package
6.7.0-alpha+incompatible
Repository: https://github.com/pingcap/tidb.git
Documentation: pkg.go.dev
# Packages
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
# Functions
AddNewAnalyzeJob records the new analyze job.
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.
DumpRealOutfile dumps a real number to lineBuf.
EncodeUniqueIndexKey encodes a unique index key.
EncodeUniqueIndexValuesForKey encodes unique index values for a key.
FinishAnalyzeJob updates the state of the analyze job to finished/failed according to `meetError` and sets the end time.
FinishAnalyzeMergeJob finishes analyze merge job.
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.
GetResultRowsCount gets the count of the statement result rows.
IsFastPlan exports for testing.
JoinerType returns the join type of a Joiner.
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.
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.
Next is a wrapper function on e.Next(), it handles some common codes.
ParseTime exports for testing.
ResetContextOfStmt resets the StmtContext and session variables.
ResetUpdateStmtCtx resets statement context for UpdateStmt.
SetFromString constructs a slice of strings from a comma separated string.
StartAnalyzeJob marks the state of the analyze job as running and sets the start time.
UpdateAnalyzeJob updates count of the processed rows when increment reaches a threshold.
# Constants
IndexAdviseVarKey is a variable key for index advise.
LeftHasNullRightHasNull means lhs is a null key, and rhs is a null key.
LeftHasNullRightNotNull means lhs is a null key, and rhs is not a null key.
LeftNotNullRightHasNull means lhs is in not a null key, and rhs is a null key.
LeftNotNullRightNotNull means lhs is in not a null key, and rhs is not a null key.
LoadDataVarKey is a variable key for load data.
LoadStatsVarKey is a variable key for load statistic.
LockStatsVarKey is a variable key for lock statistic.
PlanReplayerDumpVarKey is a variable key for plan replayer dump.
PlanReplayerLoadVarKey is a variable key for plan replayer load.
Unknown for those default value.
UnlockStatsVarKey is a variable key for unlock statistic.
# Variables
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
ErrSavepointNotSupportedWithBinlog export for testing.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
Error instances.
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.
InTest is a flag that bypass gcs authentication in unit tests.
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.
ShardCount controls the shard maps within the concurrent map.
TableStatsCacheExpiry is the expiry time for table stats cache.
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
AccountLockTelemetryInfo records account lock/unlock information during execution.
AdminPluginsExec indicates AdminPlugins executor.
AdminResetTelemetryIDExec is an executor for ADMIN RESET TELEMETRY_ID.
AdminShowTelemetryExec is an executor for ADMIN SHOW TELEMETRY.
AfFinalResult indicates aggregation functions final result.
AggSpillDiskAction implements memory.ActionOnExceed for unparalleled HashAgg.
AggWorkerInfo contains the agg worker information.
AggWorkerStat record the AggWorker runtime stat.
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.
AnalyzeFastExec represents Fast Analyze executor.
AnalyzeIndexExec represents analyze index push down executor.
AnalyzeTestFastExec is for fast sample in unit test.
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.
ChangeExec represents a change 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.
CommitTask is used for fetching data from data preparing routine into committing routine.
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.
ExplainExec represents an explain executor.
FieldMapping inticates the relationship between input field and table column or user variable.
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.
HashAggExec deals with all the aggregate functions.
HashAggFinalWorker indicates the final workers of parallel hash agg execution, the number of the worker can be set by `tidb_hashagg_final_concurrency`.
HashAggInput indicates the input of hash agg exec.
HashAggIntermData indicates the intermediate data of aggregation execution.
HashAggPartialWorker indicates the partial workers of parallel hash agg execution, the number of the worker can be set by `tidb_hashagg_partial_concurrency`.
HashAggRuntimeStats record the HashAggExec runtime stat.
HashJoinExec implements the hash join algorithm.
HistoryHotRegion records each hot region's statistics.
HistoryHotRegions records filtered hot regions stored in each PD.
HistoryHotRegionsRequest wrap conditions push down to PD.
IndexAdvice represents the index advice.
IndexAdviseExec represents a index advise executor.
IndexAdviseInfo saves the information of index advise operation.
IndexLookUpExecutor implements double read for index scan.
IndexLookUpJoin employs one outer worker and N innerWorkers to execute concurrently.
IndexLookUpMergeJoin realizes IndexLookUpJoin by merge join It preserves the order of the outer table and support batch lookup.
IndexLookUpRunTimeStats record the indexlookup runtime stat.
IndexMergeReaderExecutor accesses a table with multiple index/table scan.
IndexMergeRuntimeStat record the indexMerge runtime stat.
IndexNestedLoopHashJoin employs one outer worker and N inner workers to execute concurrently.
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.
LoadDataInfo saves the information of loading data operation.
LoadStatsExec represents a load statistic executor.
LoadStatsInfo saves the information of loading statistic operation.
LockStatsExec represents a lock statistic executor.
MaxOneRowExec checks if the number of rows that a query returns is at maximum one.
MemTableReaderExec executes memTable information retrieving from the MemTable components.
MergeJoinExec implements the merge join algorithm.
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.
NestedLoopApplyExec is the executor for apply.
ParallelNestedLoopApplyExec is the executor for apply.
PartitionTelemetryInfo records table partition telemetry information during execution.
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).
RecoverIndexExec represents a recover index executor.
ReloadExprPushdownBlacklistExec indicates ReloadExprPushdownBlacklist executor.
ReloadOptRuleBlacklistExec indicates ReloadOptRuleBlacklist executor.
ReplaceExec represents a replace executor.
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.
SortExec represents sorting executor.
SplitIndexRegionExec represents a split index regions executor.
SplitTableRegionExec represents a split table regions executor.
SQLBindExec represents a bind executor.
StreamAggExec deals with all the aggregate functions.
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.
TelemetryInfo records some telemetry information during execution.
TiFlashSystemTableRetriever is used to read system table from tiflash.
TopNExec implements a Top-N algorithm and it is built from a SELECT statement with ORDER BY and LIMIT.
TraceExec represents a root executor of trace query.
UnionExec pulls all it's children's result and returns to its parent directly.
UnionScanExec merges the rows from dirty table and the rows from distsql request.
UnlockStatsExec represents a unlock statistic executor.
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.
Executor is the physical implementation of a algebra operator.
MockPhysicalPlan is used to return a specified executor in when build.
WithForeignKeyTrigger indicates the executor has foreign key check or cascade.
# Type aliases
IndexAdviseVarKeyType is a dummy type to avoid naming collision in context.
IterCb :Iterator callback,called for every key,value found in maps.
NAAJType is join detail type only used by null-aware AntiLeftOuterSemiJoin.
TestShowClusterConfigFunc is used to test 'show config ...'.
UpsertCb : Callback to return new element to be inserted into the map It is called while lock is held, therefore it MUST NOT try to access other keys in same map, as it can lead to deadlock since Go sync.RWLock is not reentrant.