Documentation
¶
Index ¶
- Variables
- func RegisterTikvServer(s *grpc.Server, srv TikvServer)
- type BatchCommandsEmptyRequest
- func (*BatchCommandsEmptyRequest) Descriptor() ([]byte, []int)
- func (m *BatchCommandsEmptyRequest) GetDelayTime() uint64
- func (m *BatchCommandsEmptyRequest) GetTestId() uint64
- func (m *BatchCommandsEmptyRequest) Marshal() (dAtA []byte, err error)
- func (m *BatchCommandsEmptyRequest) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchCommandsEmptyRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchCommandsEmptyRequest) ProtoMessage()
- func (m *BatchCommandsEmptyRequest) Reset()
- func (m *BatchCommandsEmptyRequest) Size() (n int)
- func (m *BatchCommandsEmptyRequest) String() string
- func (m *BatchCommandsEmptyRequest) Unmarshal(dAtA []byte) error
- func (m *BatchCommandsEmptyRequest) XXX_DiscardUnknown()
- func (m *BatchCommandsEmptyRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchCommandsEmptyRequest) XXX_Merge(src proto.Message)
- func (m *BatchCommandsEmptyRequest) XXX_Size() int
- func (m *BatchCommandsEmptyRequest) XXX_Unmarshal(b []byte) error
- type BatchCommandsEmptyResponse
- func (*BatchCommandsEmptyResponse) Descriptor() ([]byte, []int)
- func (m *BatchCommandsEmptyResponse) GetTestId() uint64
- func (m *BatchCommandsEmptyResponse) Marshal() (dAtA []byte, err error)
- func (m *BatchCommandsEmptyResponse) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchCommandsEmptyResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchCommandsEmptyResponse) ProtoMessage()
- func (m *BatchCommandsEmptyResponse) Reset()
- func (m *BatchCommandsEmptyResponse) Size() (n int)
- func (m *BatchCommandsEmptyResponse) String() string
- func (m *BatchCommandsEmptyResponse) Unmarshal(dAtA []byte) error
- func (m *BatchCommandsEmptyResponse) XXX_DiscardUnknown()
- func (m *BatchCommandsEmptyResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchCommandsEmptyResponse) XXX_Merge(src proto.Message)
- func (m *BatchCommandsEmptyResponse) XXX_Size() int
- func (m *BatchCommandsEmptyResponse) XXX_Unmarshal(b []byte) error
- type BatchCommandsRequest
- func (*BatchCommandsRequest) Descriptor() ([]byte, []int)
- func (m *BatchCommandsRequest) GetRequestIds() []uint64
- func (m *BatchCommandsRequest) GetRequests() []*BatchCommandsRequest_Request
- func (m *BatchCommandsRequest) Marshal() (dAtA []byte, err error)
- func (m *BatchCommandsRequest) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchCommandsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchCommandsRequest) ProtoMessage()
- func (m *BatchCommandsRequest) Reset()
- func (m *BatchCommandsRequest) Size() (n int)
- func (m *BatchCommandsRequest) String() string
- func (m *BatchCommandsRequest) Unmarshal(dAtA []byte) error
- func (m *BatchCommandsRequest) XXX_DiscardUnknown()
- func (m *BatchCommandsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchCommandsRequest) XXX_Merge(src proto.Message)
- func (m *BatchCommandsRequest) XXX_Size() int
- func (m *BatchCommandsRequest) XXX_Unmarshal(b []byte) error
- type BatchCommandsRequest_Request
- func (*BatchCommandsRequest_Request) Descriptor() ([]byte, []int)
- func (m *BatchCommandsRequest_Request) GetBatchGet() *kvrpcpb.BatchGetRequest
- func (m *BatchCommandsRequest_Request) GetBatchRollback() *kvrpcpb.BatchRollbackRequest
- func (m *BatchCommandsRequest_Request) GetCheckSecondaryLocks() *kvrpcpb.CheckSecondaryLocksRequest
- func (m *BatchCommandsRequest_Request) GetCheckTxnStatus() *kvrpcpb.CheckTxnStatusRequest
- func (m *BatchCommandsRequest_Request) GetCleanup() *kvrpcpb.CleanupRequest
- func (m *BatchCommandsRequest_Request) GetCmd() isBatchCommandsRequest_Request_Cmd
- func (m *BatchCommandsRequest_Request) GetCommit() *kvrpcpb.CommitRequest
- func (m *BatchCommandsRequest_Request) GetCoprocessor() *coprocessor.Request
- func (m *BatchCommandsRequest_Request) GetDeleteRange() *kvrpcpb.DeleteRangeRequest
- func (m *BatchCommandsRequest_Request) GetEmpty() *BatchCommandsEmptyRequest
- func (m *BatchCommandsRequest_Request) GetFlashbackToVersion() *kvrpcpb.FlashbackToVersionRequest
- func (m *BatchCommandsRequest_Request) GetGC() *kvrpcpb.GCRequest
- func (m *BatchCommandsRequest_Request) GetGet() *kvrpcpb.GetRequest
- func (m *BatchCommandsRequest_Request) GetImport() *kvrpcpb.ImportRequest
- func (m *BatchCommandsRequest_Request) GetPessimisticLock() *kvrpcpb.PessimisticLockRequest
- func (m *BatchCommandsRequest_Request) GetPessimisticRollback() *kvrpcpb.PessimisticRollbackRequest
- func (m *BatchCommandsRequest_Request) GetPrepareFlashbackToVersion() *kvrpcpb.PrepareFlashbackToVersionRequest
- func (m *BatchCommandsRequest_Request) GetPrewrite() *kvrpcpb.PrewriteRequest
- func (m *BatchCommandsRequest_Request) GetRawBatchDelete() *kvrpcpb.RawBatchDeleteRequest
- func (m *BatchCommandsRequest_Request) GetRawBatchGet() *kvrpcpb.RawBatchGetRequest
- func (m *BatchCommandsRequest_Request) GetRawBatchPut() *kvrpcpb.RawBatchPutRequest
- func (m *BatchCommandsRequest_Request) GetRawBatchScan() *kvrpcpb.RawBatchScanRequest
- func (m *BatchCommandsRequest_Request) GetRawCoprocessor() *kvrpcpb.RawCoprocessorRequest
- func (m *BatchCommandsRequest_Request) GetRawDelete() *kvrpcpb.RawDeleteRequest
- func (m *BatchCommandsRequest_Request) GetRawDeleteRange() *kvrpcpb.RawDeleteRangeRequest
- func (m *BatchCommandsRequest_Request) GetRawGet() *kvrpcpb.RawGetRequest
- func (m *BatchCommandsRequest_Request) GetRawPut() *kvrpcpb.RawPutRequest
- func (m *BatchCommandsRequest_Request) GetRawScan() *kvrpcpb.RawScanRequest
- func (m *BatchCommandsRequest_Request) GetResolveLock() *kvrpcpb.ResolveLockRequest
- func (m *BatchCommandsRequest_Request) GetScan() *kvrpcpb.ScanRequest
- func (m *BatchCommandsRequest_Request) GetScanLock() *kvrpcpb.ScanLockRequest
- func (m *BatchCommandsRequest_Request) GetTxnHeartBeat() *kvrpcpb.TxnHeartBeatRequest
- func (m *BatchCommandsRequest_Request) Marshal() (dAtA []byte, err error)
- func (m *BatchCommandsRequest_Request) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchCommandsRequest_Request) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchCommandsRequest_Request) ProtoMessage()
- func (m *BatchCommandsRequest_Request) Reset()
- func (m *BatchCommandsRequest_Request) Size() (n int)
- func (m *BatchCommandsRequest_Request) String() string
- func (m *BatchCommandsRequest_Request) Unmarshal(dAtA []byte) error
- func (m *BatchCommandsRequest_Request) XXX_DiscardUnknown()
- func (m *BatchCommandsRequest_Request) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchCommandsRequest_Request) XXX_Merge(src proto.Message)
- func (*BatchCommandsRequest_Request) XXX_OneofWrappers() []interface{}
- func (m *BatchCommandsRequest_Request) XXX_Size() int
- func (m *BatchCommandsRequest_Request) XXX_Unmarshal(b []byte) error
- type BatchCommandsRequest_Request_BatchGet
- type BatchCommandsRequest_Request_BatchRollback
- type BatchCommandsRequest_Request_CheckSecondaryLocks
- type BatchCommandsRequest_Request_CheckTxnStatus
- type BatchCommandsRequest_Request_Cleanup
- type BatchCommandsRequest_Request_Commit
- type BatchCommandsRequest_Request_Coprocessor
- type BatchCommandsRequest_Request_DeleteRange
- type BatchCommandsRequest_Request_Empty
- type BatchCommandsRequest_Request_FlashbackToVersion
- type BatchCommandsRequest_Request_GC
- type BatchCommandsRequest_Request_Get
- type BatchCommandsRequest_Request_Import
- type BatchCommandsRequest_Request_PessimisticLock
- type BatchCommandsRequest_Request_PessimisticRollback
- type BatchCommandsRequest_Request_PrepareFlashbackToVersion
- type BatchCommandsRequest_Request_Prewrite
- type BatchCommandsRequest_Request_RawBatchDelete
- type BatchCommandsRequest_Request_RawBatchGet
- type BatchCommandsRequest_Request_RawBatchPut
- type BatchCommandsRequest_Request_RawBatchScan
- type BatchCommandsRequest_Request_RawCoprocessor
- type BatchCommandsRequest_Request_RawDelete
- type BatchCommandsRequest_Request_RawDeleteRange
- type BatchCommandsRequest_Request_RawGet
- type BatchCommandsRequest_Request_RawPut
- type BatchCommandsRequest_Request_RawScan
- type BatchCommandsRequest_Request_ResolveLock
- type BatchCommandsRequest_Request_Scan
- type BatchCommandsRequest_Request_ScanLock
- type BatchCommandsRequest_Request_TxnHeartBeat
- type BatchCommandsResponse
- func (*BatchCommandsResponse) Descriptor() ([]byte, []int)
- func (m *BatchCommandsResponse) GetRequestIds() []uint64
- func (m *BatchCommandsResponse) GetResponses() []*BatchCommandsResponse_Response
- func (m *BatchCommandsResponse) GetTransportLayerLoad() uint64
- func (m *BatchCommandsResponse) Marshal() (dAtA []byte, err error)
- func (m *BatchCommandsResponse) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchCommandsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchCommandsResponse) ProtoMessage()
- func (m *BatchCommandsResponse) Reset()
- func (m *BatchCommandsResponse) Size() (n int)
- func (m *BatchCommandsResponse) String() string
- func (m *BatchCommandsResponse) Unmarshal(dAtA []byte) error
- func (m *BatchCommandsResponse) XXX_DiscardUnknown()
- func (m *BatchCommandsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchCommandsResponse) XXX_Merge(src proto.Message)
- func (m *BatchCommandsResponse) XXX_Size() int
- func (m *BatchCommandsResponse) XXX_Unmarshal(b []byte) error
- type BatchCommandsResponse_Response
- func (*BatchCommandsResponse_Response) Descriptor() ([]byte, []int)
- func (m *BatchCommandsResponse_Response) GetBatchGet() *kvrpcpb.BatchGetResponse
- func (m *BatchCommandsResponse_Response) GetBatchRollback() *kvrpcpb.BatchRollbackResponse
- func (m *BatchCommandsResponse_Response) GetCheckSecondaryLocks() *kvrpcpb.CheckSecondaryLocksResponse
- func (m *BatchCommandsResponse_Response) GetCheckTxnStatus() *kvrpcpb.CheckTxnStatusResponse
- func (m *BatchCommandsResponse_Response) GetCleanup() *kvrpcpb.CleanupResponse
- func (m *BatchCommandsResponse_Response) GetCmd() isBatchCommandsResponse_Response_Cmd
- func (m *BatchCommandsResponse_Response) GetCommit() *kvrpcpb.CommitResponse
- func (m *BatchCommandsResponse_Response) GetCoprocessor() *coprocessor.Response
- func (m *BatchCommandsResponse_Response) GetDeleteRange() *kvrpcpb.DeleteRangeResponse
- func (m *BatchCommandsResponse_Response) GetEmpty() *BatchCommandsEmptyResponse
- func (m *BatchCommandsResponse_Response) GetFlashbackToVersion() *kvrpcpb.FlashbackToVersionResponse
- func (m *BatchCommandsResponse_Response) GetGC() *kvrpcpb.GCResponse
- func (m *BatchCommandsResponse_Response) GetGet() *kvrpcpb.GetResponse
- func (m *BatchCommandsResponse_Response) GetImport() *kvrpcpb.ImportResponse
- func (m *BatchCommandsResponse_Response) GetPessimisticLock() *kvrpcpb.PessimisticLockResponse
- func (m *BatchCommandsResponse_Response) GetPessimisticRollback() *kvrpcpb.PessimisticRollbackResponse
- func (m *BatchCommandsResponse_Response) GetPrepareFlashbackToVersion() *kvrpcpb.PrepareFlashbackToVersionResponse
- func (m *BatchCommandsResponse_Response) GetPrewrite() *kvrpcpb.PrewriteResponse
- func (m *BatchCommandsResponse_Response) GetRawBatchDelete() *kvrpcpb.RawBatchDeleteResponse
- func (m *BatchCommandsResponse_Response) GetRawBatchGet() *kvrpcpb.RawBatchGetResponse
- func (m *BatchCommandsResponse_Response) GetRawBatchPut() *kvrpcpb.RawBatchPutResponse
- func (m *BatchCommandsResponse_Response) GetRawBatchScan() *kvrpcpb.RawBatchScanResponse
- func (m *BatchCommandsResponse_Response) GetRawCoprocessor() *kvrpcpb.RawCoprocessorResponse
- func (m *BatchCommandsResponse_Response) GetRawDelete() *kvrpcpb.RawDeleteResponse
- func (m *BatchCommandsResponse_Response) GetRawDeleteRange() *kvrpcpb.RawDeleteRangeResponse
- func (m *BatchCommandsResponse_Response) GetRawGet() *kvrpcpb.RawGetResponse
- func (m *BatchCommandsResponse_Response) GetRawPut() *kvrpcpb.RawPutResponse
- func (m *BatchCommandsResponse_Response) GetRawScan() *kvrpcpb.RawScanResponse
- func (m *BatchCommandsResponse_Response) GetResolveLock() *kvrpcpb.ResolveLockResponse
- func (m *BatchCommandsResponse_Response) GetScan() *kvrpcpb.ScanResponse
- func (m *BatchCommandsResponse_Response) GetScanLock() *kvrpcpb.ScanLockResponse
- func (m *BatchCommandsResponse_Response) GetTxnHeartBeat() *kvrpcpb.TxnHeartBeatResponse
- func (m *BatchCommandsResponse_Response) Marshal() (dAtA []byte, err error)
- func (m *BatchCommandsResponse_Response) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchCommandsResponse_Response) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchCommandsResponse_Response) ProtoMessage()
- func (m *BatchCommandsResponse_Response) Reset()
- func (m *BatchCommandsResponse_Response) Size() (n int)
- func (m *BatchCommandsResponse_Response) String() string
- func (m *BatchCommandsResponse_Response) Unmarshal(dAtA []byte) error
- func (m *BatchCommandsResponse_Response) XXX_DiscardUnknown()
- func (m *BatchCommandsResponse_Response) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchCommandsResponse_Response) XXX_Merge(src proto.Message)
- func (*BatchCommandsResponse_Response) XXX_OneofWrappers() []interface{}
- func (m *BatchCommandsResponse_Response) XXX_Size() int
- func (m *BatchCommandsResponse_Response) XXX_Unmarshal(b []byte) error
- type BatchCommandsResponse_Response_BatchGet
- type BatchCommandsResponse_Response_BatchRollback
- type BatchCommandsResponse_Response_CheckSecondaryLocks
- type BatchCommandsResponse_Response_CheckTxnStatus
- type BatchCommandsResponse_Response_Cleanup
- type BatchCommandsResponse_Response_Commit
- type BatchCommandsResponse_Response_Coprocessor
- type BatchCommandsResponse_Response_DeleteRange
- type BatchCommandsResponse_Response_Empty
- type BatchCommandsResponse_Response_FlashbackToVersion
- type BatchCommandsResponse_Response_GC
- type BatchCommandsResponse_Response_Get
- type BatchCommandsResponse_Response_Import
- type BatchCommandsResponse_Response_PessimisticLock
- type BatchCommandsResponse_Response_PessimisticRollback
- type BatchCommandsResponse_Response_PrepareFlashbackToVersion
- type BatchCommandsResponse_Response_Prewrite
- type BatchCommandsResponse_Response_RawBatchDelete
- type BatchCommandsResponse_Response_RawBatchGet
- type BatchCommandsResponse_Response_RawBatchPut
- type BatchCommandsResponse_Response_RawBatchScan
- type BatchCommandsResponse_Response_RawCoprocessor
- type BatchCommandsResponse_Response_RawDelete
- type BatchCommandsResponse_Response_RawDeleteRange
- type BatchCommandsResponse_Response_RawGet
- type BatchCommandsResponse_Response_RawPut
- type BatchCommandsResponse_Response_RawScan
- type BatchCommandsResponse_Response_ResolveLock
- type BatchCommandsResponse_Response_Scan
- type BatchCommandsResponse_Response_ScanLock
- type BatchCommandsResponse_Response_TxnHeartBeat
- type BatchRaftMessage
- func (*BatchRaftMessage) Descriptor() ([]byte, []int)
- func (m *BatchRaftMessage) GetMsgs() []*raft_serverpb.RaftMessage
- func (m *BatchRaftMessage) Marshal() (dAtA []byte, err error)
- func (m *BatchRaftMessage) MarshalTo(dAtA []byte) (int, error)
- func (m *BatchRaftMessage) MarshalToSizedBuffer(dAtA []byte) (int, error)
- func (*BatchRaftMessage) ProtoMessage()
- func (m *BatchRaftMessage) Reset()
- func (m *BatchRaftMessage) Size() (n int)
- func (m *BatchRaftMessage) String() string
- func (m *BatchRaftMessage) Unmarshal(dAtA []byte) error
- func (m *BatchRaftMessage) XXX_DiscardUnknown()
- func (m *BatchRaftMessage) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
- func (m *BatchRaftMessage) XXX_Merge(src proto.Message)
- func (m *BatchRaftMessage) XXX_Size() int
- func (m *BatchRaftMessage) XXX_Unmarshal(b []byte) error
- type TikvClient
- type TikvServer
- type Tikv_BatchCommandsClient
- type Tikv_BatchCommandsServer
- type Tikv_BatchCoprocessorClient
- type Tikv_BatchCoprocessorServer
- type Tikv_BatchRaftClient
- type Tikv_BatchRaftServer
- type Tikv_CoprocessorStreamClient
- type Tikv_CoprocessorStreamServer
- type Tikv_EstablishMPPConnectionClient
- type Tikv_EstablishMPPConnectionServer
- type Tikv_FetchDisaggPagesClient
- type Tikv_FetchDisaggPagesServer
- type Tikv_RaftClient
- type Tikv_RaftServer
- type Tikv_SnapshotClient
- type Tikv_SnapshotServer
- type Tikv_TabletSnapshotClient
- type Tikv_TabletSnapshotServer
- type UnimplementedTikvServer
- func (*UnimplementedTikvServer) BatchCommands(srv Tikv_BatchCommandsServer) error
- func (*UnimplementedTikvServer) BatchCoprocessor(req *coprocessor.BatchRequest, srv Tikv_BatchCoprocessorServer) error
- func (*UnimplementedTikvServer) BatchRaft(srv Tikv_BatchRaftServer) error
- func (*UnimplementedTikvServer) CancelDisaggTask(ctx context.Context, req *disaggregated.CancelDisaggTaskRequest) (*disaggregated.CancelDisaggTaskResponse, error)
- func (*UnimplementedTikvServer) CancelMPPTask(ctx context.Context, req *mpp.CancelTaskRequest) (*mpp.CancelTaskResponse, error)
- func (*UnimplementedTikvServer) CheckLeader(ctx context.Context, req *kvrpcpb.CheckLeaderRequest) (*kvrpcpb.CheckLeaderResponse, error)
- func (*UnimplementedTikvServer) CheckLockObserver(ctx context.Context, req *kvrpcpb.CheckLockObserverRequest) (*kvrpcpb.CheckLockObserverResponse, error)
- func (*UnimplementedTikvServer) Compact(ctx context.Context, req *kvrpcpb.CompactRequest) (*kvrpcpb.CompactResponse, error)
- func (*UnimplementedTikvServer) Coprocessor(ctx context.Context, req *coprocessor.Request) (*coprocessor.Response, error)
- func (*UnimplementedTikvServer) CoprocessorStream(req *coprocessor.Request, srv Tikv_CoprocessorStreamServer) error
- func (*UnimplementedTikvServer) DispatchMPPTask(ctx context.Context, req *mpp.DispatchTaskRequest) (*mpp.DispatchTaskResponse, error)
- func (*UnimplementedTikvServer) EstablishDisaggTask(ctx context.Context, req *disaggregated.EstablishDisaggTaskRequest) (*disaggregated.EstablishDisaggTaskResponse, error)
- func (*UnimplementedTikvServer) EstablishMPPConnection(req *mpp.EstablishMPPConnectionRequest, srv Tikv_EstablishMPPConnectionServer) error
- func (*UnimplementedTikvServer) FetchDisaggPages(req *disaggregated.FetchDisaggPagesRequest, srv Tikv_FetchDisaggPagesServer) error
- func (*UnimplementedTikvServer) GetDisaggConfig(ctx context.Context, req *disaggregated.GetDisaggConfigRequest) (*disaggregated.GetDisaggConfigResponse, error)
- func (*UnimplementedTikvServer) GetLockWaitHistory(ctx context.Context, req *kvrpcpb.GetLockWaitHistoryRequest) (*kvrpcpb.GetLockWaitHistoryResponse, error)
- func (*UnimplementedTikvServer) GetLockWaitInfo(ctx context.Context, req *kvrpcpb.GetLockWaitInfoRequest) (*kvrpcpb.GetLockWaitInfoResponse, error)
- func (*UnimplementedTikvServer) GetStoreSafeTS(ctx context.Context, req *kvrpcpb.StoreSafeTSRequest) (*kvrpcpb.StoreSafeTSResponse, error)
- func (*UnimplementedTikvServer) GetTiFlashSystemTable(ctx context.Context, req *kvrpcpb.TiFlashSystemTableRequest) (*kvrpcpb.TiFlashSystemTableResponse, error)
- func (*UnimplementedTikvServer) IsAlive(ctx context.Context, req *mpp.IsAliveRequest) (*mpp.IsAliveResponse, error)
- func (*UnimplementedTikvServer) KVPessimisticRollback(ctx context.Context, req *kvrpcpb.PessimisticRollbackRequest) (*kvrpcpb.PessimisticRollbackResponse, error)
- func (*UnimplementedTikvServer) KvBatchGet(ctx context.Context, req *kvrpcpb.BatchGetRequest) (*kvrpcpb.BatchGetResponse, error)
- func (*UnimplementedTikvServer) KvBatchRollback(ctx context.Context, req *kvrpcpb.BatchRollbackRequest) (*kvrpcpb.BatchRollbackResponse, error)
- func (*UnimplementedTikvServer) KvCheckSecondaryLocks(ctx context.Context, req *kvrpcpb.CheckSecondaryLocksRequest) (*kvrpcpb.CheckSecondaryLocksResponse, error)
- func (*UnimplementedTikvServer) KvCheckTxnStatus(ctx context.Context, req *kvrpcpb.CheckTxnStatusRequest) (*kvrpcpb.CheckTxnStatusResponse, error)
- func (*UnimplementedTikvServer) KvCleanup(ctx context.Context, req *kvrpcpb.CleanupRequest) (*kvrpcpb.CleanupResponse, error)
- func (*UnimplementedTikvServer) KvCommit(ctx context.Context, req *kvrpcpb.CommitRequest) (*kvrpcpb.CommitResponse, error)
- func (*UnimplementedTikvServer) KvDeleteRange(ctx context.Context, req *kvrpcpb.DeleteRangeRequest) (*kvrpcpb.DeleteRangeResponse, error)
- func (*UnimplementedTikvServer) KvFlashbackToVersion(ctx context.Context, req *kvrpcpb.FlashbackToVersionRequest) (*kvrpcpb.FlashbackToVersionResponse, error)
- func (*UnimplementedTikvServer) KvGC(ctx context.Context, req *kvrpcpb.GCRequest) (*kvrpcpb.GCResponse, error)
- func (*UnimplementedTikvServer) KvGet(ctx context.Context, req *kvrpcpb.GetRequest) (*kvrpcpb.GetResponse, error)
- func (*UnimplementedTikvServer) KvImport(ctx context.Context, req *kvrpcpb.ImportRequest) (*kvrpcpb.ImportResponse, error)
- func (*UnimplementedTikvServer) KvPessimisticLock(ctx context.Context, req *kvrpcpb.PessimisticLockRequest) (*kvrpcpb.PessimisticLockResponse, error)
- func (*UnimplementedTikvServer) KvPrepareFlashbackToVersion(ctx context.Context, req *kvrpcpb.PrepareFlashbackToVersionRequest) (*kvrpcpb.PrepareFlashbackToVersionResponse, error)
- func (*UnimplementedTikvServer) KvPrewrite(ctx context.Context, req *kvrpcpb.PrewriteRequest) (*kvrpcpb.PrewriteResponse, error)
- func (*UnimplementedTikvServer) KvResolveLock(ctx context.Context, req *kvrpcpb.ResolveLockRequest) (*kvrpcpb.ResolveLockResponse, error)
- func (*UnimplementedTikvServer) KvScan(ctx context.Context, req *kvrpcpb.ScanRequest) (*kvrpcpb.ScanResponse, error)
- func (*UnimplementedTikvServer) KvScanLock(ctx context.Context, req *kvrpcpb.ScanLockRequest) (*kvrpcpb.ScanLockResponse, error)
- func (*UnimplementedTikvServer) KvTxnHeartBeat(ctx context.Context, req *kvrpcpb.TxnHeartBeatRequest) (*kvrpcpb.TxnHeartBeatResponse, error)
- func (*UnimplementedTikvServer) MvccGetByKey(ctx context.Context, req *kvrpcpb.MvccGetByKeyRequest) (*kvrpcpb.MvccGetByKeyResponse, error)
- func (*UnimplementedTikvServer) MvccGetByStartTs(ctx context.Context, req *kvrpcpb.MvccGetByStartTsRequest) (*kvrpcpb.MvccGetByStartTsResponse, error)
- func (*UnimplementedTikvServer) PhysicalScanLock(ctx context.Context, req *kvrpcpb.PhysicalScanLockRequest) (*kvrpcpb.PhysicalScanLockResponse, error)
- func (*UnimplementedTikvServer) Raft(srv Tikv_RaftServer) error
- func (*UnimplementedTikvServer) RawBatchDelete(ctx context.Context, req *kvrpcpb.RawBatchDeleteRequest) (*kvrpcpb.RawBatchDeleteResponse, error)
- func (*UnimplementedTikvServer) RawBatchGet(ctx context.Context, req *kvrpcpb.RawBatchGetRequest) (*kvrpcpb.RawBatchGetResponse, error)
- func (*UnimplementedTikvServer) RawBatchPut(ctx context.Context, req *kvrpcpb.RawBatchPutRequest) (*kvrpcpb.RawBatchPutResponse, error)
- func (*UnimplementedTikvServer) RawBatchScan(ctx context.Context, req *kvrpcpb.RawBatchScanRequest) (*kvrpcpb.RawBatchScanResponse, error)
- func (*UnimplementedTikvServer) RawChecksum(ctx context.Context, req *kvrpcpb.RawChecksumRequest) (*kvrpcpb.RawChecksumResponse, error)
- func (*UnimplementedTikvServer) RawCompareAndSwap(ctx context.Context, req *kvrpcpb.RawCASRequest) (*kvrpcpb.RawCASResponse, error)
- func (*UnimplementedTikvServer) RawCoprocessor(ctx context.Context, req *kvrpcpb.RawCoprocessorRequest) (*kvrpcpb.RawCoprocessorResponse, error)
- func (*UnimplementedTikvServer) RawDelete(ctx context.Context, req *kvrpcpb.RawDeleteRequest) (*kvrpcpb.RawDeleteResponse, error)
- func (*UnimplementedTikvServer) RawDeleteRange(ctx context.Context, req *kvrpcpb.RawDeleteRangeRequest) (*kvrpcpb.RawDeleteRangeResponse, error)
- func (*UnimplementedTikvServer) RawGet(ctx context.Context, req *kvrpcpb.RawGetRequest) (*kvrpcpb.RawGetResponse, error)
- func (*UnimplementedTikvServer) RawGetKeyTTL(ctx context.Context, req *kvrpcpb.RawGetKeyTTLRequest) (*kvrpcpb.RawGetKeyTTLResponse, error)
- func (*UnimplementedTikvServer) RawPut(ctx context.Context, req *kvrpcpb.RawPutRequest) (*kvrpcpb.RawPutResponse, error)
- func (*UnimplementedTikvServer) RawScan(ctx context.Context, req *kvrpcpb.RawScanRequest) (*kvrpcpb.RawScanResponse, error)
- func (*UnimplementedTikvServer) ReadIndex(ctx context.Context, req *kvrpcpb.ReadIndexRequest) (*kvrpcpb.ReadIndexResponse, error)
- func (*UnimplementedTikvServer) RegisterLockObserver(ctx context.Context, req *kvrpcpb.RegisterLockObserverRequest) (*kvrpcpb.RegisterLockObserverResponse, error)
- func (*UnimplementedTikvServer) RemoveLockObserver(ctx context.Context, req *kvrpcpb.RemoveLockObserverRequest) (*kvrpcpb.RemoveLockObserverResponse, error)
- func (*UnimplementedTikvServer) ReportMPPTaskStatus(ctx context.Context, req *mpp.ReportTaskStatusRequest) (*mpp.ReportTaskStatusResponse, error)
- func (*UnimplementedTikvServer) Snapshot(srv Tikv_SnapshotServer) error
- func (*UnimplementedTikvServer) SplitRegion(ctx context.Context, req *kvrpcpb.SplitRegionRequest) (*kvrpcpb.SplitRegionResponse, error)
- func (*UnimplementedTikvServer) TabletSnapshot(srv Tikv_TabletSnapshotServer) error
- func (*UnimplementedTikvServer) TryAddLock(ctx context.Context, req *disaggregated.TryAddLockRequest) (*disaggregated.TryAddLockResponse, error)
- func (*UnimplementedTikvServer) TryMarkDelete(ctx context.Context, req *disaggregated.TryMarkDeleteRequest) (*disaggregated.TryMarkDeleteResponse, error)
- func (*UnimplementedTikvServer) UnsafeDestroyRange(ctx context.Context, req *kvrpcpb.UnsafeDestroyRangeRequest) (*kvrpcpb.UnsafeDestroyRangeResponse, error)
Constants ¶
This section is empty.
Variables ¶
Functions ¶
func RegisterTikvServer ¶
func RegisterTikvServer(s *grpc.Server, srv TikvServer)
Types ¶
type BatchCommandsEmptyRequest ¶
type BatchCommandsEmptyRequest struct { // ID of the test request. TestId uint64 `protobuf:"varint,1,opt,name=test_id,json=testId,proto3" json:"test_id,omitempty"` // TiKV needs to delay at least such a time to response the client. DelayTime uint64 `protobuf:"varint,2,opt,name=delay_time,json=delayTime,proto3" json:"delay_time,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchCommandsEmptyRequest) Descriptor ¶
func (*BatchCommandsEmptyRequest) Descriptor() ([]byte, []int)
func (*BatchCommandsEmptyRequest) GetDelayTime ¶
func (m *BatchCommandsEmptyRequest) GetDelayTime() uint64
func (*BatchCommandsEmptyRequest) GetTestId ¶
func (m *BatchCommandsEmptyRequest) GetTestId() uint64
func (*BatchCommandsEmptyRequest) Marshal ¶
func (m *BatchCommandsEmptyRequest) Marshal() (dAtA []byte, err error)
func (*BatchCommandsEmptyRequest) MarshalTo ¶
func (m *BatchCommandsEmptyRequest) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsEmptyRequest) MarshalToSizedBuffer ¶
func (m *BatchCommandsEmptyRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsEmptyRequest) ProtoMessage ¶
func (*BatchCommandsEmptyRequest) ProtoMessage()
func (*BatchCommandsEmptyRequest) Reset ¶
func (m *BatchCommandsEmptyRequest) Reset()
func (*BatchCommandsEmptyRequest) Size ¶
func (m *BatchCommandsEmptyRequest) Size() (n int)
func (*BatchCommandsEmptyRequest) String ¶
func (m *BatchCommandsEmptyRequest) String() string
func (*BatchCommandsEmptyRequest) Unmarshal ¶
func (m *BatchCommandsEmptyRequest) Unmarshal(dAtA []byte) error
func (*BatchCommandsEmptyRequest) XXX_DiscardUnknown ¶
func (m *BatchCommandsEmptyRequest) XXX_DiscardUnknown()
func (*BatchCommandsEmptyRequest) XXX_Marshal ¶
func (m *BatchCommandsEmptyRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchCommandsEmptyRequest) XXX_Merge ¶
func (m *BatchCommandsEmptyRequest) XXX_Merge(src proto.Message)
func (*BatchCommandsEmptyRequest) XXX_Size ¶
func (m *BatchCommandsEmptyRequest) XXX_Size() int
func (*BatchCommandsEmptyRequest) XXX_Unmarshal ¶
func (m *BatchCommandsEmptyRequest) XXX_Unmarshal(b []byte) error
type BatchCommandsEmptyResponse ¶
type BatchCommandsEmptyResponse struct { // ID of the test request. TestId uint64 `protobuf:"varint,1,opt,name=test_id,json=testId,proto3" json:"test_id,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchCommandsEmptyResponse) Descriptor ¶
func (*BatchCommandsEmptyResponse) Descriptor() ([]byte, []int)
func (*BatchCommandsEmptyResponse) GetTestId ¶
func (m *BatchCommandsEmptyResponse) GetTestId() uint64
func (*BatchCommandsEmptyResponse) Marshal ¶
func (m *BatchCommandsEmptyResponse) Marshal() (dAtA []byte, err error)
func (*BatchCommandsEmptyResponse) MarshalTo ¶
func (m *BatchCommandsEmptyResponse) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsEmptyResponse) MarshalToSizedBuffer ¶
func (m *BatchCommandsEmptyResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsEmptyResponse) ProtoMessage ¶
func (*BatchCommandsEmptyResponse) ProtoMessage()
func (*BatchCommandsEmptyResponse) Reset ¶
func (m *BatchCommandsEmptyResponse) Reset()
func (*BatchCommandsEmptyResponse) Size ¶
func (m *BatchCommandsEmptyResponse) Size() (n int)
func (*BatchCommandsEmptyResponse) String ¶
func (m *BatchCommandsEmptyResponse) String() string
func (*BatchCommandsEmptyResponse) Unmarshal ¶
func (m *BatchCommandsEmptyResponse) Unmarshal(dAtA []byte) error
func (*BatchCommandsEmptyResponse) XXX_DiscardUnknown ¶
func (m *BatchCommandsEmptyResponse) XXX_DiscardUnknown()
func (*BatchCommandsEmptyResponse) XXX_Marshal ¶
func (m *BatchCommandsEmptyResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchCommandsEmptyResponse) XXX_Merge ¶
func (m *BatchCommandsEmptyResponse) XXX_Merge(src proto.Message)
func (*BatchCommandsEmptyResponse) XXX_Size ¶
func (m *BatchCommandsEmptyResponse) XXX_Size() int
func (*BatchCommandsEmptyResponse) XXX_Unmarshal ¶
func (m *BatchCommandsEmptyResponse) XXX_Unmarshal(b []byte) error
type BatchCommandsRequest ¶
type BatchCommandsRequest struct { Requests []*BatchCommandsRequest_Request `protobuf:"bytes,1,rep,name=requests,proto3" json:"requests,omitempty"` RequestIds []uint64 `protobuf:"varint,2,rep,packed,name=request_ids,json=requestIds,proto3" json:"request_ids,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchCommandsRequest) Descriptor ¶
func (*BatchCommandsRequest) Descriptor() ([]byte, []int)
func (*BatchCommandsRequest) GetRequestIds ¶
func (m *BatchCommandsRequest) GetRequestIds() []uint64
func (*BatchCommandsRequest) GetRequests ¶
func (m *BatchCommandsRequest) GetRequests() []*BatchCommandsRequest_Request
func (*BatchCommandsRequest) Marshal ¶
func (m *BatchCommandsRequest) Marshal() (dAtA []byte, err error)
func (*BatchCommandsRequest) MarshalTo ¶
func (m *BatchCommandsRequest) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest) ProtoMessage ¶
func (*BatchCommandsRequest) ProtoMessage()
func (*BatchCommandsRequest) Reset ¶
func (m *BatchCommandsRequest) Reset()
func (*BatchCommandsRequest) Size ¶
func (m *BatchCommandsRequest) Size() (n int)
func (*BatchCommandsRequest) String ¶
func (m *BatchCommandsRequest) String() string
func (*BatchCommandsRequest) Unmarshal ¶
func (m *BatchCommandsRequest) Unmarshal(dAtA []byte) error
func (*BatchCommandsRequest) XXX_DiscardUnknown ¶
func (m *BatchCommandsRequest) XXX_DiscardUnknown()
func (*BatchCommandsRequest) XXX_Marshal ¶
func (m *BatchCommandsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchCommandsRequest) XXX_Merge ¶
func (m *BatchCommandsRequest) XXX_Merge(src proto.Message)
func (*BatchCommandsRequest) XXX_Size ¶
func (m *BatchCommandsRequest) XXX_Size() int
func (*BatchCommandsRequest) XXX_Unmarshal ¶
func (m *BatchCommandsRequest) XXX_Unmarshal(b []byte) error
type BatchCommandsRequest_Request ¶
type BatchCommandsRequest_Request struct { // Types that are valid to be assigned to Cmd: // *BatchCommandsRequest_Request_Get // *BatchCommandsRequest_Request_Scan // *BatchCommandsRequest_Request_Prewrite // *BatchCommandsRequest_Request_Commit // *BatchCommandsRequest_Request_Import // *BatchCommandsRequest_Request_Cleanup // *BatchCommandsRequest_Request_BatchGet // *BatchCommandsRequest_Request_BatchRollback // *BatchCommandsRequest_Request_ScanLock // *BatchCommandsRequest_Request_ResolveLock // *BatchCommandsRequest_Request_GC // *BatchCommandsRequest_Request_DeleteRange // *BatchCommandsRequest_Request_RawGet // *BatchCommandsRequest_Request_RawBatchGet // *BatchCommandsRequest_Request_RawPut // *BatchCommandsRequest_Request_RawBatchPut // *BatchCommandsRequest_Request_RawDelete // *BatchCommandsRequest_Request_RawBatchDelete // *BatchCommandsRequest_Request_RawScan // *BatchCommandsRequest_Request_RawDeleteRange // *BatchCommandsRequest_Request_RawBatchScan // *BatchCommandsRequest_Request_Coprocessor // *BatchCommandsRequest_Request_PessimisticLock // *BatchCommandsRequest_Request_PessimisticRollback // *BatchCommandsRequest_Request_CheckTxnStatus // *BatchCommandsRequest_Request_TxnHeartBeat // *BatchCommandsRequest_Request_CheckSecondaryLocks // *BatchCommandsRequest_Request_RawCoprocessor // *BatchCommandsRequest_Request_FlashbackToVersion // *BatchCommandsRequest_Request_PrepareFlashbackToVersion // *BatchCommandsRequest_Request_Empty Cmd isBatchCommandsRequest_Request_Cmd `protobuf_oneof:"cmd"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchCommandsRequest_Request) Descriptor ¶
func (*BatchCommandsRequest_Request) Descriptor() ([]byte, []int)
func (*BatchCommandsRequest_Request) GetBatchGet ¶
func (m *BatchCommandsRequest_Request) GetBatchGet() *kvrpcpb.BatchGetRequest
func (*BatchCommandsRequest_Request) GetBatchRollback ¶
func (m *BatchCommandsRequest_Request) GetBatchRollback() *kvrpcpb.BatchRollbackRequest
func (*BatchCommandsRequest_Request) GetCheckSecondaryLocks ¶
func (m *BatchCommandsRequest_Request) GetCheckSecondaryLocks() *kvrpcpb.CheckSecondaryLocksRequest
func (*BatchCommandsRequest_Request) GetCheckTxnStatus ¶
func (m *BatchCommandsRequest_Request) GetCheckTxnStatus() *kvrpcpb.CheckTxnStatusRequest
func (*BatchCommandsRequest_Request) GetCleanup ¶
func (m *BatchCommandsRequest_Request) GetCleanup() *kvrpcpb.CleanupRequest
func (*BatchCommandsRequest_Request) GetCmd ¶
func (m *BatchCommandsRequest_Request) GetCmd() isBatchCommandsRequest_Request_Cmd
func (*BatchCommandsRequest_Request) GetCommit ¶
func (m *BatchCommandsRequest_Request) GetCommit() *kvrpcpb.CommitRequest
func (*BatchCommandsRequest_Request) GetCoprocessor ¶
func (m *BatchCommandsRequest_Request) GetCoprocessor() *coprocessor.Request
func (*BatchCommandsRequest_Request) GetDeleteRange ¶
func (m *BatchCommandsRequest_Request) GetDeleteRange() *kvrpcpb.DeleteRangeRequest
func (*BatchCommandsRequest_Request) GetEmpty ¶
func (m *BatchCommandsRequest_Request) GetEmpty() *BatchCommandsEmptyRequest
func (*BatchCommandsRequest_Request) GetFlashbackToVersion ¶
func (m *BatchCommandsRequest_Request) GetFlashbackToVersion() *kvrpcpb.FlashbackToVersionRequest
func (*BatchCommandsRequest_Request) GetGC ¶
func (m *BatchCommandsRequest_Request) GetGC() *kvrpcpb.GCRequest
func (*BatchCommandsRequest_Request) GetGet ¶
func (m *BatchCommandsRequest_Request) GetGet() *kvrpcpb.GetRequest
func (*BatchCommandsRequest_Request) GetImport ¶
func (m *BatchCommandsRequest_Request) GetImport() *kvrpcpb.ImportRequest
func (*BatchCommandsRequest_Request) GetPessimisticLock ¶
func (m *BatchCommandsRequest_Request) GetPessimisticLock() *kvrpcpb.PessimisticLockRequest
func (*BatchCommandsRequest_Request) GetPessimisticRollback ¶
func (m *BatchCommandsRequest_Request) GetPessimisticRollback() *kvrpcpb.PessimisticRollbackRequest
func (*BatchCommandsRequest_Request) GetPrepareFlashbackToVersion ¶
func (m *BatchCommandsRequest_Request) GetPrepareFlashbackToVersion() *kvrpcpb.PrepareFlashbackToVersionRequest
func (*BatchCommandsRequest_Request) GetPrewrite ¶
func (m *BatchCommandsRequest_Request) GetPrewrite() *kvrpcpb.PrewriteRequest
func (*BatchCommandsRequest_Request) GetRawBatchDelete ¶
func (m *BatchCommandsRequest_Request) GetRawBatchDelete() *kvrpcpb.RawBatchDeleteRequest
func (*BatchCommandsRequest_Request) GetRawBatchGet ¶
func (m *BatchCommandsRequest_Request) GetRawBatchGet() *kvrpcpb.RawBatchGetRequest
func (*BatchCommandsRequest_Request) GetRawBatchPut ¶
func (m *BatchCommandsRequest_Request) GetRawBatchPut() *kvrpcpb.RawBatchPutRequest
func (*BatchCommandsRequest_Request) GetRawBatchScan ¶
func (m *BatchCommandsRequest_Request) GetRawBatchScan() *kvrpcpb.RawBatchScanRequest
func (*BatchCommandsRequest_Request) GetRawCoprocessor ¶
func (m *BatchCommandsRequest_Request) GetRawCoprocessor() *kvrpcpb.RawCoprocessorRequest
func (*BatchCommandsRequest_Request) GetRawDelete ¶
func (m *BatchCommandsRequest_Request) GetRawDelete() *kvrpcpb.RawDeleteRequest
func (*BatchCommandsRequest_Request) GetRawDeleteRange ¶
func (m *BatchCommandsRequest_Request) GetRawDeleteRange() *kvrpcpb.RawDeleteRangeRequest
func (*BatchCommandsRequest_Request) GetRawGet ¶
func (m *BatchCommandsRequest_Request) GetRawGet() *kvrpcpb.RawGetRequest
func (*BatchCommandsRequest_Request) GetRawPut ¶
func (m *BatchCommandsRequest_Request) GetRawPut() *kvrpcpb.RawPutRequest
func (*BatchCommandsRequest_Request) GetRawScan ¶
func (m *BatchCommandsRequest_Request) GetRawScan() *kvrpcpb.RawScanRequest
func (*BatchCommandsRequest_Request) GetResolveLock ¶
func (m *BatchCommandsRequest_Request) GetResolveLock() *kvrpcpb.ResolveLockRequest
func (*BatchCommandsRequest_Request) GetScan ¶
func (m *BatchCommandsRequest_Request) GetScan() *kvrpcpb.ScanRequest
func (*BatchCommandsRequest_Request) GetScanLock ¶
func (m *BatchCommandsRequest_Request) GetScanLock() *kvrpcpb.ScanLockRequest
func (*BatchCommandsRequest_Request) GetTxnHeartBeat ¶
func (m *BatchCommandsRequest_Request) GetTxnHeartBeat() *kvrpcpb.TxnHeartBeatRequest
func (*BatchCommandsRequest_Request) Marshal ¶
func (m *BatchCommandsRequest_Request) Marshal() (dAtA []byte, err error)
func (*BatchCommandsRequest_Request) MarshalTo ¶
func (m *BatchCommandsRequest_Request) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request) ProtoMessage ¶
func (*BatchCommandsRequest_Request) ProtoMessage()
func (*BatchCommandsRequest_Request) Reset ¶
func (m *BatchCommandsRequest_Request) Reset()
func (*BatchCommandsRequest_Request) Size ¶
func (m *BatchCommandsRequest_Request) Size() (n int)
func (*BatchCommandsRequest_Request) String ¶
func (m *BatchCommandsRequest_Request) String() string
func (*BatchCommandsRequest_Request) Unmarshal ¶
func (m *BatchCommandsRequest_Request) Unmarshal(dAtA []byte) error
func (*BatchCommandsRequest_Request) XXX_DiscardUnknown ¶
func (m *BatchCommandsRequest_Request) XXX_DiscardUnknown()
func (*BatchCommandsRequest_Request) XXX_Marshal ¶
func (m *BatchCommandsRequest_Request) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchCommandsRequest_Request) XXX_Merge ¶
func (m *BatchCommandsRequest_Request) XXX_Merge(src proto.Message)
func (*BatchCommandsRequest_Request) XXX_OneofWrappers ¶
func (*BatchCommandsRequest_Request) XXX_OneofWrappers() []interface{}
XXX_OneofWrappers is for the internal use of the proto package.
func (*BatchCommandsRequest_Request) XXX_Size ¶
func (m *BatchCommandsRequest_Request) XXX_Size() int
func (*BatchCommandsRequest_Request) XXX_Unmarshal ¶
func (m *BatchCommandsRequest_Request) XXX_Unmarshal(b []byte) error
type BatchCommandsRequest_Request_BatchGet ¶
type BatchCommandsRequest_Request_BatchGet struct {
BatchGet *kvrpcpb.BatchGetRequest `protobuf:"bytes,7,opt,name=BatchGet,proto3,oneof" json:"BatchGet,omitempty"`
}
func (*BatchCommandsRequest_Request_BatchGet) MarshalTo ¶
func (m *BatchCommandsRequest_Request_BatchGet) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_BatchGet) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_BatchGet) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_BatchGet) Size ¶
func (m *BatchCommandsRequest_Request_BatchGet) Size() (n int)
type BatchCommandsRequest_Request_BatchRollback ¶
type BatchCommandsRequest_Request_BatchRollback struct {
BatchRollback *kvrpcpb.BatchRollbackRequest `protobuf:"bytes,8,opt,name=BatchRollback,proto3,oneof" json:"BatchRollback,omitempty"`
}
func (*BatchCommandsRequest_Request_BatchRollback) MarshalTo ¶
func (m *BatchCommandsRequest_Request_BatchRollback) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_BatchRollback) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_BatchRollback) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_BatchRollback) Size ¶
func (m *BatchCommandsRequest_Request_BatchRollback) Size() (n int)
type BatchCommandsRequest_Request_CheckSecondaryLocks ¶
type BatchCommandsRequest_Request_CheckSecondaryLocks struct {
CheckSecondaryLocks *kvrpcpb.CheckSecondaryLocksRequest `protobuf:"bytes,33,opt,name=CheckSecondaryLocks,proto3,oneof" json:"CheckSecondaryLocks,omitempty"`
}
func (*BatchCommandsRequest_Request_CheckSecondaryLocks) MarshalTo ¶
func (m *BatchCommandsRequest_Request_CheckSecondaryLocks) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_CheckSecondaryLocks) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_CheckSecondaryLocks) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_CheckSecondaryLocks) Size ¶
func (m *BatchCommandsRequest_Request_CheckSecondaryLocks) Size() (n int)
type BatchCommandsRequest_Request_CheckTxnStatus ¶
type BatchCommandsRequest_Request_CheckTxnStatus struct {
CheckTxnStatus *kvrpcpb.CheckTxnStatusRequest `protobuf:"bytes,25,opt,name=CheckTxnStatus,proto3,oneof" json:"CheckTxnStatus,omitempty"`
}
func (*BatchCommandsRequest_Request_CheckTxnStatus) MarshalTo ¶
func (m *BatchCommandsRequest_Request_CheckTxnStatus) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_CheckTxnStatus) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_CheckTxnStatus) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_CheckTxnStatus) Size ¶
func (m *BatchCommandsRequest_Request_CheckTxnStatus) Size() (n int)
type BatchCommandsRequest_Request_Cleanup ¶
type BatchCommandsRequest_Request_Cleanup struct {
Cleanup *kvrpcpb.CleanupRequest `protobuf:"bytes,6,opt,name=Cleanup,proto3,oneof" json:"Cleanup,omitempty"`
}
func (*BatchCommandsRequest_Request_Cleanup) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Cleanup) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Cleanup) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Cleanup) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Cleanup) Size ¶
func (m *BatchCommandsRequest_Request_Cleanup) Size() (n int)
type BatchCommandsRequest_Request_Commit ¶
type BatchCommandsRequest_Request_Commit struct {
Commit *kvrpcpb.CommitRequest `protobuf:"bytes,4,opt,name=Commit,proto3,oneof" json:"Commit,omitempty"`
}
func (*BatchCommandsRequest_Request_Commit) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Commit) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Commit) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Commit) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Commit) Size ¶
func (m *BatchCommandsRequest_Request_Commit) Size() (n int)
type BatchCommandsRequest_Request_Coprocessor ¶
type BatchCommandsRequest_Request_Coprocessor struct {
Coprocessor *coprocessor.Request `protobuf:"bytes,22,opt,name=Coprocessor,proto3,oneof" json:"Coprocessor,omitempty"`
}
func (*BatchCommandsRequest_Request_Coprocessor) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Coprocessor) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Coprocessor) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Coprocessor) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Coprocessor) Size ¶
func (m *BatchCommandsRequest_Request_Coprocessor) Size() (n int)
type BatchCommandsRequest_Request_DeleteRange ¶
type BatchCommandsRequest_Request_DeleteRange struct {
DeleteRange *kvrpcpb.DeleteRangeRequest `protobuf:"bytes,12,opt,name=DeleteRange,proto3,oneof" json:"DeleteRange,omitempty"`
}
func (*BatchCommandsRequest_Request_DeleteRange) MarshalTo ¶
func (m *BatchCommandsRequest_Request_DeleteRange) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_DeleteRange) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_DeleteRange) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_DeleteRange) Size ¶
func (m *BatchCommandsRequest_Request_DeleteRange) Size() (n int)
type BatchCommandsRequest_Request_Empty ¶
type BatchCommandsRequest_Request_Empty struct {
Empty *BatchCommandsEmptyRequest `protobuf:"bytes,255,opt,name=Empty,proto3,oneof" json:"Empty,omitempty"`
}
func (*BatchCommandsRequest_Request_Empty) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Empty) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Empty) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Empty) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Empty) Size ¶
func (m *BatchCommandsRequest_Request_Empty) Size() (n int)
type BatchCommandsRequest_Request_FlashbackToVersion ¶
type BatchCommandsRequest_Request_FlashbackToVersion struct {
FlashbackToVersion *kvrpcpb.FlashbackToVersionRequest `protobuf:"bytes,35,opt,name=FlashbackToVersion,proto3,oneof" json:"FlashbackToVersion,omitempty"`
}
func (*BatchCommandsRequest_Request_FlashbackToVersion) MarshalTo ¶
func (m *BatchCommandsRequest_Request_FlashbackToVersion) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_FlashbackToVersion) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_FlashbackToVersion) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_FlashbackToVersion) Size ¶
func (m *BatchCommandsRequest_Request_FlashbackToVersion) Size() (n int)
type BatchCommandsRequest_Request_GC ¶
type BatchCommandsRequest_Request_GC struct {
GC *kvrpcpb.GCRequest `protobuf:"bytes,11,opt,name=GC,proto3,oneof" json:"GC,omitempty"`
}
func (*BatchCommandsRequest_Request_GC) MarshalTo ¶
func (m *BatchCommandsRequest_Request_GC) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_GC) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_GC) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_GC) Size ¶
func (m *BatchCommandsRequest_Request_GC) Size() (n int)
type BatchCommandsRequest_Request_Get ¶
type BatchCommandsRequest_Request_Get struct {
Get *kvrpcpb.GetRequest `protobuf:"bytes,1,opt,name=Get,proto3,oneof" json:"Get,omitempty"`
}
func (*BatchCommandsRequest_Request_Get) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Get) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Get) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Get) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Get) Size ¶
func (m *BatchCommandsRequest_Request_Get) Size() (n int)
type BatchCommandsRequest_Request_Import ¶
type BatchCommandsRequest_Request_Import struct {
Import *kvrpcpb.ImportRequest `protobuf:"bytes,5,opt,name=Import,proto3,oneof" json:"Import,omitempty"`
}
func (*BatchCommandsRequest_Request_Import) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Import) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Import) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Import) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Import) Size ¶
func (m *BatchCommandsRequest_Request_Import) Size() (n int)
type BatchCommandsRequest_Request_PessimisticLock ¶
type BatchCommandsRequest_Request_PessimisticLock struct {
PessimisticLock *kvrpcpb.PessimisticLockRequest `protobuf:"bytes,23,opt,name=PessimisticLock,proto3,oneof" json:"PessimisticLock,omitempty"`
}
func (*BatchCommandsRequest_Request_PessimisticLock) MarshalTo ¶
func (m *BatchCommandsRequest_Request_PessimisticLock) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_PessimisticLock) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_PessimisticLock) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_PessimisticLock) Size ¶
func (m *BatchCommandsRequest_Request_PessimisticLock) Size() (n int)
type BatchCommandsRequest_Request_PessimisticRollback ¶
type BatchCommandsRequest_Request_PessimisticRollback struct {
PessimisticRollback *kvrpcpb.PessimisticRollbackRequest `protobuf:"bytes,24,opt,name=PessimisticRollback,proto3,oneof" json:"PessimisticRollback,omitempty"`
}
func (*BatchCommandsRequest_Request_PessimisticRollback) MarshalTo ¶
func (m *BatchCommandsRequest_Request_PessimisticRollback) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_PessimisticRollback) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_PessimisticRollback) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_PessimisticRollback) Size ¶
func (m *BatchCommandsRequest_Request_PessimisticRollback) Size() (n int)
type BatchCommandsRequest_Request_PrepareFlashbackToVersion ¶
type BatchCommandsRequest_Request_PrepareFlashbackToVersion struct {
PrepareFlashbackToVersion *kvrpcpb.PrepareFlashbackToVersionRequest `protobuf:"bytes,36,opt,name=PrepareFlashbackToVersion,proto3,oneof" json:"PrepareFlashbackToVersion,omitempty"`
}
func (*BatchCommandsRequest_Request_PrepareFlashbackToVersion) MarshalTo ¶
func (m *BatchCommandsRequest_Request_PrepareFlashbackToVersion) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_PrepareFlashbackToVersion) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_PrepareFlashbackToVersion) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_PrepareFlashbackToVersion) Size ¶
func (m *BatchCommandsRequest_Request_PrepareFlashbackToVersion) Size() (n int)
type BatchCommandsRequest_Request_Prewrite ¶
type BatchCommandsRequest_Request_Prewrite struct {
Prewrite *kvrpcpb.PrewriteRequest `protobuf:"bytes,3,opt,name=Prewrite,proto3,oneof" json:"Prewrite,omitempty"`
}
func (*BatchCommandsRequest_Request_Prewrite) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Prewrite) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Prewrite) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Prewrite) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Prewrite) Size ¶
func (m *BatchCommandsRequest_Request_Prewrite) Size() (n int)
type BatchCommandsRequest_Request_RawBatchDelete ¶
type BatchCommandsRequest_Request_RawBatchDelete struct {
RawBatchDelete *kvrpcpb.RawBatchDeleteRequest `protobuf:"bytes,18,opt,name=RawBatchDelete,proto3,oneof" json:"RawBatchDelete,omitempty"`
}
func (*BatchCommandsRequest_Request_RawBatchDelete) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawBatchDelete) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchDelete) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawBatchDelete) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchDelete) Size ¶
func (m *BatchCommandsRequest_Request_RawBatchDelete) Size() (n int)
type BatchCommandsRequest_Request_RawBatchGet ¶
type BatchCommandsRequest_Request_RawBatchGet struct {
RawBatchGet *kvrpcpb.RawBatchGetRequest `protobuf:"bytes,14,opt,name=RawBatchGet,proto3,oneof" json:"RawBatchGet,omitempty"`
}
func (*BatchCommandsRequest_Request_RawBatchGet) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawBatchGet) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchGet) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawBatchGet) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchGet) Size ¶
func (m *BatchCommandsRequest_Request_RawBatchGet) Size() (n int)
type BatchCommandsRequest_Request_RawBatchPut ¶
type BatchCommandsRequest_Request_RawBatchPut struct {
RawBatchPut *kvrpcpb.RawBatchPutRequest `protobuf:"bytes,16,opt,name=RawBatchPut,proto3,oneof" json:"RawBatchPut,omitempty"`
}
func (*BatchCommandsRequest_Request_RawBatchPut) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawBatchPut) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchPut) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawBatchPut) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchPut) Size ¶
func (m *BatchCommandsRequest_Request_RawBatchPut) Size() (n int)
type BatchCommandsRequest_Request_RawBatchScan ¶
type BatchCommandsRequest_Request_RawBatchScan struct {
RawBatchScan *kvrpcpb.RawBatchScanRequest `protobuf:"bytes,21,opt,name=RawBatchScan,proto3,oneof" json:"RawBatchScan,omitempty"`
}
func (*BatchCommandsRequest_Request_RawBatchScan) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawBatchScan) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchScan) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawBatchScan) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawBatchScan) Size ¶
func (m *BatchCommandsRequest_Request_RawBatchScan) Size() (n int)
type BatchCommandsRequest_Request_RawCoprocessor ¶
type BatchCommandsRequest_Request_RawCoprocessor struct {
RawCoprocessor *kvrpcpb.RawCoprocessorRequest `protobuf:"bytes,34,opt,name=RawCoprocessor,proto3,oneof" json:"RawCoprocessor,omitempty"`
}
func (*BatchCommandsRequest_Request_RawCoprocessor) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawCoprocessor) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawCoprocessor) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawCoprocessor) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawCoprocessor) Size ¶
func (m *BatchCommandsRequest_Request_RawCoprocessor) Size() (n int)
type BatchCommandsRequest_Request_RawDelete ¶
type BatchCommandsRequest_Request_RawDelete struct {
RawDelete *kvrpcpb.RawDeleteRequest `protobuf:"bytes,17,opt,name=RawDelete,proto3,oneof" json:"RawDelete,omitempty"`
}
func (*BatchCommandsRequest_Request_RawDelete) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawDelete) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawDelete) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawDelete) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawDelete) Size ¶
func (m *BatchCommandsRequest_Request_RawDelete) Size() (n int)
type BatchCommandsRequest_Request_RawDeleteRange ¶
type BatchCommandsRequest_Request_RawDeleteRange struct {
RawDeleteRange *kvrpcpb.RawDeleteRangeRequest `protobuf:"bytes,20,opt,name=RawDeleteRange,proto3,oneof" json:"RawDeleteRange,omitempty"`
}
func (*BatchCommandsRequest_Request_RawDeleteRange) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawDeleteRange) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawDeleteRange) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawDeleteRange) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawDeleteRange) Size ¶
func (m *BatchCommandsRequest_Request_RawDeleteRange) Size() (n int)
type BatchCommandsRequest_Request_RawGet ¶
type BatchCommandsRequest_Request_RawGet struct {
RawGet *kvrpcpb.RawGetRequest `protobuf:"bytes,13,opt,name=RawGet,proto3,oneof" json:"RawGet,omitempty"`
}
func (*BatchCommandsRequest_Request_RawGet) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawGet) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawGet) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawGet) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawGet) Size ¶
func (m *BatchCommandsRequest_Request_RawGet) Size() (n int)
type BatchCommandsRequest_Request_RawPut ¶
type BatchCommandsRequest_Request_RawPut struct {
RawPut *kvrpcpb.RawPutRequest `protobuf:"bytes,15,opt,name=RawPut,proto3,oneof" json:"RawPut,omitempty"`
}
func (*BatchCommandsRequest_Request_RawPut) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawPut) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawPut) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawPut) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawPut) Size ¶
func (m *BatchCommandsRequest_Request_RawPut) Size() (n int)
type BatchCommandsRequest_Request_RawScan ¶
type BatchCommandsRequest_Request_RawScan struct {
RawScan *kvrpcpb.RawScanRequest `protobuf:"bytes,19,opt,name=RawScan,proto3,oneof" json:"RawScan,omitempty"`
}
func (*BatchCommandsRequest_Request_RawScan) MarshalTo ¶
func (m *BatchCommandsRequest_Request_RawScan) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawScan) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_RawScan) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_RawScan) Size ¶
func (m *BatchCommandsRequest_Request_RawScan) Size() (n int)
type BatchCommandsRequest_Request_ResolveLock ¶
type BatchCommandsRequest_Request_ResolveLock struct {
ResolveLock *kvrpcpb.ResolveLockRequest `protobuf:"bytes,10,opt,name=ResolveLock,proto3,oneof" json:"ResolveLock,omitempty"`
}
func (*BatchCommandsRequest_Request_ResolveLock) MarshalTo ¶
func (m *BatchCommandsRequest_Request_ResolveLock) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_ResolveLock) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_ResolveLock) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_ResolveLock) Size ¶
func (m *BatchCommandsRequest_Request_ResolveLock) Size() (n int)
type BatchCommandsRequest_Request_Scan ¶
type BatchCommandsRequest_Request_Scan struct {
Scan *kvrpcpb.ScanRequest `protobuf:"bytes,2,opt,name=Scan,proto3,oneof" json:"Scan,omitempty"`
}
func (*BatchCommandsRequest_Request_Scan) MarshalTo ¶
func (m *BatchCommandsRequest_Request_Scan) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Scan) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_Scan) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_Scan) Size ¶
func (m *BatchCommandsRequest_Request_Scan) Size() (n int)
type BatchCommandsRequest_Request_ScanLock ¶
type BatchCommandsRequest_Request_ScanLock struct {
ScanLock *kvrpcpb.ScanLockRequest `protobuf:"bytes,9,opt,name=ScanLock,proto3,oneof" json:"ScanLock,omitempty"`
}
func (*BatchCommandsRequest_Request_ScanLock) MarshalTo ¶
func (m *BatchCommandsRequest_Request_ScanLock) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_ScanLock) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_ScanLock) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_ScanLock) Size ¶
func (m *BatchCommandsRequest_Request_ScanLock) Size() (n int)
type BatchCommandsRequest_Request_TxnHeartBeat ¶
type BatchCommandsRequest_Request_TxnHeartBeat struct {
TxnHeartBeat *kvrpcpb.TxnHeartBeatRequest `protobuf:"bytes,26,opt,name=TxnHeartBeat,proto3,oneof" json:"TxnHeartBeat,omitempty"`
}
func (*BatchCommandsRequest_Request_TxnHeartBeat) MarshalTo ¶
func (m *BatchCommandsRequest_Request_TxnHeartBeat) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_TxnHeartBeat) MarshalToSizedBuffer ¶
func (m *BatchCommandsRequest_Request_TxnHeartBeat) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsRequest_Request_TxnHeartBeat) Size ¶
func (m *BatchCommandsRequest_Request_TxnHeartBeat) Size() (n int)
type BatchCommandsResponse ¶
type BatchCommandsResponse struct { Responses []*BatchCommandsResponse_Response `protobuf:"bytes,1,rep,name=responses,proto3" json:"responses,omitempty"` RequestIds []uint64 `protobuf:"varint,2,rep,packed,name=request_ids,json=requestIds,proto3" json:"request_ids,omitempty"` // 280 means TiKV gRPC cpu usage is 280%. TransportLayerLoad uint64 `protobuf:"varint,3,opt,name=transport_layer_load,json=transportLayerLoad,proto3" json:"transport_layer_load,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchCommandsResponse) Descriptor ¶
func (*BatchCommandsResponse) Descriptor() ([]byte, []int)
func (*BatchCommandsResponse) GetRequestIds ¶
func (m *BatchCommandsResponse) GetRequestIds() []uint64
func (*BatchCommandsResponse) GetResponses ¶
func (m *BatchCommandsResponse) GetResponses() []*BatchCommandsResponse_Response
func (*BatchCommandsResponse) GetTransportLayerLoad ¶
func (m *BatchCommandsResponse) GetTransportLayerLoad() uint64
func (*BatchCommandsResponse) Marshal ¶
func (m *BatchCommandsResponse) Marshal() (dAtA []byte, err error)
func (*BatchCommandsResponse) MarshalTo ¶
func (m *BatchCommandsResponse) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse) ProtoMessage ¶
func (*BatchCommandsResponse) ProtoMessage()
func (*BatchCommandsResponse) Reset ¶
func (m *BatchCommandsResponse) Reset()
func (*BatchCommandsResponse) Size ¶
func (m *BatchCommandsResponse) Size() (n int)
func (*BatchCommandsResponse) String ¶
func (m *BatchCommandsResponse) String() string
func (*BatchCommandsResponse) Unmarshal ¶
func (m *BatchCommandsResponse) Unmarshal(dAtA []byte) error
func (*BatchCommandsResponse) XXX_DiscardUnknown ¶
func (m *BatchCommandsResponse) XXX_DiscardUnknown()
func (*BatchCommandsResponse) XXX_Marshal ¶
func (m *BatchCommandsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchCommandsResponse) XXX_Merge ¶
func (m *BatchCommandsResponse) XXX_Merge(src proto.Message)
func (*BatchCommandsResponse) XXX_Size ¶
func (m *BatchCommandsResponse) XXX_Size() int
func (*BatchCommandsResponse) XXX_Unmarshal ¶
func (m *BatchCommandsResponse) XXX_Unmarshal(b []byte) error
type BatchCommandsResponse_Response ¶
type BatchCommandsResponse_Response struct { // Types that are valid to be assigned to Cmd: // *BatchCommandsResponse_Response_Get // *BatchCommandsResponse_Response_Scan // *BatchCommandsResponse_Response_Prewrite // *BatchCommandsResponse_Response_Commit // *BatchCommandsResponse_Response_Import // *BatchCommandsResponse_Response_Cleanup // *BatchCommandsResponse_Response_BatchGet // *BatchCommandsResponse_Response_BatchRollback // *BatchCommandsResponse_Response_ScanLock // *BatchCommandsResponse_Response_ResolveLock // *BatchCommandsResponse_Response_GC // *BatchCommandsResponse_Response_DeleteRange // *BatchCommandsResponse_Response_RawGet // *BatchCommandsResponse_Response_RawBatchGet // *BatchCommandsResponse_Response_RawPut // *BatchCommandsResponse_Response_RawBatchPut // *BatchCommandsResponse_Response_RawDelete // *BatchCommandsResponse_Response_RawBatchDelete // *BatchCommandsResponse_Response_RawScan // *BatchCommandsResponse_Response_RawDeleteRange // *BatchCommandsResponse_Response_RawBatchScan // *BatchCommandsResponse_Response_Coprocessor // *BatchCommandsResponse_Response_PessimisticLock // *BatchCommandsResponse_Response_PessimisticRollback // *BatchCommandsResponse_Response_CheckTxnStatus // *BatchCommandsResponse_Response_TxnHeartBeat // *BatchCommandsResponse_Response_CheckSecondaryLocks // *BatchCommandsResponse_Response_RawCoprocessor // *BatchCommandsResponse_Response_FlashbackToVersion // *BatchCommandsResponse_Response_PrepareFlashbackToVersion // *BatchCommandsResponse_Response_Empty Cmd isBatchCommandsResponse_Response_Cmd `protobuf_oneof:"cmd"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchCommandsResponse_Response) Descriptor ¶
func (*BatchCommandsResponse_Response) Descriptor() ([]byte, []int)
func (*BatchCommandsResponse_Response) GetBatchGet ¶
func (m *BatchCommandsResponse_Response) GetBatchGet() *kvrpcpb.BatchGetResponse
func (*BatchCommandsResponse_Response) GetBatchRollback ¶
func (m *BatchCommandsResponse_Response) GetBatchRollback() *kvrpcpb.BatchRollbackResponse
func (*BatchCommandsResponse_Response) GetCheckSecondaryLocks ¶
func (m *BatchCommandsResponse_Response) GetCheckSecondaryLocks() *kvrpcpb.CheckSecondaryLocksResponse
func (*BatchCommandsResponse_Response) GetCheckTxnStatus ¶
func (m *BatchCommandsResponse_Response) GetCheckTxnStatus() *kvrpcpb.CheckTxnStatusResponse
func (*BatchCommandsResponse_Response) GetCleanup ¶
func (m *BatchCommandsResponse_Response) GetCleanup() *kvrpcpb.CleanupResponse
func (*BatchCommandsResponse_Response) GetCmd ¶
func (m *BatchCommandsResponse_Response) GetCmd() isBatchCommandsResponse_Response_Cmd
func (*BatchCommandsResponse_Response) GetCommit ¶
func (m *BatchCommandsResponse_Response) GetCommit() *kvrpcpb.CommitResponse
func (*BatchCommandsResponse_Response) GetCoprocessor ¶
func (m *BatchCommandsResponse_Response) GetCoprocessor() *coprocessor.Response
func (*BatchCommandsResponse_Response) GetDeleteRange ¶
func (m *BatchCommandsResponse_Response) GetDeleteRange() *kvrpcpb.DeleteRangeResponse
func (*BatchCommandsResponse_Response) GetEmpty ¶
func (m *BatchCommandsResponse_Response) GetEmpty() *BatchCommandsEmptyResponse
func (*BatchCommandsResponse_Response) GetFlashbackToVersion ¶
func (m *BatchCommandsResponse_Response) GetFlashbackToVersion() *kvrpcpb.FlashbackToVersionResponse
func (*BatchCommandsResponse_Response) GetGC ¶
func (m *BatchCommandsResponse_Response) GetGC() *kvrpcpb.GCResponse
func (*BatchCommandsResponse_Response) GetGet ¶
func (m *BatchCommandsResponse_Response) GetGet() *kvrpcpb.GetResponse
func (*BatchCommandsResponse_Response) GetImport ¶
func (m *BatchCommandsResponse_Response) GetImport() *kvrpcpb.ImportResponse
func (*BatchCommandsResponse_Response) GetPessimisticLock ¶
func (m *BatchCommandsResponse_Response) GetPessimisticLock() *kvrpcpb.PessimisticLockResponse
func (*BatchCommandsResponse_Response) GetPessimisticRollback ¶
func (m *BatchCommandsResponse_Response) GetPessimisticRollback() *kvrpcpb.PessimisticRollbackResponse
func (*BatchCommandsResponse_Response) GetPrepareFlashbackToVersion ¶
func (m *BatchCommandsResponse_Response) GetPrepareFlashbackToVersion() *kvrpcpb.PrepareFlashbackToVersionResponse
func (*BatchCommandsResponse_Response) GetPrewrite ¶
func (m *BatchCommandsResponse_Response) GetPrewrite() *kvrpcpb.PrewriteResponse
func (*BatchCommandsResponse_Response) GetRawBatchDelete ¶
func (m *BatchCommandsResponse_Response) GetRawBatchDelete() *kvrpcpb.RawBatchDeleteResponse
func (*BatchCommandsResponse_Response) GetRawBatchGet ¶
func (m *BatchCommandsResponse_Response) GetRawBatchGet() *kvrpcpb.RawBatchGetResponse
func (*BatchCommandsResponse_Response) GetRawBatchPut ¶
func (m *BatchCommandsResponse_Response) GetRawBatchPut() *kvrpcpb.RawBatchPutResponse
func (*BatchCommandsResponse_Response) GetRawBatchScan ¶
func (m *BatchCommandsResponse_Response) GetRawBatchScan() *kvrpcpb.RawBatchScanResponse
func (*BatchCommandsResponse_Response) GetRawCoprocessor ¶
func (m *BatchCommandsResponse_Response) GetRawCoprocessor() *kvrpcpb.RawCoprocessorResponse
func (*BatchCommandsResponse_Response) GetRawDelete ¶
func (m *BatchCommandsResponse_Response) GetRawDelete() *kvrpcpb.RawDeleteResponse
func (*BatchCommandsResponse_Response) GetRawDeleteRange ¶
func (m *BatchCommandsResponse_Response) GetRawDeleteRange() *kvrpcpb.RawDeleteRangeResponse
func (*BatchCommandsResponse_Response) GetRawGet ¶
func (m *BatchCommandsResponse_Response) GetRawGet() *kvrpcpb.RawGetResponse
func (*BatchCommandsResponse_Response) GetRawPut ¶
func (m *BatchCommandsResponse_Response) GetRawPut() *kvrpcpb.RawPutResponse
func (*BatchCommandsResponse_Response) GetRawScan ¶
func (m *BatchCommandsResponse_Response) GetRawScan() *kvrpcpb.RawScanResponse
func (*BatchCommandsResponse_Response) GetResolveLock ¶
func (m *BatchCommandsResponse_Response) GetResolveLock() *kvrpcpb.ResolveLockResponse
func (*BatchCommandsResponse_Response) GetScan ¶
func (m *BatchCommandsResponse_Response) GetScan() *kvrpcpb.ScanResponse
func (*BatchCommandsResponse_Response) GetScanLock ¶
func (m *BatchCommandsResponse_Response) GetScanLock() *kvrpcpb.ScanLockResponse
func (*BatchCommandsResponse_Response) GetTxnHeartBeat ¶
func (m *BatchCommandsResponse_Response) GetTxnHeartBeat() *kvrpcpb.TxnHeartBeatResponse
func (*BatchCommandsResponse_Response) Marshal ¶
func (m *BatchCommandsResponse_Response) Marshal() (dAtA []byte, err error)
func (*BatchCommandsResponse_Response) MarshalTo ¶
func (m *BatchCommandsResponse_Response) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response) ProtoMessage ¶
func (*BatchCommandsResponse_Response) ProtoMessage()
func (*BatchCommandsResponse_Response) Reset ¶
func (m *BatchCommandsResponse_Response) Reset()
func (*BatchCommandsResponse_Response) Size ¶
func (m *BatchCommandsResponse_Response) Size() (n int)
func (*BatchCommandsResponse_Response) String ¶
func (m *BatchCommandsResponse_Response) String() string
func (*BatchCommandsResponse_Response) Unmarshal ¶
func (m *BatchCommandsResponse_Response) Unmarshal(dAtA []byte) error
func (*BatchCommandsResponse_Response) XXX_DiscardUnknown ¶
func (m *BatchCommandsResponse_Response) XXX_DiscardUnknown()
func (*BatchCommandsResponse_Response) XXX_Marshal ¶
func (m *BatchCommandsResponse_Response) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchCommandsResponse_Response) XXX_Merge ¶
func (m *BatchCommandsResponse_Response) XXX_Merge(src proto.Message)
func (*BatchCommandsResponse_Response) XXX_OneofWrappers ¶
func (*BatchCommandsResponse_Response) XXX_OneofWrappers() []interface{}
XXX_OneofWrappers is for the internal use of the proto package.
func (*BatchCommandsResponse_Response) XXX_Size ¶
func (m *BatchCommandsResponse_Response) XXX_Size() int
func (*BatchCommandsResponse_Response) XXX_Unmarshal ¶
func (m *BatchCommandsResponse_Response) XXX_Unmarshal(b []byte) error
type BatchCommandsResponse_Response_BatchGet ¶
type BatchCommandsResponse_Response_BatchGet struct {
BatchGet *kvrpcpb.BatchGetResponse `protobuf:"bytes,7,opt,name=BatchGet,proto3,oneof" json:"BatchGet,omitempty"`
}
func (*BatchCommandsResponse_Response_BatchGet) MarshalTo ¶
func (m *BatchCommandsResponse_Response_BatchGet) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_BatchGet) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_BatchGet) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_BatchGet) Size ¶
func (m *BatchCommandsResponse_Response_BatchGet) Size() (n int)
type BatchCommandsResponse_Response_BatchRollback ¶
type BatchCommandsResponse_Response_BatchRollback struct {
BatchRollback *kvrpcpb.BatchRollbackResponse `protobuf:"bytes,8,opt,name=BatchRollback,proto3,oneof" json:"BatchRollback,omitempty"`
}
func (*BatchCommandsResponse_Response_BatchRollback) MarshalTo ¶
func (m *BatchCommandsResponse_Response_BatchRollback) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_BatchRollback) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_BatchRollback) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_BatchRollback) Size ¶
func (m *BatchCommandsResponse_Response_BatchRollback) Size() (n int)
type BatchCommandsResponse_Response_CheckSecondaryLocks ¶
type BatchCommandsResponse_Response_CheckSecondaryLocks struct {
CheckSecondaryLocks *kvrpcpb.CheckSecondaryLocksResponse `protobuf:"bytes,33,opt,name=CheckSecondaryLocks,proto3,oneof" json:"CheckSecondaryLocks,omitempty"`
}
func (*BatchCommandsResponse_Response_CheckSecondaryLocks) MarshalTo ¶
func (m *BatchCommandsResponse_Response_CheckSecondaryLocks) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_CheckSecondaryLocks) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_CheckSecondaryLocks) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_CheckSecondaryLocks) Size ¶
func (m *BatchCommandsResponse_Response_CheckSecondaryLocks) Size() (n int)
type BatchCommandsResponse_Response_CheckTxnStatus ¶
type BatchCommandsResponse_Response_CheckTxnStatus struct {
CheckTxnStatus *kvrpcpb.CheckTxnStatusResponse `protobuf:"bytes,25,opt,name=CheckTxnStatus,proto3,oneof" json:"CheckTxnStatus,omitempty"`
}
func (*BatchCommandsResponse_Response_CheckTxnStatus) MarshalTo ¶
func (m *BatchCommandsResponse_Response_CheckTxnStatus) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_CheckTxnStatus) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_CheckTxnStatus) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_CheckTxnStatus) Size ¶
func (m *BatchCommandsResponse_Response_CheckTxnStatus) Size() (n int)
type BatchCommandsResponse_Response_Cleanup ¶
type BatchCommandsResponse_Response_Cleanup struct {
Cleanup *kvrpcpb.CleanupResponse `protobuf:"bytes,6,opt,name=Cleanup,proto3,oneof" json:"Cleanup,omitempty"`
}
func (*BatchCommandsResponse_Response_Cleanup) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Cleanup) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Cleanup) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Cleanup) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Cleanup) Size ¶
func (m *BatchCommandsResponse_Response_Cleanup) Size() (n int)
type BatchCommandsResponse_Response_Commit ¶
type BatchCommandsResponse_Response_Commit struct {
Commit *kvrpcpb.CommitResponse `protobuf:"bytes,4,opt,name=Commit,proto3,oneof" json:"Commit,omitempty"`
}
func (*BatchCommandsResponse_Response_Commit) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Commit) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Commit) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Commit) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Commit) Size ¶
func (m *BatchCommandsResponse_Response_Commit) Size() (n int)
type BatchCommandsResponse_Response_Coprocessor ¶
type BatchCommandsResponse_Response_Coprocessor struct {
Coprocessor *coprocessor.Response `protobuf:"bytes,22,opt,name=Coprocessor,proto3,oneof" json:"Coprocessor,omitempty"`
}
func (*BatchCommandsResponse_Response_Coprocessor) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Coprocessor) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Coprocessor) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Coprocessor) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Coprocessor) Size ¶
func (m *BatchCommandsResponse_Response_Coprocessor) Size() (n int)
type BatchCommandsResponse_Response_DeleteRange ¶
type BatchCommandsResponse_Response_DeleteRange struct {
DeleteRange *kvrpcpb.DeleteRangeResponse `protobuf:"bytes,12,opt,name=DeleteRange,proto3,oneof" json:"DeleteRange,omitempty"`
}
func (*BatchCommandsResponse_Response_DeleteRange) MarshalTo ¶
func (m *BatchCommandsResponse_Response_DeleteRange) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_DeleteRange) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_DeleteRange) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_DeleteRange) Size ¶
func (m *BatchCommandsResponse_Response_DeleteRange) Size() (n int)
type BatchCommandsResponse_Response_Empty ¶
type BatchCommandsResponse_Response_Empty struct {
Empty *BatchCommandsEmptyResponse `protobuf:"bytes,255,opt,name=Empty,proto3,oneof" json:"Empty,omitempty"`
}
func (*BatchCommandsResponse_Response_Empty) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Empty) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Empty) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Empty) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Empty) Size ¶
func (m *BatchCommandsResponse_Response_Empty) Size() (n int)
type BatchCommandsResponse_Response_FlashbackToVersion ¶
type BatchCommandsResponse_Response_FlashbackToVersion struct {
FlashbackToVersion *kvrpcpb.FlashbackToVersionResponse `protobuf:"bytes,35,opt,name=FlashbackToVersion,proto3,oneof" json:"FlashbackToVersion,omitempty"`
}
func (*BatchCommandsResponse_Response_FlashbackToVersion) MarshalTo ¶
func (m *BatchCommandsResponse_Response_FlashbackToVersion) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_FlashbackToVersion) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_FlashbackToVersion) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_FlashbackToVersion) Size ¶
func (m *BatchCommandsResponse_Response_FlashbackToVersion) Size() (n int)
type BatchCommandsResponse_Response_GC ¶
type BatchCommandsResponse_Response_GC struct {
GC *kvrpcpb.GCResponse `protobuf:"bytes,11,opt,name=GC,proto3,oneof" json:"GC,omitempty"`
}
func (*BatchCommandsResponse_Response_GC) MarshalTo ¶
func (m *BatchCommandsResponse_Response_GC) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_GC) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_GC) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_GC) Size ¶
func (m *BatchCommandsResponse_Response_GC) Size() (n int)
type BatchCommandsResponse_Response_Get ¶
type BatchCommandsResponse_Response_Get struct {
Get *kvrpcpb.GetResponse `protobuf:"bytes,1,opt,name=Get,proto3,oneof" json:"Get,omitempty"`
}
func (*BatchCommandsResponse_Response_Get) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Get) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Get) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Get) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Get) Size ¶
func (m *BatchCommandsResponse_Response_Get) Size() (n int)
type BatchCommandsResponse_Response_Import ¶
type BatchCommandsResponse_Response_Import struct {
Import *kvrpcpb.ImportResponse `protobuf:"bytes,5,opt,name=Import,proto3,oneof" json:"Import,omitempty"`
}
func (*BatchCommandsResponse_Response_Import) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Import) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Import) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Import) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Import) Size ¶
func (m *BatchCommandsResponse_Response_Import) Size() (n int)
type BatchCommandsResponse_Response_PessimisticLock ¶
type BatchCommandsResponse_Response_PessimisticLock struct {
PessimisticLock *kvrpcpb.PessimisticLockResponse `protobuf:"bytes,23,opt,name=PessimisticLock,proto3,oneof" json:"PessimisticLock,omitempty"`
}
func (*BatchCommandsResponse_Response_PessimisticLock) MarshalTo ¶
func (m *BatchCommandsResponse_Response_PessimisticLock) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_PessimisticLock) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_PessimisticLock) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_PessimisticLock) Size ¶
func (m *BatchCommandsResponse_Response_PessimisticLock) Size() (n int)
type BatchCommandsResponse_Response_PessimisticRollback ¶
type BatchCommandsResponse_Response_PessimisticRollback struct {
PessimisticRollback *kvrpcpb.PessimisticRollbackResponse `protobuf:"bytes,24,opt,name=PessimisticRollback,proto3,oneof" json:"PessimisticRollback,omitempty"`
}
func (*BatchCommandsResponse_Response_PessimisticRollback) MarshalTo ¶
func (m *BatchCommandsResponse_Response_PessimisticRollback) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_PessimisticRollback) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_PessimisticRollback) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_PessimisticRollback) Size ¶
func (m *BatchCommandsResponse_Response_PessimisticRollback) Size() (n int)
type BatchCommandsResponse_Response_PrepareFlashbackToVersion ¶
type BatchCommandsResponse_Response_PrepareFlashbackToVersion struct {
PrepareFlashbackToVersion *kvrpcpb.PrepareFlashbackToVersionResponse `protobuf:"bytes,36,opt,name=PrepareFlashbackToVersion,proto3,oneof" json:"PrepareFlashbackToVersion,omitempty"`
}
func (*BatchCommandsResponse_Response_PrepareFlashbackToVersion) MarshalTo ¶
func (m *BatchCommandsResponse_Response_PrepareFlashbackToVersion) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_PrepareFlashbackToVersion) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_PrepareFlashbackToVersion) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_PrepareFlashbackToVersion) Size ¶
func (m *BatchCommandsResponse_Response_PrepareFlashbackToVersion) Size() (n int)
type BatchCommandsResponse_Response_Prewrite ¶
type BatchCommandsResponse_Response_Prewrite struct {
Prewrite *kvrpcpb.PrewriteResponse `protobuf:"bytes,3,opt,name=Prewrite,proto3,oneof" json:"Prewrite,omitempty"`
}
func (*BatchCommandsResponse_Response_Prewrite) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Prewrite) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Prewrite) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Prewrite) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Prewrite) Size ¶
func (m *BatchCommandsResponse_Response_Prewrite) Size() (n int)
type BatchCommandsResponse_Response_RawBatchDelete ¶
type BatchCommandsResponse_Response_RawBatchDelete struct {
RawBatchDelete *kvrpcpb.RawBatchDeleteResponse `protobuf:"bytes,18,opt,name=RawBatchDelete,proto3,oneof" json:"RawBatchDelete,omitempty"`
}
func (*BatchCommandsResponse_Response_RawBatchDelete) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawBatchDelete) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchDelete) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawBatchDelete) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchDelete) Size ¶
func (m *BatchCommandsResponse_Response_RawBatchDelete) Size() (n int)
type BatchCommandsResponse_Response_RawBatchGet ¶
type BatchCommandsResponse_Response_RawBatchGet struct {
RawBatchGet *kvrpcpb.RawBatchGetResponse `protobuf:"bytes,14,opt,name=RawBatchGet,proto3,oneof" json:"RawBatchGet,omitempty"`
}
func (*BatchCommandsResponse_Response_RawBatchGet) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawBatchGet) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchGet) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawBatchGet) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchGet) Size ¶
func (m *BatchCommandsResponse_Response_RawBatchGet) Size() (n int)
type BatchCommandsResponse_Response_RawBatchPut ¶
type BatchCommandsResponse_Response_RawBatchPut struct {
RawBatchPut *kvrpcpb.RawBatchPutResponse `protobuf:"bytes,16,opt,name=RawBatchPut,proto3,oneof" json:"RawBatchPut,omitempty"`
}
func (*BatchCommandsResponse_Response_RawBatchPut) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawBatchPut) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchPut) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawBatchPut) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchPut) Size ¶
func (m *BatchCommandsResponse_Response_RawBatchPut) Size() (n int)
type BatchCommandsResponse_Response_RawBatchScan ¶
type BatchCommandsResponse_Response_RawBatchScan struct {
RawBatchScan *kvrpcpb.RawBatchScanResponse `protobuf:"bytes,21,opt,name=RawBatchScan,proto3,oneof" json:"RawBatchScan,omitempty"`
}
func (*BatchCommandsResponse_Response_RawBatchScan) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawBatchScan) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchScan) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawBatchScan) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawBatchScan) Size ¶
func (m *BatchCommandsResponse_Response_RawBatchScan) Size() (n int)
type BatchCommandsResponse_Response_RawCoprocessor ¶
type BatchCommandsResponse_Response_RawCoprocessor struct {
RawCoprocessor *kvrpcpb.RawCoprocessorResponse `protobuf:"bytes,34,opt,name=RawCoprocessor,proto3,oneof" json:"RawCoprocessor,omitempty"`
}
func (*BatchCommandsResponse_Response_RawCoprocessor) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawCoprocessor) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawCoprocessor) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawCoprocessor) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawCoprocessor) Size ¶
func (m *BatchCommandsResponse_Response_RawCoprocessor) Size() (n int)
type BatchCommandsResponse_Response_RawDelete ¶
type BatchCommandsResponse_Response_RawDelete struct {
RawDelete *kvrpcpb.RawDeleteResponse `protobuf:"bytes,17,opt,name=RawDelete,proto3,oneof" json:"RawDelete,omitempty"`
}
func (*BatchCommandsResponse_Response_RawDelete) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawDelete) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawDelete) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawDelete) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawDelete) Size ¶
func (m *BatchCommandsResponse_Response_RawDelete) Size() (n int)
type BatchCommandsResponse_Response_RawDeleteRange ¶
type BatchCommandsResponse_Response_RawDeleteRange struct {
RawDeleteRange *kvrpcpb.RawDeleteRangeResponse `protobuf:"bytes,20,opt,name=RawDeleteRange,proto3,oneof" json:"RawDeleteRange,omitempty"`
}
func (*BatchCommandsResponse_Response_RawDeleteRange) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawDeleteRange) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawDeleteRange) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawDeleteRange) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawDeleteRange) Size ¶
func (m *BatchCommandsResponse_Response_RawDeleteRange) Size() (n int)
type BatchCommandsResponse_Response_RawGet ¶
type BatchCommandsResponse_Response_RawGet struct {
RawGet *kvrpcpb.RawGetResponse `protobuf:"bytes,13,opt,name=RawGet,proto3,oneof" json:"RawGet,omitempty"`
}
func (*BatchCommandsResponse_Response_RawGet) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawGet) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawGet) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawGet) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawGet) Size ¶
func (m *BatchCommandsResponse_Response_RawGet) Size() (n int)
type BatchCommandsResponse_Response_RawPut ¶
type BatchCommandsResponse_Response_RawPut struct {
RawPut *kvrpcpb.RawPutResponse `protobuf:"bytes,15,opt,name=RawPut,proto3,oneof" json:"RawPut,omitempty"`
}
func (*BatchCommandsResponse_Response_RawPut) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawPut) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawPut) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawPut) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawPut) Size ¶
func (m *BatchCommandsResponse_Response_RawPut) Size() (n int)
type BatchCommandsResponse_Response_RawScan ¶
type BatchCommandsResponse_Response_RawScan struct {
RawScan *kvrpcpb.RawScanResponse `protobuf:"bytes,19,opt,name=RawScan,proto3,oneof" json:"RawScan,omitempty"`
}
func (*BatchCommandsResponse_Response_RawScan) MarshalTo ¶
func (m *BatchCommandsResponse_Response_RawScan) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawScan) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_RawScan) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_RawScan) Size ¶
func (m *BatchCommandsResponse_Response_RawScan) Size() (n int)
type BatchCommandsResponse_Response_ResolveLock ¶
type BatchCommandsResponse_Response_ResolveLock struct {
ResolveLock *kvrpcpb.ResolveLockResponse `protobuf:"bytes,10,opt,name=ResolveLock,proto3,oneof" json:"ResolveLock,omitempty"`
}
func (*BatchCommandsResponse_Response_ResolveLock) MarshalTo ¶
func (m *BatchCommandsResponse_Response_ResolveLock) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_ResolveLock) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_ResolveLock) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_ResolveLock) Size ¶
func (m *BatchCommandsResponse_Response_ResolveLock) Size() (n int)
type BatchCommandsResponse_Response_Scan ¶
type BatchCommandsResponse_Response_Scan struct {
Scan *kvrpcpb.ScanResponse `protobuf:"bytes,2,opt,name=Scan,proto3,oneof" json:"Scan,omitempty"`
}
func (*BatchCommandsResponse_Response_Scan) MarshalTo ¶
func (m *BatchCommandsResponse_Response_Scan) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Scan) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_Scan) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_Scan) Size ¶
func (m *BatchCommandsResponse_Response_Scan) Size() (n int)
type BatchCommandsResponse_Response_ScanLock ¶
type BatchCommandsResponse_Response_ScanLock struct {
ScanLock *kvrpcpb.ScanLockResponse `protobuf:"bytes,9,opt,name=ScanLock,proto3,oneof" json:"ScanLock,omitempty"`
}
func (*BatchCommandsResponse_Response_ScanLock) MarshalTo ¶
func (m *BatchCommandsResponse_Response_ScanLock) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_ScanLock) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_ScanLock) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_ScanLock) Size ¶
func (m *BatchCommandsResponse_Response_ScanLock) Size() (n int)
type BatchCommandsResponse_Response_TxnHeartBeat ¶
type BatchCommandsResponse_Response_TxnHeartBeat struct {
TxnHeartBeat *kvrpcpb.TxnHeartBeatResponse `protobuf:"bytes,26,opt,name=TxnHeartBeat,proto3,oneof" json:"TxnHeartBeat,omitempty"`
}
func (*BatchCommandsResponse_Response_TxnHeartBeat) MarshalTo ¶
func (m *BatchCommandsResponse_Response_TxnHeartBeat) MarshalTo(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_TxnHeartBeat) MarshalToSizedBuffer ¶
func (m *BatchCommandsResponse_Response_TxnHeartBeat) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchCommandsResponse_Response_TxnHeartBeat) Size ¶
func (m *BatchCommandsResponse_Response_TxnHeartBeat) Size() (n int)
type BatchRaftMessage ¶
type BatchRaftMessage struct { Msgs []*raft_serverpb.RaftMessage `protobuf:"bytes,1,rep,name=msgs,proto3" json:"msgs,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` }
func (*BatchRaftMessage) Descriptor ¶
func (*BatchRaftMessage) Descriptor() ([]byte, []int)
func (*BatchRaftMessage) GetMsgs ¶
func (m *BatchRaftMessage) GetMsgs() []*raft_serverpb.RaftMessage
func (*BatchRaftMessage) Marshal ¶
func (m *BatchRaftMessage) Marshal() (dAtA []byte, err error)
func (*BatchRaftMessage) MarshalToSizedBuffer ¶
func (m *BatchRaftMessage) MarshalToSizedBuffer(dAtA []byte) (int, error)
func (*BatchRaftMessage) ProtoMessage ¶
func (*BatchRaftMessage) ProtoMessage()
func (*BatchRaftMessage) Reset ¶
func (m *BatchRaftMessage) Reset()
func (*BatchRaftMessage) Size ¶
func (m *BatchRaftMessage) Size() (n int)
func (*BatchRaftMessage) String ¶
func (m *BatchRaftMessage) String() string
func (*BatchRaftMessage) Unmarshal ¶
func (m *BatchRaftMessage) Unmarshal(dAtA []byte) error
func (*BatchRaftMessage) XXX_DiscardUnknown ¶
func (m *BatchRaftMessage) XXX_DiscardUnknown()
func (*BatchRaftMessage) XXX_Marshal ¶
func (m *BatchRaftMessage) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)
func (*BatchRaftMessage) XXX_Merge ¶
func (m *BatchRaftMessage) XXX_Merge(src proto.Message)
func (*BatchRaftMessage) XXX_Size ¶
func (m *BatchRaftMessage) XXX_Size() int
func (*BatchRaftMessage) XXX_Unmarshal ¶
func (m *BatchRaftMessage) XXX_Unmarshal(b []byte) error
type TikvClient ¶
type TikvClient interface { // Commands using a transactional interface. KvGet(ctx context.Context, in *kvrpcpb.GetRequest, opts ...grpc.CallOption) (*kvrpcpb.GetResponse, error) KvScan(ctx context.Context, in *kvrpcpb.ScanRequest, opts ...grpc.CallOption) (*kvrpcpb.ScanResponse, error) KvPrewrite(ctx context.Context, in *kvrpcpb.PrewriteRequest, opts ...grpc.CallOption) (*kvrpcpb.PrewriteResponse, error) KvPessimisticLock(ctx context.Context, in *kvrpcpb.PessimisticLockRequest, opts ...grpc.CallOption) (*kvrpcpb.PessimisticLockResponse, error) KVPessimisticRollback(ctx context.Context, in *kvrpcpb.PessimisticRollbackRequest, opts ...grpc.CallOption) (*kvrpcpb.PessimisticRollbackResponse, error) KvTxnHeartBeat(ctx context.Context, in *kvrpcpb.TxnHeartBeatRequest, opts ...grpc.CallOption) (*kvrpcpb.TxnHeartBeatResponse, error) KvCheckTxnStatus(ctx context.Context, in *kvrpcpb.CheckTxnStatusRequest, opts ...grpc.CallOption) (*kvrpcpb.CheckTxnStatusResponse, error) KvCheckSecondaryLocks(ctx context.Context, in *kvrpcpb.CheckSecondaryLocksRequest, opts ...grpc.CallOption) (*kvrpcpb.CheckSecondaryLocksResponse, error) KvCommit(ctx context.Context, in *kvrpcpb.CommitRequest, opts ...grpc.CallOption) (*kvrpcpb.CommitResponse, error) KvImport(ctx context.Context, in *kvrpcpb.ImportRequest, opts ...grpc.CallOption) (*kvrpcpb.ImportResponse, error) KvCleanup(ctx context.Context, in *kvrpcpb.CleanupRequest, opts ...grpc.CallOption) (*kvrpcpb.CleanupResponse, error) KvBatchGet(ctx context.Context, in *kvrpcpb.BatchGetRequest, opts ...grpc.CallOption) (*kvrpcpb.BatchGetResponse, error) KvBatchRollback(ctx context.Context, in *kvrpcpb.BatchRollbackRequest, opts ...grpc.CallOption) (*kvrpcpb.BatchRollbackResponse, error) KvScanLock(ctx context.Context, in *kvrpcpb.ScanLockRequest, opts ...grpc.CallOption) (*kvrpcpb.ScanLockResponse, error) KvResolveLock(ctx context.Context, in *kvrpcpb.ResolveLockRequest, opts ...grpc.CallOption) (*kvrpcpb.ResolveLockResponse, error) KvGC(ctx context.Context, in *kvrpcpb.GCRequest, opts ...grpc.CallOption) (*kvrpcpb.GCResponse, error) KvDeleteRange(ctx context.Context, in *kvrpcpb.DeleteRangeRequest, opts ...grpc.CallOption) (*kvrpcpb.DeleteRangeResponse, error) KvPrepareFlashbackToVersion(ctx context.Context, in *kvrpcpb.PrepareFlashbackToVersionRequest, opts ...grpc.CallOption) (*kvrpcpb.PrepareFlashbackToVersionResponse, error) KvFlashbackToVersion(ctx context.Context, in *kvrpcpb.FlashbackToVersionRequest, opts ...grpc.CallOption) (*kvrpcpb.FlashbackToVersionResponse, error) // Raw commands; no transaction support. RawGet(ctx context.Context, in *kvrpcpb.RawGetRequest, opts ...grpc.CallOption) (*kvrpcpb.RawGetResponse, error) RawBatchGet(ctx context.Context, in *kvrpcpb.RawBatchGetRequest, opts ...grpc.CallOption) (*kvrpcpb.RawBatchGetResponse, error) RawPut(ctx context.Context, in *kvrpcpb.RawPutRequest, opts ...grpc.CallOption) (*kvrpcpb.RawPutResponse, error) RawBatchPut(ctx context.Context, in *kvrpcpb.RawBatchPutRequest, opts ...grpc.CallOption) (*kvrpcpb.RawBatchPutResponse, error) RawDelete(ctx context.Context, in *kvrpcpb.RawDeleteRequest, opts ...grpc.CallOption) (*kvrpcpb.RawDeleteResponse, error) RawBatchDelete(ctx context.Context, in *kvrpcpb.RawBatchDeleteRequest, opts ...grpc.CallOption) (*kvrpcpb.RawBatchDeleteResponse, error) RawScan(ctx context.Context, in *kvrpcpb.RawScanRequest, opts ...grpc.CallOption) (*kvrpcpb.RawScanResponse, error) RawDeleteRange(ctx context.Context, in *kvrpcpb.RawDeleteRangeRequest, opts ...grpc.CallOption) (*kvrpcpb.RawDeleteRangeResponse, error) RawBatchScan(ctx context.Context, in *kvrpcpb.RawBatchScanRequest, opts ...grpc.CallOption) (*kvrpcpb.RawBatchScanResponse, error) // Get TTL of the key. Returns 0 if TTL is not set for the key. RawGetKeyTTL(ctx context.Context, in *kvrpcpb.RawGetKeyTTLRequest, opts ...grpc.CallOption) (*kvrpcpb.RawGetKeyTTLResponse, error) // Compare if the value in database equals to `RawCASRequest.previous_value` before putting the new value. If not, this request will have no effect and the value in the database will be returned. RawCompareAndSwap(ctx context.Context, in *kvrpcpb.RawCASRequest, opts ...grpc.CallOption) (*kvrpcpb.RawCASResponse, error) RawChecksum(ctx context.Context, in *kvrpcpb.RawChecksumRequest, opts ...grpc.CallOption) (*kvrpcpb.RawChecksumResponse, error) // Store commands (sent to a each TiKV node in a cluster, rather than a certain region). UnsafeDestroyRange(ctx context.Context, in *kvrpcpb.UnsafeDestroyRangeRequest, opts ...grpc.CallOption) (*kvrpcpb.UnsafeDestroyRangeResponse, error) RegisterLockObserver(ctx context.Context, in *kvrpcpb.RegisterLockObserverRequest, opts ...grpc.CallOption) (*kvrpcpb.RegisterLockObserverResponse, error) CheckLockObserver(ctx context.Context, in *kvrpcpb.CheckLockObserverRequest, opts ...grpc.CallOption) (*kvrpcpb.CheckLockObserverResponse, error) RemoveLockObserver(ctx context.Context, in *kvrpcpb.RemoveLockObserverRequest, opts ...grpc.CallOption) (*kvrpcpb.RemoveLockObserverResponse, error) PhysicalScanLock(ctx context.Context, in *kvrpcpb.PhysicalScanLockRequest, opts ...grpc.CallOption) (*kvrpcpb.PhysicalScanLockResponse, error) // Commands for executing SQL in the TiKV coprocessor (i.e., 'pushed down' to TiKV rather than // executed in TiDB). Coprocessor(ctx context.Context, in *coprocessor.Request, opts ...grpc.CallOption) (*coprocessor.Response, error) CoprocessorStream(ctx context.Context, in *coprocessor.Request, opts ...grpc.CallOption) (Tikv_CoprocessorStreamClient, error) BatchCoprocessor(ctx context.Context, in *coprocessor.BatchRequest, opts ...grpc.CallOption) (Tikv_BatchCoprocessorClient, error) // Command for executing custom user requests in TiKV coprocessor_v2. RawCoprocessor(ctx context.Context, in *kvrpcpb.RawCoprocessorRequest, opts ...grpc.CallOption) (*kvrpcpb.RawCoprocessorResponse, error) // Raft commands (sent between TiKV nodes). Raft(ctx context.Context, opts ...grpc.CallOption) (Tikv_RaftClient, error) BatchRaft(ctx context.Context, opts ...grpc.CallOption) (Tikv_BatchRaftClient, error) Snapshot(ctx context.Context, opts ...grpc.CallOption) (Tikv_SnapshotClient, error) TabletSnapshot(ctx context.Context, opts ...grpc.CallOption) (Tikv_TabletSnapshotClient, error) // Sent from TM or TiDB to a TiKV node. SplitRegion(ctx context.Context, in *kvrpcpb.SplitRegionRequest, opts ...grpc.CallOption) (*kvrpcpb.SplitRegionResponse, error) // Sent from TiFlash or TiKV to a TiKV node. ReadIndex(ctx context.Context, in *kvrpcpb.ReadIndexRequest, opts ...grpc.CallOption) (*kvrpcpb.ReadIndexResponse, error) // Commands for debugging transactions. MvccGetByKey(ctx context.Context, in *kvrpcpb.MvccGetByKeyRequest, opts ...grpc.CallOption) (*kvrpcpb.MvccGetByKeyResponse, error) MvccGetByStartTs(ctx context.Context, in *kvrpcpb.MvccGetByStartTsRequest, opts ...grpc.CallOption) (*kvrpcpb.MvccGetByStartTsResponse, error) // Batched commands. BatchCommands(ctx context.Context, opts ...grpc.CallOption) (Tikv_BatchCommandsClient, error) // These are for mpp execution. DispatchMPPTask(ctx context.Context, in *mpp.DispatchTaskRequest, opts ...grpc.CallOption) (*mpp.DispatchTaskResponse, error) CancelMPPTask(ctx context.Context, in *mpp.CancelTaskRequest, opts ...grpc.CallOption) (*mpp.CancelTaskResponse, error) EstablishMPPConnection(ctx context.Context, in *mpp.EstablishMPPConnectionRequest, opts ...grpc.CallOption) (Tikv_EstablishMPPConnectionClient, error) IsAlive(ctx context.Context, in *mpp.IsAliveRequest, opts ...grpc.CallOption) (*mpp.IsAliveResponse, error) ReportMPPTaskStatus(ctx context.Context, in *mpp.ReportTaskStatusRequest, opts ...grpc.CallOption) (*mpp.ReportTaskStatusResponse, error) /// CheckLeader sends all information (includes region term and epoch) to other stores. /// Once a store receives a request, it checks term and epoch for each region, and sends the regions whose /// term and epoch match with local information in the store. /// After the client collected all responses from all stores, it checks if got a quorum of responses from /// other stores for every region, and decides to advance resolved ts from these regions. CheckLeader(ctx context.Context, in *kvrpcpb.CheckLeaderRequest, opts ...grpc.CallOption) (*kvrpcpb.CheckLeaderResponse, error) /// Get the minimal `safe_ts` from regions at the store GetStoreSafeTS(ctx context.Context, in *kvrpcpb.StoreSafeTSRequest, opts ...grpc.CallOption) (*kvrpcpb.StoreSafeTSResponse, error) /// Get the information about lock waiting from TiKV. GetLockWaitInfo(ctx context.Context, in *kvrpcpb.GetLockWaitInfoRequest, opts ...grpc.CallOption) (*kvrpcpb.GetLockWaitInfoResponse, error) /// Compact a specified key range. This request is not restricted to raft leaders and will not be replicated. /// It only compacts data on this node. /// TODO: Currently this RPC is designed to be only compatible with TiFlash. /// Shall be move out in https://github.com/gottingen/kvproto/issues/912 Compact(ctx context.Context, in *kvrpcpb.CompactRequest, opts ...grpc.CallOption) (*kvrpcpb.CompactResponse, error) /// Get the information about history lock waiting from TiKV. GetLockWaitHistory(ctx context.Context, in *kvrpcpb.GetLockWaitHistoryRequest, opts ...grpc.CallOption) (*kvrpcpb.GetLockWaitHistoryResponse, error) /// Get system table from TiFlash GetTiFlashSystemTable(ctx context.Context, in *kvrpcpb.TiFlashSystemTableRequest, opts ...grpc.CallOption) (*kvrpcpb.TiFlashSystemTableResponse, error) // These are for TiFlash disaggregated architecture /// Try to lock a S3 object, atomically TryAddLock(ctx context.Context, in *disaggregated.TryAddLockRequest, opts ...grpc.CallOption) (*disaggregated.TryAddLockResponse, error) /// Try to delete a S3 object, atomically TryMarkDelete(ctx context.Context, in *disaggregated.TryMarkDeleteRequest, opts ...grpc.CallOption) (*disaggregated.TryMarkDeleteResponse, error) /// Build the disaggregated task on TiFlash write node EstablishDisaggTask(ctx context.Context, in *disaggregated.EstablishDisaggTaskRequest, opts ...grpc.CallOption) (*disaggregated.EstablishDisaggTaskResponse, error) /// Cancel the disaggregated task on TiFlash write node CancelDisaggTask(ctx context.Context, in *disaggregated.CancelDisaggTaskRequest, opts ...grpc.CallOption) (*disaggregated.CancelDisaggTaskResponse, error) /// Exchange page data between TiFlash write node and compute node FetchDisaggPages(ctx context.Context, in *disaggregated.FetchDisaggPagesRequest, opts ...grpc.CallOption) (Tikv_FetchDisaggPagesClient, error) /// Compute node get configuration from Write node GetDisaggConfig(ctx context.Context, in *disaggregated.GetDisaggConfigRequest, opts ...grpc.CallOption) (*disaggregated.GetDisaggConfigResponse, error) }
TikvClient is the client API for Tikv service.
For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.
func NewTikvClient ¶
func NewTikvClient(cc *grpc.ClientConn) TikvClient
type TikvServer ¶
type TikvServer interface { // Commands using a transactional interface. KvGet(context.Context, *kvrpcpb.GetRequest) (*kvrpcpb.GetResponse, error) KvScan(context.Context, *kvrpcpb.ScanRequest) (*kvrpcpb.ScanResponse, error) KvPrewrite(context.Context, *kvrpcpb.PrewriteRequest) (*kvrpcpb.PrewriteResponse, error) KvPessimisticLock(context.Context, *kvrpcpb.PessimisticLockRequest) (*kvrpcpb.PessimisticLockResponse, error) KVPessimisticRollback(context.Context, *kvrpcpb.PessimisticRollbackRequest) (*kvrpcpb.PessimisticRollbackResponse, error) KvTxnHeartBeat(context.Context, *kvrpcpb.TxnHeartBeatRequest) (*kvrpcpb.TxnHeartBeatResponse, error) KvCheckTxnStatus(context.Context, *kvrpcpb.CheckTxnStatusRequest) (*kvrpcpb.CheckTxnStatusResponse, error) KvCheckSecondaryLocks(context.Context, *kvrpcpb.CheckSecondaryLocksRequest) (*kvrpcpb.CheckSecondaryLocksResponse, error) KvCommit(context.Context, *kvrpcpb.CommitRequest) (*kvrpcpb.CommitResponse, error) KvImport(context.Context, *kvrpcpb.ImportRequest) (*kvrpcpb.ImportResponse, error) KvCleanup(context.Context, *kvrpcpb.CleanupRequest) (*kvrpcpb.CleanupResponse, error) KvBatchGet(context.Context, *kvrpcpb.BatchGetRequest) (*kvrpcpb.BatchGetResponse, error) KvBatchRollback(context.Context, *kvrpcpb.BatchRollbackRequest) (*kvrpcpb.BatchRollbackResponse, error) KvScanLock(context.Context, *kvrpcpb.ScanLockRequest) (*kvrpcpb.ScanLockResponse, error) KvResolveLock(context.Context, *kvrpcpb.ResolveLockRequest) (*kvrpcpb.ResolveLockResponse, error) KvGC(context.Context, *kvrpcpb.GCRequest) (*kvrpcpb.GCResponse, error) KvDeleteRange(context.Context, *kvrpcpb.DeleteRangeRequest) (*kvrpcpb.DeleteRangeResponse, error) KvPrepareFlashbackToVersion(context.Context, *kvrpcpb.PrepareFlashbackToVersionRequest) (*kvrpcpb.PrepareFlashbackToVersionResponse, error) KvFlashbackToVersion(context.Context, *kvrpcpb.FlashbackToVersionRequest) (*kvrpcpb.FlashbackToVersionResponse, error) // Raw commands; no transaction support. RawGet(context.Context, *kvrpcpb.RawGetRequest) (*kvrpcpb.RawGetResponse, error) RawBatchGet(context.Context, *kvrpcpb.RawBatchGetRequest) (*kvrpcpb.RawBatchGetResponse, error) RawPut(context.Context, *kvrpcpb.RawPutRequest) (*kvrpcpb.RawPutResponse, error) RawBatchPut(context.Context, *kvrpcpb.RawBatchPutRequest) (*kvrpcpb.RawBatchPutResponse, error) RawDelete(context.Context, *kvrpcpb.RawDeleteRequest) (*kvrpcpb.RawDeleteResponse, error) RawBatchDelete(context.Context, *kvrpcpb.RawBatchDeleteRequest) (*kvrpcpb.RawBatchDeleteResponse, error) RawScan(context.Context, *kvrpcpb.RawScanRequest) (*kvrpcpb.RawScanResponse, error) RawDeleteRange(context.Context, *kvrpcpb.RawDeleteRangeRequest) (*kvrpcpb.RawDeleteRangeResponse, error) RawBatchScan(context.Context, *kvrpcpb.RawBatchScanRequest) (*kvrpcpb.RawBatchScanResponse, error) // Get TTL of the key. Returns 0 if TTL is not set for the key. RawGetKeyTTL(context.Context, *kvrpcpb.RawGetKeyTTLRequest) (*kvrpcpb.RawGetKeyTTLResponse, error) // Compare if the value in database equals to `RawCASRequest.previous_value` before putting the new value. If not, this request will have no effect and the value in the database will be returned. RawCompareAndSwap(context.Context, *kvrpcpb.RawCASRequest) (*kvrpcpb.RawCASResponse, error) RawChecksum(context.Context, *kvrpcpb.RawChecksumRequest) (*kvrpcpb.RawChecksumResponse, error) // Store commands (sent to a each TiKV node in a cluster, rather than a certain region). UnsafeDestroyRange(context.Context, *kvrpcpb.UnsafeDestroyRangeRequest) (*kvrpcpb.UnsafeDestroyRangeResponse, error) RegisterLockObserver(context.Context, *kvrpcpb.RegisterLockObserverRequest) (*kvrpcpb.RegisterLockObserverResponse, error) CheckLockObserver(context.Context, *kvrpcpb.CheckLockObserverRequest) (*kvrpcpb.CheckLockObserverResponse, error) RemoveLockObserver(context.Context, *kvrpcpb.RemoveLockObserverRequest) (*kvrpcpb.RemoveLockObserverResponse, error) PhysicalScanLock(context.Context, *kvrpcpb.PhysicalScanLockRequest) (*kvrpcpb.PhysicalScanLockResponse, error) // Commands for executing SQL in the TiKV coprocessor (i.e., 'pushed down' to TiKV rather than // executed in TiDB). Coprocessor(context.Context, *coprocessor.Request) (*coprocessor.Response, error) CoprocessorStream(*coprocessor.Request, Tikv_CoprocessorStreamServer) error BatchCoprocessor(*coprocessor.BatchRequest, Tikv_BatchCoprocessorServer) error // Command for executing custom user requests in TiKV coprocessor_v2. RawCoprocessor(context.Context, *kvrpcpb.RawCoprocessorRequest) (*kvrpcpb.RawCoprocessorResponse, error) // Raft commands (sent between TiKV nodes). Raft(Tikv_RaftServer) error BatchRaft(Tikv_BatchRaftServer) error Snapshot(Tikv_SnapshotServer) error TabletSnapshot(Tikv_TabletSnapshotServer) error // Sent from TM or TiDB to a TiKV node. SplitRegion(context.Context, *kvrpcpb.SplitRegionRequest) (*kvrpcpb.SplitRegionResponse, error) // Sent from TiFlash or TiKV to a TiKV node. ReadIndex(context.Context, *kvrpcpb.ReadIndexRequest) (*kvrpcpb.ReadIndexResponse, error) // Commands for debugging transactions. MvccGetByKey(context.Context, *kvrpcpb.MvccGetByKeyRequest) (*kvrpcpb.MvccGetByKeyResponse, error) MvccGetByStartTs(context.Context, *kvrpcpb.MvccGetByStartTsRequest) (*kvrpcpb.MvccGetByStartTsResponse, error) // Batched commands. BatchCommands(Tikv_BatchCommandsServer) error // These are for mpp execution. DispatchMPPTask(context.Context, *mpp.DispatchTaskRequest) (*mpp.DispatchTaskResponse, error) CancelMPPTask(context.Context, *mpp.CancelTaskRequest) (*mpp.CancelTaskResponse, error) EstablishMPPConnection(*mpp.EstablishMPPConnectionRequest, Tikv_EstablishMPPConnectionServer) error IsAlive(context.Context, *mpp.IsAliveRequest) (*mpp.IsAliveResponse, error) ReportMPPTaskStatus(context.Context, *mpp.ReportTaskStatusRequest) (*mpp.ReportTaskStatusResponse, error) /// CheckLeader sends all information (includes region term and epoch) to other stores. /// Once a store receives a request, it checks term and epoch for each region, and sends the regions whose /// term and epoch match with local information in the store. /// After the client collected all responses from all stores, it checks if got a quorum of responses from /// other stores for every region, and decides to advance resolved ts from these regions. CheckLeader(context.Context, *kvrpcpb.CheckLeaderRequest) (*kvrpcpb.CheckLeaderResponse, error) /// Get the minimal `safe_ts` from regions at the store GetStoreSafeTS(context.Context, *kvrpcpb.StoreSafeTSRequest) (*kvrpcpb.StoreSafeTSResponse, error) /// Get the information about lock waiting from TiKV. GetLockWaitInfo(context.Context, *kvrpcpb.GetLockWaitInfoRequest) (*kvrpcpb.GetLockWaitInfoResponse, error) /// Compact a specified key range. This request is not restricted to raft leaders and will not be replicated. /// It only compacts data on this node. /// TODO: Currently this RPC is designed to be only compatible with TiFlash. /// Shall be move out in https://github.com/gottingen/kvproto/issues/912 Compact(context.Context, *kvrpcpb.CompactRequest) (*kvrpcpb.CompactResponse, error) /// Get the information about history lock waiting from TiKV. GetLockWaitHistory(context.Context, *kvrpcpb.GetLockWaitHistoryRequest) (*kvrpcpb.GetLockWaitHistoryResponse, error) /// Get system table from TiFlash GetTiFlashSystemTable(context.Context, *kvrpcpb.TiFlashSystemTableRequest) (*kvrpcpb.TiFlashSystemTableResponse, error) // These are for TiFlash disaggregated architecture /// Try to lock a S3 object, atomically TryAddLock(context.Context, *disaggregated.TryAddLockRequest) (*disaggregated.TryAddLockResponse, error) /// Try to delete a S3 object, atomically TryMarkDelete(context.Context, *disaggregated.TryMarkDeleteRequest) (*disaggregated.TryMarkDeleteResponse, error) /// Build the disaggregated task on TiFlash write node EstablishDisaggTask(context.Context, *disaggregated.EstablishDisaggTaskRequest) (*disaggregated.EstablishDisaggTaskResponse, error) /// Cancel the disaggregated task on TiFlash write node CancelDisaggTask(context.Context, *disaggregated.CancelDisaggTaskRequest) (*disaggregated.CancelDisaggTaskResponse, error) /// Exchange page data between TiFlash write node and compute node FetchDisaggPages(*disaggregated.FetchDisaggPagesRequest, Tikv_FetchDisaggPagesServer) error /// Compute node get configuration from Write node GetDisaggConfig(context.Context, *disaggregated.GetDisaggConfigRequest) (*disaggregated.GetDisaggConfigResponse, error) }
TikvServer is the server API for Tikv service.
type Tikv_BatchCommandsClient ¶
type Tikv_BatchCommandsClient interface { Send(*BatchCommandsRequest) error Recv() (*BatchCommandsResponse, error) grpc.ClientStream }
type Tikv_BatchCommandsServer ¶
type Tikv_BatchCommandsServer interface { Send(*BatchCommandsResponse) error Recv() (*BatchCommandsRequest, error) grpc.ServerStream }
type Tikv_BatchCoprocessorClient ¶
type Tikv_BatchCoprocessorClient interface { Recv() (*coprocessor.BatchResponse, error) grpc.ClientStream }
type Tikv_BatchCoprocessorServer ¶
type Tikv_BatchCoprocessorServer interface { Send(*coprocessor.BatchResponse) error grpc.ServerStream }
type Tikv_BatchRaftClient ¶
type Tikv_BatchRaftClient interface { Send(*BatchRaftMessage) error CloseAndRecv() (*raft_serverpb.Done, error) grpc.ClientStream }
type Tikv_BatchRaftServer ¶
type Tikv_BatchRaftServer interface { SendAndClose(*raft_serverpb.Done) error Recv() (*BatchRaftMessage, error) grpc.ServerStream }
type Tikv_CoprocessorStreamClient ¶
type Tikv_CoprocessorStreamClient interface { Recv() (*coprocessor.Response, error) grpc.ClientStream }
type Tikv_CoprocessorStreamServer ¶
type Tikv_CoprocessorStreamServer interface { Send(*coprocessor.Response) error grpc.ServerStream }
type Tikv_EstablishMPPConnectionClient ¶
type Tikv_EstablishMPPConnectionClient interface { Recv() (*mpp.MPPDataPacket, error) grpc.ClientStream }
type Tikv_EstablishMPPConnectionServer ¶
type Tikv_EstablishMPPConnectionServer interface { Send(*mpp.MPPDataPacket) error grpc.ServerStream }
type Tikv_FetchDisaggPagesClient ¶
type Tikv_FetchDisaggPagesClient interface { Recv() (*disaggregated.PagesPacket, error) grpc.ClientStream }
type Tikv_FetchDisaggPagesServer ¶
type Tikv_FetchDisaggPagesServer interface { Send(*disaggregated.PagesPacket) error grpc.ServerStream }
type Tikv_RaftClient ¶
type Tikv_RaftClient interface { Send(*raft_serverpb.RaftMessage) error CloseAndRecv() (*raft_serverpb.Done, error) grpc.ClientStream }
type Tikv_RaftServer ¶
type Tikv_RaftServer interface { SendAndClose(*raft_serverpb.Done) error Recv() (*raft_serverpb.RaftMessage, error) grpc.ServerStream }
type Tikv_SnapshotClient ¶
type Tikv_SnapshotClient interface { Send(*raft_serverpb.SnapshotChunk) error CloseAndRecv() (*raft_serverpb.Done, error) grpc.ClientStream }
type Tikv_SnapshotServer ¶
type Tikv_SnapshotServer interface { SendAndClose(*raft_serverpb.Done) error Recv() (*raft_serverpb.SnapshotChunk, error) grpc.ServerStream }
type Tikv_TabletSnapshotClient ¶
type Tikv_TabletSnapshotClient interface { Send(*raft_serverpb.TabletSnapshotRequest) error Recv() (*raft_serverpb.TabletSnapshotResponse, error) grpc.ClientStream }
type Tikv_TabletSnapshotServer ¶
type Tikv_TabletSnapshotServer interface { Send(*raft_serverpb.TabletSnapshotResponse) error Recv() (*raft_serverpb.TabletSnapshotRequest, error) grpc.ServerStream }
type UnimplementedTikvServer ¶
type UnimplementedTikvServer struct { }
UnimplementedTikvServer can be embedded to have forward compatible implementations.
func (*UnimplementedTikvServer) BatchCommands ¶
func (*UnimplementedTikvServer) BatchCommands(srv Tikv_BatchCommandsServer) error
func (*UnimplementedTikvServer) BatchCoprocessor ¶
func (*UnimplementedTikvServer) BatchCoprocessor(req *coprocessor.BatchRequest, srv Tikv_BatchCoprocessorServer) error
func (*UnimplementedTikvServer) BatchRaft ¶
func (*UnimplementedTikvServer) BatchRaft(srv Tikv_BatchRaftServer) error
func (*UnimplementedTikvServer) CancelDisaggTask ¶
func (*UnimplementedTikvServer) CancelDisaggTask(ctx context.Context, req *disaggregated.CancelDisaggTaskRequest) (*disaggregated.CancelDisaggTaskResponse, error)
func (*UnimplementedTikvServer) CancelMPPTask ¶
func (*UnimplementedTikvServer) CancelMPPTask(ctx context.Context, req *mpp.CancelTaskRequest) (*mpp.CancelTaskResponse, error)
func (*UnimplementedTikvServer) CheckLeader ¶
func (*UnimplementedTikvServer) CheckLeader(ctx context.Context, req *kvrpcpb.CheckLeaderRequest) (*kvrpcpb.CheckLeaderResponse, error)
func (*UnimplementedTikvServer) CheckLockObserver ¶
func (*UnimplementedTikvServer) CheckLockObserver(ctx context.Context, req *kvrpcpb.CheckLockObserverRequest) (*kvrpcpb.CheckLockObserverResponse, error)
func (*UnimplementedTikvServer) Compact ¶
func (*UnimplementedTikvServer) Compact(ctx context.Context, req *kvrpcpb.CompactRequest) (*kvrpcpb.CompactResponse, error)
func (*UnimplementedTikvServer) Coprocessor ¶
func (*UnimplementedTikvServer) Coprocessor(ctx context.Context, req *coprocessor.Request) (*coprocessor.Response, error)
func (*UnimplementedTikvServer) CoprocessorStream ¶
func (*UnimplementedTikvServer) CoprocessorStream(req *coprocessor.Request, srv Tikv_CoprocessorStreamServer) error
func (*UnimplementedTikvServer) DispatchMPPTask ¶
func (*UnimplementedTikvServer) DispatchMPPTask(ctx context.Context, req *mpp.DispatchTaskRequest) (*mpp.DispatchTaskResponse, error)
func (*UnimplementedTikvServer) EstablishDisaggTask ¶
func (*UnimplementedTikvServer) EstablishDisaggTask(ctx context.Context, req *disaggregated.EstablishDisaggTaskRequest) (*disaggregated.EstablishDisaggTaskResponse, error)
func (*UnimplementedTikvServer) EstablishMPPConnection ¶
func (*UnimplementedTikvServer) EstablishMPPConnection(req *mpp.EstablishMPPConnectionRequest, srv Tikv_EstablishMPPConnectionServer) error
func (*UnimplementedTikvServer) FetchDisaggPages ¶
func (*UnimplementedTikvServer) FetchDisaggPages(req *disaggregated.FetchDisaggPagesRequest, srv Tikv_FetchDisaggPagesServer) error
func (*UnimplementedTikvServer) GetDisaggConfig ¶
func (*UnimplementedTikvServer) GetDisaggConfig(ctx context.Context, req *disaggregated.GetDisaggConfigRequest) (*disaggregated.GetDisaggConfigResponse, error)
func (*UnimplementedTikvServer) GetLockWaitHistory ¶
func (*UnimplementedTikvServer) GetLockWaitHistory(ctx context.Context, req *kvrpcpb.GetLockWaitHistoryRequest) (*kvrpcpb.GetLockWaitHistoryResponse, error)
func (*UnimplementedTikvServer) GetLockWaitInfo ¶
func (*UnimplementedTikvServer) GetLockWaitInfo(ctx context.Context, req *kvrpcpb.GetLockWaitInfoRequest) (*kvrpcpb.GetLockWaitInfoResponse, error)
func (*UnimplementedTikvServer) GetStoreSafeTS ¶
func (*UnimplementedTikvServer) GetStoreSafeTS(ctx context.Context, req *kvrpcpb.StoreSafeTSRequest) (*kvrpcpb.StoreSafeTSResponse, error)
func (*UnimplementedTikvServer) GetTiFlashSystemTable ¶
func (*UnimplementedTikvServer) GetTiFlashSystemTable(ctx context.Context, req *kvrpcpb.TiFlashSystemTableRequest) (*kvrpcpb.TiFlashSystemTableResponse, error)
func (*UnimplementedTikvServer) IsAlive ¶
func (*UnimplementedTikvServer) IsAlive(ctx context.Context, req *mpp.IsAliveRequest) (*mpp.IsAliveResponse, error)
func (*UnimplementedTikvServer) KVPessimisticRollback ¶
func (*UnimplementedTikvServer) KVPessimisticRollback(ctx context.Context, req *kvrpcpb.PessimisticRollbackRequest) (*kvrpcpb.PessimisticRollbackResponse, error)
func (*UnimplementedTikvServer) KvBatchGet ¶
func (*UnimplementedTikvServer) KvBatchGet(ctx context.Context, req *kvrpcpb.BatchGetRequest) (*kvrpcpb.BatchGetResponse, error)
func (*UnimplementedTikvServer) KvBatchRollback ¶
func (*UnimplementedTikvServer) KvBatchRollback(ctx context.Context, req *kvrpcpb.BatchRollbackRequest) (*kvrpcpb.BatchRollbackResponse, error)
func (*UnimplementedTikvServer) KvCheckSecondaryLocks ¶
func (*UnimplementedTikvServer) KvCheckSecondaryLocks(ctx context.Context, req *kvrpcpb.CheckSecondaryLocksRequest) (*kvrpcpb.CheckSecondaryLocksResponse, error)
func (*UnimplementedTikvServer) KvCheckTxnStatus ¶
func (*UnimplementedTikvServer) KvCheckTxnStatus(ctx context.Context, req *kvrpcpb.CheckTxnStatusRequest) (*kvrpcpb.CheckTxnStatusResponse, error)
func (*UnimplementedTikvServer) KvCleanup ¶
func (*UnimplementedTikvServer) KvCleanup(ctx context.Context, req *kvrpcpb.CleanupRequest) (*kvrpcpb.CleanupResponse, error)
func (*UnimplementedTikvServer) KvCommit ¶
func (*UnimplementedTikvServer) KvCommit(ctx context.Context, req *kvrpcpb.CommitRequest) (*kvrpcpb.CommitResponse, error)
func (*UnimplementedTikvServer) KvDeleteRange ¶
func (*UnimplementedTikvServer) KvDeleteRange(ctx context.Context, req *kvrpcpb.DeleteRangeRequest) (*kvrpcpb.DeleteRangeResponse, error)
func (*UnimplementedTikvServer) KvFlashbackToVersion ¶
func (*UnimplementedTikvServer) KvFlashbackToVersion(ctx context.Context, req *kvrpcpb.FlashbackToVersionRequest) (*kvrpcpb.FlashbackToVersionResponse, error)
func (*UnimplementedTikvServer) KvGC ¶
func (*UnimplementedTikvServer) KvGC(ctx context.Context, req *kvrpcpb.GCRequest) (*kvrpcpb.GCResponse, error)
func (*UnimplementedTikvServer) KvGet ¶
func (*UnimplementedTikvServer) KvGet(ctx context.Context, req *kvrpcpb.GetRequest) (*kvrpcpb.GetResponse, error)
func (*UnimplementedTikvServer) KvImport ¶
func (*UnimplementedTikvServer) KvImport(ctx context.Context, req *kvrpcpb.ImportRequest) (*kvrpcpb.ImportResponse, error)
func (*UnimplementedTikvServer) KvPessimisticLock ¶
func (*UnimplementedTikvServer) KvPessimisticLock(ctx context.Context, req *kvrpcpb.PessimisticLockRequest) (*kvrpcpb.PessimisticLockResponse, error)
func (*UnimplementedTikvServer) KvPrepareFlashbackToVersion ¶
func (*UnimplementedTikvServer) KvPrepareFlashbackToVersion(ctx context.Context, req *kvrpcpb.PrepareFlashbackToVersionRequest) (*kvrpcpb.PrepareFlashbackToVersionResponse, error)
func (*UnimplementedTikvServer) KvPrewrite ¶
func (*UnimplementedTikvServer) KvPrewrite(ctx context.Context, req *kvrpcpb.PrewriteRequest) (*kvrpcpb.PrewriteResponse, error)
func (*UnimplementedTikvServer) KvResolveLock ¶
func (*UnimplementedTikvServer) KvResolveLock(ctx context.Context, req *kvrpcpb.ResolveLockRequest) (*kvrpcpb.ResolveLockResponse, error)
func (*UnimplementedTikvServer) KvScan ¶
func (*UnimplementedTikvServer) KvScan(ctx context.Context, req *kvrpcpb.ScanRequest) (*kvrpcpb.ScanResponse, error)
func (*UnimplementedTikvServer) KvScanLock ¶
func (*UnimplementedTikvServer) KvScanLock(ctx context.Context, req *kvrpcpb.ScanLockRequest) (*kvrpcpb.ScanLockResponse, error)
func (*UnimplementedTikvServer) KvTxnHeartBeat ¶
func (*UnimplementedTikvServer) KvTxnHeartBeat(ctx context.Context, req *kvrpcpb.TxnHeartBeatRequest) (*kvrpcpb.TxnHeartBeatResponse, error)
func (*UnimplementedTikvServer) MvccGetByKey ¶
func (*UnimplementedTikvServer) MvccGetByKey(ctx context.Context, req *kvrpcpb.MvccGetByKeyRequest) (*kvrpcpb.MvccGetByKeyResponse, error)
func (*UnimplementedTikvServer) MvccGetByStartTs ¶
func (*UnimplementedTikvServer) MvccGetByStartTs(ctx context.Context, req *kvrpcpb.MvccGetByStartTsRequest) (*kvrpcpb.MvccGetByStartTsResponse, error)
func (*UnimplementedTikvServer) PhysicalScanLock ¶
func (*UnimplementedTikvServer) PhysicalScanLock(ctx context.Context, req *kvrpcpb.PhysicalScanLockRequest) (*kvrpcpb.PhysicalScanLockResponse, error)
func (*UnimplementedTikvServer) Raft ¶
func (*UnimplementedTikvServer) Raft(srv Tikv_RaftServer) error
func (*UnimplementedTikvServer) RawBatchDelete ¶
func (*UnimplementedTikvServer) RawBatchDelete(ctx context.Context, req *kvrpcpb.RawBatchDeleteRequest) (*kvrpcpb.RawBatchDeleteResponse, error)
func (*UnimplementedTikvServer) RawBatchGet ¶
func (*UnimplementedTikvServer) RawBatchGet(ctx context.Context, req *kvrpcpb.RawBatchGetRequest) (*kvrpcpb.RawBatchGetResponse, error)
func (*UnimplementedTikvServer) RawBatchPut ¶
func (*UnimplementedTikvServer) RawBatchPut(ctx context.Context, req *kvrpcpb.RawBatchPutRequest) (*kvrpcpb.RawBatchPutResponse, error)
func (*UnimplementedTikvServer) RawBatchScan ¶
func (*UnimplementedTikvServer) RawBatchScan(ctx context.Context, req *kvrpcpb.RawBatchScanRequest) (*kvrpcpb.RawBatchScanResponse, error)
func (*UnimplementedTikvServer) RawChecksum ¶
func (*UnimplementedTikvServer) RawChecksum(ctx context.Context, req *kvrpcpb.RawChecksumRequest) (*kvrpcpb.RawChecksumResponse, error)
func (*UnimplementedTikvServer) RawCompareAndSwap ¶
func (*UnimplementedTikvServer) RawCompareAndSwap(ctx context.Context, req *kvrpcpb.RawCASRequest) (*kvrpcpb.RawCASResponse, error)
func (*UnimplementedTikvServer) RawCoprocessor ¶
func (*UnimplementedTikvServer) RawCoprocessor(ctx context.Context, req *kvrpcpb.RawCoprocessorRequest) (*kvrpcpb.RawCoprocessorResponse, error)
func (*UnimplementedTikvServer) RawDelete ¶
func (*UnimplementedTikvServer) RawDelete(ctx context.Context, req *kvrpcpb.RawDeleteRequest) (*kvrpcpb.RawDeleteResponse, error)
func (*UnimplementedTikvServer) RawDeleteRange ¶
func (*UnimplementedTikvServer) RawDeleteRange(ctx context.Context, req *kvrpcpb.RawDeleteRangeRequest) (*kvrpcpb.RawDeleteRangeResponse, error)
func (*UnimplementedTikvServer) RawGet ¶
func (*UnimplementedTikvServer) RawGet(ctx context.Context, req *kvrpcpb.RawGetRequest) (*kvrpcpb.RawGetResponse, error)
func (*UnimplementedTikvServer) RawGetKeyTTL ¶
func (*UnimplementedTikvServer) RawGetKeyTTL(ctx context.Context, req *kvrpcpb.RawGetKeyTTLRequest) (*kvrpcpb.RawGetKeyTTLResponse, error)
func (*UnimplementedTikvServer) RawPut ¶
func (*UnimplementedTikvServer) RawPut(ctx context.Context, req *kvrpcpb.RawPutRequest) (*kvrpcpb.RawPutResponse, error)
func (*UnimplementedTikvServer) RawScan ¶
func (*UnimplementedTikvServer) RawScan(ctx context.Context, req *kvrpcpb.RawScanRequest) (*kvrpcpb.RawScanResponse, error)
func (*UnimplementedTikvServer) ReadIndex ¶
func (*UnimplementedTikvServer) ReadIndex(ctx context.Context, req *kvrpcpb.ReadIndexRequest) (*kvrpcpb.ReadIndexResponse, error)
func (*UnimplementedTikvServer) RegisterLockObserver ¶
func (*UnimplementedTikvServer) RegisterLockObserver(ctx context.Context, req *kvrpcpb.RegisterLockObserverRequest) (*kvrpcpb.RegisterLockObserverResponse, error)
func (*UnimplementedTikvServer) RemoveLockObserver ¶
func (*UnimplementedTikvServer) RemoveLockObserver(ctx context.Context, req *kvrpcpb.RemoveLockObserverRequest) (*kvrpcpb.RemoveLockObserverResponse, error)
func (*UnimplementedTikvServer) ReportMPPTaskStatus ¶
func (*UnimplementedTikvServer) ReportMPPTaskStatus(ctx context.Context, req *mpp.ReportTaskStatusRequest) (*mpp.ReportTaskStatusResponse, error)
func (*UnimplementedTikvServer) Snapshot ¶
func (*UnimplementedTikvServer) Snapshot(srv Tikv_SnapshotServer) error
func (*UnimplementedTikvServer) SplitRegion ¶
func (*UnimplementedTikvServer) SplitRegion(ctx context.Context, req *kvrpcpb.SplitRegionRequest) (*kvrpcpb.SplitRegionResponse, error)
func (*UnimplementedTikvServer) TabletSnapshot ¶
func (*UnimplementedTikvServer) TabletSnapshot(srv Tikv_TabletSnapshotServer) error
func (*UnimplementedTikvServer) TryAddLock ¶
func (*UnimplementedTikvServer) TryAddLock(ctx context.Context, req *disaggregated.TryAddLockRequest) (*disaggregated.TryAddLockResponse, error)
func (*UnimplementedTikvServer) TryMarkDelete ¶
func (*UnimplementedTikvServer) TryMarkDelete(ctx context.Context, req *disaggregated.TryMarkDeleteRequest) (*disaggregated.TryMarkDeleteResponse, error)
func (*UnimplementedTikvServer) UnsafeDestroyRange ¶
func (*UnimplementedTikvServer) UnsafeDestroyRange(ctx context.Context, req *kvrpcpb.UnsafeDestroyRangeRequest) (*kvrpcpb.UnsafeDestroyRangeResponse, error)
Click to show internal directories.
Click to hide internal directories.