package
9.0.0-alpha+incompatible
Repository: https://github.com/pingcap/tidb.git
Documentation: pkg.go.dev
# Functions
AddNewAnalyzeJob records the new analyze job.
BRIECreateDatabase creates the database with OnExistIgnore option.
BRIECreateTable creates the table with OnExistIgnore option.
BRIECreateTables creates the tables with OnExistIgnore option in batch.
CalculateBatchSize calculates a suitable initial batch size.
ColumnName returns `column`.
ConstructResultOfShowCreateDatabase constructs the result for show create database.
ConstructResultOfShowCreatePlacementPolicy constructs the result for show create placement policy.
ConstructResultOfShowCreateSequence constructs the result for show create sequence.
ConstructResultOfShowCreateTable constructs the result for show create table.
ConvertConfigItem2JSON converts the config item specified by key and val to json.
CountStmtNode records the number of statements with the same type.
DecodeRowValToChunk decodes row value into chunk checking row format used.
Detach detaches the current executor from the session context.
DumpRealOutfile dumps a real number to lineBuf.
FillOneImportJobInfo is exported for testing.
FormatSQL is used to format the original SQL, e.g.
GenCascadeDeleteAST uses to generate cascade delete ast, export for test.
GenCascadeSetNullAST uses to generate foreign key `SET NULL` ast, export for test.
GenCascadeUpdateAST uses to generate cascade update ast, export for test.
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.
GetEncodedPlan returned same as getEncodedPlan.
GetLackHandles gets the handles in expectedHandles but not in obtainedHandlesMap.
GetPhysID returns the physical id used, either the table's id or a partition's ID.
GetPlanDigest will try to get the select plan tree if the plan is select or the select plan of delete/update/insert statement.
GetResultRowsCount gets the count of the statement result rows.
IsFastPlan exports for testing.
LoadExprPushdownBlacklist loads the latest data from table mysql.expr_pushdown_blacklist.
LoadOptRuleBlacklist loads the latest data from table mysql.opt_rule_blacklist.
LockKeys locks the keys for pessimistic transaction.
MockNewCacheTableSnapShot only serves for test.
NewAnalyzeResultsNotifyWaitGroupWrapper is to create analyzeResultsNotifyWaitGroupWrapper.
NewCoprocessorDAGHandler creates a new CoprocessorDAGHandler.
NewLoadDataWorker creates a new LoadDataWorker that is ready to work.
NewMockExecutorBuilderForTest is ONLY used in test.
NewPrepareExec creates a new PrepareExec.
NewProfileBuilder returns a new profileBuilder.
NewRowDecoder creates a chunk decoder for new row format row value decode.
NewSimpleSeekerOnReadCloser creates a SimpleSeekerOnReadCloser.
ParseTime exports for testing.
ResetContextOfStmt resets the StmtContext and session variables.
ResetDeleteStmtCtx resets statement context for DeleteStmt.
ResetGlobalBRIEQueueForTest resets the ID allocation for the global BRIE queue.
ResetUpdateStmtCtx resets statement context for UpdateStmt.
SetFromString constructs a slice of strings from a comma separated string.
Start the backend components.
Stop the backend components.
TableName returns `schema`.`table`.
ValidateImportIntoColAssignmentsWithEncodeCtx validates the column assignment expressions should be compatible with the encoding context (which maybe different with the context in the current session).
# Constants
LoadDataReaderBuilderKey stores the reader channel that reads from the connection.
LoadDataVarKey is a variable key for load data.
LoadStatsVarKey is a variable key for load statistic.
PlanReplayerDumpVarKey is a variable key for plan replayer dump.
PlanReplayerLoadVarKey is a variable key for plan replayer load.
# Variables
AnalyzeProgressTest is for test.
CheckTableFastBucketSize is the bucket size of fast check table.
CloseSession will be assigned by session package.
CreateSession will be assigned by session package.
ErrSavepointNotSupportedWithBinlog export for testing.
GlobalAnalyzeMemoryTracker is the ancestor of all the Analyze jobs' memory tracker and child of global Tracker.
GlobalDiskUsageTracker is the ancestor of all the Executors' disk tracker.
GlobalMemoryUsageTracker is the ancestor of all the Executors' memory tracker and GlobalMemory Tracker.
IndexMergeCancelFuncForTest is used just for test.
LookupTableTaskChannelSize represents the channel size of the index double read taskChan.
MaxRegionSampleSize is the max sample size for one region when analyze v1 collects samples from table.
ParseSlowLogBatchSize is the batch size of slow-log lines for a worker to parse, exported for testing.
QueryReplacer replaces new line and tab for grep result including query string.
RandSeed is the seed for randing package.
SplitBatchCreateTableForTest is only used for test.
TestSetConfigHTTPHandlerKey is used as the key to store 'TestSetConfigDoRequestFunc' in the context.
TestSetConfigServerInfoKey is used as the key to store 'TestSetConfigServerInfoFunc' in the context.
TestShowClusterConfigKey is the key used to store TestShowClusterConfigFunc.
# Structs
AdminPluginsExec indicates AdminPlugins executor.
AdminShowBDRRoleExec represents a show BDR role executor.
AlterDDLJobExec indicates an Executor for alter config of a DDL Job.
AnalyzeColumnsExec represents Analyze columns push down executor.
AnalyzeColumnsExecV1 is used to maintain v1 analyze process.
AnalyzeColumnsExecV2 is used to maintain v2 analyze process.
AnalyzeExec represents Analyze executor.
AnalyzeIndexExec represents analyze index push down executor.
BatchPointGetExec executes a bunch of point select queries.
BRIEExec represents an executor for BRIE statements (BACKUP, RESTORE, etc).
CancelDDLJobsExec represents a cancel DDL jobs executor.
CheckIndexRangeExec outputs the index values which has handle between begin and end.
ChecksumTableExec represents ChecksumTable executor.
CheckTableExec represents a check table executor.
CleanupIndexExec represents a cleanup index executor.
CommandDDLJobsExec is the general struct for Cancel/Pause/Resume commands on DDL jobs.
CompactTableTiFlashExec represents an executor for "ALTER TABLE [NAME] COMPACT TIFLASH REPLICA" statement.
Compiler compiles an ast.StmtNode to a physical plan.
CoprocessorDAGHandler uses to handle cop dag request.
CTEExec implements CTE.
CTEStorages stores resTbl and iterInTbl for CTEExec.
CTETableReaderExec scans data in iterInTbl, which is filled by corresponding CTEExec.
DDLExec represents a DDL executor.
DDLJobRetriever retrieve the DDLJobs.
DDLJobsReaderExec executes DDLJobs information retrieving.
DeallocateExec represent a DEALLOCATE executor.
DeleteExec represents a delete executor.
ExecStmt implements the sqlexec.Statement interface, it builds a planner.Plan to an sqlexec.Statement.
ExecuteExec represents an EXECUTE executor.
ExpandExec is used to execute expand logical plan.
ExplainExec represents an explain executor.
FastCheckTableExec represents a check table executor.
FKCascadeExec uses to execute foreign key cascade behaviour.
FKCascadeRuntimeStats contains the FKCascadeExec runtime stats.
FKCheckExec uses to check foreign key constraint.
FKCheckRuntimeStats contains the FKCheckExec runtime stats.
GrantExec executes GrantStmt.
HistoryHotRegion records each hot region's statistics.
HistoryHotRegions records filtered hot regions stored in each PD.
HistoryHotRegionsRequest wrap conditions push down to PD.
ImportIntoActionExec represents a import into action executor.
ImportIntoExec represents a IMPORT INTO executor.
IndexLookUpExecutor implements double read for index scan.
IndexLookUpRunTimeStats record the indexlookup runtime stat.
IndexMergeReaderExecutor accesses a table with multiple index/table scan.
IndexMergeRuntimeStat record the indexMerge runtime stat.
IndexReaderExecutor sends dag request and reads index data from kv layer.
InsertExec represents an insert executor.
InsertRuntimeStat record the stat about insert and check.
InsertValues is the data to insert.
LimitExec represents limit executor It ignores 'Offset' rows from src, then returns 'Count' rows at maximum.
LoadDataExec represents a load data executor.
LoadDataWorker does a LOAD DATA job.
LoadStatsExec represents a load statistic executor.
LoadStatsInfo saves the information of loading statistic operation.
MaxOneRowExec checks if the number of rows that a query returns is at maximum one.
MemTableReaderExec executes memTable information retrieving from the MemTable components.
MetricRetriever uses to read metric data.
MetricsSummaryByLabelRetriever uses to read metric detail data.
MetricsSummaryRetriever uses to read metric data.
MockExecutorBuilder is a wrapper for executorBuilder.
MockMetricsPromDataKey is for test.
MPPGather dispatch MPP tasks and read data from root tasks.
ParallelNestedLoopApplyExec is the executor for apply.
PauseDDLJobsExec indicates an Executor for Pause a DDL Job.
PessimisticLockCacheGetter implements the kv.Getter interface.
PipelinedWindowExec is the executor for window functions.
PlanReplayerCaptureInfo indicates capture info.
PlanReplayerDumpInfo indicates dump info.
PlanReplayerExec represents a plan replayer executor.
PlanReplayerLoadExec represents a plan replayer load executor.
PlanReplayerLoadInfo contains file path and session context.
PointGetExecutor executes point select query.
PrepareExec represents a PREPARE executor.
ProjectionExec implements the physical Projection Operator: https://en.wikipedia.org/wiki/Projection_(relational_algebra).
RecommendIndexExec represents a recommend index executor.
RecoverIndexExec represents a recover index executor.
ReloadExprPushdownBlacklistExec indicates ReloadExprPushdownBlacklist executor.
ReloadOptRuleBlacklistExec indicates ReloadOptRuleBlacklist executor.
ReplaceExec represents a replace executor.
ResumeDDLJobsExec indicates an Executor for Resume a DDL Job.
RevokeExec executes RevokeStmt.
SelectIntoExec represents a SelectInto executor.
SelectionExec represents a filter executor.
SelectLockExec represents a select lock executor.
SetConfigExec executes 'SET CONFIG' statement.
SetExecutor executes set statement.
ShowDDLExec represents a show DDL executor.
ShowDDLJobQueriesExec represents a show DDL job queries executor.
ShowDDLJobQueriesWithRangeExec represents a show DDL job queries with range executor.
ShowDDLJobsExec represent a show DDL jobs executor.
ShowExec represents a show executor.
ShowNextRowIDExec represents a show the next row ID executor.
ShowSlowExec represents the executor of showing the slow queries.
ShuffleExec is the executor to run other executors in a parallel manner.
SimpleExec represents simple statement executor.
SimpleSeekerOnReadCloser provides Seek(0, SeekCurrent) on ReadCloser.
SplitIndexRegionExec represents a split index regions executor.
SplitTableRegionExec represents a split table regions executor.
SQLBindExec represents a bind executor.
TableDualExec represents a dual table executor.
TableReaderExecutor sends DAG request and reads table data from kv layer.
TableSampleExecutor fetches a few rows through kv.Scan according to the specific sample method.
TableScanExec is a table scan executor without result fields.
TiFlashSystemTableRetriever is used to read system table from tiflash.
TraceExec represents a root executor of trace query.
TrafficCancelExec sends cancel traffic job requests to TiProxy.
TrafficCaptureExec sends capture traffic requests to TiProxy.
TrafficReplayExec sends replay traffic requests to TiProxy.
TrafficShowExec sends show traffic job requests to TiProxy.
UnionScanExec merges the rows from dirty table and the rows from distsql request.
UpdatedValuesCouple contains the updated new row the old rows, exporting for test.
UpdateExec represents a new update executor.
WindowExec is the executor for window functions.
# Interfaces
Closeable is a interface for closeable structures.
WithForeignKeyTrigger indicates the executor has foreign key check or cascade.
# Type aliases
LoadDataReaderBuilder is a function type that builds a reader from a file path.
TestShowClusterConfigFunc is used to test 'show config ...'.