package
2.1.0-rc.2+incompatible
Repository: https://github.com/coderushing/tidb.git
Documentation: pkg.go.dev
# Packages
No description provided by the author
# Functions
BuildLogicalPlan used to build logical plan from ast.Node.
Cacheable checks whether the input ast is cacheable.
NewPSTMTPlanCacheKey creates a new pstmtPlanCacheKey object.
NewPSTMTPlanCacheValue creates a SQLCacheValue.
Optimize does optimization and creates a Plan.
PreparedPlanCacheEnabled returns whether the prepared plan cache is enabled.
Preprocess resolves table names of the node, and checks some statements validation.
SetPBColumnsDefaultValue sets the default values of tipb.ColumnInfos.
SetPreparedPlanCache sets isEnabled to true, then prepared plan cache is enabled.
SupportStreaming returns true if a pushed down operation supports using coprocessor streaming API.
ToString explains a Plan, returns description string.
# Constants
AntiLeftOuterSemiJoin means if row a in table A matches some rows in B, output (a, false), otherwise, output (a, true).
AntiSemiJoin means if row a in table A does not match any row in B, then output a.
CompleteAgg supposes its input is original results.
ErrExprInOrderBy is in order by items for the error of ErrFieldNotInGroupBy.
ErrExprInSelect is in select fields for the error of ErrFieldNotInGroupBy.
FinalAgg supposes its input is partial results.
InnerJoin means inner join.
LeftOuterJoin means left join.
LeftOuterSemiJoin means if row a in table A matches some rows in B, output (a, true), otherwise, output (a, false).
RightOuterJoin means right join.
SemiJoin means if row a in table A matches some rows in B, just output a.
StreamedAgg supposes its input is sorted by group by key.
TiDBHashJoin is hint enforce hash join.
TiDBIndexNestedLoopJoin is hint enforce index nested loop join.
TiDBMergeJoin is hint enforce merge join.
TypeAgg is the type of Aggregation.
TypeApply is the type of Apply.
TypeDelete is the type of Delete.
TypeDual is the type of TableDual.
TypeExists is the type of Exists.
TypeHashAgg is the type of HashAgg.
TypeHashLeftJoin is the type of left hash join.
TypeHashRightJoin is the type of right hash join.
TypeIdxScan is the type of IndexScan.
TypeIndexJoin is the type of index look up join.
TypeIndexLookUp is the type of IndexLookUp.
TypeIndexReader is the type of IndexReader.
TypeInsert is the type of Insert.
TypeJoin is the type of Join.
TypeLimit is the type of Limit.
TypeLock is the type of SelectLock.
TypeMaxOneRow is the type of MaxOneRow.
TypeMemTableScan is the type of TableScan.
TypeMergeJoin is the type of merge join.
TypeProj is the type of Projection.
TypeSel is the type of Selection.
TypeSet is the type of Set.
TypeShow is the type of show.
TypeSort is the type of Sort.
TypeStreamAgg is the type of StreamAgg.
TypeTableReader is the type of TableReader.
TypeTableScan is the type of TableScan.
TypeTopN is the type of TopN.
TypeUnion is the type of Union.
TypeUnionScan is the type of UnionScan.
TypeUpdate is the type of Update.
# Variables
AllowCartesianProduct means whether tidb allows cartesian join without equal conditions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
error definitions.
EvalSubquery evaluates incorrelated subqueries once.
PreparedPlanCacheCapacity stores the global config "prepared-plan-cache-capacity".
# Structs
AggregateFuncExtractor visits Expr tree.
Analyze represents an analyze plan.
AnalyzeColumnsTask is used for analyze columns.
AnalyzeIndexTask is used for analyze index.
ByItems wraps a "by" item.
CancelDDLJobs represents a cancel DDL jobs plan.
CheckIndex is used for checking index data, built from the 'admin check index' statement.
CheckIndexRange is used for checking index data, output the index values that handle within begin and end.
ChecksumTable is used for calculating table checksum, built from the `admin checksum table` statement.
CheckTable is used for checking table data, built from the 'admin check table' statement.
CleanupIndex is used to delete dangling index data.
DataSource represents a tablescan without condition push down.
DDL represents a DDL statement plan.
Deallocate represents deallocate plan.
Delete represents a delete plan.
ErrExprLoc is for generate the ErrFieldNotInGroupBy error info.
Execute represents prepare plan.
Explain represents a explain plan.
Insert represents an insert plan.
InsertGeneratedColumns is for completing generated columns in Insert.
LoadData represents a loaddata plan.
LoadStats represents a load stats plan.
LogicalAggregation represents an aggregate plan.
LogicalApply gets one row from outer executor and gets one row from inner executor according to outer row.
LogicalJoin is the logical join plan.
LogicalLimit represents offset and limit plan.
LogicalLock represents a select lock plan.
LogicalMaxOneRow checks if a query returns no more than one row.
LogicalProjection represents a select fields plan.
LogicalSelection represents a where or having predicate.
LogicalSort stands for the order by plan.
LogicalTableDual represents a dual table plan.
LogicalTopN represents a top-n plan.
LogicalUnionAll represents LogicalUnionAll plan.
LogicalUnionScan is only used in non read-only txn.
NominalSort asks sort properties for its child.
PhysicalApply represents apply plan, only used for subquery.
PhysicalHashAgg is hash operator of aggregate.
PhysicalHashJoin represents hash join for inner/ outer join.
PhysicalIndexJoin represents the plan of index look up join.
PhysicalIndexLookUpReader is the index look up reader in tidb.
PhysicalIndexReader is the index reader in tidb.
PhysicalIndexScan represents an index scan plan.
PhysicalLimit is the physical operator of Limit.
PhysicalLock is the physical operator of lock, which is used for `select ..
PhysicalMaxOneRow is the physical operator of maxOneRow.
PhysicalMemTable reads memory table.
PhysicalMergeJoin represents merge join for inner/ outer join.
PhysicalProjection is the physical operator of projection.
PhysicalSelection represents a filter.
PhysicalSort is the physical operator of sort, which implements a memory sort.
PhysicalStreamAgg is stream operator of aggregate.
PhysicalTableDual is the physical operator of dual.
PhysicalTableReader is the table reader in tidb.
PhysicalTableScan represents a table scan plan.
PhysicalTopN is the physical operator of topN.
PhysicalUnionAll is the physical operator of UnionAll.
PhysicalUnionScan represents a union scan operator.
PointGetPlan is a fast plan for simple point get.
Prepare represents prepare plan.
Prepared represents a prepared statement.
PSTMTPlanCacheValue stores the cached Statement and StmtNode.
RecoverIndex is used for backfilling corrupted index data.
Set represents a plan for set stmt.
Show represents a show plan.
ShowDDL is for showing DDL information.
ShowDDLJobQueries is for showing DDL job queries sql.
ShowDDLJobs is for showing DDL job list.
Simple represents a simple statement plan which doesn't need any optimization.
Trace represents a trace plan.
Update represents Update plan.
# Interfaces
LogicalPlan is a tree of logical operators.
PhysicalPlan is a tree of the physical operators.
Plan is the description of an execution flow.
# Type aliases
AggregationType stands for the mode of aggregation plan.
JoinType contains CrossJoin, InnerJoin, LeftOuterJoin, RightOuterJoin, FullOuterJoin, SemiJoin.