package
9.0.0-alpha+incompatible
Repository: https://github.com/pingcap/tidb.git
Documentation: pkg.go.dev
# Functions
BoolToOnOff returns the string representation of a bool, i.e.
CheckSysVarIsRemoved returns an error if the sysvar has been removed.
GetDDLErrorCountLimit gets ddlErrorCountlimit size.
GetDDLFlashbackConcurrency gets ddlFlashbackConcurrency count.
GetDDLReorgBatchSize gets ddlReorgBatchSize.
GetDDLReorgRowFormat gets ddlReorgRowFormat version.
GetDDLReorgWorkerCounter gets ddlReorgWorkerCounter.
GetMaxDeltaSchemaCount gets maxDeltaSchemaCount size.
GetStatusVars gets registered statistics status variables.
GetSysVar returns sys var info for name as key.
GetSysVars deep copies the sysVars list under a RWLock.
GlobalSystemVariableInitialValue gets the default value for a system variable including ones that are dynamically set (e.g.
IsAdaptiveReplicaReadEnabled returns whether adaptive closest replica read can be enabled.
IsRemovedSysVar returns true if the sysvar has been removed.
NewMockGlobalAccessor implements GlobalVarAccessor interface.
NewMockGlobalAccessor4Tests creates a new MockGlobalAccessor for use in the testsuite.
NewPlanCacheParamList creates a new PlanCacheParams.
NewRowIDShardGenerator creates a new RowIDShardGenerator.
NewSequenceState creates a SequenceState.
NewSessionVars creates a session vars object.
NewTemporaryTableData creates a new TemporaryTableData.
NewTxnReadTS creates TxnReadTS.
NewUserVars creates a new user UserVars object.
OnOffToTrueFalse convert "ON"/"OFF" to "true"/"false".
OrderByDependency orders the vars by dependency.
ParseAnalyzeSkipColumnTypes converts tidb_analyze_skip_column_types to the map form.
RegisterStatistics registers statistics.
RegisterSysVar adds a sysvar to the SysVars list.
RuntimeFilterModeStringToMode convert RuntimeFilterModeString to RuntimeFilterMode If name is legal, it will return Runtime Filter Mode and true Else, it will return -1 and false The second param means the convert is ok or not.
RuntimeFilterTypeStringToType convert RuntimeFilterTypeNameString to RuntimeFilterType If name is legal, it will return Runtime Filter Type and true Else, it will return -1 and false The second param means the convert is ok or not.
SetDDLErrorCountLimit sets ddlErrorCountlimit size.
SetDDLFlashbackConcurrency sets ddlFlashbackConcurrency count.
SetDDLReorgBatchSize sets ddlReorgBatchSize size.
SetDDLReorgRowFormat sets ddlReorgRowFormat version.
SetDDLReorgWorkerCounter sets ddlReorgWorkerCounter count.
SetEnableAdaptiveReplicaRead set `enableAdaptiveReplicaRead` with given value.
SetMaxDeltaSchemaCount sets maxDeltaSchemaCount size.
SetSysVar sets a sysvar.
TiDBOptEnableClustered converts enable clustered options to ClusteredIndexDefMode.
TidbOptInt converts a string to an int.
TidbOptInt64 converts a string to an int64.
TiDBOptOn could be used for all tidb session variable options, we use "ON"/1 to turn on those options.
TiDBOptOnOffWarn converts On/Off/Warn to an int.
TidbOptUint64 converts a string to an uint64.
ToRuntimeFilterType convert session var value to RuntimeFilterType list If sessionVarValue is legal, it will return RuntimeFilterType list and true The second param means the convert is ok or not.
ToTiPBTiFlashPreAggMode return the corresponding tipb value of preaggregation mode.
UnregisterStatistics unregisters statistics.
UnregisterSysVar removes a sysvar from the SysVars list currently only used in tests.
ValidAnalyzeSkipColumnTypes makes validation for tidb_analyze_skip_column_types.
ValidTiFlashPreAggMode returns all valid modes.
# Constants
AssertionFastStr is a choice of variable TiDBTxnAssertionLevel that means assertions that doesn't affect performance should be performed.
AssertionLevelFast indicates assertions that doesn't affect performance should be performed.
AssertionLevelOff indicates no assertion should be performed.
AssertionLevelStrict indicates full assertions should be performed, even if the performance might be slowed down.
AssertionOffStr is a choice of variable TiDBTxnAssertionLevel that means no assertion should be performed.
AssertionStrictStr is a choice of variable TiDBTxnAssertionLevel that means full assertions should be performed, even if the performance might be slowed down.
AuthenticationLDAPSASLAuthMethodName defines the authentication method used by LDAP SASL authentication plugin.
AuthenticationLDAPSASLBindBaseDN defines the `dn` to search the users in.
AuthenticationLDAPSASLBindRootDN defines the `dn` of the user to login the LDAP server and perform search.
AuthenticationLDAPSASLBindRootPWD defines the password of the user to login the LDAP server and perform search.
AuthenticationLDAPSASLCAPath defines the ca certificate to verify LDAP connection in LDAP SASL authentication plugin.
AuthenticationLDAPSASLInitPoolSize defines the init size of connection pool to LDAP server for SASL plugin.
AuthenticationLDAPSASLMaxPoolSize defines the max size of connection pool to LDAP server for SASL plugin.
AuthenticationLDAPSASLReferral defines whether to enable LDAP referral for LDAP SASL authentication plugin.
AuthenticationLDAPSASLServerHost defines the server host of LDAP server for LDAP SASL authentication plugin.
AuthenticationLDAPSASLServerPort defines the port of LDAP server for LDAP SASL authentication plugin.
AuthenticationLDAPSASLTLS defines whether to use TLS connection in LDAP SASL authentication plugin.
AuthenticationLDAPSASLUserSearchAttr defines the attribute of username in LDAP server.
AuthenticationLDAPSimpleAuthMethodName defines the authentication method used by LDAP Simple authentication plugin.
AuthenticationLDAPSimpleBindBaseDN defines the `dn` to search the users in.
AuthenticationLDAPSimpleBindRootDN defines the `dn` of the user to login the LDAP server and perform search.
AuthenticationLDAPSimpleBindRootPWD defines the password of the user to login the LDAP server and perform search.
AuthenticationLDAPSimpleCAPath defines the ca certificate to verify LDAP connection in LDAP Simple authentication plugin.
AuthenticationLDAPSimpleInitPoolSize defines the init size of connection pool to LDAP server for SASL plugin.
AuthenticationLDAPSimpleMaxPoolSize defines the max size of connection pool to LDAP server for SASL plugin.
AuthenticationLDAPSimpleReferral defines whether to enable LDAP referral for LDAP Simple authentication plugin.
AuthenticationLDAPSimpleServerHost defines the server host of LDAP server for LDAP Simple authentication plugin.
AuthenticationLDAPSimpleServerPort defines the port of LDAP server for LDAP Simple authentication plugin.
AuthenticationLDAPSimpleTLS defines whether to use TLS connection in LDAP Simple authentication plugin.
AuthenticationLDAPSimpleUserSearchAttr defines the attribute of username in LDAP server.
AutoCommit is the name for 'autocommit' system variable.
AutoIncrementIncrement is the name of 'auto_increment_increment' system variable.
AutoIncrementOffset is the name of 'auto_increment_offset' system variable.
AutomaticSpPrivileges is the name for 'automatic_sp_privileges' system variable.
ForcePreAggStr means 1st hashagg will be pre aggregated.
AvoidTemporalUpgrade is the name for 'avoid_temporal_upgrade' system variable.
BigTables is the name for 'big_tables' system variable.
BinlogDirectNonTransactionalUpdates is the name for 'binlog_direct_non_transactional_updates' system variable.
BinlogOrderCommits is the name for 'binlog_order_commits' system variable.
BinlogRowQueryLogEvents is the name for 'binlog_rows_query_log_events' system variable.
BlockEncryptionMode is the name for 'block_encryption_mode' system variable.
CharacterSetClient is the name for character_set_client system variable.
CharacterSetConnection is the name for character_set_connection system variable.
CharacterSetFilesystem is the name for character_set_filesystem system variable.
CharacterSetResults is the name of the 'character_set_results' system variable.
CharacterSetServer is the name of 'character_set_server' system variable.
CharacterSetSystem is the name for character_set_system system variable.
CharsetDatabase is the name for character_set_database system variable.
CheckProxyUsers is the name for 'check_proxy_users' system variable.
ClusteredIndexDefModeIntOnly indicates only single int primary key will default be clustered.
ClusteredIndexDefModeOff indicates primary key will default be non-clustered.
ClusteredIndexDefModeOn indicates primary key will default be clustered.
CollationConnection is the name for collation_connection system variable.
CollationDatabase is the name for collation_database system variable.
CollationServer is the name of 'collation_server' variable.
ConcurrencyUnset means the value the of the concurrency related variable is unset.
ConnectTimeout is the name for 'connect_timeout' system variable.
ConnStatusShutdown indicates that the connection status is closed by server.
ConnTypeSocket indicates socket without TLS.
ConnTypeTLS indicates socket with TLS.
ConnTypeUnixSocket indicates Unix Socket.
CoreFile is the name for 'core_file' system variable.
CTEMaxRecursionDepth is the name of 'cte_max_recursion_depth' system variable.
DataDir is the name for 'datadir' system variable.
Default TiDB system variable values.
Default TiDB system variable values.
DefaultAuthPlugin is the name of 'default_authentication_plugin' system variable.
DefaultCollationForUTF8MB4 is the name of 'default_collation_for_utf8mb4' variable.
Default TiDB system variable values.
DefaultPasswordLifetime is the name for 'default_password_lifetime' 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.
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.
50s.
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.
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.
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.
Deprecated: This variable is deprecated, please do not use this 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.
100GB.
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.
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.
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.
600s.
Default TiDB system variable values.
60s.
10 minutes.
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.
DefTiDBGOGCTunerThreshold is to limit TiDBGOGCTunerThreshold.
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.
32MB.
64MB.
1GB.
disable optimization by default.
Default TiDB system variable values.
60s.
60s.
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.
64 MB.
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.
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.
3s.
64MB.
Default TiDB system variable values.
0ms.
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.
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.
300s.
Default TiDB system variable values.
DelayKeyWrite is the name for 'delay_key_write' system variable.
DisconnectOnExpiredPassword is the name for 'disconnect_on_expired_password' system variable.
DivPrecisionIncrement indicates the number of digits by which to increase the scale of the result of division operations performed with the / operator.
Dynamic indicates only prune at execute phase.
DynamicOnly is out-of-date.
EndMarkersInJSON is the name for 'end_markers_in_json' system variable.
EnforceGtidConsistency is the name for 'enforce_gtid_consistency' system variable.
ErrorCount is the name for 'error_count' system variable.
Flush is the name for 'flush' system variable.
FlushTime is the name for 'flush_time' system variable.
ForcePreAggStr means 1st hashagg will be pre aggregated.
ForcePreAggStr means 1st hashagg will be pre aggregated.
ForeignKeyChecks is the name for 'foreign_key_checks' system variable.
FullDayTimeFormat is the full format of analyze start time and end time.
GeneralLog is the name for 'general_log' system variable.
Global config name list.
Global config name list.
GroupConcatMaxLen is the name for 'group_concat_max_len' system variable.
Hostname is the name for 'hostname' system variable.
Identity is the name of 'identity' system variable.
In type of runtime filter, like "t.k1 in (?)" MinMax type of runtime filter, like "t.k1 < ? and t.k1 > ?".
InitConnect is the name of 'init_connect' system variable.
InnodbAdaptiveFlushing is the name for 'innodb_adaptive_flushing' system variable.
InnodbAdaptiveHashIndex is the name for 'innodb_adaptive_hash_index' system variable.
InnodbBufferPoolDumpAtShutdown is the name for 'innodb_buffer_pool_dump_at_shutdown' system variable.
InnodbBufferPoolDumpNow is the name for 'innodb_buffer_pool_dump_now' system variable.
InnodbBufferPoolLoadAbort is the name for 'innodb_buffer_pool_load_abort' system variable.
InnodbBufferPoolLoadNow is the name for 'innodb_buffer_pool_load_now' system variable.
InnodbCmpPerIndexEnabled is the name for 'innodb_cmp_per_index_enabled' system variable.
InnodbCommitConcurrency is the name for 'innodb_commit_concurrency' system variable.
InnodbDisableSortFileCache is the name for 'innodb_disable_sort_file_cache' system variable.
InnodbFastShutdown is the name for 'innodb_fast_shutdown' system variable.
InnodbFilePerTable is the name for 'innodb_file_per_table' system variable.
#nosec G101.
InnodbLockWaitTimeout is the name for 'innodb_lock_wait_timeout' system variable.
InnodbLogCompressedPages is the name for 'innodb_log_compressed_pages' system variable.
InnodbOptimizeFullTextOnly is the name for 'innodb_optimize_fulltext_only' system variable.
InnodbPrintAllDeadlocks is the name for 'innodb_print_all_deadlocks' system variable.
InnodbRandomReadAhead is the name for 'innodb_random_read_ahead' system variable.
InnodbStatsAutoRecalc is the name for 'innodb_stats_auto_recalc' system variable.
InnodbStatsOnMetadata is the name for 'innodb_stats_on_metadata' system variable.
InnodbStatsPersistent is the name for 'innodb_stats_persistent' system variable.
InnodbStatusOutput is the name for 'innodb_status_output' system variable.
InnodbStatusOutputLocks is the name for 'innodb_status_output_locks' system variable.
InnodbStrictMode is the name for 'innodb_strict_mode' system variable.
InnodbSupportXA is the name for 'innodb_support_xa' system variable.
InnodbTableLocks is the name for 'innodb_table_locks' system variable.
InteractiveTimeout is the name for 'interactive_timeout' system variable.
IntOnly means enable for int type.
KeepFilesOnCreate is the name for 'keep_files_on_create' system variable.
LastInsertID is the name of 'last_insert_id' system variable.
LocalInFile is the name for 'local_infile' system variable.
LogBinTrustFunctionCreators is the name for 'log_bin_trust_function_creators' system variable.
LogQueriesNotUsingIndexes is the name for 'log_queries_not_using_indexes' system variable.
LogSlowAdminStatements is the name for 'log_slow_admin_statements' system variable.
LogSlowSlaveStatements is the name for 'log_slow_slave_statements' system variable.
LowerCaseTableNames is the name for 'lower_case_table_names' system variable.
LowPriorityUpdates is the name for 'low_priority_updates' system variable.
Marker is a special log redact behavior.
MaskPwd is the mask of password for LDAP variables.
MasterVerifyChecksum is the name for 'master_verify_checksum' system variable.
MaxAllowedPacket is the name of the 'max_allowed_packet' system variable.
MaxConfigurableConcurrency is the maximum number of "threads" (goroutines) that can be specified for any type of configuration item that has concurrent workers.
MaxConnectErrors is the name for 'max_connect_errors' system variable.
MaxConnections is the name for 'max_connections' system variable.
MaxDDLReorgBatchSize is exported for testing.
MaxExecutionTime is the name of the 'max_execution_time' system variable.
MaxPreparedStmtCount is the name for 'max_prepared_stmt_count' system variable.
MaxPreSplitRegions is the maximum number of regions that can be pre-split.
MaxShardRowIDBits is the maximum number of bits that can be used for row-id sharding.
MaxSortLength is the name for 'max_sort_length' system variable.
MaxSpRecursionDepth is the name for 'max_sp_recursion_depth' system variable.
1TB.
MaxUserConnections is the name for 'max_user_connections' system variable.
Default TiDB system variable values.
10s.
60s.
In type of runtime filter, like "t.k1 in (?)" MinMax type of runtime filter, like "t.k1 < ? and t.k1 > ?".
Default TiDB system variable values.
MppExchangeCompressionMode indicates the data compression method in mpp exchange operator.
MppVersion indicates the mpp-version used to build mpp plan.
MyISAMUseMmap is the name for 'myisam_use_mmap' system variable.
NetBufferLength is the name for 'net_buffer_length' system variable.
NetWriteTimeout is the name of 'net_write_timeout' variable.
Off is the canonical string for OFF.
OffInt is used by TiDBOptOnOffWarn.
OfflineMode is the name for 'offline_mode' system variable.
OldAlterTable is the name for 'old_alter_table' system variable.
OldPasswords is the name for 'old_passwords' system variable.
On is the canonical string for ON.
OnInt is used TiDBOptOnOffWarn.
OOMActionCancel constants represents the valid action configurations for OOMAction "CANCEL".
OOMActionLog constants represents the valid action configurations for OOMAction "LOG".
OptimisticTxnMode is the name for tidb_txn_mode system variable.
OptimizerSwitch is the name of 'optimizer_switch' system variable.
OptObjectiveDeterminate is a possible value for TiDBOptObjective.
OptObjectiveModerate is a possible value and the default value for TiDBOptObjective.
PasswordReuseHistory limit a few passwords to reuse.
PasswordReuseTime limit how long passwords can be reused.
PDEnableFollowerHandleRegion indicates whether to enable the PD Follower handle region API.
PerformanceSchema is the name for 'performance_schema' system variable.
PessimisticTxnMode is the name for tidb_txn_mode system variable.
PlacementModeIgnore indicates ignore all placement operations in ddl.
PlacementModeStrict indicates all placement operations should be checked strictly in ddl.
PluginDir is the name of 'plugin_dir' system variable.
PluginLoad is the name of 'plugin_load' system variable.
Port is the name for 'port' system variable.
Profiling is the name for 'Profiling' system variable.
PseudoSlaveMode is the name for 'pseudo_slave_mode' system variable.
QueryCacheSize is the name of 'query_cache_size' system variable.
QueryCacheType is the name for 'query_cache_type' system variable.
QueryCacheWlockInvalidate is the name for 'query_cache_wlock_invalidate' system variable.
RandSeed1 is the name of 'rand_seed1' system variable.
RandSeed2 is the name of 'rand_seed2' system variable.
ReadConsistencyStrict means read by strict consistency, default value.
ReadConsistencyWeak means read can be weak consistency.
ReadOnly is the name of the 'read_only' system variable.
RelayLogPurge is the name for 'relay_log_purge' system variable.
RequireSecureTransport indicates the secure mode for data transport.
RFOff disable runtime filter RFLocal enable local runtime filter RFGlobal enable local and global runtime filter.
RFOff disable runtime filter RFLocal enable local runtime filter RFGlobal enable local and global runtime filter.
RFOff disable runtime filter RFLocal enable local runtime filter RFGlobal enable local and global runtime filter.
ScatterGlobal means scatter region at global level.
ScatterOff means default, will not scatter region.
ScatterTable means scatter region at table level.
ScopeGlobal means the system variable can be changed globally.
ScopeInstance means it is similar to global but doesn't propagate to other TiDB servers.
ScopeNone means the system variable can not be changed dynamically.
ScopeSession means the system variable can only be changed in current session.
SecureAuth is the name for 'secure_auth' system variable.
SessionTrackGtids is the name for 'session_track_gtids' system variable.
ShowOldTemporals is the name for 'show_old_temporals' system variable.
SkipNameResolve is the name for 'skip_name_resolve' system variable.
SlaveAllowBatching is the name for 'slave_allow_batching' system variable.
SlaveCompressedProtocol is the name for 'slave_compressed_protocol' system variable.
SlowLogBackoffDetail is the detail of backoff.
SlowLogBackoffTotal is the total time doing backoff.
SlowLogBinaryPlan is used to record the binary plan.
SlowLogBinaryPlanPrefix is the prefix of the binary plan value.
SlowLogCompileTimeStr is the compile plan time.
SlowLogConnIDStr is slow log field name.
SlowLogCopBackoffPrefix contains backoff information.
SlowLogCopProcAddr is the address of TiKV where the cop-task which cost max process time run.
SlowLogCopProcAvg is the average process time of all cop-tasks.
SlowLogCopProcMax is the max process time of all cop-tasks.
SlowLogCopProcP90 is the p90 process time of all cop-tasks.
#nosec G101.
#nosec G101.
SlowLogCopWaitMax is the max wait time of all cop-tasks.
#nosec G101.
SlowLogDBStr is slow log field name.
SlowLogDigestStr is slow log field name.
SlowLogDiskMax is the max number bytes of disk used in this statement.
SlowLogExecRetryCount is the execution retry count.
SlowLogExecRetryTime is the execution retry time.
SlowLogHasMoreResults is used to indicate whether this sql has more following results.
SlowLogHostStr only for slow_query table usage.
SlowLogIndexNamesStr is slow log field name.
SlowLogIsExplicitTxn is used to indicate whether this sql execute in explicit transaction or not.
SlowLogIsInternalStr is slow log field name.
SlowLogIsSyncStatsFailed is used to indicate whether any failure happen during sync stats.
SlowLogIsWriteCacheTable is used to indicate whether writing to the cache table need to wait for the read lock to expire.
SlowLogKeyspaceID is slow log field name.
SlowLogKeyspaceName is slow log field name.
SlowLogKVTotal is the total time waiting for kv.
SlowLogMemMax is the max number bytes of memory used in this statement.
SlowLogNumCopTasksStr is the number of cop-tasks.
SlowLogOptimizeTimeStr is the optimization time.
SlowLogParseTimeStr is the parse sql time.
SlowLogPDTotal is the total time waiting for pd.
SlowLogPlan is used to record the query plan.
SlowLogPlanDigest is used to record the query plan digest.
SlowLogPlanFromBinding is used to indicate whether this plan is matched with the hints in the binding.
SlowLogPlanFromCache is used to indicate whether this plan is from plan cache.
SlowLogPlanPrefix is the prefix of the plan value.
SlowLogPlanSuffix is the suffix of the plan value.
SlowLogPrepared is used to indicate whether this sql execute in prepare.
SlowLogPreprocSubQueriesStr is the number of pre-processed sub-queries.
SlowLogPreProcSubQueryTimeStr is the total time of pre-processing sub-queries.
SlowLogPrevStmt is used to show the previous executed statement.
SlowLogPrevStmtPrefix is the prefix of Prev_stmt in slow log file.
use for slow log table, slow log will not print this field name but print sql directly.
SlowLogQueryTimeStr is slow log field name.
SlowLogResourceGroup is the resource group name that the current session bind.
SlowLogResultRows is the row count of the SQL result.
SlowLogRewriteTimeStr is the rewrite time.
SlowLogRowPrefixStr is slow log row prefix.
SlowLogRRU is the read request_unit(RU) cost.
SlowLogSessAliasStr is the session alias set by user.
SlowLogSpaceMarkStr is slow log space mark.
SlowLogSQLSuffixStr is slow log suffix.
SlowLogStartPrefixStr is slow log start row prefix.
SlowLogStatsInfoStr is plan stats info.
SlowLogSucc is used to indicate whether this sql execute successfully.
SlowLogTidbCPUUsageDuration is the total tidb cpu usages.
SlowLogTikvCPUUsageDuration is the total tikv cpu usages.
SlowLogTimeStr is slow log field name.
SlowLogTxnStartTSStr is slow log field name.
SlowLogUserAndHostStr is the user and host field name, which is compatible with MySQL.
SlowLogUserStr is slow log field name.
SlowLogWaitRUDuration is the total duration for kv requests to wait available request-units.
SlowLogWaitTSTimeStr is the time of waiting TS.
SlowLogWarnings is the warnings generated during executing the statement.
SlowLogWriteSQLRespTotal is the total time used to write response to client.
SlowLogWRU is the write request_unit(RU) cost.
SlowQueryLog is the name for 'slow_query_log' system variable.
Socket is the name for 'socket' system variable.
SQLAutoIsNull is the name for 'sql_auto_is_null' system variable.
SQLBigSelects is the name for 'sql_big_selects' system variable.
SQLModeVar is the name of the 'sql_mode' system variable.
SQLNotes is the name for 'sql_notes' system variable.
SQLQuoteShowCreate is the name for 'sql_quote_show_create' system variable.
SQLRequirePrimaryKey is the name of `sql_require_primary_key` system variable.
SQLSafeUpdates is the name for 'sql_safe_updates' system variable.
SQLSelectLimit is the name for 'sql_select_limit' system variable.
SQLWarnings is the name for 'sql_warnings' system variable.
Static indicates only prune at plan phase.
StaticButPrepareDynamic is out-of-date.
StaticOnly is out-of-date.
SuperReadOnly is the name for 'super_read_only' system variable.
SyncBinlog is the name for 'sync_binlog' system variable.
SystemTimeZone is the name of 'system_time_zone' system variable.
TableDefinitionCache is the name for 'table_definition_cache' system variable.
ThreadPoolSize is the name of 'thread_pool_size' variable.
TiDBAdaptiveClosestReadThreshold is for reading data from closest replicas(with same 'zone' label).
TiDBAllowAutoRandExplicitInsert indicates whether explicit insertion on auto_random column is allowed.
TiDBAllowBatchCop means if we should send batch coprocessor to TiFlash.
TiDBAllowFallbackToTiKV indicates the engine types whose unavailability triggers fallback to TiKV.
TiDBAllowFunctionForExpressionIndex is the name of `TiDBAllowFunctionForExpressionIndex` system variable.
TiDBAllowMPPExecution means if we should use mpp way to execute query or not.
TiDBAllowRemoveAutoInc indicates whether a user can drop the auto_increment column attribute or not.
TiDBAllowTiFlashCop means we only use MPP mode to query data.
TiDBAnalyzeColumnOptions specifies the default column selection strategy for both manual and automatic analyze operations.
TiDBAnalyzeDistSQLScanConcurrency is the number of concurrent workers to scan regions to collect statistics (FMSketch, Samples).
TiDBAnalyzePartitionConcurrency is the number of concurrent workers to save statistics to the system tables.
TiDBAnalyzeSkipColumnTypes indicates the column types whose statistics would not be collected when executing the ANALYZE command.
TiDBAnalyzeVersion indicates how tidb collects the analyzed statistics and how use to it.
TiDBAutoAnalyzeConcurrency is the concurrency of the auto analyze.
TiDB system variable names that only in session scope.
TiDBAutoAnalyzePartitionBatchSize indicates the batch size for partition tables for auto analyze in dynamic mode Deprecated: This variable is deprecated, please do not use this variable.
TiDBAutoAnalyzeRatio will run if (table modify count)/(table row count) is greater than this value.
TiDBAutoAnalyzeStartTime will run if current time is within start time and end time.
TiDBAutoBuildStatsConcurrency is the number of concurrent workers to automatically analyze tables or partitions.
TiDBBackoffLockFast is used for tikv backoff base time in milliseconds.
TiDBBackOffWeight is used to control the max back off time in TiDB.
TiDBBatchCommit is used to enable/disable auto-split the transaction.
TiDBBatchDelete is used to enable/disable auto-split delete data.
TiDBBatchInsert is used to enable/disable auto-split insert data.
TiDBBatchPendingTiFlashCount indicates the maximum count of non-available TiFlash tables.
TiDBBCJThresholdCount is used to limit the count of small table for mpp broadcast join.
TiDBBCJThresholdSize is used to limit the size of small table for mpp broadcast join.
TiDBBuildSamplingStatsConcurrency is used to control the concurrency of building stats using sampling.
TiDBBuildStatsConcurrency specifies the number of concurrent workers used for analyzing tables or partitions.
TiDBCapturePlanBaseline indicates whether the capture of plan baselines is enabled.
TiDBCDCWriteSource indicates the following data is written by TiCDC if it is not 0.
TiDBCheckMb4ValueInUTF8 is used to control whether to enable the check wrong utf8 value.
TiDBChecksumTableConcurrency 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.
TiDBCloudStorageURI used to set a cloud storage uri for ddl add index and import into.
TiDBCommitterConcurrency controls the number of running concurrent requests in the commit phase.
TiDBConfig is a read-only variable that shows the config of the current server.
TiDBConstraintCheckInPlace indicates to check the constraint when the SQL executing.
TiDBConstraintCheckInPlacePessimistic controls whether to skip certain kinds of pessimistic locks.
TiDBCostModelVersion is a internal switch to indicates the cost model version.
TiDBCurrentTS is used to get the current transaction timestamp.
TiDBDDLDiskQuota used to set disk quota for lightning add index.
TiDBDDLEnableFastReorg indicates whether to use lighting backfill process for adding index.
TiDBDDLErrorCountLimit defines the count of ddl error limit.
TiDBDDLFlashbackConcurrency defines the count of ddl flashback workers.
TiDBDDLReorgBatchSize defines the transaction batch size of ddl reorg workers.
TiDBDDLReorgMaxWriteSpeed defines the max write limitation for the lightning local backend.
TiDBDDLReorgPriority defines the operations' priority of adding indices.
TiDBDDLReorgWorkerCount defines the count of ddl reorg workers.
TiDB system variable names that only in session scope.
TiDBDefaultStrMatchSelectivity controls some special cardinality estimation strategy for string match functions (like and regexp).
TiDBDisableColumnTrackingTime records the last time TiDBEnableColumnTracking is set off.
TiDBDisableTxnAutoRetry disables transaction auto retry.
TiDBDistSQLScanConcurrency is used to set the concurrency of a distsql scan task.
TiDBDMLBatchSize is used to split the insert/delete data into small batches.
TiDBDMLType indicates the execution type of DML in TiDB.
TiDBEnable1PC indicates whether to enable the one-phase commit feature.
TiDBEnableAnalyzeSnapshot indicates whether to read data on snapshot when collecting statistics.
TiDBEnableAsyncCommit indicates whether to enable the async commit feature.
TiDBEnableAsyncMergeGlobalStats indicates whether to enable async merge global stats.
TiDBEnableAutoAnalyze determines whether TiDB executes automatic analysis.
TiDBEnableAutoAnalyzePriorityQueue determines whether TiDB executes automatic analysis with priority queue.
TiDBEnableAutoIncrementInGenerated disables the mysql compatibility check on using auto-incremented columns in expression indexes and generated columns described here https://dev.mysql.com/doc/refman/5.7/en/create-table-generated-columns.html for details.
TiDBEnableBatchDML enables batch dml.
TiDBEnableCascadesPlanner is used to control whether to enable the cascades planner.
TiDBEnableCheckConstraint indicates whether to enable check constraint feature.
TiDBEnableChunkRPC enables TiDB to use Chunk format for coprocessor requests.
TiDBEnableClusteredIndex indicates if clustered index feature is enabled.
TiDBEnableCollectExecutionInfo indicates that whether execution info is collected.
TiDBEnableColumnTracking enables collecting predicate columns.
TiDBEnableDDL indicates whether the tidb-server campaigns the DDL owner,.
TiDBEnableDistTask indicates whether to enable the distributed execute background tasks(For example DDL, Import etc).
TiDBEnableEnhancedSecurity restricts SUPER users from certain operations.
TiDBEnableExchangePartition indicates whether to enable exchange partition.
TiDBEnableExtendedStats indicates whether the extended statistics feature is enabled.
TiDBEnableExternalTSRead indicates whether to enable read through an external ts.
TiDBEnableFastAnalyze indicates to use fast analyze.
TiDBEnableFastCreateTable indicates whether to enable the fast create table feature.
TiDBEnableForeignKey indicates whether to enable foreign key feature.
TiDBEnableGCAwareMemoryTrack indicates whether to turn-on GC-aware memory track.
TiDBEnableGlobalIndex means if we could create an global index on a partition table or not.
TiDBEnableGOGCTuner is to enable GOGC tuner.
TiDBEnableHistoricalStats enables the historical statistics feature (default off).
TiDBEnableHistoricalStatsForCapture indicates whether use historical stats in plan replayer capture.
TiDBEnableIndexMerge indicates to generate IndexMergePath.
TiDBEnableIndexMergeJoin indicates whether to enable index merge join.
TiDBEnableINLJoinInnerMultiPattern indicates whether enable multi pattern for inner side of inl join.
TiDBEnableInstancePlanCache indicates whether to enable instance plan cache.
TiDBEnableLazyCursorFetch defines whether to enable the lazy cursor fetch.
TiDBEnableLegacyInstanceScope indicates if instance scope can be set with SET SESSION.
TiDBEnableListTablePartition is used to control list table partition feature.
TiDBEnableLocalTxn indicates whether to enable Local Txn.
TiDBEnableMDL indicates whether to enable MDL.
TiDBEnableMutationChecker indicates whether to check data consistency for mutations.
TiDBEnableNewCostInterface is a internal switch to indicates whether to use the new cost calculation interface.
TiDBEnableNonPreparedPlanCache indicates whether to enable non-prepared plan cache.
TiDBEnableNonPreparedPlanCacheForDML indicates whether to enable non-prepared plan cache for DML statements.
TiDBEnableNoopFuncs set true will enable using fake funcs(like get_lock release_lock).
TiDBEnableNoopVariables is used to indicate if noops appear in SHOW [GLOBAL] VARIABLES.
TiDBEnableOrderedResultMode indicates if stabilize query results.
TiDBEnablePaging indicates whether paging is enabled in coprocessor requests.
TiDBEnableParallelApply is used for parallel apply.
TiDBEnableParallelHashaggSpill is the name of the `tidb_enable_parallel_hashagg_spill` system variable.
TiDBEnablePipelinedWindowFunction is used to control whether to use pipelined window function, it only works when tidb_enable_window_function = true.
TiDBEnablePlanCacheForParamLimit controls whether prepare statement with parameterized limit can be cached.
TiDBEnablePlanCacheForSubquery controls whether prepare statement with subquery can be cached.
TiDBEnablePlanReplayerCapture indicates whether to enable plan replayer capture.
TiDBEnablePlanReplayerContinuousCapture indicates whether to enable continuous capture.
TiDBEnablePrepPlanCache indicates whether to enable prepared plan cache.
TiDBEnablePrepPlanCacheMemoryMonitor indicates whether to enable prepared plan cache monitor.
TiDBEnablePseudoForOutdatedStats indicates whether use pseudo for outdated stats.
TiDBEnableRateLimitAction indicates whether enabled ratelimit action.
TiDBEnableResourceControl indicates whether resource control feature is enabled.
TiDBEnableReusechunk indicates whether to enable chunk alloc.
TiDBEnableRowLevelChecksum is used to control whether to append checksum to row values.
TiDBEnableSharedLockPromotion indicates whether the `select for share` statement would be executed as `select for update` statements which do acquire pessimistic locks.
TiDBEnableSlowLog enables TiDB to log slow queries.
TiDBEnableStatsOwner indicates whether the tidb-server campaigns the Stats owner,.
TiDBEnableStmtSummary indicates whether the statement summary is enabled.
TiDBEnableStrictDoubleTypeCheck is used to control table field double type syntax check.
TiDBEnableTablePartition is used to control table partition feature.
TiDBEnableTelemetry indicates that whether usage data report to PingCAP is enabled.
TiDBEnableTiFlashPipelineMode means if we should use pipeline model to execute query or not in tiflash.
TiDBEnableTiFlashReadForWriteStmt indicates whether to enable TiFlash to read for write statements.
TiDBEnableTmpStorageOnOOM controls whether to enable the temporary storage for some operators when a single SQL statement exceeds the memory quota specified by the memory quota.
TiDBEnableTopSQL indicates whether the top SQL is enabled.
TiDBEnableTSOFollowerProxy indicates whether to enable the TSO Follower Proxy feature of PD client.
TiDBEnableUnsafeSubstitute indicates whether to enable generate column takes unsafe substitute.
TiDBEnableVectorizedExpression is used to control whether to enable the vectorized expression evaluation.
TiDBEnableWindowFunction is used to control whether to enable the window function.
TiDBEnforceMPPExecution means if we should enforce mpp way to execute query or not.
TiDBEvolvePlanBaselines indicates whether the evolution of plan baselines is enabled.
TiDBEvolvePlanTaskEndTime is the end time of evolution task.
TiDBEvolvePlanTaskMaxTime controls the max time of a single evolution task.
TiDBEvolvePlanTaskStartTime is the start time of evolution task.
TiDBExecutorConcurrency is used for controlling the concurrency of all types of executors.
TiDBExpensiveQueryTimeThreshold indicates the time threshold of expensive query.
TiDBExpensiveTxnTimeThreshold indicates the time threshold of expensive transaction.
TiDBExplicitRequestSourceType indicates the source of the request, it's a complement of RequestSourceType.
TiDBExternalTS is the ts to read through when the `TiDBEnableExternalTsRead` is on.
TiDBFastCheckTable enables fast check table.
TiDBForcePriority defines the operations' priority of all statements.
TiDBFoundInBinding indicates whether the last statement was matched with the hints in the binding.
TiDBFoundInPlanCache indicates whether the last statement was found in plan cache.
TiDBGCConcurrency sets the concurrency of garbage collection.
TiDBGCEnable turns garbage collection on or OFF.
TiDBGCLifetime sets the retention window of older versions.
TiDBGCMaxWaitTime sets max time for gc advances the safepoint delayed by active transactions.
TiDBGCRunInterval sets the interval that GC runs.
TiDBGCScanLockMode enables the green GC feature (deprecated).
TiDBGeneralLog is used to log every query in the server in info level.
TiDBGenerateBinaryPlan indicates whether binary plan should be generated in slow log and statements summary.
TiDBGOGCTunerMaxValue is the max value of GOGC that GOGC tuner can change to.
TiDBGOGCTunerMinValue is the min value of GOGC that GOGC tuner can change to.
TiDBGOGCTunerThreshold is to control the threshold of GOGC tuner.
TiDBGuaranteeLinearizability indicates whether to guarantee linearizability.
TiDBHashAggFinalConcurrency is used for hash agg executor.
TiDBHashAggPartialConcurrency is used for hash agg executor.
TiDBHashExchangeWithNewCollation means if hash exchange is supported when new collation is on.
TiDBHashJoinConcurrency is used for hash join executor.
TiDBHashJoinVersion indicates whether to use hash join implementation v2.
TiDBHistoricalStatsDuration indicates the duration to remain tidb historical stats.
TiDBIdleTransactionTimeout indicates the maximum time duration a transaction could be idle, unit is second.
TiDBIgnoreInlistPlanDigest enables TiDB to generate the same plan digest with SQL using different in-list arguments.
TiDBIgnorePreparedCacheCloseStmt indicates whether to ignore close-stmt commands for prepared statements.
TiDBIndexJoinBatchSize is used to set the batch size of an index lookup join.
TiDBIndexJoinDoubleReadPenaltyCostRate indicates whether to add some penalty cost to IndexJoin and how much of it.
TiDBIndexLookupConcurrency is used for index lookup executor.
TiDBIndexLookupJoinConcurrency is used for index lookup join executor.
TiDBIndexLookupSize is used for index lookup executor.
TiDBIndexMergeIntersectionConcurrency is used for parallel worker of index merge intersection.
TiDBIndexSerialScanConcurrency 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.
TiDBInitChunkSize is used to control the init chunk size during query execution.
TiDBInstancePlanCacheMaxMemSize indicates the maximum memory size of instance plan cache.
TiDBInstancePlanCacheReservedPercentage indicates the percentage memory to evict.
TiDBIsolationReadEngines indicates the tidb only read from the stores whose engine type is involved in IsolationReadEngines.
TiDBLastDDLInfo is used to get the last ddl info within the current session.
TiDBLastPlanReplayerToken is used to get the last plan replayer token within the current session.
TiDBLastQueryInfo is used to get the last query info within the current session.
TiDBLastTxnInfo is used to get the last transaction info within the current session.
TiDBLoadBasedReplicaReadThreshold is the wait duration threshold to enable replica read automatically.
TiDBLoadBindingTimeout is the name of the 'tidb_load_binding_timeout' system variable.
TiDBLockUnchangedKeys indicates whether to lock duplicate keys in INSERT IGNORE and REPLACE statements, or unchanged unique keys in UPDATE statements, see PR #42210 and #42713.
TiDBLogFileMaxDays is used to log every query in the server in info level.
TiDBLowResolutionTSO is used for reading data with low resolution TSO which is updated once every two seconds.
TiDBLowResolutionTSOUpdateInterval defines how often to refresh low resolution timestamps.
TiDBMaxAutoAnalyzeTime is the max time that auto analyze can run.
TiDBMaxBytesBeforeTiFlashExternalGroupBy is the maximum bytes used by a TiFlash hash aggregation before spill to disk.
TiDBMaxBytesBeforeTiFlashExternalJoin is the maximum bytes used by a TiFlash join before spill to disk.
TiDBMaxBytesBeforeTiFlashExternalSort is the maximum bytes used by a TiFlash sort/TopN before spill to disk.
TiDBMaxChunkSize is used to control the max chunk size during query execution.
TiDBMaxDeltaSchemaCount defines the max length of deltaSchemaInfos.
TiDBMaxPagingSize is used to control the max paging size in the coprocessor paging protocol.
TiDBMaxTiFlashThreads is the maximum number of threads to execute the request which is pushed down to tiflash.
TiDBMemOOMAction indicates what operation TiDB perform when a single SQL statement exceeds the memory quota specified by tidb_mem_quota_query and cannot be spilled to disk.
TiDBMemoryDebugModeAlarmRatio is used set tidb memory debug mode bias ratio.
TiDBMemoryDebugModeMinHeapInUse is used to set tidb memory debug mode trigger threshold.
TiDBMemoryUsageAlarmKeepRecordNum indicates the number of saved alarm files.
TiDBMemoryUsageAlarmRatio indicates the alarm threshold when memory usage of the tidb-server exceeds.
TiDBMemQuotaAnalyze indicates the memory quota for all analyze jobs.
TiDBMemQuotaApplyCache controls the memory quota of a query.
TiDBMemQuotaBindingCache indicates the memory quota for the bind cache.
Bytes.
TiDBMergeJoinConcurrency is used for merge join parallel executor.
TiDBMergePartitionStatsConcurrency indicates the concurrency when merge partition stats into global stats.
TiDBMetricSchemaRangeDuration indicates the range duration when query metric schema.
TiDBMetricSchemaStep indicates the step when query metric schema.
TiDBMinPagingSize is used to control the min paging size in the coprocessor paging protocol.
TiDBMPPStoreFailTTL is the unavailable time when a store is detected failed.
TiDBMultiStatementMode enables multi statement at the risk of SQL injection provides backwards compatibility.
TiDBNonPreparedPlanCacheSize controls the size of non-prepared plan cache.
TiDBNonTransactionalIgnoreError is used to ignore error in non-transactional DMLs.
TiDBOpt3StageDistinctAgg is used to indicate whether to plan and execute the distinct agg in 3 stages.
TiDBOptAdvancedJoinHint indicates whether the join method hint is compatible with join order hint.
TiDBOptAggPushDown is used to enable/disable the optimizer rule of aggregation push down.
TiDBOptCartesianBCJ is used to disable/enable broadcast cartesian join in MPP mode.
TiDBOptConcurrencyFactor is the CPU cost of additional one goroutine.
TiDBOptCopCPUFactor is the CPU cost of processing one expression for one row in coprocessor.
TiDBOptCorrelationExpFactor is an exponential factor to control heuristic approach when tidb_opt_correlation_threshold is not satisfied.
TiDBOptCorrelationThreshold is a guard to enable row count estimation using column order correlation.
TiDBOptCPUFactor is the CPU cost of processing one expression for one row.
TiDBOptDeriveTopN is used to enable/disable the optimizer rule of deriving topN.
TiDBOptDescScanFactor is the IO cost of scanning 1 byte data on TiKV in desc order.
TiDBOptDiskFactor is the IO cost of reading/writing one byte to temporary disk.
TiDBOptDistinctAggPushDown is used to decide whether agg with distinct should be pushed to tikv/tiflash.
TiDBOptEnable3StageMultiDistinctAgg is used to indicate whether to plan and execute the multi distinct agg in 3 stages.
TiDBOptEnableCorrelationAdjustment is used to indicates if enable correlation adjustment.
TiDBOptEnableFuzzyBinding indicates whether to enable the universal binding.
TiDBOptEnableHashJoin indicates whether to enable hash join.
TiDBOptEnableLateMaterialization indicates whether to enable late materialization.
TiDBOptEnableMPPSharedCTEExecution indicates whether the optimizer try to build shared CTE scan during MPP execution.
TiDB system variable names that only in session scope.
TiDBOptFixControl makes the user able to control some details of the optimizer behavior.
TiDBOptForceInlineCTE is used to enable/disable inline CTE.
TiDBOptimizerEnableNAAJ is used to open the newly null-aware anti join.
TiDBOptimizerEnableNewOnlyFullGroupByCheck is used to open the newly only_full_group_by check by maintaining functional dependency.
TiDB system variable names that only in session scope.
TiDBOptimizerSelectivityLevel is used to control the selectivity estimation level.
TiDBOptInSubqToJoinAndAgg is used to enable/disable the optimizer rule of rewriting IN subquery.
TiDBOptJoinReorderThreshold defines the threshold less than which we'll choose a rather time-consuming algorithm to calculate the join order.
TiDBOptLimitPushDownThreshold determines if push Limit or TopN down to TiKV forcibly.
TiDBOptMemoryFactor is the memory cost of storing one tuple.
TiDB system variable names that only in session scope.
TiDBOptNetworkFactor is the network cost of transferring 1 byte data.
TiDBOptObjective indicates whether the optimizer should be more stable, predictable or more aggressive.
TiDBOptOrderingIdxSelRatio is the ratio the optimizer will assume applies when non indexed filtering rows are found via the ordering index.
TiDBOptOrderingIdxSelThresh is the threshold for optimizer to consider the ordering index.
TiDBOptPreferRangeScan is used to enable/disable the optimizer to always prefer range scan over table scan, ignoring their costs.
TiDBOptPrefixIndexSingleScan indicates whether to do some optimizations to avoid double scan for prefix index.
TiDBOptProjectionPushDown is used to control whether to pushdown projection to coprocessor.
TiDBOptRangeMaxSize is the max memory limit for ranges.
TiDBOptScanFactor is the IO cost of scanning 1 byte data on TiKV.
TiDBOptSeekFactor is the IO cost of seeking the start value in a range on TiKV or TiFlash.
TiDBOptSkewDistinctAgg is used to indicate the distinct agg has data skew.
TiDBOptTiFlashConcurrencyFactor is concurrency number of tiflash computation.
TiDBOptUseInvisibleIndexes indicates whether to use invisible indexes.
TiDBOptWriteRowID is used to enable/disable the operations of insert、replace and update to _tidb_rowid.
TiDBPartitionPruneMode indicates the partition prune mode used.
TiDBPersistAnalyzeOptions persists analyze options for later analyze and auto-analyze.
TiDBPessimisticTransactionFairLocking controls whether fair locking for pessimistic transaction is enabled.
TiDBPlacementMode is used to control the mode for placement.
TiDBPlanCacheInvalidationOnFreshStats controls if plan cache will be invalidated automatically when related stats are analyzed after the plan cache is generated.
TiDBPlanCacheMaxPlanSize controls the maximum size of a plan that can be cached.
TiDBPProfSQLCPU is used to add label sql label to pprof result.
TiDBPreferBCJByExchangeDataSize indicates the method used to choose mpp broadcast join.
TiDBPrepPlanCacheMemoryGuardRatio is used to prevent [performance.max-memory] from being exceeded.
TiDBPrepPlanCacheSize indicates the number of cached statements.
TiDBPreSplitRegions means all the tables created in the current session will be pre-splited.
TiDBProjectionConcurrency is used for projection operator.
TiDBQueryLogMaxLen is used to set the max length of the query in the log.
TiDBRCReadCheckTS indicates the tso optimization for read-consistency read is enabled.
TiDBRCWriteCheckTs indicates whether some special write statements don't get latest tso from PD at RC.
TiDBReadConsistency indicates whether the autocommit read statement goes through TiKV RC.
TiDBReadStaleness indicates the staleness duration for following statement.
TiDBRecordPlanInSlowLog is used to log the plan of the slow query.
TiDBRedactLog indicates that whether redact log.
TiDBRegardNULLAsPoint indicates whether regard NULL as point when optimizing.
TiDBRemoveOrderbyInSubquery indicates whether to remove ORDER BY in subquery.
TiDBReplicaRead is used for reading data from replicas, followers for example.
TiDBResourceControlStrictMode indicates whether resource control strict mode is enabled.
TiDBRestrictedReadOnly is meant for the cloud admin to toggle the cluster read only.
TiDBRetryLimit is the maximum number of retries when committing a transaction.
TiDBRowFormatVersion is used to control tidb row format version current.
TiDBRuntimeFilterModeName the mode of runtime filter, such as "OFF", "LOCAL".
TiDBRuntimeFilterTypeName the value of is string, a runtime filter type list split by ",", such as: "IN,MIN_MAX".
TiDBScatterRegion will scatter the regions for DDLs when it is "table" or "global", "" indicates not trigger scatter.
TiDBSchemaCacheSize indicates the size of infoschema meta data which are cached in V2 implementation.
TiDBSchemaVersionCacheLimit defines the capacity size of domain infoSchema cache.
TiDBServerMemoryLimit indicates the memory limit of the tidb-server instance.
TiDBServerMemoryLimitGCTrigger indicates the gc percentage of the TiDBServerMemoryLimit.
TiDBServerMemoryLimitSessMinSize indicates the minimal memory used of a session, that becomes a candidate for session kill.
TiDBServiceScope indicates the role for tidb for distributed task framework.
TiDBSessionAlias indicates the alias of a session which is used for tracing.
TiDBSessionPlanCacheSize controls the size of session plan cache.
TiDBShardAllocateStep indicates the max size of continuous rowid shard in one transaction.
TiDBShardRowIDBits means all the tables created in the current session will be sharded.
TiDBSimplifiedMetrics controls whether to unregister some unused metrics.
TiDBSkipASCIICheck skips the ASCII validate process old tidb may already have fields with invalid ASCII bytes disable ASCII validate can guarantee a safe replication.
TiDBSkipIsolationLevelCheck is used to control whether to return error when set unsupported transaction isolation level.
TiDBSkipMissingPartitionStats controls how to handle missing partition stats when merging partition stats to global stats.
TiDBSkipUTF8Check 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.
TiDBSlowLogThreshold is used to set the slow log threshold in the server.
TiDBSlowQueryFile indicates which slow query log file for SLOW_QUERY table to parse.
TiDBSlowTxnLogThreshold is used to set the slow transaction log threshold in the server.
TiDBSnapshot is used for reading history data, the default value is empty string.
TiDBSourceID indicates the source ID of the TiDB server.
TiDBStatsCacheMemQuota records stats cache quota.
TiDBStatsLoadPseudoTimeout indicates whether to fallback to pseudo stats after load timeout.
TiDBStatsLoadSyncWait indicates the time sql execution will sync-wait for stats load.
TiDBStmtSummaryEnablePersistent indicates whether to enable file persistence for stmtsummary.
TiDBStmtSummaryFileMaxBackups indicates the maximum number of files written by stmtsummary.
TiDBStmtSummaryFileMaxDays indicates how many days the files written by stmtsummary will be kept.
TiDBStmtSummaryFileMaxSize indicates the maximum size (in mb) of a single file written by stmtsummary.
TiDBStmtSummaryFilename indicates the file name written by stmtsummary.
TiDBStmtSummaryHistorySize indicates the history size of each statement summary.
TiDBStmtSummaryInternalQuery indicates whether the statement summary contain internal query.
TiDBStmtSummaryMaxSQLLength indicates the max length of displayed normalized sql and sample sql.
TiDBStmtSummaryMaxStmtCount indicates the max number of statements kept in memory.
TiDBStmtSummaryRefreshInterval indicates the refresh interval in seconds for each statement summary.
TiDBStoreBatchSize indicates the batch size of coprocessor in the same store.
TiDBStoreLimit indicates the limit of sending request to a store, 0 means without limit.
TiDBStreamAggConcurrency is used for stream aggregation parallel executor.
TiDBSuperReadOnly is tidb's variant of mysql's super_read_only, which has some differences from mysql's super_read_only.
TiDBSysdateIsNow is the name of the `tidb_sysdate_is_now` system variable.
TiDBSysProcScanConcurrency is used to set the scan concurrency of for backend system processes, like auto-analyze.
TiDBTableCacheLease indicates the read lock lease of a cached table.
TiDBTmpTableMaxSize indicates the max memory size of temporary tables.
TiDBTopSQLMaxMetaCount indicates the max capacity of the collect meta per second.
TiDBTopSQLMaxTimeSeriesCount indicates the max number of statements been collected in each time series.
TiDBTrackAggregateMemoryUsage indicates whether track the memory usage of aggregate function.
TiDBTSOClientBatchMaxWaitTime indicates the max value of the TSO Batch Wait interval time of PD client.
TiDBTSOClientRPCMode controls how the TSO client performs the TSO RPC requests.
TiDBTTLDeleteBatchSize is used to control the batch size in the DELETE statement for TTL jobs.
TiDBTTLDeleteRateLimit is used to control the delete rate limit for TTL jobs in each node.
TiDBTTLDeleteWorkerCount indicates the count of the delete workers in each TiDB node.
TiDBTTLJobEnable is used to enable/disable scheduling ttl job.
TiDBTTLJobScheduleWindowEndTime is used to restrict the end time of the time window of scheduling the ttl jobs.
TiDBTTLJobScheduleWindowStartTime is used to restrict the start time of the time window of scheduling the ttl jobs.
TiDBTTLRunningTasks limits the count of running ttl tasks.
TiDBTTLScanBatchSize is used to control the batch size in the SELECT statement for TTL jobs.
TiDBTTLScanWorkerCount indicates the count of the scan workers in each TiDB node.
TiDBTxnAssertionLevel indicates how strict the assertion will be, which helps to detect and preventing data & index inconsistency problems.
TiDBTxnCommitBatchSize is used to control the batch size of transaction commit related requests sent by TiDB to TiKV.
TiDBTxnEntrySizeLimit indicates the max size of a entry in membuf.
TiDBTxnMode is used to control the transaction behavior.
TiDBTxnReadTS indicates the next transaction should be staleness transaction and provide the startTS.
TiDBTxnScope indicates whether using global transactions or local transactions.
TiDBUseAlloc indicates whether the last statement used chunk alloc.
TiDBUsePlanBaselines indicates whether the use of plan baselines is enabled.
TiDBWaitSplitRegionFinish defines the split region behaviour is sync or async.
TiDBWaitSplitRegionTimeout uses to set the split and scatter region back off time.
TiDBWindowConcurrency is used for window parallel executor.
TiFlashComputeDispatchPolicy indicates how to dispatch task to tiflash_compute nodes.
TiFlashFastScan indicates whether use fast scan in tiflash.
TiDB system variable names that both in session and global scope.
Fine grained shuffle is disabled when TiFlashFineGrainedShuffleStreamCount is zero.
TiFlashHashAggPreAggMode indicates the policy of 1st hashagg.
TiFlashMemQuotaQueryPerNode is the maximum bytes used by a TiFlash Query on each TiFlash node.
TiFlashQuerySpillRatio is the threshold that TiFlash will trigger auto spill when the memory usage is above this percentage.
TiFlashReplicaRead is used to set the policy of TiFlash replica read when the query needs the TiFlash engine.
TiKVClientReadTimeout is the name of the 'tikv_client_read_timeout' system variable.
Timestamp is the name for 'timestamp' system variable.
TimeZone is the name of the 'time_zone' system variable.
TransactionIsolation is the name of the 'transaction_isolation' system variable.
TransactionReadOnly is the name of 'transaction_read_only' system variable.
TSOClientRPCModeDefault is a choice of variable TiDBTSOClientRPCMode.
TSOClientRPCModeParallel is a choice of variable TiDBTSOClientRPCMode.
TSOClientRPCModeParallelFast is a choice of variable TiDBTSOClientRPCMode.
TxnIsolation is the name of the 'tx_isolation' system variable.
TxnIsolationOneShot is the name of the 'tx_isolation_one_shot' system variable.
TxReadOnly is the name of 'tx_read_only' system variable.
TypeBool for boolean.
TypeDuration for a golang duration (a TiDB extension).
TypeEnum for Enum.
TypeFloat for Double.
TypeInt for integer.
TypeStr is the default.
TypeTime for time of day (a TiDB extension).
TypeUnsigned for Unsigned integer.
UniqueChecks is the name for 'unique_checks' system variable.
ValidatePasswordCheckUserName controls whether validate_password compares passwords to the user name part of the effective user account for the current session.
ValidatePasswordDictionary specified the dictionary that validate_password uses for checking passwords.
ValidatePasswordEnable turns on/off the validation of password.
ValidatePasswordLength specified the minimum number of characters that validate_password requires passwords to have.
ValidatePasswordMixedCaseCount specified the minimum number of lowercase and uppercase characters that validate_password requires.
ValidatePasswordNumberCount specified the minimum number of numeric (digit) characters that validate_password requires.
ValidatePasswordPolicy specifies the password policy enforced by validate_password.
ValidatePasswordSpecialCharCount specified the minimum number of nonalphanumeric characters that validate_password requires.
Version is the name of 'version' system variable.
VersionComment is the name of 'version_comment' system variable.
WaitTimeout is the name for 'wait_timeout' system variable.
Warn means return warnings.
WarningCount is the name for 'warning_count' system variable.
WarnInt is used by TiDBOptOnOffWarn.
WindowingUseHighPrecision is the name of 'windowing_use_high_precision' system variable.
# Variables
AnalyzeColumnOptions is a global variable that indicates the default column choice for ANALYZE.
Process global variables.
Process global variables.
ChangeSchemaCacheSize is called when tidb_schema_cache_size is changed.
Process global variables.
DDLDiskQuota is the temporary variable for set disk quota for lightning.
Process global variables.
DDLSlowOprThreshold is the threshold for ddl slow operations, uint is millisecond.
DefaultStatusVarScopeFlag is the default scope of status variables.
DefTiDBServerMemoryLimit indicates the default value of TiDBServerMemoryLimit(TotalMem * 80%).
DisableDDL is the func registered by ddl to disable running ddl in this instance.
DisableGlobalResourceControlFunc is the function registered by tikv_driver to unset cluster resource control.
DisableStatsOwner is the func registered by stats to disable running stats in this instance.
Process global variables.
Process global variables.
Process global variables.
EnableDDL is the func registered by ddl to enable running ddl in this instance.
Process global variables.
Process global variables.
EnableFastReorg indicates whether to use lightning to enhance DDL reorg performance.
EnableForeignKey indicates whether to enable foreign key feature.
EnableGlobalResourceControlFunc is the function registered by tikv_driver to set cluster resource control.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
always set the default value to false because the resource control in kv-client is not inited It will be initialized to the right value after the first call of `rebuildSysVarCache`.
Process global variables.
EnableRowLevelChecksum indicates whether to append checksum to row values.
EnableStatsOwner is the func registered by stats to enable running stats in this instance.
Process global variables.
Process global variables.
Process global variables.
TODO: set value by session variable.
ErrFunctionsNoopImpl is an error to say the behavior is protected by the tidb_enable_noop_functions sysvar.
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.
Process global variables.
Process global variables.
Process global variables.
GAFunction4ExpressionIndex stores functions GA for expression index.
Process global variables.
GenerateBinaryPlan decides whether we should record binary plan in slow log and stmt summary.
GetExternalTimestamp is the func registered by staleread to get externaltimestamp from pd.
GetMemQuotaAnalyze is the func registered by global/subglobal tracker to get memory quota.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
variables for plan cache.
PreparedStmtCount is exported for test.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
SchemaCacheSizeLowerBound will adjust the schema cache size to this value if it is lower than this value.
SchemaCacheSizeLowerBoundStr is the string representation of SchemaCacheSizeLowerBound.
Process global variables.
Process global variables.
Process global variables.
SetCharsetVariables is the system variable names related to set charset statements.
SetExternalTimestamp is the func registered by staleread to set externaltimestamp in pd.
SetGlobalResourceControl is the func registered by domain to set cluster resource control.
SetLowResolutionTSOUpdateInterval is the func registered by domain to set slow resolution tso update interval.
SetMemQuotaAnalyze is the func registered by global/subglobal tracker to set memory quota.
SetNamesVariables is the system variable names related to set names statements.
SetPDClientDynamicOption is the func registered by domain.
SetStatsCacheCapacity is the func registered by domain to set statsCache memory quota.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
SwitchFastCreateTable is the func registered by DDL to switch fast create table.
SwitchMDL is the func registered by DDL to switch MDL.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
Process global variables.
ValidateCloudStorageURI validates the cloud storage URI.
Process global variables.
Process global variables.
# Structs
BatchSize defines batch size values.
ColSize is a data struct to store the delta information for a table.
Concurrency defines concurrency values.
ConnectionInfo presents the connection information, which is mainly used by audit logs.
JSONSQLWarnForSlowLog helps to print the SQLWarn through the slow log in JSON format.
LazyStmtText represents the sql text of a stmt that used in log.
MemQuota defines memory quota values.
MockGlobalAccessor implements GlobalVarAccessor interface.
PlanCacheParamList stores the parameters for plan cache.
RetryInfo saves retry information.
RewritePhaseInfo records some information about the rewrite phase.
RowIDShardGenerator is used to generate shard for row id.
SavepointRecord indicates a transaction's savepoint record.
SequenceState cache all sequence's latest value accessed by lastval() builtins.
SessionVars is to handle user-defined or global variables in the current session.
SlowQueryLogItems is a collection of items that should be included in the slow query log.
StatusVal is the value of the corresponding status variable.
SysVar is for system variable.
TableDelta stands for the changed count for one table or partition.
TableSnapshot represents a data snapshot of the table contained in `information_schema`.
TransactionContext is used to store variables that has transaction scope.
TxnCtxNeedToRestore stores transaction variables which need to be restored when rolling back to a savepoint.
TxnCtxNoNeedToRestore stores transaction variables which do not need to restored when rolling back to a savepoint.
TxnReadTS indicates the value and used situation for tx_read_ts.
UserVars is used to provide user variable operations.
WriteStmtBufs can be used by insert/replace/delete/update statement.
# Interfaces
DeltaCols is used to update the delta size for cols.
GlobalVarAccessor is the interface for accessing global scope system and status variables.
HookContext contains the necessary variables for executing set/get hook.
SessionVarsProvider provides the session variables.
Statistics is the interface of statistics.
TemporaryTableData is a interface to maintain temporary data in session.
UserVarsReader is used to read user defined variables.
# Type aliases
AssertionLevel controls the assertion that will be performed during transactions.
ClusteredIndexDefMode controls the default clustered property for primary key.
DeltaColsMap implements DeltaCols.
PartitionPruneMode presents the prune mode used.
ReadConsistencyLevel is the level of read consistency.
RuntimeFilterMode the mode of runtime filter "OFF", "LOCAL".
RuntimeFilterType type of runtime filter "IN".
ScopeFlag is for system variable whether can be changed in global/session dynamically or not.
TypeFlag is the SysVar type, which doesn't exactly match MySQL types.