A B C D E F G H I J K L M N O P Q R S T U V W Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort(Executor) - Method in class com.mckoi.database.jdbc.MConnection
- abs() - Method in class com.mckoi.util.BigNumber
- AbsFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.AbsFunction
- absolute(int) - Method in class com.mckoi.database.jdbc.MResultSet
- AbstractAggregateFunction - Class in com.mckoi.database
-
Provides convenience methods for handling aggregate functions (functions that are evaluated over a grouping set).
- AbstractAggregateFunction(String, Expression[]) - Constructor for class com.mckoi.database.AbstractAggregateFunction
-
Constructs an aggregate function.
- AbstractBlockIntegerList - Class in com.mckoi.util
-
An implementation of a list of integer values that are stored across an array of blocks.
- AbstractBlockIntegerList() - Constructor for class com.mckoi.util.AbstractBlockIntegerList
-
Constructs the list.
- AbstractBlockIntegerList(IntegerListBlockInterface[]) - Constructor for class com.mckoi.util.AbstractBlockIntegerList
-
Constructs the list from the given set of initial blocks.
- AbstractBlockIntegerList(IntegerListInterface) - Constructor for class com.mckoi.util.AbstractBlockIntegerList
-
Copies the information from the given BlockIntegerList into a new object and performs a deep clone of the information in this container.
- AbstractBlockIntegerList(IntegerVector) - Constructor for class com.mckoi.util.AbstractBlockIntegerList
-
Constructs the list by copying the contents from an IntegerVector.
- AbstractBlockIntegerList.BILIterator - Class in com.mckoi.util
-
Our iterator that walks through the list.
- AbstractDataTable - Class in com.mckoi.database
-
This is the abstract class implemented by a DataTable like table.
- AbstractDataTable() - Constructor for class com.mckoi.database.AbstractDataTable
- AbstractDBConfig - Class in com.mckoi.database.control
-
An abstract implementation of DBConfig.
- AbstractDBConfig(File) - Constructor for class com.mckoi.database.control.AbstractDBConfig
-
Constructs the DBConfig.
- AbstractFunction - Class in com.mckoi.database
-
An abstract implementation of Function.
- AbstractFunction(String, Expression[]) - Constructor for class com.mckoi.database.AbstractFunction
-
Constructs the Function with the given expression array as parameters.
- AbstractInternalTableInfo - Class in com.mckoi.database
-
An implementation of InternalTableInfo that provides a number of methods to aid in the productions of the InternalTableInfo interface.
- AbstractInternalTableInfo(String, DataTableDef[]) - Constructor for class com.mckoi.database.AbstractInternalTableInfo
-
Constructs the container than manages the creation of the given table objects.
- AbstractInternalTableInfo2 - Class in com.mckoi.database
-
An implementation of InternalTableInfo that provides a number of methods to aid in the productions of the InternalTableInfo interface for a transaction specific model of a set of tables that is based on a single system table.
- AbstractInternalTableInfo2(Transaction, TableName) - Constructor for class com.mckoi.database.AbstractInternalTableInfo2
-
Constructor.
- AbstractJDBCDatabaseInterface - Class in com.mckoi.database.jdbcserver
-
An abstract implementation of JDBCDatabaseInterface that provides a connection between a single DatabaseConnection and a DatabaseInterface implementation.
- AbstractJDBCDatabaseInterface(Database) - Constructor for class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Sets up the database interface.
- AbstractJDBCDatabaseInterface.JDIQueryResponse - Class in com.mckoi.database.jdbcserver
-
The response to a query.
- AbstractJDBCDatabaseInterface.ResultSetInfo - Class in com.mckoi.database.jdbcserver
-
Whenever a ResultSet is generated, this object contains the result set.
- AbstractQueryContext - Class in com.mckoi.database
-
An abstract implementation of QueryContext
- AbstractQueryContext() - Constructor for class com.mckoi.database.AbstractQueryContext
- AbstractRef(long, byte, long, boolean) - Constructor for class com.mckoi.database.BlobStore.AbstractRef
-
Constructs the Ref implementation.
- AbstractResource(String, long, StoreDataAccessor) - Constructor for class com.mckoi.store.JournalledSystem.AbstractResource
-
Constructs the resource.
- AbstractStore - Class in com.mckoi.store
-
Provides an abstract implementation of Store.
- AbstractStore(boolean) - Constructor for class com.mckoi.store.AbstractStore
-
Constructs the store.
- AbstractStore.AreaOutputStream - Class in com.mckoi.store
-
A simple OutputStream implementation that is on top of an AreaWriter object.
- AbstractStore.StoreArea - Class in com.mckoi.store
- AbstractStore.StoreAreaInputStream - Class in com.mckoi.store
- AbstractStore.StoreAreaWriter - Class in com.mckoi.store
- AbstractStore.StoreMutableArea - Class in com.mckoi.store
- AbstractStreamableObject - Class in com.mckoi.database.jdbc
-
An abstract class that provides various convenience behaviour for creating streamable java.sql.Blob and java.sql.Clob classes.
- AbstractStreamableObject(MConnection, int, byte, long, long) - Constructor for class com.mckoi.database.jdbc.AbstractStreamableObject
-
Constructor.
- AbstractStreamableObject.StreamableObjectInputStream - Class in com.mckoi.database.jdbc
-
An InputStream that is used to read the data from the streamable object as a basic byte encoding.
- acceptsURL(String) - Method in class com.mckoi.database.jdbc.MDriver
- access_count - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The number of times this page has been accessed since it was created.
- ACCOUNT - Static variable in interface com.mckoi.database.sql.SQLConstants
- ACKNOWLEDGEMENT - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Sent as an acknowledgement to a command.
- act_blob_store - Variable in class com.mckoi.database.TableDataConglomerate
-
The actual Store implementation that maintains the BlobStore information for this conglomerate (if there is one).
- act_state_store - Variable in class com.mckoi.database.TableDataConglomerate
-
The actual store that backs the state store.
- action - Variable in class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- action - Variable in class com.mckoi.database.interpret.AlterTableAction
-
The action to perform.
- ACTION - Static variable in interface com.mckoi.database.sql.SQLConstants
- actions - Variable in class com.mckoi.database.interpret.AlterTable
-
The list of actions to perform in this alter statement.
- active - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Set to true when this interface is active.
- actually_finished - Variable in class com.mckoi.store.JournalledSystem.JournalingThread
- add(int) - Method in class com.mckoi.database.Privileges
-
Adds a privilege and returns a new Privileges object with the new priv set.
- add(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Adds an int to the end of the list.
- add(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Adds an int to the end of the list.
- add(int, int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Adds an int at the given position in the list.
- add(int, int) - Method in interface com.mckoi.util.IntegerListInterface
-
Adds an integet to the given position in the list.
- add(int, String) - Method in class com.mckoi.util.Stats
-
Adds the given value to a stat property.
- add(DataTableDef) - Method in class com.mckoi.database.TableDescriptions
-
Adds a new DataTableDef object to the list of tables in the database.
- add(RootTable, IntegerVector) - Method in class com.mckoi.database.RawTableInformation
-
Adds a new DataTable or ReferenceTable, and IntegerVector row set into the object.
- add(RowData) - Method in class com.mckoi.database.DataTable
-
Adds a given 'RowData' object to the table.
- add(RowData[]) - Method in class com.mckoi.database.DataTable
-
Adds an array of 'RowData' objects to the table.
- add(BigNumber) - Method in class com.mckoi.util.BigNumber
- add(String) - Method in class com.mckoi.util.StringListBucket
-
Adds a string to the end of the list.
- add(String, int) - Method in class com.mckoi.util.StringListBucket
-
Adds a string to the given index of the list.
- ADD - Static variable in interface com.mckoi.database.sql.SQLConstants
- add_escapes(String) - Method in exception com.mckoi.database.sql.ParseException
-
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
- add_op - Static variable in class com.mckoi.database.Operator
- addAction(AlterTableAction) - Method in class com.mckoi.database.interpret.AlterTable
-
Adds an action to perform in this alter statement.
- addAllAreasUsed(ArrayList) - Method in class com.mckoi.database.FixedRecordList
-
Adds to the given ArrayList all the areas in the store that are used by this structure (as Long).
- addAllAreasUsed(ArrayList) - Method in class com.mckoi.database.IndexSetStore
-
Adds to the given ArrayList all the areas in the store that are used by this structure (as Long).
- addAllFromTable(FromTableInterface) - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Adds all columns from the given FromTableInterface object.
- addBatch() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- addBatch(SQLQuery) - Method in class com.mckoi.database.jdbc.MStatement
-
Adds a query to the batch of queries executed by this statement.
- addBatch(String) - Method in class com.mckoi.database.jdbc.MStatement
- addCellToColumnSchemes(int, int) - Method in class com.mckoi.database.DefaultDataTable
-
Adds a single column of a row to the selectable scheme indexing.
- addCheckConstraint(TableName, Expression, short, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.addCheckConstraint method.
- addCheckConstraint(TableName, Expression, short, String) - Method in class com.mckoi.database.Transaction
-
Adds a check expression that becomes perminent when the transaction is committed.
- addColumn(DataTableColumnDef) - Method in class com.mckoi.database.DataTableDef
- addCommand(byte) - Method in class com.mckoi.database.MasterTableJournal
-
Adds a command to the journal.
- addCommand(byte) - Method in class com.mckoi.database.TransactionJournal
-
Adds a command to the journal.
- addConnection(ServerConnection) - Method in interface com.mckoi.database.jdbcserver.ConnectionPoolServer
-
Connects a new ServerConnection into the pool of connections to clients that this server maintains.
- addConnection(ServerConnection) - Method in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
Connects a new ServerConnection into the pool of connections to clients that this server maintains.
- addConnection(ServerConnection) - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
Connects a new ServerConnection into the pool of connections to clients that this server maintains.
- addConstraint(String) - Method in class com.mckoi.database.interpret.ColumnDef
-
Adds a constraint to this column.
- addConstraintDef(ConstraintDef) - Method in class com.mckoi.database.interpret.CreateTable
-
Adds a new ConstraintDef object to this create statement.
- addDataIndexDef(DataIndexDef) - Method in class com.mckoi.database.DataIndexSetDef
-
Adds a DataIndexDef to this table.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.CompositeTable
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.DataTable
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.DataTableFilter
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.FilterTable
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.FunctionTable
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.JoinedTable
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.Table
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDataTableListener(DataTableListener) - Method in class com.mckoi.database.TemporaryTable
-
Adds a DataTableListener to the DataTable objects at the root of this table tree hierarchy.
- addDefProperty(DefaultDBConfig.ConfigProperty) - Static method in class com.mckoi.database.control.DefaultDBConfig
-
Adds a default property to the CONFIG_DEFAULTS map.
- addDeletedArea(long) - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Adds to the list of deleted areas in this block.
- addDeleteResource(StateStore.StateResource) - Method in class com.mckoi.database.StateStore
-
Adds the given StateResource to the deleted table list.
- added_list - Variable in class com.mckoi.database.TableBackedCache
-
The list of added rows to the table above when a change is committed.
- added_rows - Variable in class com.mckoi.database.TableCommitModificationEvent
-
A normalized list of all rows that were added by the transaction being committed.
- addElement(Object) - Method in class com.mckoi.database.Expression
-
Adds a new element into the expression.
- addElement(Object) - Method in class com.mckoi.database.interpret.AlterTableAction
-
Adds a parameter to this action.
- addEntry(byte, int) - Method in class com.mckoi.database.MasterTableJournal
-
Adds a new command to this journal.
- addEscapes(String) - Static method in error com.mckoi.database.sql.TokenMgrError
-
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
- addForeignKeyConstraint(TableName, String[], TableName, String[], String, String, short, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.addForeignKeyConstraint method.
- addForeignKeyConstraint(TableName, String[], TableName, String[], String, String, short, String) - Method in class com.mckoi.database.Transaction
-
Adds a foreign key constraint to the database which becomes perminent when the transaction is committed.
- addFunction(String, Class) - Method in class com.mckoi.database.FunctionFactory
-
Adds a new static function to this factory.
- addFunction(String, Class, int) - Method in class com.mckoi.database.FunctionFactory
-
Adds a new function to this factory.
- addFunctionFactory(FunctionFactory) - Method in class com.mckoi.database.TransactionSystem
-
Registers a new FunctionFactory with the database system.
- addFunctionRef(String, Expression) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Adds a function resource to the set.
- addGrant(Privileges, int, String, String, boolean, String) - Method in class com.mckoi.database.GrantManager
-
Adds a grant on the given database object.
- addGrantToAllTablesInSchema(String, Privileges, String, boolean, String) - Method in class com.mckoi.database.GrantManager
-
For all tables in the given schema, this adds the given grant for each of the tables.
- addHiddenFunction(String, Expression, QueryContext) - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Adds a new hidden function into the column set.
- addIndexLists(int, byte) - Method in class com.mckoi.database.IndexStore
-
Adds a number of blank index tables to the index store.
- addIndexLists(int, int, int) - Method in class com.mckoi.database.IndexSetStore
-
Adds a number of blank index tables to the index store.
- addIndexSetToList(IndexSet) - Method in class com.mckoi.database.IndexStore
-
Adds a SnapshotIndexSet to the list of sets that this store has dispatched.
- addInt(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Adds an int to the block.
- addInt(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Adds an int to the block.
- addInt(int) - Method in class com.mckoi.util.IntegerVector
-
Adds an int to the vector.
- addInternalTableInfo(InternalTableInfo) - Method in class com.mckoi.database.Transaction
-
Adds an internal table container (InternalTableInfo) used to resolve internal tables.
- addJoin(int) - Method in class com.mckoi.database.interpret.FromClause
-
Adds a Join to the from clause.
- addJoin(int) - Method in class com.mckoi.database.JoiningSet
-
Adds a joining type to the set with no 'on' expression.
- addJoin(int, Expression) - Method in class com.mckoi.database.interpret.FromClause
-
Adds a Join to the from clause.
- addJoin(int, Expression) - Method in class com.mckoi.database.JoiningSet
-
Adds a joining type to the set, and an 'on' expression.
- addLock(Lock) - Method in class com.mckoi.database.LockHandle
-
Adds a new lock to the locks for this handle.
- addLock(Lock) - Method in class com.mckoi.database.LockingQueue
-
Adds a lock to the queue.
- addMarkedTable(String, Table) - Method in class com.mckoi.database.AbstractQueryContext
-
Marks a table in a query plan.
- addMarkedTable(String, Table) - Method in interface com.mckoi.database.QueryContext
-
Marks a table in a query plan.
- addNativeTableGenerator(Transaction, TableName) - Static method in class com.mckoi.database.SequenceManager
-
Static convenience - adds an entry to the Sequence table for a native table in the database.
- addOperator(Operator) - Method in class com.mckoi.database.Expression
-
Adds a new operator into the expression.
- AddOperator() - Constructor for class com.mckoi.database.Operator.AddOperator
- addOperatorToExpression(Expression, Operator) - Method in class com.mckoi.database.sql.SQL
-
Helper for expression parsing.
- addParameter(int) - Method in class com.mckoi.database.MasterTableJournal
-
Adds a parameter to the journal command parameters.
- addParameter(int) - Method in class com.mckoi.database.TransactionJournal
-
Adds a parameter to the journal command parameters.
- addPlanTableSource(Planner.PlanTableSource) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Add a PlanTableSource to this planner.
- addPreviousJoin(int, Expression) - Method in class com.mckoi.database.interpret.FromClause
-
Hack, add a joining type to the previous entry from the end.
- addPreviousJoin(int, Expression) - Method in class com.mckoi.database.JoiningSet
-
Hack, add a joining type to the previous entry from the end.
- addPrimaryKeyConstraint(TableName, String[], short, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.addPrimaryKeyConstraint method.
- addPrimaryKeyConstraint(TableName, String[], short, String) - Method in class com.mckoi.database.Transaction
-
Adds a primary key constraint that becomes perminent when the transaction is committed.
- addRange(SelectableRange, IntegerVector) - Method in class com.mckoi.database.CollatedBaseSearch
-
Adds a range from this set to the given IntegerVector.
- addRangeToSet(int, int, IntegerVector) - Method in class com.mckoi.database.CollatedBaseSearch
-
Adds the set indexes to the list that represent the range of values between the start (inclusive) and end offset (inclusive) given.
- addRangeToSet(int, int, IntegerVector) - Method in class com.mckoi.database.InsertSearch
- addReference() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Adds a reference to this object.
- addReference() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Adds a reference preventing the journal file from being deleted.
- address - Variable in class com.mckoi.database.jdbcserver.TCPServer
-
The InetAddress the JDBC server is bound to.
- addressableNodeCount() - Method in class com.mckoi.database.FixedRecordList
-
Returns the total number of nodes that are currently addressable by this list structure.
- addResultSet(AbstractJDBCDatabaseInterface.ResultSetInfo) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Adds this result set to the list of result sets being handled through this processor.
- addRootLock() - Method in class com.mckoi.database.GTDataSource
- addRootLock() - Method in class com.mckoi.database.MasterTableDataSource
-
Grabs a root lock on this table.
- addRootLock() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- addRootLock() - Method in interface com.mckoi.database.MutableTableDataSource
-
Puts this source under a 'root lock'.
- addRow(RowData) - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- addRow(RowData) - Method in class com.mckoi.database.DataTable
-
Adds a new row of data to the table.
- addRow(RowData) - Method in interface com.mckoi.database.DataTableFile
-
Adds a complete new row into the table.
- addRow(RowData) - Method in class com.mckoi.database.GTDataSource
- addRow(RowData) - Method in class com.mckoi.database.MasterTableDataSource
-
Adds a new row to this table and returns an index that is used to reference this row by the 'getCellContents' method.
- addRow(RowData) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- addRow(RowData) - Method in interface com.mckoi.database.MutableTableDataSource
-
Adds a row to the source.
- addRowsLock() - Method in interface com.mckoi.database.DataTableFile
-
Locks the data in the file to prevent the system overwritting entries that have been marked as removed.
- addRowsToList(int[], IntegerVector) - Method in class com.mckoi.database.TableBackedCache
-
Adds new row ids to the given list.
- addRowToColumnSchemes(int) - Method in class com.mckoi.database.DefaultDataTable
-
This is called when a row is in the table, and the SelectableScheme objects for each column need to be notified of the rows existance, therefore build up the relational model for the columns.
- addSchemaConstraint(DatabaseConnection, TableName, ConstraintDef) - Static method in class com.mckoi.database.interpret.CreateTable
-
Adds a schema constraint to the rules for the schema represented by the manager.
- addSector(byte[]) - Method in class com.mckoi.database.FixedSizeDataStore
-
Adds a new sector into the store.
- addSector(byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Adds a new sector into the store.
- addSelectedFromTable(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Adds the given table name to the list of tables that are selected from within the transaction in this connection.
- addSelectedFromTable(TableName) - Method in class com.mckoi.database.Transaction
-
Called by the query evaluation layer when information is selected from this table as part of this transaction.
- addSelectedFromTable(String) - Method in class com.mckoi.database.DatabaseConnection
-
Adds the given table name to the list of tables that are selected from within the transaction in this connection.
- addSingleVarPlanTo(ArrayList, Planner.PlanTableSource, Variable, Variable, Expression[], Operator) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Adds a single var plan to the given list.
- addSQLWarning(SQLWarning) - Method in class com.mckoi.database.jdbc.MConnection
-
Adds a new SQLWarning to the chain.
- addSQLWarning(SQLWarning) - Method in class com.mckoi.database.jdbc.MResultSet
-
Adds a new SQLWarning to the chain.
- addSQLWarning(SQLWarning) - Method in class com.mckoi.database.jdbc.MStatement
-
Adds a new SQLWarning to the chain.
- addStatement(PreparedStatement) - Method in class com.mckoi.jfccontrols.QueryAgent.QueryThread
-
Sets the PreparedStatement that we want to execute.
- addTable(FromTableInterface) - Method in class com.mckoi.database.interpret.Statement
-
Add an FromTableInterface that is used within this query.
- addTable(FromTableInterface) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Adds a table resource to the set.
- addTable(TableName) - Method in class com.mckoi.database.JoiningSet
-
Adds a new table into the set being joined.
- addTable(String) - Method in class com.mckoi.database.interpret.FromClause
-
Adds a table name to this FROM clause.
- addTable(String, String) - Method in class com.mckoi.database.interpret.FromClause
-
Adds a table name + alias to this FROM clause.
- addTableDeclaration(String, TableSelectExpression, String) - Method in class com.mckoi.database.interpret.FromClause
-
A generic form of a table declaration.
- addTableDef(String, FromTableDef) - Method in class com.mckoi.database.interpret.FromClause
- addTableSource(QueryPlanNode, FromTableInterface) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Adds a new table source to the planner given a Plan that 'creates' the source, and a FromTableInterface that describes the source created by the plan.
- addToBinChain(long, long) - Method in class com.mckoi.store.AbstractStore
-
Adds the given area to the bin represented by the bin_chain_index.
- addToDate(Date) - Method in class com.mckoi.util.TimeFrame
-
Returns a Date that is the addition of this period of time to the given date.
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.ExpressionPlan
-
Adds this expression into the plan tree.
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ComplexSingleExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ConstantExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveJoinExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSelectExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSubQueryExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimplePatternExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSelectExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSingleExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSubQueryExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.StandardJoinExpressionPlan
- addToPlanTree() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SubLogicExpressionPlan
- addToRecordList(long) - Method in class com.mckoi.database.BlobStore
-
Finds a free place to add a record and returns an index to the record here.
- addToRecordList(long) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Finds a free place to add a record and returns an index to the record here.
- addToRecordList(long, long) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Adds a record to the given position in the fixed structure.
- addTransaction(Transaction) - Method in class com.mckoi.database.OpenTransactionList
-
Adds a new open transaction to the list.
- addTransactionJournal(MasterTableJournal) - Method in class com.mckoi.database.MultiVersionTableIndices
-
Adds a transaction journal to the list of modifications on the indices kept here.
- addTransactionModificationListener(TableName, TransactionModificationListener) - Method in class com.mckoi.database.TableDataConglomerate
-
Adds a listener for transactional modification events that occur on the given table in this conglomerate.
- addTriggerListener(DatabaseConnection, String, int, String, TriggerListener) - Method in class com.mckoi.database.TriggerManager
-
Adds a listener for an event with the given 'id' for this user session.
- addTriggerListener(String, TriggerListener) - Method in class com.mckoi.database.jdbc.MckoiConnection
-
Registers a TriggerListener to listen for any triggers that are fired with the given name.
- addTriggerListener(String, TriggerListener) - Method in class com.mckoi.database.jdbc.MConnection
-
Adds a TriggerListener that listens for all triggers events with the name given.
- addType(String, int, int, String, String, String, boolean) - Method in class com.mckoi.database.GTSQLTypeInfoDataSource
-
Adds a type description.
- addUniqueConstraint(TableName, String[], short, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.addUniqueConstraint method.
- addUniqueConstraint(TableName, String[], short, String) - Method in class com.mckoi.database.Transaction
-
Adds a unique constraint to the database which becomes perminant when the transaction is committed.
- addUserToGroup(DatabaseQueryContext, String, String) - Method in class com.mckoi.database.Database
-
Adds the user to the given group.
- addVar(Object) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Adds a variable to the query.
- addVirtualColumn(DataTableColumnDef) - Method in class com.mckoi.database.DataTableDef
-
Same as 'addColumn' only this does not perform a check to ensure no two columns are the same.
- addVisibleResource(StateStore.StateResource) - Method in class com.mckoi.database.StateStore
-
Adds the given StateResource to the visible table list.
- addVisibleTable(MasterTableDataSource, IndexSet) - Method in class com.mckoi.database.SimpleTransaction
-
Adds a MasterTableDataSource and IndexSet to this transaction view.
- adjustBeginLineColumn(int, int) - Method in class com.mckoi.database.sql.SimpleCharStream
-
Method to adjust line and column numbers for the start of a token.
- AFTER - Static variable in interface com.mckoi.database.sql.SQLConstants
- AFTER - Static variable in class com.mckoi.database.TableModificationEvent
-
Event that occurs after the action
- AFTER_DELETE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event for after a delete.
- AFTER_INSERT - Static variable in class com.mckoi.database.TableModificationEvent
-
Event for after an insert.
- AFTER_LAST_VALUE - Static variable in class com.mckoi.database.SelectableRange
-
Represents the various points in the set on the value to represent the set range.
- AFTER_UPDATE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event for after an update.
- afterLast() - Method in class com.mckoi.database.jdbc.MResultSet
- AggOrFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.AggOrFunction
- AGGREGATE - Static variable in interface com.mckoi.database.FunctionInfo
-
A type that represents an aggregate function.
- aggregate_count - Variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The count of aggregate and constant columns included in the result set.
- ALERT - Static variable in class com.mckoi.debug.Debug
-
Deprecated.
- ALERT - Static variable in interface com.mckoi.debug.Lvl
- alias - Variable in class com.mckoi.database.interpret.SelectColumn
-
The alias of this column string.
- alias_name - Variable in class com.mckoi.database.QueryPlan.FetchTableNode
-
The name to alias the table as.
- alias_name - Variable in class com.mckoi.database.QueryPlan.FetchViewNode
-
The name to alias the table as.
- aliases - Variable in class com.mckoi.database.SubsetColumnTable
-
The resolved Variable aliases for this subset.
- all(QueryContext, Expression, Operator, Table) - Method in class com.mckoi.database.Table
-
Evaluates a non-correlated ALL type operator given the LHS expression, the RHS subquery and the ALL operator to use.
- ALL - Static variable in class com.mckoi.database.Operator
-
The ANY and ALL enumerator.
- ALL - Static variable in class com.mckoi.database.Privileges
-
The priv to allow full access to the database object.
- ALL - Static variable in interface com.mckoi.database.sql.SQLConstants
- all_map - Static variable in class com.mckoi.database.Operator
- all_op - Variable in class com.mckoi.database.QueryPlan.CompositeNode
-
If this is true, the composite includes all results from both children, otherwise removes deplicates.
- all_resources - Variable in class com.mckoi.store.JournalledSystem
-
The map of all resources that are available.
- all_table_names - Variable in class com.mckoi.database.interpret.FromClause
-
A list of all table names in this from clause.
- all_vars - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSubQueryExpressionPlan
- allChangeInformation() - Method in class com.mckoi.database.MasterTableJournal
-
Returns three lists - a list of all rows that were inserted, a list of all rows that were deleted, and a list of all updates.
- allColumnMatchesValue(int, Operator, TObject) - Method in class com.mckoi.database.Table
-
Returns true if the given column contains all values that the given operator returns true for with the given value.
- allColumns() - Method in class com.mckoi.database.interpret.FromTableDirectSource
- allColumns() - Method in interface com.mckoi.database.interpret.FromTableInterface
-
Returns an array of Variable objects that references each column available in this table set item in order from left column to right column.
- allColumns() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
- allDeletedSectors() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Returns the sectors that were deleted when this store committed.
- allElements() - Method in class com.mckoi.database.AbstractFunction
-
Returns the list of all elements that are used by this function.
- allElements() - Method in class com.mckoi.database.Expression
-
Returns a complete list of all element objects that are in this expression and in the parameters of the functions of this expression.
- allElements() - Method in interface com.mckoi.database.Function
-
Returns the list of all element objects that this function uses as its parameters.
- allElements() - Method in class com.mckoi.database.interpret.SearchExpression
-
Returns all the Elements from all expressions in this condition tree.
- alloc(long) - Method in class com.mckoi.store.AbstractStore
-
Allocates a block of memory from the backing area of the given size and returns a pointer to that area.
- allocateLargeObject(byte, long) - Method in class com.mckoi.database.BlobStore
-
Allocates an area in the store for a large binary object to be stored.
- allocation_length - Variable in class com.mckoi.database.IndexStore
-
The current of the allocation information.
- allocation_sector - Variable in class com.mckoi.database.IndexStore
-
The start sector where the block allocation information is currently stored.
- allocation_store - Variable in class com.mckoi.database.VariableSizeDataStore
-
The index data allocation file.
- AllOperator(String) - Constructor for class com.mckoi.database.Operator.AllOperator
- allProceduresAreCallable() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- allRowsIn(int, Table) - Method in class com.mckoi.database.Table
-
Given a table and column (from this table), this returns all the rows from this table that are also in the first column of the given table.
- allRowsNotIn(int, Table) - Method in class com.mckoi.database.Table
-
Given a table and column (from this table), this returns all the rows from this table that are not in the first column of the given table.
- allSwitchesStartingWith(String) - Method in class com.mckoi.util.CommandLine
-
Returns a list of all switches on the command line that start with the given string.
- allTables() - Method in class com.mckoi.database.interpret.FromClause
-
Returns a Set of FromTableDef objects that represent all the tables that are in this from clause.
- allTablesAreSelectable() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- allVariables() - Method in class com.mckoi.database.AbstractFunction
-
Returns the list of all Variable's that are used by this function.
- allVariables() - Method in class com.mckoi.database.Expression
-
Returns a complete List of Variable objects in this expression not including correlated variables.
- allVariables() - Method in interface com.mckoi.database.Function
-
Returns the list of Variable objects that this function uses as its parameters.
- Alter() - Method in class com.mckoi.database.sql.SQL
- ALTER - Static variable in class com.mckoi.database.Privileges
-
The priv to alter objects (only applicable for SCHEMA grant objects).
- ALTER - Static variable in interface com.mckoi.database.sql.SQLConstants
- alterCacheDynamics(int, int) - Method in class com.mckoi.database.DataCellCache
-
Dynamically resizes the data cell cache so it can store more/less data.
- alterCreateTable(DataTableDef) - Method in class com.mckoi.database.DatabaseConnection
-
Given a DataTableDef, if the table exists then it is updated otherwise if it doesn't exist then it is created.
- alterCreateTable(DataTableDef, int, int) - Method in class com.mckoi.database.DatabaseConnection
-
Given a DataTableDef, if the table exists then it is updated otherwise if it doesn't exist then it is created.
- alterCreateTable(DataTableDef, int, int) - Method in class com.mckoi.database.Transaction
-
Given a DataTableDef, if the table exists then it is updated otherwise if it doesn't exist then it is created.
- alterTable(TableName, DataTableDef) - Method in class com.mckoi.database.Transaction
-
Alters the table with the given name within this transaction to the specified table definition.
- alterTable(TableName, DataTableDef, int, int) - Method in class com.mckoi.database.Transaction
-
Alter the table with the given name to the new definition and give the copied table a new data sector size.
- AlterTable - Class in com.mckoi.database.interpret
-
Logic for the ALTER TABLE SQL statement.
- AlterTable() - Constructor for class com.mckoi.database.interpret.AlterTable
- AlterTable() - Method in class com.mckoi.database.sql.SQL
- AlterTableAction - Class in com.mckoi.database.interpret
-
Represents an action in an ALTER TABLE SQL statement.
- AlterTableAction() - Constructor for class com.mckoi.database.interpret.AlterTableAction
-
Constructor.
- AlterUser() - Method in class com.mckoi.database.sql.SQL
- alterUserPassword(DatabaseQueryContext, String, String) - Method in class com.mckoi.database.Database
-
Alters the password of the user but otherwise does not change any information about the user.
- always_reindex_dirty_tables - Variable in class com.mckoi.database.TransactionSystem
-
If this is set to true, during boot up the engine will reindex all the tables that weren't closed.
- alwaysReindexDirtyTables() - Method in class com.mckoi.database.TransactionSystem
-
Returns the status of the 'always_reindex_dirty_tables' property.
- amountMemory(TObject) - Static method in class com.mckoi.database.DataCellCache
-
Returns an approximation of the amount of memory taken by a TObject.
- AND - Static variable in interface com.mckoi.database.sql.SQLConstants
- and_op - Static variable in class com.mckoi.database.Operator
- AndOperator() - Constructor for class com.mckoi.database.Operator.AndOperator
- any(QueryContext, Expression, Operator, Table) - Method in class com.mckoi.database.Table
-
Evaluates a non-correlated ANY type operator given the LHS expression, the RHS subquery and the ANY operator to use.
- ANY - Static variable in class com.mckoi.database.Operator
-
The ANY and ALL enumerator.
- ANY - Static variable in interface com.mckoi.database.sql.SQLConstants
- any_map - Static variable in class com.mckoi.database.Operator
- anyAllNonCorrelated(Table, Variable[], Operator, Table) - Static method in class com.mckoi.database.TableFunctions
-
The function for a non-correlated ANY or ALL sub-query operation between a left and right branch.
- AnyOperator(String) - Constructor for class com.mckoi.database.Operator.AnyOperator
- append(IntegerVector) - Method in class com.mckoi.util.IntegerVector
-
Appends an IntegerVector to the end of the array.
- appendDayType(StringBuffer, double, boolean) - Static method in class com.mckoi.util.GeneralFormatter
- appendExpression(Expression) - Method in class com.mckoi.database.interpret.SearchExpression
-
Concatinates a new expression to the end of this expression and uses the 'AND' operator to seperate the expressions.
- appendFrame(StringBuffer, double, String, boolean, boolean) - Static method in class com.mckoi.util.GeneralFormatter
-
Appends a frame of time onto the given StringBuffer.
- appendHourType(StringBuffer, double, boolean) - Static method in class com.mckoi.util.GeneralFormatter
- appendMinuteType(StringBuffer, double, boolean) - Static method in class com.mckoi.util.GeneralFormatter
- appendWeekType(StringBuffer, double, boolean) - Static method in class com.mckoi.util.GeneralFormatter
-
Appends time frame representation information into the given StringBuffer for various types of visual time frame formats.
- approximateMemoryUse() - Method in class com.mckoi.database.TObject
-
Returns the approximate memory use of this object in bytes.
- archive_count - Variable in class com.mckoi.util.LogWriter
-
The number of backup archives of log files.
- Area - Interface in com.mckoi.store
-
An interface for access the contents of an area of a store.
- area_map - Variable in class com.mckoi.store.HeapStore
-
A hash map of area pointer to byte[] array that represents the area.
- AreaOutputStream(AreaWriter) - Constructor for class com.mckoi.store.AbstractStore.AreaOutputStream
- AreaWriter - Interface in com.mckoi.store
-
The interface used for setting up an area initially in a store.
- arg - Variable in class com.mckoi.database.sql.SQL.JJCalls
- args - Variable in class com.mckoi.database.interpret.Show
-
Arguments of the show statement.
- args - Variable in class com.mckoi.util.CommandLine
-
The command line arguments.
- array - Variable in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
The array of int's stored in this block.
- ARRAY - Static variable in interface com.mckoi.database.global.SQLTypes
- ARRAY_TYPE - Static variable in class com.mckoi.database.TType
-
A type that represents an array.
- AS - Static variable in interface com.mckoi.database.sql.SQLConstants
- asBigDecimal() - Method in class com.mckoi.util.BigNumber
-
Returns the big number as a BigDecimal object.
- asBlob(Object) - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns the given object as a Blob instance.
- ASC - Static variable in interface com.mckoi.database.sql.SQLConstants
- ascending - Variable in class com.mckoi.database.interpret.ByColumn
-
If 'order by' then true if sort is ascending (default).
- AsciiInputStream - Class in com.mckoi.database.jdbc
-
An InputStream that converts a Reader to a plain ascii stream.
- AsciiInputStream(Reader) - Constructor for class com.mckoi.database.jdbc.AsciiInputStream
- AsciiInputStream(String) - Constructor for class com.mckoi.database.jdbc.AsciiInputStream
- AsciiReader - Class in com.mckoi.database.jdbc
-
A java.io.Reader implementation that wraps around an ascii input stream (8-bit per char stream).
- AsciiReader(InputStream) - Constructor for class com.mckoi.database.jdbc.AsciiReader
-
Constructs the reader.
- asClob(Object) - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns the given object as a Clob instance.
- asEncodedString(TType) - Static method in class com.mckoi.database.TType
-
Encodes a TType into a string which is a useful way to serialize a TType.
- asEncodedString(TType[]) - Static method in class com.mckoi.database.TType
-
Given an array of TType, returns a String that that is the encoded form of the array and that can be later decoded back into an array of TType.
- ask(String, String[], int) - Method in class com.mckoi.util.ShellUserTerminal
- ask(String, String[], int) - Method in interface com.mckoi.util.UserTerminal
-
Asks the user a question from the 'question' string.
- asNonQuotedRef(Token) - Static method in class com.mckoi.database.sql.Util
-
Returns the Token as a non quoted reference.
- assertIsOpen() - Method in class com.mckoi.database.BlobStore.AbstractRef
-
Asserts that this blob is open for writing.
- Assignment - Class in com.mckoi.database
-
An assignment from a variable to an expression.
- Assignment(Variable, Expression) - Constructor for class com.mckoi.database.Assignment
-
Constructs the assignment.
- ASSIGNMENT - Static variable in interface com.mckoi.database.sql.SQLConstants
- assignment_count - Variable in class com.mckoi.database.RowData.RDVariableResolver
- AssignmentList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- asSQLString() - Method in class com.mckoi.database.TType
-
Returns this TType as a fully parsable declared SQL type.
- attachTableBackedCache(TableBackedCache) - Method in class com.mckoi.database.DatabaseConnection
-
Attaches a TableBackedCache object to this DatabaseConnection which is notified when a transaction is started and stopped, and when the table being backed has changes made to it.
- attachTo(TableDataConglomerate) - Method in class com.mckoi.database.TableBackedCache
-
Attaches this object to a conglomerate.
- authenticate(Database, String, String, String, DatabaseCallBack) - Method in class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
-
Tries to authenticate the username and password against the given database.
- authenticateUser(String, String, String) - Method in class com.mckoi.database.Database
-
Tries to authenticate a username/password against this database.
- AUTHENTICATION_ERROR - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
There was an authentication error.
- authentication_tries - Variable in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Number of authentications tried.
- AUTHOR - Static variable in class com.mckoi.database.global.StandardMessages
-
The name of the author (me).
- auto_commit - Variable in class com.mckoi.database.DatabaseConnection
-
If this is true then the database connection is in 'auto-commit' mode.
- auto_commit - Variable in class com.mckoi.database.jdbc.MConnection
-
Set to true if the connection is in auto-commit mode.
- auto_resize_result_table - Variable in class com.mckoi.tools.JDBCQueryTool
-
Set to true if the table is auto resize (default).
- AUTOCOMMIT - Static variable in interface com.mckoi.database.sql.SQLConstants
- autoCommitFailureClosesAllResultSets() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- available - Variable in class com.mckoi.database.sql.SimpleCharStream
- available() - Method in class com.mckoi.database.CellBufferInputStream
- available() - Method in class com.mckoi.database.CellInputStream
- available() - Method in class com.mckoi.database.DataCellSerialization
- available() - Method in class com.mckoi.database.jdbc.AsciiInputStream
- available() - Method in class com.mckoi.database.jdbc.UnicodeToBinaryStream
- available() - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- available() - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
- available() - Method in class com.mckoi.util.PagedInputStream
- available_worker_threads - Variable in class com.mckoi.database.WorkerPool
-
This is a queue of 'WorkerThread' objects that are currently available to process commands from the service providers.
- average_row_count_action - Variable in class com.mckoi.tools.ConglomerateViewPane
-
An action for calculating the average row size in the table.
- AvgFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.AvgFunction
B
- B_SIZE - Static variable in class com.mckoi.database.BlobStore.BLOBInputStream
- B_SIZE - Static variable in class com.mckoi.database.jdbc.AbstractStreamableObject.StreamableObjectInputStream
-
The default size of the buffer.
- backed_by_table - Variable in class com.mckoi.database.TableBackedCache
-
The table that this cache is backed by.
- backup(int) - Method in class com.mckoi.database.sql.SimpleCharStream
- backup_file - Variable in class com.mckoi.database.TableDescriptions
-
The backup file for table descriptions.
- BasicColumnList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- batch_list - Variable in class com.mckoi.database.jdbc.MStatement
-
The list of queries to execute in a batch.
- BD_ONE - Static variable in class com.mckoi.database.global.CastHelper
- BD_ZERO - Static variable in class com.mckoi.database.global.CastHelper
-
A couple of standard BigNumber statics.
- BD_ZERO - Static variable in class com.mckoi.database.jdbc.MResultSet
-
BigNumber for 0.
- BD_ZERO - Static variable in class com.mckoi.util.BigNumber
-
Statics.
- BD_ZERO - Static variable in class com.mckoi.util.TimeFrame
- been_locked - Variable in class com.mckoi.database.TableAccessState
-
Set to true when the table is first locked.
- BEFORE - Static variable in interface com.mckoi.database.sql.SQLConstants
- BEFORE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event that occurs before the action
- BEFORE_DELETE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event for before a delete.
- BEFORE_FIRST_VALUE - Static variable in class com.mckoi.database.SelectableRange
-
Represents the various points in the set on the value to represent the set range.
- BEFORE_INSERT - Static variable in class com.mckoi.database.TableModificationEvent
-
Event for before an insert.
- BEFORE_UPDATE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event for before an update.
- beforeFirst() - Method in class com.mckoi.database.jdbc.MResultSet
- BeforeOrAfter() - Method in class com.mckoi.database.sql.SQL
- beginColumn - Variable in class com.mckoi.database.sql.Token
-
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
- beginLine - Variable in class com.mckoi.database.sql.Token
-
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
- BeginToken() - Method in class com.mckoi.database.sql.SimpleCharStream
- BETWEEN - Static variable in interface com.mckoi.database.sql.SQLConstants
- BetweenPredicate(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- big_decimal - Variable in class com.mckoi.util.BigNumber
-
The BigDecimal representation.
- BIG_NUMBER_ONE - Static variable in class com.mckoi.util.BigNumber
- BIG_NUMBER_ZERO - Static variable in class com.mckoi.util.BigNumber
-
Statics for 0 and 1.
- bigClasses - Static variable in class com.mckoi.database.Caster
- BIGINT - Static variable in interface com.mckoi.database.global.SQLTypes
- BIGINT - Static variable in interface com.mckoi.database.sql.SQLConstants
- BigNumber - Class in com.mckoi.util
-
Extends BigDecimal to allow a number to be positive infinity, negative infinity and not-a-number.
- BigNumber(byte[], int, byte) - Constructor for class com.mckoi.util.BigNumber
- BigNumber(byte, BigDecimal) - Constructor for class com.mckoi.util.BigNumber
-
Constructs the number.
- bigNumberVal(BigNumber) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of numeric type that represents the given BigNumber value.
- bigPrims - Static variable in class com.mckoi.database.Caster
- BILIterator(int, int) - Constructor for class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- bin_area - Variable in class com.mckoi.store.AbstractStore
-
A buffered work area we work with when reading/writing bin pointers from the file header.
- BIN_AREA_OFFSET - Static variable in class com.mckoi.store.AbstractStore
-
The offset into the file that the bin area starts.
- BIN_ENTRIES - Static variable in class com.mckoi.store.AbstractStore
- BIN_SIZES - Static variable in class com.mckoi.store.AbstractStore
-
The default bin sizes in bytes.
- BINARY - Static variable in interface com.mckoi.database.global.SQLTypes
- BINARY - Static variable in interface com.mckoi.database.sql.SQLConstants
- BINARY_TYPE - Static variable in class com.mckoi.database.TType
-
A default binary (SQL BLOB) type of unlimited maximum size.
- binarySearch(Object, IndexComparator) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Considers each int a reference to another structure, and the block sorted by these structures.
- binarySearch(Object, IndexComparator) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Considers each int a reference to another structure, and the block sorted by these structures.
- BinaryToHexFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.BinaryToHexFunction
- BinaryToUnicodeReader - Class in com.mckoi.database.jdbc
-
A Reader implementation that wraps around a unicode encoded input stream that encodes each unicode character as 2 bytes.
- BinaryToUnicodeReader(InputStream) - Constructor for class com.mckoi.database.jdbc.BinaryToUnicodeReader
-
Constructor.
- binaryType(int, int) - Static method in class com.mckoi.database.TType
-
Returns a TBinaryType object.
- bind_address - Variable in class com.mckoi.database.control.TCPJDBCServer
-
An InetAddress representing the interface that server is bound to - useful for multi-homed machines.
- BIT - Static variable in interface com.mckoi.database.global.SQLTypes
- BIT - Static variable in interface com.mckoi.database.sql.SQLConstants
- BIT_COUNT - Static variable in class com.mckoi.database.GTPrivMapDataSource
-
Number of bits.
- BIT_COUNT - Static variable in class com.mckoi.database.Privileges
-
The number of bits available to set.
- BIT_MASK - Static variable in class com.mckoi.database.Privileges
-
The bit mask.
- bitClasses - Static variable in class com.mckoi.database.Caster
- bitPrims - Static variable in class com.mckoi.database.Caster
- bitWiseOr(BigNumber) - Method in class com.mckoi.util.BigNumber
- blankSelectableSchemes() - Method in class com.mckoi.database.DefaultDataTable
-
Blanks all the column schemes in the table to an initial state.
- blankSelectableSchemes(int) - Method in class com.mckoi.database.DataTable
-
Overwritten from DefaultDataTable to do nothing.
- blankSelectableSchemes(int) - Method in class com.mckoi.database.DefaultDataTable
-
Blanks all the column schemes in this table to a specific type of scheme.
- BlindSearch - Class in com.mckoi.database
-
This is a scheme that performs a blind search of a given set.
- BlindSearch(TableDataSource, int) - Constructor for class com.mckoi.database.BlindSearch
-
The Constructor.
- BlindSearch.RangeChecker - Class in com.mckoi.database
-
Object used to during range check loop.
- blob - Variable in class com.mckoi.database.jdbc.MBlob
-
The ByteLongObject that is a container for the data in this blob.
- BLOB - Static variable in interface com.mckoi.database.global.SQLTypes
- BLOB - Static variable in interface com.mckoi.database.sql.SQLConstants
- blob_id_map - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Mantains a mapping from streamable object id for a particular object that is currently being uploaded to the server.
- blob_store - Variable in class com.mckoi.database.TableDataConglomerate
-
The BlobStore object for this conglomerate.
- blob_store_interface - Variable in class com.mckoi.database.MasterTableDataSource
-
An abstracted reference to a BlobStore for managing blob references and blob data.
- BlobAccessor - Interface in com.mckoi.database.global
-
An interface that provides access to basic information about a BLOB so that we may compare BLOBs implemented in different ways.
- BLOBInputStream() - Constructor for class com.mckoi.database.global.ByteLongObject.BLOBInputStream
- BLOBInputStream(long, long) - Constructor for class com.mckoi.database.BlobStore.BLOBInputStream
- BlobRef - Interface in com.mckoi.database.global
-
A lightweight interface that is a reference to a blob in a BlobStore.
- BlobRefImpl(long, byte, long, boolean) - Constructor for class com.mckoi.database.BlobStore.BlobRefImpl
-
Constructs the BlobRef implementation.
- BlobStore - Class in com.mckoi.database
-
A structure inside an Area that maintains the storage of any number of large binary objects.
- BlobStore(Store) - Constructor for class com.mckoi.database.BlobStore
-
Constructs the BlobStore on the given Area object.
- BlobStore.AbstractRef - Class in com.mckoi.database
-
An abstract implementation of a Ref object for referencing large objects in this blob store.
- BlobStore.BLOBInputStream - Class in com.mckoi.database
-
An InputStream implementation that reads from the underlying blob data as fixed size pages.
- BlobStore.BlobRefImpl - Class in com.mckoi.database
-
An implementation of BlobRef used to represent a blob reference inside this blob store.
- BlobStore.ClobRefImpl - Class in com.mckoi.database
-
An implementation of ClobRef used to represent a reference to a large character object inside this blob store.
- BlobStore.CopyBlobInfo - Class in com.mckoi.database
-
Simple structure used when copying blob information.
- BlobStoreInterface - Interface in com.mckoi.database
-
A very restricted interface for accessing a blob store.
- block() - Method in class com.mckoi.jfccontrols.SwingBlockUtil
-
Utility that blocks the Swing EventDispatchThread, and then emulates the inner loop of the dispatcher thread itself.
- block_entries - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
The total number of entries in the index block.
- block_index - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- block_list - Variable in class com.mckoi.util.AbstractBlockIntegerList
-
The list of blocks (objects in this list are of type 'IntegerListBlockInterface'.
- block_offset - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- block_p - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
A pointer to the area where this block can be found.
- block_row_count - Variable in class com.mckoi.database.jdbc.MResultSet
-
The number of rows in 'result_block'
- block_size - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
The block size of elements in this block.
- block_size - Variable in class com.mckoi.database.IndexStore
-
The size of a 'block' element of index information in a list.
- block_state - Variable in class com.mckoi.jfccontrols.SwingBlockUtil
-
The state we are currently in.
- block_top_row - Variable in class com.mckoi.database.jdbc.MResultSet
-
The row number of the first row of the 'result_block'
- block_util - Variable in class com.mckoi.jfccontrols.QueryAgent
-
The utility for blocking the swing event dispatch thread.
- blockForCommand() - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
-
Blocks until a complete command has been read in.
- blockForRequest() - Method in interface com.mckoi.database.jdbcserver.ServerConnection
-
Blocks until a complete command is available to be processed.
- blockForRequest() - Method in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
Block waiting for a complete command to become available.
- BlockIntegerList - Class in com.mckoi.util
-
An implementation of AbstractBlockIntegerList that stores all int values in blocks that are entirely stored in main memory.
- BlockIntegerList() - Constructor for class com.mckoi.util.BlockIntegerList
-
Constructs the list.
- BlockIntegerList(IntegerListInterface) - Constructor for class com.mckoi.util.BlockIntegerList
-
Copies the information from the given BlockIntegerList into a new object and performs a deep clone of the information in this container.
- BlockIntegerList(IntegerVector) - Constructor for class com.mckoi.util.BlockIntegerList
- BlockIntegerList.IntArrayListBlock - Class in com.mckoi.util
-
The block that contains the actual int values of the list.
- BMPage(JournalledResource, long, int) - Constructor for class com.mckoi.store.LoggingBufferManager.BMPage
-
Constructs the page.
- BOOLEAN - Static variable in interface com.mckoi.database.global.SQLTypes
- BOOLEAN - Static variable in interface com.mckoi.database.sql.SQLConstants
- BOOLEAN_FALSE - Static variable in class com.mckoi.database.TObject
- BOOLEAN_LITERAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- BOOLEAN_NULL - Static variable in class com.mckoi.database.TObject
- BOOLEAN_TRUE - Static variable in class com.mckoi.database.TObject
- BOOLEAN_TYPE - Static variable in class com.mckoi.database.TType
-
A default boolean (SQL BIT) type.
- booleanColumn(String) - Static method in class com.mckoi.database.GTDataSource
- BooleanOperator(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- booleanType(int) - Static method in class com.mckoi.database.TType
-
Returns a TBooleanType object.
- booleanVal(boolean) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of boolean type that is either true or false.
- boot(DBConfig) - Method in interface com.mckoi.database.jdbc.LocalBootable
-
Boots the database with the given configuration.
- boot(DBConfig) - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Boots the local database with the given configuration.
- booted - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Set to true if the database is booted.
- BOTH - Static variable in interface com.mckoi.database.sql.SQLConstants
- bottomInt() - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Overwritten from IntArrayListBlock, returns the first entry of the block.
- bottomInt() - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Overwritten from IntArrayListBlock, returns the first entry of the block.
- bottomInt() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
The bottom int in the list.
- bottomInt() - Method in class com.mckoi.util.IntegerListBlockInterface
-
The bottom int in the list.
- BranchQueryPlanNode(QueryPlanNode, QueryPlanNode) - Constructor for class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
The Constructor.
- breakByOperator(ArrayList, String) - Method in class com.mckoi.database.Expression
-
Breaks this expression into a list of sub-expressions that are split by the given operator.
- BResource(long, String) - Constructor for class com.mckoi.store.LoggingBufferManager.BResource
-
Constructs the resource.
- bringToHead(Cache.ListNode) - Method in class com.mckoi.util.Cache
-
Brings 'node' to the start of the list.
- buf - Variable in class com.mckoi.database.CellBufferInputStream
- buf - Variable in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
-
The sector buffers.
- buf - Variable in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
A snapshot of the allocation table.
- buf - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ServerCommand
- buf - Variable in class com.mckoi.store.AbstractStore
-
Reads an 8 byte long at the given position in the data area.
- buf - Variable in class com.mckoi.util.ByteBuffer
-
The byte[] array itself.
- buf - Variable in class com.mckoi.util.LengthMarkedBufferedInputStream
-
The buffer that is used to read in whatever is on the stream.
- buf - Variable in class com.mckoi.util.PagedInputStream
-
The buffer.
- buf_length - Variable in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
The length of the allocation table.
- bufcolumn - Variable in class com.mckoi.database.sql.SimpleCharStream
- buffer - Variable in class com.mckoi.database.sql.SimpleCharStream
- buffer - Variable in class com.mckoi.store.AbstractStore.StoreArea
- buffer - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
Small buffer.
- buffer - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The buffer that contains the data for this page.
- buffer_manager - Variable in class com.mckoi.database.TransactionSystem
-
A LoggingBufferManager object used to manage pages of ScatteringFileStore objects in the file system.
- buffer_manager - Variable in class com.mckoi.store.JournalledFileStore
-
The buffering strategy for accessing the data in an underlying file.
- buffer_pos - Variable in class com.mckoi.util.PagedInputStream
-
The start buffer position.
- BUFFER_SIZE - Static variable in class com.mckoi.store.AbstractStore.StoreArea
- BUFFER_SIZE - Variable in class com.mckoi.util.PagedInputStream
-
The size of the buffer page.
- buffered_sector - Variable in class com.mckoi.database.FixedSizeDataStore
-
The sector that we currently have loaded into the buffer.
- bufline - Variable in class com.mckoi.database.sql.SimpleCharStream
- bufpos - Variable in class com.mckoi.database.sql.SimpleCharStream
- bufsize - Variable in class com.mckoi.database.sql.SimpleCharStream
- build_state - Variable in class com.mckoi.database.RIDList
-
The RID list build state.
- buildIndex(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Builds the given index number (from the DataIndexSetDef).
- buildIndexes() - Method in class com.mckoi.database.MasterTableDataSource
-
Builds a complete index set on the data in this table.
- buildPage(long, long, byte[], int) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Reconstructs a modification that is logged in this journal.
- buildTriggerList() - Method in class com.mckoi.database.ConnectionTriggerManager
-
Build the trigger list if it is not validated.
- ByColumn - Class in com.mckoi.database.interpret
-
Object used to represent a column in the 'order by' and 'group by' clauses of a select statement.
- ByColumn() - Constructor for class com.mckoi.database.interpret.ByColumn
- byte_count - Variable in class com.mckoi.util.BigNumber
-
If this can be represented as an int or long, this contains the number of bytes needed to represent the number.
- ByteArrayUtil - Class in com.mckoi.util
-
Static utilities for byte arrays.
- ByteArrayUtil() - Constructor for class com.mckoi.util.ByteArrayUtil
- ByteBuffer - Class in com.mckoi.util
-
A wrapper for an array of byte[].
- ByteBuffer(byte[]) - Constructor for class com.mckoi.util.ByteBuffer
- ByteBuffer(byte[], int, int) - Constructor for class com.mckoi.util.ByteBuffer
-
Constructs the buffer.
- ByteLongObject - Class in com.mckoi.database.global
-
A byte array that can be transferred between the client and server.
- ByteLongObject(byte[]) - Constructor for class com.mckoi.database.global.ByteLongObject
- ByteLongObject(byte[], int, int) - Constructor for class com.mckoi.database.global.ByteLongObject
-
Constructor.
- ByteLongObject(InputStream, int) - Constructor for class com.mckoi.database.global.ByteLongObject
- ByteLongObject.BLOBInputStream - Class in com.mckoi.database.global
-
Inner class that encapsulates the byte long object in an input stream.
- byteValue() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as a byte.
C
- cache - Variable in class com.mckoi.database.DataCellCache
-
The master cache.
- cache - Variable in class com.mckoi.database.MasterTableDataSource
-
A reference to the DataCellCache object.
- cache - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
How many values we cache.
- cache - Variable in class com.mckoi.database.StatementCache
-
The internal cache representation.
- Cache - Class in com.mckoi.util
-
Represents a cache of Objects.
- Cache() - Constructor for class com.mckoi.util.Cache
- Cache(int) - Constructor for class com.mckoi.util.Cache
- Cache(int, int) - Constructor for class com.mckoi.util.Cache
- Cache(int, int, int) - Constructor for class com.mckoi.util.Cache
-
The Constructors.
- CACHE - Static variable in interface com.mckoi.database.sql.SQLConstants
- cache_value - Variable in class com.mckoi.database.interpret.Sequence
- Cache.ListNode - Class in com.mckoi.util
-
An element in the linked list structure.
- cached_function - Variable in class com.mckoi.database.FunctionDef
-
A cached Function object that was generated when this FunctionDef was looked up.
- cached_table_name - Variable in class com.mckoi.database.MasterTableDataSource
-
A cached TableName for this data source.
- CachedRow() - Constructor for class com.mckoi.database.jdbc.RowCache.CachedRow
- cachedTableName() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns a cached TableName for this data source.
- CachePointNode(QueryPlanNode) - Constructor for class com.mckoi.database.QueryPlan.CachePointNode
-
Constructor.
- calcHashCode(long, long) - Static method in class com.mckoi.store.LoggingBufferManager
-
Calculates a hash code given an id value and a page_number value.
- calcHashRIDDifference(int) - Method in class com.mckoi.database.RIDList
-
Calculates the 'hash_rid_difference' variable.
- calcRange(QueryContext, DataTableColumnDef, SelectableRangeSet, Expression) - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
-
Calculates a list of SelectableRange objects that represent the range of the expression.
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TArrayType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TBinaryType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TBooleanType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TDateType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TJavaObjectType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TNullType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TNumericType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TQueryPlanType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TStringType
- calculateApproximateMemoryUse(Object) - Method in class com.mckoi.database.TType
-
Calculates the approximate memory usage of an object of this type in bytes.
- calculateRowReferenceList() - Method in class com.mckoi.database.JoinedTable
-
Returns a row reference list.
- calculateSectorSpan(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Calculates the number of sectors the given length of bytes will span.
- calcValue(int, int, DataCellCache) - Method in class com.mckoi.database.FunctionTable
-
Return a TObject that represents the value of the 'column', 'row' of this table.
- Call - Class in com.mckoi.database.interpret
-
A statement that calls a procedure, and returns a resultant table.
- Call() - Constructor for class com.mckoi.database.interpret.Call
- Call() - Method in class com.mckoi.database.sql.SQL
- CALL - Static variable in interface com.mckoi.database.sql.SQLConstants
- call_back - Variable in class com.mckoi.database.DatabaseConnection
-
A loop-back object that is managing this connection.
- CALLBACK - Static variable in interface com.mckoi.database.sql.SQLConstants
- can_be_recovered - Variable in class com.mckoi.store.JournalledSystem.JournalSummary
-
True if the journal is recoverable (has one or more complete check points available).
- canBeRepresentedAsInt() - Method in class com.mckoi.util.BigNumber
-
Returns true if this BigNumber can be represented by a 32-bit int (has no scale).
- canBeRepresentedAsLong() - Method in class com.mckoi.util.BigNumber
-
Returns true if this BigNumber can be represented by a 64-bit long (has no scale).
- cancel() - Method in class com.mckoi.database.jdbc.MStatement
- cancel() - Static method in class com.mckoi.jfccontrols.QueryAgent
-
Cancels the query that is currently being executed (if any).
- cancelQuery() - Method in class com.mckoi.jfccontrols.QueryAgent
-
Cancels any query that is currently being executed by this agent.
- cancelRowUpdates() - Method in class com.mckoi.database.jdbc.MResultSet
- canContain(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns true if the block has enough room to fill with the given number of integers.
- canContain(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Returns true if the block has enough room to fill with the given number of integers.
- canMakeString(Object) - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns true if the given object is either an instanceof StringObject or is an instanceof StreamableObject, and therefore can be made into a string.
- CANONICAL_DECOMPOSITION - Static variable in interface com.mckoi.database.sql.SQLConstants
- canPlansBeNaturallyJoined(Planner.PlanTableSource, Planner.PlanTableSource) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Returns true if it is possible to naturally join the two plans.
- canPrepare(Object) - Method in interface com.mckoi.database.ExpressionPreparer
-
Returns true if this preparer will prepare the given object in an expression.
- canUserAlterTableObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can alter a table or view with the given name, otherwise returns false.
- canUserCompactTableObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can compact a table with the given name, otherwise returns false.
- canUserCreateAndDropSchema(DatabaseQueryContext, User, String) - Method in class com.mckoi.database.Database
-
Returns true if the user is permitted to create and drop schema's in the database, otherwise returns false.
- canUserCreateAndDropUsers(DatabaseQueryContext, User) - Method in class com.mckoi.database.Database
-
Returns true if the user is permitted to create, alter and drop user information from the database, otherwise returns false.
- canUserCreateProcedureObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can create a procedure with the given name, otherwise returns false.
- canUserCreateSequenceObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can create a sequence with the given name, otherwise returns false.
- canUserCreateTableObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can create a table or view with the given name, otherwise returns false.
- canUserDeleteFromTableObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can delete from a table or view with the given name and given columns, otherwise returns false.
- canUserDropProcedureObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can drop a procedure with the given name, otherwise returns false.
- canUserDropSequenceObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can drop a sequence with the given name, otherwise returns false.
- canUserDropTableObject(DatabaseQueryContext, User, TableName) - Method in class com.mckoi.database.Database
-
Returns true if the user can drop a table or view with the given name, otherwise returns false.
- canUserExecuteStoredProcedure(DatabaseQueryContext, User, String) - Method in class com.mckoi.database.Database
-
Returns true if the user is allowed to execute the given stored procedure.
- canUserInsertIntoTableObject(DatabaseQueryContext, User, TableName, Variable[]) - Method in class com.mckoi.database.Database
-
Returns true if the user can insert into a table or view with the given name and given columns, otherwise returns false.
- canUserSelectFromTableObject(DatabaseQueryContext, User, TableName, Variable[]) - Method in class com.mckoi.database.Database
-
Returns true if the user can select from a table or view with the given name and given columns, otherwise returns false.
- canUserShutDown(DatabaseQueryContext, User) - Method in class com.mckoi.database.Database
-
Returns true if the user can shut down the database server.
- canUserUpdateTableObject(DatabaseQueryContext, User, TableName, Variable[]) - Method in class com.mckoi.database.Database
-
Returns true if the user can update a table or view with the given name and given columns, otherwise returns false.
- capacity() - Method in class com.mckoi.store.AbstractStore.StoreArea
- capacity() - Method in interface com.mckoi.store.Area
-
Returns the capacity of the area.
- capacity() - Method in interface com.mckoi.store.AreaWriter
-
Returns the size of this area.
- capacity() - Method in class com.mckoi.store.HeapStore.HeapArea
- CASCADE - Static variable in interface com.mckoi.database.sql.SQLConstants
- CASCADE - Static variable in class com.mckoi.database.Transaction
- case_insensitive - Variable in class com.mckoi.database.interpret.FromTableDirectSource
-
Set to true if this should do case insensitive resolutions.
- case_insensitive - Variable in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Set to true if this should do case insensitive resolutions.
- case_insensitive - Variable in class com.mckoi.database.interpret.TableExpressionFromSet
-
Set to true if this should do case insensitive resolutions.
- case_insensitive_identifiers - Variable in class com.mckoi.database.DatabaseConnection
-
True if this connection resolves identifiers case insensitive.
- case_insensitive_identifiers - Variable in class com.mckoi.database.jdbc.MConnection
-
This is set to true if the MResultSet column lookup methods are case insensitive.
- case_insensitive_identifiers - Variable in class com.mckoi.database.sql.SQL
-
Set to true if the SQL identifiers are converted to upper case.
- caseCheck(String) - Method in class com.mckoi.database.sql.SQL
-
If the parser has been defined as case insensitive then this returns the uppercase version of the given string.
- CAST - Static variable in interface com.mckoi.database.sql.SQLConstants
- cast_to_type - Variable in class com.mckoi.database.InternalFunctionFactory.SQLCastFunction
- castArg(TObject, Class) - Static method in class com.mckoi.database.Caster
-
Cast the object to the specified target.
- castArgs(TObject[], Class[]) - Static method in class com.mckoi.database.Caster
-
Cast the given arguments to the specified classes.
- castArgsToConstructor(TObject[], Constructor) - Static method in class com.mckoi.database.Caster
-
Cast the given arguments to the specified constructors parameter types.
- Caster - Class in com.mckoi.database
-
Methods to choose and perform casts from database type to Java types.
- Caster() - Constructor for class com.mckoi.database.Caster
- CastHelper - Class in com.mckoi.database.global
-
Various utility methods for helping to cast a Java object to a type that is conformant to an SQL type.
- CastHelper() - Constructor for class com.mckoi.database.global.CastHelper
- castObjectToSQLType(Object, int, int, int, String) - Static method in class com.mckoi.database.global.CastHelper
-
Casts a Java object to the SQL type specified by the given DataTableColumnDef object.
- castObjectToTType(Object, TType) - Static method in class com.mckoi.database.TType
-
Casts the given Java object to the given type.
- castTo(TType) - Method in class com.mckoi.database.TObject
-
Casts this object to the given type and returns a new TObject.
- castToMckoiObject(Object) - Method in class com.mckoi.database.jdbc.MPreparedStatement
-
Converts a Java Object using the JDBC type conversion rules.
- CATALOG - Static variable in class com.mckoi.database.GrantManager
-
Represents a CATALOG object to grant privs over for this user.
- cell_in - Variable in class com.mckoi.database.V1MasterTableDataSource
-
The persistent object we use to read information from a row stream.
- CellBufferInputStream - Class in com.mckoi.database
-
This is a reusable cell stream object that is extended from the ByteArrayInputStream class, which provides methods for reusing the object on a different byte[] arrays.
- CellBufferInputStream() - Constructor for class com.mckoi.database.CellBufferInputStream
-
The Constructor.
- CellBufferOutputStream - Class in com.mckoi.database
-
This is a ByteArrayOutputStream that allows access to the underlying byte array.
- CellBufferOutputStream(int) - Constructor for class com.mckoi.database.CellBufferOutputStream
-
The Constructor.
- CellInput - Interface in com.mckoi.database
- CellInputStream - Class in com.mckoi.database
-
An implementation of CellInput that reads data from an underlying stream.
- CellInputStream(InputStream) - Constructor for class com.mckoi.database.CellInputStream
-
The Constructor.
- chainComposite(TableSelectExpression, String, boolean) - Method in class com.mckoi.database.interpret.TableSelectExpression
-
Chains a new composite function to this expression.
- changeRangeSizeToEncompass(SelectableRange, SelectableRange) - Static method in class com.mckoi.database.SelectableRangeSet
-
Alters the first range so it encompasses the second range.
- changes_since_commit - Variable in class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- changeSQL(String) - Method in class com.mckoi.jfccontrols.Query
-
Returns a copy of this Query object but with a different query string.
- CHAR - Static variable in interface com.mckoi.database.global.SQLTypes
- CHAR - Static variable in interface com.mckoi.database.sql.SQLConstants
- char_buffer - Variable in class com.mckoi.database.CellBufferInputStream
- char_buffer - Variable in class com.mckoi.database.CellInputStream
- char_buffer - Variable in class com.mckoi.database.DataCellSerialization
- CHARACTER - Static variable in interface com.mckoi.database.sql.SQLConstants
- CHECK - Static variable in class com.mckoi.database.interpret.ConstraintDef
-
A CHECK constraint.
- CHECK - Static variable in interface com.mckoi.database.sql.SQLConstants
- check_expression - Variable in class com.mckoi.database.interpret.ConstraintDef
- CHECK_INFO_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- check_point_in_progress - Variable in class com.mckoi.store.LoggingBufferManager
-
Set to true when a 'setCheckPoint' is in progress.
- CHECK_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
A Check constraint violation error code.
- checkAccess(int) - Method in class com.mckoi.database.Lock
-
Checks the access for this lock.
- checkAccess(DataTable, int) - Method in class com.mckoi.database.LockHandle
-
Blocks until access to the given DataTable object is safe.
- checkAccess(Lock) - Method in class com.mckoi.database.LockingQueue
-
Looks at the queue and _blocks_ if the access to the table by the means specified in the lock is allowed or not.
- checkAddConstraintViolations(SimpleTransaction, TableDataSource, int[], short) - Static method in class com.mckoi.database.TableDataConglomerate
-
Performs constraint violation checks on an addition of the given set of row indices into the TableDataSource in the given transaction.
- checkAddConstraintViolations(SimpleTransaction, TableDataSource, int, short) - Static method in class com.mckoi.database.TableDataConglomerate
-
Performs constraint violation checks on an addition of the given row index into the TableDataSource in the given transaction.
- checkAllAddConstraintViolations(SimpleTransaction, TableDataSource, short) - Static method in class com.mckoi.database.TableDataConglomerate
-
Performs constraint violation checks on all the rows in the given table.
- checkAllConstraints(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Checks all the rows in the table for immediate constraint violations and when the transaction is next committed check for all deferred constraint violations.
- checkAllConstraints(TableName) - Method in class com.mckoi.database.Transaction
-
Checks all the rows in the table for immediate constraint violations and when the transaction is next committed check for all deferred constraint violations.
- checkAllowCreate(TableName) - Static method in class com.mckoi.database.DatabaseConnection
-
Generates an exception if the name of the table is reserved and the creation of the table should be prevented.
- checkAndRepair(String, UserTerminal) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Performs a complete check and repair of the table.
- checkAndRepair(String, UserTerminal) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Performs a complete check and repair of the table.
- checkAndRepairRecord(int, List, UserTerminal) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Checks and repairs a record if it requires repairing.
- checkAvailable(InetAddress, int) - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Checks to see if there's already something listening on the jdbc port.
- checkClean() - Method in class com.mckoi.database.DataCellCache.DCCache
- checkClean() - Method in class com.mckoi.util.Cache
-
This is called whenever at Object is put into the cache.
- checkColumnConstraint(String, String[], TableName, String) - Method in class com.mckoi.database.interpret.AlterTable
- checkColumnList(ArrayList) - Method in class com.mckoi.database.interpret.ColumnChecker
-
Checks all the columns in the list and throws an exception if any column names are not found in the columns in this create.
- checkColumnNamesMatch(DatabaseConnection, String, String) - Method in class com.mckoi.database.interpret.AlterTable
-
Returns true if the column names match.
- checkCurrentConnection() - Method in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
Checks each connection in the 'service_connection_list' list.
- checkCurrentConnections() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
Checks each connection in the 'service_connection_list' list.
- checkExclusive() - Method in class com.mckoi.database.DatabaseConnection
- checkExists(DBConfig) - Method in interface com.mckoi.database.jdbc.LocalBootable
-
Attempts to test if the database exists or not.
- checkExists(DBConfig) - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Attempts to test if the database exists or not.
- checkExpression(Expression) - Method in class com.mckoi.database.interpret.ColumnChecker
-
Resolves all the variables in the expression throwing a DatabaseException if any errors found.
- CheckExpression() - Constructor for class com.mckoi.database.Transaction.CheckExpression
- checkFieldConstraintViolations(SimpleTransaction, TableDataSource, int[]) - Static method in class com.mckoi.database.TableDataConglomerate
-
Checks that the nullibility and class of the fields in the given rows are valid.
- checkForCleanup() - Method in class com.mckoi.database.MasterTableDataSource
-
Checks to determine if it is safe to clean up any resources in the table, and if it is safe to do so, the space is reclaimed.
- checkForCleanup() - Method in class com.mckoi.database.V1MasterTableDataSource
- checkForCleanup() - Method in class com.mckoi.database.V2MasterTableDataSource
- checkImmutable() - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Throws an error if the list is immutable.
- checkInExclusiveMode() - Method in class com.mckoi.database.DataTable
-
Checks the database is in exclusive mode.
- checkLogSize() - Method in class com.mckoi.util.LogWriter
-
Checks the size of the file, and if it has reached or exceeded the maximum limit then archive the log.
- checkMutable() - Method in class com.mckoi.database.DataTableDef
-
Checks that this object is mutable.
- checkNotDisposed() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Checks if the interface is disposed, and if it is generates a friendly SQLException informing the user of this.
- checkOut() - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- checkOut() - Method in class com.mckoi.store.HeapStore.HeapArea
- checkOut() - Method in interface com.mckoi.store.MutableArea
-
Checks out all changes made to this area.
- checkPointer(long) - Method in class com.mckoi.store.AbstractStore
-
Checks the pointer is valid.
- checkPositionBounds(int) - Method in class com.mckoi.store.AbstractStore.StoreArea
- checkPositionBounds(int) - Method in class com.mckoi.store.HeapStore.HeapArea
- checkReadLock() - Method in class com.mckoi.database.DataTable
-
Check that we can safely read from this table.
- checkReadWriteLock() - Method in class com.mckoi.database.DataTable
-
Check that we can safely read/write from this table.
- checkRemoveConstraintViolations(SimpleTransaction, TableDataSource, int[], short) - Static method in class com.mckoi.database.TableDataConglomerate
-
Performs constraint violation checks on a removal of the given set of row indexes from the TableDataSource in the given transaction.
- checkRemoveConstraintViolations(SimpleTransaction, TableDataSource, int, short) - Static method in class com.mckoi.database.TableDataConglomerate
-
Performs constraint violation checks on a removal of the given row index from the TableDataSource in the given transaction.
- checkSafeOperation() - Method in class com.mckoi.database.DataTable
-
Check that we can run a safe operation.
- checkSchemeSorted() - Method in class com.mckoi.database.InsertSearch
-
Checks that the scheme is in sorted order.
- checkSorted(IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
- checkSorted(IntegerIterator, IndexComparator) - Static method in class com.mckoi.util.AbstractBlockIntegerList
- checkUserSelectPermissions(DatabaseQueryContext, User, QueryPlanNode) - Static method in class com.mckoi.database.interpret.Select
-
Checks the permissions for this user to determine if they are allowed to select (read) from tables in this plan.
- checkVisibleTables(UserTerminal) - Method in class com.mckoi.database.TableDataConglomerate
-
Checks the list of committed tables in this conglomerate.
- child - Variable in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
-
The single child node.
- child() - Method in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
-
Returns the child plan.
- class_constraint - Variable in class com.mckoi.database.DataTableColumnDef
-
If this is a Java Object column, this is a constraint that the object must be derived from to be added to this column.
- class_type - Variable in class com.mckoi.database.TJavaObjectType
-
The type of class this is contrained to or null if it is not constrained to a java class.
- classType() - Method in class com.mckoi.database.DataTableColumnDef
-
Returns the Class of Java object that represents this column.
- classType() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns the class of Java object for this field.
- clean() - Method in class com.mckoi.util.Cache
-
Cleans away some old elements in the cache.
- cleanup() - Method in class com.mckoi.database.Transaction
-
Cleans up this transaction.
- cleanup_queue - Variable in class com.mckoi.database.SimpleTransaction
-
A queue of MasterTableDataSource and IndexSet objects that are pending to be cleaned up when this transaction is disposed.
- cleanUpConglomerate() - Method in class com.mckoi.database.TableDataConglomerate
-
Cleans up the conglomerate by deleting all tables marked as deleted.
- clear() - Method in class com.mckoi.database.jdbc.RowCache
-
Flushes the complete contents of the cache.
- clear() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Clears all the parameters.
- clear() - Method in class com.mckoi.database.TableDescriptions
-
Clears this object completely.
- clear() - Method in class com.mckoi.jfccontrols.ResultSetTableModel
-
Clears the model of the current result set.
- clear() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Clears the object to be re-used.
- clear() - Method in class com.mckoi.util.Cache
- clear() - Method in class com.mckoi.util.IntegerListBlockInterface
-
Clears the object to be re-used.
- clear() - Method in class com.mckoi.util.IntegerVector
-
Clears the object to be re-used.
- clear() - Method in class com.mckoi.util.StringListBucket
-
Clears the list of all string elements.
- clear(Object) - Method in class com.mckoi.util.HashMapList
-
Clears the all the values for the given key.
- clearAllDatabaseConnectionTriggers(DatabaseConnection) - Method in class com.mckoi.database.TriggerManager
-
Clears all the user triggers that have been defined.
- clearAllGrants(DatabaseConnection) - Method in class com.mckoi.database.Database
-
Clears all the grant information in the sUSRGrant table.
- clearAllRootLocks() - Method in class com.mckoi.database.MasterTableDataSource
-
Clears all root locks on the table.
- clearBatch() - Method in class com.mckoi.database.jdbc.MStatement
- clearCache() - Method in class com.mckoi.database.AbstractQueryContext
-
Clears the cache of any cached tables.
- clearCache() - Method in interface com.mckoi.database.QueryContext
-
Clears the cache of any cached tables.
- clearColumnScheme(int) - Method in class com.mckoi.database.DefaultDataTable
-
Clears the SelectableScheme information for the given column.
- clearDeletedSectors() - Method in class com.mckoi.database.FixedSizeDataStore
-
Cleans up so all deleted sectors are completely removed from the store.
- clearHash() - Method in class com.mckoi.util.Cache
-
Clears the entire hashtable of all entries.
- clearInternal() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
-
Clears the internal state.
- clearParameters() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- clearProcessingRequest() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
-
Clears the flag that says we are processing a request.
- clearResultSetMap() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Clears the contents of the result set map.
- clearWarnings() - Method in class com.mckoi.database.jdbc.MConnection
- clearWarnings() - Method in class com.mckoi.database.jdbc.MResultSet
- clearWarnings() - Method in class com.mckoi.database.jdbc.MStatement
- client_closed - Variable in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
If this is set to true, the thread run method should close off.
- client_threads - Variable in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
The list of all threads that were created to deal with incoming commands.
- ClientThread(ServerConnection) - Constructor for class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
The Constructor.
- CLOB - Static variable in interface com.mckoi.database.global.SQLTypes
- CLOB - Static variable in interface com.mckoi.database.sql.SQLConstants
- ClobRef - Interface in com.mckoi.database.global
-
A reference to a large character object in the database.
- ClobRefImpl(long, byte, long, boolean) - Constructor for class com.mckoi.database.BlobStore.ClobRefImpl
-
Constructs the ClobRef implementation.
- clone() - Method in class com.mckoi.database.Assignment
- clone() - Method in class com.mckoi.database.CorrelatedVariable
-
Clones the object.
- clone() - Method in class com.mckoi.database.Expression
-
Performs a deep clone of this object, calling 'clone' on any elements that are mutable or shallow copying immutable members.
- clone() - Method in class com.mckoi.database.FunctionDef
-
Performs a deep clone of this object.
- clone() - Method in class com.mckoi.database.interpret.AlterTableAction
- clone() - Method in class com.mckoi.database.interpret.ByColumn
- clone() - Method in class com.mckoi.database.interpret.ColumnDef
- clone() - Method in class com.mckoi.database.interpret.ConstraintDef
- clone() - Method in class com.mckoi.database.interpret.FromClause
- clone() - Method in class com.mckoi.database.interpret.FromTableDef
-
Clones the object (deep clone of immutable members).
- clone() - Method in class com.mckoi.database.interpret.SearchExpression
- clone() - Method in class com.mckoi.database.interpret.SelectColumn
- clone() - Method in class com.mckoi.database.interpret.TableSelectExpression
- clone() - Method in class com.mckoi.database.JoiningSet
-
Performs a deep clone on this object.
- clone() - Method in class com.mckoi.database.JoiningSet.JoinPart
- clone() - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
Deep clone.
- clone() - Method in class com.mckoi.database.QueryPlan.CachePointNode
- clone() - Method in class com.mckoi.database.QueryPlan.ConstantSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.CreateFunctionsNode
- clone() - Method in class com.mckoi.database.QueryPlan.DistinctNode
- clone() - Method in class com.mckoi.database.QueryPlan.EquiJoinNode
- clone() - Method in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.FetchTableNode
- clone() - Method in class com.mckoi.database.QueryPlan.FetchViewNode
- clone() - Method in class com.mckoi.database.QueryPlan.FunctionalSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.GroupNode
- clone() - Method in class com.mckoi.database.QueryPlan.JoinNode
- clone() - Method in class com.mckoi.database.QueryPlan.MarkerNode
- clone() - Method in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
- clone() - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.SimpleSelectNode
- clone() - Method in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
-
Deep clone.
- clone() - Method in class com.mckoi.database.QueryPlan.SingleRowTableNode
- clone() - Method in class com.mckoi.database.QueryPlan.SortNode
- clone() - Method in class com.mckoi.database.QueryPlan.SubsetNode
- clone() - Method in interface com.mckoi.database.QueryPlanNode
-
Deep clones this query plan.
- clone() - Method in class com.mckoi.database.StatementTree
-
Performs a deep clone of this object, calling 'clone' on any elements that are mutable or shallow copying immutable members.
- clone() - Method in interface com.mckoi.database.StatementTreeObject
-
Performs a DEEP clone of this object if it is mutable, or a deep clone of its mutable members.
- clone() - Method in class com.mckoi.database.Variable
-
Performs a deep clone of this object.
- cloneArray(Expression[]) - Static method in class com.mckoi.database.QueryPlan
-
Convenience, replaces all elements of the array with clone versions of themselves.
- cloneArray(Variable[]) - Static method in class com.mckoi.database.QueryPlan
-
Convenience, replaces all elements of the array with clone versions of themselves.
- cloneSingleObject(Object) - Static method in class com.mckoi.database.StatementTree
-
Clones a single object.
- close() - Method in class com.mckoi.database.BlobStore.AbstractRef
-
Marks this large object as closed to write operations.
- close() - Method in class com.mckoi.database.CellBufferInputStream
- close() - Method in class com.mckoi.database.CellInputStream
- close() - Method in class com.mckoi.database.control.DBSystem
-
Closes this database system so it is no longer able to process queries.
- close() - Method in class com.mckoi.database.DatabaseConnection
-
Closes this database connection.
- close() - Method in class com.mckoi.database.DataCellSerialization
- close() - Method in class com.mckoi.database.FixedSizeDataStore
-
Closes the data store.
- close() - Method in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
- close() - Method in class com.mckoi.database.IndexSetStore
-
Closes this index set (cleans up).
- close() - Method in class com.mckoi.database.IndexStore
-
Cleanly closes the index store.
- close() - Method in class com.mckoi.database.InternalJDBCHelper.InternalConnection
-
Overwritten from MConnection - closing an internal connection is a no-op.
- close() - Method in class com.mckoi.database.jdbc.AsciiReader
- close() - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- close() - Method in class com.mckoi.database.jdbc.MConnection
- close() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- close() - Method in class com.mckoi.database.jdbc.MResultSet
- close() - Method in class com.mckoi.database.jdbc.MStatement
- close() - Method in interface com.mckoi.database.jdbcserver.ConnectionPoolServer
-
Closes this connection pool server down.
- close() - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Closes the connection with the client.
- close() - Method in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
Call this method to stop the thread.
- close() - Method in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
Closes this connection pool server down.
- close() - Method in interface com.mckoi.database.jdbcserver.ServerConnection
-
Closes this connection.
- close() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
Closes this connection pool server down.
- close() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
Call this method to stop the farmer thread.
- close() - Method in class com.mckoi.database.jdbcserver.TCPJDBCServerConnection
-
Completely closes the connection to the client.
- close() - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Closes the JDBC Server.
- close() - Method in class com.mckoi.database.TableDataConglomerate
-
Closes this conglomerate.
- close() - Method in class com.mckoi.database.V1MasterTableDataSource
-
Closes this master table in the file system.
- close() - Method in class com.mckoi.database.VariableSizeDataStore
-
Closes the data store.
- close() - Method in class com.mckoi.store.AbstractStore.AreaOutputStream
- close() - Method in class com.mckoi.store.AbstractStore
-
Closes the store.
- close() - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- close() - Method in class com.mckoi.store.IOStoreDataAccessor
- close() - Method in interface com.mckoi.store.JournalledResource
-
Closes the resource.
- close() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Closes the journal file.
- close() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Closes the resource.
- close() - Method in class com.mckoi.store.JournalledSystem.Resource
-
Closes the resource.
- close() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- close() - Method in interface com.mckoi.store.StoreDataAccessor
-
Closes the underlying data area representation.
- close() - Method in class com.mckoi.store.StreamFile
-
Closes the file.
- close() - Method in class com.mckoi.util.Log
-
Closes the log file.
- close() - Method in class com.mckoi.util.LogWriter
- close() - Method in class com.mckoi.util.NullLog
- close() - Method in class com.mckoi.util.PagedInputStream
- close(boolean) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Closes this master table in the file system.
- close(JournalledResource) - Method in class com.mckoi.store.LoggingBufferManager
- CLOSE - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Closes the protocol stream.
- close_transaction_disabled - Variable in class com.mckoi.database.DatabaseConnection
-
A flag which if set to true, will not allow 'commit' or 'rollback' commands on the transaction to occur and therefore prevent any open transaction from closing.
- closeAndCommit() - Method in class com.mckoi.database.Transaction
-
Closes and marks a transaction as committed.
- closeAndDelete() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Closes and deletes the journal file.
- closeAndDropTable(String) - Method in class com.mckoi.database.TableDataConglomerate
-
Closes and drops the MasterTableDataSource.
- closeAndRollback() - Method in class com.mckoi.database.Transaction
-
Closes and rolls back a transaction as if the commands the transaction ran never happened.
- closeConnection() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
-
Closes the connection.
- closeConnection() - Method in class com.mckoi.database.jdbc.StreamDatabaseInterface
- closeCurrentResult() - Method in class com.mckoi.database.jdbc.MResultSet
-
Closes the current server side result for this result set ready for a new one.
- closed - Variable in class com.mckoi.database.jdbc.StreamDatabaseInterface
- closed - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable.LocalJDBCDatabaseInterface
- closed - Variable in class com.mckoi.database.Transaction
-
True if this transaction is closed.
- closed_on_server - Variable in class com.mckoi.database.jdbc.MResultSet
-
Set to true if the result set is closed on the server.
- closeOnCompletion() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- closeOnCompletion() - Method in class com.mckoi.database.jdbc.MStatement
- closeStore(Store) - Method in interface com.mckoi.database.StoreSystem
-
Closes a store that has been either created or opened with the 'createStore' or 'openStore' methods.
- closeStore(Store) - Method in class com.mckoi.database.V1FileStoreSystem
- closeStore(Store) - Method in class com.mckoi.database.V1HeapStoreSystem
- closestPrime(int) - Static method in class com.mckoi.database.DataCellCache
-
Returns a prime number from PRIME_LIST that is the closest prime greater or equal to the given value.
- closeTable(String, boolean) - Method in class com.mckoi.database.TableDataConglomerate
-
Closes the MasterTableDataSource with the given source ident.
- closeTransaction(Transaction) - Method in class com.mckoi.database.TableDataConglomerate
-
This is called to notify the conglomerate that the transaction has closed.
- cmd - Variable in class com.mckoi.database.interpret.Statement
-
The StatementTree object that is the container for the query.
- coalescArea(long, long) - Method in class com.mckoi.store.AbstractStore
-
Coalesc one or more areas into a larger area.
- CoalesceFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.CoalesceFunction
- col_count - Variable in class com.mckoi.database.RowData
-
The number of columns in the row.
- col_desc - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
A set of ColumnDescription that describes each column in the ResultSet.
- col_index_list - Variable in class com.mckoi.database.interpret.Insert
-
For 'from_values' and 'from_select', this is a list of indices into the 'insert_table' for the columns that we are inserting data into.
- col_list - Variable in class com.mckoi.database.interpret.Insert
- col_list - Variable in class com.mckoi.database.jdbc.MResultSet
-
The array of ColumnDescription that describes each column in the result set.
- COL_LOOKUP_LOCK - Variable in class com.mckoi.database.DataTableDef
- COL_LOOKUP_LOCK - Variable in class com.mckoi.database.Table
- col_name_lookup - Variable in class com.mckoi.database.DataTableDef
- col_name_lookup - Variable in class com.mckoi.database.Table
- col_var_list - Variable in class com.mckoi.database.interpret.Insert
-
The list of Variable objects the represent the list of columns being inserted into in this query.
- COLLATE - Static variable in interface com.mckoi.database.sql.SQLConstants
- CollatedBaseSearch - Class in com.mckoi.database
-
An implementation of SelectableScheme that is based on some collated set of data.
- CollatedBaseSearch(TableDataSource, int) - Constructor for class com.mckoi.database.CollatedBaseSearch
-
The Constructor.
- collator - Variable in class com.mckoi.database.TStringType
-
The Collator object for this type, created when we first compare objects.
- CollectionEvent() - Constructor for class com.mckoi.database.MasterTableGarbageCollector.CollectionEvent
- column - Variable in class com.mckoi.database.DataCellCache.DCCacheKey
- column - Variable in class com.mckoi.database.RIDList
-
The column in the master table.
- column - Variable in class com.mckoi.database.SelectableScheme
-
The column number in the tree this tree helps.
- column - Variable in class com.mckoi.database.sql.SimpleCharStream
- column_count - Variable in class com.mckoi.database.MasterTableDataSource
-
The number of columns in this table.
- column_count - Variable in class com.mckoi.database.MultiVersionTableIndices
-
The number of columns in the referenced table.
- column_filter - Variable in class com.mckoi.database.JoinedTable
-
Gives a column filter to the given column to route correctly to the ancestor.
- column_hash - Variable in class com.mckoi.database.jdbc.MResultSet
-
A Hashtable that acts as a cache for column name/column number look ups.
- column_list - Variable in class com.mckoi.database.DataTableDef
-
The list of DataTableColumnDef objects that are the definitions of each column in the table.
- column_list - Variable in class com.mckoi.database.interpret.ConstraintDef
- column_list2 - Variable in class com.mckoi.database.interpret.ConstraintDef
- column_map - Variable in class com.mckoi.database.SubsetColumnTable
-
Maps from the column in this table to the column in the parent table.
- column_name - Variable in class com.mckoi.database.RIDList
-
The name of the column of this rid list.
- column_name - Variable in class com.mckoi.database.Variable
-
The column name itself.
- column_names - Variable in class com.mckoi.database.DataIndexDef
-
The list of column name that this index represents.
- column_rid_list - Variable in class com.mckoi.database.MasterTableDataSource
-
The list of RIDList objects for each column in this table.
- column_scheme - Variable in class com.mckoi.database.CompositeTable
-
The schemes to describe the entity relation in the given column.
- column_scheme - Variable in class com.mckoi.database.DefaultDataTable
-
A list of schemes for managing the data relations of each column.
- column_scheme - Variable in class com.mckoi.database.FilterTable
-
The schemes to describe the entity relation in the given column.
- column_scheme - Variable in class com.mckoi.database.JoinedTable
-
The schemes to describe the entity relation in the given column.
- column_schemes - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The SelectableScheme array that represents the schemes for the columns within this transaction.
- column_sets - Variable in class com.mckoi.database.interpret.Insert
- column_sets - Variable in class com.mckoi.database.interpret.UpdateTable
-
An array of Assignment objects which represent what we are changing.
- column_table - Variable in class com.mckoi.database.JoinedTable
-
Maps the column number in this table to the reference_list array to route to.
- columnAt(int) - Method in class com.mckoi.database.DataTableDef
- ColumnChecker - Class in com.mckoi.database.interpret
-
A class that abstracts the checking of information in a table.
- ColumnChecker() - Constructor for class com.mckoi.database.interpret.ColumnChecker
- ColumnConstraint(ColumnDef) - Method in class com.mckoi.database.sql.SQL
- columnContainsCell(int, TObject) - Method in class com.mckoi.database.Table
-
Returns true if the given cell is found in the table.
- columnContainsValue(int, TObject) - Method in class com.mckoi.database.Table
-
Returns true if the given column number contains the value given.
- columnCount() - Method in class com.mckoi.database.DataTableDef
- columnCount() - Method in class com.mckoi.database.jdbc.MResultSet
-
The column count of columns in the result set.
- ColumnDataType(ColumnDef) - Method in class com.mckoi.database.sql.SQL
- ColumnDeclarationList(ArrayList, ArrayList) - Method in class com.mckoi.database.sql.SQL
- ColumnDef - Class in com.mckoi.database.interpret
-
Represents a column definition (description).
- ColumnDef() - Constructor for class com.mckoi.database.interpret.ColumnDef
- ColumnDefinition() - Method in class com.mckoi.database.sql.SQL
- ColumnDescription - Class in com.mckoi.database.global
-
This is a description of a column and the data it stores.
- ColumnDescription(ColumnDescription) - Constructor for class com.mckoi.database.global.ColumnDescription
- ColumnDescription(String, int, boolean) - Constructor for class com.mckoi.database.global.ColumnDescription
- ColumnDescription(String, int, int, boolean) - Constructor for class com.mckoi.database.global.ColumnDescription
-
The Constructors if the type does require a size.
- ColumnDescription(String, ColumnDescription) - Constructor for class com.mckoi.database.global.ColumnDescription
- columnDescriptionValue(String) - Method in class com.mckoi.database.DataTableColumnDef
-
Returns this column as a ColumnDescription object and gives the column description the given name.
- ColumnGroup() - Constructor for class com.mckoi.database.Transaction.ColumnGroup
- ColumnGroupReference() - Constructor for class com.mckoi.database.Transaction.ColumnGroupReference
- columnMatchesValue(int, Operator, TObject) - Method in class com.mckoi.database.Table
-
Returns true if the given column contains a value that the given operator returns true for with the given value.
- columnMerge(Table) - Method in class com.mckoi.database.Table
-
Returns a Table that is a merge of this table and the destination table.
- ColumnName() - Method in class com.mckoi.database.sql.SQL
- ColumnNameVariable() - Method in class com.mckoi.database.sql.SQL
- ColumnOrConstraintDefinition(ArrayList, ArrayList) - Method in class com.mckoi.database.sql.SQL
- columns - Variable in class com.mckoi.database.interpret.CreateTable
-
List of column declarations (ColumnDef)
- columns - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The list of columns to select from.
- columns - Variable in class com.mckoi.database.QueryPlan.DistinctNode
-
The list of columns to be distinct.
- columns - Variable in class com.mckoi.database.QueryPlan.GroupNode
-
The columns to group by.
- columns - Variable in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
-
The list of columns to select the range of.
- columns - Variable in class com.mckoi.database.QueryPlan.SortNode
-
The list of columns to sort.
- columns - Variable in class com.mckoi.database.Transaction.ColumnGroup
-
The list of columns that make up the group.
- columnValue(int, Object) - Method in class com.mckoi.database.GTDataSource
-
Returns a TObject that represents a value for the given column in this table.
- com_bytes - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
The command to write out to the server.
- com_data - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
- com.mckoi - package com.mckoi
-
The Mckoi Database; the JDBC driver is in this package.
- com.mckoi.database - package com.mckoi.database
-
The core database classes for Mckoi.
- com.mckoi.database.control - package com.mckoi.database.control
- com.mckoi.database.global - package com.mckoi.database.global
-
This package includes database constants such as Types.
- com.mckoi.database.interpret - package com.mckoi.database.interpret
- com.mckoi.database.jdbc - package com.mckoi.database.jdbc
-
The JDBC interface to Mckoi.
- com.mckoi.database.jdbcserver - package com.mckoi.database.jdbcserver
-
Implementation of the DatabaseInterface interface, including classes to handle local (embedded) mode and remote (client/server) mode.
- com.mckoi.database.procedure - package com.mckoi.database.procedure
- com.mckoi.database.regexbridge - package com.mckoi.database.regexbridge
-
Implementations of the RegexLibrary interface, which allows the application to select which regular expression package to use.
- com.mckoi.database.sql - package com.mckoi.database.sql
-
These classes parse SQL statements in Mckoi.
- com.mckoi.debug - package com.mckoi.debug
-
Debugging classes for Mckoi.
- com.mckoi.jfccontrols - package com.mckoi.jfccontrols
-
JFC classes to access a Mckoi database from a Swing application.
- com.mckoi.runtime - package com.mckoi.runtime
-
The main (starting) class for a Mckoi database server.
- com.mckoi.store - package com.mckoi.store
- com.mckoi.tools - package com.mckoi.tools
-
Tools for manipulating a Mckoi database.
- com.mckoi.util - package com.mckoi.util
-
Miscellaneous utility classes.
- command - Variable in class com.mckoi.database.interpret.CompleteTransaction
- command - Variable in class com.mckoi.database.WorkerThread
-
The Runnable command we are currently processing.
- command_journal - Variable in class com.mckoi.database.MasterTableJournal
-
A byte[] array that represents the set of commands a transaction performed on this table.
- command_journal - Variable in class com.mckoi.database.TransactionJournal
-
A byte[] array that represents the set of commands a transaction performed on a table.
- COMMAND_LOGGING - Static variable in class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
-
Set this to true if command logging is enabled.
- command_parameters - Variable in class com.mckoi.database.MasterTableJournal
-
An IntegerVector that is filled with parameters from the command journal.
- command_parameters - Variable in class com.mckoi.database.TransactionJournal
-
An IntegerVector that is filled with parameters from the command journal.
- CommandLine - Class in com.mckoi.util
-
Used to parse a command-line.
- CommandLine(String[]) - Constructor for class com.mckoi.util.CommandLine
-
Constructs the command line parser from the String[] array passed as the argument to the application.
- commands_list - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
The list of commands received from the server that are pending to be processed (ServerCommand).
- commands_log - Variable in class com.mckoi.database.Database
-
This log file records the DQL commands executed on the server.
- commands_run - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
- commands_waited - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
- comment - Variable in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- commit() - Method in class com.mckoi.database.DatabaseConnection
-
Tries to commit the current transaction.
- commit() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Creates a new buffer for an index store if it is committed.
- commit() - Method in class com.mckoi.database.jdbc.MConnection
- commit() - Method in class com.mckoi.database.StateStore
-
Commits the current state to disk so that it makes a persistent change to the state.
- COMMIT - Static variable in interface com.mckoi.database.sql.SQLConstants
- commit_id - Variable in class com.mckoi.database.MasterTableJournal
-
The commit id given to this change when it is committed.
- commit_id - Variable in class com.mckoi.database.TableDataConglomerate
-
The current commit id for committed transactions.
- commit_id - Variable in class com.mckoi.database.TableDataConglomerate.NameSpaceJournal
-
The commit_id of this journal entry.
- commit_id - Variable in class com.mckoi.database.Transaction
-
The commit_id that represents the id of the last commit that occurred when this transaction was created.
- commit_lock - Variable in class com.mckoi.database.TableDataConglomerate
-
This lock is obtained when we go to commit a change to the table.
- commitDropIndex(int) - Method in class com.mckoi.database.IndexSetStore
-
Commits a change that drops an index from the index set.
- commitIndexHeader() - Method in class com.mckoi.database.IndexSetStore
-
Commits the index header with the current values set in 'index_blocks'.
- commitIndexSet(IndexSet) - Method in class com.mckoi.database.IndexSetStore
-
Commits changes made to a snapshop of an IndexSet as being permanent changes to the state of the index store.
- commitIndexSet(IndexSet) - Method in class com.mckoi.database.IndexStore
-
Commits changes made to a snapshop of an IndexSet as being permanent changes to the state of the index store.
- commitIndexSet(IndexSet) - Method in class com.mckoi.database.MasterTableDataSource
-
Commits changes made to an IndexSet returned by the 'createIndexSet' method.
- commitIndexSet(IndexSet) - Method in class com.mckoi.database.V1MasterTableDataSource
- commitIndexSet(IndexSet) - Method in class com.mckoi.database.V2MasterTableDataSource
- CommitTableInfo() - Constructor for class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- commitTableListContains(List, MasterTableDataSource) - Static method in class com.mckoi.database.TableDataConglomerate
-
Returns true if the given List of 'CommitTableInfo' objects contains an entry for the given master table.
- COMMITTED_ADDED - Static variable in interface com.mckoi.database.RawDiagnosticTable
-
Statics that represent the various states of a record.
- COMMITTED_REMOVED - Static variable in interface com.mckoi.database.RawDiagnosticTable
-
Statics that represent the various states of a record.
- commitToTables(IntegerVector, IntegerVector) - Method in class com.mckoi.database.TableDataConglomerate
-
Sets the given List of MasterTableDataSource objects to the currently committed list of tables in this conglomerate.
- commitTransactionChange(long, MasterTableJournal, IndexSet) - Method in class com.mckoi.database.MasterTableDataSource
-
Adds a new transaction modification to this master table source.
- Compact - Class in com.mckoi.database.interpret
-
Statement that handles COMPACT sql command.
- Compact() - Constructor for class com.mckoi.database.interpret.Compact
- Compact() - Method in class com.mckoi.database.sql.SQL
- COMPACT - Static variable in class com.mckoi.database.Privileges
-
The priv to compact a database object.
- COMPACT - Static variable in interface com.mckoi.database.sql.SQLConstants
- compact_type - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
How this block is compacted in the store.
- compactTable(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Compacts the table with the given name.
- compactTable(TableName) - Method in class com.mckoi.database.Transaction
-
Compacts the table with the given name within this transaction.
- compactTable(String) - Method in class com.mckoi.database.DatabaseConnection
-
Compacts the table with the given name.
- comparableTypes(TObject) - Method in class com.mckoi.database.TObject
-
Returns true if the type of this object is logically comparable to the type of the given object.
- comparableTypes(TType) - Method in class com.mckoi.database.TArrayType
- comparableTypes(TType) - Method in class com.mckoi.database.TBinaryType
- comparableTypes(TType) - Method in class com.mckoi.database.TBooleanType
- comparableTypes(TType) - Method in class com.mckoi.database.TDateType
- comparableTypes(TType) - Method in class com.mckoi.database.TJavaObjectType
- comparableTypes(TType) - Method in class com.mckoi.database.TNullType
- comparableTypes(TType) - Method in class com.mckoi.database.TNumericType
- comparableTypes(TType) - Method in class com.mckoi.database.TQueryPlanType
- comparableTypes(TType) - Method in class com.mckoi.database.TStringType
-
For strings, the locale must be the same for the types to be comparable.
- comparableTypes(TType) - Method in class com.mckoi.database.TType
-
Returns true if the type of this object is logically comparable to the type of the given object.
- compare(int, int) - Method in interface com.mckoi.util.IndexComparator
-
Returns >0 if the value pointed to by index1 is greater than the value pointed to by index2, or &tl; 0 if the value pointed to by index 1 is less than the value pointed to by index 2.
- compare(int, Object) - Method in interface com.mckoi.util.IndexComparator
-
Returns > 0 if the value pointed to by index1 is greater than 'val', or < 0 if the value pointed to by index 1 is less than 'val'.
- compareBlobs(BlobAccessor, BlobAccessor) - Static method in class com.mckoi.database.TBinaryType
-
Utility method for comparing one blob with another.
- compareCells(TObject, TObject, Operator) - Static method in class com.mckoi.database.Table
-
Compares cell1 with cell2 and if the given operator evalutes to true then returns true, otherwise false.
- compareObs(Object, Object) - Method in class com.mckoi.database.TArrayType
- compareObs(Object, Object) - Method in class com.mckoi.database.TBinaryType
- compareObs(Object, Object) - Method in class com.mckoi.database.TBooleanType
- compareObs(Object, Object) - Method in class com.mckoi.database.TDateType
- compareObs(Object, Object) - Method in class com.mckoi.database.TJavaObjectType
- compareObs(Object, Object) - Method in class com.mckoi.database.TNullType
- compareObs(Object, Object) - Method in class com.mckoi.database.TNumericType
- compareObs(Object, Object) - Method in class com.mckoi.database.TQueryPlanType
- compareObs(Object, Object) - Method in class com.mckoi.database.TStringType
- compareObs(Object, Object) - Method in class com.mckoi.database.TType
-
Compares two objects that are logically comparable under this type.
- compareTo(TObject) - Method in class com.mckoi.database.TObject
-
Compares this object with the given object (which is of a logically comparable type).
- compareTo(BigNumber) - Method in class com.mckoi.util.BigNumber
-
Compares this BigNumber with the given BigNumber.
- compareTo(Object) - Method in class com.mckoi.database.DatabaseDispatcher.DatabaseEvent
- compareTo(Object) - Method in class com.mckoi.database.global.NullObject
-
Deprecated.
- compareTo(Object) - Method in class com.mckoi.database.interpret.Planner.ExpressionPlan
- compareTo(Object) - Method in class com.mckoi.database.RawRowElement
- compareTo(Object) - Method in class com.mckoi.database.RawTableElement
- compareTo(Object) - Method in class com.mckoi.database.TableName
-
Comparable.
- compareTo(Object) - Method in class com.mckoi.database.Variable
-
Comparable.
- compareToNoNulls(TObject) - Method in class com.mckoi.database.TObject
-
Compares this object with the given object (which is of a logically comparable type).
- compatIsPrimaryKey() - Method in class com.mckoi.database.DataTableColumnDef
- compatIsUnique() - Method in class com.mckoi.database.DataTableColumnDef
- complete() - Method in class com.mckoi.database.BlobStore.AbstractRef
- complete() - Method in interface com.mckoi.database.global.Ref
-
This method is called when the write phrase has completed, and it marks this large object as complete.
- complete_mark_name - Variable in class com.mckoi.database.QueryPlan.LeftOuterJoinNode
-
The name of the mark that points to the left table that represents the complete set.
- completeBlob(BlobStore.AbstractRef) - Method in class com.mckoi.database.BlobStore
-
Call this to complete a blob in the store after a blob has been completely written.
- completeRecordStreamWrite() - Method in class com.mckoi.database.VariableSizeDataStore
-
Updates the record allocation table with the data in the output stream returned by 'getRecordOutputStream'.
- CompleteTransaction - Class in com.mckoi.database.interpret
-
This represents either a COMMIT or ROLLBACK SQL command.
- CompleteTransaction() - Constructor for class com.mckoi.database.interpret.CompleteTransaction
- CompleteTransaction() - Method in class com.mckoi.database.sql.SQL
- ComplexSingleExpressionPlan(Variable, Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ComplexSingleExpressionPlan
- composite_function - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
If there is a composite function this is set to the composite enumeration from CompositeTable.
- composite_op - Variable in class com.mckoi.database.QueryPlan.CompositeNode
-
The composite operation (either CompositeTable.UNION, EXCEPT, INTERSECT).
- composite_tables - Variable in class com.mckoi.database.CompositeTable
-
The tables being made a composite of.
- CompositeNode(QueryPlanNode, QueryPlanNode, int, boolean) - Constructor for class com.mckoi.database.QueryPlan.CompositeNode
- CompositeTable - Class in com.mckoi.database
-
A composite of two or more datasets used to implement UNION, INTERSECTION, and DIFFERENCE.
- CompositeTable(Table[]) - Constructor for class com.mckoi.database.CompositeTable
-
Consturcts the composite table assuming the first item in the list is the master table.
- CompositeTable(Table, Table[]) - Constructor for class com.mckoi.database.CompositeTable
-
Constructs the composite table given the 'master_table' (the field structure this composite dataset is based on), and a list of tables to be the composite of this table.
- compress_buf - Variable in class com.mckoi.database.DataCellSerialization
- compress_buffer - Variable in class com.mckoi.database.VariableSizeDataStore
- compress_length - Variable in class com.mckoi.database.DataCellSerialization
- COMPRESSED_WRITE_ENABLED - Static variable in class com.mckoi.database.VariableSizeDataStore
-
Set to true to enable compressed writes.
- concat(Expression) - Method in class com.mckoi.database.Expression
-
Merges an expression with this expression.
- CONCAT - Static variable in interface com.mckoi.database.sql.SQLConstants
- concat_op - Static variable in class com.mckoi.database.Operator
- ConcatFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.ConcatFunction
- ConcatOperator() - Constructor for class com.mckoi.database.Operator.ConcatOperator
- concatTableSources(Planner.PlanTableSource, Planner.PlanTableSource, QueryPlanNode) - Static method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Forms a new PlanTableSource that's the concatination of the given two PlanTableSource objects.
- concurrent_modification_data - Variable in class com.mckoi.database.RIDList
- concurrent_modification_info - Variable in class com.mckoi.database.RIDList
-
A list of modifications made to the index while it is being built.
- ConditionsExpression(SearchExpression) - Method in class com.mckoi.database.sql.SQL
- config - Variable in class com.mckoi.database.control.DBSystem
-
The DBConfig object that describes the startup configuration of the database.
- config - Variable in class com.mckoi.database.TransactionSystem
-
The ResourceBundle that contains properties of the entire database system.
- CONFIG_DEFAULTS - Static variable in class com.mckoi.database.control.DefaultDBConfig
-
A Hashtable of default configuration values.
- ConfigProperty(String, String, String) - Constructor for class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- ConfigProperty(String, String, String, String) - Constructor for class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- conglomerate - Variable in class com.mckoi.database.Database
-
The TableDataConglomerate that contains the conglomerate of tables for this database.
- conglomerate - Variable in class com.mckoi.database.DatabaseConnection
-
The TableDataConglomerate object that is used for transactional access to the data.
- conglomerate - Variable in class com.mckoi.database.SequenceManager
-
The TableDataConglomerate object.
- conglomerate - Variable in class com.mckoi.database.Transaction
-
The TableDataConglomerate that this transaction is within the context of.
- conglomerate - Variable in class com.mckoi.tools.ConglomerateViewPane
-
The conglomerate.
- ConglomerateViewPane - Class in com.mckoi.tools
-
The pane the shows the contents of a conglomerate.
- ConglomerateViewPane(TableDataConglomerate) - Constructor for class com.mckoi.tools.ConglomerateViewPane
-
Constructor.
- ConglomerateViewPane.DTableModel - Class in com.mckoi.tools
-
A TableModel for displaying the contents of a RawDiagnosticTable.
- ConglomerateViewPane.StoreViewPane - Class in com.mckoi.tools
-
The view of the content of a store.
- connect(String, Properties) - Method in class com.mckoi.database.jdbc.MDriver
- connect_id - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
The connection id.
- connection - Variable in class com.mckoi.database.ConnectionTriggerManager
-
The DatabaseConnection.
- connection - Variable in class com.mckoi.database.DataTable
-
The DatabaseConnection object that is the parent of this DataTable.
- connection - Variable in class com.mckoi.database.GrantManager
-
The DatabaseConnection instance.
- connection - Variable in class com.mckoi.database.jdbc.AbstractStreamableObject
-
The MConnection object that this object was returned as part of the result of.
- connection - Variable in class com.mckoi.database.jdbc.MckoiConnection
-
The wrapped MConnection.
- connection - Variable in class com.mckoi.database.jdbc.MDatabaseMetaData
-
The Connection object associated with this meta data.
- connection - Variable in class com.mckoi.database.jdbc.MResultSet
-
The MConnection that this result set is in.
- connection - Variable in class com.mckoi.database.jdbc.MStatement
-
The MConnection object for this statement.
- connection - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
-
The local variables.
- connection - Variable in class com.mckoi.database.jdbcserver.TCPJDBCServerConnection
-
The socket connection with the client.
- connection - Variable in class com.mckoi.database.ProcedureManager
-
The DatabaseConnection.
- connection - Variable in class com.mckoi.database.TableModificationEvent
-
The DatabaseConnection of the table that the modification occurred in.
- connection - Variable in class com.mckoi.database.ViewManager
-
The DatabaseConnection.
- connection - Variable in class com.mckoi.jfccontrols.QueryAgent
-
The JDBC Connection object for the connection to the database.
- connection() - Method in class com.mckoi.jfccontrols.QueryAgent
-
Returns the connection for the JDBC interface.
- CONNECTION_INFO - Static variable in class com.mckoi.database.interpret.Show
- connection_internal_table_info - Variable in class com.mckoi.database.DatabaseConnection
-
A local member that represents the static list of internal tables that represent connection specific properties such as username, connection, statistics, etc.
- connection_lock - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
The connection lock object.
- connection_pool - Variable in class com.mckoi.database.jdbcserver.TCPServer
-
The ConnectionPoolServer that polls the ServerConnection for new commands to process.
- connection_pool_model - Variable in class com.mckoi.database.jdbcserver.TCPServer
-
The connection pool model used for this server.
- connection_string - Variable in class com.mckoi.database.User
-
The connection string that identifies how this user is connected to the database.
- connection_thread - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface
-
The thread that dispatches commands to the server.
- connection_trigger_manager - Variable in class com.mckoi.database.DatabaseConnection
-
The connection trigger manager that handles actions that cause triggers to fire on this connection.
- ConnectionInternalTableInfo() - Constructor for class com.mckoi.database.DatabaseConnection.ConnectionInternalTableInfo
-
Constructor.
- ConnectionPoolServer - Interface in com.mckoi.database.jdbcserver
-
An interface for the connection pool for a server.
- CONNECTIONS - Static variable in class com.mckoi.database.interpret.Show
- ConnectionThread() - Constructor for class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Constructs the connection thread.
- ConnectionTriggerManager - Class in com.mckoi.database
-
A trigger manager on a DatabaseConnection that maintains a list of all triggers set in the database, and the types of triggers they are.
- ConnectionTriggerManager(DatabaseConnection) - Constructor for class com.mckoi.database.ConnectionTriggerManager
-
Constructs the manager.
- ConnectionTriggerManager.CTMBackedCache - Class in com.mckoi.database
-
A TableBackedCache that manages the list of connection level triggers that are currently active on this connection.
- ConnectionTriggerManager.TriggerInfo - Class in com.mckoi.database
-
Container class for all trigger actions defined on the database.
- ConnectionTriggerManager.TriggerInternalTableInfo - Class in com.mckoi.database
-
An object that models the list of triggers as table objects in a transaction.
- connectToDatabase() - Method in class com.mckoi.database.jdbc.TCPStreamDatabaseInterface
-
Connects to the database.
- connectToJVM() - Method in interface com.mckoi.database.jdbc.LocalBootable
-
Connects this interface to the database currently running in this JVM.
- connectToJVM() - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Creates a new LocalDatabaseInterface that is connected to the database currently running in this VM.
- connectToLocal(String, String, Properties) - Method in class com.mckoi.database.jdbc.MDriver
-
Makes a connection to a local database.
- connSetup(int, ColumnDescription[], int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Called by the ConnectionThread when we have received the initial bag of the result set.
- constant_count - Variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The count of aggregate and constant columns included in the result set.
- ConstantExpressionPlan(Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ConstantExpressionPlan
- ConstantSelectNode(QueryPlanNode, Expression) - Constructor for class com.mckoi.database.QueryPlan.ConstantSelectNode
- constraining_class - Variable in class com.mckoi.database.DataTableColumnDef
-
The constraining Class object itself.
- CONSTRAINT - Static variable in interface com.mckoi.database.sql.SQLConstants
- ConstraintAttributes(ConstraintDef) - Method in class com.mckoi.database.sql.SQL
- ConstraintDef - Class in com.mckoi.database.interpret
-
Represents a constraint definition (description) for a table.
- ConstraintDef() - Constructor for class com.mckoi.database.interpret.ConstraintDef
- constraintIntegrityCheck() - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- constraintIntegrityCheck() - Method in class com.mckoi.database.GTDataSource
- constraintIntegrityCheck() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- constraintIntegrityCheck() - Method in interface com.mckoi.database.MutableTableDataSource
-
Performs all constraint integrity checks and actions to any modifications based on any changes that happened to the table since that last call to this method.
- ConstraintName() - Method in class com.mckoi.database.sql.SQL
- constraints - Variable in class com.mckoi.database.interpret.CreateTable
-
List of table constraints (ConstraintDef)
- constraints_format - Variable in class com.mckoi.database.DataTableColumnDef
-
A string that contains some constraints.
- construct_proto - Variable in class com.mckoi.database.FunctionFactory
-
Constructor arguments for the function.
- constructor - Variable in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- contains(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Assuming the list is sorted, this performs a binary search and returns true if the value is found, otherwise returns false.
- contains(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Assuming the list is sorted, this performs a binary search and returns true if the value is found, otherwise returns false.
- contains(int) - Method in class com.mckoi.util.IntegerVector
-
Returns true if the vector contains the given value.
- contains(Object, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Assuming the list is sorted, this performs a binary search and returns true if the value is found, otherwise returns false.
- contains(Object, IndexComparator) - Method in interface com.mckoi.util.IntegerListInterface
-
Assuming the list is sorted, this performs a binary search and returns true if the key value is found, otherwise returns false.
- contains(String) - Method in class com.mckoi.util.StringListBucket
-
Returns true if the list contains the given element string.
- containsKey(Object) - Method in class com.mckoi.util.HashMapList
-
Returns true if the map contains the key.
- containsLargeObjects() - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns true if this ResultSet contains large objects.
- containsNotOperator() - Method in class com.mckoi.database.Expression
-
Returns true if the expression contains a NOT operator somewhere in it.
- containsSwitch(String) - Method in class com.mckoi.util.CommandLine
-
Returns true if the switch is in the command line.
- containsSwitchFrom(String) - Method in class com.mckoi.util.CommandLine
-
Given a comma deliminated list, this scans for one of the switches in the list.
- containsSwitchStart(String) - Method in class com.mckoi.util.CommandLine
-
Returns true if the command line contains a switch starting with the given string.
- containsTableName(TableName) - Method in class com.mckoi.database.AbstractInternalTableInfo
-
Returns true if this container contains a table with the given name.
- containsTableName(TableName) - Method in class com.mckoi.database.AbstractInternalTableInfo2
- containsTableName(TableName) - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- containsTableName(TableName) - Method in interface com.mckoi.database.InternalTableInfo
-
Returns true if this container contains a table with the given name.
- containsTableName(TableName) - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- containsUniqueKey(String) - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Returns true if this table source contains the unique table name reference.
- containsVariable(Variable) - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Returns true if this table source contains the variable reference.
- containsVisibleResource(int) - Method in class com.mckoi.database.StateStore
-
Returns true if the visible list contains a state resource with the given table id value.
- content - Variable in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- contents - Variable in class com.mckoi.util.Cache.ListNode
-
The object contents for this element.
- context - Variable in class com.mckoi.database.FunctionTable
-
The context of this function table.
- context - Variable in class com.mckoi.database.GrantManager
-
The QueryContext instance.
- context - Variable in class com.mckoi.database.ProcedureManager
-
The context.
- context - Variable in class com.mckoi.database.ViewManager
-
The context.
- controller - Variable in class com.mckoi.database.control.DBSystem
-
The DBController object.
- convert(File, DebugLogger) - Method in class com.mckoi.database.StateStore
-
Reads a legacy state file (pre version 1) and converts it to a state store format compatible with this store.
- convertAllUserTables(DatabaseConnection, PrintStream) - Method in class com.mckoi.database.Database
-
Processes each table in user space and converts the format to the newest version of the data file format.
- convertColumnDef(ColumnDef) - Static method in class com.mckoi.database.interpret.CreateTable
-
Returns a com.mckoi.database.interpret.ColumnDef object a a com.mckoi.database.DataTableColumnDef object.
- convertIndexFiles1(File, IndexStore, DataTableDef, DebugLogger) - Static method in class com.mckoi.database.ConvertUtils
-
Upgrades an .ijf index file to an .iid IndexStore.
- convertPreGrant(DatabaseConnection, String) - Method in class com.mckoi.database.Database
-
Goes through all tables in the database not in the SYS_INFO schema and adds an entry in the grant table for it.
- convertPreSchema(DatabaseConnection) - Method in class com.mckoi.database.Database
-
Converts tables from a database that are pre database schema.
- convertToCurrent(PrintStream, String) - Method in class com.mckoi.database.Database
-
Functionality for converting and old database format to the existing format.
- convertToScatteringStore(File) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
-
Given a file, this will convert to a scattering file store with files no larger than the maximum slice size.
- convertToType(Object, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
-
Converts the given Object to the given SQL type object.
- ConvertUtils - Class in com.mckoi.database
-
Various static database convertion tools for converting for upgrading parts of the database.
- ConvertUtils() - Constructor for class com.mckoi.database.ConvertUtils
- copy() - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Makes a copy of this table source.
- copy() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Makes an exact duplicate copy (deep clone) of this planner object.
- copy() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Creates an exact copy of this object.
- copy(int, MasterTableDataSource, IndexSet) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Creates a new v2 master table data source that is a copy of the given MasterTableDataSource object.
- copy(TableDataSource, boolean) - Method in class com.mckoi.database.BlindSearch
-
Returns an exact copy of this scheme including any optimization information.
- copy(TableDataSource, boolean) - Method in class com.mckoi.database.GTPrivMapDataSource.PrivMapSearch
- copy(TableDataSource, boolean) - Method in class com.mckoi.database.InsertSearch
-
Returns an exact copy of this scheme including any optimization information.
- copy(TableDataSource, boolean) - Method in class com.mckoi.database.SelectableScheme
-
Returns an exact copy of this scheme including any optimization information.
- copyAllFrom(IndexSet) - Method in class com.mckoi.database.IndexSetStore
-
Overwrites all existing index information in this store and sets it to a copy of the given IndexSet object.
- CopyBlobInfo() - Constructor for class com.mckoi.database.BlobStore.CopyBlobInfo
- copyFrom(StoreSystem, BlobStore) - Method in class com.mckoi.database.BlobStore
-
Copies all the blob data from the given BlobStore into this blob store.
- copyFrom(Table, int) - Method in class com.mckoi.database.TemporaryTable
-
Copies the contents of the row of the given Table onto the end of this table.
- copyMasterTable(MasterTableDataSource, IndexSet) - Method in class com.mckoi.database.TableDataConglomerate
-
Creates a table store in this conglomerate that is an exact copy of the given MasterTableDataSource.
- copyRecordFrom(MasterTableDataSource, int) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Copies the record at the given index in the source table to the same record index in this table.
- COPYRIGHT - Static variable in class com.mckoi.database.global.StandardMessages
-
The standard copyright message.
- copyTable(MasterTableDataSource, IndexSet) - Method in class com.mckoi.database.Transaction
-
Generates an exact copy of the table within this transaction.
- copyTextFrom(Expression) - Method in class com.mckoi.database.Expression
-
Copies the text from the given expression.
- copyTo(int[], int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Copies all the data from this block into the given int[] array.
- copyTo(int[], int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Copies all the data from this block into the given int[] array.
- copyTo(AreaWriter, int) - Method in class com.mckoi.store.AbstractStore.StoreArea
- copyTo(AreaWriter, int) - Method in interface com.mckoi.store.Area
-
Copies 'size' bytes from the current position of this Area to the destination AreaWriter.
- copyTo(AreaWriter, int) - Method in class com.mckoi.store.HeapStore.HeapArea
- copyTo(Store) - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Copies this index block to the given Store and returns a pointer to the block within the store.
- copyTo(Store) - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Copies the index data in this block to a new block in the given store and returns a pointer to the new block.
- copyTo(IntegerListBlockInterface) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Copies all the data from this block into the given destination block.
- copyTo(IntegerListBlockInterface) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Copies all the data from this block into the given destination block.
- copyTo(File) - Method in class com.mckoi.database.FixedSizeDataStore
-
Copies the entire contents of this store to a destination directory.
- copyTo(File) - Method in class com.mckoi.database.IndexStore
-
Copies the persistant part of this to another store.
- copyTo(File) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Copies the persistant information in this table data source to the given directory in the file system.
- copyTo(File) - Method in class com.mckoi.database.VariableSizeDataStore
-
Copies this data store to the given path.
- copyToArray(int[], int, int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Copies the data from each block into the given int[] array.
- correct_ascending - Variable in class com.mckoi.database.QueryPlan.SortNode
-
Whether to sort the column in ascending or descending order
- CorrelatedVariable - Class in com.mckoi.database
-
A wrapper for a variable in a sub-query that references a column outside of the current query.
- CorrelatedVariable(Variable, int) - Constructor for class com.mckoi.database.CorrelatedVariable
-
Constructs the CorrelatedVariable.
- count - Variable in class com.mckoi.database.CellBufferInputStream
- count - Variable in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
-
The number of bytes we have read.
- count - Variable in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
-
Total bytes written.
- count - Variable in class com.mckoi.database.TriggerEvent
-
The number of times this event was fired.
- count - Variable in class com.mckoi.util.AbstractBlockIntegerList
-
The total number of ints in the list.
- count - Variable in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
The number of block entries in this list.
- count - Variable in class com.mckoi.util.LengthMarkedBufferedInputStream
-
The number of valid bytes in the buffer.
- count() - Method in class com.mckoi.database.OpenTransactionList
-
Returns the number of transactions that are open on the conglomerate.
- COUNT - Static variable in interface com.mckoi.database.sql.SQLConstants
- CountFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.CountFunction
- countStoreFiles() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
-
Counts the number of files in the file store that represent this store.
- cr_resolver - Variable in class com.mckoi.database.FunctionTable
-
The TableVariableResolver for the table we are cross referencing.
- create() - Method in class com.mckoi.database.BlobStore
-
Creates the blob store and returns a pointer in the store to the header information.
- create() - Method in class com.mckoi.database.FixedRecordList
-
Creates the structure in the store, and returns a pointer to the structure.
- create() - Method in class com.mckoi.database.IndexSetStore
-
Creates a new black index set store and returns a pointer to a static area that is later used to reference this index set in this store.
- create() - Method in class com.mckoi.database.StateStore
-
Creates the state store in the store and returns a pointer to the header used later for initializing the state.
- create(int) - Method in class com.mckoi.database.IndexStore
-
Creates a new black index store and returns leaving the newly created store in an open state.
- create(int, DataTableDef) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Create this master table in the file system at the given path.
- create(int, DataTableDef, int, int) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Physically create this master table in the file system at the given path.
- create(DataTableDef) - Method in interface com.mckoi.database.DataTableFile
-
Creates a new file of the given table.
- create(String) - Method in class com.mckoi.database.TableDataConglomerate
-
Creates a new conglomerate at the given path in the file system.
- create(String, String) - Method in class com.mckoi.database.Database
-
Creates and sets up a new database to an initial empty state.
- create(String, String, DBConfig) - Method in interface com.mckoi.database.jdbc.LocalBootable
-
Attempts to create a new database system with the given name, and the given username/password as the admin user for the system.
- create(String, String, DBConfig) - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Creates and boots a local database with the given configuration.
- Create() - Method in class com.mckoi.database.sql.SQL
- CREATE - Static variable in class com.mckoi.database.Privileges
-
The priv to create objects (only applicable for SCHEMA grant objects).
- CREATE - Static variable in interface com.mckoi.database.sql.SQLConstants
- create_statement - Variable in class com.mckoi.database.interpret.AlterTable
-
The create statement that we use to alter the current table.
- create_stmt - Variable in class com.mckoi.database.interpret.AlterTable
-
The prepared create table statement.
- createAndCastFromObject(TType, Object) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of the given type and with the given Java object.
- createAndList(ArrayList, Expression) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Given an Expression, this will return a list of expressions that can be safely executed as a set of 'and' operations.
- createAndList(ArrayList, Expression) - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
-
Given an Expression, this will return a list of expressions that can be safely executed as a set of 'and' operations.
- createArea(long) - Method in class com.mckoi.store.AbstractStore
- createArea(long) - Method in class com.mckoi.store.HeapStore
- createArea(long) - Method in interface com.mckoi.store.Store
-
Allocates a block of memory in the store of the specified size and returns an AreaWriter object that can be used to initialize the contents of the area.
- createArrayOf(String, Object[]) - Method in class com.mckoi.database.jdbc.MConnection
- createBigNumber(byte[], int, byte) - Method in class com.mckoi.database.DataCellSerialization
-
Creates a BigNumber object used to store a numeric value in the database.
- createBinaryColumn(String) - Static method in class com.mckoi.database.DataTableColumnDef
-
Convenience helper - creates a DataTableColumnDef that holds a binary value.
- createBlankIndexBlock() - Method in class com.mckoi.database.IndexSetStore
-
Creates a new blank index block in the store and returns a pointer to the area.
- createBlob() - Method in class com.mckoi.database.jdbc.MConnection
- createBooleanColumn(String) - Static method in class com.mckoi.database.DataTableColumnDef
-
Convenience helper - creates a DataTableColumnDef that holds a boolean value.
- createClob() - Method in class com.mckoi.database.jdbc.MConnection
- created_database_objects - Variable in class com.mckoi.database.Transaction
-
The name of all database objects that were created in this transaction.
- created_names - Variable in class com.mckoi.database.TableDataConglomerate.NameSpaceJournal
-
The list of names created in this journal.
- createDatabase(DBConfig) - Static method in class com.mckoi.database.control.DBController
-
Creates a Database object for the given DBConfig configuration.
- createDatabase(DBConfig, String, String) - Method in class com.mckoi.database.control.DBController
-
Creates a database in the local JVM (and filesystem) given the configuration in DBConfig and returns a DBSystem object.
- createDataTableDef() - Method in class com.mckoi.database.interpret.CreateTable
-
Creates a DataTableDef that describes the table that was defined by this create statement.
- createDataTableDef(String, String) - Static method in class com.mckoi.database.ConnectionTriggerManager.TriggerInternalTableInfo
- createDataTableDef(String, String) - Static method in class com.mckoi.database.ProcedureManager.ProcedureInternalTableInfo
- createDataTableDef(String, String) - Static method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- createDefaultLocalBootable() - Static method in class com.mckoi.database.jdbc.MDriver
-
Creates a new LocalBootable object that is used to manage the connections to a database running locally.
- createEmptyTable(Database, String, String[]) - Method in class com.mckoi.database.interpret.Show
-
Convenience, creates an empty table with the given column names.
- createEncodedTableFile(MasterTableDataSource) - Static method in class com.mckoi.database.TableDataConglomerate
-
Returns a string that is an encoded table file name.
- createEvent(Runnable) - Method in class com.mckoi.database.Database
-
Creates an event for the database dispatcher.
- createEvent(Runnable) - Method in class com.mckoi.database.DatabaseDispatcher
-
Creates an event object that is passed into 'addEventToDispatch' method to run the given Runnable method after the time has passed.
- createEvent(Runnable) - Method in class com.mckoi.database.TransactionSystem
-
Creates an event object that is passed into 'postEvent' method to run the given Runnable method after the time has passed.
- createFetchQueryPlanNode() - Method in class com.mckoi.database.interpret.FromTableDirectSource
-
Creates a QueryPlanNode to be added into a query tree that fetches the table source.
- createFileStore(String) - Method in class com.mckoi.database.V1FileStoreSystem
-
Creates the JournalledFileStore object for this table.
- CreateFunction() - Method in class com.mckoi.database.sql.SQL
- CreateFunctionsNode(QueryPlanNode, Expression[], String[]) - Constructor for class com.mckoi.database.QueryPlan.CreateFunctionsNode
-
Constructor.
- createGroupMatrix(Variable[]) - Method in class com.mckoi.database.FunctionTable
-
Creates a grouping matrix for the given tables.
- CreateIndex() - Method in class com.mckoi.database.sql.SQL
- createIndexIntegerList() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Creates and returns a mutable IndexIntegerList object based on this view of the index.
- createIndexSet() - Method in class com.mckoi.database.MasterTableDataSource
-
Creates and returns an IndexSet object that is used to create indices for this table source.
- createIndexSet() - Method in class com.mckoi.database.V1MasterTableDataSource
- createIndexSet() - Method in class com.mckoi.database.V2MasterTableDataSource
- createInternalTable(int) - Method in class com.mckoi.database.AbstractInternalTableInfo2
- createInternalTable(int) - Method in class com.mckoi.database.ConnectionTriggerManager.TriggerInternalTableInfo
- createInternalTable(int) - Method in class com.mckoi.database.DatabaseConnection.ConnectionInternalTableInfo
- createInternalTable(int) - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- createInternalTable(int) - Method in interface com.mckoi.database.InternalTableInfo
-
This is the factory method for generating the internal table for the given table in this container.
- createInternalTable(int) - Method in class com.mckoi.database.ProcedureManager.ProcedureInternalTableInfo
- createInternalTable(int) - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- createInternalTable(int) - Method in class com.mckoi.database.Transaction.TransactionInternalTables
- createInternalTable(int) - Method in class com.mckoi.database.ViewManager.ViewInternalTableInfo
- createInternalTableInfo(Transaction) - Static method in class com.mckoi.database.ConnectionTriggerManager
-
Returns an InternalTableInfo object used to model the list of triggers that are accessible within the given Transaction object.
- createInternalTableInfo(Transaction) - Static method in class com.mckoi.database.ProcedureManager
-
Returns an InternalTableInfo object used to model the list of procedures that are accessible within the given Transaction object.
- createInternalTableInfo(Transaction) - Static method in class com.mckoi.database.SequenceManager
-
Returns an InternalTableInfo object used to model the list of sequence generators that are accessible within the given Transaction object.
- createInternalTableInfo(ViewManager, Transaction) - Static method in class com.mckoi.database.ViewManager
-
Returns an InternalTableInfo object used to model the list of views that are accessible within the given Transaction object.
- createJDBCConnection(User, DatabaseConnection) - Static method in class com.mckoi.database.InternalJDBCHelper
-
Returns a java.sql.Connection object that is bound to the given DatabaseConnection object.
- createListNode() - Method in class com.mckoi.util.Cache
-
Creates a new ListNode.
- createLookupRowList(Table) - Static method in class com.mckoi.database.NaturallyJoinedTable
-
Creates a lookup list for rows in the given table.
- createMappedListBlocks() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Creates and returns an array of all the MappedListBlock objects that make up this view of the index integer list.
- createMasterTable(DataTableDef, int, int) - Method in class com.mckoi.database.TableDataConglomerate
-
Creates a table store in this conglomerate with the given name and returns a reference to the table.
- createMutableTableDataSourceAtCommit(MasterTableDataSource) - Method in class com.mckoi.database.SimpleTransaction
-
Returns a new MutableTableDataSource for the view of the MasterTableDataSource at the start of this transaction.
- createMutableTableDataSourceAtCommit(MasterTableDataSource) - Method in class com.mckoi.database.Transaction
-
Overwritten from SimpleTransaction.
- createNClob() - Method in class com.mckoi.database.jdbc.MConnection
- createNewConnection(User, DatabaseConnection.CallBack) - Method in class com.mckoi.database.Database
-
Returns a new DatabaseConnection instance that is used against this database.
- createNewKey() - Method in class com.mckoi.database.interpret.FromClause
-
Creates a new unique key string.
- createNewLargeObject(byte, long) - Method in class com.mckoi.database.DatabaseConnection
-
Allocates a new large object in the Blob store of this conglomerate of the given type and size.
- createNewLargeObject(byte, long) - Method in class com.mckoi.database.TableDataConglomerate
-
Creates and allocates storage for a new large object in the blob store.
- createNewWindow(Connection, boolean, boolean) - Static method in class com.mckoi.tools.JDBCQueryTool
-
Creates a new JDBC Query Tool window.
- createNumericColumn(String) - Static method in class com.mckoi.database.DataTableColumnDef
-
Convenience helper - creates a DataTableColumnDef that holds a numeric value.
- createObjectFetchQueryPlan(TableName, TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Creates a QueryPlanNode to fetch the given table object from this connection.
- createProcedureConnection(User) - Method in class com.mckoi.database.DatabaseConnection
-
Creates an object that implements ProcedureConnection that provides access to this connection.
- createRandomeOuterJoinName() - Static method in class com.mckoi.database.interpret.Planner
-
Returns a randomly generated outer join name.
- createResource(String) - Method in class com.mckoi.store.JournalledSystem
-
Creates a resource.
- createResource(String) - Method in class com.mckoi.store.LoggingBufferManager
-
Creates a new resource.
- createRIDCache() - Method in class com.mckoi.database.RIDList
-
If rid_list is null then create it now.
- createRowDataObject(QueryContext) - Method in class com.mckoi.database.DataTable
-
Generates an empty RowData object for 'addRow'ing into the Table.
- createSchema(String, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.createSchema method.
- createSchema(String, String) - Method in class com.mckoi.database.Transaction
-
Create a new schema in this transaction.
- CreateSchema() - Method in class com.mckoi.database.sql.SQL
- createSchemaInfoTables(DatabaseConnection) - Method in class com.mckoi.database.Database
-
Creates the schema information tables introducted in version 0.90.
- createSelectableSchemeForColumn(IndexSet, TableDataSource, int) - Method in class com.mckoi.database.MasterTableDataSource
-
Creates a SelectableScheme object for the given column in this table.
- createSelectableSchemeForIndex(IndexSet, TableDataSource, int) - Method in class com.mckoi.database.MasterTableDataSource
-
Creates a SelectableScheme object for the given index in the index set def in this table.
- CreateSequence() - Method in class com.mckoi.database.sql.SQL
- createSequenceGenerator(TableName, long, long, long, long, long, boolean) - Method in class com.mckoi.database.DatabaseConnection
-
Creates a new sequence generator with the given TableName and initializes it with the given details.
- createSequenceGenerator(TableName, long, long, long, long, long, boolean) - Method in class com.mckoi.database.Transaction
-
Creates a new sequence generator with the given TableName and initializes it with the given details.
- createSequenceGenerator(Transaction, TableName, long, long, long, long, long, boolean) - Static method in class com.mckoi.database.SequenceManager
-
Creates a new sequence generator with the given name and details.
- createSliceDataAccessor(File) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
-
Creates a StoreDataAccessor object for accessing a given slice.
- createSQLXML() - Method in class com.mckoi.database.jdbc.MConnection
- createStatement() - Method in class com.mckoi.database.jdbc.MConnection
- createStatement(int, int) - Method in class com.mckoi.database.jdbc.MConnection
- createStatement(int, int, int) - Method in class com.mckoi.database.jdbc.MConnection
- createStore(String) - Method in interface com.mckoi.database.StoreSystem
-
Creates and returns a new persistent Store object given the unique name of the store.
- createStore(String) - Method in class com.mckoi.database.V1FileStoreSystem
- createStore(String) - Method in class com.mckoi.database.V1HeapStoreSystem
- createStoreDataAccessor(String) - Method in interface com.mckoi.store.LoggingBufferManager.StoreDataAccessorFactory
-
Returns a StoreDataAccessor object for the given resource name.
- createStreamableObject(InputStream, int, byte) - Method in class com.mckoi.database.jdbc.MConnection
-
Creates a StreamableObject on the JDBC client side given an InputStream, and length and a type.
- createStreamableObject(InputStream, int, byte) - Method in class com.mckoi.database.jdbc.MStatement
-
Generates a new StreamableObject and stores it in the hold for future access by the server.
- createStringColumn(String) - Static method in class com.mckoi.database.DataTableColumnDef
-
Convenience helper - creates a DataTableColumnDef that holds a string value.
- createStruct(String, Object[]) - Method in class com.mckoi.database.jdbc.MConnection
- createSubstitution(String) - Method in class com.mckoi.database.sql.SQL
-
Creates and returns a parameter substitution.
- createSystemTables(DatabaseConnection) - Method in class com.mckoi.database.Database
-
Creates all the priv/password system tables.
- createSystemViews(DatabaseConnection) - Method in class com.mckoi.database.Database
-
Creates all the system views.
- createTable(DataTableDef) - Method in class com.mckoi.database.DatabaseConnection
-
Create a new table within the context of the current connection transaction.
- createTable(DataTableDef) - Method in class com.mckoi.database.Transaction
-
Creates a new table within this transaction.
- createTable(DataTableDef, int, int) - Method in class com.mckoi.database.DatabaseConnection
-
Create a new table with a starting initial sector size.
- createTable(DataTableDef, int, int) - Method in class com.mckoi.database.Transaction
-
Creates a new table within this transaction with the given sector size.
- CreateTable - Class in com.mckoi.database.interpret
-
A parsed state container for the 'create' statement.
- CreateTable() - Constructor for class com.mckoi.database.interpret.CreateTable
- CreateTable() - Method in class com.mckoi.database.sql.SQL
- createTableDataSourceAtCommit(SimpleTransaction) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns a MutableTableDataSource object that represents this data source at the time the given transaction started.
- createTableDataSourceAtCommit(SimpleTransaction, MasterTableJournal) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns a MutableTableDataSource object that represents this data source at the time the given transaction started, and also also makes any modifications that are described by the journal in the table.
- createTableTrigger(String, String, int, TableName, String, TObject[]) - Method in class com.mckoi.database.ConnectionTriggerManager
-
Creates a new trigger action on a stored procedure and makes the change to the transaction of this DatabaseConnection.
- createTransaction() - Method in class com.mckoi.database.TableDataConglomerate
-
Starts a new transaction.
- createTrigger(String, String, int) - Method in class com.mckoi.database.DatabaseConnection
-
Adds a type of trigger for the given trigger source (usually the name of the table).
- CreateTrigger - Class in com.mckoi.database.interpret
-
A parsed state container for the 'CREATE TRIGGER' statement.
- CreateTrigger() - Constructor for class com.mckoi.database.interpret.CreateTrigger
- CreateTrigger() - Method in class com.mckoi.database.sql.SQL
- createTTypeFor(int, int, int, String, int, int, String) - Static method in class com.mckoi.database.DataTableColumnDef
-
Returns a TType object for a column with the given type information.
- createUser(DatabaseQueryContext, String, String) - Method in class com.mckoi.database.Database
-
Creates and adds a new user to this database.
- CreateUser() - Method in class com.mckoi.database.sql.SQL
- createVariableResolver() - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
-
Creates a resolver that resolves variables within a set of the group.
- createView(SQLQuery, ViewDef) - Method in class com.mckoi.database.DatabaseConnection
-
Creates a new view.
- CreateView() - Method in class com.mckoi.database.sql.SQL
- createViewChildNode(QueryContext) - Method in class com.mckoi.database.QueryPlan.FetchViewNode
-
Returns the QueryPlanNode that resolves to the view.
- createViewQueryPlanNode(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns a freshly deserialized QueryPlanNode object for the given view object.
- createViewQueryPlanNode(TableName) - Method in class com.mckoi.database.DatabaseQueryContext
-
Creates a QueryPlanNode for the view with the given name.
- createViewQueryPlanNode(TableName) - Method in class com.mckoi.database.ViewManager
-
Returns a freshly deserialized QueryPlanNode object for the given view object.
- crop(int, int) - Method in class com.mckoi.util.IntegerVector
-
Crops the IntegerVector so it only contains values between start (inclusive) and end (exclusive).
- cropArea(long, long) - Method in class com.mckoi.store.AbstractStore
-
Crops the area to the given size.
- CROSS - Static variable in interface com.mckoi.database.sql.SQLConstants
- cross_ref_table - Variable in class com.mckoi.database.FunctionTable
-
The table that this function table cross references.
- CTALIAS - Static variable in interface com.mckoi.database.sql.SQLConstants
- CTMBackedCache() - Constructor for class com.mckoi.database.ConnectionTriggerManager.CTMBackedCache
-
Constructor.
- cur_offset - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- cur_sector - Variable in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
-
The cur sector to use.
- cur_seq_id - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
The sequence id for resources modified in this log.
- curChar - Variable in class com.mckoi.database.sql.SQLTokenManager
- curLexState - Variable in class com.mckoi.database.sql.SQLTokenManager
- current_block - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- current_block_size - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- current_c - Variable in class com.mckoi.database.jdbc.UnicodeToBinaryStream
-
The current character if 'lr_byte' is 1.
- current_cache_size - Variable in class com.mckoi.database.DataCellCache
-
The current size of the cache.
- current_cache_size - Variable in class com.mckoi.util.Cache
-
The current cache size.
- CURRENT_DATE - Static variable in interface com.mckoi.database.sql.SQLConstants
- current_old_new_state - Variable in class com.mckoi.database.DatabaseConnection
-
The current state of the OLD and NEW system tables including any cached information about the tables.
- current_page_count - Variable in class com.mckoi.store.LoggingBufferManager
-
The number of pages in this buffer.
- current_path - Variable in class com.mckoi.database.control.AbstractDBConfig
-
The current base path of the database configuration.
- current_schema - Variable in class com.mckoi.database.DatabaseConnection
-
The name of the schema that this connection is currently in.
- current_schema - Variable in class com.mckoi.database.SystemQueryContext
-
The context schema of this context.
- current_T - Variable in class com.mckoi.store.LoggingBufferManager
-
A timer that represents the T value in buffer pages.
- current_table - Variable in class com.mckoi.tools.ConglomerateViewPane
-
The current selected table.
- CURRENT_TIME - Static variable in interface com.mckoi.database.sql.SQLConstants
- CURRENT_TIMESTAMP - Static variable in interface com.mckoi.database.sql.SQLConstants
- current_val - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The current value of this sequence generator.
- currentPath() - Method in class com.mckoi.database.control.AbstractDBConfig
- currentPath() - Method in interface com.mckoi.database.control.DBConfig
-
Returns the current path set for this configuration.
- currentSequenceValue(String) - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns the current sequence value returned for the given sequence generator within the connection defined by this context.
- currentSequenceValue(String) - Method in interface com.mckoi.database.QueryContext
-
Returns the current sequence value returned for the given sequence generator within the connection defined by this context.
- currentSequenceValue(String) - Method in class com.mckoi.database.SystemQueryContext
-
Returns the current sequence value returned for the given sequence generator within the connection defined by this context.
- currentToken - Variable in exception com.mckoi.database.sql.ParseException
-
This is the last token that has been consumed successfully.
- currentUniqueID() - Method in class com.mckoi.database.IndexStore
-
The current unique id.
- currentUniqueID() - Method in class com.mckoi.database.MasterTableDataSource
-
Atomically returns the current 'unique_id' value for this table.
- currentUniqueID() - Method in class com.mckoi.database.V1MasterTableDataSource
- currentUniqueID() - Method in class com.mckoi.database.V2MasterTableDataSource
- currentUniqueID(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns the current unique id for the given table name.
- CurrValFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.CurrValFunction
- curValue(SimpleTransaction, TableName) - Method in class com.mckoi.database.SequenceManager
-
Returns the current value from the sequence generator.
- cycle - Variable in class com.mckoi.database.interpret.Sequence
- cycle - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
True if the sequence key is cycled.
- CYCLE - Static variable in interface com.mckoi.database.sql.SQLConstants
D
- data - Variable in class com.mckoi.database.global.ByteLongObject
-
The binary data.
- data - Variable in class com.mckoi.store.IOStoreDataAccessor
-
The underlying RandomAccessFile containing the data.
- data - Variable in class com.mckoi.store.JournalledSystem.AbstractResource
-
The backing object.
- data - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
The StreamFile object for reading and writing entries to/from the journal.
- data - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The StoreDataAccessor that the page content is part of.
- data - Variable in class com.mckoi.store.ScatteringStoreDataAccessor.FileSlice
- data - Variable in class com.mckoi.store.StreamFile
-
The RandomAccessFile.
- DATA_AREA_OFFSET - Static variable in class com.mckoi.store.AbstractStore
-
The offset into the file that the data areas start.
- data_cell_cache - Variable in class com.mckoi.database.TransactionSystem
-
The DataCellCache that is a shared resource between on database's.
- DATA_CELL_CACHING - Variable in class com.mckoi.database.MasterTableDataSource
-
Set to false to disable cell caching.
- data_cell_list - Variable in class com.mckoi.database.RowData
-
A list of TObject objects in the table.
- data_cell_serializer - Variable in class com.mckoi.database.V1MasterTableDataSource
-
The object we use to serialize TObject objects.
- data_deleted - Variable in class com.mckoi.store.JournalledSystem.Resource
-
True if the data resource was deleted.
- data_exists - Variable in class com.mckoi.store.JournalledSystem.Resource
-
True if the data store exists.
- data_file - Variable in class com.mckoi.database.FixedSizeDataStore
-
The File that keeps the data.
- data_open - Variable in class com.mckoi.store.JournalledSystem.Resource
-
True if the data resource is open.
- data_out - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
A DataOutputStream object used to write entries to the journal file.
- data_source - Variable in class com.mckoi.database.DataTable
-
A low level access to the underlying transactional data source.
- data_source - Variable in class com.mckoi.database.MasterTableGarbageCollector
-
The MasterTableDataSource that this collector is managing.
- data_store - Variable in class com.mckoi.database.FixedSizeDataStore
-
The RandomAccessFile object for the data file.
- data_store - Variable in class com.mckoi.database.V1MasterTableDataSource
-
A VariableSizeDataStore object that physically contains the information stored in the file system in the contents of the data source.
- data_store - Variable in class com.mckoi.database.VariableSizeDataStore
-
The actual data file.
- data_store_size - Variable in class com.mckoi.database.FixedSizeDataStore
-
The file size of the data store.
- data_table_def - Variable in class com.mckoi.database.interpret.FromTableDirectSource
-
The DataTableDef object that describes the table.
- database - Variable in class com.mckoi.database.control.DBSystem
-
The underlying Database object of this system.
- database - Variable in class com.mckoi.database.DatabaseConnection
-
The Database object that this connection is on.
- database - Variable in class com.mckoi.database.DatabaseQueryContext
-
The DatabaseConnection.
- database - Variable in class com.mckoi.database.DefaultDataTable
-
The Database object that this table is a child of.
- database - Variable in class com.mckoi.database.GTConnectionInfoDataSource
-
The DatabaseConnection object that this is table is modelling the information within.
- database - Variable in class com.mckoi.database.GTCurrentConnectionsDataSource
-
The DatabaseConnection object that this is table is modelling the information within.
- database - Variable in class com.mckoi.database.GTSQLTypeInfoDataSource
-
The DatabaseConnection object.
- database - Variable in class com.mckoi.database.InternalJDBCHelper.InternalDatabaseInterface
-
The internal connection to the database.
- database - Variable in class com.mckoi.database.interpret.Statement
-
The Database context.
- database - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
The Databas object that represents the context of this database interface.
- database - Variable in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
The Database parent.
- database - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
The Database context.
- database - Variable in class com.mckoi.database.jdbcserver.TCPServer
-
The parent Database object that describes everything about the database this TCP server is for.
- database - Variable in class com.mckoi.database.TriggerManager.TriggerAction
- database - Variable in class com.mckoi.database.User
-
The database object that this user is currently logged into.
- database - Variable in class com.mckoi.database.WorkerPool.RunCommand
- Database - Class in com.mckoi.database
-
The representation of a single database in the system.
- Database(DatabaseSystem, String) - Constructor for class com.mckoi.database.Database
-
The Constructor.
- database_call_back - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface
-
A DatabaseCallBack implementation that is notified of all events that are received from the database.
- database_connection - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
The database connection transaction.
- DATABASE_EVENT - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Denotes an event from the database (trigger, etc).
- database_list - Variable in class com.mckoi.database.DatabaseSystem
-
The list of Database objects that this system is being managed by this VM.
- database_name - Variable in class com.mckoi.database.jdbc.MDatabaseMetaData
-
The name and version of the database we are connected to.
- database_version - Variable in class com.mckoi.database.jdbc.MDatabaseMetaData
-
The name and version of the database we are connected to.
- DatabaseCallBack - Interface in com.mckoi.database.jdbc
-
An interface that is input to the DatabaseInterface as a way to be notified of event information from inside the database.
- DatabaseConnection - Class in com.mckoi.database
-
An object that represents a connection to a Database.
- DatabaseConnection(Database, User, DatabaseConnection.CallBack) - Constructor for class com.mckoi.database.DatabaseConnection
-
(package protected) Constructs the connection.
- DatabaseConnection.CallBack - Interface in com.mckoi.database
-
Call back interface for events that occur within the connection instance.
- DatabaseConnection.ConnectionInternalTableInfo - Class in com.mckoi.database
-
An internal table info object that handles tables internal to a DatabaseConnection object.
- DatabaseConnection.DCProcedureConnection - Class in com.mckoi.database
-
An implementation of ProcedureConnection generated from this object.
- DatabaseConnection.OldAndNewInternalTableInfo - Class in com.mckoi.database
-
An internal table info object that handles OLD and NEW tables for triggered actions.
- DatabaseConnection.OldNewTableState - Class in com.mckoi.database
-
An object that stores state about the trigger table OLD and NEW when the connection is set up to execute a stored procedure.
- DatabaseConnection.TriggeredOldNewDataSource - Class in com.mckoi.database
-
A MutableTableDataSource implementation that is used for trigger actions to represent the data in the OLD and NEW tables.
- DatabaseConstants - Interface in com.mckoi.database
-
Contant static values that determine several parameters of the database operation.
- DatabaseConstraintViolationException - Exception in com.mckoi.database
-
A database exception that represents a constraint violation.
- DatabaseConstraintViolationException(int, String) - Constructor for exception com.mckoi.database.DatabaseConstraintViolationException
-
Constructor.
- DatabaseDispatcher - Class in com.mckoi.database
-
This is the database system dispatcher thread.
- DatabaseDispatcher(TransactionSystem) - Constructor for class com.mckoi.database.DatabaseDispatcher
-
NOTE: Constructing this object will start the thread.
- DatabaseDispatcher.DatabaseEvent - Class in com.mckoi.database
- databaseEvent(int, String) - Method in interface com.mckoi.database.jdbc.DatabaseCallBack
-
Called when the database has generated an event that this user is listening for.
- databaseEvent(int, String) - Method in class com.mckoi.database.jdbc.MConnection
- DatabaseEvent(Runnable) - Constructor for class com.mckoi.database.DatabaseDispatcher.DatabaseEvent
- DatabaseException - Exception in com.mckoi.database
-
Exception thrown where various problems occur within the database.
- DatabaseException(int, String) - Constructor for exception com.mckoi.database.DatabaseException
- DatabaseException(String) - Constructor for exception com.mckoi.database.DatabaseException
- databaseExists(DBConfig) - Method in class com.mckoi.database.control.DBController
-
Returns true if a Mckoi database exists in the given directory of the file system, otherwise returns false if the path doesn't contain a database.
- DatabaseInterface - Interface in com.mckoi.database.jdbc
-
The interface with the Database whether it be remotely via TCP/IP or locally within the current JVM.
- databaseObjectCreated(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Notifies this transaction that a database object with the given name has successfully been created.
- databaseObjectCreated(TableName) - Method in class com.mckoi.database.Transaction
-
Notifies this transaction that a database object with the given name has successfully been created.
- databaseObjectDropped(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Notifies this transaction that a database object with the given name has successfully been dropped.
- databaseObjectDropped(TableName) - Method in class com.mckoi.database.Transaction
-
Notifies this transaction that a database object with the given name has successfully been dropped.
- DatabaseProcedure - Interface in com.mckoi.database
-
This interface represents a database procedure that is executed on the server side.
- DatabaseQueryContext - Class in com.mckoi.database
-
An implementation of a QueryContext based on a DatabaseConnection object.
- DatabaseQueryContext(DatabaseConnection) - Constructor for class com.mckoi.database.DatabaseQueryContext
-
Constructs the QueryContext.
- DatabaseSystem - Class in com.mckoi.database
-
This class provides information about shared resources available for the entire database system running in this VM.
- DatabaseSystem() - Constructor for class com.mckoi.database.DatabaseSystem
-
Constructor.
- DatabaseSystem.ShutdownThread - Class in com.mckoi.database
-
The shut down thread.
- DataCellCache - Class in com.mckoi.database
-
This object represents a cache for accesses to the the data cells within a Table.
- DataCellCache(TransactionSystem, int, int) - Constructor for class com.mckoi.database.DataCellCache
- DataCellCache(TransactionSystem, int, int, int) - Constructor for class com.mckoi.database.DataCellCache
-
The Constructors.
- DataCellCache.DCCache - Class in com.mckoi.database
-
This extends the 'Cache' class.
- DataCellCache.DCCacheKey - Class in com.mckoi.database
-
Inner class that creates an object that hashes nicely over the cache source.
- DataCellSerialization - Class in com.mckoi.database
-
An object that manages the serialization and deserialization of objects to the database file system.
- DataCellSerialization() - Constructor for class com.mckoi.database.DataCellSerialization
-
Constructor.
- dataDefinitionCausesTransactionCommit() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- dataDefinitionIgnoredInTransactions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- DataFileConvertTool - Class in com.mckoi.tools
-
A tool for converting between different versions of the database file system.
- DataFileConvertTool() - Constructor for class com.mckoi.tools.DataFileConvertTool
- DataIndexDef - Class in com.mckoi.database
-
Represents index meta-information on a table.
- DataIndexDef(DataIndexDef) - Constructor for class com.mckoi.database.DataIndexDef
- DataIndexDef(String, String[], int, String, boolean) - Constructor for class com.mckoi.database.DataIndexDef
-
Constructor.
- DataIndexSetDef - Class in com.mckoi.database
-
Represents the meta-data for a set of indexes of a table.
- DataIndexSetDef(DataIndexSetDef) - Constructor for class com.mckoi.database.DataIndexSetDef
- DataIndexSetDef(TableName) - Constructor for class com.mckoi.database.DataIndexSetDef
-
Constructor.
- DataTable - Class in com.mckoi.database
-
DataTable is a wrapper for a MutableTableDataSource that fits into the query hierarchy level.
- DataTable(DatabaseConnection, MutableTableDataSource) - Constructor for class com.mckoi.database.DataTable
-
Cosntructs the data table.
- DataTableColumnDef - Class in com.mckoi.database
-
All the information regarding a column in a table.
- DataTableColumnDef() - Constructor for class com.mckoi.database.DataTableColumnDef
-
Constructs the column definition.
- DataTableColumnDef(DataTableColumnDef) - Constructor for class com.mckoi.database.DataTableColumnDef
-
Creates a copy of the given column definition.
- DataTableDef - Class in com.mckoi.database
-
A definition of a table.
- DataTableDef() - Constructor for class com.mckoi.database.DataTableDef
-
Constructs this DataTableDef file.
- DataTableDef(DataTableDef) - Constructor for class com.mckoi.database.DataTableDef
-
Copy constructor.
- DataTableFile - Interface in com.mckoi.database
-
This interface handles the abstraction of retreiving information from a database file.
- DataTableFilter - Class in com.mckoi.database
-
This object sits on top of a DataTable object filtering out certain types of calls.
- DataTableFilter(AbstractDataTable) - Constructor for class com.mckoi.database.DataTableFilter
-
The Constructor.
- DataTableListener - Interface in com.mckoi.database
-
A DataTableListener is notified of all modifications to the raw entries of the data table.
- DATE - Static variable in interface com.mckoi.database.global.SQLTypes
- DATE - Static variable in interface com.mckoi.database.sql.SQLConstants
- date_format - Variable in class com.mckoi.util.Log
-
Date formatter.
- date_format_ful - Static variable in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- date_format_lon - Static variable in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- date_format_med - Static variable in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- date_format_sho - Static variable in class com.mckoi.database.InternalFunctionFactory.DateObFunction
-
The date format object that handles the conversion of Date objects to a string readable representation of the given date.
- date_format_sql - Static variable in class com.mckoi.database.global.CastHelper
-
Date, Time and Timestamp parser/formatters
- date_format_sql - Static variable in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- DATE_TYPE - Static variable in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- DATE_TYPE - Static variable in class com.mckoi.database.TType
-
A default date (SQL TIMESTAMP) type.
- dateClasses - Static variable in class com.mckoi.database.Caster
- dateColumn(String) - Static method in class com.mckoi.database.GTDataSource
- dateErrorString(String, DateFormat[]) - Static method in class com.mckoi.database.global.CastHelper
-
Helper that generates an appropriate error message for a date format error.
- DateFormatFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.DateFormatFunction
- DateObFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.DateObFunction
- datePrims - Static variable in class com.mckoi.database.Caster
- dateType(int) - Static method in class com.mckoi.database.TType
-
Returns a TDateType object.
- dateVal(Date) - Static method in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- dateVal(Date) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of DATE type that represents the given time value.
- DAYS - Static variable in class com.mckoi.util.TimeFrame
-
Formatting enum.
- DB_BINARY - Static variable in interface com.mckoi.database.global.Types
- DB_BLOB - Static variable in interface com.mckoi.database.global.Types
- DB_BOOLEAN - Static variable in interface com.mckoi.database.global.Types
- db_call_back - Variable in class com.mckoi.database.jdbcserver.JDBCProcessor
-
The database call back method that sends database events back to the client.
- db_interface - Variable in class com.mckoi.database.jdbc.MConnection
-
The interface to the database.
- db_interface - Variable in class com.mckoi.database.jdbcserver.JDBCProcessor
-
The interface to the database.
- DB_NUMERIC - Static variable in interface com.mckoi.database.global.Types
- DB_NUMERIC_EXTENDED - Static variable in interface com.mckoi.database.global.Types
- DB_OBJECT - Static variable in interface com.mckoi.database.global.Types
- db_path - Variable in class com.mckoi.database.TransactionSystem
-
The path in the file system for the database files.
- DB_STRING - Static variable in interface com.mckoi.database.global.Types
- DB_TIME - Static variable in interface com.mckoi.database.global.Types
- db_type - Variable in class com.mckoi.database.DataTableColumnDef
-
The actual column type in the database (as defined in com.mckoi.database.global.Types).
- DB_UNKNOWN - Static variable in interface com.mckoi.database.global.Types
- DBConfig - Interface in com.mckoi.database.control
-
A container object of configuration details of a database system.
- DBConglomerateDiagTool - Class in com.mckoi.tools
-
An interactive tool for diagnosing the contents of a TableDataConglomerate object.
- DBConglomerateDiagTool() - Constructor for class com.mckoi.tools.DBConglomerateDiagTool
- DBConglomerateRepairTool - Class in com.mckoi.tools
-
A command line repair tool for repairing a corrupted conglomerate.
- DBConglomerateRepairTool() - Constructor for class com.mckoi.tools.DBConglomerateRepairTool
- DBController - Class in com.mckoi.database.control
-
An object that provides methods for creating and controlling database systems in the current JVM.
- DBController() - Constructor for class com.mckoi.database.control.DBController
-
This object can not be constructed outside of this package.
- dbsys - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
The local DBSystem database object.
- DBSystem - Class in com.mckoi.database.control
-
An object used to access and control a single database system running in the current JVM.
- DBSystem(DBController, DBConfig, Database) - Constructor for class com.mckoi.database.control.DBSystem
-
Package-protected constructor.
- DCCache(int, int) - Constructor for class com.mckoi.database.DataCellCache.DCCache
-
The Constructor.
- DCCacheKey(int, short, int) - Constructor for class com.mckoi.database.DataCellCache.DCCacheKey
- DCProcedureConnection() - Constructor for class com.mckoi.database.DatabaseConnection.DCProcedureConnection
- debug - Variable in class com.mckoi.database.FixedSizeDataStore
-
A DebugLogger object we can use to write debug messages to.
- debug - Variable in class com.mckoi.database.IndexSetStore
-
A DebugLogger object used to log debug messages to.
- debug - Variable in class com.mckoi.database.IndexStore
-
A DebugLogger object used to log debug messages to.
- debug - Variable in class com.mckoi.database.jdbcserver.JDBCProcessor
-
An object the debug information can be logged to.
- debug - Variable in class com.mckoi.database.Lock
-
The DebugLogger object that we log debug message to.
- debug - Variable in class com.mckoi.database.LockHandle
-
The DebugLogger object that we log debug messages to.
- debug - Variable in class com.mckoi.database.LockingMechanism
-
The DebugLogger object that we log debug messages to.
- debug - Variable in class com.mckoi.database.VariableSizeDataStore
-
A DebugLogger object used to log error messages to.
- debug - Variable in class com.mckoi.store.JournalledSystem
-
A debug log to output information to.
- Debug - Class in com.mckoi.debug
-
Deprecated.use DebugLogger implementations instead.
- Debug() - Constructor for class com.mckoi.debug.Debug
-
Deprecated.
- Debug() - Method in class com.mckoi.database.Database
-
Returns the DebugLogger implementation from the DatabaseSystem.
- Debug() - Method in class com.mckoi.database.DatabaseConnection
-
Returns a DebugLogger object that we can use to log debug messages to.
- Debug() - Method in class com.mckoi.database.DataTable
-
Convenience - used to log debug messages.
- Debug() - Method in class com.mckoi.database.interpret.Statement
-
Returns a DebugLogger object used to log debug commands.
- Debug() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Returns a DebugLogger object that can be used to log debug messages against.
- Debug() - Method in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
Returns a DebugLogger object that we can log debug messages to.
- Debug() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
Returns a DebugLogger object that we can log debug messages to.
- Debug() - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Returns a DebugLogger object that we can log debug messages to.
- Debug() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the DebugLogger object that can be used to log debug messages.
- Debug() - Method in class com.mckoi.database.MasterTableGarbageCollector
-
Returns the DebugLogger object that we can use to log debug messages.
- Debug() - Method in class com.mckoi.database.MultiVersionTableIndices
-
Returns the DebugLogger object used to log debug messages.
- Debug() - Method in class com.mckoi.database.RIDList
-
Returns a DebugLogger object that we can use to log debug messages.
- Debug() - Method in class com.mckoi.database.SelectableScheme
-
Returns the DebugLogger object to log debug messages to.
- Debug() - Method in class com.mckoi.database.SimpleTransaction
-
Returns a DebugLogger object that we use to log debug messages to.
- Debug() - Method in class com.mckoi.database.StatementCache
-
Returns a DebugLogger object we can use to log debug messages.
- Debug() - Method in class com.mckoi.database.Table
-
Returns a DebugLogger object that we can use to log debug messages to.
- Debug() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the DebugLogger object that we use to log debug messages to.
- Debug() - Method in class com.mckoi.database.TransactionSystem
-
Returns the DebugLogger object that is used to log debug message.
- Debug() - Method in class com.mckoi.database.WorkerPool
-
Returns a DebugLogger object that we can use to log debug messages.
- Debug() - Method in class com.mckoi.database.WorkerThread
-
Returns a DebugLogger object we can use to log debug messages.
- DEBUG_immutable_set_size - Variable in class com.mckoi.database.InsertSearch
-
If this is immutable, this stores the number of entries in 'set_list' when this object was made.
- debug_level - Static variable in class com.mckoi.debug.Debug
-
Deprecated.This variable specifies the level of debugging information that is output.
- debug_level - Variable in class com.mckoi.debug.DefaultDebugLogger
-
This variable specifies the level of debugging information that is output.
- debug_lock - Static variable in class com.mckoi.debug.Debug
-
Deprecated.The debug lock object.
- debug_lock - Variable in class com.mckoi.debug.DefaultDebugLogger
-
The debug lock object.
- DEBUG_QUERY - Static variable in class com.mckoi.database.Table
- debug_read_lock_count - Variable in class com.mckoi.database.DataTable
-
The number of read locks we have on this table.
- debug_write_lock_count - Variable in class com.mckoi.database.DataTable
-
The number of write locks we have on this table (this should only ever be 0 or 1).
- DebugLogger - Interface in com.mckoi.debug
-
An interface for logging errors, warnings, messages, and exceptions in the Mckoi system.
- debugStream - Variable in class com.mckoi.database.sql.SQLTokenManager
- debugString(int, StringBuffer) - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
- debugString(int, StringBuffer) - Method in class com.mckoi.database.QueryPlan.FetchTableNode
- debugString(int, StringBuffer) - Method in class com.mckoi.database.QueryPlan.FetchViewNode
- debugString(int, StringBuffer) - Method in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
- debugString(int, StringBuffer) - Method in class com.mckoi.database.QueryPlan.SingleRowTableNode
- debugString(int, StringBuffer) - Method in interface com.mckoi.database.QueryPlanNode
-
Writes a textural representation of the node to the StringBuffer at the given indent level.
- DECIMAL - Static variable in interface com.mckoi.database.global.SQLTypes
- DECIMAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- declareAs(TableName) - Method in class com.mckoi.database.DataTable
-
We can declare a DataTable as a new type.
- decodeString(String) - Static method in class com.mckoi.database.TType
-
Decodes a String that has been encoded with the 'asEncodedString' method and returns a TType that represented the type.
- decodeTypes(String) - Static method in class com.mckoi.database.TType
-
Decodes a list (or array) of TType objects that was previously encoded with the 'asEncodedString(Type[])' method.
- decomposition - Variable in class com.mckoi.database.TStringType
-
The decomposition mode of the collator for this string type (as defined in java.text.Collator).
- decreaseSize() - Method in class com.mckoi.database.FixedRecordList
-
Decreases the size of the list structure.
- decrement(String) - Method in class com.mckoi.util.Stats
-
Decrements a stat property.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTConnectionInfoDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTCurrentConnectionsDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTPrivMapDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTProductDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTSQLTypeInfoDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTStatisticsDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTTableColumnsDataSource
-
The data table def that describes this table of data source.
- DEF_DATA_TABLE_DEF - Static variable in class com.mckoi.database.GTTableInfoDataSource
-
The data table def that describes this table of data source.
- def_list - Variable in class com.mckoi.database.interpret.FromClause
-
A list of all FromTableDef objects in this clause in order of when they were specified.
- DEFAULT - Static variable in interface com.mckoi.database.sql.SQLConstants
- default_expression - Variable in class com.mckoi.database.interpret.ColumnDef
- default_expression_string - Variable in class com.mckoi.database.DataTableColumnDef
-
The default expression string.
- DEFAULT_FETCH_SIZE - Static variable in class com.mckoi.database.jdbc.MResultSet
-
The default fetch size.
- DEFAULT_SCHEMA - Static variable in class com.mckoi.database.Database
-
The name of the default schema.
- DEFAULT_TCP_PORT - Static variable in class com.mckoi.database.control.TCPJDBCServer
-
The default TCP port for Mckoi SQL Database.
- default_value - Variable in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- DefaultDataTable - Class in com.mckoi.database
-
This represents a default implementation of a DataTable.
- DefaultDataTable(Database) - Constructor for class com.mckoi.database.DefaultDataTable
-
The Constructor.
- DefaultDBConfig - Class in com.mckoi.database.control
-
Implements a default database configuration that is useful for setting up a database.
- DefaultDBConfig() - Constructor for class com.mckoi.database.control.DefaultDBConfig
-
Constructs the configuration with the current system path as the configuration path.
- DefaultDBConfig(File) - Constructor for class com.mckoi.database.control.DefaultDBConfig
-
Constructs the configuration.
- DefaultDBConfig.ConfigProperty - Class in com.mckoi.database.control
-
An object the describes a single configuration property and the default value for it.
- DefaultDebugLogger - Class in com.mckoi.debug
-
A default implementation of DebugLogger that logs messages to a PrintWriter object.
- DefaultDebugLogger() - Constructor for class com.mckoi.debug.DefaultDebugLogger
- defaultLexState - Variable in class com.mckoi.database.sql.SQLTokenManager
- DefaultLocalBootable - Class in com.mckoi.database.jdbcserver
-
A bootable object that filters through to a JDBCDatabaseInterface but is thread-safe and multi-threaded.
- DefaultLocalBootable() - Constructor for class com.mckoi.database.jdbcserver.DefaultLocalBootable
- DefaultLocalBootable.LocalJDBCDatabaseInterface - Class in com.mckoi.database.jdbcserver
-
A local implementation of JDBCDatabaseInterface that will dispose the parent LocalBootable object when the last open connection is disposed.
- DEFERRABLE - Static variable in interface com.mckoi.database.sql.SQLConstants
- deferred - Variable in class com.mckoi.database.interpret.ConstraintDef
- deferred - Variable in class com.mckoi.database.Transaction.CheckExpression
-
Whether this is deferred or initially immediate.
- deferred - Variable in class com.mckoi.database.Transaction.ColumnGroup
-
Whether this is deferred or initially immediate.
- deferred - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
Whether this is deferred or initially immediate.
- DEFERRED - Static variable in interface com.mckoi.database.sql.SQLConstants
- deferredString(short) - Static method in class com.mckoi.database.TableDataConglomerate
-
Convenience, returns either 'Immediate' or 'Deferred' dependant on the deferred short.
- defineJavaProcedure(ProcedureName, String, TType, TType[], String) - Method in class com.mckoi.database.ProcedureManager
-
Defines a Java stored procedure.
- defineView(ViewDef, SQLQuery, User) - Method in class com.mckoi.database.ViewManager
-
Defines a view.
- deflater - Variable in class com.mckoi.database.DataCellSerialization
-
A Deflater and Inflater used to compress and uncompress the size of data fields put into the store.
- deflater - Variable in class com.mckoi.database.VariableSizeDataStore
-
A Deflater and Inflater used to compress and uncompress the size of data fields put into the store.
- del_list_change - Variable in class com.mckoi.database.StateStore
-
Set to true if the delete list was changed.
- del_p - Variable in class com.mckoi.database.StateStore
-
Pointer to the delete table area in the store.
- delete() - Method in class com.mckoi.database.FixedSizeDataStore
-
Deletes the data store from the file system.
- delete() - Method in class com.mckoi.database.IndexStore
-
Deletes the store.
- delete() - Method in class com.mckoi.database.TableDataConglomerate
-
Deletes and closes the conglomerate.
- delete() - Method in class com.mckoi.database.VariableSizeDataStore
-
Deletes the store from the file system.
- delete() - Method in class com.mckoi.store.IOStoreDataAccessor
- delete() - Method in class com.mckoi.store.JournalledFileStore
-
Deletes this store from the file system.
- delete() - Method in interface com.mckoi.store.JournalledResource
-
Deletes the resource.
- delete() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Deletes the resource.
- delete() - Method in class com.mckoi.store.JournalledSystem.Resource
-
Deletes the resource.
- delete() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- delete() - Method in interface com.mckoi.store.StoreDataAccessor
-
Deletes the data area resource.
- delete() - Method in class com.mckoi.store.StreamFile
-
Deletes the file.
- delete(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Deletes the data at the given index position.
- delete(Table) - Method in class com.mckoi.database.DataTable
- delete(Table, int) - Method in class com.mckoi.database.DataTable
-
This is the public method for removing a given result set from this table.
- delete(File, String) - Static method in class com.mckoi.database.VariableSizeDataStore
-
Convenience for deleting a VariableSizeDataStore store.
- Delete - Class in com.mckoi.database.interpret
-
Logic for the DELETE FROM SQL statement.
- Delete() - Constructor for class com.mckoi.database.interpret.Delete
- Delete() - Method in class com.mckoi.database.sql.SQL
- DELETE - Static variable in class com.mckoi.database.Privileges
-
The priv to DELETE from a database object.
- DELETE - Static variable in interface com.mckoi.database.sql.SQLConstants
- DELETE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event type for delete action.
- DELETE - Static variable in class com.mckoi.database.TriggerEvent
- delete_head - Variable in class com.mckoi.database.FixedSizeDataStore
-
The head of the deleted sectors.
- delete_hits_key - Variable in class com.mckoi.database.MasterTableDataSource
- delete_list - Variable in class com.mckoi.database.StateStore
-
The list of deleted state resources.
- delete_on_shutdown - Variable in class com.mckoi.database.Database
-
A flag which, when set to true, will cause the engine to delete the database from the file system when it is shut down.
- delete_rule - Variable in class com.mckoi.database.interpret.ConstraintDef
- delete_rule - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The delete rule.
- deleteAcross(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Deletes a set of sectors that have been chained together.
- deleteAllAreas(ArrayList) - Method in class com.mckoi.database.IndexSetStore
-
Delete all areas specified in the list (as a list of Long).
- deleteAllSectors() - Method in class com.mckoi.database.FixedSizeDataStore
-
Deletes all sectors in the entire store.
- deleteAllUserGroups(DatabaseQueryContext, String) - Method in class com.mckoi.database.Database
-
Deletes all the groups the user belongs to.
- deleteArea(long) - Method in class com.mckoi.store.AbstractStore
- deleteArea(long) - Method in class com.mckoi.store.HeapStore
- deleteArea(long) - Method in interface com.mckoi.store.Store
-
Deletes an area that was previously allocated by the 'createArea' method by the area id.
- deleteBlockChain() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Recursively calls through the block hierarchy and deletes and blocks that can be deleted.
- deleted - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
True if this block is marked as deleted.
- DELETED - Static variable in class com.mckoi.database.FixedSizeDataStore
-
The mark that indicates whether a sector is deleted (available) or being used.
- DELETED - Static variable in interface com.mckoi.database.RawDiagnosticTable
-
Statics that represent the various states of a record.
- deleted_areas - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
The list of deleted areas that can safely be disposed when this object is disposed.
- deleted_blocks - Variable in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
The mapped elements that were deleted.
- deleted_blocks - Variable in class com.mckoi.database.IndexStore.IndexIntegerList
-
The mapped elements that were deleted.
- deleted_rows - Variable in class com.mckoi.database.MasterTableGarbageCollector
-
The list of all rows from the master table that we have been notified of being deleted.
- deleted_sectors - Variable in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
The sectors that are to be deleted when a garbage collection cycle occurs.
- deleteListBlock(IntegerListBlockInterface) - Method in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
We must maintain a list of deleted blocks.
- deleteListBlock(IntegerListBlockInterface) - Method in class com.mckoi.database.IndexStore.IndexIntegerList
-
We must maintain a list of deleted blocks.
- deleteListBlock(IntegerListBlockInterface) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Called when the class decides this ListBlock is no longer needed.
- deleteListBlock(IntegerListBlockInterface) - Method in class com.mckoi.util.BlockIntegerList
-
Called when the class decides this ListBlock is no longer needed.
- deleteProcedure(ProcedureName) - Method in class com.mckoi.database.ProcedureManager
-
Deletes the procedure with the given name, or generates an error if the procedure doesn't exist.
- deleteRow() - Method in class com.mckoi.database.jdbc.MResultSet
- deleteRows(IntegerVector) - Method in class com.mckoi.database.SimpleTableQuery
-
Deletes all the given indexes in this table.
- deletesAreDetected(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- deleteSector(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Deletes a sector from the store.
- deleteSingle(int, Object) - Method in class com.mckoi.database.SimpleTableQuery
-
Deletes a single entry from the table where the given column equals the given value.
- deleteStore(Store) - Method in interface com.mckoi.database.StoreSystem
-
Permanently deletes a store from the system - use with care! Returns true if the store was successfully deleted and the resources associated with it were freed.
- deleteStore(Store) - Method in class com.mckoi.database.V1FileStoreSystem
- deleteStore(Store) - Method in class com.mckoi.database.V1HeapStoreSystem
- deleteTrigger(String) - Method in class com.mckoi.database.DatabaseConnection
-
Removes a type of trigger for the given trigger source (usually the name of the table).
- deleteUser(DatabaseQueryContext, String) - Method in class com.mckoi.database.Database
-
Deletes the user from the system.
- deleteView(TableName) - Method in class com.mckoi.database.ViewManager
-
Deletes the view with the given name, or returns false if no entries were deleted from the view table.
- dereferenceAssignment(Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Dereferences a fully qualified reference that is within this set.
- DESC - Static variable in interface com.mckoi.database.sql.SQLConstants
- Describe() - Method in class com.mckoi.database.sql.SQL
- DESCRIBE - Static variable in interface com.mckoi.database.sql.SQLConstants
- DESCRIBE_TABLE - Static variable in class com.mckoi.database.interpret.Show
- deserialize(ByteLongObject) - Static method in class com.mckoi.database.global.ObjectTranslator
-
Deserializes a ByteLongObject to a Java object.
- deserializeFromBlob(BlobAccessor) - Static method in class com.mckoi.database.ViewDef
-
Creates an instance of ViewDef from the serialized information stored in the blob.
- deserializeFromBlob(ByteLongObject) - Static method in class com.mckoi.database.jdbc.SQLQuery
-
Deserializes an SQLQuery object from a ByteLongObject.
- deserializeJavaObjects(TObject[]) - Static method in class com.mckoi.database.Caster
-
Find any JAVA_OBJECTs in the args and deserialize them into real Java objects.
- detatchFrom(TableDataConglomerate) - Method in class com.mckoi.database.TableBackedCache
-
Call to detach this object from a TableDataConglomerate.
- diag_table - Variable in class com.mckoi.tools.ConglomerateViewPane.DTableModel
- diagnose(String, String) - Static method in class com.mckoi.tools.DBConglomerateDiagTool
- DIGIT - Static variable in interface com.mckoi.database.sql.SQLConstants
- digits - Static variable in class com.mckoi.database.InternalFunctionFactory.BinaryToHexFunction
- dirty_open - Variable in class com.mckoi.store.AbstractStore
-
True if the store was opened dirtily (was not previously closed cleanly).
- DIRTY_TABLE_SELECT - Static variable in exception com.mckoi.database.TransactionException
-
Thrown when a transaction selects data from a table that has committed changes to it from another transaction.
- dirtyOpen(String) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Opens this source in the most minimal way.
- disable_tracing() - Method in class com.mckoi.database.sql.SQL
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.Expression
-
Discovers all the correlated variables in this expression.
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
Default implementation that discovers correlated variables for the given offset level.
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.ConstantSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.CreateFunctionsNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.FetchTableNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.FetchViewNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.FunctionalSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.GroupNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.JoinNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.SimpleSelectNode
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
-
Default implementation that discovers correlated variables for the given offset level.
- discoverCorrelatedVariables(int, ArrayList) - Method in class com.mckoi.database.QueryPlan.SingleRowTableNode
- discoverCorrelatedVariables(int, ArrayList) - Method in interface com.mckoi.database.QueryPlanNode
-
Discovers all the correlated variables in the plan (and plan children) that reference a particular layer.
- discoverSize() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
-
Discovers the size of the data resource (doesn't require the file to be open).
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.Expression
-
Discovers all the tables in the sub-queries of this expression.
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
Default implementation delegates responsibility to children.
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.ConstantSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.CreateFunctionsNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.FetchTableNode
-
Adds the table name to the list if it's not already in there.
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.FetchViewNode
-
Adds the table name to the list if it's not already in there.
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.FunctionalSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.GroupNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.JoinNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.SimpleSelectNode
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
-
Default implementation delegates responsibility to child.
- discoverTableNames(ArrayList) - Method in class com.mckoi.database.QueryPlan.SingleRowTableNode
- discoverTableNames(ArrayList) - Method in interface com.mckoi.database.QueryPlanNode
-
Discovers a list of TableName that represent the sources that this query requires to complete itself.
- dispatch_id - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ServerCommand
- dispatcher - Variable in class com.mckoi.database.TransactionSystem
-
The dispatcher.
- dispatchID() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ServerCommand
- dispatchTrigger(String) - Method in class com.mckoi.database.jdbc.MConnection.TriggerDispatchThread
-
Dispatches a trigger message to the listeners.
- DISPLAY_COMMAND_TIME - Static variable in class com.mckoi.database.WorkerThread
-
If this is set to true, the server displays the time each executed command took.
- DISPLAY_STATS - Static variable in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
If this is set to true then the server periodically outputs statistics about the connections.
- DISPLAY_STATS - Static variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
If this is set to true then the server periodically outputs statistics about the connections.
- displayStatistics() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
Displays statistics about the server.
- dispose() - Method in class com.mckoi.database.BlindSearch
-
Disposes and invalidates the BlindSearch.
- dispose() - Method in class com.mckoi.database.CollatedBaseSearch
-
Disposes and invalidates the BlindSearch.
- dispose() - Method in class com.mckoi.database.DatabaseConnection.DCProcedureConnection
- dispose() - Method in class com.mckoi.database.DatabaseSystem
-
Disposes all the resources associated with this DatabaseSystem and invalidates this object.
- dispose() - Method in class com.mckoi.database.GTConnectionInfoDataSource
- dispose() - Method in class com.mckoi.database.GTCurrentConnectionsDataSource
- dispose() - Method in class com.mckoi.database.GTDataSource
- dispose() - Method in class com.mckoi.database.GTProductDataSource
- dispose() - Method in class com.mckoi.database.GTSQLTypeInfoDataSource
- dispose() - Method in class com.mckoi.database.GTStatisticsDataSource
- dispose() - Method in class com.mckoi.database.GTTableColumnsDataSource
- dispose() - Method in class com.mckoi.database.GTTableInfoDataSource
- dispose() - Method in interface com.mckoi.database.IndexSet
-
Cleans up and disposes the resources associated with this set of index.
- dispose() - Method in class com.mckoi.database.IndexSetStore.IndexIntegerList
- dispose() - Method in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
- dispose() - Method in class com.mckoi.database.IndexStore.IndexIntegerList
- dispose() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
- dispose() - Method in class com.mckoi.database.InsertSearch
-
Disposes this scheme.
- dispose() - Method in class com.mckoi.database.InternalJDBCHelper.InternalDatabaseInterface
- dispose() - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Called when the connection is disposed.
- dispose() - Method in class com.mckoi.database.jdbc.MResultSet
-
Disposes of all resources associated with this result set.
- dispose() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- dispose() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Disposes this object.
- dispose() - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable.LocalJDBCDatabaseInterface
- dispose() - Method in class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
- dispose() - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Disposes of this processor.
- dispose() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- dispose() - Method in interface com.mckoi.database.MutableTableDataSource
-
Disposes this table data source.
- dispose() - Method in class com.mckoi.database.SelectableScheme
-
Dispose and invalidate this scheme.
- dispose() - Method in class com.mckoi.database.SimpleTableQuery
-
Disposes this object and frees any resources associated with it.
- dispose() - Method in class com.mckoi.database.Transaction
-
Disposes this transaction without rolling back or committing the changes.
- dispose() - Method in class com.mckoi.database.TransactionSystem
-
Disposes this object.
- dispose() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Disposes of the page buffer if it can be disposed (there are no references to the page and the page is initialized).
- dispose(boolean) - Method in class com.mckoi.database.MasterTableDataSource
-
Disposes of all in-memory resources associated with this table and invalidates this object.
- dispose(boolean) - Method in class com.mckoi.database.V1MasterTableDataSource
- dispose(boolean) - Method in class com.mckoi.database.V2MasterTableDataSource
- DISPOSE_RESULT - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Disposes the server-side resources associated with a result.
- DISPOSE_STREAMABLE_OBJECT - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Disposes of the resources associated with a streamable object on the server.
- disposeAllIndices() - Method in class com.mckoi.database.SimpleTransaction
-
Disposes of all IndexSet objects currently accessed by this Transaction.
- disposed - Variable in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
Set to true when disposed.
- disposed - Variable in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
-
Set to true when this object is disposed.
- disposed - Variable in class com.mckoi.database.IndexStore.IndexIntegerList
-
Set to true when disposed.
- disposed - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Set to true when this database interface is disposed.
- disposeJDBCConnection(Connection) - Static method in class com.mckoi.database.InternalJDBCHelper
-
Disposes the JDBC Connection object returned by the 'createJDBCConnection' method.
- disposeProcedureConnection(ProcedureConnection) - Method in class com.mckoi.database.DatabaseConnection
-
Disposes of the ProcedureConnection that was previously created by the 'createProcedure' method.
- disposeResult(int) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Disposes of a result of a query on the server.
- disposeResult(int) - Method in class com.mckoi.database.jdbc.MConnection
-
Disposes of the server-side resources associated with the result set with result_id.
- disposeResult(int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Releases the server side resources associated with a given query key returned by the server.
- disposeResult(int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- disposeResult(int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
- disposeResult(int, byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Disposes of a result set we queries via the 'QUERY' command.
- disposeResultSet(int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Disposes of the result set with the given result_id.
- disposeStreamableObject(int, byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Disposes of a streamable object.
- disposeStreamableObject(int, long) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Disposes a streamable object channel with the given identifier.
- disposeStreamableObject(int, long) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Disposes the resources associated with a streamable object on the server.
- disposeStreamableObject(int, long) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- disposeStreamableObject(int, long) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
- disposeTransaction() - Method in class com.mckoi.database.DatabaseConnection
-
Private method that disposes the current transaction.
- distinct - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
True if we only search for distinct elements.
- distinct() - Method in class com.mckoi.database.Table
-
Deprecated.- not a proper SQL distinct.
- distinct(int[]) - Method in class com.mckoi.database.Table
-
Returns a new table that has only distinct rows in it.
- DISTINCT - Static variable in interface com.mckoi.database.global.SQLTypes
- DISTINCT - Static variable in interface com.mckoi.database.sql.SQLConstants
- DistinctCountFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.DistinctCountFunction
- DistinctNode(QueryPlanNode, Variable[]) - Constructor for class com.mckoi.database.QueryPlan.DistinctNode
- div_op - Static variable in class com.mckoi.database.Operator
- divide(BigNumber) - Method in class com.mckoi.util.BigNumber
- DIVIDE - Static variable in interface com.mckoi.database.sql.SQLConstants
- DivideOperator() - Constructor for class com.mckoi.database.Operator.DivideOperator
- doBoot(DBConfig) - Static method in class com.mckoi.runtime.McKoiDBMain
-
Performs the boot command.
- doCreate(String, String, String, DBConfig) - Static method in class com.mckoi.runtime.McKoiDBMain
-
Performs the create command.
- doEscapeSubstitutions() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Performs any JDBC escape processing on the query.
- doesMaxRowSizeIncludeBlobs() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- DoExpression() - Method in class com.mckoi.database.sql.SQL
- doHardRowRemove(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Actually deletes the row from the table.
- doInsertSort(IntegerVector, int) - Method in class com.mckoi.database.BlindSearch
- DOMAIN - Static variable in class com.mckoi.database.GrantManager
-
Represents a DOMAIN object to grant privs over for the user.
- doMaintenance() - Method in interface com.mckoi.database.DataTableFile
-
This is called periodically when this data table file requires some maintenance.
- Done() - Method in class com.mckoi.database.sql.SimpleCharStream
- DoNonBooleanExpression() - Method in class com.mckoi.database.sql.SQL
- dont_synch_filesystem - Variable in class com.mckoi.database.TransactionSystem
-
Set to true if the file handles should NOT be synchronized with the system file IO when the indices are written.
- dontSynchFileSystem() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if we shouldn't synchronize with the file system when important indexing information is flushed to the disk.
- doOpeningScan() - Method in class com.mckoi.database.MasterTableDataSource
-
This is called by the 'open' method.
- doPings() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
Performs a ping on a single random connection.
- doShutDown(String, String, String, String) - Static method in class com.mckoi.runtime.McKoiDBMain
-
Performs the shutdown command.
- DOT_DELIMINATED_REF - Static variable in interface com.mckoi.database.sql.SQLConstants
- DOUBLE - Static variable in interface com.mckoi.database.global.SQLTypes
- DOUBLE - Static variable in interface com.mckoi.database.sql.SQLConstants
- doubleClasses - Static variable in class com.mckoi.database.Caster
- doublePrims - Static variable in class com.mckoi.database.Caster
- doubleVal(double) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of numeric type that represents the given double value.
- doubleValue() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as a double.
- DRIVER_MAJOR_VERSION - Static variable in class com.mckoi.database.jdbc.MDriver
- DRIVER_MINOR_VERSION - Static variable in class com.mckoi.database.jdbc.MDriver
- DRIVER_NAME - Static variable in class com.mckoi.database.jdbc.MDriver
- DRIVER_VERSION - Static variable in class com.mckoi.database.jdbc.MDriver
- drop() - Method in interface com.mckoi.database.DataTableFile
-
Deletes the data table file in the file system.
- drop() - Method in class com.mckoi.database.MasterTableDataSource
-
Disposes and drops this table.
- drop() - Method in class com.mckoi.database.V1MasterTableDataSource
- drop() - Method in class com.mckoi.database.V2MasterTableDataSource
- Drop() - Method in class com.mckoi.database.sql.SQL
- DROP - Static variable in class com.mckoi.database.Privileges
-
The priv to drop objects (only applicable for SCHEMA grant objects).
- DROP - Static variable in interface com.mckoi.database.sql.SQLConstants
- DROP_COLUMN_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
Column can't be dropped before of an reference to it.
- DROP_TABLE_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
Tried to drop a table that is referenced by another source.
- drop_tables - Variable in class com.mckoi.database.interpret.DropTable
-
The list of tables to drop.
- dropAllBlobReferences() - Method in class com.mckoi.database.V2MasterTableDataSource
-
Scans the table and drops ALL blob references in this table.
- dropAllConstraintsForTable(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.dropAllConstraintsForTable method.
- dropAllConstraintsForTable(TableName) - Method in class com.mckoi.database.Transaction
-
Drops all the constraints defined for the given table.
- dropCheckConstraintForTable(TableName, String) - Method in class com.mckoi.database.Transaction
-
Drops a single named check constraint from the given table.
- dropForeignKeyReferenceConstraintForTable(TableName, String) - Method in class com.mckoi.database.Transaction
-
Drops a single named foreign key reference from the given table.
- DropFunction() - Method in class com.mckoi.database.sql.SQL
- DropIndex() - Method in class com.mckoi.database.sql.SQL
- dropNamedConstraint(TableName, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.dropNamedConstraint method.
- dropNamedConstraint(TableName, String) - Method in class com.mckoi.database.Transaction
-
Drops the named constraint from the transaction.
- dropped_database_objects - Variable in class com.mckoi.database.Transaction
-
The name of all database objects that were dropped in this transaction.
- dropped_names - Variable in class com.mckoi.database.TableDataConglomerate.NameSpaceJournal
-
The list of names dropped in this journal.
- dropPrimaryKeyConstraintForTable(TableName, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.dropPrimaryKeyConstraintForTable method.
- dropPrimaryKeyConstraintForTable(TableName, String) - Method in class com.mckoi.database.Transaction
-
Drops the primary key constraint for the given table.
- dropSchema(String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.dropSchema method.
- dropSchema(String) - Method in class com.mckoi.database.Transaction
-
Drops a schema from this transaction.
- DropSchema() - Method in class com.mckoi.database.sql.SQL
- DropSequence() - Method in class com.mckoi.database.sql.SQL
- dropSequenceGenerator(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Drops an existing sequence generator with the given name.
- dropSequenceGenerator(TableName) - Method in class com.mckoi.database.Transaction
-
Drops an existing sequence generator with the given name.
- dropSequenceGenerator(Transaction, TableName) - Static method in class com.mckoi.database.SequenceManager
- dropTable(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Drops a table from within the context of the current connection transaction.
- dropTable(TableName) - Method in class com.mckoi.database.Transaction
-
Drops a table within this transaction.
- dropTable(String) - Method in class com.mckoi.database.DatabaseConnection
-
Drops a table from within the context of the current connection transaction.
- DropTable - Class in com.mckoi.database.interpret
-
The logic of the 'DROP TABLE' SQL command.
- DropTable() - Constructor for class com.mckoi.database.interpret.DropTable
- DropTable() - Method in class com.mckoi.database.sql.SQL
- dropTrigger(String, String) - Method in class com.mckoi.database.ConnectionTriggerManager
-
Drops a trigger that has previously been defined.
- DropTrigger - Class in com.mckoi.database.interpret
-
A parsed state container for the 'DROP TRIGGER' statement.
- DropTrigger() - Constructor for class com.mckoi.database.interpret.DropTrigger
- DropTrigger() - Method in class com.mckoi.database.sql.SQL
- dropUniqueConstraintForTable(TableName, String) - Method in class com.mckoi.database.Transaction
-
Drops a single named unique constraint from the given table.
- DropUser() - Method in class com.mckoi.database.sql.SQL
- dropView(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Drops the view with the given name and returns true if the drop succeeded.
- DropView() - Method in class com.mckoi.database.sql.SQL
- DSFunctionLookup() - Constructor for class com.mckoi.database.TransactionSystem.DSFunctionLookup
- DTableModel(RawDiagnosticTable) - Constructor for class com.mckoi.tools.ConglomerateViewPane.DTableModel
- dump(Table, PrintStream) - Static method in class com.mckoi.database.DumpHelper
-
Dumps the contents of a table to the given output stream.
- dump(PrintStream) - Method in class com.mckoi.database.DataTableColumnDef
-
Dumps information about this object to the PrintStream.
- dump(PrintStream) - Method in class com.mckoi.database.DataTableDef
-
Outputs to the PrintStream for debugging.
- DumpHelper - Class in com.mckoi.database
-
A helper class for the 'Table.dumpTo' method.
- DumpHelper() - Constructor for class com.mckoi.database.DumpHelper
- dumpTo(PrintStream) - Method in class com.mckoi.database.Table
-
Dumps the contents of the table in a human readable form to the given output stream.
- DUPLICATE_TABLE - Static variable in exception com.mckoi.database.TransactionException
-
Thrown when a transaction conflict occurs and would cause duplicate tables to be created.
E
- EACH - Static variable in interface com.mckoi.database.sql.SQLConstants
- element_size - Variable in class com.mckoi.database.FixedRecordList
-
The fixed size of the elements in the list.
- elementAt(int) - Method in class com.mckoi.database.Expression
-
Returns the element at the given position in the postfix list.
- elements - Variable in class com.mckoi.database.Expression
-
The list of elements followed by operators in our expression.
- elements - Variable in class com.mckoi.database.interpret.AlterTableAction
-
Element parameters to do with the action.
- elementToObject(int, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Expression
-
Returns the element at the given position in the expression list.
- EMPTY_BYTE_LONG_OBJECT - Static variable in class com.mckoi.database.DataCellSerialization
-
A 0 size ByteLongObject object.
- EMPTY_INTEGER_LISTS - Static variable in class com.mckoi.database.IndexSetStore
-
A convenience static empty integer list array.
- EMPTY_INTEGER_LISTS - Static variable in class com.mckoi.database.IndexStore
-
A convenience static empty integer list array.
- EMPTY_LIST - Static variable in class com.mckoi.database.SelectableScheme
-
Some statics.
- EMPTY_LIST - Static variable in class com.mckoi.util.HashMapList
- EMPTY_PRIVS - Static variable in class com.mckoi.database.Privileges
-
No privileges.
- emptySelect() - Method in class com.mckoi.database.Table
-
Returns a new Table based on this table with no rows in it.
- ENABLE_LOGGING - Variable in class com.mckoi.store.JournalledSystem
-
Set to true for logging behaviour.
- enable_tracing() - Method in class com.mckoi.database.sql.SQL
- end - Variable in class com.mckoi.database.SelectableRange
-
The end of the range to select from the set.
- end_offset - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- end_pointer - Variable in class com.mckoi.store.AbstractStore.StoreArea
- end_pointer - Variable in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- end_pointer - Variable in class com.mckoi.store.HeapStore.HeapArea
-
The end pointer of the area.
- end_pointer - Variable in class com.mckoi.store.StreamFile
-
Pointer to the end of the file.
- end_table_name - Variable in class com.mckoi.database.interpret.FromTableSubQuerySource
-
The TableName that this source is generated to (aliased name).
- endColumn - Variable in class com.mckoi.database.sql.Token
-
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
- endLine - Variable in class com.mckoi.database.sql.Token
-
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
- endOfDataAreaPointer() - Method in class com.mckoi.store.AbstractStore
-
Returns a pointer to the end of the current data area.
- endOfDataAreaPointer() - Method in class com.mckoi.store.JournalledFileStore
- ensureCapacity(int) - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
-
Ensures that the buffer is large enough to store the given value.
- ensureCapacityForAddition() - Method in class com.mckoi.util.IntegerVector
-
Ensures there's enough room to make a single addition to the list.
- ensureCapacityForAdditions(int) - Method in class com.mckoi.util.IntegerVector
-
Ensures there's enough room to make 'n' additions to the list.
- ensureColumnSchemeCurrent(int) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
Ensures that the scheme column index is as current as the latest journal change.
- ensureGroup() - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
-
Ensures that 'group' is set up.
- ensureIndexLoaded() - Method in class com.mckoi.database.jdbc.MResultSet
-
Ensures that the row index pointed to by 'real_index' is actually loaded into the 'result_block'.
- ensureRowIndexListCurrent() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
Ensures that the row list is as current as the latest journal change.
- ensureVarList() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Makes sure the 'vars' list is created correctly.
- entries() - Method in class com.mckoi.database.MasterTableJournal
-
Returns the total number of journal entries.
- entryAddTableRow(int, int) - Method in class com.mckoi.database.TransactionJournal
-
Makes a journal entry that a table entry has been added to the table with the given id.
- entryAddTouchedTable(int) - Method in class com.mckoi.database.TransactionJournal
-
Logs in this journal that the transaction touched the given table id.
- entryRemoveTableRow(int, int) - Method in class com.mckoi.database.TransactionJournal
-
Makes a journal entry that a table entry has been removed from the table with the given id.
- entryTableConstraintAlter(int) - Method in class com.mckoi.database.TransactionJournal
-
Makes a journal entry that a table with the given 'table_id' has been altered by this transaction.
- entryTableCreate(int) - Method in class com.mckoi.database.TransactionJournal
-
Makes a journal entry that a table with the given 'table_id' has been created by this transaction.
- entryTableDrop(int) - Method in class com.mckoi.database.TransactionJournal
-
Makes a journal entry that a table with the given 'table_id' has been dropped by this transaction.
- EOF - Static variable in interface com.mckoi.database.sql.SQLConstants
- eol - Variable in exception com.mckoi.database.sql.ParseException
-
The end of line string for this machine.
- eq_op - Static variable in class com.mckoi.database.Operator
- EqualOperator() - Constructor for class com.mckoi.database.Operator.EqualOperator
- equals(IntegerVector) - Method in class com.mckoi.util.IntegerVector
-
Returns true if this vector is equal to the given vector.
- equals(Object) - Method in class com.mckoi.database.DataCellCache.DCCacheKey
- equals(Object) - Method in class com.mckoi.database.global.ColumnDescription
-
The 'equals' method, used to determine equality between column descriptions.
- equals(Object) - Method in class com.mckoi.database.GrantManager.GrantQuery
- equals(Object) - Method in class com.mckoi.database.jdbc.RowCache.RowRef
- equals(Object) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Returns true if this query is equal to another.
- equals(Object) - Method in class com.mckoi.database.Operator
- equals(Object) - Method in class com.mckoi.database.ParameterSubstitution
-
Equality test.
- equals(Object) - Method in class com.mckoi.database.Privileges
- equals(Object) - Method in class com.mckoi.database.ProcedureName
-
Equality test.
- equals(Object) - Method in class com.mckoi.database.SelectableRange
-
Returns true if this range is equal to the given range.
- equals(Object) - Method in class com.mckoi.database.TableName
-
Equality.
- equals(Object) - Method in class com.mckoi.database.TObject
-
Equality test.
- equals(Object) - Method in class com.mckoi.database.Variable
-
Equality.
- equals(Object) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
- equals(Object) - Method in class com.mckoi.util.BigNumber
-
The equals comparison uses the BigDecimal 'equals' method to compare values.
- equals(Object) - Method in class com.mckoi.util.TimeFrame
-
Returns true if the TimeFrame is equal to another.
- EQUALS - Static variable in interface com.mckoi.database.sql.SQLConstants
- equalsIgnoreCase(TableName) - Method in class com.mckoi.database.TableName
-
Equality but ignore the case.
- EquiJoinNode(QueryPlanNode, QueryPlanNode, Variable[], Variable[]) - Constructor for class com.mckoi.database.QueryPlan.EquiJoinNode
- err - Static variable in class com.mckoi.debug.Debug
-
Deprecated.The print stream where the error information is output to.
- err - Variable in class com.mckoi.debug.DefaultDebugLogger
-
The print stream where the error information is output to.
- ERROR - Static variable in class com.mckoi.debug.Debug
-
Deprecated.
- ERROR - Static variable in interface com.mckoi.debug.Lvl
- error_code - Variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
The error code.
- error_code - Variable in exception com.mckoi.database.DatabaseException
- error_on_dirty_select - Variable in class com.mckoi.database.DatabaseConnection
-
True if transactions through this connection generate an error when there is a dirty select on a table.
- errorCode - Variable in error com.mckoi.database.sql.TokenMgrError
-
Indicates the reason why the exception is thrown.
- escape_processing - Variable in class com.mckoi.database.jdbc.MStatement
- escapeJDBCSubstitution(String) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Given a JDBC escape code of the form {keyword ...
- escapeTranslated(String) - Static method in class com.mckoi.database.sql.Util
-
Translate a string with escape codes into a un-escaped Java string.
- establishPendingConnections() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
Establishes a connection with any current pending connections in the 'pending_connections_list'.
- establishReference(long) - Method in class com.mckoi.database.BlobStore
-
Tells the BlobStore that a static reference has been established in a table to the blob referenced by the given id.
- establishReference(long) - Method in interface com.mckoi.database.BlobStoreInterface
-
Tells the BlobStore that a static reference has been established in a table to the blob referenced by the given id.
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.AddOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.AllOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.AndOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.AnyOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.ConcatOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.DivideOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.EqualOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.GreaterEqualOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.GreaterOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.IsNotOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.IsOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.LesserEqualOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.LesserOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.MultiplyOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.NotEqualOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.OrOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.ParenOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.PatternMatchFalseOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.PatternMatchTrueOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.RegexOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.SimpleOperator
- eval(TObject, TObject, GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Operator.SubtractOperator
- eval_result - Variable in class com.mckoi.database.CorrelatedVariable
-
The temporary value this variable has been set to evaluate to.
- eval_stack - Variable in class com.mckoi.database.Expression
-
The evaluation stack for when the expression is evaluated.
- evalAggregate(GroupResolver, QueryContext, TObject, TObject) - Method in class com.mckoi.database.AbstractAggregateFunction
-
Evaluates the aggregate function for the given values and returns the result.
- evalAggregate(GroupResolver, QueryContext, TObject, TObject) - Method in class com.mckoi.database.InternalFunctionFactory.AggOrFunction
- evalAggregate(GroupResolver, QueryContext, TObject, TObject) - Method in class com.mckoi.database.InternalFunctionFactory.AvgFunction
- evalAggregate(GroupResolver, QueryContext, TObject, TObject) - Method in class com.mckoi.database.InternalFunctionFactory.MaxFunction
- evalAggregate(GroupResolver, QueryContext, TObject, TObject) - Method in class com.mckoi.database.InternalFunctionFactory.MinFunction
- evalAggregate(GroupResolver, QueryContext, TObject, TObject) - Method in class com.mckoi.database.InternalFunctionFactory.SumFunction
- evaluate() - Method in class com.mckoi.database.interpret.AlterTable
- evaluate() - Method in class com.mckoi.database.interpret.Call
- evaluate() - Method in class com.mckoi.database.interpret.Compact
- evaluate() - Method in class com.mckoi.database.interpret.CompleteTransaction
- evaluate() - Method in class com.mckoi.database.interpret.CreateTable
- evaluate() - Method in class com.mckoi.database.interpret.CreateTrigger
- evaluate() - Method in class com.mckoi.database.interpret.Delete
- evaluate() - Method in class com.mckoi.database.interpret.DropTable
- evaluate() - Method in class com.mckoi.database.interpret.DropTrigger
- evaluate() - Method in class com.mckoi.database.interpret.Function
- evaluate() - Method in class com.mckoi.database.interpret.Insert
- evaluate() - Method in class com.mckoi.database.interpret.Misc
- evaluate() - Method in class com.mckoi.database.interpret.NoOp
- evaluate() - Method in class com.mckoi.database.interpret.PrivManager
- evaluate() - Method in class com.mckoi.database.interpret.Schema
- evaluate() - Method in class com.mckoi.database.interpret.Select
-
Evaluates the select statement with the given Database context.
- evaluate() - Method in class com.mckoi.database.interpret.Sequence
- evaluate() - Method in class com.mckoi.database.interpret.Set
- evaluate() - Method in class com.mckoi.database.interpret.Show
- evaluate() - Method in class com.mckoi.database.interpret.Statement
-
Evaluates the statement and returns a table that represents the result set.
- evaluate() - Method in class com.mckoi.database.interpret.UpdateTable
- evaluate() - Method in class com.mckoi.database.interpret.UserManager
- evaluate() - Method in class com.mckoi.database.interpret.ViewManager
- evaluate(Assignment, QueryContext) - Method in class com.mckoi.database.RowData
-
Evaluates a single assignment on this RowData object.
- evaluate(Expression, QueryContext) - Method in class com.mckoi.database.RowData
-
Evaluates the expression and returns the object it evaluates to using the local VariableResolver to resolve variables in the expression.
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.AbstractAggregateFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.Expression
-
Evaluates this expression and returns an Object that represents the result of the evaluation.
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in interface com.mckoi.database.Function
-
Evaluates the function and returns a TObject that represents the result of the function.
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.AbsFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.BinaryToHexFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.CoalesceFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ConcatFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.CountFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.CurrValFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.DateFormatFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.DistinctCountFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ForeignRuleConvert
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.GreatestFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.HexToBinaryFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.IfFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.JavaObjectInstantiation
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.JavaObjectInstantiation2
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.LeastFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.LengthFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.LowerFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.LTrimFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ModFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.NextValFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.PowFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.PrivGroupsFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.PrivilegeString
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.RoundFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.RTrimFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SetValFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SignFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SQLCastFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SQLTrimFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SQLTypeString
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SqrtFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SubstringFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.TimeObFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.TimeStampObFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ToNumberFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.UniqueKeyFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.UpperFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.UserFunction
- evaluate(GroupResolver, VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ViewDataConvert
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.CachePointNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.CompositeNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.ConstantSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.CreateFunctionsNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.DistinctNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.EquiJoinNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.FetchTableNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.FetchViewNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.FunctionalSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.GroupNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.JoinNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.LeftOuterJoinNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.LogicalUnionNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.MarkerNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.NaturalJoinNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.SimpleSelectNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.SingleRowTableNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.SortNode
- evaluate(QueryContext) - Method in class com.mckoi.database.QueryPlan.SubsetNode
- evaluate(QueryContext) - Method in interface com.mckoi.database.QueryPlanNode
-
Evaluates the node and returns the result as a Table.
- evaluate(VariableResolver, QueryContext) - Method in class com.mckoi.database.Expression
-
Evaluation without a grouping table.
- evaluate(Connection, String, String, String) - Method in class com.mckoi.tools.JDBCScriptTool
-
Evaluates the input script and outputs the result to the output stream.
- evaluateConstants(ArrayList, ArrayList) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a list of constant conditional exressions of the form '3 + 2 = 0', 'true = true', etc.
- evaluateMultiples(ArrayList, ArrayList) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a list of expressions containing multiple variable expression.
- evaluatePatterns(ArrayList, ArrayList) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a list of expressions that are pattern searches (eg.
- evaluateSingles(ArrayList, ArrayList) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a list of single variable conditional expressions of the form a = 3, a > 1 + 2, a - 2 = 1, 3 = a, concat(a, 'a') = '3a', etc.
- evaluateSubLogic(ArrayList, ArrayList) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a list of expressions that are sub-expressions themselves.
- evaluateSubQueries(ArrayList, ArrayList) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a list of expressions containing sub-queries.
- event_queue - Variable in class com.mckoi.database.DatabaseDispatcher
- event_type - Variable in class com.mckoi.database.TableModificationEvent
-
The type of event that occurred.
- eventQueue() - Method in class com.mckoi.jfccontrols.QueryAgent
-
Returns the current system EventQueue.
- eventQueue() - Static method in class com.mckoi.jfccontrols.SwingBlockUtil
-
Returns the current system EventQueue.
- exactSize(Object) - Static method in class com.mckoi.database.global.ObjectTransfer
-
Returns the exact size an object will take up when serialized.
- EXCEPT - Static variable in class com.mckoi.database.CompositeTable
-
The composite function for finding the difference of the tables.
- EXCEPT - Static variable in interface com.mckoi.database.sql.SQLConstants
- exception(int, SQLException) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Creates a response that represents an SQL exception failure.
- EXCEPTION - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Operation threw an exception.
- EXCEPTIONS_TO_ERR - Static variable in class com.mckoi.debug.Debug
-
Deprecated.Set this to true to output all exceptions to System.err.
- EXCLUSIVE_MODE - Static variable in class com.mckoi.database.LockingMechanism
- execQuery(SQLQuery) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Executes the query and returns a QueryResponse object that describes the result of the query.
- execQuery(SQLQuery) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- execQuery(SQLQuery) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
- execQuery(SQLQuery) - Method in class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
- execute() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- execute(DatabaseConnection, SQLQuery) - Method in class com.mckoi.database.interpret.SQLQueryExecutor
-
Executes the given SQLQuery object on the given DatabaseConnection object.
- execute(User, DatabaseConnection, Runnable) - Method in class com.mckoi.database.Database
-
Executes database functions from the 'run' method of the given runnable instance on the first available worker thread.
- execute(User, DatabaseConnection, Runnable) - Method in class com.mckoi.database.DatabaseSystem
-
Executes database functions from the 'run' method of the given runnable instance on the first available worker thread.
- execute(User, DatabaseConnection, Runnable) - Method in class com.mckoi.database.WorkerPool
-
Executes database functions from the 'run' method of the given runnable instance on a worker thread.
- execute(User, DatabaseConnection, Runnable) - Method in class com.mckoi.database.WorkerThread
-
Tells the worker thread that the user is executing the given command.
- execute(User, Object[]) - Method in interface com.mckoi.database.DatabaseProcedure
-
Executes the procudure and returns the resultant table.
- execute(Query) - Static method in class com.mckoi.jfccontrols.QueryAgent
-
Executes a query on the default query agent for this VM.
- execute(String) - Method in class com.mckoi.database.jdbc.MStatement
- execute(String, int) - Method in class com.mckoi.database.jdbc.MStatement
- execute(String, int[]) - Method in class com.mckoi.database.jdbc.MStatement
- execute(String, String[]) - Method in class com.mckoi.database.jdbc.MStatement
- EXECUTE - Static variable in interface com.mckoi.database.sql.SQLConstants
- executeBatch() - Method in class com.mckoi.database.jdbc.MStatement
- executeDeleteReferentialAction(Transaction.ColumnGroupReference, TObject[], QueryContext) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
Executes a delete referential action.
- executeQueries(SQLQuery[]) - Method in class com.mckoi.database.jdbc.MStatement
-
Executes a batch of SQL queries as listed as an array.
- executeQueries(SQLQuery[], MResultSet[]) - Method in class com.mckoi.database.jdbc.MConnection
-
Sends the batch of SQLQuery objects to the database to be executed.
- executeQuery() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- executeQuery(SQLQuery) - Method in class com.mckoi.database.jdbc.MStatement
-
Executes the given SQLQuery object and fill's in at most the top 10 entries of the result set.
- executeQuery(SQLQuery) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Sends a command to the server to process a query.
- executeQuery(SQLQuery, MResultSet) - Method in class com.mckoi.database.jdbc.MConnection
-
Sends the SQL string to the database to be executed.
- executeQuery(Query) - Method in class com.mckoi.jfccontrols.QueryAgent
-
Executes a query, blocking until a response from the server has been received.
- executeQuery(String) - Method in class com.mckoi.database.jdbc.MStatement
- executeUpdate() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- executeUpdate(String) - Method in class com.mckoi.database.jdbc.MStatement
- executeUpdate(String, int) - Method in class com.mckoi.database.jdbc.MStatement
- executeUpdate(String, int[]) - Method in class com.mckoi.database.jdbc.MStatement
- executeUpdate(String, String[]) - Method in class com.mckoi.database.jdbc.MStatement
- executeUpdateReferentialAction(Transaction.ColumnGroupReference, TObject[], TObject[], QueryContext) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
Executes an update referential action.
- ExhaustiveJoinExpressionPlan(Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveJoinExpressionPlan
- exhaustiveSelect(QueryContext, Expression) - Method in class com.mckoi.database.Table
-
Exhaustively searches through this table for rows that match the expression given.
- ExhaustiveSelectExpressionPlan(Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSelectExpressionPlan
- ExhaustiveSelectNode(QueryPlanNode, Expression) - Constructor for class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- ExhaustiveSubQueryExpressionPlan(List, Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSubQueryExpressionPlan
- exists() - Method in class com.mckoi.database.Database
-
Returns true if the database exists.
- exists() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns true if the file for this store exists.
- exists() - Method in class com.mckoi.database.IndexStore
-
Returns true if the index store file exists.
- exists() - Method in class com.mckoi.database.TableDescriptions
-
Returns true if the table descriptions file exists.
- exists() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns true if the data store exists.
- exists() - Method in class com.mckoi.store.IOStoreDataAccessor
- exists() - Method in class com.mckoi.store.JournalledFileStore
-
Returns true if this store exists in the file system.
- exists() - Method in interface com.mckoi.store.JournalledResource
-
Returns true if the resource currently exists.
- exists() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Returns true if the resource currently exists.
- exists() - Method in class com.mckoi.store.JournalledSystem.Resource
-
Returns true if the resource currently exists.
- exists() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- exists() - Method in interface com.mckoi.store.StoreDataAccessor
-
Returns true if the resource exists.
- exists(File, String) - Static method in class com.mckoi.database.VariableSizeDataStore
-
Convenience for checking if a given data store exists or not.
- exists(String) - Method in class com.mckoi.database.TableDataConglomerate
-
Returns true if the conglomerate exists in the file system and can be opened.
- exists(String) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Returns true if the master table data source with the given filename exists.
- exists(String) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Returns true if the master table data source with the given source identity exists.
- EXISTS - Static variable in interface com.mckoi.database.sql.SQLConstants
- existsSingle(int, Object) - Method in class com.mckoi.database.SimpleTableQuery
-
Returns true if there is a single row in the table where the given column is equal to the given value, otherwise returns false.
- existsTableWithColumn(Variable) - Method in class com.mckoi.database.interpret.Statement
-
Given a fully resolved table name ( eg.
- exp - Variable in class com.mckoi.database.interpret.ByColumn
-
The expression that we are ordering by.
- exp - Variable in class com.mckoi.database.interpret.Set
-
The Expression that is the value to assign the variable to (if applicable).
- exp_info - Variable in class com.mckoi.database.FunctionTable
-
Some information about the expression list.
- exp_list - Variable in class com.mckoi.database.FunctionTable
-
The list of expressions that are evaluated to form each column.
- ExpandBuff(boolean) - Method in class com.mckoi.database.sql.SimpleCharStream
- expandDataArea(long) - Method in class com.mckoi.store.AbstractStore
-
Expands the data area by at least the minimum size given.
- expectedTokenSequences - Variable in exception com.mckoi.database.sql.ParseException
-
Each entry in this array is an array of integers.
- expEnd(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
-
Helper for expression parsing.
- expEndParen(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
-
Helper for expression parsing.
- EXPLAIN - Static variable in interface com.mckoi.database.sql.SQLConstants
- explode(String, String) - Static method in class com.mckoi.util.StringUtil
-
Performs an 'explode' operation on the given source string.
- expOperator(Expression, Stack, Operator) - Method in class com.mckoi.database.sql.SQL
-
Helper for expression parsing.
- exposeAllColumns() - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Exposes all the columns in all the child tables.
- exposeAllColumnsFromSource(FromTableInterface) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Exposes all the columns from the given FromTableInterface.
- exposeAllColumnsFromSource(TableName) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Exposes all the columns from the given table name.
- exposed_variables - Variable in class com.mckoi.database.interpret.TableExpressionFromSet
-
The list of Variable references in this set that are exposed to the outside, including function aliases.
- exposeVariable(Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Adds a variable in this from set that is exposed to the outside.
- expression - Variable in class com.mckoi.database.Assignment
-
Set expression that is the rhs of the assignment.
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ComplexSingleExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ConstantExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveJoinExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSelectExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ExhaustiveSubQueryExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimplePatternExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSelectExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSingleExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSubQueryExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SingleVarPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.StandardJoinExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SubLogicExpressionPlan
- expression - Variable in class com.mckoi.database.interpret.SelectColumn
-
The expression of this column.
- expression - Variable in class com.mckoi.database.QueryPlan.ConstantSelectNode
-
The search expression.
- expression - Variable in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
-
The search expression.
- expression - Variable in class com.mckoi.database.QueryPlan.FunctionalSelectNode
-
The function expression (eg.
- expression - Variable in class com.mckoi.database.QueryPlan.RangeSelectNode
-
A simple expression that represents the range to select.
- expression - Variable in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
-
The search expression.
- expression - Variable in class com.mckoi.database.Transaction.CheckExpression
-
The expression to check.
- expression(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
-
Parse an expression.
- Expression - Class in com.mckoi.database
-
An expression that can be evaluated in a statement.
- Expression() - Constructor for class com.mckoi.database.Expression
-
Constructs a new Expression.
- Expression(Expression) - Constructor for class com.mckoi.database.Expression
-
Constructs a copy of the given Expression.
- Expression(Expression, Operator, Expression) - Constructor for class com.mckoi.database.Expression
-
Constructs a new Expression from the concatination of expression1 and expression2 and the operator for them.
- Expression(Object) - Constructor for class com.mckoi.database.Expression
-
Constructs a new Expression with a single object element.
- expression_parser - Static variable in class com.mckoi.database.Expression
-
A static expression parser.
- ExpressionList() - Method in class com.mckoi.database.sql.SQL
- expressionListToString(Expression[]) - Static method in class com.mckoi.database.sql.Util
-
Returns an array of Expression objects as a comma deliminated string.
- ExpressionPlan() - Constructor for class com.mckoi.database.interpret.Planner.ExpressionPlan
- ExpressionPreparer - Interface in com.mckoi.database
-
An interface used to prepare an Expression object.
- expressionQualifier() - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Returns an ExpressionPreparer that qualifies all variables in an expression to either a qualified Variable or a CorrelatedVariable object.
- ExpressionTest() - Method in class com.mckoi.database.sql.SQL
- extGetDate(int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Access column as java.util.Date (which is the native object used in the mckoi database to handle time).
- extGetDate(String) - Method in class com.mckoi.database.jdbc.MResultSet
-
Access column as java.util.Date (which is the native object used in the mckoi database to handle time).
- extQueryTimeMillis() - Method in class com.mckoi.database.jdbc.MResultSet
-
The number of milliseconds it took the server to execute this query.
- EXTRA_SECTOR_SIZE - Static variable in class com.mckoi.database.FixedSizeDataStore
-
The number of bytes that are stored in a sector in addition to the user data in a sector.
- extSetDate(int, Date) - Method in class com.mckoi.database.jdbc.MPreparedStatement
F
- factories - Variable in class com.mckoi.database.TransactionSystem.DSFunctionLookup
- FAILED - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Operation failed (followed by a UTF String error message).
- farmer - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
The ServerFarmer object that polls for information from the clients and dispatches the request to the worker threads.
- farmer_closed - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
If this is set to true, then the farmer run method should close off.
- fastFindColumnName(String) - Method in class com.mckoi.database.DataTableDef
-
A faster way to find a column index given a string column name.
- fastFindFieldName(Variable) - Method in class com.mckoi.database.Table
-
A faster way to find a column index given a string column name.
- fetch_size - Variable in class com.mckoi.database.jdbc.MResultSet
-
The number of rows to fetch each time we need to get rows from the database.
- fetch_size - Variable in class com.mckoi.database.jdbc.MStatement
- fetchPage(JournalledResource, long) - Method in class com.mckoi.store.LoggingBufferManager
-
Fetches and returns a page from a store.
- FetchTableNode(TableName, TableName) - Constructor for class com.mckoi.database.QueryPlan.FetchTableNode
- FetchViewNode(TableName, TableName) - Constructor for class com.mckoi.database.QueryPlan.FetchViewNode
- FF_FunctionInfo(String, int, Constructor) - Constructor for class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- file - Variable in class com.mckoi.database.IndexStore
-
The name of the index store file.
- file - Variable in class com.mckoi.store.IOStoreDataAccessor
-
The File object representing the file in the file system.
- file - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
The File object of this journal in the file system.
- file - Variable in class com.mckoi.store.StreamFile
-
The File object.
- file_hits_key - Variable in class com.mckoi.database.MasterTableDataSource
- file_name - Variable in class com.mckoi.database.V1MasterTableDataSource
-
The file name of this store in the conglomerate path.
- file_name - Variable in class com.mckoi.database.V2MasterTableDataSource
-
The file name of this store in the conglomerate path.
- file_name - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
The name of the file in the file system minus the extension.
- FileSlice() - Constructor for class com.mckoi.store.ScatteringStoreDataAccessor.FileSlice
- FillBuff() - Method in class com.mckoi.database.sql.SimpleCharStream
- fillBuffer(long) - Method in class com.mckoi.util.PagedInputStream
-
Fills the buffer with data from the blob at the given position.
- filterHavingClause(Expression, ArrayList, QueryContext) - Static method in class com.mckoi.database.interpret.Planner
-
Given a HAVING clause expression, this will generate a new HAVING clause expression with all aggregate expressions put into the given extra function list.
- FilterTable - Class in com.mckoi.database
-
A table that is a filter for another table.
- FilterTable(Table) - Constructor for class com.mckoi.database.FilterTable
-
The Constructor.
- finalize() - Method in class com.mckoi.database.Database
- finalize() - Method in class com.mckoi.database.DatabaseConnection
- finalize() - Method in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
- finalize() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
- finalize() - Method in class com.mckoi.database.jdbc.MResultSet
- finalize() - Method in class com.mckoi.database.jdbc.MStatement
-
The statement will close when it is garbage collected.
- finalize() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Clean up if this object is GC'd.
- finalize() - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable.LocalJDBCDatabaseInterface
- finalize() - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
- finalize() - Method in class com.mckoi.database.LockHandle
-
On garbage collection, this will call 'unlockAll' just in case the program did not use the 'LockingMechanism.unlockTables' method in error.
- finalize() - Method in class com.mckoi.database.SimpleTableQuery
-
To be save we call dispose from the finalize method.
- finalize() - Method in class com.mckoi.database.TableDataConglomerate
- finalize() - Method in class com.mckoi.database.Transaction
-
Finalize, we should close the transaction.
- find(String, String) - Static method in class com.mckoi.util.StringUtil
-
Finds the index of the given string in the source string.
- findAllJournalsSince(long) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns a list of all MasterTableJournal objects that have been successfully committed against this table that have an 'commit_id' that is greater or equal to the given.
- findAllJournalsSince(long) - Method in class com.mckoi.database.MultiVersionTableIndices
-
Returns a list of all MasterTableJournal objects that have been successfully committed against this table that have an 'commit_id' that is greater or equal to the given.
- findAllocatedAreasNotIn(ArrayList) - Method in class com.mckoi.store.AbstractStore
-
Scans the area list, and any areas that aren't deleted and aren't found in the given ArrayList are returned as leaked areas.
- findBestConstructor(Constructor[], TObject[]) - Static method in class com.mckoi.database.Caster
-
Search for the best constructor that we can use with the given argument types.
- findBlockContaining(Object, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Uses a binary search algorithm to quickly determine the index of the IntegerListBlockInterface within 'block_list' of the block that contains the given key value using the IndexComparator as a lookup comparator.
- findColumn(String) - Method in class com.mckoi.database.jdbc.MResultSet
- findColumnIndex(String) - Method in class com.mckoi.database.jdbc.MResultSet
-
Searches for the index of the column with the given name.
- findColumnIndices(DataTableDef, String[]) - Static method in class com.mckoi.database.TableDataConglomerate
-
Returns a list of column indices into the given DataTableDef for the given column names.
- findColumnName(Variable) - Method in class com.mckoi.database.Table.TableVariableResolver
- findColumnName(Variable) - Method in class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- findColumnName(String) - Method in class com.mckoi.database.DataTableDef
- findCommonTableSource(List) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Finds a common PlanTableSource that contains the list of variables given.
- findFieldName(Variable) - Method in class com.mckoi.database.CompositeTable
- findFieldName(Variable) - Method in class com.mckoi.database.DataTable
- findFieldName(Variable) - Method in class com.mckoi.database.DataTableFilter
-
Given a fully qualified variable field name, ie.
- findFieldName(Variable) - Method in class com.mckoi.database.DefaultDataTable
-
Given a fully qualified variable field name, ie.
- findFieldName(Variable) - Method in class com.mckoi.database.FilterTable
-
Given a fully qualified variable field name, ie.
- findFieldName(Variable) - Method in class com.mckoi.database.JoinedTable
-
Given a fully qualified variable field name, ie.
- findFieldName(Variable) - Method in class com.mckoi.database.ReferenceTable
-
Given a fully qualified variable field name, ie.
- findFieldName(Variable) - Method in class com.mckoi.database.SubsetColumnTable
-
Given a fully qualified variable field name, ie.
- findFieldName(Variable) - Method in class com.mckoi.database.Table
-
Given a fully qualified variable field name, ie.
- findFieldName(String) - Method in class com.mckoi.database.RowData
-
Finds the field in this RowData with the given name.
- findFirstBlock(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Uses a binary search algorithm to quickly determine the index of the IntegerListBlockInterface within 'block_list' of the block that contains the given value.
- findFirstBlock(Object, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Uses a binary search algorithm to quickly determine the index of the IntegerListBlockInterface within 'block_list' of the block that contains the given key value using the IndexComparator as a lookup comparator.
- findFreeSector() - Method in class com.mckoi.database.FixedSizeDataStore
-
Finds the first free available sector that we can use.
- findFreeSectorPastNext() - Method in class com.mckoi.database.FixedSizeDataStore
-
Finds the first free available sector past the next one.
- findFreeSectors(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Finds the first 'n' available sectors that we can use.
- findIndexForColumns(String[]) - Method in class com.mckoi.database.DataIndexSetDef
-
Finds the first index for the given column name list.
- findIndexWithName(String) - Method in class com.mckoi.database.DataIndexSetDef
-
Finds the index with the given name and returns the index in the list of the index (confusing comment!).
- findKeys(TableDataSource, int[], TObject[]) - Static method in class com.mckoi.database.TableDataConglomerate
-
Returns the key indices found in the given table.
- findLastBlock(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Uses a binary search algorithm to quickly determine the index of the IntegerListBlockInterface within 'block_list' of the block that contains the given value.
- findLastBlock(Object, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Uses a binary search algorithm to quickly determine the index of the IntegerListBlockInterface within 'block_list' of the block that contains the given key value using the IndexComparator as a lookup comparator.
- findProcedureEntry(DataTable, ProcedureName) - Method in class com.mckoi.database.ProcedureManager
-
Given the SYS_FUNCTION table, this returns a new table that contains the entry with the given procedure name, or an empty result if nothing found.
- findTable(String, String) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Returns the first FromTableInterface object that matches the given schema, table reference.
- findTableInQuery(String, String) - Method in class com.mckoi.database.interpret.Statement
-
Returns the first FromTableInterface object that matches the given schema, table reference.
- findTableName(TableName) - Method in class com.mckoi.database.AbstractInternalTableInfo
-
Finds the index in this container of the given table name, otherwise returns -1.
- findTableName(TableName) - Method in class com.mckoi.database.AbstractInternalTableInfo2
- findTableName(TableName) - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- findTableName(TableName) - Method in interface com.mckoi.database.InternalTableInfo
-
Finds the index in this container of the given table name, otherwise returns -1.
- findTableName(TableName) - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- findTableSource(Variable) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Finds and returns the PlanTableSource in the list of tables that contains the given Variable reference.
- findTableSourceWithUniqueKey(String) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Finds and returns the PlanTableSource in the list of table that contains the given unique key name.
- findTableWithColumn(Variable) - Method in class com.mckoi.database.interpret.Statement
-
Given a fully resolved table name ( eg.
- findTrigger(QueryContext, DataTable, String, String) - Method in class com.mckoi.database.ConnectionTriggerManager
-
Returns a Table object that contains the trigger information with the given name.
- findViewEntry(DataTable, TableName) - Method in class com.mckoi.database.ViewManager
-
Given the SYS_VIEW table, this returns a new table that contains the entry with the given view name, or an empty result if the view is not found.
- findVisibleTable(TableName, boolean) - Method in class com.mckoi.database.SimpleTransaction
-
Searches through the list of tables visible within this transaction and returns the MasterTableDataSource object with the given name.
- finish() - Method in class com.mckoi.database.DatabaseDispatcher
-
Ends this dispatcher thread.
- finish() - Method in class com.mckoi.store.AbstractStore.StoreAreaWriter
- finish() - Method in interface com.mckoi.store.AreaWriter
-
Finishes the area writer object.
- finish() - Method in class com.mckoi.store.HeapStore.HeapAreaWriter
- finish() - Method in class com.mckoi.store.JournalledSystem.JournalingThread
- finished - Variable in class com.mckoi.database.DatabaseDispatcher
- finished - Variable in class com.mckoi.database.DatabaseSystem.ShutdownThread
- finished - Variable in class com.mckoi.store.JournalledSystem.JournalingThread
- finishMode(int) - Method in class com.mckoi.database.LockingMechanism
-
This must be called when the calls to a Database object have finished.
- firePendingTriggerEvents() - Method in class com.mckoi.database.DatabaseConnection
-
Fires any triggers that are pending in the trigger buffer.
- fireTableEvent(TableModificationEvent) - Method in class com.mckoi.database.DatabaseConnection
-
Notifies this connection that an insert/delete or update operation has occurred on some table of this DatabaseConnection.
- fireTrigger(DatabaseConnection, String, TriggerEvent) - Method in class com.mckoi.database.DatabaseConnection
-
Notifies when a trigger has fired for this user.
- fireTrigger(DatabaseConnection, String, TriggerEvent) - Method in interface com.mckoi.database.TriggerListener
-
Notifies that a trigger event fired.
- fireTrigger(TriggerEvent) - Method in class com.mckoi.database.TriggerManager
-
Notifies all the listeners on a trigger_source (ie.
- first - Variable in class com.mckoi.database.sql.SQL.JJCalls
- first() - Method in class com.mckoi.database.jdbc.MResultSet
- first_delete_chain_record - Variable in class com.mckoi.database.BlobStore
-
The first delete chain element.
- first_delete_chain_record - Variable in class com.mckoi.database.V2MasterTableDataSource
-
The first delete chain element.
- first_entry - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
The first entry in the block.
- first_entry - Variable in class com.mckoi.database.IndexStore.MappedListBlock
-
The first entry in the block.
- first_ext - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
The extension of the first file in the sliced set.
- FIRST_IN_SET - Static variable in class com.mckoi.database.SelectableRange
-
An object that represents the first value in the set.
- first_sector - Variable in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
-
The first sector we wrote to.
- FIRST_VALUE - Static variable in class com.mckoi.database.SelectableRange
-
Represents the various points in the set on the value to represent the set range.
- first_write_position - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The first position in the buffer that was last written.
- firstInCollationOrder() - Method in class com.mckoi.database.CollatedBaseSearch
-
Returns the first value of this column (in collated order).
- firstInCollationOrder() - Method in class com.mckoi.database.InsertSearch
- fix(UserTerminal) - Method in class com.mckoi.database.FixedSizeDataStore
-
Attempts to repair this data store to a correct state.
- fix(UserTerminal) - Method in class com.mckoi.database.IndexStore
-
Performs checks to determine that the index store is stable.
- fix(UserTerminal) - Method in class com.mckoi.database.VariableSizeDataStore
-
Attempts to fix a corrupt VariableSizeDataStore object.
- fix(String, UserTerminal) - Method in class com.mckoi.database.TableDataConglomerate
-
Checks the conglomerate state file.
- fixed_area_element - Variable in class com.mckoi.store.HeapStore
-
The fixed area element (a 64 byte area).
- FIXED_AREA_OFFSET - Static variable in class com.mckoi.store.AbstractStore
-
The offset into the file of the 64 byte fixed area.
- fixed_list - Variable in class com.mckoi.database.BlobStore
-
The FixedRecordList structure that maintains a list of fixed size records for blob reference counting.
- FixedRecordList - Class in com.mckoi.database
-
A structure that provides a fast way to read and write fixed sized nodes in a Store object.
- FixedRecordList(Store, int) - Constructor for class com.mckoi.database.FixedRecordList
-
Constructs the structure.
- FixedSizeDataStore - Class in com.mckoi.database
-
A file format that allows for the very quick retreival of data that is stored within it.
- FixedSizeDataStore(File, int, boolean, DebugLogger) - Constructor for class com.mckoi.database.FixedSizeDataStore
-
Constructs the data store.
- FixedSizeDataStore(File, int, DebugLogger) - Constructor for class com.mckoi.database.FixedSizeDataStore
- FixedSizeDataStore.SectorInputStream - Class in com.mckoi.database
-
An input stream that reads information across a sector chain starting at the given head sector.
- FixedSizeDataStore.SectorOutputStream - Class in com.mckoi.database
-
A buffered OutputStream object that writes all data written to the stream out to the store.
- flags - Variable in class com.mckoi.database.GrantManager.GrantQuery
- FLOAT - Static variable in interface com.mckoi.database.global.SQLTypes
- FLOAT - Static variable in interface com.mckoi.database.sql.SQLConstants
- floatClasses - Static variable in class com.mckoi.database.Caster
- floatPrims - Static variable in class com.mckoi.database.Caster
- floatValue() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as a float.
- FLOCK_EXT - Static variable in class com.mckoi.database.V1FileStoreSystem
-
The name of the file extention of the file lock on this conglomerate.
- flush() - Method in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
- flush() - Method in class com.mckoi.database.IndexStore
-
Flushes all information in this index store to the file representing this store in the file system.
- flush() - Method in class com.mckoi.store.AbstractStore.AreaOutputStream
- flush() - Method in class com.mckoi.store.HeapStore
- flush() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Flushes this page out to disk, but does not remove from memory.
- flush() - Method in class com.mckoi.util.LogWriter
- flush_buffer - Variable in class com.mckoi.database.IndexStore
- flushAndSynch() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Synchronizes the log.
- flushBlobStore() - Method in class com.mckoi.database.DatabaseConnection
-
Tells the conglomerate to flush the blob store.
- flushBlobStore() - Method in class com.mckoi.database.TableDataConglomerate
-
Called when one or more blobs has been completed.
- flushCachedFunctionLookup() - Method in class com.mckoi.database.TransactionSystem
-
Flushes the 'FunctionLookup' object returned by the getFunctionLookup method.
- flushCommand() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Flushes the command in 'com_bytes' to the server.
- flushContents(FunctionFactory[]) - Method in class com.mckoi.database.TransactionSystem.DSFunctionLookup
- flushGenerator(TableName) - Method in class com.mckoi.database.SequenceManager
-
Flushes a sequence generator from the cache.
- flushIndexChanges() - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- flushIndexChanges() - Method in class com.mckoi.database.GTDataSource
- flushIndexChanges() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- flushIndexChanges() - Method in interface com.mckoi.database.MutableTableDataSource
-
Flushes all changes made on this MutableTableDataSource to the backing index scheme (IndexSet).
- flushLargeObjectRefFromCache(long) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Removes the large object reference from the HashMap for the given streamable object id from the HashMap.
- flushOperatorStack(Expression, Stack, int) - Method in class com.mckoi.database.sql.SQL
-
Flush the operator stack until the stack is either empty or the top element is either a "(" or of a precedence lower than the given precedence.
- flushSequenceManager(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Flushes the sequence cache.
- flushTableCache(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Flushes the table cache and purges the cache of the entry for the given table name.
- flushTriggerEvents(ArrayList) - Method in class com.mckoi.database.TriggerManager
-
Flushes the list of TriggerEvent objects and dispatches them to the users that are listening.
- FOR - Static variable in interface com.mckoi.database.sql.SQLConstants
- FOREIGN - Static variable in interface com.mckoi.database.sql.SQLConstants
- FOREIGN_COLS_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- FOREIGN_INFO_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- foreign_key - Variable in class com.mckoi.database.DataTableColumnDef
-
Deprecated.
- FOREIGN_KEY - Static variable in class com.mckoi.database.interpret.ConstraintDef
-
A FOREIGN_KEY constraint.
- FOREIGN_KEY_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
A Foreign Key constraint violation error code.
- ForeignRuleConvert(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.ForeignRuleConvert
- format(int) - Method in class com.mckoi.util.TimeFrame
-
Returns a string that represents this time frame formatted as a string.
- format(int, boolean) - Method in class com.mckoi.util.TimeFrame
-
Returns a string that represents this time frame formatted as a string.
- formatAsText(ResultSet, PrintWriter) - Static method in class com.mckoi.util.ResultOutputUtil
-
Formats the ResultSet as plain mono-spaced text and outputs the result to the PrintWriter.
- formatDateAsString(Date) - Static method in class com.mckoi.database.global.CastHelper
-
Formats the date object as a standard SQL string.
- formatPriv(int) - Static method in class com.mckoi.database.Privileges
-
Returns a String that represents the given priv bit.
- formatter_cache - Static variable in class com.mckoi.database.InternalFunctionFactory.DateFormatFunction
- formQueryPlan(DatabaseConnection, TableSelectExpression, TableExpressionFromSet, ArrayList) - Static method in class com.mckoi.database.interpret.Planner
-
Forms a query plan (QueryPlanNode) from the given TableSelectExpression and TableExpressionFromSet.
- found_count - Variable in class com.mckoi.util.SearchResults
-
The number of elements in the array that match the given search criteria.
- found_index - Variable in class com.mckoi.util.SearchResults
-
The index in the array of the found elements.
- fp - Variable in class com.mckoi.store.StreamFile.SFInputStream
- free() - Method in class com.mckoi.database.jdbc.MBlob
- free() - Method in class com.mckoi.database.jdbc.MClob
- free() - Method in class com.mckoi.database.jdbc.MStreamableBlob
- free() - Method in class com.mckoi.database.jdbc.MStreamableClob
- free(long) - Method in class com.mckoi.store.AbstractStore
-
Frees a previously allocated area in the store.
- free_bin_list - Variable in class com.mckoi.store.AbstractStore
-
The free bin list contains 128 entries pointing to the first available block in the bin.
- freed - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
Set to true when this index block is freed from the index store.
- FROM - Static variable in interface com.mckoi.database.sql.SQLConstants
- from_clause - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The from clause.
- from_select - Variable in class com.mckoi.database.interpret.Insert
- from_set - Variable in class com.mckoi.database.interpret.FromTableSubQuerySource
-
The fully prepared TableExpressionFromSet object that is used to qualify variables in the table.
- from_set - Variable in class com.mckoi.database.interpret.Insert
- from_set - Variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The tables we are selecting from.
- from_values - Variable in class com.mckoi.database.interpret.Insert
- fromBigDecimal(BigDecimal) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from a BigDecimal.
- fromClass(Class) - Static method in class com.mckoi.database.TType
-
Given a java class, this will return a default TType object that can encapsulate Java objects of this type.
- FromClause - Class in com.mckoi.database.interpret
-
A container for the From clause of a select statement.
- FromClause() - Constructor for class com.mckoi.database.interpret.FromClause
- FromClauseJoin(FromClause) - Method in class com.mckoi.database.sql.SQL
- fromData(byte[], int, byte) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from the given data.
- fromDouble(double) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from a double.
- fromFloat(float) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from a float.
- fromInt(int) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from an int.
- fromLong(long) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from a long.
- fromString(String) - Static method in class com.mckoi.database.global.StringObject
-
Static method that returns a StringObject from the given java.lang.String.
- fromString(String) - Static method in class com.mckoi.util.BigNumber
-
Creates a BigNumber from a string.
- fromString(String) - Method in class com.mckoi.util.StringListBucket
-
Imports from a String into this bucket.
- FromTableDef - Class in com.mckoi.database.interpret
-
Describes a single table declaration in the from clause of a table expression (SELECT).
- FromTableDef(TableSelectExpression) - Constructor for class com.mckoi.database.interpret.FromTableDef
-
A simple sub-query table definition (not aliased).
- FromTableDef(TableSelectExpression, String) - Constructor for class com.mckoi.database.interpret.FromTableDef
-
A table that is a sub-query and given an aliased name.
- FromTableDef(String) - Constructor for class com.mckoi.database.interpret.FromTableDef
-
A simple table definition (not aliased).
- FromTableDef(String, String) - Constructor for class com.mckoi.database.interpret.FromTableDef
-
Constructs the table def.
- FromTableDirectSource - Class in com.mckoi.database.interpret
-
An implementation of FromTableInterface that wraps around an TableName/AbstractDataTable object.
- FromTableDirectSource(DatabaseConnection, TableQueryDef, String, TableName, TableName) - Constructor for class com.mckoi.database.interpret.FromTableDirectSource
-
Constructs the source.
- FromTableInterface - Interface in com.mckoi.database.interpret
-
A single table resource item in a query which handles the behaviour of resolving references to columns as well as providing various base utility methods for resolving general variable names.
- FromTableSubQuerySource - Class in com.mckoi.database.interpret
-
An implementation of FromTableInterface that wraps around a TableSelectExpression object as a sub-query source.
- FromTableSubQuerySource(DatabaseConnection, String, TableSelectExpression, TableExpressionFromSet, TableName) - Constructor for class com.mckoi.database.interpret.FromTableSubQuerySource
-
Constructs the source.
- FULL_DECOMPOSITION - Static variable in interface com.mckoi.database.sql.SQLConstants
- FULL_OUTER_JOIN - Static variable in class com.mckoi.database.JoiningSet
- FULL_RANGE - Static variable in class com.mckoi.database.SelectableRange
-
The range that represents the entire range (including null).
- FULL_RANGE_NO_NULLS - Static variable in class com.mckoi.database.SelectableRange
-
The range that represents the entire range (not including null).
- full_sweep_due - Variable in class com.mckoi.database.MasterTableGarbageCollector
-
If this is true, then a full sweep of the table is due to reclaim all deleted rows from the table.
- fullPatternMatch(String, String, char) - Static method in class com.mckoi.database.PatternSearch
-
Matches a pattern against a string and returns true if it matches or false otherwise.
- fun_class_mapping - Variable in class com.mckoi.database.FunctionFactory
-
The mapping of 'fun_name' to 'fun_class' for each function that's registered with this factory.
- fun_name - Variable in class com.mckoi.database.interpret.Function
-
The name of the function.
- fun_table_def - Variable in class com.mckoi.database.FunctionTable
-
The DataTableDef object that describes the columns in this function table.
- Function - Class in com.mckoi.database.interpret
-
A handler for defining and dropping functions.
- Function - Interface in com.mckoi.database
-
Represents a function that is part of an expression to be evaluated.
- Function() - Constructor for class com.mckoi.database.interpret.Function
- Function() - Method in class com.mckoi.database.sql.SQL
- FUNCTION - Static variable in interface com.mckoi.database.sql.SQLConstants
- function_col_list - Variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The list of functions in this column set.
- function_factory_list - Variable in class com.mckoi.database.TransactionSystem
-
The list of FunctionFactory objects that handle different functions from SQL.
- function_list - Variable in class com.mckoi.database.QueryPlan.CreateFunctionsNode
-
The list of functions to create.
- function_list - Variable in class com.mckoi.database.QueryPlan.GroupNode
-
Any aggregate functions (or regular function columns) that are to be planned.
- function_lookup - Variable in class com.mckoi.database.TransactionSystem
-
The FunctionLookup object that can resolve a FunctionDef object to a Function object.
- function_resources - Variable in class com.mckoi.database.interpret.TableExpressionFromSet
-
The list of function expression resources.
- FUNCTION_TABLE_NAME - Static variable in class com.mckoi.database.FunctionTable
-
The table name given to all function tables.
- FUNCTION_TABLE_NAME - Static variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The name of the table where functions are defined.
- FunctionalSelectNode(QueryPlanNode, Expression) - Constructor for class com.mckoi.database.QueryPlan.FunctionalSelectNode
- FunctionDef - Class in com.mckoi.database
-
A definition of a function including its name and parameters.
- FunctionDef(String, Expression[]) - Constructor for class com.mckoi.database.FunctionDef
-
Constructs the FunctionDef.
- functionDefined(String) - Method in class com.mckoi.database.FunctionFactory
-
Returns true if the function name is defined in this factory.
- FunctionFactory - Class in com.mckoi.database
-
A factory that generates Function objects given a function name and a set of expression's that represent parameters.
- FunctionFactory() - Constructor for class com.mckoi.database.FunctionFactory
-
Constructs the FunctionFactory.
- FunctionFactory.FF_FunctionInfo - Class in com.mckoi.database
-
An implementation of FunctionInfo.
- FunctionIdentifier() - Method in class com.mckoi.database.sql.SQL
- FunctionInfo - Interface in com.mckoi.database
-
Meta information about a function.
- FunctionLookup - Interface in com.mckoi.database
-
An interface that resolves and generates a Function objects given a FunctionDef object.
- FunctionName() - Method in class com.mckoi.database.sql.SQL
- FunctionParams() - Method in class com.mckoi.database.sql.SQL
- FunctionTable - Class in com.mckoi.database
-
A table that has a number of columns and as many rows as the refering table.
- FunctionTable(Expression[], String[], DatabaseQueryContext) - Constructor for class com.mckoi.database.FunctionTable
- FunctionTable(Table, Expression[], String[], DatabaseQueryContext) - Constructor for class com.mckoi.database.FunctionTable
-
Constructs the FunctionTable.
- FunctionTable.TableGroupResolver - Class in com.mckoi.database
-
Group resolver.
- FunctionTable.TableGroupResolver.TableGVResolver - Class in com.mckoi.database
G
- g_op - Static variable in class com.mckoi.database.Operator
- garbage_collector - Variable in class com.mckoi.database.MasterTableDataSource
-
Manages scanning and deleting of rows marked as deleted within this data source.
- gen - Variable in class com.mckoi.database.sql.SQL.JJCalls
- GeneralFormatter - Class in com.mckoi.util
-
This class provides several static convenience functions for formatting various types of information such as a time frame.
- GeneralFormatter() - Constructor for class com.mckoi.util.GeneralFormatter
- GeneralParser - Class in com.mckoi.util
-
This class provides several static convenience functions for parsing various types of character sequences.
- GeneralParser() - Constructor for class com.mckoi.util.GeneralParser
- generatedKeyAlwaysReturned() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- generateFromSet(TableSelectExpression, DatabaseConnection) - Static method in class com.mckoi.database.interpret.Planner
-
Given a TableExpression, generates a TableExpressionFromSet object.
- generateFunction(FunctionDef) - Method in class com.mckoi.database.FunctionFactory
-
Creates a Function object for the function with the given name with the given arguments.
- generateFunction(FunctionDef) - Method in interface com.mckoi.database.FunctionLookup
-
Generate the Function given a FunctionDef object.
- generateFunction(FunctionDef) - Method in class com.mckoi.database.TransactionSystem.DSFunctionLookup
- generateParseException() - Method in class com.mckoi.database.sql.SQL
- generateResolvedVariableList() - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Returns a Variable[] array for each variable that is exposed in this from set.
- geq_op - Static variable in class com.mckoi.database.Operator
- get() - Method in class com.mckoi.store.AbstractStore.StoreArea
- get() - Method in interface com.mckoi.store.Area
- get() - Method in class com.mckoi.store.HeapStore.HeapArea
- get(byte[], int, int) - Method in class com.mckoi.store.AbstractStore.StoreArea
- get(byte[], int, int) - Method in interface com.mckoi.store.Area
- get(byte[], int, int) - Method in class com.mckoi.store.HeapStore.HeapArea
- get(byte[], int, int) - Method in class com.mckoi.util.ByteBuffer
-
Gets a byte array from the buffer.
- get(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Returns the int at the given position in the list.
- get(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Returns the int at the given position (0 first, 1 second, etc) in the list.
- get(int) - Method in class com.mckoi.util.StringListBucket
-
Returns the string at the given index of the list.
- get(int, int) - Method in class com.mckoi.database.SimpleTableQuery
-
Gets the TObject at the given cell in the table.
- get(int, int, int) - Method in class com.mckoi.database.DataCellCache
-
Gets a TObject from the cache.
- get(Object) - Method in class com.mckoi.util.Cache
-
If the cache contains the cell with the given key, this method will return the object.
- get(Object) - Method in class com.mckoi.util.HashMapList
-
Returns the list of values that are in the map under this key.
- get(String) - Static method in class com.mckoi.database.Operator
-
Returns an Operator with the given string.
- get(String) - Method in class com.mckoi.database.StatementCache
-
Gets a StatementTree for the query string if it is stored in the cache.
- get(String) - Method in class com.mckoi.util.Stats
-
Retrieves the current Object value of a stat property.
- get_total - Variable in class com.mckoi.util.Cache
- getAction() - Method in class com.mckoi.database.interpret.AlterTableAction
-
Returns the name of this action.
- getAddedRows() - Method in class com.mckoi.database.TableCommitModificationEvent
-
Returns the normalized list of all rows that were inserted or updated in this table of the transaction being committed.
- getAlias() - Method in class com.mckoi.database.interpret.FromTableDef
-
Returns the alias for this table (or null if no alias given).
- getAliasedName() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Returns the aliased table name of this sub-query or null if it is left as-is.
- getAllAreas() - Method in class com.mckoi.store.AbstractStore
-
Returns a List of Long objects that contain a complete list of all areas in the store.
- getAllAreas() - Method in class com.mckoi.store.HeapStore
- getAllAreas() - Method in interface com.mckoi.store.Store
-
Returns a complete list of pointers to all areas in the Store as Long objects sorted from lowest pointer to highest.
- getAllBlockPointers() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Returns a list of pointers to all mapped blocks.
- getAllBlocks() - Method in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
Returns the array of all MappedListBlock that are in this list.
- getAllBlocks() - Method in class com.mckoi.database.IndexStore.IndexIntegerList
-
Returns the array of all MappedListBlock that are in this list.
- getAllFunctionInfo() - Method in class com.mckoi.database.FunctionFactory
-
Returns the list of all function names that this FunctionFactory manages.
- getAllLists() - Method in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
-
Returns all the lists that have been created by calls to 'getIndex'
- getAllLists() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Returns all the lists that have been created by calls to 'getIndex'
- getAllNamesCreated() - Method in class com.mckoi.database.Transaction
-
Returns the normalized list of database object names created in this transaction.
- getAllNamesDropped() - Method in class com.mckoi.database.Transaction
-
Returns the normalized list of database object names dropped in this transaction.
- getAllTableFileNames() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the list of file names for all tables in this conglomerate.
- GetAlterTableAction() - Method in class com.mckoi.database.sql.SQL
- getArea(long) - Method in class com.mckoi.store.AbstractStore
- getArea(long) - Method in class com.mckoi.store.HeapStore
- getArea(long) - Method in interface com.mckoi.store.Store
-
Returns an object that allows for the contents of an area (represented by the 'id' parameter) to be read.
- getAreaElement(long) - Method in class com.mckoi.store.HeapStore
-
Searches the hash map and returns the area element for the given pointer.
- getAreaHeader(long, long[]) - Method in class com.mckoi.store.AbstractStore
-
Sets the 'header' array with information from the header of the given pointer.
- getAreaInputStream(long) - Method in class com.mckoi.store.AbstractStore
- getAreaInputStream(long) - Method in class com.mckoi.store.HeapStore
- getAreaInputStream(long) - Method in interface com.mckoi.store.Store
-
Returns an InputStream implementation that allows for the area with the given identifier to be read sequentially.
- getAreaSize(long) - Method in class com.mckoi.store.AbstractStore
-
Convenience for finding the size of an area.
- getAreaWriter() - Method in class com.mckoi.store.HeapStore.HeapAreaElement
-
Returns a new AreaWriter object for this element.
- getArgTypesString(TObject[]) - Static method in class com.mckoi.database.Caster
-
Get a string giving the database types of all of the arguments.
- getArray(boolean) - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Overwritten from IntArrayListBlock, this returns the int[] array that contains the contents of the block.
- getArray(boolean) - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Overwritten from IntArrayListBlock, this returns the int[] array that contains the contents of the block.
- getArray(boolean) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns the int[] array for this block.
- getArray(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getArray(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getArrayLength() - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Overwritten from IntArrayListBlock, returns the capacity of the block.
- getArrayLength() - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Overwritten from IntArrayListBlock, returns the capacity of the block.
- getArrayLength() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns the count of int's in this block.
- getAsciiStream() - Method in class com.mckoi.database.jdbc.MClob
- getAsciiStream() - Method in class com.mckoi.database.jdbc.MStreamableClob
- getAsciiStream(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getAsciiStream(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getAttributes(String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getAutoCommit() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the auto-commit status of this connection.
- getAutoCommit() - Method in class com.mckoi.database.InternalJDBCHelper.InternalConnection
-
Overwritten from MConnection - auto-commit is disabled and can not be enabled.
- getAutoCommit() - Method in class com.mckoi.database.jdbc.MConnection
- getBeginColumn() - Method in class com.mckoi.database.sql.SimpleCharStream
- getBeginLine() - Method in class com.mckoi.database.sql.SimpleCharStream
- getBestRowIdentifier(String, String, String, int, boolean) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getBigDecimal(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getBigDecimal(int, int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Deprecated.
- getBigDecimal(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getBigDecimal(String, int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Deprecated.
- getBigNumber(int) - Method in class com.mckoi.database.jdbc.MResultSet
- GetBinarySQLType() - Method in class com.mckoi.database.sql.SQL
- getBinaryStream() - Method in class com.mckoi.database.jdbc.MBlob
- getBinaryStream() - Method in class com.mckoi.database.jdbc.MStreamableBlob
- getBinaryStream(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getBinaryStream(long, long) - Method in class com.mckoi.database.jdbc.MBlob
- getBinaryStream(long, long) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- getBinaryStream(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getBlob(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getBlob(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getBlobStore() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the BlobStore for this conglomerate.
- getBlockPointer() - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Returns a pointer to the area that contains this block.
- getBlockSize() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Returns the block size that has been set on this list.
- getBlockSize() - Method in class com.mckoi.database.IndexStore
-
Returns the block size of this store.
- getBoolean(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getBoolean(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getBoolean(String) - Method in class com.mckoi.database.StatementTree
-
Gets a boolean entry from the statement tree.
- GetBooleanOperator() - Method in class com.mckoi.database.sql.SQL
- GetBooleanSQLType() - Method in class com.mckoi.database.sql.SQL
- getBuf() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ServerCommand
- getBuffer() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.MByteArrayOutputStream
- getBufferManager() - Method in class com.mckoi.database.TransactionSystem
-
Returns the LoggingBufferManager object enabling us to create no file stores in the file system.
- getByte() - Method in class com.mckoi.util.ByteBuffer
- getByte(int) - Method in class com.mckoi.database.global.ByteLongObject
-
Returns the byte at offset 'n' into the binary object.
- getByte(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getByte(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getByteArray() - Method in class com.mckoi.database.CellBufferOutputStream
-
Returns the underlying stream you should not use the stream while you have a handle on this reference.
- getByteArray() - Method in class com.mckoi.database.global.ByteLongObject
-
Returns the internal byte[] of this binary object.
- getByteBuffer() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Returns the ByteBuffer for the snapshot of this store when it was created.
- getBytes(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getBytes(long, int) - Method in class com.mckoi.database.jdbc.MBlob
- getBytes(long, int) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- getBytes(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getCachedNode(long) - Method in class com.mckoi.database.AbstractQueryContext
-
Returns a cached table or null if it isn't cached.
- getCachedNode(long) - Method in interface com.mckoi.database.QueryContext
-
Returns a cached table or null if it isn't cached.
- getCastingCost(TObject[], int[], Class[]) - Static method in class com.mckoi.database.Caster
-
Get the cost for casting the given arg types to the desired target classes.
- getCastingCost(TObject, int, Class) - Static method in class com.mckoi.database.Caster
-
Get the cost to cast an SQL type to the desired target class.
- getCastingCost(TObject, String[], Class[], Class) - Static method in class com.mckoi.database.Caster
-
Get the cost to cast to the specified target from the set of allowable primitives and object classes.
- getCatalog() - Method in class com.mckoi.database.jdbc.MConnection
- getCatalogName(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getCatalogs() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getCatalogSeparator() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getCatalogTerm() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getCellContents(int) - Method in class com.mckoi.database.RIDList
-
Gets the cell at the given row in the column of the master table.
- getCellContents(int) - Method in class com.mckoi.database.SelectableScheme
-
Obtains the given cell in the row from the table.
- getCellContents(int, int) - Method in class com.mckoi.database.CompositeTable
- getCellContents(int, int) - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.DataTable
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.DataTableFilter
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.FilterTable
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.FunctionTable
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.GTConnectionInfoDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTCurrentConnectionsDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTPrivMapDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTProductDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTSQLTypeInfoDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTStatisticsDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTTableColumnsDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.GTTableInfoDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Gets the cell contents of the cell at the given row/column.
- getCellContents(int, int) - Method in class com.mckoi.database.JoinedTable
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the cell contents of the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- getCellContents(int, int) - Method in class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- getCellContents(int, int) - Method in class com.mckoi.database.OuterTable
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in interface com.mckoi.database.RawDiagnosticTable
-
Returns the contents of the given cell in this table.
- getCellContents(int, int) - Method in class com.mckoi.database.SubsetColumnTable
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.Table
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.TableAccessState
-
Returns the cell at the given row/column coordinates in the table.
- getCellContents(int, int) - Method in interface com.mckoi.database.TableDataSource
-
Returns an object that represents the information in the given cell in the table.
- getCellContents(int, int) - Method in class com.mckoi.database.TemporaryTable
-
Returns an object that represents the information in the given cell in the table.
- getCellData(int) - Method in class com.mckoi.database.RowData
-
Returns the TObject that represents the information in the given column of the row.
- getChar() - Method in class com.mckoi.store.AbstractStore.StoreArea
- getChar() - Method in interface com.mckoi.store.Area
- getChar() - Method in class com.mckoi.store.HeapStore.HeapArea
- getChar(byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Returns the chart at the given offset of the byte array.
- getCharacterStream() - Method in class com.mckoi.database.jdbc.MClob
- getCharacterStream() - Method in class com.mckoi.database.jdbc.MStreamableClob
- getCharacterStream(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getCharacterStream(long, long) - Method in class com.mckoi.database.jdbc.MClob
- getCharacterStream(long, long) - Method in class com.mckoi.database.jdbc.MStreamableClob
- getCharacterStream(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getClassConstraint() - Method in class com.mckoi.database.DataTableColumnDef
-
If this column represents a Java Object, this returns the name of the class the objects stored in the column must be derived from.
- getClassConstraintAsClass() - Method in class com.mckoi.database.DataTableColumnDef
-
If this column represents a Java Object, this returns the class object that is the constraining class for the column.
- getClassName() - Method in class com.mckoi.database.StatementTree
-
Gets the interpreter class that services this tree.
- getClientInfo() - Method in class com.mckoi.database.jdbc.MConnection
- getClientInfo(String) - Method in class com.mckoi.database.jdbc.MConnection
- getClientInfoProperties() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getClob(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getClob(String) - Method in class com.mckoi.database.jdbc.MResultSet
- GetCollateDecomposition() - Method in class com.mckoi.database.sql.SQL
- GetCollateStrength() - Method in class com.mckoi.database.sql.SQL
- getCollator() - Method in class com.mckoi.database.TStringType
-
Returns the java.text.Collator object for this string type.
- getColumn() - Method in class com.mckoi.database.SelectableScheme
-
Returns the column this scheme is indexing in the table.
- getColumn() - Method in class com.mckoi.database.sql.SimpleCharStream
-
Deprecated.
- getColumn(int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns the ColumnDescription of the given column (first column is 0, etc).
- getColumnClassName(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getColumnCount() - Method in class com.mckoi.database.CompositeTable
- getColumnCount() - Method in class com.mckoi.database.DataTable
- getColumnCount() - Method in class com.mckoi.database.DataTableFilter
-
Returns the number of columns in the table.
- getColumnCount() - Method in class com.mckoi.database.DefaultDataTable
-
Returns the number of columns in the table.
- getColumnCount() - Method in class com.mckoi.database.FilterTable
-
Returns the number of columns in the table.
- getColumnCount() - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getColumnCount() - Method in interface com.mckoi.database.jdbc.QueryResponse
-
The number of columns in the query result.
- getColumnCount() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- getColumnCount() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Returns the column count.
- getColumnCount() - Method in class com.mckoi.database.JoinedTable
-
Returns the number of columns in the table.
- getColumnCount() - Method in class com.mckoi.database.RowData
-
Returns the number of columns (cells) in this row.
- getColumnCount() - Method in class com.mckoi.database.SubsetColumnTable
-
Returns the number of columns in the table.
- getColumnCount() - Method in class com.mckoi.database.Table
-
Returns the number of columns in the table.
- getColumnCount() - Method in class com.mckoi.jfccontrols.ResultSetTableModel
- getColumnCount() - Method in class com.mckoi.tools.ConglomerateViewPane.DTableModel
- getColumnDefAt(int) - Method in class com.mckoi.database.Table
-
Returns the DataTableColumnDef object for the given column index.
- getColumnDescription(int) - Method in interface com.mckoi.database.jdbc.QueryResponse
-
The ColumnDescription object that describes column 'n' in the result.
- getColumnDescription(int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- getColumnDisplaySize(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getColumnLabel(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getColumnList() - Method in class com.mckoi.database.interpret.ConstraintDef
-
Returns the first column list as a string array.
- getColumnList2() - Method in class com.mckoi.database.interpret.ConstraintDef
-
Returns the first column list as a string array.
- getColumnName(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getColumnName(int) - Method in class com.mckoi.database.RowData
-
Returns the name of the given column number.
- getColumnName(int) - Method in class com.mckoi.jfccontrols.ResultSetTableModel
- getColumnName(int) - Method in class com.mckoi.tools.ConglomerateViewPane.DTableModel
- getColumnNames() - Method in class com.mckoi.database.DataIndexDef
-
Returns the column names that make up this index.
- getColumnPrivileges(String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getColumns(String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getColumnScheme(int) - Method in class com.mckoi.database.GTDataSource
- getColumnScheme(int) - Method in class com.mckoi.database.GTPrivMapDataSource
- getColumnScheme(int) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- getColumnScheme(int) - Method in class com.mckoi.database.Table
-
Returns the SelectableScheme that indexes the given column in this table.
- getColumnScheme(int) - Method in interface com.mckoi.database.TableDataSource
-
Returns the SelectableScheme that we use as an index for rows in the given column of this source.
- getColumnType(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getColumnTypeName(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getCommand(int) - Method in class com.mckoi.database.MasterTableJournal
-
Returns the command of the nth entry in the journal.
- getCommand(int, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Blocks until a response from the server has been received with the given dispatch id.
- getCommandsLog() - Method in class com.mckoi.database.Database
-
Returns the log file where commands are recorded.
- getComment() - Method in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- getCommitID() - Method in class com.mckoi.database.MasterTableJournal
-
Returns the commit_id that has been set for this journal.
- getCommitID() - Method in class com.mckoi.database.Transaction
-
Returns the 'commit_id' which is the last commit that occured before this transaction was created.
- getCompactType() - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Returns the compact type of this block.
- GetComposite() - Method in class com.mckoi.database.sql.SQL
- getConcurrency() - Method in class com.mckoi.database.jdbc.MResultSet
- getConfig() - Method in class com.mckoi.database.control.DBSystem
-
Returns an immutable version of the database system configuration.
- getConfigBoolean(String, boolean) - Method in class com.mckoi.database.TransactionSystem
-
Returns a configuration value, or the default if it's not found.
- getConfigInt(String, int) - Method in class com.mckoi.database.TransactionSystem
-
Returns a configuration value, or the default if it's not found.
- getConfigString(String, String) - Method in class com.mckoi.database.TransactionSystem
-
Returns a configuration value, or the default if it's not found.
- getConglomerate() - Method in class com.mckoi.database.Database
-
Returns the conglomerate for this database.
- getConglomerate() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the conglomerate of this connection.
- getConglomerate() - Method in class com.mckoi.database.Transaction
-
Returns the TableDataConglomerate of this transaction.
- getConnection() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getConnection() - Method in class com.mckoi.database.jdbc.MStatement
- getConnection() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
-
Queries the internal state.
- getConnection(String, String) - Method in class com.mckoi.database.control.DBSystem
-
Makes a connection to the database and returns a java.sql.Connection object that can be used to execute queries on the database.
- getConnection(String, String, String) - Method in class com.mckoi.database.control.DBSystem
-
Makes a connection to the database and returns a java.sql.Connection object that can be used to execute queries on the database.
- getConnectionString() - Method in class com.mckoi.database.User
-
Returns the string that describes how this user is connected to the engine.
- getConnectionTriggerManager() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the connection trigger manager for this connection.
- getConstructor() - Method in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- getContents() - Method in class com.mckoi.database.jdbc.StreamableObjectPart
-
Returns the contents of this ResultCellPart.
- getCount() - Method in class com.mckoi.database.TriggerEvent
-
Returns the number of times this event was fired.
- getCount() - Method in class com.mckoi.util.SearchResults
-
Functions for querying information in the results.
- getCrossReference(String, String, String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getCurrentCacheSize() - Method in class com.mckoi.database.DataCellCache
-
Returns an estimation of the current cache size in bytes.
- getCurrentSchema() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the name of the schema that this connection is within.
- getCursorName() - Method in class com.mckoi.database.jdbc.MResultSet
- getDataAreaSize(JournalledResource) - Method in class com.mckoi.store.LoggingBufferManager
- getDatabase() - Method in class com.mckoi.database.CompositeTable
- getDatabase() - Method in class com.mckoi.database.control.DBSystem
-
Returns the com.mckoi.database.Database object for this control.
- getDatabase() - Method in class com.mckoi.database.DatabaseConnection.DCProcedureConnection
- getDatabase() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the Database object for this connection.
- getDatabase() - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns the Database object that this context is a child of.
- getDatabase() - Method in class com.mckoi.database.DataTableFilter
-
Returns the Database context for this filtered table.
- getDatabase() - Method in class com.mckoi.database.DefaultDataTable
-
Returns the Database object this table is part of.
- getDatabase() - Method in class com.mckoi.database.FilterTable
-
Returns the parent Database object.
- getDatabase() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Returns the Database that is the context of this interface.
- getDatabase() - Method in class com.mckoi.database.JoinedTable
-
We simply pick the first table to resolve the Database object.
- getDatabase() - Method in interface com.mckoi.database.ProcedureConnection
-
Returns the Database object for this database providing access to various general database features including backing up replication and configuration.
- getDatabase() - Method in class com.mckoi.database.Table
-
Returns the Database object that this table is derived from.
- getDatabase() - Method in class com.mckoi.database.User
-
Returns the Database object that this user belongs to.
- getDatabaseConnection() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Returns the DatabaseConnection objcet for this connection.
- getDatabaseConnection() - Method in class com.mckoi.database.TableModificationEvent
-
Returns the DatabaseConnection that this event fired in.
- getDatabaseMajorVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDatabaseMinorVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDatabasePath() - Method in class com.mckoi.database.TransactionSystem
-
Returns the path of the database in the local file system if the database exists within the local file system.
- getDatabaseProductName() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDatabaseProductVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDataCellCache() - Method in class com.mckoi.database.Database
-
Returns the system DataCellCache.
- getDataCellCache() - Method in class com.mckoi.database.TransactionSystem
-
Returns a DataCellCache object that is a shared resource between all database's running on this VM.
- getDataIndexSetDef() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the DataIndexSetDef object that represents the indexes on this table.
- getDataTableDef() - Method in class com.mckoi.database.CompositeTable
- getDataTableDef() - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- getDataTableDef() - Method in class com.mckoi.database.DataTable
-
Returns the DataTableDef object for this table.
- getDataTableDef() - Method in class com.mckoi.database.DataTableFilter
-
Returns a DataTableDef object that defines the name of the table and the layout of the columns of the table.
- getDataTableDef() - Method in class com.mckoi.database.FilterTable
-
Returns a DataTableDef object that defines the name of the table and the layout of the columns of the table.
- getDataTableDef() - Method in class com.mckoi.database.FunctionTable
-
Returns the DataTableDef object that represents the columns in this function table.
- getDataTableDef() - Method in class com.mckoi.database.GTConnectionInfoDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTCurrentConnectionsDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTPrivMapDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTProductDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTSQLTypeInfoDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTStatisticsDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTTableColumnsDataSource
- getDataTableDef() - Method in class com.mckoi.database.GTTableInfoDataSource
- getDataTableDef() - Method in class com.mckoi.database.JoinedTable
-
Returns the DataTableDef object that describes the columns in this table.
- getDataTableDef() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the DataTableDef object that represents the topology of this table data source (name, columns, etc).
- getDataTableDef() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- getDataTableDef() - Method in class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- getDataTableDef() - Method in interface com.mckoi.database.RawDiagnosticTable
-
Returns the DataTableDef object that describes the logical topology of the columns in this table.
- getDataTableDef() - Method in class com.mckoi.database.ReferenceTable
-
Returns the 'modified' DataTableDef object for this reference.
- getDataTableDef() - Method in class com.mckoi.database.SubsetColumnTable
-
Returns the DataTableDef object that describes the columns and name of this table.
- getDataTableDef() - Method in class com.mckoi.database.Table
-
Returns a DataTableDef object that defines the name of the table and the layout of the columns of the table.
- getDataTableDef() - Method in class com.mckoi.database.TableAccessState
-
Returns the DataTableDef object that contains information on the columns of the table.
- getDataTableDef() - Method in interface com.mckoi.database.TableDataSource
-
Returns a DataTableDef object that defines the layout of the table that this data is in.
- getDataTableDef() - Method in interface com.mckoi.database.TableQueryDef
-
Returns an immutable DataTableDef object that describes the columns in this table source, and the name of the table.
- getDataTableDef() - Method in class com.mckoi.database.TemporaryTable
- getDataTableDef() - Method in class com.mckoi.database.ViewDef
-
Returns the DataTableDef for this view.
- getDataTableDef(int) - Method in class com.mckoi.database.AbstractInternalTableInfo
-
Returns the DataTableDef object that describes the table at the given index in this container.
- getDataTableDef(int) - Method in class com.mckoi.database.AbstractInternalTableInfo2
- getDataTableDef(int) - Method in class com.mckoi.database.ConnectionTriggerManager.TriggerInternalTableInfo
- getDataTableDef(int) - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- getDataTableDef(int) - Method in interface com.mckoi.database.InternalTableInfo
-
Returns the DataTableDef object that describes the table at the given index in this container.
- getDataTableDef(int) - Method in class com.mckoi.database.ProcedureManager.ProcedureInternalTableInfo
- getDataTableDef(int) - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- getDataTableDef(int) - Method in class com.mckoi.database.ViewManager.ViewInternalTableInfo
- getDataTableDef(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns the DataTableDef for the table with the given name.
- getDataTableDef(TableName) - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns a DataTableDef for the given table name.
- getDataTableDef(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns the DataTableDef for the table with the given name that is visible within this transaction.
- getDate(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getDate(int, Calendar) - Method in class com.mckoi.database.jdbc.MResultSet
- getDate(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getDate(String, Calendar) - Method in class com.mckoi.database.jdbc.MResultSet
- GetDateSQLType() - Method in class com.mckoi.database.sql.SQL
- getDBInterface() - Method in class com.mckoi.database.InternalJDBCHelper.InternalConnection
-
Returns the InternalDatabaseInterface that is used in this connection.
- getDBProcedure(String, DatabaseConnection) - Method in class com.mckoi.database.Database
-
Resolves a procedure name into a DBProcedure object.
- getDBType() - Method in class com.mckoi.database.DataTableColumnDef
- getDBTypeString() - Method in class com.mckoi.database.DataTableColumnDef
-
Returns the type as a String.
- getDecomposition() - Method in class com.mckoi.database.DataTableColumnDef
- getDecomposition() - Method in class com.mckoi.database.TStringType
-
Returns the decomposition of this string type as defined in java.text.Collator.
- getDef(String) - Method in class com.mckoi.database.TableDescriptions
-
Returns the DataTableDef object for the table with the given name.
- getDefault() - Static method in class com.mckoi.database.control.DBController
-
Returns the static controller for this JVM.
- getDefaultAgent() - Static method in class com.mckoi.jfccontrols.QueryAgent
-
Returns the QueryAgent for this VM.
- getDefaultExpression(TransactionSystem) - Method in class com.mckoi.database.DataTableColumnDef
- getDefaultExpressionString() - Method in class com.mckoi.database.DataTableColumnDef
- getDefaultTransactionIsolation() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDefaultValue() - Method in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- getDefaultValue(String) - Method in class com.mckoi.database.control.AbstractDBConfig
-
Returns the default value for the configuration property with the given key.
- getDefaultValue(String) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Gets the default value for the given property value.
- getDeletedBlocks() - Method in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
Returns the array of all MappedListBlock that were deleted from this list.
- getDeletedBlocks() - Method in class com.mckoi.database.IndexStore.IndexIntegerList
-
Returns the array of all MappedListBlock that were deleted from this list.
- getDeleteList() - Method in class com.mckoi.database.StateStore
-
Returns a list of all table resources that are currently in the deleted list.
- getDeleteRule() - Method in class com.mckoi.database.interpret.ConstraintDef
-
Returns the delete rule if this is a foreign key reference.
- getDiagnosticTable(String) - Method in class com.mckoi.database.TableDataConglomerate
-
Returns a RawDiagnosticTable object that is used for diagnostics of the table with the given file name.
- getDIn(InputStream) - Static method in class com.mckoi.database.V2MasterTableDataSource
-
Convenience - wraps the given input stream around a buffered data input stream.
- getDispatcher() - Method in class com.mckoi.database.TransactionSystem
-
Returns the DatabaseDispatcher object.
- getDouble(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getDouble(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getDOut(OutputStream) - Static method in class com.mckoi.database.V2MasterTableDataSource
-
Convenience - wraps the given output stream around a buffered data output stream.
- getDriverMajorVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDriverMinorVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDriverName() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDriverVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getDynamicDataTableDef(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns the DataTableDef for a dynamic table defined in this transaction.
- getDynamicDataTableDef(TableName) - Method in class com.mckoi.database.Transaction
-
Returns the DataTableDef for the given internal table.
- getDynamicTable(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
If this transaction implementation defines dynamic tables (tables whose content is determined by some function), this should return the table here as a MutableTableDataSource object.
- getDynamicTable(TableName) - Method in class com.mckoi.database.Transaction
-
Returns an instance of MutableDataTableSource that represents the contents of the internal table with the given name.
- getDynamicTableList() - Method in class com.mckoi.database.SimpleTransaction
-
Returns a list of all dynamic table names.
- getDynamicTableList() - Method in class com.mckoi.database.Transaction
-
Returns a list of all dynamic table names.
- getDynamicTableType(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns a string type describing the type of the dynamic table.
- getDynamicTableType(TableName) - Method in class com.mckoi.database.Transaction
-
Returns a string type describing the type of the dynamic table.
- getElement(int) - Method in class com.mckoi.database.interpret.AlterTableAction
-
Returns element 'n'.
- getElement(long) - Method in class com.mckoi.store.HeapStore
-
Returns the HeapAreaElement for the given pointer.
- getElements() - Method in class com.mckoi.database.interpret.AlterTableAction
-
Returns the ArrayList that represents the parameters of this action.
- getEnd() - Method in class com.mckoi.database.SelectableRange
-
Returns the end of the range.
- getEndColumn() - Method in class com.mckoi.database.sql.SimpleCharStream
- getEndExpression() - Method in class com.mckoi.database.Expression
-
Returns the end Expression of this expression.
- getEndFlag() - Method in class com.mckoi.database.SelectableRange
-
Returns the place for the range to end (either BEFORE_FIRST_VALUE or LAST VALUE).
- getEndLine() - Method in class com.mckoi.database.sql.SimpleCharStream
- getErrorCode() - Method in exception com.mckoi.database.DatabaseConstraintViolationException
-
Returns the violation error code.
- getErrorCode() - Method in exception com.mckoi.database.DatabaseException
-
Returns the error code.
- getEvalResult() - Method in class com.mckoi.database.CorrelatedVariable
-
Returns the value this correlated variable evaluates to.
- getExportedKeys(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getExpression() - Method in class com.mckoi.database.Assignment
-
Returns the Expression for this assignment.
- getExtraNameCharacters() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getFetchDirection() - Method in class com.mckoi.database.jdbc.MResultSet
- getFetchDirection() - Method in class com.mckoi.database.jdbc.MStatement
- getFetchSize() - Method in class com.mckoi.database.jdbc.MResultSet
- getFetchSize() - Method in class com.mckoi.database.jdbc.MStatement
- getFields() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Returns the ColumnDescription array of all the columns in the result.
- getFileName() - Method in class com.mckoi.database.V1MasterTableDataSource
-
Returns the name of the file in the conglomerate that represents this store in the file system.
- getFirstCellContent(int) - Method in class com.mckoi.database.Table
-
Returns the TObject value that represents the first item in the set or null if there are no items in the column set.
- getFirstCellContent(int[]) - Method in class com.mckoi.database.Table
-
Returns the TObject value that represents the first item in the set or null if there are no items in the column set.
- getFirstTable() - Method in class com.mckoi.database.JoiningSet
-
Returns the first table in the join set.
- getFirstWaitingThread() - Method in class com.mckoi.database.WorkerPool
-
This returns the first available WorkerThread object from the thread pool.
- getFixedAreaElement() - Method in class com.mckoi.store.HeapStore
-
Returns a MutableArea object for the fixed position.
- getFloat(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getFloat(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getFloatSize(int) - Static method in class com.mckoi.database.TType
-
Get the number of bytes used by a floating type.
- getForeignKey() - Method in class com.mckoi.database.DataTableColumnDef
-
Deprecated.
- getFromExpression() - Method in class com.mckoi.database.interpret.SearchExpression
-
Returns the search expression as an Expression object.
- getFromHash(Object) - Method in class com.mckoi.util.Cache
-
Finds the node with the given key in the hash table and returns it.
- getFromSet() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Returns the TableExpressionFromSet for this sub-query.
- getFunction(QueryContext) - Method in class com.mckoi.database.FunctionDef
-
Returns a Function object from this FunctionDef.
- getFunctionColumns(String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getFunctionFactoryName() - Method in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- getFunctionFactoryName() - Method in interface com.mckoi.database.FunctionInfo
-
The name of the function factory class that this function is handled by.
- getFunctionInfo(String) - Method in class com.mckoi.database.FunctionFactory
-
Returns a FunctionInfo instance of the function with the given name that this FunctionFactory manages.
- getFunctionLookup() - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns the system FunctionLookup object.
- getFunctionLookup() - Method in interface com.mckoi.database.QueryContext
-
Returns a FunctionLookup object used to convert FunctionDef objects to Function objects when evaluating an expression.
- getFunctionLookup() - Method in class com.mckoi.database.SystemQueryContext
-
Returns the system FunctionLookup object.
- getFunctionLookup() - Method in class com.mckoi.database.TransactionSystem
-
Returns a FunctionLookup object that will search through the function factories in this database system and find and resolve a function.
- getFunctions(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getGeneratedKeys() - Method in class com.mckoi.database.jdbc.MStatement
- getGenerator(TableName) - Method in class com.mckoi.database.SequenceManager
-
Returns a SequenceGenerator object representing the sequence generator with the given name.
- getGivenTableName() - Method in class com.mckoi.database.interpret.FromTableDirectSource
-
Returns the given name of the table.
- getGrantManager() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the GrantManager object that manages grants for tables in the database for this connection/user.
- getGrantManager() - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns the GrantManager object that is used to determine grant information for the database.
- getHashSize() - Method in class com.mckoi.util.Cache
-
Deprecated.
- getHoldability() - Method in class com.mckoi.database.jdbc.MConnection
- getHoldability() - Method in class com.mckoi.database.jdbc.MResultSet
- getID() - Method in class com.mckoi.database.BlobStore.AbstractRef
- getID() - Method in interface com.mckoi.database.global.Ref
-
An id used to reference this object in the context of the database.
- getID() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Returns the unique id associated with this index store.
- getID() - Method in class com.mckoi.database.ParameterSubstitution
-
Returns the number of this parameter id.
- getID() - Method in class com.mckoi.store.AbstractStore.StoreArea
- getID() - Method in interface com.mckoi.store.Area
-
Returns the unique identifier that represents this area.
- getID() - Method in interface com.mckoi.store.AreaWriter
-
Returns the unique identifier that represents this area in the store.
- getID() - Method in class com.mckoi.store.HeapStore.HeapArea
- getID() - Method in class com.mckoi.store.HeapStore.HeapAreaElement
-
Returns the heap id for this element.
- getID() - Method in interface com.mckoi.store.JournalledResource
-
Returns a unique id for this resource.
- getID() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
-
Returns the unique id of this page.
- getID() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Returns the id of the JournalledResource that is being buffered.
- getID() - Method in class com.mckoi.store.LoggingBufferManager.BResource
-
Returns the id assigned to this resource.
- getIdentifier() - Method in class com.mckoi.database.global.StreamableObject
-
Returns an identifier that can identify this object within some context.
- getIdentifierQuoteString() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- GetImage() - Method in class com.mckoi.database.sql.SimpleCharStream
- getImportedKeys(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getIndex() - Method in class com.mckoi.util.SearchResults
- getIndex(int) - Method in interface com.mckoi.database.IndexSet
-
Returns a mutable object that implements IntegerListInterface for the given index number in this set of indices.
- getIndex(int) - Method in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
- getIndex(int) - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
- getIndexInfo(String, String, String, boolean, boolean) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getIndexNumber() - Method in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
Returns the index number of this list.
- getIndexNumber() - Method in class com.mckoi.database.IndexStore.IndexIntegerList
-
Returns the index number of this list.
- getIndexScheme() - Method in class com.mckoi.database.DataTableColumnDef
-
Returns the name of the scheme we use to index this column.
- getIndexSector() - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Returns the sector in the file of this block.
- getIndexSetForTable(MasterTableDataSource) - Method in class com.mckoi.database.SimpleTransaction
-
Returns the IndexSet for the given MasterTableDataSource object that is visible in this transaction.
- getInputStream() - Method in class com.mckoi.database.BlobStore.BlobRefImpl
- getInputStream() - Method in interface com.mckoi.database.global.BlobAccessor
-
Returns an InputStream that allows us to read the contents of the blob from start to finish.
- getInputStream() - Method in class com.mckoi.database.global.ByteLongObject
-
Returns an InputStream that allows us to read the entire byte long object.
- getInputStream() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ServerCommand
- getInputStream() - Method in class com.mckoi.store.HeapStore.HeapAreaElement
-
Returns a new InputStream that is used to read from the area.
- getInputStream() - Method in class com.mckoi.store.StreamFile
-
Returns an InputStream to the file that allows us to read from the start to the end of the file.
- getInt() - Method in class com.mckoi.store.AbstractStore.StoreArea
- getInt() - Method in interface com.mckoi.store.Area
- getInt() - Method in class com.mckoi.store.HeapStore.HeapArea
- getInt() - Method in class com.mckoi.util.ByteBuffer
- getInt(byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Returns the int at the given offset of the byte array.
- getInt(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getInt(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getInt(String) - Method in class com.mckoi.database.StatementTree
-
Gets an integer entry from the statement tree.
- getIntSize(int) - Static method in class com.mckoi.database.TType
-
Get the number of bytes used by an integer type.
- getInverseState() - Method in class com.mckoi.util.BigNumber
-
Returns the inverse of the state.
- getJavaClassTypeString() - Method in class com.mckoi.database.TJavaObjectType
-
Returns the java class type of this type.
- getJDBCConnection() - Method in class com.mckoi.database.DatabaseConnection.DCProcedureConnection
- getJDBCConnection() - Method in class com.mckoi.database.DatabaseConnection
-
Returns a java.sql.Connection object that can be used as a JDBC interface to access the current transaction of this DatabaseConnection.
- getJDBCConnection() - Method in interface com.mckoi.database.ProcedureConnection
-
Returns a JDBC Connection implementation for executing queries on this connection.
- getJDBCMajorVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getJDBCMinorVersion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getJDBCPort() - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Returns the port the JDBC server is on.
- getJoinSet() - Method in class com.mckoi.database.interpret.FromClause
-
Returns the JoiningSet object for the FROM clause.
- getJoinType(int) - Method in class com.mckoi.database.interpret.FromClause
-
Returns the type of join after table 'n' in the set of tables in the from clause.
- getJoinType(int) - Method in class com.mckoi.database.JoiningSet
-
Returns the type of join after table 'n' in the set.
- getJournal() - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- getJournal() - Method in class com.mckoi.database.GTDataSource
- getJournal() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- getJournal() - Method in interface com.mckoi.database.MutableTableDataSource
-
Returns a journal that details the changes to this data source since it was created.
- getJournalFile() - Method in class com.mckoi.store.JournalledSystem.JournalEntry
-
Returns the journal file for this entry.
- getJournalFileName(int) - Static method in class com.mckoi.store.JournalledSystem
-
Returns a journal file name with the given number.
- getJournalNumber() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Returns the journal number assigned to this journal.
- getKey() - Method in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- getLargeObject(long) - Method in class com.mckoi.database.BlobStore
-
Returns a Ref object that allows read-only access to a large object in this blob store.
- getLargeObject(long) - Method in interface com.mckoi.database.BlobStoreInterface
-
Given a large object reference identifier, generates a Ref implementation that provides access to the information in the large object.
- getLargeObjectRefFor(long) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Returns a reference object that handles the given streamable object id in this database interface.
- getLargeObjectRefFor(long, byte, long) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Returns a reference implementation object that handles an object that is either currently being pushed onto the server from the client, or is being used to reference a large object in an SQLQuery.
- getLastCellContent(int) - Method in class com.mckoi.database.Table
-
Returns the TObject value that represents the last item in the set or null if there are no items in the column set.
- getLastCellContent(int[]) - Method in class com.mckoi.database.Table
-
Returns the TObject value that represents the last item in the set or null if there are no items in the column set.
- getLastCommandTime() - Method in class com.mckoi.database.User
-
Returnst the last time a command was executed by this user.
- getLeftRowIndex(int) - Method in class com.mckoi.database.NaturallyJoinedTable
-
Given a row index between 0 and left table row count, this will return a row index into the left table's row domain.
- getLengthOfLastOutputStream() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the number of bytes that were written out by the last closed output stream returned by 'getSectorOutputStream'.
- getLine() - Method in class com.mckoi.database.sql.SimpleCharStream
-
Deprecated.
- getLocale() - Method in class com.mckoi.database.TStringType
-
Returns the locale of the string.
- getLocaleString() - Method in class com.mckoi.database.DataTableColumnDef
- getLocaleString() - Method in class com.mckoi.database.TStringType
-
Returns the locale information as a formatted string.
- getLockingMechanism() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the LockingMechanism object that is within the context of this database connection.
- getLockingMode() - Method in interface com.mckoi.database.DatabaseProcedure
-
Returns the locking mode in which the database operates.
- getLogDirectory() - Method in class com.mckoi.database.TransactionSystem
-
Returns the current log directory or null if no logging should occur.
- getLong() - Method in class com.mckoi.store.AbstractStore.StoreArea
- getLong() - Method in interface com.mckoi.store.Area
- getLong() - Method in class com.mckoi.store.HeapStore.HeapArea
- getLong(byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Returns the long at the given offset of the byte array.
- getLong(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getLong(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getMajorVersion() - Method in class com.mckoi.database.jdbc.MDriver
- getMarkedTable(String) - Method in class com.mckoi.database.AbstractQueryContext
-
Returns a table that was marked in a query plan or null if no mark was found.
- getMarkedTable(String) - Method in interface com.mckoi.database.QueryContext
-
Returns a table that was marked in a query plan or null if no mark was found.
- getMasterTable(int) - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the MasterTableDataSource in this conglomerate with the given table id.
- getMaxBinaryLiteralLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxCatalogNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxCharLiteralLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxColumnNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxColumnsInGroupBy() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxColumnsInIndex() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxColumnsInOrderBy() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxColumnsInSelect() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxColumnsInTable() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxConnections() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxCursorNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxFieldSize() - Method in class com.mckoi.database.jdbc.MStatement
- getMaximumSize() - Method in class com.mckoi.database.TBinaryType
-
Returns the maximum size of this binary type.
- getMaximumSize() - Method in class com.mckoi.database.TStringType
-
Returns the maximum size of the string (-1 is don't care).
- getMaxIndexLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxProcedureNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxRows() - Method in class com.mckoi.database.jdbc.MStatement
- getMaxRowSize() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxSchemaNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxStatementLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxStatements() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxTableNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxTablesInSelect() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMaxUserNameLength() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getMckoiConnection() - Method in class com.mckoi.database.jdbc.MConnection
-
Returns this MConnection wrapped in a MckoiConnection object.
- getMessage() - Method in exception com.mckoi.database.sql.ParseException
-
This method has the standard behavior when this object has been created using the standard constructors.
- getMessage() - Method in error com.mckoi.database.sql.TokenMgrError
-
You can also modify the body of this method to customize your error messages.
- getMetaData() - Method in class com.mckoi.database.jdbc.MConnection
- getMetaData() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- getMetaData() - Method in class com.mckoi.database.jdbc.MResultSet
- getMinorVersion() - Method in class com.mckoi.database.jdbc.MDriver
- getMoreResults() - Method in class com.mckoi.database.jdbc.MStatement
- getMoreResults(int) - Method in class com.mckoi.database.jdbc.MStatement
- getMutableArea() - Method in class com.mckoi.store.HeapStore.HeapAreaElement
-
Returns a new MutableArea object for this element.
- getMutableArea(long) - Method in class com.mckoi.store.AbstractStore
- getMutableArea(long) - Method in class com.mckoi.store.HeapStore
- getMutableArea(long) - Method in interface com.mckoi.store.Store
-
Returns an object that allows for the contents of an area (represented by the 'id' parameter) to be read and written.
- getName() - Method in class com.mckoi.database.AbstractFunction
-
Returns the name of the function.
- getName() - Method in class com.mckoi.database.Database
-
Returns the name of this database.
- getName() - Method in class com.mckoi.database.DataIndexDef
-
Returns the name of this index.
- getName() - Method in class com.mckoi.database.DataTableColumnDef
- getName() - Method in class com.mckoi.database.DataTableDef
- getName() - Method in interface com.mckoi.database.Function
-
Returns the name of the function.
- getName() - Method in class com.mckoi.database.FunctionDef
-
The name of the function.
- getName() - Method in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- getName() - Method in interface com.mckoi.database.FunctionInfo
-
The name of the function as used by the SQL grammar to reference it.
- getName() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns the name of the field.
- getName() - Method in class com.mckoi.database.interpret.FromTableDef
-
Returns the name of the table.
- getName() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the name of this table source.
- getName() - Method in class com.mckoi.database.ProcedureName
-
Returns the name of this procedure.
- getName() - Method in class com.mckoi.database.SchemaDef
-
Returns the case correct name of the schema.
- getName() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the name given to this conglomerate.
- getName() - Method in class com.mckoi.database.TableName
-
Returns the table name.
- getName() - Method in class com.mckoi.database.TriggerManager.TriggerAction
-
Returns the name of the trigger.
- getName() - Method in class com.mckoi.database.Variable
-
Returns the column name context.
- getName() - Method in class com.mckoi.store.LoggingBufferManager.BResource
-
Returns the name of this resource.
- getNCharacterStream(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getNCharacterStream(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getNClob(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getNClob(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getNetworkTimeout() - Method in class com.mckoi.database.jdbc.MConnection
- getNewColumnNames() - Method in class com.mckoi.database.QueryPlan.SubsetNode
-
Returns the list of new column names that represent the new columns in this subset.
- getNextAreaHeader(long, long[]) - Method in class com.mckoi.store.AbstractStore
-
Sets the 'header' array with information from the next header to the given pointer, and returns a pointer to the next area.
- getNextToken() - Method in class com.mckoi.database.sql.SQL
- getNextToken() - Method in class com.mckoi.database.sql.SQLTokenManager
- getNString(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getNString(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getNumericFunctions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- GetNumericOperator() - Method in class com.mckoi.database.sql.SQL
- GetNumericSQLType() - Method in class com.mckoi.database.sql.SQL
- getObject() - Method in class com.mckoi.database.TObject
-
Returns a java.lang.Object that is the data behind this object.
- getObject(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getObject(int, Class<T>) - Method in class com.mckoi.database.jdbc.MResultSet
- getObject(int, Map) - Method in class com.mckoi.database.jdbc.MResultSet
- getObject(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getObject(String) - Method in class com.mckoi.database.StatementTree
-
Gets an object entry from the statement tree.
- getObject(String, Class<T>) - Method in class com.mckoi.database.jdbc.MResultSet
- getObject(String, Map) - Method in class com.mckoi.database.jdbc.MResultSet
- getOldNewTableState() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the current state of the old/new tables.
- getOnExpression(int) - Method in class com.mckoi.database.interpret.FromClause
-
Returns the ON Expression for the type of join after table 'n' in the set.
- getOnExpression(int) - Method in class com.mckoi.database.JoiningSet
-
Returns the ON Expression for the type of join after table 'n' in the set.
- getOptimizableValue() - Method in class com.mckoi.database.interpret.Planner.ExpressionPlan
-
Returns the optimizable value for this plan.
- getOriginalColumns() - Method in class com.mckoi.database.QueryPlan.SubsetNode
-
Returns the list of original columns that represent the mappings from the columns in this subset.
- getOutputStream() - Method in class com.mckoi.store.AbstractStore.StoreAreaWriter
- getOutputStream() - Method in interface com.mckoi.store.AreaWriter
-
Returns an OutputStream that can be used to write to this area.
- getOutputStream() - Method in class com.mckoi.store.HeapStore.HeapAreaWriter
- getOutputStream() - Method in class com.mckoi.store.StreamFile
-
Opens an OutputStream to the file.
- getPageNumber() - Method in class com.mckoi.store.JournalledSystem.JournalEntry
-
Returns the page number of this modification log entry.
- getPageSize() - Method in interface com.mckoi.store.JournalledResource
-
Returns the page size.
- getPageSize() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
-
Returns the size of the page.
- getParameter(int) - Method in class com.mckoi.database.AbstractFunction
-
Returns the parameter at the given index in the parameters list.
- getParameter(int) - Method in class com.mckoi.jfccontrols.Query
-
Returns parameters number 'n' where 0 is the first parameters, etc.
- getParameterMetaData() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- getParameters() - Method in class com.mckoi.database.FunctionDef
-
The list of parameters that are passed to the function.
- getParent() - Method in class com.mckoi.database.FilterTable
-
Returns the parent table.
- getParent() - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Returns the parent of this set.
- getParentLogger() - Method in class com.mckoi.database.jdbc.MDriver
- getPath() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the path of the database.
- getPath() - Method in class com.mckoi.database.V1MasterTableDataSource
-
Returns the path of where this table is located.
- getPeriod() - Method in class com.mckoi.util.TimeFrame
-
Returns the number of milliseconds for the period of this time frame.
- getPersistantVar(String) - Method in class com.mckoi.database.Transaction
-
Returns the value of the persistent variable with the given name or null if it doesn't exist.
- getPersistentVar(String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.getPersistentVar method.
- getPlan() - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Returns the plan for this table source.
- getPointer() - Method in class com.mckoi.database.DataIndexDef
-
Returns the pointer to the index in the IndexSet.
- getPointer() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Returns the pointer to this index block in the store.
- getPosition() - Method in class com.mckoi.store.JournalledSystem.JournalEntry
-
Returns the position of the log entry in the journal file.
- getPrecision(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getPreviousAreaHeader(long, long[]) - Method in class com.mckoi.store.AbstractStore
-
Sets the 'header' array with information from the previous header to the given pointer, and returns a pointer to the previous area.
- getPrimaryKeys(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getPrivs(int, String, String, boolean, String, boolean) - Method in class com.mckoi.database.GrantManager
- getProcedureColumns(String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getProcedureManager() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the ProcedureManager object that manages database functions and procedures in the database for this connection/user.
- getProcedures(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getProcedureTerm() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getPropertyInfo(String, Properties) - Method in class com.mckoi.database.jdbc.MDriver
- getPseudoColumns(String, String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getQuery() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Returns the query string.
- getQueryLevelOffset() - Method in class com.mckoi.database.CorrelatedVariable
-
Returns the number of sub-query branches back that the reference for this variable can be found.
- getQueryPlanNode() - Method in class com.mckoi.database.Expression
-
Returns the QueryPlanNode object in this expression if it evaluates to a single QueryPlanNode, otherwise returns null.
- getQueryPlanNode() - Method in interface com.mckoi.database.TableQueryDef
-
Returns a QueryPlanNode that can be put into a plan tree and can be evaluated to find the result of the table.
- getQueryPlanNode() - Method in class com.mckoi.database.ViewDef
-
Returns the QueryPlanNode for this view.
- getQueryTimeMillis() - Method in interface com.mckoi.database.jdbc.QueryResponse
-
The time, in milliseconds, that the query took to execute.
- getQueryTimeMillis() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- getQueryTimeout() - Method in class com.mckoi.database.jdbc.MStatement
- getQueueFor(DataTable) - Method in class com.mckoi.database.LockingMechanism
-
This is a helper function for returning the LockingQueue object for the DataTable object.
- getRawColumn(int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns the column Object of the current index.
- getRawColumn(String) - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns the column Object of the name of the current index.
- getRawDiagnosticTable() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns an implementation of RawDiagnosticTable that we can use to diagnose problems with the data in this source.
- getRawSize() - Method in class com.mckoi.database.BlobStore.AbstractRef
- getRawSize() - Method in interface com.mckoi.database.global.Ref
-
The 'raw' size of this large object in bytes when it is in its byte[] form.
- getReader() - Method in class com.mckoi.database.BlobStore.ClobRefImpl
- getReader() - Method in interface com.mckoi.database.global.StringAccessor
-
Returns a Reader that allows the string to be read sequentually from start to finish.
- getReader() - Method in class com.mckoi.database.global.StringObject
-
Returns a Reader that can read from the string.
- getReadTables(DatabaseConnection) - Method in interface com.mckoi.database.DatabaseProcedure
-
This returns a DataTable[] array that lists the DataTables that are read during this procedure.
- getRecordInputStream(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns an InputStream that is used to read a record in this store with the given index.
- getRecordOutputStream() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns an OutputStream object that can be used to write data into the store.
- getRef(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getRef(long) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Returns a Ref that has been cached in this table object by its identifier value.
- getRef(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getReferenceCount() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Returns the number of references to this object.
- getReferenceRows() - Method in class com.mckoi.database.VirtualTable
-
Returns the list of IntegerVector that represents the rows that this VirtualTable references.
- getReferenceTable() - Method in class com.mckoi.database.FunctionTable
-
Returns the Table this function is based on.
- getReferenceTables() - Method in class com.mckoi.database.JoinedTable
-
Returns the list of Table objects that represent this VirtualTable.
- getRegexLibrary() - Method in class com.mckoi.database.TransactionSystem
-
Returns the regular expression library from the configuration file.
- getRemovedRows() - Method in class com.mckoi.database.TableCommitModificationEvent
-
Returns the normalized list of all rows that were deleted or updated in this table of the transaction being committed.
- getReservedLong() - Method in class com.mckoi.database.FixedRecordList
-
Returns the 8 byte long that is reserved for storing the delete chain (if there is one).
- getResolvedVariable(int) - Method in class com.mckoi.database.CompositeTable
- getResolvedVariable(int) - Method in class com.mckoi.database.DataTable
- getResolvedVariable(int) - Method in class com.mckoi.database.DataTableFilter
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.DefaultDataTable
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.FilterTable
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.JoinedTable
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.ReferenceTable
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.SubsetColumnTable
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.Table
-
Returns a fully qualified Variable object that represents the name of the column at the given index.
- getResolvedVariable(int) - Method in class com.mckoi.database.TableAccessState
-
Returns the TableName of the given column of this table.
- getResource(String) - Method in class com.mckoi.store.JournalledSystem
-
Returns the Resource with the given name.
- getResultID() - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns the 'result_id' that is used as a key to refer to the result set on the server that is the result of the query.
- getResultID() - Method in interface com.mckoi.database.jdbc.QueryResponse
-
Returns a number that identifies this query within the set of queries executed on the connection.
- getResultID() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- getResultPart(int, int, int) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Returns a part of a result set.
- getResultPart(int, int, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Requests a part of a result of a query.
- getResultPart(int, int, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- getResultPart(int, int, int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
- getResultPart(Vector, MConnection, int, int, int, int, int) - Method in class com.mckoi.database.jdbc.RowCache
-
Requests a block of parts.
- getResultSet() - Method in class com.mckoi.database.jdbc.MStatement
- getResultSet(int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Gets the result set with the given result_id.
- getResultSetConcurrency() - Method in class com.mckoi.database.jdbc.MStatement
- getResultSetHoldability() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getResultSetHoldability() - Method in class com.mckoi.database.jdbc.MStatement
- getResultSetType() - Method in class com.mckoi.database.jdbc.MStatement
- getRightRowIndex(int) - Method in class com.mckoi.database.NaturallyJoinedTable
-
Given a row index between 0 and right table row count, this will return a row index into the right table's row domain.
- getRootColumnScheme(int) - Method in class com.mckoi.database.DataTable
-
Returns the SelectableScheme for the given column.
- getRootColumnScheme(int) - Method in class com.mckoi.database.DefaultDataTable
-
Returns the SelectableScheme for the given column.
- getRootTableName() - Method in class com.mckoi.database.interpret.FromTableDirectSource
-
Returns the root name of the table.
- getRow() - Method in class com.mckoi.database.jdbc.MResultSet
- getRowCache() - Method in class com.mckoi.database.jdbc.MConnection
-
Returns the row Cache object for this connection.
- getRowCount() - Method in class com.mckoi.database.CompositeTable
- getRowCount() - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- getRowCount() - Method in class com.mckoi.database.DataTable
-
Returns the current row count.
- getRowCount() - Method in class com.mckoi.database.DataTableFilter
-
Returns the number of rows stored in the table.
- getRowCount() - Method in class com.mckoi.database.DefaultDataTable
-
Returns the number of rows stored in the table.
- getRowCount() - Method in class com.mckoi.database.FilterTable
-
Returns the number of rows stored in the table.
- getRowCount() - Method in class com.mckoi.database.GTConnectionInfoDataSource
- getRowCount() - Method in class com.mckoi.database.GTCurrentConnectionsDataSource
- getRowCount() - Method in class com.mckoi.database.GTDataSource
- getRowCount() - Method in class com.mckoi.database.GTPrivMapDataSource
- getRowCount() - Method in class com.mckoi.database.GTProductDataSource
- getRowCount() - Method in class com.mckoi.database.GTSQLTypeInfoDataSource
- getRowCount() - Method in class com.mckoi.database.GTStatisticsDataSource
- getRowCount() - Method in class com.mckoi.database.GTTableColumnsDataSource
- getRowCount() - Method in class com.mckoi.database.GTTableInfoDataSource
- getRowCount() - Method in interface com.mckoi.database.jdbc.QueryResponse
-
The total number of rows in the query result.
- getRowCount() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- getRowCount() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Returns the row count.
- getRowCount() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- getRowCount() - Method in class com.mckoi.database.NaturallyJoinedTable
- getRowCount() - Method in class com.mckoi.database.OuterTable
-
Returns the modified row count.
- getRowCount() - Method in class com.mckoi.database.SimpleTableQuery
-
Returns the total number of rows in this table.
- getRowCount() - Method in class com.mckoi.database.Table
-
Returns the number of rows stored in the table.
- getRowCount() - Method in interface com.mckoi.database.TableDataSource
-
Returns the number of rows in this data source.
- getRowCount() - Method in class com.mckoi.database.VirtualTable
-
Returns the number of rows stored in the table.
- getRowCount() - Method in class com.mckoi.jfccontrols.ResultSetTableModel
- getRowCount() - Method in class com.mckoi.tools.ConglomerateViewPane.DTableModel
- getRowData() - Method in class com.mckoi.database.TableModificationEvent
-
Returns the RowData object that represents the change that is being made to the table either by an INSERT or UPDATE.
- getRowId(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getRowId(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getRowIdLifetime() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getRowIndex() - Method in class com.mckoi.database.TableModificationEvent
-
Returns the index of the row in the table that was affected by this event or -1 if event type is INSERT.
- getRowIndex(int) - Method in class com.mckoi.database.MasterTableJournal
-
Returns the row index of the nth entry in the journal.
- getRowIndexList() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
Returns the entire row list for this table.
- getRows() - Method in class com.mckoi.database.RawTableInformation
-
Returns a IntegerVector[] list of the rows in the table that have been added.
- getScale() - Method in class com.mckoi.database.DataTableColumnDef
- getScale() - Method in class com.mckoi.database.global.ColumnDescription
-
If this is a number, returns the scale of the field.
- getScale() - Method in class com.mckoi.database.TNumericType
-
Returns the scale of the number (-1 is don't care).
- getScale() - Method in class com.mckoi.util.BigNumber
-
Returns the scale of this number, or -1 if the number has no scale (if it -inf, +inf or NaN).
- getScale(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getSchema() - Method in class com.mckoi.database.DataTable
-
Returns the schema that this table is within.
- getSchema() - Method in class com.mckoi.database.DataTableDef
- getSchema() - Method in class com.mckoi.database.jdbc.MConnection
- getSchema() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the schema name of this table source.
- getSchema() - Method in class com.mckoi.database.ProcedureName
-
Returns the schema of this procedure.
- getSchema() - Method in class com.mckoi.database.TableName
-
Returns the schema name or null if the schema name is unknown.
- getSchemaList() - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.getSchemaList method.
- getSchemaList() - Method in class com.mckoi.database.Transaction
-
Returns an array of SchemaDef objects for each schema currently setup in the database.
- getSchemaName(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getSchemas() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSchemas(String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSchemaTerm() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSearchStringEscape() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSector(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Gets the contents of the sector at the given index.
- getSector(int, byte[]) - Method in class com.mckoi.database.FixedSizeDataStore
-
Gets the contents of the sector at the given index.
- getSector(int, byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Gets the contents of the sector at the given index.
- getSectorAsIntArray(int, int[]) - Method in class com.mckoi.database.FixedSizeDataStore
-
Gets the contents of the sector at the given index as an int[] array.
- getSectorChain(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Traverses a sector chain and returns an array of all sectors that are part of the chain.
- getSectorChain(int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Traverses a sector chain and returns an array of all sectors that are part of the chain.
- getSectorInputStream(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns an InputStream implementation that is used to read a stream of information from the store.
- getSectorOfLastOutputStream() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the first sector the OutputStream returned by 'getSectorOutputStream' wrote to.
- getSectorOutputStream() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns an OutputStream implementation that is used to write a stream of information into this data store.
- getSectorSize() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the number of bytes that the user may store in a sector.
- getSectorUseCount() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the number of sectors in the store that are being used (as opposed to being deleted).
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.CompositeTable
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.DataTable
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.DataTableFilter
-
Returns a SelectableScheme for the given column in the given VirtualTable row domain.
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.DefaultDataTable
-
Returns a SelectableScheme object for the given column of the VirtualTable.
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.FilterTable
-
Returns a SelectableScheme for the given column in the given VirtualTable row domain.
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.JoinedTable
-
Returns a SelectableScheme for the given column in the given VirtualTable row domain.
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.OuterTable
-
Returns a SelectableScheme for the given column in the given VirtualTable row domain.
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.SubsetColumnTable
-
Returns a SelectableScheme for the given column in the given VirtualTable row domain.
- getSelectableSchemeFor(int, int, Table) - Method in class com.mckoi.database.Table
-
Returns a SelectableScheme for the given column in the given VirtualTable row domain.
- getSequenceManager() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the SequenceManager object for this conglomerate.
- getServerErrorMsg() - Method in exception com.mckoi.database.jdbc.MSQLException
-
Returns the error message that generated this exception.
- getServerErrorStackTrace() - Method in exception com.mckoi.database.jdbc.MSQLException
-
Returns the server side stack trace for this error.
- getShort() - Method in class com.mckoi.store.AbstractStore.StoreArea
- getShort() - Method in interface com.mckoi.store.Area
- getShort() - Method in class com.mckoi.store.HeapStore.HeapArea
- getShort() - Method in class com.mckoi.util.ByteBuffer
- getShort(byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Returns the short at the given offset of the byte array.
- getShort(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getShort(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getSingleCellContent(int) - Method in class com.mckoi.database.Table
-
If the given column contains all items of the same value, this method returns the value.
- getSingleCellContent(int[]) - Method in class com.mckoi.database.Table
-
If the given column contains all items of the same value, this method returns the value.
- getSingleRowTable() - Method in class com.mckoi.database.Database
-
Returns a static table that has a single row but no columns.
- getSingleTableSource() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Returns the single PlanTableSource for this planner.
- getSize() - Method in class com.mckoi.database.DataTableColumnDef
- getSize() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns the size of the given field.
- getSize() - Method in class com.mckoi.database.global.StreamableObject
-
Returns the size of the object stream, or -1 if the size is unknown.
- getSize() - Method in class com.mckoi.database.TNumericType
-
Returns the size of the number (-1 is don't care).
- getSize() - Method in class com.mckoi.store.IOStoreDataAccessor
- getSize() - Method in interface com.mckoi.store.JournalledResource
-
Returns the current size of this resource.
- getSize() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Returns the size of this resource.
- getSize() - Method in class com.mckoi.store.JournalledSystem.Resource
-
Returns the size of this resource.
- getSize() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- getSize() - Method in interface com.mckoi.store.StoreDataAccessor
-
Returns the current size of the underlying data area.
- getSize() - Method in class com.mckoi.util.IntegerVector
-
Returns the size of the vector.
- getSnapshotIndexSet() - Method in class com.mckoi.database.IndexSetStore
-
Returns a current snapshot of the current indexes that are committed in this store.
- getSnapshotIndexSet() - Method in class com.mckoi.database.IndexStore
-
Returns a current snapshot of the current indexes that are committed in this store.
- getSortedElements() - Method in class com.mckoi.database.RawTableInformation
-
Returns an array of RawTableElement sorted into a consistant order.
- getSource() - Method in class com.mckoi.database.TriggerEvent
-
Returns the source of this event.
- getSourceIdent() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns a string that uniquely identifies this table within the conglomerate context.
- getSourceIdent() - Method in class com.mckoi.database.V1MasterTableDataSource
- getSourceIdent() - Method in class com.mckoi.database.V2MasterTableDataSource
- getSQLKeywords() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSQLQuery() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Returns the SQLQuery that was used to produce this result.
- getSQLStateType() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSqlType(TObject) - Static method in class com.mckoi.database.Caster
-
Get the SQL type for a database argument.
- getSQLType() - Method in class com.mckoi.database.DataTableColumnDef
- getSQLType() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns a value from java.sql.Type that is the SQL type defined for this column.
- getSQLType() - Method in class com.mckoi.database.TType
-
Returns the SQL type of this.
- getSQLTypeName() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns the name (as a string) of the SQL type or null if the type is not understood.
- getSqlTypes(TObject[]) - Static method in class com.mckoi.database.Caster
-
Get the SQL types for the given database arguments.
- getSQLTypeString() - Method in class com.mckoi.database.DataTableColumnDef
-
Returns the type as a String.
- getSQLXML(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getSQLXML(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getStart() - Method in class com.mckoi.database.SelectableRange
-
Returns the start of the range.
- getStartFlag() - Method in class com.mckoi.database.SelectableRange
-
Returns the place for the range to start (either FIRST_VALUE or AFTER_LAST_VALUE)
- getState() - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Returns the state of the connection.
- getState() - Method in class com.mckoi.util.BigNumber
-
Returns the state of this number.
- getStatement() - Method in class com.mckoi.database.jdbc.MResultSet
- getStatementCache() - Method in class com.mckoi.database.DatabaseSystem
-
Returns the StatementCache that is used to cache StatementTree objects that are being queried by the database.
- getStreamableId() - Method in class com.mckoi.database.jdbc.AbstractStreamableObject
-
Returns the streamable object identifier for referencing this streamable object on the server.
- getStreamableObjectPart(int, long, long, int) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Returns a section of a large binary or character stream in a result set.
- getStreamableObjectPart(int, long, long, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Requests a part of an open StreamableObject channel.
- getStreamableObjectPart(int, long, long, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- getStreamableObjectPart(int, long, long, int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
- getStrength() - Method in class com.mckoi.database.DataTableColumnDef
- getStrength() - Method in class com.mckoi.database.TStringType
-
Returns the strength of this string type as defined in java.text.Collator.
- getString() - Method in class com.mckoi.jfccontrols.Query
-
Returns the query string.
- getString(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getString(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getStringFunctions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- GetStringOperator() - Method in class com.mckoi.database.sql.SQL
- GetStringSQLType() - Method in class com.mckoi.database.sql.SQL
- GetSubQueryBooleanOperator() - Method in class com.mckoi.database.sql.SQL
- getSubQueryForm(int) - Method in class com.mckoi.database.Operator
-
Returns the ANY or ALL form of this operator.
- getSubQueryForm(String) - Method in class com.mckoi.database.Operator
-
Same as above only it handles the type as a string.
- getSubQueryFormRepresentation() - Method in class com.mckoi.database.Operator
-
Returns the sub query representation of this operator.
- getSubsetScheme(Table, int) - Method in class com.mckoi.database.SelectableScheme
-
Asks the Scheme for a SelectableScheme abject that describes a sub-set of the set handled by this Scheme.
- getSubString(long, int) - Method in class com.mckoi.database.jdbc.MClob
- getSubString(long, int) - Method in class com.mckoi.database.jdbc.MStreamableClob
- GetSuffix(int) - Method in class com.mckoi.database.sql.SimpleCharStream
- getSuperTables(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSuperTypes(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getSystem() - Method in class com.mckoi.database.Database
-
Returns the DatabaseSystem that this Database is from.
- getSystem() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the DatabaseSystem object for this connection.
- getSystem() - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns a TransactionSystem object that is used to determine information about the transactional system.
- getSystem() - Method in class com.mckoi.database.GTDataSource
- getSystem() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the TransactionSystem for this table.
- getSystem() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- getSystem() - Method in interface com.mckoi.database.QueryContext
-
Returns a TransactionSystem object that is used to determine information about the transactional system.
- getSystem() - Method in class com.mckoi.database.SelectableScheme
-
Returns the global transaction system.
- getSystem() - Method in class com.mckoi.database.SimpleTransaction
-
Returns the TransactionSystem that this Transaction is part of.
- getSystem() - Method in class com.mckoi.database.SystemQueryContext
-
Returns a TransactionSystem object that is used to determine information about the transactional system.
- getSystem() - Method in class com.mckoi.database.Table
-
Returns the TransactionSystem object that this table is part of.
- getSystem() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the TransactionSystem that this conglomerate is part of.
- getSystem() - Method in interface com.mckoi.database.TableDataSource
-
Returns the TransactionSystem object that describes global properties about the data source that generated this object.
- getSystemFunctions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getTable() - Method in class com.mckoi.database.Lock
-
Returns the DataTable object this lock is locking
- getTable() - Method in class com.mckoi.database.LockingQueue
-
Returns the DataTable object the queue is 'attached' to.
- getTable() - Method in class com.mckoi.database.SelectableScheme
-
Returns the Table.
- getTable(int) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Returns the FromTableInterface object at the given index position in this set.
- getTable(int) - Method in class com.mckoi.database.JoiningSet
-
Returns table 'n' in the result set where table 0 is the first table in the join set.
- getTable(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns a DataTable that represents the table from the given schema, name in the database.
- getTable(TableName) - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns a DataTable from the database with the given table name.
- getTable(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns a MutableTableDataSource object that represents the table with the given name within this transaction.
- getTable(String) - Method in class com.mckoi.database.DatabaseConnection
-
Returns a DataTable that represents the table with the given name in the database from the current connection schema.
- getTableAccessState() - Method in class com.mckoi.database.Table
-
This returns an object that can only access the cells that are in this table, and has no other access to the 'Table' class's functionality.
- getTableClass() - Method in class com.mckoi.database.DataTableDef
- getTableCount() - Method in class com.mckoi.database.AbstractInternalTableInfo
-
Returns the number of internal table sources that this object is maintaining.
- getTableCount() - Method in class com.mckoi.database.AbstractInternalTableInfo2
- getTableCount() - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- getTableCount() - Method in interface com.mckoi.database.InternalTableInfo
-
Returns the number of internal table sources that this object is maintaining.
- getTableCount() - Method in class com.mckoi.database.JoiningSet
-
Returns the number of tables that are in this set.
- getTableCount() - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- getTableDataSource(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns a TableDataSource object that represents the table with the given name within this transaction.
- getTableExpression() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Returns the TableSelectExpression for this sub-query.
- getTableID() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns table_id - the unique identifier for this data source.
- getTableID() - Method in class com.mckoi.database.MasterTableJournal
-
Returns the table id of the master table this journal is for.
- getTableList() - Method in class com.mckoi.database.DatabaseConnection
-
Returns a TableName[] array that contains the list of database tables that are visible by this transaction.
- getTableList() - Method in class com.mckoi.database.SimpleTransaction
-
Returns a list of table names that are visible within this transaction.
- getTableList() - Method in class com.mckoi.database.TableDescriptions
-
Returns a list of table name's sorted in alphebetical order.
- getTableName() - Method in class com.mckoi.database.AbstractDataTable
-
Returns the fully resolved table name.
- getTableName() - Method in class com.mckoi.database.DataTableDef
- getTableName() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the TableName of this table source.
- getTableName() - Method in class com.mckoi.database.ReferenceTable
-
Filters the name of the table.
- getTableName() - Method in class com.mckoi.database.TableCommitModificationEvent
-
Returns the name of the table.
- getTableName() - Method in class com.mckoi.database.TableModificationEvent
-
Returns the name of the table of this modification.
- getTableName() - Method in class com.mckoi.database.Variable
-
Returns the TableName context.
- getTableName(int) - Method in class com.mckoi.database.AbstractInternalTableInfo
-
Returns the name of the table at the given index in this container.
- getTableName(int) - Method in class com.mckoi.database.AbstractInternalTableInfo2
- getTableName(int) - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- getTableName(int) - Method in interface com.mckoi.database.InternalTableInfo
-
Returns the name of the table at the given index in this container.
- getTableName(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- getTableName(int) - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- getTablePrivileges(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getTableQueryDef(TableName, TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns a TableQueryDef object that describes the characteristics of a table including the name (TableName), the columns (DataTableDef) and the query plan to produce the table (QueryPlanNode).
- getTables() - Method in class com.mckoi.database.RawTableInformation
-
Returns an AbstractDataTable[] array of all the tables that have been added.
- getTables(String, String, String, String[]) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getTablesConstraintAltered() - Method in class com.mckoi.database.TransactionJournal
-
Returns the list of tables id's that were constraint altered by this journal.
- getTablesCreated() - Method in class com.mckoi.database.TransactionJournal
-
Returns the list of tables id's that were created by this journal.
- getTablesDropped() - Method in class com.mckoi.database.TransactionJournal
-
Returns the list of tables id's that were dropped by this journal.
- getTableSelectExpression() - Method in class com.mckoi.database.interpret.FromTableDef
-
Returns the TableSelectExpression if this is a subquery table.
- GetTableSelectExpression() - Method in class com.mckoi.database.sql.SQL
- getTableType(int) - Method in class com.mckoi.database.AbstractInternalTableInfo
-
Returns a String that describes the type of the table at the given index.
- getTableType(int) - Method in class com.mckoi.database.AbstractInternalTableInfo2
- getTableType(int) - Method in class com.mckoi.database.ConnectionTriggerManager.TriggerInternalTableInfo
- getTableType(int) - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- getTableType(int) - Method in interface com.mckoi.database.InternalTableInfo
-
Returns a String that describes the type of the table at the given index.
- getTableType(int) - Method in class com.mckoi.database.ProcedureManager.ProcedureInternalTableInfo
- getTableType(int) - Method in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- getTableType(int) - Method in class com.mckoi.database.ViewManager.ViewInternalTableInfo
- getTableType(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns the type of the table object.
- getTableType(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns the type of the table object with the given name.
- getTableTypes() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getTime(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getTime(int, Calendar) - Method in class com.mckoi.database.jdbc.MResultSet
- getTime(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getTime(String, Calendar) - Method in class com.mckoi.database.jdbc.MResultSet
- getTimeConnected() - Method in class com.mckoi.database.User
-
Returns the time the user connected.
- getTimeDateFunctions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getTimestamp(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getTimestamp(int, Calendar) - Method in class com.mckoi.database.jdbc.MResultSet
- getTimestamp(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getTimestamp(String, Calendar) - Method in class com.mckoi.database.jdbc.MResultSet
- getToken(int) - Method in class com.mckoi.database.sql.SQL
- getTransaction() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the transaction.
- getTransaction() - Method in class com.mckoi.database.SequenceManager
-
Returns a new Transaction object for manipulating and querying the system state.
- getTransaction() - Method in class com.mckoi.database.TableCommitModificationEvent
-
Returns the Transaction that represents the view of the database when the changes to the table have been committed.
- getTransactionIsolation() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the transaction isolation level of this connection.
- getTransactionIsolation() - Method in class com.mckoi.database.jdbc.MConnection
- getTransactionIsolationAsString() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the transaction isolation level of this connection as a string.
- getTriggerManager() - Method in class com.mckoi.database.Database
-
Returns the system trigger manager.
- getTType() - Method in class com.mckoi.database.DataTableColumnDef
-
Returns the TType for this column.
- getTType() - Method in class com.mckoi.database.TObject
-
Returns the type of this object.
- GetTType() - Method in class com.mckoi.database.sql.SQL
- getTTypeForColumn(int) - Method in class com.mckoi.database.Table
-
Returns a TType object that would represent values at the given column index.
- getTTypeForColumn(Variable) - Method in class com.mckoi.database.Table
-
Returns a TType object that would represent values in the given column.
- getType() - Method in class com.mckoi.database.BlobStore.AbstractRef
- getType() - Method in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- getType() - Method in class com.mckoi.database.DataIndexDef
-
Returns a String that describes the type of index this is.
- getType() - Method in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- getType() - Method in interface com.mckoi.database.FunctionInfo
-
The type of function, either STATIC, AGGREGATE or STATE_BASED (eg.
- getType() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns an integer representing the type of the field.
- getType() - Method in interface com.mckoi.database.global.Ref
-
The type of large object that is being referenced.
- getType() - Method in class com.mckoi.database.global.StreamableObject
-
Returns the type of object this stub represents.
- getType() - Method in class com.mckoi.database.jdbc.AbstractStreamableObject
-
Returns the encoding type of this object.
- getType() - Method in class com.mckoi.database.jdbc.MResultSet
- getType() - Method in class com.mckoi.database.Lock
-
Returns the type of lock.
- getType() - Method in class com.mckoi.database.SchemaDef
-
Returns the type of this schema.
- getType() - Method in class com.mckoi.database.TableModificationEvent
-
Returns the event type.
- getType() - Method in exception com.mckoi.database.TransactionException
-
Returns the type of transaction error this is.
- getType() - Method in class com.mckoi.database.TriggerEvent
-
Returns the type of this event.
- getTypeAsString() - Method in class com.mckoi.database.Lock
-
Returns the type of the lock as a string.
- getTypeInfo() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getTypeMap() - Method in class com.mckoi.database.jdbc.MConnection
- getUDTs(String, String, String, int[]) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getUnicodeStream(int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Deprecated.
- getUnicodeStream(String) - Method in class com.mckoi.database.jdbc.MResultSet
-
Deprecated.
- getUniqueGroup() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns the unique group that this column is in.
- getUniqueKey() - Method in class com.mckoi.database.interpret.FromTableDef
-
Returns the unique key.
- getUniqueKey() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Returns the unique name of this source.
- getUniqueName() - Method in class com.mckoi.database.interpret.FromTableDirectSource
- getUniqueName() - Method in interface com.mckoi.database.interpret.FromTableInterface
-
Returns a unique name given to this table source.
- getUniqueName() - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
- getUpdateCount() - Method in class com.mckoi.database.jdbc.MStatement
- getUpdateRule() - Method in class com.mckoi.database.interpret.ConstraintDef
-
Returns the update rule if this is a foreign key reference.
- getURL() - Method in class com.mckoi.database.jdbc.MConnection
-
Returns the url string used to make this connection.
- getURL() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getURL(int) - Method in class com.mckoi.database.jdbc.MResultSet
- getURL(String) - Method in class com.mckoi.database.jdbc.MResultSet
- getUser() - Method in class com.mckoi.database.DatabaseConnection
-
Returns the User object for this connection.
- getUser() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Returns the User object for this connection.
- getUserManager() - Method in class com.mckoi.database.Database
-
Returns the system user manager.
- getUserManager() - Method in class com.mckoi.database.DatabaseSystem
-
Returns the UserManager object that handles users that are connected to the database.
- getUserName() - Method in class com.mckoi.database.DatabaseQueryContext
-
Returns the user name of the connection.
- getUserName() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getUserName() - Method in interface com.mckoi.database.QueryContext
-
Returns the user name of the connection.
- getUserName() - Method in class com.mckoi.database.SystemQueryContext
-
Returns the user name of the connection.
- getUserName() - Method in class com.mckoi.database.User
-
Returns the name of the user.
- getValue(String) - Method in class com.mckoi.database.control.AbstractDBConfig
- getValue(String) - Method in interface com.mckoi.database.control.DBConfig
-
Returns the value that was set for the configuration property with the given name.
- getValueAt(int, int) - Method in class com.mckoi.jfccontrols.ResultSetTableModel
- getValueAt(int, int) - Method in class com.mckoi.tools.ConglomerateViewPane.DTableModel
- getVar(int, int, Object) - Method in class com.mckoi.database.SimpleTableQuery
-
Assuming the table stores a key/value mapping, this returns the contents of value_column for any rows where key_column is equal to the key_value.
- getVariable() - Method in class com.mckoi.database.Assignment
-
Returns the variable for this assignment.
- getVariable() - Method in class com.mckoi.database.CorrelatedVariable
-
Returns the wrapped Variable.
- getVariable() - Method in class com.mckoi.database.Expression
-
Returns the Variable if this expression evaluates to a single variable, otherwise returns null.
- getVariableResolver() - Method in class com.mckoi.database.RowData
-
Returns a VariableResolver to use within this RowData context.
- getVariableResolver() - Method in class com.mckoi.database.Table
-
Returns a TableVariableResolver object for this table.
- getVariableResolver(int) - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
- getVariableResolver(int) - Method in interface com.mckoi.database.GroupResolver
-
Returns a VariableResolver that can be used to resolve variable in the get set of the group.
- getVars() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Returns the array of all objects that are to be used as substitutions for '?' in the query.
- getVersionColumns(String, String, String) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- getViewCache() - Method in class com.mckoi.database.ViewManager
-
Returns the local cache of ViewDef objects.
- getViewDef(HashMap, TableDataSource, int) - Static method in class com.mckoi.database.ViewManager
-
Creates a ViewDef object for the given index value in the table.
- getViewDef(HashMap, TableDataSource, TableName) - Static method in class com.mckoi.database.ViewManager
-
Creates a ViewDef object for the given view name in the table.
- getVisibleList() - Method in class com.mckoi.database.StateStore
-
Returns a list of all table resources that are currently in the visible list.
- getVisibleTable(int) - Method in class com.mckoi.database.SimpleTransaction
-
Returns a MasterTableDataSource object representing table 'n' in the set of tables visible in this transaction.
- getVisibleTableCount() - Method in class com.mckoi.database.SimpleTransaction
-
Returns the number of visible tables being managed by this transaction.
- getVisibleTables() - Method in class com.mckoi.database.SimpleTransaction
-
Returns a list of all visible tables.
- getWarnings() - Method in class com.mckoi.database.jdbc.MConnection
- getWarnings() - Method in class com.mckoi.database.jdbc.MResultSet
- getWarnings() - Method in class com.mckoi.database.jdbc.MStatement
- getWarnings() - Method in interface com.mckoi.database.jdbc.QueryResponse
-
Returns any warnings about the query.
- getWarnings() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- getWidestType(TType, TType) - Static method in class com.mckoi.database.TType
-
Assuming that the two types are numeric types, this will return the 'widest' of the two types.
- getWriteTables(DatabaseConnection) - Method in interface com.mckoi.database.DatabaseProcedure
-
Returns a DataTable[] array that lists the DataTables that are written to during this procedure.
- GLOB_EXPRESSION - Static variable in class com.mckoi.database.FunctionFactory
- GLOB_ID - Static variable in class com.mckoi.database.QueryPlan.CachePointNode
- GLOB_LIST - Static variable in class com.mckoi.database.FunctionFactory
-
Represents a function argument * for glob's such as 'count(*)'
- GLOB_LOCK - Static variable in class com.mckoi.database.QueryPlan.CachePointNode
- glob_name - Variable in class com.mckoi.database.interpret.SelectColumn
-
If the column represents a glob of columns (eg.
- globalResolveReference(int, Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Resolves the given Variable reference within the chained list of TableExpressionFromSet objects to a CorrelatedVariable.
- GLOBVARIABLE - Static variable in interface com.mckoi.database.sql.SQLConstants
- GR - Static variable in interface com.mckoi.database.sql.SQLConstants
- Grant() - Method in class com.mckoi.database.sql.SQL
- GRANT - Static variable in interface com.mckoi.database.sql.SQLConstants
- grant_manager - Variable in class com.mckoi.database.DatabaseConnection
-
The GrantManager object for this connection.
- grant_table_changed - Variable in class com.mckoi.database.GrantManager
-
Set to true if the grant table is modified in this manager.
- grantHostAccessToUser(DatabaseQueryContext, String, String, String) - Method in class com.mckoi.database.Database
-
Grants the given user access to connect to the database from the given host address.
- GrantManager - Class in com.mckoi.database
-
A class that manages the grants on a database for a given database connection and user.
- GrantManager(DatabaseConnection) - Constructor for class com.mckoi.database.GrantManager
-
Constructs the GrantManager.
- GrantManager.GrantQuery - Class in com.mckoi.database
-
Inner class that represents a grant query on a particular object, param and user name.
- GrantQuery(int, String, String, boolean, boolean) - Constructor for class com.mckoi.database.GrantManager.GrantQuery
- GreaterEqualOperator() - Constructor for class com.mckoi.database.Operator.GreaterEqualOperator
- GreaterOperator() - Constructor for class com.mckoi.database.Operator.GreaterOperator
- GreatestFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.GreatestFunction
- GREQ - Static variable in interface com.mckoi.database.sql.SQLConstants
- group - Variable in class com.mckoi.database.FunctionTable.TableGroupResolver
-
The IntegerVector that represents the group we are currently processing.
- group_by - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The list of columns to group by.
- GROUP_BY_FUNCTION_TABLE - Static variable in class com.mckoi.database.interpret.Planner
-
The name of the GROUP BY function table.
- group_links - Variable in class com.mckoi.database.FunctionTable
-
The group row links.
- group_lookup - Variable in class com.mckoi.database.FunctionTable
-
The lookup mapping for row->group_index used for grouping.
- group_max - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The group max variable or null if no group max.
- group_max_column - Variable in class com.mckoi.database.QueryPlan.GroupNode
-
The group max column.
- group_number - Variable in class com.mckoi.database.FunctionTable.TableGroupResolver
-
The current group number.
- group_resolver - Variable in class com.mckoi.database.FunctionTable
-
The TableGroupResolver for the table.
- GROUPBY - Static variable in interface com.mckoi.database.sql.SQLConstants
- GroupHelper - Class in com.mckoi.database
-
Deprecated.don't use this anymore
- GroupHelper(Table, String[]) - Constructor for class com.mckoi.database.GroupHelper
-
Deprecated.Constructs the helper.
- groupID() - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
- groupID() - Method in interface com.mckoi.database.GroupResolver
-
A number that uniquely identifies this group from all the others in the set of groups.
- GROUPMAX - Static variable in interface com.mckoi.database.sql.SQLConstants
- GroupMaxColumn() - Method in class com.mckoi.database.sql.SQL
-
NOTE: This is an extension, allows for us to specify a column to return the max value for each row representing a group.
- GroupNode(QueryPlanNode, Variable[], Variable, Expression[], String[]) - Constructor for class com.mckoi.database.QueryPlan.GroupNode
-
Groups over the given columns from the child.
- GroupNode(QueryPlanNode, Variable, Expression[], String[]) - Constructor for class com.mckoi.database.QueryPlan.GroupNode
-
Groups over the entire child (always ends in 1 result in set).
- GroupResolver - Interface in com.mckoi.database
-
Similar to VariableResolver, this method is used by grouping Functions to find information about the current group being evaluated (used for evaluating aggregate functions).
- groupRows(int) - Method in class com.mckoi.database.FunctionTable
-
Returns an IntegerVector that represents the list of all rows in the group the index is at.
- GROUPS - Static variable in interface com.mckoi.database.sql.SQLConstants
- groupSize(int) - Method in class com.mckoi.database.FunctionTable
-
The size of the group with the given number.
- groupsUserBelongsTo(DatabaseQueryContext, String) - Method in class com.mckoi.database.Database
-
Returns the list of all user groups the user belongs to.
- growListStructure() - Method in class com.mckoi.database.V2MasterTableDataSource
-
Grows the list structure to accomodate more entries.
- growParametersList(int) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Grows the parameters list to the given size.
- GTConnectionInfoDataSource - Class in com.mckoi.database
-
An implementation of MutableTableDataSource that presents the current connection information.
- GTConnectionInfoDataSource(DatabaseConnection) - Constructor for class com.mckoi.database.GTConnectionInfoDataSource
-
Constructor.
- GTCurrentConnectionsDataSource - Class in com.mckoi.database
-
An implementation of MutableTableDataSource that presents the current list of connections on the database.
- GTCurrentConnectionsDataSource(DatabaseConnection) - Constructor for class com.mckoi.database.GTCurrentConnectionsDataSource
-
Constructor.
- GTDataSource - Class in com.mckoi.database
-
A base class for a dynamically generated data source.
- GTDataSource(TransactionSystem) - Constructor for class com.mckoi.database.GTDataSource
-
Constructor.
- GTPrivMapDataSource - Class in com.mckoi.database
-
A GTDataSource that maps a Privs 11-bit set to strings that represent the priv in human understandable string.
- GTPrivMapDataSource(DatabaseConnection) - Constructor for class com.mckoi.database.GTPrivMapDataSource
-
Constructor.
- GTPrivMapDataSource.PrivMapSearch - Class in com.mckoi.database
-
A SelectableScheme that makes searching on the 'priv_bit' column a lot less painless!
- GTProductDataSource - Class in com.mckoi.database
-
An implementation of MutableTableDataSource that models information about the software.
- GTProductDataSource(Transaction) - Constructor for class com.mckoi.database.GTProductDataSource
-
Constructor.
- GTSQLTypeInfoDataSource - Class in com.mckoi.database
-
A GTDataSource that models all SQL types that are available.
- GTSQLTypeInfoDataSource(DatabaseConnection) - Constructor for class com.mckoi.database.GTSQLTypeInfoDataSource
-
Constructor.
- GTStatisticsDataSource - Class in com.mckoi.database
-
An implementation of MutableTableDataSource that presents database statistical information.
- GTStatisticsDataSource(DatabaseConnection) - Constructor for class com.mckoi.database.GTStatisticsDataSource
-
Constructor.
- GTTableColumnsDataSource - Class in com.mckoi.database
-
An implementation of MutableTableDataSource that presents information about the columns of all tables in all schema.
- GTTableColumnsDataSource(Transaction) - Constructor for class com.mckoi.database.GTTableColumnsDataSource
-
Constructor.
- GTTableInfoDataSource - Class in com.mckoi.database
-
An implementation of MutableTableDataSource that presents information about the tables in all schema.
- GTTableInfoDataSource(Transaction) - Constructor for class com.mckoi.database.GTTableInfoDataSource
-
Constructor.
H
- handleEndReached() - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
-
Private method, it is called when the end of the marked length is reached.
- handleExecuteThrowable(Throwable, SQLQuery) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Wraps a Throwable thrown by the execution of a query in DatabaseConnection with an SQLException and puts the appropriate error messages to the debug log.
- hardCheckAndReclaimRow(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Checks the given record index, and if it's possible to reclaim it then it does so here.
- hardRemoveRow(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Permanently removes a row from this table.
- hardSynch() - Method in class com.mckoi.database.FixedSizeDataStore
-
Performs a hard synchronization of this store.
- hardSynch() - Method in class com.mckoi.database.IndexStore
-
Performs a hard synchronization of this index store.
- hardSynch() - Method in class com.mckoi.database.VariableSizeDataStore
-
Hard synchronizes the data from memory into the hard copy on disk.
- has_added_table_rows - Variable in class com.mckoi.database.TransactionJournal
-
Optimization, these flags are set to true when various types of journal entries are made to the transaction journal.
- has_changed - Variable in class com.mckoi.util.IntegerListBlockInterface
-
Set to true whenever the integers of this block are changed via the mutation methods.
- has_constraint_alterations - Variable in class com.mckoi.database.TransactionJournal
-
Optimization, these flags are set to true when various types of journal entries are made to the transaction journal.
- has_created_tables - Variable in class com.mckoi.database.TransactionJournal
-
Optimization, these flags are set to true when various types of journal entries are made to the transaction journal.
- has_dropped_tables - Variable in class com.mckoi.database.TransactionJournal
-
Optimization, these flags are set to true when various types of journal entries are made to the transaction journal.
- has_join_occurred - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
If a join has occurred since the planner was constructed or copied then this is set to true.
- has_removed_table_rows - Variable in class com.mckoi.database.TransactionJournal
-
Optimization, these flags are set to true when various types of journal entries are made to the transaction journal.
- has_shutdown - Variable in class com.mckoi.database.V2MasterTableDataSource
-
Set to true when the VM has shutdown and writes should no longer be possible on the object.
- hasAggregateFunction(QueryContext) - Method in class com.mckoi.database.Expression
-
Cascades through the expression and if any aggregate functions are found returns true, otherwise returns false.
- hasChanged() - Method in class com.mckoi.util.IntegerListBlockInterface
-
Returns true if this store has been modified.
- hasDeletedSectors() - Method in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Returns true if this store has deleted items.
- hash_next - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
A reference to the next page with this hash key.
- hash_rid_difference - Variable in class com.mckoi.database.RIDList
-
The difference between each hash when the uid_list was last created or rehashed.
- hashCode() - Method in class com.mckoi.database.DataCellCache.DCCacheKey
- hashCode() - Method in class com.mckoi.database.GrantManager.GrantQuery
- hashCode() - Method in class com.mckoi.database.jdbc.RowCache.RowRef
- hashCode() - Method in class com.mckoi.database.ProcedureName
-
The hash key.
- hashCode() - Method in class com.mckoi.database.TableName
-
Hash code.
- hashCode() - Method in class com.mckoi.database.Variable
-
Hash code.
- HashMapList - Class in com.mckoi.util
-
A HashMap that maps from a source to a list of items for that source.
- HashMapList() - Constructor for class com.mckoi.util.HashMapList
-
Constructs the map.
- hasJoinOccured() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Returns true if a join has occurred ('table_list' has been modified).
- hasMoreRows() - Method in interface com.mckoi.database.RowEnumeration
-
Determines if there are any rows left in the enumeration.
- hasMoreRows() - Method in class com.mckoi.database.SimpleRowEnumeration
- hasNEWTable() - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- hasNext() - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- hasNext() - Method in interface com.mckoi.util.IntegerIterator
-
Returns true if this list iterator has more elements when traversing the list in the forward direction.
- hasOLDTable() - Method in class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- hasPendingCommand() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- hasPrevious() - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- hasPrevious() - Method in interface com.mckoi.util.IntegerIterator
-
Returns true if this list iterator has more elements when traversing the list in the reverse direction.
- hasRootsLocked() - Method in class com.mckoi.database.CompositeTable
- hasRootsLocked() - Method in class com.mckoi.database.DataTable
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRootsLocked() - Method in class com.mckoi.database.DataTableFilter
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRootsLocked() - Method in class com.mckoi.database.FilterTable
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRootsLocked() - Method in class com.mckoi.database.FunctionTable
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRootsLocked() - Method in class com.mckoi.database.JoinedTable
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRootsLocked() - Method in class com.mckoi.database.Table
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRootsLocked() - Method in class com.mckoi.database.TemporaryTable
-
Returns true if the table has its row roots locked (via the lockRoot(int) method.
- hasRowsLocked() - Method in interface com.mckoi.database.DataTableFile
-
Returns true if the file currently has all of its rows locked.
- hasShutDown() - Method in class com.mckoi.database.Database
-
Returns true if the database has shut down.
- hasShutDown() - Method in class com.mckoi.database.DatabaseSystem
-
Returns true if 'shutDown' method has been called.
- hasSubQuery() - Method in class com.mckoi.database.Expression
-
Returns true if the expression has a subquery (eg 'in ( select ...
- hasTransactionChangesPending() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns true if this table has any journal modifications that have not yet been incorporated into master index.
- hasTransactionChangesPending() - Method in class com.mckoi.database.MultiVersionTableIndices
-
Returns true if this table has any journal modifications that have not yet been incorporated into master index.
- HAVING - Static variable in interface com.mckoi.database.sql.SQLConstants
- having_clause - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The having clause.
- head_warning - Variable in class com.mckoi.database.jdbc.MConnection
-
SQL warnings for this connection.
- head_warning - Variable in class com.mckoi.database.jdbc.MResultSet
-
SQL warnings for this result set.
- head_warning - Variable in class com.mckoi.database.jdbc.MStatement
- header_area - Variable in class com.mckoi.database.StateStore
-
The header area of the state store.
- header_area - Variable in class com.mckoi.database.V2MasterTableDataSource
-
The header area itself.
- header_buf - Variable in class com.mckoi.store.AbstractStore
- header_info - Variable in class com.mckoi.store.AbstractStore
- header_info2 - Variable in class com.mckoi.store.AbstractStore
- heap_area - Variable in class com.mckoi.store.HeapStore.HeapArea
-
A pointer to the byte[] array representing the entire area.
- heap_area - Variable in class com.mckoi.store.HeapStore.HeapAreaElement
-
A byte[] array that represents the volatile heap area.
- heap_id - Variable in class com.mckoi.store.HeapStore.HeapAreaElement
-
The id of this heap area (used as the hash key).
- HeapArea(long, byte[], int, int) - Constructor for class com.mckoi.store.HeapStore.HeapArea
-
Constructor.
- HeapAreaElement(long, int) - Constructor for class com.mckoi.store.HeapStore.HeapAreaElement
-
Constructs the HeapAreaElement.
- HeapAreaWriter(long, byte[], int, int) - Constructor for class com.mckoi.store.HeapStore.HeapAreaWriter
- HeapStore - Class in com.mckoi.store
-
An implementation of the Store interface that persists information in the volatile JVM heap memory.
- HeapStore() - Constructor for class com.mckoi.store.HeapStore
-
Defaults heap size to 257 elements.
- HeapStore(int) - Constructor for class com.mckoi.store.HeapStore
-
Creates the HeapStore.
- HeapStore.HeapArea - Class in com.mckoi.store
-
An implementation of Area for a byte[] array from the heap.
- HeapStore.HeapAreaElement - Class in com.mckoi.store
-
An area allocated from the heap store represented by a volatile byte[] array.
- HeapStore.HeapAreaWriter - Class in com.mckoi.store
- HexToBinaryFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.HexToBinaryFunction
- highestSearch(TObject, IntegerVector, int, int) - Method in class com.mckoi.database.BlindSearch
-
Searches for a given TObject (ob) in the row list between the two bounds.
- host - Variable in class com.mckoi.database.jdbc.TCPStreamDatabaseInterface
-
The name of the host we are connected to.
- host_name - Variable in class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
-
The unique host name denoting the client that's connected.
- HOURS - Static variable in class com.mckoi.util.TimeFrame
-
Formatting enum.
I
- id - Variable in class com.mckoi.database.global.StreamableObject
-
The identifier that identifies this object.
- id - Variable in class com.mckoi.database.QueryPlan.CachePointNode
-
The unique identifier of this cache point.
- id - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The id value of this sequence key.
- id - Variable in class com.mckoi.store.AbstractStore.StoreArea
- id - Variable in class com.mckoi.store.HeapStore.HeapArea
-
The ID of this area.
- id - Variable in class com.mckoi.store.JournalledSystem.AbstractResource
-
The id assigned to this resource by this session.
- id - Variable in class com.mckoi.store.LoggingBufferManager.BResource
-
The id assigned to the resource.
- IDENTICAL_STRENGTH - Static variable in interface com.mckoi.database.sql.SQLConstants
- IDENTIFIER - Static variable in interface com.mckoi.database.sql.SQLConstants
- IF - Static variable in interface com.mckoi.database.sql.SQLConstants
- IfFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.IfFunction
- IGNORE - Static variable in interface com.mckoi.database.sql.SQLConstants
- ignore_case_for_identifiers - Variable in class com.mckoi.database.TransactionSystem
-
Set to true if the parser should ignore case when searching for a schema, table or column using an identifier.
- ignoreIdentifierCase() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if the parser should ignore case when searching for schema/table/column identifiers.
- image - Variable in class com.mckoi.database.sql.Token
-
The string image of the token.
- IMMEDIATE - Static variable in interface com.mckoi.database.sql.SQLConstants
- immutable - Variable in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- immutable - Variable in class com.mckoi.database.DataIndexSetDef
-
True if this object is immutable.
- immutable - Variable in class com.mckoi.database.DataTableDef
-
Set to true if this data table def is immutable.
- immutable - Variable in class com.mckoi.database.SelectableScheme
-
Set to true if this scheme is immutable (can't be changed).
- immutable - Variable in class com.mckoi.util.AbstractBlockIntegerList
-
If this is set to true, then the list is immutable (we are not permitted to insert or remove integers from the list).
- immutable() - Method in class com.mckoi.database.DataTableDef
-
Returns true if this is immutable.
- immutableCopy() - Method in class com.mckoi.database.control.AbstractDBConfig
- immutableCopy() - Method in interface com.mckoi.database.control.DBConfig
-
Makes an immutable copy of this configuration.
- implode(List, String) - Static method in class com.mckoi.util.StringUtil
-
This is the inverse of 'explode'.
- in - Variable in class com.mckoi.database.jdbc.StreamDatabaseInterface
-
The data input stream for the db protocol.
- in - Variable in class com.mckoi.tools.JDBCScriptTool
-
The Reader we are reading the script commands from.
- in - Variable in class com.mckoi.util.LengthMarkedBufferedInputStream
-
The chained InputStream that is underneath this object.
- in(Table, Table, int[], int[]) - Static method in class com.mckoi.database.INHelper
-
A multi-column version of IN.
- in(Table, Table, int, int) - Static method in class com.mckoi.database.INHelper
-
This implements the 'in' command.
- IN - Static variable in interface com.mckoi.database.sql.SQLConstants
- in_exclusive_mode - Variable in class com.mckoi.database.LockingMechanism
-
This boolean is set as soon as a Thread requests to go into 'exclusive mode'.
- in_op - Static variable in class com.mckoi.database.Operator
- inBuf - Variable in class com.mckoi.database.sql.SimpleCharStream
- increaseSize() - Method in class com.mckoi.database.FixedRecordList
-
Increases the size of the list structure so it may accomodate more record entries.
- increment - Variable in class com.mckoi.database.interpret.Sequence
- increment(String) - Method in class com.mckoi.util.Stats
-
Increments a stat property.
- INCREMENT - Static variable in interface com.mckoi.database.sql.SQLConstants
- increment_by - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The number we increment the sequence key by.
- incrementCurrentValue() - Method in class com.mckoi.database.SequenceManager.SequenceGenerator
- incrementLastValue() - Method in class com.mckoi.database.SequenceManager.SequenceGenerator
- incrementValue(long) - Method in class com.mckoi.database.SequenceManager.SequenceGenerator
- indentBuffer(int, StringBuffer) - Static method in class com.mckoi.database.QueryPlan
- index - Variable in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
-
Current index in buf.
- index - Variable in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
-
Current index in the buffer
- index - Variable in class com.mckoi.database.global.ByteLongObject.BLOBInputStream
- index - Variable in class com.mckoi.database.SimpleRowEnumeration
-
The current index.
- index - Variable in class com.mckoi.util.IntegerVector
-
The index of the last value of the array.
- INDEX - Static variable in interface com.mckoi.database.sql.SQLConstants
- INDEX_BLIST - Static variable in interface com.mckoi.database.sql.SQLConstants
- index_block_p - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
A pointer that references the area in the store.
- index_blocks - Variable in class com.mckoi.database.IndexSetStore
-
The index blocks - one for each index being stored.
- index_def - Variable in class com.mckoi.database.MasterTableDataSource
-
A DataIndexSetDef object that describes the indexes on the table.
- index_desc - Variable in class com.mckoi.database.DataTableColumnDef
-
The type of index to use on this column.
- index_header_area - Variable in class com.mckoi.database.IndexSetStore
- index_header_p - Variable in class com.mckoi.database.IndexSetStore
-
The index header area.
- index_header_p - Variable in class com.mckoi.database.V2MasterTableDataSource
-
Points to the index header area.
- index_key - Variable in class com.mckoi.database.VariableSizeDataStore
-
A buffer to store the index key.
- index_list - Variable in class com.mckoi.database.DataIndexSetDef
-
The list of indexes in the table.
- index_name - Variable in class com.mckoi.database.DataIndexDef
-
The name of this index.
- INDEX_NONE - Static variable in interface com.mckoi.database.sql.SQLConstants
- index_num - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
The index of this block in the index set.
- index_num - Variable in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
The number of the index in the store that this list represents.
- index_num - Variable in class com.mckoi.database.IndexStore.IndexIntegerList
-
The number of the index in the store that this list represents.
- index_pointer - Variable in class com.mckoi.database.DataIndexDef
-
Returns the index set pointer of this index.
- index_sector - Variable in class com.mckoi.database.IndexStore.MappedListBlock
-
The sector in the index file that this block can be found.
- INDEX_SECTOR_SIZE - Static variable in class com.mckoi.database.VariableSizeDataStore
-
The size of elements of each allocation sector.
- index_set - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The IndexSet for this mutable table source.
- index_set - Variable in class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- index_set_garbage - Variable in class com.mckoi.database.IndexStore
-
The list of SnapshotIndexSet objects that have been deleted and are ready for garbage collection.
- index_store - Variable in class com.mckoi.database.IndexStore
-
The FixedSizeDataStore that contains all the data of the index store.
- index_store - Variable in class com.mckoi.database.V1MasterTableDataSource
-
An IndexStore object that manages the indexes for this table.
- index_store - Variable in class com.mckoi.database.V2MasterTableDataSource
-
An IndexSetStore object that manages the indexes for this table.
- index_str - Variable in class com.mckoi.database.interpret.ColumnDef
- index_table_list - Variable in class com.mckoi.database.IndexStore
-
The list of table sector entries that are currently committed.
- index_table_list_buf - Variable in class com.mckoi.database.IndexStore
- index_type - Variable in class com.mckoi.database.DataIndexDef
-
The type of Index this is.
- indexAt(int) - Method in class com.mckoi.database.DataIndexSetDef
-
Returns the DataIndexDef at the given index in this list.
- IndexBlock(int, int, long) - Constructor for class com.mckoi.database.IndexSetStore.IndexBlock
-
Constructs the IndexBlock.
- IndexComparator - Interface in com.mckoi.util
-
A comparator that is used within BlockIntegerList that compares two int values which are indices to data that is being compared.
- indexCount() - Method in class com.mckoi.database.DataIndexSetDef
-
Returns the total number of index in this table.
- IndexIntegerList(int, int, IndexSetStore.MappedListBlock[]) - Constructor for class com.mckoi.database.IndexSetStore.IndexIntegerList
-
Constructs the list with the given set of blocks.
- IndexIntegerList(int, IndexStore.MappedListBlock[]) - Constructor for class com.mckoi.database.IndexStore.IndexIntegerList
-
Constructs the list with the given set of blocks.
- IndexName() - Method in class com.mckoi.database.sql.SQL
- indexOf(int) - Method in class com.mckoi.util.IntegerVector
-
Returns the first index of the given row in the array, or -1 if not found.
- indexOfPlanTableSource(Planner.PlanTableSource) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Returns the index of the given PlanTableSource in the table list.
- indexOfVar(String) - Method in class com.mckoi.util.StringListBucket
-
Returns the index of the given string in the bucket, or -1 if not found.
- IndexSet - Interface in com.mckoi.database
-
A set of list of indexes.
- IndexSetStore - Class in com.mckoi.database
-
A class that manages the storage of a set of transactional index lists in a way that is fast to modify.
- IndexSetStore(Store, TransactionSystem) - Constructor for class com.mckoi.database.IndexSetStore
-
Constructs the IndexSetStore over the given Store object.
- IndexSetStore.IndexBlock - Class in com.mckoi.database
-
Represents a single 'Index block' area in the store.
- IndexSetStore.IndexIntegerList - Class in com.mckoi.database
-
The IntegerListInterface implementation that is used to represent a mutable snapshop of the indices at a given point in time.
- IndexSetStore.MappedListBlock - Class in com.mckoi.database
-
An IntegerListBlockInterface implementation that maps a block of a list to an underlying file system representation.
- IndexSetStore.SnapshotIndexSet - Class in com.mckoi.database
-
The implementation of IndexSet which represents a mutable snapshot of the indices stored in this set.
- IndexStore - Class in com.mckoi.database
-
A class that manages the storage of a set of transactional index lists in a way that is fast to modify.
- IndexStore(File, DebugLogger) - Constructor for class com.mckoi.database.IndexStore
-
Constructs the IndexStore.
- IndexStore.IndexIntegerList - Class in com.mckoi.database
-
The IntegerListInterface implementation that is used to represent a mutable snapshop of the indices at a given point in time.
- IndexStore.MappedListBlock - Class in com.mckoi.database
-
An IntegerListBlockInterface implementation that maps a block of a list to an underlying file system representation.
- IndexStore.SnapshotIndexSet - Class in com.mckoi.database
-
The implementation of IndexSet which represents a mutable snapshot of the indices stored in this set.
- indexStringArray(String, String[]) - Method in class com.mckoi.database.Table
-
Helper function.
- indexWithName(String) - Method in class com.mckoi.database.DataIndexSetDef
-
Returns the DataIndexDef with the given name or null if it couldn't be found.
- inflater - Variable in class com.mckoi.database.DataCellSerialization
- inflater - Variable in class com.mckoi.database.VariableSizeDataStore
- INFORMATION - Static variable in class com.mckoi.debug.Debug
-
Deprecated.Some sample debug levels.
- INFORMATION - Static variable in interface com.mckoi.debug.Lvl
-
Some sample debug levels.
- INHelper - Class in com.mckoi.database
-
This is a static class that provides methods for performing the Query table command 'in' and 'not in'.
- INHelper() - Constructor for class com.mckoi.database.INHelper
- init() - Method in class com.mckoi.database.Database
-
Initializes the database.
- init() - Method in class com.mckoi.database.DatabaseConnection
-
Initializes this DatabaseConnection (possibly by initializing state from the database).
- init() - Method in class com.mckoi.database.FunctionFactory
-
Initializes this FunctionFactory.
- init() - Method in class com.mckoi.database.GTConnectionInfoDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.GTCurrentConnectionsDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.GTProductDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.GTSQLTypeInfoDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.GTStatisticsDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.GTTableColumnsDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.GTTableInfoDataSource
-
Initialize the data source.
- init() - Method in class com.mckoi.database.IndexStore
-
Initializes the IndexStore.
- init() - Method in class com.mckoi.database.InternalFunctionFactory
-
Registers the function classes with this factory.
- init(long) - Method in class com.mckoi.database.BlobStore
-
Initializes the blob store given a pointer to the blob store pointer header (the value previously returned by the 'create' method).
- init(long) - Method in class com.mckoi.database.FixedRecordList
-
Initializes the structure from the store.
- init(long) - Method in class com.mckoi.database.IndexSetStore
-
Initializes this index set.
- init(long) - Method in class com.mckoi.database.StateStore
-
Initializes the state store given a pointer to the header area in the store.
- init(DBConfig) - Method in class com.mckoi.database.DatabaseSystem
-
Inits the DatabaseSystem with the configuration properties of the system.
- init(DBConfig) - Method in class com.mckoi.database.TransactionSystem
-
Inits the TransactionSystem with the configuration properties of the system.
- init(DatabaseConnection, StatementTree, SQLQuery) - Method in class com.mckoi.database.interpret.Statement
-
Sets up internal variables for this statement for derived classes to use.
- init(Table[]) - Method in class com.mckoi.database.JoinedTable
-
Helper function for initializing the variables in the joined table.
- init(Table[]) - Method in class com.mckoi.database.VirtualTable
-
Helper function for the constructor.
- init(User, DatabaseConnection) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Initializes this database interface with a User and DatabaseConnection object.
- init(VariableResolver) - Method in class com.mckoi.database.AbstractFunction
-
The init function.
- init_lock - Variable in class com.mckoi.store.JournalledSystem
- initAgent(Connection) - Static method in class com.mckoi.jfccontrols.QueryAgent
-
Initialises the QueryAgent with the given JDBC Connection.
- initBlank() - Method in class com.mckoi.database.IndexStore
-
Initializes the index store to a blank state.
- INITIAL_BUFFER_SIZE - Static variable in class com.mckoi.util.LengthMarkedBufferedInputStream
-
The initial buffer size of the internal input buffer.
- initialised - Variable in class com.mckoi.database.Database
-
This is set to true when the 'init()' method is first called.
- initialize() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Initializes the page buffer.
- initializeBlobStore() - Method in class com.mckoi.database.TableDataConglomerate
-
Initializes the BlobStore.
- initialized - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
True if this page is initialized.
- initializeSystemTableSchema() - Method in class com.mckoi.database.TableDataConglomerate
-
Populates the system table schema with initial data for an empty conglomerate.
- initializeToEmpty() - Method in class com.mckoi.store.AbstractStore
-
Initializes the store to an empty state.
- INITIALLY - Static variable in interface com.mckoi.database.sql.SQLConstants
- INITIALLY_DEFERRED - Static variable in class com.mckoi.database.Transaction
-
The type of deferrance.
- INITIALLY_IMMEDIATE - Static variable in class com.mckoi.database.Transaction
- initTTypeInfo() - Method in class com.mckoi.database.DataTableColumnDef
-
Initializes the TType information for a column.
- INNER - Static variable in interface com.mckoi.database.sql.SQLConstants
- INNER_JOIN - Static variable in class com.mckoi.database.JoiningSet
-
Statics for Join Types.
- input - Variable in class com.mckoi.database.jdbc.AsciiReader
-
The 8-bit per character Ascii input straem.
- input - Variable in class com.mckoi.database.jdbc.BinaryToUnicodeReader
-
The wrapped InputStream.
- INPUT_BUFFER_SIZE - Static variable in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
The size in bytes of the buffer used for reading information from the input stream from the client.
- input_stream - Variable in class com.mckoi.database.sql.SQLTokenManager
- inputStream - Variable in class com.mckoi.database.sql.SimpleCharStream
- insert(int) - Method in class com.mckoi.database.BlindSearch
-
This scheme doesn't take any notice of insertions or removals.
- insert(int) - Method in class com.mckoi.database.CollatedBaseSearch
-
This scheme doesn't take any notice of insertions or removals.
- insert(int) - Method in class com.mckoi.database.InsertSearch
-
Inserts a row into the list.
- insert(int) - Method in class com.mckoi.database.SelectableScheme
-
Inserts the given element into the set.
- Insert - Class in com.mckoi.database.interpret
-
The instance class that stores all the information about an insert statement for processing.
- Insert() - Constructor for class com.mckoi.database.interpret.Insert
- Insert() - Method in class com.mckoi.database.sql.SQL
- INSERT - Static variable in class com.mckoi.database.Privileges
-
The priv to INSERT to a database object.
- INSERT - Static variable in interface com.mckoi.database.sql.SQLConstants
- INSERT - Static variable in class com.mckoi.database.TableModificationEvent
-
Event type for insert action.
- INSERT - Static variable in class com.mckoi.database.TriggerEvent
-
Statics that represent the different types of high layer trigger events.
- insert_hits_key - Variable in class com.mckoi.database.MasterTableDataSource
- insert_table - Variable in class com.mckoi.database.interpret.Insert
-
The table we are inserting stuff to.
- InsertDataList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- InsertElement() - Method in class com.mckoi.database.sql.SQL
- InsertExpressionList() - Method in class com.mckoi.database.sql.SQL
- insertIntAt(int, int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Inserts an int at the given position.
- insertIntAt(int, int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Inserts an int at the given position.
- insertIntAt(int, int) - Method in class com.mckoi.util.IntegerVector
-
Inserts an int at the given position.
- insertIntoBlock(int, int, IntegerListBlockInterface, int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Inserts a value in the given block position in the list.
- insertListBlock(int, IntegerListBlockInterface) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Inserts a ListBlock at the given block in the list of ListBlock's.
- insertRID(TObject, int) - Method in class com.mckoi.database.RIDList
-
Algorithm for inserting a new row into the rid table.
- insertRow() - Method in class com.mckoi.database.jdbc.MResultSet
- insertsAreDetected(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- InsertSearch - Class in com.mckoi.database
-
This is a SelectableScheme similar in some ways to the binary tree.
- InsertSearch(TableDataSource, int) - Constructor for class com.mckoi.database.InsertSearch
-
The Constructor.
- InsertSearch(TableDataSource, int, IntegerListInterface) - Constructor for class com.mckoi.database.InsertSearch
-
Constructor sets the scheme with a pre-sorted list.
- InsertSearch(TableDataSource, int, IntegerVector) - Constructor for class com.mckoi.database.InsertSearch
-
Constructor sets the scheme with a pre-sorted list.
- InsertSearch(TableDataSource, InsertSearch, boolean) - Constructor for class com.mckoi.database.InsertSearch
-
Constructs this as a copy of the given, either mutable or immutable copy.
- insertSort(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Inserts plain 'int' values into the list in sorted order.
- insertSort(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Inserts plain 'int' values into the list in sorted order.
- insertSort(Object, int, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Inserts the key/index pair into the list at the correct sorted position (determine by the IndexComparator).
- insertSort(Object, int, IndexComparator) - Method in interface com.mckoi.util.IntegerListInterface
-
Inserts the key/index pair into the list at the correct sorted position (determine by the IndexComparator).
- INT - Static variable in interface com.mckoi.database.sql.SQLConstants
- IntArrayListBlock() - Constructor for class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Blank protected constructor.
- IntArrayListBlock(int) - Constructor for class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Constructs the block to a specific size.
- intAt(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns the int at the given position in the array.
- intAt(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Returns the int at the given position in the array.
- intAt(int) - Method in class com.mckoi.util.IntegerVector
-
Returns the Int at the given position.
- intClasses - Static variable in class com.mckoi.database.Caster
- INTEGER - Static variable in interface com.mckoi.database.global.SQLTypes
- INTEGER - Static variable in interface com.mckoi.database.sql.SQLConstants
- integer_lists - Variable in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
-
The list of IndexIntegerList objects that have been returned via the 'getIndex(n)' method.
- integer_lists - Variable in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
The list of IndexIntegerList objects that have been returned via the 'getIndex(n)' method.
- IntegerIterator - Interface in com.mckoi.util
-
An iterator for a list of integer's.
- IntegerListBlockInterface - Class in com.mckoi.util
-
A block of an AbstractBlockIntegerList.
- IntegerListBlockInterface() - Constructor for class com.mckoi.util.IntegerListBlockInterface
- IntegerListInterface - Interface in com.mckoi.util
-
An interface for querying and accessing a list of primitive integers.
- IntegerStat() - Constructor for class com.mckoi.util.Stats.IntegerStat
- IntegerVector - Class in com.mckoi.util
-
Similar to the Vector class, except this can only store integer values.
- IntegerVector() - Constructor for class com.mckoi.util.IntegerVector
-
The Constructors.
- IntegerVector(int) - Constructor for class com.mckoi.util.IntegerVector
- IntegerVector(IntegerListInterface) - Constructor for class com.mckoi.util.IntegerVector
- IntegerVector(IntegerVector) - Constructor for class com.mckoi.util.IntegerVector
- internal_counter - Variable in class com.mckoi.database.control.DBSystem
-
An internal counter for internal connections created on this system.
- internal_db_interface - Variable in class com.mckoi.database.InternalJDBCHelper.InternalConnection
-
The DatabaseInterface for this connection.
- INTERNAL_DEF_LIST - Static variable in class com.mckoi.database.DatabaseConnection
-
A list of DataTableDef system table definitions for tables internal to the database connection.
- INTERNAL_DEF_LIST - Static variable in class com.mckoi.database.Transaction
-
A list of DataTableDef system table definitions for tables internal to the transaction.
- internal_name - Variable in class com.mckoi.database.interpret.SelectColumn
-
The name of this column used internally to reference it.
- INTERNAL_SECURE_USERNAME - Static variable in class com.mckoi.database.Database
-
The username of the internal secure user.
- internal_system_user - Variable in class com.mckoi.database.Database
-
An internal secure User that is given full grant access to the entire database.
- internal_tables - Variable in class com.mckoi.database.Transaction
-
The list of InternalTableInfo objects that are containers for generating internal tables (GTDataSource).
- internal_tables_i - Variable in class com.mckoi.database.Transaction
-
A pointer in the internal_tables list.
- internalAddRow(RowData) - Method in class com.mckoi.database.MasterTableDataSource
-
Adds a new row to this table and returns an index that is used to reference this row by the 'getCellContents' method.
- internalAddRow(RowData) - Method in class com.mckoi.database.V1MasterTableDataSource
- internalAddRow(RowData) - Method in class com.mckoi.database.V2MasterTableDataSource
- internalClose() - Method in class com.mckoi.database.jdbc.MConnection
-
Closes this connection by calling the 'dispose' method in the database interface.
- internalClose() - Method in class com.mckoi.store.AbstractStore
-
Internally closes the backing area.
- internalClose() - Method in class com.mckoi.store.JournalledFileStore
-
Internally closes the backing area.
- InternalConnection(DatabaseConnection, InternalJDBCHelper.InternalDatabaseInterface, int, int) - Constructor for class com.mckoi.database.InternalJDBCHelper.InternalConnection
-
Constructs the internal java.sql.Connection.
- internalCreateUser(DatabaseQueryContext, String, String, Expression[], String) - Method in class com.mckoi.database.interpret.UserManager
-
Private method that creates a new user.
- InternalDatabaseInterface(User, DatabaseConnection) - Constructor for class com.mckoi.database.InternalJDBCHelper.InternalDatabaseInterface
-
Constructor.
- internalDeleteRow(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Removes the row at the given index so that any resources associated with the row may be immediately available to be recycled.
- internalDeleteRow(int) - Method in class com.mckoi.database.V1MasterTableDataSource
- internalDeleteRow(int) - Method in class com.mckoi.database.V2MasterTableDataSource
- internalDispose() - Method in class com.mckoi.database.control.DBSystem
-
Disposes of all the resources associated with this system.
- internalDispose() - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Disposes all resources associated with this object.
- InternalFunctionFactory - Class in com.mckoi.database
-
A FunctionFactory for all internal SQL functions (including aggregate, mathematical, string functions).
- InternalFunctionFactory() - Constructor for class com.mckoi.database.InternalFunctionFactory
- InternalFunctionFactory.AbsFunction - Class in com.mckoi.database
- InternalFunctionFactory.AggOrFunction - Class in com.mckoi.database
- InternalFunctionFactory.AvgFunction - Class in com.mckoi.database
- InternalFunctionFactory.BinaryToHexFunction - Class in com.mckoi.database
- InternalFunctionFactory.CoalesceFunction - Class in com.mckoi.database
- InternalFunctionFactory.ConcatFunction - Class in com.mckoi.database
- InternalFunctionFactory.CountFunction - Class in com.mckoi.database
- InternalFunctionFactory.CurrValFunction - Class in com.mckoi.database
- InternalFunctionFactory.DateFormatFunction - Class in com.mckoi.database
- InternalFunctionFactory.DateObFunction - Class in com.mckoi.database
- InternalFunctionFactory.DistinctCountFunction - Class in com.mckoi.database
- InternalFunctionFactory.ForeignRuleConvert - Class in com.mckoi.database
- InternalFunctionFactory.GreatestFunction - Class in com.mckoi.database
- InternalFunctionFactory.HexToBinaryFunction - Class in com.mckoi.database
- InternalFunctionFactory.IfFunction - Class in com.mckoi.database
- InternalFunctionFactory.JavaObjectInstantiation - Class in com.mckoi.database
- InternalFunctionFactory.JavaObjectInstantiation2 - Class in com.mckoi.database
- InternalFunctionFactory.LeastFunction - Class in com.mckoi.database
- InternalFunctionFactory.LengthFunction - Class in com.mckoi.database
- InternalFunctionFactory.LowerFunction - Class in com.mckoi.database
- InternalFunctionFactory.LTrimFunction - Class in com.mckoi.database
- InternalFunctionFactory.MaxFunction - Class in com.mckoi.database
- InternalFunctionFactory.MinFunction - Class in com.mckoi.database
- InternalFunctionFactory.ModFunction - Class in com.mckoi.database
- InternalFunctionFactory.NextValFunction - Class in com.mckoi.database
- InternalFunctionFactory.PowFunction - Class in com.mckoi.database
- InternalFunctionFactory.PrivGroupsFunction - Class in com.mckoi.database
- InternalFunctionFactory.PrivilegeString - Class in com.mckoi.database
- InternalFunctionFactory.RoundFunction - Class in com.mckoi.database
- InternalFunctionFactory.RTrimFunction - Class in com.mckoi.database
- InternalFunctionFactory.SetValFunction - Class in com.mckoi.database
- InternalFunctionFactory.SignFunction - Class in com.mckoi.database
- InternalFunctionFactory.SQLCastFunction - Class in com.mckoi.database
- InternalFunctionFactory.SQLTrimFunction - Class in com.mckoi.database
- InternalFunctionFactory.SQLTypeString - Class in com.mckoi.database
- InternalFunctionFactory.SqrtFunction - Class in com.mckoi.database
- InternalFunctionFactory.SubstringFunction - Class in com.mckoi.database
- InternalFunctionFactory.SumFunction - Class in com.mckoi.database
- InternalFunctionFactory.TimeObFunction - Class in com.mckoi.database
- InternalFunctionFactory.TimeStampObFunction - Class in com.mckoi.database
- InternalFunctionFactory.ToNumberFunction - Class in com.mckoi.database
- InternalFunctionFactory.UniqueKeyFunction - Class in com.mckoi.database
- InternalFunctionFactory.UpperFunction - Class in com.mckoi.database
- InternalFunctionFactory.UserFunction - Class in com.mckoi.database
- InternalFunctionFactory.ViewDataConvert - Class in com.mckoi.database
- internalGetCellContents(int, int) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the cell contents of the given cell in the table.
- internalGetCellContents(int, int) - Method in class com.mckoi.database.V1MasterTableDataSource
- internalGetCellContents(int, int) - Method in class com.mckoi.database.V2MasterTableDataSource
- InternalJDBCHelper - Class in com.mckoi.database
-
Helper and convenience methods and classes for creating a JDBC interface that has direct access to an open transaction of a DatabaseConnection.
- InternalJDBCHelper() - Constructor for class com.mckoi.database.InternalJDBCHelper
- InternalJDBCHelper.InternalConnection - Class in com.mckoi.database
-
A derived java.sql.Connection class from MConnection.
- InternalJDBCHelper.InternalDatabaseInterface - Class in com.mckoi.database
-
An implementation of DatabaseInterface used to execute queries on the DatabaseConnection and return results to the JDBC client.
- internalOpen(boolean) - Method in class com.mckoi.store.AbstractStore
-
Internally opens the backing area.
- internalOpen(boolean) - Method in class com.mckoi.store.JournalledFileStore
-
Internally opens the backing area.
- internalOrderIndexSet(IntegerVector) - Method in class com.mckoi.database.SelectableScheme
-
Returns a BlockIntegerList that represents the given row_set sorted in the order of this scheme.
- internalPurgeCache() - Method in class com.mckoi.database.TableBackedCache
-
Internal method which copies the 'added' and 'removed' row lists and calls the 'purgeCacheOfInvalidatedEntries' method.
- internalResultSet() - Method in class com.mckoi.database.jdbc.MStatement
-
Returns the single ResultSet object for this statement.
- internalResultSetList(int) - Method in class com.mckoi.database.jdbc.MStatement
-
Returns an array of ResultSet objects of the give length for this statement.
- internalSet(int, Object) - Method in class com.mckoi.jfccontrols.Query
-
Sets a parameter.
- internalSetPrivs(Privileges, int, String, String, boolean, String) - Method in class com.mckoi.database.GrantManager
-
Internal method that sets the privs for the given object, param, grantee, grant option and granter.
- internalSetUserGroupsAndLock(DatabaseQueryContext, String, Expression[], String) - Method in class com.mckoi.database.interpret.UserManager
-
Private method that sets the user groups and lock status.
- internalSystemUser() - Method in class com.mckoi.database.Database
-
Returns the internal system user for this database.
- InternalTableInfo - Interface in com.mckoi.database
-
A class that acts as a container for any system tables that are generated from information inside the database engine.
- internalWrite(PrintWriter, int, String, String) - Static method in class com.mckoi.debug.Debug
-
Deprecated.Internal method that writes out the given information on the output stream provided.
- internalWrite(PrintWriter, int, String, String) - Method in class com.mckoi.debug.DefaultDebugLogger
-
Internal method that writes out the given information on the output stream provided.
- intersect(Operator, TObject) - Method in class com.mckoi.database.SelectableRangeSet
-
Intersects this range with the given Operator and value constraint.
- INTERSECT - Static variable in class com.mckoi.database.CompositeTable
-
The composite function for finding the interestion of the tables.
- INTERSECT - Static variable in interface com.mckoi.database.sql.SQLConstants
- intersectRange(SelectableRange, Operator, TObject, boolean) - Static method in class com.mckoi.database.SelectableRangeSet
-
Intersects the given SelectableRange object with the given Operator and value constraint.
- INTO - Static variable in interface com.mckoi.database.sql.SQLConstants
- intPrims - Static variable in class com.mckoi.database.Caster
- intVal(int) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of numeric type that represents the given int value.
- intValue() - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns this ResultSet as an 'int' value.
- intValue() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as an int.
- INVALID_LEXICAL_STATE - Static variable in error com.mckoi.database.sql.TokenMgrError
-
Tried to change to an invalid lexical state.
- invalidateGrantCache() - Method in class com.mckoi.database.GrantManager
-
Flushes any grant information that's being cached.
- invalidateTriggerList() - Method in class com.mckoi.database.ConnectionTriggerManager
-
Invalidates the trigger list causing the list to rebuild when a potential triggering event next occurs.
- invalidateViewCache() - Method in class com.mckoi.database.ViewManager
-
Invalidates the view cache.
- inverse() - Method in class com.mckoi.database.Operator
-
Returns the inverse operator of this operator.
- invoke(ProcedureConnection, String) - Static method in class com.mckoi.database.procedure.SystemBackup
-
The stored procedure invokation method.
- invokeJavaV1Procedure(ProcedureName, String, TType, TType[], String, TObject[]) - Method in class com.mckoi.database.ProcedureManager
-
Invokes a Java (type 1) procedure.
- invokeProcedure(ProcedureName, TObject[]) - Method in class com.mckoi.database.ProcedureManager
-
Invokes the procedure with the given name and the given parameters and returns the procedure return value.
- IOStoreDataAccessor - Class in com.mckoi.store
-
An implementation of StoreDataAccessor that uses the standard Java IO API to access data in some underlying file in the filesystem.
- IOStoreDataAccessor(File) - Constructor for class com.mckoi.store.IOStoreDataAccessor
-
Constructor.
- is(String) - Method in class com.mckoi.database.Operator
-
Returns true if this operator is equal to the operator string.
- IS - Static variable in interface com.mckoi.database.sql.SQLConstants
- is_aggregate - Variable in class com.mckoi.database.AbstractFunction
-
Set to true if this is an aggregate function (requires a group).
- is_built - Variable in class com.mckoi.database.RIDList
-
Set to true if this list has been fully built.
- is_closed - Variable in class com.mckoi.database.jdbc.MConnection
-
Set to true if the connection is closed.
- is_closed - Variable in class com.mckoi.database.jdbcserver.TCPJDBCServerConnection
-
Is set to true when the connection to the client is closed.
- is_closed - Variable in class com.mckoi.database.MasterTableDataSource
-
True if this table source is closed.
- is_composite_all - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
If this is an ALL composite (no removal of duplicate rows) it is true.
- is_executing_commands - Variable in class com.mckoi.database.WorkerPool
-
If this is set to false, then no commands will be executed by the 'execute' method.
- is_null - Variable in class com.mckoi.database.DataCellSerialization
-
Set to true if null.
- is_op - Static variable in class com.mckoi.database.Operator
- is_open - Variable in class com.mckoi.store.IOStoreDataAccessor
-
True if the file is open.
- is_open - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
True when open.
- is_pending_command - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- is_ping_client - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- is_processing_request - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- is_updated - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Set to true when this source has been updated from when it was constructed or copied.
- isAddCommand(byte) - Static method in class com.mckoi.database.MasterTableJournal
-
Returns true if the given command is an addition command.
- isAfter() - Method in class com.mckoi.database.TableModificationEvent
-
Returns true if this is a AFTER event.
- isAfterLast() - Method in class com.mckoi.database.jdbc.MResultSet
- isAggregate(FunctionDef) - Method in class com.mckoi.database.FunctionFactory
-
Returns true if the function defined by FunctionDef is an aggregate function, or false otherwise.
- isAggregate(FunctionDef) - Method in interface com.mckoi.database.FunctionLookup
-
Returns true if the function defined by FunctionDef is an aggregate function, or false otherwise.
- isAggregate(FunctionDef) - Method in class com.mckoi.database.TransactionSystem.DSFunctionLookup
- isAggregate(QueryContext) - Method in class com.mckoi.database.AbstractFunction
-
Returns whether the function is an aggregate function or not.
- isAggregate(QueryContext) - Method in interface com.mckoi.database.Function
-
Returns true if this function is an aggregate function.
- isAggregate(QueryContext) - Method in class com.mckoi.database.FunctionDef
-
Returns true if this function is an aggregate, or the parameters are aggregates.
- isAutoIncrement(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isBefore() - Method in class com.mckoi.database.TableModificationEvent
-
Returns true if this is a BEFORE event.
- isBeforeFirst() - Method in class com.mckoi.database.jdbc.MResultSet
- isBlocked() - Method in class com.mckoi.jfccontrols.SwingBlockUtil
-
Returns true if the event dispatcher is blocked.
- isBooted() - Method in interface com.mckoi.database.jdbc.LocalBootable
-
Returns true if there is a database currently booted in the current JVM.
- isBooted() - Method in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
Returns true if a database has successfully been booted in this JVM.
- isBuilt() - Method in class com.mckoi.database.RIDList
-
Quick way of determining if the RID list has been built.
- isCaseInsensitiveIdentifiers() - Method in class com.mckoi.database.jdbc.MConnection
-
Returns true if the database has case insensitive identifiers.
- isCaseSensitive(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isCatalogAtStart() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- isClosed() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns true if the store is closed.
- isClosed() - Method in class com.mckoi.database.jdbc.MConnection
- isClosed() - Method in class com.mckoi.database.jdbc.MResultSet
- isClosed() - Method in class com.mckoi.database.jdbc.MStatement
- isClosed() - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Returns true if the connection to the client is closed.
- isClosed() - Method in class com.mckoi.database.jdbcserver.TCPJDBCServerConnection
-
Returns true if the connection to the client has been closed.
- isClosed() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns true if this table source is closed.
- isClosed() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns true if the conglomerate is closed.
- isCloseOnCompletion() - Method in class com.mckoi.database.jdbc.MPreparedStatement
- isCloseOnCompletion() - Method in class com.mckoi.database.jdbc.MStatement
- isCompressed(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns true if the given record is compressed.
- isCondition() - Method in class com.mckoi.database.Operator
- isConstant() - Method in class com.mckoi.database.Expression
-
Returns true if the expression doesn't include any variables or non constant functions (is constant).
- isCurrency(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isDefinitelyWritable(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isDelete() - Method in class com.mckoi.database.TableModificationEvent
-
Returns true if this is an DELETE event.
- isDeleted() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Returns true if the journal is deleted.
- isDynamicTable(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns true if the given table name is a dynamically generated table and is not a table that is found in the table list defined in this transaction object.
- isDynamicTable(TableName) - Method in class com.mckoi.database.Transaction
-
Returns true if the given table name represents a dynamically generated system table.
- isEmpty() - Method in class com.mckoi.database.Privileges
-
Returns true if this Privileges object contains no priv entries.
- isEmpty() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns true if the block is empty.
- isEmpty() - Method in class com.mckoi.util.IntegerListBlockInterface
-
Returns true if the block is empty.
- isFirst() - Method in class com.mckoi.database.jdbc.MResultSet
- isFull() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns true if the block is full.
- isFull() - Method in class com.mckoi.util.IntegerListBlockInterface
-
Returns true if the block is full.
- isGlob() - Method in class com.mckoi.database.AbstractFunction
-
Returns true if the param is the special case glob parameter (*).
- isImmutable() - Method in class com.mckoi.database.SelectableScheme
-
Returns true if this scheme is immutable.
- isImmutable() - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Returns true if this interface is immutable.
- isImmutable() - Method in interface com.mckoi.util.IntegerListInterface
-
Returns true if this interface is immutable.
- isInCaseInsensitiveMode() - Method in class com.mckoi.database.DatabaseConnection
-
Returns true if the connection is in case insensitive mode.
- isIndexableType() - Method in class com.mckoi.database.DataTableColumnDef
-
Returns true if this type of column is able to be indexed.
- isInExclusiveMode() - Method in class com.mckoi.database.DataTable
-
Returns true if the database is in exclusive mode.
- isInExclusiveMode() - Method in class com.mckoi.database.LockingMechanism
-
Returns true if we are locked into exclusive mode.
- isInitialized() - Method in class com.mckoi.database.Database
-
Returns true if the database is initialised.
- isInsert() - Method in class com.mckoi.database.TableModificationEvent
-
Returns true if this is an INSERT event.
- isInterestedIn(int) - Static method in class com.mckoi.debug.Debug
-
Deprecated.Queries the current debug level.
- isInterestedIn(int) - Method in interface com.mckoi.debug.DebugLogger
-
Queries the current debug level.
- isInterestedIn(int) - Method in class com.mckoi.debug.DefaultDebugLogger
- isLast() - Method in class com.mckoi.database.jdbc.MResultSet
- isLogical() - Method in class com.mckoi.database.Operator
- isMathematical() - Method in class com.mckoi.database.Operator
- isn_op - Static variable in class com.mckoi.database.Operator
- isNot() - Method in class com.mckoi.database.Operator
- isNoTime() - Method in class com.mckoi.util.TimeFrame
-
Returns true if this time frame represents no time.
- isNotInversible() - Method in class com.mckoi.database.Operator
-
Returns true if this operator is not inversible.
- isNotNull() - Method in class com.mckoi.database.DataTableColumnDef
- isNotNull() - Method in class com.mckoi.database.global.ColumnDescription
-
Determines whether the field can contain a null value or not.
- isNotNull() - Method in class com.mckoi.database.interpret.ColumnDef
-
Returns true if this column has the not null constraint set for it.
- IsNotOperator() - Constructor for class com.mckoi.database.Operator.IsNotOperator
- isNull() - Method in class com.mckoi.database.TObject
-
Returns true if the object is null.
- isNullable(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isNumericType() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns true if this column is a numeric type.
- IsOperator() - Constructor for class com.mckoi.database.Operator.IsOperator
- isPage(long, long) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Returns true if this page matches the given id/page_number.
- isPattern() - Method in class com.mckoi.database.Operator
- isPingClient() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- isPoolable() - Method in class com.mckoi.database.jdbc.MStatement
- isPrimaryKey() - Method in class com.mckoi.database.interpret.ColumnDef
-
Returns true if this column has a primary key constraint set on it.
- isProcessingRequest() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- isQuantifiable() - Method in class com.mckoi.database.global.ColumnDescription
-
Returns true if the type of the field is searchable.
- isQueryDone() - Method in class com.mckoi.jfccontrols.QueryAgent
-
Returns true if the query is done or not yet.
- isReadOnly() - Method in class com.mckoi.database.Database
-
Returns true if this database is in read only mode.
- isReadOnly() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns true if the store has been opened in read only mode.
- isReadOnly() - Method in class com.mckoi.database.IndexStore
-
Returns true if this store is read only.
- isReadOnly() - Method in class com.mckoi.database.jdbc.MConnection
- isReadOnly() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- isReadOnly() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns true if the source is read only.
- isReadOnly() - Method in class com.mckoi.database.SimpleTransaction
-
Returns true if the transaction is read-only, otherwise returns false.
- isReadOnly() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns true if the system is in read only mode.
- isReadOnly() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns true if the store was openned in read only mode.
- isReadOnly(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isRemoveCommand(byte) - Static method in class com.mckoi.database.MasterTableJournal
-
Returns true if the given command is a removal command.
- isRootLocked() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns true if the table is currently under a root lock (has 1 or more root locks on it).
- isRowValid(int) - Method in interface com.mckoi.database.DataTableFile
-
Returns true if the given row index points to a valid and available row entry.
- isSameTable(DataTable) - Method in class com.mckoi.database.RowData
-
Returns the table object this row data is assigned to.
- isSearchable(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isSectorDeleted(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns true if the sector number is flagged as deleted.
- isSigned(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isSorted() - Method in class com.mckoi.util.IntegerVector
-
Test routine to check vector is sorted.
- isStrictGetObject() - Method in class com.mckoi.database.jdbc.MConnection
-
Returns true if strict get object is enabled (default).
- isSubQuery() - Method in class com.mckoi.database.Operator
- isSubQueryForm(int) - Method in class com.mckoi.database.Operator
-
Given a parameter of either NONE, ANY, ALL or SINGLE, this returns true if this operator is of the given type.
- isSubQueryTable() - Method in class com.mckoi.database.interpret.FromTableDef
-
Returns true if this item in the FROM clause is a subquery table.
- isTrue(TObject) - Static method in class com.mckoi.database.Operator
-
Returns true if the given TObject is a boolean and is true.
- isUnique() - Method in class com.mckoi.database.global.ColumnDescription
-
Determines whether the field can contain two items that are identical.
- isUnique() - Method in class com.mckoi.database.interpret.ColumnDef
-
Returns true if this column has the unique constraint set for it.
- isUniqueColumns(TableDataSource, int, String[], boolean) - Static method in class com.mckoi.database.TableDataConglomerate
-
Checks the uniqueness of the columns in the row of the table.
- isUniqueIndex() - Method in class com.mckoi.database.DataIndexDef
-
Returns true if this is a unique index.
- isUpdate() - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns true if this result set contains 1 column and 1 row and the name of the column is 'result'.
- isUpdate() - Method in class com.mckoi.database.TableModificationEvent
-
Returns true if this is an UPDATE event.
- isUpdated() - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Returns true if the planner was updated.
- isValid(int) - Method in class com.mckoi.database.jdbc.MConnection
- isValidBoundarySize(long) - Static method in class com.mckoi.store.AbstractStore
-
Returns true if the given area size is valid.
- isWildCard(char) - Static method in class com.mckoi.database.PatternSearch
-
Returns true if the given character is a wild card (unknown).
- isWorthCompacting() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns true if a compact table is necessary.
- isWorthCompacting() - Method in class com.mckoi.database.V2MasterTableDataSource
- isWrapperFor(Class) - Method in class com.mckoi.database.jdbc.MConnection
- isWrapperFor(Class) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- isWrapperFor(Class) - Method in class com.mckoi.database.jdbc.MResultSet
- isWrapperFor(Class) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- isWrapperFor(Class) - Method in class com.mckoi.database.jdbc.MStatement
- isWritable(int) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- iterativeSearch(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Performs an iterative search through the int values in the list.
- iterativeSearch(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Performs an iterative search through the int values in the list.
- iterativeSearch(int, int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Performs an iterative search from the given position to the end of the list in the block.
- iterativeSearch(int, int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Performs an iterative search from the given position to the end of the list in the block.
- iterator() - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Returns an IntegerIterator that will walk from the start to the end this list.
- iterator() - Method in interface com.mckoi.util.IntegerListInterface
-
Returns an IntegerIterator that will walk from the start to the end this list.
- iterator(int, int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Returns an IntegerIterator that will walk from the start offset (inclusive) to the end offset (inclusive) of this list.
- iterator(int, int) - Method in interface com.mckoi.util.IntegerListInterface
-
Returns an IntegerIterator that will walk from the start offset (inclusive) to the end offset (inclusive) of this list.
J
- JAVA - Static variable in interface com.mckoi.database.sql.SQLConstants
- JAVA_OBJECT - Static variable in interface com.mckoi.database.global.SQLTypes
- JAVA_OBJECT - Static variable in interface com.mckoi.database.sql.SQLConstants
- JAVA_OBJECT_ARRAY_REF - Static variable in interface com.mckoi.database.sql.SQLConstants
- JAVA_TYPE_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
Java type constraint violation error code (tried to insert a Java object that wasn't derived from the java object type defined for the column).
- javaClass() - Method in class com.mckoi.database.TArrayType
- javaClass() - Method in class com.mckoi.database.TBinaryType
- javaClass() - Method in class com.mckoi.database.TBooleanType
- javaClass() - Method in class com.mckoi.database.TDateType
- javaClass() - Method in class com.mckoi.database.TJavaObjectType
- javaClass() - Method in class com.mckoi.database.TNullType
- javaClass() - Method in class com.mckoi.database.TNumericType
- javaClass() - Method in class com.mckoi.database.TQueryPlanType
- javaClass() - Method in class com.mckoi.database.TStringType
- javaClass() - Method in class com.mckoi.database.TType
-
Returns the Java Class that is used to represent this type of object.
- JavaInstantiation() - Method in class com.mckoi.database.sql.SQL
- JavaObjectInstantiation(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.JavaObjectInstantiation
- JavaObjectInstantiation2(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.JavaObjectInstantiation2
- javaObjectType(String) - Static method in class com.mckoi.database.TType
-
Returns a TBinaryType constrained for the given class.
- javaProcedureMethod(String, TType[]) - Static method in class com.mckoi.database.ProcedureManager
-
Given a Java location_str and a list of parameter types, returns an immutable 'Method' object that can be used to invoke a Java stored procedure.
- JavaRegex - Class in com.mckoi.database.regexbridge
-
A bridge to the internal Java regular expression library that was introduced in Java 1.4.
- JavaRegex() - Constructor for class com.mckoi.database.regexbridge.JavaRegex
- jdbc_connection - Variable in class com.mckoi.database.DatabaseConnection.DCProcedureConnection
-
The JDBCConnection created by this object.
- jdbc_connection - Variable in class com.mckoi.database.DatabaseConnection
-
The current java.sql.Connection object that can be used to access the transaction internally.
- JDBC_SCHEMA - Static variable in class com.mckoi.database.Database
-
The name of the schema that contains JDBC helper tables.
- jdbcCompliant() - Method in class com.mckoi.database.jdbc.MDriver
- JDBCDatabaseInterface - Class in com.mckoi.database.jdbcserver
-
An implementation of jdbc.DatabaseInterface on the server-side.
- JDBCDatabaseInterface(Database, String) - Constructor for class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
-
Sets up the processor.
- JDBCDriver - Class in com.mckoi
-
Instance class that registers the mckoi JDBC driver with the JDBC Driver Manager.
- JDBCDriver() - Constructor for class com.mckoi.JDBCDriver
-
Constructor.
- jdbcObjectCast(Object, int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Casts an internal object to the sql_type given for return by methods such as 'getObject'.
- JDBCProcessor - Class in com.mckoi.database.jdbcserver
-
This processes JDBC commands from a JDBC client and dispatches the commands to the database.
- JDBCProcessor(DatabaseInterface, DebugLogger) - Constructor for class com.mckoi.database.jdbcserver.JDBCProcessor
-
Sets up the processor.
- JDBCQueryTool - Class in com.mckoi.tools
-
A graphical interactive SQL query tool that allows for queries to be executed to a JDBC driver.
- JDBCQueryTool(QueryAgent) - Constructor for class com.mckoi.tools.JDBCQueryTool
-
Constructs the JComponent.
- JDBCQueryTool(Connection) - Constructor for class com.mckoi.tools.JDBCQueryTool
-
Constructs the JComponent.
- JDBCScriptTool - Class in com.mckoi.tools
-
A tool that reads an input SQL script and output information for the result either to an output file or through System.out.
- JDBCScriptTool(Reader, PrintWriter) - Constructor for class com.mckoi.tools.JDBCScriptTool
-
Constructs the tool.
- jdbcSQLClass(int) - Static method in class com.mckoi.database.jdbc.MResultSetMetaData
-
Returns the object class that a given sql_type will produce by the 'getObject' call in ResultSet.
- JDIQueryResponse(int, AbstractJDBCDatabaseInterface.ResultSetInfo, int, String) - Constructor for class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- jj_2_1(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_10(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_11(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_12(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_13(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_14(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_15(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_16(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_17(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_2(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_3(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_4(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_5(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_6(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_7(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_8(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_9(int) - Method in class com.mckoi.database.sql.SQL
- jj_2_rtns - Variable in class com.mckoi.database.sql.SQL
- jj_3_1() - Method in class com.mckoi.database.sql.SQL
- jj_3_10() - Method in class com.mckoi.database.sql.SQL
- jj_3_11() - Method in class com.mckoi.database.sql.SQL
- jj_3_12() - Method in class com.mckoi.database.sql.SQL
- jj_3_13() - Method in class com.mckoi.database.sql.SQL
- jj_3_14() - Method in class com.mckoi.database.sql.SQL
- jj_3_15() - Method in class com.mckoi.database.sql.SQL
- jj_3_16() - Method in class com.mckoi.database.sql.SQL
- jj_3_17() - Method in class com.mckoi.database.sql.SQL
- jj_3_2() - Method in class com.mckoi.database.sql.SQL
- jj_3_3() - Method in class com.mckoi.database.sql.SQL
- jj_3_4() - Method in class com.mckoi.database.sql.SQL
- jj_3_5() - Method in class com.mckoi.database.sql.SQL
- jj_3_6() - Method in class com.mckoi.database.sql.SQL
- jj_3_7() - Method in class com.mckoi.database.sql.SQL
- jj_3_8() - Method in class com.mckoi.database.sql.SQL
- jj_3_9() - Method in class com.mckoi.database.sql.SQL
- jj_3R_100() - Method in class com.mckoi.database.sql.SQL
- jj_3R_101() - Method in class com.mckoi.database.sql.SQL
- jj_3R_102() - Method in class com.mckoi.database.sql.SQL
- jj_3R_103() - Method in class com.mckoi.database.sql.SQL
- jj_3R_104() - Method in class com.mckoi.database.sql.SQL
- jj_3R_105() - Method in class com.mckoi.database.sql.SQL
- jj_3R_106() - Method in class com.mckoi.database.sql.SQL
- jj_3R_107() - Method in class com.mckoi.database.sql.SQL
- jj_3R_108() - Method in class com.mckoi.database.sql.SQL
- jj_3R_109() - Method in class com.mckoi.database.sql.SQL
- jj_3R_110() - Method in class com.mckoi.database.sql.SQL
- jj_3R_111() - Method in class com.mckoi.database.sql.SQL
- jj_3R_112() - Method in class com.mckoi.database.sql.SQL
- jj_3R_113() - Method in class com.mckoi.database.sql.SQL
- jj_3R_114() - Method in class com.mckoi.database.sql.SQL
- jj_3R_115() - Method in class com.mckoi.database.sql.SQL
- jj_3R_116() - Method in class com.mckoi.database.sql.SQL
- jj_3R_117() - Method in class com.mckoi.database.sql.SQL
- jj_3R_118() - Method in class com.mckoi.database.sql.SQL
- jj_3R_119() - Method in class com.mckoi.database.sql.SQL
- jj_3R_120() - Method in class com.mckoi.database.sql.SQL
- jj_3R_121() - Method in class com.mckoi.database.sql.SQL
- jj_3R_122() - Method in class com.mckoi.database.sql.SQL
- jj_3R_123() - Method in class com.mckoi.database.sql.SQL
- jj_3R_124() - Method in class com.mckoi.database.sql.SQL
- jj_3R_125() - Method in class com.mckoi.database.sql.SQL
- jj_3R_126() - Method in class com.mckoi.database.sql.SQL
- jj_3R_127() - Method in class com.mckoi.database.sql.SQL
- jj_3R_128() - Method in class com.mckoi.database.sql.SQL
- jj_3R_129() - Method in class com.mckoi.database.sql.SQL
- jj_3R_130() - Method in class com.mckoi.database.sql.SQL
- jj_3R_131() - Method in class com.mckoi.database.sql.SQL
- jj_3R_132() - Method in class com.mckoi.database.sql.SQL
- jj_3R_133() - Method in class com.mckoi.database.sql.SQL
- jj_3R_134() - Method in class com.mckoi.database.sql.SQL
- jj_3R_135() - Method in class com.mckoi.database.sql.SQL
- jj_3R_136() - Method in class com.mckoi.database.sql.SQL
- jj_3R_137() - Method in class com.mckoi.database.sql.SQL
- jj_3R_138() - Method in class com.mckoi.database.sql.SQL
- jj_3R_17() - Method in class com.mckoi.database.sql.SQL
- jj_3R_18() - Method in class com.mckoi.database.sql.SQL
- jj_3R_19() - Method in class com.mckoi.database.sql.SQL
- jj_3R_20() - Method in class com.mckoi.database.sql.SQL
- jj_3R_21() - Method in class com.mckoi.database.sql.SQL
- jj_3R_22() - Method in class com.mckoi.database.sql.SQL
- jj_3R_23() - Method in class com.mckoi.database.sql.SQL
- jj_3R_24() - Method in class com.mckoi.database.sql.SQL
- jj_3R_25() - Method in class com.mckoi.database.sql.SQL
- jj_3R_26() - Method in class com.mckoi.database.sql.SQL
- jj_3R_27() - Method in class com.mckoi.database.sql.SQL
- jj_3R_28() - Method in class com.mckoi.database.sql.SQL
- jj_3R_29() - Method in class com.mckoi.database.sql.SQL
- jj_3R_30() - Method in class com.mckoi.database.sql.SQL
- jj_3R_31() - Method in class com.mckoi.database.sql.SQL
- jj_3R_32() - Method in class com.mckoi.database.sql.SQL
- jj_3R_33() - Method in class com.mckoi.database.sql.SQL
- jj_3R_34() - Method in class com.mckoi.database.sql.SQL
- jj_3R_35() - Method in class com.mckoi.database.sql.SQL
- jj_3R_36() - Method in class com.mckoi.database.sql.SQL
- jj_3R_37() - Method in class com.mckoi.database.sql.SQL
- jj_3R_38() - Method in class com.mckoi.database.sql.SQL
- jj_3R_39() - Method in class com.mckoi.database.sql.SQL
- jj_3R_40() - Method in class com.mckoi.database.sql.SQL
- jj_3R_41() - Method in class com.mckoi.database.sql.SQL
- jj_3R_42() - Method in class com.mckoi.database.sql.SQL
- jj_3R_43() - Method in class com.mckoi.database.sql.SQL
- jj_3R_44() - Method in class com.mckoi.database.sql.SQL
- jj_3R_45() - Method in class com.mckoi.database.sql.SQL
- jj_3R_46() - Method in class com.mckoi.database.sql.SQL
- jj_3R_47() - Method in class com.mckoi.database.sql.SQL
- jj_3R_48() - Method in class com.mckoi.database.sql.SQL
- jj_3R_49() - Method in class com.mckoi.database.sql.SQL
- jj_3R_50() - Method in class com.mckoi.database.sql.SQL
- jj_3R_51() - Method in class com.mckoi.database.sql.SQL
- jj_3R_52() - Method in class com.mckoi.database.sql.SQL
- jj_3R_53() - Method in class com.mckoi.database.sql.SQL
- jj_3R_54() - Method in class com.mckoi.database.sql.SQL
- jj_3R_55() - Method in class com.mckoi.database.sql.SQL
- jj_3R_56() - Method in class com.mckoi.database.sql.SQL
- jj_3R_57() - Method in class com.mckoi.database.sql.SQL
- jj_3R_58() - Method in class com.mckoi.database.sql.SQL
- jj_3R_59() - Method in class com.mckoi.database.sql.SQL
- jj_3R_60() - Method in class com.mckoi.database.sql.SQL
- jj_3R_61() - Method in class com.mckoi.database.sql.SQL
- jj_3R_62() - Method in class com.mckoi.database.sql.SQL
- jj_3R_63() - Method in class com.mckoi.database.sql.SQL
- jj_3R_64() - Method in class com.mckoi.database.sql.SQL
- jj_3R_65() - Method in class com.mckoi.database.sql.SQL
- jj_3R_66() - Method in class com.mckoi.database.sql.SQL
- jj_3R_67() - Method in class com.mckoi.database.sql.SQL
- jj_3R_68() - Method in class com.mckoi.database.sql.SQL
- jj_3R_69() - Method in class com.mckoi.database.sql.SQL
- jj_3R_70() - Method in class com.mckoi.database.sql.SQL
- jj_3R_71() - Method in class com.mckoi.database.sql.SQL
- jj_3R_72() - Method in class com.mckoi.database.sql.SQL
- jj_3R_73() - Method in class com.mckoi.database.sql.SQL
- jj_3R_74() - Method in class com.mckoi.database.sql.SQL
- jj_3R_75() - Method in class com.mckoi.database.sql.SQL
- jj_3R_76() - Method in class com.mckoi.database.sql.SQL
- jj_3R_77() - Method in class com.mckoi.database.sql.SQL
- jj_3R_78() - Method in class com.mckoi.database.sql.SQL
- jj_3R_79() - Method in class com.mckoi.database.sql.SQL
- jj_3R_80() - Method in class com.mckoi.database.sql.SQL
- jj_3R_81() - Method in class com.mckoi.database.sql.SQL
- jj_3R_82() - Method in class com.mckoi.database.sql.SQL
- jj_3R_83() - Method in class com.mckoi.database.sql.SQL
- jj_3R_84() - Method in class com.mckoi.database.sql.SQL
- jj_3R_85() - Method in class com.mckoi.database.sql.SQL
- jj_3R_86() - Method in class com.mckoi.database.sql.SQL
- jj_3R_87() - Method in class com.mckoi.database.sql.SQL
- jj_3R_88() - Method in class com.mckoi.database.sql.SQL
- jj_3R_89() - Method in class com.mckoi.database.sql.SQL
- jj_3R_90() - Method in class com.mckoi.database.sql.SQL
- jj_3R_91() - Method in class com.mckoi.database.sql.SQL
- jj_3R_92() - Method in class com.mckoi.database.sql.SQL
- jj_3R_93() - Method in class com.mckoi.database.sql.SQL
- jj_3R_94() - Method in class com.mckoi.database.sql.SQL
- jj_3R_95() - Method in class com.mckoi.database.sql.SQL
- jj_3R_96() - Method in class com.mckoi.database.sql.SQL
- jj_3R_97() - Method in class com.mckoi.database.sql.SQL
- jj_3R_98() - Method in class com.mckoi.database.sql.SQL
- jj_3R_99() - Method in class com.mckoi.database.sql.SQL
- jj_add_error_token(int, int) - Method in class com.mckoi.database.sql.SQL
- jj_consume_token(int) - Method in class com.mckoi.database.sql.SQL
- jj_endpos - Variable in class com.mckoi.database.sql.SQL
- jj_expentries - Variable in class com.mckoi.database.sql.SQL
- jj_expentry - Variable in class com.mckoi.database.sql.SQL
- jj_gc - Variable in class com.mckoi.database.sql.SQL
- jj_gen - Variable in class com.mckoi.database.sql.SQL
- jj_input_stream - Variable in class com.mckoi.database.sql.SQL
- jj_kind - Variable in class com.mckoi.database.sql.SQL
- jj_la - Variable in class com.mckoi.database.sql.SQL
- jj_la1 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_0 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_1 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_2 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_3 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_4 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_5 - Variable in class com.mckoi.database.sql.SQL
- jj_la1_6 - Variable in class com.mckoi.database.sql.SQL
- jj_lastpos - Variable in class com.mckoi.database.sql.SQL
- jj_lasttokens - Variable in class com.mckoi.database.sql.SQL
- jj_nt - Variable in class com.mckoi.database.sql.SQL
- jj_ntk - Variable in class com.mckoi.database.sql.SQL
- jj_ntk() - Method in class com.mckoi.database.sql.SQL
- jj_rescan - Variable in class com.mckoi.database.sql.SQL
- jj_rescan_token() - Method in class com.mckoi.database.sql.SQL
- jj_save(int, int) - Method in class com.mckoi.database.sql.SQL
- jj_scan_token(int) - Method in class com.mckoi.database.sql.SQL
- jj_scanpos - Variable in class com.mckoi.database.sql.SQL
- jj_semLA - Variable in class com.mckoi.database.sql.SQL
- jjAddStates(int, int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjbitVec0 - Static variable in class com.mckoi.database.sql.SQLTokenManager
- jjbitVec2 - Static variable in class com.mckoi.database.sql.SQLTokenManager
- JJCalls() - Constructor for class com.mckoi.database.sql.SQL.JJCalls
- jjCanMove_0(int, int, int, long, long) - Static method in class com.mckoi.database.sql.SQLTokenManager
- jjCheckNAdd(int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjCheckNAddStates(int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjCheckNAddStates(int, int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjCheckNAddTwoStates(int, int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjFillToken() - Method in class com.mckoi.database.sql.SQLTokenManager
- jjmatchedKind - Variable in class com.mckoi.database.sql.SQLTokenManager
- jjmatchedPos - Variable in class com.mckoi.database.sql.SQLTokenManager
- jjMoveNfa_0(int, int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa0_0() - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa1_0(long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa10_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa11_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa12_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa13_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa14_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa15_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa16_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa17_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa18_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa19_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa2_0(long, long, long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa20_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa21_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa22_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa23_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa24_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa25_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa26_0(long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa3_0(long, long, long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa4_0(long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa5_0(long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa6_0(long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa7_0(long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa8_0(long, long, long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjMoveStringLiteralDfa9_0(long, long, long, long) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjnewStateCnt - Variable in class com.mckoi.database.sql.SQLTokenManager
- jjnextStates - Static variable in class com.mckoi.database.sql.SQLTokenManager
- jjround - Variable in class com.mckoi.database.sql.SQLTokenManager
- jjrounds - Variable in class com.mckoi.database.sql.SQLTokenManager
- jjstateSet - Variable in class com.mckoi.database.sql.SQLTokenManager
- jjStopAtPos(int, int) - Method in class com.mckoi.database.sql.SQLTokenManager
- jjstrLiteralImages - Static variable in class com.mckoi.database.sql.SQLTokenManager
- jjtoSkip - Static variable in class com.mckoi.database.sql.SQLTokenManager
- jjtoToken - Static variable in class com.mckoi.database.sql.SQLTokenManager
- join(Table) - Method in class com.mckoi.database.Table
-
Performs a natural join of this table with the given table.
- JOIN - Static variable in interface com.mckoi.database.sql.SQLConstants
- join_op - Variable in class com.mckoi.database.QueryPlan.JoinNode
-
The operator to join under (=, <>, >, <, >=, <=).
- join_set - Variable in class com.mckoi.database.interpret.FromClause
-
The JoiningSet object that we have created to represent the joins in this FROM clause.
- join_set - Variable in class com.mckoi.database.JoiningSet
-
The list of tables we are joining together a JoinPart object that represents how the tables are joined.
- joinAllPlansToSingleSource(List) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Given a list of PlanTableSource objects, this will produce a plan that naturally joins all the tables together into a single plan.
- joinAllPlansWithVariables(List) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Creates a single PlanTableSource that encapsulates all the given variables in a single table.
- JoinedTable - Class in com.mckoi.database
-
A Table that represents the result of one or more other tables joined together.
- JoinedTable() - Constructor for class com.mckoi.database.JoinedTable
-
Protected constructor.
- JoinedTable(Table) - Constructor for class com.mckoi.database.JoinedTable
-
Constructs the JoinedTable with a single table.
- JoinedTable(Table[]) - Constructor for class com.mckoi.database.JoinedTable
-
Constructs the JoinedTable with the list of tables in the parent.
- JoiningSet - Class in com.mckoi.database
-
Used in TableSet to describe how we naturally join the tables together.
- JoiningSet() - Constructor for class com.mckoi.database.JoiningSet
-
Constructs the JoiningSet.
- JoiningSet.JoinPart - Class in com.mckoi.database
- JoinNode(QueryPlanNode, QueryPlanNode, Variable, Operator, Expression) - Constructor for class com.mckoi.database.QueryPlan.JoinNode
- JoinPart(int) - Constructor for class com.mckoi.database.JoiningSet.JoinPart
- JoinPart(int, Expression) - Constructor for class com.mckoi.database.JoiningSet.JoinPart
-
Constructs the JoinPart.
- journal - Variable in class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- journal - Variable in class com.mckoi.database.Transaction
-
The journal for this transaction.
- journal - Variable in class com.mckoi.store.JournalledSystem.JournalEntry
-
The journal file.
- journal_archives - Variable in class com.mckoi.store.JournalledSystem
-
The archive of journal files currently pending (JournalFile).
- journal_count_stat_key - Variable in class com.mckoi.database.MultiVersionTableIndices
- journal_entries - Variable in class com.mckoi.database.MasterTableJournal
-
The number of entries in this journal.
- journal_entries - Variable in class com.mckoi.database.TransactionJournal
-
The number of entries in this journal.
- journal_file - Variable in class com.mckoi.store.JournalledSystem.JournalSummary
-
The JournalFile object that is a summary of.
- journal_list_comparator - Variable in class com.mckoi.store.JournalledSystem
- journal_map - Variable in class com.mckoi.store.JournalledSystem.Resource
-
The hash of all journal entries on this resource (JournalEntry).
- journal_number - Variable in class com.mckoi.store.JournalledSystem
-
The current journal file number.
- journal_number - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
The journal number of this journal.
- journal_path - Variable in class com.mckoi.store.JournalledSystem
-
The path to the journal files.
- JournalEntry(String, JournalledSystem.JournalFile, long, long) - Constructor for class com.mckoi.store.JournalledSystem.JournalEntry
-
Constructs the entry.
- JournalFile(File, boolean) - Constructor for class com.mckoi.store.JournalledSystem.JournalFile
-
Constructs the journal file.
- journaling_thread - Variable in class com.mckoi.store.JournalledSystem
-
A thread that runs in the background and persists information that is in the journal.
- JournalingThread() - Constructor for class com.mckoi.store.JournalledSystem.JournalingThread
-
Constructor.
- journalled_system - Variable in class com.mckoi.store.LoggingBufferManager
-
The JournalledSystem object that handles journalling of all data.
- JournalledFileStore - Class in com.mckoi.store
-
An implementation of AbstractStore that persists to an underlying data format via a robust journalling system that supports check point and crash recovery.
- JournalledFileStore(String, LoggingBufferManager, boolean) - Constructor for class com.mckoi.store.JournalledFileStore
-
Constructs the ScatteringFileStore.
- JournalledResource - Interface in com.mckoi.store
-
An interface that allows for the reading and writing of pages to/from a journalled.
- JournalledSystem - Class in com.mckoi.store
-
Manages a journalling data store management system.
- JournalledSystem(File, boolean, int, LoggingBufferManager.StoreDataAccessorFactory, DebugLogger, boolean) - Constructor for class com.mckoi.store.JournalledSystem
- JournalledSystem.AbstractResource - Class in com.mckoi.store
-
An abstract resource.
- JournalledSystem.JournalEntry - Class in com.mckoi.store
-
A JournalEntry represents a modification that has been logging in the journal for a specific page of a resource.
- JournalledSystem.JournalFile - Class in com.mckoi.store
-
A JournalFile represents a file in which modification are logged out to when changes are made.
- JournalledSystem.JournalingThread - Class in com.mckoi.store
-
Thread that persists the journal in the backgroudn.
- JournalledSystem.JournalSummary - Class in com.mckoi.store
-
Summary information about a journal.
- JournalledSystem.NonLoggingResource - Class in com.mckoi.store
-
An implementation of AbstractResource that doesn't log.
- JournalledSystem.Resource - Class in com.mckoi.store
-
Represents a resource in this system.
- JournalSummary(JournalledSystem.JournalFile) - Constructor for class com.mckoi.store.JournalledSystem.JournalSummary
-
Constructor.
K
- key - Variable in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- key - Variable in class com.mckoi.util.Cache.ListNode
-
The key in the Hashtable for this object.
- KEY - Static variable in interface com.mckoi.database.sql.SQLConstants
- key_columns - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The list of columns that make up the key.
- key_map - Variable in class com.mckoi.database.control.AbstractDBConfig
-
The Hashtable mapping from configuration key to value for the key.
- key_table_name - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The key table name.
- key_value_pairs - Variable in class com.mckoi.database.GTConnectionInfoDataSource
-
The list of info keys/values in this object.
- key_value_pairs - Variable in class com.mckoi.database.GTCurrentConnectionsDataSource
-
The list of info keys/values in this object.
- key_value_pairs - Variable in class com.mckoi.database.GTProductDataSource
-
The list of info keys/values in this object.
- key_value_pairs - Variable in class com.mckoi.database.GTSQLTypeInfoDataSource
-
The list of info keys/values in this object.
- keyList() - Method in class com.mckoi.util.Stats
-
Return a String array of all stat keys sorted in order from lowest to highest.
- keySet() - Method in class com.mckoi.util.HashMapList
-
The Set of all keys.
- kind - Variable in class com.mckoi.database.sql.Token
-
An integer that describes the kind of this token.
L
- l_op - Static variable in class com.mckoi.database.Operator
- LANGUAGE - Static variable in interface com.mckoi.database.sql.SQLConstants
- largeObjectTest(int) - Static method in class com.mckoi.database.Database
-
Returns true if the given sql type is possibly a large object.
- last() - Method in class com.mckoi.database.Expression
-
Returns the element at the end of the postfix list (the last element).
- last() - Method in class com.mckoi.database.jdbc.MResultSet
- last_checkpoint - Variable in class com.mckoi.store.JournalledSystem.JournalSummary
-
The position of the last checkpoint in the journal.
- last_command_time - Variable in class com.mckoi.database.User
-
The last time this user executed a command on the connection.
- last_entry - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
The last entry in the block.
- last_entry - Variable in class com.mckoi.database.IndexStore.MappedListBlock
-
The last entry in the block.
- last_entry_ri_check - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The last time any changes to the journal were check for referential integrity violations.
- last_garbage_success_event - Variable in class com.mckoi.database.MasterTableGarbageCollector
-
The time when the last garbage collection event occurred.
- last_garbage_try_event - Variable in class com.mckoi.database.MasterTableGarbageCollector
- LAST_IN_SET - Static variable in class com.mckoi.database.SelectableRange
-
An object that represents the last value in the set.
- last_sector - Variable in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
-
The last sector we wrote to.
- last_value - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The last value of this sequence key.
- LAST_VALUE - Static variable in class com.mckoi.database.SelectableRange
-
Represents the various points in the set on the value to represent the set range.
- last_was_null - Variable in class com.mckoi.database.jdbc.MResultSet
-
Set to true if the last 'getxxx' method was a null.
- last_write_position - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The last position in the buffer that was last written.
- lastCloseClean() - Method in class com.mckoi.store.AbstractStore
- lastCloseClean() - Method in class com.mckoi.store.HeapStore
- lastCloseClean() - Method in interface com.mckoi.store.Store
-
Returns true if the store was closed cleanly.
- lastInCollationOrder() - Method in class com.mckoi.database.CollatedBaseSearch
-
Returns the last value of this column (in collated order).
- lastInCollationOrder() - Method in class com.mckoi.database.InsertSearch
- lastSequenceValue(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns the sequence value for the given sequence generator that was last returned by a call to 'nextSequenceValue'.
- lastSequenceValue(String) - Method in class com.mckoi.database.DatabaseConnection
-
Returns the current sequence value for the given sequence generator that was last returned by a call to 'nextSequenceValue'.
- LE - Static variable in interface com.mckoi.database.sql.SQLConstants
- LEADING - Static variable in interface com.mckoi.database.sql.SQLConstants
- LeastFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.LeastFunction
- LEEQ - Static variable in interface com.mckoi.database.sql.SQLConstants
- left - Variable in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
The left and right node.
- left() - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
Returns the left node.
- LEFT - Static variable in interface com.mckoi.database.sql.SQLConstants
- left_columns - Variable in class com.mckoi.database.QueryPlan.EquiJoinNode
-
The columns in the left table.
- left_columns - Variable in class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
-
The columns in the left table.
- left_is_simple_enum - Variable in class com.mckoi.database.NaturallyJoinedTable
- left_join_type - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
- left_on_expr - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
- LEFT_OUTER_JOIN - Static variable in class com.mckoi.database.JoiningSet
- left_plan - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
-
How this plan is naturally joined to other plans in the source.
- left_row_count - Variable in class com.mckoi.database.NaturallyJoinedTable
-
The row counts of the left and right tables.
- left_set - Variable in class com.mckoi.database.NaturallyJoinedTable
-
The lookup row set for the left and right tables.
- left_var - Variable in class com.mckoi.database.QueryPlan.JoinNode
-
The variable in the left table to be joined.
- left_var - Variable in class com.mckoi.database.QueryPlan.SimpleSelectNode
-
The LHS variable.
- LeftOuterJoinNode(QueryPlanNode, String) - Constructor for class com.mckoi.database.QueryPlan.LeftOuterJoinNode
- length() - Method in class com.mckoi.database.BlobStore.AbstractRef
- length() - Method in class com.mckoi.database.BlobStore.ClobRefImpl
- length() - Method in interface com.mckoi.database.global.BlobAccessor
-
Returns the size of the BLOB.
- length() - Method in class com.mckoi.database.global.ByteLongObject
-
Returns the size of the data in this object.
- length() - Method in interface com.mckoi.database.global.StringAccessor
-
Returns the number of characters in the string.
- length() - Method in class com.mckoi.database.global.StringObject
-
Returns the length of the string.
- length() - Method in class com.mckoi.database.jdbc.MBlob
- length() - Method in class com.mckoi.database.jdbc.MClob
- length() - Method in class com.mckoi.database.jdbc.MStreamableBlob
- length() - Method in class com.mckoi.database.jdbc.MStreamableClob
- length() - Method in class com.mckoi.store.StreamFile
-
Returns the current length of the data.
- LengthFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.LengthFunction
- LengthMarkedBufferedInputStream - Class in com.mckoi.util
-
Reads a command block on the underlying stream that is constrained by a length marker preceeding the command.
- LengthMarkedBufferedInputStream(InputStream) - Constructor for class com.mckoi.util.LengthMarkedBufferedInputStream
-
The Constructor.
- leq_op - Static variable in class com.mckoi.database.Operator
- LesserEqualOperator() - Constructor for class com.mckoi.database.Operator.LesserEqualOperator
- LesserOperator() - Constructor for class com.mckoi.database.Operator.LesserOperator
- LETTER - Static variable in interface com.mckoi.database.sql.SQLConstants
- LEXICAL_ERROR - Static variable in error com.mckoi.database.sql.TokenMgrError
-
Lexical error occured.
- LexicalError(boolean, int, int, int, String, char) - Static method in error com.mckoi.database.sql.TokenMgrError
-
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
- lexicographicalOrder(StringAccessor, StringAccessor) - Method in class com.mckoi.database.TStringType
-
An implementation of a lexicographical compareTo operation on a StringAccessor object.
- lexStateNames - Static variable in class com.mckoi.database.sql.SQLTokenManager
- LIKE - Static variable in interface com.mckoi.database.sql.SQLConstants
- like_op - Static variable in class com.mckoi.database.Operator
- lim - Variable in class com.mckoi.util.ByteBuffer
-
The length of the buf array.
- limit - Variable in class com.mckoi.database.interpret.Delete
-
The limit of the number of rows that are updated by this statement.
- limit - Variable in class com.mckoi.database.interpret.UpdateTable
-
The limit of the number of rows that are updated by this statement.
- limit() - Method in class com.mckoi.util.ByteBuffer
-
Returns the limit of this buffer.
- LIMIT - Static variable in interface com.mckoi.database.sql.SQLConstants
- line - Variable in class com.mckoi.database.sql.SimpleCharStream
- list - Variable in class com.mckoi.util.IntegerVector
-
The int array.
- LIST - Static variable in class com.mckoi.database.Privileges
-
The priv to view objects in a schema (only applicable for SCHEMA grant objects).
- list_block_area - Variable in class com.mckoi.database.FixedRecordList
- list_block_count - Variable in class com.mckoi.database.FixedRecordList
-
The number of blocks in the list block.
- list_block_element - Variable in class com.mckoi.database.FixedRecordList
-
Pointers to the blocks in the list block.
- list_end - Variable in class com.mckoi.util.Cache
-
A pointer to the end of the list.
- list_header_area - Variable in class com.mckoi.database.FixedRecordList
-
The header for the list blocks.
- list_header_p - Variable in class com.mckoi.database.FixedRecordList
-
A pointer to the list header area.
- list_header_p - Variable in class com.mckoi.database.V2MasterTableDataSource
-
Points to the block list header area.
- list_start - Variable in class com.mckoi.util.Cache
-
A pointer to the start of the list.
- list_structure - Variable in class com.mckoi.database.V2MasterTableDataSource
-
The structure that manages the pointers to the records.
- list_validated - Variable in class com.mckoi.database.ConnectionTriggerManager
-
If this is false then the list is not validated and must be refreshed when we next access trigger information.
- listBlockCount() - Method in class com.mckoi.database.FixedRecordList
-
Returns the number of block elements in this list structure.
- listBlockFirstPosition(int) - Method in class com.mckoi.database.FixedRecordList
-
Returns the index of the first node in the given block number.
- listBlockNodeCount(int) - Method in class com.mckoi.database.FixedRecordList
-
Returns the number of nodes that can be stored in the given block, where block 0 is the first block (32 addressable nodes).
- listenedBy(int) - Method in class com.mckoi.database.TableModificationEvent
-
Returns true if the given listener type should be notified of this type of table modification event.
- listener - Variable in class com.mckoi.database.TableBackedCache
-
The listener object.
- listener - Variable in class com.mckoi.database.TriggerManager.TriggerAction
- listener_map - Variable in class com.mckoi.database.TriggerManager
-
Maps from the user session (User) to the list of TriggerAction objects for this user.
- listenToEventDispatcher() - Static method in class com.mckoi.debug.Debug
-
Deprecated.Sets up the system so that the debug messenger will intercept event dispatch errors and output the event to the debug stream.
- listenToEventDispatcher() - Method in class com.mckoi.debug.DefaultDebugLogger
-
Sets up the system so that the debug messenger will intercept event dispatch errors and output the event to the debug stream.
- ListNode() - Constructor for class com.mckoi.util.Cache.ListNode
- liveCopyAllDataTo(TableDataConglomerate) - Method in class com.mckoi.database.Transaction
-
Copies all the tables within this transaction view to the destination conglomerate object.
- liveCopyTo(TableDataConglomerate) - Method in class com.mckoi.database.TableDataConglomerate
-
Makes a complete copy of this database to the position represented by the given TableDataConglomerate object.
- liveCopyTo(File) - Method in class com.mckoi.database.Database
-
Copies all the persistent data in this database (the conglomerate) to the given destination path.
- load() - Method in class com.mckoi.database.TableDescriptions
-
Load the entire list of table descriptions for this database.
- load(String, boolean) - Method in interface com.mckoi.database.DataTableFile
-
Loads a previously created table.
- loadDataTableDef() - Method in class com.mckoi.database.V1MasterTableDataSource
- loadFromFile(File) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Loads all the configuration settings from a configuration file.
- loadFromStream(InputStream) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Loads all the configuration values from the given InputStream.
- loadFromURL(URL) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Loads all the configuration values from the given URL.
- loadInternal() - Method in class com.mckoi.database.MasterTableDataSource
-
Loads the internal variables.
- loadMasterTable(int, String, int) - Method in class com.mckoi.database.TableDataConglomerate
-
Loads the master table given the table_id and the name of the table resource in the database path.
- loadNextSector() - Method in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
-
Loads the next sector in the chain into sector_buffer and sets index to the start of the buffer.
- local_cache - Variable in class com.mckoi.database.ViewManager
-
A local cache of ViewDef objects mapped by row id in the system view table.
- local_session_map - Variable in class com.mckoi.database.jdbc.MDriver
-
The mapping of the database configuration URL string to the LocalBootable object that manages the connection.
- LocalBootable - Interface in com.mckoi.database.jdbc
-
An interface that is implemented by an object that boots up the database.
- locale - Variable in class com.mckoi.database.TStringType
-
The locale of the string.
- locale_str - Variable in class com.mckoi.database.DataTableColumnDef
-
The locale string if this column represents a string.
- LocalJDBCDatabaseInterface(Database, String) - Constructor for class com.mckoi.database.jdbcserver.DefaultLocalBootable.LocalJDBCDatabaseInterface
- locatorsUpdateCopy() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- lock - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Lock object.
- lock - Variable in class com.mckoi.database.IndexStore.MappedListBlock
-
Lock object.
- lock - Variable in class com.mckoi.database.jdbc.MConnection
- lock - Variable in class com.mckoi.store.IOStoreDataAccessor
-
A lock because access to the data is stateful.
- lock - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
A lock when modifying the true_data_size, and slice_list.
- lock() - Method in class com.mckoi.database.FixedSizeDataStore
-
Locks the store by some process so that we may not reclaim deleted sectors.
- lock() - Method in class com.mckoi.database.VariableSizeDataStore
-
Locks the store so that not deleted elements may be overwritten.
- lock(String) - Method in interface com.mckoi.database.StoreSystem
-
Attempts to lock this store system exclusively so that no other process may access or change the persistent data in the store.
- lock(String) - Method in class com.mckoi.database.V1FileStoreSystem
- lock(String) - Method in class com.mckoi.database.V1HeapStoreSystem
- Lock - Class in com.mckoi.database
-
This is a lock on a table in the LockingMechanism class.
- Lock(int, LockingQueue, DebugLogger) - Constructor for class com.mckoi.database.Lock
-
The Constructor.
- LOCK - Static variable in interface com.mckoi.database.sql.SQLConstants
- lock_count - Variable in class com.mckoi.database.FixedSizeDataStore
-
The number of locks that have been put on this store.
- LOCK_DEBUG - Static variable in class com.mckoi.database.DataTable
-
------ NOTE: Following values are only kept for lock debugging reasons.
- lock_file - Variable in class com.mckoi.database.V1FileStoreSystem
-
The lock file.
- LOCK_GROUP - Static variable in class com.mckoi.database.Database
-
The name of the lock group.
- lock_index - Variable in class com.mckoi.database.LockHandle
-
A temporary index used during initialisation of object to add locks.
- lock_list - Variable in class com.mckoi.database.LockHandle
-
The array of Lock objects that are being used in this locking process.
- locked - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Incremented when we lock roots.
- locked() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns true if the store is locked from reclaiming deleted rows.
- locked() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns true if we are locked.
- lockForWrite() - Method in class com.mckoi.store.HeapStore
- lockForWrite() - Method in class com.mckoi.store.JournalledFileStore
- lockForWrite() - Method in class com.mckoi.store.LoggingBufferManager
-
Obtains a write lock on the buffer.
- lockForWrite() - Method in interface com.mckoi.store.Store
-
It is often useful to guarentee that a certain sequence of updates to a store is completed and not broken in the middle.
- LockHandle - Class in com.mckoi.database
-
This represents a handle for a series of locks that a query has over the tables in a database.
- LockHandle(int, DebugLogger) - Constructor for class com.mckoi.database.LockHandle
-
The Constructor.
- locking_mechanism - Variable in class com.mckoi.database.DatabaseConnection
-
The locking mechanism within this connection.
- LockingMechanism - Class in com.mckoi.database
-
This class represents a model for locking the tables in a database during any sequence of concurrent read/write accesses.
- LockingMechanism(DebugLogger) - Constructor for class com.mckoi.database.LockingMechanism
-
Constructor.
- LockingQueue - Class in com.mckoi.database
-
This class is used in the 'LockingMechanism' class.
- LockingQueue(DataTable) - Constructor for class com.mckoi.database.LockingQueue
-
The Constructor.
- lockRoot(int) - Method in class com.mckoi.database.CompositeTable
- lockRoot(int) - Method in class com.mckoi.database.DataTable
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockRoot(int) - Method in class com.mckoi.database.DataTableFilter
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockRoot(int) - Method in class com.mckoi.database.FilterTable
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockRoot(int) - Method in class com.mckoi.database.FunctionTable
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockRoot(int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Locks the root of the result set.
- lockRoot(int) - Method in class com.mckoi.database.JoinedTable
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockRoot(int) - Method in class com.mckoi.database.Table
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockRoot(int) - Method in class com.mckoi.database.TableAccessState
-
Locks the root rows of the table.
- lockRoot(int) - Method in class com.mckoi.database.TemporaryTable
-
Locks the root table(s) of this table so that it is impossible to overwrite the underlying rows that may appear in this table.
- lockTables(DataTable[], DataTable[]) - Method in class com.mckoi.database.LockingMechanism
-
This method locks the given tables for either reading or writing.
- log(String) - Method in class com.mckoi.util.Log
-
Writes an entry to the log file.
- log(String) - Method in class com.mckoi.util.NullLog
- Log - Class in com.mckoi.util
-
A log file/stream that logs some information generated by the system.
- Log() - Constructor for class com.mckoi.util.Log
- Log(File) - Constructor for class com.mckoi.util.Log
- Log(File, int, int) - Constructor for class com.mckoi.util.Log
- Log(String) - Constructor for class com.mckoi.util.Log
- log_directory - Variable in class com.mckoi.database.TransactionSystem
-
The log directory.
- log_file - Variable in class com.mckoi.util.LogWriter
-
The log file.
- log_file_size - Variable in class com.mckoi.util.LogWriter
-
Current size of the log file.
- log_output - Variable in class com.mckoi.util.Log
-
The output stream where log information is output to.
- logException(Throwable) - Static method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
-
Writes the exception to the JDBC log stream.
- logger - Variable in class com.mckoi.database.DatabaseConnection
-
The DebugLogger object that we can use to log messages to.
- logger - Variable in class com.mckoi.database.TransactionSystem
-
A logger to output any debugging messages.
- LoggingBufferManager - Class in com.mckoi.store
-
A paged random access buffer manager that caches access between a Store and the underlying filesystem and that also handles check point logging and crash recovery (via a JournalledSystem object).
- LoggingBufferManager(File, boolean, int, int, LoggingBufferManager.StoreDataAccessorFactory, DebugLogger, boolean) - Constructor for class com.mckoi.store.LoggingBufferManager
-
Constructs the manager.
- LoggingBufferManager(File, File, boolean, int, int, String, long, DebugLogger, boolean) - Constructor for class com.mckoi.store.LoggingBufferManager
-
Constructs the manager with a scattering store implementation that converts the resource to a file in the given path.
- LoggingBufferManager.BMPage - Class in com.mckoi.store
-
A page from a store that is currently being cached in memory.
- LoggingBufferManager.BResource - Class in com.mckoi.store
-
A data resource that is being buffered.
- LoggingBufferManager.StoreDataAccessorFactory - Interface in com.mckoi.store
-
A factory interface for creating StoreDataAccessor objects from resource names.
- logicalEvaluate(Expression) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates a search Expression clause.
- LogicalUnionNode(QueryPlanNode, QueryPlanNode) - Constructor for class com.mckoi.database.QueryPlan.LogicalUnionNode
- login(String, String, String) - Method in class com.mckoi.database.jdbc.MConnection
-
Attempts to login to the database interface with the given default schema, username and password.
- login(String, String, String, DatabaseCallBack) - Method in class com.mckoi.database.InternalJDBCHelper.InternalDatabaseInterface
- login(String, String, String, DatabaseCallBack) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Attempts to log in to the database as the given username with the given password.
- login(String, String, String, DatabaseCallBack) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- login(String, String, String, DatabaseCallBack) - Method in class com.mckoi.database.jdbcserver.JDBCDatabaseInterface
- login(Properties, String) - Method in class com.mckoi.database.jdbc.MConnection
-
Logs into the JDBC server running on a remote machine.
- logln(String) - Method in class com.mckoi.util.Log
- logln(String) - Method in class com.mckoi.util.NullLog
- logout() - Method in class com.mckoi.database.User
-
Logs out this user object.
- logPageModification(String, long, byte[], int, int) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Logs a page modification to the end of the log and returns a pointer in the file to the modification.
- logQueries() - Method in class com.mckoi.database.DatabaseSystem
-
If query logging is enabled (all queries are output to 'commands.log' in the log directory), this returns true.
- logResourceDelete(String) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Logs that a resource was deleted.
- logResourceSizeChange(String, long) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Logs a resource size change.
- LogWriter - Class in com.mckoi.util
-
A Writer that writes information to a log file that archives old log entries when it goes above a certain size.
- LogWriter(File, long, int) - Constructor for class com.mckoi.util.LogWriter
-
Constructs the log writer.
- LONG - Static variable in interface com.mckoi.database.sql.SQLConstants
- long_representation - Variable in class com.mckoi.util.BigNumber
-
A 'long' representation of this number.
- longVal(long) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of numeric type that represents the given long value.
- longValue() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as a long.
- LONGVARBINARY - Static variable in interface com.mckoi.database.global.SQLTypes
- LONGVARBINARY - Static variable in interface com.mckoi.database.sql.SQLConstants
- LONGVARCHAR - Static variable in interface com.mckoi.database.global.SQLTypes
- LONGVARCHAR - Static variable in interface com.mckoi.database.sql.SQLConstants
- lookingAhead - Variable in class com.mckoi.database.sql.SQL
- lookup_comparison_list_enabled - Variable in class com.mckoi.database.TransactionSystem
-
Set to true if lookup comparison lists are enabled.
- lookupComparisonListEnabled() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if we should generate lookup caches in InsertSearch otherwise returns false.
- LOOP_DETECTED - Static variable in error com.mckoi.database.sql.TokenMgrError
-
Detected (and bailed out of) an infinite loop in the token manager.
- lower_cells - Variable in class com.mckoi.database.BlindSearch.RangeChecker
-
The TObject objects to check against.
- lower_flags - Variable in class com.mckoi.database.BlindSearch.RangeChecker
-
The list of flags for each check in the range.
- LowerFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.LowerFunction
- lr_byte - Variable in class com.mckoi.database.jdbc.UnicodeToBinaryStream
-
If this is 0 we are on the left byte of the character.
- LTrimFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.LTrimFunction
- Lvl - Interface in com.mckoi.debug
-
Debug level static values.
M
- MAGIC - Static variable in class com.mckoi.database.BlobStore
-
The magic value for fixed record list structures.
- MAGIC - Static variable in class com.mckoi.database.FixedRecordList
-
The magic value for fixed record list structures.
- MAGIC - Static variable in class com.mckoi.database.FixedSizeDataStore
-
The Magic number used to help identify that the file we are reading is formatted as a fixed size data store.
- MAGIC - Static variable in class com.mckoi.database.IndexSetStore
-
The magic value that we use to mark the start area.
- MAGIC - Variable in class com.mckoi.database.StateStore
-
The MAGIC value used for state header areas.
- MAGIC - Static variable in class com.mckoi.store.AbstractStore
-
The magic value.
- main(String[]) - Static method in class com.mckoi.database.PatternSearch
- main(String[]) - Static method in class com.mckoi.database.SelectableRangeSet
-
A test application.
- main(String[]) - Static method in class com.mckoi.database.sql.SQL
- main(String[]) - Static method in class com.mckoi.runtime.McKoiDBMain
-
The McKoi Database application starting point.
- main(String[]) - Static method in class com.mckoi.tools.DataFileConvertTool
-
Application start point.
- main(String[]) - Static method in class com.mckoi.tools.DBConglomerateDiagTool
-
Application start point.
- main(String[]) - Static method in class com.mckoi.tools.DBConglomerateRepairTool
-
Application start point.
- main(String[]) - Static method in class com.mckoi.tools.JDBCQueryTool
-
Application start point.
- main(String[]) - Static method in class com.mckoi.tools.JDBCScriptTool
-
The application start point.
- makeMasterTableJournals() - Method in class com.mckoi.database.TransactionJournal
-
Generates an array of MasterTableJournal objects that specify the changes that occur to each table affected by this transaction.
- makeString(Object) - Method in class com.mckoi.database.jdbc.MResultSet
-
If the object represents a String or is a form that can be readily translated to a String (such as a Clob, String, BigNumber, Boolean, etc) the string representation of the given Object is returned.
- makeTableFileName(TransactionSystem, int, TableName) - Static method in class com.mckoi.database.MasterTableDataSource
-
Creates a unique table name to give a file.
- makeUniqueConstraintName(String, BigNumber) - Static method in class com.mckoi.database.Transaction
-
Convenience, generates a unique constraint name.
- map - Variable in class com.mckoi.database.StatementTree
-
A map that maps from the name of the tree element to the object that contains information about.
- map - Variable in class com.mckoi.util.HashMapList
- MappedListBlock(int) - Constructor for class com.mckoi.database.IndexSetStore.MappedListBlock
-
Creates an empty block.
- MappedListBlock(int) - Constructor for class com.mckoi.database.IndexStore.MappedListBlock
-
Creates an empty block.
- MappedListBlock(int, int, int, int) - Constructor for class com.mckoi.database.IndexStore.MappedListBlock
-
Constructor.
- MappedListBlock(long, long, long, int, byte, int) - Constructor for class com.mckoi.database.IndexSetStore.MappedListBlock
-
Constructor.
- mark - Variable in class com.mckoi.database.CellBufferInputStream
- mark - Variable in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- mark(int) - Method in class com.mckoi.database.CellBufferInputStream
- mark(int) - Method in class com.mckoi.database.CellInputStream
- mark(int) - Method in class com.mckoi.database.DataCellSerialization
- mark(int) - Method in class com.mckoi.database.jdbc.AsciiReader
- mark(int) - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- mark(int) - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- mark(int) - Method in class com.mckoi.util.PagedInputStream
- mark_name - Variable in class com.mckoi.database.QueryPlan.MarkerNode
-
The name of this mark.
- mark_position - Variable in class com.mckoi.util.PagedInputStream
-
Last marked position.
- markAsCommittedDropped(int) - Method in class com.mckoi.database.TableDataConglomerate
-
Marks the given table id as committed dropped.
- markAsDeleted() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Marks this block as deleted.
- marked_index - Variable in class com.mckoi.util.LengthMarkedBufferedInputStream
-
The current index of the marked area that is being read.
- marked_input - Variable in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
The LengthMarkedBufferedInputStream we use to poll for commands from the client.
- marked_length - Variable in class com.mckoi.util.LengthMarkedBufferedInputStream
-
The area of the buffer that is marked as being an available command.
- marked_tables - Variable in class com.mckoi.database.AbstractQueryContext
-
Any marked tables that are made during the evaluation of a query plan.
- marker_randomizer - Static variable in class com.mckoi.database.interpret.Planner
-
Used to generate unique marker names.
- MarkerNode(QueryPlanNode, String) - Constructor for class com.mckoi.database.QueryPlan.MarkerNode
-
Constructor.
- markFullSweep() - Method in class com.mckoi.database.MasterTableGarbageCollector
-
Called by the MasterTableDataSoruce to notify the collector to do a full sweep and remove of records in the table at the next scheduled collection.
- markRowAsDeleted(int) - Method in class com.mckoi.database.MasterTableGarbageCollector
-
Called by the MasterTableDataSoruce to notify the collector that a row has been marked as committed deleted.
- markSupported() - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- markSupported() - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
- markSupported() - Method in class com.mckoi.util.PagedInputStream
- master - Variable in class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- master_table - Variable in class com.mckoi.database.CompositeTable
-
The 'master table' used to resolve information about this table such as fields and field types.
- master_table - Variable in class com.mckoi.database.RIDList
-
The master table for the column this is in.
- MasterTableDataSource - Class in com.mckoi.database
-
A master table data source provides facilities for read/writing and maintaining low level data in a table.
- MasterTableDataSource(TransactionSystem, StoreSystem, OpenTransactionList, BlobStoreInterface) - Constructor for class com.mckoi.database.MasterTableDataSource
-
Constructs the MasterTableDataSource.
- MasterTableDataSource.MMutableTableDataSource - Class in com.mckoi.database
-
A MutableTableDataSource object as returned by the 'createTableDataSourceAtCommit' method.
- MasterTableDataSource.MRawDiagnosticTable - Class in com.mckoi.database
-
A RawDiagnosticTable implementation that provides direct access to the root data of this table source bypassing any indexing schemes.
- MasterTableGarbageCollector - Class in com.mckoi.database
-
A row garbage collector for a master table data source that manages garbage collection over a MasterTableDataSource object.
- MasterTableGarbageCollector(MasterTableDataSource) - Constructor for class com.mckoi.database.MasterTableGarbageCollector
-
Constructs the garbage collector.
- MasterTableGarbageCollector.CollectionEvent - Class in com.mckoi.database
-
The garbage collection event.
- MasterTableJournal - Class in com.mckoi.database
-
A journal of changes that occured to a table in a data conglomerate during a transaction.
- MasterTableJournal() - Constructor for class com.mckoi.database.MasterTableJournal
- MasterTableJournal(int) - Constructor for class com.mckoi.database.MasterTableJournal
-
Constructs the master table journal.
- MasterTableListener - Interface in com.mckoi.database
-
An interface that is notified of add/remove events on a MasterTableDataSource.
- matchesReference(String, String, String) - Method in class com.mckoi.database.interpret.FromTableDirectSource
- matchesReference(String, String, String) - Method in interface com.mckoi.database.interpret.FromTableInterface
-
Returns true if this source will match the given catalog, schema and table.
- matchesReference(String, String, String) - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
- matchesVar(Variable, String, String, String, String) - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
If the given Variable matches the reference then this method returns true.
- MAX_BIN_SIZE - Static variable in class com.mckoi.store.AbstractStore
- max_block_size - Variable in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
The maximum block size.
- max_block_size - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
The maximum size of the block.
- max_cache_size - Variable in class com.mckoi.util.Cache
-
The maximum number of DataCell objects that can be stored in the cache at any one time.
- MAX_CACHE_SIZE - Variable in class com.mckoi.database.DataCellCache.DCCache
-
The maximum size that the cache can grow to in bytes.
- MAX_CELL_SIZE - Variable in class com.mckoi.database.DataCellCache
-
The maximum size of a DataCell that is allowed to go in the cache.
- MAX_DATABASE_NAME_LENGTH - Static variable in interface com.mckoi.database.DatabaseConstants
-
The maximum length in characters of the string that represents the name of the database.
- MAX_DAYS - Static variable in class com.mckoi.util.GeneralFormatter
- max_field_size - Variable in class com.mckoi.database.jdbc.MStatement
- MAX_HOURS - Static variable in class com.mckoi.util.GeneralFormatter
- MAX_MILLISECONDS - Static variable in class com.mckoi.util.GeneralFormatter
- MAX_MINUTES - Static variable in class com.mckoi.util.GeneralFormatter
- max_pages - Variable in class com.mckoi.store.LoggingBufferManager
-
The maximum number of pages that should be kept in memory before pages are written out to disk.
- MAX_PASSWORD_LENGTH - Static variable in interface com.mckoi.database.DatabaseConstants
-
The maximum length in character of the string that holds a users password.
- MAX_PRIVGROUP_NAME_LENGTH - Static variable in interface com.mckoi.database.DatabaseConstants
-
The maximum length in characters of the string that represents the name of a privaledge group.
- max_row_count - Variable in class com.mckoi.database.jdbc.MResultSet
-
The maximum row count as set in the Statement by the 'setMaxRows' method or 0 if the max row count is not important.
- max_row_count - Variable in class com.mckoi.database.jdbc.MStatement
- MAX_SECONDS - Static variable in class com.mckoi.util.GeneralFormatter
- max_size - Variable in class com.mckoi.database.TBinaryType
-
This constrained size of the binary block of data or -1 if there is no size limit.
- max_size - Variable in class com.mckoi.database.TStringType
-
The maximum allowed size for the string.
- max_size - Variable in class com.mckoi.util.LogWriter
-
The maximum size of the log before it is archived.
- max_slice_size - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
The maximum size a file slice can grow too before a new slice is created.
- MAX_TABLE_NAME_LENGTH - Static variable in interface com.mckoi.database.DatabaseConstants
-
The maximum length in characters of the string that holds the table name.
- MAX_USER_NAME_LENGTH - Static variable in interface com.mckoi.database.DatabaseConstants
-
The maximum length in characters of the string that holds the user name.
- max_value - Variable in class com.mckoi.database.interpret.Sequence
- max_value - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The maximum value of the sequence key.
- MAX_WEEKS - Static variable in class com.mckoi.util.GeneralFormatter
-
These statics represent switches for the visual formatting of the time frame.
- maxBigNumByte - Static variable in class com.mckoi.database.Caster
-
The maximum positive byte value as a BigNumber.
- maxBigNumDouble - Static variable in class com.mckoi.database.Caster
-
The maximum positive double value as a BigNumber.
- maxBigNumFloat - Static variable in class com.mckoi.database.Caster
-
The maximum positive float value as a BigNumber.
- maxBigNumInt - Static variable in class com.mckoi.database.Caster
-
The maximum positive integer value as a BigNumber.
- maxBigNumLong - Static variable in class com.mckoi.database.Caster
-
The maximum positive long value as a BigNumber.
- maxBigNumShort - Static variable in class com.mckoi.database.Caster
-
The maximum positive short value as a BigNumber.
- maxFromEachGroup(int) - Method in class com.mckoi.database.FunctionTable
-
Returns a list of rows that represent the maximum row of the given column from each distinct group in this table.
- MaxFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.MaxFunction
- maximum_commit_id - Variable in class com.mckoi.database.OpenTransactionList
-
The maximum commit id of the current list.
- MAXIMUM_FETCH_SIZE - Static variable in class com.mckoi.database.jdbc.MResultSet
-
The maximum fetch size.
- MAXIMUM_WORKER_THREADS - Variable in class com.mckoi.database.WorkerPool
-
This is the maximum number of worker threads that will be created.
- maxNextCharInd - Variable in class com.mckoi.database.sql.SimpleCharStream
- MAXVALUE - Static variable in interface com.mckoi.database.sql.SQLConstants
- MBlob - Class in com.mckoi.database.jdbc
-
An implementation of an sql.Blob object.
- MBlob(ByteLongObject) - Constructor for class com.mckoi.database.jdbc.MBlob
-
Constructs the blob.
- MByteArrayOutputStream() - Constructor for class com.mckoi.database.jdbc.RemoteDatabaseInterface.MByteArrayOutputStream
- mckoi_protocol_url - Static variable in class com.mckoi.database.jdbc.MDriver
- MckoiConnection - Class in com.mckoi.database.jdbc
-
Wraps a Connection and provides Mckoi specific extensions that are outside the JDBC specification.
- MckoiConnection(Connection) - Constructor for class com.mckoi.database.jdbc.MckoiConnection
-
Constructs the Mckoi specific extension access object.
- McKoiDBMain - Class in com.mckoi.runtime
-
The start point of the Mckoi SQL database server.
- McKoiDBMain() - Constructor for class com.mckoi.runtime.McKoiDBMain
- MClob - Class in com.mckoi.database.jdbc
-
An implementation of java.sql.Clob over a java.util.String object.
- MClob(String) - Constructor for class com.mckoi.database.jdbc.MClob
-
Constructs the Clob implementation.
- MConnection - Class in com.mckoi.database.jdbc
-
JDBC implementation of the connection object to a Mckoi database.
- MConnection(String, DatabaseInterface, int, int) - Constructor for class com.mckoi.database.jdbc.MConnection
-
Constructor.
- MConnection.TriggerDispatchThread - Class in com.mckoi.database.jdbc
-
The thread that handles all dispatching of trigger events.
- MDatabaseMetaData - Class in com.mckoi.database.jdbc
-
An implementation of JDBC's DatabaseMetaData.
- MDatabaseMetaData(MConnection) - Constructor for class com.mckoi.database.jdbc.MDatabaseMetaData
-
Constructor.
- MDriver - Class in com.mckoi.database.jdbc
-
JDBC implementation of the driver for the Mckoi database.
- MDriver() - Constructor for class com.mckoi.database.jdbc.MDriver
-
Constructor is public so that instances of the JDBC driver can be created by developers.
- memory_index_set_list - Variable in class com.mckoi.database.IndexStore
-
The list of SnapshotIndexSet objects returned via the 'getSnapshotIndexSet' method.
- merge(Privileges) - Method in class com.mckoi.database.Privileges
-
Merges privs from the given privilege object with this set of privs.
- mergeIn(Table) - Method in class com.mckoi.database.OuterTable
-
Merges the given table in with this table.
- mergeJournalChanges(long) - Method in class com.mckoi.database.MasterTableDataSource
-
Updates the master records from the journal logs up to the given 'commit_id'.
- mergeJournalChanges(long) - Method in class com.mckoi.database.MultiVersionTableIndices
-
Updates the master records from the journal logs up to the given 'commit_id'.
- mergeTables(Planner.PlanTableSource, Planner.PlanTableSource, QueryPlanNode) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Joins two tables when a plan is generated for joining the two tables.
- mergeWithReference(Variable) - Method in class com.mckoi.database.FunctionTable
-
Returns a Table that is this function table merged with the cross reference table.
- MESSAGE - Static variable in class com.mckoi.debug.Debug
-
Deprecated.
- MESSAGE - Static variable in interface com.mckoi.debug.Lvl
- meta_data - Variable in class com.mckoi.jfccontrols.ResultSetTableModel
-
The ResultSetMetaData object for this result set.
- MILLIS_IN_DAY - Static variable in class com.mckoi.util.GeneralFormatter
- MILLIS_IN_DAY - Static variable in class com.mckoi.util.GeneralParser
- MILLIS_IN_HOUR - Static variable in class com.mckoi.util.GeneralFormatter
- MILLIS_IN_HOUR - Static variable in class com.mckoi.util.GeneralParser
- MILLIS_IN_MINUTE - Static variable in class com.mckoi.util.GeneralFormatter
- MILLIS_IN_MINUTE - Static variable in class com.mckoi.util.GeneralParser
- MILLIS_IN_SECOND - Static variable in class com.mckoi.util.GeneralFormatter
- MILLIS_IN_SECOND - Static variable in class com.mckoi.util.GeneralParser
- MILLIS_IN_WEEK - Static variable in class com.mckoi.util.GeneralFormatter
-
These statics represent some information about how many milliseconds are in various measures of time.
- MILLIS_IN_WEEK - Static variable in class com.mckoi.util.GeneralParser
-
These statics represent some information about how many milliseconds are in various measures of time.
- min_value - Variable in class com.mckoi.database.interpret.Sequence
- min_value - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The minimum value of the sequence key.
- minBigNumByte - Static variable in class com.mckoi.database.Caster
-
The maximum positive byte value as a BigNumber.
- minBigNumFloat - Static variable in class com.mckoi.database.Caster
-
The minimum positive float value as a BigNumber.
- minBigNumInt - Static variable in class com.mckoi.database.Caster
-
The maximum positive integer value as a BigNumber.
- minBigNumLong - Static variable in class com.mckoi.database.Caster
-
The maximum positive long value as a BigNumber.
- minBigNumShort - Static variable in class com.mckoi.database.Caster
-
The maximum positive short value as a BigNumber.
- MinFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.MinFunction
- minimalCreate(String) - Method in class com.mckoi.database.TableDataConglomerate
-
Minimally creates a new conglomerate but does NOT initialize any of the system tables.
- minimalTableDataSource(IntegerListInterface) - Method in class com.mckoi.database.MasterTableDataSource
-
Creates a minimal TableDataSource object that represents this MasterTableDataSource.
- minimum_commit_id - Variable in class com.mckoi.database.OpenTransactionList
-
The minimum commit id of the current list.
- minimumBinSizeIndex(long) - Method in class com.mckoi.store.AbstractStore
-
Returns the bin index that would be the minimum size to store the given object.
- minimumCommitID(Transaction) - Method in class com.mckoi.database.OpenTransactionList
-
Returns the minimum commit id not including the given transaction object.
- MINUTES - Static variable in class com.mckoi.util.TimeFrame
-
Formatting enum.
- MINVALUE - Static variable in interface com.mckoi.database.sql.SQLConstants
- misc - Variable in class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- Misc - Class in com.mckoi.database.interpret
-
Misc statements that I couldn't be bothered to roll a new Statement class for.
- Misc() - Constructor for class com.mckoi.database.interpret.Misc
- MMutableTableDataSource(SimpleTransaction, MasterTableJournal) - Constructor for class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
Constructs the data source.
- ModFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.ModFunction
- modification_listeners - Variable in class com.mckoi.database.TableDataConglomerate
-
All listeners for modification events on tables in this conglomerate.
- modification_lock - Variable in class com.mckoi.database.RIDList
- modified_table_def - Variable in class com.mckoi.database.ReferenceTable
-
The modified DataTableDef object for this reference.
- moveLargeObjectsToBlobStore(DatabaseConnection, PrintStream) - Method in class com.mckoi.database.Database
-
Scans all the user tables for large objects and if a large object is found, it is moved into the BlobStore.
- moveTo(IntegerListBlockInterface, int, int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Moves a set of values from the end of this block and inserts it into the given block at the destination index specified.
- moveTo(IntegerListBlockInterface, int, int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Moves a set of values from the end of this block and inserts it into the given block at the destination index specified.
- moveToCurrentRow() - Method in class com.mckoi.database.jdbc.MResultSet
- moveToInsertRow() - Method in class com.mckoi.database.jdbc.MResultSet
- MPreparedStatement - Class in com.mckoi.database.jdbc
-
An implementation of a JDBC prepared statement.
- MPreparedStatement(MConnection, String) - Constructor for class com.mckoi.database.jdbc.MPreparedStatement
-
Constructs the PreparedStatement.
- MRawDiagnosticTable() - Constructor for class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- MResultSet - Class in com.mckoi.database.jdbc
-
Implementation of a ResultSet.
- MResultSet(MConnection, MStatement) - Constructor for class com.mckoi.database.jdbc.MResultSet
-
Constructor.
- MResultSetMetaData - Class in com.mckoi.database.jdbc
-
An implementation of JDBC's ResultSetmetaData.
- MResultSetMetaData(MResultSet) - Constructor for class com.mckoi.database.jdbc.MResultSetMetaData
-
Constructs the ResultSetMetaData over the given result set.
- MSQLException - Exception in com.mckoi.database.jdbc
-
SQLException used by the McKoi database engine.
- MSQLException() - Constructor for exception com.mckoi.database.jdbc.MSQLException
- MSQLException(String) - Constructor for exception com.mckoi.database.jdbc.MSQLException
- MSQLException(String, String) - Constructor for exception com.mckoi.database.jdbc.MSQLException
- MSQLException(String, String, int) - Constructor for exception com.mckoi.database.jdbc.MSQLException
- MSQLException(String, String, int, String) - Constructor for exception com.mckoi.database.jdbc.MSQLException
-
MSQL Specific.
- MSQLException(String, String, int, Throwable) - Constructor for exception com.mckoi.database.jdbc.MSQLException
-
MSQL Specific.
- MStatement - Class in com.mckoi.database.jdbc
-
An implementation of JDBC Statement.
- MStatement(MConnection) - Constructor for class com.mckoi.database.jdbc.MStatement
-
Constructs the statement.
- MStreamableBlob - Class in com.mckoi.database.jdbc
-
A Blob that is a large object that may be streamed from the server directly to this object.
- MStreamableBlob(MConnection, int, byte, long, long) - Constructor for class com.mckoi.database.jdbc.MStreamableBlob
-
Constructs the blob.
- MStreamableClob - Class in com.mckoi.database.jdbc
-
A Clob that is a large object that may be streamed from the server directly to this object.
- MStreamableClob(MConnection, int, byte, long, long) - Constructor for class com.mckoi.database.jdbc.MStreamableClob
-
Constructs the Clob.
- mul_op - Static variable in class com.mckoi.database.Operator
- multi_result_set_index - Variable in class com.mckoi.database.jdbc.MStatement
-
For multiple result sets, the index of the result set we are currently on.
- MultiColumnEquiSelectNode(QueryPlanNode, Variable[], Expression[]) - Constructor for class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
- multiply(BigNumber) - Method in class com.mckoi.util.BigNumber
- MultiplyOperator() - Constructor for class com.mckoi.database.Operator.MultiplyOperator
- MultiThreadedConnectionPoolServer - Class in com.mckoi.database.jdbcserver
-
A multi-threaded implementation of a connection pool server.
- MultiThreadedConnectionPoolServer(Database) - Constructor for class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer
-
The Constructor.
- MultiThreadedConnectionPoolServer.ClientThread - Class in com.mckoi.database.jdbcserver
-
This thread blocks waiting for a complete command to arrive from the client it is connected to.
- MultiVersionTableIndices - Class in com.mckoi.database
-
This class manages a set of indices for a table over different versions.
- MultiVersionTableIndices(TransactionSystem, TableName, int) - Constructor for class com.mckoi.database.MultiVersionTableIndices
-
Constructs this object with the given number of column.
- mutable_block - Variable in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Set to true if the loaded block is mutable.
- mutable_block - Variable in class com.mckoi.database.IndexStore.MappedListBlock
-
Set to true if the loaded block is mutable.
- mutable_NEW - Variable in class com.mckoi.database.DatabaseConnection.OldNewTableState
-
If true then the 'new_data' information is mutable which would be true for a BEFORE trigger.
- MutableArea - Interface in com.mckoi.store
-
An interface for an area that can be modified.
- MutableTableDataSource - Interface in com.mckoi.database
-
A mutable data source that allows for the addition and removal of rows.
N
- name - Variable in class com.mckoi.database.AbstractFunction
-
The name of the function.
- name - Variable in class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- name - Variable in class com.mckoi.database.Database
-
The name of this database.
- name - Variable in class com.mckoi.database.DataTableColumnDef
-
The name of the column.
- name - Variable in class com.mckoi.database.FunctionDef
-
The name of the function.
- name - Variable in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- name - Variable in class com.mckoi.database.global.ColumnDescription
-
The name of the field.
- name - Variable in class com.mckoi.database.interpret.ByColumn
-
The name of the column in the 'by'.
- name - Variable in class com.mckoi.database.interpret.ColumnDef
- name - Variable in class com.mckoi.database.interpret.ConstraintDef
- name - Variable in class com.mckoi.database.ProcedureName
-
The name of this procedure.
- name - Variable in class com.mckoi.database.SchemaDef
-
The name of the schema (eg.
- name - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The name of this sequence key.
- name - Variable in class com.mckoi.database.StateStore.StateResource
-
The unique name given to the resource to distinguish it from all other resources.
- name - Variable in class com.mckoi.database.TableDataConglomerate
-
The name given to this conglomerate.
- name - Variable in class com.mckoi.database.Transaction.CheckExpression
-
The name of the check expression (the constraint name).
- name - Variable in class com.mckoi.database.Transaction.ColumnGroup
-
The name of the group (the constraint name).
- name - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The name of the group (the constraint name).
- name - Variable in class com.mckoi.store.JournalledSystem.AbstractResource
-
The unique name given this resource (the file name).
- name - Variable in class com.mckoi.store.LoggingBufferManager.BResource
-
The unique name of the resource within the store.
- NAME - Static variable in class com.mckoi.database.global.StandardMessages
-
The global name of the system.
- NAME - Static variable in interface com.mckoi.database.sql.SQLConstants
- name_list - Variable in class com.mckoi.database.QueryPlan.CreateFunctionsNode
-
The list of names to give each function table.
- name_list - Variable in class com.mckoi.database.QueryPlan.GroupNode
-
The list of names to give each function table.
- name_store_map - Variable in class com.mckoi.database.V1HeapStoreSystem
-
A mapping from name to Store object for this heap store system.
- namespace_journal_list - Variable in class com.mckoi.database.TableDataConglomerate
-
The list of all name space journals for the history of committed transactions.
- NameSpaceJournal(long, ArrayList, ArrayList) - Constructor for class com.mckoi.database.TableDataConglomerate.NameSpaceJournal
-
Constructs the journal.
- NaN - Static variable in class com.mckoi.util.BigNumber
- NaN_STATE - Static variable in class com.mckoi.util.BigNumber
- nativeSQL(String) - Method in class com.mckoi.database.jdbc.MConnection
- NATURAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- naturalJoinAll() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Naturally joins all remaining tables sources to make a final single plan which is returned.
- NaturalJoinNode(QueryPlanNode, QueryPlanNode) - Constructor for class com.mckoi.database.QueryPlan.NaturalJoinNode
- NaturallyJoinedTable - Class in com.mckoi.database
-
A table that is the cartesian product of two tables.
- NaturallyJoinedTable(Table, Table) - Constructor for class com.mckoi.database.NaturallyJoinedTable
-
Constructs the table.
- naturallyJoinPlans(Planner.PlanTableSource, Planner.PlanTableSource) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Naturally joins two PlanTableSource objects in this planner.
- NEG_INF_STATE - Static variable in class com.mckoi.util.BigNumber
-
State enumerations.
- NEGATIVE_INFINITY - Static variable in class com.mckoi.util.BigNumber
-
Statics for negative infinity, positive infinity and NaN.
- neq_op - Static variable in class com.mckoi.database.Operator
- NEW - Static variable in interface com.mckoi.database.sql.SQLConstants
- new_column_names - Variable in class com.mckoi.database.QueryPlan.SubsetNode
-
New names to assign the columns.
- NEW_data_table - Variable in class com.mckoi.database.DatabaseConnection.OldNewTableState
-
The DataTable object that represents the NEW table, if set.
- NEW_row_data - Variable in class com.mckoi.database.DatabaseConnection.OldNewTableState
-
The RowData of the new data that is being inserted/updated in the trigger source table.
- NEW_TRIGGER_TABLE - Static variable in class com.mckoi.database.Database
-
The NEW table used inside a triggered procedure to represent a triggered row after the operation occurs.
- newListBlock() - Method in class com.mckoi.database.IndexSetStore.IndexIntegerList
-
Creates a new block for the list.
- newListBlock() - Method in class com.mckoi.database.IndexStore.IndexIntegerList
-
Creates a new block for the list.
- newListBlock() - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Creates a new ListBlock for the given implementation.
- newListBlock() - Method in class com.mckoi.util.BlockIntegerList
-
Creates a new ListBlock to fill with ints.
- newRow() - Method in class com.mckoi.database.TemporaryTable
-
Creates a new row where cells can be inserted into.
- newToken(int) - Static method in class com.mckoi.database.sql.Token
-
Returns a new Token object, by default.
- newTopJournalFile() - Method in class com.mckoi.store.JournalledSystem
-
Creates a new top journal file.
- next - Variable in class com.mckoi.database.sql.SQL.JJCalls
- next - Variable in class com.mckoi.database.sql.Token
-
A reference to the next regular (non-special) token from the input stream.
- next - Variable in class com.mckoi.util.Cache.ListNode
-
Links to the next and previous nodes.
- next - Variable in class com.mckoi.util.IntegerListBlockInterface
-
The next block in the chain.
- next() - Method in class com.mckoi.database.jdbc.MResultSet
- next() - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- next() - Method in interface com.mckoi.util.IntegerIterator
-
Returns the next element in the list.
- next_composite - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The composite table itself.
- next_hash_element - Variable in class com.mckoi.store.HeapStore.HeapAreaElement
-
The pointer to the next HeapAreaElement in this hash key.
- next_hash_entry - Variable in class com.mckoi.util.Cache.ListNode
-
The next node in the hash link on this hash value, or 'null' if last hash entry.
- next_page - Variable in class com.mckoi.store.JournalledSystem.JournalEntry
-
The next journal entry with the same page number
- nextAssignment() - Method in class com.mckoi.database.RowData.RDVariableResolver
- nextCommandFromServer(int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
-
Blocks until the next command is received from the server.
- nextCommandFromServer(int) - Method in class com.mckoi.database.jdbc.StreamDatabaseInterface
-
Blocks until the next command is received from the server.
- nextDispatchID() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Returns a unique dispatch id number for a command.
- nextQuery() - Method in class com.mckoi.tools.JDBCScriptTool
-
Fetches the next query from the input.
- nextRowIndex() - Method in interface com.mckoi.database.RowEnumeration
-
Returns the next row index from the enumeration.
- nextRowIndex() - Method in class com.mckoi.database.SimpleRowEnumeration
- nextSequenceValue(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Requests of the sequence generator the next value from the sequence.
- nextSequenceValue(String) - Method in class com.mckoi.database.DatabaseConnection
-
Requests of the sequence generator the next value from the sequence.
- nextSequenceValue(String) - Method in class com.mckoi.database.DatabaseQueryContext
-
Increments the sequence generator and returns the next unique key.
- nextSequenceValue(String) - Method in interface com.mckoi.database.QueryContext
-
Increments the sequence generator and returns the next unique key.
- nextSequenceValue(String) - Method in class com.mckoi.database.SystemQueryContext
-
Increments the sequence generator and returns the next unique key.
- nextTableID() - Method in class com.mckoi.database.StateStore
-
Returns the next table id and increments the table_id counter.
- nextUniqueID() - Method in class com.mckoi.database.IndexStore
-
Atomically returns the next 'unique_id' value from this file.
- nextUniqueID() - Method in class com.mckoi.database.MasterTableDataSource
-
Atomically returns the next 'unique_id' value from this table.
- nextUniqueID() - Method in class com.mckoi.database.V1MasterTableDataSource
- nextUniqueID() - Method in class com.mckoi.database.V2MasterTableDataSource
- nextUniqueID(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns the next unique identifier for the given table from the schema.
- nextUniqueID(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Atomically returns a unique id that can be used as a seed for a set of unique identifiers for a table.
- nextUniqueID(String) - Method in class com.mckoi.database.DatabaseConnection
-
Returns the next unique identifier for the given table in the connection schema.
- nextUniqueID(String) - Method in class com.mckoi.database.SystemQueryContext
-
Returns a unique key for the given table source in the database.
- nextUniqueKey() - Method in interface com.mckoi.database.DataTableFile
-
Returns a unique number.
- nextUniqueTableID() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the next unique table_id value for a new table and updates the conglomerate state information as appropriate.
- NextValFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.NextValFunction
- nextValue(SimpleTransaction, TableName) - Method in class com.mckoi.database.SequenceManager
-
Returns the next value from the sequence generator.
- nin_op - Static variable in class com.mckoi.database.Operator
- nlike_op - Static variable in class com.mckoi.database.Operator
- NO - Static variable in interface com.mckoi.database.sql.SQLConstants
- NO_ACTION - Static variable in class com.mckoi.database.Transaction
-
Foreign key referential trigger actions.
- NO_DECOMPOSITION - Static variable in interface com.mckoi.database.sql.SQLConstants
- noColumnCopy() - Method in class com.mckoi.database.DataTableDef
-
Returns a copy of this object, except with no columns or constraints.
- node_hash - Variable in class com.mckoi.util.Cache
-
The array of ListNode objects arranged by hashing value.
- nodeCount() - Method in class com.mckoi.util.Cache
-
Returns the number of nodes that are currently being stored in the cache.
- nonBooleanExpression(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
-
Parses a non-boolean expression.
- NonCorrelatedAnyAllNode(QueryPlanNode, QueryPlanNode, Variable[], Operator) - Constructor for class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
- NONE - Static variable in class com.mckoi.database.Operator
-
The ANY and ALL enumerator.
- NonLoggingResource(String, long, StoreDataAccessor) - Constructor for class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Constructs the resource.
- NoOp - Class in com.mckoi.database.interpret
-
A no operation statement.
- NoOp() - Constructor for class com.mckoi.database.interpret.NoOp
- norm_added_rows - Variable in class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- norm_removed_rows - Variable in class com.mckoi.database.TableDataConglomerate.CommitTableInfo
- normalize(Expression) - Static method in class com.mckoi.database.sql.Util
-
Normalizes the Expression by removing all NOT operators and altering the expression as appropriate.
- normalize(Expression, boolean) - Static method in class com.mckoi.database.sql.Util
-
Normalizes the Expression by removing all NOT operators and altering the expression as appropriate.
- normalizedAddedRows() - Method in class com.mckoi.database.MasterTableJournal
-
Returns a normalized list of all rows that were added in this journal, but not including those rows also removed.
- normalizedRemovedRows() - Method in class com.mckoi.database.MasterTableJournal
-
Returns a normalized list of all rows that were removed from this journal.
- NOT - Static variable in interface com.mckoi.database.sql.SQLConstants
- NOT_DEFERRABLE - Static variable in class com.mckoi.database.Transaction
- not_null - Variable in class com.mckoi.database.global.ColumnDescription
-
If true, the field may not be null.
- not_null - Variable in class com.mckoi.database.interpret.ColumnDef
- not_op - Static variable in class com.mckoi.database.Operator
- NOTEQ - Static variable in interface com.mckoi.database.sql.SQLConstants
- NotEqualOperator() - Constructor for class com.mckoi.database.Operator.NotEqualOperator
- notifyAddRWLock(int) - Method in class com.mckoi.database.DataTable
-
This is called by the 'Lock' class to notify this DataTable that a read/ write lock has been applied to this table.
- notifyComplete(PreparedStatement, ResultSet) - Method in class com.mckoi.jfccontrols.QueryAgent
-
This is called when a query has finished and a valid ResultSet was returned as the result.
- notifyException(PreparedStatement, SQLException) - Method in class com.mckoi.jfccontrols.QueryAgent
-
This is called when a query has finished and an SQLException was thrown.
- notifyGetWalks(long, long) - Method in class com.mckoi.database.DataCellCache.DCCache
- notifyGetWalks(long, long) - Method in class com.mckoi.util.Cache
-
Notifies that some statistical information about the hash map has updated.
- notifyPostRecover() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- notifyPostRecover() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
- notifyPostRecover() - Method in class com.mckoi.store.JournalledSystem.Resource
- notifyReleaseRWLock(int) - Method in class com.mckoi.database.DataTable
-
This is called by the 'Lock' class to notify this DataTable that a read/ write lock has been released from this table.
- notifyTriggerEvent(TriggerEvent) - Method in class com.mckoi.database.DatabaseConnection
-
Informs the underlying transaction that a high level transaction event has occurred and should be dispatched to any listeners occordingly.
- notifyWipingNode(Object) - Method in class com.mckoi.database.DataCellCache.DCCache
- notifyWipingNode(Object) - Method in class com.mckoi.util.Cache
-
Notifies that the given object has been wiped from the cache by the clean up procedure.
- notifyWorkerReady(WorkerThread) - Method in class com.mckoi.database.WorkerPool
-
This is called by a WorkerThread when it is decided that it is ready to service a new command.
- notIn(Table, Table, int[], int[]) - Static method in class com.mckoi.database.INHelper
-
A multi-column version of NOT IN.
- notIn(Table, Table, int, int) - Static method in class com.mckoi.database.INHelper
-
This implements the 'not_in' command.
- notInUse() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Returns true if this PageBuffer is not in use (has 0 reference count and is not inialized.
- NULL - Static variable in interface com.mckoi.database.global.SQLTypes
- NULL_LITERAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- NULL_OBJ - Static variable in class com.mckoi.database.global.NullObject
-
Deprecated.
- NULL_OBJECT - Static variable in class com.mckoi.database.TObject
- NULL_TYPE - Static variable in class com.mckoi.database.TType
-
A default NULL type.
- NULLABLE_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
A Nullable constraint violation error code (data added to not null columns that was null).
- nullLog() - Static method in class com.mckoi.util.Log
-
Returns a Log that won't actually store a log.
- NullLog - Class in com.mckoi.util
-
An implementation of Log that doesn't log anything.
- NullLog() - Constructor for class com.mckoi.util.NullLog
- NullObject - Class in com.mckoi.database.global
-
Deprecated.do not use. Nulls are now handled via TObject and TType. This method is only kept around for legacy with older databases.
- NullObject() - Constructor for class com.mckoi.database.global.NullObject
-
Deprecated.
- nullPlusNonNullIsNull() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- nullsAreSortedAtEnd() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- nullsAreSortedAtStart() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- nullsAreSortedHigh() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- nullsAreSortedLow() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- nullVal() - Static method in class com.mckoi.database.TObject
-
Returns a TObject of NULL type that represents a null value.
- NUMBER_LITERAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- number_state - Variable in class com.mckoi.util.BigNumber
-
The state of the number, either 0 for number is the BigDecimal, 1 for negative infinity, 2 for positive infinity and 3 for NaN.
- NUMERIC - Static variable in interface com.mckoi.database.global.SQLTypes
- NUMERIC - Static variable in interface com.mckoi.database.sql.SQLConstants
- NUMERIC_TYPE - Static variable in class com.mckoi.database.TType
-
A default numeric (SQL NUMERIC) type of unlimited size and scale.
- numericColumn(String) - Static method in class com.mckoi.database.GTDataSource
- NumericOperator(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- numericType(int, int, int) - Static method in class com.mckoi.database.TType
-
Returns a TNumericType object of the given size and scale.
O
- ob - Variable in class com.mckoi.database.TObject
-
The Java representation of the object.
- ob_p - Variable in class com.mckoi.database.BlobStore.CopyBlobInfo
- object - Variable in class com.mckoi.database.GrantManager.GrantQuery
- OBJECT_COST - Static variable in class com.mckoi.database.Caster
-
The cost to cast to the closes Java object type.
- ObjectTransfer - Class in com.mckoi.database.global
-
Provides static methods for transfering different types of objects over a Data input/output stream.
- ObjectTransfer() - Constructor for class com.mckoi.database.global.ObjectTransfer
- ObjectTranslator - Class in com.mckoi.database.global
-
This object compliments ObjectTransfer and provides a method to translate any object into a type the database engine can process.
- ObjectTranslator() - Constructor for class com.mckoi.database.global.ObjectTranslator
- objectVal(Object) - Static method in class com.mckoi.database.TObject
-
Returns a TObject from the given Java value.
- OLD - Static variable in interface com.mckoi.database.sql.SQLConstants
- OLD_data_table - Variable in class com.mckoi.database.DatabaseConnection.OldNewTableState
-
The DataTable object that represents the OLD table, if set.
- old_new_table_info - Variable in class com.mckoi.database.DatabaseConnection
-
A local member that represents the OLD and NEW system tables that represent the OLD and NEW data in a triggered action.
- OLD_row_index - Variable in class com.mckoi.database.DatabaseConnection.OldNewTableState
-
The row index of the OLD data that is being updated or deleted in the trigger source table.
- OLD_TRIGGER_TABLE - Static variable in class com.mckoi.database.Database
-
The OLD table used inside a triggered procedure to represent a triggered row before the operation occurs.
- OldAndNewInternalTableInfo() - Constructor for class com.mckoi.database.DatabaseConnection.OldAndNewInternalTableInfo
- OldNewTableState() - Constructor for class com.mckoi.database.DatabaseConnection.OldNewTableState
-
Default constructor.
- OldNewTableState(TableName, int, RowData, boolean) - Constructor for class com.mckoi.database.DatabaseConnection.OldNewTableState
-
Constructor.
- ON - Static variable in interface com.mckoi.database.sql.SQLConstants
- on_expression - Variable in class com.mckoi.database.JoiningSet.JoinPart
-
The expression that we are joining on (eg.
- on_object - Variable in class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- ONE_CHAR - Static variable in class com.mckoi.database.PatternSearch
- ONE_LIST - Static variable in class com.mckoi.database.SelectableScheme
- ONE_VAL - Static variable in class com.mckoi.database.SequenceManager
-
A static TObject that represents numeric 1.
- only_if_exists - Variable in class com.mckoi.database.interpret.DropTable
-
Only create if table doesn't exist.
- only_if_not_exists - Variable in class com.mckoi.database.interpret.CreateTable
-
Only create if table doesn't exist.
- op - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSelectExpressionPlan
- op - Variable in class com.mckoi.database.Operator
-
A string that represents this operator.
- op - Variable in class com.mckoi.database.QueryPlan.SimpleSelectNode
-
The operator to select under (=, <>, >, <, >=, <=).
- open - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
Set when the store is openned.
- open() - Method in class com.mckoi.store.AbstractStore
-
Opens the data store.
- open(boolean) - Method in class com.mckoi.database.FixedSizeDataStore
-
Opens the data store.
- open(boolean) - Method in class com.mckoi.database.IndexStore
-
Opens this index store.
- open(boolean) - Method in class com.mckoi.database.VariableSizeDataStore
-
Opens the data store.
- open(boolean) - Method in class com.mckoi.store.IOStoreDataAccessor
- open(boolean) - Method in interface com.mckoi.store.JournalledResource
-
Opens the resource.
- open(boolean) - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Opens the resource.
- open(boolean) - Method in class com.mckoi.store.JournalledSystem.Resource
-
Opens the resource.
- open(boolean) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- open(boolean) - Method in interface com.mckoi.store.StoreDataAccessor
-
Opens the underlying data area representation.
- open(long) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Opens the journal file.
- open(String) - Method in class com.mckoi.database.TableDataConglomerate
-
Opens a conglomerate.
- open(String) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Opens an existing master table from the file system at the path of the conglomerate this belongs to.
- open(String) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Opens an existing master table from the file system at the path of the conglomerate this belongs to.
- open_connections - Variable in class com.mckoi.database.jdbcserver.DefaultLocalBootable
-
The number of connections that are current open.
- open_for_write - Variable in class com.mckoi.database.BlobStore.AbstractRef
-
Set to true if this large object is open for writing, otherwise the object is an immutable static object.
- open_transaction_stacks - Variable in class com.mckoi.database.OpenTransactionList
-
A list of Error objects created when the transaction is added to the open transactions list.
- open_transactions - Variable in class com.mckoi.database.MasterTableDataSource
-
The list of all open transactions managed by the parent conglomerate.
- open_transactions - Variable in class com.mckoi.database.OpenTransactionList
-
The list of open transactions.
- open_transactions - Variable in class com.mckoi.database.TableDataConglomerate
-
The list of transactions that are currently open over this conglomerate.
- openForRecovery() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Opens the journal for recovery.
- openScanAndFix(UserTerminal) - Method in class com.mckoi.store.AbstractStore
-
Opens/scans the store looking for any errors with the layout.
- openStore(String) - Method in interface com.mckoi.database.StoreSystem
-
Opens an existing persistent Store object in the system and returns the Store object that contains its data.
- openStore(String) - Method in class com.mckoi.database.V1FileStoreSystem
- openStore(String) - Method in class com.mckoi.database.V1HeapStoreSystem
- OpenTransactionList - Class in com.mckoi.database
-
The list of all currently open transactions.
- OpenTransactionList(TransactionSystem) - Constructor for class com.mckoi.database.OpenTransactionList
-
Creates the list.
- Operand(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- Operator - Class in com.mckoi.database
-
An operator for an expression.
- Operator(String) - Constructor for class com.mckoi.database.Operator
-
Constructs the Operator.
- Operator(String, int) - Constructor for class com.mckoi.database.Operator
- Operator(String, int, int) - Constructor for class com.mckoi.database.Operator
- Operator.AddOperator - Class in com.mckoi.database
- Operator.AllOperator - Class in com.mckoi.database
- Operator.AndOperator - Class in com.mckoi.database
- Operator.AnyOperator - Class in com.mckoi.database
- Operator.ConcatOperator - Class in com.mckoi.database
- Operator.DivideOperator - Class in com.mckoi.database
- Operator.EqualOperator - Class in com.mckoi.database
- Operator.GreaterEqualOperator - Class in com.mckoi.database
- Operator.GreaterOperator - Class in com.mckoi.database
- Operator.IsNotOperator - Class in com.mckoi.database
- Operator.IsOperator - Class in com.mckoi.database
- Operator.LesserEqualOperator - Class in com.mckoi.database
- Operator.LesserOperator - Class in com.mckoi.database
- Operator.MultiplyOperator - Class in com.mckoi.database
- Operator.NotEqualOperator - Class in com.mckoi.database
- Operator.OrOperator - Class in com.mckoi.database
- Operator.ParenOperator - Class in com.mckoi.database
- Operator.PatternMatchFalseOperator - Class in com.mckoi.database
- Operator.PatternMatchTrueOperator - Class in com.mckoi.database
- Operator.RegexOperator - Class in com.mckoi.database
- Operator.SimpleOperator - Class in com.mckoi.database
- Operator.SubtractOperator - Class in com.mckoi.database
- operatorAdd(TObject) - Method in class com.mckoi.database.TObject
-
Mathematical addition of this object to the given object.
- operatorConcat(TObject) - Method in class com.mckoi.database.TObject
-
String concat of this object to the given object.
- operatorDivide(TObject) - Method in class com.mckoi.database.TObject
-
Mathematical division of this object to the given object.
- operatorEquals(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorGreater(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorGreaterEquals(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorIs(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorLess(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorLessEquals(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorMultiply(TObject) - Method in class com.mckoi.database.TObject
-
Mathematical multiply of this object to the given object.
- operatorNot() - Method in class com.mckoi.database.TObject
-
Performs a logical NOT on this value.
- operatorNotEquals(TObject) - Method in class com.mckoi.database.TObject
-
Comparison of this object and the given object.
- operatorOr(TObject) - Method in class com.mckoi.database.TObject
-
Bitwise OR operation of this object with the given object.
- operatorSubtract(TObject) - Method in class com.mckoi.database.TObject
-
Mathematical subtraction of this object to the given object.
- OpPart(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- OPT_last_col - Variable in class com.mckoi.database.V1MasterTableDataSource
- OPT_last_row - Variable in class com.mckoi.database.V1MasterTableDataSource
-
Some variables that are used for optimization in the 'getCellContents' method.
- OPT_last_skip_offset - Variable in class com.mckoi.database.V1MasterTableDataSource
- optimisedPostSet(int) - Method in class com.mckoi.database.JoinedTable
-
This is an optimisation that should only be called _after_ a 'set' method has been called.
- optimizable_value - Variable in class com.mckoi.database.interpret.Planner.ExpressionPlan
-
How optimizable an expression is.
- OPTIMIZE - Static variable in interface com.mckoi.database.sql.SQLConstants
- OPTION - Static variable in interface com.mckoi.database.sql.SQLConstants
- OR - Static variable in interface com.mckoi.database.sql.SQLConstants
- or_op - Static variable in class com.mckoi.database.Operator
- order_by - Variable in class com.mckoi.database.interpret.Select
-
The list of all columns to order by.
- order_cols - Variable in class com.mckoi.database.interpret.Select
-
The list of columns in the 'order_by' clause fully resolved.
- ORDERBY - Static variable in interface com.mckoi.database.sql.SQLConstants
- orderByColumn(int, boolean) - Method in class com.mckoi.database.Table
-
Returns a Table which is identical to this table, except it is sorted by the given column name.
- orderByColumn(Variable) - Method in class com.mckoi.database.Table
- orderByColumn(Variable, boolean) - Method in class com.mckoi.database.Table
- orderByColumns(int[]) - Method in class com.mckoi.database.Table
-
Returns a table that is ordered by the given column numbers.
- orderedRowList(int[]) - Method in class com.mckoi.database.Table
-
Returns an IntegerVector that represents the list of rows in this table in sorted order by the given column map.
- OrderingSpec() - Method in class com.mckoi.database.sql.SQL
- origIn(Table, Table, int, int) - Static method in class com.mckoi.database.INHelper
-
This implements the 'in' command.
- original_check_expression - Variable in class com.mckoi.database.interpret.ConstraintDef
- original_columns - Variable in class com.mckoi.database.QueryPlan.SubsetNode
-
The original columns in the child that we are to make the subset of.
- original_default_expression - Variable in class com.mckoi.database.interpret.ColumnDef
- OrOperator() - Constructor for class com.mckoi.database.Operator.OrOperator
- OTHER - Static variable in interface com.mckoi.database.global.SQLTypes
- othersDeletesAreVisible(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- othersInsertsAreVisible(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- othersUpdatesAreVisible(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- out - Variable in class com.mckoi.database.jdbc.StreamDatabaseInterface
-
The data output stream for the db protocol.
- out - Variable in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
The output stream to the client formatted as a DataOutputStream.
- out - Static variable in class com.mckoi.debug.Debug
-
Deprecated.The print stream where the debugging information is output to.
- out - Variable in class com.mckoi.debug.DefaultDebugLogger
-
The print stream where the debugging information is output to.
- out - Variable in class com.mckoi.tools.JDBCScriptTool
-
The Writer we are outputing the script results to.
- out - Variable in class com.mckoi.util.LogWriter
-
The log file FileWriter.
- OUTER - Static variable in interface com.mckoi.database.sql.SQLConstants
- outer_row_count - Variable in class com.mckoi.database.OuterTable
-
The row count of the outer rows.
- outer_rows - Variable in class com.mckoi.database.OuterTable
-
The merged rows.
- OuterTable - Class in com.mckoi.database
-
A Table class for forming OUTER type results.
- OuterTable(Table) - Constructor for class com.mckoi.database.OuterTable
-
Constructs the OuterTable given the base table.
- OUTPUT_BUFFER_SIZE - Static variable in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
The size in bytes of the buffer used for writing information onto the output stream to the client.
- output_stream - Variable in class com.mckoi.store.StreamFile
-
The OutputStream object for this file.
- outside(Table) - Method in class com.mckoi.database.Table
-
Finds all rows in this table that are 'outside' the result in the given table.
- overwriteSector(int, byte[]) - Method in class com.mckoi.database.FixedSizeDataStore
-
Writes the contents of a sector into the store overwritting any other information that may be stored there.
- overwriteSector(int, byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Writes the contents of a sector into the store overwritting any other information that may be stored there.
- ownDeletesAreVisible(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- ownInsertsAreVisible(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- ownUpdatesAreVisible(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
P
- paddedString(String, int) - Static method in class com.mckoi.database.global.CastHelper
-
Returns the given string padded or truncated to the given size.
- page - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The page number.
- page_buffer - Variable in class com.mckoi.store.JournalledSystem.Resource
-
A temporary buffer the size of a page.
- PAGE_CACHE_COMPARATOR - Variable in class com.mckoi.store.LoggingBufferManager
-
A Comparator used to sort cache entries.
- page_list - Variable in class com.mckoi.store.LoggingBufferManager
-
The list of all pages.
- page_map - Variable in class com.mckoi.store.LoggingBufferManager
-
A hash map of all pages currently in memory keyed by store_id and page number.
- page_number - Variable in class com.mckoi.store.JournalledSystem.JournalEntry
-
The page number of this modification.
- page_size - Variable in class com.mckoi.store.JournalledSystem
-
The page size.
- page_size - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The size of the page.
- page_size - Variable in class com.mckoi.store.LoggingBufferManager
-
The size of each page.
- pageAccessed(LoggingBufferManager.BMPage) - Method in class com.mckoi.store.LoggingBufferManager
-
Called when a page is accessed.
- pageCreated(LoggingBufferManager.BMPage) - Method in class com.mckoi.store.LoggingBufferManager
-
Called when a new page is created.
- PagedInputStream - Class in com.mckoi.util
-
An implementation of InputStream that reads data from an underlying representation in fixed sized pages.
- PagedInputStream(int, long) - Constructor for class com.mckoi.util.PagedInputStream
-
Constructs the input stream.
- par1_op - Static variable in class com.mckoi.database.Operator
- par2_op - Static variable in class com.mckoi.database.Operator
- param - Variable in class com.mckoi.database.GrantManager.GrantQuery
- parameter_count - Variable in class com.mckoi.database.jdbc.SQLQuery
- parameter_id - Variable in class com.mckoi.database.ParameterSubstitution
-
The numerical number of this parameter substitution.
- parameter_id - Variable in class com.mckoi.database.sql.SQL
-
The parameter id.
- PARAMETER_REF - Static variable in interface com.mckoi.database.sql.SQLConstants
- parameterCount() - Method in class com.mckoi.database.AbstractFunction
-
Returns the number of parameters for this function.
- parameterCount() - Method in class com.mckoi.jfccontrols.Query
-
Returns the number of parameters.
- parameters - Variable in class com.mckoi.database.jdbc.SQLQuery
-
The list of all variable substitutions that are in the query.
- parameters - Variable in class com.mckoi.jfccontrols.Query
-
The parameters of the query (if any).
- parameters_index - Variable in class com.mckoi.database.jdbc.SQLQuery
- ParameterSubstitution - Class in com.mckoi.database
-
An object that represents a constant value that is to be lately binded to a constant value in an Expression.
- ParameterSubstitution(int) - Constructor for class com.mckoi.database.ParameterSubstitution
-
Creates the substitution.
- params - Variable in class com.mckoi.database.AbstractFunction
-
The list of expressions this function has as parameters.
- params - Variable in class com.mckoi.database.FunctionDef
-
The list of parameters for the function.
- PARANOID_CHECKS - Static variable in class com.mckoi.store.LoggingBufferManager
-
Set to true for extra assertions.
- ParenOperator(String) - Constructor for class com.mckoi.database.Operator.ParenOperator
- parent - Variable in class com.mckoi.database.DataTableFilter
-
The parent DataTable object.
- parent - Variable in class com.mckoi.database.FilterTable
-
The Table we are filtering the columns from.
- parent - Variable in class com.mckoi.database.interpret.TableExpressionFromSet
-
The parent TableExpressionFromSet if one exists.
- parent_block - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
The parent IndexBlock.
- parent_stream - Variable in class com.mckoi.database.CellInputStream
-
The parent input stream.
- parent_table - Variable in class com.mckoi.database.LockingQueue
-
The DataTable this queue is 'protecting'
- parse(String) - Static method in class com.mckoi.database.Expression
-
Static method that parses the given string which contains an expression into an Expression object.
- parse(String) - Static method in class com.mckoi.util.TimeFrame
-
Parses the given String and returns a TimeFrame object that represents the date.
- parseBigDecimal(CharacterIterator) - Static method in class com.mckoi.util.GeneralParser
-
This assumes there is a decimal number waiting on the iterator.
- parseDigitString(CharacterIterator, StringBuffer) - Static method in class com.mckoi.util.GeneralParser
-
Parses a string of 0 or more digits and appends the digits into the string buffer.
- parseEncodedVariables(String, Properties) - Static method in class com.mckoi.database.jdbc.MDriver
-
Given a URL encoded arguments string, this will extract the var=value pairs and put them in the given Properties object.
- ParseException - Exception in com.mckoi.database.sql
-
This exception is thrown when parse errors are encountered.
- ParseException() - Constructor for exception com.mckoi.database.sql.ParseException
-
The following constructors are for use by you for whatever purpose you can think of.
- ParseException(Token, int[][], String[]) - Constructor for exception com.mckoi.database.sql.ParseException
-
This constructor is used by the method "generateParseException" in the generated parser.
- ParseException(String) - Constructor for exception com.mckoi.database.sql.ParseException
- parseExpression() - Method in class com.mckoi.database.sql.SQL
- parseFileString(File, String, String) - Static method in class com.mckoi.database.TransactionSystem
-
Parses a file string to an absolute position in the file system.
- parseJavaLocationString(String) - Static method in class com.mckoi.database.ProcedureManager
-
Given a location string as defined for a Java stored procedure, this parses the string into the various parts.
- parseNumberToken(Token, boolean) - Static method in class com.mckoi.database.sql.Util
-
Parses a NUMBER_LITERAL Token with a sign boolean.
- parseQuotedString(String) - Static method in class com.mckoi.database.TType
-
Returns the value of a string that is quoted.
- parseString(String) - Static method in class com.mckoi.database.Privileges
-
Given a string, returns the priv bit for it.
- parseTimeMeasure(CharacterIterator) - Static method in class com.mckoi.util.GeneralParser
-
Parses a time grammer waiting on the character iterator.
- parseWordString(CharacterIterator, StringBuffer) - Static method in class com.mckoi.util.GeneralParser
-
Parses a string of 0 or more words and appends the characters into the string buffer.
- part_contents - Variable in class com.mckoi.database.jdbc.StreamableObjectPart
-
The byte[] array that is the contents of the cell from the server.
- PASSWORD - Static variable in interface com.mckoi.database.sql.SQLConstants
- path - Variable in class com.mckoi.database.V1FileStoreSystem
-
The path in the filesystem where the data files are located.
- path - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
The path of this store in the file system.
- patternMatch(String, String, char) - Static method in class com.mckoi.database.PatternSearch
-
This is the pattern match recurrsive method.
- PatternMatchFalseOperator() - Constructor for class com.mckoi.database.Operator.PatternMatchFalseOperator
- PatternMatchTrueOperator() - Constructor for class com.mckoi.database.Operator.PatternMatchTrueOperator
- PatternSearch - Class in com.mckoi.database
-
This is a static class that performs the operations to do a pattern search on a given column of a table.
- PatternSearch() - Constructor for class com.mckoi.database.PatternSearch
- pending_connections_list - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
The list of ServerConnection objects that are pending to be added into the current service provider list next time it is checked.
- performCollectionEvent(boolean) - Method in class com.mckoi.database.MasterTableGarbageCollector
-
Performs the actual garbage collection event.
- performTriggerAction(TableModificationEvent) - Method in class com.mckoi.database.ConnectionTriggerManager
-
Performs any trigger action for this event.
- period - Variable in class com.mckoi.util.TimeFrame
-
A BigDecimal that represents the number of milliseconds the time frame represents.
- permits(int) - Method in class com.mckoi.database.Privileges
-
Returns true if this privileges permits the given priv.
- persist(long, long) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Plays the log from the given offset in the file to the next checkpoint.
- persistArchives(int) - Method in class com.mckoi.store.JournalledSystem.JournalingThread
-
Persists the journal_archives list until the list is at least the given size.
- persistClose() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- persistClose() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
- persistClose() - Method in class com.mckoi.store.JournalledSystem.Resource
- persistDelete() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- persistDelete() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
- persistDelete() - Method in class com.mckoi.store.JournalledSystem.Resource
- PERSISTENT_VAR_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- persistOpen(boolean) - Method in class com.mckoi.store.JournalledSystem.Resource
- persistPageChange(long, int, int, DataInputStream) - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- persistPageChange(long, int, int, DataInputStream) - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
- persistPageChange(long, int, int, DataInputStream) - Method in class com.mckoi.store.JournalledSystem.Resource
- persistSetSize(long) - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- persistSetSize(long) - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
- persistSetSize(long) - Method in class com.mckoi.store.JournalledSystem.Resource
- physicalRecordCount() - Method in class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- physicalRecordCount() - Method in interface com.mckoi.database.RawDiagnosticTable
-
Returns the number of physical records in the table.
- ping() - Method in interface com.mckoi.database.jdbcserver.ServerConnection
-
Pings the connection.
- ping() - Method in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
Pings the client to check it's still alive.
- PING - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Ping command.
- PING_BREAK - Static variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
The number of milliseconds between client pings.
- placeIntAt(int, int) - Method in class com.mckoi.util.IntegerVector
-
Places an int at the given position, overwriting anything that was previously there.
- plan - Variable in class com.mckoi.database.interpret.Delete
-
The plan for the set of records we are deleting in this query.
- plan - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
-
The Plan for this table source.
- plan - Variable in class com.mckoi.database.interpret.Select
-
The plan for evaluating this select expression.
- plan - Variable in class com.mckoi.database.interpret.UpdateTable
-
The plan for the set of records we are updating in this query.
- plan - Variable in class com.mckoi.database.interpret.ViewManager
-
If this is a create command, the QueryPlanNode that represents the view plan.
- planAllOuterJoins() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Plans all outer joins.
- planForExpression(Expression) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evaluates the search Expression clause and alters the banches of the plans in this object as necessary.
- planForExpressionList(List) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Generates a plan to evaluate the given list of expressions (logically separated with AND).
- planForOrderBy(QueryPlanNode, ArrayList, TableExpressionFromSet, ArrayList) - Static method in class com.mckoi.database.interpret.Planner
-
Plans an ORDER BY set.
- Planner - Class in com.mckoi.database.interpret
-
Various methods for forming query plans on SQL queries.
- Planner() - Constructor for class com.mckoi.database.interpret.Planner
- Planner.ExpressionPlan - Class in com.mckoi.database.interpret
-
An abstract class that represents an expression to be added into a plan.
- Planner.PlanTableSource - Class in com.mckoi.database.interpret
-
Represents a single table source being planned.
- Planner.QuerySelectColumnSet - Class in com.mckoi.database.interpret
-
A container object for the set of SelectColumn objects selected in a query.
- Planner.QueryTableSetPlanner - Class in com.mckoi.database.interpret
-
A table set planner that maintains a list of table dependence lists and progressively constructs a plan tree from the bottom up.
- Planner.QueryTableSetPlanner.ComplexSingleExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.ConstantExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.ExhaustiveJoinExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.ExhaustiveSelectExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.ExhaustiveSubQueryExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.SimplePatternExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.SimpleSelectExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.SimpleSingleExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.SimpleSubQueryExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.SingleVarPlan - Class in com.mckoi.database.interpret
-
Convenience class that stores an expression to evaluate for a table.
- Planner.QueryTableSetPlanner.StandardJoinExpressionPlan - Class in com.mckoi.database.interpret
- Planner.QueryTableSetPlanner.SubLogicExpressionPlan - Class in com.mckoi.database.interpret
- planSearchExpression(SearchExpression) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Evalutes the WHERE clause of the table expression.
- PlanTableSource(QueryPlanNode, Variable[], String[]) - Constructor for class com.mckoi.database.interpret.Planner.PlanTableSource
-
Constructor.
- pointer - Variable in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- poll_wait_time - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
The number of milliseconds to wait between each poll of the 'available' method of the socket.
- pollForCommand(int) - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
-
Checks to see if there is a complete command waiting on the input stream.
- pop() - Method in class com.mckoi.database.Expression
-
Pops an element from the evaluation stack.
- port - Variable in class com.mckoi.database.jdbc.TCPStreamDatabaseInterface
-
The port we are connected to.
- port - Variable in class com.mckoi.database.jdbcserver.TCPServer
-
The port the JDBC server is on.
- portConnection(Socket) - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Called whenever a new connection has been received on the port.
- pos - Variable in class com.mckoi.database.CellBufferInputStream
- pos - Variable in class com.mckoi.util.ByteBuffer
-
The current position in the array.
- POS_INF_STATE - Static variable in class com.mckoi.util.BigNumber
- position - Variable in class com.mckoi.store.AbstractStore.StoreArea
- position - Variable in class com.mckoi.store.HeapStore.HeapArea
-
The current pointer into the area.
- position - Variable in class com.mckoi.store.JournalledSystem.JournalEntry
-
The position in the journal file.
- position - Variable in class com.mckoi.util.PagedInputStream
-
The current position in the stream.
- position() - Method in class com.mckoi.store.AbstractStore.StoreArea
- position() - Method in interface com.mckoi.store.Area
-
Returns the current position of the pointer within the area.
- position() - Method in class com.mckoi.store.HeapStore.HeapArea
- position() - Method in class com.mckoi.util.ByteBuffer
-
Returns the current position.
- position(byte[], long) - Method in class com.mckoi.database.jdbc.MBlob
- position(byte[], long) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- position(int) - Method in class com.mckoi.store.AbstractStore.StoreArea
- position(int) - Method in interface com.mckoi.store.Area
-
Sets the position within the area.
- position(int) - Method in class com.mckoi.store.HeapStore.HeapArea
- position(int) - Method in class com.mckoi.util.ByteBuffer
-
Sets the position in to the buffer.
- position(String, long) - Method in class com.mckoi.database.jdbc.MClob
- position(String, long) - Method in class com.mckoi.database.jdbc.MStreamableClob
- position(Blob, long) - Method in class com.mckoi.database.jdbc.MBlob
- position(Blob, long) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- position(Clob, long) - Method in class com.mckoi.database.jdbc.MClob
- position(Clob, long) - Method in class com.mckoi.database.jdbc.MStreamableClob
- positionOfRangePoint(byte, TObject) - Method in class com.mckoi.database.CollatedBaseSearch
-
Given a flag (FIRST_VALUE, LAST_VALUE, BEFORE_FIRST_VALUE or AFTER_LAST_VALUE) and a value which is either a place marker (first, last in set) or a TObject object, this will determine the position in this set of the range point.
- positionOnNode(long) - Method in class com.mckoi.database.FixedRecordList
-
Returns an Area object from the list block area with the position over the record entry requested.
- POSITIVE_INFINITY - Static variable in class com.mckoi.util.BigNumber
- PositiveIntegerConstant() - Method in class com.mckoi.database.sql.SQL
- postEvalAggregate(GroupResolver, QueryContext, TObject) - Method in class com.mckoi.database.AbstractAggregateFunction
-
Called just before the value is returned to the parent.
- postEvalAggregate(GroupResolver, QueryContext, TObject) - Method in class com.mckoi.database.InternalFunctionFactory.AvgFunction
- postEvent(int, Object) - Method in class com.mckoi.database.Database
-
Posts an event on the database dispatcher.
- postEvent(int, Object) - Method in class com.mckoi.database.DatabaseDispatcher
-
Adds a new event to be dispatched on the queue after 'time_to_wait' milliseconds has passed.
- postEvent(int, Object) - Method in class com.mckoi.database.TransactionSystem
-
Adds a new event to be dispatched on the queue after 'time_to_wait' milliseconds has passed.
- PowFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.PowFunction
- precedence - Variable in class com.mckoi.database.Operator
-
The precedence of this operator.
- precedence() - Method in class com.mckoi.database.Operator
- prepare() - Method in class com.mckoi.database.interpret.AlterTable
- prepare() - Method in class com.mckoi.database.interpret.Call
- prepare() - Method in class com.mckoi.database.interpret.Compact
- prepare() - Method in class com.mckoi.database.interpret.CompleteTransaction
- prepare() - Method in class com.mckoi.database.interpret.CreateTable
- prepare() - Method in class com.mckoi.database.interpret.CreateTrigger
- prepare() - Method in class com.mckoi.database.interpret.Delete
- prepare() - Method in class com.mckoi.database.interpret.DropTable
- prepare() - Method in class com.mckoi.database.interpret.DropTrigger
- prepare() - Method in class com.mckoi.database.interpret.Function
- prepare() - Method in class com.mckoi.database.interpret.Insert
- prepare() - Method in class com.mckoi.database.interpret.Misc
- prepare() - Method in class com.mckoi.database.interpret.NoOp
- prepare() - Method in class com.mckoi.database.interpret.PrivManager
- prepare() - Method in class com.mckoi.database.interpret.Schema
- prepare() - Method in class com.mckoi.database.interpret.Select
-
Prepares the select statement with a Database object.
- prepare() - Method in class com.mckoi.database.interpret.Sequence
- prepare() - Method in class com.mckoi.database.interpret.Set
- prepare() - Method in class com.mckoi.database.interpret.Show
- prepare() - Method in class com.mckoi.database.interpret.Statement
-
Prepares the statement with the given Database object.
- prepare() - Method in class com.mckoi.database.interpret.UpdateTable
- prepare() - Method in class com.mckoi.database.interpret.UserManager
- prepare() - Method in class com.mckoi.database.interpret.ViewManager
- prepare(boolean) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Prepares the query by parsing the query string and performing any updates that are required before being passed down to the lower layers of the database engine for processing.
- prepare(DatabaseConnection) - Method in class com.mckoi.database.JoiningSet
-
Resolves the schema of tables in this joining set.
- prepare(ExpressionPreparer) - Method in class com.mckoi.database.Expression
-
A general prepare that cascades through the expression and its parents and substitutes an elements that the preparer wants to substitute.
- prepare(ExpressionPreparer) - Method in class com.mckoi.database.interpret.SearchExpression
-
Prepares the expression.
- prepare(QueryContext) - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Resolves all variable objects in each column.
- prepare(Object) - Method in interface com.mckoi.database.ExpressionPreparer
-
Returns the new translated object to be mutated from the given element.
- prepareAllExpressions(ExpressionPreparer) - Method in class com.mckoi.database.StatementTree
-
For each expression in this StatementTree this method will call the 'prepare' method in each expression.
- prepareAllInList(List, ExpressionPreparer) - Static method in class com.mckoi.database.interpret.TableSelectExpression
-
Prepares all the expressions in the list.
- prepareCall(String) - Method in class com.mckoi.database.jdbc.MConnection
- prepareCall(String, int, int) - Method in class com.mckoi.database.jdbc.MConnection
- prepareCall(String, int, int, int) - Method in class com.mckoi.database.jdbc.MConnection
- prepared - Variable in class com.mckoi.database.jdbc.SQLQuery
-
Set to true when this query is prepared via the prepare method.
- prepared_select - Variable in class com.mckoi.database.interpret.Insert
-
If this is a 'from_select' insert, the prepared Select object.
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.Assignment
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.AlterTableAction
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.ByColumn
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.ColumnDef
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.ConstraintDef
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.FromClause
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.FromTableDef
-
Prepares the expressions in this table def.
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.SearchExpression
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.SelectColumn
- prepareExpressions(ExpressionPreparer) - Method in class com.mckoi.database.interpret.TableSelectExpression
- prepareExpressions(ExpressionPreparer) - Method in interface com.mckoi.database.StatementTreeObject
-
Prepares all expressions in this statement tree object by passing the ExpressionPreparer object to the 'prepare' method of the expression.
- prepareExpressionsInObject(Object, ExpressionPreparer) - Method in class com.mckoi.database.StatementTree
- prepareMutate(boolean) - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Makes the block mutable if it is immutable.
- prepareMutate(boolean) - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Makes the block mutable if it is immutable.
- prepareParameters(ExpressionPreparer) - Method in class com.mckoi.database.AbstractFunction
-
Prepares the parameters of the function.
- prepareParameters(ExpressionPreparer) - Method in interface com.mckoi.database.Function
-
Prepares the exressions that are the parameters of this function.
- prepareSearchExpression(DatabaseConnection, TableExpressionFromSet, SearchExpression) - Static method in class com.mckoi.database.interpret.Planner
-
Prepares the given SearchExpression object.
- prepareSelectColumn(SelectColumn, QueryContext) - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Prepares the given SelectColumn by fully qualifying the expression and allocating it correctly within this context.
- prepareStatement(String) - Method in class com.mckoi.database.jdbc.MConnection
- prepareStatement(String, int) - Method in class com.mckoi.database.jdbc.MConnection
- prepareStatement(String, int[]) - Method in class com.mckoi.database.jdbc.MConnection
- prepareStatement(String, int, int) - Method in class com.mckoi.database.jdbc.MConnection
- prepareStatement(String, int, int, int) - Method in class com.mckoi.database.jdbc.MConnection
- prepareStatement(String, String[]) - Method in class com.mckoi.database.jdbc.MConnection
- prepareTransactionCheckConstraint(DataTableDef, Transaction.CheckExpression) - Method in class com.mckoi.database.DatabaseSystem
-
Given a Transaction.CheckExpression, this will prepare the expression and return a new prepared CheckExpression.
- prepareTransactionCheckConstraint(DataTableDef, Transaction.CheckExpression) - Method in class com.mckoi.database.TransactionSystem
-
Given a Transaction.CheckExpression, this will prepare the expression and return a new prepared CheckExpression.
- preserve_table_structure - Variable in class com.mckoi.jfccontrols.ResultSetTableModel
-
If true, a table structure change event is NOT thrown if the result set looks similar to an updated result set.
- prevCharIsCR - Variable in class com.mckoi.database.sql.SimpleCharStream
- prevCharIsLF - Variable in class com.mckoi.database.sql.SimpleCharStream
- previous - Variable in class com.mckoi.util.Cache.ListNode
- previous - Variable in class com.mckoi.util.IntegerListBlockInterface
-
The previous block in the chain.
- previous() - Method in class com.mckoi.database.jdbc.MResultSet
- previous() - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- previous() - Method in interface com.mckoi.util.IntegerIterator
-
Returns the previous element in the list.
- previous_user - Variable in class com.mckoi.database.DatabaseConnection.DCProcedureConnection
-
The User of this connection before this procedure was started.
- PRIMARY - Static variable in interface com.mckoi.database.sql.SQLConstants
- PRIMARY_COLS_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- PRIMARY_INFO_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- primary_key - Variable in class com.mckoi.database.interpret.ColumnDef
- PRIMARY_KEY - Static variable in class com.mckoi.database.interpret.ConstraintDef
-
A PRIMARY_KEY constraint.
- PRIMARY_KEY_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
A Primary Key constraint violation error code.
- PRIMARY_STRENGTH - Static variable in interface com.mckoi.database.sql.SQLConstants
- PRIME_LIST - Static variable in class com.mckoi.database.DataCellCache
-
A list of primes ordered from lowest to highest.
- PRIMITIVE_COST - Static variable in class com.mckoi.database.Caster
-
The cost to cast to the closest Java primitive type.
- print(String) - Method in class com.mckoi.util.ShellUserTerminal
- print(String) - Method in interface com.mckoi.util.UserTerminal
-
Outputs a string of information to the terminal.
- PRINT_ALERT_TO_MESSAGES - Static variable in class com.mckoi.debug.Debug
-
Deprecated.Set this to true if all alerts to messages are to be output to System.out.
- PRINT_ALERT_TO_MESSAGES - Static variable in class com.mckoi.debug.DefaultDebugLogger
-
Set this to true if all alerts to messages are to be output to System.out.
- printByteArray(byte[]) - Static method in class com.mckoi.database.jdbcserver.JDBCProcessor
- printDebugInfo() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
- printGraph(PrintStream, int) - Method in class com.mckoi.database.FilterTable
-
Prints a graph of the table hierarchy to the stream.
- printGraph(PrintStream, int) - Method in class com.mckoi.database.JoinedTable
-
Prints a graph of the table hierarchy to the stream.
- printGraph(PrintStream, int) - Method in class com.mckoi.database.Table
-
Prints a graph of the table hierarchy to the stream.
- println(String) - Method in class com.mckoi.util.ShellUserTerminal
- println(String) - Method in interface com.mckoi.util.UserTerminal
-
Outputs a string of information and a newline to the terminal.
- printStackTrace() - Method in exception com.mckoi.database.jdbc.MSQLException
-
Overwrites the print stack trace information with some more detailed information about the error.
- printStackTrace(PrintStream) - Method in exception com.mckoi.database.jdbc.MSQLException
-
Overwrites the print stack trace information with some more detailed information about the error.
- printStackTrace(PrintWriter) - Method in exception com.mckoi.database.jdbc.MSQLException
-
Overwrites the print stack trace information with some more detailed information about the error.
- printSyntax() - Static method in class com.mckoi.runtime.McKoiDBMain
-
Print the syntax.
- printSyntax() - Static method in class com.mckoi.tools.DataFileConvertTool
-
Prints the syntax.
- printSyntax() - Static method in class com.mckoi.tools.DBConglomerateDiagTool
-
Prints the syntax.
- printSyntax() - Static method in class com.mckoi.tools.DBConglomerateRepairTool
-
Prints the syntax.
- printSyntax() - Static method in class com.mckoi.tools.JDBCQueryTool
-
Prints the syntax to System.out.
- printSyntax() - Static method in class com.mckoi.tools.JDBCScriptTool
-
Prints the syntax to System.out.
- printTo(PrintStream) - Method in class com.mckoi.util.Stats
-
Outputs the stats to a print stream.
- priv_cache - Variable in class com.mckoi.database.GrantManager
-
A cache of privileges for the various tables in the database.
- PrivGroupsFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.PrivGroupsFunction
- Privileges - Class in com.mckoi.database
-
A set of privileges to grant a user for an object.
- Privileges() - Constructor for class com.mckoi.database.Privileges
- Privileges(int) - Constructor for class com.mckoi.database.Privileges
-
Constructor.
- PRIVILEGES - Static variable in interface com.mckoi.database.sql.SQLConstants
- PrivilegeString(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.PrivilegeString
- PrivList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- PrivListItem(ArrayList) - Method in class com.mckoi.database.sql.SQL
- PrivManager - Class in com.mckoi.database.interpret
-
Handler for grant/revoke queries for setting up grant information in the database.
- PrivManager() - Constructor for class com.mckoi.database.interpret.PrivManager
- PrivMapSearch(TableDataSource, int) - Constructor for class com.mckoi.database.GTPrivMapDataSource.PrivMapSearch
- PrivObject() - Method in class com.mckoi.database.sql.SQL
- privs - Variable in class com.mckoi.database.Privileges
-
The priv bit map.
- ProcArgumentName() - Method in class com.mckoi.database.sql.SQL
- PROCEDURE - Static variable in interface com.mckoi.database.sql.SQLConstants
- PROCEDURE_ALL_PRIVS - Static variable in class com.mckoi.database.Privileges
-
All access (execute/update/delete/etc) privs for a procedure object.
- PROCEDURE_EXECUTE_PRIVS - Static variable in class com.mckoi.database.Privileges
-
Execute access privs for a procedure object.
- procedure_manager - Variable in class com.mckoi.database.DatabaseConnection
-
The procedure manager object for this connection.
- ProcedureConnection - Interface in com.mckoi.database
-
An interface for accessing a database connection inside a stored procedure.
- ProcedureException - Exception in com.mckoi.database
-
An exception that is generated from a stored procedure when some erronious condition occurs.
- ProcedureException(String) - Constructor for exception com.mckoi.database.ProcedureException
-
Construct the exception.
- procedureExists(ProcedureName) - Method in class com.mckoi.database.ProcedureManager
-
Returns true if the procedure with the given name exists.
- procedureExists(TableName) - Method in class com.mckoi.database.ProcedureManager
-
Returns true if the procedure with the given table name exists.
- procedureInfoString(ProcedureName, TType, TType[]) - Static method in class com.mckoi.database.ProcedureManager
-
Formats a string that gives information about the procedure, return type and param types.
- ProcedureInternalTableInfo(Transaction) - Constructor for class com.mckoi.database.ProcedureManager.ProcedureInternalTableInfo
- ProcedureManager - Class in com.mckoi.database
-
A DatabaseConnection procedure manager.
- ProcedureManager(DatabaseConnection) - Constructor for class com.mckoi.database.ProcedureManager
-
Constructs the ProcedureManager for a DatabaseConnection.
- ProcedureManager.ProcedureInternalTableInfo - Class in com.mckoi.database
-
An object that models the list of procedures as table objects in a transaction.
- ProcedureName - Class in com.mckoi.database
-
The name of a procedure as understood by a ProcedureManager.
- ProcedureName(TableName) - Constructor for class com.mckoi.database.ProcedureName
-
Constructs the ProcedureName from a TableName.
- ProcedureName(String, String) - Constructor for class com.mckoi.database.ProcedureName
-
Constructs the ProcedureName.
- ProcedureName() - Method in class com.mckoi.database.sql.SQL
- processCommit(Transaction, ArrayList, ArrayList, ArrayList, TransactionJournal) - Method in class com.mckoi.database.TableDataConglomerate
-
Tries to commit a transaction to the conglomerate.
- processEvent(byte[]) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Processes a server side event.
- processing_command - Variable in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
This is set to true if we are processing a request from the client.
- processJDBCCommand(byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Processes a single JDBCCommand from the client.
- processQuery(byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Processes a query on the byte[] array and returns the result.
- processRequest() - Method in interface com.mckoi.database.jdbcserver.ServerConnection
-
Processes a pending command on the connection.
- processRequest() - Method in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
Processes a request from this connection.
- processRollback(Transaction, ArrayList, TransactionJournal) - Method in class com.mckoi.database.TableDataConglomerate
-
Rollbacks a transaction and invalidates any changes that the transaction made to the database.
- ProcParameterList(ArrayList, ArrayList) - Method in class com.mckoi.database.sql.SQL
- PRODUCT - Static variable in class com.mckoi.database.interpret.Show
- properties - Variable in class com.mckoi.util.Stats
-
Where the stat properties are held.
- ProtocolConstants - Interface in com.mckoi.database.jdbc
-
Constants used in the JDBC database communication protocol.
- PUBLIC - Static variable in interface com.mckoi.database.sql.SQLConstants
- PUBLIC_USERNAME - Static variable in class com.mckoi.database.GrantManager
-
The name of the 'public' username.
- PUBLIC_USERNAME_STR - Static variable in class com.mckoi.database.GrantManager
-
The string representing the public user (privs granted to all users).
- purgeCacheOfInvalidatedEntries(IntegerVector, IntegerVector) - Method in class com.mckoi.database.ConnectionTriggerManager.CTMBackedCache
- purgeCacheOfInvalidatedEntries(IntegerVector, IntegerVector) - Method in class com.mckoi.database.TableBackedCache
-
This method is called when the transaction starts and finishes and must purge the cache of all invalidated entries.
- push(Object) - Method in class com.mckoi.database.Expression
-
Pushes an element onto the evaluation stack.
- PUSH_STREAMABLE_OBJECT_PART - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
For pushing a part of a streamable object onto the server from the client.
- pushStreamableObjectPart(byte, long, long, byte[], long, int) - Method in interface com.mckoi.database.jdbc.DatabaseInterface
-
Pushes a part of a streamable object from the client onto the server.
- pushStreamableObjectPart(byte, long, long, byte[], long, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Pushes a part of a streamable object onto the server.
- pushStreamableObjectPart(byte, long, long, byte[], long, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
- pushStreamableObjectPart(byte, long, long, byte[], long, int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
- pushStreamableObjectPart(int, byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Pushes a part of a streamable object onto the server.
- put(byte) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- put(byte) - Method in interface com.mckoi.store.AreaWriter
- put(byte) - Method in class com.mckoi.store.HeapStore.HeapArea
- put(byte) - Method in interface com.mckoi.store.MutableArea
- put(byte[]) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- put(byte[]) - Method in interface com.mckoi.store.AreaWriter
- put(byte[]) - Method in class com.mckoi.store.HeapStore.HeapArea
- put(byte[]) - Method in interface com.mckoi.store.MutableArea
- put(byte[]) - Method in class com.mckoi.util.ByteBuffer
- put(byte[], int, int) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- put(byte[], int, int) - Method in interface com.mckoi.store.AreaWriter
- put(byte[], int, int) - Method in class com.mckoi.store.HeapStore.HeapArea
- put(byte[], int, int) - Method in interface com.mckoi.store.MutableArea
- put(byte[], int, int) - Method in class com.mckoi.util.ByteBuffer
-
Puts a byte array into the buffer.
- put(int, int, int, TObject) - Method in class com.mckoi.database.DataCellCache
-
Puts a TObject on the cache for the given row/column of the table.
- put(ByteBuffer) - Method in class com.mckoi.util.ByteBuffer
-
Puts a ByteBuffer in to this buffer.
- put(Object, Object) - Method in class com.mckoi.util.Cache
-
Puts an Object into the cache with the given key.
- put(Object, Object) - Method in class com.mckoi.util.HashMapList
-
Puts a value into the map list.
- put(String, StatementTree) - Method in class com.mckoi.database.StatementCache
-
Puts a new query string/StatementTree into the cache.
- putBoolean(String, boolean) - Method in class com.mckoi.database.StatementTree
-
Puts a boolean into the statement tree map.
- putByte(byte) - Method in class com.mckoi.util.ByteBuffer
-
Puts/Gets a byte into the buffer at the current position.
- putByteLongObjectInBlobStore(ByteLongObject) - Method in class com.mckoi.database.BlobStore
-
Convenience method that converts the given ByteLongObject into a BlobRef object and pushes it into the given BlobStore object.
- putCachedNode(long, Table) - Method in class com.mckoi.database.AbstractQueryContext
-
Put a Table into the cache.
- putCachedNode(long, Table) - Method in interface com.mckoi.database.QueryContext
-
Put a Table into the cache.
- putChar(char) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- putChar(char) - Method in interface com.mckoi.store.AreaWriter
- putChar(char) - Method in class com.mckoi.store.HeapStore.HeapArea
- putChar(char) - Method in interface com.mckoi.store.MutableArea
- putInt(int) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- putInt(int) - Method in interface com.mckoi.store.AreaWriter
- putInt(int) - Method in class com.mckoi.store.HeapStore.HeapArea
- putInt(int) - Method in interface com.mckoi.store.MutableArea
- putInt(int) - Method in class com.mckoi.util.ByteBuffer
-
Puts/Gets an integer into the buffer at the current position.
- putInt(String, int) - Method in class com.mckoi.database.StatementTree
-
Puts an integer into the statement tree map.
- putIntoHash(Cache.ListNode) - Method in class com.mckoi.util.Cache
-
Puts the node with the given key into the hash table.
- putLong(long) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- putLong(long) - Method in interface com.mckoi.store.AreaWriter
- putLong(long) - Method in class com.mckoi.store.HeapStore.HeapArea
- putLong(long) - Method in interface com.mckoi.store.MutableArea
- putObject(String, Object) - Method in class com.mckoi.database.StatementTree
-
Puts a new entry into the statement tree map.
- putShort(short) - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- putShort(short) - Method in interface com.mckoi.store.AreaWriter
- putShort(short) - Method in class com.mckoi.store.HeapStore.HeapArea
- putShort(short) - Method in interface com.mckoi.store.MutableArea
- putShort(short) - Method in class com.mckoi.util.ByteBuffer
-
Puts/Gets a short into the buffer at the current position.
- putStringInBlobStore(String) - Method in class com.mckoi.database.BlobStore
-
Convenience method that converts the given String into a ClobRef object and pushes it into the given BlobStore object.
Q
- qualify(String, String) - Static method in class com.mckoi.database.ProcedureName
-
Returns a version of this procedure qualified to the given schema (unless the schema is present).
- qualifyVariable(Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Attempts to qualify the given Variable object to a value found either in this from set, or a value in the parent from set.
- query - Variable in class com.mckoi.database.interpret.Statement
-
The SQLQuery object that was used to produce this statement.
- query - Variable in class com.mckoi.database.jdbc.SQLQuery
-
The SQL String.
- query - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
The SQLQuery that was executed to produce this result.
- Query - Class in com.mckoi.jfccontrols
-
Encapsulates the information in a query to the database.
- Query(String) - Constructor for class com.mckoi.jfccontrols.Query
-
Constructs the query.
- QUERY - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Query sent to the server for processing.
- query_agent - Static variable in class com.mckoi.jfccontrols.QueryAgent
- query_agent - Variable in class com.mckoi.tools.JDBCQueryTool
-
The agent used to make queries on the JDBC connection.
- query_finished - Variable in class com.mckoi.jfccontrols.QueryAgent
-
This represents the state of the result of the query.
- query_level_offset - Variable in class com.mckoi.database.CorrelatedVariable
-
The number of sub-query branches back that the reference for this variable can be found.
- query_logging - Variable in class com.mckoi.database.DatabaseSystem
-
True if all queries on the database should be logged in the 'commands.log' file in the log directory.
- QUERY_PLAN_TYPE - Static variable in class com.mckoi.database.TType
-
A type that represents a query plan (sub-select).
- query_string - Variable in class com.mckoi.jfccontrols.Query
-
The string to query.
- query_text_area - Variable in class com.mckoi.tools.JDBCQueryTool
-
The JTextArea where the query is entered.
- query_thread - Variable in class com.mckoi.jfccontrols.QueryAgent
-
The thread we use to send commands to the JDBC connection.
- query_time - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- query_time - Variable in class com.mckoi.tools.JDBCQueryTool
-
The time it took to execute the query in milliseconds.
- query_time_ms - Variable in class com.mckoi.database.jdbc.MResultSet
-
The length of time it took to execute this query in ms.
- query_timeout - Variable in class com.mckoi.database.jdbc.MStatement
- QUERY_TIMEOUT - Static variable in class com.mckoi.database.jdbc.MDriver
-
The timeout for a query in seconds.
- query_window_count - Static variable in class com.mckoi.tools.JDBCQueryTool
-
The number of query windows we have open.
- QueryAgent - Class in com.mckoi.jfccontrols
-
A class that is an agent for queries from the client environment to the server.
- QueryAgent(Connection) - Constructor for class com.mckoi.jfccontrols.QueryAgent
-
Constructs the query agent.
- QueryAgent.QueryThread - Class in com.mckoi.jfccontrols
-
The query thread.
- queryCommand(int, byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Executes a query and returns the header for the result in the response.
- QueryContext - Interface in com.mckoi.database
-
Facts about a particular query including the root table sources, user name of the controlling context, sequence state, etc.
- QueryPlan - Class in com.mckoi.database
-
Various helper methods for constructing a plan tree, and the plan node implementations themselves.
- QueryPlan() - Constructor for class com.mckoi.database.QueryPlan
- QueryPlan.BranchQueryPlanNode - Class in com.mckoi.database
-
A QueryPlanNode that is a branch with two child nodes.
- QueryPlan.CachePointNode - Class in com.mckoi.database
-
A cache point node that only evaluates the child if the result can not be found in the cache with the given unique id.
- QueryPlan.CompositeNode - Class in com.mckoi.database
-
A branch node for performing a composite function on two child nodes.
- QueryPlan.ConstantSelectNode - Class in com.mckoi.database
-
The node for evaluating an expression that contains entirely constant values (no variables).
- QueryPlan.CreateFunctionsNode - Class in com.mckoi.database
-
The node for merging the child node with a set of new function columns over the entire result.
- QueryPlan.DistinctNode - Class in com.mckoi.database
-
The node for performing a distinct operation on the given columns of the child node.
- QueryPlan.EquiJoinNode - Class in com.mckoi.database
-
A branch node for equi-joining two tables together given two sets of columns.
- QueryPlan.ExhaustiveSelectNode - Class in com.mckoi.database
-
The node for performing a exhaustive select operation on the child node.
- QueryPlan.FetchTableNode - Class in com.mckoi.database
-
The node for fetching a table from the current transaction.
- QueryPlan.FetchViewNode - Class in com.mckoi.database
-
The node that fetches a view from the current connection.
- QueryPlan.FunctionalSelectNode - Class in com.mckoi.database
-
The node for performing a functional select operation on the child node.
- QueryPlan.GroupNode - Class in com.mckoi.database
-
The node for performing a grouping operation on the columns of the child node.
- QueryPlan.JoinNode - Class in com.mckoi.database
-
A branch node for a non-equi join between two tables.
- QueryPlan.LeftOuterJoinNode - Class in com.mckoi.database
-
A branch node for a left outer join.
- QueryPlan.LogicalUnionNode - Class in com.mckoi.database
-
A branch node for a logical union of two tables of identical types.
- QueryPlan.MarkerNode - Class in com.mckoi.database
-
A marker node that takes the result of a child and marks it as a name that can later be retrieved.
- QueryPlan.MultiColumnEquiSelectNode - Class in com.mckoi.database
-
The node for performing an equi-select on a group of columns of the child node.
- QueryPlan.NaturalJoinNode - Class in com.mckoi.database
-
A branch node for naturally joining two tables together.
- QueryPlan.NonCorrelatedAnyAllNode - Class in com.mckoi.database
-
A branch node for a non-correlated ANY or ALL sub-query evaluation.
- QueryPlan.RangeSelectNode - Class in com.mckoi.database
-
The node for performing a simple indexed query on a single column of the child node.
- QueryPlan.SimplePatternSelectNode - Class in com.mckoi.database
-
The node for evaluating a simple pattern search on a table which includes a single left hand variable or constant, a pattern type (LIKE, NOT LIKE or REGEXP), and a right hand constant (eg.
- QueryPlan.SimpleSelectNode - Class in com.mckoi.database
-
The node for performing a simple select operation on a table.
- QueryPlan.SingleQueryPlanNode - Class in com.mckoi.database
-
A QueryPlanNode with a single child.
- QueryPlan.SingleRowTableNode - Class in com.mckoi.database
-
A node for creating a table with a single row.
- QueryPlan.SortNode - Class in com.mckoi.database
-
The node for performing a sort operation on the given columns of the child node.
- QueryPlan.SubsetNode - Class in com.mckoi.database
-
The node for finding a subset and renaming the columns of the results in the child node.
- QueryPlanNode - Interface in com.mckoi.database
-
A node element of a query plan tree.
- queryProductInformation() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
-
Queries product information about the database we are connected to.
- QueryResponse - Interface in com.mckoi.database.jdbc
-
The response to a query executed via the 'execQuery' method in the DatabaseInterface interface.
- QuerySelectColumnSet(TableExpressionFromSet) - Constructor for class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Constructor.
- queryTableCheckExpressions(SimpleTransaction, TableName) - Static method in class com.mckoi.database.Transaction
-
Returns a set of check expressions that are constrained over all new columns added to the given table in this transaction.
- queryTableCheckExpressions(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.queryTableCheckExpression method.
- queryTableForeignKeyReferences(SimpleTransaction, TableName) - Static method in class com.mckoi.database.Transaction
-
Returns an array of column references in the given table that represent foreign key references.
- queryTableForeignKeyReferences(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.queryTableForeignKeyReferences method.
- queryTableImportedForeignKeyReferences(SimpleTransaction, TableName) - Static method in class com.mckoi.database.Transaction
-
Returns an array of column references in the given table that represent foreign key references that reference columns in the given table.
- queryTableImportedForeignKeyReferences(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.queryTableImportedForeignKeyReferences method.
- queryTablePrimaryKeyGroup(SimpleTransaction, TableName) - Static method in class com.mckoi.database.Transaction
-
Returns a set of primary key groups that are constrained to be unique for the given table in this transaction (there can be only 1 primary key defined for a table).
- queryTablePrimaryKeyGroup(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.queryTablePrimaryKeyGroup method.
- QueryTableSetPlanner() - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Constructor.
- queryTablesRelationallyLinkedTo(SimpleTransaction, TableName) - Static method in class com.mckoi.database.Transaction
-
Returns the list of tables (as a TableName array) that are dependant on the data in the given table to maintain referential consistancy.
- queryTablesRelationallyLinkedTo(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.queryTablesRelationallyLinkedTo method.
- queryTableUniqueGroups(SimpleTransaction, TableName) - Static method in class com.mckoi.database.Transaction
-
Returns a set of unique groups that are constrained to be unique for the given table in this transaction.
- queryTableUniqueGroups(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.queryTableUniqueGroups method.
- QueryThread() - Constructor for class com.mckoi.jfccontrols.QueryAgent.QueryThread
- queue - Variable in class com.mckoi.database.Lock
-
The table queue this lock is 'inside'.
- queue - Variable in class com.mckoi.database.LockingQueue
-
This is the queue that stores the table locks.
- queues_map - Variable in class com.mckoi.database.LockingMechanism
-
This Hashtable is a mapping from a 'DataTable' to the 'LockingQueue' object that is available for it.
- quickSort() - Method in class com.mckoi.util.IntegerVector
-
Performs a quick sort on the entire vector.
- quickSort(int, int) - Method in class com.mckoi.util.IntegerVector
-
Performs a quick sort on the array between the min and max bounds.
- quickSort(Comparable[]) - Static method in class com.mckoi.util.SortUtil
-
Performs a quick sort on the given array of Comparable objects.
- quickSort(Comparable[], int, int) - Static method in class com.mckoi.util.SortUtil
-
Performs a quick sort on the given array of Comparable objects between the min and maximum range.
- quote(String) - Static method in class com.mckoi.database.jdbc.MckoiConnection
-
Given a string, this will use escape codes to convert the Java string into a Mckoi SQL string that can be parsed correctly by the database.
- QUOTED_DELIMINATED_REF - Static variable in interface com.mckoi.database.sql.SQLConstants
- QUOTED_VARIABLE - Static variable in interface com.mckoi.database.sql.SQLConstants
- QUOTEDGLOBVARIABLE - Static variable in interface com.mckoi.database.sql.SQLConstants
R
- range_set - Variable in class com.mckoi.database.SelectableRangeSet
-
The list of ranges.
- RangeChecker(SelectableRange[]) - Constructor for class com.mckoi.database.BlindSearch.RangeChecker
-
Constructs the checker.
- rangeIntersectedBy(SelectableRange, SelectableRange) - Static method in class com.mckoi.database.SelectableRangeSet
-
Returns true if the two SelectableRange ranges intersect.
- rangeSelect(Variable, SelectableRange[]) - Method in class com.mckoi.database.Table
-
A single column range select on this table.
- RangeSelectNode(QueryPlanNode, Expression) - Constructor for class com.mckoi.database.QueryPlan.RangeSelectNode
- raw_info - Variable in class com.mckoi.database.RawTableInformation
-
A Vector containing a list of DataTables, and 'row index' IntegerVectors of the given rows in the table.
- rawDataSectorSize() - Method in class com.mckoi.database.V1MasterTableDataSource
-
Returns the current sector size for this data source.
- RawDiagnosticTable - Interface in com.mckoi.database
-
An interface that allows for the inspection and repair of the raw data in a file.
- rawRecordCount() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns the total number of records that are in the store (including deleted records.
- rawRecordSize(int) - Method in class com.mckoi.database.V1MasterTableDataSource
-
Returns the number of bytes the row takes up in the data file.
- rawRowCount() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the raw count or rows in the table, including uncommited, committed and deleted rows.
- rawRowCount() - Method in class com.mckoi.database.V1MasterTableDataSource
- rawRowCount() - Method in class com.mckoi.database.V2MasterTableDataSource
- RawRowElement - Class in com.mckoi.database
-
A container class to hold each row of a list of tables.
- RawRowElement() - Constructor for class com.mckoi.database.RawRowElement
- rawSectorCount() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the total number of sectors that are currently available (includes used and deleted sectors).
- rawSize() - Method in class com.mckoi.database.jdbc.AbstractStreamableObject
-
Returns the number of bytes in this streamable object.
- RawTableElement - Class in com.mckoi.database
-
A container class to hold the DataTable and IntegerVector row set of a given table in the list.
- RawTableElement() - Constructor for class com.mckoi.database.RawTableElement
- RawTableInformation - Class in com.mckoi.database
-
This object represents the lowest level DataTable information of a given VirtualTable.
- RawTableInformation() - Constructor for class com.mckoi.database.RawTableInformation
-
The constructor.
- RDVariableResolver() - Constructor for class com.mckoi.database.RowData.RDVariableResolver
- read() - Method in class com.mckoi.database.CellBufferInputStream
-
Sped up methods.
- read() - Method in class com.mckoi.database.CellInputStream
- read() - Method in class com.mckoi.database.DataCellSerialization
- read() - Method in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
- read() - Method in class com.mckoi.database.global.ByteLongObject.BLOBInputStream
- read() - Method in class com.mckoi.database.jdbc.AsciiInputStream
- read() - Method in class com.mckoi.database.jdbc.AsciiReader
- read() - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- read() - Method in class com.mckoi.database.jdbc.UnicodeToBinaryStream
-
Reads the next character from the stream.
- read() - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- read() - Method in class com.mckoi.store.StreamFile.SFInputStream
- read() - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
- read() - Method in class com.mckoi.util.PagedInputStream
- read(byte[]) - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- read(byte[], int, int) - Method in class com.mckoi.database.CellBufferInputStream
- read(byte[], int, int) - Method in class com.mckoi.database.CellInputStream
- read(byte[], int, int) - Method in class com.mckoi.database.DataCellSerialization
- read(byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
- read(byte[], int, int) - Method in class com.mckoi.database.global.ByteLongObject.BLOBInputStream
- read(byte[], int, int) - Method in class com.mckoi.database.jdbc.AsciiInputStream
- read(byte[], int, int) - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- read(byte[], int, int) - Method in class com.mckoi.store.StreamFile.SFInputStream
- read(byte[], int, int) - Method in class com.mckoi.util.LengthMarkedBufferedInputStream
- read(byte[], int, int) - Method in class com.mckoi.util.PagedInputStream
- read(char[], int, int) - Method in class com.mckoi.database.jdbc.AsciiReader
- read(char[], int, int) - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- read(int) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Reads a single byte from the cached page from memory.
- read(int, byte[], int, int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Reads a variable length byte[] array from the given index position.
- read(int, byte[], int, int) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Reads a part of this page into the cached page from memory.
- read(long, byte[], int) - Method in class com.mckoi.database.BlobStore.AbstractRef
- read(long, byte[], int) - Method in interface com.mckoi.database.global.Ref
-
Reads a part of this large object from the store into the given byte buffer.
- read(long, byte[], int) - Method in interface com.mckoi.store.JournalledResource
-
Reads a page of some previously specified size into the byte array.
- read(long, byte[], int) - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Reads a page from the resource.
- read(long, byte[], int) - Method in class com.mckoi.store.JournalledSystem.Resource
-
Reads a page from the resource.
- read(long, byte[], int, int) - Method in class com.mckoi.store.IOStoreDataAccessor
- read(long, byte[], int, int) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- read(long, byte[], int, int) - Method in interface com.mckoi.store.StoreDataAccessor
-
Reads a block of data from the underlying data area at the given position into the byte array at the given offset.
- read(DataInput) - Static method in class com.mckoi.database.DataIndexDef
-
Reads a DataIndexDef from the given DataInput object.
- read(DataInput) - Static method in class com.mckoi.database.DataIndexSetDef
-
Reads the DataIndexSetDef object from the given DataInput.
- read(DataInput) - Static method in class com.mckoi.database.DataTableColumnDef
-
Reads this column from a DataInputStream.
- read(DataInput) - Static method in class com.mckoi.database.DataTableDef
-
Reads this DataTableDef file from the data input stream.
- READ - Static variable in class com.mckoi.database.Lock
-
These statics are used to define whether the lock is a READ or WRITE lock.
- read_only - Variable in class com.mckoi.database.FixedSizeDataStore
-
Set to true if we opened the store in read only mode, otherwise false.
- read_only - Variable in class com.mckoi.database.SimpleTransaction
-
If true, this is a read-only transaction and does not permit any type of modification to this vew of the database.
- read_only - Variable in class com.mckoi.database.V1FileStoreSystem
-
True if the stores are read-only.
- read_only - Variable in class com.mckoi.store.AbstractStore
-
True if this is read-only.
- read_only - Variable in class com.mckoi.store.JournalledSystem.AbstractResource
-
True if this resource is read_only.
- read_only - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
True if the journal file is read only.
- read_only - Variable in class com.mckoi.store.JournalledSystem
-
If the journal system is in read only mode.
- read_only_access - Variable in class com.mckoi.database.TransactionSystem
-
Set to true if the database is in read only mode.
- readAcross(int, byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Reads information across a chain of sectors and fills the byte[] array buffer.
- readBins() - Method in class com.mckoi.store.AbstractStore
-
Reads the bins from the header information in the file.
- readBlobByteArray(long, long, byte[], int, int) - Method in class com.mckoi.database.BlobStore
-
Reads a section of the blob referenced by the given id, offset and length into the byte array.
- readBoolean() - Method in class com.mckoi.database.CellBufferInputStream
- readBoolean() - Method in class com.mckoi.database.CellInputStream
- readBoolean() - Method in class com.mckoi.database.DataCellSerialization
- readByte() - Method in class com.mckoi.database.CellBufferInputStream
- readByte() - Method in class com.mckoi.database.CellInputStream
- readByte() - Method in class com.mckoi.database.DataCellSerialization
- readByteArrayFrom(long, byte[], int, int) - Method in class com.mckoi.store.AbstractStore
-
Reads a byte array from the given position in the file.
- readByteArrayFrom(long, byte[], int, int) - Method in class com.mckoi.store.JournalledFileStore
- readByteArrayFrom(JournalledResource, long, byte[], int, int) - Method in class com.mckoi.store.LoggingBufferManager
- readByteFrom(long) - Method in class com.mckoi.store.AbstractStore
-
Reads a byte from the given position in the file.
- readByteFrom(long) - Method in class com.mckoi.store.JournalledFileStore
- readByteFrom(JournalledResource, long) - Method in class com.mckoi.store.LoggingBufferManager
- readChar() - Method in class com.mckoi.database.CellBufferInputStream
- readChar() - Method in class com.mckoi.database.CellInputStream
- readChar() - Method in class com.mckoi.database.DataCellSerialization
- readChar() - Method in class com.mckoi.database.sql.SimpleCharStream
- readChars(int) - Method in class com.mckoi.database.CellBufferInputStream
- readChars(int) - Method in interface com.mckoi.database.CellInput
-
Reads a string of chars from the input stream up to the given length and returns it as a String object.
- readChars(int) - Method in class com.mckoi.database.CellInputStream
- readChars(int) - Method in class com.mckoi.database.DataCellSerialization
- READCOMMITTED - Static variable in interface com.mckoi.database.sql.SQLConstants
- readDouble() - Method in class com.mckoi.database.CellBufferInputStream
- readDouble() - Method in class com.mckoi.database.CellInputStream
- readDouble() - Method in class com.mckoi.database.DataCellSerialization
- readDroppedTables() - Method in class com.mckoi.database.TableDataConglomerate
-
Reads in the list of committed dropped tables on this conglomerate.
- reader - Variable in class com.mckoi.database.jdbc.AsciiInputStream
- reader - Variable in class com.mckoi.database.jdbc.UnicodeToBinaryStream
-
The Reader we are wrapping.
- readFloat() - Method in class com.mckoi.database.CellBufferInputStream
- readFloat() - Method in class com.mckoi.database.CellInputStream
- readFloat() - Method in class com.mckoi.database.DataCellSerialization
- readFrom(DataInputStream) - Static method in class com.mckoi.database.global.ColumnDescription
-
Reads a ColumnDescription from the given DataInputStream and returns a new instance of it.
- readFrom(DataInputStream) - Static method in class com.mckoi.database.global.ObjectTransfer
-
Writes an object from the data input stream.
- readFrom(DataInputStream) - Static method in class com.mckoi.database.jdbc.SQLQuery
-
Reads an SQLQuery object from the data input stream.
- readFrom(DataInputStream) - Method in class com.mckoi.database.MasterTableJournal
-
Reads the journal entries from the given DataInputStream to this object.
- readFrom(InputStream) - Method in class com.mckoi.database.BlindSearch
-
Reads the entire state of the scheme from the input stream.
- readFrom(InputStream) - Method in class com.mckoi.database.CollatedBaseSearch
-
Reads the entire state of the scheme from the input stream.
- readFrom(InputStream) - Method in class com.mckoi.database.InsertSearch
-
Reads the entire state of the scheme from the input stream.
- readFrom(InputStream) - Method in class com.mckoi.database.SelectableScheme
-
Reads the entire contents of the scheme from a InputStream object.
- readFromCellInput(CellInput) - Method in class com.mckoi.database.DataCellSerialization
-
Reads an object from the given CellInput.
- readFully(byte[]) - Method in class com.mckoi.database.CellBufferInputStream
- readFully(byte[]) - Method in class com.mckoi.database.CellInputStream
- readFully(byte[]) - Method in class com.mckoi.database.DataCellSerialization
- readFully(byte[], int, int) - Method in class com.mckoi.database.CellBufferInputStream
- readFully(byte[], int, int) - Method in class com.mckoi.database.CellInputStream
- readFully(byte[], int, int) - Method in class com.mckoi.database.DataCellSerialization
- readFully(long, byte[], int, int) - Method in class com.mckoi.store.StreamFile
-
Fully reads a block from a section of the file into the given byte[] array at the given position.
- readIndexTableList() - Method in class com.mckoi.database.IndexStore
-
Reads the index table allocation list in to the ByteBuffer object.
- readInt() - Method in class com.mckoi.database.CellBufferInputStream
- readInt() - Method in class com.mckoi.database.CellInputStream
- readInt() - Method in class com.mckoi.database.DataCellSerialization
- readLine() - Method in class com.mckoi.database.CellBufferInputStream
- readLine() - Method in class com.mckoi.database.CellInputStream
- readLine() - Method in class com.mckoi.database.DataCellSerialization
- readLong() - Method in class com.mckoi.database.CellBufferInputStream
- readLong() - Method in class com.mckoi.database.CellInputStream
- readLong() - Method in class com.mckoi.database.DataCellSerialization
- readLongAt(long) - Method in class com.mckoi.store.AbstractStore
- readObject(ObjectInputStream) - Method in class com.mckoi.database.Expression
-
Reads the state of this object from the object stream.
- readObject(ObjectInputStream) - Method in class com.mckoi.database.TObject
-
Serialization overwritten method.
- readOnlyAccess() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if the database is in read only mode.
- readPageContent(byte[], long, int) - Method in class com.mckoi.database.BlobStore.BLOBInputStream
- readPageContent(byte[], long, int) - Method in class com.mckoi.database.jdbc.AbstractStreamableObject.StreamableObjectInputStream
- readPageContent(byte[], long, int) - Method in class com.mckoi.util.PagedInputStream
-
Reads the page at the given offset in the underlying data into the given byte[] array.
- readPageContent(long, byte[], int) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Reads the current page content into memory.
- readRecord(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Reads in a complete record and puts it into the returned byte[] array.
- readRecordType(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Reads the record state for the given record in the table.
- readRecordType(int) - Method in class com.mckoi.database.V1MasterTableDataSource
- readRecordType(int) - Method in class com.mckoi.database.V2MasterTableDataSource
- readRecordType(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Reads the 32-bit type_key int for the given record.
- readReservedBuffer(byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Reads from the buffer reserve into the given byte array.
- readReservedBuffer(byte[], int, int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Reads reserved information from the variable data store.
- readSector(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Read the 'nth' sector from the store and fills the internal 'sector_buffer' with the contents.
- readSerialization(CellInput) - Method in class com.mckoi.database.DataCellSerialization
-
Reads input from the given CellInput object.
- readShort() - Method in class com.mckoi.database.CellBufferInputStream
- readShort() - Method in class com.mckoi.database.CellInputStream
- readShort() - Method in class com.mckoi.database.DataCellSerialization
- readStateResourceList(ArrayList, long) - Method in class com.mckoi.database.StateStore
-
Reads the state resource list from the given area in the store.
- readStoreHeaders() - Method in class com.mckoi.database.V2MasterTableDataSource
-
Read the store headers and initialize any internal object state.
- readString(int) - Method in class com.mckoi.database.VariableSizeDataStore
- READUNCOMMITTED - Static variable in interface com.mckoi.database.sql.SQLConstants
- readUnsignedByte() - Method in class com.mckoi.database.CellBufferInputStream
- readUnsignedByte() - Method in class com.mckoi.database.CellInputStream
- readUnsignedByte() - Method in class com.mckoi.database.DataCellSerialization
- readUnsignedShort() - Method in class com.mckoi.database.CellBufferInputStream
- readUnsignedShort() - Method in class com.mckoi.database.CellInputStream
- readUnsignedShort() - Method in class com.mckoi.database.DataCellSerialization
- readUTF() - Method in class com.mckoi.database.CellBufferInputStream
- readUTF() - Method in class com.mckoi.database.CellInputStream
- readUTF() - Method in class com.mckoi.database.DataCellSerialization
- readVisibleTables() - Method in class com.mckoi.database.TableDataConglomerate
-
Reads in the list of committed tables in this conglomerate.
- ready() - Method in class com.mckoi.database.jdbc.AsciiReader
- ready() - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- REAL - Static variable in interface com.mckoi.database.global.SQLTypes
- REAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- real_index - Variable in class com.mckoi.database.jdbc.MResultSet
-
The real index of the result set we are currently at.
- real_index_offset - Variable in class com.mckoi.database.jdbc.MResultSet
-
The offset into 'result_block' where 'real_index' is.
- realIndexUpdate() - Method in class com.mckoi.database.jdbc.MResultSet
-
This should be called when the 'real_index' variable changes.
- really_open - Variable in class com.mckoi.store.JournalledSystem.Resource
-
True if the underlying resource is really open.
- realTableExists(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns true if the table with the given name exists within this transaction.
- reboundArea(long, long[], boolean) - Method in class com.mckoi.store.AbstractStore
-
Rebounds the given area with the given header information.
- rebuildAllIndices(File, String) - Method in class com.mckoi.database.V1MasterTableDataSource
-
This may only be called from the 'fix' method.
- reclaimTopFree() - Method in class com.mckoi.database.FixedSizeDataStore
-
Reclaims the first sector from the free sector list.
- RECORD_STATE_ERROR - Static variable in interface com.mckoi.database.RawDiagnosticTable
-
Denotes an erroneous record state.
- RECORD_UID - Variable in class com.mckoi.database.InsertSearch
-
If this is true, then this SelectableScheme records additional rid information that can be used to very quickly identify whether a value is greater, equal or less.
- recordDeleted(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns true if the record with the given index is deleted from the table.
- recordDeleted(int) - Method in class com.mckoi.database.V1MasterTableDataSource
- recordDeleted(int) - Method in class com.mckoi.database.V2MasterTableDataSource
- recordDeleted(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns true if the given record is marked as deleted or not.
- recordMiscInformation(int) - Method in class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- recordMiscInformation(int) - Method in interface com.mckoi.database.RawDiagnosticTable
-
Returns any misc information regarding this row as a human readable string.
- recordSectorCount(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns the number of sectors the given record takes up in the data store.
- recordSize(int) - Method in class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- recordSize(int) - Method in interface com.mckoi.database.RawDiagnosticTable
-
The number of bytes the record takes up on the underlying media.
- recordSize(int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns the size of the given record number (compressed size if applicable).
- recordState(int) - Method in class com.mckoi.database.MasterTableDataSource.MRawDiagnosticTable
- recordState(int) - Method in interface com.mckoi.database.RawDiagnosticTable
-
Returns the state of the given record index.
- recordTypeInfo(int) - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the record type of the given record index.
- reduceCacheSize(long) - Method in class com.mckoi.database.DataCellCache
-
Reduce the cache size by the given amount.
- Ref - Interface in com.mckoi.database.global
-
An interface that represents a reference to a object that isn't stored in main memory.
- REF - Static variable in interface com.mckoi.database.global.SQLTypes
- ref_columns - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The list of columns that make up the referenced group.
- ref_count - Variable in class com.mckoi.database.BlobStore.CopyBlobInfo
- ref_table_name - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The referenced table name.
- reference_count - Variable in class com.mckoi.database.IndexSetStore.IndexBlock
-
The number of references to this object.
- reference_count - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
The number of threads currently looking at info in this journal.
- reference_count - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The number of references on this page.
- reference_id - Variable in class com.mckoi.database.BlobStore.AbstractRef
-
The reference identifier.
- reference_id - Variable in class com.mckoi.database.BlobStore.BLOBInputStream
- reference_list - Variable in class com.mckoi.database.JoinedTable
-
The list of tables that make up the join.
- reference_table_name - Variable in class com.mckoi.database.interpret.ConstraintDef
- referenceAdd() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Adds 1 to the reference counter on this page.
- referenceRemove() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Removes 1 from the reference counter on this page.
- REFERENCES - Static variable in class com.mckoi.database.Privileges
-
The priv to REFERENCE a database object.
- REFERENCES - Static variable in interface com.mckoi.database.sql.SQLConstants
- ReferenceTable - Class in com.mckoi.database
-
This is an implementation of a Table that references a DataTable as its parent.
- ReferenceTable(Table, DataTableDef) - Constructor for class com.mckoi.database.ReferenceTable
-
Constructs the ReferenceTable given the parent table, and a new DataTableDef that describes the columns in this table.
- ReferenceTable(Table, TableName) - Constructor for class com.mckoi.database.ReferenceTable
-
The Constructor.
- ReferentialTrigger() - Method in class com.mckoi.database.sql.SQL
- refreshLastCommandTime() - Method in class com.mckoi.database.User
-
Refreshes the last time a command was executed by this user.
- refreshRow() - Method in class com.mckoi.database.jdbc.MResultSet
- REGEX - Static variable in interface com.mckoi.database.sql.SQLConstants
- regex_library - Variable in class com.mckoi.database.TransactionSystem
-
The regular expression library bridge for the library we are configured to use.
- REGEX_LITERAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- regex_op - Static variable in class com.mckoi.database.Operator
- RegexLibrary - Interface in com.mckoi.database
-
An interface that links with a Regex library.
- regexMatch(TransactionSystem, String, String) - Static method in class com.mckoi.database.PatternSearch
-
Matches a string against a regular expression pattern.
- regexMatch(String, String, String) - Method in class com.mckoi.database.regexbridge.JavaRegex
- regexMatch(String, String, String) - Method in interface com.mckoi.database.RegexLibrary
-
Matches a regular expression against a string value.
- RegexOperator() - Constructor for class com.mckoi.database.Operator.RegexOperator
- regexSearch(Table, int, String) - Static method in class com.mckoi.database.PatternSearch
-
Matches a column of a table against a constant regular expression pattern.
- regexSearch(Table, int, String, String) - Method in class com.mckoi.database.regexbridge.JavaRegex
- regexSearch(Table, int, String, String) - Method in interface com.mckoi.database.RegexLibrary
-
Performs a regular expression search on the given column of the table.
- regexStringToClass(String) - Static method in class com.mckoi.database.TransactionSystem
-
Given a regular expression string representing a particular library, this will return the name of the class to use as a bridge between the library and Mckoi.
- register() - Static method in class com.mckoi.database.jdbc.MDriver
-
Static method that registers this driver with the JDBC driver manager.
- registered - Static variable in class com.mckoi.database.jdbc.MDriver
-
Set to true when this driver is registered.
- registerShutdownDelegate() - Method in class com.mckoi.database.control.TCPJDBCServer
-
Registers the delegate that closes this server when the database shuts down.
- registerShutDownDelegate(Runnable) - Method in class com.mckoi.database.Database
-
Registers the delegate that is executed when the shutdown thread is activated.
- registerShutDownDelegate(Runnable) - Method in class com.mckoi.database.DatabaseSystem
-
Registers the delegate that is executed when the shutdown thread is activated.
- rehashRIDList(int) - Method in class com.mckoi.database.RIDList
-
Rehashes the entire rid list.
- ReInit(SimpleCharStream) - Method in class com.mckoi.database.sql.SQLTokenManager
- ReInit(SimpleCharStream, int) - Method in class com.mckoi.database.sql.SQLTokenManager
- ReInit(SQLTokenManager) - Method in class com.mckoi.database.sql.SQL
- ReInit(InputStream) - Method in class com.mckoi.database.sql.SimpleCharStream
- ReInit(InputStream) - Method in class com.mckoi.database.sql.SQL
- ReInit(InputStream, int, int) - Method in class com.mckoi.database.sql.SimpleCharStream
- ReInit(InputStream, int, int, int) - Method in class com.mckoi.database.sql.SimpleCharStream
- ReInit(Reader) - Method in class com.mckoi.database.sql.SimpleCharStream
- ReInit(Reader) - Method in class com.mckoi.database.sql.SQL
- ReInit(Reader, int, int) - Method in class com.mckoi.database.sql.SimpleCharStream
- ReInit(Reader, int, int, int) - Method in class com.mckoi.database.sql.SimpleCharStream
- ReInitRounds() - Method in class com.mckoi.database.sql.SQLTokenManager
- relationally_linked_tables - Variable in class com.mckoi.database.interpret.Delete
-
Tables that are relationally linked to the table being inserted into, set after 'prepare'.
- relationally_linked_tables - Variable in class com.mckoi.database.interpret.Insert
-
Tables that are relationally linked to the table being inserted into, set after 'prepare'.
- relationally_linked_tables - Variable in class com.mckoi.database.interpret.UpdateTable
-
Tables that are relationally linked to the table being inserted into, set after 'prepare'.
- relative(int) - Method in class com.mckoi.database.jdbc.MResultSet
- release() - Method in class com.mckoi.database.Lock
-
Removes this lock from the queue.
- releaseReference(long) - Method in class com.mckoi.database.BlobStore
-
Tells the BlobStore that a static reference has been released to the given blob.
- releaseReference(long) - Method in interface com.mckoi.database.BlobStoreInterface
-
Tells the BlobStore that a static reference has been released to the given blob.
- releaseSavepoint(Savepoint) - Method in class com.mckoi.database.jdbc.MConnection
- RemoteDatabaseInterface - Class in com.mckoi.database.jdbc
-
An abstract implementation of DatabaseInterface that retrieves information from a remote server host.
- RemoteDatabaseInterface() - Constructor for class com.mckoi.database.jdbc.RemoteDatabaseInterface
- RemoteDatabaseInterface.ConnectionThread - Class in com.mckoi.database.jdbc
-
The connection thread that can dispatch commands concurrently through the in/out pipe.
- RemoteDatabaseInterface.MByteArrayOutputStream - Class in com.mckoi.database.jdbc
-
A ByteArrayOutputStream that allows us access to the underlying byte[] array.
- RemoteDatabaseInterface.ServerCommand - Class in com.mckoi.database.jdbc
-
Represents the data in a command from the server.
- remove() - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- remove() - Method in interface com.mckoi.util.IntegerIterator
-
Removes from the list the last element returned by the iterator.
- remove(int) - Method in class com.mckoi.database.BlindSearch
-
This scheme doesn't take any notice of insertions or removals.
- remove(int) - Method in class com.mckoi.database.CollatedBaseSearch
-
This scheme doesn't take any notice of insertions or removals.
- remove(int) - Method in class com.mckoi.database.InsertSearch
-
Removes a row from the list.
- remove(int) - Method in class com.mckoi.database.Privileges
-
Removes a privilege with a column list parameter.
- remove(int) - Method in class com.mckoi.database.SelectableScheme
-
Removes the given element from the set.
- remove(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Removes an int from the given position in the list.
- remove(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Removes an int from the given position in the list.
- remove(int) - Method in class com.mckoi.util.StringListBucket
-
Removes the string at the given index of the list.
- remove(int, int, int) - Method in class com.mckoi.database.DataCellCache
-
Removes a TObject from the cache.
- remove(Privileges) - Method in class com.mckoi.database.Privileges
-
Removes the given privileges from this privileges object and returns the new privileges object.
- remove(Object) - Method in class com.mckoi.util.Cache
-
Ensures that there is no cell with the given key in the cache.
- remove(Object, Object) - Method in class com.mckoi.util.HashMapList
-
Removes the given value from the list with the given key.
- remove(String) - Method in class com.mckoi.database.TableDescriptions
-
Removes a DataTableDef object from the list with the given name.
- removeAll() - Method in class com.mckoi.util.Cache
-
Clear the cache of all the entries.
- removeAllBlobReferencesForRecord(long) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Removes all blob references in the record area pointed to by 'record_p'.
- removed_list - Variable in class com.mckoi.database.TableBackedCache
-
The list of removed rows from the table above when a change is committed.
- removed_rows - Variable in class com.mckoi.database.TableCommitModificationEvent
-
A normalized list of all rows that were removed by the transaction being committed.
- removeDataIndexDef(int) - Method in class com.mckoi.database.DataIndexSetDef
-
Removes a DataIndexDef to this table.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.CompositeTable
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.DataTable
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.DataTableFilter
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.FilterTable
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.FunctionTable
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.JoinedTable
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.Table
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDataTableListener(DataTableListener) - Method in class com.mckoi.database.TemporaryTable
-
Removes a DataTableListener from the DataTable objects at the root of this table tree hierarchy.
- removeDeleteResource(String) - Method in class com.mckoi.database.StateStore
-
Removes the resource with the given name from the deleted list.
- removeDuplicates() - Method in class com.mckoi.database.RawTableInformation
-
Removes any duplicate rows from this RawTableInformation object.
- removeDuplicates(boolean) - Method in class com.mckoi.database.CompositeTable
-
Removes duplicate rows from the table.
- removeFromBinChain(long, long) - Method in class com.mckoi.store.AbstractStore
-
Removes the given area from the bin chain.
- removeFromBlock(int, IntegerListBlockInterface, int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Removes the value from the given position in the specified block.
- removeFromHash(Object) - Method in class com.mckoi.util.Cache
-
Removes the given node from the hash table.
- removeFunction(String) - Method in class com.mckoi.database.FunctionFactory
-
Removes a static function from this factory.
- removeGrant(Privileges, int, String, String, boolean, String) - Method in class com.mckoi.database.GrantManager
-
Removes a grant on the given object for the given grantee, grant option and granter.
- removeIndexSetFromList(IndexSet) - Method in class com.mckoi.database.IndexStore
-
Removes a SnapshotIndexSet from the list of sets that this store is managing.
- removeInt(int) - Method in class com.mckoi.util.IntegerVector
-
Removes the first Int found that matched the specified value.
- removeIntAt(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Removes an Int from the specified position in the block.
- removeIntAt(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Removes an Int from the specified position in the block.
- removeIntAt(int) - Method in class com.mckoi.util.IntegerVector
-
Removes an Int from the specified position in the list.
- removeListBlock(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Removes a IntegerListBlockInterface from the given index in the list of IntegerListBlockInterface's.
- removeLock(Lock) - Method in class com.mckoi.database.LockingQueue
-
Removes a lock from the queue.
- removeNativeTableGenerator(Transaction, TableName) - Static method in class com.mckoi.database.SequenceManager
-
Static convenience - removes an entry in the Sequence table for a native table in the database.
- removeRef(long) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Removes a Ref that has been cached in this table object by its identifier value.
- removeReference() - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Removes a reference to this object.
- removeReference() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Removes a reference, if we are at the last reference the journal file is deleted.
- removeResource(ArrayList, String) - Method in class com.mckoi.database.StateStore
-
Removes the given resource from the list.
- removeRID(int) - Method in class com.mckoi.database.RIDList
-
Removes a RID entry from the given row.
- removeRootLock() - Method in class com.mckoi.database.GTDataSource
- removeRootLock() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- removeRootLock() - Method in class com.mckoi.database.MasterTableDataSource
-
Removes a root lock from this table.
- removeRootLock() - Method in interface com.mckoi.database.MutableTableDataSource
-
Removes a root lock from this source.
- removeRow(int) - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- removeRow(int) - Method in class com.mckoi.database.DataTable
-
Removes the given row from the table.
- removeRow(int) - Method in interface com.mckoi.database.DataTableFile
-
Removes a row from the table at the given index.
- removeRow(int) - Method in class com.mckoi.database.GTDataSource
- removeRow(int) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- removeRow(int) - Method in interface com.mckoi.database.MutableTableDataSource
-
Completely removes a row from the source.
- removeRowsLock() - Method in interface com.mckoi.database.DataTableFile
-
Unlocks the data in the file to indicate that the system may safely overwrite removed entries in the file.
- removeRowToColumnSchemes(int) - Method in class com.mckoi.database.DefaultDataTable
-
This is called when an index to a row needs to be removed from the SelectableScheme objects.
- removeSort(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Removes a plain 'int' value from the sorted position in the list only if it's already in the list.
- removeSort(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Removes a plain 'int' value from the sorted position in the list only if it's already in the list.
- removeSort(Object, int, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Removes the key/val pair from the list by first searching for it, and then removing it from the list.
- removeSort(Object, int, IndexComparator) - Method in interface com.mckoi.util.IntegerListInterface
-
Removes the key/val pair from the list by first searching for it, and then removing it from the list.
- removeStreamableObject(StreamableObject) - Method in class com.mckoi.database.jdbc.MConnection
-
Removes the StreamableObject from the hold on the JDBC client.
- removeTopEntries(int) - Method in class com.mckoi.database.MasterTableJournal
-
Removes the top n entries from the journal.
- removeTransaction(Transaction) - Method in class com.mckoi.database.OpenTransactionList
-
Removes an open transaction from the list.
- removeTransactionModificationListener(TableName, TransactionModificationListener) - Method in class com.mckoi.database.TableDataConglomerate
-
Removes a listener for transaction modification events on the given table in this conglomerate as previously set by the 'addTransactionModificationListener' method.
- removeTriggerListener(DatabaseConnection, String) - Method in class com.mckoi.database.TriggerManager
-
Removes a trigger for the given user session.
- removeTriggerListener(String, TriggerListener) - Method in class com.mckoi.database.jdbc.MckoiConnection
-
Removes a TriggerListener that is listening for triggers with the given name.
- removeTriggerListener(String, TriggerListener) - Method in class com.mckoi.database.jdbc.MConnection
-
Removes the TriggerListener for the given trigger name.
- removeVisibleResource(String) - Method in class com.mckoi.database.StateStore
-
Removes the resource with the given name from the visible list.
- removeVisibleTable(MasterTableDataSource) - Method in class com.mckoi.database.SimpleTransaction
-
Removes a MasterTableDataSource (and its IndexSet) from this view and puts the information on the cleanup queue.
- rename(File, String, File, String) - Static method in class com.mckoi.database.VariableSizeDataStore
-
Convenience for renaming a VariableSizeDataStore store to another name.
- repair() - Method in class com.mckoi.database.FixedSizeDataStore
-
Repairs the consistancy of the store.
- repair(String, String) - Static method in class com.mckoi.tools.DBConglomerateRepairTool
- repairScan(ArrayList, long, long, boolean, int) - Method in class com.mckoi.store.AbstractStore
-
Performs a repair scan from the given pointer.
- REPEATABLEREAD - Static variable in interface com.mckoi.database.sql.SQLConstants
- request_processing - Variable in class com.mckoi.database.RIDList
-
Set to true if a request to build the rid list is on the event dispatcher.
- requestBuildRIDList() - Method in class com.mckoi.database.RIDList
-
Requests that a rid_list should be built for this column.
- requestPending() - Method in interface com.mckoi.database.jdbcserver.ServerConnection
-
This should return true if it has been determined that there is an entire command waiting to be serviced on this connection.
- requestPending() - Method in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
Inspects the input stream and determines in there's a command pending to be processed.
- requestResultPart(int, int, int) - Method in class com.mckoi.database.jdbc.MConnection
-
Called by MResultSet to query a part of a result from the server.
- requestStreamableObjectPart(int, long, long, int) - Method in class com.mckoi.database.jdbc.MConnection
-
Requests a part of a streamable object from the server.
- reset() - Method in class com.mckoi.database.CellBufferInputStream
- reset() - Method in class com.mckoi.database.CellInputStream
- reset() - Method in class com.mckoi.database.interpret.Statement
-
Resets this statement so it may be re-prepared and evaluated again.
- reset() - Method in class com.mckoi.database.jdbc.AsciiInputStream
- reset() - Method in class com.mckoi.database.jdbc.AsciiReader
- reset() - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- reset() - Method in class com.mckoi.database.LockingMechanism
-
Resets this object so it may be reused.
- reset() - Method in class com.mckoi.database.sql.SQL
-
Resets the parameter id.
- reset() - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- reset() - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Resets this object.
- reset() - Method in class com.mckoi.util.PagedInputStream
- resetAllSystemTableID() - Method in class com.mckoi.database.TableDataConglomerate
-
Resets the table sequence id for all the system tables managed by the conglomerate.
- resetSession() - Method in class com.mckoi.util.Stats
-
Resets all stats that start with "{session}" to 0.
- resetTableID(TableName) - Method in class com.mckoi.database.TableDataConglomerate
-
Given a table with a 'id' field, this will check that the sequence value for the table is at least greater than the maximum id in the column.
- resolve() - Method in class com.mckoi.database.BlindSearch.RangeChecker
-
Resolves the ranges.
- resolve(TableName, String) - Static method in class com.mckoi.database.Variable
-
Attempts to resolve a string '[table_name].[column]' to a Variable instance.
- resolve(Variable) - Method in class com.mckoi.database.FunctionTable.TableGroupResolver.TableGVResolver
- resolve(Variable) - Method in class com.mckoi.database.RowData.RDVariableResolver
- resolve(Variable) - Method in class com.mckoi.database.Table.TableVariableResolver
- resolve(Variable) - Method in class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- resolve(Variable) - Method in interface com.mckoi.database.VariableResolver
-
Returns the value of a given variable.
- resolve(Variable, int) - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
- resolve(Variable, int) - Method in interface com.mckoi.database.GroupResolver
-
Returns the value of a variable of a group.
- resolve(String) - Static method in class com.mckoi.database.TableName
-
Resolves a [schema name].[table name] type syntax to a TableName object.
- resolve(String) - Static method in class com.mckoi.database.Variable
-
Attempts to resolve a string '[table_name].[column]' to a Variable instance.
- resolve(String, String) - Static method in class com.mckoi.database.TableName
-
Resolves a [schema name].[table name] type syntax to a TableName object.
- resolveAgainstAliases(Variable) - Method in class com.mckoi.database.interpret.Statement
-
Overwrite this method if your statement has some sort of column aliasing capability (such as a select statement).
- resolveAllRowsForTableAt(IntegerVector, int) - Method in class com.mckoi.database.JoinedTable
-
Given an IntegerVector that represents a list of pointers to rows in this table, this resolves the rows to row indexes in the given parent table.
- resolveAllRowsForTableAt(IntegerVector, int) - Method in class com.mckoi.database.NaturallyJoinedTable
- resolveAllRowsForTableAt(IntegerVector, int) - Method in class com.mckoi.database.VirtualTable
- resolveAssignmentReference(Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Resolves the given Variable object to an assignment if it's possible to do so within the context of this set.
- resolveCell(TObject) - Method in class com.mckoi.database.BlindSearch.RangeChecker
-
Resolves a cell.
- resolveColumn(Variable) - Method in class com.mckoi.database.interpret.Statement
-
Attempts to resolve an ambiguous column name such as 'id' into a Variable from the tables in this statement.
- resolveColumn(String, String, String, String) - Method in class com.mckoi.database.interpret.FromTableDirectSource
- resolveColumn(String, String, String, String) - Method in interface com.mckoi.database.interpret.FromTableInterface
-
Returns a Variable that is a fully resolved form of the given column in this table set.
- resolveColumn(String, String, String, String) - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
- resolveColumnCount(String, String, String, String) - Method in class com.mckoi.database.interpret.FromTableDirectSource
- resolveColumnCount(String, String, String, String) - Method in interface com.mckoi.database.interpret.FromTableInterface
-
Returns the number of instances we can resolve the given catalog, schema, table and column name to a column or columns within this item.
- resolveColumnCount(String, String, String, String) - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
- resolveColumnName(String) - Method in class com.mckoi.database.interpret.ColumnChecker
-
Returns the resolved column name if the column exists within the table being checked under, or null if it doesn't.
- resolveColumnName(String, boolean) - Method in class com.mckoi.database.DataTableDef
-
Resolves a single column name to its correct form.
- resolveColumns(boolean, Expression) - Method in class com.mckoi.database.DataTableDef
-
Resolves variables in a column so that any unresolved column names point to this table.
- resolveColumnsInArray(DatabaseConnection, ArrayList) - Method in class com.mckoi.database.DataTableDef
-
Given a list of column names referencing entries in this table, this will resolve each one to its correct form.
- resolved_name - Variable in class com.mckoi.database.interpret.SelectColumn
-
The fully resolved name that this column is given in the resulting table.
- resolveExpression(Expression) - Method in class com.mckoi.database.interpret.Statement
-
Given an Expression, this will run through the expression and resolve any variable names via the 'resolveVariableName' method here.
- resolveFunctionName(String, Expression[]) - Static method in class com.mckoi.database.sql.Util
-
Returns a Function object that represents the name and expression list (of parameters) of a function.
- resolveIndexName(String, boolean) - Method in class com.mckoi.database.DataIndexSetDef
-
Attempts to resolve the given index name from the index in this table.
- resolveReference(Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Resolves the given Variable object to a fully resolved Variable within the context of this table expression.
- resolveRowForTableAt(int, int) - Method in class com.mckoi.database.JoinedTable
-
Given a row and a table index (to a parent reference table), this will return the row index in the given parent table for the given row.
- resolveRowForTableAt(int, int) - Method in class com.mckoi.database.NaturallyJoinedTable
- resolveRowForTableAt(int, int) - Method in class com.mckoi.database.VirtualTable
- resolveSchema(String) - Method in class com.mckoi.database.TableName
-
Resolves a schema reference in a table name.
- resolveSchemaCase(String, boolean) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.resolveSchemaCase method.
- resolveSchemaCase(String, boolean) - Method in class com.mckoi.database.Transaction
-
Resolves the case of the given schema name if the database is performing case insensitive identifier matching.
- resolveSchemaName(String) - Method in class com.mckoi.database.DatabaseConnection
-
Convenience - returns the SchemaDef object given the name of the schema.
- resolveSortedSet() - Method in class com.mckoi.database.BlindSearch.RangeChecker
- resolveTableColumnReference(Variable) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Resolves the given Variable against the table columns in this from set.
- resolveTableName(TableName) - Method in class com.mckoi.database.Variable
-
Returns a ColumnName that is resolved against a table name context only if the ColumnName is unknown in this object.
- resolveTableName(String) - Method in class com.mckoi.database.DatabaseConnection
-
Resolves a TableName string (eg.
- resolveTableName(String, DatabaseConnection) - Method in class com.mckoi.database.interpret.Statement
-
Resolves a TableName string (eg.
- resolveToClass(String) - Static method in class com.mckoi.database.ProcedureManager
-
Resolves a Java class specification string to a Java Class object.
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.CompositeTable
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.DataTable
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.DataTableFilter
-
Return the list of DataTable and row sets that make up the raw information in this table.
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.DefaultDataTable
-
Return the list of DataTable and row sets that make up the raw information in this table.
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.FilterTable
-
Return the list of DataTable and row sets that make up the raw information in this table.
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.JoinedTable
-
Return the list of DataTable and row sets that make up the raw information in this table.
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.SubsetColumnTable
-
Return the list of DataTable and row sets that make up the raw information in this table.
- resolveToRawTable(RawTableInformation) - Method in class com.mckoi.database.Table
-
Return the list of DataTable and row sets that make up the raw information in this table.
- resolveToRawTable(RawTableInformation, IntegerVector) - Method in class com.mckoi.database.JoinedTable
-
Returns an object that contains fully resolved, one level only information about the DataTable and the row indices of the data in this table.
- resolveToTableName(String) - Method in class com.mckoi.database.DatabaseConnection
-
Resolves the given string to a table name, throwing an exception if the reference is ambiguous.
- resolveToTableName(String, String, boolean) - Method in class com.mckoi.database.SimpleTransaction
-
Resolves the given string to a table name, throwing an exception if the reference is ambiguous.
- resolveToVariable(String) - Method in class com.mckoi.database.TemporaryTable
-
Resolves the given column name (eg 'id' or 'Customer.id' or 'APP.Customer.id') to a column in this table.
- resolveTree() - Method in class com.mckoi.database.interpret.Statement
-
Performs initial preparation on the contents of the StatementTree by resolving all sub queries and mapping functions to their executable forms.
- resolveVariableName(Variable) - Method in class com.mckoi.database.interpret.Statement
-
Given a Variable object, this will resolve the name into a column name the database understands (substitutes aliases, etc).
- Resource(String, long, StoreDataAccessor) - Constructor for class com.mckoi.store.JournalledSystem.Resource
-
Constructs the resource.
- resource_id_map - Variable in class com.mckoi.store.JournalledSystem.JournalFile
-
A map between a resource name and an id for this journal file.
- resource_list - Variable in class com.mckoi.store.JournalledSystem.JournalSummary
-
The list of all resource names that this journal 'touches'.
- resource_name - Variable in class com.mckoi.store.JournalledFileStore
-
The name of the resource.
- resource_name - Variable in class com.mckoi.store.JournalledSystem.JournalEntry
-
The resource that this page is on.
- RESTRICT - Static variable in interface com.mckoi.database.sql.SQLConstants
- result - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
The table that is the result.
- result_block - Variable in class com.mckoi.database.jdbc.MResultSet
-
The Vector that contains the Objects downloaded into this result set.
- result_id - Variable in class com.mckoi.database.jdbc.MResultSet
-
The current result_id for the information in the current result set.
- result_id - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- result_is_simple_enum - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Set to true if the result table has a SimpleRowEnumeration, therefore guarenteeing we do not need to store a row lookup list.
- result_row_count - Variable in class com.mckoi.database.jdbc.MResultSet
-
The number of rows in the result set.
- result_row_count - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
The number of rows in the result.
- RESULT_SECTION - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Requests a section of a result from the server.
- result_set - Variable in class com.mckoi.database.jdbc.MResultSetMetaData
-
The parent MResultSet object.
- result_set - Variable in class com.mckoi.jfccontrols.QueryAgent
-
If a ResultSet was obtained from the query, the ResultSet.
- result_set - Variable in class com.mckoi.jfccontrols.ResultSetTableModel
-
The scrollable ResultSet source.
- result_set_id - Variable in class com.mckoi.database.jdbc.AbstractStreamableObject
-
The result_id of the ResultSet this clob is from.
- result_set_info - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- result_set_list - Variable in class com.mckoi.database.jdbc.MStatement
-
The list of all MResultSet objects that represents the results of a query.
- result_set_map - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
The mapping that maps from result id number to Table object that this JDBC connection is currently maintaining.
- result_table - Variable in class com.mckoi.tools.JDBCQueryTool
-
The JTable where the query result is printed.
- ResultOutputUtil - Class in com.mckoi.util
-
Utilities for parsing a ResultSet and outputing it in different forms.
- ResultOutputUtil() - Constructor for class com.mckoi.util.ResultOutputUtil
- ResultPart - Class in com.mckoi.database.jdbc
-
A container class that holds a part of a result set.
- ResultPart() - Constructor for class com.mckoi.database.jdbc.ResultPart
- ResultPart(int) - Constructor for class com.mckoi.database.jdbc.ResultPart
- resultSection(int, byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Responds with a part of the result set of a query made via the 'QUERY' command.
- ResultSetInfo(SQLQuery, Table) - Constructor for class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Constructs the result set.
- ResultSetTableModel - Class in com.mckoi.jfccontrols
-
An implementation of a javax.swing.table.TableModel that updates itself from a scrollable java.sql.ResultSet source.
- ResultSetTableModel() - Constructor for class com.mckoi.jfccontrols.ResultSetTableModel
- ResultSetTableModel(ResultSet) - Constructor for class com.mckoi.jfccontrols.ResultSetTableModel
-
Constructs the model.
- resultTable(DatabaseQueryContext, int) - Static method in class com.mckoi.database.FunctionTable
-
Returns a FunctionTable that has an int value made into a BigDecimal.
- resultTable(DatabaseQueryContext, Expression) - Static method in class com.mckoi.database.FunctionTable
-
Returns a FunctionTable that has a single Expression evaluated in it.
- resultTable(DatabaseQueryContext, TObject) - Static method in class com.mckoi.database.FunctionTable
-
Returns a FunctionTable that has a single TObject in it.
- resultTable(DatabaseQueryContext, Object) - Static method in class com.mckoi.database.FunctionTable
-
Returns a FunctionTable that has a single Object in it.
- RETURNS - Static variable in interface com.mckoi.database.sql.SQLConstants
- returnTType() - Method in class com.mckoi.database.AbstractFunction
- returnTType() - Method in class com.mckoi.database.CorrelatedVariable
-
Returns the TType this correlated variable evaluates to.
- returnTType() - Method in class com.mckoi.database.InternalFunctionFactory.LowerFunction
- returnTType() - Method in class com.mckoi.database.InternalFunctionFactory.PrivGroupsFunction
- returnTType() - Method in class com.mckoi.database.InternalFunctionFactory.SubstringFunction
- returnTType() - Method in class com.mckoi.database.InternalFunctionFactory.UpperFunction
- returnTType() - Method in class com.mckoi.database.InternalFunctionFactory.UserFunction
- returnTType() - Method in class com.mckoi.database.Operator
-
The type of object this Operator evaluates to.
- returnTType(Variable) - Method in class com.mckoi.database.FunctionTable.TableGroupResolver.TableGVResolver
- returnTType(Variable) - Method in class com.mckoi.database.RowData.RDVariableResolver
- returnTType(Variable) - Method in class com.mckoi.database.Table.TableVariableResolver
- returnTType(Variable) - Method in class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- returnTType(Variable) - Method in interface com.mckoi.database.VariableResolver
-
Returns the TType of object the given variable is.
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.AbstractFunction
-
By Default, we assume a function returns a Numeric object.
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.Expression
-
Determines the type of object this expression evaluates to.
- returnTType(VariableResolver, QueryContext) - Method in interface com.mckoi.database.Function
-
The type of object this function returns.
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.BinaryToHexFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.CoalesceFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ConcatFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.CurrValFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.DateFormatFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.DateObFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.GreatestFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.HexToBinaryFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.IfFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.JavaObjectInstantiation
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.JavaObjectInstantiation2
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.LeastFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.LTrimFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.MaxFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.MinFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.NextValFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.PrivilegeString
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.RTrimFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SetValFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SQLCastFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SQLTrimFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.SQLTypeString
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.TimeObFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.TimeStampObFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.UniqueKeyFunction
- returnTType(VariableResolver, QueryContext) - Method in class com.mckoi.database.InternalFunctionFactory.ViewDataConvert
- reverse() - Method in class com.mckoi.database.Operator
-
Returns an Operator that is the reverse of this Operator.
- reverse() - Method in class com.mckoi.util.IntegerVector
-
Reverses all the list of integers.
- reverse_column_map - Variable in class com.mckoi.database.SubsetColumnTable
-
Maps from the column in the parent table, to the column in this table.
- Revoke() - Method in class com.mckoi.database.sql.SQL
- REVOKE - Static variable in interface com.mckoi.database.sql.SQLConstants
- revokeAllGrantsOnObject(int, String) - Method in class com.mckoi.database.GrantManager
-
Completely removes all privs granted on the given object for all users.
- revokeAllGrantsOnObject(int, String, String, boolean, String) - Method in class com.mckoi.database.GrantManager
-
Removes all privs granted on the given object for the given grantee with the given grant option.
- rid_list - Variable in class com.mckoi.database.RIDList
-
The contents of our list.
- RIDList - Class in com.mckoi.database
-
This is an optimization to help sorting over a column in a table.
- RIDList(MasterTableDataSource, int) - Constructor for class com.mckoi.database.RIDList
-
Constructs the object.
- right - Variable in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
The left and right node.
- right() - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
-
Returns the right node.
- RIGHT - Static variable in interface com.mckoi.database.sql.SQLConstants
- right_columns - Variable in class com.mckoi.database.QueryPlan.EquiJoinNode
-
The columns in the right table.
- right_expression - Variable in class com.mckoi.database.QueryPlan.JoinNode
-
The expression evaluated on the right table.
- right_expression - Variable in class com.mckoi.database.QueryPlan.SimpleSelectNode
-
The RHS expression.
- right_is_simple_enum - Variable in class com.mckoi.database.NaturallyJoinedTable
- right_join_type - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
- right_on_expr - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
- RIGHT_OUTER_JOIN - Static variable in class com.mckoi.database.JoiningSet
- right_plan - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
-
How this plan is naturally joined to other plans in the source.
- right_row_count - Variable in class com.mckoi.database.NaturallyJoinedTable
-
The row counts of the left and right tables.
- right_set - Variable in class com.mckoi.database.NaturallyJoinedTable
-
The lookup row set for the left and right tables.
- rollback() - Method in class com.mckoi.database.DatabaseConnection
-
Rolls back the current transaction operating within this connection.
- rollback() - Method in class com.mckoi.database.jdbc.MConnection
- rollback(Savepoint) - Method in class com.mckoi.database.jdbc.MConnection
- ROLLBACK - Static variable in interface com.mckoi.database.sql.SQLConstants
- rollbackEntries(int) - Method in class com.mckoi.database.MasterTableJournal
-
Rolls back the last n entries of this journal.
- rollbackTransactionChange(MasterTableJournal) - Method in class com.mckoi.database.MasterTableDataSource
-
Rolls back a transaction change in this table source.
- rollForwardRecover() - Method in class com.mckoi.store.JournalledSystem
-
Recovers any lost operations that are currently in the journal.
- root_lock - Variable in class com.mckoi.database.MasterTableDataSource
-
The number of root locks this table data source has on it.
- root_lock_key - Variable in class com.mckoi.database.MasterTableDataSource
-
The keys we use for Database.stats() for information for this table.
- root_name - Variable in class com.mckoi.database.interpret.FromTableDirectSource
-
The root name of the table.
- roots_locked - Variable in class com.mckoi.database.CompositeTable
-
The number of root locks on this table.
- roots_locked - Variable in class com.mckoi.database.JoinedTable
-
Incremented when the roots are locked.
- RootTable - Interface in com.mckoi.database
-
Interface that is implemented by all Root tables.
- RoundFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.RoundFunction
- row - Variable in class com.mckoi.database.DataCellCache.DCCacheKey
- row - Variable in class com.mckoi.database.jdbc.RowCache.CachedRow
- row - Variable in class com.mckoi.database.jdbc.RowCache.RowRef
- ROW - Static variable in interface com.mckoi.database.sql.SQLConstants
- row_cache - Variable in class com.mckoi.database.jdbc.MConnection
-
A cache of all rows retrieved from the server.
- row_cache - Variable in class com.mckoi.database.jdbc.RowCache
-
The actual cache that stores the rows.
- row_count - Variable in class com.mckoi.database.DefaultDataTable
-
The number of rows in the table.
- row_count - Variable in class com.mckoi.database.GTTableColumnsDataSource
-
The number of rows in this table.
- row_count - Variable in class com.mckoi.database.GTTableInfoDataSource
-
The number of rows in this table.
- row_count - Variable in class com.mckoi.database.VirtualTable
-
The number of rows in the table.
- row_count - Variable in class com.mckoi.jfccontrols.ResultSetTableModel
-
The number of rows in the result set.
- row_count_store - Variable in class com.mckoi.database.SimpleRowEnumeration
-
The number of rows in the enumeration.
- row_data - Variable in class com.mckoi.database.jdbc.RowCache.CachedRow
- row_data - Variable in class com.mckoi.database.TableModificationEvent
-
A RowData object representing the row that is being inserted by this modification.
- row_index - Variable in class com.mckoi.database.Table.TableVariableResolver
- row_index - Variable in class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- row_index - Variable in class com.mckoi.database.TableModificationEvent
-
The row index of the table that is before removed by this modification.
- row_index_map - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
IntegerVector that contains the row index into the table for each row of the result.
- row_list - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The index that represents the rows that are within this table data source within this transaction.
- row_list - Variable in class com.mckoi.database.VirtualTable
-
Array of IntegerVectors that represent the rows taken from the given parents.
- row_list_rebuild - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The 'recovery point' to which the row index in this table source has rebuilt to.
- ROW_REMOVE_CLASH - Static variable in exception com.mckoi.database.TransactionException
-
Thrown when a transaction deletes or updates a row that another transaction has committed a change to.
- row_set - Variable in class com.mckoi.database.RawTableElement
- row_vals - Variable in class com.mckoi.database.RawRowElement
- rowAdded(int, RowData) - Method in interface com.mckoi.database.MasterTableListener
-
Notifies of a new row addition to the underlying representation.
- rowAdded(DataTable, int) - Method in interface com.mckoi.database.DataTableListener
-
Called after a row entry in the table is added.
- RowCache - Class in com.mckoi.database.jdbc
-
A Cache that stores rows retrieved from the server in result set's.
- RowCache(int, int) - Constructor for class com.mckoi.database.jdbc.RowCache
-
Constructs the cache.
- RowCache.CachedRow - Class in com.mckoi.database.jdbc
-
A cached row.
- RowCache.RowRef - Class in com.mckoi.database.jdbc
-
Used for the hash key in the cache.
- rowCount() - Method in class com.mckoi.database.jdbc.MResultSet
-
The total number of rows in the result set.
- rowCountOfReferenceTable(SimpleTransaction, int, TableName, String[], TableName, String[], boolean) - Static method in class com.mckoi.database.TableDataConglomerate
-
Finds the number of rows that are referenced between the given row of table1 and that match table2.
- RowData - Class in com.mckoi.database
-
Represents a row of data to be added into a table.
- RowData(TableDataSource) - Constructor for class com.mckoi.database.RowData
-
The Constructor generates a blank row.
- RowData(TransactionSystem, int) - Constructor for class com.mckoi.database.RowData
-
To create a RowData object without an underlying table.
- RowData.RDVariableResolver - Class in com.mckoi.database
-
Variable resolver for this context.
- rowDeleted() - Method in class com.mckoi.database.jdbc.MResultSet
- rowDeleted(DataTable, int) - Method in interface com.mckoi.database.DataTableListener
-
Called before a row entry in the table is deleted.
- rowEnumeration() - Method in class com.mckoi.database.CompositeTable
- rowEnumeration() - Method in class com.mckoi.database.DataTable
-
Returns an Enumeration of the rows in this table.
- rowEnumeration() - Method in class com.mckoi.database.DataTableFilter
-
Returns an Enumeration of the rows in this table.
- rowEnumeration() - Method in class com.mckoi.database.FilterTable
-
Returns an Enumeration of the rows in this table.
- rowEnumeration() - Method in class com.mckoi.database.FunctionTable
-
Returns an Enumeration of the rows in this table.
- rowEnumeration() - Method in class com.mckoi.database.GTDataSource
- rowEnumeration() - Method in class com.mckoi.database.JoinedTable
-
Returns an Enumeration of the rows in this table.
- rowEnumeration() - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- rowEnumeration() - Method in class com.mckoi.database.SimpleTableQuery
-
Returns a RowEnumeration that is used to iterate through the entire list of valid rows in the table.
- rowEnumeration() - Method in class com.mckoi.database.Table
-
Returns an Enumeration of the rows in this table.
- rowEnumeration() - Method in interface com.mckoi.database.TableDataSource
-
Returns an iterator that is used to sequentually step through all valid rows in this source.
- rowEnumeration() - Method in class com.mckoi.database.TemporaryTable
-
Returns an Enumeration of the rows in this table.
- RowEnumeration - Interface in com.mckoi.database
-
This enumeration allows for access to a tables rows.
- rowGroup(int) - Method in class com.mckoi.database.FunctionTable
-
Returns the group of the row at the given index.
- rowInserted() - Method in class com.mckoi.database.jdbc.MResultSet
- RowRef(int, int) - Constructor for class com.mckoi.database.jdbc.RowCache.RowRef
- rowRemoved(int) - Method in interface com.mckoi.database.MasterTableListener
-
Notifies that a row has been permanently removed from the underlying representation.
- rowUpdated() - Method in class com.mckoi.database.jdbc.MResultSet
- RTrimFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.RTrimFunction
- run() - Method in class com.mckoi.database.DatabaseDispatcher
- run() - Method in class com.mckoi.database.DatabaseSystem.ShutdownThread
- run() - Method in class com.mckoi.database.jdbc.MConnection.TriggerDispatchThread
- run() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Listens for commands from the server.
- run() - Method in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
The Runnable method of the farmer thread.
- run() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
The Runnable method of the farmer thread.
- run() - Method in class com.mckoi.database.MasterTableGarbageCollector.CollectionEvent
- run() - Method in class com.mckoi.database.WorkerThread
-
Starts executing this worker thread.
- run() - Method in class com.mckoi.jfccontrols.QueryAgent.QueryThread
- run() - Method in class com.mckoi.store.JournalledSystem.JournalingThread
- run_queue - Variable in class com.mckoi.database.WorkerPool
-
A list of pending Runnable objects that are due to be executed.
- RunCommand(User, DatabaseConnection, Runnable) - Constructor for class com.mckoi.database.WorkerPool.RunCommand
- runnable - Variable in class com.mckoi.database.DatabaseDispatcher.DatabaseEvent
- runnable - Variable in class com.mckoi.database.WorkerPool.RunCommand
- running_dispatch_id - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Running dispatch id values which we use as a unique key.
- running_fun_number - Variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The current number of 'FUNCTIONTABLE.' columns in the table.
S
- s_col_list - Variable in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
The list of SelectColumn.
- s_object_hold - Variable in class com.mckoi.database.jdbc.MConnection
-
A mapping from a streamable object id to InputStream used to represent the object when being uploaded to the database engine.
- s_object_id - Variable in class com.mckoi.database.jdbc.MConnection
-
An unique id count given to streamable object being uploaded to the server.
- s_run_file_hits - Variable in class com.mckoi.database.V1MasterTableDataSource
- s_run_file_hits - Variable in class com.mckoi.database.V2MasterTableDataSource
- s_run_total_hits - Variable in class com.mckoi.database.V1MasterTableDataSource
- safeSetComparator() - Method in class com.mckoi.database.InsertSearch
-
This needs to be called to access 'set_comparator' in thread busy methods.
- save() - Method in class com.mckoi.database.TableDescriptions
-
Updates the table description file in the database.
- saveDataTableDef(DataTableDef) - Method in class com.mckoi.database.V1MasterTableDataSource
- scale - Variable in class com.mckoi.database.DataTableColumnDef
-
The scale of the data.
- scale - Variable in class com.mckoi.database.global.ColumnDescription
-
The scale of a numerical value.
- scale - Variable in class com.mckoi.database.TNumericType
-
The scale of the number.
- scanForLeaks() - Method in class com.mckoi.database.V2MasterTableDataSource
-
Looks for any leaks in the file.
- ScatteringStoreDataAccessor - Class in com.mckoi.store
-
An implementation of StoreDataAccessor that scatters the addressible data resource across multiple files in the file system.
- ScatteringStoreDataAccessor(File, String, String, long) - Constructor for class com.mckoi.store.ScatteringStoreDataAccessor
-
Constructs the store data accessor.
- ScatteringStoreDataAccessor.FileSlice - Class in com.mckoi.store
-
An object that contains information about a file slice.
- schema - Variable in class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- schema - Variable in class com.mckoi.database.ProcedureName
-
The schema of this procedure.
- Schema - Class in com.mckoi.database.interpret
-
Statement container that handles the CREATE SCHEMA and DROP SCHEMA statements.
- Schema() - Constructor for class com.mckoi.database.interpret.Schema
- SCHEMA - Static variable in class com.mckoi.database.GrantManager
-
Represents a SCHEMA object to grant privs over for the user.
- SCHEMA - Static variable in interface com.mckoi.database.sql.SQLConstants
- SCHEMA_ALL_PRIVS - Static variable in class com.mckoi.database.Privileges
-
All access privs for a schema object.
- SCHEMA_INFO_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
-
The schema info table.
- SCHEMA_MANAGER_GROUP - Static variable in class com.mckoi.database.Database
-
The name of the schema manager group.
- schema_name - Variable in class com.mckoi.database.interpret.Schema
-
The name of the schema.
- schema_name - Variable in class com.mckoi.database.TableName
-
The name of the schema of the table.
- SCHEMA_READ_PRIVS - Static variable in class com.mckoi.database.Privileges
-
Read access privs for a schema object.
- SchemaDef - Class in com.mckoi.database
-
A definition of a schema.
- SchemaDef(String, String) - Constructor for class com.mckoi.database.SchemaDef
-
Constructs the SchemaDef.
- schemaExists(String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.schemaExists method.
- schemaExists(String) - Method in class com.mckoi.database.Transaction
-
Returns true if the schema exists within this transaction.
- SchemaName() - Method in class com.mckoi.database.sql.SQL
- scheme_rebuilds - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The 'recovery point' to which the schemes in this table source have rebuilt to.
- sda_factory - Variable in class com.mckoi.store.JournalledSystem
-
A factory that creates StoreDataAccessor objects used to access the resource with the given name.
- search(Table, int, String) - Static method in class com.mckoi.database.PatternSearch
-
This is the search method.
- search(Table, int, String, char) - Static method in class com.mckoi.database.PatternSearch
-
This is the search method.
- search(TObject, IntegerVector, int, int) - Method in class com.mckoi.database.BlindSearch
-
We implement an insert sort algorithm here.
- search_expression - Variable in class com.mckoi.database.interpret.SearchExpression
-
The originating expression.
- searchAndReplace(String, String, String) - Static method in class com.mckoi.util.StringUtil
-
Searches for various instances of the 'search' string and replaces them with the 'replace' string.
- SearchExpression - Class in com.mckoi.database.interpret
-
Search expression is a form of an Expression that is split up into component parts that can be easily formed into a search query.
- SearchExpression() - Constructor for class com.mckoi.database.interpret.SearchExpression
- searchFirst(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Assuming a sorted block, finds the first index in the block that equals the given value.
- searchFirst(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Assuming a sorted block, finds the first index in the block that equals the given value.
- searchFirst(TObject) - Method in class com.mckoi.database.CollatedBaseSearch
-
Finds the position in the collated set of the first value in the column equal to the given value.
- searchFirst(TObject) - Method in class com.mckoi.database.GTPrivMapDataSource.PrivMapSearch
- searchFirst(TObject) - Method in class com.mckoi.database.InsertSearch
- searchFirst(Object, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Returns the index of the first value in this set that equals the given value.
- searchFirst(Object, IndexComparator) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Considers each int a reference to another structure, and the block sorted by these structures.
- searchFirst(Object, IndexComparator) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Considers each int a reference to another structure, and the block sorted by these structures.
- searchFirst(Object, IndexComparator) - Method in interface com.mckoi.util.IntegerListInterface
-
Returns the index of the first value in this set that equals the given value.
- searchLast(int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Assuming a sorted block, finds the first index in the block that equals the given value.
- searchLast(int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Assuming a sorted block, finds the first index in the block that equals the given value.
- searchLast(TObject) - Method in class com.mckoi.database.CollatedBaseSearch
-
Finds the position in the collated set of the last value in the column equal to the given value.
- searchLast(TObject) - Method in class com.mckoi.database.GTPrivMapDataSource.PrivMapSearch
- searchLast(TObject) - Method in class com.mckoi.database.InsertSearch
- searchLast(Object, IndexComparator) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Returns the index of the last value in this set that equals the given value.
- searchLast(Object, IndexComparator) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Considers each int a reference to another structure, and the block sorted by these structures.
- searchLast(Object, IndexComparator) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Considers each int a reference to another structure, and the block sorted by these structures.
- searchLast(Object, IndexComparator) - Method in interface com.mckoi.util.IntegerListInterface
-
Returns the index of the last value in this set that equals the given value.
- SearchResults - Class in com.mckoi.util
-
This object stores the result of a given search.
- SearchResults() - Constructor for class com.mckoi.util.SearchResults
-
The Constructor.
- SECONDARY_STRENGTH - Static variable in interface com.mckoi.database.sql.SQLConstants
- sector - Variable in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
-
The current sector we are traversing.
- sector_buffer - Variable in class com.mckoi.database.FixedSizeDataStore
-
The sector buffer.
- sector_buffer - Variable in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
-
A reference to the sector buffer.
- sector_cache - Variable in class com.mckoi.database.FixedSizeDataStore
-
A cache of sectors read from the store.
- sector_cache - Variable in class com.mckoi.database.IndexStore
-
A cache of int[] array blocks that are accessed by this store.
- SECTOR_DATA_OFFSET - Static variable in class com.mckoi.database.FixedSizeDataStore
-
The offset in the file where the sector data starts.
- sector_offset - Variable in class com.mckoi.database.FixedSizeDataStore
-
The offset where the header information finishes and the sector data starts.
- sector_output_stream - Variable in class com.mckoi.database.FixedSizeDataStore
-
The last sector output stream that was created.
- sector_output_stream - Variable in class com.mckoi.database.VariableSizeDataStore
- sector_size - Variable in class com.mckoi.database.FixedSizeDataStore
-
The size of each 'sector'
- sectorCount() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the total number of sectors in the file.
- SectorInputStream(int) - Constructor for class com.mckoi.database.FixedSizeDataStore.SectorInputStream
-
Constructor.
- SectorOutputStream() - Constructor for class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
- SECTORS_CACHED - Static variable in class com.mckoi.database.FixedSizeDataStore
-
If true then sectors are cached in the 'sector_cache'.
- sectorSize() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns the size (in bytes) of the sectors used to store information in the data file.
- SECURE_GROUP - Static variable in class com.mckoi.database.Database
-
THe name of the secure access group.
- seek(int) - Method in class com.mckoi.database.CellBufferOutputStream
-
Sets the pointer to specified point in the array.
- seekSector(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Seeks to the 'nth' sector in the store.
- select - Variable in class com.mckoi.database.interpret.Insert
- Select - Class in com.mckoi.database.interpret
-
Logic for interpreting an SQL SELECT statement.
- Select() - Constructor for class com.mckoi.database.interpret.Select
- Select() - Method in class com.mckoi.database.sql.SQL
- SELECT - Static variable in class com.mckoi.database.Privileges
-
The priv to SELECT from a database object.
- SELECT - Static variable in interface com.mckoi.database.sql.SQLConstants
- select_expression - Variable in class com.mckoi.database.interpret.Select
-
The TableSelectExpression representing the select query itself.
- select_expression - Variable in class com.mckoi.database.interpret.ViewManager
-
If this is a create command, the TableSelectExpression that forms the view.
- SelectableRange - Class in com.mckoi.database
-
An object that represents a range of values to select from a list.
- SelectableRange(byte, TObject, byte, TObject) - Constructor for class com.mckoi.database.SelectableRange
-
Constructs the range.
- SelectableRangeSet - Class in com.mckoi.database
-
Represents a complex normalized range of a list.
- SelectableRangeSet() - Constructor for class com.mckoi.database.SelectableRangeSet
-
Constructs the SelectableRangeSet to a full range (a range that encompases all values).
- SelectableScheme - Class in com.mckoi.database
-
Represents a base class for a mechanism to select ranges from a given set.
- SelectableScheme(TableDataSource, int) - Constructor for class com.mckoi.database.SelectableScheme
-
The constructor for all schemes.
- selectAll() - Method in class com.mckoi.database.BlindSearch
- selectAll() - Method in class com.mckoi.database.CollatedBaseSearch
- selectAll() - Method in class com.mckoi.database.InsertSearch
-
The select operations for this scheme.
- selectAll() - Method in class com.mckoi.database.SelectableScheme
-
These are the select operations that are the main purpose of the scheme.
- selectAll() - Method in class com.mckoi.database.Table
-
Returns a list of rows that represents the enumerator order of this table.
- selectAll(int) - Method in class com.mckoi.database.Table
-
Returns an array that represents the sorted order of this table by the given column number.
- selectAllColumnsFromAllSources() - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Sets up this queriable with all columns from all table sources.
- selectAllColumnsFromSource(TableName) - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Adds all column from the given table object.
- selectAllNonNull() - Method in class com.mckoi.database.SelectableScheme
-
Selects all values in the column that are not null.
- selectBetween(TObject, TObject) - Method in class com.mckoi.database.SelectableScheme
- SelectColumn - Class in com.mckoi.database.interpret
-
Represents a column selected to be in the output of a select statement.
- SelectColumn() - Constructor for class com.mckoi.database.interpret.SelectColumn
- SelectColumn() - Method in class com.mckoi.database.sql.SQL
- SelectColumnList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- selected_from_tables - Variable in class com.mckoi.database.Transaction
-
All tables selected from in this transaction.
- selectEqual(TObject) - Method in class com.mckoi.database.SelectableScheme
- selectFirst() - Method in class com.mckoi.database.SelectableScheme
- selectFirst(int) - Method in class com.mckoi.database.Table
-
Returns an array that represents the first sorted element(s) of the given column number.
- selectFromPattern(int, Operator, TObject) - Method in class com.mckoi.database.Table
-
Selects all the rows where the given column matches the given pattern.
- selectFromRegex(int, Operator, TObject) - Method in class com.mckoi.database.Table
-
Selects all the rows where the given column matches the regular expression.
- selectGreater(TObject) - Method in class com.mckoi.database.SelectableScheme
- selectGreaterOrEqual(TObject) - Method in class com.mckoi.database.SelectableScheme
- SelectGroupByList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- selectIndexesEqual(int, TObject) - Method in class com.mckoi.database.SimpleTableQuery
-
Finds the index of all the rows in the table where the given column is equal to the given object.
- selectIndexesEqual(int, TObject, int, TObject) - Method in class com.mckoi.database.SimpleTableQuery
-
Finds the index of all the rows in the table where the given column is equal to the given object for both of the clauses.
- selectIndexesEqual(int, Object) - Method in class com.mckoi.database.SimpleTableQuery
-
Finds the index of all the rows in the table where the given column is equal to the given object.
- selectIndexesEqual(int, Object, int, Object) - Method in class com.mckoi.database.SimpleTableQuery
-
Finds the index of all the rows in the table where the given column is equal to the given object for both of the clauses.
- selectLast() - Method in class com.mckoi.database.SelectableScheme
- selectLast(int) - Method in class com.mckoi.database.Table
-
Returns an array that represents the last sorted element(s) of the given column number.
- selectLess(TObject) - Method in class com.mckoi.database.SelectableScheme
- selectLessOrEqual(TObject) - Method in class com.mckoi.database.SelectableScheme
- selectNotEqual(TObject) - Method in class com.mckoi.database.SelectableScheme
- selectNotFirst() - Method in class com.mckoi.database.SelectableScheme
- selectNotLast() - Method in class com.mckoi.database.SelectableScheme
- SelectOrderByList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- selectRange(int, SelectableRange[]) - Method in class com.mckoi.database.Table
-
Returns an array that represents the sorted order of this table of all values in the given SelectableRange objects of the given column index.
- selectRange(SelectableRange) - Method in class com.mckoi.database.BlindSearch
- selectRange(SelectableRange) - Method in class com.mckoi.database.CollatedBaseSearch
- selectRange(SelectableRange) - Method in class com.mckoi.database.SelectableScheme
-
Selects the given range of values from this index.
- selectRange(SelectableRange[]) - Method in class com.mckoi.database.BlindSearch
- selectRange(SelectableRange[]) - Method in class com.mckoi.database.CollatedBaseSearch
- selectRange(SelectableRange[]) - Method in class com.mckoi.database.SelectableScheme
-
Selects a set of ranges from this index.
- selectRest(int) - Method in class com.mckoi.database.Table
-
Returns an array that represents the rest of the sorted element(s) of the given column number.
- selectRows(int[], Operator, TObject[]) - Method in class com.mckoi.database.Table
-
Returns a set that respresents the list of multi-column row numbers selected from the table given the condition.
- selectRows(int, Operator, TObject) - Method in class com.mckoi.database.Table
-
Returns a set that represents the list of row numbers selected from the table given the condition.
- selectRows(int, TObject, TObject) - Method in class com.mckoi.database.Table
-
Selects the rows in a table column between two minimum and maximum bounds.
- selectSingleColumn(SelectColumn) - Method in class com.mckoi.database.interpret.Planner.QuerySelectColumnSet
-
Adds a single SelectColumn to the list of output columns from the query.
- SelectTableList(FromClause) - Method in class com.mckoi.database.sql.SQL
- sendCloseCommand() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Sends close command to server.
- sendEvent(byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Sends an event to the client.
- sendEvent(byte[]) - Method in class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
- seq_id - Variable in class com.mckoi.store.JournalledSystem
-
The unique sequence id counter for this session.
- seq_name - Variable in class com.mckoi.database.interpret.Sequence
- Sequence - Class in com.mckoi.database.interpret
-
A statement tree for creating and dropping sequence generators.
- Sequence() - Constructor for class com.mckoi.database.interpret.Sequence
- SEQUENCE - Static variable in interface com.mckoi.database.sql.SQLConstants
- sequence_id - Variable in class com.mckoi.database.V2MasterTableDataSource
-
The current sequence id.
- sequence_key_map - Variable in class com.mckoi.database.SequenceManager
-
A hashmap that maps from the TableName of the sequence key to the object that manages this sequence (SequenceGenerator).
- sequence_manager - Variable in class com.mckoi.database.SimpleTransaction
-
The SequenceManager for this abstract transaction.
- sequence_manager - Variable in class com.mckoi.database.TableDataConglomerate
-
The SequenceManager object for this conglomerate.
- sequence_value_cache - Variable in class com.mckoi.database.SimpleTransaction
-
A local cache for sequence values.
- SequenceGenerator(long, TableName) - Constructor for class com.mckoi.database.SequenceManager.SequenceGenerator
- SequenceGenerator(long, TableName, long, long, long, long, long, long, boolean) - Constructor for class com.mckoi.database.SequenceManager.SequenceGenerator
- SequenceInternalTableInfo(Transaction) - Constructor for class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- SequenceManager - Class in com.mckoi.database
-
An object that manages the creation and removal of sequence keys, and that offers access to the sequence values (possibly cached).
- SequenceManager(TableDataConglomerate) - Constructor for class com.mckoi.database.SequenceManager
-
Constructs the object.
- SequenceManager.SequenceGenerator - Class in com.mckoi.database
-
An object that encapsulates information about the sequence key.
- SequenceManager.SequenceInternalTableInfo - Class in com.mckoi.database
-
An object that models the list of sequences as table objects in a transaction.
- SequenceName() - Method in class com.mckoi.database.sql.SQL
- SERIALIZABLE - Static variable in interface com.mckoi.database.sql.SQLConstants
- serialize(Object) - Static method in class com.mckoi.database.global.ObjectTranslator
-
Serializes the Java object to a ByteLongObject.
- serializeToBlob() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Serializes an SQLQuery object to a ByteLongObject.
- serializeToBlob() - Method in class com.mckoi.database.ViewDef
-
Forms this ViewDef object into a serialized ByteLongObject object that can be stored in a table.
- serialVersionUID - Static variable in class com.mckoi.database.Assignment
- serialVersionUID - Static variable in class com.mckoi.database.CorrelatedVariable
- serialVersionUID - Static variable in class com.mckoi.database.Expression
-
Serialization UID.
- serialVersionUID - Static variable in class com.mckoi.database.FunctionDef
- serialVersionUID - Static variable in class com.mckoi.database.global.ByteLongObject
- serialVersionUID - Static variable in class com.mckoi.database.global.NullObject
-
Deprecated.
- serialVersionUID - Static variable in class com.mckoi.database.global.StringObject
- serialVersionUID - Static variable in class com.mckoi.database.interpret.AlterTableAction
- serialVersionUID - Static variable in class com.mckoi.database.interpret.ByColumn
- serialVersionUID - Static variable in class com.mckoi.database.interpret.ColumnDef
- serialVersionUID - Static variable in class com.mckoi.database.interpret.ConstraintDef
- serialVersionUID - Static variable in class com.mckoi.database.interpret.FromClause
- serialVersionUID - Static variable in class com.mckoi.database.interpret.FromTableDef
- serialVersionUID - Static variable in class com.mckoi.database.interpret.SearchExpression
- serialVersionUID - Static variable in class com.mckoi.database.interpret.SelectColumn
- serialVersionUID - Static variable in class com.mckoi.database.interpret.TableSelectExpression
- serialVersionUID - Static variable in class com.mckoi.database.JoiningSet.JoinPart
- serialVersionUID - Static variable in class com.mckoi.database.JoiningSet
- serialVersionUID - Static variable in class com.mckoi.database.Operator.AddOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.AllOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.AndOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.AnyOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.DivideOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.EqualOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.GreaterEqualOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.GreaterOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.IsNotOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.IsOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.LesserEqualOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.LesserOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.MultiplyOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.NotEqualOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.OrOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.ParenOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.PatternMatchFalseOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.PatternMatchTrueOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.RegexOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.SimpleOperator
- serialVersionUID - Static variable in class com.mckoi.database.Operator.SubtractOperator
- serialVersionUID - Static variable in class com.mckoi.database.ParameterSubstitution
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.CachePointNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.CompositeNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.ConstantSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.CreateFunctionsNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.DistinctNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.EquiJoinNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.FetchTableNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.FetchViewNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.FunctionalSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.GroupNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.JoinNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.LeftOuterJoinNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.LogicalUnionNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.MarkerNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.NaturalJoinNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.RangeSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.SimpleSelectNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.SingleRowTableNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.SortNode
- serialVersionUID - Static variable in class com.mckoi.database.QueryPlan.SubsetNode
- serialVersionUID - Static variable in class com.mckoi.database.StatementTree
- serialVersionUID - Static variable in class com.mckoi.database.TableName
- serialVersionUID - Static variable in class com.mckoi.database.TArrayType
- serialVersionUID - Static variable in class com.mckoi.database.TBinaryType
- serialVersionUID - Static variable in class com.mckoi.database.TBooleanType
- serialVersionUID - Static variable in class com.mckoi.database.TDateType
- serialVersionUID - Static variable in class com.mckoi.database.TJavaObjectType
- serialVersionUID - Static variable in class com.mckoi.database.TNullType
- serialVersionUID - Static variable in class com.mckoi.database.TNumericType
- serialVersionUID - Static variable in class com.mckoi.database.TObject
- serialVersionUID - Static variable in class com.mckoi.database.TQueryPlanType
- serialVersionUID - Static variable in class com.mckoi.database.TStringType
- serialVersionUID - Static variable in class com.mckoi.database.TType
- serialVersionUID - Static variable in class com.mckoi.database.Variable
- serialVersionUID - Static variable in class com.mckoi.util.BigNumber
- server - Variable in class com.mckoi.database.control.TCPJDBCServer
-
The TCPServer object that is managing the connections to this database.
- server_connection - Variable in class com.mckoi.database.jdbcserver.MultiThreadedConnectionPoolServer.ClientThread
-
The ServerConnection object being serviced by this thread.
- server_connections_list - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
The list of ServerConnection objects that are currently being serviced by this server.
- server_error_msg - Variable in exception com.mckoi.database.jdbc.MSQLException
- SERVER_REQUEST - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Denotes a server side request for information.
- server_socket - Variable in class com.mckoi.database.jdbcserver.TCPServer
-
The ServerSocket object where the database server is bound.
- server_stack_trace - Variable in exception com.mckoi.database.jdbc.MSQLException
- SERVER_VERSION - Static variable in class com.mckoi.database.jdbcserver.JDBCProcessor
-
The version of the server protocol.
- ServerCommand(int, byte[]) - Constructor for class com.mckoi.database.jdbc.RemoteDatabaseInterface.ServerCommand
- ServerConnection - Interface in com.mckoi.database.jdbcserver
-
A server side connection with a client.
- ServerConnectionState(ServerConnection) - Constructor for class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
-
The Constructor.
- ServerFarmer() - Constructor for class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
The Constructor.
- set(int, String) - Method in class com.mckoi.util.Stats
-
Sets the given stat name with the given value.
- set(Table[], BlockIntegerList[]) - Method in class com.mckoi.database.VirtualTable
-
Sets the rows in this table as above, but uses a BlockIntegerList array as an argument instead.
- set(Table[], IntegerVector[]) - Method in class com.mckoi.database.VirtualTable
-
This is used in a join to set a list or joined rows and tables.
- set(Table, BlockIntegerList) - Method in class com.mckoi.database.VirtualTable
-
Sets the rows in this table as above, but uses a BlockIntegerList as an argument instead.
- set(Table, IntegerVector) - Method in class com.mckoi.database.VirtualTable
-
Sets the rows in this table.
- set(Variable) - Method in class com.mckoi.database.Variable
-
Sets this Variable object with information from the given Variable.
- Set - Class in com.mckoi.database.interpret
-
The SQL SET statement.
- Set() - Constructor for class com.mckoi.database.interpret.Set
- Set() - Method in class com.mckoi.database.sql.SQL
- SET - Static variable in interface com.mckoi.database.sql.SQLConstants
- set_comparator - Variable in class com.mckoi.database.InsertSearch
-
The IndexComparator that we use to refer elements in the set to actual data objects.
- set_comparator - Variable in class com.mckoi.database.RIDList
-
The IndexComparator that we use to refer elements in the set to actual data objects.
- SET_DEFAULT - Static variable in class com.mckoi.database.Transaction
- set_end_flag - Variable in class com.mckoi.database.SelectableRange
-
Denotes the place for the range to end with respect to the end value.
- set_id - Variable in class com.mckoi.database.IndexStore.SnapshotIndexSet
-
A unique id given to this index set.
- SET_ID_KEY - Variable in class com.mckoi.database.IndexStore
-
A unique key that is incremented each time a new IndexSet object is created.
- set_index - Variable in class com.mckoi.database.FunctionTable.TableGroupResolver.TableGVResolver
- set_list - Variable in class com.mckoi.database.InsertSearch
-
The sorted list of rows in this set.
- set_list - Variable in class com.mckoi.database.RIDList
-
The sorted list of rows in this set.
- SET_NULL - Static variable in class com.mckoi.database.Transaction
- set_start_flag - Variable in class com.mckoi.database.SelectableRange
-
Denotes the place for the range to start with respect to the start value.
- set_type - Variable in class com.mckoi.database.Operator
-
If this is a set operator such as ANY or ALL then this is set with the flag type.
- setAction(String) - Method in class com.mckoi.database.interpret.AlterTableAction
-
Set the action to perform.
- setAggregate(boolean) - Method in class com.mckoi.database.AbstractFunction
-
Call this from the constructor if the function is an aggregate.
- setArray(byte[]) - Method in class com.mckoi.database.CellBufferInputStream
-
Sets up the stream to the start of the underlying array.
- setArray(byte[], int, int) - Method in class com.mckoi.database.CellBufferInputStream
-
Sets up the stream to the underlying array with the given variables.
- setArray(int, Array) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setAsciiStream(int, InputStream) - Method in class com.mckoi.database.jdbc.MStatement
- setAsciiStream(int, InputStream, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setAsciiStream(int, InputStream, long) - Method in class com.mckoi.database.jdbc.MStatement
- setAsciiStream(long) - Method in class com.mckoi.database.jdbc.MClob
- setAsciiStream(long) - Method in class com.mckoi.database.jdbc.MStreamableClob
- setAsciiStream(String, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- setAsciiStream(String, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- setAutoCommit(boolean) - Method in class com.mckoi.database.DatabaseConnection
-
Sets the auto-commit mode.
- setAutoCommit(boolean) - Method in class com.mckoi.database.InternalJDBCHelper.InternalConnection
-
Overwritten from MConnection - auto-commit is disabled and can not be enabled.
- setAutoCommit(boolean) - Method in class com.mckoi.database.jdbc.MConnection
- setBigDecimal(int, BigDecimal) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setBigDecimal(int, BigDecimal) - Method in class com.mckoi.jfccontrols.Query
- setBigDecimal(BigDecimal) - Method in class com.mckoi.util.BigNumber
- setBinaryStream(int, InputStream) - Method in class com.mckoi.database.jdbc.MStatement
- setBinaryStream(int, InputStream, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setBinaryStream(int, InputStream, long) - Method in class com.mckoi.database.jdbc.MStatement
- setBinaryStream(long) - Method in class com.mckoi.database.jdbc.MBlob
- setBinaryStream(long) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- setBinaryStream(String, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- setBinaryStream(String, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- setBlob(int, InputStream) - Method in class com.mckoi.database.jdbc.MStatement
- setBlob(int, InputStream, long) - Method in class com.mckoi.database.jdbc.MStatement
- setBlob(int, Blob) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setBlob(String, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- setBlob(String, Blob) - Method in class com.mckoi.database.jdbc.MResultSet
- setBoolean(int, boolean) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setBoolean(int, boolean) - Method in class com.mckoi.jfccontrols.Query
- setByte(int, byte) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setBytes(int, byte[]) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setBytes(long, byte[]) - Method in class com.mckoi.database.jdbc.MBlob
- setBytes(long, byte[]) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- setBytes(long, byte[], int, int) - Method in class com.mckoi.database.jdbc.MBlob
- setBytes(long, byte[], int, int) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- setCachePoints() - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Sets a CachePointNode with the given key on all of the plan table sources in 'table_list'.
- setCacheSize(int) - Method in class com.mckoi.database.DataCellCache.DCCache
-
Used to dynamically alter the size of the cache.
- setCaseInsensitive(boolean) - Method in class com.mckoi.database.interpret.FromTableDirectSource
-
Toggle the case sensitivity flag.
- setCaseInsensitive(boolean) - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
-
Toggle the case sensitivity flag.
- setCaseInsensitive(boolean) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Toggle the case sensitivity flag.
- setCaseInsensitiveIdentifiers(boolean) - Method in class com.mckoi.database.jdbc.MConnection
-
Toggles whether this connection is handling identifiers as case insensitive or not.
- setCatalog(String) - Method in class com.mckoi.database.jdbc.MConnection
- setCellFrom(Table, int, int, String) - Method in class com.mckoi.database.TemporaryTable
-
Copies the cell from the given table (src_col, src_row) to the last row of the column specified of this table.
- setChar(char, byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Sets the short at the given offset of the byte array.
- setCharacterStream(int, Reader) - Method in class com.mckoi.database.jdbc.MStatement
- setCharacterStream(int, Reader, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setCharacterStream(int, Reader, long) - Method in class com.mckoi.database.jdbc.MStatement
- setCharacterStream(long) - Method in class com.mckoi.database.jdbc.MClob
- setCharacterStream(long) - Method in class com.mckoi.database.jdbc.MStreamableClob
- setCharacterStream(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- setCharacterStream(String, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- setCheck(Expression) - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets object up for a check constraint.
- setCheckPoint() - Method in interface com.mckoi.database.StoreSystem
-
Sets a new check point at the current state of this store system.
- setCheckPoint() - Method in class com.mckoi.database.V1FileStoreSystem
- setCheckPoint() - Method in class com.mckoi.database.V1HeapStoreSystem
- setCheckPoint() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Sets a check point.
- setCheckPoint(boolean) - Method in class com.mckoi.store.JournalledSystem
-
Sets a check point in the log.
- setCheckPoint(boolean) - Method in class com.mckoi.store.LoggingBufferManager
-
Sets a check point in the log.
- setClassConstraint(String) - Method in class com.mckoi.database.DataTableColumnDef
-
If this column represents a Java object, this must be a class the object is derived from to be added to this column.
- setClientInfo(String, String) - Method in class com.mckoi.database.jdbc.MConnection
- setClientInfo(Properties) - Method in class com.mckoi.database.jdbc.MConnection
- setClob(int, Reader) - Method in class com.mckoi.database.jdbc.MStatement
- setClob(int, Reader, long) - Method in class com.mckoi.database.jdbc.MStatement
- setClob(int, Clob) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setClob(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- setClob(String, Clob) - Method in class com.mckoi.database.jdbc.MResultSet
- setColumnData(int, TObject) - Method in class com.mckoi.database.RowData
-
Sets up a column by casting the value from the given TObject to a type that is compatible with the column.
- setColumnDataFromObject(int, Object) - Method in class com.mckoi.database.RowData
-
Sets up a column from an Object.
- setColumnDataFromTObject(int, TObject) - Method in class com.mckoi.database.RowData
-
Sets up a column from a TObject.
- setColumnMap(int[], Variable[]) - Method in class com.mckoi.database.SubsetColumnTable
-
Adds a column map into this table.
- setColumnName(String) - Method in class com.mckoi.database.Variable
-
Sets the column name of this variable.
- setColumnToDefault(int, QueryContext) - Method in class com.mckoi.database.RowData
-
Sets the given column number to the default value for this column.
- setColumnToNull(int) - Method in class com.mckoi.database.RowData
-
This is a special case situation for setting the column cell to 'null'.
- setCommitID(long) - Method in class com.mckoi.database.MasterTableJournal
-
Sets the 'commit_id'.
- setCount() - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Returns the number of FromTableInterface objects in this set.
- setCurrentSchema(String) - Method in class com.mckoi.database.DatabaseConnection
-
Sets the schema that this connection is within.
- setCursorName(String) - Method in class com.mckoi.database.jdbc.MStatement
- setDataAreaSize(long) - Method in class com.mckoi.store.AbstractStore
-
Sets the size of the data area.
- setDataAreaSize(long) - Method in class com.mckoi.store.JournalledFileStore
- setDataAreaSize(JournalledResource, long) - Method in class com.mckoi.store.LoggingBufferManager
- setDatabasePath(String) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Sets the path of the database.
- setDataStoreSize(long) - Method in class com.mckoi.database.FixedSizeDataStore
-
Sets the length of the data store to the given size.
- setDataType(TType) - Method in class com.mckoi.database.interpret.ColumnDef
-
Sets the type of data of this column.
- setDate(int, Date) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setDate(int, Date, Calendar) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setDate(int, Date) - Method in class com.mckoi.jfccontrols.Query
- setDBType(int) - Method in class com.mckoi.database.DataTableColumnDef
- setDebugLevel(int) - Method in class com.mckoi.database.TransactionSystem
-
Sets the debug minimum level that is output to the logger.
- setDebugLevel(int) - Static method in class com.mckoi.debug.Debug
-
Deprecated.Sets the debug level that's to be output to the stream.
- setDebugLevel(int) - Method in class com.mckoi.debug.DefaultDebugLogger
-
Sets the debug level that's to be output to the stream.
- setDebugOutput(Writer) - Method in class com.mckoi.database.TransactionSystem
-
Sets the Writer output for the debug logger.
- setDebugStream(PrintStream) - Method in class com.mckoi.database.sql.SQLTokenManager
- setDefaultExpression(Expression) - Method in class com.mckoi.database.DataTableColumnDef
- setDefaultExpression(Expression) - Method in class com.mckoi.database.interpret.ColumnDef
-
Sets the default expression (this is used to make a new constraint).
- setDefaultForRest(QueryContext) - Method in class com.mckoi.database.RowData
-
Any columns in the row of data that haven't been set yet (they will be 'null') will be set to the default value during this method.
- setDefaultSchema(String) - Method in class com.mckoi.database.DatabaseConnection
-
Changes the default schema to the given schema.
- setDeleteOnClose(boolean) - Method in class com.mckoi.database.control.DBSystem
-
Sets a flag that causes the database to delete itself from the file system when it is shut down.
- setDeleteOnShutdown(boolean) - Method in class com.mckoi.database.Database
-
If the 'deleteOnShutdown' flag is set, the database will delete the database from the file system when it is shutdown.
- setDiagnosticModel(RawDiagnosticTable) - Method in class com.mckoi.tools.ConglomerateViewPane.StoreViewPane
-
Sets this store with the given RaDiagnosticTable model.
- setDouble(int, double) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setDouble(int, double) - Method in class com.mckoi.jfccontrols.Query
- setElementAt(int, Object) - Method in class com.mckoi.database.Expression
-
Sets the element at the given position in the postfix list.
- setErrorOnDirtySelect(boolean) - Method in class com.mckoi.database.Transaction
-
Sets the transaction error on dirty select for this transaction.
- setEscapeProcessing(boolean) - Method in class com.mckoi.database.jdbc.MStatement
- setEvalResult(TObject) - Method in class com.mckoi.database.CorrelatedVariable
-
Sets the value this correlated variable evaluates to.
- setFetchDirection(int) - Method in class com.mckoi.database.jdbc.MResultSet
- setFetchDirection(int) - Method in class com.mckoi.database.jdbc.MStatement
- setFetchSize(int) - Method in class com.mckoi.database.jdbc.MResultSet
- setFetchSize(int) - Method in class com.mckoi.database.jdbc.MStatement
- setFloat(int, float) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setForeignKey(String) - Method in class com.mckoi.database.DataTableColumnDef
-
Deprecated.
- setForeignKey(String, ArrayList, ArrayList, String, String) - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets object up for foreign key reference.
- setFromExpression(Expression) - Method in class com.mckoi.database.interpret.SearchExpression
-
Sets this search expression from the given expression.
- setFromResolver(VariableResolver) - Method in class com.mckoi.database.CorrelatedVariable
-
Given a VariableResolver this will set the value of the correlated variable.
- setFromRow(int) - Method in class com.mckoi.database.RowData
-
Populates the RowData object with information from a specific row from the underlying DataTable.
- setFromTType(TType) - Method in class com.mckoi.database.DataTableColumnDef
-
Sets this DataTableColumnDef object up from information in the TType object.
- setGivenName(TableName) - Method in class com.mckoi.database.QueryPlan.SubsetNode
-
Sets the given table name of the resultant table.
- setHoldability(int) - Method in class com.mckoi.database.jdbc.MConnection
- setID() - Method in class com.mckoi.database.FunctionTable.TableGroupResolver.TableGVResolver
- setID() - Method in class com.mckoi.database.RowData.RDVariableResolver
- setID() - Method in class com.mckoi.database.Table.TableVariableResolver
- setID() - Method in class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- setID() - Method in interface com.mckoi.database.VariableResolver
-
A number that uniquely identifies the current state of the variable resolver.
- setIgnoreIdentifierCase(boolean) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Sets that the engine ignores case for identifiers.
- setImmutable() - Method in class com.mckoi.database.DataIndexSetDef
-
Sets the immutable flag.
- setImmutable() - Method in class com.mckoi.database.DataTableDef
-
Sets this DataTableDef to immutable which means nothing is able to change it.
- setImmutable() - Method in class com.mckoi.database.SelectableScheme
-
Sets this scheme to immutable.
- setImmutable() - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Sets the list as immutable (we aren't allowed to change the contents).
- setImmutable() - Method in interface com.mckoi.util.IntegerListInterface
-
Makes this list immutable effectively making it read-only.
- setImmutable(boolean) - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- setIndex(int) - Method in class com.mckoi.database.FunctionTable.TableGroupResolver.TableGVResolver
- setIndex(Token) - Method in class com.mckoi.database.interpret.ColumnDef
-
Sets the indexing.
- setIndexScheme(String) - Method in class com.mckoi.database.DataTableColumnDef
-
Sets the indexing scheme for this column.
- setIndexSetForTable(MasterTableDataSource, IndexSet) - Method in class com.mckoi.database.SimpleTransaction
-
Sets the IndexSet for the given MasterTableDataSource object in this transaction.
- setInitiallyDeferred() - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets that this constraint is initially deferred.
- setInt(int, byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Sets the int at the given offset of the byte array.
- setInt(int, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setInt(int, int) - Method in class com.mckoi.jfccontrols.Query
- setIntAt(int, int) - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Sets an int at the given position, overwriting anything that was previously there.
- setIntAt(int, int) - Method in class com.mckoi.util.IntegerListBlockInterface
-
Sets an int at the given position, overwriting anything that was previously there.
- setIntAt(int, int) - Method in class com.mckoi.util.IntegerVector
-
Sets an int at the given position, overwriting anything that was previously there.
- setIsExecutingCommands(boolean) - Method in class com.mckoi.database.Database
-
Controls whether the database is allowed to execute commands or not.
- setIsExecutingCommands(boolean) - Method in class com.mckoi.database.DatabaseSystem
-
Controls whether the database system is allowed to execute commands or not.
- setIsExecutingCommands(boolean) - Method in class com.mckoi.database.WorkerPool
-
Controls whether the database is allowed to execute commands or not.
- setJoinInfoBetweenSources(int, int, Expression) - Method in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
Links the last added table source to the previous added table source through this joining information.
- setJoinInfoMergedBetween(Planner.PlanTableSource, Planner.PlanTableSource) - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
This is called when two plans are merged together to set up the left and right join information for the new plan.
- setLeftJoinInfo(Planner.PlanTableSource, int, Expression) - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Sets the left join information for this plan.
- setLockHandle(LockHandle) - Method in interface com.mckoi.database.DatabaseProcedure
-
Sets the LockHandle object for this procedure.
- setLogDirectory(File) - Method in class com.mckoi.database.TransactionSystem
-
Sets the log directory.
- setLogPath(String) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Sets the path of the log.
- setLong(int, long) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setLong(int, long) - Method in class com.mckoi.jfccontrols.Query
- setLong(long, byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Sets the long at the given offset of the byte array.
- setMaxFieldSize(int) - Method in class com.mckoi.database.jdbc.MStatement
- setMaxRowCount(int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Sets the maximum number of rows that this ResultSet will return or 0 if the max number of rows is not important.
- setMaxRows(int) - Method in class com.mckoi.database.jdbc.MStatement
- setMinimumDebugLevel(int) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Sets the minimum debug level for output to the debug log file.
- setMode(int) - Method in class com.mckoi.database.LockingMechanism
-
This method _must_ be called before a threads initial access to a Database object.
- setName(String) - Method in class com.mckoi.database.DataTableColumnDef
- setName(String) - Method in class com.mckoi.database.interpret.ColumnDef
-
Sets the name of the column.
- setName(String) - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets the name of the constraint.
- setNCharacterStream(int, Reader) - Method in class com.mckoi.database.jdbc.MStatement
- setNCharacterStream(int, Reader, long) - Method in class com.mckoi.database.jdbc.MStatement
- setNCharacterStream(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- setNClob(int, Reader) - Method in class com.mckoi.database.jdbc.MStatement
- setNClob(int, Reader, long) - Method in class com.mckoi.database.jdbc.MStatement
- setNClob(int, NClob) - Method in class com.mckoi.database.jdbc.MStatement
- setNClob(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- setNetworkTimeout(Executor, int) - Method in class com.mckoi.database.jdbc.MConnection
- setNotDeferrable() - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets that this constraint is not deferrable.
- setNotNull(boolean) - Method in class com.mckoi.database.DataTableColumnDef
- setNString(int, String) - Method in class com.mckoi.database.jdbc.MStatement
- setNull(int, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setNull(int, int, String) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setObject(int, Object) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setObject(int, Object) - Method in class com.mckoi.jfccontrols.Query
- setObject(int, Object, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setObject(int, Object, int, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setOldNewTableState(DatabaseConnection.OldNewTableState) - Method in class com.mckoi.database.DatabaseConnection
-
Sets the current state of the old/new tables.
- setOptimizableValue(float) - Method in class com.mckoi.database.interpret.Planner.ExpressionPlan
-
Sets the optimizable value of this plan.
- setOutput(Writer) - Static method in class com.mckoi.debug.Debug
-
Deprecated.Sets up the OutputStream to which the debug information is to be output to.
- setOutput(Writer) - Method in class com.mckoi.debug.DefaultDebugLogger
-
Sets up the OutputStream to which the debug information is to be output to.
- setParent(TableExpressionFromSet) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
-
Sets the parent of this expression.
- setParentIndexBlock(IndexSetStore.IndexBlock) - Method in class com.mckoi.database.IndexSetStore.IndexBlock
-
Sets the parent IndexBlock, the index that this index block succeeded.
- setParentStream(InputStream) - Method in class com.mckoi.database.CellInputStream
-
Sets the parent input stream for this stream.
- setPendingCommand() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- setPersistentVar(String, String) - Method in class com.mckoi.database.DatabaseConnection
-
Same as the Transaction.setPersistentVar method.
- setPersistentVar(String, String) - Method in class com.mckoi.database.Transaction
-
Sets a persistent variable of the database that becomes a committed change once this transaction is committed.
- setPingClient() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
- setPoolable(boolean) - Method in class com.mckoi.database.jdbc.MStatement
- setPreserveTableStructure(boolean) - Method in class com.mckoi.jfccontrols.ResultSetTableModel
-
A property that checks for changes when a result set is updated and preserves the layout if the updated result set looks similar.
- setPrimaryKey(ArrayList) - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets object up for a primary key constraint.
- setProcessingRequest() - Method in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerConnectionState
-
Sets the various states to true.
- SetQuantifier() - Method in class com.mckoi.database.sql.SQL
- setQueryTime(int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Sets the length of time in milliseconds (server-side) it took to execute this query.
- setQueryTimeout(int) - Method in class com.mckoi.database.jdbc.MStatement
- setReadOnly() - Method in class com.mckoi.database.SimpleTransaction
-
Sets this transaction as read only.
- setReadOnly(boolean) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Sets that the database is read only.
- setReadOnly(boolean) - Method in class com.mckoi.database.jdbc.MConnection
- setRef(int, Ref) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setReservedLong(long) - Method in class com.mckoi.database.FixedRecordList
-
Sets the 8 byte long that is reserved for storing the delete chain (if there is one).
- setRightJoinInfo(Planner.PlanTableSource, int, Expression) - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Sets the right join information for this plan.
- setRow(int) - Method in class com.mckoi.database.Table.TableVariableResolver
- setRowCell(TObject, int, int) - Method in class com.mckoi.database.TemporaryTable
-
Sets the cell in the given column / row to the given value.
- setRowCell(TObject, String) - Method in class com.mckoi.database.TemporaryTable
-
Sets the cell in the column of the last row of this table to the given TObject.
- setRowData(RowData) - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- setRowId(int, RowId) - Method in class com.mckoi.database.jdbc.MStatement
- setRowObject(TObject, int) - Method in class com.mckoi.database.TemporaryTable
-
Sets the cell in the column of the last row of this table to the given TObject.
- setRowObject(TObject, int, int) - Method in class com.mckoi.database.TemporaryTable
-
Sets the cell in the column of the last row of this table to the given TObject.
- setRowObject(TObject, String) - Method in class com.mckoi.database.TemporaryTable
-
Sets the cell in the column of the last row of this table to the given TObject.
- setSavepoint() - Method in class com.mckoi.database.jdbc.MConnection
- setSavepoint(String) - Method in class com.mckoi.database.jdbc.MConnection
- setScale(int) - Method in class com.mckoi.database.DataTableColumnDef
- setScale(int) - Method in class com.mckoi.database.global.ColumnDescription
-
Sets the scale of the numerical values stored.
- setScale(int, int) - Method in class com.mckoi.util.BigNumber
- setSchema(String) - Method in class com.mckoi.database.jdbc.MConnection
- setSectorHeader(byte, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Sets up the sector header information in 'sector_buffer'.
- setSequenceValue(TableName, long) - Method in class com.mckoi.database.SimpleTransaction
-
Sets the sequence value for the given sequence generator.
- setSequenceValue(String, long) - Method in class com.mckoi.database.DatabaseConnection
-
Sets the sequence value for the given sequence generator.
- setSequenceValue(String, long) - Method in class com.mckoi.database.DatabaseQueryContext
-
Sets the current sequence value for the given sequence generator.
- setSequenceValue(String, long) - Method in interface com.mckoi.database.QueryContext
-
Sets the current sequence value for the given sequence generator.
- setSequenceValue(String, long) - Method in class com.mckoi.database.SystemQueryContext
-
Sets the current sequence value for the given sequence generator.
- setShort(int, short) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setShort(short, byte[], int) - Static method in class com.mckoi.util.ByteArrayUtil
-
Sets the short at the given offset of the byte array.
- setSize() - Method in class com.mckoi.database.CollatedBaseSearch
-
The size of the set (the number of rows in this column).
- setSize() - Method in class com.mckoi.database.InsertSearch
- setSize(int) - Method in class com.mckoi.database.DataTableColumnDef
- setSize(long) - Method in class com.mckoi.store.IOStoreDataAccessor
- setSize(long) - Method in interface com.mckoi.store.JournalledResource
-
Sets the new size of the resource.
- setSize(long) - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Sets the size of the resource.
- setSize(long) - Method in class com.mckoi.store.JournalledSystem.Resource
-
Sets the size of the resource.
- setSize(long) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- setSize(long) - Method in interface com.mckoi.store.StoreDataAccessor
-
Sets the size of the underlying data area to the given size.
- setSQLType(int) - Method in class com.mckoi.database.DataTableColumnDef
- setSQLType(int) - Method in class com.mckoi.database.global.ColumnDescription
-
Sets the SQL type for this ColumnDescription object.
- setSQLXML(int, SQLXML) - Method in class com.mckoi.database.jdbc.MStatement
- setStrictGetObject(boolean) - Method in class com.mckoi.database.jdbc.MckoiConnection
-
This method can be used to disable strict get object in ResultSet.
- setStrictGetObject(boolean) - Method in class com.mckoi.database.jdbc.MConnection
-
Toggles strict get object.
- setString(int, String) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setString(int, String) - Method in class com.mckoi.jfccontrols.Query
- setString(long, String) - Method in class com.mckoi.database.jdbc.MClob
- setString(long, String) - Method in class com.mckoi.database.jdbc.MStreamableClob
- setString(long, String, int, int) - Method in class com.mckoi.database.jdbc.MClob
- setString(long, String, int, int) - Method in class com.mckoi.database.jdbc.MStreamableClob
- setStringLocale(String, int, int) - Method in class com.mckoi.database.DataTableColumnDef
- setSystemGrants(DatabaseConnection, String) - Method in class com.mckoi.database.Database
-
Set up the system table grants.
- setSystemTableListeners() - Method in class com.mckoi.database.Database
-
Sets the system table listeners on the SYS_INFO.sUSRView table.
- setTable(int, TableName) - Method in class com.mckoi.database.JoiningSet
-
Sets the table at the given position in this joining set.
- setTableClass(String) - Method in class com.mckoi.database.DataTableDef
- setTableName(TableName) - Method in class com.mckoi.database.DataTableDef
- setTableName(TableName) - Method in class com.mckoi.database.Variable
-
Sets the TableName of this variable.
- setTime(int, Time) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setTime(int, Time, Calendar) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setTimeFrame(int, TimeFrame) - Method in class com.mckoi.jfccontrols.Query
- setTimestamp(int, Timestamp) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setTimestamp(int, Timestamp, Calendar) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.CompositeTable
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.DataTable
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.DataTableFilter
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.DefaultDataTable
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.FilterTable
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.JoinedTable
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.SubsetColumnTable
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToRowTableDomain(int, IntegerVector, TableDataSource) - Method in class com.mckoi.database.Table
-
Given a set, this trickles down through the Table hierarchy resolving the given row_set to a form that the given ancestor understands.
- setToSerialize(TObject) - Method in class com.mckoi.database.DataCellSerialization
-
Sets this up with a TObject to serialize.
- setTransactionIsolation(int) - Method in class com.mckoi.database.jdbc.MConnection
- setTransactionIsolation(String) - Method in class com.mckoi.database.DatabaseConnection
-
Sets the transaction isolation level from a string.
- setTypeMap(Map) - Method in class com.mckoi.database.jdbc.MConnection
- setUnicodeStream(int, InputStream, int) - Method in class com.mckoi.database.jdbc.MPreparedStatement
-
Deprecated.
- setUnique() - Method in class com.mckoi.database.global.ColumnDescription
-
Sets this column to unique.
- setUnique(ArrayList) - Method in class com.mckoi.database.interpret.ConstraintDef
-
Sets object up for a unique constraint.
- setUniqueGroup(int) - Method in class com.mckoi.database.global.ColumnDescription
-
Sets the column to belong to the specified unique group in the table.
- setUniqueID(long) - Method in class com.mckoi.database.IndexStore
-
Sets the unique id for this store.
- setUniqueID(long) - Method in class com.mckoi.database.MasterTableDataSource
-
Sets the unique id for this store.
- setUniqueID(long) - Method in class com.mckoi.database.V1MasterTableDataSource
- setUniqueID(long) - Method in class com.mckoi.database.V2MasterTableDataSource
- setUniqueID(TableName, long) - Method in class com.mckoi.database.SimpleTransaction
-
Sets the unique id for the given table name.
- setUniqueKey(String) - Method in class com.mckoi.database.interpret.FromTableDef
-
Sets the unique key.
- setup(InputStream, OutputStream) - Method in class com.mckoi.database.jdbc.StreamDatabaseInterface
-
Sets up the stream connection with the given input/output stream.
- setupAllConstraints() - Method in class com.mckoi.database.interpret.CreateTable
-
Sets up all constraints specified in this create statement.
- setupAllSelectableSchemes() - Method in class com.mckoi.database.TemporaryTable
-
This should be called if you want to perform table operations on this TemporaryTable.
- setupComparator() - Method in class com.mckoi.database.InsertSearch
-
Sets the internal comparator that enables us to sort and lookup on the data in this column.
- setupComparator() - Method in class com.mckoi.database.RIDList
-
Sets the internal comparator that enables us to sort and lookup on the data in this column.
- setupDataIndexSetDef() - Method in class com.mckoi.database.MasterTableDataSource
-
Sets up the DataIndexSetDef object from the information set in this object.
- setupDataTableDef(DataTableDef) - Method in class com.mckoi.database.MasterTableDataSource
-
Sets up the DataTableDef.
- setUpdated() - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Sets the updated flag.
- setupEntire(int[], Expression[], QueryContext) - Method in class com.mckoi.database.RowData
-
Sets up an entire row given the array of Expressions and a list of indices to the columns to set.
- setupEntire(int[], List, QueryContext) - Method in class com.mckoi.database.RowData
-
Sets up an entire row given the list of insert elements and a list of indices to the columns to set.
- setupEntire(Assignment[], QueryContext) - Method in class com.mckoi.database.RowData
-
Sets up an entire row given the array of assignments.
- setUpGroupForRow(int) - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
-
Given a row index, this will setup the information in this resolver to solve for this group.
- setupIndexesForCompositeFunction(int, boolean) - Method in class com.mckoi.database.CompositeTable
-
Sets up the indexes in this composite table by performing for composite function on the tables.
- setupInitialStore() - Method in class com.mckoi.database.V2MasterTableDataSource
-
Sets up an initial store (should only be called from the 'create' method).
- setupInternal() - Method in class com.mckoi.database.TableDataConglomerate
-
Sets up the internal state of this object.
- setupLog(DBConfig) - Method in class com.mckoi.database.TransactionSystem
-
Sets up the log file from the config information.
- setupRange(int, SelectableRange) - Method in class com.mckoi.database.BlindSearch.RangeChecker
-
Set up a range.
- setupRowCache(int, int) - Method in class com.mckoi.database.TransactionSystem
-
Hack - set up the DataCellCache in DatabaseSystem so we can use the MasterTableDataSource object without having to boot a new DatabaseSystem.
- setupSystemFunctions(DatabaseConnection, String) - Method in class com.mckoi.database.Database
-
Sets all the standard functions and procedures available to engine.
- setupVars(int) - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
-
Sets up the internal variables given an offset.
- setURL(int, URL) - Method in class com.mckoi.database.jdbc.MPreparedStatement
- setUser(User) - Method in class com.mckoi.database.DatabaseConnection
-
Sets the User object for this connection.
- setUserLock(DatabaseQueryContext, User, boolean) - Method in class com.mckoi.database.Database
-
Sets the lock status for the given user.
- SetValFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SetValFunction
- setValue(SimpleTransaction, TableName, long) - Method in class com.mckoi.database.SequenceManager
-
Sets the current value of the sequence generator.
- setValue(String, String) - Method in class com.mckoi.database.control.AbstractDBConfig
-
Sets the configuration value for the key property key.
- setValue(String, String) - Method in class com.mckoi.database.control.DefaultDBConfig
-
Overwrites the configuration key with the given value.
- setVar(int, Object) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Sets a variable at the given index.
- setVar(int, Object[]) - Method in class com.mckoi.database.SimpleTableQuery
-
Adds a new key/value mapping in this table.
- setVar(String, Expression) - Method in class com.mckoi.database.DatabaseConnection
-
Assigns a variable to the expression for this connection.
- setVariableLengthStream(int, InputStream, int, byte) - Method in class com.mckoi.database.jdbc.MPreparedStatement
-
Given an InputStream and a length of bytes to read from the stream, this method will insert a correct type of parameter into the statement to handle this size of object.
- setVerboseColumnNames(boolean) - Method in class com.mckoi.database.jdbc.MckoiConnection
-
This method is used to enable verbose column names in ResultSetMetaData.
- setVerboseColumnNames(boolean) - Method in class com.mckoi.database.jdbc.MConnection
-
Toggles verbose column names from ResultSetMetaData.
- setWholeTableAsGroup() - Method in class com.mckoi.database.FunctionTable
-
Sets the whole reference table as a single group.
- SFInputStream() - Constructor for class com.mckoi.store.StreamFile.SFInputStream
- SFOutputStream() - Constructor for class com.mckoi.store.StreamFile.SFOutputStream
- shared_mode - Variable in class com.mckoi.database.LockingMechanism
-
This contains the number of Threads that have requested to go into 'shared mode'.
- SHARED_MODE - Static variable in class com.mckoi.database.LockingMechanism
-
Class statics.
- ShellUserTerminal - Class in com.mckoi.util
-
An implementation of UserTerminal that uses the shell terminal via System.in and System.out.
- ShellUserTerminal() - Constructor for class com.mckoi.util.ShellUserTerminal
- shortValue() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as a short.
- shouldWipeMoreNodes() - Method in class com.mckoi.database.DataCellCache.DCCache
- shouldWipeMoreNodes() - Method in class com.mckoi.util.Cache
-
Returns true if the clean-up method that periodically cleans up the cache, should clean up more elements from the cache.
- Show - Class in com.mckoi.database.interpret
-
Statement that handles SHOW and DESCRIBE sql commands.
- Show() - Constructor for class com.mckoi.database.interpret.Show
- Show() - Method in class com.mckoi.database.sql.SQL
- SHOW - Static variable in interface com.mckoi.database.sql.SQLConstants
- show_type - Variable in class com.mckoi.database.interpret.Show
-
The type of information that we are to show.
- shut_down_delegates - Variable in class com.mckoi.database.DatabaseSystem
- shutdown - Variable in class com.mckoi.database.DatabaseSystem
-
Set to true when the database is shut down.
- shutdown - Variable in class com.mckoi.database.interpret.Misc
-
Set to true if this statement is a shutdown statement.
- shutdown - Variable in class com.mckoi.database.WorkerThread
-
Set to true to turn off this worker thread.
- shutdown() - Method in class com.mckoi.database.Database
-
Cleanly shuts down the database.
- shutdown() - Method in interface com.mckoi.database.DataTableFile
-
Shuts down the table.
- shutdown() - Method in class com.mckoi.database.WorkerPool
-
Shuts down the WorkerPool object stopping all worker threads.
- shutdown() - Method in class com.mckoi.database.WorkerThread
-
Shuts down this worker thread.
- ShutDown() - Method in class com.mckoi.database.sql.SQL
- SHUTDOWN - Static variable in interface com.mckoi.database.sql.SQLConstants
- shutdown_thread - Variable in class com.mckoi.database.DatabaseSystem
-
The thread to run to shut down the database system.
- shutdownHookCleanup() - Method in class com.mckoi.database.MasterTableDataSource
-
Called by the 'shutdown hook' on the conglomerate.
- shutdownHookCleanup() - Method in class com.mckoi.database.V1MasterTableDataSource
- shutdownHookCleanup() - Method in class com.mckoi.database.V2MasterTableDataSource
- ShutdownThread() - Constructor for class com.mckoi.database.DatabaseSystem.ShutdownThread
- SignFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SignFunction
- signum() - Method in class com.mckoi.util.BigNumber
- simple(Object, Operator, Object) - Static method in class com.mckoi.database.Expression
-
Generates a simple expression from two objects and an operator.
- SimpleCharStream - Class in com.mckoi.database.sql
-
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
- SimpleCharStream(InputStream) - Constructor for class com.mckoi.database.sql.SimpleCharStream
- SimpleCharStream(InputStream, int, int) - Constructor for class com.mckoi.database.sql.SimpleCharStream
- SimpleCharStream(InputStream, int, int, int) - Constructor for class com.mckoi.database.sql.SimpleCharStream
- SimpleCharStream(Reader) - Constructor for class com.mckoi.database.sql.SimpleCharStream
- SimpleCharStream(Reader, int, int) - Constructor for class com.mckoi.database.sql.SimpleCharStream
- SimpleCharStream(Reader, int, int, int) - Constructor for class com.mckoi.database.sql.SimpleCharStream
- simpleJoin(QueryContext, Table, Variable, Operator, Expression) - Method in class com.mckoi.database.Table
-
A simple join operation.
- SimpleOperator(String) - Constructor for class com.mckoi.database.Operator.SimpleOperator
- SimpleOperator(String, int) - Constructor for class com.mckoi.database.Operator.SimpleOperator
- SimplePatternExpressionPlan(Variable, Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimplePatternExpressionPlan
- SimplePatternSelectNode(QueryPlanNode, Expression) - Constructor for class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- SimpleRowEnumeration - Class in com.mckoi.database
-
A RowEnumeration implementation that represents a sequence of rows that can be referenced in incremental order between 0 and row_count (exclusive).
- SimpleRowEnumeration(int) - Constructor for class com.mckoi.database.SimpleRowEnumeration
-
Constructs the RowEnumeration.
- simpleSelect(QueryContext, Variable, Operator, Expression) - Method in class com.mckoi.database.Table
-
A simple select on this table.
- SimpleSelectExpressionPlan(Variable, Operator, Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSelectExpressionPlan
- SimpleSelectNode(QueryPlanNode, Variable, Operator, Expression) - Constructor for class com.mckoi.database.QueryPlan.SimpleSelectNode
- SimpleSingleExpressionPlan(Variable, Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSingleExpressionPlan
- SimpleSubQueryExpressionPlan(Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSubQueryExpressionPlan
- simpleSuccess(int) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Creates a response that indicates a simple success of an operation with the given dispatch id.
- SimpleTableQuery - Class in com.mckoi.database
-
A simple convenience interface for querying a MutableTableDataSource instance.
- SimpleTableQuery(TableDataSource) - Constructor for class com.mckoi.database.SimpleTableQuery
-
Constructs the SimpleTableQuery with the given MutableTableDataSource object.
- SimpleTransaction - Class in com.mckoi.database
-
An simple implementation of Transaction that provides various facilities for implementing a Transaction object on a number of MasterTableDataSource tables.
- SimpleTransaction(TransactionSystem, SequenceManager) - Constructor for class com.mckoi.database.SimpleTransaction
-
Constructs the AbstractTransaction.
- single(int) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Convenience, returns a single 4 byte array with the given int encoded into it.
- SINGLE_ROW_TABLE - Variable in class com.mckoi.database.Database
-
A table that has a single row but no columns.
- single_var - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.ComplexSingleExpressionPlan
- single_var - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimplePatternExpressionPlan
- single_var - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSelectExpressionPlan
- single_var - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SimpleSingleExpressionPlan
- single_var - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SingleVarPlan
- singleArrayCellMap(TObject) - Method in class com.mckoi.database.Table
-
Convenience, returns a TObject[] array given a single TObject, or null if the TObject is null (not if TObject represents a null value).
- singleColumnTable(Database, String, Class) - Static method in class com.mckoi.database.TemporaryTable
-
Creates a table with a single column with the given name and type.
- SingleQueryPlanNode(QueryPlanNode) - Constructor for class com.mckoi.database.QueryPlan.SingleQueryPlanNode
-
Constructor.
- singleRowSelect(int) - Method in class com.mckoi.database.Table
-
Selects a single row at the given index from this table.
- SingleRowTableNode() - Constructor for class com.mckoi.database.QueryPlan.SingleRowTableNode
- SingleThreadedConnectionPoolServer - Class in com.mckoi.database.jdbcserver
-
A generic database server class that provides a thread that dispatches commands to the underlying database.
- SingleThreadedConnectionPoolServer(Database) - Constructor for class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer
-
The Constructor.
- SingleThreadedConnectionPoolServer.ServerConnectionState - Class in com.mckoi.database.jdbcserver
-
This contains state information about a ServerConnection that is being maintained by the server.
- SingleThreadedConnectionPoolServer.ServerFarmer - Class in com.mckoi.database.jdbcserver
-
This thread is a low priority thread that checks all the current service providers periodically to determine if there's any commands pending.
- SingleVarPlan() - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SingleVarPlan
- size - Variable in class com.mckoi.database.BlobStore.AbstractRef
-
The total size of the large object in bytes.
- size - Variable in class com.mckoi.database.BlobStore.CopyBlobInfo
- size - Variable in class com.mckoi.database.DataTableColumnDef
-
The size of the data.
- size - Variable in class com.mckoi.database.global.ColumnDescription
-
The size of the type.
- size - Variable in class com.mckoi.database.global.StreamableObject
-
The size of the object in bytes.
- size - Variable in class com.mckoi.database.jdbc.AbstractStreamableObject
-
The size of the streamable object.
- size - Variable in class com.mckoi.database.TNumericType
-
The size of the number.
- size - Variable in class com.mckoi.store.IOStoreDataAccessor
-
The size of the data area.
- size - Variable in class com.mckoi.store.JournalledSystem.Resource
-
The size of the resource.
- size - Variable in class com.mckoi.util.PagedInputStream
-
The total size of the underlying dataset.
- size() - Method in class com.mckoi.database.Expression
-
Returns the number of elements and operators that are in this postfix list.
- size() - Method in class com.mckoi.database.FunctionTable.TableGroupResolver
- size() - Method in interface com.mckoi.database.GroupResolver
-
The total number of set items in this group.
- size() - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface.MByteArrayOutputStream
- size() - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Returns the size of the journal file in bytes.
- size() - Method in class com.mckoi.util.AbstractBlockIntegerList
-
The number of integers that are in the list.
- size() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Returns the number of entries in this block.
- size() - Method in class com.mckoi.util.IntegerListBlockInterface
-
Returns the number of entries in this block.
- size() - Method in interface com.mckoi.util.IntegerListInterface
-
The number of integers that are in the list.
- size() - Method in class com.mckoi.util.IntegerVector
-
Returns the size of the vector.
- size() - Method in class com.mckoi.util.StringListBucket
-
Returns the number of string elements in the list.
- size(Object) - Static method in class com.mckoi.database.global.ObjectTransfer
-
Makes an estimate of the size of the object.
- skip(long) - Method in class com.mckoi.database.CellBufferInputStream
- skip(long) - Method in class com.mckoi.database.CellInputStream
- skip(long) - Method in class com.mckoi.database.DataCellSerialization
- skip(long) - Method in class com.mckoi.database.FixedSizeDataStore.SectorInputStream
- skip(long) - Method in class com.mckoi.database.jdbc.AsciiInputStream
- skip(long) - Method in class com.mckoi.database.jdbc.AsciiReader
- skip(long) - Method in class com.mckoi.database.jdbc.BinaryToUnicodeReader
- skip(long) - Method in class com.mckoi.store.AbstractStore.StoreAreaInputStream
- skip(long) - Method in class com.mckoi.store.StreamFile.SFInputStream
- skip(long) - Method in class com.mckoi.util.PagedInputStream
- skipBytes(int) - Method in class com.mckoi.database.CellBufferInputStream
- skipBytes(int) - Method in class com.mckoi.database.CellInputStream
- skipBytes(int) - Method in class com.mckoi.database.DataCellSerialization
- skipSerialization(CellInput) - Method in class com.mckoi.database.DataCellSerialization
-
Returns the number of bytes to skip on the stream to go past the next serialization.
- skipStream(InputStream, long) - Method in class com.mckoi.database.V2MasterTableDataSource
- skipWhiteSpace(CharacterIterator) - Static method in class com.mckoi.util.GeneralParser
-
Moves the iterator past any white space.
- slice_list - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
The list of RandomAccessFile objects for each file that represents a slice of the store.
- slicePartFile(int) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
-
Given an index value, this will return a File object for the nth slice in the file system.
- smallClasses - Static variable in class com.mckoi.database.Caster
- SMALLINT - Static variable in interface com.mckoi.database.global.SQLTypes
- SMALLINT - Static variable in interface com.mckoi.database.sql.SQLConstants
- smallPrims - Static variable in class com.mckoi.database.Caster
- snapshot_index_blocks - Variable in class com.mckoi.database.IndexSetStore.SnapshotIndexSet
-
The list of IndexBlock object that represent the view of the index set when the view was created.
- SnapshotIndexSet(byte[], int) - Constructor for class com.mckoi.database.IndexStore.SnapshotIndexSet
-
Constructor.
- SnapshotIndexSet(IndexSetStore.IndexBlock[]) - Constructor for class com.mckoi.database.IndexSetStore.SnapshotIndexSet
-
Constructor.
- socket - Variable in class com.mckoi.database.jdbc.TCPStreamDatabaseInterface
-
The Socket connection.
- soft_index_storage - Variable in class com.mckoi.database.TransactionSystem
-
Set to false if there is conservative index memory storage.
- softIndexStorage() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if all table indices are kept behind a soft reference that can be garbage collected.
- SOME - Static variable in interface com.mckoi.database.sql.SQLConstants
- sorted_against_column - Variable in class com.mckoi.database.JoinedTable
-
The column that we are sorted against.
- sorted_set - Variable in class com.mckoi.database.BlindSearch.RangeChecker
-
The sorted list of all items in the set created as a cache for finding the first and last values.
- sortedIndexOf(int) - Method in class com.mckoi.util.IntegerVector
-
Searches the entire sorted list for the given value and returns the index of it.
- sortedIndexOf(int, int, int) - Method in class com.mckoi.util.IntegerVector
-
This is a very quick search for a value given a sorted array.
- sortedIndexOf(Comparable[], Comparable, int, int) - Static method in class com.mckoi.util.SortUtil
-
Quickly finds the index of the given object in the list.
- sortedIntCount(int) - Method in class com.mckoi.util.IntegerVector
-
Given a sorted list, this will return the count of this value in the list.
- sortedQuickFind(Comparable[], Comparable, SearchResults) - Static method in class com.mckoi.util.SortUtil
-
Quickly finds the given element in the array of objects.
- sortedSet(IntegerVector) - Method in class com.mckoi.database.RIDList
-
Given an unsorted set of rows in this table, this will return the row list sorted in descending order.
- SortNode(QueryPlanNode, Variable[], boolean[]) - Constructor for class com.mckoi.database.QueryPlan.SortNode
- SortUtil - Class in com.mckoi.util
-
Provides various sort utilities for a list of objects that implement Comparable.
- SortUtil() - Constructor for class com.mckoi.util.SortUtil
- source - Variable in class com.mckoi.database.TriggerEvent
-
The source of the trigger (eg.
- specialConstructor - Variable in exception com.mckoi.database.sql.ParseException
-
This variable determines which constructor was used to create this object and thereby affects the semantics of the "getMessage" method (see below).
- specialToken - Variable in class com.mckoi.database.sql.Token
-
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
- split() - Method in class com.mckoi.database.Expression
-
Returns an array of two Expression objects that represent the left hand and right and side of the last operator in the post fix notation.
- splitArea(long, long) - Method in class com.mckoi.store.AbstractStore
-
Splits an area pointed to by 'pointer' at a new boundary point.
- SQL - Class in com.mckoi.database.sql
- SQL(SQLTokenManager) - Constructor for class com.mckoi.database.sql.SQL
- SQL(InputStream) - Constructor for class com.mckoi.database.sql.SQL
- SQL(Reader) - Constructor for class com.mckoi.database.sql.SQL
- sql_exception - Variable in class com.mckoi.jfccontrols.QueryAgent
-
If an exception was thrown, the SQLException.
- sql_executor - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
The SQL parser object for this interface.
- sql_parser - Static variable in class com.mckoi.database.interpret.SQLQueryExecutor
-
The SQL parser state.
- sql_type - Variable in class com.mckoi.database.DataTableColumnDef
-
The sql column type (as defined in java.sql.Types).
- sql_type - Variable in class com.mckoi.database.global.ColumnDescription
-
The SQL type as defined in java.sql.Types.
- sql_type - Variable in class com.mckoi.database.TType
-
The type as an SQL identifier from com.mckoi.database.global.SQLTypes.
- SQL.JJCalls - Class in com.mckoi.database.sql
- SQLADD - Static variable in interface com.mckoi.database.sql.SQLConstants
- SQLCastFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SQLCastFunction
- SQLCOLUMN - Static variable in interface com.mckoi.database.sql.SQLConstants
- SQLConstants - Interface in com.mckoi.database.sql
- SQLDEFAULT - Static variable in interface com.mckoi.database.sql.SQLConstants
- SQLIdentifier() - Method in class com.mckoi.database.sql.SQL
- SQLLoginException - Exception in com.mckoi.database.jdbc
-
An SQLException that signifies username/password authentication failed.
- SQLLoginException() - Constructor for exception com.mckoi.database.jdbc.SQLLoginException
- SQLLoginException(String) - Constructor for exception com.mckoi.database.jdbc.SQLLoginException
- SQLLoginException(String, String) - Constructor for exception com.mckoi.database.jdbc.SQLLoginException
- SQLLoginException(String, String, int) - Constructor for exception com.mckoi.database.jdbc.SQLLoginException
- SQLQuery - Class in com.mckoi.database.jdbc
-
Represents an SQL Query to the database.
- SQLQuery() - Constructor for class com.mckoi.database.jdbc.SQLQuery
-
Empty constructor.
- SQLQuery(String) - Constructor for class com.mckoi.database.jdbc.SQLQuery
-
Constructs the query.
- SQLQueryExecutor - Class in com.mckoi.database.interpret
-
An object used to execute SQL queries against a given DatabaseConnection object.
- SQLQueryExecutor() - Constructor for class com.mckoi.database.interpret.SQLQueryExecutor
-
Constructs the executor.
- SQLRETURN - Static variable in interface com.mckoi.database.sql.SQLConstants
- SQLTokenManager - Class in com.mckoi.database.sql
- SQLTokenManager(SimpleCharStream) - Constructor for class com.mckoi.database.sql.SQLTokenManager
- SQLTokenManager(SimpleCharStream, int) - Constructor for class com.mckoi.database.sql.SQLTokenManager
- SQLTrimFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SQLTrimFunction
- SQLTypes - Interface in com.mckoi.database.global
-
A JDBC independant type definition list.
- SQLTypeString(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SQLTypeString
- sqlTypeToString(int) - Static method in class com.mckoi.database.DataTableColumnDef
-
Returns a string that represents the given SQLType enumeration passed to it.
- sqrt() - Method in class com.mckoi.util.BigNumber
- SqrtFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SqrtFunction
- standardColumnChecker(DatabaseConnection, TableName) - Static method in class com.mckoi.database.interpret.ColumnChecker
-
Given a DatabaseConnection and a TableName object, this returns an implementation of ColumnChecker that is able to check that the column name exists in the table, and that the reference is not ambigious.
- standardInverse(Expression) - Static method in class com.mckoi.database.sql.Util
-
Returns an expression that is (exp) = false which is the natural inverse of all expressions.
- StandardJoinExpressionPlan(Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.StandardJoinExpressionPlan
- StandardMessages - Class in com.mckoi.database.global
-
This class contains a number of standard messages that are displayed throughout the operation of the database.
- StandardMessages() - Constructor for class com.mckoi.database.global.StandardMessages
- STAR - Static variable in interface com.mckoi.database.sql.SQLConstants
- start - Variable in class com.mckoi.database.SelectableRange
-
The start of the range to select from the set.
- start - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The start value of the sequence generator.
- start() - Method in class com.mckoi.database.control.TCPJDBCServer
-
Starts the server and binds it to the given port.
- start() - Method in class com.mckoi.store.JournalledSystem
-
Starts the journal system.
- start() - Method in class com.mckoi.store.LoggingBufferManager
-
Starts the buffer manager.
- start(InetAddress, int, String) - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Starts the server running.
- START - Static variable in interface com.mckoi.database.sql.SQLConstants
- start_area - Variable in class com.mckoi.database.IndexSetStore
-
The starting header of this index set.
- start_offset - Variable in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- start_pointer - Variable in class com.mckoi.store.AbstractStore.StoreArea
- start_pointer - Variable in class com.mckoi.store.HeapStore.HeapArea
-
The start pointer in the heap area.
- start_time - Variable in class com.mckoi.database.WorkerThread
-
The time the command was started.
- start_value - Variable in class com.mckoi.database.interpret.Sequence
- startDatabase(DBConfig) - Method in class com.mckoi.database.control.DBController
-
Starts a database in the local JVM given the configuration in DBConfig and returns a DBSystem object.
- startShutDownThread() - Method in class com.mckoi.database.Database
-
Starts the shutdown thread which should contain delegates that shut the database and all its resources down.
- startShutDownThread() - Method in class com.mckoi.database.DatabaseSystem
-
This starts the ShutDown thread that is used to shut down the database server.
- stat_display - Variable in class com.mckoi.database.jdbcserver.SingleThreadedConnectionPoolServer.ServerFarmer
-
Staticial information collected.
- state - Variable in class com.mckoi.database.jdbcserver.JDBCProcessor
-
The current state we are in.
- STATE_BASED - Static variable in interface com.mckoi.database.FunctionInfo
-
A function that is non-aggregate but whose return value is not guarenteed to be the same given the identical parameters over subsequent calls.
- STATE_POST - Static variable in class com.mckoi.database.TableDataConglomerate
-
The postfix on the name of the state file for the database store name.
- state_store - Variable in class com.mckoi.database.TableDataConglomerate
-
A store for the conglomerate state container.
- statement - Variable in class com.mckoi.database.jdbc.MPreparedStatement
-
The SQLQuery object constructed for this statement.
- statement - Variable in class com.mckoi.database.jdbc.MResultSet
-
The MStatement that this result is from.
- Statement - Class in com.mckoi.database.interpret
-
Provides a set of useful utility functions to use by all the interpretted statements.
- Statement() - Constructor for class com.mckoi.database.interpret.Statement
- Statement() - Method in class com.mckoi.database.sql.SQL
- statement_cache - Variable in class com.mckoi.database.DatabaseSystem
-
The StatementCache that maintains a cache of parsed queries.
- statement_class - Variable in class com.mckoi.database.StatementTree
-
The class of statement this is.
- StatementCache - Class in com.mckoi.database
-
A cache that maintains a serialized set of StatementTree objects that can be deserialized on demand.
- StatementCache(DatabaseSystem, int, int, int) - Constructor for class com.mckoi.database.StatementCache
-
Constructs the cache.
- StatementException - Exception in com.mckoi.database
-
An error that is thrown when there is erronious information in a statement.
- StatementException(String) - Constructor for exception com.mckoi.database.StatementException
- statements - Variable in class com.mckoi.jfccontrols.QueryAgent.QueryThread
- StatementTree - Class in com.mckoi.database
-
A serializable container class for a parsed query language statement.
- StatementTree(String) - Constructor for class com.mckoi.database.StatementTree
-
Constructs the StatementTree.
- StatementTreeObject - Interface in com.mckoi.database
-
An complex object that is to be contained within a StatementTree object.
- StateResource(long, String) - Constructor for class com.mckoi.database.StateStore.StateResource
- StateStore - Class in com.mckoi.database
-
A store that manages the current state of all tables in a Conglomerate.
- StateStore(Store) - Constructor for class com.mckoi.database.StateStore
-
Constructs the StateStore.
- StateStore.StateResource - Class in com.mckoi.database
-
Represents a single StateResource in either a visible or delete list in this state file.
- STATIC - Static variable in interface com.mckoi.database.FunctionInfo
-
A type that represents a static function.
- STATIC_LEXER_ERROR - Static variable in error com.mckoi.database.sql.TokenMgrError
-
An attempt wass made to create a second instance of a static token manager.
- staticFlag - Static variable in class com.mckoi.database.sql.SimpleCharStream
- statistics_info - Variable in class com.mckoi.database.GTStatisticsDataSource
-
Contains all the statistics information for this session.
- stats - Variable in class com.mckoi.database.GTStatisticsDataSource
-
The system database stats.
- stats - Variable in class com.mckoi.database.TransactionSystem
-
The stats object that keeps track of database statistics.
- stats() - Method in class com.mckoi.database.Database
-
Convenience static for accessing the global Stats object.
- stats() - Method in class com.mckoi.database.TransactionSystem
-
Returns a com.mckoi.util.Stats object that can be used to keep track of database statistics for this VM.
- Stats - Class in com.mckoi.util
-
An object that is used to store and update various stats.
- Stats() - Constructor for class com.mckoi.util.Stats
-
Constructs the object.
- Stats.IntegerStat - Class in com.mckoi.util
- statsScan(HashMap) - Method in class com.mckoi.store.AbstractStore
-
Performs an extensive lookup on all the tables in this store and sets a number of properties in the given HashMap (property name(String) -> property description(Object)).
- statString(String) - Method in class com.mckoi.util.Stats
-
Returns a String representation of the stat with the given key name.
- STATUS - Static variable in class com.mckoi.database.interpret.Show
- status_text - Variable in class com.mckoi.tools.JDBCQueryTool
-
The JLabel status bar at the bottom of the window.
- statusString() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns a string that contains diagnostic information.
- statusString() - Method in class com.mckoi.database.IndexStore
-
Returns a string that contains diagnostic information.
- stop() - Method in class com.mckoi.database.control.TCPJDBCServer
-
Stops the server running on the given port.
- stop() - Method in class com.mckoi.store.JournalledSystem
-
Stops the journal system.
- stop() - Method in class com.mckoi.store.LoggingBufferManager
-
Stops the buffer manager.
- store - Variable in class com.mckoi.database.BlobStore
-
The outer Store object that is to contain the blob store.
- store - Variable in class com.mckoi.database.FixedRecordList
-
The backing Store object that persistantly stores the structure.
- store - Variable in class com.mckoi.database.IndexSetStore
-
The Store that contains all the data of the index store.
- store - Variable in class com.mckoi.database.StateStore
-
The Store object this state store wraps around.
- store - Variable in class com.mckoi.database.V2MasterTableDataSource
-
The backing store object.
- Store - Interface in com.mckoi.store
-
A store is a resource where areas can be allocated and freed to store objects.
- store_name_map - Variable in class com.mckoi.database.V1HeapStoreSystem
-
A mapping from Store object to name.
- store_resource - Variable in class com.mckoi.store.JournalledFileStore
-
The JournalledResource object that's used to journal all read/write operations to the above 'store_accessor'.
- store_system - Variable in class com.mckoi.database.MasterTableDataSource
-
The StoreSystem implementation that represents the data persistence layer.
- store_system - Variable in class com.mckoi.database.TableDataConglomerate
-
The StoreSystem object used by this conglomerate to store the underlying representation.
- store_system - Variable in class com.mckoi.database.TransactionSystem
-
The underlying StoreSystem implementation that encapsulates the behaviour for storing data persistantly.
- StoreArea(long, long) - Constructor for class com.mckoi.store.AbstractStore.StoreArea
- StoreArea(long, long, long) - Constructor for class com.mckoi.store.AbstractStore.StoreArea
- StoreAreaInputStream(long, long) - Constructor for class com.mckoi.store.AbstractStore.StoreAreaInputStream
- StoreAreaWriter(long, long) - Constructor for class com.mckoi.store.AbstractStore.StoreAreaWriter
- StoreDataAccessor - Interface in com.mckoi.store
-
An interface for low level store data access methods.
- storeExists(String) - Method in interface com.mckoi.database.StoreSystem
-
Returns true if the store with the given name exists within the system, or false otherwise.
- storeExists(String) - Method in class com.mckoi.database.V1FileStoreSystem
- storeExists(String) - Method in class com.mckoi.database.V1HeapStoreSystem
- StoreMutableArea(long, long) - Constructor for class com.mckoi.store.AbstractStore.StoreMutableArea
- StoreMutableArea(long, long, long) - Constructor for class com.mckoi.store.AbstractStore.StoreMutableArea
- storeResultLocally() - Method in class com.mckoi.database.jdbc.MResultSet
-
Asks the server for all the rows in the result set and stores it locally within this object.
- storesLowerCaseIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- storesLowerCaseQuotedIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- storesMixedCaseIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- storesMixedCaseQuotedIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- storesUpperCaseIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- storesUpperCaseQuotedIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- storeSystem() - Method in class com.mckoi.database.Database
-
Returns the StoreSystem for this Database.
- storeSystem() - Method in class com.mckoi.database.MasterTableDataSource
-
Returns the StoreSystem object used to manage stores in the persistence system.
- storeSystem() - Method in class com.mckoi.database.TableDataConglomerate
-
Returns the StoreSystem used by this conglomerate to manage the persistent state of the database.
- storeSystem() - Method in class com.mckoi.database.TransactionSystem
-
Returns the StoreSystem encapsulation being used in this database.
- StoreSystem - Interface in com.mckoi.database
-
An object that creates and manages the Store objects that the database engine uses to represent itself on an external medium such as a disk, and that constitute the low level persistent data format.
- StoreViewPane() - Constructor for class com.mckoi.tools.ConglomerateViewPane.StoreViewPane
- str - Variable in class com.mckoi.database.global.StringObject
-
The java.lang.String object.
- str - Variable in class com.mckoi.database.jdbc.MClob
-
The string the Clob is based on.
- str_decomposition - Variable in class com.mckoi.database.DataTableColumnDef
-
The locale Collator decomposition if this column represents a string.
- str_strength - Variable in class com.mckoi.database.DataTableColumnDef
-
The locale Collator strength if this column represents a string.
- streamable_blob_map - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
A HashMap of blob_reference_id values to Ref objects used to handle and streamable objects in this result.
- streamable_object_id - Variable in class com.mckoi.database.jdbc.AbstractStreamableObject
-
The streamable object identifier.
- streamable_object_list - Variable in class com.mckoi.database.jdbc.MStatement
-
The list of streamable objects created via the 'createStreamableObject' method.
- STREAMABLE_OBJECT_SECTION - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Requests a section of a streamable object from the server.
- StreamableObject - Class in com.mckoi.database.global
-
An object that is streamable (such as a long binary object, or a long string object).
- StreamableObject(byte, long, long) - Constructor for class com.mckoi.database.global.StreamableObject
-
Constructs the StreamableObject.
- StreamableObjectInputStream(long) - Constructor for class com.mckoi.database.jdbc.AbstractStreamableObject.StreamableObjectInputStream
-
Construct the input stream.
- StreamableObjectPart - Class in com.mckoi.database.jdbc
-
Represents a response from the server for a section of a streamable object.
- StreamableObjectPart(byte[]) - Constructor for class com.mckoi.database.jdbc.StreamableObjectPart
-
Constructs the ResultCellPart.
- streamableObjectSection(int, byte[]) - Method in class com.mckoi.database.jdbcserver.JDBCProcessor
-
Returns a section of a streamable object.
- StreamDatabaseInterface - Class in com.mckoi.database.jdbc
-
An stream implementation of an interface to a McKoi database.
- StreamDatabaseInterface() - Constructor for class com.mckoi.database.jdbc.StreamDatabaseInterface
- StreamFile - Class in com.mckoi.store
-
A RandomAccessFile that acts as an OutputStream, and can also be read as an InputStream.
- StreamFile(File, String) - Constructor for class com.mckoi.store.StreamFile
-
Constructor.
- StreamFile.SFInputStream - Class in com.mckoi.store
- StreamFile.SFOutputStream - Class in com.mckoi.store
- StreamJDBCServerConnection - Class in com.mckoi.database.jdbcserver
-
A generic JDBC stream protocol server that reads JDBC commands from a stream from each connection and dispatches the commands appropriately.
- StreamJDBCServerConnection(DatabaseInterface, InputStream, OutputStream, DebugLogger) - Constructor for class com.mckoi.database.jdbcserver.StreamJDBCServerConnection
-
Sets up the protocol connection.
- strength - Variable in class com.mckoi.database.TStringType
-
The strength of the collator for this string (as defined in java.text.Collator).
- strict_get_object - Variable in class com.mckoi.database.jdbc.MConnection
-
If the ResultSet.getObject method should return the raw object type (eg.
- STRING - Static variable in interface com.mckoi.database.sql.SQLConstants
- STRING_COMPARATOR - Static variable in class com.mckoi.util.Stats
-
Comparator for sorting the list of keys (for 1.1 implementation without Comparable String objects).
- string_list - Variable in class com.mckoi.util.StringListBucket
-
The String List.
- STRING_LITERAL - Static variable in interface com.mckoi.database.sql.SQLConstants
- STRING_TYPE - Static variable in class com.mckoi.database.TType
-
A default string (SQL VARCHAR) type of unlimited maximum size and null locale.
- StringAccessor - Interface in com.mckoi.database.global
-
An interface used by the engine to access and process strings.
- stringClasses - Static variable in class com.mckoi.database.Caster
- stringColumn(String) - Static method in class com.mckoi.database.GTDataSource
-
Convenience methods for constructing a DataTableDef for the dynamically generated table.
- stringColumnList(String[]) - Static method in class com.mckoi.database.TableDataConglomerate
-
Convenience, converts a String[] array to a comma deliminated string list.
- stringCompare(String, String) - Method in class com.mckoi.database.interpret.FromTableDirectSource
- stringCompare(String, String) - Method in class com.mckoi.database.interpret.FromTableSubQuerySource
- stringCompare(String, String) - Method in class com.mckoi.database.interpret.TableExpressionFromSet
- StringListBucket - Class in com.mckoi.util
-
A utility container class for holding a list of strings.
- StringListBucket() - Constructor for class com.mckoi.util.StringListBucket
-
Constructs the bucket.
- StringListBucket(String) - Constructor for class com.mckoi.util.StringListBucket
- StringObject - Class in com.mckoi.database.global
-
A concrete implementation of StringAccessor that uses a java.lang.String object.
- StringObject(String) - Constructor for class com.mckoi.database.global.StringObject
-
Constructs the object.
- StringOperator(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- stringPrims - Static variable in class com.mckoi.database.Caster
- stringRepresentation() - Method in class com.mckoi.database.Operator
-
Returns the string value of this operator.
- stringType(int, int, String, int, int) - Static method in class com.mckoi.database.TType
-
Returns a TStringType object of the given size and locale information.
- StringUtil - Class in com.mckoi.util
-
Various String utilities.
- StringUtil() - Constructor for class com.mckoi.util.StringUtil
- stringVal(StringObject) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of VARCHAR type that represents the given StringObject value.
- stringVal(String) - Static method in class com.mckoi.database.TObject
-
Returns a TObject of VARCHAR type that represents the given String value.
- stripColumnList(String, ArrayList) - Static method in class com.mckoi.database.interpret.ColumnChecker
-
Calls the 'stripTableName' method on all elements in the given list.
- stripTableName(String, String) - Static method in class com.mckoi.database.interpret.ColumnChecker
-
Given a column name string, this will strip off the preceeding table name if there is one specified.
- STRUCT - Static variable in interface com.mckoi.database.global.SQLTypes
- sub_op - Static variable in class com.mckoi.database.Operator
- sub_query_operator - Variable in class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
-
The SubQuery operator, eg.
- SubLogicExpressionPlan(Expression) - Constructor for class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SubLogicExpressionPlan
- subquery_table - Variable in class com.mckoi.database.interpret.FromTableDef
-
If this is true, then the table def represents a sub-query table.
- SubQueryExpression(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- SubQueryOperator(Expression, Stack) - Method in class com.mckoi.database.sql.SQL
- subselect_table - Variable in class com.mckoi.database.interpret.FromTableDef
-
The TableSelectExpression if this is a subquery table.
- subset_table_def - Variable in class com.mckoi.database.SubsetColumnTable
-
The DataTableDef object that describes the subset column of this table.
- SubsetColumnTable - Class in com.mckoi.database
-
This object is a filter that sits atop a Table object.
- SubsetColumnTable(Table) - Constructor for class com.mckoi.database.SubsetColumnTable
-
The Constructor.
- SubsetNode(QueryPlanNode, Variable[], Variable[]) - Constructor for class com.mckoi.database.QueryPlan.SubsetNode
- substituteAliasedVariable(Variable, ArrayList) - Static method in class com.mckoi.database.interpret.Planner
- substituteAliasedVariables(Expression, ArrayList) - Static method in class com.mckoi.database.interpret.Planner
-
Substitutes any aliased variables in the given expression with the function name equivalent.
- substituteReservedTableName(TableName) - Static method in class com.mckoi.database.DatabaseConnection
-
If the given table name is a reserved name, then we must substitute it with its correct form.
- SubstringFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SubstringFunction
- subtract(BigNumber) - Method in class com.mckoi.util.BigNumber
- SUBTRACT - Static variable in interface com.mckoi.database.sql.SQLConstants
- SubtractOperator() - Constructor for class com.mckoi.database.Operator.SubtractOperator
- SUCCESS - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Operation was successful.
- SumFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.SumFunction
- supportsAlterTableWithAddColumn() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsAlterTableWithDropColumn() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsANSI92EntryLevelSQL() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsANSI92FullSQL() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsANSI92IntermediateSQL() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsBatchUpdates() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCatalogsInDataManipulation() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCatalogsInIndexDefinitions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCatalogsInPrivilegeDefinitions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCatalogsInProcedureCalls() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCatalogsInTableDefinitions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsColumnAliasing() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsConvert() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsConvert(int, int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCoreSQLGrammar() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsCorrelatedSubqueries() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsDataDefinitionAndDataManipulationTransactions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsDataManipulationTransactionsOnly() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsDifferentTableCorrelationNames() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsExpressionsInOrderBy() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsExtendedSQLGrammar() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsFullOuterJoins() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsGetGeneratedKeys() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsGroupBy() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsGroupByBeyondSelect() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsGroupByUnrelated() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsIntegrityEnhancementFacility() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsLikeEscapeClause() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsLimitedOuterJoins() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsMinimumSQLGrammar() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsMixedCaseIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsMixedCaseQuotedIdentifiers() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsMultipleOpenResults() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsMultipleResultSets() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsMultipleTransactions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsNamedParameters() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsNonNullableColumns() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsOpenCursorsAcrossCommit() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsOpenCursorsAcrossRollback() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsOpenStatementsAcrossCommit() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsOpenStatementsAcrossRollback() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsOrderByUnrelated() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsOuterJoins() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsPositionedDelete() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsPositionedUpdate() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsResultSetConcurrency(int, int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsResultSetHoldability(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsResultSetType(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSavepoints() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSchemasInDataManipulation() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSchemasInIndexDefinitions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSchemasInPrivilegeDefinitions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSchemasInProcedureCalls() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSchemasInTableDefinitions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSelectForUpdate() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsStatementPooling() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsStoredFunctionsUsingCallSyntax() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsStoredProcedures() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSubqueriesInComparisons() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSubqueriesInExists() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSubqueriesInIns() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsSubqueriesInQuantifieds() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsTableCorrelationNames() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsTransactionIsolationLevel(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsTransactions() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsUnion() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- supportsUnionAll() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- SwingBlockUtil - Class in com.mckoi.jfccontrols
-
Helper class for providing blocking behaviour on the AWT/Swing event dispatcher thread without freezing up the user interface.
- SwingBlockUtil() - Constructor for class com.mckoi.jfccontrols.SwingBlockUtil
- switchArgument(String) - Method in class com.mckoi.util.CommandLine
-
Returns the contents of a switch variable if the switch is found on the command line.
- switchArgument(String, String) - Method in class com.mckoi.util.CommandLine
-
Returns the contents of a switch variable if the switch is found on the command line.
- switchArguments(String, int) - Method in class com.mckoi.util.CommandLine
-
Returns the contents of a set of arguments found after a switch on the command line.
- SwitchTo(int) - Method in class com.mckoi.database.sql.SQLTokenManager
- sync_buffer - Variable in class com.mckoi.database.FixedSizeDataStore
- synch() - Method in class com.mckoi.database.FixedSizeDataStore
-
Synchronizes the memory store with the file header.
- synch() - Method in class com.mckoi.database.VariableSizeDataStore
-
Synchronizes all the data in memory with the hard copy on disk.
- synch() - Method in class com.mckoi.store.HeapStore
- synch() - Method in class com.mckoi.store.IOStoreDataAccessor
- synch() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- synch() - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
- synch() - Method in class com.mckoi.store.JournalledSystem.Resource
- synch() - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- synch() - Method in interface com.mckoi.store.StoreDataAccessor
-
Synchronizes the data area by forcing any data out of the OS buffers onto the disk.
- synch() - Method in class com.mckoi.store.StreamFile
-
Synchs the file.
- synchAll() - Method in class com.mckoi.database.V1MasterTableDataSource
- SYS_DATA_TRIGGER - Static variable in class com.mckoi.database.Database
-
The system internally generated 'sUSRDataTrigger' table.
- SYS_DB_STATISTICS - Static variable in class com.mckoi.database.Database
-
The system internally generated 'sUSRDatabaseStatistics' table.
- SYS_FUNCTION - Static variable in class com.mckoi.database.Database
-
The function table.
- SYS_FUNCTIONFACTORY - Static variable in class com.mckoi.database.Database
-
The function factory table.
- SYS_GRANTS - Static variable in class com.mckoi.database.Database
- SYS_LABEL - Static variable in class com.mckoi.database.Database
-
The label table.
- SYS_PASSWORD - Static variable in class com.mckoi.database.Database
-
The password privs and grants table.
- SYS_SEQUENCE - Static variable in class com.mckoi.database.TableDataConglomerate
- SYS_SEQUENCE_INFO - Static variable in class com.mckoi.database.TableDataConglomerate
- SYS_SERVICE - Static variable in class com.mckoi.database.Database
-
The services table.
- SYS_TABLE_COLUMNS - Static variable in class com.mckoi.database.Database
-
The system internally generated 'sUSRTableColumns' table.
- SYS_TABLE_INFO - Static variable in class com.mckoi.database.Database
-
The system internally generated 'sUSRTableInfo' table.
- SYS_USERCONNECT - Static variable in class com.mckoi.database.Database
- SYS_USERPRIV - Static variable in class com.mckoi.database.Database
- SYS_VIEW - Static variable in class com.mckoi.database.Database
-
The view table.
- system - Variable in class com.mckoi.database.control.TCPJDBCServer
-
The DBSystem object that we are serving.
- system - Variable in class com.mckoi.database.Database
-
The DatabaseSystem that this database is part of.
- system - Variable in class com.mckoi.database.DatabaseDispatcher
- system - Variable in class com.mckoi.database.DataCellCache
-
The TransactionSystem that this cache is from.
- system - Variable in class com.mckoi.database.GTDataSource
-
The TransactionSystem object for this table.
- system - Variable in class com.mckoi.database.IndexSetStore
-
The TransactionSystem for this index set.
- system - Variable in class com.mckoi.database.MasterTableDataSource
-
The global TransactionSystem object that points to the global system that this table source belongs to.
- system - Variable in class com.mckoi.database.MultiVersionTableIndices
-
The system object.
- system - Variable in class com.mckoi.database.OpenTransactionList
-
The system that this transaction list is part of.
- system - Variable in class com.mckoi.database.RIDList
-
The TransactionSystem that we are in.
- system - Variable in class com.mckoi.database.RowData
-
The TransactionSystem this RowData is a context of.
- system - Variable in class com.mckoi.database.SimpleTransaction
-
The TransactionSystem context.
- system - Variable in class com.mckoi.database.StatementCache
-
The DatabaseSystem of this cache.
- system - Variable in class com.mckoi.database.SystemQueryContext
-
The wrapped TransactionSystem object.
- system - Variable in class com.mckoi.database.TableDataConglomerate
-
The TransactionSystem that this Conglomerate is a child of.
- system - Variable in class com.mckoi.database.TriggerManager
-
The parent TransactionSystem object.
- system - Variable in class com.mckoi.database.V1FileStoreSystem
-
The TransactionSystem that contains the various configuration options for the database.
- system - Variable in class com.mckoi.database.WorkerPool
-
The TransactionSystem that this pool is part of.
- SYSTEM_ERR - Static variable in class com.mckoi.debug.Debug
-
Deprecated.The PrintWriter for the system error stream.
- SYSTEM_ERR - Static variable in class com.mckoi.debug.DefaultDebugLogger
-
The PrintWriter for the system error stream.
- SYSTEM_OUT - Static variable in class com.mckoi.debug.Debug
-
Deprecated.The PrintWriter for the system output stream.
- SYSTEM_OUT - Static variable in class com.mckoi.debug.DefaultDebugLogger
-
The PrintWriter for the system output stream.
- SYSTEM_SCHEMA - Static variable in class com.mckoi.database.Database
-
The name of the system schema that contains tables refering to system information.
- SYSTEM_SCHEMA - Static variable in class com.mckoi.database.TableDataConglomerate
-
The name of the system schema where persistant conglomerate state is stored.
- SystemBackup - Class in com.mckoi.database.procedure
-
A stored procedure that backs up the entire database to the given directory in the file system.
- SystemBackup() - Constructor for class com.mckoi.database.procedure.SystemBackup
- SystemQueryContext - Class in com.mckoi.database
-
A QueryContext that only wraps around a TransactionSystem and does not provide implementations for the 'getTable', and 'getDatabase' methods.
- SystemQueryContext(SimpleTransaction, String) - Constructor for class com.mckoi.database.SystemQueryContext
-
Constructs the QueryContext.
T
- t - Variable in class com.mckoi.store.LoggingBufferManager.BMPage
-
The time this page was last accessed.
- T_lock - Variable in class com.mckoi.store.LoggingBufferManager
-
A lock used when accessing the current_T, page_list and current_page_count members.
- table - Variable in class com.mckoi.database.RawTableElement
- table - Variable in class com.mckoi.database.RowData
-
The TableDataSource object that this RowData is in, or is destined to be in.
- table - Variable in class com.mckoi.database.SelectableScheme
-
The table data source with the column this scheme indexes.
- table - Variable in class com.mckoi.database.SimpleTableQuery
-
The TableDataSource we are wrapping.
- table - Variable in class com.mckoi.database.TableAccessState
-
The underlying Table object.
- table - Variable in class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- table - Variable in class com.mckoi.tools.ConglomerateViewPane.StoreViewPane
-
The JTable that contains the information.
- Table - Class in com.mckoi.database
-
This is a definition for a table in the database.
- Table() - Constructor for class com.mckoi.database.Table
-
The Constructor.
- TABLE - Static variable in class com.mckoi.database.GrantManager
-
Represents a TABLE object to grant privs over for the user.
- TABLE - Static variable in interface com.mckoi.database.sql.SQLConstants
- TABLE_ADD - Static variable in class com.mckoi.database.MasterTableJournal
-
Journal commands.
- TABLE_ADD - Static variable in class com.mckoi.database.TransactionJournal
-
Journal commands.
- table_alias - Variable in class com.mckoi.database.interpret.FromTableDef
-
The alias of the table or null if no alias was defined.
- TABLE_ALL_PRIVS - Static variable in class com.mckoi.database.Privileges
-
Enable all privs for the object.
- table_backed_cache_list - Variable in class com.mckoi.database.DatabaseConnection
-
The list of all TableBackedCache objects that have been attached to this DatabaseConnection and are to be notified of transaction start/end events.
- table_cache - Variable in class com.mckoi.database.SimpleTransaction
-
A cache of tables that have been accessed via this transaction.
- TABLE_CONSTRAINT_ALTER - Static variable in class com.mckoi.database.TransactionJournal
- TABLE_CREATE - Static variable in class com.mckoi.database.TransactionJournal
- table_def - Variable in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- table_def - Variable in class com.mckoi.database.MasterTableDataSource
-
A DataTableDef object that describes the table topology.
- table_def - Variable in class com.mckoi.database.RowData
-
The definition of the table.
- table_def - Variable in class com.mckoi.database.SimpleTableQuery
-
The DataTableDef for this table.
- table_def - Variable in class com.mckoi.database.TemporaryTable
-
The DataTableDef object that describes the columns in this table.
- table_def_list - Variable in class com.mckoi.database.AbstractInternalTableInfo
-
The list of DataTableDef objects that descibe each table in the above list.
- table_desc_file - Variable in class com.mckoi.database.TableDescriptions
-
The File that contains the table descriptions list.
- TABLE_DESC_FILE - Static variable in class com.mckoi.database.TableDescriptions
-
The filename of the file that describes every table in the database.
- table_descriptions - Variable in class com.mckoi.database.TableDescriptions
-
A hash table that maps from table name to the DataTableDef object that describes the table.
- TABLE_DROP - Static variable in class com.mckoi.database.TransactionJournal
- TABLE_DROPPED - Static variable in exception com.mckoi.database.TransactionException
-
Thrown when a transaction adds/removes/modifies rows from a table that has been dropped by another transaction.
- table_expression - Variable in class com.mckoi.database.interpret.FromTableSubQuerySource
-
The wrapped object.
- table_id - Variable in class com.mckoi.database.DataCellCache.DCCacheKey
- table_id - Variable in class com.mckoi.database.jdbc.RowCache.RowRef
- table_id - Variable in class com.mckoi.database.MasterTableDataSource
-
An integer that uniquely identifies this data source within the conglomerate.
- table_id - Variable in class com.mckoi.database.MasterTableJournal
-
The master table id.
- table_id - Variable in class com.mckoi.database.StateStore.StateResource
-
The unique identifier for the resource.
- table_id - Variable in class com.mckoi.database.StateStore
-
The current table identifier.
- table_indexes - Variable in class com.mckoi.database.CompositeTable
-
The list of indexes of rows to include in each table.
- table_indices - Variable in class com.mckoi.database.MasterTableDataSource
-
A multi-version representation of the table indices kept for this table including the row list and the scheme indices.
- table_indices - Variable in class com.mckoi.database.SimpleTransaction
-
An IndexSet for each visible table from the above list.
- table_journal - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
A journal of changes to this source since it was created.
- table_key - Variable in class com.mckoi.database.interpret.FromClause
-
An id used for making unique names for anonymous inner selects.
- table_list - Variable in class com.mckoi.database.AbstractInternalTableInfo
-
The list of table names (as TableName) that this object maintains.
- table_list - Variable in class com.mckoi.database.GTTableInfoDataSource
-
The list of all TableName visible to the transaction.
- table_list - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner
-
The list of PlanTableSource objects for each source being planned.
- table_list - Variable in class com.mckoi.database.interpret.Statement
-
The list of all FromTableInterface objects of resources referenced in this query.
- table_list - Variable in class com.mckoi.database.TableDataConglomerate
-
The list of all tables that are currently open in this conglomerate.
- table_listeners - Variable in class com.mckoi.database.TransactionSystem
-
A list of table names and listeners that are notified of add and remove events in a table.
- table_lock_check - Variable in class com.mckoi.database.TransactionSystem
-
Set to true if locking checks should be performed each time a table is accessed.
- table_map - Variable in class com.mckoi.database.TriggerManager
-
Maps from the trigger source string to the list of TriggerAction objects that are listening for events from this source.
- table_model - Variable in class com.mckoi.tools.JDBCQueryTool
-
The ResultSetTableModel for the table model that contains our result set.
- table_name - Variable in class com.mckoi.database.AbstractInternalTableInfo2
-
The table in the transaction that contains the list of items we are modelling.
- table_name - Variable in class com.mckoi.database.DataIndexSetDef
-
The TableName this index set meta data is for.
- table_name - Variable in class com.mckoi.database.DataTableDef
-
A TableName object that represents this data table def.
- table_name - Variable in class com.mckoi.database.interpret.AlterTable
-
The name of the table we are altering.
- table_name - Variable in class com.mckoi.database.interpret.Compact
-
The name the table that we are to update.
- table_name - Variable in class com.mckoi.database.interpret.CreateTable
-
The name of the table to create.
- table_name - Variable in class com.mckoi.database.interpret.Delete
-
The name the table that we are to delete from.
- table_name - Variable in class com.mckoi.database.interpret.FromTableDef
-
The name of the table this definition references.
- table_name - Variable in class com.mckoi.database.interpret.FromTableDirectSource
-
The given TableName of this table.
- table_name - Variable in class com.mckoi.database.interpret.Insert
- table_name - Variable in class com.mckoi.database.interpret.Show
-
The name the table that we are to update.
- table_name - Variable in class com.mckoi.database.interpret.UpdateTable
-
The name the table that we are to update.
- table_name - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The name of this table.
- table_name - Variable in class com.mckoi.database.MultiVersionTableIndices
-
The name of the table.
- table_name - Variable in class com.mckoi.database.QueryPlan.FetchTableNode
-
The name of the table to fetch.
- table_name - Variable in class com.mckoi.database.QueryPlan.FetchViewNode
-
The name of the view to fetch.
- table_name - Variable in class com.mckoi.database.ReferenceTable
-
This represents the new name of the table.
- table_name - Variable in class com.mckoi.database.RIDList
-
The TableName of the table.
- table_name - Variable in class com.mckoi.database.TableCommitModificationEvent
-
The name of the table that is being changed.
- table_name - Variable in class com.mckoi.database.TableModificationEvent
-
The name of the table that was modified.
- table_name - Variable in class com.mckoi.database.TableName
-
The name of the table.
- table_name - Variable in class com.mckoi.database.Variable
-
The TableName that is the context of this column.
- table_query - Variable in class com.mckoi.database.interpret.FromTableDirectSource
-
The TableQueryDef object that links to the underlying table.
- TABLE_READ_PRIVS - Static variable in class com.mckoi.database.Privileges
-
Read privs for the object.
- TABLE_REMOVE - Static variable in class com.mckoi.database.MasterTableJournal
- TABLE_REMOVE - Static variable in class com.mckoi.database.TransactionJournal
- TABLE_REMOVE_CLASH - Static variable in exception com.mckoi.database.TransactionException
-
Thrown when a transaction drops or alters a table that another transaction has committed a change to.
- table_resources - Variable in class com.mckoi.database.interpret.TableExpressionFromSet
-
The list of table resources in this set.
- table_source - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SingleVarPlan
- table_storage - Variable in class com.mckoi.database.TemporaryTable
-
A Vector that represents the storage of TObject[] arrays for each row of the table.
- table_type - Variable in class com.mckoi.database.AbstractInternalTableInfo
-
The table type of table objects returned by this method.
- table_type_class - Variable in class com.mckoi.database.DataTableDef
-
The type of table this is (this is the class name of the object that maintains the underlying database files).
- table_types - Variable in class com.mckoi.database.GTTableInfoDataSource
-
The list of all table types that are visible.
- TABLE_UPDATE_ADD - Static variable in class com.mckoi.database.MasterTableJournal
- TABLE_UPDATE_REMOVE - Static variable in class com.mckoi.database.MasterTableJournal
- Table.TableVariableResolver - Class in com.mckoi.database
-
An implementation of VariableResolver that we can use to resolve column names in this table to cells for a specific row.
- TableAccessState - Class in com.mckoi.database
-
This class provides very limited access to a Table object.
- TableAccessState(Table) - Constructor for class com.mckoi.database.TableAccessState
-
The Constructor.
- TableAliasName() - Method in class com.mckoi.database.sql.SQL
- TableBackedCache - Class in com.mckoi.database
-
A TableBackedCache is a special type of a cache in a DataTableConglomerate that is backed by a table in the database.
- TableBackedCache(TableName) - Constructor for class com.mckoi.database.TableBackedCache
-
Constructs this object.
- tableCommitChange(TableCommitModificationEvent) - Method in interface com.mckoi.database.TransactionModificationListener
-
An action for when changes to a table are committed.
- TableCommitModificationEvent - Class in com.mckoi.database
-
An object that encapsulates all row modification information about a table when a change to the table is about to be committed.
- TableCommitModificationEvent(SimpleTransaction, TableName, int[], int[]) - Constructor for class com.mckoi.database.TableCommitModificationEvent
-
Constructs the event.
- TableConstraintDefinition() - Method in class com.mckoi.database.sql.SQL
- TableDataConglomerate - Class in com.mckoi.database
-
A conglomerate of data that represents the contents of all tables in a complete database.
- TableDataConglomerate(TransactionSystem, StoreSystem) - Constructor for class com.mckoi.database.TableDataConglomerate
-
Constructs the conglomerate.
- TableDataConglomerate.CommitTableInfo - Class in com.mckoi.database
-
A static container class for information collected about a table during the commit cycle.
- TableDataConglomerate.NameSpaceJournal - Class in com.mckoi.database
-
A journal for handling namespace clashes between transactions.
- TableDataConglomerate.TableRowVariableResolver - Class in com.mckoi.database
-
A variable resolver for a single row of a table source.
- TableDataSource - Interface in com.mckoi.database
-
This interface represents the source of data in a table.
- TableDeclaration(FromClause) - Method in class com.mckoi.database.sql.SQL
- TableDescriptions - Class in com.mckoi.database
-
An object that is a key part of Database.
- TableDescriptions(File) - Constructor for class com.mckoi.database.TableDescriptions
-
Constructs this object with the database in the given directory.
- tableExists(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Returns true if the table exists within this connection transaction.
- tableExists(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Returns true if the database table object with the given name exists within this transaction.
- tableExists(String) - Method in class com.mckoi.database.DatabaseConnection
-
Returns true if the table exists within this connection transaction.
- TableExpressionFromSet - Class in com.mckoi.database.interpret
-
A set of tables and function references that make up the resources made available by a table expression.
- TableExpressionFromSet(DatabaseConnection) - Constructor for class com.mckoi.database.interpret.TableExpressionFromSet
-
Constructs the object.
- TableExpressionRefResolver - Class in com.mckoi.database.interpret
-
This class is used to resolve a reference name to a concrete table/column in a table expression.
- TableExpressionRefResolver() - Constructor for class com.mckoi.database.interpret.TableExpressionRefResolver
- TableFunctions - Class in com.mckoi.database
-
A number of functions that are table set functions such as simple select operations, joins, unions, sub-query operations, etc.
- TableFunctions() - Constructor for class com.mckoi.database.TableFunctions
- TableGroupResolver() - Constructor for class com.mckoi.database.FunctionTable.TableGroupResolver
- TableGVResolver() - Constructor for class com.mckoi.database.FunctionTable.TableGroupResolver.TableGVResolver
- tableLockingEnabled() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if the database should perform checking of table locks.
- TableModificationEvent - Class in com.mckoi.database
-
The event information of when a table is modified inside a transaction.
- TableModificationEvent(DatabaseConnection, TableName, int, boolean) - Constructor for class com.mckoi.database.TableModificationEvent
-
Constructs a delete event.
- TableModificationEvent(DatabaseConnection, TableName, int, RowData, boolean) - Constructor for class com.mckoi.database.TableModificationEvent
-
Constructs an update event.
- TableModificationEvent(DatabaseConnection, TableName, int, RowData, int, boolean) - Constructor for class com.mckoi.database.TableModificationEvent
-
General Constructor.
- TableModificationEvent(DatabaseConnection, TableName, RowData, boolean) - Constructor for class com.mckoi.database.TableModificationEvent
-
Constructs an insert event.
- TableName - Class in com.mckoi.database
-
A name of a table and any associated referencing information.
- TableName(String) - Constructor for class com.mckoi.database.TableName
- TableName(String, String) - Constructor for class com.mckoi.database.TableName
-
Constructs the name.
- TableName() - Method in class com.mckoi.database.sql.SQL
- TableQueryDef - Interface in com.mckoi.database
-
An interface to an object that describes characteristics of a table based object in the database.
- TableRowVariableResolver(TableDataSource, int) - Constructor for class com.mckoi.database.TableDataConglomerate.TableRowVariableResolver
- TABLES - Static variable in class com.mckoi.database.interpret.Show
- tables_cache - Variable in class com.mckoi.database.DatabaseConnection
-
A HashMap of DataTable objects that have been created within this connection.
- TableSelectExpression - Class in com.mckoi.database.interpret
-
A container object for the a table select expression, eg.
- TableSelectExpression() - Constructor for class com.mckoi.database.interpret.TableSelectExpression
-
Constructor.
- TableVariableResolver() - Constructor for class com.mckoi.database.Table.TableVariableResolver
- TArrayType - Class in com.mckoi.database
-
An implementation of TType for an expression array.
- TArrayType() - Constructor for class com.mckoi.database.TArrayType
-
Constructs the type.
- TBinaryType - Class in com.mckoi.database
-
An implementation of TType for a binary block of data.
- TBinaryType(int, int) - Constructor for class com.mckoi.database.TBinaryType
-
Constructs the type.
- TBooleanType - Class in com.mckoi.database
-
An implementation of TType for a boolean value.
- TBooleanType(int) - Constructor for class com.mckoi.database.TBooleanType
-
Constructs the type.
- tcp_port - Variable in class com.mckoi.database.control.TCPJDBCServer
-
The TCP port that this server is bound to.
- TCPJDBCServer - Class in com.mckoi.database.control
-
Attaches to a DBSystem, and binds a TCP port and serves queries for JDBC connections.
- TCPJDBCServer(DBSystem) - Constructor for class com.mckoi.database.control.TCPJDBCServer
-
Constructs the TCP JDBC with the given DBSystem object, and sets the TCP port and address (for multi-homed computers) to the setting of the configuration in 'system'.
- TCPJDBCServer(DBSystem, int) - Constructor for class com.mckoi.database.control.TCPJDBCServer
-
Constructs the TCP JDBC with the given DBSystem object, and sets the TCP port that we serve the database from.
- TCPJDBCServer(DBSystem, InetAddress, int) - Constructor for class com.mckoi.database.control.TCPJDBCServer
-
Constructs the TCP JDBC with the given DBSystem object, and sets the inet address and TCP port that we serve the database from.
- TCPJDBCServerConnection - Class in com.mckoi.database.jdbcserver
-
A ServerConnection that processes JDBC queries from a client from a TCP Socket.
- TCPJDBCServerConnection(DatabaseInterface, Socket, DebugLogger) - Constructor for class com.mckoi.database.jdbcserver.TCPJDBCServerConnection
-
Constructs the ServerConnection object.
- TCPServer - Class in com.mckoi.database.jdbcserver
-
A TCP/IP socket server that opens a single port and allows JDBC clients to connect through the port to talk with the database.
- TCPServer(Database) - Constructor for class com.mckoi.database.jdbcserver.TCPServer
-
Constructs the TCPServer over the given DatabaseSystem configuration.
- TCPStreamDatabaseInterface - Class in com.mckoi.database.jdbc
-
Connection to the database via the TCP protocol.
- TCPStreamDatabaseInterface(String, int) - Constructor for class com.mckoi.database.jdbc.TCPStreamDatabaseInterface
-
Constructor.
- TDateType - Class in com.mckoi.database
-
An implementation of TType for date objects.
- TDateType(int) - Constructor for class com.mckoi.database.TDateType
-
Constructs the type.
- temp_desc_file - Variable in class com.mckoi.database.TableDescriptions
-
The File we use to temporary store the table descriptions as we save them.
- temporary - Variable in class com.mckoi.database.interpret.CreateTable
-
Set to true if this create statement is for a temporary table.
- TEMPORARY - Static variable in interface com.mckoi.database.sql.SQLConstants
- TemporaryTable - Class in com.mckoi.database
-
This class represents a temporary table that is built from data that is not related to any underlying DataTable object from the database.
- TemporaryTable(Database, String, DataTableColumnDef[]) - Constructor for class com.mckoi.database.TemporaryTable
-
The Constructor.
- TemporaryTable(DefaultDataTable) - Constructor for class com.mckoi.database.TemporaryTable
-
Constructs this TemporaryTable based on the given Table object.
- TemporaryTable(String, Table) - Constructor for class com.mckoi.database.TemporaryTable
-
Constructs this TemporaryTable based on the fields from the given Table object.
- TERTIARY_STRENGTH - Static variable in interface com.mckoi.database.sql.SQLConstants
- Test() - Method in class com.mckoi.database.sql.SQL
- testCommitClash(DataTableDef, MasterTableJournal) - Method in class com.mckoi.database.MasterTableJournal
-
Throws a transaction clash exception if it detects a clash between journal entries.
- testSearch(String, String, boolean) - Static method in class com.mckoi.database.PatternSearch
- text - Variable in class com.mckoi.database.Expression
-
The expression as a plain human readable string.
- text() - Method in class com.mckoi.database.Expression
-
Returns the StringBuffer that we can use to append plain text representation as we are parsing the expression.
- TEXT - Static variable in interface com.mckoi.database.sql.SQLConstants
- tgv_resolver - Variable in class com.mckoi.database.FunctionTable.TableGroupResolver
-
A VariableResolver that can resolve variables within a set of a group.
- there_is_backing_data - Variable in class com.mckoi.store.JournalledSystem.Resource
-
True if there is actually data to be read in the above object.
- thread_closed - Variable in class com.mckoi.database.jdbc.RemoteDatabaseInterface.ConnectionThread
-
Set to true when the thread is closed.
- TIME - Static variable in interface com.mckoi.database.global.SQLTypes
- TIME - Static variable in interface com.mckoi.database.sql.SQLConstants
- time_connected - Variable in class com.mckoi.database.User
-
The time this user connected.
- time_format_sql - Static variable in class com.mckoi.database.global.CastHelper
- time_to_run_event - Variable in class com.mckoi.database.DatabaseDispatcher.DatabaseEvent
- TIME_TYPE - Static variable in class com.mckoi.database.InternalFunctionFactory.TimeObFunction
- timeClasses - Static variable in class com.mckoi.database.Caster
- TimeFrame - Class in com.mckoi.util
-
An immutable object that represents a frame of time down to the accuracy of a millisecond.
- TimeFrame(BigDecimal) - Constructor for class com.mckoi.util.TimeFrame
-
Constructs the TimeFrame for the given time.
- timeNow() - Method in class com.mckoi.database.InternalFunctionFactory.TimeObFunction
- TimeObFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.TimeObFunction
- timePrims - Static variable in class com.mckoi.database.Caster
- TIMESTAMP - Static variable in interface com.mckoi.database.global.SQLTypes
- TIMESTAMP - Static variable in interface com.mckoi.database.sql.SQLConstants
- TIMESTAMP_TYPE - Static variable in class com.mckoi.database.InternalFunctionFactory.TimeStampObFunction
- TIMESTAMP_VALUE_INCLUDES_NANOS - Static variable in class com.mckoi.database.jdbc.MPreparedStatement
-
True if the timestamp value includes nanoseconds, which is the case starting with Java 1.4.0
- timestampClasses - Static variable in class com.mckoi.database.Caster
- TimeStampObFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.TimeStampObFunction
- timestampPrims - Static variable in class com.mckoi.database.Caster
- tinyClasses - Static variable in class com.mckoi.database.Caster
- TINYINT - Static variable in interface com.mckoi.database.global.SQLTypes
- TINYINT - Static variable in interface com.mckoi.database.sql.SQLConstants
- tinyPrims - Static variable in class com.mckoi.database.Caster
- titleString() - Method in class com.mckoi.database.QueryPlan.BranchQueryPlanNode
- titleString() - Method in class com.mckoi.database.QueryPlan.CachePointNode
- titleString() - Method in class com.mckoi.database.QueryPlan.ConstantSelectNode
- titleString() - Method in class com.mckoi.database.QueryPlan.CreateFunctionsNode
- titleString() - Method in class com.mckoi.database.QueryPlan.DistinctNode
- titleString() - Method in class com.mckoi.database.QueryPlan.ExhaustiveSelectNode
- titleString() - Method in class com.mckoi.database.QueryPlan.FetchTableNode
- titleString() - Method in class com.mckoi.database.QueryPlan.FetchViewNode
- titleString() - Method in class com.mckoi.database.QueryPlan.GroupNode
- titleString() - Method in class com.mckoi.database.QueryPlan.JoinNode
- titleString() - Method in class com.mckoi.database.QueryPlan.LeftOuterJoinNode
- titleString() - Method in class com.mckoi.database.QueryPlan.LogicalUnionNode
- titleString() - Method in class com.mckoi.database.QueryPlan.MarkerNode
- titleString() - Method in class com.mckoi.database.QueryPlan.NaturalJoinNode
- titleString() - Method in class com.mckoi.database.QueryPlan.NonCorrelatedAnyAllNode
- titleString() - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
- titleString() - Method in class com.mckoi.database.QueryPlan.SimplePatternSelectNode
- titleString() - Method in class com.mckoi.database.QueryPlan.SimpleSelectNode
- titleString() - Method in class com.mckoi.database.QueryPlan.SingleQueryPlanNode
- titleString() - Method in class com.mckoi.database.QueryPlan.SingleRowTableNode
- titleString() - Method in class com.mckoi.database.QueryPlan.SortNode
- titleString() - Method in class com.mckoi.database.QueryPlan.SubsetNode
- TJavaObjectType - Class in com.mckoi.database
-
An implementation of TType for a java object of possibly defined type.
- TJavaObjectType(String) - Constructor for class com.mckoi.database.TJavaObjectType
-
Constructs the type.
- tname - Variable in class com.mckoi.database.interpret.AlterTable
-
The TableName object.
- tname - Variable in class com.mckoi.database.interpret.CreateTable
-
The TableName object.
- tname - Variable in class com.mckoi.database.interpret.Delete
-
The TableName object of the table being created.
- tname - Variable in class com.mckoi.database.interpret.Insert
-
The TableName we are inserting into.
- tname - Variable in class com.mckoi.database.interpret.UpdateTable
-
The TableName object set during 'prepare'.
- TNullType - Class in com.mckoi.database
-
An implementation of TType that represents a NULL type.
- TNullType() - Constructor for class com.mckoi.database.TNullType
-
Constructs the type.
- TNumericType - Class in com.mckoi.database
-
An implementation of TType for a number.
- TNumericType(int, int, int) - Constructor for class com.mckoi.database.TNumericType
-
Constructs a type with the given sql_type value, the size, and the scale of the number.
- TO - Static variable in interface com.mckoi.database.sql.SQLConstants
- toArrayParamObject(Expression[]) - Static method in class com.mckoi.database.sql.Util
-
Converts an expression array to an array type that can be added to an expression.
- toBigNumber() - Method in class com.mckoi.database.TObject
-
Returns the BigNumber of this object if this object is a numeric type.
- toBigNumber(String) - Static method in class com.mckoi.database.global.CastHelper
-
Converts the given string to a BigNumber.
- TObject - Class in com.mckoi.database
-
A TObject is a strongly typed object in a database engine.
- TObject(TType, Object) - Constructor for class com.mckoi.database.TObject
-
Constructs the TObject as the given type.
- toBoolean() - Method in class com.mckoi.database.TObject
-
Returns the Boolean of this object if this object is a boolean type.
- toBooleanValue(Expression) - Static method in class com.mckoi.database.DatabaseConnection
-
Evaluates the expression to a boolean value (true or false).
- toByteArray() - Method in class com.mckoi.util.BigNumber
-
Returns this number as a byte array (unscaled).
- toClass(int) - Static method in class com.mckoi.database.global.TypeUtil
-
Converts from a db type to a Class object.
- toColumns(SimpleTableQuery, IntegerVector) - Static method in class com.mckoi.database.Transaction
-
Convenience, given a SimpleTableQuery object this will return a list of column names in sequence that represent the columns in a group constraint.
- toDate(long) - Static method in class com.mckoi.database.global.CastHelper
-
Returns the given long value as a date object.
- toDate(String) - Static method in class com.mckoi.database.global.CastHelper
-
Parses a String as an SQL date.
- toDBType(Class) - Static method in class com.mckoi.database.global.TypeUtil
-
Converts from a Class object to a type as specified in Types.
- toEncodedString() - Method in class com.mckoi.database.Privileges
-
Converts this privilege to an encoded string.
- toInt() - Method in class com.mckoi.database.Privileges
-
Returns this Privileges object as an encoded int bit array.
- toIntArray() - Method in class com.mckoi.util.IntegerVector
-
Converts the vector into an int[] array.
- toJavaObject(Object) - Static method in class com.mckoi.database.global.CastHelper
-
Converts the given object to an SQL JAVA_OBJECT type by serializing the object.
- token - Variable in class com.mckoi.database.sql.SQL
- Token - Class in com.mckoi.database.sql
-
Describes the input token stream.
- Token() - Constructor for class com.mckoi.database.sql.Token
- token_source - Variable in class com.mckoi.database.sql.SQL
- tokenBegin - Variable in class com.mckoi.database.sql.SimpleCharStream
- tokenImage - Variable in exception com.mckoi.database.sql.ParseException
-
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
- tokenImage - Static variable in interface com.mckoi.database.sql.SQLConstants
- TokenMgrError - Error in com.mckoi.database.sql
- TokenMgrError() - Constructor for error com.mckoi.database.sql.TokenMgrError
- TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error com.mckoi.database.sql.TokenMgrError
- TokenMgrError(String, int) - Constructor for error com.mckoi.database.sql.TokenMgrError
- toMap() - Method in class com.mckoi.database.Table
-
Assuming this table is a 2 column key/value table, and the first column is a string, this will convert it into a map.
- ToNumberFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.ToNumberFunction
- top_journal_file - Variable in class com.mckoi.store.JournalledSystem
-
The current top journal file.
- top_journal_lock - Variable in class com.mckoi.store.JournalledSystem
-
Mutex when accessing the top journal file.
- toParamObject(Token, boolean) - Static method in class com.mckoi.database.sql.Util
-
Converts a Token which is either a STRING_LITERAL, NUMBER_LITERAL or IDENTIFIER into a Java Object.
- topFromEachGroup() - Method in class com.mckoi.database.FunctionTable
-
Returns a list of rows that represent one row from each distinct group in this table.
- topInt() - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Overwritten from IntArrayListBlock, returns the last entry of the block.
- topInt() - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Overwritten from IntArrayListBlock, returns the last entry of the block.
- topInt() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
The top int in the list.
- topInt() - Method in class com.mckoi.util.IntegerListBlockInterface
-
The top int in the list.
- topJournal() - Method in class com.mckoi.store.JournalledSystem
-
Returns the current top journal file.
- toSelectableRangeArray() - Method in class com.mckoi.database.SelectableRangeSet
-
Returns the range as an array of SelectableRange or an empty array if there is no range.
- toString() - Method in class com.mckoi.database.AbstractDataTable
-
Returns a string that represents this table.
- toString() - Method in class com.mckoi.database.AbstractFunction
- toString() - Method in class com.mckoi.database.BlobStore.ClobRefImpl
- toString() - Method in class com.mckoi.database.control.TCPJDBCServer
-
Returns a string that contains some information about the server that is running.
- toString() - Method in class com.mckoi.database.CorrelatedVariable
- toString() - Method in class com.mckoi.database.Expression
-
Returns a string representation of this object for diagnostic purposes.
- toString() - Method in class com.mckoi.database.FunctionDef
-
Human understandable string, used for the column title.
- toString() - Method in class com.mckoi.database.global.ByteLongObject
- toString() - Method in class com.mckoi.database.global.NullObject
-
Deprecated.
- toString() - Method in interface com.mckoi.database.global.StringAccessor
-
Returns this string as a java.lang.String object.
- toString() - Method in class com.mckoi.database.global.StringObject
-
Returns this object as a java.lang.String object (easy!)
- toString() - Method in class com.mckoi.database.interpret.ByColumn
- toString() - Method in class com.mckoi.database.interpret.SearchExpression
- toString() - Method in class com.mckoi.database.interpret.Select
-
Outputs information for debugging.
- toString() - Method in class com.mckoi.database.interpret.SelectColumn
- toString() - Method in class com.mckoi.database.jdbc.MPreparedStatement
-
For diagnostics.
- toString() - Method in class com.mckoi.database.jdbc.SQLQuery
-
Outputs the query as text (for debugging)
- toString() - Method in class com.mckoi.database.jdbcserver.TCPServer
-
Returns human understandable information about the server.
- toString() - Method in class com.mckoi.database.Lock
- toString() - Method in class com.mckoi.database.LockHandle
- toString() - Method in class com.mckoi.database.LockingQueue
- toString() - Method in class com.mckoi.database.MasterTableJournal
-
Debugging.
- toString() - Method in class com.mckoi.database.OpenTransactionList
- toString() - Method in class com.mckoi.database.Operator
- toString() - Method in class com.mckoi.database.Privileges
- toString() - Method in class com.mckoi.database.ProcedureName
-
Returns this procedure name as a string.
- toString() - Method in class com.mckoi.database.RowData
-
Returns a string representation of this row.
- toString() - Method in class com.mckoi.database.SchemaDef
- toString() - Method in class com.mckoi.database.SelectableRange
-
Outputs this range as a string.
- toString() - Method in class com.mckoi.database.SelectableRangeSet
-
Outputs this range as a string, for diagnostic and testing purposes.
- toString() - Method in class com.mckoi.database.SelectableScheme
-
Diagnostic information.
- toString() - Method in class com.mckoi.database.sql.Token
-
Returns the image.
- toString() - Method in class com.mckoi.database.StatementTree
-
For diagnostic.
- toString() - Method in class com.mckoi.database.SubsetColumnTable
-
Returns a string that represents this table.
- toString() - Method in class com.mckoi.database.Table
-
Returns a string that represents this table.
- toString() - Method in class com.mckoi.database.TableName
-
To string.
- toString() - Method in class com.mckoi.database.TObject
- toString() - Method in class com.mckoi.database.V1MasterTableDataSource
-
For diagnostic.
- toString() - Method in class com.mckoi.database.V2MasterTableDataSource
-
For diagnostic.
- toString() - Method in class com.mckoi.database.Variable
-
To string.
- toString() - Method in class com.mckoi.jfccontrols.Query
-
For debugging.
- toString() - Method in class com.mckoi.store.AbstractStore.StoreArea
- toString() - Method in class com.mckoi.store.AbstractStore.StoreMutableArea
- toString() - Method in class com.mckoi.store.HeapStore.HeapArea
- toString() - Method in class com.mckoi.store.JournalledFileStore
- toString() - Method in class com.mckoi.store.JournalledSystem.AbstractResource
- toString() - Method in class com.mckoi.store.JournalledSystem.JournalFile
- toString() - Method in class com.mckoi.util.AbstractBlockIntegerList
- toString() - Method in class com.mckoi.util.BigNumber
-
Returns this big number as a string.
- toString() - Method in class com.mckoi.util.BlockIntegerList.IntArrayListBlock
-
Converts the block into a String.
- toString() - Method in class com.mckoi.util.IntegerVector
-
Converts the vector into a String.
- toString() - Method in class com.mckoi.util.Stats
-
Returns a String that can be use to print out the values of all the stats.
- toString() - Method in class com.mckoi.util.StringListBucket
- toString() - Method in class com.mckoi.util.TimeFrame
-
For Debugging.
- toStringBuffer() - Method in class com.mckoi.util.StringListBucket
-
Returns the bucket as a StringBuffer.
- toStringValue() - Method in class com.mckoi.database.TObject
-
Returns the String of this object if this object is a string type.
- total_allocated_space - Variable in class com.mckoi.store.AbstractStore
-
The total amount of allocated space within this store since the store was openned.
- total_gets - Variable in class com.mckoi.util.Cache
-
Some statistics about the hashing algorithm.
- total_hits_key - Variable in class com.mckoi.database.MasterTableDataSource
- total_row_count - Variable in class com.mckoi.tools.JDBCQueryTool
-
Total number of rows in the result.
- totalAllocatedSinceStart() - Method in class com.mckoi.store.AbstractStore
-
Returns the total allocated space since the file was openned.
- totalSize() - Method in class com.mckoi.database.FixedSizeDataStore
-
Returns the size of the data store file.
- totalStoreSize() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns the size of the data file that keeps all the data in this store.
- toTechString() - Method in class com.mckoi.database.Variable
-
To a differently formatted string.
- toTime(String) - Static method in class com.mckoi.database.global.CastHelper
-
Parses a String as an SQL time.
- toTimeStamp(String) - Static method in class com.mckoi.database.global.CastHelper
-
Parses a String as an SQL timestamp.
- touched_tables - Variable in class com.mckoi.database.Transaction
-
All tables touched by this transaction.
- touched_tables - Variable in class com.mckoi.database.TransactionJournal
-
The list of table's that have been touched by this transaction.
- TQueryPlanType - Class in com.mckoi.database
-
An implementation of TType for a query plan value.
- TQueryPlanType() - Constructor for class com.mckoi.database.TQueryPlanType
-
Constructs the type.
- TRACKING - Static variable in class com.mckoi.database.OpenTransactionList
-
True to enable transaction tracking.
- TRAILING - Static variable in interface com.mckoi.database.sql.SQLConstants
- tran_read_only - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
True if the transaction is read-only.
- transaction - Variable in class com.mckoi.database.AbstractInternalTableInfo2
-
The transaction we are connected to.
- transaction - Variable in class com.mckoi.database.DatabaseConnection
-
The current Transaction that this connection is operating within.
- transaction - Variable in class com.mckoi.database.GTTableColumnsDataSource
-
The transaction that is the view of this information.
- transaction - Variable in class com.mckoi.database.GTTableInfoDataSource
-
The transaction that is the view of this information.
- transaction - Variable in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
-
The Transaction object that this MutableTableDataSource was generated from.
- transaction - Variable in class com.mckoi.database.SequenceManager.SequenceInternalTableInfo
- transaction - Variable in class com.mckoi.database.SystemQueryContext
-
The Transaction this is a part of.
- transaction - Variable in class com.mckoi.database.TableCommitModificationEvent
-
A SimpleTransaction that can be used to query tables in the database - the view of which will be the view when the transaction is committed.
- Transaction - Class in com.mckoi.database
-
An open transaction that manages all data access to the TableDataConglomerate.
- Transaction(TableDataConglomerate, long, ArrayList, ArrayList) - Constructor for class com.mckoi.database.Transaction
-
Constructs the transaction.
- transaction_active - Variable in class com.mckoi.database.TableBackedCache
-
Set to true when the backing DatabaseConnection has a transaction open.
- transaction_disabled_flag - Variable in class com.mckoi.database.DatabaseConnection.DCProcedureConnection
-
The 'close_transaction_disabled' flag when this connection was created.
- transaction_error_on_dirty_select - Variable in class com.mckoi.database.Transaction
-
True if an error should be generated on a dirty select.
- transaction_error_on_dirty_select - Variable in class com.mckoi.database.TransactionSystem
-
Transaction option, if this is true then a transaction error is generated during commit if a transaction selects data from a table that has committed changes to it during commit time.
- transaction_isolation - Variable in class com.mckoi.database.DatabaseConnection
-
The current transaction isolation level this connect is operating under.
- transaction_mod_list - Variable in class com.mckoi.database.MultiVersionTableIndices
-
A list of MasterTableJournal objects that represent the changes that have occurred to this master index after various transactions have been committed.
- Transaction.CheckExpression - Class in com.mckoi.database
-
Represents a constraint expression to check.
- Transaction.ColumnGroup - Class in com.mckoi.database
-
A group of columns as used by the constraint system.
- Transaction.ColumnGroupReference - Class in com.mckoi.database
-
Represents a reference from a group of columns in one table to a group of columns in another table.
- Transaction.TransactionInternalTables - Class in com.mckoi.database
-
A static internal table info for internal tables to the transaction.
- transactionChangeString() - Method in class com.mckoi.database.MasterTableDataSource
- transactionChangeString() - Method in class com.mckoi.database.MultiVersionTableIndices
-
Returns a string describing the transactions pending on this table.
- transactionErrorOnDirtySelect() - Method in class com.mckoi.database.Transaction
-
Returns true if the conglomerate commit procedure should check for dirty selects and produce a transaction error.
- transactionErrorOnDirtySelect() - Method in class com.mckoi.database.TransactionSystem
-
Returns true if during commit the engine should look for any selects on a modified table and fail if they are detected.
- TransactionException - Exception in com.mckoi.database
-
Thrown when a transaction error happens.
- TransactionException(int, String) - Constructor for exception com.mckoi.database.TransactionException
- transactionFinished() - Method in class com.mckoi.database.TableBackedCache
-
Called from DatabaseConnection to notify that object that a transaction has closed.
- TransactionInternalTables() - Constructor for class com.mckoi.database.Transaction.TransactionInternalTables
-
Constructor.
- TRANSACTIONISOLATIONLEVEL - Static variable in interface com.mckoi.database.sql.SQLConstants
- TransactionJournal - Class in com.mckoi.database
-
The list of all primitive operations to the database that a transaction performed.
- TransactionJournal() - Constructor for class com.mckoi.database.TransactionJournal
-
Constructs a blank journal.
- TransactionModificationListener - Interface in com.mckoi.database
-
A listener that is notified of table modification events made by a transaction, both immediately inside a transaction and when a transaction commits.
- transactionStarted() - Method in class com.mckoi.database.TableBackedCache
-
Called from DatabaseConnection to notify this object that a new transaction has been started.
- TransactionSystem - Class in com.mckoi.database
-
A class that provides information and global functions for the transaction layer in the engine.
- TransactionSystem() - Constructor for class com.mckoi.database.TransactionSystem
-
Constructor.
- TransactionSystem.DSFunctionLookup - Class in com.mckoi.database
-
A FunctionLookup implementation that will look up a function from a list of FunctionFactory objects provided with.
- translate(Object) - Static method in class com.mckoi.database.global.ObjectTranslator
-
Translates the given object to a type the database can process.
- translateObjectType(Object) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Translates the given object to a type the object can process.
- TRIGGER - Static variable in interface com.mckoi.database.sql.SQLConstants
- trigger_event - Variable in class com.mckoi.database.TriggerManager.TriggerAction
- trigger_event_buffer - Variable in class com.mckoi.database.DatabaseConnection
-
A buffer of triggers.
- trigger_event_list - Variable in class com.mckoi.database.DatabaseConnection
-
A list of triggers that are fired by actions taken on tables in this transaction.
- trigger_list - Variable in class com.mckoi.database.jdbc.MConnection
-
The list of trigger listeners registered with the connection.
- trigger_manager - Variable in class com.mckoi.database.Database
-
The database wide TriggerManager object that dispatches trigger events to the DatabaseConnection objects that are listening for the events.
- trigger_messages_queue - Variable in class com.mckoi.database.jdbc.MConnection.TriggerDispatchThread
- trigger_modified - Variable in class com.mckoi.database.ConnectionTriggerManager
-
True if the trigger table was modified during the last transaction.
- trigger_name - Variable in class com.mckoi.database.interpret.DropTrigger
-
The name of this trigger.
- trigger_name - Variable in class com.mckoi.database.TriggerManager.TriggerAction
- trigger_source - Variable in class com.mckoi.database.DatabaseConnection.OldNewTableState
-
The name of the table that is the trigger source.
- trigger_source - Variable in class com.mckoi.database.TriggerManager.TriggerAction
- trigger_thread - Variable in class com.mckoi.database.jdbc.MConnection
-
A Thread that handles all dispatching of trigger events to the JDBC client.
- TriggerAction(DatabaseConnection, String, int, String, TriggerListener) - Constructor for class com.mckoi.database.TriggerManager.TriggerAction
-
Constructor.
- TriggerDispatchThread() - Constructor for class com.mckoi.database.jdbc.MConnection.TriggerDispatchThread
- TriggeredOldNewDataSource(TransactionSystem, DataTableDef) - Constructor for class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
-
Constructor.
- TriggerEvent - Class in com.mckoi.database
-
A trigger event represents a high level action that occured in the database.
- TriggerEvent(int, String) - Constructor for class com.mckoi.database.TriggerEvent
- TriggerEvent(int, String, int) - Constructor for class com.mckoi.database.TriggerEvent
-
Constructs the trigger event.
- triggerExists(String, String) - Method in class com.mckoi.database.ConnectionTriggerManager
-
Returns true if the trigger exists, false otherwise.
- triggerFired(String) - Method in interface com.mckoi.database.jdbc.TriggerListener
-
Notifies this listener that the trigger with the name has been fired.
- TriggerInfo() - Constructor for class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- TriggerInternalTableInfo(Transaction) - Constructor for class com.mckoi.database.ConnectionTriggerManager.TriggerInternalTableInfo
- TriggerListener - Interface in com.mckoi.database.jdbc
-
A listener that is notified when the trigger being listened to is fired.
- TriggerListener - Interface in com.mckoi.database
-
A listener that can listen for high layer trigger events.
- TriggerManager - Class in com.mckoi.database
-
An object that manages high level trigger events within a Database context.
- TriggerManager(TransactionSystem) - Constructor for class com.mckoi.database.TriggerManager
-
Constructor.
- TriggerManager.TriggerAction - Class in com.mckoi.database
-
Encapsulates the information of a trigger listener for a specific event for a user.
- TriggerName() - Method in class com.mckoi.database.sql.SQL
- triggerNotify(String, int, String, int) - Method in interface com.mckoi.database.DatabaseConnection.CallBack
-
Notifies the callee that a trigger event was fired that this user is listening for.
- triggers_active - Variable in class com.mckoi.database.ConnectionTriggerManager
-
The list of triggers currently in view.
- TriggerType() - Method in class com.mckoi.database.sql.SQL
- TriggerTypes(ArrayList) - Method in class com.mckoi.database.sql.SQL
- TRIM - Static variable in interface com.mckoi.database.sql.SQLConstants
- true_file_length - Variable in class com.mckoi.store.ScatteringStoreDataAccessor
-
The current actual physical size of the store data on disk.
- TRUE_VAL - Static variable in class com.mckoi.database.SequenceManager
-
A static TObject that represents boolean true.
- truncate(long) - Method in class com.mckoi.database.jdbc.MBlob
- truncate(long) - Method in class com.mckoi.database.jdbc.MClob
- truncate(long) - Method in class com.mckoi.database.jdbc.MStreamableBlob
- truncate(long) - Method in class com.mckoi.database.jdbc.MStreamableClob
- tryResolveCase(TableName) - Method in class com.mckoi.database.DatabaseConnection
-
Attempts to resolve the given table name to its correct case assuming the table name represents a case insensitive version of the name.
- tryResolveCase(TableName) - Method in class com.mckoi.database.SimpleTransaction
-
Attempts to resolve the given table name to its correct case assuming the table name represents a case insensitive version of the name.
- ts_format_sql - Static variable in class com.mckoi.database.global.CastHelper
- TS_merge_count - Variable in class com.mckoi.database.MultiVersionTableIndices
- TS_merge_size - Variable in class com.mckoi.database.MultiVersionTableIndices
- TStringType - Class in com.mckoi.database
-
An implementation of TType for a String.
- TStringType(int, int, String) - Constructor for class com.mckoi.database.TStringType
-
Constructor without strength and decomposition that sets to default levels.
- TStringType(int, int, String, int, int) - Constructor for class com.mckoi.database.TStringType
-
Constructs a type with the given sql_type value, the maximum size, and the locale of the string.
- TStringType(int, int, Locale, int, int) - Constructor for class com.mckoi.database.TStringType
-
Constructs a type with the given sql_type value, the maximum size, and the locale of the string.
- TType - Class in com.mckoi.database
-
A TType object represents a type in a database engine.
- TType(int) - Constructor for class com.mckoi.database.TType
-
Constructs the type object.
- type - Variable in class com.mckoi.database.BlobStore.AbstractRef
-
The type of large object.
- type - Variable in class com.mckoi.database.ConnectionTriggerManager.TriggerInfo
- type - Variable in class com.mckoi.database.control.DefaultDBConfig.ConfigProperty
- type - Variable in class com.mckoi.database.DataCellSerialization
-
The type of object.
- type - Variable in class com.mckoi.database.DataTableColumnDef
-
The TType object for this column.
- type - Variable in class com.mckoi.database.FunctionFactory.FF_FunctionInfo
- type - Variable in class com.mckoi.database.global.ColumnDescription
-
The type of the field, from the Types object.
- type - Variable in class com.mckoi.database.global.StreamableObject
-
The type of the object.
- type - Variable in class com.mckoi.database.interpret.ColumnDef
- type - Variable in class com.mckoi.database.interpret.ConstraintDef
- type - Variable in class com.mckoi.database.interpret.Function
-
The type of command we are running through this Function object.
- type - Variable in class com.mckoi.database.interpret.Schema
-
The type (either 'create' or 'drop').
- type - Variable in class com.mckoi.database.interpret.Sequence
- type - Variable in class com.mckoi.database.interpret.Set
-
The type of set this is.
- type - Variable in class com.mckoi.database.interpret.ViewManager
-
The type of command we are running through this ViewManager.
- type - Variable in class com.mckoi.database.jdbc.AbstractStreamableObject
-
The type of encoding of the stream.
- type - Variable in class com.mckoi.database.JoiningSet.JoinPart
-
The type of join.
- type - Variable in class com.mckoi.database.Lock
-
This stores the type of lock.
- type - Variable in class com.mckoi.database.SchemaDef
-
The type of this schema (eg.
- type - Variable in class com.mckoi.database.SequenceManager.SequenceGenerator
-
The type of this sequence key.
- type - Variable in class com.mckoi.database.TObject
-
The type of this object.
- type - Variable in exception com.mckoi.database.TransactionException
-
The type of error.
- type - Variable in class com.mckoi.database.TriggerEvent
-
The type of this event.
- TYPE_NULLABLE - Static variable in class com.mckoi.database.GTSQLTypeInfoDataSource
-
Constant for type_nullable types.
- typeEquals(RootTable) - Method in class com.mckoi.database.AbstractDataTable
-
This function is used to check that two tables are identical.
- typeEquals(RootTable) - Method in class com.mckoi.database.CompositeTable
- typeEquals(RootTable) - Method in class com.mckoi.database.OuterTable
-
This function is used to check that two tables are identical.
- typeEquals(RootTable) - Method in class com.mckoi.database.ReferenceTable
- typeEquals(RootTable) - Method in interface com.mckoi.database.RootTable
-
This is function is used to check that two root tables are identical.
- typeEquals(RootTable) - Method in class com.mckoi.database.SubsetColumnTable
-
This function is used to check that two tables are identical.
- Types - Interface in com.mckoi.database.global
-
The possible types used in the database.
- TypeUtil - Class in com.mckoi.database.global
-
Utility for converting to and from 'Types' objects.
- TypeUtil() - Constructor for class com.mckoi.database.global.TypeUtil
U
- unblock() - Method in class com.mckoi.jfccontrols.SwingBlockUtil
-
Unblocks any call to the 'block' method.
- UNCOMMITTED - Static variable in interface com.mckoi.database.RawDiagnosticTable
-
Statics that represent the various states of a record.
- UnicodeToBinaryStream - Class in com.mckoi.database.jdbc
-
An object that wraps around a Reader and translates the unicode stream into a stream of bytes that the database is able to transfer to the database.
- UnicodeToBinaryStream(Reader) - Constructor for class com.mckoi.database.jdbc.UnicodeToBinaryStream
-
Constructs the stream.
- union(Operator, TObject) - Method in class com.mckoi.database.SelectableRangeSet
-
Unions this range with the given Operator and value constraint.
- union(RawTableInformation) - Method in class com.mckoi.database.RawTableInformation
-
Finds the union of this information with the given information.
- union(SelectableRangeSet) - Method in class com.mckoi.database.SelectableRangeSet
-
Unions the current range set with the given range set.
- union(Table) - Method in class com.mckoi.database.Table
-
Returns a new Table that is the union of the this table and the given table.
- UNION - Static variable in class com.mckoi.database.CompositeTable
-
The composite function for finding the union of the tables.
- UNION - Static variable in interface com.mckoi.database.sql.SQLConstants
- unique - Variable in class com.mckoi.database.DataIndexDef
-
True if this index may only contain unique values.
- unique - Variable in class com.mckoi.database.global.ColumnDescription
-
If true, the field may only contain unique values.
- unique - Variable in class com.mckoi.database.interpret.ColumnDef
- UNIQUE - Static variable in class com.mckoi.database.interpret.ConstraintDef
-
A UNIQUE constraint.
- UNIQUE - Static variable in interface com.mckoi.database.sql.SQLConstants
- UNIQUE_COLS_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- unique_group - Variable in class com.mckoi.database.global.ColumnDescription
-
This represents the 'unique_group' that this column is in.
- unique_id - Variable in class com.mckoi.database.FunctionTable
-
A unique id given to this FunctionTable when it is created.
- unique_id - Variable in class com.mckoi.database.IndexStore
-
Unique id field that contains a unique number that can be incremented atomically.
- unique_id - Variable in class com.mckoi.database.jdbc.MResultSet
-
A unique int that refers to this result set.
- unique_id_key - Static variable in class com.mckoi.database.jdbc.MResultSet
-
The current unique id key.
- unique_id_key - Variable in class com.mckoi.store.HeapStore
-
A unique id key incremented for each new area created.
- unique_id_seq - Variable in class com.mckoi.store.LoggingBufferManager
-
A unique id key counter for all stores using this buffer manager.
- UNIQUE_INFO_TABLE - Static variable in class com.mckoi.database.TableDataConglomerate
- unique_key - Variable in class com.mckoi.database.interpret.FromTableDef
-
The unique key name given to this table definition.
- unique_key - Variable in class com.mckoi.database.interpret.FromTableSubQuerySource
-
A unique name given to this source that is used to reference it in a TableSet.
- UNIQUE_KEY_SEQ - Static variable in class com.mckoi.database.FunctionTable
-
The key used to make distinct unique ids for FunctionTables.
- unique_name - Variable in class com.mckoi.database.interpret.FromTableDirectSource
-
The unique name given to this source.
- unique_names - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
-
The list of unique key names of the tables in this plan.
- unique_result_id - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
This is incremented every time a result set is added to the map.
- UNIQUE_VIOLATION - Static variable in exception com.mckoi.database.DatabaseConstraintViolationException
-
A Unique constraint violation error code.
- uniqueInsertSort(int) - Method in class com.mckoi.util.AbstractBlockIntegerList
-
Inserts plain 'int' value into the sorted position in the list only if it isn't already in the list.
- uniqueInsertSort(int) - Method in interface com.mckoi.util.IntegerListInterface
-
Inserts plain 'int' value into the sorted position in the list only if it isn't already in the list.
- UniqueKeyFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.UniqueKeyFunction
- UNKNOWN_SCHEMA_NAME - Static variable in class com.mckoi.database.TableName
-
The constant 'schema_name' that defines a schema that is unknown.
- UNKNOWN_TABLE_NAME - Static variable in class com.mckoi.database.Variable
-
Static that represents an unknown table name.
- unlock() - Method in class com.mckoi.database.FixedSizeDataStore
-
Unlocks the store.
- unlock() - Method in class com.mckoi.database.VariableSizeDataStore
-
Unlocks the store so that deleted elements can be reclaimed again.
- unlock(String) - Method in interface com.mckoi.database.StoreSystem
-
Unlocks the exclusive access to the persistent store objects.
- unlock(String) - Method in class com.mckoi.database.V1FileStoreSystem
- unlock(String) - Method in class com.mckoi.database.V1HeapStoreSystem
- UNLOCK - Static variable in interface com.mckoi.database.sql.SQLConstants
- unlockAll() - Method in class com.mckoi.database.LockHandle
-
Unlocks all the locks in this handle.
- unlocked - Variable in class com.mckoi.database.LockHandle
-
Set when the 'unlockAll' method is called for the first time.
- unlockForWrite() - Method in class com.mckoi.store.HeapStore
- unlockForWrite() - Method in class com.mckoi.store.JournalledFileStore
- unlockForWrite() - Method in class com.mckoi.store.LoggingBufferManager
-
Releases a write lock on the buffer.
- unlockForWrite() - Method in interface com.mckoi.store.Store
-
See the 'lockForWrite' method description.
- unlockRoot(int) - Method in class com.mckoi.database.CompositeTable
- unlockRoot(int) - Method in class com.mckoi.database.DataTable
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockRoot(int) - Method in class com.mckoi.database.DataTableFilter
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockRoot(int) - Method in class com.mckoi.database.FilterTable
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockRoot(int) - Method in class com.mckoi.database.FunctionTable
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockRoot(int) - Method in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.ResultSetInfo
-
Unlocks the root of the result set.
- unlockRoot(int) - Method in class com.mckoi.database.JoinedTable
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockRoot(int) - Method in class com.mckoi.database.Table
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockRoot(int) - Method in class com.mckoi.database.TableAccessState
-
Unlocks the root rows of the table.
- unlockRoot(int) - Method in class com.mckoi.database.TemporaryTable
-
Unlocks the root tables so that the underlying rows may once again be used if they are not locked and have been removed.
- unlockTables(LockHandle) - Method in class com.mckoi.database.LockingMechanism
-
Unlocks the tables that were previously locked by the 'lockTables' method.
- unsupported() - Static method in exception com.mckoi.database.jdbc.MSQLException
-
Returns an SQLException that is used for all unsupported features of the JDBC driver.
- unsupported16() - Static method in exception com.mckoi.database.jdbc.MSQLException
-
Generates the feature not supported exception.
- unwrap(Class) - Method in class com.mckoi.database.jdbc.MConnection
- unwrap(Class) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- unwrap(Class) - Method in class com.mckoi.database.jdbc.MResultSet
- unwrap(Class) - Method in class com.mckoi.database.jdbc.MResultSetMetaData
- unwrap(Class) - Method in class com.mckoi.database.jdbc.MStatement
- update(DataTableDef) - Method in interface com.mckoi.database.DataTableFile
-
Updates a file of the given table.
- update(QueryContext, Table, Assignment[], int) - Method in class com.mckoi.database.DataTable
-
Updates the table by applying the assignment operations over each row that is found in the input 'table' set.
- Update() - Method in class com.mckoi.database.sql.SQL
- UPDATE - Static variable in class com.mckoi.database.Privileges
-
The priv to UPDATE a database object.
- UPDATE - Static variable in interface com.mckoi.database.sql.SQLConstants
- UPDATE - Static variable in class com.mckoi.database.TableModificationEvent
-
Event type for update action.
- UPDATE - Static variable in class com.mckoi.database.TriggerEvent
- update_rule - Variable in class com.mckoi.database.interpret.ConstraintDef
- update_rule - Variable in class com.mckoi.database.Transaction.ColumnGroupReference
-
The update rule.
- update_table - Variable in class com.mckoi.database.interpret.Delete
-
The DataTable we are deleting from .
- update_table - Variable in class com.mckoi.database.interpret.UpdateTable
-
The DataTable we are updating.
- updateArray(int, Array) - Method in class com.mckoi.database.jdbc.MResultSet
- updateArray(String, Array) - Method in class com.mckoi.database.jdbc.MResultSet
- updateAsciiStream(int, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- updateAsciiStream(int, InputStream, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateAsciiStream(int, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateAsciiStream(String, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- updateAsciiStream(String, InputStream, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateAsciiStream(String, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBigDecimal(int, BigDecimal) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBigDecimal(String, BigDecimal) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBinaryStream(int, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBinaryStream(int, InputStream, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBinaryStream(int, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBinaryStream(String, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBinaryStream(String, InputStream, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBinaryStream(String, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBlob(int, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBlob(int, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBlob(int, Blob) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBlob(String, InputStream) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBlob(String, InputStream, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBlob(String, Blob) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBoolean(int, boolean) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBoolean(String, boolean) - Method in class com.mckoi.database.jdbc.MResultSet
- updateByte(int, byte) - Method in class com.mckoi.database.jdbc.MResultSet
- updateByte(String, byte) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBytes(int, byte[]) - Method in class com.mckoi.database.jdbc.MResultSet
- updateBytes(String, byte[]) - Method in class com.mckoi.database.jdbc.MResultSet
- updateCharacterStream(int, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateCharacterStream(int, Reader, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateCharacterStream(int, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateCharacterStream(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateCharacterStream(String, Reader, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateCharacterStream(String, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateClob(int, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateClob(int, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateClob(int, Clob) - Method in class com.mckoi.database.jdbc.MResultSet
- updateClob(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateClob(String, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateClob(String, Clob) - Method in class com.mckoi.database.jdbc.MResultSet
- updateDatabaseVars(QueryContext, DataTable, String, String) - Static method in class com.mckoi.database.Database
-
Given the sUSRDatabaseVars table, this will update the given key with the given value in the table in the current transaction.
- updateDate(int, Date) - Method in class com.mckoi.database.jdbc.MResultSet
- updateDate(String, Date) - Method in class com.mckoi.database.jdbc.MResultSet
- updateDouble(int, double) - Method in class com.mckoi.database.jdbc.MResultSet
- updateDouble(String, double) - Method in class com.mckoi.database.jdbc.MResultSet
- updateFile() - Method in interface com.mckoi.database.DataTableFile
-
Flushes all information that may be cached in memory to disk.
- updateFloat(int, float) - Method in class com.mckoi.database.jdbc.MResultSet
- updateFloat(String, float) - Method in class com.mckoi.database.jdbc.MResultSet
- updateGeneratorState(SequenceManager.SequenceGenerator) - Method in class com.mckoi.database.SequenceManager
-
Updates the state of the sequence key in the sequence tables in the database.
- updateInt(int, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateInt(String, int) - Method in class com.mckoi.database.jdbc.MResultSet
- UpdateLineColumn(char) - Method in class com.mckoi.database.sql.SimpleCharStream
- updateListHeaderArea() - Method in class com.mckoi.database.FixedRecordList
-
Updates the list header area from the information store within the state of this object.
- updateLong(int, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateLong(String, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNCharacterStream(int, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNCharacterStream(int, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNCharacterStream(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNCharacterStream(String, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNClob(int, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNClob(int, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNClob(int, NClob) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNClob(String, Reader) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNClob(String, Reader, long) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNClob(String, NClob) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNString(int, String) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNString(String, String) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNull(int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateNull(String) - Method in class com.mckoi.database.jdbc.MResultSet
- updateObject(int, Object) - Method in class com.mckoi.database.jdbc.MResultSet
- updateObject(int, Object, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updateObject(String, Object) - Method in class com.mckoi.database.jdbc.MResultSet
- updateObject(String, Object, int) - Method in class com.mckoi.database.jdbc.MResultSet
- updatePlan(QueryPlanNode) - Method in class com.mckoi.database.interpret.Planner.PlanTableSource
-
Updates the plan.
- updateRange(QueryContext, SelectableRangeSet, DataTableColumnDef, Expression) - Method in class com.mckoi.database.QueryPlan.RangeSelectNode
-
Updates a range with the given expression.
- updateRef(int, Ref) - Method in class com.mckoi.database.jdbc.MResultSet
- updateRef(String, Ref) - Method in class com.mckoi.database.jdbc.MResultSet
- updateResultPart(int, int) - Method in class com.mckoi.database.jdbc.MResultSet
-
Asks the server for more information about this result set to put into the 'result_block'.
- updateResultSet(ResultSet) - Method in class com.mckoi.jfccontrols.ResultSetTableModel
-
Updates the result set in this model with the given ResultSet object.
- updateRow() - Method in class com.mckoi.database.jdbc.MResultSet
- updateRow(int, RowData) - Method in class com.mckoi.database.DatabaseConnection.TriggeredOldNewDataSource
- updateRow(int, RowData) - Method in class com.mckoi.database.DataTable
-
Updates the given row with the given data in this table.
- updateRow(int, RowData) - Method in class com.mckoi.database.GTDataSource
- updateRow(int, RowData) - Method in class com.mckoi.database.MasterTableDataSource.MMutableTableDataSource
- updateRow(int, RowData) - Method in interface com.mckoi.database.MutableTableDataSource
-
Updates a row in the source.
- updateRowId(int, RowId) - Method in class com.mckoi.database.jdbc.MResultSet
- updateRowId(String, RowId) - Method in class com.mckoi.database.jdbc.MResultSet
- updatesAreDetected(int) - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- updateShort(int, short) - Method in class com.mckoi.database.jdbc.MResultSet
- updateShort(String, short) - Method in class com.mckoi.database.jdbc.MResultSet
- updateSQLXML(int, SQLXML) - Method in class com.mckoi.database.jdbc.MResultSet
- updateSQLXML(String, SQLXML) - Method in class com.mckoi.database.jdbc.MResultSet
- updateStatus() - Method in class com.mckoi.tools.JDBCQueryTool
-
Updates the status bar.
- updateString(int, String) - Method in class com.mckoi.database.jdbc.MResultSet
- updateString(String, String) - Method in class com.mckoi.database.jdbc.MResultSet
- updateSystemTableSchema() - Method in class com.mckoi.database.TableDataConglomerate
-
Create the system tables that must be present in a conglomerates.
- updateTable(DataTableDef) - Method in class com.mckoi.database.DatabaseConnection
-
Updates a given table within the context of the current connection transaction.
- updateTable(DataTableDef, int, int) - Method in class com.mckoi.database.DatabaseConnection
-
Updates a given table within the context of the current connection transaction.
- UpdateTable - Class in com.mckoi.database.interpret
-
The instance class that stores all the information about an update statement for processing.
- UpdateTable() - Constructor for class com.mckoi.database.interpret.UpdateTable
- updateTime(int, Time) - Method in class com.mckoi.database.jdbc.MResultSet
- updateTime(String, Time) - Method in class com.mckoi.database.jdbc.MResultSet
- updateTimestamp(int, Timestamp) - Method in class com.mckoi.database.jdbc.MResultSet
- updateTimestamp(String, Timestamp) - Method in class com.mckoi.database.jdbc.MResultSet
- updateVisibleTable(MasterTableDataSource, IndexSet) - Method in class com.mckoi.database.SimpleTransaction
-
Updates a MastertableDataSource (and its IndexSet) for this view.
- uploadStreamableObjects(SQLQuery) - Method in class com.mckoi.database.jdbc.MConnection
-
Uploads any streamable objects found in an SQLQuery into the database.
- upper_cells - Variable in class com.mckoi.database.BlindSearch.RangeChecker
- upper_flags - Variable in class com.mckoi.database.BlindSearch.RangeChecker
- UpperFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.UpperFunction
- url - Variable in class com.mckoi.database.jdbc.MConnection
-
The JDBC URL used to make this connection.
- USAGE - Static variable in class com.mckoi.database.Privileges
-
The priv to see statistics on a database object.
- USAGE - Static variable in interface com.mckoi.database.sql.SQLConstants
- USE - Static variable in interface com.mckoi.database.sql.SQLConstants
- use_compressed - Variable in class com.mckoi.database.DataCellSerialization
-
If true, when writing out use the compressed form.
- USED - Static variable in class com.mckoi.database.FixedSizeDataStore
-
The mark that indicates whether a sector is deleted (available) or being used.
- used_sector_count - Variable in class com.mckoi.database.FixedSizeDataStore
-
The number of used sectors in the store.
- usedRecordCount() - Method in class com.mckoi.database.VariableSizeDataStore
-
Returns the number of records that are being used.
- user - Variable in class com.mckoi.database.DatabaseConnection
-
The User that this connection has been made by.
- user - Variable in class com.mckoi.database.interpret.Statement
-
The user context.
- user - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface
-
Access to information regarding the user logged in on this connection.
- user - Variable in class com.mckoi.database.WorkerPool.RunCommand
- User - Class in com.mckoi.database
-
Encapsulates the information about a single user logged into the system.
- User(String, Database, String, long) - Constructor for class com.mckoi.database.User
-
The Constructor.
- USER - Static variable in interface com.mckoi.database.sql.SQLConstants
- USER_AUTHENTICATION_FAILED - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Sent if login failed because username or password were invalid.
- USER_AUTHENTICATION_PASSED - Static variable in interface com.mckoi.database.jdbc.ProtocolConstants
-
Sent if login passed.
- user_list - Variable in class com.mckoi.database.UserManager
-
The list of User objects that are currently connected to the database engine.
- user_manager - Variable in class com.mckoi.database.DatabaseSystem
-
The UserManager object that handles users connected to the database engine.
- USER_MANAGER_GROUP - Static variable in class com.mckoi.database.Database
-
The name of the user manager group.
- user_name - Variable in class com.mckoi.database.User
-
The name of the user.
- UserAccessException - Exception in com.mckoi.database
-
An exception that is thrown when the user is not permitted to perform a certain action.
- UserAccessException(String) - Constructor for exception com.mckoi.database.UserAccessException
- userAllowedAccessFromHost(DatabaseQueryContext, String, String) - Method in class com.mckoi.database.Database
-
Performs check to determine if user is allowed access from the given host.
- userAt(int) - Method in class com.mckoi.database.UserManager
-
Returns the User object at index 'n' in the manager where 0 is the first user.
- userBelongsToGroup(DatabaseQueryContext, String, String) - Method in class com.mckoi.database.Database
-
Returns true if the given user belongs to the given group otherwise returns false.
- userCount() - Method in class com.mckoi.database.UserManager
-
Returns the number of users that are logged in.
- userExists(DatabaseQueryContext, String) - Method in class com.mckoi.database.Database
-
Returns true if a user exists in this database, otherwise returns false.
- UserFunction(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.UserFunction
- userGrantOptions(int, String, String) - Method in class com.mckoi.database.GrantManager
-
Returns all Privileges for the given object for the given grantee (user) that the user is allowed to give grant options for.
- userGrants(int, String, String) - Method in class com.mckoi.database.GrantManager
-
Returns all Privileges for the given object for the given grantee (user).
- userHasSchemaGrant(DatabaseQueryContext, User, String, int) - Method in class com.mckoi.database.Database
-
Returns true if the grant manager permits a schema operation (eg, CREATE, ALTER and DROP table operations) for the given user.
- userHasSecureAccess(DatabaseQueryContext, User) - Method in class com.mckoi.database.Database
-
Returns true if the user belongs to the secure access priv group.
- userHasTableObjectGrant(DatabaseQueryContext, User, TableName, Variable[], int) - Method in class com.mckoi.database.Database
-
Returns true if the grant manager permits a table object operation (eg, SELECT, INSERT, UPDATE, DELETE and COMPACT table operations) for the given user.
- userLoggedIn(User) - Method in class com.mckoi.database.UserManager
-
Called when a new user connects to the engine.
- userLoggedOut(User) - Method in class com.mckoi.database.UserManager
-
Called when the user logs out of the engine.
- UserManager - Class in com.mckoi.database.interpret
-
Handler for User commands for creating, altering and dropping user accounts in the database.
- UserManager - Class in com.mckoi.database
-
A class that manages the list of users connected to the engine.
- UserManager() - Constructor for class com.mckoi.database.interpret.UserManager
- UserManager() - Constructor for class com.mckoi.database.UserManager
-
Constructs the UserManager.
- UserManagerCommand(StatementTree) - Method in class com.mckoi.database.sql.SQL
- username - Variable in class com.mckoi.database.GrantManager.GrantQuery
- UserName() - Method in class com.mckoi.database.sql.SQL
- UserNameList(ArrayList) - Method in class com.mckoi.database.sql.SQL
- UserTerminal - Interface in com.mckoi.util
-
An interface that represents a terminal that is asked questions in human and machine understandable terms, and sends answers.
- usesLocalFilePerTable() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- usesLocalFiles() - Method in class com.mckoi.database.jdbc.MDatabaseMetaData
- USING - Static variable in interface com.mckoi.database.sql.SQLConstants
- Util - Class in com.mckoi.database.sql
-
Various utility methods for the iterpreter.
- Util() - Constructor for class com.mckoi.database.sql.Util
V
- V1FileStoreSystem - Class in com.mckoi.database
-
An implementation of StoreSystem that manages persistant data through the native file system.
- V1FileStoreSystem(TransactionSystem, File, boolean) - Constructor for class com.mckoi.database.V1FileStoreSystem
-
Constructor.
- V1HeapStoreSystem - Class in com.mckoi.database
-
An implementation of StoreSystem that stores all persistent data on the heap using HeapStore objects.
- V1HeapStoreSystem() - Constructor for class com.mckoi.database.V1HeapStoreSystem
-
Constructor.
- V1MasterTableDataSource - Class in com.mckoi.database
-
A MasterTableDataSource that uses IndexStore and VariableSizeDataStore as its backing mechanism for representing the table structure in a file on disk.
- V1MasterTableDataSource(TransactionSystem, StoreSystem, OpenTransactionList) - Constructor for class com.mckoi.database.V1MasterTableDataSource
-
The Constructor.
- V2MasterTableDataSource - Class in com.mckoi.database
-
A MasterTableDataSource that is backed by a non-shared com.mckoi.store.Store object.
- V2MasterTableDataSource(TransactionSystem, StoreSystem, OpenTransactionList, BlobStoreInterface) - Constructor for class com.mckoi.database.V2MasterTableDataSource
-
The Constructor.
- value - Variable in class com.mckoi.database.interpret.Set
-
The value to assign the value to (if applicable).
- value - Variable in class com.mckoi.util.Stats.IntegerStat
- values - Variable in class com.mckoi.database.QueryPlan.MultiColumnEquiSelectNode
-
The values of the cells to equi-select (must be constant expressions).
- VALUES - Static variable in interface com.mckoi.database.sql.SQLConstants
- values_list - Variable in class com.mckoi.database.interpret.Insert
- valuesEqual(TObject) - Method in class com.mckoi.database.TObject
-
Equality test.
- var_list - Variable in class com.mckoi.database.interpret.Planner.PlanTableSource
-
The list of fully qualified Variable objects that are accessable within this plan.
- var_name - Variable in class com.mckoi.database.interpret.Set
-
The variable name of this set statement.
- VARBINARY - Static variable in interface com.mckoi.database.global.SQLTypes
- VARBINARY - Static variable in interface com.mckoi.database.sql.SQLConstants
- VARCHAR - Static variable in interface com.mckoi.database.global.SQLTypes
- VARCHAR - Static variable in interface com.mckoi.database.sql.SQLConstants
- variable - Variable in class com.mckoi.database.Assignment
-
The Variable that is the lhs of the assignment.
- variable - Variable in class com.mckoi.database.CorrelatedVariable
-
The Variable reference itself.
- variable - Variable in class com.mckoi.database.interpret.Planner.QueryTableSetPlanner.SingleVarPlan
- Variable - Class in com.mckoi.database
-
This represents a column name that may be qualified.
- Variable(TableName, String) - Constructor for class com.mckoi.database.Variable
-
Constructs the ColumnName.
- Variable(Variable) - Constructor for class com.mckoi.database.Variable
- Variable(String) - Constructor for class com.mckoi.database.Variable
- variable_resolver - Variable in class com.mckoi.database.RowData
- VariableResolver - Interface in com.mckoi.database
-
An interface to resolve a variable name to a constant object.
- VariableSizeDataStore - Class in com.mckoi.database
-
Provides a mechanism for storing variable length data in a file which can quickly be indexed via a reference number.
- VariableSizeDataStore(File, int, DebugLogger) - Constructor for class com.mckoi.database.VariableSizeDataStore
-
Constructs the variable size store.
- VariableSizeDataStore(File, DebugLogger) - Constructor for class com.mckoi.database.VariableSizeDataStore
- vars - Variable in class com.mckoi.database.interpret.FromTableSubQuerySource
-
The list of all variable names in the resultant source.
- VARYING - Static variable in interface com.mckoi.database.sql.SQLConstants
- verbose_column_names - Variable in class com.mckoi.database.jdbc.MConnection
-
If the ResultSetMetaData.getColumnName method should return a succinct form of the column name as most JDBC implementations do, this should be set to false (the default).
- verboseColumnNames() - Method in class com.mckoi.database.jdbc.MConnection
-
Returns true if ResultSetMetaData should return verbose column names.
- verboseColumnNames() - Method in class com.mckoi.database.jdbc.MResultSet
-
Returns true if verbose column names are enabled on the connection.
- VERSION - Static variable in class com.mckoi.database.global.StandardMessages
-
The global version number of the database system.
- VIEW - Static variable in interface com.mckoi.database.sql.SQLConstants
- view_cache - Variable in class com.mckoi.database.ViewManager.ViewInternalTableInfo
- view_def - Variable in class com.mckoi.database.ViewDef
-
The DataTableDef object that describes the view column def.
- view_manager - Variable in class com.mckoi.database.DatabaseConnection
-
The connection view manager that handles view information through this connection.
- view_manager - Variable in class com.mckoi.database.ViewManager.ViewInternalTableInfo
- view_name - Variable in class com.mckoi.database.interpret.ViewManager
-
The view name to create/drop.
- view_pane - Variable in class com.mckoi.tools.ConglomerateViewPane
-
The view of the store.
- view_query_node - Variable in class com.mckoi.database.ViewDef
-
The QueryPlanNode that is used to evaluate the view.
- view_table_changed - Variable in class com.mckoi.database.ViewManager
-
Set to true when the connection makes changes to the view table through this manager.
- ViewDataConvert(Expression[]) - Constructor for class com.mckoi.database.InternalFunctionFactory.ViewDataConvert
- ViewDef - Class in com.mckoi.database
-
A ViewDef object is a definition of a view stored in the database.
- ViewDef(DataTableDef, QueryPlanNode) - Constructor for class com.mckoi.database.ViewDef
-
Constructs the ViewDef object.
- viewExists(TableName) - Method in class com.mckoi.database.ViewManager
-
Returns true if the view with the given name exists.
- ViewInternalTableInfo(ViewManager, Transaction) - Constructor for class com.mckoi.database.ViewManager.ViewInternalTableInfo
- ViewManager - Class in com.mckoi.database.interpret
-
Handler for creating and dropping views in the database.
- ViewManager - Class in com.mckoi.database
-
A DatabaseConnection view manager.
- ViewManager() - Constructor for class com.mckoi.database.interpret.ViewManager
- ViewManager(DatabaseConnection) - Constructor for class com.mckoi.database.ViewManager
-
Constructs the ViewManager for a DatabaseConnection.
- ViewManager.ViewInternalTableInfo - Class in com.mckoi.database
-
An object that models the list of views as table objects in a transaction.
- VirtualTable - Class in com.mckoi.database
-
A VirtualTable is a representation of a table whose rows are actually physically stored in another table.
- VirtualTable() - Constructor for class com.mckoi.database.VirtualTable
- VirtualTable(Table) - Constructor for class com.mckoi.database.VirtualTable
- VirtualTable(Table[]) - Constructor for class com.mckoi.database.VirtualTable
-
The Constructor.
- vis_list_change - Variable in class com.mckoi.database.StateStore
-
Set to true if the visible list was changed.
- vis_p - Variable in class com.mckoi.database.StateStore
-
Pointer to the visible table area in the store.
- visible_list - Variable in class com.mckoi.database.StateStore
-
The list of visible state resources.
- visible_tables - Variable in class com.mckoi.database.GTTableColumnsDataSource
-
The list of all DataTableDef visible to the transaction.
- visible_tables - Variable in class com.mckoi.database.SimpleTransaction
-
The list of tables that represent this transaction's view of the database.
- VM_DB_CONTROLLER - Static variable in class com.mckoi.database.control.DBController
-
The static DBController object.
- vname - Variable in class com.mckoi.database.interpret.ViewManager
-
The view name as a TableName object.
- vt_table_def - Variable in class com.mckoi.database.JoinedTable
-
The DataTableDef object that describes the columns and name of this table.
W
- waitTillFinished() - Method in class com.mckoi.database.DatabaseSystem.ShutdownThread
- waitUntilAllWorkersQuiet() - Method in class com.mckoi.database.DatabaseSystem
-
Waits until all executing commands have stopped.
- waitUntilAllWorkersQuiet() - Method in class com.mckoi.database.WorkerPool
-
Waits until all executing commands have stopped.
- waitUntilFinished() - Method in class com.mckoi.store.JournalledSystem.JournalingThread
- waitUntilShutdown() - Method in class com.mckoi.database.Database
-
Blocks until the database has shut down.
- waitUntilShutdown() - Method in class com.mckoi.database.DatabaseSystem
-
Wait until the shutdown thread has completed.
- walkBack() - Method in class com.mckoi.util.AbstractBlockIntegerList.BILIterator
- WARNING - Static variable in class com.mckoi.debug.Debug
-
Deprecated.
- WARNING - Static variable in interface com.mckoi.debug.Lvl
- warnings - Variable in class com.mckoi.database.jdbcserver.AbstractJDBCDatabaseInterface.JDIQueryResponse
- was_checked - Variable in class com.mckoi.database.Lock
-
This is set to true when the 'checkAccess' method is called on this lock.
- wasNull() - Method in class com.mckoi.database.jdbc.MResultSet
- WEEKS - Static variable in class com.mckoi.util.TimeFrame
-
Formatting enum.
- WHERE - Static variable in interface com.mckoi.database.sql.SQLConstants
- where_clause - Variable in class com.mckoi.database.interpret.Show
-
The search expression for the show statement (where clause).
- where_clause - Variable in class com.mckoi.database.interpret.TableSelectExpression
-
The where clause.
- where_condition - Variable in class com.mckoi.database.interpret.Delete
-
If the delete statement has a 'where' clause, then this is set here.
- where_condition - Variable in class com.mckoi.database.interpret.UpdateTable
-
If the update statement has a 'where' clause, then this is set here.
- whole_table_as_group - Variable in class com.mckoi.database.FunctionTable
-
Whether the whole table is a group.
- whole_table_group - Variable in class com.mckoi.database.FunctionTable
-
If the whole table is a group, this is the grouping rows.
- whole_table_group_size - Variable in class com.mckoi.database.FunctionTable
-
The total size of the whole table group size.
- whole_table_is_simple_enum - Variable in class com.mckoi.database.FunctionTable
-
If the whole table is a simple enumeration (row index is 0 to getRowCount) then this is true.
- wilderness_pointer - Variable in class com.mckoi.store.AbstractStore
-
A pointer to the wilderness area (the last deleted area in the store), or -1 if there is no wilderness area.
- wipe() - Method in class com.mckoi.database.DataCellCache
-
Completely wipe the cache of all entries.
- wipe_to - Variable in class com.mckoi.util.Cache
-
The number of nodes that should be left available when the cache becomes too full and a clean up operation occurs.
- wipeLastOutputStream() - Method in class com.mckoi.database.FixedSizeDataStore
-
Wipes the SectorOutputStream from this object.
- WITH - Static variable in interface com.mckoi.database.sql.SQLConstants
- worker_pool - Variable in class com.mckoi.database.DatabaseSystem
-
The WorkerPool object that manages access to the database(s) in the system.
- worker_pool - Variable in class com.mckoi.database.WorkerThread
-
The WorkerPool object that this worker thread is for.
- worker_thread_count - Variable in class com.mckoi.database.WorkerPool
-
The number of worker threads that have been created in total.
- WorkerPool - Class in com.mckoi.database
-
Maintains a pool of worker threads that are used to dispatch commands to a Database sub-system.
- WorkerPool(TransactionSystem, int) - Constructor for class com.mckoi.database.WorkerPool
-
Constructs the worker thread pool.
- WorkerPool.RunCommand - Class in com.mckoi.database
-
Structures within the run_queue list.
- WorkerThread - Class in com.mckoi.database
-
This is a worker thread.
- WorkerThread(WorkerPool) - Constructor for class com.mckoi.database.WorkerThread
-
Constructs the thread.
- write(byte[]) - Method in class com.mckoi.store.AbstractStore.AreaOutputStream
- write(byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
- write(byte[], int, int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Writes a variable length byte[] array to the first available index.
- write(byte[], int, int) - Method in class com.mckoi.store.AbstractStore.AreaOutputStream
- write(byte[], int, int) - Method in class com.mckoi.store.StreamFile.SFOutputStream
- write(char[], int, int) - Method in class com.mckoi.util.LogWriter
- write(int) - Method in class com.mckoi.database.FixedSizeDataStore.SectorOutputStream
- write(int) - Method in class com.mckoi.store.AbstractStore.AreaOutputStream
- write(int) - Method in class com.mckoi.store.StreamFile.SFOutputStream
- write(int) - Method in class com.mckoi.util.LogWriter
- write(int, byte) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Writes a single byte to the page in memory.
- write(int, byte[], int, int) - Method in class com.mckoi.store.LoggingBufferManager.BMPage
-
Writes to the given part of the page in memory.
- write(int, Class, String) - Static method in class com.mckoi.debug.Debug
-
Deprecated.
- write(int, Class, String) - Method in interface com.mckoi.debug.DebugLogger
- write(int, Class, String) - Method in class com.mckoi.debug.DefaultDebugLogger
- write(int, Object, String) - Static method in class com.mckoi.debug.Debug
-
Deprecated.This writes the given debugging string.
- write(int, Object, String) - Method in interface com.mckoi.debug.DebugLogger
-
This writes the given debugging string.
- write(int, Object, String) - Method in class com.mckoi.debug.DefaultDebugLogger
- write(int, String, String) - Static method in class com.mckoi.debug.Debug
-
Deprecated.
- write(int, String, String) - Method in interface com.mckoi.debug.DebugLogger
- write(int, String, String) - Method in class com.mckoi.debug.DefaultDebugLogger
- write(long, byte[], int) - Method in class com.mckoi.database.BlobStore.AbstractRef
- write(long, byte[], int) - Method in interface com.mckoi.database.global.Ref
-
This method is used to write the contents of the large object into the backing store.
- write(long, byte[], int, int) - Method in class com.mckoi.store.IOStoreDataAccessor
- write(long, byte[], int, int) - Method in interface com.mckoi.store.JournalledResource
-
Writes a page of some previously specified size to the top log.
- write(long, byte[], int, int) - Method in class com.mckoi.store.JournalledSystem.NonLoggingResource
-
Writes a page of some previously specified size.
- write(long, byte[], int, int) - Method in class com.mckoi.store.JournalledSystem.Resource
-
Writes a page of some previously specified size to the top log.
- write(long, byte[], int, int) - Method in class com.mckoi.store.ScatteringStoreDataAccessor
- write(long, byte[], int, int) - Method in interface com.mckoi.store.StoreDataAccessor
-
Writes a block of data to the underlying data area from the byte array at the given offset.
- write(DataOutput) - Method in class com.mckoi.database.DataIndexDef
-
Writes this object to the given DataOutputStream.
- write(DataOutput) - Method in class com.mckoi.database.DataIndexSetDef
-
Writes this DataIndexSetDef object to the given DataOutput.
- write(DataOutput) - Method in class com.mckoi.database.DataTableColumnDef
-
Writes this column information out to a DataOutputStream.
- write(DataOutput) - Method in class com.mckoi.database.DataTableDef
-
Writes this DataTableDef file to the data output stream.
- write(Object, String) - Static method in class com.mckoi.debug.Debug
-
Deprecated.this is a legacy debug method.
- write(String, int, int) - Method in class com.mckoi.util.LogWriter
- WRITE - Static variable in class com.mckoi.database.Lock
- write_lock - Variable in class com.mckoi.store.LoggingBufferManager
-
A mutex for when modifying the write lock information.
- write_lock_count - Variable in class com.mckoi.store.LoggingBufferManager
-
The number of write locks currently on the buffer.
- writeAcross(byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Writes a byte[] array of data across as many sectors as it takes to store the data.
- writeAllBins() - Method in class com.mckoi.store.AbstractStore
-
Updates all bins to the data area header area.
- writeBinIndex(int) - Method in class com.mckoi.store.AbstractStore
-
Updates the given bin index to the data area header area.
- writeBlobByteArray(long, long, byte[], int) - Method in class com.mckoi.database.BlobStore
-
Writes a section of the blob referenced by the given id, offset and length to the byte array.
- writeBoolean(boolean) - Method in class com.mckoi.database.DataCellSerialization
- writeBreak(int[], PrintWriter) - Static method in class com.mckoi.util.ResultOutputUtil
-
Writes a break.
- writeBufToSector(int, int, byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Writes the contents of the byte[] array to the sector, setting the USED flag to true, and the 'next' int in the sector header.
- writeByte(int) - Method in class com.mckoi.database.DataCellSerialization
- writeByteArrayTo(long, byte[], int, int) - Method in class com.mckoi.store.AbstractStore
-
Writes a byte array to the given position in the file.
- writeByteArrayTo(long, byte[], int, int) - Method in class com.mckoi.store.JournalledFileStore
- writeByteArrayTo(JournalledResource, long, byte[], int, int) - Method in class com.mckoi.store.LoggingBufferManager
- writeByteArrayToPT(long, byte[], int, int) - Method in class com.mckoi.store.AbstractStore
-
WriteByteArrayTo pass-through method.
- writeByteTo(long, int) - Method in class com.mckoi.store.AbstractStore
-
Writes a byte to the given position in the file.
- writeByteTo(long, int) - Method in class com.mckoi.store.JournalledFileStore
- writeByteTo(JournalledResource, long, int) - Method in class com.mckoi.store.LoggingBufferManager
- writeByteToPT(long, int) - Method in class com.mckoi.store.AbstractStore
-
WriteByteTo pass-through method.
- writeChar(int) - Method in class com.mckoi.database.DataCellSerialization
- writeChars(String) - Method in class com.mckoi.database.DataCellSerialization
- writeCommandToServer(byte[], int, int) - Method in class com.mckoi.database.jdbc.RemoteDatabaseInterface
-
Writes the given command to the server.
- writeCommandToServer(byte[], int, int) - Method in class com.mckoi.database.jdbc.StreamDatabaseInterface
-
Writes the given command to the server.
- writeException(int, Throwable) - Static method in class com.mckoi.debug.Debug
-
Deprecated.This writes the given Exception but gives it a 'debug_level'.
- writeException(int, Throwable) - Method in interface com.mckoi.debug.DebugLogger
-
This writes the given Exception but gives it a 'debug_level'.
- writeException(int, Throwable) - Method in class com.mckoi.debug.DefaultDebugLogger
- writeException(Throwable) - Static method in class com.mckoi.debug.Debug
-
Deprecated.This writes the given Exception.
- writeException(Throwable) - Method in interface com.mckoi.debug.DebugLogger
-
This writes the given Exception.
- writeException(Throwable) - Method in class com.mckoi.debug.DefaultDebugLogger
- writeInt(int) - Method in class com.mckoi.database.DataCellSerialization
- writeListToStore(ArrayList) - Method in class com.mckoi.database.StateStore
-
Writes the given list to the store and returns a pointer to the area once the write has finished.
- writeLong(long) - Method in class com.mckoi.database.DataCellSerialization
- writeObject(ObjectOutputStream) - Method in class com.mckoi.database.Expression
-
Writes the state of this object to the object stream.
- writeObject(ObjectOutputStream) - Method in class com.mckoi.database.TObject
-
Writes the state of this object to the object stream.
- writer - Variable in class com.mckoi.store.AbstractStore.AreaOutputStream
- writeRecordToStore(RowData) - Method in class com.mckoi.database.V2MasterTableDataSource
-
Writes a record to the store and returns a pointer to the area that represents the new record.
- writeRecordType(int, int) - Method in class com.mckoi.database.MasterTableDataSource
-
Sets the record type for the given record in the table and returns the previous state of the record.
- writeRecordType(int, int) - Method in class com.mckoi.database.V1MasterTableDataSource
- writeRecordType(int, int) - Method in class com.mckoi.database.V2MasterTableDataSource
- writeRecordType(int, int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Updates the 32-bit type_key int of a record.
- writeReservedBuffer(byte[], int, int) - Method in class com.mckoi.database.FixedSizeDataStore
- writeReservedBuffer(byte[], int, int) - Method in class com.mckoi.database.VariableSizeDataStore
- writeReservedBuffer(byte[], int, int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Every data store has a 128 byte buffer that can be used to store state information.
- writeReservedBuffer(byte[], int, int, int) - Method in class com.mckoi.database.VariableSizeDataStore
-
Writes reserved information to the variable data store.
- writeResourceName(String, DataOutputStream) - Method in class com.mckoi.store.JournalledSystem.JournalFile
-
Writes a resource identifier to the stream for the resource with the given name.
- writeRow(int[], String[], PrintWriter) - Static method in class com.mckoi.util.ResultOutputUtil
-
Writes a row of data.
- writeSector(int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Writes the sector data in 'sector_buffer' to the given sector offset in the store.
- writeSector(int, int) - Method in class com.mckoi.database.FixedSizeDataStore
-
Writes the sector data in 'sector_buffer' to the given sector offset in the store.
- writeSerialization(DataOutputStream) - Method in class com.mckoi.database.DataCellSerialization
-
Writes the current serialized data buffer to the output stream.
- writeShort(int) - Method in class com.mckoi.database.DataCellSerialization
- writeStateResourceList(ArrayList, DataOutputStream) - Method in class com.mckoi.database.StateStore
-
Writes the state resource list to the given area in the store.
- writeString(String) - Method in class com.mckoi.database.VariableSizeDataStore
- writeTime() - Static method in class com.mckoi.debug.Debug
-
Deprecated.Writes out the time to the debug stream.
- writeTime() - Method in class com.mckoi.debug.DefaultDebugLogger
- writeTo(DataOutput, Object) - Static method in class com.mckoi.database.global.ObjectTransfer
-
Writes an object to the data output stream.
- writeTo(DataOutputStream) - Method in class com.mckoi.database.global.ColumnDescription
-
Writes this ColumnDescription to the given DataOutputStream.
- writeTo(DataOutputStream) - Method in class com.mckoi.database.jdbc.SQLQuery
-
Writes the SQL query to the data output stream.
- writeTo(OutputStream) - Method in class com.mckoi.database.BlindSearch
-
Writes the entire state of the scheme to the output stream.
- writeTo(OutputStream) - Method in class com.mckoi.database.CollatedBaseSearch
-
Writes the entire state of the scheme to the output stream.
- writeTo(OutputStream) - Method in class com.mckoi.database.InsertSearch
-
Writes the entire state of the scheme to the output stream.
- writeTo(OutputStream) - Method in class com.mckoi.database.SelectableScheme
-
Writes the entire contents of the scheme to an OutputStream object.
- writeToBuffer(TObject) - Method in class com.mckoi.database.DataCellSerialization
-
Writes the TObject to the data buffer in this object.
- writeToStore() - Method in class com.mckoi.database.IndexSetStore.MappedListBlock
-
Writes this block to a new sector in the index file and updates the information in this object accordingly.
- writeToStore() - Method in class com.mckoi.database.IndexStore.MappedListBlock
-
Writes this block to a new sector in the index file and updates the information in this object accordingly.
Z
- ZERO_NUMBER - Static variable in class com.mckoi.database.sql.Util
- ZERO_OR_MORE_CHARS - Static variable in class com.mckoi.database.PatternSearch
-
Statics for the tokens.
- zeroNumber() - Static method in class com.mckoi.database.sql.Util
-
Returns numeric 0
All Classes All Packages