Modifier and Type | Method and Description |
---|---|
static void |
ConnectorWorkItem.initLanguageBridgeFactory(LanguageBridgeFactory factory,
CommandContext context,
SourceCapabilities capabilities) |
void |
LanguageBridgeFactory.setCommandContext(CommandContext commandContext) |
Constructor and Description |
---|
ExecutionContextImpl(CommandContext commandContext,
String connectorName,
String partId,
String execCount,
ConnectorWorkItem workItem) |
Modifier and Type | Field and Description |
---|---|
protected CommandContext |
Request.context |
Modifier and Type | Method and Description |
---|---|
QueryProcessor |
QueryProcessorFactoryImpl.createQueryProcessor(String query,
String recursionGroup,
CommandContext commandContext,
Object... params) |
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) |
boolean |
DefaultAuthorizationValidator.hasRole(String roleName,
CommandContext commandContext) |
boolean |
AuthorizationValidator.hasRole(String roleName,
CommandContext commandContext)
Uses the context or other information to determine if the current user has the given role name.
|
void |
ExplainProcessPlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr) |
boolean |
DefaultAuthorizationValidator.isAccessible(AbstractMetadataRecord record,
CommandContext commandContext) |
boolean |
AuthorizationValidator.isAccessible(AbstractMetadataRecord record,
CommandContext commandContext)
Determines if the metadata record is accessible in system queries
|
Object |
DataTierManagerImpl.lookupCodeValue(CommandContext context,
String codeTableName,
String returnElementName,
String keyElementName,
Object keyValue) |
TupleSource |
DataTierManagerImpl.registerRequest(CommandContext context,
Command command,
String modelName,
RegisterRequestParameter parameterObject) |
static void |
PreparedStatementRequest.resolveParameterValues(List<Reference> params,
List values,
CommandContext context,
QueryMetadataInterface metadata) |
void |
PreparedPlan.setPlan(ProcessorPlan planValue,
CommandContext context)
Set the ProcessorPlan.
|
boolean |
DefaultAuthorizationValidator.validate(String[] originalSql,
Command command,
QueryMetadataInterface metadata,
CommandContext commandContext,
AuthorizationValidator.CommandType commandType) |
boolean |
AuthorizationValidator.validate(String[] originalSql,
Command command,
QueryMetadataInterface metadata,
CommandContext commandContext,
AuthorizationValidator.CommandType commandType)
Validates the given command.
|
Modifier and Type | Method and Description |
---|---|
CommandContext |
AtomicRequestMessage.getCommandContext() |
Modifier and Type | Method and Description |
---|---|
void |
AtomicRequestMessage.setCommandContext(CommandContext commandContext) |
Modifier and Type | Field and Description |
---|---|
protected CommandContext |
Evaluator.context |
Modifier and Type | Method and Description |
---|---|
void |
Evaluator.initialize(CommandContext context,
ProcessorDataManager dataMgr) |
static JsonType |
Evaluator.jsonArray(CommandContext context,
Function f,
Object[] vals,
JSONFunctionMethods.JSONBuilder builder,
Evaluator eval,
List<?> tuple) |
Constructor and Description |
---|
Evaluator(Map elements,
ProcessorDataManager dataMgr,
CommandContext context) |
Modifier and Type | Method and Description |
---|---|
static ClobType |
GeometryFunctionMethods.asGml(CommandContext context,
GeometryType geometry) |
static ClobType |
GeometryFunctionMethods.asKml(CommandContext context,
GeometryType geometry) |
JsonType |
JSONFunctionMethods.JSONBuilder.close(CommandContext cc) |
static Object |
FunctionMethods.commandPayload(CommandContext context) |
static Object |
FunctionMethods.commandPayload(CommandContext context,
String param) |
static ClobType |
FunctionMethods.concat(CommandContext context,
ClobType str1,
ClobType str2) |
static ClobType |
FunctionMethods.concat2(CommandContext context,
ClobType str1,
ClobType str2) |
static Object |
FunctionMethods.convert(CommandContext context,
Object src,
String type) |
static Object |
FunctionMethods.current_database(CommandContext context) |
static Time |
FunctionMethods.current_time(CommandContext context,
int precision) |
static Timestamp |
FunctionMethods.current_timestamp(CommandContext context,
int precision) |
static Object |
FunctionMethods.currentDate(CommandContext context) |
static Object |
FunctionMethods.currentTime(CommandContext context) |
static Object |
FunctionMethods.currentTimestamp(CommandContext context) |
static String |
FunctionMethods.format(CommandContext context,
Date date,
String format) |
static String |
FunctionMethods.format(CommandContext context,
Number number,
String format) |
static Long |
SystemFunctionMethods.generated_key(CommandContext context) |
static Object |
SystemFunctionMethods.generated_key(CommandContext context,
String column) |
static GeographyType |
GeographyFunctionMethods.geogFromBlob(CommandContext context,
BlobType wkb) |
static GeographyType |
GeographyFunctionMethods.geogFromText(CommandContext ctx,
ClobType wkt) |
static Object |
FunctionDescriptor.importValue(Object result,
Class<?> expectedType,
CommandContext context) |
Object |
FunctionDescriptor.invokeFunction(Object[] values,
CommandContext context,
Object functionTarget)
Invoke the function described in the function descriptor, using the
values provided.
|
static JsonType |
JSONFunctionMethods.jsonArray(CommandContext context,
Object... vals) |
static Object |
FunctionMethods.modifyTimeZone(CommandContext context,
Timestamp value,
String targetTimezoneString) |
static int |
FunctionMethods.mvstatus(CommandContext context,
String schemaName,
String viewName) |
static BigDecimal |
FunctionMethods.parseBigDecimal(CommandContext context,
String number,
String format) |
static Object |
FunctionMethods.parseBigInteger(CommandContext context,
String number,
String format) |
static Object |
FunctionMethods.parseDouble(CommandContext context,
String number,
String format) |
static Object |
FunctionMethods.parseFloat(CommandContext context,
String number,
String format) |
static Object |
FunctionMethods.parseInteger(CommandContext context,
String number,
String format) |
static Object |
FunctionMethods.parseLong(CommandContext context,
String number,
String format) |
static Timestamp |
FunctionMethods.parseTimestamp(CommandContext context,
String timestamp,
String format) |
static Object |
FunctionMethods.rand(CommandContext context) |
static Object |
FunctionMethods.rand(CommandContext context,
Integer seed) |
static String |
FunctionMethods.regexpReplace(CommandContext context,
CharSequence source,
String regex,
String replacement,
String flags)
Perform find-replace operation on a string using regular expressions.
|
static ClobType |
FunctionMethods.regexpReplace(CommandContext context,
ClobType source,
String regex,
String replacement) |
static ClobType |
FunctionMethods.regexpReplace(CommandContext context,
ClobType source,
String regex,
String replacement,
String flags) |
static String |
FunctionMethods.regexpReplace(CommandContext context,
String source,
String regex,
String replacement)
Perform find-replace operation on a string using regular expressions.
|
static String |
FunctionMethods.regexpReplace(CommandContext context,
String source,
String regex,
String replacement,
String flags) |
static Object |
FunctionMethods.session_id(CommandContext context) |
static Object |
SystemFunctionMethods.teiid_session_get(CommandContext context,
String key) |
static Object |
SystemFunctionMethods.teiid_session_set(CommandContext context,
String key,
Object value) |
static Object |
FunctionMethods.user(CommandContext context) |
static Object |
FunctionMethods.user(CommandContext context,
boolean includeSecurityDomain) |
Modifier and Type | Method and Description |
---|---|
void |
AggregateFunction.addInput(List<?> tuple,
CommandContext commandContext) |
void |
NthValue.addInput(List<?> tuple,
CommandContext commandContext,
long startFrame,
long endFrame,
TupleBuffer frame) |
void |
UserDefined.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
StringAgg.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
SingleArgumentAggregateFunction.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
RankingFunctionBig.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
RankingFunction.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
NthValue.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
LeadLagValue.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
CountBig.addInputDirect(List<?> tuple,
CommandContext commandContext) |
void |
Count.addInputDirect(List<?> tuple,
CommandContext commandContext) |
abstract void |
AggregateFunction.addInputDirect(List<?> tuple,
CommandContext commandContext)
Called for the element value in every row of a group.
|
void |
XMLAgg.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
TextAgg.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
Sum.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
StatsFunction.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
abstract void |
SingleArgumentAggregateFunction.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
Ntile.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
Min.addInputDirect(Object value,
List<?> tuple,
CommandContext commandContext) |
void |
Max.addInputDirect(Object value,
List<?> tuple,
CommandContext commandContext) |
void |
JSONArrayAgg.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
FirstLastValue.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
ConstantFunction.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
Avg.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
void |
ArrayAgg.addInputDirect(Object input,
List<?> tuple,
CommandContext commandContext) |
Object |
XMLAgg.getResult(CommandContext commandContext) |
Object |
UserDefined.getResult(CommandContext commandContext) |
Object |
TextAgg.getResult(CommandContext commandContext) |
Object |
Sum.getResult(CommandContext commandContext) |
Object |
StringAgg.getResult(CommandContext commandContext) |
Object |
StatsFunction.getResult(CommandContext commandContext) |
Object |
RankingFunctionBig.getResult(CommandContext commandContext) |
Object |
RankingFunction.getResult(CommandContext commandContext) |
Object |
Ntile.getResult(CommandContext commandContext) |
Object |
NthValue.getResult(CommandContext commandContext) |
Object |
Min.getResult(CommandContext commandContext) |
Object |
Max.getResult(CommandContext commandContext) |
Object |
LeadLagValue.getResult(CommandContext commandContext) |
Object |
JSONArrayAgg.getResult(CommandContext commandContext) |
Object |
FirstLastValue.getResult(CommandContext commandContext) |
Object |
CountBig.getResult(CommandContext commandContext) |
Object |
Count.getResult(CommandContext commandContext) |
Object |
ConstantFunction.getResult(CommandContext commandContext) |
Object |
Avg.getResult(CommandContext commandContext) |
Object |
ArrayAgg.getResult(CommandContext commandContext) |
abstract Object |
AggregateFunction.getResult(CommandContext commandContext)
Called after all values have been processed to get the result.
|
Modifier and Type | Method and Description |
---|---|
XMLType |
XMLSystemFunctions.XmlConcat.close(CommandContext context) |
Object |
XMLHelper.evaluate(XMLType val,
XMLCast expression,
CommandContext context) |
Object |
XMLHelper.evaluateXMLQuery(List<?> tuple,
XMLQuery xmlQuery,
boolean exists,
Map<String,Object> parameters,
CommandContext context) |
static boolean |
SecuritySystemFunctions.hasRole(CommandContext context,
String roleName) |
static boolean |
SecuritySystemFunctions.hasRole(CommandContext context,
String roleType,
String roleName) |
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 memory
|
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) |
static ClobType |
XMLSystemFunctions.xslTransform(CommandContext context,
Object xml,
Object styleSheet) |
Modifier and Type | Method and Description |
---|---|
void |
SourceTriggerActionPlanner.CompositeProcessorPlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr) |
ProcessorPlan |
SourceTriggerActionPlanner.optimize(Command command,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context) |
ProcessorPlan |
ProcedurePlanner.optimize(Command procCommand,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context)
Produce a ProcessorPlan for the CreateUpdateProcedureCommand on the current node
of the CommandTreeNode, the procedure plan construction involves using the child
processor plans.
|
ProcessorPlan |
DdlPlanner.optimize(Command command,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context) |
ProcessorPlan |
CommandPlanner.optimize(Command command,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context)
Allows the planner a chance to optimize the canonical plan(s) stored in
the CommandTreeNode tree.
|
ProcessorPlan |
BatchedUpdatePlanner.optimize(Command command,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context)
Optimizes batched updates by batching all contiguous commands that relate to the same physical model.
|
ProcessorPlan |
TriggerActionPlanner.optimize(ProcedureContainer userCommand,
TriggerAction ta,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context) |
static ProcessorPlan |
QueryOptimizer.optimizePlan(Command command,
QueryMetadataInterface metadata,
IDGenerator idGenerator,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context) |
Modifier and Type | Method and Description |
---|---|
static boolean |
RowBasedSecurityHelper.applyRowSecurity(QueryMetadataInterface metadata,
GroupSymbol group,
CommandContext cc) |
static SymbolMap |
RelationalPlanner.buildGroupingNode(Collection<AggregateSymbol> aggs,
List<? extends Expression> groupingCols,
PlanNode groupNode,
CommandContext cc,
IDGenerator idGenerator)
Build a grouping node that introduces a anon group (without a inline view source node)
|
PlanNode |
OptimizerRule.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
static Criteria |
RowBasedSecurityHelper.getRowBasedFilters(QueryMetadataInterface metadata,
GroupSymbol group,
CommandContext cc,
boolean constraintsOnly) |
void |
RelationalPlanner.initialize(Command command,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context) |
static List<? extends Expression> |
ColumnMaskingHelper.maskColumns(List<ElementSymbol> cols,
GroupSymbol group,
QueryMetadataInterface metadata,
CommandContext cc) |
Constructor and Description |
---|
PlanToProcessConverter(QueryMetadataInterface metadata,
IDGenerator idGenerator,
AnalysisRecord analysisRecord,
CapabilitiesFinder capFinder,
CommandContext context) |
Modifier and Type | Method and Description |
---|---|
static NewCalculateCostUtil.DependentCostAnalysis |
NewCalculateCostUtil.computeCostForDepJoin(PlanNode joinNode,
boolean leftIndependent,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
CommandContext context)
Computes the cost of a Dependent Join
The worst possible cost will arise from a high independent ndv (many dependent sets) and a low dependent ndv (possibly many matches per set)
This logic uses the same assumption as criteria in that ndv is used as a divisor of cardinality.
|
static NewCalculateCostUtil.DependentCostAnalysis |
NewCalculateCostUtil.computeCostForDepJoin(PlanNode independentNode,
PlanNode dependentNode,
List independentExpressions,
List dependentExpressions,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
CommandContext context) |
PlanNode |
RuleDecomposeJoin.decomposeJoin(PlanNode joinNode,
PlanNode root,
QueryMetadataInterface metadata,
CommandContext context) |
PlanNode |
RulePushLargeIn.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePushAggregates.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext ctx) |
PlanNode |
RulePlanUnions.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePlanSubqueries.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePlanSorts.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePlanProcedures.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePlanOuterJoins.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePlanJoins.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePlaceAccess.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleMergeVirtual.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleMergeCriteria.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleImplementJoinStrategy.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleDecomposeJoin.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleCopyCriteria.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context)
Execute the rule as described in the class comments.
|
PlanNode |
RuleCollapseSource.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleCleanCriteria.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleChooseJoinStrategy.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleChooseDependent.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleCalculateCost.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleAssignOutputElements.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context)
Execute the rule.
|
PlanNode |
RuleApplySecurity.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleAccessPatternValidation.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleValidateWhereAll.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context)
Verifies that a model with "supports where all" is being passed an atomic
query with a criteria.
|
PlanNode |
RuleSubstituteExpressions.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleRemoveOptionalJoins.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleRaiseNull.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RuleRaiseAccess.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
PlanNode |
RulePushSelectCriteria.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context)
Execute the rule as described in the class comments.
|
PlanNode |
RulePushNonJoinCriteria.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context)
Execute the rule as described in the class comments.
|
PlanNode |
RulePushLimit.execute(PlanNode plan,
QueryMetadataInterface metadata,
CapabilitiesFinder capabilitiesFinder,
RuleStack rules,
AnalysisRecord analysisRecord,
CommandContext context) |
Constructor and Description |
---|
RulePlanSubqueries(IDGenerator idGenerator,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
CommandContext |
QueryProcessor.getContext() |
CommandContext |
ProcessorPlan.getContext()
Get the processor context, which can be modified.
|
Modifier and Type | Method and Description |
---|---|
QueryProcessor |
QueryProcessor.ProcessorFactory.createQueryProcessor(String query,
String recursionGroup,
CommandContext commandContext,
Object... params) |
PreparedPlan |
QueryProcessor.ProcessorFactory.getPreparedPlan(String query,
String recursionGroup,
CommandContext commandContext,
QueryMetadataInterface metadata) |
void |
ProcessorPlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr)
Initialize the plan with some required pieces of data for making
queries.
|
void |
DdlPlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr) |
void |
BatchedUpdatePlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr) |
Object |
ProcessorDataManager.lookupCodeValue(CommandContext context,
String codeTableName,
String returnElementName,
String keyElementName,
Object keyValue)
Lookup a value from a cached code table.
|
TupleSource |
ProcessorDataManager.registerRequest(CommandContext context,
Command command,
String modelName,
RegisterRequestParameter parameterObject) |
void |
ProcessorPlan.setContext(CommandContext context) |
Constructor and Description |
---|
BatchCollector(BatchCollector.BatchProducer sourceNode,
BufferManager bm,
CommandContext context,
boolean forwardOnly) |
QueryProcessor(ProcessorPlan plan,
CommandContext context,
BufferManager bufferMgr,
ProcessorDataManager dataMgr)
Construct a processor with all necessary information to process.
|
Modifier and Type | Method and Description |
---|---|
CommandContext |
ProcedurePlan.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
ProcedurePlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager buffer) |
void |
ForEachRowPlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr) |
Object |
ProcedurePlan.lookupCodeValue(CommandContext context,
String codeTableName,
String returnElementName,
String keyElementName,
Object keyValue) |
TupleSource |
ProcedurePlan.registerRequest(CommandContext context,
Command command,
String modelName,
RegisterRequestParameter parameterObject) |
Modifier and Type | Method and Description |
---|---|
CommandContext |
RelationalNode.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
SortingFilter.addInputDirect(List<?> tuple,
CommandContext commandContext) |
protected void |
GroupingNode.closeGroup(int colDiff,
boolean reset,
CommandContext context) |
Object |
SortingFilter.getResult(CommandContext commandContext) |
void |
RelationalNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
ObjectTableNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
JoinNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
GroupingNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
ArrayTableNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
AccessNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
WindowFunctionProjectNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
UnionAllNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
TextTableNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
SelectNode.initialize(CommandContext context,
BufferManager bufferManager,
ProcessorDataManager dataMgr) |
void |
RelationalPlan.initialize(CommandContext context,
ProcessorDataManager dataMgr,
BufferManager bufferMgr) |
void |
RelationalNode.setContext(CommandContext context) |
static void |
DependentProcedureExecutionNode.shareVariableContext(RelationalNode node,
CommandContext context) |
Constructor and Description |
---|
SubqueryAwareEvaluator(Map elements,
ProcessorDataManager dataMgr,
CommandContext context,
BufferManager manager) |
Modifier and Type | Method and Description |
---|---|
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) |
TupleSource |
TempTableDataManager.registerRequest(CommandContext context,
Command command,
String modelName,
RegisterRequestParameter parameterObject) |
void |
TempTableStore.removeTempTableByName(String tempTableName,
CommandContext context) |
Modifier and Type | Method and Description |
---|---|
CommandContext |
CommandContext.clone() |
static CommandContext |
CommandContext.getThreadLocalContext() |
Modifier and Type | Method and Description |
---|---|
static SimpleDateFormat |
CommandContext.getDateFormat(CommandContext context,
String format) |
static DecimalFormat |
CommandContext.getDecimalFormat(CommandContext context,
String format) |
static Pattern |
CommandContext.getPattern(CommandContext context,
String regex,
int flags)
Compile a regular expression into a
Pattern and cache it in
the CommandContext for future use. |
static void |
CommandContext.pushThreadLocalContext(CommandContext context) |
Constructor and Description |
---|
GeneratedKeysImpl(String[] colNames,
Class<?>[] types,
CommandContext commandContext) |
Copyright © 2020. All rights reserved.