package
1.0.0
Repository: https://github.com/wangxiangustc/tidb.git
Documentation: pkg.go.dev

# Packages

No description provided by the author

# Functions

BuildLogicalPlan is exported and only used for test.
Cacheable checks whether the input ast is cacheable.
InsertPlan means inserting plan between two plans.
MockResolveName only serves for test.
Optimize does optimization and creates a Plan.
PrepareStmt prepares a raw statement parsed from parser.
Preprocess does preprocess work for optimizer.
RemovePlan means removing a plan.
ResolveName resolves table name and column name.
ToString explains a Plan, returns description string.
UseDAGPlanBuilder checks if we use new DAG planner.
Validate checkes whether the node is valid.

# Constants

Error codes.
Error codes.
Error codes.
Error codes.
Optimizer error codes.
Optimizer error codes.
Optimizer error codes.
MySQL error code.
Optimizer error codes.
Error codes.
Optimizer error codes.
Error codes.
Optimizer error codes.
Error codes.
Error codes.
CompleteAgg supposes its input is original results.
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.
Error codes.
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.
TypeCache is the type of cache.
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.
TypeHashSemiJoin is the type of hash semi 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.
TypeUpate is the type of Update.

# Variables

AllowCartesianProduct means whether tidb allows cartesian join without equal conditions.
Error instances.
Error instances.
Error instances.
Error instances.
Optimizer base errors.
Optimizer base errors.
Optimizer base errors.
Optimizer base errors.
Optimizer base errors.
Optimizer base errors.
Error instances.
Optimizer base errors.
Error instances.
Error instances.
Error instances.
EvalSubquery evaluates incorrelated subqueries once.
JoinConcurrency means the number of goroutines that participate in joining.
Error instances.

# 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.
Cache plan is a physical plan which stores the result of its child node.
CheckTable is used for checking table data, built from the 'admin check table' statement.
DataSource represents a tablescan without condition push down.
DDL represents a DDL statement plan.
Deallocate represents deallocate plan.
Delete represents a delete plan.
Execute represents prepare plan.
Exists checks if a query returns result.
Explain represents a explain plan.
Insert represents an insert plan.
InsertGeneratedColumns is for completing generated columns in Insert.
Limit represents offset and limit plan.
LoadData represents a loaddata 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.
MaxOneRow checks if a query returns no more than one row.
PhysicalAggregation is Aggregation's physical plan.
PhysicalApply represents apply plan, only used for subquery.
PhysicalHashJoin represents hash join for inner/ outer join.
PhysicalHashSemiJoin represents hash join for semi 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.
PhysicalMemTable reads memory table.
PhysicalMergeJoin represents merge join for inner/ outer join.
PhysicalTableReader is the table reader in tidb.
PhysicalTableScan represents a table scan plan.
PhysicalUnionScan represents a union scan operator.
Prepare represents prepare plan.
Projection represents a select fields plan.
Selection means a filter.
SelectLock represents a select lock plan.
Set represents a plan for set stmt.
Show represents a show plan.
ShowDDL is for showing DDL information.
ShowDDLJobs is for showing DDL job list.
Simple represents a simple statement plan which doesn't need any optimization.
Sort stands for the order by plan.
TableDual represents a dual table plan.
TopN represents a top-n plan.
Union represents Union 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.