proto

package
v0.0.0-...-3d1347b Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: May 5, 2023 License: BSD-2-Clause Imports: 13 Imported by: 0

Documentation

Index

Constants

View Source
const (
	RaftTransport_AppendEntriesPipeline_FullMethodName = "/transport.RaftTransport/AppendEntriesPipeline"
	RaftTransport_AppendEntries_FullMethodName         = "/transport.RaftTransport/AppendEntries"
	RaftTransport_RequestVote_FullMethodName           = "/transport.RaftTransport/RequestVote"
	RaftTransport_TimeoutNow_FullMethodName            = "/transport.RaftTransport/TimeoutNow"
	RaftTransport_InstallSnapshot_FullMethodName       = "/transport.RaftTransport/InstallSnapshot"
)

Variables

View Source
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,
	}
)

Enum value maps for Log_LogType.

View Source
var (
	ErrInvalidLength        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflow          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroup = fmt.Errorf("proto: unexpected end of group")
)
View Source
var File_transport_proto protoreflect.FileDescriptor
View Source
var RaftTransport_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "transport.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,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "AppendEntriesPipeline",
			Handler:       _RaftTransport_AppendEntriesPipeline_Handler,
			ServerStreams: true,
			ClientStreams: true,
		},
		{
			StreamName:    "InstallSnapshot",
			Handler:       _RaftTransport_InstallSnapshot_Handler,
			ClientStreams: true,
		},
	},
	Metadata: "transport.proto",
}

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)

Functions

func RegisterRaftTransportServer

func RegisterRaftTransportServer(s grpc.ServiceRegistrar, srv RaftTransportServer)

Types

type AppendEntriesRequest

type AppendEntriesRequest struct {
	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"`
	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"`
	// contains filtered or unexported fields
}

func (*AppendEntriesRequest) Descriptor deprecated

func (*AppendEntriesRequest) Descriptor() ([]byte, []int)

Deprecated: Use AppendEntriesRequest.ProtoReflect.Descriptor instead.

func (*AppendEntriesRequest) GetEntries

func (x *AppendEntriesRequest) GetEntries() []*Log

func (*AppendEntriesRequest) GetLeaderCommitIndex

func (x *AppendEntriesRequest) GetLeaderCommitIndex() uint64

func (*AppendEntriesRequest) GetPrevLogEntry

func (x *AppendEntriesRequest) GetPrevLogEntry() uint64

func (*AppendEntriesRequest) GetPrevLogTerm

func (x *AppendEntriesRequest) GetPrevLogTerm() uint64

func (*AppendEntriesRequest) GetRpcHeader

func (x *AppendEntriesRequest) GetRpcHeader() *RPCHeader

func (*AppendEntriesRequest) GetTerm

func (x *AppendEntriesRequest) GetTerm() uint64

func (*AppendEntriesRequest) MarshalToSizedBufferVT

func (m *AppendEntriesRequest) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*AppendEntriesRequest) MarshalToVT

func (m *AppendEntriesRequest) MarshalToVT(dAtA []byte) (int, error)

func (*AppendEntriesRequest) MarshalVT

func (m *AppendEntriesRequest) MarshalVT() (dAtA []byte, err error)

func (*AppendEntriesRequest) ProtoMessage

func (*AppendEntriesRequest) ProtoMessage()

func (*AppendEntriesRequest) ProtoReflect

func (x *AppendEntriesRequest) ProtoReflect() protoreflect.Message

func (*AppendEntriesRequest) Reset

func (x *AppendEntriesRequest) Reset()

func (*AppendEntriesRequest) SizeVT

func (m *AppendEntriesRequest) SizeVT() (n int)

func (*AppendEntriesRequest) String

func (x *AppendEntriesRequest) String() string

func (*AppendEntriesRequest) UnmarshalVT

func (m *AppendEntriesRequest) UnmarshalVT(dAtA []byte) error

type AppendEntriesResponse

type AppendEntriesResponse struct {
	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"`
	// contains filtered or unexported fields
}

func (*AppendEntriesResponse) Descriptor deprecated

func (*AppendEntriesResponse) Descriptor() ([]byte, []int)

Deprecated: Use AppendEntriesResponse.ProtoReflect.Descriptor instead.

func (*AppendEntriesResponse) GetLastLog

func (x *AppendEntriesResponse) GetLastLog() uint64

func (*AppendEntriesResponse) GetNoRetryBackoff

func (x *AppendEntriesResponse) GetNoRetryBackoff() bool

func (*AppendEntriesResponse) GetRpcHeader

func (x *AppendEntriesResponse) GetRpcHeader() *RPCHeader

func (*AppendEntriesResponse) GetSuccess

func (x *AppendEntriesResponse) GetSuccess() bool

func (*AppendEntriesResponse) GetTerm

func (x *AppendEntriesResponse) GetTerm() uint64

func (*AppendEntriesResponse) MarshalToSizedBufferVT

func (m *AppendEntriesResponse) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*AppendEntriesResponse) MarshalToVT

func (m *AppendEntriesResponse) MarshalToVT(dAtA []byte) (int, error)

func (*AppendEntriesResponse) MarshalVT

func (m *AppendEntriesResponse) MarshalVT() (dAtA []byte, err error)

func (*AppendEntriesResponse) ProtoMessage

func (*AppendEntriesResponse) ProtoMessage()

func (*AppendEntriesResponse) ProtoReflect

func (x *AppendEntriesResponse) ProtoReflect() protoreflect.Message

func (*AppendEntriesResponse) Reset

func (x *AppendEntriesResponse) Reset()

func (*AppendEntriesResponse) SizeVT

func (m *AppendEntriesResponse) SizeVT() (n int)

func (*AppendEntriesResponse) String

func (x *AppendEntriesResponse) String() string

func (*AppendEntriesResponse) UnmarshalVT

func (m *AppendEntriesResponse) UnmarshalVT(dAtA []byte) error

type InstallSnapshotRequest

type InstallSnapshotRequest struct {
	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"`
	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"`
	// contains filtered or unexported fields
}

The first InstallSnapshotRequest on the stream contains all the metadata. All further messages contain only data.

func (*InstallSnapshotRequest) Descriptor deprecated

func (*InstallSnapshotRequest) Descriptor() ([]byte, []int)

Deprecated: Use InstallSnapshotRequest.ProtoReflect.Descriptor instead.

func (*InstallSnapshotRequest) GetConfiguration

func (x *InstallSnapshotRequest) GetConfiguration() []byte

func (*InstallSnapshotRequest) GetConfigurationIndex

func (x *InstallSnapshotRequest) GetConfigurationIndex() uint64

func (*InstallSnapshotRequest) GetData

func (x *InstallSnapshotRequest) GetData() []byte

func (*InstallSnapshotRequest) GetLastLogIndex

func (x *InstallSnapshotRequest) GetLastLogIndex() uint64

func (*InstallSnapshotRequest) GetLastLogTerm

func (x *InstallSnapshotRequest) GetLastLogTerm() uint64

func (*InstallSnapshotRequest) GetLeader

func (x *InstallSnapshotRequest) GetLeader() []byte

func (*InstallSnapshotRequest) GetRpcHeader

func (x *InstallSnapshotRequest) GetRpcHeader() *RPCHeader

func (*InstallSnapshotRequest) GetSize

func (x *InstallSnapshotRequest) GetSize() int64

func (*InstallSnapshotRequest) GetSnapshotVersion

func (x *InstallSnapshotRequest) GetSnapshotVersion() int64

func (*InstallSnapshotRequest) GetTerm

func (x *InstallSnapshotRequest) GetTerm() uint64

func (*InstallSnapshotRequest) MarshalToSizedBufferVT

func (m *InstallSnapshotRequest) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*InstallSnapshotRequest) MarshalToVT

func (m *InstallSnapshotRequest) MarshalToVT(dAtA []byte) (int, error)

func (*InstallSnapshotRequest) MarshalVT

func (m *InstallSnapshotRequest) MarshalVT() (dAtA []byte, err error)

func (*InstallSnapshotRequest) ProtoMessage

func (*InstallSnapshotRequest) ProtoMessage()

func (*InstallSnapshotRequest) ProtoReflect

func (x *InstallSnapshotRequest) ProtoReflect() protoreflect.Message

func (*InstallSnapshotRequest) Reset

func (x *InstallSnapshotRequest) Reset()

func (*InstallSnapshotRequest) SizeVT

func (m *InstallSnapshotRequest) SizeVT() (n int)

func (*InstallSnapshotRequest) String

func (x *InstallSnapshotRequest) String() string

func (*InstallSnapshotRequest) UnmarshalVT

func (m *InstallSnapshotRequest) UnmarshalVT(dAtA []byte) error

type InstallSnapshotResponse

type InstallSnapshotResponse struct {
	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"`
	// contains filtered or unexported fields
}

func (*InstallSnapshotResponse) Descriptor deprecated

func (*InstallSnapshotResponse) Descriptor() ([]byte, []int)

Deprecated: Use InstallSnapshotResponse.ProtoReflect.Descriptor instead.

func (*InstallSnapshotResponse) GetRpcHeader

func (x *InstallSnapshotResponse) GetRpcHeader() *RPCHeader

func (*InstallSnapshotResponse) GetSuccess

func (x *InstallSnapshotResponse) GetSuccess() bool

func (*InstallSnapshotResponse) GetTerm

func (x *InstallSnapshotResponse) GetTerm() uint64

func (*InstallSnapshotResponse) MarshalToSizedBufferVT

func (m *InstallSnapshotResponse) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*InstallSnapshotResponse) MarshalToVT

func (m *InstallSnapshotResponse) MarshalToVT(dAtA []byte) (int, error)

func (*InstallSnapshotResponse) MarshalVT

func (m *InstallSnapshotResponse) MarshalVT() (dAtA []byte, err error)

func (*InstallSnapshotResponse) ProtoMessage

func (*InstallSnapshotResponse) ProtoMessage()

func (*InstallSnapshotResponse) ProtoReflect

func (x *InstallSnapshotResponse) ProtoReflect() protoreflect.Message

func (*InstallSnapshotResponse) Reset

func (x *InstallSnapshotResponse) Reset()

func (*InstallSnapshotResponse) SizeVT

func (m *InstallSnapshotResponse) SizeVT() (n int)

func (*InstallSnapshotResponse) String

func (x *InstallSnapshotResponse) String() string

func (*InstallSnapshotResponse) UnmarshalVT

func (m *InstallSnapshotResponse) UnmarshalVT(dAtA []byte) error

type Log

type Log struct {
	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=transport.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"`
	// contains filtered or unexported fields
}

func (*Log) Descriptor deprecated

func (*Log) Descriptor() ([]byte, []int)

Deprecated: Use Log.ProtoReflect.Descriptor instead.

func (*Log) GetAppendedAt

func (x *Log) GetAppendedAt() *timestamppb.Timestamp

func (*Log) GetData

func (x *Log) GetData() []byte

func (*Log) GetExtensions

func (x *Log) GetExtensions() []byte

func (*Log) GetIndex

func (x *Log) GetIndex() uint64

func (*Log) GetTerm

func (x *Log) GetTerm() uint64

func (*Log) GetType

func (x *Log) GetType() Log_LogType

func (*Log) MarshalToSizedBufferVT

func (m *Log) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*Log) MarshalToVT

func (m *Log) MarshalToVT(dAtA []byte) (int, error)

func (*Log) MarshalVT

func (m *Log) MarshalVT() (dAtA []byte, err error)

func (*Log) ProtoMessage

func (*Log) ProtoMessage()

func (*Log) ProtoReflect

func (x *Log) ProtoReflect() protoreflect.Message

func (*Log) Reset

func (x *Log) Reset()

func (*Log) SizeVT

func (m *Log) SizeVT() (n int)

func (*Log) String

func (x *Log) String() string

func (*Log) UnmarshalVT

func (m *Log) UnmarshalVT(dAtA []byte) error

type Log_LogType

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
)

func (Log_LogType) Descriptor

func (Log_LogType) Enum

func (x Log_LogType) Enum() *Log_LogType

func (Log_LogType) EnumDescriptor deprecated

func (Log_LogType) EnumDescriptor() ([]byte, []int)

Deprecated: Use Log_LogType.Descriptor instead.

func (Log_LogType) Number

func (x Log_LogType) Number() protoreflect.EnumNumber

func (Log_LogType) String

func (x Log_LogType) String() string

func (Log_LogType) Type

type RPCHeader

type RPCHeader struct {
	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"`
	// contains filtered or unexported fields
}

func (*RPCHeader) Descriptor deprecated

func (*RPCHeader) Descriptor() ([]byte, []int)

Deprecated: Use RPCHeader.ProtoReflect.Descriptor instead.

func (*RPCHeader) GetAddr

func (x *RPCHeader) GetAddr() []byte

func (*RPCHeader) GetId

func (x *RPCHeader) GetId() []byte

func (*RPCHeader) GetProtocolVersion

func (x *RPCHeader) GetProtocolVersion() int64

func (*RPCHeader) MarshalToSizedBufferVT

func (m *RPCHeader) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*RPCHeader) MarshalToVT

func (m *RPCHeader) MarshalToVT(dAtA []byte) (int, error)

func (*RPCHeader) MarshalVT

func (m *RPCHeader) MarshalVT() (dAtA []byte, err error)

func (*RPCHeader) ProtoMessage

func (*RPCHeader) ProtoMessage()

func (*RPCHeader) ProtoReflect

func (x *RPCHeader) ProtoReflect() protoreflect.Message

func (*RPCHeader) Reset

func (x *RPCHeader) Reset()

func (*RPCHeader) SizeVT

func (m *RPCHeader) SizeVT() (n int)

func (*RPCHeader) String

func (x *RPCHeader) String() string

func (*RPCHeader) UnmarshalVT

func (m *RPCHeader) UnmarshalVT(dAtA []byte) error

type RaftTransportClient

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)
}

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 RaftTransportServer

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
	// contains filtered or unexported methods
}

RaftTransportServer is the server API for RaftTransport service. All implementations must embed UnimplementedRaftTransportServer for forward compatibility

type RaftTransport_AppendEntriesPipelineClient

type RaftTransport_AppendEntriesPipelineClient interface {
	Send(*AppendEntriesRequest) error
	Recv() (*AppendEntriesResponse, error)
	grpc.ClientStream
}

type RaftTransport_AppendEntriesPipelineServer

type RaftTransport_AppendEntriesPipelineServer interface {
	Send(*AppendEntriesResponse) error
	Recv() (*AppendEntriesRequest, error)
	grpc.ServerStream
}

type RaftTransport_InstallSnapshotClient

type RaftTransport_InstallSnapshotClient interface {
	Send(*InstallSnapshotRequest) error
	CloseAndRecv() (*InstallSnapshotResponse, error)
	grpc.ClientStream
}

type RaftTransport_InstallSnapshotServer

type RaftTransport_InstallSnapshotServer interface {
	SendAndClose(*InstallSnapshotResponse) error
	Recv() (*InstallSnapshotRequest, error)
	grpc.ServerStream
}

type RequestVoteRequest

type RequestVoteRequest struct {
	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,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"`
	// contains filtered or unexported fields
}

func (*RequestVoteRequest) Descriptor deprecated

func (*RequestVoteRequest) Descriptor() ([]byte, []int)

Deprecated: Use RequestVoteRequest.ProtoReflect.Descriptor instead.

func (*RequestVoteRequest) GetLastLogIndex

func (x *RequestVoteRequest) GetLastLogIndex() uint64

func (*RequestVoteRequest) GetLastLogTerm

func (x *RequestVoteRequest) GetLastLogTerm() uint64

func (*RequestVoteRequest) GetLeadershipTransfer

func (x *RequestVoteRequest) GetLeadershipTransfer() bool

func (*RequestVoteRequest) GetRpcHeader

func (x *RequestVoteRequest) GetRpcHeader() *RPCHeader

func (*RequestVoteRequest) GetTerm

func (x *RequestVoteRequest) GetTerm() uint64

func (*RequestVoteRequest) MarshalToSizedBufferVT

func (m *RequestVoteRequest) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*RequestVoteRequest) MarshalToVT

func (m *RequestVoteRequest) MarshalToVT(dAtA []byte) (int, error)

func (*RequestVoteRequest) MarshalVT

func (m *RequestVoteRequest) MarshalVT() (dAtA []byte, err error)

func (*RequestVoteRequest) ProtoMessage

func (*RequestVoteRequest) ProtoMessage()

func (*RequestVoteRequest) ProtoReflect

func (x *RequestVoteRequest) ProtoReflect() protoreflect.Message

func (*RequestVoteRequest) Reset

func (x *RequestVoteRequest) Reset()

func (*RequestVoteRequest) SizeVT

func (m *RequestVoteRequest) SizeVT() (n int)

func (*RequestVoteRequest) String

func (x *RequestVoteRequest) String() string

func (*RequestVoteRequest) UnmarshalVT

func (m *RequestVoteRequest) UnmarshalVT(dAtA []byte) error

type RequestVoteResponse

type RequestVoteResponse struct {
	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"`
	// contains filtered or unexported fields
}

func (*RequestVoteResponse) Descriptor deprecated

func (*RequestVoteResponse) Descriptor() ([]byte, []int)

Deprecated: Use RequestVoteResponse.ProtoReflect.Descriptor instead.

func (*RequestVoteResponse) GetGranted

func (x *RequestVoteResponse) GetGranted() bool

func (*RequestVoteResponse) GetPeers

func (x *RequestVoteResponse) GetPeers() []byte

func (*RequestVoteResponse) GetRpcHeader

func (x *RequestVoteResponse) GetRpcHeader() *RPCHeader

func (*RequestVoteResponse) GetTerm

func (x *RequestVoteResponse) GetTerm() uint64

func (*RequestVoteResponse) MarshalToSizedBufferVT

func (m *RequestVoteResponse) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*RequestVoteResponse) MarshalToVT

func (m *RequestVoteResponse) MarshalToVT(dAtA []byte) (int, error)

func (*RequestVoteResponse) MarshalVT

func (m *RequestVoteResponse) MarshalVT() (dAtA []byte, err error)

func (*RequestVoteResponse) ProtoMessage

func (*RequestVoteResponse) ProtoMessage()

func (*RequestVoteResponse) ProtoReflect

func (x *RequestVoteResponse) ProtoReflect() protoreflect.Message

func (*RequestVoteResponse) Reset

func (x *RequestVoteResponse) Reset()

func (*RequestVoteResponse) SizeVT

func (m *RequestVoteResponse) SizeVT() (n int)

func (*RequestVoteResponse) String

func (x *RequestVoteResponse) String() string

func (*RequestVoteResponse) UnmarshalVT

func (m *RequestVoteResponse) UnmarshalVT(dAtA []byte) error

type TimeoutNowRequest

type TimeoutNowRequest struct {
	RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"`
	// contains filtered or unexported fields
}

func (*TimeoutNowRequest) Descriptor deprecated

func (*TimeoutNowRequest) Descriptor() ([]byte, []int)

Deprecated: Use TimeoutNowRequest.ProtoReflect.Descriptor instead.

func (*TimeoutNowRequest) GetRpcHeader

func (x *TimeoutNowRequest) GetRpcHeader() *RPCHeader

func (*TimeoutNowRequest) MarshalToSizedBufferVT

func (m *TimeoutNowRequest) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*TimeoutNowRequest) MarshalToVT

func (m *TimeoutNowRequest) MarshalToVT(dAtA []byte) (int, error)

func (*TimeoutNowRequest) MarshalVT

func (m *TimeoutNowRequest) MarshalVT() (dAtA []byte, err error)

func (*TimeoutNowRequest) ProtoMessage

func (*TimeoutNowRequest) ProtoMessage()

func (*TimeoutNowRequest) ProtoReflect

func (x *TimeoutNowRequest) ProtoReflect() protoreflect.Message

func (*TimeoutNowRequest) Reset

func (x *TimeoutNowRequest) Reset()

func (*TimeoutNowRequest) SizeVT

func (m *TimeoutNowRequest) SizeVT() (n int)

func (*TimeoutNowRequest) String

func (x *TimeoutNowRequest) String() string

func (*TimeoutNowRequest) UnmarshalVT

func (m *TimeoutNowRequest) UnmarshalVT(dAtA []byte) error

type TimeoutNowResponse

type TimeoutNowResponse struct {
	RpcHeader *RPCHeader `protobuf:"bytes,1,opt,name=rpc_header,json=rpcHeader,proto3" json:"rpc_header,omitempty"`
	// contains filtered or unexported fields
}

func (*TimeoutNowResponse) Descriptor deprecated

func (*TimeoutNowResponse) Descriptor() ([]byte, []int)

Deprecated: Use TimeoutNowResponse.ProtoReflect.Descriptor instead.

func (*TimeoutNowResponse) GetRpcHeader

func (x *TimeoutNowResponse) GetRpcHeader() *RPCHeader

func (*TimeoutNowResponse) MarshalToSizedBufferVT

func (m *TimeoutNowResponse) MarshalToSizedBufferVT(dAtA []byte) (int, error)

func (*TimeoutNowResponse) MarshalToVT

func (m *TimeoutNowResponse) MarshalToVT(dAtA []byte) (int, error)

func (*TimeoutNowResponse) MarshalVT

func (m *TimeoutNowResponse) MarshalVT() (dAtA []byte, err error)

func (*TimeoutNowResponse) ProtoMessage

func (*TimeoutNowResponse) ProtoMessage()

func (*TimeoutNowResponse) ProtoReflect

func (x *TimeoutNowResponse) ProtoReflect() protoreflect.Message

func (*TimeoutNowResponse) Reset

func (x *TimeoutNowResponse) Reset()

func (*TimeoutNowResponse) SizeVT

func (m *TimeoutNowResponse) SizeVT() (n int)

func (*TimeoutNowResponse) String

func (x *TimeoutNowResponse) String() string

func (*TimeoutNowResponse) UnmarshalVT

func (m *TimeoutNowResponse) UnmarshalVT(dAtA []byte) error

type UnimplementedRaftTransportServer

type UnimplementedRaftTransportServer struct {
}

UnimplementedRaftTransportServer must be embedded to have forward compatible implementations.

func (UnimplementedRaftTransportServer) AppendEntries

func (UnimplementedRaftTransportServer) AppendEntriesPipeline

func (UnimplementedRaftTransportServer) InstallSnapshot

func (UnimplementedRaftTransportServer) RequestVote

func (UnimplementedRaftTransportServer) TimeoutNow

type UnsafeRaftTransportServer

type UnsafeRaftTransportServer interface {
	// contains filtered or unexported methods
}

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.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL