package kvrpcpb

Mouse Melon logoGet desktop application:
View/edit binary Protocol Buffers messages

enum APIVersion

kvrpcpb.proto:944

The API version the server and the client is using. See more details in https://github.com/tikv/rfcs/blob/master/text/0069-api-v2.md.

Used in: backup.BackupMeta, backup.BackupRequest, backup.BackupResponse, debugpb.GetStoreInfoResponse, disaggregated.DisaggTaskMeta, import_sstpb.SSTMeta, CompactRequest, Context, mpp.TaskMeta, raft_serverpb.StoreIdent

enum Action

kvrpcpb.proto:1405

Used in: CheckTxnStatusResponse

message AlreadyExist

kvrpcpb.proto:1063

Used in: KeyError

enum Assertion

kvrpcpb.proto:1337

Used in: AssertionFailed, Mutation

message AssertionFailed

kvrpcpb.proto:1095

Used in: KeyError

enum AssertionLevel

kvrpcpb.proto:1343

Used in: FlushRequest, PrewriteRequest

message BatchGetRequest

kvrpcpb.proto:450

Similar to a `Get` request.

Used as request type in: tikvpb.Tikv.KvBatchGet

Used as field type in: tikvpb.BatchCommandsRequest.Request

message BatchGetResponse

kvrpcpb.proto:456

Used as response type in: tikvpb.Tikv.KvBatchGet

Used as field type in: tikvpb.BatchCommandsResponse.Response

message BatchRollbackRequest

kvrpcpb.proto:470

Rollback a prewritten transaction. This will remove the preliminary data from the database, unlock locks, and leave a rollback tombstone.

Used as request type in: tikvpb.Tikv.KvBatchRollback

Used as field type in: tikvpb.BatchCommandsRequest.Request

message BatchRollbackResponse

kvrpcpb.proto:481

Used as response type in: tikvpb.Tikv.KvBatchRollback

Used as field type in: tikvpb.BatchCommandsResponse.Response

message BroadcastTxnStatusRequest

kvrpcpb.proto:1678

Used as request type in: tikvpb.Tikv.BroadcastTxnStatus

Used as field type in: tikvpb.BatchCommandsRequest.Request

message BroadcastTxnStatusResponse

kvrpcpb.proto:1694

Used as response type in: tikvpb.Tikv.BroadcastTxnStatus

Used as field type in: tikvpb.BatchCommandsResponse.Response

(message has no fields)

message BufferBatchGetRequest

kvrpcpb.proto:1636

BufferBatchGet is introduced from the pipelined DML protocol. It is similar to a BatchGet request, except that it can only read the data that has been flushed by itself.

Used as request type in: tikvpb.Tikv.KvBufferBatchGet

Used as field type in: tikvpb.BatchCommandsRequest.Request

message BufferBatchGetResponse

kvrpcpb.proto:1642

Used as response type in: tikvpb.Tikv.KvBufferBatchGet

Used as field type in: tikvpb.BatchCommandsResponse.Response

message CheckLeaderRequest

kvrpcpb.proto:1438

Used as request type in: tikvpb.Tikv.CheckLeader

message CheckLeaderResponse

kvrpcpb.proto:1443

Used as response type in: tikvpb.Tikv.CheckLeader

message CheckLockObserverRequest

kvrpcpb.proto:747

Used as request type in: tikvpb.Tikv.CheckLockObserver

message CheckLockObserverResponse

kvrpcpb.proto:752

Used as response type in: tikvpb.Tikv.CheckLockObserver

message CheckSecondaryLocksRequest

kvrpcpb.proto:356

Part of the async commit protocol, checks for locks on all supplied keys. If a lock is missing, does not have a successful status, or belongs to another transaction, TiKV will leave a rollback tombstone for that key.

Used as request type in: tikvpb.Tikv.KvCheckSecondaryLocks

Used as field type in: tikvpb.BatchCommandsRequest.Request

message CheckSecondaryLocksResponse

kvrpcpb.proto:363

Used as response type in: tikvpb.Tikv.KvCheckSecondaryLocks

Used as field type in: tikvpb.BatchCommandsResponse.Response

message CheckTxnStatusRequest

kvrpcpb.proto:304

CheckTxnStatusRequest checks the status of a transaction. If the transaction is rollbacked/committed, return that result. If the TTL of the transaction is exhausted, abort that transaction and inform the caller. Otherwise, returns the TTL information for the transaction. CheckTxnStatusRequest may also push forward the minCommitTS of a large transaction.

Used as request type in: tikvpb.Tikv.KvCheckTxnStatus

Used as field type in: tikvpb.BatchCommandsRequest.Request

message CheckTxnStatusResponse

kvrpcpb.proto:337

Used as response type in: tikvpb.Tikv.KvCheckTxnStatus

Used as field type in: tikvpb.BatchCommandsResponse.Response

enum ChecksumAlgorithm

kvrpcpb.proto:1533

Used in: RawChecksumRequest

message CleanupRequest

kvrpcpb.proto:432

Cleanup a key by possibly unlocking it. From 4.0 onwards, this message is no longer used.

Used as request type in: tikvpb.Tikv.KvCleanup

Used as field type in: tikvpb.BatchCommandsRequest.Request

message CleanupResponse

kvrpcpb.proto:442

Used as response type in: tikvpb.Tikv.KvCleanup

Used as field type in: tikvpb.BatchCommandsResponse.Response

enum CommandPri

kvrpcpb.proto:1120

Used in: Context, raft_cmdpb.RaftRequestHeader

message CommitRequest

kvrpcpb.proto:389

The second phase of writing to TiKV. If there are no errors or conflicts, then this request commits a transaction so that its data can be read by other transactions.

Used as request type in: tikvpb.Tikv.KvCommit

Used as field type in: tikvpb.BatchCommandsRequest.Request

message CommitResponse

kvrpcpb.proto:410

Used as response type in: tikvpb.Tikv.KvCommit

Used as field type in: tikvpb.BatchCommandsResponse.Response

enum CommitRole

kvrpcpb.proto:378

CommitRole indicates the current commit request is a primary commit or a secondary commit.

Used in: CommitRequest

message CommitTsExpired

kvrpcpb.proto:1079

Used in: KeyError

message CommitTsTooLarge

kvrpcpb.proto:1091

Used in: KeyError

message CompactError

kvrpcpb.proto:1551

Used in: CompactResponse

message CompactErrorCompactInProgress

kvrpcpb.proto:1564

Used in: CompactError

(message has no fields)

message CompactErrorInvalidStartKey

kvrpcpb.proto:1560

Used in: CompactError

(message has no fields)

message CompactErrorPhysicalTableNotExist

kvrpcpb.proto:1562

Used in: CompactError

(message has no fields)

message CompactErrorTooManyPendingTasks

kvrpcpb.proto:1566

Used in: CompactError

(message has no fields)

message CompactRequest

kvrpcpb.proto:1568

Used as request type in: tikvpb.Tikv.Compact

message CompactResponse

kvrpcpb.proto:1595

Used as response type in: tikvpb.Tikv.Compact

message Context

kvrpcpb.proto:844

Miscellaneous metadata attached to most requests.

Used in: backup.BackupRequest, coprocessor.BatchRequest, coprocessor.Request, debugpb.FlashbackToVersionRequest, import_sstpb.ApplyRequest, import_sstpb.CompactRequest, import_sstpb.DownloadRequest, import_sstpb.DuplicateDetectRequest, import_sstpb.IngestRequest, import_sstpb.MultiIngestRequest, import_sstpb.RawWriteRequest, import_sstpb.WriteRequest, BatchGetRequest, BatchRollbackRequest, BroadcastTxnStatusRequest, BufferBatchGetRequest, CheckLockObserverRequest, CheckSecondaryLocksRequest, CheckTxnStatusRequest, CleanupRequest, CommitRequest, DeleteRangeRequest, FlashbackToVersionRequest, FlushRequest, GCRequest, GetHealthFeedbackRequest, GetLockWaitHistoryRequest, GetLockWaitInfoRequest, GetRequest, MvccGetByKeyRequest, MvccGetByStartTsRequest, PessimisticLockRequest, PessimisticRollbackRequest, PhysicalScanLockRequest, PrepareFlashbackToVersionRequest, PrewriteRequest, RawBatchDeleteRequest, RawBatchGetRequest, RawBatchPutRequest, RawBatchScanRequest, RawCASRequest, RawChecksumRequest, RawCoprocessorRequest, RawDeleteRangeRequest, RawDeleteRequest, RawGetKeyTTLRequest, RawGetRequest, RawPutRequest, RawScanRequest, ReadIndexRequest, RegisterLockObserverRequest, RemoveLockObserverRequest, ResolveLockRequest, ScanLockRequest, ScanRequest, SplitRegionRequest, TxnHeartBeatRequest, UnsafeDestroyRangeRequest

message Deadlock

kvrpcpb.proto:1067

Used in: KeyError

message DebugInfo

kvrpcpb.proto:1116

Used in: KeyError

message DeleteRangeRequest

kvrpcpb.proto:546

Delete a range of data from TiKV.

Used as request type in: tikvpb.Tikv.KvDeleteRange

Used as field type in: tikvpb.BatchCommandsRequest.Request

message DeleteRangeResponse

kvrpcpb.proto:556

Used as response type in: tikvpb.Tikv.KvDeleteRange

Used as field type in: tikvpb.BatchCommandsResponse.Response

enum DiskFullOpt

kvrpcpb.proto:1133

Operation allowed info during each TiKV storage threshold.

Used in: Context

message ExecDetails

kvrpcpb.proto:1241

Used in: coprocessor.BatchResponse, coprocessor.Response

message ExecDetailsV2

kvrpcpb.proto:1253

Used in: coprocessor.Response, coprocessor.StoreBatchTaskResponse, BatchGetResponse, BatchRollbackResponse, BufferBatchGetResponse, CheckSecondaryLocksResponse, CheckTxnStatusResponse, CommitResponse, FlushResponse, GetResponse, PessimisticLockResponse, PessimisticRollbackResponse, PrewriteResponse, ResolveLockResponse, ScanLockResponse, TxnHeartBeatResponse

enum ExtraOp

kvrpcpb.proto:1419

Used in: cdcpb.ChangeDataRequest

message FlashbackToVersionRequest

kvrpcpb.proto:583

Flashback the region to a specific point with the given `version`, please make sure the region is "locked" by `PrepareFlashbackToVersionRequest` first, otherwise this request will fail.

Used as request type in: tikvpb.Tikv.KvFlashbackToVersion

Used as field type in: tikvpb.BatchCommandsRequest.Request

message FlashbackToVersionResponse

kvrpcpb.proto:595

Used as response type in: tikvpb.Tikv.KvFlashbackToVersion

Used as field type in: tikvpb.BatchCommandsResponse.Response

message FlushRequest

kvrpcpb.proto:1616

Flush is introduced from the pipelined DML protocol. A Flush request writes some keys and values to TiKV, storing in LOCK and DEFAULT CF, just like a Prewrite request.

Used as request type in: tikvpb.Tikv.KvFlush

Used as field type in: tikvpb.BatchCommandsRequest.Request

message FlushResponse

kvrpcpb.proto:1628

Used as response type in: tikvpb.Tikv.KvFlush

Used as field type in: tikvpb.BatchCommandsResponse.Response

message GCRequest

kvrpcpb.proto:535

Request TiKV to garbage collect all non-current data older than `safe_point`.

Used as request type in: tikvpb.Tikv.KvGC

Used as field type in: tikvpb.BatchCommandsRequest.Request

message GCResponse

kvrpcpb.proto:540

Used as response type in: tikvpb.Tikv.KvGC

Used as field type in: tikvpb.BatchCommandsResponse.Response

message GetHealthFeedbackRequest

kvrpcpb.proto:1654

Actively request TiKV to report health feedback information. TiKV won't omit the health feedback information when sending the `BatchCommandsResponse` that contains this response. The health feedback information won't be replied in the response, but will be attached to `BatchCommandsResponse.health_feedback` field as usual. Only works when batch RPC is enabled.

Used as request type in: tikvpb.Tikv.GetHealthFeedback

Used as field type in: tikvpb.BatchCommandsRequest.Request

message GetHealthFeedbackResponse

kvrpcpb.proto:1658

Used as response type in: tikvpb.Tikv.GetHealthFeedback

Used as field type in: tikvpb.BatchCommandsResponse.Response

message GetLockWaitHistoryRequest

kvrpcpb.proto:1502

Used as request type in: tikvpb.Tikv.GetLockWaitHistory

message GetLockWaitHistoryResponse

kvrpcpb.proto:1508

Used as response type in: tikvpb.Tikv.GetLockWaitHistory

message GetLockWaitInfoRequest

kvrpcpb.proto:1490

Used as request type in: tikvpb.Tikv.GetLockWaitInfo

message GetLockWaitInfoResponse

kvrpcpb.proto:1496

Used as response type in: tikvpb.Tikv.GetLockWaitInfo

message GetRequest

kvrpcpb.proto:30

A transactional get command. Lookup a value for `key` in the transaction with starting timestamp = `version`.

Used as request type in: tikvpb.Tikv.KvGet

Used as field type in: tikvpb.BatchCommandsRequest.Request

message GetResponse

kvrpcpb.proto:36

Used as response type in: tikvpb.Tikv.KvGet

Used as field type in: tikvpb.BatchCommandsResponse.Response

message HealthFeedback

kvrpcpb.proto:1664

Used in: GetHealthFeedbackResponse, tikvpb.BatchCommandsResponse

message ImportRequest

kvrpcpb.proto:420

Not yet implemented.

Used as request type in: tikvpb.Tikv.KvImport

Used as field type in: tikvpb.BatchCommandsRequest.Request

message ImportResponse

kvrpcpb.proto:425

Used as response type in: tikvpb.Tikv.KvImport

Used as field type in: tikvpb.BatchCommandsResponse.Response

enum IsolationLevel

kvrpcpb.proto:1126

Used in: Context

message KeyError

kvrpcpb.proto:1027

Used in: backup.Error, BatchGetResponse, BatchRollbackResponse, BufferBatchGetResponse, CheckSecondaryLocksResponse, CheckTxnStatusResponse, CleanupResponse, CommitResponse, FlushResponse, GCResponse, GetResponse, KvPair, PessimisticLockResponse, PessimisticRollbackResponse, PrewriteResponse, ResolveLockResponse, ScanLockResponse, ScanResponse, SplitRegionResponse, TxnHeartBeatResponse

message KeyRange

kvrpcpb.proto:1414

Used in: backup.BackupRequest, backup.SortedSubRanges, RawBatchScanRequest, RawChecksumRequest, RawCoprocessorRequest, ReadIndexRequest, StoreSafeTSRequest, raft_cmdpb.ReadIndexRequest

message KvPair

kvrpcpb.proto:1320

Used in: BatchGetResponse, BufferBatchGetResponse, RawBatchGetResponse, RawBatchPutRequest, RawBatchScanResponse, RawScanResponse, ScanResponse

message LeaderInfo

kvrpcpb.proto:1425

Used in: CheckLeaderRequest

message LockInfo

kvrpcpb.proto:1005

Used in: coprocessor.Response, coprocessor.StoreBatchTaskResponse, disaggregated.ErrorLocked, CheckLockObserverResponse, CheckSecondaryLocksResponse, CheckTxnStatusResponse, KeyError, PhysicalScanLockResponse, PrimaryMismatch, ReadIndexResponse, ScanLockResponse, raft_cmdpb.ReadIndexResponse

message Mutation

kvrpcpb.proto:1352

Used in: FlushRequest, ImportRequest, PessimisticLockRequest, PrewriteRequest

message MvccDebugInfo

kvrpcpb.proto:1111

Used in: DebugInfo

message MvccGetByKeyRequest

kvrpcpb.proto:818

Used as request type in: tikvpb.Tikv.MvccGetByKey

message MvccGetByKeyResponse

kvrpcpb.proto:823

Used as response type in: tikvpb.Tikv.MvccGetByKey

message MvccGetByStartTsRequest

kvrpcpb.proto:829

Used as request type in: tikvpb.Tikv.MvccGetByStartTs

message MvccGetByStartTsResponse

kvrpcpb.proto:834

Used as response type in: tikvpb.Tikv.MvccGetByStartTs

message MvccInfo

kvrpcpb.proto:1391

Used in: debugpb.ScanMvccResponse, MvccDebugInfo, MvccGetByKeyResponse, MvccGetByStartTsResponse

message MvccLock

kvrpcpb.proto:1376

Used in: MvccInfo

message MvccValue

kvrpcpb.proto:1371

Used in: MvccInfo

message MvccWrite

kvrpcpb.proto:1359

Used in: MvccInfo

enum Op

kvrpcpb.proto:1326

Used in: LockInfo, Mutation, MvccLock, MvccWrite

message PessimisticLockKeyResult

kvrpcpb.proto:219

Used in: PessimisticLockResponse

enum PessimisticLockKeyResultType

kvrpcpb.proto:213

Used in: PessimisticLockKeyResult

message PessimisticLockRequest

kvrpcpb.proto:174

Lock a set of keys to prepare to write to them.

Used as request type in: tikvpb.Tikv.KvPessimisticLock

Used as field type in: tikvpb.BatchCommandsRequest.Request

message PessimisticLockResponse

kvrpcpb.proto:236

Used as response type in: tikvpb.Tikv.KvPessimisticLock

Used as field type in: tikvpb.BatchCommandsResponse.Response

enum PessimisticLockWakeUpMode

kvrpcpb.proto:161

Used to specify the behavior when a pessimistic lock request is woken up after waiting for another lock.

Used in: PessimisticLockRequest

message PessimisticRollbackRequest

kvrpcpb.proto:258

Unlock keys locked using `PessimisticLockRequest`.

Used as request type in: tikvpb.Tikv.KVPessimisticRollback

Used as field type in: tikvpb.BatchCommandsRequest.Request

message PessimisticRollbackResponse

kvrpcpb.proto:265

Used as response type in: tikvpb.Tikv.KVPessimisticRollback

Used as field type in: tikvpb.BatchCommandsResponse.Response

message PhysicalScanLockRequest

kvrpcpb.proto:767

Used as request type in: tikvpb.Tikv.PhysicalScanLock

message PhysicalScanLockResponse

kvrpcpb.proto:774

Used as response type in: tikvpb.Tikv.PhysicalScanLock

message PrepareFlashbackToVersionRequest

kvrpcpb.proto:564

Preparing the flashback for a region/key range will "lock" the region so that there is no any read, write or schedule operation could be proposed before the actual flashback operation.

Used as request type in: tikvpb.Tikv.KvPrepareFlashbackToVersion

Used as field type in: tikvpb.BatchCommandsRequest.Request

message PrepareFlashbackToVersionResponse

kvrpcpb.proto:575

Used as response type in: tikvpb.Tikv.KvPrepareFlashbackToVersion

Used as field type in: tikvpb.BatchCommandsResponse.Response

message PrewriteRequest

kvrpcpb.proto:83

A prewrite is the first phase of writing to TiKV. It contains all data to be written in a transaction. TiKV will write the data in a preliminary state. Data cannot be read until it has been committed. The client should only commit a transaction once all prewrites succeed.

Used as request type in: tikvpb.Tikv.KvPrewrite

Used as field type in: tikvpb.BatchCommandsRequest.Request

message PrewriteRequest.ForUpdateTSConstraint

kvrpcpb.proto:95

for_update_ts constriants that should be checked when prewriting a pessimistic transaction.

Used in: PrewriteRequest

enum PrewriteRequest.PessimisticAction

kvrpcpb.proto:85

What kind of checks need to be performed for keys in a pessimistic transaction.

Used in: PrewriteRequest

message PrewriteResponse

kvrpcpb.proto:144

Used as response type in: tikvpb.Tikv.KvPrewrite

Used as field type in: tikvpb.BatchCommandsResponse.Response

message PrimaryMismatch

kvrpcpb.proto:1103

Used in: KeyError

message RawBatchDeleteRequest

kvrpcpb.proto:670

Used as request type in: tikvpb.Tikv.RawBatchDelete

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawBatchDeleteResponse

kvrpcpb.proto:677

Used as response type in: tikvpb.Tikv.RawBatchDelete

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawBatchGetRequest

kvrpcpb.proto:615

Used as request type in: tikvpb.Tikv.RawBatchGet

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawBatchGetResponse

kvrpcpb.proto:621

Used as response type in: tikvpb.Tikv.RawBatchGet

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawBatchPutRequest

kvrpcpb.proto:640

Used as request type in: tikvpb.Tikv.RawBatchPut

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawBatchPutResponse

kvrpcpb.proto:653

Used as response type in: tikvpb.Tikv.RawBatchPut

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawBatchScanRequest

kvrpcpb.proto:711

Used as request type in: tikvpb.Tikv.RawBatchScan

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawBatchScanResponse

kvrpcpb.proto:720

Used as response type in: tikvpb.Tikv.RawBatchScan

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawCASRequest

kvrpcpb.proto:1471

Used as request type in: tikvpb.Tikv.RawCompareAndSwap

message RawCASResponse

kvrpcpb.proto:1481

Used as response type in: tikvpb.Tikv.RawCompareAndSwap

message RawChecksumRequest

kvrpcpb.proto:1537

Used as request type in: tikvpb.Tikv.RawChecksum

message RawChecksumResponse

kvrpcpb.proto:1543

Used as response type in: tikvpb.Tikv.RawChecksum

message RawCoprocessorRequest

kvrpcpb.proto:1514

Used as request type in: tikvpb.Tikv.RawCoprocessor

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawCoprocessorResponse

kvrpcpb.proto:1525

Used as response type in: tikvpb.Tikv.RawCoprocessor

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawDeleteRangeRequest

kvrpcpb.proto:699

Used as request type in: tikvpb.Tikv.RawDeleteRange

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawDeleteRangeResponse

kvrpcpb.proto:706

Used as response type in: tikvpb.Tikv.RawDeleteRange

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawDeleteRequest

kvrpcpb.proto:658

Used as request type in: tikvpb.Tikv.RawDelete

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawDeleteResponse

kvrpcpb.proto:665

Used as response type in: tikvpb.Tikv.RawDelete

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawGetKeyTTLRequest

kvrpcpb.proto:1458

Used as request type in: tikvpb.Tikv.RawGetKeyTTL

message RawGetKeyTTLResponse

kvrpcpb.proto:1464

Used as response type in: tikvpb.Tikv.RawGetKeyTTL

message RawGetRequest

kvrpcpb.proto:602

Used as request type in: tikvpb.Tikv.RawGet

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawGetResponse

kvrpcpb.proto:608

Used as response type in: tikvpb.Tikv.RawGet

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawPutRequest

kvrpcpb.proto:626

Used as request type in: tikvpb.Tikv.RawPut

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawPutResponse

kvrpcpb.proto:635

Used as response type in: tikvpb.Tikv.RawPut

Used as field type in: tikvpb.BatchCommandsResponse.Response

message RawScanRequest

kvrpcpb.proto:682

Used as request type in: tikvpb.Tikv.RawScan

Used as field type in: tikvpb.BatchCommandsRequest.Request

message RawScanResponse

kvrpcpb.proto:694

Used as response type in: tikvpb.Tikv.RawScan

Used as field type in: tikvpb.BatchCommandsResponse.Response

message ReadIndexRequest

kvrpcpb.proto:799

Sent from TiFlash to a TiKV node.

Used as request type in: tikvpb.Tikv.ReadIndex

message ReadIndexResponse

kvrpcpb.proto:808

Used as response type in: tikvpb.Tikv.ReadIndex

message ReadState

kvrpcpb.proto:1433

Used in: LeaderInfo

message RegisterLockObserverRequest

kvrpcpb.proto:738

Used as request type in: tikvpb.Tikv.RegisterLockObserver

message RegisterLockObserverResponse

kvrpcpb.proto:743

Used as response type in: tikvpb.Tikv.RegisterLockObserver

message RemoveLockObserverRequest

kvrpcpb.proto:758

Used as request type in: tikvpb.Tikv.RemoveLockObserver

message RemoveLockObserverResponse

kvrpcpb.proto:763

Used as response type in: tikvpb.Tikv.RemoveLockObserver

message ResolveLockRequest

kvrpcpb.proto:513

For all keys locked by the transaction identified by `start_version`, either commit or rollback the transaction and unlock the key.

Used as request type in: tikvpb.Tikv.KvResolveLock

Used as field type in: tikvpb.BatchCommandsRequest.Request

message ResolveLockResponse

kvrpcpb.proto:527

Used as response type in: tikvpb.Tikv.KvResolveLock

Used as field type in: tikvpb.BatchCommandsResponse.Response

message ResourceControlContext

kvrpcpb.proto:929

Used in: Context

message ScanDetail

kvrpcpb.proto:1184

Only reserved for compatibility.

Used in: ExecDetails

message ScanDetailV2

kvrpcpb.proto:1190

Used in: ExecDetailsV2

message ScanInfo

kvrpcpb.proto:1177

Used in: ScanDetail

message ScanLockRequest

kvrpcpb.proto:490

Scan the database for locks. Used at the start of the GC process to find all old locks.

Used as request type in: tikvpb.Tikv.KvScanLock

Used as field type in: tikvpb.BatchCommandsRequest.Request

message ScanLockResponse

kvrpcpb.proto:502

Used as response type in: tikvpb.Tikv.KvScanLock

Used as field type in: tikvpb.BatchCommandsResponse.Response

message ScanRequest

kvrpcpb.proto:53

Scan fetches values for a range of keys; it is part of the transaction with starting timestamp = `version`.

Used as request type in: tikvpb.Tikv.KvScan

Used as field type in: tikvpb.BatchCommandsRequest.Request

message ScanResponse

kvrpcpb.proto:70

Used as response type in: tikvpb.Tikv.KvScan

Used as field type in: tikvpb.BatchCommandsResponse.Response

message SourceStmt

kvrpcpb.proto:997

Used in: Context

message SplitRegionRequest

kvrpcpb.proto:780

Sent from PD to a TiKV node.

Used as request type in: tikvpb.Tikv.SplitRegion

message SplitRegionResponse

kvrpcpb.proto:788

Used as response type in: tikvpb.Tikv.SplitRegion

message StoreSafeTSRequest

kvrpcpb.proto:1448

Used as request type in: tikvpb.Tikv.GetStoreSafeTS

message StoreSafeTSResponse

kvrpcpb.proto:1454

Used as response type in: tikvpb.Tikv.GetStoreSafeTS

message TiFlashSystemTableRequest

kvrpcpb.proto:1606

Used as request type in: tikvpb.Tikv.GetTiFlashSystemTable

message TiFlashSystemTableResponse

kvrpcpb.proto:1610

Used as response type in: tikvpb.Tikv.GetTiFlashSystemTable

message TimeDetail

kvrpcpb.proto:1139

Used in: ExecDetails, ExecDetailsV2

message TimeDetailV2

kvrpcpb.proto:1155

Used in: ExecDetailsV2

message TxnHeartBeatRequest

kvrpcpb.proto:273

Used to update the lock_ttl of a psessimistic and/or large transaction to prevent it from been killed.

Used as request type in: tikvpb.Tikv.KvTxnHeartBeat

Used as field type in: tikvpb.BatchCommandsRequest.Request

message TxnHeartBeatResponse

kvrpcpb.proto:290

Used as response type in: tikvpb.Tikv.KvTxnHeartBeat

Used as field type in: tikvpb.BatchCommandsResponse.Response

message TxnInfo

kvrpcpb.proto:1397

Used in: ResolveLockRequest

message TxnLockNotFound

kvrpcpb.proto:1107

Used in: KeyError

message TxnNotFound

kvrpcpb.proto:1086

Used in: KeyError

message TxnStatus

kvrpcpb.proto:1683

Used in: BroadcastTxnStatusRequest

message UnsafeDestroyRangeRequest

kvrpcpb.proto:727

Used as request type in: tikvpb.Tikv.UnsafeDestroyRange

message UnsafeDestroyRangeResponse

kvrpcpb.proto:733

Used as response type in: tikvpb.Tikv.UnsafeDestroyRange

message WriteConflict

kvrpcpb.proto:1045

Used in: KeyError

enum WriteConflict.Reason

kvrpcpb.proto:1046

Used in: WriteConflict

message WriteDetail

kvrpcpb.proto:1267

Used in: ExecDetailsV2