mirror of
https://github.com/talent-plan/tinykv.git
synced 2024-12-27 13:20:24 +08:00
70a9cc68a9
Project4A does not need `Server.Latches`.
105 lines
3.2 KiB
Go
105 lines
3.2 KiB
Go
package server
|
|
|
|
import (
|
|
"context"
|
|
|
|
"github.com/pingcap-incubator/tinykv/kv/coprocessor"
|
|
"github.com/pingcap-incubator/tinykv/kv/storage"
|
|
"github.com/pingcap-incubator/tinykv/kv/storage/raft_storage"
|
|
"github.com/pingcap-incubator/tinykv/kv/transaction/latches"
|
|
coppb "github.com/pingcap-incubator/tinykv/proto/pkg/coprocessor"
|
|
"github.com/pingcap-incubator/tinykv/proto/pkg/kvrpcpb"
|
|
"github.com/pingcap-incubator/tinykv/proto/pkg/tinykvpb"
|
|
"github.com/pingcap/tidb/kv"
|
|
)
|
|
|
|
var _ tinykvpb.TinyKvServer = new(Server)
|
|
|
|
// Server is a TinyKV server, it 'faces outwards', sending and receiving messages from clients such as TinySQL.
|
|
type Server struct {
|
|
storage storage.Storage
|
|
|
|
// (Used in 4B)
|
|
Latches *latches.Latches
|
|
|
|
// coprocessor API handler, out of course scope
|
|
copHandler *coprocessor.CopHandler
|
|
}
|
|
|
|
func NewServer(storage storage.Storage) *Server {
|
|
return &Server{
|
|
storage: storage,
|
|
Latches: latches.NewLatches(),
|
|
}
|
|
}
|
|
|
|
// The below functions are Server's gRPC API (implements TinyKvServer).
|
|
|
|
// Raft commands (tinykv <-> tinykv)
|
|
// Only used for RaftStorage, so trivially forward it.
|
|
func (server *Server) Raft(stream tinykvpb.TinyKv_RaftServer) error {
|
|
return server.storage.(*raft_storage.RaftStorage).Raft(stream)
|
|
}
|
|
|
|
// Snapshot stream (tinykv <-> tinykv)
|
|
// Only used for RaftStorage, so trivially forward it.
|
|
func (server *Server) Snapshot(stream tinykvpb.TinyKv_SnapshotServer) error {
|
|
return server.storage.(*raft_storage.RaftStorage).Snapshot(stream)
|
|
}
|
|
|
|
// Transactional API.
|
|
func (server *Server) KvGet(_ context.Context, req *kvrpcpb.GetRequest) (*kvrpcpb.GetResponse, error) {
|
|
// Your Code Here (4B).
|
|
return nil, nil
|
|
}
|
|
|
|
func (server *Server) KvPrewrite(_ context.Context, req *kvrpcpb.PrewriteRequest) (*kvrpcpb.PrewriteResponse, error) {
|
|
// Your Code Here (4B).
|
|
return nil, nil
|
|
}
|
|
|
|
func (server *Server) KvCommit(_ context.Context, req *kvrpcpb.CommitRequest) (*kvrpcpb.CommitResponse, error) {
|
|
// Your Code Here (4B).
|
|
return nil, nil
|
|
}
|
|
|
|
func (server *Server) KvScan(_ context.Context, req *kvrpcpb.ScanRequest) (*kvrpcpb.ScanResponse, error) {
|
|
// Your Code Here (4C).
|
|
return nil, nil
|
|
}
|
|
|
|
func (server *Server) KvCheckTxnStatus(_ context.Context, req *kvrpcpb.CheckTxnStatusRequest) (*kvrpcpb.CheckTxnStatusResponse, error) {
|
|
// Your Code Here (4C).
|
|
return nil, nil
|
|
}
|
|
|
|
func (server *Server) KvBatchRollback(_ context.Context, req *kvrpcpb.BatchRollbackRequest) (*kvrpcpb.BatchRollbackResponse, error) {
|
|
// Your Code Here (4C).
|
|
return nil, nil
|
|
}
|
|
|
|
func (server *Server) KvResolveLock(_ context.Context, req *kvrpcpb.ResolveLockRequest) (*kvrpcpb.ResolveLockResponse, error) {
|
|
// Your Code Here (4C).
|
|
return nil, nil
|
|
}
|
|
|
|
// SQL push down commands.
|
|
func (server *Server) Coprocessor(_ context.Context, req *coppb.Request) (*coppb.Response, error) {
|
|
resp := new(coppb.Response)
|
|
reader, err := server.storage.Reader(req.Context)
|
|
if err != nil {
|
|
if regionErr, ok := err.(*raft_storage.RegionError); ok {
|
|
resp.RegionError = regionErr.RequestErr
|
|
return resp, nil
|
|
}
|
|
return nil, err
|
|
}
|
|
switch req.Tp {
|
|
case kv.ReqTypeDAG:
|
|
return server.copHandler.HandleCopDAGRequest(reader, req), nil
|
|
case kv.ReqTypeAnalyze:
|
|
return server.copHandler.HandleCopAnalyzeRequest(reader, req), nil
|
|
}
|
|
return nil, nil
|
|
}
|