Uses of Class
org.teiid.core.TeiidProcessingException
-
-
Uses of TeiidProcessingException in org.teiid.api.exception.query
Subclasses of TeiidProcessingException in org.teiid.api.exception.query Modifier and Type Class Description 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
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 metadataclass
QueryValidatorException
This exception is thrown if an error is discovered while validating the query. -
Uses of TeiidProcessingException in org.teiid.client
Subclasses of TeiidProcessingException in org.teiid.client Modifier and Type Class Description class
ProcedureErrorInstructionException
Used to notify the user that the virtual procedure raised an error.Methods in org.teiid.client that throw TeiidProcessingException Modifier and Type Method Description boolean
DQP. cancelRequest(long requestID)
ResultsFuture<?>
DQP. closeLobChunkStream(int lobRequestId, long requestId, String streamId)
ResultsFuture<?>
DQP. closeRequest(long requestID)
ResultsFuture<ResultsMessage>
DQP. executeRequest(long reqID, RequestMessage message)
MetadataResult
DQP. getMetadata(long requestID)
MetadataResult
DQP. getMetadata(long requestID, String preparedSql, boolean allowDoubleQuotedVariable)
ResultsFuture<ResultsMessage>
DQP. processCursorRequest(long reqID, int batchFirst, int fetchSize)
ResultsFuture<LobChunk>
DQP. requestNextLobChunk(int lobRequestId, long requestId, String streamId)
void
RequestMessage. setTxnAutoWrapMode(String txnAutoWrapMode)
Sets the txnAutoWrapMode. -
Uses of TeiidProcessingException in org.teiid.client.security
Subclasses of TeiidProcessingException in org.teiid.client.security Modifier and Type Class Description class
InvalidSessionException
class
LogonException
This exception is thrown when an attempt to log in to obtain a session has failed.class
TeiidSecurityException
-
Uses of TeiidProcessingException in org.teiid.client.xa
Subclasses of TeiidProcessingException in org.teiid.client.xa Modifier and Type Class Description class
XATransactionException
Exception which occurs if an error occurs within the server that is XA transaction-related. -
Uses of TeiidProcessingException in org.teiid.common.buffer
Methods in org.teiid.common.buffer that throw TeiidProcessingException Modifier and Type Method Description protected abstract List<?>
AbstractTupleSource. finalRow()
protected List<?>
TupleBuffer.TupleBufferTupleSource. finalRow()
protected abstract TupleBatch
AbstractTupleSource. getBatch(long row)
protected List<?>
AbstractTupleSource. getCurrentTuple()
boolean
AbstractTupleSource. hasNext()
boolean
IndexedTupleSource. hasNext()
List<?>
AbstractTupleSource. nextTuple()
List<?>
TupleBrowser. nextTuple()
List<?>
TupleSource. nextTuple()
Returns the next tuple -
Uses of TeiidProcessingException in org.teiid.core.types
Subclasses of TeiidProcessingException in org.teiid.core.types Modifier and Type Class Description class
TransformationException
The exception is thrown when an error occurs during data transformation, typically a formatting error or an invalid input type. -
Uses of TeiidProcessingException in org.teiid.deployers
Subclasses of TeiidProcessingException in org.teiid.deployers Modifier and Type Class Description class
VirtualDatabaseException
The base exception from which all Runtime Metadata Exceptions extend.Methods in org.teiid.deployers that throw TeiidProcessingException Modifier and Type Method Description TempTable
CompositeGlobalTableStore. createMatTable(String matTableName, GroupSymbol group)
TempMetadataID
CompositeGlobalTableStore. getGlobalTempTableMetadataId(Object groupID)
-
Uses of TeiidProcessingException in org.teiid.dqp.internal.process
Methods in org.teiid.dqp.internal.process that throw TeiidProcessingException Modifier and Type Method Description boolean
DQPCore. cancelRequest(long requestID)
ResultsFuture<?>
DQPCore. closeLobChunkStream(int lobRequestId, long requestId, String streamId)
ResultsFuture<?>
DQPCore. closeRequest(long requestId)
QueryProcessor
QueryProcessorFactoryImpl. createQueryProcessor(String query, String recursionGroup, CommandContext commandContext, Object... params)
ResultsFuture<ResultsMessage>
DQPCore. executeRequest(long reqID, RequestMessage requestMsg)
ResultsFuture<ResultsMessage>
DQPCore. executeRequest(long reqID, RequestMessage requestMsg, Long queryTimeout)
protected void
PreparedStatementRequest. generatePlan(boolean addLimit)
protected void
Request. generatePlan(boolean prepared)
state side effects: creates the analysis record creates the command context sets the pre-rewrite command on the request adds a limit clause if the row limit is specified sets the processor planstatic int
DataTierManagerImpl. getLevel(String level)
MetadataResult
DQPCore. getMetadata(long requestID)
MetadataResult
DQPCore. getMetadata(long requestID, String preparedSql, boolean allowDoubleQuotedVariable)
PreparedPlan
QueryProcessorFactoryImpl. getPreparedPlan(String query, String recursionGroup, CommandContext commandContext, QueryMetadataInterface metadata)
TupleSource
TupleSourceCache. getSharedTupleSource(CommandContext context, Command command, String modelName, RegisterRequestParameter parameterObject, BufferManager bufferMgr, ProcessorDataManager pdm)
Object
DataTierManagerImpl. lookupCodeValue(CommandContext context, String codeTableName, String returnElementName, String keyElementName, Object keyValue)
TupleBatch
ExplainProcessPlan. nextBatch()
List<?>
DataTierTupleSource. nextTuple()
List<?>
TupleSourceCache.CopyOnReadTupleSource. nextTuple()
void
ExplainProcessPlan. open()
ResultsFuture<ResultsMessage>
DQPCore. processCursorRequest(long reqID, int batchFirst, int fetchSize)
protected void
RequestWorkItem. processNew()
void
PreparedStatementRequest. processRequest()
void
Request. processRequest()
TupleSource
DataTierManagerImpl. registerRequest(CommandContext context, Command command, String modelName, RegisterRequestParameter parameterObject)
ResultsFuture<LobChunk>
DQPCore. requestNextLobChunk(int lobRequestId, long requestId, String streamId)
protected boolean
RequestWorkItem. sendResultsIfNeeded(TupleBatch batch)
Send results if they have been requested. -
Uses of TeiidProcessingException in org.teiid.dqp.service
Subclasses of TeiidProcessingException in org.teiid.dqp.service Modifier and Type Class Description class
SessionServiceException
-
Uses of TeiidProcessingException in org.teiid.jdbc
Methods in org.teiid.jdbc that throw TeiidProcessingException Modifier and Type Method Description void
ConnectionImpl. cancelRequest(String id)
Cancel the request -
Uses of TeiidProcessingException in org.teiid.odata.api
Methods in org.teiid.odata.api that throw TeiidProcessingException Modifier and Type Method Description Connection
Client. open()
-
Uses of TeiidProcessingException in org.teiid.olingo.common
Methods in org.teiid.olingo.common that throw TeiidProcessingException Modifier and Type Method Description static Object
ODataTypeManager. parseLiteral(org.apache.olingo.commons.api.edm.EdmParameter edmParameter, Class<?> runtimeType, String value)
-
Uses of TeiidProcessingException in org.teiid.olingo.service
Subclasses of TeiidProcessingException in org.teiid.olingo.service Modifier and Type Class Description class
TeiidNotImplementedException
Methods in org.teiid.olingo.service that throw TeiidProcessingException Modifier and Type Method Description static void
ODataSQLBuilder. checkExpandLevel(int expandLevel)
OlingoBridge.HandlerInfo
OlingoBridge. getHandlers(String baseUri, Client client, String schemaName)
Connection
LocalClient. open()
Constructors in org.teiid.olingo.service that throw TeiidProcessingException Constructor Description ProcedureSQLBuilder(MetadataStore metadata, org.apache.olingo.commons.api.edm.EdmOperation edmOperation, org.teiid.olingo.service.TeiidServiceHandler.OperationParameterValueProvider parameterProvider, ArrayList<SQLParameter> params)
-
Uses of TeiidProcessingException in org.teiid.olingo.web
Methods in org.teiid.olingo.web that throw TeiidProcessingException Modifier and Type Method Description void
ODataFilter. internalDoFilter(javax.servlet.ServletRequest request, javax.servlet.ServletResponse response, javax.servlet.FilterChain chain)
boolean
OpenApiHandler. processOpenApiMetadata(javax.servlet.http.HttpServletRequest httpRequest, VDBKey key, String uri, String modelName, javax.servlet.ServletResponse response, org.apache.olingo.server.api.ServiceMetadata serviceMetadata, Map<String,String> parameters)
-
Uses of TeiidProcessingException in org.teiid.query.eval
Methods in org.teiid.query.eval that throw TeiidProcessingException Modifier and Type Method Description protected Object
Evaluator. evaluateProcedure(Function function, List<?> tuple, Object[] values)
protected Object
Evaluator. evaluatePushdown(Function function, List<?> tuple, Object[] values)
protected ValueIterator
Evaluator. evaluateSubquery(SubqueryContainer<?> container, List<?> tuple)
static JsonType
Evaluator. jsonArray(CommandContext context, Function f, Object[] vals, JSONFunctionMethods.JSONBuilder builder, Evaluator eval, List<?> tuple)
-
Uses of TeiidProcessingException in org.teiid.query.function
Methods in org.teiid.query.function that throw TeiidProcessingException Modifier and Type Method Description void
JSONFunctionMethods.JSONBuilder. addValue(Object object)
void
JSONFunctionMethods.JSONBuilder. addValue(String key, Object object)
JsonType
JSONFunctionMethods.JSONBuilder. close(CommandContext cc)
void
JSONFunctionMethods.JSONBuilder. end(boolean array)
static JsonType
JSONFunctionMethods. jsonArray(CommandContext context, Object... vals)
void
JSONFunctionMethods.JSONBuilder. start(boolean array)
void
JSONFunctionMethods.JSONBuilder. startValue(String key)
-
Uses of TeiidProcessingException in org.teiid.query.function.aggregate
Methods in org.teiid.query.function.aggregate that throw TeiidProcessingException Modifier and Type Method Description void
AggregateFunction. addInput(List<?> tuple, CommandContext commandContext)
void
NthValue. addInput(List<?> tuple, CommandContext commandContext, long startFrame, long endFrame, TupleBuffer frame)
abstract void
AggregateFunction. addInputDirect(List<?> tuple, CommandContext commandContext)
Called for the element value in every row of a group.void
ArrayAgg. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
void
Count. addInputDirect(List<?> tuple, CommandContext commandContext)
void
CountBig. addInputDirect(List<?> tuple, CommandContext commandContext)
void
FirstLastValue. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
void
JSONArrayAgg. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
void
LeadLagValue. addInputDirect(List<?> tuple, CommandContext commandContext)
void
NthValue. addInputDirect(List<?> tuple, CommandContext commandContext)
void
Ntile. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
abstract void
SingleArgumentAggregateFunction. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
void
SingleArgumentAggregateFunction. addInputDirect(List<?> tuple, CommandContext commandContext)
void
StringAgg. addInputDirect(List<?> tuple, CommandContext commandContext)
void
TextAgg. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
void
UserDefined. addInputDirect(List<?> tuple, CommandContext commandContext)
void
XMLAgg. addInputDirect(Object input, List<?> tuple, CommandContext commandContext)
abstract Object
AggregateFunction. getResult(CommandContext commandContext)
Called after all values have been processed to get the result.Object
ArrayAgg. getResult(CommandContext commandContext)
Object
JSONArrayAgg. getResult(CommandContext commandContext)
Object
LeadLagValue. getResult(CommandContext commandContext)
Object
NthValue. getResult(CommandContext commandContext)
Object
StringAgg. getResult(CommandContext commandContext)
Object
TextAgg. getResult(CommandContext commandContext)
Object
UserDefined. getResult(CommandContext commandContext)
Object
XMLAgg. getResult(CommandContext commandContext)
-
Uses of TeiidProcessingException in org.teiid.query.function.source
Methods in org.teiid.query.function.source that throw TeiidProcessingException Modifier and Type Method Description void
XMLSystemFunctions.XmlConcat. addValue(Object object)
XMLType
XMLSystemFunctions.XmlConcat. close(CommandContext context)
static Source
XMLSystemFunctions. convertToSource(Object value)
boolean
XMLHelper. isValidNCName(String prefix)
static SQLXML
XMLSystemFunctions. jsonToXml(CommandContext context, String rootName, Blob json)
static SQLXML
XMLSystemFunctions. jsonToXml(CommandContext context, String rootName, Blob json, boolean stream)
static SQLXML
XMLSystemFunctions. jsonToXml(CommandContext context, String rootName, Clob json)
static SQLXML
XMLSystemFunctions. jsonToXml(CommandContext context, String rootName, Clob json, boolean stream)
static SQLXMLImpl
XMLSystemFunctions. saveToBufferManager(BufferManager bufferMgr, XMLTranslator translator, CommandContext context)
This method saves the given XML object to the buffer manager's disk process Documents less than the maxMemorySize will be held directly in memoryString[]
XMLHelper. validateQName(String name)
void
XMLHelper. validateXpath(String xpath)
static XMLType
XMLSystemFunctions. xmlConcat(CommandContext context, XMLType xml, Object... other)
static XMLType
XMLSystemFunctions. xmlElement(CommandContext context, String name, Evaluator.NameValuePair<String>[] namespaces, Evaluator.NameValuePair<?>[] attributes, List<?> contents)
Basic support for xmlelement.static XMLType
XMLSystemFunctions. xmlForest(CommandContext context, Evaluator.NameValuePair[] namespaces, Evaluator.NameValuePair[] values)
Constructors in org.teiid.query.function.source that throw TeiidProcessingException Constructor Description XmlConcat(BufferManager bm)
-
Uses of TeiidProcessingException in org.teiid.query.metadata
Methods in org.teiid.query.metadata that throw TeiidProcessingException Modifier and Type Method Description ScriptEngine
BasicQueryMetadata. getScriptEngine(String language)
ScriptEngine
BasicQueryMetadataWrapper. getScriptEngine(String langauge)
ScriptEngine
QueryMetadataInterface. getScriptEngine(String langauge)
ScriptEngine
BasicQueryMetadata. getScriptEngineDirect(String language)
ScriptEngine
TransformationMetadata. getScriptEngineDirect(String language)
-
Uses of TeiidProcessingException in org.teiid.query.optimizer
Methods in org.teiid.query.optimizer that throw TeiidProcessingException Modifier and Type Method Description TupleBatch
SourceTriggerActionPlanner.CompositeProcessorPlan. nextBatch()
void
SourceTriggerActionPlanner.CompositeProcessorPlan. open()
ProcessorPlan
TriggerActionPlanner. optimize(ProcedureContainer userCommand, TriggerAction ta, IDGenerator idGenerator, QueryMetadataInterface metadata, CapabilitiesFinder capFinder, AnalysisRecord analysisRecord, CommandContext context)
-
Uses of TeiidProcessingException in org.teiid.query.optimizer.relational
Methods in org.teiid.query.optimizer.relational that throw TeiidProcessingException Modifier and Type Method Description static Command
RowBasedSecurityHelper. checkUpdateRowBasedFilters(ProcedureContainer container, Command procedure, RelationalPlanner planner)
protected RelationalNode
PlanToProcessConverter. convertNode(PlanNode node)
PlanNode
RelationalPlanner. generatePlan(Command cmd)
static Criteria
RowBasedSecurityHelper. getRowBasedFilters(QueryMetadataInterface metadata, GroupSymbol group, CommandContext cc, boolean constraintsOnly, Policy.Operation operation)
static List<? extends Expression>
ColumnMaskingHelper. maskColumns(List<ElementSymbol> cols, GroupSymbol group, QueryMetadataInterface metadata, CommandContext cc)
-
Uses of TeiidProcessingException in org.teiid.query.processor
Methods in org.teiid.query.processor that throw TeiidProcessingException Modifier and Type Method Description TupleBuffer
BatchCollector. collectTuples()
TupleBuffer
BatchCollector. collectTuples(boolean singleBatch)
QueryProcessor
QueryProcessor.ProcessorFactory. createQueryProcessor(String query, String recursionGroup, CommandContext commandContext, Object... params)
protected List<?>
BatchIterator. finalRow()
protected void
BatchCollector. flushBatchDirect(TupleBatch batch, boolean add)
protected TupleBatch
BatchIterator. getBatch(long row)
TupleBuffer
BatchCollector.BatchProducer. getBuffer(int maxRows)
return the final tuple buffer or null if not availableTupleBuffer
ProcessorPlan. getBuffer(int maxRows)
return the final tuple buffer or null if not availableTupleBuffer
QueryProcessor. getBuffer(int maxRows)
protected List<?>
BatchIterator. getCurrentTuple()
PreparedPlan
QueryProcessor.ProcessorFactory. getPreparedPlan(String query, String recursionGroup, CommandContext commandContext, QueryMetadataInterface metadata)
void
QueryProcessor. init()
Object
ProcessorDataManager. lookupCodeValue(CommandContext context, String codeTableName, String returnElementName, String keyElementName, Object keyValue)
Lookup a value from a cached code table.TupleBatch
BatchCollector.BatchProducer. nextBatch()
Get a batch of results or possibly an Exception.TupleBatch
BatchedUpdatePlan. nextBatch()
TupleBatch
DdlPlan. nextBatch()
abstract TupleBatch
ProcessorPlan. nextBatch()
Get a batch of results or possibly an Exception.TupleBatch
QueryProcessor. nextBatch()
List<Object>
BatchCollector.BatchProducerTupleSource. nextTuple()
void
BatchedUpdatePlan. open()
void
DdlPlan. open()
abstract void
ProcessorPlan. open()
Open the plan for processing.void
BatchIterator. readAhead(long limit)
TupleSource
ProcessorDataManager. registerRequest(CommandContext context, Command command, String modelName, RegisterRequestParameter parameterObject)
String
DdlPlan.SetPropertyProcessor. setProperty(VDBMetaData vdb, AbstractMetadataRecord record, String key, String value)
-
Uses of TeiidProcessingException in org.teiid.query.processor.proc
Methods in org.teiid.query.processor.proc that throw TeiidProcessingException Modifier and Type Method Description void
ProcedurePlan. executePlan(ProcessorPlan command, String rsName, Map<ElementSymbol,ElementSymbol> procAssignments, CreateCursorResultSetInstruction.Mode mode, boolean usesLocalTemp)
boolean
ProcedurePlan. iterateCursor(String rsName)
Object
ProcedurePlan. lookupCodeValue(CommandContext context, String codeTableName, String returnElementName, String keyElementName, Object keyValue)
TupleBatch
ForEachRowPlan. nextBatch()
TupleBatch
ProcedurePlan. nextBatch()
TupleBatch
ProcedurePlan. nextBatchDirect()
void
ForEachRowPlan. open()
void
ProcedurePlan. open()
void
AssignmentInstruction. 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
BlockInstruction. process(ProcedurePlan procEnv)
void
CreateCursorResultSetInstruction. process(ProcedurePlan procEnv)
void
ErrorInstruction. process(ProcedurePlan env)
void
ExecDynamicSqlInstruction. process(ProcedurePlan procEnv)
Processing this instruction executes the ProcessorPlan for the command on the CommandStatement of the update procedure language.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.abstract void
ProgramInstruction. process(ProcedurePlan env)
Allow this instruction to do whatever processing it needs, and to in turn manipulate the running program.TupleSource
ProcedurePlan. registerRequest(CommandContext context, Command command, String modelName, RegisterRequestParameter parameterObject)
boolean
LoopInstruction. testCondition(ProcedurePlan procEnv)
boolean
RepeatedInstruction. testCondition(ProcedurePlan procEnv)
boolean
WhileInstruction. testCondition(ProcedurePlan procEnv)
-
Uses of TeiidProcessingException in org.teiid.query.processor.relational
Methods in org.teiid.query.processor.relational that throw TeiidProcessingException Modifier and Type Method Description void
SortingFilter. addInputDirect(List<?> tuple, CommandContext commandContext)
protected void
GroupingNode. closeGroup(int colDiff, boolean reset, CommandContext context)
protected boolean
MergeJoinStrategy. compareToPrevious(org.teiid.query.processor.relational.SourceState target)
void
EnhancedSortMergeJoinStrategy. createIndex(org.teiid.query.processor.relational.SourceState state, MergeJoinStrategy.SortOption sortOption)
Create an index of the smaller sizeprotected void
SortUtility. doMerge(int rowLimit)
protected Object
SubqueryAwareEvaluator. evaluateProcedure(Function function, List<?> tuple, Object[] values)
Implements procedure function handling.protected Object
SubqueryAwareEvaluator. evaluatePushdown(Function function, List<?> tuple, Object[] values)
Implements must pushdown function handling if supported by the source.protected ValueIterator
SubqueryAwareEvaluator. evaluateSubquery(SubqueryContainer<?> container, List<?> tuple)
TupleBuffer
RelationalNode. getBuffer(int maxRows)
return the final tuple buffer or null if not availableTupleBuffer
RelationalPlan. getBuffer(int maxRows)
TupleBuffer
LimitNode. getBufferDirect(int maxRows)
TupleBuffer
ProjectNode. getBufferDirect(int maxRows)
protected TupleBuffer
RelationalNode. getBufferDirect(int maxRows)
For subclasses to override if they wish to return a buffer rather than batches.TupleBuffer
SortNode. getBufferDirect(int maxRows)
Set<Object>
DependentValueSource. getCachedSet(Expression valueExpression)
Object
SortingFilter. getResult(CommandContext commandContext)
protected void
SortUtility. initialSort(boolean onePass, boolean lowLatency, int rowLimit)
creates sorted sublists stored in tuplebuffersprotected void
EnhancedSortMergeJoinStrategy. loadLeft()
protected void
JoinStrategy. loadLeft()
protected void
MergeJoinStrategy. loadLeft()
protected void
EnhancedSortMergeJoinStrategy. loadRight()
protected void
JoinStrategy. loadRight()
protected void
MergeJoinStrategy. loadRight()
protected void
NestedLoopJoinStrategy. loadRight()
protected void
SortUtility. mergePhase(int rowLimit)
TupleBatch
RelationalNode. nextBatch()
Wrapper for nextBatchDirect that does performance timing - callers should always call this rather than nextBatchDirect().TupleBatch
RelationalPlan. nextBatch()
TupleBatch
AccessNode. nextBatchDirect()
protected TupleBatch
ArrayTableNode. nextBatchDirect()
TupleBatch
BatchedUpdateNode. nextBatchDirect()
TupleBatch
DupRemoveNode. nextBatchDirect()
TupleBatch
GroupingNode. nextBatchDirect()
TupleBatch
JoinNode. nextBatchDirect()
protected TupleBatch
LimitNode. nextBatchDirect()
protected TupleBatch
ObjectTableNode. nextBatchDirect()
TupleBatch
PlanExecutionNode. 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 insertCountTupleBatch
ProjectNode. nextBatchDirect()
protected abstract TupleBatch
RelationalNode. nextBatchDirect()
Template method for subclasses to implement.TupleBatch
SelectNode. nextBatchDirect()
TupleBatch
SortNode. nextBatchDirect()
protected TupleBatch
TextTableNode. nextBatchDirect()
TupleBatch
UnionAllNode. nextBatchDirect()
protected TupleBatch
WindowFunctionProjectNode. nextBatchDirect()
protected TupleBatch
JoinNode. nextBatchDirectInternal()
TupleBatch
UnionAllNode. nextBatchDirectInternal()
protected Command
AccessNode. nextCommand()
protected Command
DependentAccessNode. nextCommand()
List<TupleBuffer>
SortUtility. onePassSort(boolean lowLatency)
void
AccessNode. open()
void
BatchedUpdateNode. open()
void
DependentProcedureAccessNode. open()
void
DependentProcedureExecutionNode. open()
void
DupRemoveNode. open()
void
JoinNode. open()
void
LimitNode. open()
void
ObjectTableNode. open()
void
PlanExecutionNode. open()
void
RelationalNode. open()
void
RelationalPlan. open()
void
SelectNode. open()
void
TextTableNode. open()
void
UnionAllNode. open()
void
JoinNode. openInternal()
void
UnionAllNode. openInternal()
protected void
JoinStrategy. openLeft()
protected void
JoinStrategy. openRight()
protected void
NestedTableJoinStrategy. openRight()
Criteria
DependentCriteriaProcessor. prepareCriteria()
protected boolean
AccessNode. prepareNextCommand(Command atomicCommand)
protected boolean
DependentAccessNode. prepareNextCommand(Command atomicCommand)
protected boolean
DependentProcedureAccessNode. prepareNextCommand(Command atomicCommand)
protected boolean
DependentProcedureCriteriaProcessor. prepareNextCommand(VariableContext context)
protected boolean
DependentProcedureExecutionNode. prepareNextCommand()
protected boolean
InsertPlanExecutionNode. prepareNextCommand()
protected boolean
PlanExecutionNode. prepareNextCommand()
protected void
EnhancedSortMergeJoinStrategy. process()
protected abstract void
JoinStrategy. process()
protected void
MergeJoinStrategy. process()
protected void
NestedTableJoinStrategy. process()
TupleBuffer
SortUtility. sort()
TupleBuffer
SortUtility. sort(int rowLimit)
static void
RelationalNode. unwrapException(TeiidRuntimeException e)
-
Uses of TeiidProcessingException in org.teiid.query.rewriter
Methods in org.teiid.query.rewriter that throw TeiidProcessingException Modifier and Type Method Description static Command
QueryRewriter. createDeleteProcedure(Delete delete, QueryMetadataInterface metadata, CommandContext context)
static Command
QueryRewriter. createUpdateProcedure(Update update, QueryMetadataInterface metadata, CommandContext context)
static Command
QueryRewriter. evaluateAndRewrite(Command command, Evaluator eval, CommandContext context, QueryMetadataInterface metadata)
static Criteria
QueryRewriter. evaluateAndRewrite(Criteria criteria, Evaluator eval, CommandContext context, QueryMetadataInterface metadata)
static Command
QueryRewriter. rewrite(Command command, QueryMetadataInterface metadata, CommandContext context)
static Command
QueryRewriter. rewrite(Command command, QueryMetadataInterface metadata, CommandContext context, Map<ElementSymbol,Expression> variableValues)
static Command
QueryRewriter. rewriteAsUpsertProcedure(Insert insert, QueryMetadataInterface metadata, CommandContext context)
static Criteria
QueryRewriter. rewriteCriteria(Criteria criteria, CommandContext context, QueryMetadataInterface metadata)
Rewrite the criteria by evaluating some trivial cases.static Expression
QueryRewriter. rewriteExpression(Expression expression, CommandContext context, QueryMetadataInterface metadata)
static Expression
QueryRewriter. rewriteExpression(Expression expression, CommandContext context, QueryMetadataInterface metadata, boolean rewriteSubcommands)
QueryCommand
QueryRewriter. rewriteOrderBy(QueryCommand queryCommand)
Rewrite the order by clause.static void
QueryRewriter. rewriteOrderBy(QueryCommand queryCommand, OrderBy orderBy, List projectedSymbols, CommandContext context, QueryMetadataInterface metadata)
-
Uses of TeiidProcessingException in org.teiid.query.sql.lang
Methods in org.teiid.query.sql.lang that throw TeiidProcessingException Modifier and Type Method Description void
XMLTable. compileXqueryExpression()
-
Uses of TeiidProcessingException in org.teiid.query.sql.symbol
Methods in org.teiid.query.sql.symbol that throw TeiidProcessingException Modifier and Type Method Description static <T> String[]
TextLine. evaluate(List<T> values, TextLine.ValueExtractor<T> valueExtractor, TextLine textLine)
-
Uses of TeiidProcessingException in org.teiid.query.sql.util
Methods in org.teiid.query.sql.util that throw TeiidProcessingException Modifier and Type Method Description Set<Object>
ValueIteratorSource. getCachedSet(Expression valueExpression)
-
Uses of TeiidProcessingException in org.teiid.query.tempdata
Methods in org.teiid.query.tempdata that throw TeiidProcessingException Modifier and Type Method Description TempTable
GlobalTableStore. createMatTable(String tableName, GroupSymbol group)
TempTable
GlobalTableStoreImpl. createMatTable(String tableName, GroupSymbol group)
TupleSource
TempTable. createTupleSource(List<? extends Expression> projectedCols, Criteria condition, OrderBy orderBy)
protected abstract TupleSource
TempTableDataManager.ProxyTupleSource. createTupleSource()
TupleSource
TempTable. delete(Criteria crit)
TempMetadataID
GlobalTableStore. getGlobalTempTableMetadataId(Object groupID)
TempMetadataID
GlobalTableStoreImpl. getGlobalTempTableMetadataId(Object viewId)
TupleSource
TempTable. insert(TupleSource tuples, List<ElementSymbol> variables, boolean canUndo, boolean upsert, CommandContext context)
Object
TempTableDataManager. lookupCodeValue(CommandContext context, String codeTableName, String returnElementName, String keyElementName, Object keyValue)
List<?>
TempTableDataManager.ProxyTupleSource. nextTuple()
TempTable
TempTableStore.RecursiveTableProcessor. process(TempTable tempTable)
TempTable
TempTableStore.TableProcessor. process(TempTable tempTable)
Ensure the temp table is ready for use.TupleSource
TempTableDataManager. registerRequest(CommandContext context, Command command, String modelName, RegisterRequestParameter parameterObject)
void
TempTableStore. removeTempTableByName(String tempTableName, CommandContext context)
TupleSource
TempTable. update(Criteria crit, SetClauseList update)
-
Uses of TeiidProcessingException in org.teiid.xquery.saxon
Methods in org.teiid.xquery.saxon that throw TeiidProcessingException Modifier and Type Method Description XMLType
SaxonXQueryExpression. createXMLType(net.sf.saxon.om.SequenceIterator iter, BufferManager bufferManager, boolean emptyOnEmpty, CommandContext context)
static SaxonXQueryExpression.Result
XQueryEvaluator. evaluateXQuery(SaxonXQueryExpression xquery, Object context, Map<String,Object> parameterValues, SaxonXQueryExpression.RowProcessor processor, CommandContext commandContext)
boolean
XMLHelperImpl. isValidNCName(String prefix)
protected TupleBatch
SaxonXMLTableNode. nextBatchDirect()
void
SaxonXMLTableNode. open()
static String[]
XMLFunctions. validateQName(String name)
String[]
XMLHelperImpl. validateQName(String name)
static void
XMLFunctions. validateXpath(String xpath)
Validate whether the XPath is a valid XPath.void
XMLHelperImpl. validateXpath(String xpath)
static String
XMLFunctions. xpathValue(Object doc, String xpath)
-