ratis

package
v0.0.0-...-06a9ffa Latest Latest
Warning

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

Go to latest
Published: Sep 2, 2022 License: Apache-2.0 Imports: 9 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	InstallSnapshotResult_name = map[int32]string{
		0: "SUCCESS",
		1: "NOT_LEADER",
		2: "IN_PROGRESS",
		3: "ALREADY_INSTALLED",
		4: "CONF_MISMATCH",
	}
	InstallSnapshotResult_value = map[string]int32{
		"SUCCESS":           0,
		"NOT_LEADER":        1,
		"IN_PROGRESS":       2,
		"ALREADY_INSTALLED": 3,
		"CONF_MISMATCH":     4,
	}
)

Enum value maps for InstallSnapshotResult.

View Source
var (
	ReplicationLevel_name = map[int32]string{
		0: "MAJORITY",
		1: "ALL",
		2: "MAJORITY_COMMITTED",
		3: "ALL_COMMITTED",
	}
	ReplicationLevel_value = map[string]int32{
		"MAJORITY":           0,
		"ALL":                1,
		"MAJORITY_COMMITTED": 2,
		"ALL_COMMITTED":      3,
	}
)

Enum value maps for ReplicationLevel.

View Source
var (
	RaftPeerRole_name = map[int32]string{
		0: "LEADER",
		1: "CANDIDATE",
		2: "FOLLOWER",
	}
	RaftPeerRole_value = map[string]int32{
		"LEADER":    0,
		"CANDIDATE": 1,
		"FOLLOWER":  2,
	}
)

Enum value maps for RaftPeerRole.

View Source
var (
	AppendEntriesReplyProto_AppendResult_name = map[int32]string{
		0: "SUCCESS",
		1: "NOT_LEADER",
		2: "INCONSISTENCY",
	}
	AppendEntriesReplyProto_AppendResult_value = map[string]int32{
		"SUCCESS":       0,
		"NOT_LEADER":    1,
		"INCONSISTENCY": 2,
	}
)

Enum value maps for AppendEntriesReplyProto_AppendResult.

View Source
var File_ratis_grpc_proto protoreflect.FileDescriptor

Functions

func RegisterAdminProtocolServiceServer

func RegisterAdminProtocolServiceServer(s *grpc.Server, srv AdminProtocolServiceServer)

func RegisterRaftClientProtocolServiceServer

func RegisterRaftClientProtocolServiceServer(s *grpc.Server, srv RaftClientProtocolServiceServer)

func RegisterRaftServerProtocolServiceServer

func RegisterRaftServerProtocolServiceServer(s *grpc.Server, srv RaftServerProtocolServiceServer)

Types

type AdminProtocolServiceClient

type AdminProtocolServiceClient interface {
	// A client-to-server RPC to add a new group
	GroupManagement(ctx context.Context, in *GroupManagementRequestProto, opts ...grpc.CallOption) (*RaftClientReplyProto, error)
	GroupList(ctx context.Context, in *GroupListRequestProto, opts ...grpc.CallOption) (*GroupListReplyProto, error)
	GroupInfo(ctx context.Context, in *GroupInfoRequestProto, opts ...grpc.CallOption) (*GroupInfoReplyProto, error)
}

AdminProtocolServiceClient is the client API for AdminProtocolService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type AdminProtocolServiceServer

type AdminProtocolServiceServer interface {
	// A client-to-server RPC to add a new group
	GroupManagement(context.Context, *GroupManagementRequestProto) (*RaftClientReplyProto, error)
	GroupList(context.Context, *GroupListRequestProto) (*GroupListReplyProto, error)
	GroupInfo(context.Context, *GroupInfoRequestProto) (*GroupInfoReplyProto, error)
}

AdminProtocolServiceServer is the server API for AdminProtocolService service.

type AppendEntriesReplyProto

type AppendEntriesReplyProto struct {
	ServerReply    *RaftRpcReplyProto                   `protobuf:"bytes,1,opt,name=serverReply,proto3" json:"serverReply,omitempty"`
	Term           uint64                               `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"`
	NextIndex      uint64                               `protobuf:"varint,3,opt,name=nextIndex,proto3" json:"nextIndex,omitempty"`
	Result         AppendEntriesReplyProto_AppendResult `protobuf:"varint,4,opt,name=result,proto3,enum=ratis.common.AppendEntriesReplyProto_AppendResult" json:"result,omitempty"`
	FollowerCommit uint64                               `protobuf:"varint,5,opt,name=followerCommit,proto3" json:"followerCommit,omitempty"`
	MatchIndex     uint64                               `protobuf:"varint,6,opt,name=matchIndex,proto3" json:"matchIndex,omitempty"`
	// contains filtered or unexported fields
}

func (*AppendEntriesReplyProto) Descriptor deprecated

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

Deprecated: Use AppendEntriesReplyProto.ProtoReflect.Descriptor instead.

func (*AppendEntriesReplyProto) GetFollowerCommit

func (x *AppendEntriesReplyProto) GetFollowerCommit() uint64

func (*AppendEntriesReplyProto) GetMatchIndex

func (x *AppendEntriesReplyProto) GetMatchIndex() uint64

func (*AppendEntriesReplyProto) GetNextIndex

func (x *AppendEntriesReplyProto) GetNextIndex() uint64

func (*AppendEntriesReplyProto) GetResult

func (*AppendEntriesReplyProto) GetServerReply

func (x *AppendEntriesReplyProto) GetServerReply() *RaftRpcReplyProto

func (*AppendEntriesReplyProto) GetTerm

func (x *AppendEntriesReplyProto) GetTerm() uint64

func (*AppendEntriesReplyProto) ProtoMessage

func (*AppendEntriesReplyProto) ProtoMessage()

func (*AppendEntriesReplyProto) ProtoReflect

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

func (*AppendEntriesReplyProto) Reset

func (x *AppendEntriesReplyProto) Reset()

func (*AppendEntriesReplyProto) String

func (x *AppendEntriesReplyProto) String() string

type AppendEntriesReplyProto_AppendResult

type AppendEntriesReplyProto_AppendResult int32
const (
	AppendEntriesReplyProto_SUCCESS       AppendEntriesReplyProto_AppendResult = 0
	AppendEntriesReplyProto_NOT_LEADER    AppendEntriesReplyProto_AppendResult = 1 // the requester's term is not large enough
	AppendEntriesReplyProto_INCONSISTENCY AppendEntriesReplyProto_AppendResult = 2 // gap between the local log and the entries or snapshot installation in progress or
)

func (AppendEntriesReplyProto_AppendResult) Descriptor

func (AppendEntriesReplyProto_AppendResult) Enum

func (AppendEntriesReplyProto_AppendResult) EnumDescriptor deprecated

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

Deprecated: Use AppendEntriesReplyProto_AppendResult.Descriptor instead.

func (AppendEntriesReplyProto_AppendResult) Number

func (AppendEntriesReplyProto_AppendResult) String

func (AppendEntriesReplyProto_AppendResult) Type

type AppendEntriesRequestProto

type AppendEntriesRequestProto struct {
	ServerRequest *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=serverRequest,proto3" json:"serverRequest,omitempty"`
	LeaderTerm    uint64               `protobuf:"varint,2,opt,name=leaderTerm,proto3" json:"leaderTerm,omitempty"`
	PreviousLog   *TermIndexProto      `protobuf:"bytes,3,opt,name=previousLog,proto3" json:"previousLog,omitempty"`
	Entries       []*LogEntryProto     `protobuf:"bytes,4,rep,name=entries,proto3" json:"entries,omitempty"`
	LeaderCommit  uint64               `protobuf:"varint,5,opt,name=leaderCommit,proto3" json:"leaderCommit,omitempty"`
	Initializing  bool                 `protobuf:"varint,6,opt,name=initializing,proto3" json:"initializing,omitempty"`
	CommitInfos   []*CommitInfoProto   `protobuf:"bytes,15,rep,name=commitInfos,proto3" json:"commitInfos,omitempty"`
	// contains filtered or unexported fields
}

func (*AppendEntriesRequestProto) Descriptor deprecated

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

Deprecated: Use AppendEntriesRequestProto.ProtoReflect.Descriptor instead.

func (*AppendEntriesRequestProto) GetCommitInfos

func (x *AppendEntriesRequestProto) GetCommitInfos() []*CommitInfoProto

func (*AppendEntriesRequestProto) GetEntries

func (x *AppendEntriesRequestProto) GetEntries() []*LogEntryProto

func (*AppendEntriesRequestProto) GetInitializing

func (x *AppendEntriesRequestProto) GetInitializing() bool

func (*AppendEntriesRequestProto) GetLeaderCommit

func (x *AppendEntriesRequestProto) GetLeaderCommit() uint64

func (*AppendEntriesRequestProto) GetLeaderTerm

func (x *AppendEntriesRequestProto) GetLeaderTerm() uint64

func (*AppendEntriesRequestProto) GetPreviousLog

func (x *AppendEntriesRequestProto) GetPreviousLog() *TermIndexProto

func (*AppendEntriesRequestProto) GetServerRequest

func (x *AppendEntriesRequestProto) GetServerRequest() *RaftRpcRequestProto

func (*AppendEntriesRequestProto) ProtoMessage

func (*AppendEntriesRequestProto) ProtoMessage()

func (*AppendEntriesRequestProto) ProtoReflect

func (*AppendEntriesRequestProto) Reset

func (x *AppendEntriesRequestProto) Reset()

func (*AppendEntriesRequestProto) String

func (x *AppendEntriesRequestProto) String() string

type CandidateInfoProto

type CandidateInfoProto struct {
	LastLeaderElapsedTimeMs uint64 `protobuf:"varint,1,opt,name=lastLeaderElapsedTimeMs,proto3" json:"lastLeaderElapsedTimeMs,omitempty"`
	// contains filtered or unexported fields
}

func (*CandidateInfoProto) Descriptor deprecated

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

Deprecated: Use CandidateInfoProto.ProtoReflect.Descriptor instead.

func (*CandidateInfoProto) GetLastLeaderElapsedTimeMs

func (x *CandidateInfoProto) GetLastLeaderElapsedTimeMs() uint64

func (*CandidateInfoProto) ProtoMessage

func (*CandidateInfoProto) ProtoMessage()

func (*CandidateInfoProto) ProtoReflect

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

func (*CandidateInfoProto) Reset

func (x *CandidateInfoProto) Reset()

func (*CandidateInfoProto) String

func (x *CandidateInfoProto) String() string

type ClientMessageEntryProto

type ClientMessageEntryProto struct {
	Content []byte `protobuf:"bytes,1,opt,name=content,proto3" json:"content,omitempty"`
	// contains filtered or unexported fields
}

func (*ClientMessageEntryProto) Descriptor deprecated

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

Deprecated: Use ClientMessageEntryProto.ProtoReflect.Descriptor instead.

func (*ClientMessageEntryProto) GetContent

func (x *ClientMessageEntryProto) GetContent() []byte

func (*ClientMessageEntryProto) ProtoMessage

func (*ClientMessageEntryProto) ProtoMessage()

func (*ClientMessageEntryProto) ProtoReflect

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

func (*ClientMessageEntryProto) Reset

func (x *ClientMessageEntryProto) Reset()

func (*ClientMessageEntryProto) String

func (x *ClientMessageEntryProto) String() string

type CommitInfoProto

type CommitInfoProto struct {
	Server      *RaftPeerProto `protobuf:"bytes,1,opt,name=server,proto3" json:"server,omitempty"`
	CommitIndex uint64         `protobuf:"varint,2,opt,name=commitIndex,proto3" json:"commitIndex,omitempty"`
	// contains filtered or unexported fields
}

func (*CommitInfoProto) Descriptor deprecated

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

Deprecated: Use CommitInfoProto.ProtoReflect.Descriptor instead.

func (*CommitInfoProto) GetCommitIndex

func (x *CommitInfoProto) GetCommitIndex() uint64

func (*CommitInfoProto) GetServer

func (x *CommitInfoProto) GetServer() *RaftPeerProto

func (*CommitInfoProto) ProtoMessage

func (*CommitInfoProto) ProtoMessage()

func (*CommitInfoProto) ProtoReflect

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

func (*CommitInfoProto) Reset

func (x *CommitInfoProto) Reset()

func (*CommitInfoProto) String

func (x *CommitInfoProto) String() string

type FileChunkProto

type FileChunkProto struct {
	Filename   string `protobuf:"bytes,1,opt,name=filename,proto3" json:"filename,omitempty"` // relative to root
	TotalSize  uint64 `protobuf:"varint,2,opt,name=totalSize,proto3" json:"totalSize,omitempty"`
	FileDigest []byte `protobuf:"bytes,3,opt,name=fileDigest,proto3" json:"fileDigest,omitempty"`
	ChunkIndex uint32 `protobuf:"varint,4,opt,name=chunkIndex,proto3" json:"chunkIndex,omitempty"`
	Offset     uint64 `protobuf:"varint,5,opt,name=offset,proto3" json:"offset,omitempty"`
	Data       []byte `protobuf:"bytes,6,opt,name=data,proto3" json:"data,omitempty"`
	Done       bool   `protobuf:"varint,7,opt,name=done,proto3" json:"done,omitempty"`
	// contains filtered or unexported fields
}

func (*FileChunkProto) Descriptor deprecated

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

Deprecated: Use FileChunkProto.ProtoReflect.Descriptor instead.

func (*FileChunkProto) GetChunkIndex

func (x *FileChunkProto) GetChunkIndex() uint32

func (*FileChunkProto) GetData

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

func (*FileChunkProto) GetDone

func (x *FileChunkProto) GetDone() bool

func (*FileChunkProto) GetFileDigest

func (x *FileChunkProto) GetFileDigest() []byte

func (*FileChunkProto) GetFilename

func (x *FileChunkProto) GetFilename() string

func (*FileChunkProto) GetOffset

func (x *FileChunkProto) GetOffset() uint64

func (*FileChunkProto) GetTotalSize

func (x *FileChunkProto) GetTotalSize() uint64

func (*FileChunkProto) ProtoMessage

func (*FileChunkProto) ProtoMessage()

func (*FileChunkProto) ProtoReflect

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

func (*FileChunkProto) Reset

func (x *FileChunkProto) Reset()

func (*FileChunkProto) String

func (x *FileChunkProto) String() string

type FollowerInfoProto

type FollowerInfoProto struct {
	LeaderInfo    *ServerRpcProto `protobuf:"bytes,1,opt,name=leaderInfo,proto3" json:"leaderInfo,omitempty"`
	OutstandingOp uint32          `protobuf:"varint,2,opt,name=outstandingOp,proto3" json:"outstandingOp,omitempty"`
	// contains filtered or unexported fields
}

func (*FollowerInfoProto) Descriptor deprecated

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

Deprecated: Use FollowerInfoProto.ProtoReflect.Descriptor instead.

func (*FollowerInfoProto) GetLeaderInfo

func (x *FollowerInfoProto) GetLeaderInfo() *ServerRpcProto

func (*FollowerInfoProto) GetOutstandingOp

func (x *FollowerInfoProto) GetOutstandingOp() uint32

func (*FollowerInfoProto) ProtoMessage

func (*FollowerInfoProto) ProtoMessage()

func (*FollowerInfoProto) ProtoReflect

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

func (*FollowerInfoProto) Reset

func (x *FollowerInfoProto) Reset()

func (*FollowerInfoProto) String

func (x *FollowerInfoProto) String() string

type GroupAddRequestProto

type GroupAddRequestProto struct {
	Group *RaftGroupProto `protobuf:"bytes,1,opt,name=group,proto3" json:"group,omitempty"` // the group to be added.
	// contains filtered or unexported fields
}

A request to add a new group

func (*GroupAddRequestProto) Descriptor deprecated

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

Deprecated: Use GroupAddRequestProto.ProtoReflect.Descriptor instead.

func (*GroupAddRequestProto) GetGroup

func (x *GroupAddRequestProto) GetGroup() *RaftGroupProto

func (*GroupAddRequestProto) ProtoMessage

func (*GroupAddRequestProto) ProtoMessage()

func (*GroupAddRequestProto) ProtoReflect

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

func (*GroupAddRequestProto) Reset

func (x *GroupAddRequestProto) Reset()

func (*GroupAddRequestProto) String

func (x *GroupAddRequestProto) String() string

type GroupInfoReplyProto

type GroupInfoReplyProto struct {
	RpcReply             *RaftRpcReplyProto `protobuf:"bytes,1,opt,name=rpcReply,proto3" json:"rpcReply,omitempty"`
	Group                *RaftGroupProto    `protobuf:"bytes,2,opt,name=group,proto3" json:"group,omitempty"`
	Role                 *RoleInfoProto     `protobuf:"bytes,3,opt,name=role,proto3" json:"role,omitempty"`
	IsRaftStorageHealthy bool               `protobuf:"varint,4,opt,name=isRaftStorageHealthy,proto3" json:"isRaftStorageHealthy,omitempty"`
	CommitInfos          []*CommitInfoProto `protobuf:"bytes,5,rep,name=commitInfos,proto3" json:"commitInfos,omitempty"`
	// contains filtered or unexported fields
}

func (*GroupInfoReplyProto) Descriptor deprecated

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

Deprecated: Use GroupInfoReplyProto.ProtoReflect.Descriptor instead.

func (*GroupInfoReplyProto) GetCommitInfos

func (x *GroupInfoReplyProto) GetCommitInfos() []*CommitInfoProto

func (*GroupInfoReplyProto) GetGroup

func (x *GroupInfoReplyProto) GetGroup() *RaftGroupProto

func (*GroupInfoReplyProto) GetIsRaftStorageHealthy

func (x *GroupInfoReplyProto) GetIsRaftStorageHealthy() bool

func (*GroupInfoReplyProto) GetRole

func (x *GroupInfoReplyProto) GetRole() *RoleInfoProto

func (*GroupInfoReplyProto) GetRpcReply

func (x *GroupInfoReplyProto) GetRpcReply() *RaftRpcReplyProto

func (*GroupInfoReplyProto) ProtoMessage

func (*GroupInfoReplyProto) ProtoMessage()

func (*GroupInfoReplyProto) ProtoReflect

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

func (*GroupInfoReplyProto) Reset

func (x *GroupInfoReplyProto) Reset()

func (*GroupInfoReplyProto) String

func (x *GroupInfoReplyProto) String() string

type GroupInfoRequestProto

type GroupInfoRequestProto struct {
	RpcRequest *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=rpcRequest,proto3" json:"rpcRequest,omitempty"`
	GroupId    *RaftGroupIdProto    `protobuf:"bytes,2,opt,name=groupId,proto3" json:"groupId,omitempty"`
	// contains filtered or unexported fields
}

func (*GroupInfoRequestProto) Descriptor deprecated

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

Deprecated: Use GroupInfoRequestProto.ProtoReflect.Descriptor instead.

func (*GroupInfoRequestProto) GetGroupId

func (x *GroupInfoRequestProto) GetGroupId() *RaftGroupIdProto

func (*GroupInfoRequestProto) GetRpcRequest

func (x *GroupInfoRequestProto) GetRpcRequest() *RaftRpcRequestProto

func (*GroupInfoRequestProto) ProtoMessage

func (*GroupInfoRequestProto) ProtoMessage()

func (*GroupInfoRequestProto) ProtoReflect

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

func (*GroupInfoRequestProto) Reset

func (x *GroupInfoRequestProto) Reset()

func (*GroupInfoRequestProto) String

func (x *GroupInfoRequestProto) String() string

type GroupListReplyProto

type GroupListReplyProto struct {
	RpcReply *RaftRpcReplyProto  `protobuf:"bytes,1,opt,name=rpcReply,proto3" json:"rpcReply,omitempty"`
	GroupId  []*RaftGroupIdProto `protobuf:"bytes,2,rep,name=groupId,proto3" json:"groupId,omitempty"`
	// contains filtered or unexported fields
}

func (*GroupListReplyProto) Descriptor deprecated

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

Deprecated: Use GroupListReplyProto.ProtoReflect.Descriptor instead.

func (*GroupListReplyProto) GetGroupId

func (x *GroupListReplyProto) GetGroupId() []*RaftGroupIdProto

func (*GroupListReplyProto) GetRpcReply

func (x *GroupListReplyProto) GetRpcReply() *RaftRpcReplyProto

func (*GroupListReplyProto) ProtoMessage

func (*GroupListReplyProto) ProtoMessage()

func (*GroupListReplyProto) ProtoReflect

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

func (*GroupListReplyProto) Reset

func (x *GroupListReplyProto) Reset()

func (*GroupListReplyProto) String

func (x *GroupListReplyProto) String() string

type GroupListRequestProto

type GroupListRequestProto struct {
	RpcRequest *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=rpcRequest,proto3" json:"rpcRequest,omitempty"`
	// contains filtered or unexported fields
}

server info requests

func (*GroupListRequestProto) Descriptor deprecated

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

Deprecated: Use GroupListRequestProto.ProtoReflect.Descriptor instead.

func (*GroupListRequestProto) GetRpcRequest

func (x *GroupListRequestProto) GetRpcRequest() *RaftRpcRequestProto

func (*GroupListRequestProto) ProtoMessage

func (*GroupListRequestProto) ProtoMessage()

func (*GroupListRequestProto) ProtoReflect

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

func (*GroupListRequestProto) Reset

func (x *GroupListRequestProto) Reset()

func (*GroupListRequestProto) String

func (x *GroupListRequestProto) String() string

type GroupManagementRequestProto

type GroupManagementRequestProto struct {
	RpcRequest *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=rpcRequest,proto3" json:"rpcRequest,omitempty"`
	// Types that are assignable to Op:
	//	*GroupManagementRequestProto_GroupAdd
	//	*GroupManagementRequestProto_GroupRemove
	Op isGroupManagementRequestProto_Op `protobuf_oneof:"Op"`
	// contains filtered or unexported fields
}

func (*GroupManagementRequestProto) Descriptor deprecated

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

Deprecated: Use GroupManagementRequestProto.ProtoReflect.Descriptor instead.

func (*GroupManagementRequestProto) GetGroupAdd

func (*GroupManagementRequestProto) GetGroupRemove

func (*GroupManagementRequestProto) GetOp

func (m *GroupManagementRequestProto) GetOp() isGroupManagementRequestProto_Op

func (*GroupManagementRequestProto) GetRpcRequest

func (*GroupManagementRequestProto) ProtoMessage

func (*GroupManagementRequestProto) ProtoMessage()

func (*GroupManagementRequestProto) ProtoReflect

func (*GroupManagementRequestProto) Reset

func (x *GroupManagementRequestProto) Reset()

func (*GroupManagementRequestProto) String

func (x *GroupManagementRequestProto) String() string

type GroupManagementRequestProto_GroupAdd

type GroupManagementRequestProto_GroupAdd struct {
	GroupAdd *GroupAddRequestProto `protobuf:"bytes,2,opt,name=groupAdd,proto3,oneof"`
}

type GroupManagementRequestProto_GroupRemove

type GroupManagementRequestProto_GroupRemove struct {
	GroupRemove *GroupRemoveRequestProto `protobuf:"bytes,3,opt,name=groupRemove,proto3,oneof"`
}

type GroupRemoveRequestProto

type GroupRemoveRequestProto struct {
	GroupId         *RaftGroupIdProto `protobuf:"bytes,1,opt,name=groupId,proto3" json:"groupId,omitempty"`                  // the group to be removed.
	DeleteDirectory bool              `protobuf:"varint,2,opt,name=deleteDirectory,proto3" json:"deleteDirectory,omitempty"` // delete the directory for that group?
	// contains filtered or unexported fields
}

func (*GroupRemoveRequestProto) Descriptor deprecated

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

Deprecated: Use GroupRemoveRequestProto.ProtoReflect.Descriptor instead.

func (*GroupRemoveRequestProto) GetDeleteDirectory

func (x *GroupRemoveRequestProto) GetDeleteDirectory() bool

func (*GroupRemoveRequestProto) GetGroupId

func (x *GroupRemoveRequestProto) GetGroupId() *RaftGroupIdProto

func (*GroupRemoveRequestProto) ProtoMessage

func (*GroupRemoveRequestProto) ProtoMessage()

func (*GroupRemoveRequestProto) ProtoReflect

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

func (*GroupRemoveRequestProto) Reset

func (x *GroupRemoveRequestProto) Reset()

func (*GroupRemoveRequestProto) String

func (x *GroupRemoveRequestProto) String() string

type InstallSnapshotReplyProto

type InstallSnapshotReplyProto struct {
	ServerReply *RaftRpcReplyProto    `protobuf:"bytes,1,opt,name=serverReply,proto3" json:"serverReply,omitempty"`
	Term        uint64                `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"`
	Result      InstallSnapshotResult `protobuf:"varint,3,opt,name=result,proto3,enum=ratis.common.InstallSnapshotResult" json:"result,omitempty"`
	// Types that are assignable to InstallSnapshotReplyBody:
	//	*InstallSnapshotReplyProto_RequestIndex
	//	*InstallSnapshotReplyProto_SnapshotIndex
	InstallSnapshotReplyBody isInstallSnapshotReplyProto_InstallSnapshotReplyBody `protobuf_oneof:"InstallSnapshotReplyBody"`
	// contains filtered or unexported fields
}

func (*InstallSnapshotReplyProto) Descriptor deprecated

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

Deprecated: Use InstallSnapshotReplyProto.ProtoReflect.Descriptor instead.

func (*InstallSnapshotReplyProto) GetInstallSnapshotReplyBody

func (m *InstallSnapshotReplyProto) GetInstallSnapshotReplyBody() isInstallSnapshotReplyProto_InstallSnapshotReplyBody

func (*InstallSnapshotReplyProto) GetRequestIndex

func (x *InstallSnapshotReplyProto) GetRequestIndex() uint32

func (*InstallSnapshotReplyProto) GetResult

func (*InstallSnapshotReplyProto) GetServerReply

func (x *InstallSnapshotReplyProto) GetServerReply() *RaftRpcReplyProto

func (*InstallSnapshotReplyProto) GetSnapshotIndex

func (x *InstallSnapshotReplyProto) GetSnapshotIndex() uint64

func (*InstallSnapshotReplyProto) GetTerm

func (x *InstallSnapshotReplyProto) GetTerm() uint64

func (*InstallSnapshotReplyProto) ProtoMessage

func (*InstallSnapshotReplyProto) ProtoMessage()

func (*InstallSnapshotReplyProto) ProtoReflect

func (*InstallSnapshotReplyProto) Reset

func (x *InstallSnapshotReplyProto) Reset()

func (*InstallSnapshotReplyProto) String

func (x *InstallSnapshotReplyProto) String() string

type InstallSnapshotReplyProto_RequestIndex

type InstallSnapshotReplyProto_RequestIndex struct {
	RequestIndex uint32 `protobuf:"varint,4,opt,name=requestIndex,proto3,oneof"` // index of the snapshot chunk request.
}

type InstallSnapshotReplyProto_SnapshotIndex

type InstallSnapshotReplyProto_SnapshotIndex struct {
	SnapshotIndex uint64 `protobuf:"varint,5,opt,name=snapshotIndex,proto3,oneof"` // index of snapshot installed after notification.
}

type InstallSnapshotRequestProto

type InstallSnapshotRequestProto struct {
	ServerRequest *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=serverRequest,proto3" json:"serverRequest,omitempty"`
	LeaderTerm    uint64               `protobuf:"varint,2,opt,name=leaderTerm,proto3" json:"leaderTerm,omitempty"`
	// Types that are assignable to InstallSnapshotRequestBody:
	//	*InstallSnapshotRequestProto_SnapshotChunk
	//	*InstallSnapshotRequestProto_Notification
	InstallSnapshotRequestBody isInstallSnapshotRequestProto_InstallSnapshotRequestBody `protobuf_oneof:"InstallSnapshotRequestBody"`
	// contains filtered or unexported fields
}

func (*InstallSnapshotRequestProto) Descriptor deprecated

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

Deprecated: Use InstallSnapshotRequestProto.ProtoReflect.Descriptor instead.

func (*InstallSnapshotRequestProto) GetInstallSnapshotRequestBody

func (m *InstallSnapshotRequestProto) GetInstallSnapshotRequestBody() isInstallSnapshotRequestProto_InstallSnapshotRequestBody

func (*InstallSnapshotRequestProto) GetLeaderTerm

func (x *InstallSnapshotRequestProto) GetLeaderTerm() uint64

func (*InstallSnapshotRequestProto) GetNotification

func (*InstallSnapshotRequestProto) GetServerRequest

func (x *InstallSnapshotRequestProto) GetServerRequest() *RaftRpcRequestProto

func (*InstallSnapshotRequestProto) GetSnapshotChunk

func (*InstallSnapshotRequestProto) ProtoMessage

func (*InstallSnapshotRequestProto) ProtoMessage()

func (*InstallSnapshotRequestProto) ProtoReflect

func (*InstallSnapshotRequestProto) Reset

func (x *InstallSnapshotRequestProto) Reset()

func (*InstallSnapshotRequestProto) String

func (x *InstallSnapshotRequestProto) String() string

type InstallSnapshotRequestProto_Notification

type InstallSnapshotRequestProto_Notification struct {
	Notification *InstallSnapshotRequestProto_NotificationProto `protobuf:"bytes,4,opt,name=notification,proto3,oneof"`
}

type InstallSnapshotRequestProto_NotificationProto

type InstallSnapshotRequestProto_NotificationProto struct {
	FirstAvailableTermIndex *TermIndexProto `protobuf:"bytes,1,opt,name=firstAvailableTermIndex,proto3" json:"firstAvailableTermIndex,omitempty"` // first available log index to notify Follower to install snapshot.
	// contains filtered or unexported fields
}

func (*InstallSnapshotRequestProto_NotificationProto) Descriptor deprecated

Deprecated: Use InstallSnapshotRequestProto_NotificationProto.ProtoReflect.Descriptor instead.

func (*InstallSnapshotRequestProto_NotificationProto) GetFirstAvailableTermIndex

func (x *InstallSnapshotRequestProto_NotificationProto) GetFirstAvailableTermIndex() *TermIndexProto

func (*InstallSnapshotRequestProto_NotificationProto) ProtoMessage

func (*InstallSnapshotRequestProto_NotificationProto) ProtoReflect

func (*InstallSnapshotRequestProto_NotificationProto) Reset

func (*InstallSnapshotRequestProto_NotificationProto) String

type InstallSnapshotRequestProto_SnapshotChunk

type InstallSnapshotRequestProto_SnapshotChunk struct {
	SnapshotChunk *InstallSnapshotRequestProto_SnapshotChunkProto `protobuf:"bytes,3,opt,name=snapshotChunk,proto3,oneof"`
}

type InstallSnapshotRequestProto_SnapshotChunkProto

type InstallSnapshotRequestProto_SnapshotChunkProto struct {
	RequestId         string                  `protobuf:"bytes,1,opt,name=requestId,proto3" json:"requestId,omitempty"`        // an identifier for chunked-requests.
	RequestIndex      uint32                  `protobuf:"varint,2,opt,name=requestIndex,proto3" json:"requestIndex,omitempty"` // the index for this request chunk. Starts from 0.
	RaftConfiguration *RaftConfigurationProto `protobuf:"bytes,3,opt,name=raftConfiguration,proto3" json:"raftConfiguration,omitempty"`
	TermIndex         *TermIndexProto         `protobuf:"bytes,4,opt,name=termIndex,proto3" json:"termIndex,omitempty"`
	FileChunks        []*FileChunkProto       `protobuf:"bytes,5,rep,name=fileChunks,proto3" json:"fileChunks,omitempty"`
	TotalSize         uint64                  `protobuf:"varint,6,opt,name=totalSize,proto3" json:"totalSize,omitempty"`
	Done              bool                    `protobuf:"varint,7,opt,name=done,proto3" json:"done,omitempty"` // whether this is the final chunk for the same req.
	// contains filtered or unexported fields
}

func (*InstallSnapshotRequestProto_SnapshotChunkProto) Descriptor deprecated

Deprecated: Use InstallSnapshotRequestProto_SnapshotChunkProto.ProtoReflect.Descriptor instead.

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetDone

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetFileChunks

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetRaftConfiguration

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetRequestId

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetRequestIndex

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetTermIndex

func (*InstallSnapshotRequestProto_SnapshotChunkProto) GetTotalSize

func (*InstallSnapshotRequestProto_SnapshotChunkProto) ProtoMessage

func (*InstallSnapshotRequestProto_SnapshotChunkProto) ProtoReflect

func (*InstallSnapshotRequestProto_SnapshotChunkProto) Reset

func (*InstallSnapshotRequestProto_SnapshotChunkProto) String

type InstallSnapshotResult

type InstallSnapshotResult int32
const (
	InstallSnapshotResult_SUCCESS           InstallSnapshotResult = 0
	InstallSnapshotResult_NOT_LEADER        InstallSnapshotResult = 1
	InstallSnapshotResult_IN_PROGRESS       InstallSnapshotResult = 2
	InstallSnapshotResult_ALREADY_INSTALLED InstallSnapshotResult = 3
	InstallSnapshotResult_CONF_MISMATCH     InstallSnapshotResult = 4
)

func (InstallSnapshotResult) Descriptor

func (InstallSnapshotResult) Enum

func (InstallSnapshotResult) EnumDescriptor deprecated

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

Deprecated: Use InstallSnapshotResult.Descriptor instead.

func (InstallSnapshotResult) Number

func (InstallSnapshotResult) String

func (x InstallSnapshotResult) String() string

func (InstallSnapshotResult) Type

type LeaderInfoProto

type LeaderInfoProto struct {
	FollowerInfo []*ServerRpcProto `protobuf:"bytes,1,rep,name=followerInfo,proto3" json:"followerInfo,omitempty"`
	// contains filtered or unexported fields
}

func (*LeaderInfoProto) Descriptor deprecated

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

Deprecated: Use LeaderInfoProto.ProtoReflect.Descriptor instead.

func (*LeaderInfoProto) GetFollowerInfo

func (x *LeaderInfoProto) GetFollowerInfo() []*ServerRpcProto

func (*LeaderInfoProto) ProtoMessage

func (*LeaderInfoProto) ProtoMessage()

func (*LeaderInfoProto) ProtoReflect

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

func (*LeaderInfoProto) Reset

func (x *LeaderInfoProto) Reset()

func (*LeaderInfoProto) String

func (x *LeaderInfoProto) String() string

type LeaderNotReadyExceptionProto

type LeaderNotReadyExceptionProto struct {
	ServerId *RaftGroupMemberIdProto `protobuf:"bytes,1,opt,name=serverId,proto3" json:"serverId,omitempty"` // id of the leader
	// contains filtered or unexported fields
}

func (*LeaderNotReadyExceptionProto) Descriptor deprecated

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

Deprecated: Use LeaderNotReadyExceptionProto.ProtoReflect.Descriptor instead.

func (*LeaderNotReadyExceptionProto) GetServerId

func (*LeaderNotReadyExceptionProto) ProtoMessage

func (*LeaderNotReadyExceptionProto) ProtoMessage()

func (*LeaderNotReadyExceptionProto) ProtoReflect

func (*LeaderNotReadyExceptionProto) Reset

func (x *LeaderNotReadyExceptionProto) Reset()

func (*LeaderNotReadyExceptionProto) String

type LogEntryProto

type LogEntryProto struct {
	Term  uint64 `protobuf:"varint,1,opt,name=term,proto3" json:"term,omitempty"`
	Index uint64 `protobuf:"varint,2,opt,name=index,proto3" json:"index,omitempty"`
	// Types that are assignable to LogEntryBody:
	//	*LogEntryProto_StateMachineLogEntry
	//	*LogEntryProto_ConfigurationEntry
	//	*LogEntryProto_MetadataEntry
	LogEntryBody isLogEntryProto_LogEntryBody `protobuf_oneof:"LogEntryBody"`
	// contains filtered or unexported fields
}

func (*LogEntryProto) Descriptor deprecated

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

Deprecated: Use LogEntryProto.ProtoReflect.Descriptor instead.

func (*LogEntryProto) GetConfigurationEntry

func (x *LogEntryProto) GetConfigurationEntry() *RaftConfigurationProto

func (*LogEntryProto) GetIndex

func (x *LogEntryProto) GetIndex() uint64

func (*LogEntryProto) GetLogEntryBody

func (m *LogEntryProto) GetLogEntryBody() isLogEntryProto_LogEntryBody

func (*LogEntryProto) GetMetadataEntry

func (x *LogEntryProto) GetMetadataEntry() *MetadataProto

func (*LogEntryProto) GetStateMachineLogEntry

func (x *LogEntryProto) GetStateMachineLogEntry() *StateMachineLogEntryProto

func (*LogEntryProto) GetTerm

func (x *LogEntryProto) GetTerm() uint64

func (*LogEntryProto) ProtoMessage

func (*LogEntryProto) ProtoMessage()

func (*LogEntryProto) ProtoReflect

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

func (*LogEntryProto) Reset

func (x *LogEntryProto) Reset()

func (*LogEntryProto) String

func (x *LogEntryProto) String() string

type LogEntryProto_ConfigurationEntry

type LogEntryProto_ConfigurationEntry struct {
	ConfigurationEntry *RaftConfigurationProto `protobuf:"bytes,4,opt,name=configurationEntry,proto3,oneof"`
}

type LogEntryProto_MetadataEntry

type LogEntryProto_MetadataEntry struct {
	MetadataEntry *MetadataProto `protobuf:"bytes,5,opt,name=metadataEntry,proto3,oneof"`
}

type LogEntryProto_StateMachineLogEntry

type LogEntryProto_StateMachineLogEntry struct {
	StateMachineLogEntry *StateMachineLogEntryProto `protobuf:"bytes,3,opt,name=stateMachineLogEntry,proto3,oneof"`
}

type MetadataProto

type MetadataProto struct {
	CommitIndex uint64 `protobuf:"varint,1,opt,name=commitIndex,proto3" json:"commitIndex,omitempty"`
	// contains filtered or unexported fields
}

func (*MetadataProto) Descriptor deprecated

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

Deprecated: Use MetadataProto.ProtoReflect.Descriptor instead.

func (*MetadataProto) GetCommitIndex

func (x *MetadataProto) GetCommitIndex() uint64

func (*MetadataProto) ProtoMessage

func (*MetadataProto) ProtoMessage()

func (*MetadataProto) ProtoReflect

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

func (*MetadataProto) Reset

func (x *MetadataProto) Reset()

func (*MetadataProto) String

func (x *MetadataProto) String() string

type NotLeaderExceptionProto

type NotLeaderExceptionProto struct {
	SuggestedLeader *RaftPeerProto   `protobuf:"bytes,1,opt,name=suggestedLeader,proto3" json:"suggestedLeader,omitempty"`
	PeersInConf     []*RaftPeerProto `protobuf:"bytes,2,rep,name=peersInConf,proto3" json:"peersInConf,omitempty"`
	// contains filtered or unexported fields
}

func (*NotLeaderExceptionProto) Descriptor deprecated

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

Deprecated: Use NotLeaderExceptionProto.ProtoReflect.Descriptor instead.

func (*NotLeaderExceptionProto) GetPeersInConf

func (x *NotLeaderExceptionProto) GetPeersInConf() []*RaftPeerProto

func (*NotLeaderExceptionProto) GetSuggestedLeader

func (x *NotLeaderExceptionProto) GetSuggestedLeader() *RaftPeerProto

func (*NotLeaderExceptionProto) ProtoMessage

func (*NotLeaderExceptionProto) ProtoMessage()

func (*NotLeaderExceptionProto) ProtoReflect

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

func (*NotLeaderExceptionProto) Reset

func (x *NotLeaderExceptionProto) Reset()

func (*NotLeaderExceptionProto) String

func (x *NotLeaderExceptionProto) String() string

type NotReplicatedExceptionProto

type NotReplicatedExceptionProto struct {
	CallId      uint64           `protobuf:"varint,1,opt,name=callId,proto3" json:"callId,omitempty"`
	Replication ReplicationLevel `protobuf:"varint,2,opt,name=replication,proto3,enum=ratis.common.ReplicationLevel" json:"replication,omitempty"`
	LogIndex    uint64           `protobuf:"varint,3,opt,name=logIndex,proto3" json:"logIndex,omitempty"`
	// contains filtered or unexported fields
}

func (*NotReplicatedExceptionProto) Descriptor deprecated

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

Deprecated: Use NotReplicatedExceptionProto.ProtoReflect.Descriptor instead.

func (*NotReplicatedExceptionProto) GetCallId

func (x *NotReplicatedExceptionProto) GetCallId() uint64

func (*NotReplicatedExceptionProto) GetLogIndex

func (x *NotReplicatedExceptionProto) GetLogIndex() uint64

func (*NotReplicatedExceptionProto) GetReplication

func (x *NotReplicatedExceptionProto) GetReplication() ReplicationLevel

func (*NotReplicatedExceptionProto) ProtoMessage

func (*NotReplicatedExceptionProto) ProtoMessage()

func (*NotReplicatedExceptionProto) ProtoReflect

func (*NotReplicatedExceptionProto) Reset

func (x *NotReplicatedExceptionProto) Reset()

func (*NotReplicatedExceptionProto) String

func (x *NotReplicatedExceptionProto) String() string

type RaftClientProtocolServiceClient

type RaftClientProtocolServiceClient interface {
	// A client-to-server RPC to set new raft configuration
	SetConfiguration(ctx context.Context, in *SetConfigurationRequestProto, opts ...grpc.CallOption) (*RaftClientReplyProto, error)
	// A client-to-server stream RPC to ordered async requests
	Ordered(ctx context.Context, opts ...grpc.CallOption) (RaftClientProtocolService_OrderedClient, error)
	// A client-to-server stream RPC for unordered async requests
	Unordered(ctx context.Context, opts ...grpc.CallOption) (RaftClientProtocolService_UnorderedClient, error)
}

RaftClientProtocolServiceClient is the client API for RaftClientProtocolService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type RaftClientProtocolServiceServer

type RaftClientProtocolServiceServer interface {
	// A client-to-server RPC to set new raft configuration
	SetConfiguration(context.Context, *SetConfigurationRequestProto) (*RaftClientReplyProto, error)
	// A client-to-server stream RPC to ordered async requests
	Ordered(RaftClientProtocolService_OrderedServer) error
	// A client-to-server stream RPC for unordered async requests
	Unordered(RaftClientProtocolService_UnorderedServer) error
}

RaftClientProtocolServiceServer is the server API for RaftClientProtocolService service.

type RaftClientProtocolService_OrderedClient

type RaftClientProtocolService_OrderedClient interface {
	Send(*RaftClientRequestProto) error
	Recv() (*RaftClientReplyProto, error)
	grpc.ClientStream
}

type RaftClientProtocolService_OrderedServer

type RaftClientProtocolService_OrderedServer interface {
	Send(*RaftClientReplyProto) error
	Recv() (*RaftClientRequestProto, error)
	grpc.ServerStream
}

type RaftClientProtocolService_UnorderedClient

type RaftClientProtocolService_UnorderedClient interface {
	Send(*RaftClientRequestProto) error
	Recv() (*RaftClientReplyProto, error)
	grpc.ClientStream
}

type RaftClientProtocolService_UnorderedServer

type RaftClientProtocolService_UnorderedServer interface {
	Send(*RaftClientReplyProto) error
	Recv() (*RaftClientRequestProto, error)
	grpc.ServerStream
}

type RaftClientReplyProto

type RaftClientReplyProto struct {
	RpcReply *RaftRpcReplyProto       `protobuf:"bytes,1,opt,name=rpcReply,proto3" json:"rpcReply,omitempty"`
	Message  *ClientMessageEntryProto `protobuf:"bytes,2,opt,name=message,proto3" json:"message,omitempty"`
	// Types that are assignable to ExceptionDetails:
	//	*RaftClientReplyProto_NotLeaderException
	//	*RaftClientReplyProto_NotReplicatedException
	//	*RaftClientReplyProto_StateMachineException
	//	*RaftClientReplyProto_LeaderNotReadyException
	ExceptionDetails isRaftClientReplyProto_ExceptionDetails `protobuf_oneof:"ExceptionDetails"`
	LogIndex         uint64                                  `protobuf:"varint,14,opt,name=logIndex,proto3" json:"logIndex,omitempty"` // When the request is a write request and the reply is success, the log index of the transaction
	CommitInfos      []*CommitInfoProto                      `protobuf:"bytes,15,rep,name=commitInfos,proto3" json:"commitInfos,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftClientReplyProto) Descriptor deprecated

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

Deprecated: Use RaftClientReplyProto.ProtoReflect.Descriptor instead.

func (*RaftClientReplyProto) GetCommitInfos

func (x *RaftClientReplyProto) GetCommitInfos() []*CommitInfoProto

func (*RaftClientReplyProto) GetExceptionDetails

func (m *RaftClientReplyProto) GetExceptionDetails() isRaftClientReplyProto_ExceptionDetails

func (*RaftClientReplyProto) GetLeaderNotReadyException

func (x *RaftClientReplyProto) GetLeaderNotReadyException() *LeaderNotReadyExceptionProto

func (*RaftClientReplyProto) GetLogIndex

func (x *RaftClientReplyProto) GetLogIndex() uint64

func (*RaftClientReplyProto) GetMessage

func (*RaftClientReplyProto) GetNotLeaderException

func (x *RaftClientReplyProto) GetNotLeaderException() *NotLeaderExceptionProto

func (*RaftClientReplyProto) GetNotReplicatedException

func (x *RaftClientReplyProto) GetNotReplicatedException() *NotReplicatedExceptionProto

func (*RaftClientReplyProto) GetRpcReply

func (x *RaftClientReplyProto) GetRpcReply() *RaftRpcReplyProto

func (*RaftClientReplyProto) GetStateMachineException

func (x *RaftClientReplyProto) GetStateMachineException() *StateMachineExceptionProto

func (*RaftClientReplyProto) ProtoMessage

func (*RaftClientReplyProto) ProtoMessage()

func (*RaftClientReplyProto) ProtoReflect

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

func (*RaftClientReplyProto) Reset

func (x *RaftClientReplyProto) Reset()

func (*RaftClientReplyProto) String

func (x *RaftClientReplyProto) String() string

type RaftClientReplyProto_LeaderNotReadyException

type RaftClientReplyProto_LeaderNotReadyException struct {
	LeaderNotReadyException *LeaderNotReadyExceptionProto `protobuf:"bytes,6,opt,name=leaderNotReadyException,proto3,oneof"`
}

type RaftClientReplyProto_NotLeaderException

type RaftClientReplyProto_NotLeaderException struct {
	NotLeaderException *NotLeaderExceptionProto `protobuf:"bytes,3,opt,name=notLeaderException,proto3,oneof"`
}

type RaftClientReplyProto_NotReplicatedException

type RaftClientReplyProto_NotReplicatedException struct {
	NotReplicatedException *NotReplicatedExceptionProto `protobuf:"bytes,4,opt,name=notReplicatedException,proto3,oneof"`
}

type RaftClientReplyProto_StateMachineException

type RaftClientReplyProto_StateMachineException struct {
	StateMachineException *StateMachineExceptionProto `protobuf:"bytes,5,opt,name=stateMachineException,proto3,oneof"`
}

type RaftClientRequestProto

type RaftClientRequestProto struct {
	RpcRequest *RaftRpcRequestProto     `protobuf:"bytes,1,opt,name=rpcRequest,proto3" json:"rpcRequest,omitempty"`
	Message    *ClientMessageEntryProto `protobuf:"bytes,2,opt,name=message,proto3" json:"message,omitempty"`
	// Types that are assignable to Type:
	//	*RaftClientRequestProto_Write
	//	*RaftClientRequestProto_Read
	//	*RaftClientRequestProto_StaleRead
	//	*RaftClientRequestProto_Watch
	Type isRaftClientRequestProto_Type `protobuf_oneof:"Type"`
	// contains filtered or unexported fields
}

normal client request

func (*RaftClientRequestProto) Descriptor deprecated

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

Deprecated: Use RaftClientRequestProto.ProtoReflect.Descriptor instead.

func (*RaftClientRequestProto) GetMessage

func (*RaftClientRequestProto) GetRead

func (*RaftClientRequestProto) GetRpcRequest

func (x *RaftClientRequestProto) GetRpcRequest() *RaftRpcRequestProto

func (*RaftClientRequestProto) GetStaleRead

func (*RaftClientRequestProto) GetType

func (m *RaftClientRequestProto) GetType() isRaftClientRequestProto_Type

func (*RaftClientRequestProto) GetWatch

func (*RaftClientRequestProto) GetWrite

func (*RaftClientRequestProto) ProtoMessage

func (*RaftClientRequestProto) ProtoMessage()

func (*RaftClientRequestProto) ProtoReflect

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

func (*RaftClientRequestProto) Reset

func (x *RaftClientRequestProto) Reset()

func (*RaftClientRequestProto) String

func (x *RaftClientRequestProto) String() string

type RaftClientRequestProto_Read

type RaftClientRequestProto_Read struct {
	Read *ReadRequestTypeProto `protobuf:"bytes,4,opt,name=read,proto3,oneof"`
}

type RaftClientRequestProto_StaleRead

type RaftClientRequestProto_StaleRead struct {
	StaleRead *StaleReadRequestTypeProto `protobuf:"bytes,5,opt,name=staleRead,proto3,oneof"`
}

type RaftClientRequestProto_Watch

type RaftClientRequestProto_Watch struct {
	Watch *WatchRequestTypeProto `protobuf:"bytes,6,opt,name=watch,proto3,oneof"`
}

type RaftClientRequestProto_Write

type RaftClientRequestProto_Write struct {
	Write *WriteRequestTypeProto `protobuf:"bytes,3,opt,name=write,proto3,oneof"`
}

type RaftConfigurationProto

type RaftConfigurationProto struct {
	Peers    []*RaftPeerProto `protobuf:"bytes,1,rep,name=peers,proto3" json:"peers,omitempty"`       // the peers in the current or new conf
	OldPeers []*RaftPeerProto `protobuf:"bytes,2,rep,name=oldPeers,proto3" json:"oldPeers,omitempty"` // the peers in the old conf
	// contains filtered or unexported fields
}

func (*RaftConfigurationProto) Descriptor deprecated

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

Deprecated: Use RaftConfigurationProto.ProtoReflect.Descriptor instead.

func (*RaftConfigurationProto) GetOldPeers

func (x *RaftConfigurationProto) GetOldPeers() []*RaftPeerProto

func (*RaftConfigurationProto) GetPeers

func (x *RaftConfigurationProto) GetPeers() []*RaftPeerProto

func (*RaftConfigurationProto) ProtoMessage

func (*RaftConfigurationProto) ProtoMessage()

func (*RaftConfigurationProto) ProtoReflect

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

func (*RaftConfigurationProto) Reset

func (x *RaftConfigurationProto) Reset()

func (*RaftConfigurationProto) String

func (x *RaftConfigurationProto) String() string

type RaftGroupIdProto

type RaftGroupIdProto struct {
	Id []byte `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftGroupIdProto) Descriptor deprecated

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

Deprecated: Use RaftGroupIdProto.ProtoReflect.Descriptor instead.

func (*RaftGroupIdProto) GetId

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

func (*RaftGroupIdProto) ProtoMessage

func (*RaftGroupIdProto) ProtoMessage()

func (*RaftGroupIdProto) ProtoReflect

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

func (*RaftGroupIdProto) Reset

func (x *RaftGroupIdProto) Reset()

func (*RaftGroupIdProto) String

func (x *RaftGroupIdProto) String() string

type RaftGroupMemberIdProto

type RaftGroupMemberIdProto struct {
	PeerId  []byte            `protobuf:"bytes,1,opt,name=peerId,proto3" json:"peerId,omitempty"`
	GroupId *RaftGroupIdProto `protobuf:"bytes,2,opt,name=groupId,proto3" json:"groupId,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftGroupMemberIdProto) Descriptor deprecated

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

Deprecated: Use RaftGroupMemberIdProto.ProtoReflect.Descriptor instead.

func (*RaftGroupMemberIdProto) GetGroupId

func (x *RaftGroupMemberIdProto) GetGroupId() *RaftGroupIdProto

func (*RaftGroupMemberIdProto) GetPeerId

func (x *RaftGroupMemberIdProto) GetPeerId() []byte

func (*RaftGroupMemberIdProto) ProtoMessage

func (*RaftGroupMemberIdProto) ProtoMessage()

func (*RaftGroupMemberIdProto) ProtoReflect

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

func (*RaftGroupMemberIdProto) Reset

func (x *RaftGroupMemberIdProto) Reset()

func (*RaftGroupMemberIdProto) String

func (x *RaftGroupMemberIdProto) String() string

type RaftGroupProto

type RaftGroupProto struct {
	GroupId *RaftGroupIdProto `protobuf:"bytes,1,opt,name=groupId,proto3" json:"groupId,omitempty"`
	Peers   []*RaftPeerProto  `protobuf:"bytes,2,rep,name=peers,proto3" json:"peers,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftGroupProto) Descriptor deprecated

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

Deprecated: Use RaftGroupProto.ProtoReflect.Descriptor instead.

func (*RaftGroupProto) GetGroupId

func (x *RaftGroupProto) GetGroupId() *RaftGroupIdProto

func (*RaftGroupProto) GetPeers

func (x *RaftGroupProto) GetPeers() []*RaftPeerProto

func (*RaftGroupProto) ProtoMessage

func (*RaftGroupProto) ProtoMessage()

func (*RaftGroupProto) ProtoReflect

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

func (*RaftGroupProto) Reset

func (x *RaftGroupProto) Reset()

func (*RaftGroupProto) String

func (x *RaftGroupProto) String() string

type RaftPeerProto

type RaftPeerProto struct {
	Id      []byte `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`           // id of the peer
	Address string `protobuf:"bytes,2,opt,name=address,proto3" json:"address,omitempty"` // e.g. IP address, hostname etc.
	// contains filtered or unexported fields
}

func (*RaftPeerProto) Descriptor deprecated

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

Deprecated: Use RaftPeerProto.ProtoReflect.Descriptor instead.

func (*RaftPeerProto) GetAddress

func (x *RaftPeerProto) GetAddress() string

func (*RaftPeerProto) GetId

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

func (*RaftPeerProto) ProtoMessage

func (*RaftPeerProto) ProtoMessage()

func (*RaftPeerProto) ProtoReflect

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

func (*RaftPeerProto) Reset

func (x *RaftPeerProto) Reset()

func (*RaftPeerProto) String

func (x *RaftPeerProto) String() string

type RaftPeerRole

type RaftPeerRole int32

* Role of raft peer

const (
	RaftPeerRole_LEADER    RaftPeerRole = 0
	RaftPeerRole_CANDIDATE RaftPeerRole = 1
	RaftPeerRole_FOLLOWER  RaftPeerRole = 2
)

func (RaftPeerRole) Descriptor

func (RaftPeerRole) Enum

func (x RaftPeerRole) Enum() *RaftPeerRole

func (RaftPeerRole) EnumDescriptor deprecated

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

Deprecated: Use RaftPeerRole.Descriptor instead.

func (RaftPeerRole) Number

func (RaftPeerRole) String

func (x RaftPeerRole) String() string

func (RaftPeerRole) Type

type RaftRpcReplyProto

type RaftRpcReplyProto struct {
	RequestorId []byte            `protobuf:"bytes,1,opt,name=requestorId,proto3" json:"requestorId,omitempty"`
	ReplyId     []byte            `protobuf:"bytes,2,opt,name=replyId,proto3" json:"replyId,omitempty"`
	RaftGroupId *RaftGroupIdProto `protobuf:"bytes,3,opt,name=raftGroupId,proto3" json:"raftGroupId,omitempty"`
	CallId      uint64            `protobuf:"varint,4,opt,name=callId,proto3" json:"callId,omitempty"`
	Success     bool              `protobuf:"varint,15,opt,name=success,proto3" json:"success,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftRpcReplyProto) Descriptor deprecated

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

Deprecated: Use RaftRpcReplyProto.ProtoReflect.Descriptor instead.

func (*RaftRpcReplyProto) GetCallId

func (x *RaftRpcReplyProto) GetCallId() uint64

func (*RaftRpcReplyProto) GetRaftGroupId

func (x *RaftRpcReplyProto) GetRaftGroupId() *RaftGroupIdProto

func (*RaftRpcReplyProto) GetReplyId

func (x *RaftRpcReplyProto) GetReplyId() []byte

func (*RaftRpcReplyProto) GetRequestorId

func (x *RaftRpcReplyProto) GetRequestorId() []byte

func (*RaftRpcReplyProto) GetSuccess

func (x *RaftRpcReplyProto) GetSuccess() bool

func (*RaftRpcReplyProto) ProtoMessage

func (*RaftRpcReplyProto) ProtoMessage()

func (*RaftRpcReplyProto) ProtoReflect

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

func (*RaftRpcReplyProto) Reset

func (x *RaftRpcReplyProto) Reset()

func (*RaftRpcReplyProto) String

func (x *RaftRpcReplyProto) String() string

type RaftRpcRequestProto

type RaftRpcRequestProto struct {
	RequestorId        []byte              `protobuf:"bytes,1,opt,name=requestorId,proto3" json:"requestorId,omitempty"`
	ReplyId            []byte              `protobuf:"bytes,2,opt,name=replyId,proto3" json:"replyId,omitempty"`
	RaftGroupId        *RaftGroupIdProto   `protobuf:"bytes,3,opt,name=raftGroupId,proto3" json:"raftGroupId,omitempty"`
	CallId             uint64              `protobuf:"varint,4,opt,name=callId,proto3" json:"callId,omitempty"`
	SlidingWindowEntry *SlidingWindowEntry `protobuf:"bytes,15,opt,name=slidingWindowEntry,proto3" json:"slidingWindowEntry,omitempty"`
	// contains filtered or unexported fields
}

func (*RaftRpcRequestProto) Descriptor deprecated

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

Deprecated: Use RaftRpcRequestProto.ProtoReflect.Descriptor instead.

func (*RaftRpcRequestProto) GetCallId

func (x *RaftRpcRequestProto) GetCallId() uint64

func (*RaftRpcRequestProto) GetRaftGroupId

func (x *RaftRpcRequestProto) GetRaftGroupId() *RaftGroupIdProto

func (*RaftRpcRequestProto) GetReplyId

func (x *RaftRpcRequestProto) GetReplyId() []byte

func (*RaftRpcRequestProto) GetRequestorId

func (x *RaftRpcRequestProto) GetRequestorId() []byte

func (*RaftRpcRequestProto) GetSlidingWindowEntry

func (x *RaftRpcRequestProto) GetSlidingWindowEntry() *SlidingWindowEntry

func (*RaftRpcRequestProto) ProtoMessage

func (*RaftRpcRequestProto) ProtoMessage()

func (*RaftRpcRequestProto) ProtoReflect

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

func (*RaftRpcRequestProto) Reset

func (x *RaftRpcRequestProto) Reset()

func (*RaftRpcRequestProto) String

func (x *RaftRpcRequestProto) String() string

type RaftServerProtocolServiceClient

type RaftServerProtocolServiceClient interface {
	RequestVote(ctx context.Context, in *RequestVoteRequestProto, opts ...grpc.CallOption) (*RequestVoteReplyProto, error)
	AppendEntries(ctx context.Context, opts ...grpc.CallOption) (RaftServerProtocolService_AppendEntriesClient, error)
	InstallSnapshot(ctx context.Context, opts ...grpc.CallOption) (RaftServerProtocolService_InstallSnapshotClient, error)
}

RaftServerProtocolServiceClient is the client API for RaftServerProtocolService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type RaftServerProtocolServiceServer

type RaftServerProtocolServiceServer interface {
	RequestVote(context.Context, *RequestVoteRequestProto) (*RequestVoteReplyProto, error)
	AppendEntries(RaftServerProtocolService_AppendEntriesServer) error
	InstallSnapshot(RaftServerProtocolService_InstallSnapshotServer) error
}

RaftServerProtocolServiceServer is the server API for RaftServerProtocolService service.

type RaftServerProtocolService_AppendEntriesClient

type RaftServerProtocolService_AppendEntriesClient interface {
	Send(*AppendEntriesRequestProto) error
	Recv() (*AppendEntriesReplyProto, error)
	grpc.ClientStream
}

type RaftServerProtocolService_AppendEntriesServer

type RaftServerProtocolService_AppendEntriesServer interface {
	Send(*AppendEntriesReplyProto) error
	Recv() (*AppendEntriesRequestProto, error)
	grpc.ServerStream
}

type RaftServerProtocolService_InstallSnapshotClient

type RaftServerProtocolService_InstallSnapshotClient interface {
	Send(*InstallSnapshotRequestProto) error
	CloseAndRecv() (*InstallSnapshotReplyProto, error)
	grpc.ClientStream
}

type RaftServerProtocolService_InstallSnapshotServer

type RaftServerProtocolService_InstallSnapshotServer interface {
	SendAndClose(*InstallSnapshotReplyProto) error
	Recv() (*InstallSnapshotRequestProto, error)
	grpc.ServerStream
}

type ReadRequestTypeProto

type ReadRequestTypeProto struct {
	// contains filtered or unexported fields
}

func (*ReadRequestTypeProto) Descriptor deprecated

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

Deprecated: Use ReadRequestTypeProto.ProtoReflect.Descriptor instead.

func (*ReadRequestTypeProto) ProtoMessage

func (*ReadRequestTypeProto) ProtoMessage()

func (*ReadRequestTypeProto) ProtoReflect

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

func (*ReadRequestTypeProto) Reset

func (x *ReadRequestTypeProto) Reset()

func (*ReadRequestTypeProto) String

func (x *ReadRequestTypeProto) String() string

type ReplicationLevel

type ReplicationLevel int32
const (
	//* Committed at the leader and replicated to the majority of peers.
	ReplicationLevel_MAJORITY ReplicationLevel = 0
	//* Committed at the leader and replicated to all peers.
	//Note that ReplicationLevel.ALL implies ReplicationLevel.MAJORITY.
	ReplicationLevel_ALL ReplicationLevel = 1
	//* Committed at majority peers.
	//Note that ReplicationLevel.MAJORITY_COMMITTED implies ReplicationLevel.MAJORITY.
	ReplicationLevel_MAJORITY_COMMITTED ReplicationLevel = 2
	//* Committed at all peers.
	//Note that ReplicationLevel.ALL_COMMITTED implies ReplicationLevel.ALL
	//and ReplicationLevel.MAJORITY_COMMITTED
	ReplicationLevel_ALL_COMMITTED ReplicationLevel = 3
)

func (ReplicationLevel) Descriptor

func (ReplicationLevel) Enum

func (ReplicationLevel) EnumDescriptor deprecated

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

Deprecated: Use ReplicationLevel.Descriptor instead.

func (ReplicationLevel) Number

func (ReplicationLevel) String

func (x ReplicationLevel) String() string

func (ReplicationLevel) Type

type RequestVoteReplyProto

type RequestVoteReplyProto struct {
	ServerReply    *RaftRpcReplyProto `protobuf:"bytes,1,opt,name=serverReply,proto3" json:"serverReply,omitempty"`
	Term           uint64             `protobuf:"varint,2,opt,name=term,proto3" json:"term,omitempty"`
	ShouldShutdown bool               `protobuf:"varint,3,opt,name=shouldShutdown,proto3" json:"shouldShutdown,omitempty"`
	// contains filtered or unexported fields
}

func (*RequestVoteReplyProto) Descriptor deprecated

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

Deprecated: Use RequestVoteReplyProto.ProtoReflect.Descriptor instead.

func (*RequestVoteReplyProto) GetServerReply

func (x *RequestVoteReplyProto) GetServerReply() *RaftRpcReplyProto

func (*RequestVoteReplyProto) GetShouldShutdown

func (x *RequestVoteReplyProto) GetShouldShutdown() bool

func (*RequestVoteReplyProto) GetTerm

func (x *RequestVoteReplyProto) GetTerm() uint64

func (*RequestVoteReplyProto) ProtoMessage

func (*RequestVoteReplyProto) ProtoMessage()

func (*RequestVoteReplyProto) ProtoReflect

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

func (*RequestVoteReplyProto) Reset

func (x *RequestVoteReplyProto) Reset()

func (*RequestVoteReplyProto) String

func (x *RequestVoteReplyProto) String() string

type RequestVoteRequestProto

type RequestVoteRequestProto struct {
	ServerRequest      *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=serverRequest,proto3" json:"serverRequest,omitempty"`
	CandidateTerm      uint64               `protobuf:"varint,2,opt,name=candidateTerm,proto3" json:"candidateTerm,omitempty"`
	CandidateLastEntry *TermIndexProto      `protobuf:"bytes,3,opt,name=candidateLastEntry,proto3" json:"candidateLastEntry,omitempty"`
	// contains filtered or unexported fields
}

func (*RequestVoteRequestProto) Descriptor deprecated

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

Deprecated: Use RequestVoteRequestProto.ProtoReflect.Descriptor instead.

func (*RequestVoteRequestProto) GetCandidateLastEntry

func (x *RequestVoteRequestProto) GetCandidateLastEntry() *TermIndexProto

func (*RequestVoteRequestProto) GetCandidateTerm

func (x *RequestVoteRequestProto) GetCandidateTerm() uint64

func (*RequestVoteRequestProto) GetServerRequest

func (x *RequestVoteRequestProto) GetServerRequest() *RaftRpcRequestProto

func (*RequestVoteRequestProto) ProtoMessage

func (*RequestVoteRequestProto) ProtoMessage()

func (*RequestVoteRequestProto) ProtoReflect

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

func (*RequestVoteRequestProto) Reset

func (x *RequestVoteRequestProto) Reset()

func (*RequestVoteRequestProto) String

func (x *RequestVoteRequestProto) String() string

type RoleInfoProto

type RoleInfoProto struct {
	Self              *RaftPeerProto `protobuf:"bytes,1,opt,name=self,proto3" json:"self,omitempty"`
	Role              RaftPeerRole   `protobuf:"varint,2,opt,name=role,proto3,enum=ratis.common.RaftPeerRole" json:"role,omitempty"`
	RoleElapsedTimeMs uint64         `protobuf:"varint,3,opt,name=roleElapsedTimeMs,proto3" json:"roleElapsedTimeMs,omitempty"`
	// Types that are assignable to PeerInfo:
	//	*RoleInfoProto_LeaderInfo
	//	*RoleInfoProto_FollowerInfo
	//	*RoleInfoProto_CandidateInfo
	PeerInfo isRoleInfoProto_PeerInfo `protobuf_oneof:"PeerInfo"`
	// contains filtered or unexported fields
}

func (*RoleInfoProto) Descriptor deprecated

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

Deprecated: Use RoleInfoProto.ProtoReflect.Descriptor instead.

func (*RoleInfoProto) GetCandidateInfo

func (x *RoleInfoProto) GetCandidateInfo() *CandidateInfoProto

func (*RoleInfoProto) GetFollowerInfo

func (x *RoleInfoProto) GetFollowerInfo() *FollowerInfoProto

func (*RoleInfoProto) GetLeaderInfo

func (x *RoleInfoProto) GetLeaderInfo() *LeaderInfoProto

func (*RoleInfoProto) GetPeerInfo

func (m *RoleInfoProto) GetPeerInfo() isRoleInfoProto_PeerInfo

func (*RoleInfoProto) GetRole

func (x *RoleInfoProto) GetRole() RaftPeerRole

func (*RoleInfoProto) GetRoleElapsedTimeMs

func (x *RoleInfoProto) GetRoleElapsedTimeMs() uint64

func (*RoleInfoProto) GetSelf

func (x *RoleInfoProto) GetSelf() *RaftPeerProto

func (*RoleInfoProto) ProtoMessage

func (*RoleInfoProto) ProtoMessage()

func (*RoleInfoProto) ProtoReflect

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

func (*RoleInfoProto) Reset

func (x *RoleInfoProto) Reset()

func (*RoleInfoProto) String

func (x *RoleInfoProto) String() string

type RoleInfoProto_CandidateInfo

type RoleInfoProto_CandidateInfo struct {
	CandidateInfo *CandidateInfoProto `protobuf:"bytes,6,opt,name=candidateInfo,proto3,oneof"`
}

type RoleInfoProto_FollowerInfo

type RoleInfoProto_FollowerInfo struct {
	FollowerInfo *FollowerInfoProto `protobuf:"bytes,5,opt,name=followerInfo,proto3,oneof"`
}

type RoleInfoProto_LeaderInfo

type RoleInfoProto_LeaderInfo struct {
	LeaderInfo *LeaderInfoProto `protobuf:"bytes,4,opt,name=leaderInfo,proto3,oneof"`
}

type ServerRpcProto

type ServerRpcProto struct {
	Id                   *RaftPeerProto `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	LastRpcElapsedTimeMs uint64         `protobuf:"varint,2,opt,name=lastRpcElapsedTimeMs,proto3" json:"lastRpcElapsedTimeMs,omitempty"`
	// contains filtered or unexported fields
}

func (*ServerRpcProto) Descriptor deprecated

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

Deprecated: Use ServerRpcProto.ProtoReflect.Descriptor instead.

func (*ServerRpcProto) GetId

func (x *ServerRpcProto) GetId() *RaftPeerProto

func (*ServerRpcProto) GetLastRpcElapsedTimeMs

func (x *ServerRpcProto) GetLastRpcElapsedTimeMs() uint64

func (*ServerRpcProto) ProtoMessage

func (*ServerRpcProto) ProtoMessage()

func (*ServerRpcProto) ProtoReflect

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

func (*ServerRpcProto) Reset

func (x *ServerRpcProto) Reset()

func (*ServerRpcProto) String

func (x *ServerRpcProto) String() string

type SetConfigurationRequestProto

type SetConfigurationRequestProto struct {
	RpcRequest *RaftRpcRequestProto `protobuf:"bytes,1,opt,name=rpcRequest,proto3" json:"rpcRequest,omitempty"`
	Peers      []*RaftPeerProto     `protobuf:"bytes,2,rep,name=peers,proto3" json:"peers,omitempty"`
	// contains filtered or unexported fields
}

setConfiguration request

func (*SetConfigurationRequestProto) Descriptor deprecated

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

Deprecated: Use SetConfigurationRequestProto.ProtoReflect.Descriptor instead.

func (*SetConfigurationRequestProto) GetPeers

func (*SetConfigurationRequestProto) GetRpcRequest

func (*SetConfigurationRequestProto) ProtoMessage

func (*SetConfigurationRequestProto) ProtoMessage()

func (*SetConfigurationRequestProto) ProtoReflect

func (*SetConfigurationRequestProto) Reset

func (x *SetConfigurationRequestProto) Reset()

func (*SetConfigurationRequestProto) String

type SlidingWindowEntry

type SlidingWindowEntry struct {
	SeqNum  uint64 `protobuf:"varint,1,opt,name=seqNum,proto3" json:"seqNum,omitempty"`   // 0 for non-sliding-window requests; >= 1 for sliding-window requests
	IsFirst bool   `protobuf:"varint,2,opt,name=isFirst,proto3" json:"isFirst,omitempty"` // Is this the first request of the sliding window?
	// contains filtered or unexported fields
}

func (*SlidingWindowEntry) Descriptor deprecated

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

Deprecated: Use SlidingWindowEntry.ProtoReflect.Descriptor instead.

func (*SlidingWindowEntry) GetIsFirst

func (x *SlidingWindowEntry) GetIsFirst() bool

func (*SlidingWindowEntry) GetSeqNum

func (x *SlidingWindowEntry) GetSeqNum() uint64

func (*SlidingWindowEntry) ProtoMessage

func (*SlidingWindowEntry) ProtoMessage()

func (*SlidingWindowEntry) ProtoReflect

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

func (*SlidingWindowEntry) Reset

func (x *SlidingWindowEntry) Reset()

func (*SlidingWindowEntry) String

func (x *SlidingWindowEntry) String() string

type StaleReadRequestTypeProto

type StaleReadRequestTypeProto struct {
	MinIndex uint64 `protobuf:"varint,1,opt,name=minIndex,proto3" json:"minIndex,omitempty"`
	// contains filtered or unexported fields
}

func (*StaleReadRequestTypeProto) Descriptor deprecated

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

Deprecated: Use StaleReadRequestTypeProto.ProtoReflect.Descriptor instead.

func (*StaleReadRequestTypeProto) GetMinIndex

func (x *StaleReadRequestTypeProto) GetMinIndex() uint64

func (*StaleReadRequestTypeProto) ProtoMessage

func (*StaleReadRequestTypeProto) ProtoMessage()

func (*StaleReadRequestTypeProto) ProtoReflect

func (*StaleReadRequestTypeProto) Reset

func (x *StaleReadRequestTypeProto) Reset()

func (*StaleReadRequestTypeProto) String

func (x *StaleReadRequestTypeProto) String() string

type StateMachineEntryProto

type StateMachineEntryProto struct {

	//*
	// StateMachine specific data which is not written to log.
	// Unlike logEntryData, stateMachineData is managed and stored by the StateMachine but not the RaftLog.
	StateMachineData []byte `protobuf:"bytes,1,opt,name=stateMachineData,proto3" json:"stateMachineData,omitempty"`
	//*
	// When stateMachineData is missing, it is the size of the serialized LogEntryProto along with stateMachineData.
	// When stateMachineData is not missing, it must be set to zero.
	LogEntryProtoSerializedSize uint32 `protobuf:"varint,2,opt,name=logEntryProtoSerializedSize,proto3" json:"logEntryProtoSerializedSize,omitempty"`
	// contains filtered or unexported fields
}

func (*StateMachineEntryProto) Descriptor deprecated

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

Deprecated: Use StateMachineEntryProto.ProtoReflect.Descriptor instead.

func (*StateMachineEntryProto) GetLogEntryProtoSerializedSize

func (x *StateMachineEntryProto) GetLogEntryProtoSerializedSize() uint32

func (*StateMachineEntryProto) GetStateMachineData

func (x *StateMachineEntryProto) GetStateMachineData() []byte

func (*StateMachineEntryProto) ProtoMessage

func (*StateMachineEntryProto) ProtoMessage()

func (*StateMachineEntryProto) ProtoReflect

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

func (*StateMachineEntryProto) Reset

func (x *StateMachineEntryProto) Reset()

func (*StateMachineEntryProto) String

func (x *StateMachineEntryProto) String() string

type StateMachineExceptionProto

type StateMachineExceptionProto struct {
	ExceptionClassName string `protobuf:"bytes,1,opt,name=exceptionClassName,proto3" json:"exceptionClassName,omitempty"`
	ErrorMsg           string `protobuf:"bytes,2,opt,name=errorMsg,proto3" json:"errorMsg,omitempty"`
	Stacktrace         []byte `protobuf:"bytes,3,opt,name=stacktrace,proto3" json:"stacktrace,omitempty"`
	// contains filtered or unexported fields
}

func (*StateMachineExceptionProto) Descriptor deprecated

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

Deprecated: Use StateMachineExceptionProto.ProtoReflect.Descriptor instead.

func (*StateMachineExceptionProto) GetErrorMsg

func (x *StateMachineExceptionProto) GetErrorMsg() string

func (*StateMachineExceptionProto) GetExceptionClassName

func (x *StateMachineExceptionProto) GetExceptionClassName() string

func (*StateMachineExceptionProto) GetStacktrace

func (x *StateMachineExceptionProto) GetStacktrace() []byte

func (*StateMachineExceptionProto) ProtoMessage

func (*StateMachineExceptionProto) ProtoMessage()

func (*StateMachineExceptionProto) ProtoReflect

func (*StateMachineExceptionProto) Reset

func (x *StateMachineExceptionProto) Reset()

func (*StateMachineExceptionProto) String

func (x *StateMachineExceptionProto) String() string

type StateMachineLogEntryProto

type StateMachineLogEntryProto struct {

	//* RaftLog entry data
	LogData []byte `protobuf:"bytes,1,opt,name=logData,proto3" json:"logData,omitempty"`
	//*
	// StateMachine entry.
	// StateMachine implementation may use this field to separate StateMachine specific data from the RaftLog data.
	StateMachineEntry *StateMachineEntryProto `protobuf:"bytes,2,opt,name=stateMachineEntry,proto3" json:"stateMachineEntry,omitempty"`
	// clientId and callId are used to rebuild the retry cache.
	ClientId []byte `protobuf:"bytes,14,opt,name=clientId,proto3" json:"clientId,omitempty"`
	CallId   uint64 `protobuf:"varint,15,opt,name=callId,proto3" json:"callId,omitempty"`
	// contains filtered or unexported fields
}

func (*StateMachineLogEntryProto) Descriptor deprecated

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

Deprecated: Use StateMachineLogEntryProto.ProtoReflect.Descriptor instead.

func (*StateMachineLogEntryProto) GetCallId

func (x *StateMachineLogEntryProto) GetCallId() uint64

func (*StateMachineLogEntryProto) GetClientId

func (x *StateMachineLogEntryProto) GetClientId() []byte

func (*StateMachineLogEntryProto) GetLogData

func (x *StateMachineLogEntryProto) GetLogData() []byte

func (*StateMachineLogEntryProto) GetStateMachineEntry

func (x *StateMachineLogEntryProto) GetStateMachineEntry() *StateMachineEntryProto

func (*StateMachineLogEntryProto) ProtoMessage

func (*StateMachineLogEntryProto) ProtoMessage()

func (*StateMachineLogEntryProto) ProtoReflect

func (*StateMachineLogEntryProto) Reset

func (x *StateMachineLogEntryProto) Reset()

func (*StateMachineLogEntryProto) String

func (x *StateMachineLogEntryProto) String() string

type TermIndexProto

type TermIndexProto struct {
	Term  uint64 `protobuf:"varint,1,opt,name=term,proto3" json:"term,omitempty"`
	Index uint64 `protobuf:"varint,2,opt,name=index,proto3" json:"index,omitempty"`
	// contains filtered or unexported fields
}

func (*TermIndexProto) Descriptor deprecated

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

Deprecated: Use TermIndexProto.ProtoReflect.Descriptor instead.

func (*TermIndexProto) GetIndex

func (x *TermIndexProto) GetIndex() uint64

func (*TermIndexProto) GetTerm

func (x *TermIndexProto) GetTerm() uint64

func (*TermIndexProto) ProtoMessage

func (*TermIndexProto) ProtoMessage()

func (*TermIndexProto) ProtoReflect

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

func (*TermIndexProto) Reset

func (x *TermIndexProto) Reset()

func (*TermIndexProto) String

func (x *TermIndexProto) String() string

type UnimplementedAdminProtocolServiceServer

type UnimplementedAdminProtocolServiceServer struct {
}

UnimplementedAdminProtocolServiceServer can be embedded to have forward compatible implementations.

func (*UnimplementedAdminProtocolServiceServer) GroupInfo

func (*UnimplementedAdminProtocolServiceServer) GroupList

func (*UnimplementedAdminProtocolServiceServer) GroupManagement

type UnimplementedRaftClientProtocolServiceServer

type UnimplementedRaftClientProtocolServiceServer struct {
}

UnimplementedRaftClientProtocolServiceServer can be embedded to have forward compatible implementations.

func (*UnimplementedRaftClientProtocolServiceServer) Ordered

func (*UnimplementedRaftClientProtocolServiceServer) SetConfiguration

func (*UnimplementedRaftClientProtocolServiceServer) Unordered

type UnimplementedRaftServerProtocolServiceServer

type UnimplementedRaftServerProtocolServiceServer struct {
}

UnimplementedRaftServerProtocolServiceServer can be embedded to have forward compatible implementations.

func (*UnimplementedRaftServerProtocolServiceServer) AppendEntries

func (*UnimplementedRaftServerProtocolServiceServer) InstallSnapshot

func (*UnimplementedRaftServerProtocolServiceServer) RequestVote

type WatchRequestTypeProto

type WatchRequestTypeProto struct {
	Index       uint64           `protobuf:"varint,1,opt,name=index,proto3" json:"index,omitempty"`
	Replication ReplicationLevel `protobuf:"varint,2,opt,name=replication,proto3,enum=ratis.common.ReplicationLevel" json:"replication,omitempty"`
	// contains filtered or unexported fields
}

func (*WatchRequestTypeProto) Descriptor deprecated

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

Deprecated: Use WatchRequestTypeProto.ProtoReflect.Descriptor instead.

func (*WatchRequestTypeProto) GetIndex

func (x *WatchRequestTypeProto) GetIndex() uint64

func (*WatchRequestTypeProto) GetReplication

func (x *WatchRequestTypeProto) GetReplication() ReplicationLevel

func (*WatchRequestTypeProto) ProtoMessage

func (*WatchRequestTypeProto) ProtoMessage()

func (*WatchRequestTypeProto) ProtoReflect

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

func (*WatchRequestTypeProto) Reset

func (x *WatchRequestTypeProto) Reset()

func (*WatchRequestTypeProto) String

func (x *WatchRequestTypeProto) String() string

type WriteRequestTypeProto

type WriteRequestTypeProto struct {
	// contains filtered or unexported fields
}

func (*WriteRequestTypeProto) Descriptor deprecated

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

Deprecated: Use WriteRequestTypeProto.ProtoReflect.Descriptor instead.

func (*WriteRequestTypeProto) ProtoMessage

func (*WriteRequestTypeProto) ProtoMessage()

func (*WriteRequestTypeProto) ProtoReflect

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

func (*WriteRequestTypeProto) Reset

func (x *WriteRequestTypeProto) Reset()

func (*WriteRequestTypeProto) String

func (x *WriteRequestTypeProto) String() string

Jump to

Keyboard shortcuts

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