Versions in this module Expand all Collapse all v3 v3.2.5 May 10, 2020 v3.2.4 May 10, 2020 Changes in this version + const NoNode + const RaftEntryEncodingScheme + var ChecksumType_name = map[int32]string + var ChecksumType_value = map[string]int32 + var ColferSizeMax uint64 = 8 * 1024 * 1024 * 1024 * 1024 + var CompressionType_name = map[int32]string + var CompressionType_value = map[string]int32 + var ConfigChangeType_name = map[int32]string + var ConfigChangeType_value = map[string]int32 + var EntryType_name = map[int32]string + var EntryType_value = map[string]int32 + var ErrIntOverflowRaft = fmt.Errorf("proto: integer overflow") + var ErrInvalidLengthRaft = fmt.Errorf("proto: negative length found during unmarshaling") + var LastChunkCount uint64 = math.MaxUint64 + var MessageType_name = map[int32]string + var MessageType_value = map[string]int32 + var PoisonChunkCount uint64 = math.MaxUint64 - 1 + var StateMachineType_name = map[int32]string + var StateMachineType_value = map[string]int32 + func GetEntrySliceInMemSize(ents []Entry) uint64 + func GetEntrySliceSize(ents []Entry) uint64 + func IsEmptySnapshot(s Snapshot) bool + func IsEmptyState(st State) bool + func IsStateEqual(a State, b State) bool + type Bootstrap struct + Addresses map[uint64]string + Join bool + Type StateMachineType + func NewBootstrapInfo(join bool, smType StateMachineType, nodes map[uint64]string) *Bootstrap + func (*Bootstrap) Descriptor() ([]byte, []int) + func (*Bootstrap) ProtoMessage() + func (b *Bootstrap) Validate(nodes map[uint64]string, join bool, smType StateMachineType) bool + func (m *Bootstrap) GetAddresses() map[uint64]string + func (m *Bootstrap) GetJoin() bool + func (m *Bootstrap) GetType() StateMachineType + func (m *Bootstrap) Marshal() (dAtA []byte, err error) + func (m *Bootstrap) MarshalTo(dAtA []byte) (int, error) + func (m *Bootstrap) Reset() + func (m *Bootstrap) Size() (n int) + func (m *Bootstrap) String() string + func (m *Bootstrap) Unmarshal(dAtA []byte) error + func (m *Bootstrap) XXX_DiscardUnknown() + func (m *Bootstrap) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Bootstrap) XXX_Merge(src proto.Message) + func (m *Bootstrap) XXX_Size() int + func (m *Bootstrap) XXX_Unmarshal(b []byte) error + type ChecksumType int32 + const CRC32IEEE + const HIGHWAY + func (ChecksumType) EnumDescriptor() ([]byte, []int) + func (x *ChecksumType) UnmarshalJSON(data []byte) error + func (x ChecksumType) Enum() *ChecksumType + func (x ChecksumType) String() string + type Chunk struct + BinVer uint32 + ChunkCount uint64 + ChunkId uint64 + ChunkSize uint64 + ClusterId uint64 + Data []byte + DeploymentId uint64 + FileChunkCount uint64 + FileChunkId uint64 + FileInfo SnapshotFile + FileSize uint64 + Filepath string + From uint64 + HasFileInfo bool + Index uint64 + Membership Membership + NodeId uint64 + OnDiskIndex uint64 + Term uint64 + Witness bool + func (*Chunk) Descriptor() ([]byte, []int) + func (*Chunk) ProtoMessage() + func (c Chunk) IsLastChunk() bool + func (c Chunk) IsLastFileChunk() bool + func (c Chunk) IsPoisonChunk() bool + func (m *Chunk) GetBinVer() uint32 + func (m *Chunk) GetChunkCount() uint64 + func (m *Chunk) GetChunkId() uint64 + func (m *Chunk) GetChunkSize() uint64 + func (m *Chunk) GetClusterId() uint64 + func (m *Chunk) GetData() []byte + func (m *Chunk) GetDeploymentId() uint64 + func (m *Chunk) GetFileChunkCount() uint64 + func (m *Chunk) GetFileChunkId() uint64 + func (m *Chunk) GetFileInfo() SnapshotFile + func (m *Chunk) GetFileSize() uint64 + func (m *Chunk) GetFilepath() string + func (m *Chunk) GetFrom() uint64 + func (m *Chunk) GetHasFileInfo() bool + func (m *Chunk) GetIndex() uint64 + func (m *Chunk) GetMembership() Membership + func (m *Chunk) GetNodeId() uint64 + func (m *Chunk) GetOnDiskIndex() uint64 + func (m *Chunk) GetTerm() uint64 + func (m *Chunk) GetWitness() bool + func (m *Chunk) Marshal() (dAtA []byte, err error) + func (m *Chunk) MarshalTo(dAtA []byte) (int, error) + func (m *Chunk) Reset() + func (m *Chunk) Size() (n int) + func (m *Chunk) String() string + func (m *Chunk) Unmarshal(dAtA []byte) error + func (m *Chunk) XXX_DiscardUnknown() + func (m *Chunk) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Chunk) XXX_Merge(src proto.Message) + func (m *Chunk) XXX_Size() int + func (m *Chunk) XXX_Unmarshal(b []byte) error + type ColferError int + func (i ColferError) Error() string + type ColferMax string + func (m ColferMax) Error() string + type ColferTail int + func (i ColferTail) Error() string + type CompressionType int32 + const NoCompression + const Snappy + func (CompressionType) EnumDescriptor() ([]byte, []int) + func (x *CompressionType) UnmarshalJSON(data []byte) error + func (x CompressionType) Enum() *CompressionType + func (x CompressionType) String() string + type ConfigChange struct + Address string + ConfigChangeId uint64 + Initialize bool + NodeID uint64 + Type ConfigChangeType + func (*ConfigChange) Descriptor() ([]byte, []int) + func (*ConfigChange) ProtoMessage() + func (m *ConfigChange) GetAddress() string + func (m *ConfigChange) GetConfigChangeId() uint64 + func (m *ConfigChange) GetInitialize() bool + func (m *ConfigChange) GetNodeID() uint64 + func (m *ConfigChange) GetType() ConfigChangeType + func (m *ConfigChange) Marshal() (dAtA []byte, err error) + func (m *ConfigChange) MarshalTo(dAtA []byte) (int, error) + func (m *ConfigChange) Reset() + func (m *ConfigChange) Size() (n int) + func (m *ConfigChange) String() string + func (m *ConfigChange) Unmarshal(dAtA []byte) error + func (m *ConfigChange) XXX_DiscardUnknown() + func (m *ConfigChange) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *ConfigChange) XXX_Merge(src proto.Message) + func (m *ConfigChange) XXX_Size() int + func (m *ConfigChange) XXX_Unmarshal(b []byte) error + type ConfigChangeType int32 + const AddNode + const AddObserver + const AddWitness + const RemoveNode + func (ConfigChangeType) EnumDescriptor() ([]byte, []int) + func (x *ConfigChangeType) UnmarshalJSON(data []byte) error + func (x ConfigChangeType) Enum() *ConfigChangeType + func (x ConfigChangeType) String() string + type Entry struct + ClientID uint64 + Cmd []byte + Index uint64 + Key uint64 + RespondedTo uint64 + SeriesID uint64 + Term uint64 + Type EntryType + func (*Entry) Descriptor() ([]byte, []int) + func (*Entry) ProtoMessage() + func (e *Entry) IsConfigChange() bool + func (e *Entry) IsEmpty() bool + func (e *Entry) IsEndOfSessionRequest() bool + func (e *Entry) IsNewSessionRequest() bool + func (e *Entry) IsNoOPSession() bool + func (e *Entry) IsSessionManaged() bool + func (e *Entry) IsUpdateEntry() bool + func (m *Entry) GetClientID() uint64 + func (m *Entry) GetCmd() []byte + func (m *Entry) GetIndex() uint64 + func (m *Entry) GetKey() uint64 + func (m *Entry) GetRespondedTo() uint64 + func (m *Entry) GetSeriesID() uint64 + func (m *Entry) GetTerm() uint64 + func (m *Entry) GetType() EntryType + func (m *Entry) Marshal() (dAtA []byte, err error) + func (m *Entry) Reset() + func (m *Entry) String() string + func (m *Entry) XXX_DiscardUnknown() + func (m *Entry) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Entry) XXX_Merge(src proto.Message) + func (m *Entry) XXX_Size() int + func (m *Entry) XXX_Unmarshal(b []byte) error + func (o *Entry) MarshalTo(buf []byte) (int, error) + func (o *Entry) Size() int + func (o *Entry) SizeUpperLimit() int + func (o *Entry) Unmarshal(data []byte) error + type EntryBatch struct + Entries []Entry + func (*EntryBatch) Descriptor() ([]byte, []int) + func (*EntryBatch) ProtoMessage() + func (m *EntryBatch) GetEntries() []Entry + func (m *EntryBatch) Marshal() (dAtA []byte, err error) + func (m *EntryBatch) MarshalTo(dAtA []byte) (int, error) + func (m *EntryBatch) Reset() + func (m *EntryBatch) Size() (n int) + func (m *EntryBatch) SizeUpperLimit() (n int) + func (m *EntryBatch) String() string + func (m *EntryBatch) Unmarshal(dAtA []byte) error + func (m *EntryBatch) XXX_DiscardUnknown() + func (m *EntryBatch) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *EntryBatch) XXX_Merge(src proto.Message) + func (m *EntryBatch) XXX_Size() int + func (m *EntryBatch) XXX_Unmarshal(b []byte) error + type EntryType int32 + const ApplicationEntry + const ConfigChangeEntry + const EncodedEntry + const MetadataEntry + func (EntryType) EnumDescriptor() ([]byte, []int) + func (x *EntryType) UnmarshalJSON(data []byte) error + func (x EntryType) Enum() *EntryType + func (x EntryType) String() string + type IChunkSink interface + ClusterID func() uint64 + Receive func(chunk Chunk) (bool, bool) + Stop func() + ToNodeID func() uint64 + type Membership struct + Addresses map[uint64]string + ConfigChangeId uint64 + Observers map[uint64]string + Removed map[uint64]bool + Witnesses map[uint64]string + func (*Membership) Descriptor() ([]byte, []int) + func (*Membership) ProtoMessage() + func (m *Membership) GetAddresses() map[uint64]string + func (m *Membership) GetConfigChangeId() uint64 + func (m *Membership) GetObservers() map[uint64]string + func (m *Membership) GetRemoved() map[uint64]bool + func (m *Membership) GetWitnesses() map[uint64]string + func (m *Membership) Marshal() (dAtA []byte, err error) + func (m *Membership) MarshalTo(dAtA []byte) (int, error) + func (m *Membership) Reset() + func (m *Membership) Size() (n int) + func (m *Membership) String() string + func (m *Membership) Unmarshal(dAtA []byte) error + func (m *Membership) XXX_DiscardUnknown() + func (m *Membership) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Membership) XXX_Merge(src proto.Message) + func (m *Membership) XXX_Size() int + func (m *Membership) XXX_Unmarshal(b []byte) error + type Message struct + ClusterId uint64 + Commit uint64 + Entries []Entry + From uint64 + Hint uint64 + HintHigh uint64 + LogIndex uint64 + LogTerm uint64 + Reject bool + Snapshot Snapshot + Term uint64 + To uint64 + Type MessageType + func (*Message) Descriptor() ([]byte, []int) + func (*Message) ProtoMessage() + func (m *Message) GetClusterId() uint64 + func (m *Message) GetCommit() uint64 + func (m *Message) GetEntries() []Entry + func (m *Message) GetFrom() uint64 + func (m *Message) GetHint() uint64 + func (m *Message) GetHintHigh() uint64 + func (m *Message) GetLogIndex() uint64 + func (m *Message) GetLogTerm() uint64 + func (m *Message) GetReject() bool + func (m *Message) GetSnapshot() Snapshot + func (m *Message) GetTerm() uint64 + func (m *Message) GetTo() uint64 + func (m *Message) GetType() MessageType + func (m *Message) Marshal() (dAtA []byte, err error) + func (m *Message) MarshalTo(dAtA []byte) (int, error) + func (m *Message) Reset() + func (m *Message) Size() (n int) + func (m *Message) SizeUpperLimit() int + func (m *Message) String() string + func (m *Message) Unmarshal(dAtA []byte) error + func (m *Message) XXX_DiscardUnknown() + func (m *Message) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Message) XXX_Merge(src proto.Message) + func (m *Message) XXX_Size() int + func (m *Message) XXX_Unmarshal(b []byte) error + type MessageBatch struct + BinVer uint32 + DeploymentId uint64 + Requests []Message + SourceAddress string + func (*MessageBatch) Descriptor() ([]byte, []int) + func (*MessageBatch) ProtoMessage() + func (m *MessageBatch) GetBinVer() uint32 + func (m *MessageBatch) GetDeploymentId() uint64 + func (m *MessageBatch) GetRequests() []Message + func (m *MessageBatch) GetSourceAddress() string + func (m *MessageBatch) Marshal() (dAtA []byte, err error) + func (m *MessageBatch) MarshalTo(dAtA []byte) (int, error) + func (m *MessageBatch) Reset() + func (m *MessageBatch) Size() (n int) + func (m *MessageBatch) SizeUpperLimit() int + func (m *MessageBatch) String() string + func (m *MessageBatch) Unmarshal(dAtA []byte) error + func (m *MessageBatch) XXX_DiscardUnknown() + func (m *MessageBatch) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *MessageBatch) XXX_Merge(src proto.Message) + func (m *MessageBatch) XXX_Size() int + func (m *MessageBatch) XXX_Unmarshal(b []byte) error + type MessageType int32 + const BatchedReadIndex + const CheckQuorum + const ConfigChangeEvent + const Election + const Heartbeat + const HeartbeatResp + const InstallSnapshot + const LeaderHeartbeat + const LeaderTransfer + const LocalTick + const NoOP + const Ping + const Pong + const Propose + const Quiesce + const RateLimit + const ReadIndex + const ReadIndexResp + const Replicate + const ReplicateResp + const RequestVote + const RequestVoteResp + const SnapshotReceived + const SnapshotStatus + const TimeoutNow + const Unreachable + func (MessageType) EnumDescriptor() ([]byte, []int) + func (x *MessageType) UnmarshalJSON(data []byte) error + func (x MessageType) Enum() *MessageType + func (x MessageType) String() string + type RaftDataStatus struct + Address string + BinVer uint32 + DeploymentId uint64 + EntryBatchSize uint64 + HardHash uint64 + Hostname string + LogdbShardCount uint64 + LogdbType string + MaxSessionCount uint64 + StepWorkerCount uint64 + func (*RaftDataStatus) Descriptor() ([]byte, []int) + func (*RaftDataStatus) ProtoMessage() + func (m *RaftDataStatus) GetAddress() string + func (m *RaftDataStatus) GetBinVer() uint32 + func (m *RaftDataStatus) GetDeploymentId() uint64 + func (m *RaftDataStatus) GetEntryBatchSize() uint64 + func (m *RaftDataStatus) GetHardHash() uint64 + func (m *RaftDataStatus) GetHostname() string + func (m *RaftDataStatus) GetLogdbShardCount() uint64 + func (m *RaftDataStatus) GetLogdbType() string + func (m *RaftDataStatus) GetMaxSessionCount() uint64 + func (m *RaftDataStatus) GetStepWorkerCount() uint64 + func (m *RaftDataStatus) Marshal() (dAtA []byte, err error) + func (m *RaftDataStatus) MarshalTo(dAtA []byte) (int, error) + func (m *RaftDataStatus) Reset() + func (m *RaftDataStatus) Size() (n int) + func (m *RaftDataStatus) String() string + func (m *RaftDataStatus) Unmarshal(dAtA []byte) error + func (m *RaftDataStatus) XXX_DiscardUnknown() + func (m *RaftDataStatus) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *RaftDataStatus) XXX_Merge(src proto.Message) + func (m *RaftDataStatus) XXX_Size() int + func (m *RaftDataStatus) XXX_Unmarshal(b []byte) error + type ReadyToRead struct + Index uint64 + SystemCtx SystemCtx + type Response struct + func (*Response) Descriptor() ([]byte, []int) + func (*Response) ProtoMessage() + func (m *Response) Marshal() (dAtA []byte, err error) + func (m *Response) MarshalTo(dAtA []byte) (int, error) + func (m *Response) Reset() + func (m *Response) Size() (n int) + func (m *Response) String() string + func (m *Response) Unmarshal(dAtA []byte) error + func (m *Response) XXX_DiscardUnknown() + func (m *Response) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Response) XXX_Merge(src proto.Message) + func (m *Response) XXX_Size() int + func (m *Response) XXX_Unmarshal(b []byte) error + type Snapshot struct + Checksum []byte + ClusterId uint64 + Dummy bool + FileSize uint64 + Filepath string + Files []*SnapshotFile + Imported bool + Index uint64 + Membership Membership + OnDiskIndex uint64 + Term uint64 + Type StateMachineType + Witness bool + func (*Snapshot) Descriptor() ([]byte, []int) + func (*Snapshot) ProtoMessage() + func (m *Snapshot) GetChecksum() []byte + func (m *Snapshot) GetClusterId() uint64 + func (m *Snapshot) GetDummy() bool + func (m *Snapshot) GetFileSize() uint64 + func (m *Snapshot) GetFilepath() string + func (m *Snapshot) GetFiles() []*SnapshotFile + func (m *Snapshot) GetImported() bool + func (m *Snapshot) GetIndex() uint64 + func (m *Snapshot) GetMembership() Membership + func (m *Snapshot) GetOnDiskIndex() uint64 + func (m *Snapshot) GetTerm() uint64 + func (m *Snapshot) GetType() StateMachineType + func (m *Snapshot) GetWitness() bool + func (m *Snapshot) Marshal() (dAtA []byte, err error) + func (m *Snapshot) MarshalTo(dAtA []byte) (int, error) + func (m *Snapshot) Reset() + func (m *Snapshot) Size() (n int) + func (m *Snapshot) String() string + func (m *Snapshot) Unmarshal(dAtA []byte) error + func (m *Snapshot) XXX_DiscardUnknown() + func (m *Snapshot) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *Snapshot) XXX_Merge(src proto.Message) + func (m *Snapshot) XXX_Size() int + func (m *Snapshot) XXX_Unmarshal(b []byte) error + func (snapshot *Snapshot) Validate(fs vfs.IFS) bool + type SnapshotFile struct + FileId uint64 + FileSize uint64 + Filepath string + Metadata []byte + func (*SnapshotFile) Descriptor() ([]byte, []int) + func (*SnapshotFile) ProtoMessage() + func (f *SnapshotFile) Filename() string + func (m *SnapshotFile) GetFileId() uint64 + func (m *SnapshotFile) GetFileSize() uint64 + func (m *SnapshotFile) GetFilepath() string + func (m *SnapshotFile) GetMetadata() []byte + func (m *SnapshotFile) Marshal() (dAtA []byte, err error) + func (m *SnapshotFile) MarshalTo(dAtA []byte) (int, error) + func (m *SnapshotFile) Reset() + func (m *SnapshotFile) Size() (n int) + func (m *SnapshotFile) String() string + func (m *SnapshotFile) Unmarshal(dAtA []byte) error + func (m *SnapshotFile) XXX_DiscardUnknown() + func (m *SnapshotFile) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *SnapshotFile) XXX_Merge(src proto.Message) + func (m *SnapshotFile) XXX_Size() int + func (m *SnapshotFile) XXX_Unmarshal(b []byte) error + type SnapshotHeader struct + ChecksumType ChecksumType + CompressionType CompressionType + DataStoreSize uint64 + GitVersion string + HeaderChecksum []byte + PayloadChecksum []byte + SessionSize uint64 + UnreliableTime uint64 + Version uint64 + func (*SnapshotHeader) Descriptor() ([]byte, []int) + func (*SnapshotHeader) ProtoMessage() + func (m *SnapshotHeader) GetChecksumType() ChecksumType + func (m *SnapshotHeader) GetCompressionType() CompressionType + func (m *SnapshotHeader) GetDataStoreSize() uint64 + func (m *SnapshotHeader) GetGitVersion() string + func (m *SnapshotHeader) GetHeaderChecksum() []byte + func (m *SnapshotHeader) GetPayloadChecksum() []byte + func (m *SnapshotHeader) GetSessionSize() uint64 + func (m *SnapshotHeader) GetUnreliableTime() uint64 + func (m *SnapshotHeader) GetVersion() uint64 + func (m *SnapshotHeader) Marshal() (dAtA []byte, err error) + func (m *SnapshotHeader) MarshalTo(dAtA []byte) (int, error) + func (m *SnapshotHeader) Reset() + func (m *SnapshotHeader) Size() (n int) + func (m *SnapshotHeader) String() string + func (m *SnapshotHeader) Unmarshal(dAtA []byte) error + func (m *SnapshotHeader) XXX_DiscardUnknown() + func (m *SnapshotHeader) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *SnapshotHeader) XXX_Merge(src proto.Message) + func (m *SnapshotHeader) XXX_Size() int + func (m *SnapshotHeader) XXX_Unmarshal(b []byte) error + type State struct + Commit uint64 + Term uint64 + Vote uint64 + func (*State) Descriptor() ([]byte, []int) + func (*State) ProtoMessage() + func (m *State) GetCommit() uint64 + func (m *State) GetTerm() uint64 + func (m *State) GetVote() uint64 + func (m *State) Marshal() (dAtA []byte, err error) + func (m *State) MarshalTo(dAtA []byte) (int, error) + func (m *State) Reset() + func (m *State) Size() (n int) + func (m *State) String() string + func (m *State) Unmarshal(dAtA []byte) error + func (m *State) XXX_DiscardUnknown() + func (m *State) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) + func (m *State) XXX_Merge(src proto.Message) + func (m *State) XXX_Size() int + func (m *State) XXX_Unmarshal(b []byte) error + type StateMachineType int32 + const ConcurrentStateMachine + const OnDiskStateMachine + const RegularStateMachine + const UnknownStateMachine + func (StateMachineType) EnumDescriptor() ([]byte, []int) + func (x *StateMachineType) UnmarshalJSON(data []byte) error + func (x StateMachineType) Enum() *StateMachineType + func (x StateMachineType) String() string + type SystemCtx struct + High uint64 + Low uint64 + type Update struct + ClusterID uint64 + CommittedEntries []Entry + DroppedEntries []Entry + DroppedReadIndexes []SystemCtx + EntriesToSave []Entry + FastApply bool + LastApplied uint64 + Messages []Message + MoreCommittedEntries bool + NodeID uint64 + ReadyToReads []ReadyToRead + Snapshot Snapshot + UpdateCommit UpdateCommit + func (ud *Update) HasUpdate() bool + type UpdateCommit struct + LastApplied uint64 + Processed uint64 + ReadyToRead uint64 + StableLogTerm uint64 + StableLogTo uint64 + StableSnapshotTo uint64 Other modules containing this package github.com/mkawserm/dragonboat