cd tools/check; \ GO111MODULE=on go build -o ../bin/goword github.com/chzchzchz/goword tools/bin/goword $(find $(go list ./...| grep -vE "cmd|github.com\/pingcap\/tidb\/tests" | sed 's|github.com/pingcap/tidb/||') -name "*.go") 2>&1 | awk '{ print } END { if (NR > 0) { exit 1 } }' bindinfo/cache.go.153: // `merge` merges two BindRecord. It will replace old bindings with new bindings if there are new updates. (godoc-local: `merge` -> merge?) config/config.go.107: // Set sys variable lower-case-table-names, ref: https://dev.mysql.com/doc/refman/5.7/en/identifier-case-sensitivity.html. (godoc-export: Set -> LowerCaseTableNames?) config/config.go.107: // Set sys variable lower-case-table-names, ref: https://dev.mysql.com/doc/refman/5.7/en/identifier-case-sensitivity.html. (godoc-export: Set -> LowerCaseTableNames?) config/config.go.180: // The client will forward the requests through the follower (godoc-export: The -> EnableForwarding?) config/config.go.180: // The client will forward the requests through the follower (godoc-export: The -> EnableForwarding?) config/config.go.298: // Log level. (godoc-export: Log -> Level?) config/config.go.298: // Log level. (godoc-export: Log -> Level?) config/config.go.300: // Log format, one of json or text. (godoc-export: Log -> Format?) config/config.go.300: // Log format, one of json or text. (godoc-export: Log -> Format?) config/config.go.302: // Disable automatic timestamps in output. Deprecated: use EnableTimestamp instead. (godoc-export: Disable -> DisableTimestamp?) config/config.go.302: // Disable automatic timestamps in output. Deprecated: use EnableTimestamp instead. (godoc-export: Disable -> DisableTimestamp?) config/config.go.364: // If set to "plaintext", the spilled files will not be encrypted. (godoc-export: If -> SpilledFileEncryptionMethod?) config/config.go.364: // If set to "plaintext", the spilled files will not be encrypted. (godoc-export: If -> SpilledFileEncryptionMethod?) config/config.go.370: // The ErrConfigValidationFailed error is used so that external callers can do a type assertion (godoc-export: The -> ErrConfigValidationFailed?) config/config.go.404: // Deprecated: use ServerMemoryQuota instead (godoc-export: Deprecated: -> MaxMemory?) config/config.go.404: // Deprecated: use ServerMemoryQuota instead (godoc-export: Deprecated: -> MaxMemory?) config/config.go.473: // PROXY protocol acceptable client networks. (godoc-export: PROXY -> Networks?) config/config.go.473: // PROXY protocol acceptable client networks. (godoc-export: PROXY -> Networks?) config/config.go.477: // PROXY protocol header read timeout, Unit is second. (godoc-export: PROXY -> HeaderTimeout?) config/config.go.477: // PROXY protocol header read timeout, Unit is second. (godoc-export: PROXY -> HeaderTimeout?) config/config.go.484: // If IgnoreError is true, when writing binlog meets error, TiDB would (godoc-export: If -> IgnoreError?) config/config.go.484: // If IgnoreError is true, when writing binlog meets error, TiDB would (godoc-export: If -> IgnoreError?) config/config.go.488: // Use socket file to write binlog, for compatible with kafka version tidb-binlog. (godoc-export: Use -> BinlogSocket?) config/config.go.488: // Use socket file to write binlog, for compatible with kafka version tidb-binlog. (godoc-export: Use -> BinlogSocket?) config/config.go.490: // The strategy for sending binlog to pump, value can be "range" or "hash" now. (godoc-export: The -> Strategy?) config/config.go.490: // The strategy for sending binlog to pump, value can be "range" or "hash" now. (godoc-export: The -> Strategy?) config/config.go.496: // The max count of retry for a single statement in a pessimistic transaction. (godoc-export: The -> MaxRetryCount?) config/config.go.496: // The max count of retry for a single statement in a pessimistic transaction. (godoc-export: The -> MaxRetryCount?) config/config.go.498: // The max count of deadlock events that will be recorded in the information_schema.deadlocks table. (godoc-export: The -> DeadlockHistoryCapacity?) config/config.go.498: // The max count of deadlock events that will be recorded in the information_schema.deadlocks table. (godoc-export: The -> DeadlockHistoryCapacity?) config/config.go.520: // Enable summary internal query. (godoc-export: Enable -> EnableInternalQuery?) config/config.go.520: // Enable summary internal query. (godoc-export: Enable -> EnableInternalQuery?) config/config.go.522: // The maximum number of statements kept in memory. (godoc-export: The -> MaxStmtCount?) config/config.go.522: // The maximum number of statements kept in memory. (godoc-export: The -> MaxStmtCount?) config/config.go.524: // The maximum length of displayed normalized SQL and sample SQL. (godoc-export: The -> MaxSQLLength?) config/config.go.524: // The maximum length of displayed normalized SQL and sample SQL. (godoc-export: The -> MaxSQLLength?) config/config.go.526: // The refresh interval of statement summary. (godoc-export: The -> RefreshInterval?) config/config.go.526: // The refresh interval of statement summary. (godoc-export: The -> RefreshInterval?) config/config.go.528: // The maximum history size of statement summary. (godoc-export: The -> HistorySize?) config/config.go.528: // The maximum history size of statement summary. (godoc-export: The -> HistorySize?) config/config.go.541: // Whether enable creating expression index. (godoc-export: Whether -> AllowsExpressionIndex?) config/config.go.541: // Whether enable creating expression index. (godoc-export: Whether -> AllowsExpressionIndex?) config/config.go.543: // Whether enable global kill. (godoc-export: Whether -> EnableGlobalKill?) config/config.go.543: // Whether enable global kill. (godoc-export: Whether -> EnableGlobalKill?) ddl/callback_test.go.44: // We recommended to pass the domain parameter to the test ddl callback, it will ensure (godoc-export: We -> Do?) ddl/callback_test.go.44: // We recommended to pass the domain parameter to the test ddl callback, it will ensure (godoc-export: We -> Do?) ddl/column.go.742: // Column type conversion between varchar to char need reorganization because (godoc-local: Column -> convertBetweenCharAndVarchar?) ddl/column.go.1237: // The following attributes are used to reduce memory allocation. (godoc-local: The -> rowRecords?) ddl/column.go.1243: // For SQL Mode and warnings. (godoc-local: For -> sqlMode?) ddl/column.go.1243: // For SQL Mode and warnings. (godoc-local: For -> sqlMode?) ddl/column_type_change_test.go.962: // Test issue #20529. (godoc-export: Test -> TestColumnTypeChangeIgnoreDisplayLength?) ddl/column_type_change_test.go.1594: // Close issue #22395 (godoc-export: Close -> TestChangingColOriginDefaultValue?) ddl/column_type_change_test.go.1815: // Close issue #22820 (godoc-export: Close -> TestChangingAttributeOfColumnWithFK?) ddl/column_type_change_test.go.1864: // Close https://github.com/pingcap/tidb/issues/24839. (godoc-export: Close -> TestChangeUnsignedIntToDatetime?) ddl/column_type_change_test.go.1884: // Close issue #23202 (godoc-export: Close -> TestDDLExitWhenCancelMeetPanic?) ddl/column_type_change_test.go.1935: // Close issue #24253 (godoc-export: Close -> TestChangeIntToBitWillPanicInBackfillIndexes?) ddl/column_type_change_test.go.1964: // Close issue #24584 (godoc-export: Close -> TestCancelCTCInReorgStateWillCauseGoroutineLeak?) ddl/column_type_change_test.go.2016: // Close issue #24971, #24973, #24974 (godoc-export: Close -> TestCTCShouldCastTheDefaultValue?) ddl/column_type_change_test.go.2044: // Close issue #25037 (godoc-export: Close -> TestCTCCastBitToBinary?) ddl/column_type_change_test.go.2110: // Fix issue https://github.com/pingcap/tidb/issues/25469 (godoc-export: Fix -> TestCastToTimeStampDecodeError?) ddl/db_change_test.go.527: // https://github.com/pingcap/tidb/pull/6249 fixes the following two test cases. (godoc-export: https://github.com/pingcap/tidb/pull/6249 -> TestWriteOnlyWriteNULL?) ddl/db_integration_test.go.160: // TestKeyWithoutLength for issue #13452 (godoc-export: TestKeyWithoutLength -> TestKeyWithoutLengthCreateTable?) ddl/db_integration_test.go.215: // for issue #9910 (godoc-export: for -> TestCreateTableWithKeyWord?) ddl/db_integration_test.go.2758: // TestDefaultValueIsLatin1 for issue #18977 (godoc-export: TestDefaultValueIsLatin1 -> TestEnumAndSetDefaultValue?) ddl/db_test.go.618: // TestCancelDropIndex tests cancel ddl job which type is drop primary key. (godoc-export: TestCancelDropIndex -> TestCancelDropPrimaryKey?) ddl/db_test.go.883: // TestCancelDropTable tests cancel ddl job which type is drop table. (godoc-export: TestCancelDropTable -> TestCancelDropTableAndSchema?) ddl/db_test.go.5444: // port from mysql (godoc-export: port -> TestLock?) ddl/db_test.go.5465: // port from mysql (godoc-export: port -> TestTableLock?) ddl/db_test.go.5499: // port from mysql (godoc-export: port -> TestTableLocksLostCommit?) ddl/db_test.go.5523: // test write local lock (godoc-export: test -> TestWriteLocal?) ddl/db_test.go.6252: // tkSQLs are the sql statements for the pessimistic transaction. (godoc-local: tkSQLs -> caseUnit?) ddl/db_test.go.6878: // Close issue #23321. (godoc-export: Close -> TestJsonUnmarshalErrWhenPanicInCancellingPath?) ddl/db_test.go.6896: // For Close issue #24288 (godoc-export: For -> TestDdlMaxLimitOfIdentifier?) ddl/db_test.go.6925: // Close issue #24580. (godoc-export: Close -> TestIssue24580?) ddl/ddl_algorithm.go.30: // If the alter algorithm is not given, the defAlgorithm will be used. (godoc-local: If -> defAlgorithm?) ddl/ddl_algorithm.go.30: // If the alter algorithm is not given, the defAlgorithm will be used. (godoc-local: If -> defAlgorithm?) ddl/delete_range.go.451: // getNowTS gets the current timestamp, in TSO. (godoc-local: getNowTS -> getNowTSO?) ddl/index.go.206: // Decimal using a binary format that packs nine decimal (base 10) digits into four bytes. (godoc-local: Decimal -> calcBytesLengthForDecimal?) ddl/index.go.825: // The following attributes are used to reduce memory allocation. (godoc-local: The -> defaultVals?) ddl/index.go.838: // The following attributes are used to reduce memory allocation. (godoc-local: The -> idxKeyBufs?) ddl/index.go.1364: // cleanupGlobalIndex handles the drop partition reorganization state to clean up index entries of partitions. (godoc-local: cleanupGlobalIndex -> cleanupGlobalIndexes?) ddl/reorg.go.71: // warnings is used to store the warnings when doing the reorg job under (godoc-local: warnings -> mu?) ddl/rollingback_test.go.35: // TestCancelJobMeetError is used to test canceling ddl job failure when convert ddl job to a rollingback job. (godoc-export: TestCancelJobMeetError -> TestCancelAddIndexJobError?) ddl/sequence.go.283: // Like setval does, restart sequence value won't affect current the step frequency. It will look backward for (godoc-local: Like -> restartSequenceValue?) ddl/sequence_test.go.839: // before this PR: (godoc-export: before -> BenchmarkInsertCacheDefaultExpr?) ddl/sequence_test.go.920: // Background: the newly added column in TiDB won't fill the known rows with specific (godoc-export: Background: -> TestSequenceDefaultLogic?) ddl/sequence_test.go.967: // Close issue #17945, sequence cache shouldn't be negative. (godoc-export: Close -> TestSequenceCacheShouldNotBeNegative?) ddl/serial_test.go.651: // TestCancelAddIndex1 tests canceling ddl job when the add index worker is not started. (godoc-export: TestCancelAddIndex1 -> TestCancelAddIndexPanic?) ddl/util/syncer.go.113: // for clean worker (godoc-local: for -> ownerChecker?) ddl/util/syncer.go.113: // for clean worker (godoc-local: for -> ownerChecker?) distsql/stream.go.43: // NOTE: curr == nil means stream finish, while len(curr.RowsData) == 0 doesn't. (godoc-local: NOTE: -> curr?) domain/domain_test.go.81: // ETCD use ip:port as unix socket address, however this address is invalid on windows. (godoc-local: ETCD -> unixSocketAvailable?) domain/infosync/info.go.112: // ServerID is a function, to always retrieve latest serverID from `Domain`, (godoc-export: ServerID -> ServerIDGetter?) domain/infosync/info.go.112: // ServerID is a function, to always retrieve latest serverID from `Domain`, (godoc-export: ServerID -> ServerIDGetter?) domain/infosync/info.go.180: // Init creates a new etcd session and stores server info to etcd. (godoc-local: Init -> init?) domain/infosync/info.go.180: // Init creates a new etcd session and stores server info to etcd. (godoc-local: Init -> init?) domain/infosync/info.go.638: // refreshTopology refreshes etcd topology with ttl stored in "/topology/tidb/ip:port/ttl". (godoc-local: refreshTopology -> updateTopologyAliveness?) domain/infosync/info.go.638: // refreshTopology refreshes etcd topology with ttl stored in "/topology/tidb/ip:port/ttl". (godoc-local: refreshTopology -> updateTopologyAliveness?) executor/admin.go.193: // below buf is used to reduce allocations. (godoc-local: below -> recoverRows?) executor/aggfuncs/aggfunc_test.go.541: // for multiple args in aggfuncs such as json_objectagg(c1, c2) (godoc-local: for -> buildMultiArgsAggTester?) executor/aggfuncs/aggfunc_test.go.541: // for multiple args in aggfuncs such as json_objectagg(c1, c2) (godoc-local: for -> buildMultiArgsAggTester?) executor/aggfuncs/aggfuncs.go.27: // All the AggFunc implementations for "COUNT" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.27: // All the AggFunc implementations for "COUNT" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.43: // All the AggFunc implementations for "APPROX_COUNT_DISTINCT" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.43: // All the AggFunc implementations for "APPROX_COUNT_DISTINCT" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.49: // All the AggFunc implementations for "APPROX_PERCENTILE" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.49: // All the AggFunc implementations for "APPROX_PERCENTILE" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.54: // All the AggFunc implementations for "FIRSTROW" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.54: // All the AggFunc implementations for "FIRSTROW" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.66: // All the AggFunc implementations for "MAX"/"MIN" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.66: // All the AggFunc implementations for "MAX"/"MIN" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.78: // All the AggFunc implementations for "AVG" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.78: // All the AggFunc implementations for "AVG" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.87: // All the AggFunc implementations for "SUM" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.87: // All the AggFunc implementations for "SUM" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.93: // All the AggFunc implementations for "GROUP_CONCAT" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.93: // All the AggFunc implementations for "GROUP_CONCAT" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.97: // All the AggFunc implementations for "BIT_OR" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.97: // All the AggFunc implementations for "BIT_OR" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.100: // All the AggFunc implementations for "BIT_XOR" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.100: // All the AggFunc implementations for "BIT_XOR" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.103: // All the AggFunc implementations for "BIT_AND" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.103: // All the AggFunc implementations for "BIT_AND" are listed here. (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.106: // All the AggFunc implementations for "JSON_OBJECTAGG" are listed here (godoc-export: All -> _?) executor/aggfuncs/aggfuncs.go.106: // All the AggFunc implementations for "JSON_OBJECTAGG" are listed here (godoc-export: All -> _?) executor/aggfuncs/builder.go.443: // buildMaxMin builds the AggFunc implementation for function "MAX" and "MIN" using by window function. (godoc-local: buildMaxMin -> buildMaxMinInWindowFunction?) executor/aggfuncs/builder.go.443: // buildMaxMin builds the AggFunc implementation for function "MAX" and "MIN" using by window function. (godoc-local: buildMaxMin -> buildMaxMinInWindowFunction?) executor/aggfuncs/func_avg.go.37: // All the following avg function implementations return the decimal result, (godoc-local: All -> baseAvgDecimal?) executor/aggfuncs/func_avg.go.37: // All the following avg function implementations return the decimal result, (godoc-local: All -> baseAvgDecimal?) executor/aggfuncs/func_avg.go.270: // All the following avg function implementations return the float64 result, (godoc-local: All -> baseAvgFloat64?) executor/aggfuncs/func_avg.go.270: // All the following avg function implementations return the float64 result, (godoc-local: All -> baseAvgFloat64?) executor/aggfuncs/func_count_distinct.go.480: // The maximum degree of buffer size before the values are discarded (godoc-local: The -> uniquesHashMaxSizeDegree?) executor/aggfuncs/func_count_distinct.go.480: // The maximum degree of buffer size before the values are discarded (godoc-local: The -> uniquesHashMaxSizeDegree?) executor/aggfuncs/func_count_distinct.go.484: // Initial buffer size degree (godoc-local: Initial -> uniquesHashSetInitialSizeDegree?) executor/aggfuncs/func_count_distinct.go.484: // Initial buffer size degree (godoc-local: Initial -> uniquesHashSetInitialSizeDegree?) executor/aggfuncs/func_count_distinct.go.558: // Increase the size of the buffer 2 times or up to new size degree. (godoc-local: Increase -> resize?) executor/aggfuncs/func_count_distinct.go.558: // Increase the size of the buffer 2 times or up to new size degree. (godoc-local: Increase -> resize?) executor/aggfuncs/func_count_distinct.go.612: // Correct system errors due to collisions during hashing in uint32. (godoc-local: Correct -> fixedSize?) executor/aggfuncs/func_count_distinct.go.612: // Correct system errors due to collisions during hashing in uint32. (godoc-local: Correct -> fixedSize?) executor/aggfuncs/func_count_distinct.go.638: // The value is divided by 2 ^ skip_degree (godoc-local: The -> good?) executor/aggfuncs/func_count_distinct.go.638: // The value is divided by 2 ^ skip_degree (godoc-local: The -> good?) executor/aggfuncs/func_count_distinct.go.643: // Insert a value (godoc-local: Insert -> insertImpl?) executor/aggfuncs/func_count_distinct.go.643: // Insert a value (godoc-local: Insert -> insertImpl?) executor/aggfuncs/func_count_distinct.go.667: // If the hash table is full enough, then do resize. (godoc-local: If -> shrinkIfNeed?) executor/aggfuncs/func_count_distinct.go.667: // If the hash table is full enough, then do resize. (godoc-local: If -> shrinkIfNeed?) executor/aggfuncs/func_count_distinct.go.686: // Delete all values whose hashes do not divide by 2 ^ skip_degree (godoc-local: Delete -> rehash?) executor/aggfuncs/func_count_distinct.go.686: // Delete all values whose hashes do not divide by 2 ^ skip_degree (godoc-local: Delete -> rehash?) executor/aggfuncs/func_count_distinct.go.704: // Insert a value into the new buffer that was in the old buffer. (godoc-local: Insert -> reinsertImpl?) executor/aggfuncs/func_count_distinct.go.704: // Insert a value into the new buffer that was in the old buffer. (godoc-local: Insert -> reinsertImpl?) executor/aggfuncs/func_first_row.go.49: // nolint:structcheck (godoc-local: nolint:structcheck -> basePartialResult4FirstRow?) executor/aggfuncs/func_first_row.go.49: // nolint:structcheck (godoc-local: nolint:structcheck -> basePartialResult4FirstRow?) executor/aggfuncs/func_group_concat.go.57: // According to MySQL, a 'group_concat' function generates exactly one 'truncated' warning during its life time, no matter (godoc-local: According -> truncated?) executor/aggfuncs/func_group_concat.go.57: // According to MySQL, a 'group_concat' function generates exactly one 'truncated' warning during its life time, no matter (godoc-local: According -> truncated?) executor/aggfuncs/func_group_concat.go.91: // nolint:structcheck (godoc-local: nolint:structcheck -> basePartialResult4GroupConcat?) executor/aggfuncs/func_group_concat.go.91: // nolint:structcheck (godoc-local: nolint:structcheck -> basePartialResult4GroupConcat?) executor/aggfuncs/func_group_concat.go.285: // If sep is truncated, we need to append part of sep to result. (godoc-local: If -> isSepTruncated?) executor/aggfuncs/func_group_concat.go.285: // If sep is truncated, we need to append part of sep to result. (godoc-local: If -> isSepTruncated?) executor/aggfuncs/func_group_concat.go.285: // If sep is truncated, we need to append part of sep to result. (godoc-local: If -> isSepTruncated?) executor/aggfuncs/func_group_concat.go.285: // If sep is truncated, we need to append part of sep to result. (godoc-local: If -> isSepTruncated?) executor/aggfuncs/func_percentile.go.93: // TODO: use []*types.MyDecimal to prevent massive value copy (godoc-local: TODO: -> partialResult4PercentileDecimal?) executor/aggfuncs/func_percentile.go.93: // TODO: use []*types.MyDecimal to prevent massive value copy (godoc-local: TODO: -> partialResult4PercentileDecimal?) executor/aggregate.go.187: // After we support parallel execution for aggregation functions with distinct, (godoc-local: After -> isUnparallelExec?) executor/aggregate.go.812: // HashAggExec employs one input reader, M partial workers and N final workers to execute parallelly. (godoc-local: HashAggExec -> parallelExec?) executor/aggregate.go.1301: // set these functions for testing (godoc-local: set -> allocateBuffer?) executor/aggregate_test.go.1454: // https://github.com/pingcap/tidb/issues/23314 (godoc-export: https://github.com/pingcap/tidb/issues/23314 -> TestIssue23314?) executor/analyze.go.115: // When the `isIndex == 0`, the idxID will be the column ID. (godoc-local: When -> idxID?) executor/analyze.go.115: // When the `isIndex == 0`, the idxID will be the column ID. (godoc-local: When -> idxID?) executor/analyze.go.1054: // subIndexWorker receive the task for each index and return the result for them. (godoc-local: subIndexWorker -> subIndexWorkerForNDV?) executor/analyze_test.go.609: // nolint:unused (godoc-local: nolint:unused -> testAnalyzeIncremental?) executor/batch_point_get.go.169: // Global temporary table would always be empty, so get the snapshot data of it is meanless. (godoc-local: Global -> globalTemporaryTableSnapshot?) executor/brie.go.395: // BootstrapSession implements glue.Glue (godoc-export: BootstrapSession -> GetDomain?) executor/builder.go.1406: // `getSnapshotTS` returns the timestamp of the snapshot that a reader should read. (godoc-local: `getSnapshotTS` -> getSnapshotTS?) executor/builder.go.2972: // check whether can runtime prune. (godoc-local: check -> partitionExpr?) executor/concurrent_map.go.23: // A "thread" safe map of type string:Anything. (godoc-local: A -> concurrentMap?) executor/concurrent_map.go.27: // A "thread" safe string to anything map. (godoc-local: A -> concurrentMapShared?) executor/concurrent_map.go.67: // Upsert: Insert or Update - updates existing element or inserts a new one using UpsertCb (godoc-export: Upsert: -> Upsert?) executor/cte.go.65: // `resTbl` and `iterInTbl` are shared by all CTEExec which reference to same the CTE. (godoc-local: `resTbl` -> resTbl?) executor/cte.go.65: // `resTbl` and `iterInTbl` are shared by all CTEExec which reference to same the CTE. (godoc-local: `resTbl` -> resTbl?) executor/cte.go.73: // Index of chunk to read from `resTbl`. (godoc-local: Index -> chkIdx?) executor/cte.go.73: // Index of chunk to read from `resTbl`. (godoc-local: Index -> chkIdx?) executor/cte.go.76: // UNION ALL or UNION DISTINCT. (godoc-local: UNION -> isDistinct?) executor/cte.go.76: // UNION ALL or UNION DISTINCT. (godoc-local: UNION -> isDistinct?) executor/cte.go.82: // Limit related info. (godoc-local: Limit -> hasLimit?) executor/cte.go.82: // Limit related info. (godoc-local: Limit -> hasLimit?) executor/cte.go.300: // Get next chunk from resTbl for limit. (godoc-local: Get -> nextChunkLimit?) executor/cte.go.405: // Check if tbl meets the requirement of limit. (godoc-local: Check -> limitDone?) executor/cte.go.443: // Compute hash values in chk and put it in hCtx.hashVals. (godoc-local: Compute -> computeChunkHash?) executor/cte.go.475: // Use hashTbl to deduplicate rows, and unique rows will be added to hashTbl. (godoc-local: Use -> deduplicate?) executor/cte.go.541: // Use the row's probe key to check if it already exists in chk or storage. (godoc-local: Use -> checkHasDup?) executor/ddl_test.go.1072: // Test filter different kind of allocators. (godoc-export: Test -> TestFilterDifferentAllocators?) executor/ddl_test.go.1325: // Test issue #9205, fix the precision problem for time type default values (godoc-export: Test -> TestIssue9205?) executor/ddl_test.go.1414: // this test will change the fail-point `mockAutoIDChange`, so we move it to the `testRecoverTable` suite (godoc-export: this -> TestRenameTable?) executor/distsql.go.159: // For a partitioned table, the IndexReaderExecutor works on a partition, so (godoc-local: For -> table?) executor/distsql.go.159: // For a partitioned table, the IndexReaderExecutor works on a partition, so (godoc-local: For -> table?) executor/distsql.go.330: // fields about accessing partition tables (godoc-local: fields -> partitionTableMode?) executor/distsql.go.330: // fields about accessing partition tables (godoc-local: fields -> partitionTableMode?) executor/distsql.go.384: // nolint:structcheck (godoc-local: nolint:structcheck -> checkIndexValue?) executor/distsql_test.go.39: // nolint:unused (godoc-local: nolint:unused -> checkGoroutineExists?) executor/executor.go.895: // All the partition tables in the children of this executor. (godoc-local: All -> partitionedTable?) executor/executor.go.898: // When SelectLock work on the partition table, we need the partition ID (godoc-local: When -> tblID2PIDColumnIndex?) executor/executor_pkg_test.go.462: // Test whether the actual buckets in Golang Map is same with the estimated number. (godoc-export: Test -> TestAggPartialResultMapperB?) executor/executor_pkg_test.go.528: // A header for a Go map. (godoc-local: A -> hmap?) executor/executor_pkg_test.go.531: // Note: the format of the hmap is also encoded in cmd/compile/internal/gc/reflect.go. (godoc-local: Note: -> count?) executor/executor_pkg_test.go.531: // Note: the format of the hmap is also encoded in cmd/compile/internal/gc/reflect.go. (godoc-local: Note: -> count?) executor/executor_test.go.1260: // issue-23038: wrong key range of index scan for year column (godoc-export: issue-23038: -> TestIndexScanWithYearCol?) executor/executor_test.go.2133: // TestGeneratedColumnRead tests generated columns using point get and batch point get (godoc-export: TestGeneratedColumnRead -> TestGeneratedColumnPointGet?) executor/executor_test.go.6788: // this is from jira issue #5856 (godoc-export: this -> TestInsertValuesWithSubQuery?) executor/executor_test.go.7001: // For issue 17256 (godoc-export: For -> TestGenerateColumnReplace?) executor/executor_test.go.7745: // https://github.com/pingcap/tidb/issues/24165. (godoc-export: https://github.com/pingcap/tidb/issues/24165. -> TestInvalidDateValueInCreateTable?) executor/explain_unit_test.go.62: // close() must be called after next() to avoid goroutines leak (godoc-export: close() -> TestExplainAnalyzeInvokeNextAndClose?) executor/explainfor_test.go.37: // mockSessionManager is a mocked session manager which is used for test. (godoc-local: mockSessionManager -> mockSessionManager1?) executor/hash_table.go.265: // TODO (fangzhuhe) remove unsafeHashTable later if it not used anymore (godoc-local: TODO -> unsafeHashTable?) executor/index_lookup_hash_join.go.63: // We build individual joiner for each inner worker when using chunk-based (godoc-local: We -> joiners?) executor/index_merge_reader.go.82: // fields about accessing partition tables (godoc-local: fields -> partitionTableMode?) executor/index_merge_reader.go.82: // fields about accessing partition tables (godoc-local: fields -> partitionTableMode?) executor/index_merge_reader_test.go.70: // issue 25045 (godoc-export: issue -> TestIndexMergeReaderIssue25045?) executor/infoschema_reader_test.go.235: // https://github.com/pingcap/tidb/issues/25467. (godoc-export: https://github.com/pingcap/tidb/issues/25467. -> TestDataTypesMaxLengthAndOctLength?) executor/insert_common.go.78: // Fill the autoID lazily to datum. This is used for being compatible with JDBC using getGeneratedKeys(). (godoc-local: Fill -> lazyFillAutoID?) executor/insert_common.go.78: // Fill the autoID lazily to datum. This is used for being compatible with JDBC using getGeneratedKeys(). (godoc-local: Fill -> lazyFillAutoID?) executor/insert_common.go.89: // LoadData use two goroutines. One for generate batch data, (godoc-local: LoadData -> isLoadData?) executor/insert_common.go.89: // LoadData use two goroutines. One for generate batch data, (godoc-local: LoadData -> isLoadData?) executor/insert_test.go.1074: // There is a potential issue in MySQL: when the value of auto_increment_offset is greater (godoc-export: There -> TestAutoIDIncrementAndOffset?) executor/insert_test.go.1574: // See https://github.com/pingcap/tidb/issues/24582 (godoc-export: See -> TestDuplicatedEntryErr?) executor/inspection_result.go.43: // represents the diagnostics item, e.g: `ddl.lease` `raftstore.cpuusage` (godoc-local: represents -> item?) executor/inspection_result.go.45: // diagnosis result value base on current cluster status (godoc-local: diagnosis -> actual?) executor/join.go.362: // Concurrently handling unmatched rows from the hash table (godoc-local: Concurrently -> handleUnmatchedRowsFromHashTable?) executor/join_test.go.2281: // test hash join when enum column got invalid value (godoc-export: test -> TestInvalidEnumVal?) executor/joiner.go.219: // lUsed/rUsed show which columns are used by father for left child and right child. (godoc-local: lUsed/rUsed -> lUsed?) executor/mem_reader.go.156: // cache for decode handle. (godoc-local: cache -> handleBytes?) executor/mem_reader.go.199: // TODO: Try to make memXXXReader lazy, There is no need to decode many rows when parent operator only need 1 row. (godoc-local: TODO: -> getMemRows?) executor/mem_reader.go.383: // partition mode (godoc-local: partition -> partitionMode?) executor/mem_reader.go.383: // partition mode (godoc-local: partition -> partitionMode?) executor/memory_test.go.107: // nolint:unused (godoc-local: nolint:unused -> readMem?) executor/memory_test.go.114: // nolint:unused (godoc-local: nolint:unused -> memDiff?) executor/memtable_reader.go.449: // Read the next stream result while current messages is drained (godoc-local: Read -> next?) executor/merge_join.go.67: // for inner table, an unbroken group may refer many chunks (godoc-local: for -> rowContainer?) executor/merge_join.go.70: // for outer table, save result of filters (godoc-local: for -> filtersSelected?) executor/mpp_gather.go.42: // following fields are construct needed (godoc-local: following -> baseExecutor?) executor/parallel_apply.go.48: // outer-side fields (godoc-local: outer-side -> outerExec?) executor/parallel_apply.go.48: // outer-side fields (godoc-local: outer-side -> outerExec?) executor/parallel_apply.go.54: // inner-side fields (godoc-local: inner-side -> corCols?) executor/parallel_apply.go.68: // fields about concurrency control (godoc-local: fields -> concurrency?) executor/parallel_apply.go.68: // fields about concurrency control (godoc-local: fields -> concurrency?) executor/pipelined_window.go.59: // curStartRow and curEndRow defines the current frame range (godoc-local: curStartRow -> lastStartRow?) executor/pipelined_window.go.59: // curStartRow and curEndRow defines the current frame range (godoc-local: curStartRow -> lastStartRow?) executor/point_get_test.go.143: // Close issue #22839 (godoc-export: Close -> TestPointGetDataTooLong?) executor/point_get_test.go.162: // issue #25489 (godoc-export: issue -> TestIssue25489?) executor/point_get_test.go.211: // issue #25320 (godoc-export: issue -> TestDistinctPlan?) executor/prepared_test.go.49: // a 'create table' DDL statement should be accepted if it has no parameters. (godoc-export: a -> TestPreparedDDL?) executor/revoke.go.125: // Checks that dynamic privileges are only of global scope. (godoc-local: Checks -> checkDynamicPrivilegeUsage?) executor/rowid_test.go.92: // Test for https://github.com/pingcap/tidb/issues/22029. (godoc-export: Test -> TestExplicitInsertRowID?) executor/seqtest/prepared_test.go.797: // mockSessionManager is a mocked session manager which is used for test. (godoc-local: mockSessionManager -> mockSessionManager1?) executor/seqtest/prepared_test.go.797: // mockSessionManager is a mocked session manager which is used for test. (godoc-local: mockSessionManager -> mockSessionManager1?) executor/shuffle.go.84: // each dataSource has a corresponding spliter (godoc-local: each -> splitters?) executor/shuffle.go.442: // This method is supposed to be used for shuffle with sorted `dataSource` (godoc-local: This -> split?) executor/simple.go.1033: // Should cover same internal mysql.* tables as DROP USER, so this function is very similar (godoc-local: Should -> executeRenameUser?) executor/simple.go.1316: // use the same internal executor to read within the same transaction, otherwise same as userExists (godoc-local: use -> userExistsInternal?) executor/simple.go.1586: // #14239 - https://github.com/pingcap/tidb/issues/14239 (godoc-local: #14239 -> asyncDelayShutdown?) executor/simple_test.go.880: // Close issue #23649. (godoc-export: Close -> TestIssue23649?) executor/slow_query.go.226: // Below fields is used to check privilege. (godoc-local: Below -> hasProcessPriv?) executor/slow_query.go.226: // Below fields is used to check privilege. (godoc-local: Below -> hasProcessPriv?) executor/slow_query.go.229: // Below fields is used to check slow log time valid. (godoc-local: Below -> enableTimeCheck?) executor/slow_query.go.229: // Below fields is used to check slow log time valid. (godoc-local: Below -> enableTimeCheck?) executor/slow_query.go.1193: // Read lines from the end of a file (godoc-local: Read -> readLastLines?) executor/slow_query_test.go.218: // It changes variable.MaxOfMaxAllowedPacket, so must be stayed in SerialSuite. (godoc-export: It -> TestParseSlowLogFileSerial?) executor/sort.go.307: // rowPointer store the chunk index and row index for each row. (godoc-local: rowPointer -> rowPtrs?) executor/split.go.59: // nolint:structcheck (godoc-local: nolint:structcheck -> splitRegionResult?) executor/split.go.610: // RegionMeta contains a region's peer detail (godoc-local: RegionMeta -> regionMeta?) executor/stale_txn_test.go.121: // IsStaleness is auto cleanup in select stmt. (godoc-local: IsStaleness -> errorStr?) executor/table_reader.go.67: // The source of key ranges varies from case to case. (godoc-local: The -> kvRangeBuilder?) executor/table_reader.go.73: // TODO: remove this field, use the kvRangeBuilder interface. (godoc-local: TODO: -> ranges?) executor/table_reader.go.397: // If the pk is unsigned and we have KeepOrder=true and want ascending order, (godoc-local: If -> optionalResult?) executor/table_reader.go.397: // If the pk is unsigned and we have KeepOrder=true and want ascending order, (godoc-local: If -> optionalResult?) executor/tiflash_test.go.549: // all goroutines exit if one goroutine hangs but another return errors (godoc-export: all -> TestMppGoroutinesExitFromErrors?) executor/union_scan_test.go.369: // See https://github.com/pingcap/tidb/issues/19136 (godoc-export: See -> TestForApplyAndUnionScan?) executor/write_test.go.3657: // TestWriteListColumnsPartitionTable2 test for write list partition when the partition by multi-columns. (godoc-export: TestWriteListColumnsPartitionTable2 -> TestWriteListPartitionTableIssue21437?) expression/bench_test.go.608: // ipv4Compat is used to generate ipv4 compatible ipv6 strings (godoc-local: ipv4Compat -> ipv4CompatByteGener?) expression/bench_test.go.975: // aesModeAttr information, needed by encryption functions (godoc-local: aesModeAttr -> aesModes?) expression/bench_test.go.975: // aesModeAttr information, needed by encryption functions (godoc-local: aesModeAttr -> aesModes?) expression/bench_test.go.1277: // a hack way to calculate length of a chunk.Column. (godoc-local: a -> getColumnLen?) expression/builtin_arithmetic.go.439: // returns true when overflowed (godoc-local: returns -> overflowCheck?) expression/builtin_cast_test.go.1421: // for issue https://github.com/pingcap/tidb/issues/16825 (godoc-export: for -> TestCastStringAsDecimalSigWithUnsignedFlagInUnion?) expression/builtin_cast_vec_test.go.200: // for issue https://github.com/pingcap/tidb/issues/16825 (godoc-export: for -> TestVectorizedCastStringAsDecimalWithUnsignedFlagInUnion?) expression/builtin_compare.go.842: // timeRes will be converted to a strRes only when the arguments is a valid datetime value. (godoc-local: timeRes -> strRes?) expression/builtin_compare_test.go.261: // greatest/least function is compatible with MySQL 8.0 (godoc-export: greatest/least -> TestGreatestLeastFunc?) expression/builtin_compare_vec_generated.go.1760: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalInt?) expression/builtin_compare_vec_generated.go.1817: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalReal?) expression/builtin_compare_vec_generated.go.1874: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalDecimal?) expression/builtin_compare_vec_generated.go.1931: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalString?) expression/builtin_compare_vec_generated.go.1994: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalTime?) expression/builtin_compare_vec_generated.go.2051: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalDuration?) expression/builtin_compare_vec_generated.go.2108: // NOTE: Coalesce just return the first non-null item, but vectorization do each item, which would incur additional errors. If this case happen, (godoc-local: NOTE: -> fallbackEvalJSON?) expression/builtin_encryption_vec.go.108: // evalString evals AES_ENCRYPT(str, key_str, iv). (godoc-local: evalString -> vecEvalString?) expression/builtin_encryption_vec.go.281: // evalString evals AES_DECRYPT(crypt_str, key_key, iv). (godoc-local: evalString -> vecEvalString?) expression/builtin_encryption_vec.go.544: // evalString evals COMPRESS(str). (godoc-local: evalString -> vecEvalString?) expression/builtin_encryption_vec.go.605: // evalString evals AES_ENCRYPT(str, key_str). (godoc-local: evalString -> vecEvalString?) expression/builtin_encryption_vec.go.738: // evalString evals UNCOMPRESS(compressed_string). (godoc-local: evalString -> vecEvalString?) expression/builtin_info.go.750: // evalInt evals a builtinTiDBIsDDLOwnerSig. (godoc-local: evalInt -> evalString?) expression/builtin_info.go.766: // String() implements Stringer. (godoc-export: String() -> String?) expression/builtin_info.go.1007: // formatBytes evals a builtinFormatBytesSig. (godoc-local: formatBytes -> evalString?) expression/builtin_info.go.1044: // formatNanoTime evals a builtinFormatNanoTimeSig, as time unit in TiDB is always nanosecond, not picosecond. (godoc-local: formatNanoTime -> evalString?) expression/builtin_info_vec.go.32: // evalString evals a builtinDatabaseSig. (godoc-local: evalString -> vecEvalString?) expression/builtin_info_vec.go.88: // evalInt evals ROW_COUNT(). (godoc-local: evalInt -> vecEvalInt?) expression/builtin_info_vec.go.105: // evalString evals a builtinCurrentUserSig. (godoc-local: evalString -> vecEvalString?) expression/builtin_info_vec.go.125: // evalString evals a builtinCurrentUserSig. (godoc-local: evalString -> vecEvalString?) expression/builtin_info_vec.go.159: // evalString evals a builtinUserSig. (godoc-local: evalString -> vecEvalString?) expression/builtin_miscellaneous_vec.go.204: // See https://dev.mysql.com/doc/refman/5.7/en/miscellaneous-functions.html#function_get-lock (godoc-local: See -> vecEvalInt?) expression/builtin_miscellaneous_vec.go.609: // See https://dev.mysql.com/doc/refman/5.7/en/miscellaneous-functions.html#function_release-lock (godoc-local: See -> vecEvalInt?) expression/builtin_miscellaneous_vec.go.661: // evalString evals UUID_TO_BIN(string_uuid, swap_flag). (godoc-local: evalString -> vecEvalString?) expression/builtin_miscellaneous_vec.go.719: // evalString evals BIN_TO_UUID(binary_uuid, swap_flag). (godoc-local: evalString -> vecEvalString?) expression/builtin_other.go.158: // nolint:structcheck (godoc-local: nolint:structcheck -> baseInSig?) expression/builtin_other.go.170: // the bool value in the map is used to identify whether the constant stored in key is signed or unsigned (godoc-local: the -> hashSet?) expression/builtin_time.go.7199: // For a SafeTS t and a time range [t1, t2]: (godoc-local: For -> calAppropriateTime?) expression/constant_propagation.go.31: // nolint:structcheck (godoc-local: nolint:structcheck -> basePropConstSolver?) expression/generator/compare_vec.go.348: // Describe the name of CompareContext(LT/LE/GT/GE/EQ/NE/NullEQ) (godoc-export: Describe -> CompareName?) expression/generator/compare_vec.go.348: // Describe the name of CompareContext(LT/LE/GT/GE/EQ/NE/NullEQ) (godoc-export: Describe -> CompareName?) expression/generator/compare_vec.go.350: // Compare Operators (godoc-export: Compare -> Operator?) expression/generator/compare_vec.go.350: // Compare Operators (godoc-export: Compare -> Operator?) expression/generator/control_vec.go.559: // Describe the name of "github.com/pingcap/tidb/types".ET{{ .ETName }} (godoc-export: Describe -> ETName?) expression/generator/control_vec.go.559: // Describe the name of "github.com/pingcap/tidb/types".ET{{ .ETName }} (godoc-export: Describe -> ETName?) expression/generator/control_vec.go.561: // Describe the name of "github.com/pingcap/tidb/expression".VecExpr.VecEval{{ .TypeName }} (godoc-export: Describe -> TypeName?) expression/generator/control_vec.go.561: // Describe the name of "github.com/pingcap/tidb/expression".VecExpr.VecEval{{ .TypeName }} (godoc-export: Describe -> TypeName?) expression/generator/control_vec.go.564: // Describe the name of "github.com/pingcap/tidb/util/chunk".*Column.Append{{ .TypeNameInColumn }}, (godoc-export: Describe -> TypeNameInColumn?) expression/generator/control_vec.go.564: // Describe the name of "github.com/pingcap/tidb/util/chunk".*Column.Append{{ .TypeNameInColumn }}, (godoc-export: Describe -> TypeNameInColumn?) expression/generator/control_vec.go.569: // Same as "github.com/pingcap/tidb/util/chunk".getFixedLen() (godoc-export: Same -> Fixed?) expression/generator/control_vec.go.569: // Same as "github.com/pingcap/tidb/util/chunk".getFixedLen() (godoc-export: Same -> Fixed?) expression/generator/helper/helper.go.18: // Describe the name of "github.com/pingcap/tidb/types".ET{{ .ETName }} . (godoc-export: Describe -> ETName?) expression/generator/helper/helper.go.18: // Describe the name of "github.com/pingcap/tidb/types".ET{{ .ETName }} . (godoc-export: Describe -> ETName?) expression/generator/helper/helper.go.18: // Describe the name of "github.com/pingcap/tidb/types".ET{{ .ETName }} . (godoc-export: Describe -> ETName?) expression/generator/helper/helper.go.18: // Describe the name of "github.com/pingcap/tidb/types".ET{{ .ETName }} . (godoc-export: Describe -> ETName?) expression/generator/helper/helper.go.20: // Describe the name of "github.com/pingcap/tidb/expression".VecExpr.VecEval{{ .TypeName }} . (godoc-export: Describe -> TypeName?) expression/generator/helper/helper.go.20: // Describe the name of "github.com/pingcap/tidb/expression".VecExpr.VecEval{{ .TypeName }} . (godoc-export: Describe -> TypeName?) expression/generator/helper/helper.go.20: // Describe the name of "github.com/pingcap/tidb/expression".VecExpr.VecEval{{ .TypeName }} . (godoc-export: Describe -> TypeName?) expression/generator/helper/helper.go.20: // Describe the name of "github.com/pingcap/tidb/expression".VecExpr.VecEval{{ .TypeName }} . (godoc-export: Describe -> TypeName?) expression/generator/helper/helper.go.22: // Describe the name of "github.com/pingcap/tidb/util/chunk".*Column.Append{{ .TypeNameInColumn }}, (godoc-export: Describe -> TypeNameInColumn?) expression/generator/helper/helper.go.22: // Describe the name of "github.com/pingcap/tidb/util/chunk".*Column.Append{{ .TypeNameInColumn }}, (godoc-export: Describe -> TypeNameInColumn?) expression/generator/helper/helper.go.22: // Describe the name of "github.com/pingcap/tidb/util/chunk".*Column.Append{{ .TypeNameInColumn }}, (godoc-export: Describe -> TypeNameInColumn?) expression/generator/helper/helper.go.22: // Describe the name of "github.com/pingcap/tidb/util/chunk".*Column.Append{{ .TypeNameInColumn }}, (godoc-export: Describe -> TypeNameInColumn?) expression/generator/helper/helper.go.27: // Describe the type name in golang. (godoc-export: Describe -> TypeNameGo?) expression/generator/helper/helper.go.27: // Describe the type name in golang. (godoc-export: Describe -> TypeNameGo?) expression/generator/helper/helper.go.27: // Describe the type name in golang. (godoc-export: Describe -> TypeNameGo?) expression/generator/helper/helper.go.27: // Describe the type name in golang. (godoc-export: Describe -> TypeNameGo?) expression/generator/helper/helper.go.29: // Same as "github.com/pingcap/tidb/util/chunk".getFixedLen() . (godoc-export: Same -> Fixed?) expression/generator/helper/helper.go.29: // Same as "github.com/pingcap/tidb/util/chunk".getFixedLen() . (godoc-export: Same -> Fixed?) expression/generator/helper/helper.go.29: // Same as "github.com/pingcap/tidb/util/chunk".getFixedLen() . (godoc-export: Same -> Fixed?) expression/generator/helper/helper.go.29: // Same as "github.com/pingcap/tidb/util/chunk".getFixedLen() . (godoc-export: Same -> Fixed?) expression/helper.go.133: // if timestamp session variable set, use session variable as current time, otherwise use cached time (godoc-local: if -> getStmtTimestamp?) expression/integration_test.go.3965: // #23157: make sure if Nullif expr is correct combined with IsNull expr. (godoc-export: #23157: -> TestNullifWithIsNull?) expression/integration_test.go.7985: // issues 14448, 19383, 17734 (godoc-export: issues -> TestNoopFunctions?) expression/integration_test.go.8813: // The actual results do not agree with the test results, It should be modified after the test suite is updated (godoc-export: The -> TestIssue17726?) expression/integration_test.go.8847: // for issue 20128 (godoc-export: for -> TestIssue20128?) expression/integration_test.go.9651: // Previously global values were cached. This is incorrect. (godoc-export: Previously -> TestGlobalCacheCorrectness?) infoschema/builder.go.40: // TODO: store is only used by autoid allocators (godoc-local: TODO: -> store?) infoschema/builder.go.40: // TODO: store is only used by autoid allocators (godoc-local: TODO: -> store?) infoschema/cache.go.40: // record SnapshotTS of the latest schema Insert. (godoc-local: record -> maxUpdatedSnapshotTS?) infoschema/cache.go.40: // record SnapshotTS of the latest schema Insert. (godoc-local: record -> maxUpdatedSnapshotTS?) infoschema/infoschema.go.92: // ruleBundleMap stores all placement rules (godoc-local: ruleBundleMap -> ruleBundleMutex?) infoschema/infoschema.go.92: // ruleBundleMap stores all placement rules (godoc-local: ruleBundleMap -> ruleBundleMutex?) infoschema/tables_test.go.968: // Test statements_summary. (godoc-export: Test -> TestStmtSummaryTable?) infoschema/tables_test.go.1220: // Test statements_summary_history. (godoc-export: Test -> TestStmtSummaryHistoryTable?) infoschema/tables_test.go.1271: // Test statements_summary_history. (godoc-export: Test -> TestStmtSummaryInternalQuery?) infoschema/tables_test.go.1322: // Test error count and warning count. (godoc-export: Test -> TestStmtSummaryErrorCount?) infoschema/tables_test.go.1384: // test stmtSummaryEvictedCount (godoc-export: test -> TestSimpleStmtSummaryEvictedCount?) infoschema/tables_test.go.1413: // test stmtSummaryEvictedCount cluster table (godoc-export: test -> TestStmtSummaryEvictedCountTable?) kv/cachedb.go.41: // Set set the key/value in cacheDB. (godoc-local: Set -> set?) kv/cachedb.go.53: // Get gets the value from cacheDB. (godoc-local: Get -> get?) kv/kv.go.259: // memTracker is used to trace and control memory usage in co-processor layer. (godoc-export: memTracker -> MemTracker?) kv/kv.go.278: // SchemaVer is for any schema-ful storage to validate schema correctness if necessary. (godoc-export: SchemaVer -> SchemaVar?) kv/kv.go.278: // SchemaVer is for any schema-ful storage to validate schema correctness if necessary. (godoc-export: SchemaVer -> SchemaVar?) kv/mpp.go.48: //MppTaskStates denotes the state of mpp tasks (godoc-export: denotes -> MppTaskStates?) meta/autoid/autoid.go.419: // Rebase implements autoid.Allocator RebaseSeq interface. (godoc-export: Rebase -> RebaseSeq?) meta/autoid/autoid.go.419: // Rebase implements autoid.Allocator RebaseSeq interface. (godoc-export: Rebase -> RebaseSeq?) meta/autoid/autoid.go.1009: // Derived fields. (godoc-export: Derived -> TypeBitsLength?) meta/autoid/autoid.go.1009: // Derived fields. (godoc-export: Derived -> TypeBitsLength?) meta/autoid/autoid.go.1009: // Derived fields. (godoc-export: Derived -> TypeBitsLength?) meta/autoid/autoid.go.1009: // Derived fields. (godoc-export: Derived -> TypeBitsLength?) meta/autoid/autoid_test.go.869: // Fix a computation logic bug in allocator computation. (godoc-export: Fix -> TestAllocComputationIssue?) meta/autoid/autoid_test.go.869: // Fix a computation logic bug in allocator computation. (godoc-export: Fix -> TestAllocComputationIssue?) owner/fail_test.go.36: // Ignore this test on the windows platform, because calling unix socket with address in (godoc-export: Ignore -> TestT?) planner/cascades/transformation_rules.go.1885: // check whether one of unique keys sets is contained by inner join keys. (godoc-local: check -> isInnerJoinKeysContainUniqueKey?) planner/cascades/transformation_rules.go.1885: // check whether one of unique keys sets is contained by inner join keys. (godoc-local: check -> isInnerJoinKeysContainUniqueKey?) planner/cascades/transformation_rules.go.2132: // TransformAggregateCaseToSelection only support `case when cond then var end` and `case when cond then var1 else var2 end`. (godoc-local: TransformAggregateCaseToSelection -> isTwoOrThreeArgCase?) planner/cascades/transformation_rules.go.2132: // TransformAggregateCaseToSelection only support `case when cond then var end` and `case when cond then var1 else var2 end`. (godoc-local: TransformAggregateCaseToSelection -> isTwoOrThreeArgCase?) planner/core/common_plans.go.197: // Check if result of GetVar expr is BinaryLiteral (godoc-local: Check -> isGetVarBinaryLiteral?) planner/core/common_plans.go.197: // Check if result of GetVar expr is BinaryLiteral (godoc-local: Check -> isGetVarBinaryLiteral?) planner/core/common_plans.go.856: // Used when partition sets are given. (godoc-export: Used -> PartitionedTable?) planner/core/common_plans.go.856: // Used when partition sets are given. (godoc-export: Used -> PartitionedTable?) planner/core/enforce_mpp_test.go.127: // general cases. (godoc-export: general -> TestEnforceMPPWarning1?) planner/core/enforce_mpp_test.go.127: // general cases. (godoc-export: general -> TestEnforceMPPWarning1?) planner/core/enforce_mpp_test.go.195: // partition table. (godoc-export: partition -> TestEnforceMPPWarning2?) planner/core/enforce_mpp_test.go.195: // partition table. (godoc-export: partition -> TestEnforceMPPWarning2?) planner/core/enforce_mpp_test.go.244: // new collation. (godoc-export: new -> TestEnforceMPPWarning3?) planner/core/enforce_mpp_test.go.244: // new collation. (godoc-export: new -> TestEnforceMPPWarning3?) planner/core/exhaust_physical_plans.go.109: // Only if the input required prop is the prefix fo join keys, we can pass through this property. (godoc-local: Only -> tryToGetChildReqProp?) planner/core/exhaust_physical_plans.go.109: // Only if the input required prop is the prefix fo join keys, we can pass through this property. (godoc-local: Only -> tryToGetChildReqProp?) planner/core/exhaust_physical_plans.go.233: // Change JoinKeys order, by offsets array (godoc-local: Change -> getNewJoinKeysByOffsets?) planner/core/exhaust_physical_plans.go.233: // Change JoinKeys order, by offsets array (godoc-local: Change -> getNewJoinKeysByOffsets?) planner/core/exhaust_physical_plans.go.410: // When inner plan is TableReader, the parameter `ranges` will be nil. Because pk only have one column. So all of its range (godoc-local: When -> constructIndexJoin?) planner/core/exhaust_physical_plans.go.410: // When inner plan is TableReader, the parameter `ranges` will be nil. Because pk only have one column. So all of its range (godoc-local: When -> constructIndexJoin?) planner/core/exhaust_physical_plans.go.1688: // LogicalJoin can generates hash join, index join and sort merge join. (godoc-local: LogicalJoin -> exhaustPhysicalPlans?) planner/core/exhaust_physical_plans.go.1688: // LogicalJoin can generates hash join, index join and sort merge join. (godoc-local: LogicalJoin -> exhaustPhysicalPlans?) planner/core/exhaust_physical_plans.go.2376: // TODO: support more operators and distinct later (godoc-local: TODO: -> checkCanPushDownToMPP?) planner/core/exhaust_physical_plans.go.2376: // TODO: support more operators and distinct later (godoc-local: TODO: -> checkCanPushDownToMPP?) planner/core/explain.go.38: // A plan is dataAccesser means it can access underlying data. (godoc-local: A -> dataAccesser?) planner/core/explain.go.38: // A plan is dataAccesser means it can access underlying data. (godoc-local: A -> dataAccesser?) planner/core/expression_rewriter.go.1749: // Now TableName in expression only used by sequence function like nextval(seq). (godoc-local: Now -> toTable?) planner/core/expression_rewriter.go.1749: // Now TableName in expression only used by sequence function like nextval(seq). (godoc-local: Now -> toTable?) planner/core/find_best_task.go.1055: // If there is a table reader which needs to keep order, we should append a pk to table scan. (godoc-local: If -> appendExtraHandleCol?) planner/core/find_best_task.go.1055: // If there is a table reader which needs to keep order, we should append a pk to table scan. (godoc-local: If -> appendExtraHandleCol?) planner/core/find_best_task_test.go.125: // 1 or 2 for physicalPlan1 or physicalPlan2. (godoc-local: 1 -> planType?) planner/core/find_best_task_test.go.125: // 1 or 2 for physicalPlan1 or physicalPlan2. (godoc-local: 1 -> planType?) planner/core/find_best_task_test.go.125: // 1 or 2 for physicalPlan1 or physicalPlan2. (godoc-local: 1 -> planType?) planner/core/find_best_task_test.go.125: // 1 or 2 for physicalPlan1 or physicalPlan2. (godoc-local: 1 -> planType?) planner/core/fragment.go.36: // following field are filled during getPlanFragment. (godoc-export: following -> TableScan?) planner/core/fragment.go.36: // following field are filled during getPlanFragment. (godoc-export: following -> TableScan?) planner/core/fragment.go.40: // following fields are filled after scheduling. (godoc-export: following -> ExchangeSender?) planner/core/fragment.go.40: // following fields are filled after scheduling. (godoc-export: following -> ExchangeSender?) planner/core/fragment.go.97: // for the task without table scan, we construct tasks according to the children's tasks. (godoc-local: for -> constructMPPTasksByChildrenTasks?) planner/core/fragment.go.97: // for the task without table scan, we construct tasks according to the children's tasks. (godoc-local: for -> constructMPPTasksByChildrenTasks?) planner/core/fragment.go.141: // We would remove all the union-all operators by 'untwist'ing and copying the plans above union-all. (godoc-local: We -> untwistPlanAndRemoveUnionAll?) planner/core/fragment.go.141: // We would remove all the union-all operators by 'untwist'ing and copying the plans above union-all. (godoc-local: We -> untwistPlanAndRemoveUnionAll?) planner/core/fragment.go.302: // single physical table means a table without partitions or a single partition in a partition table. (godoc-local: single -> constructMPPTasksImpl?) planner/core/fragment.go.302: // single physical table means a table without partitions or a single partition in a partition table. (godoc-local: single -> constructMPPTasksImpl?) planner/core/handle_cols.go.51: // GetFieldTypes return field types of columns. (godoc-export: GetFieldTypes -> GetFieldsTypes?) planner/core/handle_cols.go.51: // GetFieldTypes return field types of columns. (godoc-export: GetFieldTypes -> GetFieldsTypes?) planner/core/integration_test.go.1481: // for issue #14822 (godoc-export: for -> TestIndexJoinTableRange?) planner/core/integration_test.go.1481: // for issue #14822 (godoc-export: for -> TestIndexJoinTableRange?) planner/core/integration_test.go.2955: // Test for issue https://github.com/pingcap/tidb/issues/21607. (godoc-export: Test -> TestConditionColPruneInPhysicalUnionScan?) planner/core/integration_test.go.2955: // Test for issue https://github.com/pingcap/tidb/issues/21607. (godoc-export: Test -> TestConditionColPruneInPhysicalUnionScan?) planner/core/integration_test.go.3001: // Test for issue https://github.com/pingcap/tidb/issues/18320 (godoc-export: Test -> TestNonaggregateColumnWithSingleValueInOnlyFullGroupByMode?) planner/core/integration_test.go.3001: // Test for issue https://github.com/pingcap/tidb/issues/18320 (godoc-export: Test -> TestNonaggregateColumnWithSingleValueInOnlyFullGroupByMode?) planner/core/integration_test.go.3264: // Apply operator may got panic because empty Projection is eliminated. (godoc-export: Apply -> TestIssue23887?) planner/core/integration_test.go.3264: // Apply operator may got panic because empty Projection is eliminated. (godoc-export: Apply -> TestIssue23887?) planner/core/integration_test.go.3573: // #22949: test HexLiteral Used in GetVar expr (godoc-export: #22949: -> TestGetVarExprWithHexLiteral?) planner/core/integration_test.go.3573: // #22949: test HexLiteral Used in GetVar expr (godoc-export: #22949: -> TestGetVarExprWithHexLiteral?) planner/core/integration_test.go.3623: // test BitLiteral used with GetVar (godoc-export: test -> TestGetVarExprWithBitLiteral?) planner/core/integration_test.go.3623: // test BitLiteral used with GetVar (godoc-export: test -> TestGetVarExprWithBitLiteral?) planner/core/integration_test.go.3703: // https://github.com/pingcap/tidb/issues/23802 (godoc-export: https://github.com/pingcap/tidb/issues/23802 -> TestPanicWhileQueryTableWithIsNull?) planner/core/integration_test.go.3703: // https://github.com/pingcap/tidb/issues/23802 (godoc-export: https://github.com/pingcap/tidb/issues/23802 -> TestPanicWhileQueryTableWithIsNull?) planner/core/integration_test.go.3747: // https://github.com/pingcap/tidb/issues/24095 (godoc-export: https://github.com/pingcap/tidb/issues/24095 -> TestIssue24095?) planner/core/integration_test.go.3747: // https://github.com/pingcap/tidb/issues/24095 (godoc-export: https://github.com/pingcap/tidb/issues/24095 -> TestIssue24095?) planner/core/logical_plan_builder.go.4433: // HandleOrdinal represents the ordinal of the handle column. (godoc-export: HandleOrdinal -> HandleCols?) planner/core/logical_plan_builder.go.4433: // HandleOrdinal represents the ordinal of the handle column. (godoc-export: HandleOrdinal -> HandleCols?) planner/core/logical_plan_builder.go.4433: // HandleOrdinal represents the ordinal of the handle column. (godoc-export: HandleOrdinal -> HandleCols?) planner/core/logical_plan_builder.go.4433: // HandleOrdinal represents the ordinal of the handle column. (godoc-export: HandleOrdinal -> HandleCols?) planner/core/logical_plan_builder.go.4662: // If tl is CTE, its TableInfo will be nil. (godoc-local: If -> isCTE?) planner/core/logical_plan_builder.go.4662: // If tl is CTE, its TableInfo will be nil. (godoc-local: If -> isCTE?) planner/core/logical_plan_builder.go.5662: // append ast.WindowSpec to []*ast.WindowSpec if absent (godoc-local: append -> appendIfAbsentWindowSpec?) planner/core/logical_plan_builder.go.5662: // append ast.WindowSpec to []*ast.WindowSpec if absent (godoc-local: append -> appendIfAbsentWindowSpec?) planner/core/logical_plan_builder.go.6243: // The recursive part/CTE's schema is nullable, and the UID should be unique. (godoc-local: The -> getResultCTESchema?) planner/core/logical_plan_builder.go.6243: // The recursive part/CTE's schema is nullable, and the UID should be unique. (godoc-local: The -> getResultCTESchema?) planner/core/logical_plans.go.394: // Originally the WHERE or ON condition is parsed into a single expression, (godoc-export: Originally -> Conditions?) planner/core/logical_plans.go.394: // Originally the WHERE or ON condition is parsed into a single expression, (godoc-export: Originally -> Conditions?) planner/core/logical_plans.go.498: // The data source may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/logical_plans.go.498: // The data source may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/logical_plans.go.498: // The data source may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/logical_plans.go.498: // The data source may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/logical_plans.go.503: // handleCol represents the handle column for the datasource, either the (godoc-local: handleCol -> handleCols?) planner/core/logical_plans.go.503: // handleCol represents the handle column for the datasource, either the (godoc-local: handleCol -> handleCols?) planner/core/logical_plans.go.503: // handleCol represents the handle column for the datasource, either the (godoc-local: handleCol -> handleCols?) planner/core/logical_plans.go.503: // handleCol represents the handle column for the datasource, either the (godoc-local: handleCol -> handleCols?) planner/core/logical_plans.go.561: // DataSource should be read-only here. (godoc-export: DataSource -> Source?) planner/core/logical_plans.go.561: // DataSource should be read-only here. (godoc-export: DataSource -> Source?) planner/core/logical_plans.go.1194: // The union between seed part and recursive part is DISTINCT or DISTINCT ALL. (godoc-export: The -> IsDistinct?) planner/core/logical_plans.go.1194: // The union between seed part and recursive part is DISTINCT or DISTINCT ALL. (godoc-export: The -> IsDistinct?) planner/core/logical_plans.go.1194: // The union between seed part and recursive part is DISTINCT or DISTINCT ALL. (godoc-export: The -> IsDistinct?) planner/core/logical_plans.go.1194: // The union between seed part and recursive part is DISTINCT or DISTINCT ALL. (godoc-export: The -> IsDistinct?) planner/core/logical_plans.go.1201: // storageID for this CTE. (godoc-export: storageID -> IDForStorage?) planner/core/logical_plans.go.1201: // storageID for this CTE. (godoc-export: storageID -> IDForStorage?) planner/core/logical_plans.go.1201: // storageID for this CTE. (godoc-export: storageID -> IDForStorage?) planner/core/logical_plans.go.1201: // storageID for this CTE. (godoc-export: storageID -> IDForStorage?) planner/core/memtable_predicate_extractor.go.58: // Extracts predicates which can be pushed down and returns the remained predicates (godoc-export: Extracts -> Extract?) planner/core/memtable_predicate_extractor.go.58: // Extracts predicates which can be pushed down and returns the remained predicates (godoc-export: Extracts -> Extract?) planner/core/memtable_predicate_extractor.go.123: // extract the OR expression, e.g: (godoc-local: extract -> extractColOrExpr?) planner/core/memtable_predicate_extractor.go.123: // extract the OR expression, e.g: (godoc-local: extract -> extractColOrExpr?) planner/core/memtable_predicate_extractor.go.159: // merges `lhs` and `datums` with CNF logic (godoc-local: merges -> merge?) planner/core/memtable_predicate_extractor.go.159: // merges `lhs` and `datums` with CNF logic (godoc-local: merges -> merge?) planner/core/memtable_predicate_extractor.go.229: // extracts the string pattern column, e.g: (godoc-local: extracts -> extractLikePatternCol?) planner/core/memtable_predicate_extractor.go.229: // extracts the string pattern column, e.g: (godoc-local: extracts -> extractLikePatternCol?) planner/core/memtable_predicate_extractor.go.368: // extracts the time range column, e.g: (godoc-local: extracts -> extractTimeRange?) planner/core/memtable_predicate_extractor.go.368: // extracts the time range column, e.g: (godoc-local: extracts -> extractTimeRange?) planner/core/memtable_predicate_extractor.go.380: // unix timestamp in nanoseconds (godoc-local: unix -> startTime?) planner/core/memtable_predicate_extractor.go.380: // unix timestamp in nanoseconds (godoc-local: unix -> startTime?) planner/core/memtable_predicate_extractor.go.586: // Pattern is used to filter the log message (godoc-export: Pattern -> Patterns?) planner/core/memtable_predicate_extractor.go.586: // Pattern is used to filter the log message (godoc-export: Pattern -> Patterns?) planner/core/memtable_predicate_extractor.go.1126: // TidbDatabases represents tidbDatabases applied to, and we should apply all tidb database if there is no database specified. (godoc-export: TidbDatabases -> TiDBDatabases?) planner/core/memtable_predicate_extractor.go.1126: // TidbDatabases represents tidbDatabases applied to, and we should apply all tidb database if there is no database specified. (godoc-export: TidbDatabases -> TiDBDatabases?) planner/core/memtable_predicate_extractor.go.1126: // TidbDatabases represents tidbDatabases applied to, and we should apply all tidb database if there is no database specified. (godoc-export: TidbDatabases -> TiDBDatabases?) planner/core/memtable_predicate_extractor.go.1126: // TidbDatabases represents tidbDatabases applied to, and we should apply all tidb database if there is no database specified. (godoc-export: TidbDatabases -> TiDBDatabases?) planner/core/memtable_predicate_extractor.go.1129: // TidbTables represents tidbTables applied to, and we should apply all tidb table if there is no table specified. (godoc-export: TidbTables -> TiDBTables?) planner/core/memtable_predicate_extractor.go.1129: // TidbTables represents tidbTables applied to, and we should apply all tidb table if there is no table specified. (godoc-export: TidbTables -> TiDBTables?) planner/core/memtable_predicate_extractor.go.1129: // TidbTables represents tidbTables applied to, and we should apply all tidb table if there is no table specified. (godoc-export: TidbTables -> TiDBTables?) planner/core/memtable_predicate_extractor.go.1129: // TidbTables represents tidbTables applied to, and we should apply all tidb table if there is no table specified. (godoc-export: TidbTables -> TiDBTables?) planner/core/partition_pruner_test.go.459: //issue 22079 (godoc-export: 22079 -> TestRangePartitionPredicatePruner?) planner/core/partition_pruner_test.go.459: //issue 22079 (godoc-export: 22079 -> TestRangePartitionPredicatePruner?) planner/core/physical_plans.go.87: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.87: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.87: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.87: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.192: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.192: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.192: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.192: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.273: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.273: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.273: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.273: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.330: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.330: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.330: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.330: // Used by partition table. (godoc-export: Used -> PartitionInfo?) planner/core/physical_plans.go.377: // The index scan may be on a partition. (godoc-local: The -> physicalTableID?) planner/core/physical_plans.go.377: // The index scan may be on a partition. (godoc-local: The -> physicalTableID?) planner/core/physical_plans.go.377: // The index scan may be on a partition. (godoc-local: The -> physicalTableID?) planner/core/physical_plans.go.377: // The index scan may be on a partition. (godoc-local: The -> physicalTableID?) planner/core/physical_plans.go.474: // The table scan may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/physical_plans.go.474: // The table scan may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/physical_plans.go.474: // The table scan may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/physical_plans.go.474: // The table scan may be a partition, rather than a real table. (godoc-local: The -> isPartition?) planner/core/physical_plans.go.763: // use the outer table to build a hash table when the outer table is smaller. (godoc-export: use -> UseOuterToBuild?) planner/core/physical_plans.go.763: // use the outer table to build a hash table when the outer table is smaller. (godoc-export: use -> UseOuterToBuild?) planner/core/physical_plans.go.763: // use the outer table to build a hash table when the outer table is smaller. (godoc-export: use -> UseOuterToBuild?) planner/core/physical_plans.go.763: // use the outer table to build a hash table when the outer table is smaller. (godoc-export: use -> UseOuterToBuild?) planner/core/physical_plans.go.766: // on which store the join executes. (godoc-local: on -> storeTp?) planner/core/physical_plans.go.766: // on which store the join executes. (godoc-local: on -> storeTp?) planner/core/physical_plans.go.766: // on which store the join executes. (godoc-local: on -> storeTp?) planner/core/physical_plans.go.766: // on which store the join executes. (godoc-local: on -> storeTp?) planner/core/physical_plans.go.1169: // These two fields are used to switch ScalarFunctions to Constants. For these (godoc-export: These -> ByItems?) planner/core/physical_plans.go.1169: // These two fields are used to switch ScalarFunctions to Constants. For these (godoc-export: These -> ByItems?) planner/core/physical_plans.go.1328: // Worker points to `executor.shuffleReceiver`. (godoc-export: Worker -> Receiver?) planner/core/physical_plans.go.1328: // Worker points to `executor.shuffleReceiver`. (godoc-export: Worker -> Receiver?) planner/core/physical_plans.go.1328: // Worker points to `executor.shuffleReceiver`. (godoc-export: Worker -> Receiver?) planner/core/physical_plans.go.1328: // Worker points to `executor.shuffleReceiver`. (godoc-export: Worker -> Receiver?) planner/core/plan.go.37: // Get the schema. (godoc-export: Get -> Schema?) planner/core/plan.go.37: // Get the schema. (godoc-export: Get -> Schema?) planner/core/plan.go.40: // Get the ID. (godoc-export: Get -> ID?) planner/core/plan.go.40: // Get the ID. (godoc-export: Get -> ID?) planner/core/plan.go.46: // Get the ID in explain statement (godoc-export: Get -> ExplainID?) planner/core/plan.go.46: // Get the ID in explain statement (godoc-export: Get -> ExplainID?) planner/core/plan.go.57: // property.StatsInfo will return the property.StatsInfo for this plan. (godoc-local: property.StatsInfo -> statsInfo?) planner/core/plan.go.57: // property.StatsInfo will return the property.StatsInfo for this plan. (godoc-local: property.StatsInfo -> statsInfo?) planner/core/plan.go.293: // Get all the children. (godoc-export: Get -> Children?) planner/core/plan.go.293: // Get all the children. (godoc-export: Get -> Children?) planner/core/plan.go.320: // getChildReqProps gets the required property by child index. (godoc-export: getChildReqProps -> GetChildReqProps?) planner/core/plan.go.320: // getChildReqProps gets the required property by child index. (godoc-export: getChildReqProps -> GetChildReqProps?) planner/core/plan.go.329: // Get all the children. (godoc-export: Get -> Children?) planner/core/plan.go.329: // Get all the children. (godoc-export: Get -> Children?) planner/core/plan.go.615: // property.StatsInfo implements the Plan interface. (godoc-local: property.StatsInfo -> statsInfo?) planner/core/plan.go.615: // property.StatsInfo implements the Plan interface. (godoc-local: property.StatsInfo -> statsInfo?) planner/core/plan.go.696: // Context implements Plan Context interface. (godoc-export: Context -> SCtx?) planner/core/plan.go.696: // Context implements Plan Context interface. (godoc-export: Context -> SCtx?) planner/core/planbuilder.go.114: // Matched indicates whether this index hint (godoc-local: Matched -> matched?) planner/core/planbuilder.go.114: // Matched indicates whether this index hint (godoc-local: Matched -> matched?) planner/core/planbuilder.go.114: // Matched indicates whether this index hint (godoc-local: Matched -> matched?) planner/core/planbuilder.go.114: // Matched indicates whether this index hint (godoc-local: Matched -> matched?) planner/core/planbuilder.go.484: // SelectLock need this information to locate the lock on partitions. (godoc-local: SelectLock -> partitionedTable?) planner/core/planbuilder.go.484: // SelectLock need this information to locate the lock on partitions. (godoc-local: SelectLock -> partitionedTable?) planner/core/planbuilder.go.493: // evalDefaultExpr needs this information to find the corresponding column. (godoc-local: evalDefaultExpr -> allNames?) planner/core/planbuilder.go.493: // evalDefaultExpr needs this information to find the corresponding column. (godoc-local: evalDefaultExpr -> allNames?) planner/core/point_get_plan_test.go.318: // Test that the plan id will be reset before optimization every time. (godoc-export: Test -> TestPointGetId?) planner/core/point_get_plan_test.go.318: // Test that the plan id will be reset before optimization every time. (godoc-export: Test -> TestPointGetId?) planner/core/prepare_test.go.305: // unit test for issue https://github.com/pingcap/tidb/issues/8518 (godoc-export: unit -> TestPrepareTableAsNameOnGroupByWithCache?) planner/core/prepare_test.go.305: // unit test for issue https://github.com/pingcap/tidb/issues/8518 (godoc-export: unit -> TestPrepareTableAsNameOnGroupByWithCache?) planner/core/prepare_test.go.348: // nolint:unused (godoc-local: nolint:unused -> readGaugeInt?) planner/core/prepare_test.go.348: // nolint:unused (godoc-local: nolint:unused -> readGaugeInt?) planner/core/prepare_test.go.362: // unit test for issue https://github.com/pingcap/tidb/issues/9478 (godoc-export: unit -> TestPrepareWithWindowFunction?) planner/core/prepare_test.go.362: // unit test for issue https://github.com/pingcap/tidb/issues/9478 (godoc-export: unit -> TestPrepareWithWindowFunction?) planner/core/prepare_test.go.999: // Test for issue https://github.com/pingcap/tidb/issues/22167 (godoc-export: Test -> TestPrepareCacheWithJoinTable?) planner/core/prepare_test.go.999: // Test for issue https://github.com/pingcap/tidb/issues/22167 (godoc-export: Test -> TestPrepareCacheWithJoinTable?) planner/core/rule_aggregation_push_down.go.30: // isDecomposable checks if an aggregate function is decomposable. An aggregation function $F$ is decomposable (godoc-local: isDecomposable -> isDecomposableWithJoin?) planner/core/rule_aggregation_push_down.go.30: // isDecomposable checks if an aggregate function is decomposable. An aggregation function $F$ is decomposable (godoc-local: isDecomposable -> isDecomposableWithJoin?) planner/core/rule_aggregation_push_down.go.266: // TODO: (godoc-local: TODO: -> makeNewAgg?) planner/core/rule_aggregation_push_down.go.266: // TODO: (godoc-local: TODO: -> makeNewAgg?) planner/core/rule_build_key_info.go.66: // If a condition is the form of (uniqueKey = constant) or (uniqueKey = Correlated column), it returns at most one row. (godoc-local: If -> checkMaxOneRowCond?) planner/core/rule_build_key_info.go.66: // If a condition is the form of (uniqueKey = constant) or (uniqueKey = Correlated column), it returns at most one row. (godoc-local: If -> checkMaxOneRowCond?) planner/core/rule_build_key_info.go.140: // A bijection exists between columns of a projection's schema and this projection's Exprs. (godoc-local: A -> buildSchemaByExprs?) planner/core/rule_build_key_info.go.140: // A bijection exists between columns of a projection's schema and this projection's Exprs. (godoc-local: A -> buildSchemaByExprs?) planner/core/rule_column_pruning.go.482: // By add const one, we can avoid empty Projection is eliminated. (godoc-local: By -> addConstOneForEmptyProjection?) planner/core/rule_column_pruning.go.482: // By add const one, we can avoid empty Projection is eliminated. (godoc-local: By -> addConstOneForEmptyProjection?) planner/core/rule_inject_extra_projection.go.103: // wrapCastForAggFunc wraps the args of an aggregate function with a cast function. (godoc-local: wrapCastForAggFunc -> wrapCastForAggFuncs?) planner/core/rule_inject_extra_projection.go.103: // wrapCastForAggFunc wraps the args of an aggregate function with a cast function. (godoc-local: wrapCastForAggFunc -> wrapCastForAggFuncs?) planner/core/rule_join_elimination.go.80: // extract join keys as a schema for inner child of a outer join (godoc-local: extract -> extractInnerJoinKeys?) planner/core/rule_join_elimination.go.80: // extract join keys as a schema for inner child of a outer join (godoc-local: extract -> extractInnerJoinKeys?) planner/core/rule_join_elimination.go.105: // check whether one of unique keys sets is contained by inner join keys (godoc-local: check -> isInnerJoinKeysContainUniqueKey?) planner/core/rule_join_elimination.go.105: // check whether one of unique keys sets is contained by inner join keys (godoc-local: check -> isInnerJoinKeysContainUniqueKey?) planner/core/rule_join_elimination.go.122: // check whether one of index sets is contained by inner join index (godoc-local: check -> isInnerJoinKeysContainIndex?) planner/core/rule_join_elimination.go.122: // check whether one of index sets is contained by inner join index (godoc-local: check -> isInnerJoinKeysContainIndex?) planner/core/rule_join_reorder.go.126: // nolint:structcheck (godoc-local: nolint:structcheck -> baseSingleGroupJoinOrderSolver?) planner/core/rule_join_reorder.go.126: // nolint:structcheck (godoc-local: nolint:structcheck -> baseSingleGroupJoinOrderSolver?) planner/core/rule_join_reorder_dp.go.252: // Make cartesian join as bushy tree. (godoc-local: Make -> makeBushyJoin?) planner/core/rule_join_reorder_dp.go.252: // Make cartesian join as bushy tree. (godoc-local: Make -> makeBushyJoin?) planner/core/rule_partition_processor.go.977: // If partFn is not nil, monotonous indicates partFn is monotonous or not. (godoc-local: If -> monotonous?) planner/core/rule_partition_processor.go.977: // If partFn is not nil, monotonous indicates partFn is monotonous or not. (godoc-local: If -> monotonous?) planner/core/rule_partition_processor.go.977: // If partFn is not nil, monotonous indicates partFn is monotonous or not. (godoc-local: If -> monotonous?) planner/core/rule_partition_processor.go.977: // If partFn is not nil, monotonous indicates partFn is monotonous or not. (godoc-local: If -> monotonous?) planner/core/rule_partition_processor.go.1081: // f(x) op const, op is > = < (godoc-local: f(x) -> dataForPrune?) planner/core/rule_partition_processor.go.1081: // f(x) op const, op is > = < (godoc-local: f(x) -> dataForPrune?) planner/core/rule_result_reorder.go.101: // extractHandleCols does the best effort to get the handle column. (godoc-local: extractHandleCols -> extractHandleCol?) planner/core/rule_result_reorder.go.101: // extractHandleCols does the best effort to get the handle column. (godoc-local: extractHandleCols -> extractHandleCol?) planner/core/stats.go.416: // getIndexMergeOrPath generates all possible IndexMergeOrPaths. (godoc-local: getIndexMergeOrPath -> generateIndexMergeOrPaths?) planner/core/stats.go.416: // getIndexMergeOrPath generates all possible IndexMergeOrPaths. (godoc-local: getIndexMergeOrPath -> generateIndexMergeOrPaths?) planner/core/stats.go.1031: // Exists and MaxOneRow produce at most one row, so we set the RowCount of stats one. (godoc-local: Exists -> getSingletonStats?) planner/core/stats.go.1031: // Exists and MaxOneRow produce at most one row, so we set the RowCount of stats one. (godoc-local: Exists -> getSingletonStats?) planner/core/task.go.87: // For table partition. (godoc-local: For -> partitionInfo?) planner/core/task.go.87: // For table partition. (godoc-local: For -> partitionInfo?) planner/core/task.go.87: // For table partition. (godoc-local: For -> partitionInfo?) planner/core/task.go.87: // For table partition. (godoc-local: For -> partitionInfo?) planner/core/task.go.581: // TiDB only require that the types fall into the same catalog but TiFlash require the type to be exactly the same, so (godoc-local: TiDB -> needConvert?) planner/core/task.go.581: // TiDB only require that the types fall into the same catalog but TiFlash require the type to be exactly the same, so (godoc-local: TiDB -> needConvert?) planner/core/task.go.661: // TiFlash join require that partition key has exactly the same type, while TiDB only guarantee the partition key is the same catalog, (godoc-local: TiFlash -> convertPartitionKeysIfNeed?) planner/core/task.go.661: // TiFlash join require that partition key has exactly the same type, while TiDB only guarantee the partition key is the same catalog, (godoc-local: TiFlash -> convertPartitionKeysIfNeed?) planner/core/util.go.63: // WindowFuncs is the collected WindowFuncExprs. (godoc-local: WindowFuncs -> windowFuncs?) planner/core/util.go.63: // WindowFuncs is the collected WindowFuncExprs. (godoc-local: WindowFuncs -> windowFuncs?) planner/property/physical_property.go.69: // indicates that whether we are allowed to add an enforcer. (godoc-export: indicates -> CanAddEnforcer?) planner/property/physical_property.go.69: // indicates that whether we are allowed to add an enforcer. (godoc-export: indicates -> CanAddEnforcer?) planner/property/physical_property.go.69: // indicates that whether we are allowed to add an enforcer. (godoc-export: indicates -> CanAddEnforcer?) planner/property/physical_property.go.69: // indicates that whether we are allowed to add an enforcer. (godoc-export: indicates -> CanAddEnforcer?) planner/property/physical_property.go.72: // If the partition type is hash, the data should be reshuffled by partition cols. (godoc-export: If -> MPPPartitionCols?) planner/property/physical_property.go.72: // If the partition type is hash, the data should be reshuffled by partition cols. (godoc-export: If -> MPPPartitionCols?) planner/property/physical_property.go.75: // which types the exchange sender belongs to, only take effects when it's a mpp task. (godoc-export: which -> MPPPartitionTp?) planner/property/physical_property.go.75: // which types the exchange sender belongs to, only take effects when it's a mpp task. (godoc-export: which -> MPPPartitionTp?) planner/property/physical_property.go.75: // which types the exchange sender belongs to, only take effects when it's a mpp task. (godoc-export: which -> MPPPartitionTp?) planner/property/physical_property.go.75: // which types the exchange sender belongs to, only take effects when it's a mpp task. (godoc-export: which -> MPPPartitionTp?) planner/property/stats_info.go.38: // Column.UniqueID -> Cardinality (godoc-export: Column.UniqueID -> Cardinality?) planner/property/stats_info.go.38: // Column.UniqueID -> Cardinality (godoc-export: Column.UniqueID -> Cardinality?) plugin/spi.go.47: // OnShutDown defines the plugin cleanup logic. (godoc-export: OnShutDown -> OnShutdown?) privilege/privilege.go.84: // Get the authentication plugin for a user (godoc-export: Get -> GetAuthPlugin?) privilege/privileges/cache.go.88: // IPv4 with netmask, cached for host match performance. (godoc-local: IPv4 -> hostIPNet?) privilege/privileges/cache.go.88: // IPv4 with netmask, cached for host match performance. (godoc-local: IPv4 -> hostIPNet?) privilege/privileges/cache.go.255: // This helps in the case that there are a number of users with (godoc-export: This -> User?) privilege/privileges/cache.go.255: // This helps in the case that there are a number of users with (godoc-export: This -> User?) server/conn.go.800: // Check if the Authentication Plugin of the server, client and user configuration matches (godoc-local: Check -> checkAuthPlugin?) server/conn.go.1803: // The first return value indicates whether the call of handleStmt has no side effect and can be retried. (godoc-local: The -> handleStmt?) server/conn.go.2210: // safe to noop except 0x01 "FLUSH PRIVILEGES" (godoc-local: safe -> handleRefresh?) server/conn_stmt.go.225: // The first return value indicates whether the call of executePreparedStmtAndWriteResult has no side effect and can be retried. (godoc-local: The -> executePreparedStmtAndWriteResult?) server/conn_test.go.857: // For issue https://github.com/pingcap/tidb/issues/25069 (godoc-export: For -> TestShowErrors?) server/http_handler.go.752: // Modifying the field name needs to negotiate with TiFlash colleague. (godoc-export: Modifying -> ID?) server/http_handler.go.752: // Modifying the field name needs to negotiate with TiFlash colleague. (godoc-export: Modifying -> ID?) server/http_handler.go.868: // Modifying the field name needs to negotiate with TiFlash colleague. (godoc-export: Modifying -> ID?) server/http_handler.go.868: // Modifying the field name needs to negotiate with TiFlash colleague. (godoc-export: Modifying -> ID?) server/http_handler.go.1859: // Supported operations: (godoc-local: Supported -> handleGC?) server/server.go.294: // Export config-related metrics (godoc-local: Export -> reportConfig?) server/server_test.go.2019: // Client errors are only incremented when using the TiDB Server protocol, (godoc-local: Client -> runTestInfoschemaClientErrors?) server/tidb_test.go.188: // this test will change `kv.TxnTotalSizeLimit` which may affect other test suites, (godoc-export: this -> TestLoadData?) server/tidb_test.go.203: // Fix issue#22540. Change tidb_dml_batch_size, (godoc-export: Fix -> TestLoadDataAutoRandom?) session/bootstrap.go.1150: // Convert statement summary global variables to non-empty values. (godoc-local: Convert -> writeStmtSummaryVars?) session/bootstrap.go.1184: // In v3.1.1, we wrongly replace the context of upgradeToVer39 with upgradeToVer44. If we upgrade from v3.1.1 to a newer version, (godoc-local: In -> upgradeToVer46?) session/bootstrap.go.1244: // When cherry-pick upgradeToVer52 to v4.0, we wrongly name it upgradeToVer48. (godoc-local: When -> upgradeToVer55?) session/bootstrap.go.1294: // When cherry-pick upgradeToVer54 to v4.0, we wrongly name it upgradeToVer49. (godoc-local: When -> upgradeToVer56?) session/bootstrap_test.go.138: // testBootstrapWithError : (godoc-export: testBootstrapWithError -> TestBootstrapWithError?) session/clustered_index_test.go.404: // Test for union scan in prefixed clustered index table. (godoc-export: Test -> TestClusteredUnionScanOnPrefixingPrimaryKey?) session/clustered_index_test.go.488: // https://github.com/pingcap/tidb/issues/20727 (godoc-export: https://github.com/pingcap/tidb/issues/20727 -> TestClusteredIndexSplitAndAddIndex?) session/clustered_index_test.go.500: // https://github.com/pingcap/tidb/issues/22453 (godoc-export: https://github.com/pingcap/tidb/issues/22453 -> TestClusteredIndexSplitAndAddIndex2?) session/clustered_index_test.go.630: // https://github.com/pingcap/tidb/issues/23106 (godoc-export: https://github.com/pingcap/tidb/issues/23106 -> TestClusteredIndexDecodeRestoredDataV5?) session/clustered_index_test.go.652: // https://github.com/pingcap/tidb/issues/23178 (godoc-export: https://github.com/pingcap/tidb/issues/23178 -> TestPrefixedClusteredIndexUniqueKeyWithNewCollation?) session/isolation_test.go.311: // cursor is not supported (godoc-export: cursor -> TestP4CLostUpdate?) session/schema_amender.go.301: // amendOperationAddIndex represents one amend operation related to a specific add index change. (godoc-local: amendOperationAddIndex -> amendOperationAddIndexInfo?) session/schema_amender_test.go.92: // Generate exist old data and new data in transaction to be amended. Also generate the expected amend mutations (godoc-local: Generate -> prepareTestData?) session/session.go.1176: // In mysql.tidb the convention has been to store the string value "true"/"false", (godoc-local: In -> trueFalseToOnOff?) session/session.go.1187: // In mysql.tidb the convention has been to store the string value "true"/"false", (godoc-local: In -> onOffToTrueFalse?) session/txn.go.50: // States of a LazyTxn should be one of the followings: (godoc-local: States -> kv?) session/txn.go.62: // TxnInfo is added for the lock view feature, the data is frequent modified but (godoc-local: TxnInfo -> mu?) session/txninfo/txn_info.go.50: // Digest of SQL currently running (godoc-export: Digest -> CurrentSQLDigest?) session/txninfo/txn_info.go.50: // Digest of SQL currently running (godoc-export: Digest -> CurrentSQLDigest?) session/txninfo/txn_info.go.50: // Digest of SQL currently running (godoc-export: Digest -> CurrentSQLDigest?) session/txninfo/txn_info.go.50: // Digest of SQL currently running (godoc-export: Digest -> CurrentSQLDigest?) session/txninfo/txn_info.go.52: // Digests of all SQLs executed in the transaction. (godoc-export: Digests -> AllSQLDigests?) session/txninfo/txn_info.go.52: // Digests of all SQLs executed in the transaction. (godoc-export: Digests -> AllSQLDigests?) session/txninfo/txn_info.go.59: // Current execution state of the transaction. (godoc-export: Current -> State?) session/txninfo/txn_info.go.59: // Current execution state of the transaction. (godoc-export: Current -> State?) session/txninfo/txn_info.go.59: // Current execution state of the transaction. (godoc-export: Current -> State?) session/txninfo/txn_info.go.59: // Current execution state of the transaction. (godoc-export: Current -> State?) session/txninfo/txn_info.go.61: // Last trying to block start time. Invalid if State is not TxnLockWaiting. (godoc-export: Last -> BlockStartTime?) session/txninfo/txn_info.go.61: // Last trying to block start time. Invalid if State is not TxnLockWaiting. (godoc-export: Last -> BlockStartTime?) session/txninfo/txn_info.go.66: // How many entries are in MemDB (godoc-export: How -> EntriesCount?) session/txninfo/txn_info.go.66: // How many entries are in MemDB (godoc-export: How -> EntriesCount?) session/txninfo/txn_info.go.68: // MemDB used memory (godoc-export: MemDB -> EntriesSize?) session/txninfo/txn_info.go.68: // MemDB used memory (godoc-export: MemDB -> EntriesSize?) session/txninfo/txn_info.go.73: // Which session this transaction belongs to (godoc-export: Which -> ConnectionID?) session/txninfo/txn_info.go.73: // Which session this transaction belongs to (godoc-export: Which -> ConnectionID?) session/txninfo/txn_info.go.75: // The user who open this session (godoc-export: The -> Username?) session/txninfo/txn_info.go.75: // The user who open this session (godoc-export: The -> Username?) session/txninfo/txn_info.go.77: // The schema this transaction works on (godoc-export: The -> CurrentDB?) session/txninfo/txn_info.go.77: // The schema this transaction works on (godoc-export: The -> CurrentDB?) sessionctx/binloginfo/binloginfo_test.go.476: // Sometimes this test doesn't clean up fail, let the function name begin with 'Z' (godoc-export: Sometimes -> TestZIgnoreError?) sessionctx/binloginfo/binloginfo_test.go.476: // Sometimes this test doesn't clean up fail, let the function name begin with 'Z' (godoc-export: Sometimes -> TestZIgnoreError?) sessionctx/context.go.60: // GetClient gets a kv.Client. (godoc-export: GetClient -> GetMPPClient?) sessionctx/stmtctx/stmtctx.go.61: // Set the following variables before execution (godoc-export: Set -> StmtHints?) sessionctx/stmtctx/stmtctx.go.61: // Set the following variables before execution (godoc-export: Set -> StmtHints?) sessionctx/stmtctx/stmtctx.go.187: // Hint Information (godoc-export: Hint -> MemQuotaQuery?) sessionctx/stmtctx/stmtctx.go.187: // Hint Information (godoc-export: Hint -> MemQuotaQuery?) sessionctx/stmtctx/stmtctx.go.187: // Hint Information (godoc-export: Hint -> MemQuotaQuery?) sessionctx/stmtctx/stmtctx.go.187: // Hint Information (godoc-export: Hint -> MemQuotaQuery?) sessionctx/stmtctx/stmtctx.go.200: // Hint flags (godoc-export: Hint -> HasAllowInSubqToJoinAndAggHint?) sessionctx/stmtctx/stmtctx.go.200: // Hint flags (godoc-export: Hint -> HasAllowInSubqToJoinAndAggHint?) sessionctx/stmtctx/stmtctx.go.200: // Hint flags (godoc-export: Hint -> HasAllowInSubqToJoinAndAggHint?) sessionctx/stmtctx/stmtctx.go.200: // Hint flags (godoc-export: Hint -> HasAllowInSubqToJoinAndAggHint?) sessionctx/stmtctx/stmtctx.go.724: // calculate backoff details (godoc-local: calculate -> backoffItem?) sessionctx/stmtctx/stmtctx.go.724: // calculate backoff details (godoc-local: calculate -> backoffItem?) sessionctx/variable/session.go.175: // TableDeltaMap lock to prevent potential data race (godoc-local: TableDeltaMap -> tdmLock?) sessionctx/variable/session.go.175: // TableDeltaMap lock to prevent potential data race (godoc-local: TableDeltaMap -> tdmLock?) sessionctx/variable/session.go.524: // TiDBAllowAutoRandExplicitInsert indicates whether explicit insertion on auto_random column is allowed. (godoc-export: TiDBAllowAutoRandExplicitInsert -> AllowAutoRandExplicitInsert?) sessionctx/variable/session.go.524: // TiDBAllowAutoRandExplicitInsert indicates whether explicit insertion on auto_random column is allowed. (godoc-export: TiDBAllowAutoRandExplicitInsert -> AllowAutoRandExplicitInsert?) sessionctx/variable/session.go.549: // ScanFactor is the IO cost of scanning 1 byte data on TiKV and TiFlash. (godoc-local: ScanFactor -> scanFactor?) sessionctx/variable/session.go.549: // ScanFactor is the IO cost of scanning 1 byte data on TiKV and TiFlash. (godoc-local: ScanFactor -> scanFactor?) sessionctx/variable/session.go.686: // use noop funcs or not (godoc-export: use -> EnableNoopFuncs?) sessionctx/variable/session.go.686: // use noop funcs or not (godoc-export: use -> EnableNoopFuncs?) sessionctx/variable/session.go.733: // EnableIndexMerge enables the generation of IndexMergePath. (godoc-local: EnableIndexMerge -> enableIndexMerge?) sessionctx/variable/session.go.733: // EnableIndexMerge enables the generation of IndexMergePath. (godoc-local: EnableIndexMerge -> enableIndexMerge?) sessionctx/variable/session.go.848: // The temporary table size threshold (godoc-export: The -> TMPTableSize?) sessionctx/variable/session.go.848: // The temporary table size threshold (godoc-export: The -> TMPTableSize?) sessionctx/variable/session.go.1737: // The variables below do not take any effect anymore, it's remaining for compatibility. (godoc-export: The -> MemQuotaHashJoin?) sessionctx/variable/session.go.1737: // The variables below do not take any effect anymore, it's remaining for compatibility. (godoc-export: The -> MemQuotaHashJoin?) sessionctx/variable/session.go.1737: // The variables below do not take any effect anymore, it's remaining for compatibility. (godoc-export: The -> MemQuotaHashJoin?) sessionctx/variable/session.go.1737: // The variables below do not take any effect anymore, it's remaining for compatibility. (godoc-export: The -> MemQuotaHashJoin?) sessionctx/variable/sysvar_test.go.453: // IsNoop is used by the documentation to auto-generate docs for real sysvars. (godoc-export: IsNoop -> TestIsNoop?) sessionctx/variable/sysvar_test.go.453: // IsNoop is used by the documentation to auto-generate docs for real sysvars. (godoc-export: IsNoop -> TestIsNoop?) sessionctx/variable/sysvar_test.go.574: // Calling GetSysVars/GetSysVar needs to return a deep copy, otherwise there will be data races. (godoc-export: Calling -> TestDeepCopyGetSysVars?) sessionctx/variable/sysvar_test.go.574: // Calling GetSysVars/GetSysVar needs to return a deep copy, otherwise there will be data races. (godoc-export: Calling -> TestDeepCopyGetSysVars?) sessionctx/variable/sysvar_test.go.601: // Test that sysvars defaults are logically valid. i.e. (godoc-export: Test -> TestDefaultValuesAreSettable?) sessionctx/variable/sysvar_test.go.601: // Test that sysvars defaults are logically valid. i.e. (godoc-export: Test -> TestDefaultValuesAreSettable?) sessionctx/variable/tidb_vars.go.737: // Export for testing. (godoc-export: Export -> MaxDDLReorgBatchSize?) sessionctx/variable/tidb_vars.go.737: // Export for testing. (godoc-export: Export -> MaxDDLReorgBatchSize?) sessionctx/variable/tidb_vars.go.766: // The refresh interval of top-sql. (godoc-export: The -> PrecisionSeconds?) sessionctx/variable/tidb_vars.go.766: // The refresh interval of top-sql. (godoc-export: The -> PrecisionSeconds?) sessionctx/variable/tidb_vars.go.768: // The maximum number of statements kept in memory. (godoc-export: The -> MaxStatementCount?) sessionctx/variable/tidb_vars.go.768: // The maximum number of statements kept in memory. (godoc-export: The -> MaxStatementCount?) sessionctx/variable/tidb_vars.go.770: // The maximum capacity of the collect map. (godoc-export: The -> MaxCollect?) sessionctx/variable/tidb_vars.go.770: // The maximum capacity of the collect map. (godoc-export: The -> MaxCollect?) sessionctx/variable/tidb_vars.go.772: // The report data interval of top-sql. (godoc-export: The -> ReportIntervalSeconds?) sessionctx/variable/tidb_vars.go.772: // The report data interval of top-sql. (godoc-export: The -> ReportIntervalSeconds?) statistics/cmsketch.go.176: // queryAddTopN TopN adds count to CMSketch.topN if exists, and returns the count of such elements after insert. (godoc-local: queryAddTopN -> updateTopNWithDelta?) statistics/feedback.go.516: // There are only two types of datum in bucket: one is `Blob`, which is for index; the other one (godoc-local: There -> bucket?) statistics/handle/handle.go.342: // MergePartitionStats2GlobalStatsByTableID merge the partition-level stats to global-level stats based on the tableInfo. (godoc-local: MergePartitionStats2GlobalStatsByTableID -> mergePartitionStats2GlobalStats?) statistics/handle/handle.go.342: // MergePartitionStats2GlobalStatsByTableID merge the partition-level stats to global-level stats based on the tableInfo. (godoc-local: MergePartitionStats2GlobalStatsByTableID -> mergePartitionStats2GlobalStats?) statistics/handle/handle.go.554: //initMemoryUsage calc total memory usage of statsCache and set statsCache.memUsage (godoc-local: calc -> initMemoryUsage?) statistics/handle/handle.go.554: //initMemoryUsage calc total memory usage of statsCache and set statsCache.memUsage (godoc-local: calc -> initMemoryUsage?) statistics/handle/handle_test.go.879: // nolint:unused (godoc-local: nolint:unused -> prepareForGlobalStatsWithOpts?) statistics/handle/handle_test.go.879: // nolint:unused (godoc-local: nolint:unused -> prepareForGlobalStatsWithOpts?) statistics/handle/handle_test.go.903: // nolint:unused (godoc-local: nolint:unused -> checkForGlobalStatsWithOpts?) statistics/handle/handle_test.go.903: // nolint:unused (godoc-local: nolint:unused -> checkForGlobalStatsWithOpts?) statistics/handle/handle_test.go.924: // nolint:unused (godoc-local: nolint:unused -> opt?) statistics/handle/handle_test.go.924: // nolint:unused (godoc-local: nolint:unused -> opt?) statistics/handle/update.go.446: // dumpTableStatDeltaToKV dumps a single delta with some table to KV and updates the version. (godoc-local: dumpTableStatDeltaToKV -> dumpTableStatCountToKV?) statistics/handle/update.go.446: // dumpTableStatDeltaToKV dumps a single delta with some table to KV and updates the version. (godoc-local: dumpTableStatDeltaToKV -> dumpTableStatCountToKV?) statistics/histogram.go.56: // Histogram elements. (godoc-export: Histogram -> Bounds?) statistics/histogram.go.68: // Used for estimating fraction of the interval [lower, upper] that lies within the [lower, value]. (godoc-local: Used -> scalars?) statistics/histogram.go.1767: // mergeParitionBuckets merges buckets[l...r) to one global bucket. (godoc-local: mergeParitionBuckets -> mergePartitionBuckets?) statistics/integration_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package statistics_test?) store/copr/batch_coprocessor.go.55: // batch Cop Response is yet to return startKey. So batchCop cannot retry partially. (godoc-local: batch -> startKey?) store/copr/batch_coprocessor.go.55: // batch Cop Response is yet to return startKey. So batchCop cannot retry partially. (godoc-local: batch -> startKey?) store/copr/batch_coprocessor.go.55: // batch Cop Response is yet to return startKey. So batchCop cannot retry partially. (godoc-local: batch -> startKey?) store/copr/batch_coprocessor.go.55: // batch Cop Response is yet to return startKey. So batchCop cannot retry partially. (godoc-local: batch -> startKey?) store/copr/batch_coprocessor.go.72: // GetExecDetails is unavailable currently, because TiFlash has not collected exec details for batch cop. (godoc-export: GetExecDetails -> GetCopRuntimeStats?) store/copr/batch_coprocessor.go.72: // GetExecDetails is unavailable currently, because TiFlash has not collected exec details for batch cop. (godoc-export: GetExecDetails -> GetCopRuntimeStats?) store/copr/batch_coprocessor.go.529: // Merge all ranges and request again. (godoc-local: Merge -> retryBatchCopTask?) store/copr/batch_coprocessor.go.529: // Merge all ranges and request again. (godoc-local: Merge -> retryBatchCopTask?) store/copr/coprocessor.go.608: // Associate each region with an independent backoffer. In this way, when multiple regions are (godoc-local: Associate -> chooseBackoffer?) store/copr/coprocessor.go.608: // Associate each region with an independent backoffer. In this way, when multiple regions are (godoc-local: Associate -> chooseBackoffer?) store/copr/mpp.go.96: // GetExecDetails is unavailable currently. (godoc-export: GetExecDetails -> GetCopRuntimeStats?) store/copr/mpp.go.96: // GetExecDetails is unavailable currently. (godoc-export: GetExecDetails -> GetCopRuntimeStats?) store/copr/mpp.go.173: // TODO:: Consider that which way is better: (godoc-local: TODO:: -> handleDispatchReq?) store/copr/mpp.go.173: // TODO:: Consider that which way is better: (godoc-local: TODO:: -> handleDispatchReq?) store/copr/mpp.go.267: // NOTE: We do not retry here, because retry is helpless when errors result from TiFlash or Network. If errors occur, the execution on TiFlash will finally stop after some minutes. (godoc-local: NOTE: -> cancelMppTasks?) store/copr/mpp.go.267: // NOTE: We do not retry here, because retry is helpless when errors result from TiFlash or Network. If errors occur, the execution on TiFlash will finally stop after some minutes. (godoc-local: NOTE: -> cancelMppTasks?) store/copr/mpp.go.357: // TODO: Test the case that user cancels the query. (godoc-export: TODO: -> Close?) store/copr/mpp.go.357: // TODO: Test the case that user cancels the query. (godoc-export: TODO: -> Close?) store/driver/txn/batch_getter_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package txn?) store/driver/txn/batch_getter_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package txn?) store/driver/txn/batch_getter_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package txn?) store/driver/txn/driver_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package txn?) store/driver/txn/driver_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package txn?) store/driver/txn/driver_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package txn?) store/driver/txn/txn_driver.go.58: // lockWaitTime in ms, except that kv.LockAlwaysWait(0) means always wait lock, kv.LockNowait(-1) means nowait lock (godoc-export: lockWaitTime -> LockKeys?) store/driver/txn/txn_driver.go.58: // lockWaitTime in ms, except that kv.LockAlwaysWait(0) means always wait lock, kv.LockNowait(-1) means nowait lock (godoc-export: lockWaitTime -> LockKeys?) store/driver/txn/txn_driver.go.58: // lockWaitTime in ms, except that kv.LockAlwaysWait(0) means always wait lock, kv.LockNowait(-1) means nowait lock (godoc-export: lockWaitTime -> LockKeys?) store/gcworker/gc_worker.go.411: // calcNewSafePoint uses the current global transaction min start timestamp to calculate the new safe point. (godoc-local: calcNewSafePoint -> calcSafePointByMinStartTS?) store/gcworker/gc_worker.go.411: // calcNewSafePoint uses the current global transaction min start timestamp to calculate the new safe point. (godoc-local: calcNewSafePoint -> calcSafePointByMinStartTS?) store/gcworker/gc_worker.go.954: // Central mode is deprecated in v5.0. This function will always return true. (godoc-local: Central -> checkUseDistributedGC?) store/gcworker/gc_worker.go.954: // Central mode is deprecated in v5.0. This function will always return true. (godoc-local: Central -> checkUseDistributedGC?) store/gcworker/gc_worker.go.1844: // GC placement rules when the partitions are removed by the GC worker. (godoc-local: GC -> doGCPlacementRules?) store/gcworker/gc_worker.go.1844: // GC placement rules when the partitions are removed by the GC worker. (godoc-local: GC -> doGCPlacementRules?) store/gcworker/gc_worker_test.go.193: // The ts that can see the version that should be deleted. (godoc-local: The -> v1Ts?) store/gcworker/gc_worker_test.go.193: // The ts that can see the version that should be deleted. (godoc-local: The -> v1Ts?) store/gcworker/gc_worker_test.go.193: // The ts that can see the version that should be deleted. (godoc-local: The -> v1Ts?) store/gcworker/gc_worker_test.go.193: // The ts that can see the version that should be deleted. (godoc-local: The -> v1Ts?) store/gcworker/gc_worker_test.go.195: // The ts that can see the version that should be kept. (godoc-local: The -> v2Ts?) store/gcworker/gc_worker_test.go.195: // The ts that can see the version that should be kept. (godoc-local: The -> v2Ts?) store/gcworker/gc_worker_test.go.195: // The ts that can see the version that should be kept. (godoc-local: The -> v2Ts?) store/gcworker/gc_worker_test.go.195: // The ts that can see the version that should be kept. (godoc-local: The -> v2Ts?) store/helper/helper.go.606: // IsBefore returns true is x is before [startKey, endKey) (godoc-local: IsBefore -> isBeforeKeyRange?) store/helper/helper.go.606: // IsBefore returns true is x is before [startKey, endKey) (godoc-local: IsBefore -> isBeforeKeyRange?) store/helper/helper.go.611: // IsBehind returns true is x is behind [startKey, endKey) (godoc-local: IsBehind -> isBehindKeyRange?) store/helper/helper.go.611: // IsBehind returns true is x is behind [startKey, endKey) (godoc-local: IsBehind -> isBehindKeyRange?) store/helper/helper.go.619: // for sorting (godoc-local: for -> byRegionStartKey?) store/helper/helper.go.619: // for sorting (godoc-local: for -> byRegionStartKey?) store/helper/helper.go.638: // for sorting (godoc-local: for -> byTableStartKey?) store/helper/helper.go.638: // for sorting (godoc-local: for -> byTableStartKey?) store/helper/helper.go.766: // request PD API, decode the response body into res (godoc-local: request -> requestPD?) store/helper/helper.go.766: // request PD API, decode the response body into res (godoc-local: request -> requestPD?) store/mockstore/mockstorage/storage.go.28: // Wraps tikv.KVStore and make it compatible with kv.Storage. (godoc-local: Wraps -> mockStorage?) store/mockstore/mockstorage/storage.go.28: // Wraps tikv.KVStore and make it compatible with kv.Storage. (godoc-local: Wraps -> mockStorage?) store/mockstore/mockstorage/storage.go.28: // Wraps tikv.KVStore and make it compatible with kv.Storage. (godoc-local: Wraps -> mockStorage?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.72: // Sync all writes to disk. Setting this to true would slow down data loading significantly.") (godoc-export: Sync -> SyncWrite?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.81: // Only used in tests. (godoc-export: Only -> VolatileMode?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.89: // The default and maximum delay in milliseconds before responding to TiDB when pessimistic (godoc-export: The -> WaitForLockTimeout?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/config/config.go.93: // The duration between waking up lock waiter, in milliseconds (godoc-export: The -> WakeUpDelayDuration?) store/mockstore/unistore/cophandler/closure_exec.go.644: // countStarProcess is used for `count(*)`. (godoc-export: countStarProcess -> Process?) store/mockstore/unistore/cophandler/closure_exec.go.644: // countStarProcess is used for `count(*)`. (godoc-export: countStarProcess -> Process?) store/mockstore/unistore/cophandler/closure_exec.go.644: // countStarProcess is used for `count(*)`. (godoc-export: countStarProcess -> Process?) store/mockstore/unistore/cophandler/closure_exec.go.644: // countStarProcess is used for `count(*)`. (godoc-export: countStarProcess -> Process?) store/mockstore/unistore/cophandler/cop_handler_test.go.63: // wrapper of test data, including encoded data, column types etc. (godoc-local: wrapper -> data?) store/mockstore/unistore/cophandler/cop_handler_test.go.63: // wrapper of test data, including encoded data, column types etc. (godoc-local: wrapper -> data?) store/mockstore/unistore/cophandler/cop_handler_test.go.63: // wrapper of test data, including encoded data, column types etc. (godoc-local: wrapper -> data?) store/mockstore/unistore/cophandler/cop_handler_test.go.63: // wrapper of test data, including encoded data, column types etc. (godoc-local: wrapper -> data?) store/mockstore/unistore/cophandler/cop_handler_test.go.153: // convert this key to the smallest key which is larger than the key given. (godoc-local: convert -> convertToPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.153: // convert this key to the smallest key which is larger than the key given. (godoc-local: convert -> convertToPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.153: // convert this key to the smallest key which is larger than the key given. (godoc-local: convert -> convertToPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.153: // convert this key to the smallest key which is larger than the key given. (godoc-local: convert -> convertToPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.173: // return whether these two keys are equal. (godoc-local: return -> isPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.173: // return whether these two keys are equal. (godoc-local: return -> isPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.173: // return whether these two keys are equal. (godoc-local: return -> isPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.173: // return whether these two keys are equal. (godoc-local: return -> isPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.187: // return a dag context according to dagReq and key ranges. (godoc-local: return -> newDagContext?) store/mockstore/unistore/cophandler/cop_handler_test.go.187: // return a dag context according to dagReq and key ranges. (godoc-local: return -> newDagContext?) store/mockstore/unistore/cophandler/cop_handler_test.go.187: // return a dag context according to dagReq and key ranges. (godoc-local: return -> newDagContext?) store/mockstore/unistore/cophandler/cop_handler_test.go.187: // return a dag context according to dagReq and key ranges. (godoc-local: return -> newDagContext?) store/mockstore/unistore/cophandler/cop_handler_test.go.213: // build and execute the executors according to the dagRequest and dagContext, (godoc-local: build -> buildExecutorsAndExecute?) store/mockstore/unistore/cophandler/cop_handler_test.go.213: // build and execute the executors according to the dagRequest and dagContext, (godoc-local: build -> buildExecutorsAndExecute?) store/mockstore/unistore/cophandler/cop_handler_test.go.213: // build and execute the executors according to the dagRequest and dagContext, (godoc-local: build -> buildExecutorsAndExecute?) store/mockstore/unistore/cophandler/cop_handler_test.go.213: // build and execute the executors according to the dagRequest and dagContext, (godoc-local: build -> buildExecutorsAndExecute?) store/mockstore/unistore/cophandler/cop_handler_test.go.238: // return a default dagBuilder (godoc-local: return -> newDagBuilder?) store/mockstore/unistore/cophandler/cop_handler_test.go.238: // return a default dagBuilder (godoc-local: return -> newDagBuilder?) store/mockstore/unistore/cophandler/cop_handler_test.go.238: // return a default dagBuilder (godoc-local: return -> newDagBuilder?) store/mockstore/unistore/cophandler/cop_handler_test.go.238: // return a default dagBuilder (godoc-local: return -> newDagBuilder?) store/mockstore/unistore/cophandler/cop_handler_test.go.290: // see tikv/src/coprocessor/util.rs for more detail (godoc-export: see -> TestIsPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.290: // see tikv/src/coprocessor/util.rs for more detail (godoc-export: see -> TestIsPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.290: // see tikv/src/coprocessor/util.rs for more detail (godoc-export: see -> TestIsPrefixNext?) store/mockstore/unistore/cophandler/cop_handler_test.go.290: // see tikv/src/coprocessor/util.rs for more detail (godoc-export: see -> TestIsPrefixNext?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp.go.355: // When a connect request comes, it contains server task (source) and client task (target), Exchanger dataCh set will find dataCh by client task. (godoc-local: When -> tunnelSetLock?) store/mockstore/unistore/cophandler/mpp_exec.go.40: // mpp executor that only servers for mpp execution (godoc-local: mpp -> mppExec?) store/mockstore/unistore/cophandler/mpp_exec.go.40: // mpp executor that only servers for mpp execution (godoc-local: mpp -> mppExec?) store/mockstore/unistore/cophandler/mpp_exec.go.40: // mpp executor that only servers for mpp execution (godoc-local: mpp -> mppExec?) store/mockstore/unistore/cophandler/mpp_exec.go.40: // mpp executor that only servers for mpp execution (godoc-local: mpp -> mppExec?) store/mockstore/unistore/cophandler/mpp_exec.go.325: // TODO: Let the join support conditions / multiple keys (godoc-local: TODO: -> joinExec?) store/mockstore/unistore/cophandler/mpp_exec.go.325: // TODO: Let the join support conditions / multiple keys (godoc-local: TODO: -> joinExec?) store/mockstore/unistore/cophandler/mpp_exec.go.325: // TODO: Let the join support conditions / multiple keys (godoc-local: TODO: -> joinExec?) store/mockstore/unistore/cophandler/mpp_exec.go.325: // TODO: Let the join support conditions / multiple keys (godoc-local: TODO: -> joinExec?) store/mockstore/unistore/cophandler/mpp_exec.go.346: // align the types of join keys and build keys (godoc-local: align -> comKeyTp?) store/mockstore/unistore/cophandler/mpp_exec.go.346: // align the types of join keys and build keys (godoc-local: align -> comKeyTp?) store/mockstore/unistore/cophandler/mpp_exec.go.346: // align the types of join keys and build keys (godoc-local: align -> comKeyTp?) store/mockstore/unistore/cophandler/mpp_exec.go.346: // align the types of join keys and build keys (godoc-local: align -> comKeyTp?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.33: // We only consume 2 bits for a random height call. (godoc-local: We -> rand?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/lockstore/lockstore.go.54: // node is a variable length struct. (godoc-local: node -> nextsBase?) store/mockstore/unistore/tikv/detector.go.50: //txns []txnKeyHashPair (godoc-local: []txnKeyHashPair -> txns?) store/mockstore/unistore/tikv/detector.go.50: //txns []txnKeyHashPair (godoc-local: []txnKeyHashPair -> txns?) store/mockstore/unistore/tikv/detector.go.50: //txns []txnKeyHashPair (godoc-local: []txnKeyHashPair -> txns?) store/mockstore/unistore/tikv/detector.go.50: //txns []txnKeyHashPair (godoc-local: []txnKeyHashPair -> txns?) store/mockstore/unistore/tikv/mock_region.go.60: // used for mpp test (godoc-local: used -> mppTaskSet?) store/mockstore/unistore/tikv/mock_region.go.60: // used for mpp test (godoc-local: used -> mppTaskSet?) store/mockstore/unistore/tikv/mock_region.go.60: // used for mpp test (godoc-local: used -> mppTaskSet?) store/mockstore/unistore/tikv/mock_region.go.60: // used for mpp test (godoc-local: used -> mppTaskSet?) store/mockstore/unistore/tikv/mvcc.go.1592: // 'm' + 1 = 'n' (godoc-local: 'm' -> metaExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1592: // 'm' + 1 = 'n' (godoc-local: 'm' -> metaExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1592: // 'm' + 1 = 'n' (godoc-local: 'm' -> metaExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1592: // 'm' + 1 = 'n' (godoc-local: 'm' -> metaExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1595: // 't' + 1 = 'u (godoc-local: 't' -> tableExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1595: // 't' + 1 = 'u (godoc-local: 't' -> tableExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1595: // 't' + 1 = 'u (godoc-local: 't' -> tableExtraPrefix?) store/mockstore/unistore/tikv/mvcc.go.1595: // 't' + 1 = 'u (godoc-local: 't' -> tableExtraPrefix?) store/mockstore/unistore/tikv/region.go.504: // initSplit splits the cluster into multiple regions. (godoc-local: initSplit -> initialSplit?) store/mockstore/unistore/tikv/region.go.504: // initSplit splits the cluster into multiple regions. (godoc-local: initSplit -> initialSplit?) store/mockstore/unistore/tikv/region.go.504: // initSplit splits the cluster into multiple regions. (godoc-local: initSplit -> initialSplit?) store/mockstore/unistore/tikv/region.go.504: // initSplit splits the cluster into multiple regions. (godoc-local: initSplit -> initialSplit?) store/mockstore/unistore/tikv/server.go.130: // For read-only requests that doesn't acquire latches, this function must be called after all locks has been checked. (godoc-local: For -> getDBReader?) store/mockstore/unistore/tikv/server.go.130: // For read-only requests that doesn't acquire latches, this function must be called after all locks has been checked. (godoc-local: For -> getDBReader?) store/mockstore/unistore/tikv/server.go.130: // For read-only requests that doesn't acquire latches, this function must be called after all locks has been checked. (godoc-local: For -> getDBReader?) store/mockstore/unistore/tikv/server.go.130: // For read-only requests that doesn't acquire latches, this function must be called after all locks has been checked. (godoc-local: For -> getDBReader?) store/mockstore/unistore/tikv/util.go.32: // SortAndDedupHashVals will change hashVals into sort ascending order and remove duplicates (godoc-local: SortAndDedupHashVals -> sortAndDedupHashVals?) store/mockstore/unistore/tikv/util.go.32: // SortAndDedupHashVals will change hashVals into sort ascending order and remove duplicates (godoc-local: SortAndDedupHashVals -> sortAndDedupHashVals?) store/mockstore/unistore/tikv/util.go.32: // SortAndDedupHashVals will change hashVals into sort ascending order and remove duplicates (godoc-local: SortAndDedupHashVals -> sortAndDedupHashVals?) store/mockstore/unistore/tikv/util.go.32: // SortAndDedupHashVals will change hashVals into sort ascending order and remove duplicates (godoc-local: SortAndDedupHashVals -> sortAndDedupHashVals?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) store/mockstore/unistore/util/lockwaiter/lockwaiter.go.95: // WakeupSleepTime, -1 means the wait is already timeout, 0 means the lock will be granted to this waiter (godoc-export: WakeupSleepTime, -> WakeupSleepTime?) structure/type.go.54: // nolint:unused (godoc-local: nolint:unused -> encodeHashMetaKey?) table/column.go.49: // If this column is a generated column, the expression will be stored here. (godoc-export: If -> GeneratedExpr?) table/column.go.49: // If this column is a generated column, the expression will be stored here. (godoc-export: If -> GeneratedExpr?) table/column.go.51: // If this column has default expr value, this expression will be stored here. (godoc-export: If -> DefaultExpr?) table/column.go.51: // If this column has default expr value, this expression will be stored here. (godoc-export: If -> DefaultExpr?) table/tables/partition.go.136: // UpperBounds: (x < y1); (x < y2); (x < y3), used by locatePartition. (godoc-export: UpperBounds: -> UpperBounds?) table/tables/partition.go.136: // UpperBounds: (x < y1); (x < y2); (x < y3), used by locatePartition. (godoc-export: UpperBounds: -> UpperBounds?) table/tables/partition.go.146: // ColOffset is the offsets of partition columns. (godoc-export: ColOffset -> ColumnOffset?) table/tables/partition.go.146: // ColOffset is the offsets of partition columns. (godoc-export: ColOffset -> ColumnOffset?) table/tables/partition.go.148: // InValues: x in (1,2); x in (3,4); x in (5,6), used for list partition. (godoc-export: InValues: -> InValues?) table/tables/partition.go.148: // InValues: x in (1,2); x in (3,4); x in (5,6), used for list partition. (godoc-export: InValues: -> InValues?) table/tables/partition.go.222: // For list columns partition pruning (godoc-export: For -> ColPrunes?) table/tables/partition.go.222: // For list columns partition pruning (godoc-export: For -> ColPrunes?) table/tables/partition.go.259: // Such as: list columns (a,b) (partition p0 values in ((1,5),(1,6))); (godoc-export: Such -> PartIdx?) table/tables/partition.go.259: // Such as: list columns (a,b) (partition p0 values in ((1,5),(1,6))); (godoc-export: Such -> PartIdx?) table/tables/partition.go.259: // Such as: list columns (a,b) (partition p0 values in ((1,5),(1,6))); (godoc-export: Such -> PartIdx?) table/tables/partition.go.259: // Such as: list columns (a,b) (partition p0 values in ((1,5),(1,6))); (godoc-export: Such -> PartIdx?) table/tables/partition.go.752: // buildListPartitionValueMapAndSorted builds list columns partition value map for the specified column. (godoc-local: buildListPartitionValueMapAndSorted -> buildPartitionValueMapAndSorted?) table/tables/partition.go.752: // buildListPartitionValueMapAndSorted builds list columns partition value map for the specified column. (godoc-local: buildListPartitionValueMapAndSorted -> buildPartitionValueMapAndSorted?) table/tables/partition.go.1029: // TODO: supports linear hashing (godoc-local: TODO: -> locateHashPartition?) table/tables/partition.go.1029: // TODO: supports linear hashing (godoc-local: TODO: -> locateHashPartition?) table/tables/partition_test.go.450: // issue 24880 (godoc-export: issue -> TestRangePartitionUnderNoUnsignedSub?) table/tables/partition_test.go.450: // issue 24880 (godoc-export: issue -> TestRangePartitionUnderNoUnsignedSub?) table/tables/tables.go.604: // The size of a temporary table is calculated by accumulating the transaction size delta. (godoc-local: The -> handleTempTableSize?) table/tables/tables.go.604: // The size of a temporary table is calculated by accumulating the transaction size delta. (godoc-local: The -> handleTempTableSize?) table/tables/tables.go.1563: // base < end when increment > 0. (godoc-local: base -> end?) table/tables/tables.go.1563: // base < end when increment > 0. (godoc-local: base -> end?) table/tables/tables.go.1563: // base < end when increment > 0. (godoc-local: base -> end?) table/tables/tables.go.1563: // base < end when increment > 0. (godoc-local: base -> end?) table/tables/tables.go.1825: // Whether it's modified in this transaction. (godoc-local: Whether -> modified?) table/tables/tables.go.1825: // Whether it's modified in this transaction. (godoc-local: Whether -> modified?) table/tables/tables.go.1825: // Whether it's modified in this transaction. (godoc-local: Whether -> modified?) table/tables/tables.go.1825: // Whether it's modified in this transaction. (godoc-local: Whether -> modified?) table/tables/tables.go.1827: // The stats of this table. So far it's always pseudo stats. (godoc-local: The -> stats?) table/tables/tables.go.1827: // The stats of this table. So far it's always pseudo stats. (godoc-local: The -> stats?) table/tables/tables.go.1829: // The autoID allocator of this table. (godoc-local: The -> autoIDAllocator?) table/tables/tables.go.1829: // The autoID allocator of this table. (godoc-local: The -> autoIDAllocator?) table/tables/tables.go.1829: // The autoID allocator of this table. (godoc-local: The -> autoIDAllocator?) table/tables/tables.go.1829: // The autoID allocator of this table. (godoc-local: The -> autoIDAllocator?) table/tables/tables.go.1831: // Table size. (godoc-local: Table -> size?) table/tables/tables.go.1831: // Table size. (godoc-local: Table -> size?) table/tables/tables.go.1831: // Table size. (godoc-local: Table -> size?) table/tables/tables.go.1831: // Table size. (godoc-local: Table -> size?) tablecodec/tablecodec_test.go.541: // Bench result: (godoc-export: Bench -> BenchmarkEncodeValue?) telemetry/data_feature_usage.go.31: // transaction usage information (godoc-export: transaction -> Txn?) telemetry/data_feature_usage.go.33: // cluster index usage information (godoc-export: cluster -> ClusterIndex?) telemetry/data_feature_usage.go.177: // ResetCTEUsage resets CTE usages. (godoc-local: ResetCTEUsage -> postReportCTEUsage?) telemetry/data_feature_usage_test.go.1: // Copyright 2021 PingCAP, Inc. (godoc-export: Copyright -> // Package telemetry_test?) telemetry/data_slow_query.go.34: // Slow Query statistic buckets (godoc-export: Slow -> SQBInfo?) telemetry/data_telemetry_host_extra.go.21: // Some information that is not included in current system tables. There is no easy way to retrieve information (godoc-local: Some -> telemetryHostExtraInfo?) telemetry/util.go.61: // See https://stackoverflow.com/a/58026884 (godoc-local: See -> sortedStringContains?) types/core_time.go.298: // calcTimeDiff calculates difference between two datetime values as seconds + microseconds. (godoc-local: calcTimeDiff -> calcTimeTimeDiff?) types/core_time.go.304: // calcTimeDiff calculates difference between a datetime value and a duration as seconds + microseconds. (godoc-local: calcTimeDiff -> calcTimeDurationDiff?) types/helper.go.111: // Returns true if the given byte is an ASCII punctuation character (printable and non-alphanumeric). (godoc-local: Returns -> isPunctuation?) types/json/binary_functions.go.646: // compareFloat64 returns an integer comparing the float64 x to y, (godoc-local: compareFloat64 -> compareFloat64PrecisionLoss?) types/json/binary_functions.go.646: // compareFloat64 returns an integer comparing the float64 x to y, (godoc-local: compareFloat64 -> compareFloat64PrecisionLoss?) types/json/binary_functions.go.1103: // extractCallbackFn: the type of CALLBACK function for extractToCallback (godoc-local: extractCallbackFn: -> extractCallbackFn?) types/json/binary_functions.go.1103: // extractCallbackFn: the type of CALLBACK function for extractToCallback (godoc-local: extractCallbackFn: -> extractCallbackFn?) types/json/binary_functions.go.1106: // extractToCallback: callback alternative of extractTo (godoc-local: extractToCallback: -> extractToCallback?) types/json/binary_functions.go.1106: // extractToCallback: callback alternative of extractTo (godoc-local: extractToCallback: -> extractToCallback?) types/json/binary_functions_test.go.1: // Copyright 2019 PingCAP, Inc. (godoc-export: Copyright -> // Package json?) types/json/binary_functions_test.go.1: // Copyright 2019 PingCAP, Inc. (godoc-export: Copyright -> // Package json?) types/mydecimal.go.55: // Truncate just truncates the decimal. (godoc-export: Truncate -> ModeTruncate?) types/mydecimal.go.57: // Ceiling is not supported now. (godoc-local: Ceiling -> modeCeiling?) types/mydecimal.go.115: // get the zero of MyDecimal with the specified result fraction digits (godoc-local: get -> zeroMyDecimalWithFrac?) types/mydecimal_test.go.304: // this test will change global variable `wordBufLen`, so it must run in serial (godoc-export: this -> TestShift?) types/mydecimal_test.go.526: // this test will change global variable `wordBufLen`, so it must run in serial (godoc-export: this -> TestFromString?) types/parser_driver/special_cmt_ctrl.go.23: // To add new features that needs to be downgrade-compatible, (godoc-local: To -> init?) types/parser_driver/special_cmt_ctrl.go.23: // To add new features that needs to be downgrade-compatible, (godoc-local: To -> init?) types/time.go.782: // helper for date part splitting, punctuation characters are valid separators anywhere, (godoc-local: helper -> isValidSeparator?) types/time.go.891: // See https://dev.mysql.com/doc/refman/5.7/en/date-and-time-literals.html. (godoc-local: See -> splitDateTime?) types/time.go.919: // See https://dev.mysql.com/doc/refman/5.7/en/date-and-time-literals.html. (godoc-local: See -> parseDatetime?) util/chunk/disk_test.go.240: // Following diagram describes the testdata we use to test: (godoc-local: Following -> testReaderWithCache?) util/chunk/disk_test.go.240: // Following diagram describes the testdata we use to test: (godoc-local: Following -> testReaderWithCache?) util/chunk/disk_test.go.331: // Here we test situations where size of data is small, so no data is flushed to disk. (godoc-local: Here -> testReaderWithCacheNoFlush?) util/chunk/disk_test.go.331: // Here we test situations where size of data is small, so no data is flushed to disk. (godoc-local: Here -> testReaderWithCacheNoFlush?) util/chunk/row_container.go.34: // RWMutex guarantees spill and get operator for rowContainer is mutually exclusive. (godoc-local: RWMutex -> sync?) util/chunk/row_container.go.34: // RWMutex guarantees spill and get operator for rowContainer is mutually exclusive. (godoc-local: RWMutex -> sync?) util/chunk/row_container.go.268: // test function only used for test sync. (godoc-local: test -> testSyncInputFunc?) util/chunk/row_container.go.268: // test function only used for test sync. (godoc-local: test -> testSyncInputFunc?) util/collate/bin.go.67: // Compile implements WildcardPattern interface. (godoc-export: Compile -> DoMatch?) util/collate/bin.go.67: // Compile implements WildcardPattern interface. (godoc-export: Compile -> DoMatch?) util/collate/collate.go.269: // decode rune by hand (godoc-local: decode -> decodeRune?) util/collate/collate.go.269: // decode rune by hand (godoc-local: decode -> decodeRune?) util/collate/general_ci.go.70: // Compile implements WildcardPattern interface. (godoc-export: Compile -> DoMatch?) util/collate/general_ci.go.70: // Compile implements WildcardPattern interface. (godoc-export: Compile -> DoMatch?) util/collate/pinyin_tidb_as_cs.go.16: // Collation of utf8mb4_zh_pinyin_tidb_as_cs (godoc-local: Collation -> zhPinyinTiDBASCSCollator?) util/collate/pinyin_tidb_as_cs.go.16: // Collation of utf8mb4_zh_pinyin_tidb_as_cs (godoc-local: Collation -> zhPinyinTiDBASCSCollator?) util/collate/pinyin_tidb_as_cs.go.20: // Collator interface, no implements now. (godoc-export: Collator -> Compare?) util/collate/pinyin_tidb_as_cs.go.20: // Collator interface, no implements now. (godoc-export: Collator -> Compare?) util/collate/pinyin_tidb_as_cs.go.25: // Collator interface, no implements now. (godoc-export: Collator -> Key?) util/collate/pinyin_tidb_as_cs.go.25: // Collator interface, no implements now. (godoc-export: Collator -> Key?) util/collate/pinyin_tidb_as_cs.go.30: // Collator interface, no implements now. (godoc-export: Collator -> Pattern?) util/collate/pinyin_tidb_as_cs.go.30: // Collator interface, no implements now. (godoc-export: Collator -> Pattern?) util/collate/unicode_ci.go.21: // magic number indicate weight has 2 uint64, should get from `longRuneMap` (godoc-local: magic -> longRune?) util/collate/unicode_ci.go.21: // magic number indicate weight has 2 uint64, should get from `longRuneMap` (godoc-local: magic -> longRune?) util/collate/unicode_ci.go.108: // convert rune to weights. (godoc-local: convert -> convertRuneUnicodeCI?) util/collate/unicode_ci.go.108: // convert rune to weights. (godoc-local: convert -> convertRuneUnicodeCI?) util/cteutil/storage.go.39: // If is first called, will open underlying storage. Otherwise will add ref count by one. (godoc-export: If -> OpenAndRef?) util/cteutil/storage.go.39: // If is first called, will open underlying storage. Otherwise will add ref count by one. (godoc-export: If -> OpenAndRef?) util/cteutil/storage.go.42: // Minus ref count by one, if ref count is zero, close underlying storage. (godoc-export: Minus -> DerefAndClose?) util/cteutil/storage.go.42: // Minus ref count by one, if ref count is zero, close underlying storage. (godoc-export: Minus -> DerefAndClose?) util/cteutil/storage.go.57: // Get Chunk by index. (godoc-export: Get -> GetChunk?) util/cteutil/storage.go.57: // Get Chunk by index. (godoc-export: Get -> GetChunk?) util/cteutil/storage.go.60: // Get row by RowPtr. (godoc-export: Get -> GetRow?) util/cteutil/storage.go.60: // Get row by RowPtr. (godoc-export: Get -> GetRow?) util/cteutil/storage.go.69: // Storage is not thread-safe. (godoc-export: Storage -> Lock?) util/cteutil/storage.go.69: // Storage is not thread-safe. (godoc-export: Storage -> Lock?) util/cteutil/storage.go.74: // Usually, Storage is filled first, then user can read it. (godoc-export: Usually, -> Done?) util/cteutil/storage.go.74: // Usually, Storage is filled first, then user can read it. (godoc-export: Usually, -> Done?) util/cteutil/storage.go.79: // Readers use iter information to determine (godoc-export: Readers -> SetIter?) util/cteutil/storage.go.79: // Readers use iter information to determine (godoc-export: Readers -> SetIter?) util/cteutil/storage.go.84: // We use this channel to notify reader that Storage is ready to read. (godoc-export: We -> GetBegCh?) util/cteutil/storage.go.84: // We use this channel to notify reader that Storage is ready to read. (godoc-export: We -> GetBegCh?) util/deadlockhistory/deadlock_history.go.41: // The ID doesn't need to be set manually and it's set when it's added into the DeadlockHistory by invoking its Push (godoc-export: The -> ID?) util/deadlockhistory/deadlock_history.go.41: // The ID doesn't need to be set manually and it's set when it's added into the DeadlockHistory by invoking its Push (godoc-export: The -> ID?) util/deadlockhistory/deadlock_history.go.41: // The ID doesn't need to be set manually and it's set when it's added into the DeadlockHistory by invoking its Push (godoc-export: The -> ID?) util/deadlockhistory/deadlock_history.go.41: // The ID doesn't need to be set manually and it's set when it's added into the DeadlockHistory by invoking its Push (godoc-export: The -> ID?) util/deadlockhistory/deadlock_history.go.55: // The `head` and `size` makes the `deadlocks` array behaves like a deque. The valid elements are (godoc-local: The -> head?) util/deadlockhistory/deadlock_history.go.55: // The `head` and `size` makes the `deadlocks` array behaves like a deque. The valid elements are (godoc-local: The -> head?) util/deadlockhistory/deadlock_history.go.55: // The `head` and `size` makes the `deadlocks` array behaves like a deque. The valid elements are (godoc-local: The -> head?) util/deadlockhistory/deadlock_history.go.55: // The `head` and `size` makes the `deadlocks` array behaves like a deque. The valid elements are (godoc-local: The -> head?) util/execdetails/execdetails.go.321: // do not use kv.StoreType because it will meet cycle import error (godoc-local: do -> storeType?) util/execdetails/execdetails.go.321: // do not use kv.StoreType because it will meet cycle import error (godoc-local: do -> storeType?) util/execdetails/execdetails.go.321: // do not use kv.StoreType because it will meet cycle import error (godoc-local: do -> storeType?) util/execdetails/execdetails.go.321: // do not use kv.StoreType because it will meet cycle import error (godoc-local: do -> storeType?) util/execdetails/execdetails.go.439: // executor's Next() called times. (godoc-local: executor's -> loop?) util/execdetails/execdetails.go.439: // executor's Next() called times. (godoc-local: executor's -> loop?) util/execdetails/execdetails.go.439: // executor's Next() called times. (godoc-local: executor's -> loop?) util/execdetails/execdetails.go.439: // executor's Next() called times. (godoc-local: executor's -> loop?) util/execdetails/execdetails.go.441: // executor consume time. (godoc-local: executor -> consume?) util/execdetails/execdetails.go.441: // executor consume time. (godoc-local: executor -> consume?) util/execdetails/execdetails.go.441: // executor consume time. (godoc-local: executor -> consume?) util/execdetails/execdetails.go.441: // executor consume time. (godoc-local: executor -> consume?) util/execdetails/execdetails.go.443: // executor return row count. (godoc-local: executor -> rows?) util/execdetails/execdetails.go.443: // executor return row count. (godoc-local: executor -> rows?) util/execdetails/execdetails.go.443: // executor return row count. (godoc-local: executor -> rows?) util/execdetails/execdetails.go.443: // executor return row count. (godoc-local: executor -> rows?) util/execdetails/execdetails.go.703: // protect concurrency (godoc-local: protect -> sync?) util/execdetails/execdetails.go.703: // protect concurrency (godoc-local: protect -> sync?) util/execdetails/execdetails.go.705: // executor concurrency information (godoc-local: executor -> concurrency?) util/execdetails/execdetails.go.705: // executor concurrency information (godoc-local: executor -> concurrency?) util/expensivequery/memory_usage_alarm.go.87: // If Performance.ServerMemoryQuota is set, use `ServerMemoryQuota * MemoryUsageAlarmRatio` to check oom risk. (godoc-local: If -> alarm4ExcessiveMemUsage?) util/expensivequery/memory_usage_alarm.go.87: // If Performance.ServerMemoryQuota is set, use `ServerMemoryQuota * MemoryUsageAlarmRatio` to check oom risk. (godoc-local: If -> alarm4ExcessiveMemUsage?) util/hint/hint_processor.go.411: // getBlockName finds the offset of query block name. It uses 0 as offset for top level update or delete, (godoc-local: getBlockName -> getBlockOffset?) util/hint/hint_processor.go.411: // getBlockName finds the offset of query block name. It uses 0 as offset for top level update or delete, (godoc-local: getBlockName -> getBlockOffset?) util/kvcache/simple_lru.go.56: // 0 indicates no quota (godoc-local: 0 -> quota?) util/kvcache/simple_lru.go.56: // 0 indicates no quota (godoc-local: 0 -> quota?) util/kvcache/simple_lru.go.56: // 0 indicates no quota (godoc-local: 0 -> quota?) util/kvcache/simple_lru.go.56: // 0 indicates no quota (godoc-local: 0 -> quota?) util/localpool/localpool_test.go.28: // nolint:unused (godoc-local: nolint:unused -> val?) util/localpool/localpool_test.go.28: // nolint:unused (godoc-local: nolint:unused -> val?) util/localpool/localpool_test.go.28: // nolint:unused (godoc-local: nolint:unused -> val?) util/localpool/localpool_test.go.28: // nolint:unused (godoc-local: nolint:unused -> val?) util/memory/meminfo.go.153: // refer to https://github.com/containerd/cgroups/blob/318312a373405e5e91134d8063d04d59768a1bff/utils.go#L251 (godoc-local: refer -> parseUint?) util/memory/meminfo.go.153: // refer to https://github.com/containerd/cgroups/blob/318312a373405e5e91134d8063d04d59768a1bff/utils.go#L251 (godoc-local: refer -> parseUint?) util/memory/meminfo.go.172: // refer to https://github.com/containerd/cgroups/blob/318312a373405e5e91134d8063d04d59768a1bff/utils.go#L243 (godoc-local: refer -> readUint?) util/memory/meminfo.go.172: // refer to https://github.com/containerd/cgroups/blob/318312a373405e5e91134d8063d04d59768a1bff/utils.go#L243 (godoc-local: refer -> readUint?) util/memory/tracker.go.56: // The children memory trackers. If the Tracker is the Global Tracker, like executor.GlobalDiskUsageTracker, (godoc-local: The -> children?) util/memory/tracker.go.56: // The children memory trackers. If the Tracker is the Global Tracker, like executor.GlobalDiskUsageTracker, (godoc-local: The -> children?) util/ranger/detacher.go.414: // If there exists an interval whose length is large than 0, return nil. Otherwise remove all unsatisfiable intervals (godoc-local: If -> allSinglePoints?) util/ranger/detacher.go.414: // If there exists an interval whose length is large than 0, return nil. Otherwise remove all unsatisfiable intervals (godoc-local: If -> allSinglePoints?) util/ranger/points.go.48: // Point is the end point of range interval. (godoc-local: Point -> point?) util/ranger/points.go.48: // Point is the end point of range interval. (godoc-local: Point -> point?) util/ranger/ranger.go.540: // We cannot use the FieldType of column directly. e.g. the column a is int32 and we have a > 1111111111111111111. (godoc-local: We -> newFieldType?) util/ranger/ranger.go.540: // We cannot use the FieldType of column directly. e.g. the column a is int32 and we have a > 1111111111111111111. (godoc-local: We -> newFieldType?) util/ranger/ranger_test.go.674: // for issue #6661 (godoc-export: for -> TestIndexRangeForUnsignedAndOverflow?) util/ranger/ranger_test.go.674: // for issue #6661 (godoc-export: for -> TestIndexRangeForUnsignedAndOverflow?) util/ranger/ranger_test.go.1653: // For https://github.com/pingcap/tidb/issues/22032 (godoc-export: For -> TestPrefixIndexRangeScan?) util/ranger/ranger_test.go.1653: // For https://github.com/pingcap/tidb/issues/22032 (godoc-export: For -> TestPrefixIndexRangeScan?) util/rowcodec/row.go.22: // small: colID []byte, offsets []uint16, optimized for most cases. (godoc-local: small: -> large?) util/rowcodec/row.go.22: // small: colID []byte, offsets []uint16, optimized for most cases. (godoc-local: small: -> large?) util/rowcodec/row.go.22: // small: colID []byte, offsets []uint16, optimized for most cases. (godoc-local: small: -> large?) util/rowcodec/row.go.22: // small: colID []byte, offsets []uint16, optimized for most cases. (godoc-local: small: -> large?) util/rowcodec/row.go.32: // for large row (godoc-local: for -> colIDs32?) util/rowcodec/row.go.32: // for large row (godoc-local: for -> colIDs32?) util/stmtsummary/evicted.go.29: // record evicted data in intervals (godoc-local: record -> history?) util/stmtsummary/evicted.go.29: // record evicted data in intervals (godoc-local: record -> history?) util/stmtsummary/evicted.go.34: // element being stored in stmtSummaryByDigestEvicted (godoc-local: element -> stmtSummaryByDigestEvictedElement?) util/stmtsummary/evicted.go.34: // element being stored in stmtSummaryByDigestEvicted (godoc-local: element -> stmtSummaryByDigestEvictedElement?) util/stmtsummary/evicted.go.46: // spawn a new pointer to stmtSummaryByDigestEvicted (godoc-local: spawn -> newStmtSummaryByDigestEvicted?) util/stmtsummary/evicted.go.46: // spawn a new pointer to stmtSummaryByDigestEvicted (godoc-local: spawn -> newStmtSummaryByDigestEvicted?) util/stmtsummary/evicted.go.53: // spawn a new pointer to stmtSummaryByDigestEvictedElement (godoc-local: spawn -> newStmtSummaryByDigestEvictedElement?) util/stmtsummary/evicted.go.53: // spawn a new pointer to stmtSummaryByDigestEvictedElement (godoc-local: spawn -> newStmtSummaryByDigestEvictedElement?) util/stmtsummary/evicted.go.154: // add an evicted record to stmtSummaryByDigestEvictedElement (godoc-local: add -> addEvicted?) util/stmtsummary/evicted.go.154: // add an evicted record to stmtSummaryByDigestEvictedElement (godoc-local: add -> addEvicted?) util/stmtsummary/evicted_test.go.29: // fake a stmtSummaryByDigest (godoc-local: fake -> newInduceSsbd?) util/stmtsummary/evicted_test.go.29: // fake a stmtSummaryByDigest (godoc-local: fake -> newInduceSsbd?) util/stmtsummary/evicted_test.go.38: // fake a stmtSummaryByDigestElement (godoc-local: fake -> newInduceSsbde?) util/stmtsummary/evicted_test.go.38: // fake a stmtSummaryByDigestElement (godoc-local: fake -> newInduceSsbde?) util/stmtsummary/evicted_test.go.48: // generate new stmtSummaryByDigestKey and stmtSummaryByDigest (godoc-local: generate -> generateStmtSummaryByDigestKeyValue?) util/stmtsummary/evicted_test.go.48: // generate new stmtSummaryByDigestKey and stmtSummaryByDigest (godoc-local: generate -> generateStmtSummaryByDigestKeyValue?) util/stmtsummary/evicted_test.go.57: // Test stmtSummaryByDigestMap.ToEvictedCountDatum (godoc-export: Test -> TestMapToEvictedCountDatum?) util/stmtsummary/evicted_test.go.57: // Test stmtSummaryByDigestMap.ToEvictedCountDatum (godoc-export: Test -> TestMapToEvictedCountDatum?) util/stmtsummary/evicted_test.go.140: // Test stmtSummaryByDigestEvicted (godoc-export: Test -> TestSimpleStmtSummaryByDigestEvicted?) util/stmtsummary/evicted_test.go.140: // Test stmtSummaryByDigestEvicted (godoc-export: Test -> TestSimpleStmtSummaryByDigestEvicted?) util/stmtsummary/evicted_test.go.218: // Test stmtSummaryByDigestEvictedElement.ToEvictedCountDatum (godoc-export: Test -> TestStmtSummaryByDigestEvictedElement?) util/stmtsummary/evicted_test.go.218: // Test stmtSummaryByDigestEvictedElement.ToEvictedCountDatum (godoc-export: Test -> TestStmtSummaryByDigestEvictedElement?) util/stmtsummary/evicted_test.go.245: // test stmtSummaryByDigestEvicted.addEvicted (godoc-export: test -> TestEvictedCountDetailed?) util/stmtsummary/evicted_test.go.245: // test stmtSummaryByDigestEvicted.addEvicted (godoc-export: test -> TestEvictedCountDetailed?) util/stmtsummary/evicted_test.go.325: // test addInfo function (godoc-export: test -> TestAddInfo?) util/stmtsummary/evicted_test.go.325: // test addInfo function (godoc-export: test -> TestAddInfo?) util/stmtsummary/statement_summary.go.36: // Same statements may appear in different schema, but they refer to different tables. (godoc-local: Same -> schemaName?) util/stmtsummary/statement_summary.go.36: // Same statements may appear in different schema, but they refer to different tables. (godoc-local: Same -> schemaName?) util/stmtsummary/statement_summary.go.36: // Same statements may appear in different schema, but they refer to different tables. (godoc-local: Same -> schemaName?) util/stmtsummary/statement_summary.go.36: // Same statements may appear in different schema, but they refer to different tables. (godoc-local: Same -> schemaName?) util/stmtsummary/statement_summary.go.39: // The digest of the previous statement. (godoc-local: The -> prevDigest?) util/stmtsummary/statement_summary.go.39: // The digest of the previous statement. (godoc-local: The -> prevDigest?) util/stmtsummary/statement_summary.go.39: // The digest of the previous statement. (godoc-local: The -> prevDigest?) util/stmtsummary/statement_summary.go.39: // The digest of the previous statement. (godoc-local: The -> prevDigest?) util/stmtsummary/statement_summary.go.41: // The digest of the plan of this SQL. (godoc-local: The -> planDigest?) util/stmtsummary/statement_summary.go.41: // The digest of the plan of this SQL. (godoc-local: The -> planDigest?) util/stmtsummary/statement_summary.go.41: // The digest of the plan of this SQL. (godoc-local: The -> planDigest?) util/stmtsummary/statement_summary.go.41: // The digest of the plan of this SQL. (godoc-local: The -> planDigest?) util/stmtsummary/statement_summary.go.43: // `hash` is the hash value of this object. (godoc-local: `hash` -> hash?) util/stmtsummary/statement_summary.go.43: // `hash` is the hash value of this object. (godoc-local: `hash` -> hash?) util/stmtsummary/statement_summary.go.63: // It's rare to read concurrently, so RWMutex is not needed. (godoc-local: It's -> sync?) util/stmtsummary/statement_summary.go.63: // It's rare to read concurrently, so RWMutex is not needed. (godoc-local: It's -> sync?) util/stmtsummary/statement_summary.go.81: // It's rare to read concurrently, so RWMutex is not needed. (godoc-local: It's -> sync?) util/stmtsummary/statement_summary.go.81: // It's rare to read concurrently, so RWMutex is not needed. (godoc-local: It's -> sync?) util/stmtsummary/statement_summary.go.85: // Each element in history is a summary in one interval. (godoc-local: Each -> history?) util/stmtsummary/statement_summary.go.85: // Each element in history is a summary in one interval. (godoc-local: Each -> history?) util/stmtsummary/statement_summary.go.87: // Following fields are common for each summary element. (godoc-local: Following -> schemaName?) util/stmtsummary/statement_summary.go.87: // Following fields are common for each summary element. (godoc-local: Following -> schemaName?) util/stmtsummary/statement_summary.go.87: // Following fields are common for each summary element. (godoc-local: Following -> schemaName?) util/stmtsummary/statement_summary.go.87: // Following fields are common for each summary element. (godoc-local: Following -> schemaName?) util/stmtsummary/statement_summary.go.101: // Each summary is summarized between [beginTime, endTime). (godoc-local: Each -> beginTime?) util/stmtsummary/statement_summary.go.101: // Each summary is summarized between [beginTime, endTime). (godoc-local: Each -> beginTime?) util/stmtsummary/statement_summary.go.101: // Each summary is summarized between [beginTime, endTime). (godoc-local: Each -> beginTime?) util/stmtsummary/statement_summary.go.101: // Each summary is summarized between [beginTime, endTime). (godoc-local: Each -> beginTime?) util/stmtsummary/statement_summary.go.104: // basic (godoc-local: basic -> sampleSQL?) util/stmtsummary/statement_summary.go.104: // basic (godoc-local: basic -> sampleSQL?) util/stmtsummary/statement_summary.go.104: // basic (godoc-local: basic -> sampleSQL?) util/stmtsummary/statement_summary.go.104: // basic (godoc-local: basic -> sampleSQL?) util/stmtsummary/statement_summary.go.115: // latency (godoc-local: latency -> sumLatency?) util/stmtsummary/statement_summary.go.115: // latency (godoc-local: latency -> sumLatency?) util/stmtsummary/statement_summary.go.115: // latency (godoc-local: latency -> sumLatency?) util/stmtsummary/statement_summary.go.115: // latency (godoc-local: latency -> sumLatency?) util/stmtsummary/statement_summary.go.123: // coprocessor (godoc-local: coprocessor -> sumNumCopTasks?) util/stmtsummary/statement_summary.go.123: // coprocessor (godoc-local: coprocessor -> sumNumCopTasks?) util/stmtsummary/statement_summary.go.123: // coprocessor (godoc-local: coprocessor -> sumNumCopTasks?) util/stmtsummary/statement_summary.go.123: // coprocessor (godoc-local: coprocessor -> sumNumCopTasks?) util/stmtsummary/statement_summary.go.129: // TiKV (godoc-local: TiKV -> sumProcessTime?) util/stmtsummary/statement_summary.go.129: // TiKV (godoc-local: TiKV -> sumProcessTime?) util/stmtsummary/statement_summary.go.129: // TiKV (godoc-local: TiKV -> sumProcessTime?) util/stmtsummary/statement_summary.go.129: // TiKV (godoc-local: TiKV -> sumProcessTime?) util/stmtsummary/statement_summary.go.150: // txn (godoc-local: txn -> commitCount?) util/stmtsummary/statement_summary.go.150: // txn (godoc-local: txn -> commitCount?) util/stmtsummary/statement_summary.go.150: // txn (godoc-local: txn -> commitCount?) util/stmtsummary/statement_summary.go.150: // txn (godoc-local: txn -> commitCount?) util/stmtsummary/statement_summary.go.175: // other (godoc-local: other -> sumMem?) util/stmtsummary/statement_summary.go.175: // other (godoc-local: other -> sumMem?) util/stmtsummary/statement_summary.go.186: // The first time this type of SQL executes. (godoc-local: The -> firstSeen?) util/stmtsummary/statement_summary.go.186: // The first time this type of SQL executes. (godoc-local: The -> firstSeen?) util/stmtsummary/statement_summary.go.188: // The last time this type of SQL executes. (godoc-local: The -> lastSeen?) util/stmtsummary/statement_summary.go.188: // The last time this type of SQL executes. (godoc-local: The -> lastSeen?) util/stmtsummary/statement_summary.go.190: // plan cache (godoc-local: plan -> planInCache?) util/stmtsummary/statement_summary.go.190: // plan cache (godoc-local: plan -> planInCache?) util/stmtsummary/statement_summary.go.194: // pessimistic execution retry information. (godoc-local: pessimistic -> execRetryCount?) util/stmtsummary/statement_summary.go.194: // pessimistic execution retry information. (godoc-local: pessimistic -> execRetryCount?) util/stmtsummary/statement_summary.go.440: // SetHistorySize sets the history size for all summaries. (godoc-export: SetHistorySize -> SetMaxStmtCount?) util/stmtsummary/statement_summary.go.440: // SetHistorySize sets the history size for all summaries. (godoc-export: SetHistorySize -> SetMaxStmtCount?) util/stmtsummary/statement_summary.go.456: // SetHistorySize sets the history size for all summaries. (godoc-export: SetHistorySize -> SetMaxSQLLength?) util/stmtsummary/statement_summary.go.456: // SetHistorySize sets the history size for all summaries. (godoc-export: SetHistorySize -> SetMaxSQLLength?) util/stmtsummary/statement_summary.go.465: // newStmtSummaryByDigest creates a stmtSummaryByDigest from StmtExecInfo. (godoc-local: newStmtSummaryByDigest -> init?) util/stmtsummary/statement_summary.go.465: // newStmtSummaryByDigest creates a stmtSummaryByDigest from StmtExecInfo. (godoc-local: newStmtSummaryByDigest -> init?) util/stmtsummary/statement_summary.go.796: // Truncate SQL to maxSQLLength. (godoc-local: Truncate -> formatSQL?) util/stmtsummary/statement_summary.go.796: // Truncate SQL to maxSQLLength. (godoc-local: Truncate -> formatSQL?) util/stmtsummary/statement_summary.go.806: // Format the backoffType map to a string or nil. (godoc-local: Format -> formatBackoffTypes?) util/stmtsummary/statement_summary.go.806: // Format the backoffType map to a string or nil. (godoc-local: Format -> formatBackoffTypes?) util/stmtsummary/statement_summary_test.go.70: // Test stmtSummaryByDigest.AddStatement. (godoc-export: Test -> TestAddStatement?) util/stmtsummary/statement_summary_test.go.70: // Test stmtSummaryByDigest.AddStatement. (godoc-export: Test -> TestAddStatement?) util/stmtsummary/statement_summary_test.go.757: // Test stmtSummaryByDigest.ToDatum. (godoc-export: Test -> TestToDatum?) util/stmtsummary/statement_summary_test.go.757: // Test stmtSummaryByDigest.ToDatum. (godoc-export: Test -> TestToDatum?) util/stmtsummary/statement_summary_test.go.854: // Test AddStatement and ToDatum parallel. (godoc-export: Test -> TestAddStatementParallel?) util/stmtsummary/statement_summary_test.go.854: // Test AddStatement and ToDatum parallel. (godoc-export: Test -> TestAddStatementParallel?) util/stmtsummary/statement_summary_test.go.891: // Test max number of statement count. (godoc-export: Test -> TestMaxStmtCount?) util/stmtsummary/statement_summary_test.go.891: // Test max number of statement count. (godoc-export: Test -> TestMaxStmtCount?) util/stmtsummary/statement_summary_test.go.949: // Test max length of normalized and sample SQL. (godoc-export: Test -> TestMaxSQLLength?) util/stmtsummary/statement_summary_test.go.949: // Test max length of normalized and sample SQL. (godoc-export: Test -> TestMaxSQLLength?) util/stmtsummary/statement_summary_test.go.992: // Test AddStatement and SetMaxStmtCount parallel. (godoc-export: Test -> TestSetMaxStmtCountParallel?) util/stmtsummary/statement_summary_test.go.992: // Test AddStatement and SetMaxStmtCount parallel. (godoc-export: Test -> TestSetMaxStmtCountParallel?) util/stmtsummary/statement_summary_test.go.1036: // Test setting EnableStmtSummary to 0. (godoc-export: Test -> TestDisableStmtSummary?) util/stmtsummary/statement_summary_test.go.1036: // Test setting EnableStmtSummary to 0. (godoc-export: Test -> TestDisableStmtSummary?) util/stmtsummary/statement_summary_test.go.1094: // Test disable and enable statement summary concurrently with adding statements. (godoc-export: Test -> TestEnableSummaryParallel?) util/stmtsummary/statement_summary_test.go.1094: // Test disable and enable statement summary concurrently with adding statements. (godoc-export: Test -> TestEnableSummaryParallel?) util/stmtsummary/statement_summary_test.go.1131: // Test GetMoreThanOnceBindableStmt. (godoc-export: Test -> TestGetMoreThanOnceBindableStmt?) util/stmtsummary/statement_summary_test.go.1131: // Test GetMoreThanOnceBindableStmt. (godoc-export: Test -> TestGetMoreThanOnceBindableStmt?) util/stmtsummary/statement_summary_test.go.1155: // Test `formatBackoffTypes`. (godoc-export: Test -> TestFormatBackoffTypes?) util/stmtsummary/statement_summary_test.go.1155: // Test `formatBackoffTypes`. (godoc-export: Test -> TestFormatBackoffTypes?) util/stmtsummary/statement_summary_test.go.1168: // Test refreshing current statement summary periodically. (godoc-export: Test -> TestRefreshCurrentSummary?) util/stmtsummary/statement_summary_test.go.1168: // Test refreshing current statement summary periodically. (godoc-export: Test -> TestRefreshCurrentSummary?) util/stmtsummary/statement_summary_test.go.1207: // Test expiring statement summary to history. (godoc-export: Test -> TestSummaryHistory?) util/stmtsummary/statement_summary_test.go.1207: // Test expiring statement summary to history. (godoc-export: Test -> TestSummaryHistory?) util/stmtsummary/statement_summary_test.go.1286: // Test summary when PrevSQL is not empty. (godoc-export: Test -> TestPrevSQL?) util/stmtsummary/statement_summary_test.go.1286: // Test summary when PrevSQL is not empty. (godoc-export: Test -> TestPrevSQL?) util/stmtsummary/variables.go.39: // This array itself won't be modified once created. Only its elements may be modified. (godoc-local: This -> variables?) util/stmtsummary/variables.go.39: // This array itself won't be modified once created. Only its elements may be modified. (godoc-local: This -> variables?) util/sys/linux/sys_test.go.1: // Copyright 2019 PingCAP, Inc. (godoc-export: Copyright -> // Package linux_test?) util/sys/linux/sys_test.go.1: // Copyright 2019 PingCAP, Inc. (godoc-export: Copyright -> // Package linux_test?) util/tableutil/tableutil.go.33: // The stats of this table (*statistics.Table). (godoc-export: The -> GetStats?) util/tableutil/tableutil.go.33: // The stats of this table (*statistics.Table). (godoc-export: The -> GetStats?) util/topsql/reporter/client.go.39: // calling decodePlan this can take a while, so should not block critical paths (godoc-local: calling -> decodePlan?) util/topsql/reporter/client.go.39: // calling decodePlan this can take a while, so should not block critical paths (godoc-local: calling -> decodePlan?) util/topsql/reporter/client.go.39: // calling decodePlan this can take a while, so should not block critical paths (godoc-local: calling -> decodePlan?) util/topsql/reporter/client.go.39: // calling decodePlan this can take a while, so should not block critical paths (godoc-local: calling -> decodePlan?) util/topsql/reporter/client.go.39: // calling decodePlan this can take a while, so should not block critical paths (godoc-local: calling -> decodePlan?) util/topsql/reporter/client.go.39: // calling decodePlan this can take a while, so should not block critical paths (godoc-local: calling -> decodePlan?) util/topsql/tracecpu/mock/mock.go.32: // sql_digest -> normalized SQL (godoc-local: sql_digest -> sqlMap?) util/topsql/tracecpu/mock/mock.go.32: // sql_digest -> normalized SQL (godoc-local: sql_digest -> sqlMap?) util/topsql/tracecpu/mock/mock.go.32: // sql_digest -> normalized SQL (godoc-local: sql_digest -> sqlMap?) util/topsql/tracecpu/mock/mock.go.32: // sql_digest -> normalized SQL (godoc-local: sql_digest -> sqlMap?) util/topsql/tracecpu/mock/mock.go.34: // plan_digest -> normalized plan (godoc-local: plan_digest -> planMap?) util/topsql/tracecpu/mock/mock.go.34: // plan_digest -> normalized plan (godoc-local: plan_digest -> planMap?) util/topsql/tracecpu/mock/mock.go.34: // plan_digest -> normalized plan (godoc-local: plan_digest -> planMap?) util/topsql/tracecpu/mock/mock.go.34: // plan_digest -> normalized plan (godoc-local: plan_digest -> planMap?) util/topsql/tracecpu/mock/mock.go.36: // (sql + plan_digest) -> sql stats (godoc-local: (sql -> sqlStatsMap?) util/topsql/tracecpu/mock/mock.go.36: // (sql + plan_digest) -> sql stats (godoc-local: (sql -> sqlStatsMap?) util/topsql/tracecpu/mock/mock.go.36: // (sql + plan_digest) -> sql stats (godoc-local: (sql -> sqlStatsMap?) util/topsql/tracecpu/mock/mock.go.36: // (sql + plan_digest) -> sql stats (godoc-local: (sql -> sqlStatsMap?) util/tracing/util.go.26: // A CallbackRecorder immediately invokes itself on received trace spans. (godoc-export: A -> CallbackRecorder?) util/tracing/util.go.26: // A CallbackRecorder immediately invokes itself on received trace spans. (godoc-export: A -> CallbackRecorder?)