v1

package
v0.0.42 Latest Latest
Warning

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

Go to latest
Published: Sep 21, 2023 License: Apache-2.0 Imports: 19 Imported by: 0

Documentation

Overview

Package v1 is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

This section is empty.

Variables

View Source
var (
	RaftServer_Suffrage_name = map[int32]string{
		0: "Voter",
		1: "Nonvoter",
		2: "Staging",
	}
	RaftServer_Suffrage_value = map[string]int32{
		"Voter":    0,
		"Nonvoter": 1,
		"Staging":  2,
	}
)

Enum value maps for RaftServer_Suffrage.

View Source
var (
	RaftLog_Type_name = map[int32]string{
		0: "Command",
		1: "Noop",
		2: "AddPeerDeprecated",
		3: "RemovePeerDeprecated",
		4: "Barrier",
		5: "Configuration",
	}
	RaftLog_Type_value = map[string]int32{
		"Command":              0,
		"Noop":                 1,
		"AddPeerDeprecated":    2,
		"RemovePeerDeprecated": 3,
		"Barrier":              4,
		"Configuration":        5,
	}
)

Enum value maps for RaftLog_Type.

View Source
var (
	InstallSnapshotRequest_Version_name = map[int32]string{
		0: "Min",
		1: "Max",
	}
	InstallSnapshotRequest_Version_value = map[string]int32{
		"Min": 0,
		"Max": 1,
	}
)

Enum value maps for InstallSnapshotRequest_Version.

View Source
var (
	Header_Version_name = map[int32]string{
		0: "Min",
		1: "Max",
	}
	Header_Version_value = map[string]int32{
		"Min": 0,
		"Max": 1,
	}
)

Enum value maps for Header_Version.

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_vince_raft_v1_raft_proto protoreflect.FileDescriptor
View Source
var Transport_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "v1.Transport",
	HandlerType: (*TransportServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "AppendEntries",
			Handler:    _Transport_AppendEntries_Handler,
		},
		{
			MethodName: "RequestVote",
			Handler:    _Transport_RequestVote_Handler,
		},
		{
			MethodName: "TimeoutNow",
			Handler:    _Transport_TimeoutNow_Handler,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "AppendEntriesPipeline",
			Handler:       _Transport_AppendEntriesPipeline_Handler,
			ServerStreams: true,
			ClientStreams: true,
		},
		{
			StreamName:    "InstallSnapshot",
			Handler:       _Transport_InstallSnapshot_Handler,
			ClientStreams: true,
		},
	},
	Metadata: "vince/raft/v1/raft.proto",
}

Transport_ServiceDesc is the grpc.ServiceDesc for Transport service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

Functions

func RegisterTransportHandler added in v0.0.31

func RegisterTransportHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error

RegisterTransportHandler registers the http handlers for service Transport to "mux". The handlers forward requests to the grpc endpoint over "conn".

func RegisterTransportHandlerClient added in v0.0.31

func RegisterTransportHandlerClient(ctx context.Context, mux *runtime.ServeMux, client TransportClient) error

RegisterTransportHandlerClient registers the http handlers for service Transport to "mux". The handlers forward requests to the grpc endpoint over the given implementation of "TransportClient". Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "TransportClient" doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in "TransportClient" to call the correct interceptors.

func RegisterTransportHandlerFromEndpoint added in v0.0.31

func RegisterTransportHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error)

RegisterTransportHandlerFromEndpoint is same as RegisterTransportHandler but automatically dials to "endpoint" and closes the connection when "ctx" gets done.

func RegisterTransportHandlerServer added in v0.0.31

func RegisterTransportHandlerServer(ctx context.Context, mux *runtime.ServeMux, server TransportServer) error

RegisterTransportHandlerServer registers the http handlers for service Transport to "mux". UnaryRPC :call TransportServer directly. StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterTransportHandlerFromEndpoint instead.

func RegisterTransportServer added in v0.0.31

func RegisterTransportServer(s grpc.ServiceRegistrar, srv TransportServer)

Types

type AppendEntriesRequest added in v0.0.31

type AppendEntriesRequest struct {
	Header            *Header    `protobuf:"bytes,1,opt,name=header,proto3" json:"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           []*RaftLog `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 added in v0.0.31

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

Deprecated: Use AppendEntriesRequest.ProtoReflect.Descriptor instead.

func (*AppendEntriesRequest) GetEntries added in v0.0.31

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

func (*AppendEntriesRequest) GetHeader added in v0.0.31

func (x *AppendEntriesRequest) GetHeader() *Header

func (*AppendEntriesRequest) GetLeaderCommitIndex added in v0.0.31

func (x *AppendEntriesRequest) GetLeaderCommitIndex() uint64

func (*AppendEntriesRequest) GetPrevLogEntry added in v0.0.31

func (x *AppendEntriesRequest) GetPrevLogEntry() uint64

func (*AppendEntriesRequest) GetPrevLogTerm added in v0.0.31

func (x *AppendEntriesRequest) GetPrevLogTerm() uint64

func (*AppendEntriesRequest) GetTerm added in v0.0.31

func (x *AppendEntriesRequest) GetTerm() uint64

func (*AppendEntriesRequest) MarshalToSizedBufferVT added in v0.0.31

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

func (*AppendEntriesRequest) MarshalToVT added in v0.0.31

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

func (*AppendEntriesRequest) MarshalVT added in v0.0.31

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

func (*AppendEntriesRequest) ProtoMessage added in v0.0.31

func (*AppendEntriesRequest) ProtoMessage()

func (*AppendEntriesRequest) ProtoReflect added in v0.0.31

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

func (*AppendEntriesRequest) Reset added in v0.0.31

func (x *AppendEntriesRequest) Reset()

func (*AppendEntriesRequest) SizeVT added in v0.0.31

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

func (*AppendEntriesRequest) String added in v0.0.31

func (x *AppendEntriesRequest) String() string

func (*AppendEntriesRequest) UnmarshalVT added in v0.0.31

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

type AppendEntriesResponse added in v0.0.31

type AppendEntriesResponse struct {
	Header         *Header `protobuf:"bytes,1,opt,name=header,proto3" json:"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 added in v0.0.31

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

Deprecated: Use AppendEntriesResponse.ProtoReflect.Descriptor instead.

func (*AppendEntriesResponse) GetHeader added in v0.0.31

func (x *AppendEntriesResponse) GetHeader() *Header

func (*AppendEntriesResponse) GetLastLog added in v0.0.31

func (x *AppendEntriesResponse) GetLastLog() uint64

func (*AppendEntriesResponse) GetNoRetryBackoff added in v0.0.31

func (x *AppendEntriesResponse) GetNoRetryBackoff() bool

func (*AppendEntriesResponse) GetSuccess added in v0.0.31

func (x *AppendEntriesResponse) GetSuccess() bool

func (*AppendEntriesResponse) GetTerm added in v0.0.31

func (x *AppendEntriesResponse) GetTerm() uint64

func (*AppendEntriesResponse) MarshalToSizedBufferVT added in v0.0.31

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

func (*AppendEntriesResponse) MarshalToVT added in v0.0.31

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

func (*AppendEntriesResponse) MarshalVT added in v0.0.31

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

func (*AppendEntriesResponse) ProtoMessage added in v0.0.31

func (*AppendEntriesResponse) ProtoMessage()

func (*AppendEntriesResponse) ProtoReflect added in v0.0.31

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

func (*AppendEntriesResponse) Reset added in v0.0.31

func (x *AppendEntriesResponse) Reset()

func (*AppendEntriesResponse) SizeVT added in v0.0.31

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

func (*AppendEntriesResponse) String added in v0.0.31

func (x *AppendEntriesResponse) String() string

func (*AppendEntriesResponse) UnmarshalVT added in v0.0.31

func (m *AppendEntriesResponse) UnmarshalVT(dAtA []byte) error
type Header struct {
	Version Header_Version `protobuf:"varint,1,opt,name=version,proto3,enum=v1.Header_Version" json:"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 (*Header) Descriptor deprecated added in v0.0.31

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

Deprecated: Use Header.ProtoReflect.Descriptor instead.

func (*Header) GetAddr added in v0.0.31

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

func (*Header) GetId added in v0.0.31

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

func (*Header) GetVersion added in v0.0.31

func (x *Header) GetVersion() Header_Version

func (*Header) MarshalToSizedBufferVT added in v0.0.31

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

func (*Header) MarshalToVT added in v0.0.31

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

func (*Header) MarshalVT added in v0.0.31

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

func (*Header) ProtoMessage added in v0.0.31

func (*Header) ProtoMessage()

func (*Header) ProtoReflect added in v0.0.31

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

func (*Header) Reset added in v0.0.31

func (x *Header) Reset()

func (*Header) SizeVT added in v0.0.31

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

func (*Header) String added in v0.0.31

func (x *Header) String() string

func (*Header) UnmarshalVT added in v0.0.31

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

type Header_Version added in v0.0.31

type Header_Version int32
const (
	Header_Min Header_Version = 0
	Header_Max Header_Version = 1
)

func (Header_Version) Descriptor added in v0.0.31

func (Header_Version) Enum added in v0.0.31

func (x Header_Version) Enum() *Header_Version

func (Header_Version) EnumDescriptor deprecated added in v0.0.31

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

Deprecated: Use Header_Version.Descriptor instead.

func (Header_Version) Number added in v0.0.31

func (Header_Version) String added in v0.0.31

func (x Header_Version) String() string

func (Header_Version) Type added in v0.0.31

type InstallSnapshotRequest added in v0.0.31

type InstallSnapshotRequest struct {
	Header             *Header                        `protobuf:"bytes,1,opt,name=header,proto3" json:"header,omitempty"`
	SnapshotVersion    InstallSnapshotRequest_Version `` /* 146-byte string literal not displayed */
	Term               uint64                         `protobuf:"varint,3,opt,name=term,proto3" json:"term,omitempty"`
	Leader             []byte                         `protobuf:"bytes,4,opt,name=leader,proto3" json:"leader,omitempty"`
	LastLogIndex       uint64                         `protobuf:"varint,5,opt,name=last_log_index,json=lastLogIndex,proto3" json:"last_log_index,omitempty"`
	LastLogTerm        uint64                         `protobuf:"varint,6,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
}

func (*InstallSnapshotRequest) Descriptor deprecated added in v0.0.31

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

Deprecated: Use InstallSnapshotRequest.ProtoReflect.Descriptor instead.

func (*InstallSnapshotRequest) GetConfiguration added in v0.0.31

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

func (*InstallSnapshotRequest) GetConfigurationIndex added in v0.0.31

func (x *InstallSnapshotRequest) GetConfigurationIndex() uint64

func (*InstallSnapshotRequest) GetData added in v0.0.31

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

func (*InstallSnapshotRequest) GetHeader added in v0.0.31

func (x *InstallSnapshotRequest) GetHeader() *Header

func (*InstallSnapshotRequest) GetLastLogIndex added in v0.0.31

func (x *InstallSnapshotRequest) GetLastLogIndex() uint64

func (*InstallSnapshotRequest) GetLastLogTerm added in v0.0.31

func (x *InstallSnapshotRequest) GetLastLogTerm() uint64

func (*InstallSnapshotRequest) GetLeader added in v0.0.31

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

func (*InstallSnapshotRequest) GetSize added in v0.0.31

func (x *InstallSnapshotRequest) GetSize() int64

func (*InstallSnapshotRequest) GetSnapshotVersion added in v0.0.31

func (*InstallSnapshotRequest) GetTerm added in v0.0.31

func (x *InstallSnapshotRequest) GetTerm() uint64

func (*InstallSnapshotRequest) MarshalToSizedBufferVT added in v0.0.31

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

func (*InstallSnapshotRequest) MarshalToVT added in v0.0.31

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

func (*InstallSnapshotRequest) MarshalVT added in v0.0.31

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

func (*InstallSnapshotRequest) ProtoMessage added in v0.0.31

func (*InstallSnapshotRequest) ProtoMessage()

func (*InstallSnapshotRequest) ProtoReflect added in v0.0.31

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

func (*InstallSnapshotRequest) Reset added in v0.0.31

func (x *InstallSnapshotRequest) Reset()

func (*InstallSnapshotRequest) SizeVT added in v0.0.31

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

func (*InstallSnapshotRequest) String added in v0.0.31

func (x *InstallSnapshotRequest) String() string

func (*InstallSnapshotRequest) UnmarshalVT added in v0.0.31

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

type InstallSnapshotRequest_Version added in v0.0.31

type InstallSnapshotRequest_Version int32
const (
	InstallSnapshotRequest_Min InstallSnapshotRequest_Version = 0
	InstallSnapshotRequest_Max InstallSnapshotRequest_Version = 1
)

func (InstallSnapshotRequest_Version) Descriptor added in v0.0.31

func (InstallSnapshotRequest_Version) Enum added in v0.0.31

func (InstallSnapshotRequest_Version) EnumDescriptor deprecated added in v0.0.31

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

Deprecated: Use InstallSnapshotRequest_Version.Descriptor instead.

func (InstallSnapshotRequest_Version) Number added in v0.0.31

func (InstallSnapshotRequest_Version) String added in v0.0.31

func (InstallSnapshotRequest_Version) Type added in v0.0.31

type InstallSnapshotResponse added in v0.0.31

type InstallSnapshotResponse struct {
	Header  *Header `protobuf:"bytes,1,opt,name=header,proto3" json:"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 added in v0.0.31

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

Deprecated: Use InstallSnapshotResponse.ProtoReflect.Descriptor instead.

func (*InstallSnapshotResponse) GetHeader added in v0.0.31

func (x *InstallSnapshotResponse) GetHeader() *Header

func (*InstallSnapshotResponse) GetSuccess added in v0.0.31

func (x *InstallSnapshotResponse) GetSuccess() bool

func (*InstallSnapshotResponse) GetTerm added in v0.0.31

func (x *InstallSnapshotResponse) GetTerm() uint64

func (*InstallSnapshotResponse) MarshalToSizedBufferVT added in v0.0.31

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

func (*InstallSnapshotResponse) MarshalToVT added in v0.0.31

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

func (*InstallSnapshotResponse) MarshalVT added in v0.0.31

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

func (*InstallSnapshotResponse) ProtoMessage added in v0.0.31

func (*InstallSnapshotResponse) ProtoMessage()

func (*InstallSnapshotResponse) ProtoReflect added in v0.0.31

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

func (*InstallSnapshotResponse) Reset added in v0.0.31

func (x *InstallSnapshotResponse) Reset()

func (*InstallSnapshotResponse) SizeVT added in v0.0.31

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

func (*InstallSnapshotResponse) String added in v0.0.31

func (x *InstallSnapshotResponse) String() string

func (*InstallSnapshotResponse) UnmarshalVT added in v0.0.31

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

type RaftConfig added in v0.0.31

type RaftConfig struct {
	Servers []*RaftServer `protobuf:"bytes,1,rep,name=servers,proto3" json:"servers,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftConfig) Descriptor deprecated added in v0.0.31

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

Deprecated: Use RaftConfig.ProtoReflect.Descriptor instead.

func (*RaftConfig) GetServers added in v0.0.31

func (x *RaftConfig) GetServers() []*RaftServer

func (*RaftConfig) MarshalToSizedBufferVT added in v0.0.31

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

func (*RaftConfig) MarshalToVT added in v0.0.31

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

func (*RaftConfig) MarshalVT added in v0.0.31

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

func (*RaftConfig) ProtoMessage added in v0.0.31

func (*RaftConfig) ProtoMessage()

func (*RaftConfig) ProtoReflect added in v0.0.31

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

func (*RaftConfig) Reset added in v0.0.31

func (x *RaftConfig) Reset()

func (*RaftConfig) SizeVT added in v0.0.31

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

func (*RaftConfig) String added in v0.0.31

func (x *RaftConfig) String() string

func (*RaftConfig) UnmarshalVT added in v0.0.31

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

type RaftEntry added in v0.0.31

type RaftEntry struct {
	Key     []byte               `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	Value   []byte               `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	Expires *durationpb.Duration `protobuf:"bytes,3,opt,name=expires,proto3" json:"expires,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftEntry) Descriptor deprecated added in v0.0.31

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

Deprecated: Use RaftEntry.ProtoReflect.Descriptor instead.

func (*RaftEntry) GetExpires added in v0.0.31

func (x *RaftEntry) GetExpires() *durationpb.Duration

func (*RaftEntry) GetKey added in v0.0.31

func (x *RaftEntry) GetKey() []byte

func (*RaftEntry) GetValue added in v0.0.31

func (x *RaftEntry) GetValue() []byte

func (*RaftEntry) MarshalToSizedBufferVT added in v0.0.31

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

func (*RaftEntry) MarshalToVT added in v0.0.31

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

func (*RaftEntry) MarshalVT added in v0.0.31

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

func (*RaftEntry) ProtoMessage added in v0.0.31

func (*RaftEntry) ProtoMessage()

func (*RaftEntry) ProtoReflect added in v0.0.31

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

func (*RaftEntry) Reset added in v0.0.31

func (x *RaftEntry) Reset()

func (*RaftEntry) SizeVT added in v0.0.31

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

func (*RaftEntry) String added in v0.0.31

func (x *RaftEntry) String() string

func (*RaftEntry) UnmarshalVT added in v0.0.31

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

type RaftLog added in v0.0.31

type RaftLog 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       RaftLog_Type           `protobuf:"varint,3,opt,name=type,proto3,enum=v1.RaftLog_Type" 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 (*RaftLog) Descriptor deprecated added in v0.0.31

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

Deprecated: Use RaftLog.ProtoReflect.Descriptor instead.

func (*RaftLog) GetAppendedAt added in v0.0.31

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

func (*RaftLog) GetData added in v0.0.31

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

func (*RaftLog) GetExtensions added in v0.0.31

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

func (*RaftLog) GetIndex added in v0.0.31

func (x *RaftLog) GetIndex() uint64

func (*RaftLog) GetTerm added in v0.0.31

func (x *RaftLog) GetTerm() uint64

func (*RaftLog) GetType added in v0.0.31

func (x *RaftLog) GetType() RaftLog_Type

func (*RaftLog) MarshalToSizedBufferVT added in v0.0.31

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

func (*RaftLog) MarshalToVT added in v0.0.31

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

func (*RaftLog) MarshalVT added in v0.0.31

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

func (*RaftLog) ProtoMessage added in v0.0.31

func (*RaftLog) ProtoMessage()

func (*RaftLog) ProtoReflect added in v0.0.31

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

func (*RaftLog) Reset added in v0.0.31

func (x *RaftLog) Reset()

func (*RaftLog) SizeVT added in v0.0.31

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

func (*RaftLog) String added in v0.0.31

func (x *RaftLog) String() string

func (*RaftLog) UnmarshalVT added in v0.0.31

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

type RaftLog_Type added in v0.0.31

type RaftLog_Type int32
const (
	RaftLog_Command              RaftLog_Type = 0
	RaftLog_Noop                 RaftLog_Type = 1
	RaftLog_AddPeerDeprecated    RaftLog_Type = 2
	RaftLog_RemovePeerDeprecated RaftLog_Type = 3
	RaftLog_Barrier              RaftLog_Type = 4
	RaftLog_Configuration        RaftLog_Type = 5
)

func (RaftLog_Type) Descriptor added in v0.0.31

func (RaftLog_Type) Enum added in v0.0.31

func (x RaftLog_Type) Enum() *RaftLog_Type

func (RaftLog_Type) EnumDescriptor deprecated added in v0.0.31

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

Deprecated: Use RaftLog_Type.Descriptor instead.

func (RaftLog_Type) Number added in v0.0.31

func (RaftLog_Type) String added in v0.0.31

func (x RaftLog_Type) String() string

func (RaftLog_Type) Type added in v0.0.31

type RaftServer added in v0.0.31

type RaftServer struct {
	Suffrage RaftServer_Suffrage `protobuf:"varint,1,opt,name=suffrage,proto3,enum=v1.RaftServer_Suffrage" json:"suffrage,omitempty"`
	Id       string              `protobuf:"bytes,2,opt,name=id,proto3" json:"id,omitempty"`
	Address  string              `protobuf:"bytes,3,opt,name=address,proto3" json:"address,omitempty"`
	Token    string              `protobuf:"bytes,4,opt,name=token,proto3" json:"token,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftServer) Descriptor deprecated added in v0.0.31

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

Deprecated: Use RaftServer.ProtoReflect.Descriptor instead.

func (*RaftServer) GetAddress added in v0.0.31

func (x *RaftServer) GetAddress() string

func (*RaftServer) GetId added in v0.0.31

func (x *RaftServer) GetId() string

func (*RaftServer) GetSuffrage added in v0.0.31

func (x *RaftServer) GetSuffrage() RaftServer_Suffrage

func (*RaftServer) GetToken added in v0.0.31

func (x *RaftServer) GetToken() string

func (*RaftServer) MarshalToSizedBufferVT added in v0.0.31

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

func (*RaftServer) MarshalToVT added in v0.0.31

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

func (*RaftServer) MarshalVT added in v0.0.31

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

func (*RaftServer) ProtoMessage added in v0.0.31

func (*RaftServer) ProtoMessage()

func (*RaftServer) ProtoReflect added in v0.0.31

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

func (*RaftServer) Reset added in v0.0.31

func (x *RaftServer) Reset()

func (*RaftServer) SizeVT added in v0.0.31

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

func (*RaftServer) String added in v0.0.31

func (x *RaftServer) String() string

func (*RaftServer) UnmarshalVT added in v0.0.31

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

type RaftServer_Suffrage added in v0.0.31

type RaftServer_Suffrage int32
const (
	RaftServer_Voter    RaftServer_Suffrage = 0
	RaftServer_Nonvoter RaftServer_Suffrage = 1
	RaftServer_Staging  RaftServer_Suffrage = 2
)

func (RaftServer_Suffrage) Descriptor added in v0.0.31

func (RaftServer_Suffrage) Enum added in v0.0.31

func (RaftServer_Suffrage) EnumDescriptor deprecated added in v0.0.31

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

Deprecated: Use RaftServer_Suffrage.Descriptor instead.

func (RaftServer_Suffrage) Number added in v0.0.31

func (RaftServer_Suffrage) String added in v0.0.31

func (x RaftServer_Suffrage) String() string

func (RaftServer_Suffrage) Type added in v0.0.31

type RequestVoteRequest added in v0.0.31

type RequestVoteRequest struct {
	Header             *Header `protobuf:"bytes,1,opt,name=header,proto3" json:"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"`
	LeadershipTransfer bool    `protobuf:"varint,5,opt,name=leadership_transfer,json=leadershipTransfer,proto3" json:"leadership_transfer,omitempty"`
	// contains filtered or unexported fields
}

func (*RequestVoteRequest) Descriptor deprecated added in v0.0.31

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

Deprecated: Use RequestVoteRequest.ProtoReflect.Descriptor instead.

func (*RequestVoteRequest) GetHeader added in v0.0.31

func (x *RequestVoteRequest) GetHeader() *Header

func (*RequestVoteRequest) GetLastLogIndex added in v0.0.31

func (x *RequestVoteRequest) GetLastLogIndex() uint64

func (*RequestVoteRequest) GetLastLogTerm added in v0.0.31

func (x *RequestVoteRequest) GetLastLogTerm() uint64

func (*RequestVoteRequest) GetLeadershipTransfer added in v0.0.31

func (x *RequestVoteRequest) GetLeadershipTransfer() bool

func (*RequestVoteRequest) GetTerm added in v0.0.31

func (x *RequestVoteRequest) GetTerm() uint64

func (*RequestVoteRequest) MarshalToSizedBufferVT added in v0.0.31

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

func (*RequestVoteRequest) MarshalToVT added in v0.0.31

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

func (*RequestVoteRequest) MarshalVT added in v0.0.31

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

func (*RequestVoteRequest) ProtoMessage added in v0.0.31

func (*RequestVoteRequest) ProtoMessage()

func (*RequestVoteRequest) ProtoReflect added in v0.0.31

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

func (*RequestVoteRequest) Reset added in v0.0.31

func (x *RequestVoteRequest) Reset()

func (*RequestVoteRequest) SizeVT added in v0.0.31

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

func (*RequestVoteRequest) String added in v0.0.31

func (x *RequestVoteRequest) String() string

func (*RequestVoteRequest) UnmarshalVT added in v0.0.31

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

type RequestVoteResponse added in v0.0.31

type RequestVoteResponse struct {
	Header  *Header `protobuf:"bytes,1,opt,name=header,proto3" json:"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"`
	// contains filtered or unexported fields
}

func (*RequestVoteResponse) Descriptor deprecated added in v0.0.31

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

Deprecated: Use RequestVoteResponse.ProtoReflect.Descriptor instead.

func (*RequestVoteResponse) GetGranted added in v0.0.31

func (x *RequestVoteResponse) GetGranted() bool

func (*RequestVoteResponse) GetHeader added in v0.0.31

func (x *RequestVoteResponse) GetHeader() *Header

func (*RequestVoteResponse) GetTerm added in v0.0.31

func (x *RequestVoteResponse) GetTerm() uint64

func (*RequestVoteResponse) MarshalToSizedBufferVT added in v0.0.31

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

func (*RequestVoteResponse) MarshalToVT added in v0.0.31

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

func (*RequestVoteResponse) MarshalVT added in v0.0.31

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

func (*RequestVoteResponse) ProtoMessage added in v0.0.31

func (*RequestVoteResponse) ProtoMessage()

func (*RequestVoteResponse) ProtoReflect added in v0.0.31

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

func (*RequestVoteResponse) Reset added in v0.0.31

func (x *RequestVoteResponse) Reset()

func (*RequestVoteResponse) SizeVT added in v0.0.31

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

func (*RequestVoteResponse) String added in v0.0.31

func (x *RequestVoteResponse) String() string

func (*RequestVoteResponse) UnmarshalVT added in v0.0.31

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

type TimeoutNowRequest added in v0.0.31

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

func (*TimeoutNowRequest) Descriptor deprecated added in v0.0.31

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

Deprecated: Use TimeoutNowRequest.ProtoReflect.Descriptor instead.

func (*TimeoutNowRequest) GetHeader added in v0.0.31

func (x *TimeoutNowRequest) GetHeader() *Header

func (*TimeoutNowRequest) MarshalToSizedBufferVT added in v0.0.31

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

func (*TimeoutNowRequest) MarshalToVT added in v0.0.31

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

func (*TimeoutNowRequest) MarshalVT added in v0.0.31

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

func (*TimeoutNowRequest) ProtoMessage added in v0.0.31

func (*TimeoutNowRequest) ProtoMessage()

func (*TimeoutNowRequest) ProtoReflect added in v0.0.31

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

func (*TimeoutNowRequest) Reset added in v0.0.31

func (x *TimeoutNowRequest) Reset()

func (*TimeoutNowRequest) SizeVT added in v0.0.31

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

func (*TimeoutNowRequest) String added in v0.0.31

func (x *TimeoutNowRequest) String() string

func (*TimeoutNowRequest) UnmarshalVT added in v0.0.31

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

type TimeoutNowResponse added in v0.0.31

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

func (*TimeoutNowResponse) Descriptor deprecated added in v0.0.31

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

Deprecated: Use TimeoutNowResponse.ProtoReflect.Descriptor instead.

func (*TimeoutNowResponse) GetHeader added in v0.0.31

func (x *TimeoutNowResponse) GetHeader() *Header

func (*TimeoutNowResponse) MarshalToSizedBufferVT added in v0.0.31

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

func (*TimeoutNowResponse) MarshalToVT added in v0.0.31

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

func (*TimeoutNowResponse) MarshalVT added in v0.0.31

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

func (*TimeoutNowResponse) ProtoMessage added in v0.0.31

func (*TimeoutNowResponse) ProtoMessage()

func (*TimeoutNowResponse) ProtoReflect added in v0.0.31

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

func (*TimeoutNowResponse) Reset added in v0.0.31

func (x *TimeoutNowResponse) Reset()

func (*TimeoutNowResponse) SizeVT added in v0.0.31

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

func (*TimeoutNowResponse) String added in v0.0.31

func (x *TimeoutNowResponse) String() string

func (*TimeoutNowResponse) UnmarshalVT added in v0.0.31

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

type TransportClient added in v0.0.31

type TransportClient interface {
	AppendEntriesPipeline(ctx context.Context, opts ...grpc.CallOption) (Transport_AppendEntriesPipelineClient, error)
	AppendEntries(ctx context.Context, in *AppendEntriesRequest, opts ...grpc.CallOption) (*AppendEntriesResponse, error)
	RequestVote(ctx context.Context, in *RequestVoteRequest, opts ...grpc.CallOption) (*RequestVoteResponse, error)
	TimeoutNow(ctx context.Context, in *TimeoutNowRequest, opts ...grpc.CallOption) (*TimeoutNowResponse, error)
	InstallSnapshot(ctx context.Context, opts ...grpc.CallOption) (Transport_InstallSnapshotClient, error)
}

TransportClient is the client API for Transport 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.

func NewTransportClient added in v0.0.31

func NewTransportClient(cc grpc.ClientConnInterface) TransportClient

type TransportServer added in v0.0.31

type TransportServer interface {
	AppendEntriesPipeline(Transport_AppendEntriesPipelineServer) error
	AppendEntries(context.Context, *AppendEntriesRequest) (*AppendEntriesResponse, error)
	RequestVote(context.Context, *RequestVoteRequest) (*RequestVoteResponse, error)
	TimeoutNow(context.Context, *TimeoutNowRequest) (*TimeoutNowResponse, error)
	InstallSnapshot(Transport_InstallSnapshotServer) error
	// contains filtered or unexported methods
}

TransportServer is the server API for Transport service. All implementations must embed UnimplementedTransportServer for forward compatibility

type Transport_AppendEntriesPipelineClient added in v0.0.31

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

type Transport_AppendEntriesPipelineServer added in v0.0.31

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

type Transport_InstallSnapshotClient added in v0.0.31

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

type Transport_InstallSnapshotServer added in v0.0.31

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

type UnimplementedTransportServer added in v0.0.31

type UnimplementedTransportServer struct {
}

UnimplementedTransportServer must be embedded to have forward compatible implementations.

func (UnimplementedTransportServer) AppendEntries added in v0.0.31

func (UnimplementedTransportServer) AppendEntriesPipeline added in v0.0.31

func (UnimplementedTransportServer) InstallSnapshot added in v0.0.31

func (UnimplementedTransportServer) RequestVote added in v0.0.31

func (UnimplementedTransportServer) TimeoutNow added in v0.0.31

type UnsafeTransportServer added in v0.0.31

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

UnsafeTransportServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to TransportServer will result in compilation errors.

Jump to

Keyboard shortcuts

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