From 7843d0ba757d4abb7b71a82c904eb6e712d51632 Mon Sep 17 00:00:00 2001 From: Mickael BOURNEUF Date: Sun, 16 Feb 2025 19:29:30 +0100 Subject: [PATCH] =?UTF-8?q?R=C3=A9cup=C3=A9ration=20du=20projet,=20l'auteu?= =?UTF-8?q?r=20ne=20le=20suivant=20plus=20beaucoup?= MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit --- .../Jille/raft-grpc-transport/LICENSE | 25 - .../Jille/raft-grpc-transport/README.md | 20 - .../Jille/raft-grpc-transport/fromproto.go | 146 -- .../Jille/raft-grpc-transport/grpcapi.go | 146 -- .../Jille/raft-grpc-transport/options.go | 13 - .../Jille/raft-grpc-transport/proto/Makefile | 6 - .../raft-grpc-transport/proto/transport.pb.go | 1390 ----------------- .../raft-grpc-transport/proto/transport.proto | 122 -- .../proto/transport_grpc.pb.go | 364 ----- .../Jille/raft-grpc-transport/raftapi.go | 329 ---- .../Jille/raft-grpc-transport/toproto.go | 147 -- .../Jille/raft-grpc-transport/transport.go | 97 -- vendor/modules.txt | 2 - 13 files changed, 2807 deletions(-) delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/LICENSE delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/README.md delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/fromproto.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/grpcapi.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/options.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/proto/Makefile delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/proto/transport.pb.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/proto/transport.proto delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/proto/transport_grpc.pb.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/raftapi.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/toproto.go delete mode 100644 vendor/github.com/Jille/raft-grpc-transport/transport.go diff --git a/vendor/github.com/Jille/raft-grpc-transport/LICENSE b/vendor/github.com/Jille/raft-grpc-transport/LICENSE deleted file mode 100644 index 67909f9..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/LICENSE +++ /dev/null @@ -1,25 +0,0 @@ -BSD 2-Clause License - -Copyright (c) 2020, Jille Timmermans -All rights reserved. - -Redistribution and use in source and binary forms, with or without -modification, are permitted provided that the following conditions are met: - -1. Redistributions of source code must retain the above copyright notice, this - list of conditions and the following disclaimer. - -2. Redistributions in binary form must reproduce the above copyright notice, - this list of conditions and the following disclaimer in the documentation - and/or other materials provided with the distribution. - -THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" -AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE -IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE -DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE -FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL -DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR -SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER -CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, -OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE -OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. diff --git a/vendor/github.com/Jille/raft-grpc-transport/README.md b/vendor/github.com/Jille/raft-grpc-transport/README.md deleted file mode 100644 index a365a9b..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/README.md +++ /dev/null @@ -1,20 +0,0 @@ -# raft-grpc-transport - -[![Godoc](https://godoc.org/github.com/Jille/raft-grpc-transport?status.svg)](https://godoc.org/github.com/Jille/raft-grpc-transport) - -This library provides a [Transport](https://godoc.org/github.com/hashicorp/raft#Transport) for https://github.com/hashicorp/raft over gRPC. - -One benefit of this is that gRPC is easy to multiplex over a single port. - -## Usage - -```go -// ... -tm := transport.New(raft.ServerAddress(myAddress), []grpc.DialOption{grpc.WithInsecure()}) -s := grpc.NewServer() -tm.Register(s) -r, err := raft.NewRaft(..., tm.Transport()) -// ... -``` - -Want more example code? Check out main.go at https://github.com/Jille/raft-grpc-example diff --git a/vendor/github.com/Jille/raft-grpc-transport/fromproto.go b/vendor/github.com/Jille/raft-grpc-transport/fromproto.go deleted file mode 100644 index d02cbaf..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/fromproto.go +++ /dev/null @@ -1,146 +0,0 @@ -package transport - -import ( - pb "github.com/Jille/raft-grpc-transport/proto" - "github.com/hashicorp/raft" -) - -func decodeAppendEntriesRequest(m *pb.AppendEntriesRequest) *raft.AppendEntriesRequest { - return &raft.AppendEntriesRequest{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - Leader: m.Leader, - PrevLogEntry: m.PrevLogEntry, - PrevLogTerm: m.PrevLogTerm, - Entries: decodeLogs(m.Entries), - LeaderCommitIndex: m.LeaderCommitIndex, - } -} - -func decodeRPCHeader(m *pb.RPCHeader) raft.RPCHeader { - return raft.RPCHeader{ - ProtocolVersion: raft.ProtocolVersion(m.ProtocolVersion), - ID: m.Id, - Addr: m.Addr, - } -} - -func decodeLogs(m []*pb.Log) []*raft.Log { - ret := make([]*raft.Log, len(m)) - for i, l := range m { - ret[i] = decodeLog(l) - } - return ret -} - -func decodeLog(m *pb.Log) *raft.Log { - return &raft.Log{ - Index: m.Index, - Term: m.Term, - Type: decodeLogType(m.Type), - Data: m.Data, - Extensions: m.Extensions, - AppendedAt: m.AppendedAt.AsTime(), - } -} - -func decodeLogType(m pb.Log_LogType) raft.LogType { - switch m { - case pb.Log_LOG_COMMAND: - return raft.LogCommand - case pb.Log_LOG_NOOP: - return raft.LogNoop - case pb.Log_LOG_ADD_PEER_DEPRECATED: - return raft.LogAddPeerDeprecated - case pb.Log_LOG_REMOVE_PEER_DEPRECATED: - return raft.LogRemovePeerDeprecated - case pb.Log_LOG_BARRIER: - return raft.LogBarrier - case pb.Log_LOG_CONFIGURATION: - return raft.LogConfiguration - default: - panic("invalid LogType") - } -} - -func decodeAppendEntriesResponse(m *pb.AppendEntriesResponse) *raft.AppendEntriesResponse { - return &raft.AppendEntriesResponse{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - LastLog: m.LastLog, - Success: m.Success, - NoRetryBackoff: m.NoRetryBackoff, - } -} - -func decodeRequestVoteRequest(m *pb.RequestVoteRequest) *raft.RequestVoteRequest { - return &raft.RequestVoteRequest{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - Candidate: m.Candidate, - LastLogIndex: m.LastLogIndex, - LastLogTerm: m.LastLogTerm, - LeadershipTransfer: m.LeadershipTransfer, - } -} - -func decodeRequestVoteResponse(m *pb.RequestVoteResponse) *raft.RequestVoteResponse { - return &raft.RequestVoteResponse{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - Peers: m.Peers, - Granted: m.Granted, - } -} - -func decodeInstallSnapshotRequest(m *pb.InstallSnapshotRequest) *raft.InstallSnapshotRequest { - return &raft.InstallSnapshotRequest{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - SnapshotVersion: raft.SnapshotVersion(m.SnapshotVersion), - Term: m.Term, - Leader: m.Leader, - LastLogIndex: m.LastLogIndex, - LastLogTerm: m.LastLogTerm, - Peers: m.Peers, - Configuration: m.Configuration, - ConfigurationIndex: m.ConfigurationIndex, - Size: m.Size, - } -} - -func decodeInstallSnapshotResponse(m *pb.InstallSnapshotResponse) *raft.InstallSnapshotResponse { - return &raft.InstallSnapshotResponse{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - Success: m.Success, - } -} - -func decodeTimeoutNowRequest(m *pb.TimeoutNowRequest) *raft.TimeoutNowRequest { - return &raft.TimeoutNowRequest{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - } -} - -func decodeTimeoutNowResponse(m *pb.TimeoutNowResponse) *raft.TimeoutNowResponse { - return &raft.TimeoutNowResponse{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - } -} - -func decodeRequestPreVoteRequest(m *pb.RequestPreVoteRequest) *raft.RequestPreVoteRequest { - return &raft.RequestPreVoteRequest{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - LastLogIndex: m.LastLogIndex, - LastLogTerm: m.LastLogTerm, - } -} - -func decodeRequestPreVoteResponse(m *pb.RequestPreVoteResponse) *raft.RequestPreVoteResponse { - return &raft.RequestPreVoteResponse{ - RPCHeader: decodeRPCHeader(m.RpcHeader), - Term: m.Term, - Granted: m.Granted, - } -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/grpcapi.go b/vendor/github.com/Jille/raft-grpc-transport/grpcapi.go deleted file mode 100644 index 1f3997f..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/grpcapi.go +++ /dev/null @@ -1,146 +0,0 @@ -package transport - -import ( - "context" - "io" - - pb "github.com/Jille/raft-grpc-transport/proto" - "github.com/hashicorp/raft" -) - -// These are requests incoming over gRPC that we need to relay to the Raft engine. - -type gRPCAPI struct { - manager *Manager - - // "Unsafe" to ensure compilation fails if new methods are added but not implemented - pb.UnsafeRaftTransportServer -} - -func (g gRPCAPI) handleRPC(command interface{}, data io.Reader) (interface{}, error) { - ch := make(chan raft.RPCResponse, 1) - rpc := raft.RPC{ - Command: command, - RespChan: ch, - Reader: data, - } - if isHeartbeat(command) { - // We can take the fast path and use the heartbeat callback and skip the queue in g.manager.rpcChan. - g.manager.heartbeatFuncMtx.Lock() - fn := g.manager.heartbeatFunc - g.manager.heartbeatFuncMtx.Unlock() - if fn != nil { - fn(rpc) - goto wait - } - } - select { - case g.manager.rpcChan <- rpc: - case <-g.manager.shutdownCh: - return nil, raft.ErrTransportShutdown - } - -wait: - select { - case resp := <-ch: - if resp.Error != nil { - return nil, resp.Error - } - return resp.Response, nil - case <-g.manager.shutdownCh: - return nil, raft.ErrTransportShutdown - } -} - -func (g gRPCAPI) AppendEntries(ctx context.Context, req *pb.AppendEntriesRequest) (*pb.AppendEntriesResponse, error) { - resp, err := g.handleRPC(decodeAppendEntriesRequest(req), nil) - if err != nil { - return nil, err - } - return encodeAppendEntriesResponse(resp.(*raft.AppendEntriesResponse)), nil -} - -func (g gRPCAPI) RequestVote(ctx context.Context, req *pb.RequestVoteRequest) (*pb.RequestVoteResponse, error) { - resp, err := g.handleRPC(decodeRequestVoteRequest(req), nil) - if err != nil { - return nil, err - } - return encodeRequestVoteResponse(resp.(*raft.RequestVoteResponse)), nil -} - -func (g gRPCAPI) TimeoutNow(ctx context.Context, req *pb.TimeoutNowRequest) (*pb.TimeoutNowResponse, error) { - resp, err := g.handleRPC(decodeTimeoutNowRequest(req), nil) - if err != nil { - return nil, err - } - return encodeTimeoutNowResponse(resp.(*raft.TimeoutNowResponse)), nil -} - -func (g gRPCAPI) RequestPreVote(ctx context.Context, req *pb.RequestPreVoteRequest) (*pb.RequestPreVoteResponse, error) { - resp, err := g.handleRPC(decodeRequestPreVoteRequest(req), nil) - if err != nil { - return nil, err - } - return encodeRequestPreVoteResponse(resp.(*raft.RequestPreVoteResponse)), nil -} - -func (g gRPCAPI) InstallSnapshot(s pb.RaftTransport_InstallSnapshotServer) error { - isr, err := s.Recv() - if err != nil { - return err - } - resp, err := g.handleRPC(decodeInstallSnapshotRequest(isr), &snapshotStream{s, isr.GetData()}) - if err != nil { - return err - } - return s.SendAndClose(encodeInstallSnapshotResponse(resp.(*raft.InstallSnapshotResponse))) -} - -type snapshotStream struct { - s pb.RaftTransport_InstallSnapshotServer - - buf []byte -} - -func (s *snapshotStream) Read(b []byte) (int, error) { - if len(s.buf) > 0 { - n := copy(b, s.buf) - s.buf = s.buf[n:] - return n, nil - } - m, err := s.s.Recv() - if err != nil { - return 0, err - } - n := copy(b, m.GetData()) - if n < len(m.GetData()) { - s.buf = m.GetData()[n:] - } - return n, nil -} - -func (g gRPCAPI) AppendEntriesPipeline(s pb.RaftTransport_AppendEntriesPipelineServer) error { - for { - msg, err := s.Recv() - if err != nil { - return err - } - resp, err := g.handleRPC(decodeAppendEntriesRequest(msg), nil) - if err != nil { - // TODO(quis): One failure doesn't have to break the entire stream? - // Or does it all go wrong when it's out of order anyway? - return err - } - if err := s.Send(encodeAppendEntriesResponse(resp.(*raft.AppendEntriesResponse))); err != nil { - return err - } - } -} - -func isHeartbeat(command interface{}) bool { - req, ok := command.(*raft.AppendEntriesRequest) - if !ok { - return false - } - return req.Term != 0 && len(req.Leader) != 0 && req.PrevLogEntry == 0 && req.PrevLogTerm == 0 && len(req.Entries) == 0 && req.LeaderCommitIndex == 0 -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/options.go b/vendor/github.com/Jille/raft-grpc-transport/options.go deleted file mode 100644 index 8726b73..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/options.go +++ /dev/null @@ -1,13 +0,0 @@ -package transport - -import "time" - -type Option func(m *Manager) - -// WithHeartbeatTimeout configures the transport to not wait for more than d -// for a heartbeat to be executed by a remote peer. -func WithHeartbeatTimeout(d time.Duration) Option { - return func(m *Manager) { - m.heartbeatTimeout = d - } -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/proto/Makefile b/vendor/github.com/Jille/raft-grpc-transport/proto/Makefile deleted file mode 100644 index 9855597..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/proto/Makefile +++ /dev/null @@ -1,6 +0,0 @@ -transport.pb.go: transport.proto - protoc --go_out=. --go_opt=paths=source_relative --go-grpc_out=. --go-grpc_opt=paths=source_relative transport.proto - -force: - rm -f transport.pb.go - make transport.pb.go diff --git a/vendor/github.com/Jille/raft-grpc-transport/proto/transport.pb.go b/vendor/github.com/Jille/raft-grpc-transport/proto/transport.pb.go deleted file mode 100644 index 6f5681d..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/proto/transport.pb.go +++ /dev/null @@ -1,1390 +0,0 @@ -// Code generated by protoc-gen-go. DO NOT EDIT. -// versions: -// protoc-gen-go v1.28.0 -// protoc v3.21.3 -// source: transport.proto - -package proto - -import ( - protoreflect "google.golang.org/protobuf/reflect/protoreflect" - protoimpl "google.golang.org/protobuf/runtime/protoimpl" - timestamppb "google.golang.org/protobuf/types/known/timestamppb" - reflect "reflect" - sync "sync" -) - -const ( - // Verify that this generated code is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(20 - protoimpl.MinVersion) - // Verify that runtime/protoimpl is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(protoimpl.MaxVersion - 20) -) - -type Log_LogType int32 - -const ( - Log_LOG_COMMAND Log_LogType = 0 - Log_LOG_NOOP Log_LogType = 1 - Log_LOG_ADD_PEER_DEPRECATED Log_LogType = 2 - Log_LOG_REMOVE_PEER_DEPRECATED Log_LogType = 3 - Log_LOG_BARRIER Log_LogType = 4 - Log_LOG_CONFIGURATION Log_LogType = 5 -) - -// Enum value maps for Log_LogType. -var ( - Log_LogType_name = map[int32]string{ - 0: "LOG_COMMAND", - 1: "LOG_NOOP", - 2: "LOG_ADD_PEER_DEPRECATED", - 3: "LOG_REMOVE_PEER_DEPRECATED", - 4: "LOG_BARRIER", - 5: "LOG_CONFIGURATION", - } - Log_LogType_value = map[string]int32{ - "LOG_COMMAND": 0, - "LOG_NOOP": 1, - "LOG_ADD_PEER_DEPRECATED": 2, - "LOG_REMOVE_PEER_DEPRECATED": 3, - "LOG_BARRIER": 4, - "LOG_CONFIGURATION": 5, - } -) - -func (x Log_LogType) Enum() *Log_LogType { - p := new(Log_LogType) - *p = x - return p -} - -func (x Log_LogType) String() string { - return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) -} - -func (Log_LogType) Descriptor() protoreflect.EnumDescriptor { - return file_transport_proto_enumTypes[0].Descriptor() -} - -func (Log_LogType) Type() protoreflect.EnumType { - return &file_transport_proto_enumTypes[0] -} - -func (x Log_LogType) Number() protoreflect.EnumNumber { - return protoreflect.EnumNumber(x) -} - -// Deprecated: Use Log_LogType.Descriptor instead. -func (Log_LogType) EnumDescriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{1, 0} -} - -type RPCHeader struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ProtocolVersion int64 `protobuf:"varint,1,opt,name=protocol_version,json=protocolVersion,proto3" json:"protocol_version,omitempty"` - Id []byte `protobuf:"bytes,2,opt,name=id,proto3" json:"id,omitempty"` - Addr []byte `protobuf:"bytes,3,opt,name=addr,proto3" json:"addr,omitempty"` -} - -func (x *RPCHeader) Reset() { - *x = RPCHeader{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[0] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RPCHeader) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RPCHeader) ProtoMessage() {} - -func (x *RPCHeader) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[0] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RPCHeader.ProtoReflect.Descriptor instead. -func (*RPCHeader) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{0} -} - -func (x *RPCHeader) GetProtocolVersion() int64 { - if x != nil { - return x.ProtocolVersion - } - return 0 -} - -func (x *RPCHeader) GetId() []byte { - if x != nil { - return x.Id - } - return nil -} - -func (x *RPCHeader) GetAddr() []byte { - if x != nil { - return x.Addr - } - return nil -} - -type Log struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Index uint64 `protobuf:"varint,1,opt,name=index,proto3" json:"index,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Type Log_LogType `protobuf:"varint,3,opt,name=type,proto3,enum=Log_LogType" json:"type,omitempty"` - Data []byte `protobuf:"bytes,4,opt,name=data,proto3" json:"data,omitempty"` - Extensions []byte `protobuf:"bytes,5,opt,name=extensions,proto3" json:"extensions,omitempty"` - AppendedAt *timestamppb.Timestamp `protobuf:"bytes,6,opt,name=appended_at,json=appendedAt,proto3" json:"appended_at,omitempty"` -} - -func (x *Log) Reset() { - *x = Log{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[1] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *Log) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*Log) ProtoMessage() {} - -func (x *Log) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[1] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use Log.ProtoReflect.Descriptor instead. -func (*Log) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{1} -} - -func (x *Log) GetIndex() uint64 { - if x != nil { - return x.Index - } - return 0 -} - -func (x *Log) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *Log) GetType() Log_LogType { - if x != nil { - return x.Type - } - return Log_LOG_COMMAND -} - -func (x *Log) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *Log) GetExtensions() []byte { - if x != nil { - return x.Extensions - } - return nil -} - -func (x *Log) GetAppendedAt() *timestamppb.Timestamp { - if x != nil { - return x.AppendedAt - } - return nil -} - -type AppendEntriesRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Leader []byte `protobuf:"bytes,3,opt,name=leader,proto3" json:"leader,omitempty"` - PrevLogEntry uint64 `protobuf:"varint,4,opt,name=prev_log_entry,json=prevLogEntry,proto3" json:"prev_log_entry,omitempty"` - PrevLogTerm uint64 `protobuf:"varint,5,opt,name=prev_log_term,json=prevLogTerm,proto3" json:"prev_log_term,omitempty"` - Entries []*Log `protobuf:"bytes,6,rep,name=entries,proto3" json:"entries,omitempty"` - LeaderCommitIndex uint64 `protobuf:"varint,7,opt,name=leader_commit_index,json=leaderCommitIndex,proto3" json:"leader_commit_index,omitempty"` -} - -func (x *AppendEntriesRequest) Reset() { - *x = AppendEntriesRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[2] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *AppendEntriesRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*AppendEntriesRequest) ProtoMessage() {} - -func (x *AppendEntriesRequest) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[2] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use AppendEntriesRequest.ProtoReflect.Descriptor instead. -func (*AppendEntriesRequest) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{2} -} - -func (x *AppendEntriesRequest) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *AppendEntriesRequest) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *AppendEntriesRequest) GetLeader() []byte { - if x != nil { - return x.Leader - } - return nil -} - -func (x *AppendEntriesRequest) GetPrevLogEntry() uint64 { - if x != nil { - return x.PrevLogEntry - } - return 0 -} - -func (x *AppendEntriesRequest) GetPrevLogTerm() uint64 { - if x != nil { - return x.PrevLogTerm - } - return 0 -} - -func (x *AppendEntriesRequest) GetEntries() []*Log { - if x != nil { - return x.Entries - } - return nil -} - -func (x *AppendEntriesRequest) GetLeaderCommitIndex() uint64 { - if x != nil { - return x.LeaderCommitIndex - } - return 0 -} - -type AppendEntriesResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - LastLog uint64 `protobuf:"varint,3,opt,name=last_log,json=lastLog,proto3" json:"last_log,omitempty"` - Success bool `protobuf:"varint,4,opt,name=success,proto3" json:"success,omitempty"` - NoRetryBackoff bool `protobuf:"varint,5,opt,name=no_retry_backoff,json=noRetryBackoff,proto3" json:"no_retry_backoff,omitempty"` -} - -func (x *AppendEntriesResponse) Reset() { - *x = AppendEntriesResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[3] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *AppendEntriesResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*AppendEntriesResponse) ProtoMessage() {} - -func (x *AppendEntriesResponse) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[3] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use AppendEntriesResponse.ProtoReflect.Descriptor instead. -func (*AppendEntriesResponse) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{3} -} - -func (x *AppendEntriesResponse) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *AppendEntriesResponse) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *AppendEntriesResponse) GetLastLog() uint64 { - if x != nil { - return x.LastLog - } - return 0 -} - -func (x *AppendEntriesResponse) GetSuccess() bool { - if x != nil { - return x.Success - } - return false -} - -func (x *AppendEntriesResponse) GetNoRetryBackoff() bool { - if x != nil { - return x.NoRetryBackoff - } - return false -} - -type RequestVoteRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Candidate []byte `protobuf:"bytes,3,opt,name=candidate,proto3" json:"candidate,omitempty"` - LastLogIndex uint64 `protobuf:"varint,4,opt,name=last_log_index,json=lastLogIndex,proto3" json:"last_log_index,omitempty"` - LastLogTerm uint64 `protobuf:"varint,5,opt,name=last_log_term,json=lastLogTerm,proto3" json:"last_log_term,omitempty"` - LeadershipTransfer bool `protobuf:"varint,6,opt,name=leadership_transfer,json=leadershipTransfer,proto3" json:"leadership_transfer,omitempty"` -} - -func (x *RequestVoteRequest) Reset() { - *x = RequestVoteRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[4] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RequestVoteRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RequestVoteRequest) ProtoMessage() {} - -func (x *RequestVoteRequest) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[4] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RequestVoteRequest.ProtoReflect.Descriptor instead. -func (*RequestVoteRequest) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{4} -} - -func (x *RequestVoteRequest) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *RequestVoteRequest) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *RequestVoteRequest) GetCandidate() []byte { - if x != nil { - return x.Candidate - } - return nil -} - -func (x *RequestVoteRequest) GetLastLogIndex() uint64 { - if x != nil { - return x.LastLogIndex - } - return 0 -} - -func (x *RequestVoteRequest) GetLastLogTerm() uint64 { - if x != nil { - return x.LastLogTerm - } - return 0 -} - -func (x *RequestVoteRequest) GetLeadershipTransfer() bool { - if x != nil { - return x.LeadershipTransfer - } - return false -} - -type RequestVoteResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Peers []byte `protobuf:"bytes,3,opt,name=peers,proto3" json:"peers,omitempty"` - Granted bool `protobuf:"varint,4,opt,name=granted,proto3" json:"granted,omitempty"` -} - -func (x *RequestVoteResponse) Reset() { - *x = RequestVoteResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[5] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RequestVoteResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RequestVoteResponse) ProtoMessage() {} - -func (x *RequestVoteResponse) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[5] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RequestVoteResponse.ProtoReflect.Descriptor instead. -func (*RequestVoteResponse) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{5} -} - -func (x *RequestVoteResponse) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *RequestVoteResponse) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *RequestVoteResponse) GetPeers() []byte { - if x != nil { - return x.Peers - } - return nil -} - -func (x *RequestVoteResponse) GetGranted() bool { - if x != nil { - return x.Granted - } - return false -} - -type TimeoutNowRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` -} - -func (x *TimeoutNowRequest) Reset() { - *x = TimeoutNowRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[6] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TimeoutNowRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TimeoutNowRequest) ProtoMessage() {} - -func (x *TimeoutNowRequest) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[6] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TimeoutNowRequest.ProtoReflect.Descriptor instead. -func (*TimeoutNowRequest) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{6} -} - -func (x *TimeoutNowRequest) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -type TimeoutNowResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` -} - -func (x *TimeoutNowResponse) Reset() { - *x = TimeoutNowResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[7] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TimeoutNowResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TimeoutNowResponse) ProtoMessage() {} - -func (x *TimeoutNowResponse) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[7] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TimeoutNowResponse.ProtoReflect.Descriptor instead. -func (*TimeoutNowResponse) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{7} -} - -func (x *TimeoutNowResponse) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -// The first InstallSnapshotRequest on the stream contains all the metadata. -// All further messages contain only data. -type InstallSnapshotRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - SnapshotVersion int64 `protobuf:"varint,11,opt,name=snapshot_version,json=snapshotVersion,proto3" json:"snapshot_version,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Leader []byte `protobuf:"bytes,3,opt,name=leader,proto3" json:"leader,omitempty"` - LastLogIndex uint64 `protobuf:"varint,4,opt,name=last_log_index,json=lastLogIndex,proto3" json:"last_log_index,omitempty"` - LastLogTerm uint64 `protobuf:"varint,5,opt,name=last_log_term,json=lastLogTerm,proto3" json:"last_log_term,omitempty"` - Peers []byte `protobuf:"bytes,6,opt,name=peers,proto3" json:"peers,omitempty"` - Configuration []byte `protobuf:"bytes,7,opt,name=configuration,proto3" json:"configuration,omitempty"` - ConfigurationIndex uint64 `protobuf:"varint,8,opt,name=configuration_index,json=configurationIndex,proto3" json:"configuration_index,omitempty"` - Size int64 `protobuf:"varint,9,opt,name=size,proto3" json:"size,omitempty"` - Data []byte `protobuf:"bytes,10,opt,name=data,proto3" json:"data,omitempty"` -} - -func (x *InstallSnapshotRequest) Reset() { - *x = InstallSnapshotRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[8] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InstallSnapshotRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InstallSnapshotRequest) ProtoMessage() {} - -func (x *InstallSnapshotRequest) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[8] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InstallSnapshotRequest.ProtoReflect.Descriptor instead. -func (*InstallSnapshotRequest) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{8} -} - -func (x *InstallSnapshotRequest) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *InstallSnapshotRequest) GetSnapshotVersion() int64 { - if x != nil { - return x.SnapshotVersion - } - return 0 -} - -func (x *InstallSnapshotRequest) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *InstallSnapshotRequest) GetLeader() []byte { - if x != nil { - return x.Leader - } - return nil -} - -func (x *InstallSnapshotRequest) GetLastLogIndex() uint64 { - if x != nil { - return x.LastLogIndex - } - return 0 -} - -func (x *InstallSnapshotRequest) GetLastLogTerm() uint64 { - if x != nil { - return x.LastLogTerm - } - return 0 -} - -func (x *InstallSnapshotRequest) GetPeers() []byte { - if x != nil { - return x.Peers - } - return nil -} - -func (x *InstallSnapshotRequest) GetConfiguration() []byte { - if x != nil { - return x.Configuration - } - return nil -} - -func (x *InstallSnapshotRequest) GetConfigurationIndex() uint64 { - if x != nil { - return x.ConfigurationIndex - } - return 0 -} - -func (x *InstallSnapshotRequest) GetSize() int64 { - if x != nil { - return x.Size - } - return 0 -} - -func (x *InstallSnapshotRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -type InstallSnapshotResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Success bool `protobuf:"varint,3,opt,name=success,proto3" json:"success,omitempty"` -} - -func (x *InstallSnapshotResponse) Reset() { - *x = InstallSnapshotResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[9] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InstallSnapshotResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InstallSnapshotResponse) ProtoMessage() {} - -func (x *InstallSnapshotResponse) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[9] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InstallSnapshotResponse.ProtoReflect.Descriptor instead. -func (*InstallSnapshotResponse) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{9} -} - -func (x *InstallSnapshotResponse) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *InstallSnapshotResponse) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *InstallSnapshotResponse) GetSuccess() bool { - if x != nil { - return x.Success - } - return false -} - -type RequestPreVoteRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - LastLogIndex uint64 `protobuf:"varint,3,opt,name=last_log_index,json=lastLogIndex,proto3" json:"last_log_index,omitempty"` - LastLogTerm uint64 `protobuf:"varint,4,opt,name=last_log_term,json=lastLogTerm,proto3" json:"last_log_term,omitempty"` -} - -func (x *RequestPreVoteRequest) Reset() { - *x = RequestPreVoteRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[10] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RequestPreVoteRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RequestPreVoteRequest) ProtoMessage() {} - -func (x *RequestPreVoteRequest) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[10] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RequestPreVoteRequest.ProtoReflect.Descriptor instead. -func (*RequestPreVoteRequest) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{10} -} - -func (x *RequestPreVoteRequest) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *RequestPreVoteRequest) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *RequestPreVoteRequest) GetLastLogIndex() uint64 { - if x != nil { - return x.LastLogIndex - } - return 0 -} - -func (x *RequestPreVoteRequest) GetLastLogTerm() uint64 { - if x != nil { - return x.LastLogTerm - } - return 0 -} - -type RequestPreVoteResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"` - Term uint64 `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"` - Granted bool `protobuf:"varint,3,opt,name=granted,proto3" json:"granted,omitempty"` -} - -func (x *RequestPreVoteResponse) Reset() { - *x = RequestPreVoteResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_transport_proto_msgTypes[11] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RequestPreVoteResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RequestPreVoteResponse) ProtoMessage() {} - -func (x *RequestPreVoteResponse) ProtoReflect() protoreflect.Message { - mi := &file_transport_proto_msgTypes[11] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RequestPreVoteResponse.ProtoReflect.Descriptor instead. -func (*RequestPreVoteResponse) Descriptor() ([]byte, []int) { - return file_transport_proto_rawDescGZIP(), []int{11} -} - -func (x *RequestPreVoteResponse) GetRpcHeader() *RPCHeader { - if x != nil { - return x.RpcHeader - } - return nil -} - -func (x *RequestPreVoteResponse) GetTerm() uint64 { - if x != nil { - return x.Term - } - return 0 -} - -func (x *RequestPreVoteResponse) GetGranted() bool { - if x != nil { - return x.Granted - } - return false -} - -var File_transport_proto protoreflect.FileDescriptor - -var file_transport_proto_rawDesc = []byte{ - 0x0a, 0x0f, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x70, 0x6f, 0x72, 0x74, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2f, 0x74, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x22, 0x5a, 0x0a, 0x09, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x12, - 0x29, 0x0a, 0x10, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x63, 0x6f, 0x6c, 0x5f, 0x76, 0x65, 0x72, 0x73, - 0x69, 0x6f, 0x6e, 0x18, 0x01, 0x20, 0x01, 0x28, 0x03, 0x52, 0x0f, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x63, 0x6f, 0x6c, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x0e, 0x0a, 0x02, 0x69, 0x64, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x02, 0x69, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x61, 0x64, - 0x64, 0x72, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x61, 0x64, 0x64, 0x72, 0x22, 0xd2, - 0x02, 0x0a, 0x03, 0x4c, 0x6f, 0x67, 0x12, 0x14, 0x0a, 0x05, 0x69, 0x6e, 0x64, 0x65, 0x78, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x04, 0x52, 0x05, 0x69, 0x6e, 0x64, 0x65, 0x78, 0x12, 0x12, 0x0a, 0x04, - 0x74, 0x65, 0x72, 0x6d, 0x18, 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, 0x72, 0x6d, - 0x12, 0x20, 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x0c, - 0x2e, 0x4c, 0x6f, 0x67, 0x2e, 0x4c, 0x6f, 0x67, 0x54, 0x79, 0x70, 0x65, 0x52, 0x04, 0x74, 0x79, - 0x70, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0c, - 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x1e, 0x0a, 0x0a, 0x65, 0x78, 0x74, 0x65, 0x6e, 0x73, - 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x0a, 0x65, 0x78, 0x74, 0x65, - 0x6e, 0x73, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x3b, 0x0a, 0x0b, 0x61, 0x70, 0x70, 0x65, 0x6e, 0x64, - 0x65, 0x64, 0x5f, 0x61, 0x74, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, - 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x52, 0x0a, 0x61, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x65, - 0x64, 0x41, 0x74, 0x22, 0x8d, 0x01, 0x0a, 0x07, 0x4c, 0x6f, 0x67, 0x54, 0x79, 0x70, 0x65, 0x12, - 0x0f, 0x0a, 0x0b, 0x4c, 0x4f, 0x47, 0x5f, 0x43, 0x4f, 0x4d, 0x4d, 0x41, 0x4e, 0x44, 0x10, 0x00, - 0x12, 0x0c, 0x0a, 0x08, 0x4c, 0x4f, 0x47, 0x5f, 0x4e, 0x4f, 0x4f, 0x50, 0x10, 0x01, 0x12, 0x1b, - 0x0a, 0x17, 0x4c, 0x4f, 0x47, 0x5f, 0x41, 0x44, 0x44, 0x5f, 0x50, 0x45, 0x45, 0x52, 0x5f, 0x44, - 0x45, 0x50, 0x52, 0x45, 0x43, 0x41, 0x54, 0x45, 0x44, 0x10, 0x02, 0x12, 0x1e, 0x0a, 0x1a, 0x4c, - 0x4f, 0x47, 0x5f, 0x52, 0x45, 0x4d, 0x4f, 0x56, 0x45, 0x5f, 0x50, 0x45, 0x45, 0x52, 0x5f, 0x44, - 0x45, 0x50, 0x52, 0x45, 0x43, 0x41, 0x54, 0x45, 0x44, 0x10, 0x03, 0x12, 0x0f, 0x0a, 0x0b, 0x4c, - 0x4f, 0x47, 0x5f, 0x42, 0x41, 0x52, 0x52, 0x49, 0x45, 0x52, 0x10, 0x04, 0x12, 0x15, 0x0a, 0x11, - 0x4c, 0x4f, 0x47, 0x5f, 0x43, 0x4f, 0x4e, 0x46, 0x49, 0x47, 0x55, 0x52, 0x41, 0x54, 0x49, 0x4f, - 0x4e, 0x10, 0x05, 0x22, 0x87, 0x02, 0x0a, 0x14, 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, - 0x74, 0x72, 0x69, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x29, 0x0a, 0x0a, - 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, - 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, - 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x12, 0x16, 0x0a, 0x06, 0x6c, - 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x06, 0x6c, 0x65, 0x61, - 0x64, 0x65, 0x72, 0x12, 0x24, 0x0a, 0x0e, 0x70, 0x72, 0x65, 0x76, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, - 0x65, 0x6e, 0x74, 0x72, 0x79, 0x18, 0x04, 0x20, 0x01, 0x28, 0x04, 0x52, 0x0c, 0x70, 0x72, 0x65, - 0x76, 0x4c, 0x6f, 0x67, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x22, 0x0a, 0x0d, 0x70, 0x72, 0x65, - 0x76, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x05, 0x20, 0x01, 0x28, 0x04, - 0x52, 0x0b, 0x70, 0x72, 0x65, 0x76, 0x4c, 0x6f, 0x67, 0x54, 0x65, 0x72, 0x6d, 0x12, 0x1e, 0x0a, - 0x07, 0x65, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x18, 0x06, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x04, - 0x2e, 0x4c, 0x6f, 0x67, 0x52, 0x07, 0x65, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x12, 0x2e, 0x0a, - 0x13, 0x6c, 0x65, 0x61, 0x64, 0x65, 0x72, 0x5f, 0x63, 0x6f, 0x6d, 0x6d, 0x69, 0x74, 0x5f, 0x69, - 0x6e, 0x64, 0x65, 0x78, 0x18, 0x07, 0x20, 0x01, 0x28, 0x04, 0x52, 0x11, 0x6c, 0x65, 0x61, 0x64, - 0x65, 0x72, 0x43, 0x6f, 0x6d, 0x6d, 0x69, 0x74, 0x49, 0x6e, 0x64, 0x65, 0x78, 0x22, 0xb5, 0x01, - 0x0a, 0x15, 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x52, - 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, 0x5f, 0x68, - 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, 0x52, 0x50, - 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, 0x61, 0x64, - 0x65, 0x72, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x02, 0x20, 0x01, 0x28, 0x04, - 0x52, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x12, 0x19, 0x0a, 0x08, 0x6c, 0x61, 0x73, 0x74, 0x5f, 0x6c, - 0x6f, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x04, 0x52, 0x07, 0x6c, 0x61, 0x73, 0x74, 0x4c, 0x6f, - 0x67, 0x12, 0x18, 0x0a, 0x07, 0x73, 0x75, 0x63, 0x63, 0x65, 0x73, 0x73, 0x18, 0x04, 0x20, 0x01, - 0x28, 0x08, 0x52, 0x07, 0x73, 0x75, 0x63, 0x63, 0x65, 0x73, 0x73, 0x12, 0x28, 0x0a, 0x10, 0x6e, - 0x6f, 0x5f, 0x72, 0x65, 0x74, 0x72, 0x79, 0x5f, 0x62, 0x61, 0x63, 0x6b, 0x6f, 0x66, 0x66, 0x18, - 0x05, 0x20, 0x01, 0x28, 0x08, 0x52, 0x0e, 0x6e, 0x6f, 0x52, 0x65, 0x74, 0x72, 0x79, 0x42, 0x61, - 0x63, 0x6b, 0x6f, 0x66, 0x66, 0x22, 0xec, 0x01, 0x0a, 0x12, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x56, 0x6f, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x29, 0x0a, 0x0a, - 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, - 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, - 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x12, 0x1c, 0x0a, 0x09, 0x63, - 0x61, 0x6e, 0x64, 0x69, 0x64, 0x61, 0x74, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x09, - 0x63, 0x61, 0x6e, 0x64, 0x69, 0x64, 0x61, 0x74, 0x65, 0x12, 0x24, 0x0a, 0x0e, 0x6c, 0x61, 0x73, - 0x74, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, 0x69, 0x6e, 0x64, 0x65, 0x78, 0x18, 0x04, 0x20, 0x01, 0x28, - 0x04, 0x52, 0x0c, 0x6c, 0x61, 0x73, 0x74, 0x4c, 0x6f, 0x67, 0x49, 0x6e, 0x64, 0x65, 0x78, 0x12, - 0x22, 0x0a, 0x0d, 0x6c, 0x61, 0x73, 0x74, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, 0x74, 0x65, 0x72, 0x6d, - 0x18, 0x05, 0x20, 0x01, 0x28, 0x04, 0x52, 0x0b, 0x6c, 0x61, 0x73, 0x74, 0x4c, 0x6f, 0x67, 0x54, - 0x65, 0x72, 0x6d, 0x12, 0x2f, 0x0a, 0x13, 0x6c, 0x65, 0x61, 0x64, 0x65, 0x72, 0x73, 0x68, 0x69, - 0x70, 0x5f, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x66, 0x65, 0x72, 0x18, 0x06, 0x20, 0x01, 0x28, 0x08, - 0x52, 0x12, 0x6c, 0x65, 0x61, 0x64, 0x65, 0x72, 0x73, 0x68, 0x69, 0x70, 0x54, 0x72, 0x61, 0x6e, - 0x73, 0x66, 0x65, 0x72, 0x22, 0x84, 0x01, 0x0a, 0x13, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x56, 0x6f, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x29, 0x0a, 0x0a, - 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, - 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, - 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x12, 0x14, 0x0a, 0x05, 0x70, - 0x65, 0x65, 0x72, 0x73, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x05, 0x70, 0x65, 0x65, 0x72, - 0x73, 0x12, 0x18, 0x0a, 0x07, 0x67, 0x72, 0x61, 0x6e, 0x74, 0x65, 0x64, 0x18, 0x04, 0x20, 0x01, - 0x28, 0x08, 0x52, 0x07, 0x67, 0x72, 0x61, 0x6e, 0x74, 0x65, 0x64, 0x22, 0x3e, 0x0a, 0x11, 0x54, - 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x4e, 0x6f, 0x77, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, - 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x22, 0x3f, 0x0a, 0x12, 0x54, - 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x4e, 0x6f, 0x77, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, - 0x72, 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x22, 0xf9, 0x02, 0x0a, - 0x16, 0x49, 0x6e, 0x73, 0x74, 0x61, 0x6c, 0x6c, 0x53, 0x6e, 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, 0x5f, 0x68, - 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, 0x52, 0x50, - 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, 0x61, 0x64, - 0x65, 0x72, 0x12, 0x29, 0x0a, 0x10, 0x73, 0x6e, 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, 0x5f, 0x76, - 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x0b, 0x20, 0x01, 0x28, 0x03, 0x52, 0x0f, 0x73, 0x6e, - 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, 0x56, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x12, 0x0a, - 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, 0x72, - 0x6d, 0x12, 0x16, 0x0a, 0x06, 0x6c, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x03, 0x20, 0x01, 0x28, - 0x0c, 0x52, 0x06, 0x6c, 0x65, 0x61, 0x64, 0x65, 0x72, 0x12, 0x24, 0x0a, 0x0e, 0x6c, 0x61, 0x73, - 0x74, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, 0x69, 0x6e, 0x64, 0x65, 0x78, 0x18, 0x04, 0x20, 0x01, 0x28, - 0x04, 0x52, 0x0c, 0x6c, 0x61, 0x73, 0x74, 0x4c, 0x6f, 0x67, 0x49, 0x6e, 0x64, 0x65, 0x78, 0x12, - 0x22, 0x0a, 0x0d, 0x6c, 0x61, 0x73, 0x74, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, 0x74, 0x65, 0x72, 0x6d, - 0x18, 0x05, 0x20, 0x01, 0x28, 0x04, 0x52, 0x0b, 0x6c, 0x61, 0x73, 0x74, 0x4c, 0x6f, 0x67, 0x54, - 0x65, 0x72, 0x6d, 0x12, 0x14, 0x0a, 0x05, 0x70, 0x65, 0x65, 0x72, 0x73, 0x18, 0x06, 0x20, 0x01, - 0x28, 0x0c, 0x52, 0x05, 0x70, 0x65, 0x65, 0x72, 0x73, 0x12, 0x24, 0x0a, 0x0d, 0x63, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0c, - 0x52, 0x0d, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, - 0x2f, 0x0a, 0x13, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, - 0x5f, 0x69, 0x6e, 0x64, 0x65, 0x78, 0x18, 0x08, 0x20, 0x01, 0x28, 0x04, 0x52, 0x12, 0x63, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x49, 0x6e, 0x64, 0x65, 0x78, - 0x12, 0x12, 0x0a, 0x04, 0x73, 0x69, 0x7a, 0x65, 0x18, 0x09, 0x20, 0x01, 0x28, 0x03, 0x52, 0x04, - 0x73, 0x69, 0x7a, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x0a, 0x20, 0x01, - 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x22, 0x72, 0x0a, 0x17, 0x49, 0x6e, 0x73, 0x74, - 0x61, 0x6c, 0x6c, 0x53, 0x6e, 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, - 0x6e, 0x73, 0x65, 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, - 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, - 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x12, 0x12, - 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, - 0x72, 0x6d, 0x12, 0x18, 0x0a, 0x07, 0x73, 0x75, 0x63, 0x63, 0x65, 0x73, 0x73, 0x18, 0x03, 0x20, - 0x01, 0x28, 0x08, 0x52, 0x07, 0x73, 0x75, 0x63, 0x63, 0x65, 0x73, 0x73, 0x22, 0xa0, 0x01, 0x0a, - 0x15, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x50, 0x72, 0x65, 0x56, 0x6f, 0x74, 0x65, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, 0x5f, 0x68, 0x65, - 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, 0x52, 0x50, 0x43, - 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, 0x61, 0x64, 0x65, - 0x72, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x02, 0x20, 0x01, 0x28, 0x04, 0x52, - 0x04, 0x74, 0x65, 0x72, 0x6d, 0x12, 0x24, 0x0a, 0x0e, 0x6c, 0x61, 0x73, 0x74, 0x5f, 0x6c, 0x6f, - 0x67, 0x5f, 0x69, 0x6e, 0x64, 0x65, 0x78, 0x18, 0x03, 0x20, 0x01, 0x28, 0x04, 0x52, 0x0c, 0x6c, - 0x61, 0x73, 0x74, 0x4c, 0x6f, 0x67, 0x49, 0x6e, 0x64, 0x65, 0x78, 0x12, 0x22, 0x0a, 0x0d, 0x6c, - 0x61, 0x73, 0x74, 0x5f, 0x6c, 0x6f, 0x67, 0x5f, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x04, 0x20, 0x01, - 0x28, 0x04, 0x52, 0x0b, 0x6c, 0x61, 0x73, 0x74, 0x4c, 0x6f, 0x67, 0x54, 0x65, 0x72, 0x6d, 0x22, - 0x71, 0x0a, 0x16, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x50, 0x72, 0x65, 0x56, 0x6f, 0x74, - 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x29, 0x0a, 0x0a, 0x72, 0x70, 0x63, - 0x5f, 0x68, 0x65, 0x61, 0x64, 0x65, 0x72, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x0a, 0x2e, - 0x52, 0x50, 0x43, 0x48, 0x65, 0x61, 0x64, 0x65, 0x72, 0x52, 0x09, 0x72, 0x70, 0x63, 0x48, 0x65, - 0x61, 0x64, 0x65, 0x72, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x04, 0x52, 0x04, 0x74, 0x65, 0x72, 0x6d, 0x12, 0x18, 0x0a, 0x07, 0x67, 0x72, 0x61, 0x6e, - 0x74, 0x65, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x08, 0x52, 0x07, 0x67, 0x72, 0x61, 0x6e, 0x74, - 0x65, 0x64, 0x32, 0xa3, 0x03, 0x0a, 0x0d, 0x52, 0x61, 0x66, 0x74, 0x54, 0x72, 0x61, 0x6e, 0x73, - 0x70, 0x6f, 0x72, 0x74, 0x12, 0x4c, 0x0a, 0x15, 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, - 0x74, 0x72, 0x69, 0x65, 0x73, 0x50, 0x69, 0x70, 0x65, 0x6c, 0x69, 0x6e, 0x65, 0x12, 0x15, 0x2e, - 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, 0x74, - 0x72, 0x69, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x28, 0x01, - 0x30, 0x01, 0x12, 0x40, 0x0a, 0x0d, 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, 0x74, 0x72, - 0x69, 0x65, 0x73, 0x12, 0x15, 0x2e, 0x41, 0x70, 0x70, 0x65, 0x6e, 0x64, 0x45, 0x6e, 0x74, 0x72, - 0x69, 0x65, 0x73, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x41, 0x70, 0x70, - 0x65, 0x6e, 0x64, 0x45, 0x6e, 0x74, 0x72, 0x69, 0x65, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x22, 0x00, 0x12, 0x3a, 0x0a, 0x0b, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x56, - 0x6f, 0x74, 0x65, 0x12, 0x13, 0x2e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x56, 0x6f, 0x74, - 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x14, 0x2e, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x56, 0x6f, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, - 0x12, 0x37, 0x0a, 0x0a, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x4e, 0x6f, 0x77, 0x12, 0x12, - 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x4e, 0x6f, 0x77, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x1a, 0x13, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x6f, 0x75, 0x74, 0x4e, 0x6f, 0x77, 0x52, - 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x48, 0x0a, 0x0f, 0x49, 0x6e, 0x73, - 0x74, 0x61, 0x6c, 0x6c, 0x53, 0x6e, 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, 0x12, 0x17, 0x2e, 0x49, - 0x6e, 0x73, 0x74, 0x61, 0x6c, 0x6c, 0x53, 0x6e, 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x18, 0x2e, 0x49, 0x6e, 0x73, 0x74, 0x61, 0x6c, 0x6c, 0x53, - 0x6e, 0x61, 0x70, 0x73, 0x68, 0x6f, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, - 0x00, 0x28, 0x01, 0x12, 0x43, 0x0a, 0x0e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x50, 0x72, - 0x65, 0x56, 0x6f, 0x74, 0x65, 0x12, 0x16, 0x2e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x50, - 0x72, 0x65, 0x56, 0x6f, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x17, 0x2e, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x50, 0x72, 0x65, 0x56, 0x6f, 0x74, 0x65, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x42, 0x2c, 0x5a, 0x2a, 0x67, 0x69, 0x74, 0x68, - 0x75, 0x62, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x4a, 0x69, 0x6c, 0x6c, 0x65, 0x2f, 0x72, 0x61, 0x66, - 0x74, 0x2d, 0x67, 0x72, 0x70, 0x63, 0x2d, 0x74, 0x72, 0x61, 0x6e, 0x73, 0x70, 0x6f, 0x72, 0x74, - 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, -} - -var ( - file_transport_proto_rawDescOnce sync.Once - file_transport_proto_rawDescData = file_transport_proto_rawDesc -) - -func file_transport_proto_rawDescGZIP() []byte { - file_transport_proto_rawDescOnce.Do(func() { - file_transport_proto_rawDescData = protoimpl.X.CompressGZIP(file_transport_proto_rawDescData) - }) - return file_transport_proto_rawDescData -} - -var file_transport_proto_enumTypes = make([]protoimpl.EnumInfo, 1) -var file_transport_proto_msgTypes = make([]protoimpl.MessageInfo, 12) -var file_transport_proto_goTypes = []interface{}{ - (Log_LogType)(0), // 0: Log.LogType - (*RPCHeader)(nil), // 1: RPCHeader - (*Log)(nil), // 2: Log - (*AppendEntriesRequest)(nil), // 3: AppendEntriesRequest - (*AppendEntriesResponse)(nil), // 4: AppendEntriesResponse - (*RequestVoteRequest)(nil), // 5: RequestVoteRequest - (*RequestVoteResponse)(nil), // 6: RequestVoteResponse - (*TimeoutNowRequest)(nil), // 7: TimeoutNowRequest - (*TimeoutNowResponse)(nil), // 8: TimeoutNowResponse - (*InstallSnapshotRequest)(nil), // 9: InstallSnapshotRequest - (*InstallSnapshotResponse)(nil), // 10: InstallSnapshotResponse - (*RequestPreVoteRequest)(nil), // 11: RequestPreVoteRequest - (*RequestPreVoteResponse)(nil), // 12: RequestPreVoteResponse - (*timestamppb.Timestamp)(nil), // 13: google.protobuf.Timestamp -} -var file_transport_proto_depIdxs = []int32{ - 0, // 0: Log.type:type_name -> Log.LogType - 13, // 1: Log.appended_at:type_name -> google.protobuf.Timestamp - 1, // 2: AppendEntriesRequest.rpc_header:type_name -> RPCHeader - 2, // 3: AppendEntriesRequest.entries:type_name -> Log - 1, // 4: AppendEntriesResponse.rpc_header:type_name -> RPCHeader - 1, // 5: RequestVoteRequest.rpc_header:type_name -> RPCHeader - 1, // 6: RequestVoteResponse.rpc_header:type_name -> RPCHeader - 1, // 7: TimeoutNowRequest.rpc_header:type_name -> RPCHeader - 1, // 8: TimeoutNowResponse.rpc_header:type_name -> RPCHeader - 1, // 9: InstallSnapshotRequest.rpc_header:type_name -> RPCHeader - 1, // 10: InstallSnapshotResponse.rpc_header:type_name -> RPCHeader - 1, // 11: RequestPreVoteRequest.rpc_header:type_name -> RPCHeader - 1, // 12: RequestPreVoteResponse.rpc_header:type_name -> RPCHeader - 3, // 13: RaftTransport.AppendEntriesPipeline:input_type -> AppendEntriesRequest - 3, // 14: RaftTransport.AppendEntries:input_type -> AppendEntriesRequest - 5, // 15: RaftTransport.RequestVote:input_type -> RequestVoteRequest - 7, // 16: RaftTransport.TimeoutNow:input_type -> TimeoutNowRequest - 9, // 17: RaftTransport.InstallSnapshot:input_type -> InstallSnapshotRequest - 11, // 18: RaftTransport.RequestPreVote:input_type -> RequestPreVoteRequest - 4, // 19: RaftTransport.AppendEntriesPipeline:output_type -> AppendEntriesResponse - 4, // 20: RaftTransport.AppendEntries:output_type -> AppendEntriesResponse - 6, // 21: RaftTransport.RequestVote:output_type -> RequestVoteResponse - 8, // 22: RaftTransport.TimeoutNow:output_type -> TimeoutNowResponse - 10, // 23: RaftTransport.InstallSnapshot:output_type -> InstallSnapshotResponse - 12, // 24: RaftTransport.RequestPreVote:output_type -> RequestPreVoteResponse - 19, // [19:25] is the sub-list for method output_type - 13, // [13:19] is the sub-list for method input_type - 13, // [13:13] is the sub-list for extension type_name - 13, // [13:13] is the sub-list for extension extendee - 0, // [0:13] is the sub-list for field type_name -} - -func init() { file_transport_proto_init() } -func file_transport_proto_init() { - if File_transport_proto != nil { - return - } - if !protoimpl.UnsafeEnabled { - file_transport_proto_msgTypes[0].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RPCHeader); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[1].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*Log); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[2].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*AppendEntriesRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[3].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*AppendEntriesResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[4].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RequestVoteRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[5].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RequestVoteResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[6].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TimeoutNowRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[7].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TimeoutNowResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[8].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InstallSnapshotRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[9].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InstallSnapshotResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[10].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RequestPreVoteRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_transport_proto_msgTypes[11].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RequestPreVoteResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - } - type x struct{} - out := protoimpl.TypeBuilder{ - File: protoimpl.DescBuilder{ - GoPackagePath: reflect.TypeOf(x{}).PkgPath(), - RawDescriptor: file_transport_proto_rawDesc, - NumEnums: 1, - NumMessages: 12, - NumExtensions: 0, - NumServices: 1, - }, - GoTypes: file_transport_proto_goTypes, - DependencyIndexes: file_transport_proto_depIdxs, - EnumInfos: file_transport_proto_enumTypes, - MessageInfos: file_transport_proto_msgTypes, - }.Build() - File_transport_proto = out.File - file_transport_proto_rawDesc = nil - file_transport_proto_goTypes = nil - file_transport_proto_depIdxs = nil -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/proto/transport.proto b/vendor/github.com/Jille/raft-grpc-transport/proto/transport.proto deleted file mode 100644 index a3e983b..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/proto/transport.proto +++ /dev/null @@ -1,122 +0,0 @@ -syntax = "proto3"; - -option go_package = "github.com/Jille/raft-grpc-transport/proto"; - -import "google/protobuf/timestamp.proto"; - -service RaftTransport { - // AppendEntriesPipeline opens an AppendEntries message stream. - rpc AppendEntriesPipeline(stream AppendEntriesRequest) returns (stream AppendEntriesResponse) {} - - // AppendEntries performs a single append entries request / response. - rpc AppendEntries(AppendEntriesRequest) returns (AppendEntriesResponse) {} - // RequestVote is the command used by a candidate to ask a Raft peer for a vote in an election. - rpc RequestVote(RequestVoteRequest) returns (RequestVoteResponse) {} - // TimeoutNow is used to start a leadership transfer to the target node. - rpc TimeoutNow(TimeoutNowRequest) returns (TimeoutNowResponse) {} - // InstallSnapshot is the command sent to a Raft peer to bootstrap its log (and state machine) from a snapshot on another peer. - rpc InstallSnapshot(stream InstallSnapshotRequest) returns (InstallSnapshotResponse) {} - // RequestPreVote is the command used by a candidate to ask a Raft peer for a vote in an election. - rpc RequestPreVote(RequestPreVoteRequest) returns (RequestPreVoteResponse) {} -} - -message RPCHeader { - int64 protocol_version = 1; - bytes id = 2; - bytes addr = 3; -} - -message Log { - enum LogType { - LOG_COMMAND = 0; - LOG_NOOP = 1; - LOG_ADD_PEER_DEPRECATED = 2; - LOG_REMOVE_PEER_DEPRECATED = 3; - LOG_BARRIER = 4; - LOG_CONFIGURATION = 5; - } - uint64 index = 1; - uint64 term = 2; - LogType type = 3; - bytes data = 4; - bytes extensions = 5; - google.protobuf.Timestamp appended_at = 6; -} - -message AppendEntriesRequest { - RPCHeader rpc_header = 1; - uint64 term = 2; - bytes leader = 3; - uint64 prev_log_entry = 4; - uint64 prev_log_term = 5; - repeated Log entries = 6; - uint64 leader_commit_index = 7; -} - -message AppendEntriesResponse { - RPCHeader rpc_header = 1; - uint64 term = 2; - uint64 last_log = 3; - bool success = 4; - bool no_retry_backoff = 5; -} - -message RequestVoteRequest { - RPCHeader rpc_header = 1; - uint64 term = 2; - bytes candidate = 3; - uint64 last_log_index = 4; - uint64 last_log_term = 5; - bool leadership_transfer = 6; -} - -message RequestVoteResponse { - RPCHeader rpc_header = 1; - uint64 term = 2; - bytes peers = 3; - bool granted = 4; -} - -message TimeoutNowRequest { - RPCHeader rpc_header = 1; -} - -message TimeoutNowResponse { - RPCHeader rpc_header = 1; -} - -// The first InstallSnapshotRequest on the stream contains all the metadata. -// All further messages contain only data. -message InstallSnapshotRequest { - RPCHeader rpc_header = 1; - int64 snapshot_version = 11; - uint64 term = 2; - bytes leader = 3; - uint64 last_log_index = 4; - uint64 last_log_term = 5; - bytes peers = 6; - bytes configuration = 7; - uint64 configuration_index = 8; - int64 size = 9; - - bytes data = 10; -} - -message InstallSnapshotResponse { - RPCHeader rpc_header = 1; - uint64 term = 2; - bool success = 3; -} - -message RequestPreVoteRequest { - RPCHeader rpc_header = 1; - uint64 term = 2; - uint64 last_log_index = 3; - uint64 last_log_term = 4; -} - -message RequestPreVoteResponse { - RPCHeader rpc_header = 1; - uint64 term = 2; - bool granted = 3; -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/proto/transport_grpc.pb.go b/vendor/github.com/Jille/raft-grpc-transport/proto/transport_grpc.pb.go deleted file mode 100644 index f10b527..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/proto/transport_grpc.pb.go +++ /dev/null @@ -1,364 +0,0 @@ -// Code generated by protoc-gen-go-grpc. DO NOT EDIT. -// versions: -// - protoc-gen-go-grpc v1.2.0 -// - protoc v3.21.3 -// source: transport.proto - -package proto - -import ( - context "context" - grpc "google.golang.org/grpc" - codes "google.golang.org/grpc/codes" - status "google.golang.org/grpc/status" -) - -// This is a compile-time assertion to ensure that this generated file -// is compatible with the grpc package it is being compiled against. -// Requires gRPC-Go v1.32.0 or later. -const _ = grpc.SupportPackageIsVersion7 - -// RaftTransportClient is the client API for RaftTransport service. -// -// For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream. -type RaftTransportClient interface { - // AppendEntriesPipeline opens an AppendEntries message stream. - AppendEntriesPipeline(ctx context.Context, opts ...grpc.CallOption) (RaftTransport_AppendEntriesPipelineClient, error) - // AppendEntries performs a single append entries request / response. - AppendEntries(ctx context.Context, in *AppendEntriesRequest, opts ...grpc.CallOption) (*AppendEntriesResponse, error) - // RequestVote is the command used by a candidate to ask a Raft peer for a vote in an election. - RequestVote(ctx context.Context, in *RequestVoteRequest, opts ...grpc.CallOption) (*RequestVoteResponse, error) - // TimeoutNow is used to start a leadership transfer to the target node. - TimeoutNow(ctx context.Context, in *TimeoutNowRequest, opts ...grpc.CallOption) (*TimeoutNowResponse, error) - // InstallSnapshot is the command sent to a Raft peer to bootstrap its log (and state machine) from a snapshot on another peer. - InstallSnapshot(ctx context.Context, opts ...grpc.CallOption) (RaftTransport_InstallSnapshotClient, error) - // RequestPreVote is the command used by a candidate to ask a Raft peer for a vote in an election. - RequestPreVote(ctx context.Context, in *RequestPreVoteRequest, opts ...grpc.CallOption) (*RequestPreVoteResponse, error) -} - -type raftTransportClient struct { - cc grpc.ClientConnInterface -} - -func NewRaftTransportClient(cc grpc.ClientConnInterface) RaftTransportClient { - return &raftTransportClient{cc} -} - -func (c *raftTransportClient) AppendEntriesPipeline(ctx context.Context, opts ...grpc.CallOption) (RaftTransport_AppendEntriesPipelineClient, error) { - stream, err := c.cc.NewStream(ctx, &RaftTransport_ServiceDesc.Streams[0], "/RaftTransport/AppendEntriesPipeline", opts...) - if err != nil { - return nil, err - } - x := &raftTransportAppendEntriesPipelineClient{stream} - return x, nil -} - -type RaftTransport_AppendEntriesPipelineClient interface { - Send(*AppendEntriesRequest) error - Recv() (*AppendEntriesResponse, error) - grpc.ClientStream -} - -type raftTransportAppendEntriesPipelineClient struct { - grpc.ClientStream -} - -func (x *raftTransportAppendEntriesPipelineClient) Send(m *AppendEntriesRequest) error { - return x.ClientStream.SendMsg(m) -} - -func (x *raftTransportAppendEntriesPipelineClient) Recv() (*AppendEntriesResponse, error) { - m := new(AppendEntriesResponse) - if err := x.ClientStream.RecvMsg(m); err != nil { - return nil, err - } - return m, nil -} - -func (c *raftTransportClient) AppendEntries(ctx context.Context, in *AppendEntriesRequest, opts ...grpc.CallOption) (*AppendEntriesResponse, error) { - out := new(AppendEntriesResponse) - err := c.cc.Invoke(ctx, "/RaftTransport/AppendEntries", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *raftTransportClient) RequestVote(ctx context.Context, in *RequestVoteRequest, opts ...grpc.CallOption) (*RequestVoteResponse, error) { - out := new(RequestVoteResponse) - err := c.cc.Invoke(ctx, "/RaftTransport/RequestVote", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *raftTransportClient) TimeoutNow(ctx context.Context, in *TimeoutNowRequest, opts ...grpc.CallOption) (*TimeoutNowResponse, error) { - out := new(TimeoutNowResponse) - err := c.cc.Invoke(ctx, "/RaftTransport/TimeoutNow", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *raftTransportClient) InstallSnapshot(ctx context.Context, opts ...grpc.CallOption) (RaftTransport_InstallSnapshotClient, error) { - stream, err := c.cc.NewStream(ctx, &RaftTransport_ServiceDesc.Streams[1], "/RaftTransport/InstallSnapshot", opts...) - if err != nil { - return nil, err - } - x := &raftTransportInstallSnapshotClient{stream} - return x, nil -} - -type RaftTransport_InstallSnapshotClient interface { - Send(*InstallSnapshotRequest) error - CloseAndRecv() (*InstallSnapshotResponse, error) - grpc.ClientStream -} - -type raftTransportInstallSnapshotClient struct { - grpc.ClientStream -} - -func (x *raftTransportInstallSnapshotClient) Send(m *InstallSnapshotRequest) error { - return x.ClientStream.SendMsg(m) -} - -func (x *raftTransportInstallSnapshotClient) CloseAndRecv() (*InstallSnapshotResponse, error) { - if err := x.ClientStream.CloseSend(); err != nil { - return nil, err - } - m := new(InstallSnapshotResponse) - if err := x.ClientStream.RecvMsg(m); err != nil { - return nil, err - } - return m, nil -} - -func (c *raftTransportClient) RequestPreVote(ctx context.Context, in *RequestPreVoteRequest, opts ...grpc.CallOption) (*RequestPreVoteResponse, error) { - out := new(RequestPreVoteResponse) - err := c.cc.Invoke(ctx, "/RaftTransport/RequestPreVote", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -// RaftTransportServer is the server API for RaftTransport service. -// All implementations must embed UnimplementedRaftTransportServer -// for forward compatibility -type RaftTransportServer interface { - // AppendEntriesPipeline opens an AppendEntries message stream. - AppendEntriesPipeline(RaftTransport_AppendEntriesPipelineServer) error - // AppendEntries performs a single append entries request / response. - AppendEntries(context.Context, *AppendEntriesRequest) (*AppendEntriesResponse, error) - // RequestVote is the command used by a candidate to ask a Raft peer for a vote in an election. - RequestVote(context.Context, *RequestVoteRequest) (*RequestVoteResponse, error) - // TimeoutNow is used to start a leadership transfer to the target node. - TimeoutNow(context.Context, *TimeoutNowRequest) (*TimeoutNowResponse, error) - // InstallSnapshot is the command sent to a Raft peer to bootstrap its log (and state machine) from a snapshot on another peer. - InstallSnapshot(RaftTransport_InstallSnapshotServer) error - // RequestPreVote is the command used by a candidate to ask a Raft peer for a vote in an election. - RequestPreVote(context.Context, *RequestPreVoteRequest) (*RequestPreVoteResponse, error) - mustEmbedUnimplementedRaftTransportServer() -} - -// UnimplementedRaftTransportServer must be embedded to have forward compatible implementations. -type UnimplementedRaftTransportServer struct { -} - -func (UnimplementedRaftTransportServer) AppendEntriesPipeline(RaftTransport_AppendEntriesPipelineServer) error { - return status.Errorf(codes.Unimplemented, "method AppendEntriesPipeline not implemented") -} -func (UnimplementedRaftTransportServer) AppendEntries(context.Context, *AppendEntriesRequest) (*AppendEntriesResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method AppendEntries not implemented") -} -func (UnimplementedRaftTransportServer) RequestVote(context.Context, *RequestVoteRequest) (*RequestVoteResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method RequestVote not implemented") -} -func (UnimplementedRaftTransportServer) TimeoutNow(context.Context, *TimeoutNowRequest) (*TimeoutNowResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method TimeoutNow not implemented") -} -func (UnimplementedRaftTransportServer) InstallSnapshot(RaftTransport_InstallSnapshotServer) error { - return status.Errorf(codes.Unimplemented, "method InstallSnapshot not implemented") -} -func (UnimplementedRaftTransportServer) RequestPreVote(context.Context, *RequestPreVoteRequest) (*RequestPreVoteResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method RequestPreVote not implemented") -} -func (UnimplementedRaftTransportServer) mustEmbedUnimplementedRaftTransportServer() {} - -// UnsafeRaftTransportServer may be embedded to opt out of forward compatibility for this service. -// Use of this interface is not recommended, as added methods to RaftTransportServer will -// result in compilation errors. -type UnsafeRaftTransportServer interface { - mustEmbedUnimplementedRaftTransportServer() -} - -func RegisterRaftTransportServer(s grpc.ServiceRegistrar, srv RaftTransportServer) { - s.RegisterService(&RaftTransport_ServiceDesc, srv) -} - -func _RaftTransport_AppendEntriesPipeline_Handler(srv interface{}, stream grpc.ServerStream) error { - return srv.(RaftTransportServer).AppendEntriesPipeline(&raftTransportAppendEntriesPipelineServer{stream}) -} - -type RaftTransport_AppendEntriesPipelineServer interface { - Send(*AppendEntriesResponse) error - Recv() (*AppendEntriesRequest, error) - grpc.ServerStream -} - -type raftTransportAppendEntriesPipelineServer struct { - grpc.ServerStream -} - -func (x *raftTransportAppendEntriesPipelineServer) Send(m *AppendEntriesResponse) error { - return x.ServerStream.SendMsg(m) -} - -func (x *raftTransportAppendEntriesPipelineServer) Recv() (*AppendEntriesRequest, error) { - m := new(AppendEntriesRequest) - if err := x.ServerStream.RecvMsg(m); err != nil { - return nil, err - } - return m, nil -} - -func _RaftTransport_AppendEntries_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(AppendEntriesRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(RaftTransportServer).AppendEntries(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/RaftTransport/AppendEntries", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(RaftTransportServer).AppendEntries(ctx, req.(*AppendEntriesRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _RaftTransport_RequestVote_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(RequestVoteRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(RaftTransportServer).RequestVote(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/RaftTransport/RequestVote", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(RaftTransportServer).RequestVote(ctx, req.(*RequestVoteRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _RaftTransport_TimeoutNow_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(TimeoutNowRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(RaftTransportServer).TimeoutNow(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/RaftTransport/TimeoutNow", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(RaftTransportServer).TimeoutNow(ctx, req.(*TimeoutNowRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _RaftTransport_InstallSnapshot_Handler(srv interface{}, stream grpc.ServerStream) error { - return srv.(RaftTransportServer).InstallSnapshot(&raftTransportInstallSnapshotServer{stream}) -} - -type RaftTransport_InstallSnapshotServer interface { - SendAndClose(*InstallSnapshotResponse) error - Recv() (*InstallSnapshotRequest, error) - grpc.ServerStream -} - -type raftTransportInstallSnapshotServer struct { - grpc.ServerStream -} - -func (x *raftTransportInstallSnapshotServer) SendAndClose(m *InstallSnapshotResponse) error { - return x.ServerStream.SendMsg(m) -} - -func (x *raftTransportInstallSnapshotServer) Recv() (*InstallSnapshotRequest, error) { - m := new(InstallSnapshotRequest) - if err := x.ServerStream.RecvMsg(m); err != nil { - return nil, err - } - return m, nil -} - -func _RaftTransport_RequestPreVote_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(RequestPreVoteRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(RaftTransportServer).RequestPreVote(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/RaftTransport/RequestPreVote", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(RaftTransportServer).RequestPreVote(ctx, req.(*RequestPreVoteRequest)) - } - return interceptor(ctx, in, info, handler) -} - -// RaftTransport_ServiceDesc is the grpc.ServiceDesc for RaftTransport service. -// It's only intended for direct use with grpc.RegisterService, -// and not to be introspected or modified (even as a copy) -var RaftTransport_ServiceDesc = grpc.ServiceDesc{ - ServiceName: "RaftTransport", - HandlerType: (*RaftTransportServer)(nil), - Methods: []grpc.MethodDesc{ - { - MethodName: "AppendEntries", - Handler: _RaftTransport_AppendEntries_Handler, - }, - { - MethodName: "RequestVote", - Handler: _RaftTransport_RequestVote_Handler, - }, - { - MethodName: "TimeoutNow", - Handler: _RaftTransport_TimeoutNow_Handler, - }, - { - MethodName: "RequestPreVote", - Handler: _RaftTransport_RequestPreVote_Handler, - }, - }, - Streams: []grpc.StreamDesc{ - { - StreamName: "AppendEntriesPipeline", - Handler: _RaftTransport_AppendEntriesPipeline_Handler, - ServerStreams: true, - ClientStreams: true, - }, - { - StreamName: "InstallSnapshot", - Handler: _RaftTransport_InstallSnapshot_Handler, - ClientStreams: true, - }, - }, - Metadata: "transport.proto", -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/raftapi.go b/vendor/github.com/Jille/raft-grpc-transport/raftapi.go deleted file mode 100644 index 13015f5..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/raftapi.go +++ /dev/null @@ -1,329 +0,0 @@ -package transport - -import ( - "context" - "io" - "sync" - "time" - - pb "github.com/Jille/raft-grpc-transport/proto" - "github.com/hashicorp/raft" - "google.golang.org/grpc" -) - -// These are calls from the Raft engine that we need to send out over gRPC. - -type raftAPI struct { - manager *Manager -} - -var _ raft.Transport = raftAPI{} -var _ raft.WithClose = raftAPI{} -var _ raft.WithPeers = raftAPI{} -var _ raft.WithPreVote = raftAPI{} - -type conn struct { - clientConn *grpc.ClientConn - client pb.RaftTransportClient - mtx sync.Mutex -} - -// Consumer returns a channel that can be used to consume and respond to RPC requests. -func (r raftAPI) Consumer() <-chan raft.RPC { - return r.manager.rpcChan -} - -// LocalAddr is used to return our local address to distinguish from our peers. -func (r raftAPI) LocalAddr() raft.ServerAddress { - return r.manager.localAddress -} - -func (r raftAPI) getPeer(target raft.ServerAddress) (pb.RaftTransportClient, error) { - r.manager.connectionsMtx.Lock() - c, ok := r.manager.connections[target] - if !ok { - c = &conn{} - c.mtx.Lock() - r.manager.connections[target] = c - } - r.manager.connectionsMtx.Unlock() - if ok { - c.mtx.Lock() - } - defer c.mtx.Unlock() - if c.clientConn == nil { - conn, err := grpc.Dial(string(target), r.manager.dialOptions...) - if err != nil { - return nil, err - } - c.clientConn = conn - c.client = pb.NewRaftTransportClient(conn) - } - return c.client, nil -} - -// AppendEntries sends the appropriate RPC to the target node. -func (r raftAPI) AppendEntries(id raft.ServerID, target raft.ServerAddress, args *raft.AppendEntriesRequest, resp *raft.AppendEntriesResponse) error { - c, err := r.getPeer(target) - if err != nil { - return err - } - ctx := context.TODO() - if r.manager.heartbeatTimeout > 0 && isHeartbeat(args) { - var cancel context.CancelFunc - ctx, cancel = context.WithTimeout(ctx, r.manager.heartbeatTimeout) - defer cancel() - } - ret, err := c.AppendEntries(ctx, encodeAppendEntriesRequest(args)) - if err != nil { - return err - } - *resp = *decodeAppendEntriesResponse(ret) - return nil -} - -// RequestVote sends the appropriate RPC to the target node. -func (r raftAPI) RequestVote(id raft.ServerID, target raft.ServerAddress, args *raft.RequestVoteRequest, resp *raft.RequestVoteResponse) error { - c, err := r.getPeer(target) - if err != nil { - return err - } - ret, err := c.RequestVote(context.TODO(), encodeRequestVoteRequest(args)) - if err != nil { - return err - } - *resp = *decodeRequestVoteResponse(ret) - return nil -} - -// TimeoutNow is used to start a leadership transfer to the target node. -func (r raftAPI) TimeoutNow(id raft.ServerID, target raft.ServerAddress, args *raft.TimeoutNowRequest, resp *raft.TimeoutNowResponse) error { - c, err := r.getPeer(target) - if err != nil { - return err - } - ret, err := c.TimeoutNow(context.TODO(), encodeTimeoutNowRequest(args)) - if err != nil { - return err - } - *resp = *decodeTimeoutNowResponse(ret) - return nil -} - -// RequestPreVote is the command used by a candidate to ask a Raft peer for a vote in an election. -func (r raftAPI) RequestPreVote(id raft.ServerID, target raft.ServerAddress, args *raft.RequestPreVoteRequest, resp *raft.RequestPreVoteResponse) error { - c, err := r.getPeer(target) - if err != nil { - return err - } - ret, err := c.RequestPreVote(context.TODO(), encodeRequestPreVoteRequest(args)) - if err != nil { - return err - } - *resp = *decodeRequestPreVoteResponse(ret) - return nil -} - -// InstallSnapshot is used to push a snapshot down to a follower. The data is read from -// the ReadCloser and streamed to the client. -func (r raftAPI) InstallSnapshot(id raft.ServerID, target raft.ServerAddress, req *raft.InstallSnapshotRequest, resp *raft.InstallSnapshotResponse, data io.Reader) error { - c, err := r.getPeer(target) - if err != nil { - return err - } - stream, err := c.InstallSnapshot(context.TODO()) - if err != nil { - return err - } - if err := stream.Send(encodeInstallSnapshotRequest(req)); err != nil { - return err - } - var buf [16384]byte - for { - n, err := data.Read(buf[:]) - if err == io.EOF || (err == nil && n == 0) { - break - } - if err != nil { - return err - } - if err := stream.Send(&pb.InstallSnapshotRequest{ - Data: buf[:n], - }); err != nil { - return err - } - } - ret, err := stream.CloseAndRecv() - if err != nil { - return err - } - *resp = *decodeInstallSnapshotResponse(ret) - return nil -} - -// AppendEntriesPipeline returns an interface that can be used to pipeline -// AppendEntries requests. -func (r raftAPI) AppendEntriesPipeline(id raft.ServerID, target raft.ServerAddress) (raft.AppendPipeline, error) { - c, err := r.getPeer(target) - if err != nil { - return nil, err - } - ctx := context.TODO() - ctx, cancel := context.WithCancel(ctx) - stream, err := c.AppendEntriesPipeline(ctx) - if err != nil { - cancel() - return nil, err - } - rpa := raftPipelineAPI{ - stream: stream, - cancel: cancel, - inflightCh: make(chan *appendFuture, 20), - doneCh: make(chan raft.AppendFuture, 20), - } - go rpa.receiver() - return rpa, nil -} - -type raftPipelineAPI struct { - stream pb.RaftTransport_AppendEntriesPipelineClient - cancel func() - inflightChMtx sync.Mutex - inflightCh chan *appendFuture - doneCh chan raft.AppendFuture -} - -// AppendEntries is used to add another request to the pipeline. -// The send may block which is an effective form of back-pressure. -func (r raftPipelineAPI) AppendEntries(req *raft.AppendEntriesRequest, resp *raft.AppendEntriesResponse) (raft.AppendFuture, error) { - af := &appendFuture{ - start: time.Now(), - request: req, - done: make(chan struct{}), - } - if err := r.stream.Send(encodeAppendEntriesRequest(req)); err != nil { - return nil, err - } - r.inflightChMtx.Lock() - select { - case <-r.stream.Context().Done(): - default: - r.inflightCh <- af - } - r.inflightChMtx.Unlock() - return af, nil -} - -// Consumer returns a channel that can be used to consume -// response futures when they are ready. -func (r raftPipelineAPI) Consumer() <-chan raft.AppendFuture { - return r.doneCh -} - -// Close closes the pipeline and cancels all inflight RPCs -func (r raftPipelineAPI) Close() error { - r.cancel() - r.inflightChMtx.Lock() - close(r.inflightCh) - r.inflightChMtx.Unlock() - return nil -} - -func (r raftPipelineAPI) receiver() { - for af := range r.inflightCh { - msg, err := r.stream.Recv() - if err != nil { - af.err = err - } else { - af.response = *decodeAppendEntriesResponse(msg) - } - close(af.done) - r.doneCh <- af - } -} - -type appendFuture struct { - raft.AppendFuture - - start time.Time - request *raft.AppendEntriesRequest - response raft.AppendEntriesResponse - err error - done chan struct{} -} - -// Error blocks until the future arrives and then -// returns the error status of the future. -// This may be called any number of times - all -// calls will return the same value. -// Note that it is not OK to call this method -// twice concurrently on the same Future instance. -func (f *appendFuture) Error() error { - <-f.done - return f.err -} - -// Start returns the time that the append request was started. -// It is always OK to call this method. -func (f *appendFuture) Start() time.Time { - return f.start -} - -// Request holds the parameters of the AppendEntries call. -// It is always OK to call this method. -func (f *appendFuture) Request() *raft.AppendEntriesRequest { - return f.request -} - -// Response holds the results of the AppendEntries call. -// This method must only be called after the Error -// method returns, and will only be valid on success. -func (f *appendFuture) Response() *raft.AppendEntriesResponse { - return &f.response -} - -// EncodePeer is used to serialize a peer's address. -func (r raftAPI) EncodePeer(id raft.ServerID, addr raft.ServerAddress) []byte { - return []byte(addr) -} - -// DecodePeer is used to deserialize a peer's address. -func (r raftAPI) DecodePeer(p []byte) raft.ServerAddress { - return raft.ServerAddress(p) -} - -// SetHeartbeatHandler is used to setup a heartbeat handler -// as a fast-pass. This is to avoid head-of-line blocking from -// disk IO. If a Transport does not support this, it can simply -// ignore the call, and push the heartbeat onto the Consumer channel. -func (r raftAPI) SetHeartbeatHandler(cb func(rpc raft.RPC)) { - r.manager.heartbeatFuncMtx.Lock() - r.manager.heartbeatFunc = cb - r.manager.heartbeatFuncMtx.Unlock() -} - -func (r raftAPI) Close() error { - return r.manager.Close() -} - -func (r raftAPI) Connect(target raft.ServerAddress, t raft.Transport) { - _, _ = r.getPeer(target) -} - -func (r raftAPI) Disconnect(target raft.ServerAddress) { - r.manager.connectionsMtx.Lock() - c, ok := r.manager.connections[target] - if !ok { - delete(r.manager.connections, target) - } - r.manager.connectionsMtx.Unlock() - if ok { - c.mtx.Lock() - c.mtx.Unlock() - _ = c.clientConn.Close() - } -} - -func (r raftAPI) DisconnectAll() { - _ = r.manager.disconnectAll() -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/toproto.go b/vendor/github.com/Jille/raft-grpc-transport/toproto.go deleted file mode 100644 index 51ce1c7..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/toproto.go +++ /dev/null @@ -1,147 +0,0 @@ -package transport - -import ( - pb "github.com/Jille/raft-grpc-transport/proto" - "github.com/hashicorp/raft" - "google.golang.org/protobuf/types/known/timestamppb" -) - -func encodeAppendEntriesRequest(s *raft.AppendEntriesRequest) *pb.AppendEntriesRequest { - return &pb.AppendEntriesRequest{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - Leader: s.Leader, - PrevLogEntry: s.PrevLogEntry, - PrevLogTerm: s.PrevLogTerm, - Entries: encodeLogs(s.Entries), - LeaderCommitIndex: s.LeaderCommitIndex, - } -} - -func encodeRPCHeader(s raft.RPCHeader) *pb.RPCHeader { - return &pb.RPCHeader{ - ProtocolVersion: int64(s.ProtocolVersion), - Id: s.ID, - Addr: s.Addr, - } -} - -func encodeLogs(s []*raft.Log) []*pb.Log { - ret := make([]*pb.Log, len(s)) - for i, l := range s { - ret[i] = encodeLog(l) - } - return ret -} - -func encodeLog(s *raft.Log) *pb.Log { - return &pb.Log{ - Index: s.Index, - Term: s.Term, - Type: encodeLogType(s.Type), - Data: s.Data, - Extensions: s.Extensions, - AppendedAt: timestamppb.New(s.AppendedAt), - } -} - -func encodeLogType(s raft.LogType) pb.Log_LogType { - switch s { - case raft.LogCommand: - return pb.Log_LOG_COMMAND - case raft.LogNoop: - return pb.Log_LOG_NOOP - case raft.LogAddPeerDeprecated: - return pb.Log_LOG_ADD_PEER_DEPRECATED - case raft.LogRemovePeerDeprecated: - return pb.Log_LOG_REMOVE_PEER_DEPRECATED - case raft.LogBarrier: - return pb.Log_LOG_BARRIER - case raft.LogConfiguration: - return pb.Log_LOG_CONFIGURATION - default: - panic("invalid LogType") - } -} - -func encodeAppendEntriesResponse(s *raft.AppendEntriesResponse) *pb.AppendEntriesResponse { - return &pb.AppendEntriesResponse{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - LastLog: s.LastLog, - Success: s.Success, - NoRetryBackoff: s.NoRetryBackoff, - } -} - -func encodeRequestVoteRequest(s *raft.RequestVoteRequest) *pb.RequestVoteRequest { - return &pb.RequestVoteRequest{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - Candidate: s.Candidate, - LastLogIndex: s.LastLogIndex, - LastLogTerm: s.LastLogTerm, - LeadershipTransfer: s.LeadershipTransfer, - } -} - -func encodeRequestVoteResponse(s *raft.RequestVoteResponse) *pb.RequestVoteResponse { - return &pb.RequestVoteResponse{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - Peers: s.Peers, - Granted: s.Granted, - } -} - -func encodeInstallSnapshotRequest(s *raft.InstallSnapshotRequest) *pb.InstallSnapshotRequest { - return &pb.InstallSnapshotRequest{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - SnapshotVersion: int64(s.SnapshotVersion), - Term: s.Term, - Leader: s.Leader, - LastLogIndex: s.LastLogIndex, - LastLogTerm: s.LastLogTerm, - Peers: s.Peers, - Configuration: s.Configuration, - ConfigurationIndex: s.ConfigurationIndex, - Size: s.Size, - } -} - -func encodeInstallSnapshotResponse(s *raft.InstallSnapshotResponse) *pb.InstallSnapshotResponse { - return &pb.InstallSnapshotResponse{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - Success: s.Success, - } -} - -func encodeTimeoutNowRequest(s *raft.TimeoutNowRequest) *pb.TimeoutNowRequest { - return &pb.TimeoutNowRequest{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - } -} - -func encodeTimeoutNowResponse(s *raft.TimeoutNowResponse) *pb.TimeoutNowResponse { - return &pb.TimeoutNowResponse{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - } -} - -func encodeRequestPreVoteRequest(s *raft.RequestPreVoteRequest) *pb.RequestPreVoteRequest { - return &pb.RequestPreVoteRequest{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - LastLogIndex: s.LastLogIndex, - LastLogTerm: s.LastLogTerm, - } -} - -func encodeRequestPreVoteResponse(s *raft.RequestPreVoteResponse) *pb.RequestPreVoteResponse { - return &pb.RequestPreVoteResponse{ - RpcHeader: encodeRPCHeader(s.RPCHeader), - Term: s.Term, - Granted: s.Granted, - } -} diff --git a/vendor/github.com/Jille/raft-grpc-transport/transport.go b/vendor/github.com/Jille/raft-grpc-transport/transport.go deleted file mode 100644 index 3591cf7..0000000 --- a/vendor/github.com/Jille/raft-grpc-transport/transport.go +++ /dev/null @@ -1,97 +0,0 @@ -// Package transport provides a Transport for github.com/hashicorp/raft over gRPC. -package transport - -import ( - "sync" - "time" - - pb "github.com/Jille/raft-grpc-transport/proto" - "github.com/hashicorp/go-multierror" - "github.com/hashicorp/raft" - "github.com/pkg/errors" - "google.golang.org/grpc" -) - -var ( - errCloseErr = errors.New("error closing connections") -) - -type Manager struct { - localAddress raft.ServerAddress - dialOptions []grpc.DialOption - - rpcChan chan raft.RPC - heartbeatFunc func(raft.RPC) - heartbeatFuncMtx sync.Mutex - heartbeatTimeout time.Duration - - connectionsMtx sync.Mutex - connections map[raft.ServerAddress]*conn - - shutdown bool - shutdownCh chan struct{} - shutdownLock sync.Mutex -} - -// New creates both components of raft-grpc-transport: a gRPC service and a Raft Transport. -func New(localAddress raft.ServerAddress, dialOptions []grpc.DialOption, options ...Option) *Manager { - m := &Manager{ - localAddress: localAddress, - dialOptions: dialOptions, - - rpcChan: make(chan raft.RPC), - connections: map[raft.ServerAddress]*conn{}, - - shutdownCh: make(chan struct{}), - } - for _, opt := range options { - opt(m) - } - return m -} - -// Register the RaftTransport gRPC service on a gRPC server. -func (m *Manager) Register(s grpc.ServiceRegistrar) { - pb.RegisterRaftTransportServer(s, gRPCAPI{manager: m}) -} - -// Transport returns a raft.Transport that communicates over gRPC. -func (m *Manager) Transport() raft.Transport { - return raftAPI{m} -} - -func (m *Manager) Close() error { - m.shutdownLock.Lock() - defer m.shutdownLock.Unlock() - - if m.shutdown { - return nil - } - - close(m.shutdownCh) - m.shutdown = true - return m.disconnectAll() -} - -func (m *Manager) disconnectAll() error { - m.connectionsMtx.Lock() - defer m.connectionsMtx.Unlock() - - err := errCloseErr - for k, conn := range m.connections { - // Lock conn.mtx to ensure Dial() is complete - conn.mtx.Lock() - conn.mtx.Unlock() - closeErr := conn.clientConn.Close() - if closeErr != nil { - err = multierror.Append(err, closeErr) - } - delete(m.connections, k) - } - - if err != errCloseErr { - return err - } - - return nil -} diff --git a/vendor/modules.txt b/vendor/modules.txt index b6c7c3b..6b5b8b2 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -1,7 +1,5 @@ # github.com/Jille/raft-grpc-transport v1.6.1 ## explicit; go 1.13 -github.com/Jille/raft-grpc-transport -github.com/Jille/raft-grpc-transport/proto # github.com/armon/go-metrics v0.4.1 ## explicit; go 1.12 github.com/armon/go-metrics