Modifier and Type | Method and Description |
---|---|
QueryMetadataInterface |
RuntimeMetadataImpl.getMetadata() |
Constructor and Description |
---|
LanguageBridgeFactory(QueryMetadataInterface metadata) |
RuntimeMetadataImpl(QueryMetadataInterface metadata) |
Modifier and Type | Field and Description |
---|---|
protected QueryMetadataInterface |
Request.metadata |
Modifier and Type | Method and Description |
---|---|
Command |
CachedResults.getCommand(String sql,
QueryMetadataInterface metadata,
ParseInfo info) |
PreparedPlan |
QueryProcessorFactoryImpl.getPreparedPlan(String query,
String recursionGroup,
CommandContext commandContext,
QueryMetadataInterface metadata) |
static void |
PreparedStatementRequest.resolveParameterValues(List<Reference> params,
List values,
CommandContext context,
QueryMetadataInterface metadata) |
static void |
MetaDataProcessor.setColumnMetadata(Column column,
Expression symbol,
QueryMetadataInterface metadata)
Set the easily determined metadata from symbol on the given Column
|
static void |
MetaDataProcessor.updateMetadataAcrossBranches(SetQuery originalCommand,
List<Column> columns,
QueryMetadataInterface metadata) |
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.
|
static void |
Request.validateWithVisitor(AbstractValidationVisitor visitor,
QueryMetadataInterface metadata,
Command command) |
Constructor and Description |
---|
QueryProcessorFactoryImpl(BufferManager bufferMgr,
ProcessorDataManager dataMgr,
CapabilitiesFinder finder,
IDGenerator idGenerator,
QueryMetadataInterface metadata) |
Modifier and Type | Class and Description |
---|---|
class |
MultiSourceMetadataWrapper
This class is a proxy to QueryMetadataInterface.
|
Modifier and Type | Method and Description |
---|---|
protected QueryMetadataInterface |
MultiSourceMetadataWrapper.createDesignTimeMetadata() |
Modifier and Type | Method and Description |
---|---|
static void |
MultiSourceElementReplacementVisitor.visit(String bindingName,
QueryMetadataInterface metadata,
Command processingCommand) |
Constructor and Description |
---|
MultiSourceElementReplacementVisitor(String bindingName,
QueryMetadataInterface metadata) |
MultiSourceMetadataWrapper(QueryMetadataInterface actualMetadata,
Map<String,String> multiSourceModels) |
MultiSourceMetadataWrapper(QueryMetadataInterface metadata,
Set<String> multiSourceModels) |
Modifier and Type | Class and Description |
---|---|
class |
BasicQueryMetadata
This is an abstract implementation of the metadata interface.
|
class |
BasicQueryMetadataWrapper |
class |
TempMetadataAdapter
This is an adapter class, it contains another instance of
QueryMetadataInterface as well as a TempMetadataStore.
|
class |
TransformationMetadata
Teiid's implementation of the QueryMetadataInterface that reads columns, groups, models etc.
|
Modifier and Type | Field and Description |
---|---|
protected QueryMetadataInterface |
BasicQueryMetadataWrapper.actualMetadata |
protected QueryMetadataInterface |
BasicQueryMetadataWrapper.designTimeMetadata |
Modifier and Type | Method and Description |
---|---|
protected QueryMetadataInterface |
TempMetadataAdapter.createDesignTimeMetadata() |
protected QueryMetadataInterface |
BasicQueryMetadataWrapper.createDesignTimeMetadata() |
QueryMetadataInterface |
QueryMetadataInterface.getDesignTimeMetadata()
Get the metadata without visibility and session tables
|
QueryMetadataInterface |
BasicQueryMetadataWrapper.getDesignTimeMetadata() |
QueryMetadataInterface |
BasicQueryMetadata.getDesignTimeMetadata() |
QueryMetadataInterface |
TempMetadataAdapter.getMetadata() |
QueryMetadataInterface |
TempMetadataAdapter.getSessionMetadata() |
QueryMetadataInterface |
QueryMetadataInterface.getSessionMetadata() |
QueryMetadataInterface |
BasicQueryMetadataWrapper.getSessionMetadata() |
QueryMetadataInterface |
BasicQueryMetadata.getSessionMetadata() |
Modifier and Type | Method and Description |
---|---|
void |
MetadataValidator.validate(VDBMetaData vdb,
ModelMetaData model,
AbstractMetadataRecord record,
ValidatorReport report,
QueryMetadataInterface metadata,
MetadataFactory mf,
QueryParser parser) |
Constructor and Description |
---|
BasicQueryMetadataWrapper(QueryMetadataInterface actualMetadata) |
TempMetadataAdapter(QueryMetadataInterface metadata,
TempMetadataStore tempStore) |
TempMetadataAdapter(QueryMetadataInterface metadata,
TempMetadataStore tempStore,
Map<Object,Object> materializationTables,
Map<Object,QueryNode> queryNodes) |
Modifier and Type | Method and Description |
---|---|
static boolean |
BatchedUpdatePlanner.isEligibleForBatching(Command command,
QueryMetadataInterface metadata)
Returns whether a command can be placed in a connector batch
|
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 | Field and Description |
---|---|
protected QueryMetadataInterface |
PlanToProcessConverter.metadata |
Modifier and Type | Method and Description |
---|---|
static boolean |
RowBasedSecurityHelper.applyRowSecurity(QueryMetadataInterface metadata,
GroupSymbol group,
CommandContext cc) |
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) |
static Object |
RelationalPlanner.getTrackableGroup(GroupSymbol group,
QueryMetadataInterface metadata) |
void |
RelationalPlanner.initialize(Command command,
IDGenerator idGenerator,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context) |
static boolean |
RelationalPlanner.isNoCacheGroup(QueryMetadataInterface metadata,
Object metadataID,
Option option) |
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 |
---|---|
void |
PlanNode.recordDebugAnnotation(String annotation,
Object modelID,
String resolution,
AnalysisRecord record,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
static LinkedHashMap<ElementSymbol,Expression> |
FrameUtil.buildSymbolMap(GroupSymbol oldGroup,
GroupSymbol newGroup,
QueryMetadataInterface metadata)
creates a symbol map of elements in oldGroup mapped to corresponding elements in newGroup
if newGroup is null, then a mapping of oldGroup elements to null constants will be returned
|
static boolean |
CriteriaCapabilityValidatorVisitor.canPushLanguageObject(LanguageObject obj,
Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord) |
static boolean |
CriteriaCapabilityValidatorVisitor.canPushLanguageObject(LanguageObject obj,
Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CriteriaCapabilityValidatorVisitor.ValidatorOptions parameterObject) |
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) |
static void |
FrameUtil.convertFrame(PlanNode startNode,
GroupSymbol oldGroup,
Set<GroupSymbol> newGroups,
Map symbolMap,
QueryMetadataInterface metadata) |
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) |
static String |
RuleAssignOutputElements.findFunctionTarget(Function function,
FunctionDescriptor fd,
CapabilitiesFinder capabiltiesFinder,
QueryMetadataInterface metadata)
Find the first schema name against which this function can be executed, or null for no target
|
static ExecutionFactory.NullOrder |
CapabilitiesUtil.getDefaultNullOrder(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static PlanNode |
RuleChooseDependent.getDependentCriteriaNode(String id,
List<Expression> independentExpressions,
List<Expression> dependentExpressions,
PlanNode indNode,
QueryMetadataInterface metadata,
NewCalculateCostUtil.DependentCostAnalysis dca,
Boolean bound,
Option.MakeDep makeDep) |
static int |
CapabilitiesUtil.getIntProperty(SourceCapabilities.Capability cap,
Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder)
Values are expected to be non-negative except for unknown/invalid = -1
|
static Object |
NewCalculateCostUtil.getKeyUsed(Collection<? extends Expression> allElements,
Set<GroupSymbol> groups,
QueryMetadataInterface metadata,
Boolean unique) |
static int |
CapabilitiesUtil.getMaxDependentPredicates(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static int |
CapabilitiesUtil.getMaxFromGroups(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static int |
CapabilitiesUtil.getMaxInCriteriaSize(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static int |
CapabilitiesUtil.getMaxProjectedColumns(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static Object |
CapabilitiesUtil.getProperty(SourceCapabilities.Capability cap,
Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static ExecutionFactory.SupportedJoinCriteria |
CapabilitiesUtil.getSupportedJoinCriteria(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
RulePlanSubqueries.isDistinct(Query query,
List<Expression> expressions,
QueryMetadataInterface metadata) |
static boolean |
JoinUtil.isNullDependent(QueryMetadataInterface metadata,
Collection<GroupSymbol> innerGroups,
Criteria crit)
Returns true if the given criteria can be anything other than false (or unknown)
given all null values for elements in the inner groups
|
static boolean |
JoinUtil.isNullDependent(QueryMetadataInterface metadata,
Collection<GroupSymbol> innerGroups,
Expression expr) |
static boolean |
CapabilitiesUtil.isSameConnector(Object modelID,
Object modelID1,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
RuleRaiseAccess.matchesForeignKey(QueryMetadataInterface metadata,
Collection<Object> leftIds,
Collection<Object> rightIds,
GroupSymbol leftGroup,
boolean exact,
boolean inner) |
static boolean |
CapabilitiesUtil.requiresCriteria(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static Query |
RuleCollapseSource.rewriteGroupByAsView(Query query,
QueryMetadataInterface metadata,
boolean addViewForOrderBy) |
static boolean |
CapabilitiesUtil.supports(SourceCapabilities.Capability cap,
Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsAggregateFunction(Object modelID,
AggregateSymbol aggregate,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsAggregates(List groupCols,
Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsCaseExpression(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsGroupAliases(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsJoin(Object modelID,
JoinType joinType,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsOrderBy(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsRowLimit(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsRowOffset(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsScalarFunction(Object modelID,
Function function,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsSearchedCaseExpression(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsSelectDistinct(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsSelectExpression(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsSelfJoins(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsSetOp(Object modelID,
SetQuery.Operation setOp,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.supportsSetQueryOrderBy(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
CapabilitiesUtil.useAnsiJoin(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
static boolean |
NewCalculateCostUtil.usesKey(Collection<? extends Expression> allElements,
QueryMetadataInterface metadata)
TODO: this uses key check is not really accurate, it doesn't take into consideration where
we are in the plan.
|
static boolean |
NewCalculateCostUtil.usesKey(Collection<? extends Expression> allElements,
Set<GroupSymbol> groups,
QueryMetadataInterface metadata,
boolean unique) |
static boolean |
NewCalculateCostUtil.usesKey(Criteria crit,
QueryMetadataInterface metadata) |
static Object |
CriteriaCapabilityValidatorVisitor.validateCommandPushdown(Object critNodeModelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AccessNode aNode,
boolean considerConformed) |
static Object |
CriteriaCapabilityValidatorVisitor.validateSubqueryPushdown(SubqueryContainer<?> subqueryContainer,
Object critNodeModelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord)
Return null if the subquery cannot be pushed down, otherwise the model
id of the pushdown target.
|
Constructor and Description |
---|
CriteriaCapabilityValidatorVisitor(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder,
SourceCapabilities caps) |
RulePlanSubqueries(IDGenerator idGenerator,
CapabilitiesFinder capFinder,
AnalysisRecord analysisRecord,
CommandContext context,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
PreparedPlan |
QueryProcessor.ProcessorFactory.getPreparedPlan(String query,
String recursionGroup,
CommandContext commandContext,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
static void |
ProcedurePlan.checkNotNull(ElementSymbol param,
Object value,
QueryMetadataInterface metadata) |
void |
ProcedurePlan.setMetadata(QueryMetadataInterface metadata) |
Constructor and Description |
---|
ExecDynamicSqlInstruction(CreateProcedureCommand parentProcCommand,
DynamicCommand command,
QueryMetadataInterface metadata,
IDGenerator idGenerator,
CapabilitiesFinder capFinder,
boolean returnable) |
Constructor and Description |
---|
InsertPlanExecutionNode(int nodeID,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
static Command |
QueryResolver.expandCommand(ProcedureContainer proc,
QueryMetadataInterface metadata,
AnalysisRecord analysisRecord) |
Command |
ProcedureContainerResolver.expandCommand(ProcedureContainer procCommand,
QueryMetadataInterface metadata,
AnalysisRecord analysis)
Expand a command by finding and attaching all subcommands to the command.
|
static void |
ProcedureContainerResolver.findChildCommandMetadata(Command currentCommand,
GroupSymbol container,
int type,
QueryMetadataInterface metadata,
boolean inferProcedureResultSetColumns)
Set the appropriate "external" metadata for the given command
|
protected abstract String |
ProcedureContainerResolver.getPlan(QueryMetadataInterface metadata,
GroupSymbol group)
For a given resolver, this returns the unparsed command.
|
static UpdateValidator.UpdateInfo |
ProcedureContainerResolver.getUpdateInfo(GroupSymbol group,
QueryMetadataInterface metadata) |
static UpdateValidator.UpdateInfo |
ProcedureContainerResolver.getUpdateInfo(GroupSymbol group,
QueryMetadataInterface metadata,
int type,
boolean validate) |
Map<ElementSymbol,Expression> |
VariableResolver.getVariableValues(Command command,
boolean changingOnly,
QueryMetadataInterface metadata) |
static Map<ElementSymbol,Expression> |
QueryResolver.getVariableValues(Command command,
boolean changingOnly,
QueryMetadataInterface metadata) |
static boolean |
QueryResolver.isView(GroupSymbol virtualGroup,
QueryMetadataInterface qmi) |
static TempMetadataStore |
QueryResolver.resolveCommand(Command currentCommand,
GroupSymbol container,
int type,
QueryMetadataInterface metadata,
boolean inferProcedureResultSetColumns)
Resolve a command in a given type container and type context.
|
static TempMetadataStore |
QueryResolver.resolveCommand(Command command,
QueryMetadataInterface metadata)
This implements an algorithm to resolve all the symbols created by the
parser into real metadata IDs
|
static TempMetadataStore |
QueryResolver.resolveCommand(Command currentCommand,
QueryMetadataInterface metadata,
boolean resolveNullLiterals) |
static void |
QueryResolver.resolveCriteria(Criteria criteria,
QueryMetadataInterface metadata)
Resolve just a criteria.
|
static QueryNode |
QueryResolver.resolveView(GroupSymbol virtualGroup,
QueryNode qnode,
String cacheString,
QueryMetadataInterface qmi,
boolean logValidation) |
static void |
QueryResolver.validateProjectedSymbols(GroupSymbol virtualGroup,
QueryMetadataInterface qmi,
Command result) |
Modifier and Type | Method and Description |
---|---|
static List<ElementSymbol> |
InsertResolver.getAutoIncrementKey(Object metadataId,
List<ElementSymbol> columns,
QueryMetadataInterface metadata) |
protected String |
UpdateResolver.getPlan(QueryMetadataInterface metadata,
GroupSymbol group) |
protected String |
InsertResolver.getPlan(QueryMetadataInterface metadata,
GroupSymbol group) |
protected String |
ExecResolver.getPlan(QueryMetadataInterface metadata,
GroupSymbol group) |
protected String |
DeleteResolver.getPlan(QueryMetadataInterface metadata,
GroupSymbol group) |
Map<ElementSymbol,Expression> |
UpdateResolver.getVariableValues(Command command,
boolean changingOnly,
QueryMetadataInterface metadata) |
Map<ElementSymbol,Expression> |
InsertResolver.getVariableValues(Command command,
boolean changingOnly,
QueryMetadataInterface metadata) |
Modifier and Type | Field and Description |
---|---|
protected QueryMetadataInterface |
ResolverVisitor.metadata |
Modifier and Type | Method and Description |
---|---|
static void |
ResolverUtil.clearGroupInfo(GroupSymbol group,
QueryMetadataInterface metadata) |
static Expression |
ResolverUtil.convertExpression(Expression sourceExpression,
String targetTypeName,
QueryMetadataInterface metadata)
Replaces a sourceExpression with a conversion of the source expression
to the target type.
|
static Expression |
ResolverUtil.convertExpression(Expression sourceExpression,
String sourceTypeName,
String targetTypeName,
QueryMetadataInterface metadata,
boolean forComparison)
Replaces a sourceExpression with a conversion of the source expression
to the target type.
|
static void |
ResolverUtil.findKeyPreserved(FromClause clause,
Set<GroupSymbol> keyPreservingGroups,
QueryMetadataInterface metadata) |
static void |
ResolverUtil.findKeyPreserved(Query query,
Set<GroupSymbol> keyPreservingGroups,
QueryMetadataInterface metadata) |
static List<GroupSymbol> |
ResolverUtil.findMatchingGroups(String groupContext,
Collection<GroupSymbol> groups,
QueryMetadataInterface metadata) |
static List |
ResolverUtil.getAccessPatternElementsInGroups(QueryMetadataInterface metadata,
Collection groups,
boolean flatten)
When access patterns are flattened, they are an approximation the user
may need to enter as criteria.
|
static Expression |
ResolverUtil.getDefault(ElementSymbol symbol,
QueryMetadataInterface metadata)
Get the default value for the parameter, which could be null
if the parameter is set to NULLABLE.
|
static boolean |
ResolverUtil.hasDefault(Object mid,
QueryMetadataInterface metadata) |
static List<ElementSymbol> |
ResolverUtil.resolveElementsInGroup(GroupSymbol group,
QueryMetadataInterface metadata)
Returns the resolved elements in the given group.
|
static void |
ResolverUtil.resolveGroup(GroupSymbol symbol,
QueryMetadataInterface metadata) |
static void |
ResolverVisitor.resolveLanguageObject(LanguageObject obj,
Collection<GroupSymbol> groups,
GroupContext externalContext,
QueryMetadataInterface metadata) |
static void |
ResolverVisitor.resolveLanguageObject(LanguageObject obj,
Collection<GroupSymbol> groups,
QueryMetadataInterface metadata) |
static void |
ResolverVisitor.resolveLanguageObject(LanguageObject obj,
QueryMetadataInterface metadata) |
static ResolverUtil.ResolvedLookup |
ResolverUtil.resolveLookup(Function lookup,
QueryMetadataInterface metadata) |
Constructor and Description |
---|
ResolverVisitor(QueryMetadataInterface metadata,
Collection<GroupSymbol> internalGroups,
GroupContext externalContext)
Constructor for ResolveElementsVisitor.
|
Modifier and Type | Method and Description |
---|---|
static Command |
QueryRewriter.createDeleteProcedure(Delete delete,
QueryMetadataInterface metadata,
CommandContext context) |
static Query |
QueryRewriter.createInlineViewQuery(GroupSymbol inlineGroup,
Command nested,
QueryMetadataInterface metadata,
List<? extends Expression> actualSymbols) |
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 Criteria |
QueryRewriter.optimizeCriteria(CompoundCriteria criteria,
QueryMetadataInterface metadata)
Performs simple expression flattening
|
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) |
static void |
QueryRewriter.rewriteOrderBy(QueryCommand queryCommand,
OrderBy orderBy,
List projectedSymbols,
CommandContext context,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
static List<Expression> |
SetQuery.getTypedProjectedSymbols(List<? extends Expression> acutal,
List<Class<?>> projectedTypes,
QueryMetadataInterface metadata) |
void |
SetQuery.setProjectedTypes(List<Class<?>> projectedTypes,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
static SymbolMap |
SymbolMap.createSymbolMap(GroupSymbol virtualGroup,
List<? extends Expression> projectCols,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
static void |
CorrelatedReferenceCollectorVisitor.collectReferences(LanguageObject obj,
Collection<GroupSymbol> groupSymbols,
List<Reference> correlatedReferences,
QueryMetadataInterface metadata)
Helper to use this visitor.
|
static EvaluatableVisitor |
EvaluatableVisitor.needsEvaluationVisitor(Object modelID,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
Constructor and Description |
---|
EvaluatableVisitor(Object modelId,
QueryMetadataInterface metadata,
CapabilitiesFinder capFinder) |
Modifier and Type | Method and Description |
---|---|
static Create |
GlobalTableStoreImpl.getCreateCommand(GroupSymbol group,
boolean matview,
QueryMetadataInterface metadata) |
static List<ElementSymbol> |
GlobalTableStoreImpl.resolveIndex(QueryMetadataInterface metadata,
List<ElementSymbol> allColumns,
Object pk)
Return a list of ElementSymbols for the given index/key object
|
Constructor and Description |
---|
GlobalTableStoreImpl(BufferManager bufferManager,
VDBMetaData vdbMetaData,
QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
QueryMetadataInterface |
CommandContext.getMetadata() |
Modifier and Type | Method and Description |
---|---|
void |
CommandContext.setMetadata(QueryMetadataInterface metadata) |
Modifier and Type | Method and Description |
---|---|
protected QueryMetadataInterface |
AbstractValidationVisitor.getMetadata() |
Modifier and Type | Method and Description |
---|---|
void |
AbstractValidationVisitor.setMetadata(QueryMetadataInterface metadata) |
static ValidatorReport |
Validator.validate(LanguageObject object,
QueryMetadataInterface metadata) |
static ValidatorReport |
Validator.validate(LanguageObject object,
QueryMetadataInterface metadata,
AbstractValidationVisitor visitor) |
Constructor and Description |
---|
UpdateValidator(QueryMetadataInterface qmi,
UpdateValidator.UpdateType insertType,
UpdateValidator.UpdateType updateType,
UpdateValidator.UpdateType deleteType) |
Copyright © 2020. All rights reserved.