Versions in this module Expand all Collapse all v1 v1.0.0 Oct 16, 2017 Changes in this version + const CodeAlterAutoID + const CodeAmbiguous + const CodeAnalyzeMissIndex + const CodeBadGeneratedColumn + const CodeIllegalReference + const CodeInvalidGroupFuncUse + const CodeInvalidWildCard + const CodeNoDB + const CodeOperandColumns + const CodeUnknownColumn + const CodeUnknownExplainFormat + const CodeUnknownTable + const CodeUnsupported + const CodeUnsupportedType + const CodeWrongArguments + const SystemInternalError + const TiDBIndexNestedLoopJoin + const TiDBMergeJoin + const TypeAgg + const TypeApply + const TypeCache + const TypeDelete + const TypeDual + const TypeExists + const TypeHashAgg + const TypeHashLeftJoin + const TypeHashRightJoin + const TypeHashSemiJoin + const TypeIdxScan + const TypeIndexJoin + const TypeIndexLookUp + const TypeIndexReader + const TypeInsert + const TypeJoin + const TypeLimit + const TypeLock + const TypeMaxOneRow + const TypeMemTableScan + const TypeMergeJoin + const TypeProj + const TypeSel + const TypeSet + const TypeShow + const TypeSort + const TypeStreamAgg + const TypeTableReader + const TypeTableScan + const TypeTopN + const TypeUnion + const TypeUnionScan + const TypeUpate + var AllowCartesianProduct = true + var ErrAlterAutoID = terror.ClassAutoid.New(CodeAlterAutoID, "No support for setting auto_increment using alter_table") + var ErrAmbiguous = terror.ClassOptimizerPlan.New(CodeAmbiguous, "Column '%s' in field list is ambiguous") + var ErrAnalyzeMissIndex = terror.ClassOptimizerPlan.New(CodeAnalyzeMissIndex, "Index '%s' in field list does not exist in table '%s'") + var ErrBadGeneratedColumn = terror.ClassOptimizerPlan.New(CodeBadGeneratedColumn, mysql.MySQLErrName[mysql.ErrBadGeneratedColumn]) + var ErrCartesianProductUnsupported = terror.ClassOptimizer.New(CodeUnsupported, "Cartesian product is unsupported") + var ErrIllegalReference = terror.ClassOptimizer.New(CodeIllegalReference, "Illegal reference") + var ErrInvalidGroupFuncUse = terror.ClassOptimizer.New(CodeInvalidGroupFuncUse, "Invalid use of group function") + var ErrInvalidWildCard = terror.ClassOptimizer.New(CodeInvalidWildCard, ...) + var ErrNoDB = terror.ClassOptimizer.New(CodeNoDB, "No database selected") + var ErrOperandColumns = terror.ClassOptimizer.New(CodeOperandColumns, "Operand should contain %d column(s)") + var ErrUnknownColumn = terror.ClassOptimizerPlan.New(CodeUnknownColumn, mysql.MySQLErrName[mysql.ErrBadField]) + var ErrUnknownExplainFormat = terror.ClassOptimizer.New(CodeUnknownExplainFormat, mysql.MySQLErrName[mysql.ErrUnknownExplainFormat]) + var ErrUnknownTable = terror.ClassOptimizerPlan.New(CodeUnknownColumn, mysql.MySQLErrName[mysql.ErrBadTable]) + var ErrUnsupportedType = terror.ClassOptimizerPlan.New(CodeUnsupportedType, "Unsupported type") + var ErrWrongArguments = terror.ClassOptimizerPlan.New(CodeWrongArguments, "Incorrect arguments to EXECUTE") + var EvalSubquery func(p PhysicalPlan, is infoschema.InfoSchema, ctx context.Context) ([][]types.Datum, error) + var JoinConcurrency = 5 + var SystemInternalErrorType = terror.ClassOptimizerPlan.New(SystemInternalError, "System internal error") + func Cacheable(node ast.Node) bool + func InsertPlan(parent Plan, child Plan, insert Plan) error + func MockResolveName(node ast.Node, info infoschema.InfoSchema, defaultSchema string, ...) error + func PrepareStmt(is infoschema.InfoSchema, ctx context.Context, node ast.Node) error + func Preprocess(node ast.Node, info infoschema.InfoSchema, ctx context.Context) error + func RemovePlan(p Plan) error + func ResolveName(node ast.Node, info infoschema.InfoSchema, ctx context.Context) error + func ToString(p Plan) string + func UseDAGPlanBuilder(ctx context.Context) bool + func Validate(node ast.Node, inPrepare bool) error + type AggregateFuncExtractor struct + AggFuncs []*ast.AggregateFuncExpr + func (a *AggregateFuncExtractor) Enter(n ast.Node) (ast.Node, bool) + func (a *AggregateFuncExtractor) Leave(n ast.Node) (ast.Node, bool) + type AggregationType int + const CompleteAgg + const FinalAgg + const StreamedAgg + func (at AggregationType) String() string + type Analyze struct + ColTasks []AnalyzeColumnsTask + IdxTasks []AnalyzeIndexTask + func (p *Analyze) AddChild(child Plan) + func (p *Analyze) AddParent(parent Plan) + func (p *Analyze) Allocator() *idAllocator + func (p *Analyze) Children() []Plan + func (p *Analyze) ExplainID() string + func (p *Analyze) ID() int + func (p *Analyze) MarshalJSON() ([]byte, error) + func (p *Analyze) Parents() []Plan + func (p *Analyze) PruneColumns(parentUsedCols []*expression.Column) + func (p *Analyze) ReplaceChild(child, newChild Plan) error + func (p *Analyze) ReplaceParent(parent, newPar Plan) error + func (p *Analyze) ResolveIndices() + func (p *Analyze) Schema() *expression.Schema + func (p *Analyze) SetChildren(children ...Plan) + func (p *Analyze) SetParents(pars ...Plan) + func (p *Analyze) SetSchema(schema *expression.Schema) + type AnalyzeColumnsTask struct + ColsInfo []*model.ColumnInfo + PKInfo *model.ColumnInfo + PushDown bool + TableInfo *model.TableInfo + type AnalyzeIndexTask struct + IndexInfo *model.IndexInfo + PushDown bool + TableInfo *model.TableInfo + type ByItems struct + Desc bool + Expr expression.Expression + func (by *ByItems) Clone() *ByItems + func (by *ByItems) String() string + type Cache struct + func (bp *Cache) ExplainInfo() string + func (p *Cache) Copy() PhysicalPlan + func (p *Cache) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Cache) AddChild(child Plan) + func (p Cache) AddParent(parent Plan) + func (p Cache) Allocator() *idAllocator + func (p Cache) Children() []Plan + func (p Cache) ExplainID() string + func (p Cache) ID() int + func (p Cache) MarshalJSON() ([]byte, error) + func (p Cache) Parents() []Plan + func (p Cache) ReplaceChild(child, newChild Plan) error + func (p Cache) ReplaceParent(parent, newPar Plan) error + func (p Cache) ResolveIndices() + func (p Cache) Schema() *expression.Schema + func (p Cache) SetChildren(children ...Plan) + func (p Cache) SetParents(pars ...Plan) + func (p Cache) SetSchema(schema *expression.Schema) + type CheckTable struct + Tables []*ast.TableName + func (p *CheckTable) AddChild(child Plan) + func (p *CheckTable) AddParent(parent Plan) + func (p *CheckTable) Allocator() *idAllocator + func (p *CheckTable) Children() []Plan + func (p *CheckTable) ExplainID() string + func (p *CheckTable) ID() int + func (p *CheckTable) MarshalJSON() ([]byte, error) + func (p *CheckTable) Parents() []Plan + func (p *CheckTable) ReplaceChild(child, newChild Plan) error + func (p *CheckTable) ReplaceParent(parent, newPar Plan) error + func (p *CheckTable) ResolveIndices() + func (p *CheckTable) Schema() *expression.Schema + func (p *CheckTable) SetChildren(children ...Plan) + func (p *CheckTable) SetParents(pars ...Plan) + func (p *CheckTable) SetSchema(schema *expression.Schema) + type DDL struct + Statement ast.DDLNode + func (p *DDL) AddChild(child Plan) + func (p *DDL) AddParent(parent Plan) + func (p *DDL) Allocator() *idAllocator + func (p *DDL) Children() []Plan + func (p *DDL) ExplainID() string + func (p *DDL) ID() int + func (p *DDL) MarshalJSON() ([]byte, error) + func (p *DDL) Parents() []Plan + func (p *DDL) ReplaceChild(child, newChild Plan) error + func (p *DDL) ReplaceParent(parent, newPar Plan) error + func (p *DDL) ResolveIndices() + func (p *DDL) Schema() *expression.Schema + func (p *DDL) SetChildren(children ...Plan) + func (p *DDL) SetParents(pars ...Plan) + func (p *DDL) SetSchema(schema *expression.Schema) + type DataSource struct + Columns []*model.ColumnInfo + DBName model.CIStr + LimitCount *int64 + NeedColHandle bool + TableAsName *model.CIStr + func (p *DataSource) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *DataSource) PruneColumns(parentUsedCols []*expression.Column) + func (p *DataSource) Schema() *expression.Schema + func (p *DataSource) TableInfo() *model.TableInfo + func (p DataSource) AddChild(child Plan) + func (p DataSource) AddParent(parent Plan) + func (p DataSource) Allocator() *idAllocator + func (p DataSource) Children() []Plan + func (p DataSource) ExplainID() string + func (p DataSource) ID() int + func (p DataSource) MarshalJSON() ([]byte, error) + func (p DataSource) Parents() []Plan + func (p DataSource) ReplaceChild(child, newChild Plan) error + func (p DataSource) ReplaceParent(parent, newPar Plan) error + func (p DataSource) ResolveIndices() + func (p DataSource) SetChildren(children ...Plan) + func (p DataSource) SetParents(pars ...Plan) + func (p DataSource) SetSchema(schema *expression.Schema) + type Deallocate struct + Name string + func (p *Deallocate) AddChild(child Plan) + func (p *Deallocate) AddParent(parent Plan) + func (p *Deallocate) Allocator() *idAllocator + func (p *Deallocate) Children() []Plan + func (p *Deallocate) ExplainID() string + func (p *Deallocate) ID() int + func (p *Deallocate) MarshalJSON() ([]byte, error) + func (p *Deallocate) Parents() []Plan + func (p *Deallocate) ReplaceChild(child, newChild Plan) error + func (p *Deallocate) ReplaceParent(parent, newPar Plan) error + func (p *Deallocate) ResolveIndices() + func (p *Deallocate) Schema() *expression.Schema + func (p *Deallocate) SetChildren(children ...Plan) + func (p *Deallocate) SetParents(pars ...Plan) + func (p *Deallocate) SetSchema(schema *expression.Schema) + type Delete struct + IsMultiTable bool + Tables []*ast.TableName + func (bp *Delete) ExplainInfo() string + func (p *Delete) Copy() PhysicalPlan + func (p *Delete) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Delete) PruneColumns(parentUsedCols []*expression.Column) + func (p *Delete) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Delete) AddChild(child Plan) + func (p Delete) AddParent(parent Plan) + func (p Delete) Allocator() *idAllocator + func (p Delete) Children() []Plan + func (p Delete) ExplainID() string + func (p Delete) ID() int + func (p Delete) MarshalJSON() ([]byte, error) + func (p Delete) Parents() []Plan + func (p Delete) ReplaceChild(child, newChild Plan) error + func (p Delete) ReplaceParent(parent, newPar Plan) error + func (p Delete) ResolveIndices() + func (p Delete) Schema() *expression.Schema + func (p Delete) SetChildren(children ...Plan) + func (p Delete) SetParents(pars ...Plan) + func (p Delete) SetSchema(schema *expression.Schema) + type Execute struct + ExecID uint32 + Name string + UsingVars []expression.Expression + func (p *Execute) AddChild(child Plan) + func (p *Execute) AddParent(parent Plan) + func (p *Execute) Allocator() *idAllocator + func (p *Execute) Children() []Plan + func (p *Execute) ExplainID() string + func (p *Execute) ID() int + func (p *Execute) MarshalJSON() ([]byte, error) + func (p *Execute) Parents() []Plan + func (p *Execute) ReplaceChild(child, newChild Plan) error + func (p *Execute) ReplaceParent(parent, newPar Plan) error + func (p *Execute) ResolveIndices() + func (p *Execute) Schema() *expression.Schema + func (p *Execute) SetChildren(children ...Plan) + func (p *Execute) SetParents(pars ...Plan) + func (p *Execute) SetSchema(schema *expression.Schema) + type Exists struct + func (bp *Exists) ExplainInfo() string + func (p *Exists) Copy() PhysicalPlan + func (p *Exists) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Exists) PruneColumns(parentUsedCols []*expression.Column) + func (p *Exists) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Exists) AddChild(child Plan) + func (p Exists) AddParent(parent Plan) + func (p Exists) Allocator() *idAllocator + func (p Exists) Children() []Plan + func (p Exists) ExplainID() string + func (p Exists) ID() int + func (p Exists) MarshalJSON() ([]byte, error) + func (p Exists) Parents() []Plan + func (p Exists) ReplaceChild(child, newChild Plan) error + func (p Exists) ReplaceParent(parent, newPar Plan) error + func (p Exists) ResolveIndices() + func (p Exists) Schema() *expression.Schema + func (p Exists) SetChildren(children ...Plan) + func (p Exists) SetParents(pars ...Plan) + func (p Exists) SetSchema(schema *expression.Schema) + type Explain struct + Rows [][]types.Datum + StmtPlan Plan + func (p *Explain) AddChild(child Plan) + func (p *Explain) AddParent(parent Plan) + func (p *Explain) Allocator() *idAllocator + func (p *Explain) Children() []Plan + func (p *Explain) ExplainID() string + func (p *Explain) ID() int + func (p *Explain) MarshalJSON() ([]byte, error) + func (p *Explain) Parents() []Plan + func (p *Explain) ReplaceChild(child, newChild Plan) error + func (p *Explain) ReplaceParent(parent, newPar Plan) error + func (p *Explain) ResolveIndices() + func (p *Explain) Schema() *expression.Schema + func (p *Explain) SetChildren(children ...Plan) + func (p *Explain) SetParents(pars ...Plan) + func (p *Explain) SetSchema(schema *expression.Schema) + type Insert struct + Columns []*ast.ColumnName + GenCols InsertGeneratedColumns + IgnoreErr bool + IsReplace bool + Lists [][]expression.Expression + NeedFillDefaultValue bool + OnDuplicate []*expression.Assignment + Priority mysql.PriorityEnum + Setlist []*expression.Assignment + Table table.Table + func (bp *Insert) ExplainInfo() string + func (p *Insert) Copy() PhysicalPlan + func (p *Insert) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Insert) PruneColumns(_ []*expression.Column) + func (p *Insert) ResolveIndices() + func (p *Insert) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Insert) AddChild(child Plan) + func (p Insert) AddParent(parent Plan) + func (p Insert) Allocator() *idAllocator + func (p Insert) Children() []Plan + func (p Insert) ExplainID() string + func (p Insert) ID() int + func (p Insert) MarshalJSON() ([]byte, error) + func (p Insert) Parents() []Plan + func (p Insert) ReplaceChild(child, newChild Plan) error + func (p Insert) ReplaceParent(parent, newPar Plan) error + func (p Insert) Schema() *expression.Schema + func (p Insert) SetChildren(children ...Plan) + func (p Insert) SetParents(pars ...Plan) + func (p Insert) SetSchema(schema *expression.Schema) + type InsertGeneratedColumns struct + Columns []*ast.ColumnName + Exprs []expression.Expression + OnDuplicates []*expression.Assignment + type JoinType int + const InnerJoin + const LeftOuterJoin + const LeftOuterSemiJoin + const RightOuterJoin + const SemiJoin + func (tp JoinType) String() string + type Limit struct + Count uint64 + Offset uint64 + func (p *Limit) Copy() PhysicalPlan + func (p *Limit) ExplainInfo() string + func (p *Limit) MarshalJSON() ([]byte, error) + func (p *Limit) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Limit) PruneColumns(parentUsedCols []*expression.Column) + func (p *Limit) ToPB(ctx context.Context) (*tipb.Executor, error) + func (p Limit) AddChild(child Plan) + func (p Limit) AddParent(parent Plan) + func (p Limit) Allocator() *idAllocator + func (p Limit) Children() []Plan + func (p Limit) ExplainID() string + func (p Limit) ID() int + func (p Limit) Parents() []Plan + func (p Limit) ReplaceChild(child, newChild Plan) error + func (p Limit) ReplaceParent(parent, newPar Plan) error + func (p Limit) ResolveIndices() + func (p Limit) Schema() *expression.Schema + func (p Limit) SetChildren(children ...Plan) + func (p Limit) SetParents(pars ...Plan) + func (p Limit) SetSchema(schema *expression.Schema) + type LoadData struct + Columns []*ast.ColumnName + FieldsInfo *ast.FieldsClause + GenCols InsertGeneratedColumns + IsLocal bool + LinesInfo *ast.LinesClause + Path string + Table *ast.TableName + func (p *LoadData) AddChild(child Plan) + func (p *LoadData) AddParent(parent Plan) + func (p *LoadData) Allocator() *idAllocator + func (p *LoadData) Children() []Plan + func (p *LoadData) ExplainID() string + func (p *LoadData) ID() int + func (p *LoadData) MarshalJSON() ([]byte, error) + func (p *LoadData) Parents() []Plan + func (p *LoadData) ReplaceChild(child, newChild Plan) error + func (p *LoadData) ReplaceParent(parent, newPar Plan) error + func (p *LoadData) ResolveIndices() + func (p *LoadData) Schema() *expression.Schema + func (p *LoadData) SetChildren(children ...Plan) + func (p *LoadData) SetParents(pars ...Plan) + func (p *LoadData) SetSchema(schema *expression.Schema) + type LogicalAggregation struct + AggFuncs []aggregation.Aggregation + GroupByItems []expression.Expression + func (p *LogicalAggregation) PredicatePushDown(predicates []expression.Expression) (ret []expression.Expression, retPlan LogicalPlan, err error) + func (p *LogicalAggregation) PruneColumns(parentUsedCols []*expression.Column) + func (p *LogicalAggregation) ResolveIndices() + func (p LogicalAggregation) AddChild(child Plan) + func (p LogicalAggregation) AddParent(parent Plan) + func (p LogicalAggregation) Allocator() *idAllocator + func (p LogicalAggregation) Children() []Plan + func (p LogicalAggregation) ExplainID() string + func (p LogicalAggregation) ID() int + func (p LogicalAggregation) MarshalJSON() ([]byte, error) + func (p LogicalAggregation) Parents() []Plan + func (p LogicalAggregation) ReplaceChild(child, newChild Plan) error + func (p LogicalAggregation) ReplaceParent(parent, newPar Plan) error + func (p LogicalAggregation) Schema() *expression.Schema + func (p LogicalAggregation) SetChildren(children ...Plan) + func (p LogicalAggregation) SetParents(pars ...Plan) + func (p LogicalAggregation) SetSchema(schema *expression.Schema) + type LogicalApply struct + func (p *LogicalApply) PruneColumns(parentUsedCols []*expression.Column) + func (p *LogicalApply) ResolveIndices() + func (p LogicalApply) AddChild(child Plan) + func (p LogicalApply) AddParent(parent Plan) + func (p LogicalApply) Allocator() *idAllocator + func (p LogicalApply) Children() []Plan + func (p LogicalApply) ExplainID() string + func (p LogicalApply) ID() int + func (p LogicalApply) MarshalJSON() ([]byte, error) + func (p LogicalApply) Parents() []Plan + func (p LogicalApply) ReplaceChild(child, newChild Plan) error + func (p LogicalApply) ReplaceParent(parent, newPar Plan) error + func (p LogicalApply) Schema() *expression.Schema + func (p LogicalApply) SetChildren(children ...Plan) + func (p LogicalApply) SetParents(pars ...Plan) + func (p LogicalApply) SetSchema(schema *expression.Schema) + type LogicalJoin struct + DefaultValues []types.Datum + EqualConditions []*expression.ScalarFunction + JoinType JoinType + LeftConditions expression.CNFExprs + LeftJoinKeys []*expression.Column + OtherConditions expression.CNFExprs + RightConditions expression.CNFExprs + RightJoinKeys []*expression.Column + func (p *LogicalJoin) PredicatePushDown(predicates []expression.Expression) (ret []expression.Expression, retPlan LogicalPlan, err error) + func (p *LogicalJoin) PruneColumns(parentUsedCols []*expression.Column) + func (p *LogicalJoin) ResolveIndices() + func (p LogicalJoin) AddChild(child Plan) + func (p LogicalJoin) AddParent(parent Plan) + func (p LogicalJoin) Allocator() *idAllocator + func (p LogicalJoin) Children() []Plan + func (p LogicalJoin) ExplainID() string + func (p LogicalJoin) ID() int + func (p LogicalJoin) MarshalJSON() ([]byte, error) + func (p LogicalJoin) Parents() []Plan + func (p LogicalJoin) ReplaceChild(child, newChild Plan) error + func (p LogicalJoin) ReplaceParent(parent, newPar Plan) error + func (p LogicalJoin) Schema() *expression.Schema + func (p LogicalJoin) SetChildren(children ...Plan) + func (p LogicalJoin) SetParents(pars ...Plan) + func (p LogicalJoin) SetSchema(schema *expression.Schema) + type LogicalPlan interface + PredicatePushDown func([]expression.Expression) ([]expression.Expression, LogicalPlan, error) + PruneColumns func([]*expression.Column) + type MaxOneRow struct + func (bp *MaxOneRow) ExplainInfo() string + func (p *MaxOneRow) Copy() PhysicalPlan + func (p *MaxOneRow) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *MaxOneRow) PruneColumns(parentUsedCols []*expression.Column) + func (p *MaxOneRow) ToPB(_ context.Context) (*tipb.Executor, error) + func (p MaxOneRow) AddChild(child Plan) + func (p MaxOneRow) AddParent(parent Plan) + func (p MaxOneRow) Allocator() *idAllocator + func (p MaxOneRow) Children() []Plan + func (p MaxOneRow) ExplainID() string + func (p MaxOneRow) ID() int + func (p MaxOneRow) MarshalJSON() ([]byte, error) + func (p MaxOneRow) Parents() []Plan + func (p MaxOneRow) ReplaceChild(child, newChild Plan) error + func (p MaxOneRow) ReplaceParent(parent, newPar Plan) error + func (p MaxOneRow) ResolveIndices() + func (p MaxOneRow) Schema() *expression.Schema + func (p MaxOneRow) SetChildren(children ...Plan) + func (p MaxOneRow) SetParents(pars ...Plan) + func (p MaxOneRow) SetSchema(schema *expression.Schema) + type PhysicalAggregation struct + AggFuncs []aggregation.Aggregation + AggType AggregationType + GroupByItems []expression.Expression + HasGby bool + func (p *PhysicalAggregation) Copy() PhysicalPlan + func (p *PhysicalAggregation) ExplainInfo() string + func (p *PhysicalAggregation) MarshalJSON() ([]byte, error) + func (p *PhysicalAggregation) ResolveIndices() + func (p *PhysicalAggregation) ToPB(ctx context.Context) (*tipb.Executor, error) + func (p PhysicalAggregation) AddChild(child Plan) + func (p PhysicalAggregation) AddParent(parent Plan) + func (p PhysicalAggregation) Allocator() *idAllocator + func (p PhysicalAggregation) Children() []Plan + func (p PhysicalAggregation) ExplainID() string + func (p PhysicalAggregation) ID() int + func (p PhysicalAggregation) Parents() []Plan + func (p PhysicalAggregation) ReplaceChild(child, newChild Plan) error + func (p PhysicalAggregation) ReplaceParent(parent, newPar Plan) error + func (p PhysicalAggregation) Schema() *expression.Schema + func (p PhysicalAggregation) SetChildren(children ...Plan) + func (p PhysicalAggregation) SetParents(pars ...Plan) + func (p PhysicalAggregation) SetSchema(schema *expression.Schema) + type PhysicalApply struct + OuterSchema []*expression.CorrelatedColumn + PhysicalJoin PhysicalPlan + func (p *PhysicalApply) Copy() PhysicalPlan + func (p *PhysicalApply) ExplainInfo() string + func (p *PhysicalApply) MarshalJSON() ([]byte, error) + func (p *PhysicalApply) ResolveIndices() + func (p *PhysicalApply) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalApply) AddChild(child Plan) + func (p PhysicalApply) AddParent(parent Plan) + func (p PhysicalApply) Allocator() *idAllocator + func (p PhysicalApply) Children() []Plan + func (p PhysicalApply) ExplainID() string + func (p PhysicalApply) ID() int + func (p PhysicalApply) Parents() []Plan + func (p PhysicalApply) ReplaceChild(child, newChild Plan) error + func (p PhysicalApply) ReplaceParent(parent, newPar Plan) error + func (p PhysicalApply) Schema() *expression.Schema + func (p PhysicalApply) SetChildren(children ...Plan) + func (p PhysicalApply) SetParents(pars ...Plan) + func (p PhysicalApply) SetSchema(schema *expression.Schema) + type PhysicalHashJoin struct + Concurrency int + DefaultValues []types.Datum + EqualConditions []*expression.ScalarFunction + JoinType JoinType + LeftConditions []expression.Expression + OtherConditions []expression.Expression + RightConditions []expression.Expression + SmallTable int + func (p *PhysicalHashJoin) Copy() PhysicalPlan + func (p *PhysicalHashJoin) ExplainInfo() string + func (p *PhysicalHashJoin) MarshalJSON() ([]byte, error) + func (p *PhysicalHashJoin) ResolveIndices() + func (p *PhysicalHashJoin) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalHashJoin) AddChild(child Plan) + func (p PhysicalHashJoin) AddParent(parent Plan) + func (p PhysicalHashJoin) Allocator() *idAllocator + func (p PhysicalHashJoin) Children() []Plan + func (p PhysicalHashJoin) ExplainID() string + func (p PhysicalHashJoin) ID() int + func (p PhysicalHashJoin) Parents() []Plan + func (p PhysicalHashJoin) ReplaceChild(child, newChild Plan) error + func (p PhysicalHashJoin) ReplaceParent(parent, newPar Plan) error + func (p PhysicalHashJoin) Schema() *expression.Schema + func (p PhysicalHashJoin) SetChildren(children ...Plan) + func (p PhysicalHashJoin) SetParents(pars ...Plan) + func (p PhysicalHashJoin) SetSchema(schema *expression.Schema) + type PhysicalHashSemiJoin struct + Anti bool + EqualConditions []*expression.ScalarFunction + LeftConditions []expression.Expression + OtherConditions []expression.Expression + RightConditions []expression.Expression + WithAux bool + func (p *PhysicalHashSemiJoin) Copy() PhysicalPlan + func (p *PhysicalHashSemiJoin) ExplainInfo() string + func (p *PhysicalHashSemiJoin) MarshalJSON() ([]byte, error) + func (p *PhysicalHashSemiJoin) ResolveIndices() + func (p *PhysicalHashSemiJoin) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalHashSemiJoin) AddChild(child Plan) + func (p PhysicalHashSemiJoin) AddParent(parent Plan) + func (p PhysicalHashSemiJoin) Allocator() *idAllocator + func (p PhysicalHashSemiJoin) Children() []Plan + func (p PhysicalHashSemiJoin) ExplainID() string + func (p PhysicalHashSemiJoin) ID() int + func (p PhysicalHashSemiJoin) Parents() []Plan + func (p PhysicalHashSemiJoin) ReplaceChild(child, newChild Plan) error + func (p PhysicalHashSemiJoin) ReplaceParent(parent, newPar Plan) error + func (p PhysicalHashSemiJoin) Schema() *expression.Schema + func (p PhysicalHashSemiJoin) SetChildren(children ...Plan) + func (p PhysicalHashSemiJoin) SetParents(pars ...Plan) + func (p PhysicalHashSemiJoin) SetSchema(schema *expression.Schema) + type PhysicalIndexJoin struct + DefaultValues []types.Datum + InnerJoinKeys []*expression.Column + KeepOrder bool + LeftConditions expression.CNFExprs + OtherConditions expression.CNFExprs + Outer bool + OuterJoinKeys []*expression.Column + RightConditions expression.CNFExprs + func (p *PhysicalIndexJoin) Copy() PhysicalPlan + func (p *PhysicalIndexJoin) ExplainInfo() string + func (p *PhysicalIndexJoin) ResolveIndices() + func (p *PhysicalIndexJoin) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalIndexJoin) AddChild(child Plan) + func (p PhysicalIndexJoin) AddParent(parent Plan) + func (p PhysicalIndexJoin) Allocator() *idAllocator + func (p PhysicalIndexJoin) Children() []Plan + func (p PhysicalIndexJoin) ExplainID() string + func (p PhysicalIndexJoin) ID() int + func (p PhysicalIndexJoin) MarshalJSON() ([]byte, error) + func (p PhysicalIndexJoin) Parents() []Plan + func (p PhysicalIndexJoin) ReplaceChild(child, newChild Plan) error + func (p PhysicalIndexJoin) ReplaceParent(parent, newPar Plan) error + func (p PhysicalIndexJoin) Schema() *expression.Schema + func (p PhysicalIndexJoin) SetChildren(children ...Plan) + func (p PhysicalIndexJoin) SetParents(pars ...Plan) + func (p PhysicalIndexJoin) SetSchema(schema *expression.Schema) + type PhysicalIndexLookUpReader struct + IndexPlans []PhysicalPlan + NeedColHandle bool + TablePlans []PhysicalPlan + func (p *PhysicalIndexLookUpReader) Copy() PhysicalPlan + func (p *PhysicalIndexLookUpReader) ExplainInfo() string + func (p *PhysicalIndexLookUpReader) ResolveIndices() + func (p *PhysicalIndexLookUpReader) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalIndexLookUpReader) AddChild(child Plan) + func (p PhysicalIndexLookUpReader) AddParent(parent Plan) + func (p PhysicalIndexLookUpReader) Allocator() *idAllocator + func (p PhysicalIndexLookUpReader) Children() []Plan + func (p PhysicalIndexLookUpReader) ExplainID() string + func (p PhysicalIndexLookUpReader) ID() int + func (p PhysicalIndexLookUpReader) MarshalJSON() ([]byte, error) + func (p PhysicalIndexLookUpReader) Parents() []Plan + func (p PhysicalIndexLookUpReader) ReplaceChild(child, newChild Plan) error + func (p PhysicalIndexLookUpReader) ReplaceParent(parent, newPar Plan) error + func (p PhysicalIndexLookUpReader) Schema() *expression.Schema + func (p PhysicalIndexLookUpReader) SetChildren(children ...Plan) + func (p PhysicalIndexLookUpReader) SetParents(pars ...Plan) + func (p PhysicalIndexLookUpReader) SetSchema(schema *expression.Schema) + type PhysicalIndexReader struct + IndexPlans []PhysicalPlan + NeedColHandle bool + OutputColumns []*expression.Column + func (p *PhysicalIndexReader) Copy() PhysicalPlan + func (p *PhysicalIndexReader) ExplainInfo() string + func (p *PhysicalIndexReader) ResolveIndices() + func (p *PhysicalIndexReader) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalIndexReader) AddChild(child Plan) + func (p PhysicalIndexReader) AddParent(parent Plan) + func (p PhysicalIndexReader) Allocator() *idAllocator + func (p PhysicalIndexReader) Children() []Plan + func (p PhysicalIndexReader) ExplainID() string + func (p PhysicalIndexReader) ID() int + func (p PhysicalIndexReader) MarshalJSON() ([]byte, error) + func (p PhysicalIndexReader) Parents() []Plan + func (p PhysicalIndexReader) ReplaceChild(child, newChild Plan) error + func (p PhysicalIndexReader) ReplaceParent(parent, newPar Plan) error + func (p PhysicalIndexReader) Schema() *expression.Schema + func (p PhysicalIndexReader) SetChildren(children ...Plan) + func (p PhysicalIndexReader) SetParents(pars ...Plan) + func (p PhysicalIndexReader) SetSchema(schema *expression.Schema) + type PhysicalIndexScan struct + Columns []*model.ColumnInfo + DBName model.CIStr + Desc bool + DoubleRead bool + Index *model.IndexInfo + OutOfOrder bool + Ranges []*types.IndexRange + Table *model.TableInfo + TableAsName *model.CIStr + func (p *PhysicalIndexScan) Copy() PhysicalPlan + func (p *PhysicalIndexScan) ExplainInfo() string + func (p *PhysicalIndexScan) IsPointGetByUniqueKey(sc *variable.StatementContext) bool + func (p *PhysicalIndexScan) MarshalJSON() ([]byte, error) + func (p *PhysicalIndexScan) ToPB(ctx context.Context) (*tipb.Executor, error) + type PhysicalMemTable struct + Columns []*model.ColumnInfo + DBName model.CIStr + NeedColHandle bool + Ranges []types.IntColumnRange + Table *model.TableInfo + TableAsName *model.CIStr + func (bp *PhysicalMemTable) ExplainInfo() string + func (p *PhysicalMemTable) Copy() PhysicalPlan + func (p *PhysicalMemTable) MarshalJSON() ([]byte, error) + func (p *PhysicalMemTable) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalMemTable) AddChild(child Plan) + func (p PhysicalMemTable) AddParent(parent Plan) + func (p PhysicalMemTable) Allocator() *idAllocator + func (p PhysicalMemTable) Children() []Plan + func (p PhysicalMemTable) ExplainID() string + func (p PhysicalMemTable) ID() int + func (p PhysicalMemTable) Parents() []Plan + func (p PhysicalMemTable) ReplaceChild(child, newChild Plan) error + func (p PhysicalMemTable) ReplaceParent(parent, newPar Plan) error + func (p PhysicalMemTable) ResolveIndices() + func (p PhysicalMemTable) Schema() *expression.Schema + func (p PhysicalMemTable) SetChildren(children ...Plan) + func (p PhysicalMemTable) SetParents(pars ...Plan) + func (p PhysicalMemTable) SetSchema(schema *expression.Schema) + type PhysicalMergeJoin struct + DefaultValues []types.Datum + Desc bool + EqualConditions []*expression.ScalarFunction + JoinType JoinType + LeftConditions []expression.Expression + OtherConditions []expression.Expression + RightConditions []expression.Expression + func (p *PhysicalMergeJoin) Copy() PhysicalPlan + func (p *PhysicalMergeJoin) ExplainInfo() string + func (p *PhysicalMergeJoin) MarshalJSON() ([]byte, error) + func (p *PhysicalMergeJoin) ResolveIndices() + func (p *PhysicalMergeJoin) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalMergeJoin) AddChild(child Plan) + func (p PhysicalMergeJoin) AddParent(parent Plan) + func (p PhysicalMergeJoin) Allocator() *idAllocator + func (p PhysicalMergeJoin) Children() []Plan + func (p PhysicalMergeJoin) ExplainID() string + func (p PhysicalMergeJoin) ID() int + func (p PhysicalMergeJoin) Parents() []Plan + func (p PhysicalMergeJoin) ReplaceChild(child, newChild Plan) error + func (p PhysicalMergeJoin) ReplaceParent(parent, newPar Plan) error + func (p PhysicalMergeJoin) Schema() *expression.Schema + func (p PhysicalMergeJoin) SetChildren(children ...Plan) + func (p PhysicalMergeJoin) SetParents(pars ...Plan) + func (p PhysicalMergeJoin) SetSchema(schema *expression.Schema) + type PhysicalPlan interface + Copy func() PhysicalPlan + ExplainInfo func() string + ToPB func(ctx context.Context) (*tipb.Executor, error) + type PhysicalTableReader struct + NeedColHandle bool + TablePlans []PhysicalPlan + func (p *PhysicalTableReader) Copy() PhysicalPlan + func (p *PhysicalTableReader) ExplainInfo() string + func (p *PhysicalTableReader) ResolveIndices() + func (p *PhysicalTableReader) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalTableReader) AddChild(child Plan) + func (p PhysicalTableReader) AddParent(parent Plan) + func (p PhysicalTableReader) Allocator() *idAllocator + func (p PhysicalTableReader) Children() []Plan + func (p PhysicalTableReader) ExplainID() string + func (p PhysicalTableReader) ID() int + func (p PhysicalTableReader) MarshalJSON() ([]byte, error) + func (p PhysicalTableReader) Parents() []Plan + func (p PhysicalTableReader) ReplaceChild(child, newChild Plan) error + func (p PhysicalTableReader) ReplaceParent(parent, newPar Plan) error + func (p PhysicalTableReader) Schema() *expression.Schema + func (p PhysicalTableReader) SetChildren(children ...Plan) + func (p PhysicalTableReader) SetParents(pars ...Plan) + func (p PhysicalTableReader) SetSchema(schema *expression.Schema) + type PhysicalTableScan struct + Columns []*model.ColumnInfo + DBName model.CIStr + Desc bool + KeepOrder bool + Ranges []types.IntColumnRange + Table *model.TableInfo + TableAsName *model.CIStr + func (p *PhysicalTableScan) Copy() PhysicalPlan + func (p *PhysicalTableScan) ExplainInfo() string + func (p *PhysicalTableScan) MarshalJSON() ([]byte, error) + func (p *PhysicalTableScan) ToPB(ctx context.Context) (*tipb.Executor, error) + type PhysicalUnionScan struct + Conditions []expression.Expression + NeedColHandle bool + func (p *PhysicalUnionScan) Copy() PhysicalPlan + func (p *PhysicalUnionScan) ExplainInfo() string + func (p *PhysicalUnionScan) ResolveIndices() + func (p *PhysicalUnionScan) ToPB(_ context.Context) (*tipb.Executor, error) + func (p PhysicalUnionScan) AddChild(child Plan) + func (p PhysicalUnionScan) AddParent(parent Plan) + func (p PhysicalUnionScan) Allocator() *idAllocator + func (p PhysicalUnionScan) Children() []Plan + func (p PhysicalUnionScan) ExplainID() string + func (p PhysicalUnionScan) ID() int + func (p PhysicalUnionScan) MarshalJSON() ([]byte, error) + func (p PhysicalUnionScan) Parents() []Plan + func (p PhysicalUnionScan) ReplaceChild(child, newChild Plan) error + func (p PhysicalUnionScan) ReplaceParent(parent, newPar Plan) error + func (p PhysicalUnionScan) Schema() *expression.Schema + func (p PhysicalUnionScan) SetChildren(children ...Plan) + func (p PhysicalUnionScan) SetParents(pars ...Plan) + func (p PhysicalUnionScan) SetSchema(schema *expression.Schema) + type Plan interface + AddChild func(children Plan) + AddParent func(parent Plan) + Allocator func() *idAllocator + Children func() []Plan + ExplainID func() string + ID func() int + Parents func() []Plan + ReplaceChild func(children, newChild Plan) error + ReplaceParent func(parent, newPar Plan) error + ResolveIndices func() + Schema func() *expression.Schema + SetChildren func(...Plan) + SetParents func(...Plan) + SetSchema func(schema *expression.Schema) + func BuildLogicalPlan(ctx context.Context, node ast.Node, is infoschema.InfoSchema) (Plan, error) + func Optimize(ctx context.Context, node ast.Node, is infoschema.InfoSchema) (Plan, error) + type Prepare struct + Name string + SQLText string + func (p *Prepare) AddChild(child Plan) + func (p *Prepare) AddParent(parent Plan) + func (p *Prepare) Allocator() *idAllocator + func (p *Prepare) Children() []Plan + func (p *Prepare) ExplainID() string + func (p *Prepare) ID() int + func (p *Prepare) MarshalJSON() ([]byte, error) + func (p *Prepare) Parents() []Plan + func (p *Prepare) ReplaceChild(child, newChild Plan) error + func (p *Prepare) ReplaceParent(parent, newPar Plan) error + func (p *Prepare) ResolveIndices() + func (p *Prepare) Schema() *expression.Schema + func (p *Prepare) SetChildren(children ...Plan) + func (p *Prepare) SetParents(pars ...Plan) + func (p *Prepare) SetSchema(schema *expression.Schema) + type Projection struct + Exprs []expression.Expression + func (p *Projection) Copy() PhysicalPlan + func (p *Projection) ExplainInfo() string + func (p *Projection) MarshalJSON() ([]byte, error) + func (p *Projection) PredicatePushDown(predicates []expression.Expression) (ret []expression.Expression, retPlan LogicalPlan, err error) + func (p *Projection) PruneColumns(parentUsedCols []*expression.Column) + func (p *Projection) ResolveIndices() + func (p *Projection) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Projection) AddChild(child Plan) + func (p Projection) AddParent(parent Plan) + func (p Projection) Allocator() *idAllocator + func (p Projection) Children() []Plan + func (p Projection) ExplainID() string + func (p Projection) ID() int + func (p Projection) Parents() []Plan + func (p Projection) ReplaceChild(child, newChild Plan) error + func (p Projection) ReplaceParent(parent, newPar Plan) error + func (p Projection) Schema() *expression.Schema + func (p Projection) SetChildren(children ...Plan) + func (p Projection) SetParents(pars ...Plan) + func (p Projection) SetSchema(schema *expression.Schema) + type SelectLock struct + Lock ast.SelectLockType + func (p *SelectLock) Copy() PhysicalPlan + func (p *SelectLock) ExplainInfo() string + func (p *SelectLock) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *SelectLock) PruneColumns(parentUsedCols []*expression.Column) + func (p *SelectLock) ToPB(_ context.Context) (*tipb.Executor, error) + func (p SelectLock) AddChild(child Plan) + func (p SelectLock) AddParent(parent Plan) + func (p SelectLock) Allocator() *idAllocator + func (p SelectLock) Children() []Plan + func (p SelectLock) ExplainID() string + func (p SelectLock) ID() int + func (p SelectLock) MarshalJSON() ([]byte, error) + func (p SelectLock) Parents() []Plan + func (p SelectLock) ReplaceChild(child, newChild Plan) error + func (p SelectLock) ReplaceParent(parent, newPar Plan) error + func (p SelectLock) ResolveIndices() + func (p SelectLock) Schema() *expression.Schema + func (p SelectLock) SetChildren(children ...Plan) + func (p SelectLock) SetParents(pars ...Plan) + func (p SelectLock) SetSchema(schema *expression.Schema) + type Selection struct + Conditions []expression.Expression + ScanController bool + func (p *Selection) Copy() PhysicalPlan + func (p *Selection) ExplainInfo() string + func (p *Selection) MarshalJSON() ([]byte, error) + func (p *Selection) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Selection) PruneColumns(parentUsedCols []*expression.Column) + func (p *Selection) ResolveIndices() + func (p *Selection) ToPB(ctx context.Context) (*tipb.Executor, error) + func (p Selection) AddChild(child Plan) + func (p Selection) AddParent(parent Plan) + func (p Selection) Allocator() *idAllocator + func (p Selection) Children() []Plan + func (p Selection) ExplainID() string + func (p Selection) ID() int + func (p Selection) Parents() []Plan + func (p Selection) ReplaceChild(child, newChild Plan) error + func (p Selection) ReplaceParent(parent, newPar Plan) error + func (p Selection) Schema() *expression.Schema + func (p Selection) SetChildren(children ...Plan) + func (p Selection) SetParents(pars ...Plan) + func (p Selection) SetSchema(schema *expression.Schema) + type Set struct + VarAssigns []*expression.VarAssignment + func (p *Set) AddChild(child Plan) + func (p *Set) AddParent(parent Plan) + func (p *Set) Allocator() *idAllocator + func (p *Set) Children() []Plan + func (p *Set) ExplainID() string + func (p *Set) ID() int + func (p *Set) MarshalJSON() ([]byte, error) + func (p *Set) Parents() []Plan + func (p *Set) ReplaceChild(child, newChild Plan) error + func (p *Set) ReplaceParent(parent, newPar Plan) error + func (p *Set) ResolveIndices() + func (p *Set) Schema() *expression.Schema + func (p *Set) SetChildren(children ...Plan) + func (p *Set) SetParents(pars ...Plan) + func (p *Set) SetSchema(schema *expression.Schema) + type Show struct + Column *ast.ColumnName + DBName string + Flag int + Full bool + GlobalScope bool + Table *ast.TableName + Tp ast.ShowStmtType + User *auth.UserIdentity + func (bp *Show) ExplainInfo() string + func (p *Show) Copy() PhysicalPlan + func (p *Show) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Show) PruneColumns(parentUsedCols []*expression.Column) + func (p *Show) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Show) AddChild(child Plan) + func (p Show) AddParent(parent Plan) + func (p Show) Allocator() *idAllocator + func (p Show) Children() []Plan + func (p Show) ExplainID() string + func (p Show) ID() int + func (p Show) MarshalJSON() ([]byte, error) + func (p Show) Parents() []Plan + func (p Show) ReplaceChild(child, newChild Plan) error + func (p Show) ReplaceParent(parent, newPar Plan) error + func (p Show) ResolveIndices() + func (p Show) Schema() *expression.Schema + func (p Show) SetChildren(children ...Plan) + func (p Show) SetParents(pars ...Plan) + func (p Show) SetSchema(schema *expression.Schema) + type ShowDDL struct + func (p *ShowDDL) AddChild(child Plan) + func (p *ShowDDL) AddParent(parent Plan) + func (p *ShowDDL) Allocator() *idAllocator + func (p *ShowDDL) Children() []Plan + func (p *ShowDDL) ExplainID() string + func (p *ShowDDL) ID() int + func (p *ShowDDL) MarshalJSON() ([]byte, error) + func (p *ShowDDL) Parents() []Plan + func (p *ShowDDL) ReplaceChild(child, newChild Plan) error + func (p *ShowDDL) ReplaceParent(parent, newPar Plan) error + func (p *ShowDDL) ResolveIndices() + func (p *ShowDDL) Schema() *expression.Schema + func (p *ShowDDL) SetChildren(children ...Plan) + func (p *ShowDDL) SetParents(pars ...Plan) + func (p *ShowDDL) SetSchema(schema *expression.Schema) + type ShowDDLJobs struct + func (p *ShowDDLJobs) AddChild(child Plan) + func (p *ShowDDLJobs) AddParent(parent Plan) + func (p *ShowDDLJobs) Allocator() *idAllocator + func (p *ShowDDLJobs) Children() []Plan + func (p *ShowDDLJobs) ExplainID() string + func (p *ShowDDLJobs) ID() int + func (p *ShowDDLJobs) MarshalJSON() ([]byte, error) + func (p *ShowDDLJobs) Parents() []Plan + func (p *ShowDDLJobs) ReplaceChild(child, newChild Plan) error + func (p *ShowDDLJobs) ReplaceParent(parent, newPar Plan) error + func (p *ShowDDLJobs) ResolveIndices() + func (p *ShowDDLJobs) Schema() *expression.Schema + func (p *ShowDDLJobs) SetChildren(children ...Plan) + func (p *ShowDDLJobs) SetParents(pars ...Plan) + func (p *ShowDDLJobs) SetSchema(schema *expression.Schema) + type Simple struct + Statement ast.StmtNode + func (p *Simple) AddChild(child Plan) + func (p *Simple) AddParent(parent Plan) + func (p *Simple) Allocator() *idAllocator + func (p *Simple) Children() []Plan + func (p *Simple) ExplainID() string + func (p *Simple) ID() int + func (p *Simple) MarshalJSON() ([]byte, error) + func (p *Simple) Parents() []Plan + func (p *Simple) ReplaceChild(child, newChild Plan) error + func (p *Simple) ReplaceParent(parent, newPar Plan) error + func (p *Simple) ResolveIndices() + func (p *Simple) Schema() *expression.Schema + func (p *Simple) SetChildren(children ...Plan) + func (p *Simple) SetParents(pars ...Plan) + func (p *Simple) SetSchema(schema *expression.Schema) + type Sort struct + ByItems []*ByItems + ExecLimit *Limit + func (p *Sort) Copy() PhysicalPlan + func (p *Sort) ExplainInfo() string + func (p *Sort) MarshalJSON() ([]byte, error) + func (p *Sort) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Sort) PruneColumns(parentUsedCols []*expression.Column) + func (p *Sort) ResolveIndices() + func (p *Sort) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Sort) AddChild(child Plan) + func (p Sort) AddParent(parent Plan) + func (p Sort) Allocator() *idAllocator + func (p Sort) Children() []Plan + func (p Sort) ExplainID() string + func (p Sort) ID() int + func (p Sort) Parents() []Plan + func (p Sort) ReplaceChild(child, newChild Plan) error + func (p Sort) ReplaceParent(parent, newPar Plan) error + func (p Sort) Schema() *expression.Schema + func (p Sort) SetChildren(children ...Plan) + func (p Sort) SetParents(pars ...Plan) + func (p Sort) SetSchema(schema *expression.Schema) + type TableDual struct + RowCount int + func (p *TableDual) Copy() PhysicalPlan + func (p *TableDual) ExplainInfo() string + func (p *TableDual) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *TableDual) PruneColumns(_ []*expression.Column) + func (p *TableDual) ToPB(_ context.Context) (*tipb.Executor, error) + func (p TableDual) AddChild(child Plan) + func (p TableDual) AddParent(parent Plan) + func (p TableDual) Allocator() *idAllocator + func (p TableDual) Children() []Plan + func (p TableDual) ExplainID() string + func (p TableDual) ID() int + func (p TableDual) MarshalJSON() ([]byte, error) + func (p TableDual) Parents() []Plan + func (p TableDual) ReplaceChild(child, newChild Plan) error + func (p TableDual) ReplaceParent(parent, newPar Plan) error + func (p TableDual) ResolveIndices() + func (p TableDual) Schema() *expression.Schema + func (p TableDual) SetChildren(children ...Plan) + func (p TableDual) SetParents(pars ...Plan) + func (p TableDual) SetSchema(schema *expression.Schema) + type TopN struct + ByItems []*ByItems + Count uint64 + Offset uint64 + func (bp *TopN) ExplainInfo() string + func (p *TopN) Copy() PhysicalPlan + func (p *TopN) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *TopN) PruneColumns(parentUsedCols []*expression.Column) + func (p *TopN) ResolveIndices() + func (p *TopN) ToPB(ctx context.Context) (*tipb.Executor, error) + func (p TopN) AddChild(child Plan) + func (p TopN) AddParent(parent Plan) + func (p TopN) Allocator() *idAllocator + func (p TopN) Children() []Plan + func (p TopN) ExplainID() string + func (p TopN) ID() int + func (p TopN) MarshalJSON() ([]byte, error) + func (p TopN) Parents() []Plan + func (p TopN) ReplaceChild(child, newChild Plan) error + func (p TopN) ReplaceParent(parent, newPar Plan) error + func (p TopN) Schema() *expression.Schema + func (p TopN) SetChildren(children ...Plan) + func (p TopN) SetParents(pars ...Plan) + func (p TopN) SetSchema(schema *expression.Schema) + type Union struct + func (bp *Union) ExplainInfo() string + func (p *Union) Copy() PhysicalPlan + func (p *Union) PredicatePushDown(predicates []expression.Expression) (ret []expression.Expression, retPlan LogicalPlan, err error) + func (p *Union) PruneColumns(parentUsedCols []*expression.Column) + func (p *Union) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Union) AddChild(child Plan) + func (p Union) AddParent(parent Plan) + func (p Union) Allocator() *idAllocator + func (p Union) Children() []Plan + func (p Union) ExplainID() string + func (p Union) ID() int + func (p Union) MarshalJSON() ([]byte, error) + func (p Union) Parents() []Plan + func (p Union) ReplaceChild(child, newChild Plan) error + func (p Union) ReplaceParent(parent, newPar Plan) error + func (p Union) ResolveIndices() + func (p Union) Schema() *expression.Schema + func (p Union) SetChildren(children ...Plan) + func (p Union) SetParents(pars ...Plan) + func (p Union) SetSchema(schema *expression.Schema) + type Update struct + IgnoreErr bool + OrderedList []*expression.Assignment + func (bp *Update) ExplainInfo() string + func (p *Update) Copy() PhysicalPlan + func (p *Update) PredicatePushDown(predicates []expression.Expression) ([]expression.Expression, LogicalPlan, error) + func (p *Update) PruneColumns(parentUsedCols []*expression.Column) + func (p *Update) ResolveIndices() + func (p *Update) ToPB(_ context.Context) (*tipb.Executor, error) + func (p Update) AddChild(child Plan) + func (p Update) AddParent(parent Plan) + func (p Update) Allocator() *idAllocator + func (p Update) Children() []Plan + func (p Update) ExplainID() string + func (p Update) ID() int + func (p Update) MarshalJSON() ([]byte, error) + func (p Update) Parents() []Plan + func (p Update) ReplaceChild(child, newChild Plan) error + func (p Update) ReplaceParent(parent, newPar Plan) error + func (p Update) Schema() *expression.Schema + func (p Update) SetChildren(children ...Plan) + func (p Update) SetParents(pars ...Plan) + func (p Update) SetSchema(schema *expression.Schema)