executor

package
v1.1.0-beta.0...-66cb425 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Nov 13, 2024 License: Apache-2.0 Imports: 243 Imported by: 0

Documentation

Index

Constants

View Source
const LoadDataReaderBuilderKey loadDataVarKeyType = 1

LoadDataReaderBuilderKey stores the reader channel that reads from the connection.

View Source
const LoadDataVarKey loadDataVarKeyType = 0

LoadDataVarKey is a variable key for load data.

View Source
const LoadStatsVarKey loadStatsVarKeyType = 0

LoadStatsVarKey is a variable key for load statistic.

View Source
const PlanReplayerDumpVarKey planReplayerDumpKeyType = 1

PlanReplayerDumpVarKey is a variable key for plan replayer dump.

View Source
const PlanReplayerLoadVarKey planReplayerLoadKeyType = 0

PlanReplayerLoadVarKey is a variable key for plan replayer load.

Variables

View Source
var (
	// RandSeed is the seed for randing package.
	// It's public for test.
	RandSeed = int64(1)

	// MaxRegionSampleSize is the max sample size for one region when analyze v1 collects samples from table.
	// It's public for test.
	MaxRegionSampleSize = int64(1000)
)
View Source
var (

	// GlobalMemoryUsageTracker is the ancestor of all the Executors' memory tracker and GlobalMemory Tracker
	GlobalMemoryUsageTracker *memory.Tracker
	// GlobalDiskUsageTracker is the ancestor of all the Executors' disk tracker
	GlobalDiskUsageTracker *disk.Tracker
	// GlobalAnalyzeMemoryTracker is the ancestor of all the Analyze jobs' memory tracker and child of global Tracker
	GlobalAnalyzeMemoryTracker *memory.Tracker
)
View Source
var (
	// AnalyzeProgressTest is for test.
	AnalyzeProgressTest struct{}
)
View Source
var (

	// CheckTableFastBucketSize is the bucket size of fast check table.
	CheckTableFastBucketSize = atomic.Int64{}
)
View Source
var CloseSession func(ctx sessionctx.Context)

CloseSession will be assigned by session package.

View Source
var CreateSession func(ctx sessionctx.Context) (sessionctx.Context, error)

CreateSession will be assigned by session package.

View Source
var ErrSavepointNotSupportedWithBinlog = errors.New("SAVEPOINT is not supported when binlog is enabled")

ErrSavepointNotSupportedWithBinlog export for testing.

View Source
var (

	// IndexMergeCancelFuncForTest is used just for test
	IndexMergeCancelFuncForTest func()
)
View Source
var LookupTableTaskChannelSize int32 = 50

LookupTableTaskChannelSize represents the channel size of the index double read taskChan.

View Source
var ParseSlowLogBatchSize = 64

ParseSlowLogBatchSize is the batch size of slow-log lines for a worker to parse, exported for testing.

View Source
var QueryReplacer = strings.NewReplacer("\r", " ", "\n", " ", "\t", " ")

QueryReplacer replaces new line and tab for grep result including query string.

View Source
var SplitBatchCreateTableForTest = splitBatchCreateTable

SplitBatchCreateTableForTest is only used for test.

View Source
var TestSetConfigHTTPHandlerKey stringutil.StringerStr = "TestSetConfigHTTPHandlerKey"

TestSetConfigHTTPHandlerKey is used as the key to store 'TestSetConfigDoRequestFunc' in the context.

View Source
var TestSetConfigServerInfoKey stringutil.StringerStr = "TestSetConfigServerInfoKey"

TestSetConfigServerInfoKey is used as the key to store 'TestSetConfigServerInfoFunc' in the context.

View Source
var TestShowClusterConfigKey stringutil.StringerStr = "TestShowClusterConfigKey"

TestShowClusterConfigKey is the key used to store TestShowClusterConfigFunc.

Functions

func AddNewAnalyzeJob

func AddNewAnalyzeJob(ctx sessionctx.Context, job *statistics.AnalyzeJob)

AddNewAnalyzeJob records the new analyze job.

func BRIECreateDatabase

func BRIECreateDatabase(sctx sessionctx.Context, schema *model.DBInfo, brComment string) error

BRIECreateDatabase creates the database with OnExistIgnore option

func BRIECreateTable

func BRIECreateTable(
	sctx sessionctx.Context,
	dbName pmodel.CIStr,
	table *model.TableInfo,
	brComment string,
	cs ...ddl.CreateTableOption,
) error

BRIECreateTable creates the table with OnExistIgnore option

func BRIECreateTables

func BRIECreateTables(
	sctx sessionctx.Context,
	tables map[string][]*model.TableInfo,
	brComment string,
	cs ...ddl.CreateTableOption,
) error

BRIECreateTables creates the tables with OnExistIgnore option in batch

func CalculateBatchSize

func CalculateBatchSize(estRows, initBatchSize, maxBatchSize int) int

CalculateBatchSize calculates a suitable initial batch size. It exports for testing.

func ColumnName

func ColumnName(column string) string

ColumnName returns `column`

func ConstructResultOfShowCreateDatabase

func ConstructResultOfShowCreateDatabase(ctx sessionctx.Context, dbInfo *model.DBInfo, ifNotExists bool, buf *bytes.Buffer) (err error)

ConstructResultOfShowCreateDatabase constructs the result for show create database.

func ConstructResultOfShowCreatePlacementPolicy

func ConstructResultOfShowCreatePlacementPolicy(policyInfo *model.PolicyInfo) string

ConstructResultOfShowCreatePlacementPolicy constructs the result for show create placement policy.

func ConstructResultOfShowCreateSequence

func ConstructResultOfShowCreateSequence(ctx sessionctx.Context, tableInfo *model.TableInfo, buf *bytes.Buffer)

ConstructResultOfShowCreateSequence constructs the result for show create sequence.

func ConstructResultOfShowCreateTable

func ConstructResultOfShowCreateTable(ctx sessionctx.Context, tableInfo *model.TableInfo, allocators autoid.Allocators, buf *bytes.Buffer) (err error)

ConstructResultOfShowCreateTable constructs the result for show create table.

func ConvertConfigItem2JSON

func ConvertConfigItem2JSON(ctx sessionctx.Context, key string, val expression.Expression) (body string, err error)

ConvertConfigItem2JSON converts the config item specified by key and val to json. For example:

set config x key="val" ==> {"key":"val"}
set config x key=233 ==> {"key":233}

func CountStmtNode

func CountStmtNode(stmtNode ast.StmtNode, resolveCtx *resolve.Context, inRestrictedSQL bool, resourceGroup string)

CountStmtNode records the number of statements with the same type.

func DecodeRowValToChunk

func DecodeRowValToChunk(sctx sessionctx.Context, schema *expression.Schema, tblInfo *model.TableInfo,
	handle kv.Handle, rowVal []byte, chk *chunk.Chunk, rd *rowcodec.ChunkDecoder) error

DecodeRowValToChunk decodes row value into chunk checking row format used.

func Detach

func Detach(originalExecutor exec.Executor) (exec.Executor, bool)

Detach detaches the current executor from the session context. After detaching, the session context can be used to execute another statement while this executor is still running. The returning value shows whether this executor is able to be detached.

NOTE: the implementation of `Detach` should guarantee that no matter whether it returns true or false, both the original executor and the returning executor should be able to be used correctly. This restriction is to make sure that if `Detach(a)` returns `true`, while other children of `a`'s parent returns `false`, the caller can still use the original one.

func DumpRealOutfile

func DumpRealOutfile(realBuf, lineBuf []byte, v float64, tp *types.FieldType) ([]byte, []byte)

DumpRealOutfile dumps a real number to lineBuf.

func FillOneImportJobInfo

func FillOneImportJobInfo(info *importer.JobInfo, result *chunk.Chunk, importedRowCount int64)

FillOneImportJobInfo is exported for testing.

func FormatSQL

func FormatSQL(sql string) stringutil.StringerFunc

FormatSQL is used to format the original SQL, e.g. truncating long SQL, appending prepared arguments.

func GenCascadeDeleteAST

func GenCascadeDeleteAST(schema, table, idx pmodel.CIStr, cols []*model.ColumnInfo, fkValues [][]types.Datum) *ast.DeleteStmt

GenCascadeDeleteAST uses to generate cascade delete ast, export for test.

func GenCascadeSetNullAST

func GenCascadeSetNullAST(schema, table, idx pmodel.CIStr, cols []*model.ColumnInfo, fkValues [][]types.Datum) *ast.UpdateStmt

GenCascadeSetNullAST uses to generate foreign key `SET NULL` ast, export for test.

func GenCascadeUpdateAST

func GenCascadeUpdateAST(schema, table, idx pmodel.CIStr, cols []*model.ColumnInfo, couple *UpdatedValuesCouple) *ast.UpdateStmt

GenCascadeUpdateAST uses to generate cascade update ast, export for test.

func GetDropOrTruncateTableInfoFromJobs

func GetDropOrTruncateTableInfoFromJobs(jobs []*model.Job, gcSafePoint uint64, dom *domain.Domain, fn func(*model.Job, *model.TableInfo) (bool, error)) (bool, error)

GetDropOrTruncateTableInfoFromJobs gets the dropped/truncated table information from DDL jobs, it will use the `start_ts` of DDL job as snapshot to get the dropped/truncated table information.

func GetEncodedPlan

func GetEncodedPlan(stmtCtx *stmtctx.StatementContext, genHint bool) (encodedPlan, hintStr string)

GetEncodedPlan returned same as getEncodedPlan

func GetLackHandles

func GetLackHandles(expectedHandles []kv.Handle, obtainedHandlesMap *kv.HandleMap) []kv.Handle

GetLackHandles gets the handles in expectedHandles but not in obtainedHandlesMap.

func GetPhysID

func GetPhysID(tblInfo *model.TableInfo, idx *int) int64

GetPhysID returns the physical id used, either the table's id or a partition's ID

func GetPlanDigest

func GetPlanDigest(stmtCtx *stmtctx.StatementContext) (string, *parser.Digest)

GetPlanDigest will try to get the select plan tree if the plan is select or the select plan of delete/update/insert statement.

func GetResultRowsCount

func GetResultRowsCount(stmtCtx *stmtctx.StatementContext, p base.Plan) int64

GetResultRowsCount gets the count of the statement result rows.

func IsFastPlan

func IsFastPlan(p base.Plan) bool

IsFastPlan exports for testing.

func LoadExprPushdownBlacklist

func LoadExprPushdownBlacklist(sctx sessionctx.Context) (err error)

LoadExprPushdownBlacklist loads the latest data from table mysql.expr_pushdown_blacklist.

func LoadOptRuleBlacklist

func LoadOptRuleBlacklist(ctx context.Context, sctx sessionctx.Context) (err error)

LoadOptRuleBlacklist loads the latest data from table mysql.opt_rule_blacklist.

func LockKeys

func LockKeys(ctx context.Context, sctx sessionctx.Context, lockWaitTime int64, keys ...kv.Key) error

LockKeys locks the keys for pessimistic transaction.

func MockNewCacheTableSnapShot

func MockNewCacheTableSnapShot(snapshot kv.Snapshot, memBuffer kv.MemBuffer) *cacheTableSnapshot

MockNewCacheTableSnapShot only serves for test.

func NewAnalyzeResultsNotifyWaitGroupWrapper

func NewAnalyzeResultsNotifyWaitGroupWrapper(notify chan *statistics.AnalyzeResults) *analyzeResultsNotifyWaitGroupWrapper

NewAnalyzeResultsNotifyWaitGroupWrapper is to create analyzeResultsNotifyWaitGroupWrapper

func NewProfileBuilder

func NewProfileBuilder(sctx sessionctx.Context, start, end time.Time, tp string) (*profileBuilder, error)

NewProfileBuilder returns a new profileBuilder.

func NewRowDecoder

func NewRowDecoder(ctx sessionctx.Context, schema *expression.Schema, tbl *model.TableInfo) *rowcodec.ChunkDecoder

NewRowDecoder creates a chunk decoder for new row format row value decode.

func ParseTime

func ParseTime(s string) (time.Time, error)

ParseTime exports for testing.

func ResetContextOfStmt

func ResetContextOfStmt(ctx sessionctx.Context, s ast.StmtNode) (err error)

ResetContextOfStmt resets the StmtContext and session variables. Before every execution, we must clear statement context.

func ResetDeleteStmtCtx

func ResetDeleteStmtCtx(sc *stmtctx.StatementContext, stmt *ast.DeleteStmt, vars *variable.SessionVars)

ResetDeleteStmtCtx resets statement context for DeleteStmt.

func ResetGlobalBRIEQueueForTest

func ResetGlobalBRIEQueueForTest()

ResetGlobalBRIEQueueForTest resets the ID allocation for the global BRIE queue. In some of our test cases, we rely on the ID is allocated from 1. When batch executing test cases, the assumation may be broken and make the cases fail.

func ResetUpdateStmtCtx

func ResetUpdateStmtCtx(sc *stmtctx.StatementContext, stmt *ast.UpdateStmt, vars *variable.SessionVars)

ResetUpdateStmtCtx resets statement context for UpdateStmt.

func SetFromString

func SetFromString(value string) []string

SetFromString constructs a slice of strings from a comma separated string. It is assumed that there is no duplicated entry. You could use addToSet to maintain this property. It is exported for tests. I HOPE YOU KNOW WHAT YOU ARE DOING.

func Start

func Start()

Start the backend components

func Stop

func Stop()

Stop the backend components

func TableName

func TableName(schema, table string) string

TableName returns `schema`.`table`

func ValidateImportIntoColAssignmentsWithEncodeCtx

func ValidateImportIntoColAssignmentsWithEncodeCtx(plan *importer.Plan, assigns []*ast.Assignment) error

ValidateImportIntoColAssignmentsWithEncodeCtx validates the column assignment expressions should be compatible with the encoding context (which maybe different with the context in the current session). For example, the function `tidb_is_ddl_owner()` requires the optional eval properties which are not provided by the encoding context, so we should avoid using it in the column assignment expressions.

Types

type AdminPluginsExec

type AdminPluginsExec struct {
	exec.BaseExecutor
	Action  core.AdminPluginsAction
	Plugins []string
}

AdminPluginsExec indicates AdminPlugins executor.

func (*AdminPluginsExec) Next

Next implements the Executor Next interface.

type AdminShowBDRRoleExec

type AdminShowBDRRoleExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

AdminShowBDRRoleExec represents a show BDR role executor.

func (*AdminShowBDRRoleExec) Next

func (e *AdminShowBDRRoleExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type AnalyzeColumnsExec

type AnalyzeColumnsExec struct {
	core.AnalyzeInfo
	// contains filtered or unexported fields
}

AnalyzeColumnsExec represents Analyze columns push down executor.

type AnalyzeColumnsExecV1

type AnalyzeColumnsExecV1 struct {
	*AnalyzeColumnsExec
}

AnalyzeColumnsExecV1 is used to maintain v1 analyze process

type AnalyzeColumnsExecV2

type AnalyzeColumnsExecV2 struct {
	*AnalyzeColumnsExec
}

AnalyzeColumnsExecV2 is used to maintain v2 analyze process

type AnalyzeExec

type AnalyzeExec struct {
	exec.BaseExecutor

	OptionsMap map[int64]core.V2AnalyzeOptions
	// contains filtered or unexported fields
}

AnalyzeExec represents Analyze executor.

func (*AnalyzeExec) Next

func (e *AnalyzeExec) Next(ctx context.Context, _ *chunk.Chunk) error

Next implements the Executor Next interface. It will collect all the sample task and run them concurrently.

type AnalyzeIndexExec

type AnalyzeIndexExec struct {
	// contains filtered or unexported fields
}

AnalyzeIndexExec represents analyze index push down executor.

type BRIEExec

type BRIEExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

BRIEExec represents an executor for BRIE statements (BACKUP, RESTORE, etc)

func (*BRIEExec) Next

func (e *BRIEExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type BatchPointGetExec

type BatchPointGetExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

BatchPointGetExec executes a bunch of point select queries.

func (*BatchPointGetExec) Close

func (e *BatchPointGetExec) Close() error

Close implements the Executor interface.

func (*BatchPointGetExec) Next

func (e *BatchPointGetExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor interface.

func (*BatchPointGetExec) Open

Open implements the Executor interface.

type CTEExec

type CTEExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CTEExec implements CTE. Following diagram describes how CTEExec works.

`iterInTbl` is shared by `CTEExec` and `CTETableReaderExec`. `CTETableReaderExec` reads data from `iterInTbl`, and its output will be stored `iterOutTbl` by `CTEExec`.

When an iteration ends, `CTEExec` will move all data from `iterOutTbl` into `iterInTbl`, which will be the input for new iteration. At the end of each iteration, data in `iterOutTbl` will also be added into `resTbl`. `resTbl` stores data of all iteration.

                                  +----------+
                    write         |iterOutTbl|
      CTEExec ------------------->|          |
         |                        +----+-----+
   -------------                       | write
   |           |                       v
other op     other op             +----------+
(seed)       (recursive)          |  resTbl  |
                 ^                |          |
                 |                +----------+
           CTETableReaderExec
                  ^
                  |  read         +----------+
                  +---------------+iterInTbl |
                                  |          |
                                  +----------+

func (*CTEExec) Close

func (e *CTEExec) Close() (firstErr error)

Close implements the Executor interface.

func (*CTEExec) Next

func (e *CTEExec) Next(ctx context.Context, req *chunk.Chunk) (err error)

Next implements the Executor interface.

func (*CTEExec) Open

func (e *CTEExec) Open(ctx context.Context) (err error)

Open implements the Executor interface.

type CTEStorages

type CTEStorages struct {
	ResTbl    cteutil.Storage
	IterInTbl cteutil.Storage
	Producer  *cteProducer
}

CTEStorages stores resTbl and iterInTbl for CTEExec. There will be a map[CTEStorageID]*CTEStorages in StmtCtx, which will store all CTEStorages to make all shared CTEs use same the CTEStorages.

type CTETableReaderExec

type CTETableReaderExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CTETableReaderExec scans data in iterInTbl, which is filled by corresponding CTEExec.

func (*CTETableReaderExec) Close

func (e *CTETableReaderExec) Close() (err error)

Close implements the Executor interface.

func (*CTETableReaderExec) Next

func (e *CTETableReaderExec) Next(_ context.Context, req *chunk.Chunk) (err error)

Next implements the Executor interface.

func (*CTETableReaderExec) Open

func (e *CTETableReaderExec) Open(ctx context.Context) error

Open implements the Executor interface.

type CancelDDLJobsExec

type CancelDDLJobsExec struct {
	*CommandDDLJobsExec
}

CancelDDLJobsExec represents a cancel DDL jobs executor.

type CheckIndexRangeExec

type CheckIndexRangeExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CheckIndexRangeExec outputs the index values which has handle between begin and end.

func (*CheckIndexRangeExec) Close

func (*CheckIndexRangeExec) Close() error

Close implements the Executor Close interface.

func (*CheckIndexRangeExec) Next

func (e *CheckIndexRangeExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*CheckIndexRangeExec) Open

Open implements the Executor Open interface.

type CheckTableExec

type CheckTableExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CheckTableExec represents a check table executor. It is built from the "admin check table" statement, and it checks if the index matches the records in the table.

func (*CheckTableExec) Close

func (e *CheckTableExec) Close() error

Close implements the Executor Close interface.

func (*CheckTableExec) Next

func (e *CheckTableExec) Next(ctx context.Context, _ *chunk.Chunk) error

Next implements the Executor Next interface.

func (*CheckTableExec) Open

func (e *CheckTableExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ChecksumTableExec

type ChecksumTableExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ChecksumTableExec represents ChecksumTable executor.

func (*ChecksumTableExec) Next

func (e *ChecksumTableExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ChecksumTableExec) Open

func (e *ChecksumTableExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type CleanupIndexExec

type CleanupIndexExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CleanupIndexExec represents a cleanup index executor. It is built from "admin cleanup index" statement, is used to delete dangling index data.

func (*CleanupIndexExec) Close

func (*CleanupIndexExec) Close() error

Close implements the Executor Close interface.

func (*CleanupIndexExec) Next

func (e *CleanupIndexExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*CleanupIndexExec) Open

func (e *CleanupIndexExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type Closeable

type Closeable interface {
	// Close closes the object.
	Close() error
}

Closeable is a interface for closeable structures.

type CommandDDLJobsExec

type CommandDDLJobsExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CommandDDLJobsExec is the general struct for Cancel/Pause/Resume commands on DDL jobs. These command currently by admin have the very similar struct and operations, it should be a better idea to have them in the same struct.

func (*CommandDDLJobsExec) Next

Next implements the Executor Next interface for Cancel/Pause/Resume

func (*CommandDDLJobsExec) Open

func (e *CommandDDLJobsExec) Open(ctx context.Context) error

Open implements the Executor for all Cancel/Pause/Resume command on DDL jobs just with different processes. And, it should not be called directly by the Executor.

type CompactTableTiFlashExec

type CompactTableTiFlashExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

CompactTableTiFlashExec represents an executor for "ALTER TABLE [NAME] COMPACT TIFLASH REPLICA" statement.

func (*CompactTableTiFlashExec) Next

Next implements the Executor Next interface.

type Compiler

type Compiler struct {
	Ctx sessionctx.Context
}

Compiler compiles an ast.StmtNode to a physical plan.

func (*Compiler) Compile

func (c *Compiler) Compile(ctx context.Context, stmtNode ast.StmtNode) (_ *ExecStmt, err error)

Compile compiles an ast.StmtNode to a physical plan.

type CoprocessorDAGHandler

type CoprocessorDAGHandler struct {
	// contains filtered or unexported fields
}

CoprocessorDAGHandler uses to handle cop dag request.

func NewCoprocessorDAGHandler

func NewCoprocessorDAGHandler(sctx sessionctx.Context) *CoprocessorDAGHandler

NewCoprocessorDAGHandler creates a new CoprocessorDAGHandler.

func (*CoprocessorDAGHandler) HandleRequest

HandleRequest handles the coprocessor request.

func (*CoprocessorDAGHandler) HandleStreamRequest

HandleStreamRequest handles the coprocessor stream request.

type DDLExec

type DDLExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

DDLExec represents a DDL executor. It grabs a DDL instance from Domain, calling the DDL methods to do the work.

func (*DDLExec) Next

func (e *DDLExec) Next(ctx context.Context, _ *chunk.Chunk) (err error)

Next implements the Executor Next interface.

type DDLJobRetriever

type DDLJobRetriever struct {
	TZLoc *time.Location
	// contains filtered or unexported fields
}

DDLJobRetriever retrieve the DDLJobs. nolint:structcheck

type DDLJobsReaderExec

type DDLJobsReaderExec struct {
	exec.BaseExecutor
	DDLJobRetriever
	// contains filtered or unexported fields
}

DDLJobsReaderExec executes DDLJobs information retrieving.

func (*DDLJobsReaderExec) Close

func (e *DDLJobsReaderExec) Close() error

Close implements the Executor Close interface.

func (*DDLJobsReaderExec) Next

func (e *DDLJobsReaderExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*DDLJobsReaderExec) Open

func (e *DDLJobsReaderExec) Open(ctx context.Context) error

Open implements the Executor Next interface.

type DeallocateExec

type DeallocateExec struct {
	exec.BaseExecutor

	Name string
}

DeallocateExec represent a DEALLOCATE executor.

func (*DeallocateExec) Next

Next implements the Executor Next interface.

type DeleteExec

type DeleteExec struct {
	exec.BaseExecutor

	IsMultiTable bool
	// contains filtered or unexported fields
}

DeleteExec represents a delete executor. See https://dev.mysql.com/doc/refman/5.7/en/delete.html

func (*DeleteExec) Close

func (e *DeleteExec) Close() error

Close implements the Executor Close interface.

func (*DeleteExec) GetFKCascades

func (e *DeleteExec) GetFKCascades() []*FKCascadeExec

GetFKCascades implements WithForeignKeyTrigger interface.

func (*DeleteExec) GetFKChecks

func (e *DeleteExec) GetFKChecks() []*FKCheckExec

GetFKChecks implements WithForeignKeyTrigger interface.

func (*DeleteExec) HasFKCascades

func (e *DeleteExec) HasFKCascades() bool

HasFKCascades implements WithForeignKeyTrigger interface.

func (*DeleteExec) Next

func (e *DeleteExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*DeleteExec) Open

func (e *DeleteExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ExecStmt

type ExecStmt struct {
	// GoCtx stores parent go context.Context for a stmt.
	GoCtx context.Context
	// InfoSchema stores a reference to the schema information.
	InfoSchema infoschema.InfoSchema
	// Plan stores a reference to the final physical plan.
	Plan base.Plan
	// Text represents the origin query text.
	Text string

	StmtNode ast.StmtNode

	Ctx sessionctx.Context

	// LowerPriority represents whether to lower the execution priority of a query.
	LowerPriority bool

	// OutputNames will be set if using cached plan
	OutputNames []*types.FieldName
	PsStmt      *plannercore.PlanCacheStmt
	// contains filtered or unexported fields
}

ExecStmt implements the sqlexec.Statement interface, it builds a planner.Plan to an sqlexec.Statement.

func (*ExecStmt) CloseRecordSet

func (a *ExecStmt) CloseRecordSet(txnStartTS uint64, lastErr error)

CloseRecordSet will finish the execution of current statement and do some record work

func (*ExecStmt) Exec

func (a *ExecStmt) Exec(ctx context.Context) (_ sqlexec.RecordSet, err error)

Exec builds an Executor from a plan. If the Executor doesn't return result, like the INSERT, UPDATE statements, it executes in this function. If the Executor returns result, execution is done after this function returns, in the returned sqlexec.RecordSet Next method.

func (*ExecStmt) FinishExecuteStmt

func (a *ExecStmt) FinishExecuteStmt(txnTS uint64, err error, hasMoreResults bool)

FinishExecuteStmt is used to record some information after `ExecStmt` execution finished: 1. record slow log if needed. 2. record summary statement. 3. record execute duration metric. 4. update the `PrevStmt` in session variable. 5. reset `DurationParse` in session variable.

func (*ExecStmt) GetStmtNode

func (a *ExecStmt) GetStmtNode() ast.StmtNode

GetStmtNode returns the stmtNode inside Statement

func (*ExecStmt) GetTextToLog

func (a *ExecStmt) GetTextToLog(keepHint bool) string

GetTextToLog return the query text to log.

func (*ExecStmt) IsPrepared

func (a *ExecStmt) IsPrepared() bool

IsPrepared returns true if stmt is a prepare statement.

func (*ExecStmt) IsReadOnly

func (a *ExecStmt) IsReadOnly(vars *variable.SessionVars) bool

IsReadOnly returns true if a statement is read only. If current StmtNode is an ExecuteStmt, we can get its prepared stmt, then using ast.IsReadOnly function to determine a statement is read only or not.

func (*ExecStmt) LogSlowQuery

func (a *ExecStmt) LogSlowQuery(txnTS uint64, succ bool, hasMoreResults bool)

LogSlowQuery is used to print the slow query in the log files.

func (*ExecStmt) OriginText

func (a *ExecStmt) OriginText() string

OriginText returns original statement as a string.

func (*ExecStmt) PointGet

func (a *ExecStmt) PointGet(ctx context.Context) (*recordSet, error)

PointGet short path for point exec directly from plan, keep only necessary steps

func (*ExecStmt) RebuildPlan

func (a *ExecStmt) RebuildPlan(ctx context.Context) (int64, error)

RebuildPlan rebuilds current execute statement plan. It returns the current information schema version that 'a' is using.

func (*ExecStmt) SummaryStmt

func (a *ExecStmt) SummaryStmt(succ bool)

SummaryStmt collects statements for information_schema.statements_summary

type ExecuteExec

type ExecuteExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ExecuteExec represents an EXECUTE executor. It cannot be executed by itself, all it needs to do is to build another Executor from a prepared statement.

func (*ExecuteExec) Build

func (e *ExecuteExec) Build(b *executorBuilder) error

Build builds a prepared statement into an executor. After Build, e.StmtExec will be used to do the real execution.

func (*ExecuteExec) Next

Next implements the Executor Next interface.

type ExpandExec

type ExpandExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ExpandExec is used to execute expand logical plan.

func (*ExpandExec) Close

func (e *ExpandExec) Close() error

Close implements the Executor Close interface.

func (*ExpandExec) Next

func (e *ExpandExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ExpandExec) Open

func (e *ExpandExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ExplainExec

type ExplainExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ExplainExec represents an explain executor.

func (*ExplainExec) Close

func (e *ExplainExec) Close() error

Close implements the Executor Close interface.

func (*ExplainExec) Next

func (e *ExplainExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ExplainExec) Open

func (e *ExplainExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type FKCascadeExec

type FKCascadeExec struct {
	// contains filtered or unexported fields
}

FKCascadeExec uses to execute foreign key cascade behaviour.

type FKCascadeRuntimeStats

type FKCascadeRuntimeStats struct {
	Total time.Duration
	Keys  int
}

FKCascadeRuntimeStats contains the FKCascadeExec runtime stats.

func (*FKCascadeRuntimeStats) Clone

Clone implements the RuntimeStats interface.

func (*FKCascadeRuntimeStats) Merge

Merge implements the RuntimeStats interface.

func (*FKCascadeRuntimeStats) String

func (s *FKCascadeRuntimeStats) String() string

String implements the RuntimeStats interface.

func (*FKCascadeRuntimeStats) Tp

func (*FKCascadeRuntimeStats) Tp() int

Tp implements the RuntimeStats interface.

type FKCheckExec

type FKCheckExec struct {
	*plannercore.FKCheck
	// contains filtered or unexported fields
}

FKCheckExec uses to check foreign key constraint. When insert/update child table, need to check the row has related row exists in refer table. When insert/update parent table, need to check the row doesn't have related row exists in refer table.

type FKCheckRuntimeStats

type FKCheckRuntimeStats struct {
	Total time.Duration
	Check time.Duration
	Lock  time.Duration
	Keys  int
}

FKCheckRuntimeStats contains the FKCheckExec runtime stats.

func (*FKCheckRuntimeStats) Clone

Clone implements the RuntimeStats interface.

func (*FKCheckRuntimeStats) Merge

Merge implements the RuntimeStats interface.

func (*FKCheckRuntimeStats) String

func (s *FKCheckRuntimeStats) String() string

String implements the RuntimeStats interface.

func (*FKCheckRuntimeStats) Tp

func (*FKCheckRuntimeStats) Tp() int

Tp implements the RuntimeStats interface.

type FastCheckTableExec

type FastCheckTableExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

FastCheckTableExec represents a check table executor. It is built from the "admin check table" statement, and it checks if the index matches the records in the table. It uses a new algorithms to check table data, which is faster than the old one(CheckTableExec).

func (*FastCheckTableExec) Next

Next implements the Executor Next interface.

func (*FastCheckTableExec) Open

func (e *FastCheckTableExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type GrantExec

type GrantExec struct {
	exec.BaseExecutor

	Privs                 []*ast.PrivElem
	ObjectType            ast.ObjectTypeType
	Level                 *ast.GrantLevel
	Users                 []*ast.UserSpec
	AuthTokenOrTLSOptions []*ast.AuthTokenOrTLSOption

	WithGrant bool
	// contains filtered or unexported fields
}

GrantExec executes GrantStmt.

func (*GrantExec) Next

func (e *GrantExec) Next(ctx context.Context, _ *chunk.Chunk) error

Next implements the Executor Next interface.

type HistoryHotRegion

type HistoryHotRegion struct {
	UpdateTime    int64   `json:"update_time"`
	RegionID      uint64  `json:"region_id"`
	StoreID       uint64  `json:"store_id"`
	PeerID        uint64  `json:"peer_id"`
	IsLearner     bool    `json:"is_learner"`
	IsLeader      bool    `json:"is_leader"`
	HotRegionType string  `json:"hot_region_type"`
	HotDegree     int64   `json:"hot_degree"`
	FlowBytes     float64 `json:"flow_bytes"`
	KeyRate       float64 `json:"key_rate"`
	QueryRate     float64 `json:"query_rate"`
	StartKey      string  `json:"start_key"`
	EndKey        string  `json:"end_key"`
}

HistoryHotRegion records each hot region's statistics. it's the response of PD.

type HistoryHotRegions

type HistoryHotRegions struct {
	HistoryHotRegion []*HistoryHotRegion `json:"history_hot_region"`
}

HistoryHotRegions records filtered hot regions stored in each PD. it's the response of PD.

type HistoryHotRegionsRequest

type HistoryHotRegionsRequest struct {
	StartTime      int64    `json:"start_time,omitempty"`
	EndTime        int64    `json:"end_time,omitempty"`
	RegionIDs      []uint64 `json:"region_ids,omitempty"`
	StoreIDs       []uint64 `json:"store_ids,omitempty"`
	PeerIDs        []uint64 `json:"peer_ids,omitempty"`
	IsLearners     []bool   `json:"is_learners,omitempty"`
	IsLeaders      []bool   `json:"is_leaders,omitempty"`
	HotRegionTypes []string `json:"hot_region_type,omitempty"`
}

HistoryHotRegionsRequest wrap conditions push down to PD.

type ImportIntoActionExec

type ImportIntoActionExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ImportIntoActionExec represents a import into action executor.

func (*ImportIntoActionExec) Next

func (e *ImportIntoActionExec) Next(ctx context.Context, _ *chunk.Chunk) (err error)

Next implements the Executor Next interface.

type ImportIntoExec

type ImportIntoExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ImportIntoExec represents a IMPORT INTO executor.

func (*ImportIntoExec) Next

func (e *ImportIntoExec) Next(ctx context.Context, req *chunk.Chunk) (err error)

Next implements the Executor Next interface.

type IndexLookUpExecutor

type IndexLookUpExecutor struct {
	exec.BaseExecutorV2

	// PushedLimit is used to skip the preceding and tailing handles when Limit is sunk into IndexLookUpReader.
	PushedLimit *plannercore.PushedDownLimit
	// contains filtered or unexported fields
}

IndexLookUpExecutor implements double read for index scan.

func (IndexLookUpExecutor) BuildExecutorForIndexJoin

func (builder IndexLookUpExecutor) BuildExecutorForIndexJoin(ctx context.Context, lookUpContents []*join.IndexJoinLookUpContent,
	indexRanges []*ranger.Range, keyOff2IdxOff []int, cwc *plannercore.ColWithCmpFuncManager, canReorderHandles bool, memTracker *memory.Tracker, interruptSignal *atomic.Value) (exec.Executor, error)

func (*IndexLookUpExecutor) Close

func (e *IndexLookUpExecutor) Close() error

Close implements Exec Close interface.

func (*IndexLookUpExecutor) Detach

func (e *IndexLookUpExecutor) Detach() (exec.Executor, bool)

Detach detaches the current executor from the session context.

func (*IndexLookUpExecutor) Next

func (e *IndexLookUpExecutor) Next(ctx context.Context, req *chunk.Chunk) error

Next implements Exec Next interface.

func (*IndexLookUpExecutor) Open

Open implements the Executor Open interface.

func (*IndexLookUpExecutor) Table

func (e *IndexLookUpExecutor) Table() table.Table

Table implements the dataSourceExecutor interface.

type IndexLookUpRunTimeStats

type IndexLookUpRunTimeStats struct {
	FetchHandleTotal int64
	FetchHandle      int64
	TaskWait         int64
	TableRowScan     int64
	TableTaskNum     int64
	Concurrency      int
	// Record the `Next` call affected wait duration details.
	NextWaitIndexScan        time.Duration
	NextWaitTableLookUpBuild time.Duration
	NextWaitTableLookUpResp  time.Duration
	// contains filtered or unexported fields
}

IndexLookUpRunTimeStats record the indexlookup runtime stat

func (*IndexLookUpRunTimeStats) Clone

Clone implements the RuntimeStats interface.

func (*IndexLookUpRunTimeStats) Merge

Merge implements the RuntimeStats interface.

func (*IndexLookUpRunTimeStats) String

func (e *IndexLookUpRunTimeStats) String() string

func (*IndexLookUpRunTimeStats) Tp

Tp implements the RuntimeStats interface.

type IndexMergeReaderExecutor

type IndexMergeReaderExecutor struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

IndexMergeReaderExecutor accesses a table with multiple index/table scan. There are three types of workers: 1. partialTableWorker/partialIndexWorker, which are used to fetch the handles 2. indexMergeProcessWorker, which is used to do the `Union` operation. 3. indexMergeTableScanWorker, which is used to get the table tuples with the given handles.

The execution flow is really like IndexLookUpReader. However, it uses multiple index scans or table scans to get the handles:

  1. use the partialTableWorkers and partialIndexWorkers to fetch the handles (a batch per time) and send them to the indexMergeProcessWorker.
  2. indexMergeProcessWorker do the `Union` operation for a batch of handles it have got. For every handle in the batch:
  3. check whether it has been accessed.
  4. if not, record it and send it to the indexMergeTableScanWorker.
  5. if accessed, just ignore it.

func (IndexMergeReaderExecutor) BuildExecutorForIndexJoin

func (builder IndexMergeReaderExecutor) BuildExecutorForIndexJoin(ctx context.Context, lookUpContents []*join.IndexJoinLookUpContent,
	indexRanges []*ranger.Range, keyOff2IdxOff []int, cwc *plannercore.ColWithCmpFuncManager, canReorderHandles bool, memTracker *memory.Tracker, interruptSignal *atomic.Value) (exec.Executor, error)

func (*IndexMergeReaderExecutor) Close

func (e *IndexMergeReaderExecutor) Close() error

Close implements Exec Close interface.

func (*IndexMergeReaderExecutor) Next

Next implements Executor Next interface.

func (*IndexMergeReaderExecutor) Open

func (e *IndexMergeReaderExecutor) Open(_ context.Context) (err error)

Open implements the Executor Open interface

func (*IndexMergeReaderExecutor) Table

Table implements the dataSourceExecutor interface.

type IndexMergeRuntimeStat

type IndexMergeRuntimeStat struct {
	IndexMergeProcess time.Duration
	FetchIdxTime      int64
	WaitTime          int64
	FetchRow          int64
	TableTaskNum      int64
	Concurrency       int
}

IndexMergeRuntimeStat record the indexMerge runtime stat

func (*IndexMergeRuntimeStat) Clone

Clone implements the RuntimeStats interface.

func (*IndexMergeRuntimeStat) Merge

Merge implements the RuntimeStats interface.

func (*IndexMergeRuntimeStat) String

func (e *IndexMergeRuntimeStat) String() string

func (*IndexMergeRuntimeStat) Tp

func (*IndexMergeRuntimeStat) Tp() int

Tp implements the RuntimeStats interface.

type IndexReaderExecutor

type IndexReaderExecutor struct {
	exec.BaseExecutorV2
	// contains filtered or unexported fields
}

IndexReaderExecutor sends dag request and reads index data from kv layer.

func (*IndexReaderExecutor) Close

func (e *IndexReaderExecutor) Close() (err error)

Close clears all resources hold by current object.

func (*IndexReaderExecutor) Detach

func (e *IndexReaderExecutor) Detach() (exec.Executor, bool)

Detach detaches the current executor from the session context.

func (*IndexReaderExecutor) Next

func (e *IndexReaderExecutor) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*IndexReaderExecutor) Open

Open implements the Executor Open interface.

func (IndexReaderExecutor) SelectResult

func (sr IndexReaderExecutor) SelectResult(ctx context.Context, dctx *distsqlctx.DistSQLContext, kvReq *kv.Request,
	fieldTypes []*types.FieldType, copPlanIDs []int, rootPlanID int) (distsql.SelectResult, error)

func (*IndexReaderExecutor) Table

func (e *IndexReaderExecutor) Table() table.Table

Table implements the dataSourceExecutor interface.

type InsertExec

type InsertExec struct {
	*InsertValues
	OnDuplicate []*expression.Assignment

	Priority mysql.PriorityEnum
	// contains filtered or unexported fields
}

InsertExec represents an insert executor.

func (*InsertExec) Close

func (e *InsertExec) Close() error

Close implements the Executor Close interface.

func (*InsertExec) GetFKCascades

func (e *InsertExec) GetFKCascades() []*FKCascadeExec

GetFKCascades implements WithForeignKeyTrigger interface.

func (*InsertExec) GetFKChecks

func (e *InsertExec) GetFKChecks() []*FKCheckExec

GetFKChecks implements WithForeignKeyTrigger interface.

func (*InsertExec) HasFKCascades

func (e *InsertExec) HasFKCascades() bool

HasFKCascades implements WithForeignKeyTrigger interface.

func (*InsertExec) Next

func (e *InsertExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*InsertExec) Open

func (e *InsertExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type InsertRuntimeStat

type InsertRuntimeStat struct {
	*execdetails.BasicRuntimeStats
	*txnsnapshot.SnapshotRuntimeStats
	*autoid.AllocatorRuntimeStats
	CheckInsertTime time.Duration
	Prefetch        time.Duration
	FKCheckTime     time.Duration
}

InsertRuntimeStat record the stat about insert and check

func (*InsertRuntimeStat) Clone

Clone implements the RuntimeStats interface.

func (*InsertRuntimeStat) Merge

func (e *InsertRuntimeStat) Merge(other execdetails.RuntimeStats)

Merge implements the RuntimeStats interface.

func (*InsertRuntimeStat) String

func (e *InsertRuntimeStat) String() string

func (*InsertRuntimeStat) Tp

func (*InsertRuntimeStat) Tp() int

Tp implements the RuntimeStats interface.

type InsertValues

type InsertValues struct {
	exec.BaseExecutor

	SelectExec exec.Executor

	Table   table.Table
	Columns []*ast.ColumnName
	Lists   [][]expression.Expression

	GenExprs []expression.Expression
	// contains filtered or unexported fields
}

InsertValues is the data to insert. nolint:structcheck

type LimitExec

type LimitExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

LimitExec represents limit executor It ignores 'Offset' rows from src, then returns 'Count' rows at maximum.

func (*LimitExec) Close

func (e *LimitExec) Close() error

Close implements the Executor Close interface.

func (*LimitExec) Next

func (e *LimitExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*LimitExec) Open

func (e *LimitExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type LoadDataExec

type LoadDataExec struct {
	exec.BaseExecutor

	FileLocRef ast.FileLocRefTp
	// contains filtered or unexported fields
}

LoadDataExec represents a load data executor.

func (*LoadDataExec) Close

func (e *LoadDataExec) Close() error

Close implements the Executor interface.

func (*LoadDataExec) Next

func (e *LoadDataExec) Next(ctx context.Context, _ *chunk.Chunk) (err error)

Next implements the Executor Next interface.

func (*LoadDataExec) Open

func (e *LoadDataExec) Open(_ context.Context) error

Open implements the Executor interface.

type LoadDataReaderBuilder

type LoadDataReaderBuilder func(filepath string) (
	r io.ReadCloser, err error,
)

LoadDataReaderBuilder is a function type that builds a reader from a file path.

type LoadDataWorker

type LoadDataWorker struct {
	UserSctx sessionctx.Context
	// contains filtered or unexported fields
}

LoadDataWorker does a LOAD DATA job.

func NewLoadDataWorker

func NewLoadDataWorker(
	userSctx sessionctx.Context,
	plan *plannercore.LoadData,
	tbl table.Table,
) (w *LoadDataWorker, err error)

NewLoadDataWorker creates a new LoadDataWorker that is ready to work.

func (*LoadDataWorker) GetController

func (e *LoadDataWorker) GetController() *importer.LoadDataController

GetController get load data controller. used in unit test.

func (*LoadDataWorker) GetInfilePath

func (e *LoadDataWorker) GetInfilePath() string

GetInfilePath get infile path.

func (*LoadDataWorker) LoadLocal

func (e *LoadDataWorker) LoadLocal(ctx context.Context, r io.ReadCloser) error

LoadLocal reads from client connection and do load data job.

func (*LoadDataWorker) TestLoadLocal

func (e *LoadDataWorker) TestLoadLocal(parser mydump.Parser) error

TestLoadLocal is a helper function for unit test.

type LoadStatsExec

type LoadStatsExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

LoadStatsExec represents a load statistic executor.

func (*LoadStatsExec) Close

func (*LoadStatsExec) Close() error

Close implements the Executor Close interface.

func (*LoadStatsExec) Next

func (e *LoadStatsExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*LoadStatsExec) Open

Open implements the Executor Open interface.

type LoadStatsInfo

type LoadStatsInfo struct {
	Path string
	Ctx  sessionctx.Context
}

LoadStatsInfo saves the information of loading statistic operation.

func (*LoadStatsInfo) Update

func (e *LoadStatsInfo) Update(data []byte) error

Update updates the stats of the corresponding table according to the data.

type MPPGather

type MPPGather struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

MPPGather dispatch MPP tasks and read data from root tasks.

func (*MPPGather) Close

func (e *MPPGather) Close() error

Close and release the used resources.

func (*MPPGather) Next

func (e *MPPGather) Next(ctx context.Context, chk *chunk.Chunk) error

Next fills data into the chunk passed by its caller.

func (*MPPGather) Open

func (e *MPPGather) Open(ctx context.Context) (err error)

Open implements the Executor Open interface.

func (*MPPGather) Table

func (e *MPPGather) Table() table.Table

Table implements the dataSourceExecutor interface.

type MaxOneRowExec

type MaxOneRowExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

MaxOneRowExec checks if the number of rows that a query returns is at maximum one. It's built from subquery expression.

func (*MaxOneRowExec) Next

func (e *MaxOneRowExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*MaxOneRowExec) Open

func (e *MaxOneRowExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type MemTableReaderExec

type MemTableReaderExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

MemTableReaderExec executes memTable information retrieving from the MemTable components

func (*MemTableReaderExec) Close

func (e *MemTableReaderExec) Close() error

Close implements the Executor Close interface.

func (*MemTableReaderExec) Next

func (e *MemTableReaderExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type MetricRetriever

type MetricRetriever struct {
	// contains filtered or unexported fields
}

MetricRetriever uses to read metric data.

type MetricsSummaryByLabelRetriever

type MetricsSummaryByLabelRetriever struct {
	// contains filtered or unexported fields
}

MetricsSummaryByLabelRetriever uses to read metric detail data.

type MetricsSummaryRetriever

type MetricsSummaryRetriever struct {
	// contains filtered or unexported fields
}

MetricsSummaryRetriever uses to read metric data.

type MockExecutorBuilder

type MockExecutorBuilder struct {
	// contains filtered or unexported fields
}

MockExecutorBuilder is a wrapper for executorBuilder. ONLY used in test.

func NewMockExecutorBuilderForTest

func NewMockExecutorBuilderForTest(ctx sessionctx.Context, is infoschema.InfoSchema) *MockExecutorBuilder

NewMockExecutorBuilderForTest is ONLY used in test.

func (*MockExecutorBuilder) Build

Build builds an executor tree according to `p`.

type MockMetricsPromDataKey

type MockMetricsPromDataKey struct{}

MockMetricsPromDataKey is for test

type ParallelNestedLoopApplyExec

type ParallelNestedLoopApplyExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ParallelNestedLoopApplyExec is the executor for apply.

func (*ParallelNestedLoopApplyExec) Close

Close implements the Executor interface.

func (*ParallelNestedLoopApplyExec) Next

func (e *ParallelNestedLoopApplyExec) Next(ctx context.Context, req *chunk.Chunk) (err error)

Next implements the Executor interface.

func (*ParallelNestedLoopApplyExec) Open

Open implements the Executor interface.

type PauseDDLJobsExec

type PauseDDLJobsExec struct {
	*CommandDDLJobsExec
}

PauseDDLJobsExec indicates an Executor for Pause a DDL Job.

type PessimisticLockCacheGetter

type PessimisticLockCacheGetter struct {
	// contains filtered or unexported fields
}

PessimisticLockCacheGetter implements the kv.Getter interface. It is used as a middle cache to construct the BufferedBatchGetter.

func (*PessimisticLockCacheGetter) Get

func (getter *PessimisticLockCacheGetter) Get(_ context.Context, key kv.Key) ([]byte, error)

Get implements the kv.Getter interface.

type PipelinedWindowExec

type PipelinedWindowExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

PipelinedWindowExec is the executor for window functions.

func (*PipelinedWindowExec) Close

func (e *PipelinedWindowExec) Close() error

Close implements the Executor Close interface.

func (*PipelinedWindowExec) Next

func (e *PipelinedWindowExec) Next(ctx context.Context, chk *chunk.Chunk) (err error)

Next implements the Executor Next interface.

func (*PipelinedWindowExec) Open

func (e *PipelinedWindowExec) Open(ctx context.Context) (err error)

Open implements the Executor Open interface

type PlanReplayerCaptureInfo

type PlanReplayerCaptureInfo struct {
	SQLDigest  string
	PlanDigest string
	Remove     bool
}

PlanReplayerCaptureInfo indicates capture info

type PlanReplayerDumpInfo

type PlanReplayerDumpInfo struct {
	ExecStmts         []ast.StmtNode
	Analyze           bool
	HistoricalStatsTS uint64
	StartTS           uint64
	Path              string
	File              *os.File
	FileName          string
	// contains filtered or unexported fields
}

PlanReplayerDumpInfo indicates dump info

func (*PlanReplayerDumpInfo) DumpSQLsFromFile

func (e *PlanReplayerDumpInfo) DumpSQLsFromFile(ctx context.Context, b []byte) error

DumpSQLsFromFile dumps plan replayer results for sqls from file

type PlanReplayerExec

type PlanReplayerExec struct {
	exec.BaseExecutor
	CaptureInfo *PlanReplayerCaptureInfo
	DumpInfo    *PlanReplayerDumpInfo
	// contains filtered or unexported fields
}

PlanReplayerExec represents a plan replayer executor.

func (*PlanReplayerExec) Next

func (e *PlanReplayerExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type PlanReplayerLoadExec

type PlanReplayerLoadExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

PlanReplayerLoadExec represents a plan replayer load executor.

func (*PlanReplayerLoadExec) Next

Next implements the Executor Next interface.

type PlanReplayerLoadInfo

type PlanReplayerLoadInfo struct {
	Path string
	Ctx  sessionctx.Context
}

PlanReplayerLoadInfo contains file path and session context.

func (*PlanReplayerLoadInfo) Update

func (e *PlanReplayerLoadInfo) Update(data []byte) error

Update updates the data of the corresponding table.

type PointGetExecutor

type PointGetExecutor struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

PointGetExecutor executes point select query.

func (*PointGetExecutor) Close

func (e *PointGetExecutor) Close() error

Close implements the Executor interface.

func (*PointGetExecutor) Init

Init set fields needed for PointGetExecutor reuse, this does NOT change baseExecutor field

func (*PointGetExecutor) Next

func (e *PointGetExecutor) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor interface.

func (*PointGetExecutor) Open

Open implements the Executor interface.

type PrepareExec

type PrepareExec struct {
	exec.BaseExecutor

	ID         uint32
	ParamCount int
	Fields     []*resolve.ResultField
	Stmt       any
	// contains filtered or unexported fields
}

PrepareExec represents a PREPARE executor.

func NewPrepareExec

func NewPrepareExec(ctx sessionctx.Context, sqlTxt string) *PrepareExec

NewPrepareExec creates a new PrepareExec.

func (*PrepareExec) Next

func (e *PrepareExec) Next(ctx context.Context, _ *chunk.Chunk) error

Next implements the Executor Next interface.

type ProjectionExec

type ProjectionExec struct {
	exec.BaseExecutorV2
	// contains filtered or unexported fields
}

ProjectionExec implements the physical Projection Operator: https://en.wikipedia.org/wiki/Projection_(relational_algebra)

func (*ProjectionExec) Close

func (e *ProjectionExec) Close() error

Close implements the Executor Close interface.

func (*ProjectionExec) Detach

func (e *ProjectionExec) Detach() (exec.Executor, bool)

Detach detaches the current executor from the session context.

func (*ProjectionExec) Next

func (e *ProjectionExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

Here we explain the execution flow of the parallel projection implementation. There are 3 main components:

  1. "projectionInputFetcher": Fetch input "Chunk" from child.
  2. "projectionWorker": Do the projection work.
  3. "ProjectionExec.Next": Return result to parent.

1. "projectionInputFetcher" gets its input and output resources from its "inputCh" and "outputCh" channel, once the input and output resources are obtained, it fetches child's result into "input.chk" and:

a. Dispatches this input to the worker specified in "input.targetWorker"
b. Dispatches this output to the main thread: "ProjectionExec.Next"
c. Dispatches this output to the worker specified in "input.targetWorker"

It is finished and exited once:

a. There is no more input from child.
b. "ProjectionExec" close the "globalFinishCh"

2. "projectionWorker" gets its input and output resources from its "inputCh" and "outputCh" channel, once the input and output resources are abtained, it calculates the projection result use "input.chk" as the input and "output.chk" as the output, once the calculation is done, it:

a. Sends "nil" or error to "output.done" to mark this input is finished.
b. Returns the "input" resource to "projectionInputFetcher.inputCh"

They are finished and exited once:

a. "ProjectionExec" closes the "globalFinishCh"

3. "ProjectionExec.Next" gets its output resources from its "outputCh" channel. After receiving an output from "outputCh", it should wait to receive a "nil" or error from "output.done" channel. Once a "nil" or error is received:

a. Returns this output to its parent
b. Returns the "output" resource to "projectionInputFetcher.outputCh"

+-----------+----------------------+--------------------------+
|           |                      |                          |
|  +--------+---------+   +--------+---------+       +--------+---------+
|  | projectionWorker |   + projectionWorker |  ...  + projectionWorker |
|  +------------------+   +------------------+       +------------------+
|       ^       ^              ^       ^                  ^       ^
|       |       |              |       |                  |       |
|    inputCh outputCh       inputCh outputCh           inputCh outputCh
|       ^       ^              ^       ^                  ^       ^
|       |       |              |       |                  |       |
|                              |       |
|                              |       +----------------->outputCh
|                              |       |                      |
|                              |       |                      v
|                      +-------+-------+--------+   +---------------------+
|                      | projectionInputFetcher |   | ProjectionExec.Next |
|                      +------------------------+   +---------+-----------+
|                              ^       ^                      |
|                              |       |                      |
|                           inputCh outputCh                  |
|                              ^       ^                      |
|                              |       |                      |
+------------------------------+       +----------------------+

func (*ProjectionExec) Open

func (e *ProjectionExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type RecommendIndexExec

type RecommendIndexExec struct {
	exec.BaseExecutor

	Action   string
	SQL      string
	AdviseID int64
	Options  []ast.RecommendIndexOption
	// contains filtered or unexported fields
}

RecommendIndexExec represents a recommend index executor.

func (*RecommendIndexExec) Next

func (e *RecommendIndexExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type RecoverIndexExec

type RecoverIndexExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

RecoverIndexExec represents a recover index executor. It is built from "admin recover index" statement, is used to backfill corrupted index.

func (*RecoverIndexExec) Next

func (e *RecoverIndexExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*RecoverIndexExec) Open

func (e *RecoverIndexExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ReloadExprPushdownBlacklistExec

type ReloadExprPushdownBlacklistExec struct {
	exec.BaseExecutor
}

ReloadExprPushdownBlacklistExec indicates ReloadExprPushdownBlacklist executor.

func (*ReloadExprPushdownBlacklistExec) Next

Next implements the Executor Next interface.

type ReloadOptRuleBlacklistExec

type ReloadOptRuleBlacklistExec struct {
	exec.BaseExecutor
}

ReloadOptRuleBlacklistExec indicates ReloadOptRuleBlacklist executor.

func (*ReloadOptRuleBlacklistExec) Next

Next implements the Executor Next interface.

type ReplaceExec

type ReplaceExec struct {
	*InsertValues
	Priority int
}

ReplaceExec represents a replace executor.

func (*ReplaceExec) Close

func (e *ReplaceExec) Close() error

Close implements the Executor Close interface.

func (*ReplaceExec) GetFKCascades

func (e *ReplaceExec) GetFKCascades() []*FKCascadeExec

GetFKCascades implements WithForeignKeyTrigger interface.

func (*ReplaceExec) GetFKChecks

func (e *ReplaceExec) GetFKChecks() []*FKCheckExec

GetFKChecks implements WithForeignKeyTrigger interface.

func (*ReplaceExec) HasFKCascades

func (e *ReplaceExec) HasFKCascades() bool

HasFKCascades implements WithForeignKeyTrigger interface.

func (*ReplaceExec) Next

func (e *ReplaceExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ReplaceExec) Open

func (e *ReplaceExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ResumeDDLJobsExec

type ResumeDDLJobsExec struct {
	*CommandDDLJobsExec
}

ResumeDDLJobsExec indicates an Executor for Resume a DDL Job.

type RevokeExec

type RevokeExec struct {
	exec.BaseExecutor

	Privs      []*ast.PrivElem
	ObjectType ast.ObjectTypeType
	Level      *ast.GrantLevel
	Users      []*ast.UserSpec
	// contains filtered or unexported fields
}

RevokeExec executes RevokeStmt.

func (*RevokeExec) Next

func (e *RevokeExec) Next(ctx context.Context, _ *chunk.Chunk) error

Next implements the Executor Next interface.

type SQLBindExec

type SQLBindExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

SQLBindExec represents a bind executor.

func (*SQLBindExec) Next

func (e *SQLBindExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type SelectIntoExec

type SelectIntoExec struct {
	exec.BaseExecutor

	core.LineFieldsInfo
	// contains filtered or unexported fields
}

SelectIntoExec represents a SelectInto executor.

func (*SelectIntoExec) Close

func (s *SelectIntoExec) Close() error

Close implements the Executor Close interface.

func (*SelectIntoExec) Next

func (s *SelectIntoExec) Next(ctx context.Context, _ *chunk.Chunk) error

Next implements the Executor Next interface.

func (*SelectIntoExec) Open

func (s *SelectIntoExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type SelectLockExec

type SelectLockExec struct {
	exec.BaseExecutor

	Lock *ast.SelectLockInfo
	// contains filtered or unexported fields
}

SelectLockExec represents a select lock executor. It is built from the "SELECT .. FOR UPDATE" or the "SELECT .. LOCK IN SHARE MODE" statement. For "SELECT .. FOR UPDATE" statement, it locks every row key from source Executor. After the execution, the keys are buffered in transaction, and will be sent to KV when doing commit. If there is any key already locked by another transaction, the transaction will rollback and retry.

func (*SelectLockExec) Next

func (e *SelectLockExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*SelectLockExec) Open

func (e *SelectLockExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type SelectionExec

type SelectionExec struct {
	exec.BaseExecutorV2
	// contains filtered or unexported fields
}

SelectionExec represents a filter executor.

func (*SelectionExec) Close

func (e *SelectionExec) Close() error

Close implements plannercore.Plan Close interface.

func (*SelectionExec) Detach

func (e *SelectionExec) Detach() (exec.Executor, bool)

Detach detaches the current executor from the session context.

func (*SelectionExec) Next

func (e *SelectionExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*SelectionExec) Open

func (e *SelectionExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type SetConfigExec

type SetConfigExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

SetConfigExec executes 'SET CONFIG' statement.

func (*SetConfigExec) Next

func (s *SetConfigExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*SetConfigExec) Open

Open implements the Executor Open interface.

type SetExecutor

type SetExecutor struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

SetExecutor executes set statement.

func (*SetExecutor) Next

func (e *SetExecutor) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type ShowDDLExec

type ShowDDLExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ShowDDLExec represents a show DDL executor.

func (*ShowDDLExec) Next

func (e *ShowDDLExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type ShowDDLJobQueriesExec

type ShowDDLJobQueriesExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ShowDDLJobQueriesExec represents a show DDL job queries executor. The jobs id that is given by 'admin show ddl job queries' statement, only be searched in the latest 10 history jobs.

func (*ShowDDLJobQueriesExec) Next

Next implements the Executor Next interface.

func (*ShowDDLJobQueriesExec) Open

Open implements the Executor Open interface.

type ShowDDLJobQueriesWithRangeExec

type ShowDDLJobQueriesWithRangeExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ShowDDLJobQueriesWithRangeExec represents a show DDL job queries with range executor. The jobs id that is given by 'admin show ddl job queries' statement, can be searched within a specified range in history jobs using offset and limit.

func (*ShowDDLJobQueriesWithRangeExec) Next

Next implements the Executor Next interface.

func (*ShowDDLJobQueriesWithRangeExec) Open

Open implements the Executor Open interface.

type ShowDDLJobsExec

type ShowDDLJobsExec struct {
	exec.BaseExecutor
	DDLJobRetriever
	// contains filtered or unexported fields
}

ShowDDLJobsExec represent a show DDL jobs executor.

func (*ShowDDLJobsExec) Close

func (e *ShowDDLJobsExec) Close() error

Close implements the Executor Close interface.

func (*ShowDDLJobsExec) Next

func (e *ShowDDLJobsExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ShowDDLJobsExec) Open

func (e *ShowDDLJobsExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ShowExec

type ShowExec struct {
	exec.BaseExecutor

	Tp                ast.ShowStmtType // Databases/Tables/Columns/....
	DBName            pmodel.CIStr
	Table             *resolve.TableNameW  // Used for showing columns.
	Partition         pmodel.CIStr         // Used for showing partition
	Column            *ast.ColumnName      // Used for `desc table column`.
	IndexName         pmodel.CIStr         // Used for show table regions.
	ResourceGroupName pmodel.CIStr         // Used for showing resource group
	Flag              int                  // Some flag parsed from sql, such as FULL.
	Roles             []*auth.RoleIdentity // Used for show grants.
	User              *auth.UserIdentity   // Used by show grants, show create user.
	Extractor         base.ShowPredicateExtractor

	CountWarningsOrErrors bool // Used for showing count(*) warnings | errors

	Full        bool
	IfNotExists bool // Used for `show create database if not exists`
	GlobalScope bool // GlobalScope is used by show variables
	Extended    bool // Used for `show extended columns from ...`

	ImportJobID *int64
	// contains filtered or unexported fields
}

ShowExec represents a show executor.

func (*ShowExec) Next

func (e *ShowExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type ShowNextRowIDExec

type ShowNextRowIDExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ShowNextRowIDExec represents a show the next row ID executor.

func (*ShowNextRowIDExec) Next

func (e *ShowNextRowIDExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

type ShowSlowExec

type ShowSlowExec struct {
	exec.BaseExecutor

	ShowSlow *ast.ShowSlow
	// contains filtered or unexported fields
}

ShowSlowExec represents the executor of showing the slow queries. It is build from the "admin show slow" statement:

admin show slow top [internal | all] N
admin show slow recent N

func (*ShowSlowExec) Next

func (e *ShowSlowExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ShowSlowExec) Open

func (e *ShowSlowExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type ShuffleExec

type ShuffleExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

ShuffleExec is the executor to run other executors in a parallel manner.

  1. It fetches chunks from M `DataSources` (value of M depends on the actual executor, e.g. M = 1 for WindowExec, M = 2 for MergeJoinExec).

  2. It splits tuples from each `DataSource` into N partitions (Only "split by hash" is implemented so far).

  3. It invokes N workers in parallel, each one has M `receiver` to receive partitions from `DataSources`

  4. It assigns partitions received as input to each worker and executes child executors.

  5. It collects outputs from each worker, then sends outputs to its parent.

    +-------------+ +-------| Main Thread | | +------+------+ | ^ | | | + v +++ outputHolderCh | | outputCh (1 x Concurrency) v +++ | ^ | | | +-------+-------+ v | | +--------------+ +--------------+ +----- | worker | ....... | worker | worker (N Concurrency): child executor, eg. WindowExec (+SortExec) | +------------+-+ +-+------------+ | ^ ^ | | | | +-+ +-+ ...... +-+ | | | | | | | | ... ... ... inputCh (Concurrency x 1) v | | | | | | inputHolderCh +++ +++ +++ v ^ ^ ^ | | | | | +------o----+ | | | +-----------------+-----+ | | | | +---+------------+------------+----+-----------+ | | Partition Splitter | | +--------------+-+------------+-+--------------+ | ^ | | | +---------------v-----------------+ +----------> | fetch data from DataSource | +---------------------------------+

func (*ShuffleExec) Close

func (e *ShuffleExec) Close() error

Close implements the Executor Close interface.

func (*ShuffleExec) Next

func (e *ShuffleExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*ShuffleExec) Open

func (e *ShuffleExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type SimpleExec

type SimpleExec struct {
	exec.BaseExecutor

	Statement  ast.StmtNode
	ResolveCtx *resolve.Context
	// IsFromRemote indicates whether the statement IS FROM REMOTE TiDB instance in cluster,
	//   and executing in coprocessor.
	//   Used for `global kill`. See https://github.com/pingcap/tidb/blob/master/docs/design/2020-06-01-global-kill.md.
	IsFromRemote bool
	// contains filtered or unexported fields
}

SimpleExec represents simple statement executor. For statements do simple execution. includes `UseStmt`, 'SetStmt`, `DoStmt`, `BeginStmt`, `CommitStmt`, `RollbackStmt`. TODO: list all simple statements.

func (*SimpleExec) Next

func (e *SimpleExec) Next(ctx context.Context, _ *chunk.Chunk) (err error)

Next implements the Executor Next interface.

type SimpleSeekerOnReadCloser

type SimpleSeekerOnReadCloser struct {
	// contains filtered or unexported fields
}

SimpleSeekerOnReadCloser provides Seek(0, SeekCurrent) on ReadCloser.

func NewSimpleSeekerOnReadCloser

func NewSimpleSeekerOnReadCloser(r io.ReadCloser) *SimpleSeekerOnReadCloser

NewSimpleSeekerOnReadCloser creates a SimpleSeekerOnReadCloser.

func (*SimpleSeekerOnReadCloser) Close

func (s *SimpleSeekerOnReadCloser) Close() error

Close implements io.Closer.

func (*SimpleSeekerOnReadCloser) GetFileSize

func (*SimpleSeekerOnReadCloser) GetFileSize() (int64, error)

GetFileSize implements storage.ExternalFileReader.

func (*SimpleSeekerOnReadCloser) Read

func (s *SimpleSeekerOnReadCloser) Read(p []byte) (n int, err error)

Read implements io.Reader.

func (*SimpleSeekerOnReadCloser) Seek

func (s *SimpleSeekerOnReadCloser) Seek(offset int64, whence int) (int64, error)

Seek implements io.Seeker.

type SplitIndexRegionExec

type SplitIndexRegionExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

SplitIndexRegionExec represents a split index regions executor.

func (*SplitIndexRegionExec) Next

func (e *SplitIndexRegionExec) Next(ctx context.Context, chk *chunk.Chunk) error

Next implements the Executor Next interface.

func (*SplitIndexRegionExec) Open

func (e *SplitIndexRegionExec) Open(context.Context) (err error)

Open implements the Executor Open interface.

type SplitTableRegionExec

type SplitTableRegionExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

SplitTableRegionExec represents a split table regions executor.

func (*SplitTableRegionExec) Next

func (e *SplitTableRegionExec) Next(ctx context.Context, chk *chunk.Chunk) error

Next implements the Executor Next interface.

func (*SplitTableRegionExec) Open

func (e *SplitTableRegionExec) Open(context.Context) (err error)

Open implements the Executor Open interface.

type TableDualExec

type TableDualExec struct {
	exec.BaseExecutorV2
	// contains filtered or unexported fields
}

TableDualExec represents a dual table executor.

func (*TableDualExec) Next

func (e *TableDualExec) Next(_ context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*TableDualExec) Open

Open implements the Executor Open interface.

type TableReaderExecutor

type TableReaderExecutor struct {
	exec.BaseExecutorV2
	// contains filtered or unexported fields
}

TableReaderExecutor sends DAG request and reads table data from kv layer.

func (*TableReaderExecutor) Close

func (e *TableReaderExecutor) Close() error

Close implements the Executor Close interface.

func (*TableReaderExecutor) Detach

func (e *TableReaderExecutor) Detach() (exec.Executor, bool)

Detach detaches the current executor from the session context.

func (*TableReaderExecutor) GetDDLOwner

func (treCtx *TableReaderExecutor) GetDDLOwner(ctx context.Context) (*infosync.ServerInfo, error)

func (*TableReaderExecutor) GetInfoSchema

func (treCtx *TableReaderExecutor) GetInfoSchema() isctx.MetaOnlyInfoSchema

func (*TableReaderExecutor) Next

func (e *TableReaderExecutor) Next(ctx context.Context, req *chunk.Chunk) error

Next fills data into the chunk passed by its caller. The task was actually done by tableReaderHandler.

func (*TableReaderExecutor) Open

Open initializes necessary variables for using this executor.

func (TableReaderExecutor) SelectResult

func (sr TableReaderExecutor) SelectResult(ctx context.Context, dctx *distsqlctx.DistSQLContext, kvReq *kv.Request,
	fieldTypes []*types.FieldType, copPlanIDs []int, rootPlanID int) (distsql.SelectResult, error)

func (*TableReaderExecutor) Table

func (e *TableReaderExecutor) Table() table.Table

Table implements the dataSourceExecutor interface.

type TableSampleExecutor

type TableSampleExecutor struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

TableSampleExecutor fetches a few rows through kv.Scan according to the specific sample method.

func (*TableSampleExecutor) Close

func (*TableSampleExecutor) Close() error

Close implements the Executor Close interface.

func (*TableSampleExecutor) Next

Next fills data into the chunk passed by its caller. The task was actually done by sampler.

func (*TableSampleExecutor) Open

Open initializes necessary variables for using this executor.

type TableScanExec

type TableScanExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

TableScanExec is a table scan executor without result fields.

func (*TableScanExec) Next

func (e *TableScanExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*TableScanExec) Open

Open implements the Executor Open interface.

type TestShowClusterConfigFunc

type TestShowClusterConfigFunc func() ([][]types.Datum, error)

TestShowClusterConfigFunc is used to test 'show config ...'.

type TiFlashSystemTableRetriever

type TiFlashSystemTableRetriever struct {
	// contains filtered or unexported fields
}

TiFlashSystemTableRetriever is used to read system table from tiflash.

type TraceExec

type TraceExec struct {
	exec.BaseExecutor
	// CollectedSpans collects all span during execution. Span is appended via
	// callback method which passes into tracer implementation.
	CollectedSpans []basictracer.RawSpan
	// contains filtered or unexported fields
}

TraceExec represents a root executor of trace query.

func (*TraceExec) Next

func (e *TraceExec) Next(ctx context.Context, req *chunk.Chunk) error

Next executes real query and collects span later.

type UnionScanExec

type UnionScanExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

UnionScanExec merges the rows from dirty table and the rows from distsql request.

func (*UnionScanExec) Close

func (us *UnionScanExec) Close() error

Close implements the Executor Close interface.

func (*UnionScanExec) Next

func (us *UnionScanExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*UnionScanExec) Open

func (us *UnionScanExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type UpdateExec

type UpdateExec struct {
	exec.BaseExecutor

	OrderedList []*expression.Assignment

	IgnoreError bool
	// contains filtered or unexported fields
}

UpdateExec represents a new update executor.

func (*UpdateExec) Close

func (e *UpdateExec) Close() error

Close implements the Executor Close interface.

func (*UpdateExec) GetFKCascades

func (e *UpdateExec) GetFKCascades() []*FKCascadeExec

GetFKCascades implements WithForeignKeyTrigger interface.

func (*UpdateExec) GetFKChecks

func (e *UpdateExec) GetFKChecks() []*FKCheckExec

GetFKChecks implements WithForeignKeyTrigger interface.

func (*UpdateExec) HasFKCascades

func (e *UpdateExec) HasFKCascades() bool

HasFKCascades implements WithForeignKeyTrigger interface.

func (*UpdateExec) Next

func (e *UpdateExec) Next(ctx context.Context, req *chunk.Chunk) error

Next implements the Executor Next interface.

func (*UpdateExec) Open

func (e *UpdateExec) Open(ctx context.Context) error

Open implements the Executor Open interface.

type UpdatedValuesCouple

type UpdatedValuesCouple struct {
	NewValues     []types.Datum
	OldValuesList [][]types.Datum
}

UpdatedValuesCouple contains the updated new row the old rows, exporting for test.

type WindowExec

type WindowExec struct {
	exec.BaseExecutor
	// contains filtered or unexported fields
}

WindowExec is the executor for window functions.

func (*WindowExec) Close

func (e *WindowExec) Close() error

Close implements the Executor Close interface.

func (*WindowExec) Next

func (e *WindowExec) Next(ctx context.Context, chk *chunk.Chunk) error

Next implements the Executor Next interface.

type WithForeignKeyTrigger

type WithForeignKeyTrigger interface {
	GetFKChecks() []*FKCheckExec
	GetFKCascades() []*FKCascadeExec
	HasFKCascades() bool
}

WithForeignKeyTrigger indicates the executor has foreign key check or cascade.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL