Uses of Class
com.metamatrix.api.exception.MetaMatrixProcessingException

Packages that use MetaMatrixProcessingException
com.metamatrix.admin.api.exception.security   
com.metamatrix.api.exception.query   
com.metamatrix.api.exception.security   
com.metamatrix.api.exception.server   
com.metamatrix.common.buffer   
com.metamatrix.common.extensionmodule.exception   
com.metamatrix.common.xa   
com.metamatrix.dqp.client   
com.metamatrix.dqp.message   
com.metamatrix.metadata.runtime   
com.metamatrix.metadata.runtime.exception   
com.metamatrix.platform.admin.api.exception   
com.metamatrix.platform.security.authorization.spi   
com.metamatrix.platform.security.membership.spi   
com.metamatrix.query.eval   
com.metamatrix.query.function.aggregate   
com.metamatrix.query.processor   
com.metamatrix.query.processor.batch   
com.metamatrix.query.processor.dynamic   
com.metamatrix.query.processor.proc   
com.metamatrix.query.processor.program   
com.metamatrix.query.processor.relational   
com.metamatrix.query.processor.xml   
com.metamatrix.query.processor.xquery   
com.metamatrix.query.sql.util   
com.metamatrix.query.tempdata   
com.metamatrix.query.xquery   
com.metamatrix.query.xquery.saxon   
com.metamatrix.vdb.edit.loader   
 

Uses of MetaMatrixProcessingException in com.metamatrix.admin.api.exception.security
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.admin.api.exception.security
 class InvalidSessionException
           
 class MetaMatrixSecurityException
           
 class SessionException
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.api.exception.query
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.api.exception.query
 class CriteriaEvaluationException
          This exception is thrown when an error occurs while evaluating a SQL criteria.
 class ExpressionEvaluationException
          This exception is thrown when an error occurs while evaluating a SQL expression.
 class FunctionExecutionException
          During processing, an invalid function was detected.
 class FunctionMetadataException
          Detected invalid function metadata during validation.
 class InvalidFunctionException
          During processing, an invalid function was detected.
 class ProcedureErrorInstructionException
          Used to notify the user that the virtual procedure raised an error.
 class QueryParserException
          Thrown when a query cannot be parsed.
 class QueryPlannerException
          This exception is thrown when an error occurs while planning the query.
 class QueryProcessingException
          This exception is thrown when an error occurs while retrieving metadata from a query component metadata facade.
 class QueryResolverException
          This exception represents the case where the query submitted could not resolved when it is checked against the metadata
 class QueryValidatorException
          This exception is thrown if an error is discovered while validating the query.
 

Uses of MetaMatrixProcessingException in com.metamatrix.api.exception.security
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.api.exception.security
 class AuthorizationException
           
 class AuthorizationMgmtException
           
 class InvalidPrincipalException
           
 class InvalidUserException
           
 class InvalidVDBException
          Indicates that an invalid VDB was requested for logon.
 class LogonException
          This exception is thrown when an attempt to log in to obtain a session has failed.
 class MembershipServiceException
           
 class MetaMatrixAuthenticationException
           
 class SessionServiceException
           
 class UnsupportedCredentialException
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.api.exception.server
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.api.exception.server
 class InvalidRequestIDException
          Thrown when trying to access a request by ID and the request does not exist.
 

Uses of MetaMatrixProcessingException in com.metamatrix.common.buffer
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.common.buffer
 class TupleSourceNotFoundException
          Indicates a TupleSource could not be found.
 

Methods in com.metamatrix.common.buffer that throw MetaMatrixProcessingException
 boolean IndexedTupleSource.hasNext()
           
 java.util.List<?> TupleSource.nextTuple()
          Returns the next tuple
 

Uses of MetaMatrixProcessingException in com.metamatrix.common.extensionmodule.exception
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.common.extensionmodule.exception
 class DuplicateExtensionModuleException
           
 class ExtensionModuleException
           
 class ExtensionModuleNotFoundException
           
 class ExtensionModuleOrderingException
           
 class InvalidExtensionModuleTypeException
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.common.xa
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.common.xa
 class XATransactionException
          Exception which occurs if an error occurs within the server that is XA transaction-related.
 

Uses of MetaMatrixProcessingException in com.metamatrix.dqp.client
 

Methods in com.metamatrix.dqp.client that throw MetaMatrixProcessingException
 void ClientSideDQP.cancelRequest(long requestID)
           
 ResultsFuture<?> ClientSideDQP.closeLobChunkStream(int lobRequestId, long requestId, java.lang.String streamId)
           
 ResultsFuture<?> ClientSideDQP.closeRequest(long requestID)
           
 ResultsFuture<ResultsMessage> ClientSideDQP.executeRequest(long reqID, RequestMessage message)
           
 MetadataResult ClientSideDQP.getMetadata(long requestID)
           
 MetadataResult ClientSideDQP.getMetadata(long requestID, java.lang.String preparedSql, boolean allowDoubleQuotedVariable)
           
 ResultsFuture<ResultsMessage> ClientSideDQP.processCursorRequest(long reqID, int batchFirst, int batchLast)
           
 ResultsFuture<LobChunk> ClientSideDQP.requestNextLobChunk(int lobRequestId, long requestId, java.lang.String streamId)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.dqp.message
 

Methods in com.metamatrix.dqp.message that throw MetaMatrixProcessingException
 void RequestMessage.setTxnAutoWrapMode(java.lang.String txnAutoWrapMode)
          Sets the txnAutoWrapMode.
 

Uses of MetaMatrixProcessingException in com.metamatrix.metadata.runtime
 

Methods in com.metamatrix.metadata.runtime that throw MetaMatrixProcessingException
 void AbstractVDBDeleteUtility.deleteVDBsMarkedForDelete(MetaMatrixSessionID id)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.metadata.runtime.exception
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.metadata.runtime.exception
 class InvalidStateException
          Thrown when an update is requested on the VirtualDatabase and the VirtualDatabase is not in the proper state to allow it.
 class VirtualDatabaseDoesNotExistException
          Thrown when the VirtualDatabase is not found.
 class VirtualDatabaseException
          The base exception from which all Runtime Metadata Exceptions extend.
 

Uses of MetaMatrixProcessingException in com.metamatrix.platform.admin.api.exception
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.platform.admin.api.exception
 class MetaMatrixAdminException
          Base exception of any specifically-administrative business exceptions
 class PermissionNodeException
           
 class PermissionNodeNotActionableException
           
 class PermissionNodeNotFoundException
           
 class ProductNotRegisteredException
          Indicates the named product is a known product, but is not registered at the MetaMatrix system.
 class UnknownProductOrSubsystemException
          Indicates a product name has been encountered that is unknown, or a subsystem name for a known product has been encountered which is unknown for that product.
 

Uses of MetaMatrixProcessingException in com.metamatrix.platform.security.authorization.spi
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.platform.security.authorization.spi
 class AuthorizationSourceConnectionException
          Thrown when a communication failure has occured with the Authorization Source.
 class AuthorizationSourceException
          Thrown when an exception has occured in the Authorization Source.
 

Uses of MetaMatrixProcessingException in com.metamatrix.platform.security.membership.spi
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.platform.security.membership.spi
 class MembershipSourceException
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.eval
 

Methods in com.metamatrix.query.eval that throw MetaMatrixProcessingException
protected  ValueIterator Evaluator.evaluateSubquery(SubqueryContainer container, java.util.List tuple)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.function.aggregate
 

Methods in com.metamatrix.query.function.aggregate that throw MetaMatrixProcessingException
 java.lang.Object AggregateFunction.getResult()
          Called after all values have been processed to get the result.
 java.lang.Object NullFilter.getResult()
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor
 

Methods in com.metamatrix.query.processor that throw MetaMatrixProcessingException
 QueryProcessor QueryProcessor.ProcessorFactory.createQueryProcessor(java.lang.String query, java.lang.String recursionGroup, CommandContext commandContext)
           
 java.lang.Object ProcessorDataManager.lookupCodeValue(CommandContext context, java.lang.String codeTableName, java.lang.String returnElementName, java.lang.String keyElementName, java.lang.Object keyValue)
          Lookup a value from a cached code table.
 java.lang.Object TempTableDataManager.lookupCodeValue(CommandContext context, java.lang.String codeTableName, java.lang.String returnElementName, java.lang.String keyElementName, java.lang.Object keyValue)
           
 TupleBatch ProcessorPlan.nextBatch()
          Get a batch of results or possibly an Exception.
 void ProcessorPlan.open()
          Open the plan for processing.
 TupleSource ProcessorDataManager.registerRequest(java.lang.Object processorId, Command command, java.lang.String modelName, java.lang.String connectorBindingId, int nodeID)
           
 TupleSource TempTableDataManager.registerRequest(java.lang.Object processorID, Command command, java.lang.String modelName, java.lang.String connectorBindingId, int nodeID)
          This is the magic method.
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.batch
 

Methods in com.metamatrix.query.processor.batch that throw MetaMatrixProcessingException
 TupleBatch BatchedUpdatePlan.nextBatch()
           
 void BatchedUpdatePlan.open()
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.dynamic
 

Methods in com.metamatrix.query.processor.dynamic that throw MetaMatrixProcessingException
static javax.xml.transform.sax.SAXSource SQLSource.createSource(java.lang.String[] columns, java.lang.Class[] types, TupleSource source)
           
static javax.xml.transform.Source XMLSource.createSource(java.lang.String[] columns, java.lang.Class[] types, TupleSource source, BufferManager bufferMgr)
           
 javax.xml.transform.Source SqlEval.executeSQL(java.lang.String sql)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.proc
 

Methods in com.metamatrix.query.processor.proc that throw MetaMatrixProcessingException
 void ProcedurePlan.executePlan(ProcessorPlan command, java.lang.String rsName)
           
 boolean ProcedurePlan.iterateCursor(java.lang.String rsName)
           
 TupleBatch ProcedurePlan.nextBatch()
           
 void ProcedurePlan.open()
           
 void ExecDynamicSqlInstruction.process(ProcedurePlan procEnv)
           Processing this instruction executes the ProcessorPlan for the command on the CommandStatement of the update procedure language.
 void AbstractAssignmentInstruction.process(ProcedurePlan procEnv)
           Updates the current variable context with a value for the Variable defined using a DeclareInstruction, the variable value is obtained by either processing a expression or a command(stored as a processplan).
 void IfInstruction.process(ProcedurePlan procEnv)
          This instruction will evaluate it's criteria, if it evaluates to true, it will push the corresponding sub Program on to the top of the program stack, and break from the loop.
 void CreateCursorResultSetInstruction.process(ProcedurePlan procEnv)
          If the result set named rsName does not exist yet in the ProcessorEnvironment, then this instruction will define that result set.
 void ExecSqlInstruction.process(ProcedurePlan procEnv)
          Processing this instruction executes the ProcessorPlan for the command on the CommandStatement of the update procedure language.
protected  void AssignmentInstruction.processValue(java.lang.Object value, VariableContext varContext)
           
protected abstract  void AbstractAssignmentInstruction.processValue(java.lang.Object value, VariableContext varContext)
           
protected  void ErrorInstruction.processValue(java.lang.Object value, VariableContext varContext)
           
 boolean LoopInstruction.testCondition(ProcedurePlan procEnv)
           
 boolean RepeatedInstruction.testCondition(ProcedurePlan procEnv)
           
 boolean WhileInstruction.testCondition(ProcedurePlan procEnv)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.program
 

Methods in com.metamatrix.query.processor.program that throw MetaMatrixProcessingException
abstract  void ProgramInstruction.process(ProcedurePlan env)
          Allow this instruction to do whatever processing it needs, and to in turn manipulate the running program, (via the ProcessorEnvironment getProgramStack method.) A typical instruction should simply increment the program counter of the current program, but specialized instructions may add sub programs to the stack or not increment the counter (so that they are executed again.)
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.relational
 

Methods in com.metamatrix.query.processor.relational that throw MetaMatrixProcessingException
 TupleSourceID BatchCollector.collectTuples()
           
 TupleSourceID BatchCollector.collectTuples(TupleBatch batch)
           
protected  boolean MergeJoinStrategy.compareToPrevious(com.metamatrix.query.processor.relational.SourceState target)
           
protected  ValueIterator SubqueryAwareEvaluator.evaluateSubquery(SubqueryContainer container, java.util.List tuple)
           
 java.util.HashSet<java.lang.Object> DependentValueSource.getCachedSet(Expression valueExpression)
           
 java.lang.Object DuplicateFilter.getResult()
           
protected  void JoinStrategy.loadLeft()
           
protected  void PartitionedSortJoin.loadLeft()
           
protected  void MergeJoinStrategy.loadLeft()
           
protected  void JoinStrategy.loadRight()
           
protected  void PartitionedSortJoin.loadRight()
           
 TupleBatch RelationalNode.nextBatch()
          Wrapper for nextBatchDirect that does performance timing - callers should always call this rather than nextBatchDirect().
 TupleBatch RelationalPlan.nextBatch()
           
 TupleBatch ProjectNode.nextBatchDirect()
           
 TupleBatch PlanExecutionNode.nextBatchDirect()
           
 TupleBatch BatchedUpdateNode.nextBatchDirect()
           
 TupleBatch ProjectIntoNode.nextBatchDirect()
          Get batch from child node Walk through each row of child batch Bind values to insertCommand Execute insertCommand Update insertCount When no more data is available, output batch with single row containing insertCount
protected abstract  TupleBatch RelationalNode.nextBatchDirect()
          Template method for subclasses to implement.
protected  TupleBatch JoinNode.nextBatchDirect()
           
 TupleBatch AccessNode.nextBatchDirect()
           
protected  TupleBatch LimitNode.nextBatchDirect()
           
 TupleBatch UnionAllNode.nextBatchDirect()
           
 TupleBatch SortNode.nextBatchDirect()
           
 TupleBatch SelectNode.nextBatchDirect()
           
 TupleBatch GroupingNode.nextBatchDirect()
           
protected abstract  java.util.List JoinStrategy.nextTuple()
           
protected  java.util.List PartitionedSortJoin.nextTuple()
           
protected  java.util.List MergeJoinStrategy.nextTuple()
           
 void PlanExecutionNode.open()
           
 void DependentProcedureAccessNode.open()
           
 void BatchedUpdateNode.open()
           
 void RelationalNode.open()
           
 void JoinNode.open()
           
 void AccessNode.open()
           
 void LimitNode.open()
           
 void UnionAllNode.open()
           
 void SortNode.open()
           
 void RelationalPlan.open()
           
 void DependentProcedureExecutionNode.open()
           
 void GroupingNode.open()
           
protected  void JoinStrategy.postLoadLeft()
           
protected  void PartitionedSortJoin.postLoadLeft()
           
protected  void MergeJoinStrategy.postLoadLeft()
           
protected  void JoinStrategy.postLoadRight()
           
protected  void PartitionedSortJoin.postLoadRight()
           
protected  void MergeJoinStrategy.postLoadRight()
           
protected  boolean PlanExecutionNode.prepareNextCommand()
           
protected  boolean DependentProcedureExecutionNode.prepareNextCommand()
           
protected  boolean DependentAccessNode.prepareNextCommand(Command atomicCommand)
           
protected  boolean DependentProcedureAccessNode.prepareNextCommand(Command atomicCommand)
           
protected  boolean AccessNode.prepareNextCommand(Command atomicCommand)
           
protected  boolean DependentProcedureCriteriaProcessor.prepareNextCommand(VariableContext context)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.xml
 

Methods in com.metamatrix.query.processor.xml that throw MetaMatrixProcessingException
 java.util.List PlanExecutor.currentRow()
          Get the result set values of the current row.
 boolean CriteriaCondition.evaluate(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 boolean RecurseProgramCondition.evaluate(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
          Evaluates to true, unless the termination criteria is true, or unless the recursion count limit has been reached
abstract  boolean Condition.evaluate(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext ontext)
          This method causes the Condition to evaluate itself.
 boolean DefaultCondition.evaluate(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
          Always returns true
 void PlanExecutor.execute(java.util.Map referenceValues)
          Execute the plan
 TupleBatch XMLPlan.nextBatch()
           
 java.util.List PlanExecutor.nextRow()
          Advance the resultset cursor to next row and retun the row values
 com.metamatrix.query.processor.xml.XMLContext MoveCursorInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
abstract  com.metamatrix.query.processor.xml.XMLContext ProcessorInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
          Allow this ProcessorInstruction to do whatever processing it needs, and to in turn manipulate the running program, (via the ProcessorEnvironment getProgramStack method.) A typical instruction should simply increment the program counter of the current program, but specialized instructions may add sub programs to the stack or not increment the counter (so that they are executed again.)
 com.metamatrix.query.processor.xml.XMLContext BlockInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext ExecStagingTableInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext EndBlockInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext IfInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
          This instruction will evaluate it's criteria, one by one.
 com.metamatrix.query.processor.xml.XMLContext AbortProcessingInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext AddCommentInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
          outputs comment for an XML element (comment node is actually child of XML element node)
 com.metamatrix.query.processor.xml.XMLContext MoveDocInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext JoinedWhileInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext InitializeDocumentInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext AddNodeInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
          Outputs an element or an attribute, or nothing, based on the state of the instruction.
 com.metamatrix.query.processor.xml.XMLContext WhileInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext ExecSqlInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 com.metamatrix.query.processor.xml.XMLContext EndDocumentInstruction.process(XMLProcessorEnvironment env, com.metamatrix.query.processor.xml.XMLContext context)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.processor.xquery
 

Methods in com.metamatrix.query.processor.xquery that throw MetaMatrixProcessingException
 TupleBatch XQueryPlan.nextBatch()
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.sql.util
 

Methods in com.metamatrix.query.sql.util that throw MetaMatrixProcessingException
 java.util.HashSet<java.lang.Object> ValueIteratorSource.getCachedSet(Expression valueExpression)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.tempdata
 

Methods in com.metamatrix.query.tempdata that throw MetaMatrixProcessingException
 TupleSource TempTableStore.registerRequest(Command command)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.xquery
 

Methods in com.metamatrix.query.xquery that throw MetaMatrixProcessingException
 void XQueryExpression.compileXQuery(java.lang.String xQueryString)
          Return the compiled XQueryExpression - the result of this call should be used as a parameter to the getDocumentNames and evaluateXQuery methods.
 java.sql.SQLXML XQueryExpression.evaluateXQuery(XQuerySQLEvaluator sqlEval)
          Evaluate the XQuery and return results.
 javax.xml.transform.Source XQuerySQLEvaluator.executeSQL(java.lang.String sql)
          Execute a SQL string that returns an XML result
 

Uses of MetaMatrixProcessingException in com.metamatrix.query.xquery.saxon
 

Methods in com.metamatrix.query.xquery.saxon that throw MetaMatrixProcessingException
 void SaxonXQueryExpression.compileXQuery(java.lang.String xQueryString)
           
 java.sql.SQLXML SaxonXQueryExpression.evaluateXQuery(XQuerySQLEvaluator sqlEval)
           
 

Uses of MetaMatrixProcessingException in com.metamatrix.vdb.edit.loader
 

Subclasses of MetaMatrixProcessingException in com.metamatrix.vdb.edit.loader
 class VdbProcessingException
          The base exception from which all Runtime Metadata Exceptions extend.
 



Copyright © 2009. All Rights Reserved.