package
2.1.0-rc.2+incompatible
Repository: https://github.com/coderushing/tidb.git
Documentation: pkg.go.dev

# Functions

GetDDLReorgWorkerCounter gets ddlReorgWorkerCounter.
GetGlobalSystemVar gets a global system variable.
GetScopeNoneSystemVar checks the validation of `key`, and return the default value if its scope is `ScopeNone`.
GetSessionOnlySysVars get the default value defined in code for session only variable.
GetSessionSystemVar gets a system variable.
GetStatusVars gets registered statistics status variables.
GetSysVar returns sys var info for name as key.
GoTimeToTS converts a Go time to uint64 timestamp.
NewMockGlobalAccessor implements GlobalVarAccessor interface.
NewSessionVars creates a session vars object.
RegisterStatistics registers statistics.
SetDDLReorgWorkerCounter sets ddlReorgWorkerCounter count.
SetSessionSystemVar sets system variable and updates SessionVars states.
TiDBOptOn could be used for all tidb session variable options, we use "ON"/1 to turn on those options.
ValidateGetSystemVar checks if system variable exists and validates its scope when get system variable.
ValidateSetSystemVar checks if system variable satisfies specific restriction.

# Constants

AnalyzeFullTimeFormat is the full format of analyze start time and end time.
special session variables.
AvoidTemporalUpgrade is the name for 'avoid_temporal_upgrade' system variable.
BigTables is the name for 'big_tables' system variable.
CharacterSetConnection is the name for character_set_connection system variable.
special session variables.
CharsetDatabase is the name for character_set_database system variable.
CheckProxyUsers is the name for 'check_proxy_users' system variable.
Variable error codes.
Variable error codes.
Variable error codes.
Variable error codes.
Variable error codes.
Variable error codes.
Variable error codes.
Variable error codes.
CollationConnection is the name for collation_connection system variable.
CollationDatabase is the name for collation_database system variable.
ConnectTimeout is the name for 'connect_timeout' system variable.
CoreFile is the name for 'core_file' system variable.
DefaultWeekFormat is the name for 'default_week_format' system variable.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
32GB.
32GB.
32GB.
32GB.
32GB.
32GB.
32GB.
Default TiDB system variable values.
Default TiDB system variable values.
Default TiDB system variable values.
DelayKeyWrite is the name for 'delay_key_write' system variable.
EndMakersInJSON is the name for 'end_markers_in_json' system variable.
ErrorCount is the name for 'error_count' system variable.
FlushTime is the name for 'flush_time' system variable.
ForeignKeyChecks is the name for 'foreign_key_checks' system variable.
GeneralLog is the name for 'general_log' system variable.
GroupConcatMaxLen is the name for 'group_concat_max_len' system variable.
InteractiveTimeout is the name for 'interactive_timeout' system variable.
LowPriorityUpdates is the name for 'low_priority_updates' system variable.
special session variables.
MaxConnectErrors is the name for 'max_connect_errors' system variable.
MaxConnections is the name for 'max_connections' system variable.
MaxSortLength is the name for 'max_sort_length' system variable.
MaxSpRecursionDepth is the name for 'max_sp_recursion_depth' system variable.
MaxUserConnections is the name for 'max_user_connections' system variable.
OfflineMode is the name for 'offline_mode' system variable.
OldPasswords is the name for 'old_passwords' system variable.
PseudoSlaveMode is the name for 'pseudo_slave_mode' system variable.
ScopeGlobal means the system variable can be changed globally.
ScopeNone means the system variable can not be changed dynamically.
ScopeSession means the system variable can only be changed in current session.
SessionTrackGtids is the name for 'session_track_gtids' system variable.
SkipNameResolve is the name for 'skip_name_resolve' system variable.
SQLLogBin is the name for 'sql_log_bin' system variable.
special session variables.
SQLSafeUpdates is the name for 'sql_safe_updates' system variable.
SQLSelectLimit is the name for 'sql_select_limit' system variable.
TableDefinitionCache is the name for 'table_definition_cache' system variable.
TiDB system variable names that only in session scope.
Auto analyze will run if (table modify count)/(table row count) is greater than this value.
Auto analyze will run if current time is within start time and end time.
tidb_backoff_lock_fast is used for tikv backoff base time in milliseconds.
tidb_batch_delete is used to enable/disable auto-split delete data.
tidb_batch_insert is used to enable/disable auto-split insert data.
tidb_build_stats_concurrency is used to speed up the ANALYZE statement, when a table has multiple indices, those indices can be scanned concurrently, with the cost of higher system performance impact.
tidb_checksum_table_concurrency is used to speed up the ADMIN CHECKSUM TABLE statement, when a table has multiple indices, those indices can be scanned concurrently, with the cost of higher system performance impact.
tidb_config is a read-only variable that shows the config of the current server.
TiDBCurrentTS is used to get the current transaction timestamp.
tidb_ddl_reorg_priority defines the operations priority of adding indices.
tidb_ddl_reorg_worker_cnt defines the count of ddl reorg workers.
tidb_disable_txn_auto_retry disables transaction auto retry.
tidb_distsql_scan_concurrency is used to set the concurrency of a distsql scan task.
tidb_dml_batch_size is used to split the insert/delete data into small batches.
tidb_enable_streaming enables TiDB to use streaming API for coprocessor requests.
tidb_enable_table_partition is used to enable table partition feature.
tidb_general_log is used to log every query in the server in info level.
tidb_hashagg_final_concurrency is used for hash agg executor.
tidb_hashagg_partial_concurrency is used for hash agg executor.
tidb_hash_join_concurrency is used for hash join executor.
tidb_index_join_batch_size is used to set the batch size of a index lookup join.
tidb_index_lookup_concurrency is used for index lookup executor.
tidb_index_lookup_join_concurrency is used for index lookup join executor.
tidb_index_lookup_size is used for index lookup executor.
tidb_index_serial_scan_concurrency is used for controlling the concurrency of index scan operation when we need to keep the data output order the same as the order of index data.
tidb_max_chunk_capacity is used to control the max chunk size during query execution.
Bytes.
Bytes.
Bytes.
Bytes.
Bytes.
Bytes.
Bytes.
Bytes.
tidb_opt_agg_push_down is used to enable/disable the optimizer rule of aggregation push down.
tidb_optimizer_selectivity_level is used to control the selectivity estimation level.
tidb_opt_insubquery_unfold is used to enable/disable the optimizer rule of in subquery unfold.
tidb_projection_concurrency is used for projection operator.
tidb_retry_limit is the maximun number of retries when committing a transaction.
tidb_skip_utf8_check skips the UTF8 validate process, validate UTF8 has performance cost, if we can make sure the input string values are valid, we can skip the check.
tidb_snapshot is used for reading history data, the default value is empty string.
special session variables.
TmpTableSize is the name for 'tmp_table_size' system variable.
special session variables.
special session variables.
WarningCount is the name for 'warning_count' system variable.

# Variables

DDLSlowOprThreshold is the threshold for ddl slow operations, uint is millisecond.
DefaultStatusVarScopeFlag is the default scope of status variables.
Error instances.
Variable errors.
Variable errors.
Error instances.
Variable errors.
Variable errors.
Variable errors.
Variable errors.
Process global variables.
SetNamesVariables is the system variable names related to set names statements.
SynonymsSysVariables is synonyms of system variables.
SysVars is global sys vars map.
Variable errors.
Variable errors.

# Structs

BatchSize defines batch size values.
Concurrency defines concurrency values.
MemQuota defines memory quota values.
MockGlobalAccessor implements GlobalVarAccessor interface.
RetryInfo saves retry information.
SessionVars is to handle user-defined or global variables in the current session.
StatusVal is the value of the corresponding status variable.
SysVar is for system variable.
TableDelta stands for the changed count for one table.
TransactionContext is used to store variables that has transaction scope.
WriteStmtBufs can be used by insert/replace/delete/update statement.

# Interfaces

GlobalVarAccessor is the interface for accessing global scope system and status variables.
Statistics is the interface of statistics.

# Type aliases

ScopeFlag is for system variable whether can be changed in global/session dynamically or not.