Documentation
¶
Index ¶
- Constants
- Variables
- func CollectCapacityStat(shardID uint64, logPath string, item *stat.LogKeeperStatItem)
- func ParseLoadErr(retryTimes int, shardID uint64, err error, logPath string, ...) (isBreak bool)
- func TransMeasurementInfos2Bytes(dataTypes []int64, rpInfos *meta.RetentionPolicyInfo) ([]byte, error)
- func UpdateCapacityStatMap(retryTimes int, shardCap int64, shardID uint64, item *stat.LogKeeperStatItem) (isRetry bool)
- type AddrRewriter
- type AnalysisCache
- type AnalysisRequest
- type AnalysisRequestType
- type AnalysisResponse
- type AssignEvent
- type AssignState
- type Backup
- type BalanceManager
- type BaseEvent
- type BaseHandler
- type CapacityStat
- type ClusterManager
- func (cm *ClusterManager) Close()
- func (cm *ClusterManager) GetEventCh() chan serf.Event
- func (cm *ClusterManager) PreviousNode() []*serf.PreviousNode
- func (cm *ClusterManager) SetMemberIds(memberIds map[uint64]struct{})
- func (cm *ClusterManager) SetStop(stop int32)
- func (cm *ClusterManager) Start()
- func (cm *ClusterManager) Stop()
- func (cm *ClusterManager) WaitEventDone()
- type CreateNode
- type CreateSqlNode
- type DbPtIds
- type EventResultInfo
- type EventType
- type Execute
- type GetContinuousQueryLease
- type GetDownSampleInfo
- type GetMeasurementInfo
- type GetMeasurementsInfo
- type GetRpMstInfos
- type GetShardInfo
- type GetStreamInfo
- type HeartbeatInfo
- type IStore
- type MSMState
- type MetaServer
- type MetaStoreInterface
- type MigrateEvent
- type MigrateStateMachine
- type MoveEvent
- type NextAction
- type Peers
- type Ping
- type Processor
- type RPCHandler
- type RaftInterface
- type RegisterQueryIDOffset
- type Report
- type ScheduleType
- type SendSysCtrlToMeta
- type Service
- type ShardStat
- type ShowCluster
- type Snapshot
- type SnapshotV2
- type Sql2MetaHeartbeat
- type Store
- func (s *Store) ApplyCmd(cmd *mproto.Command) error
- func (s *Store) ClearCapStatMap()
- func (s *Store) ClearOpsMap()
- func (s *Store) CloneDatabases() map[string]*meta.DatabaseInfo
- func (s *Store) Close() error
- func (s *Store) CreateSqlNode(httpHost string, gossipAddr string) ([]byte, error)
- func (s *Store) ExpandGroups() error
- func (s *Store) GetClose() chan struct{}
- func (s *Store) GetClusterManager() *ClusterManager
- func (s *Store) GetData() *meta.Data
- func (s *Store) GetDownSampleInfo() ([]byte, error)
- func (s *Store) GetNodeTmpIndex(role mclient.Role, nodeId uint64) (uint64, error)
- func (s *Store) GetRpMstInfos(db, rp string, dataTypes []int64) ([]byte, error)
- func (s *Store) GetUserInfo() ([]byte, error)
- func (s *Store) IsLeader() bool
- func (s *Store) Join(n *meta.NodeInfo) (*meta.NodeInfo, error)
- func (s *Store) ModifyRepDBMasterPt(db string, rgId uint32, newMasterPtId uint32) error
- func (s *Store) Open(raftln net.Listener) error
- func (s *Store) RemoveNode(nodeIds []uint64) error
- func (s *Store) SetClusterManager(cm *ClusterManager)
- func (s *Store) SetData(data *meta.Data)
- func (s *Store) SetSegregateNodeStatus(status []uint64, nodeIds []uint64) error
- func (s *Store) ShowCluster(body []byte) ([]byte, error)
- func (s *Store) SpecialCtlData(cmd string) error
- func (s *Store) TryUpdateNodeTmpIndex(role mclient.Role, index uint64, nodeId uint64)
- func (s *Store) UpLoadCapacityStat()
- func (s *Store) UpdateCacheDataV2()
- func (s *Store) UpdateLoad(b []byte) error
- func (s *Store) UpdateNodeTmpIndex(role mclient.Role, index uint64, nodeId uint64)
- func (s *Store) UpdateOpsMapCacheBytes() error
- func (s *Store) UpdateSqlNodeStatus(id uint64, status int32, lTime uint64, gossipPort string) error
- func (s *Store) WaitNodeTakeOverDone(nodeIds []uint64, address []string, preSegregateStatus []uint64) error
- type Update
- type VerifyDataNodeStatus
Constants ¶
View Source
const ( HeartTimeOut = 15 LockTimeOut = 15 )
View Source
const ( Stopped = iota Running Stopping )
View Source
const ( DeleteDatabase = iota DeleteRp DeleteMeasurement )
View Source
const (
// Default sqlite database
DefaultDatabase = "sqlite.db"
)
Retention policy settings.
View Source
const (
MuxHeader = 8
)
View Source
const SerialBalanceAlgoName string = "v1.0"
View Source
const (
UpdateTmpIndexGap = 20
)
Raft configuration.
Variables ¶
View Source
var (
CapacityStatMap = &sync.Map{}
)
View Source
var ErrRaftNotOpen = fmt.Errorf("raft instance is not ready")
View Source
var ErrRaftTransOpenFailed = fmt.Errorf("raft trans open failed")
Functions ¶
func CollectCapacityStat ¶ added in v1.3.0
func CollectCapacityStat(shardID uint64, logPath string, item *stat.LogKeeperStatItem)
func ParseLoadErr ¶ added in v1.3.0
func TransMeasurementInfos2Bytes ¶ added in v1.0.0
func TransMeasurementInfos2Bytes(dataTypes []int64, rpInfos *meta.RetentionPolicyInfo) ([]byte, error)
func UpdateCapacityStatMap ¶ added in v1.3.0
Types ¶
type AddrRewriter ¶
type AddrRewriter struct {
// contains filtered or unexported fields
}
func NewAddrRewriter ¶
func NewAddrRewriter() *AddrRewriter
func (*AddrRewriter) RewriteHost ¶
func (r *AddrRewriter) RewriteHost(addr string) string
func (*AddrRewriter) SetHostname ¶
func (r *AddrRewriter) SetHostname(hostname string)
type AnalysisCache ¶
type AnalysisRequest ¶
type AnalysisRequest struct { AnalysisCache Req AnalysisRequestType `json:"req"` }
type AnalysisRequestType ¶
type AnalysisRequestType int
const ( AquireLock AnalysisRequestType = iota Heart ReleaseLock )
type AnalysisResponse ¶
type AnalysisResponse struct { AnalysisCache Error string `json:"error"` Ok bool `json:"ok"` }
type AssignEvent ¶
type AssignEvent struct { BaseEvent // contains filtered or unexported fields }
func NewAssignEvent ¶
func (*AssignEvent) String ¶ added in v1.0.0
func (e *AssignEvent) String() string
type AssignState ¶
type AssignState int
const ( Init AssignState = 0 StartAssign AssignState = 8 AssignFailed AssignState = 9 Assigned AssignState = 10 Final AssignState = 11 )
func (AssignState) String ¶
func (s AssignState) String() string
type Backup ¶ added in v1.3.0
type Backup struct { IsRemote bool IsNode bool BackupPath string // contains filtered or unexported fields }
func (*Backup) RunBackupMeta ¶ added in v1.3.0
type BalanceManager ¶ added in v1.0.0
type BalanceManager struct {
// contains filtered or unexported fields
}
func NewBalanceManager ¶ added in v1.0.0
func NewBalanceManager(algo string) *BalanceManager
func (*BalanceManager) Start ¶ added in v1.0.0
func (b *BalanceManager) Start()
Start balance goroutine
func (*BalanceManager) Stop ¶ added in v1.0.0
func (b *BalanceManager) Stop()
Stop balance goroutine
type BaseHandler ¶
type BaseHandler struct {
// contains filtered or unexported fields
}
func (*BaseHandler) InitHandler ¶
func (h *BaseHandler) InitHandler(store MetaStoreInterface, conf *config.Meta, closing chan struct{})
type CapacityStat ¶ added in v1.3.0
type ClusterManager ¶
type ClusterManager struct {
// contains filtered or unexported fields
}
func CreateClusterManager ¶ added in v1.0.0
func CreateClusterManager() *ClusterManager
func NewClusterManager ¶
func NewClusterManager(store storeInterface) *ClusterManager
func (*ClusterManager) Close ¶
func (cm *ClusterManager) Close()
func (*ClusterManager) GetEventCh ¶
func (cm *ClusterManager) GetEventCh() chan serf.Event
func (*ClusterManager) PreviousNode ¶
func (cm *ClusterManager) PreviousNode() []*serf.PreviousNode
func (*ClusterManager) SetMemberIds ¶ added in v1.1.1
func (cm *ClusterManager) SetMemberIds(memberIds map[uint64]struct{})
func (*ClusterManager) SetStop ¶ added in v1.1.1
func (cm *ClusterManager) SetStop(stop int32)
func (*ClusterManager) Start ¶
func (cm *ClusterManager) Start()
func (*ClusterManager) Stop ¶
func (cm *ClusterManager) Stop()
func (*ClusterManager) WaitEventDone ¶
func (cm *ClusterManager) WaitEventDone()
type CreateNode ¶
type CreateNode struct { BaseHandler // contains filtered or unexported fields }
func (*CreateNode) Instance ¶
func (h *CreateNode) Instance() RPCHandler
func (*CreateNode) SetRequestMsg ¶
func (h *CreateNode) SetRequestMsg(data transport.Codec) error
type CreateSqlNode ¶ added in v1.3.0
type CreateSqlNode struct { BaseHandler // contains filtered or unexported fields }
func (*CreateSqlNode) Instance ¶ added in v1.3.0
func (h *CreateSqlNode) Instance() RPCHandler
func (*CreateSqlNode) Process ¶ added in v1.3.0
func (h *CreateSqlNode) Process() (transport.Codec, error)
func (*CreateSqlNode) SetRequestMsg ¶ added in v1.3.0
func (h *CreateSqlNode) SetRequestMsg(data transport.Codec) error
type EventResultInfo ¶
type EventResultInfo struct {
// contains filtered or unexported fields
}
type Execute ¶
type Execute struct { BaseHandler // contains filtered or unexported fields }
func (*Execute) Instance ¶
func (h *Execute) Instance() RPCHandler
type GetContinuousQueryLease ¶ added in v1.1.0
type GetContinuousQueryLease struct { BaseHandler // contains filtered or unexported fields }
func (*GetContinuousQueryLease) Instance ¶ added in v1.1.0
func (h *GetContinuousQueryLease) Instance() RPCHandler
func (*GetContinuousQueryLease) Process ¶ added in v1.1.0
func (h *GetContinuousQueryLease) Process() (transport.Codec, error)
func (*GetContinuousQueryLease) SetRequestMsg ¶ added in v1.1.0
func (h *GetContinuousQueryLease) SetRequestMsg(data transport.Codec) error
type GetDownSampleInfo ¶ added in v1.0.0
type GetDownSampleInfo struct { BaseHandler // contains filtered or unexported fields }
func (*GetDownSampleInfo) Instance ¶ added in v1.0.0
func (h *GetDownSampleInfo) Instance() RPCHandler
func (*GetDownSampleInfo) Process ¶ added in v1.0.0
func (h *GetDownSampleInfo) Process() (transport.Codec, error)
func (*GetDownSampleInfo) SetRequestMsg ¶ added in v1.0.0
func (h *GetDownSampleInfo) SetRequestMsg(data transport.Codec) error
type GetMeasurementInfo ¶ added in v1.0.0
type GetMeasurementInfo struct { BaseHandler // contains filtered or unexported fields }
func (*GetMeasurementInfo) Instance ¶ added in v1.0.0
func (h *GetMeasurementInfo) Instance() RPCHandler
func (*GetMeasurementInfo) Process ¶ added in v1.0.0
func (h *GetMeasurementInfo) Process() (transport.Codec, error)
func (*GetMeasurementInfo) SetRequestMsg ¶ added in v1.0.0
func (h *GetMeasurementInfo) SetRequestMsg(data transport.Codec) error
type GetMeasurementsInfo ¶ added in v1.1.0
type GetMeasurementsInfo struct { BaseHandler // contains filtered or unexported fields }
func (*GetMeasurementsInfo) Instance ¶ added in v1.1.0
func (h *GetMeasurementsInfo) Instance() RPCHandler
func (*GetMeasurementsInfo) Process ¶ added in v1.1.0
func (h *GetMeasurementsInfo) Process() (transport.Codec, error)
func (*GetMeasurementsInfo) SetRequestMsg ¶ added in v1.1.0
func (h *GetMeasurementsInfo) SetRequestMsg(data transport.Codec) error
type GetRpMstInfos ¶ added in v1.0.0
type GetRpMstInfos struct { BaseHandler // contains filtered or unexported fields }
func (*GetRpMstInfos) Instance ¶ added in v1.0.0
func (h *GetRpMstInfos) Instance() RPCHandler
func (*GetRpMstInfos) Process ¶ added in v1.0.0
func (h *GetRpMstInfos) Process() (transport.Codec, error)
func (*GetRpMstInfos) SetRequestMsg ¶ added in v1.0.0
func (h *GetRpMstInfos) SetRequestMsg(data transport.Codec) error
type GetShardInfo ¶
type GetShardInfo struct { BaseHandler // contains filtered or unexported fields }
func (*GetShardInfo) Instance ¶
func (h *GetShardInfo) Instance() RPCHandler
func (*GetShardInfo) SetRequestMsg ¶
func (h *GetShardInfo) SetRequestMsg(data transport.Codec) error
type GetStreamInfo ¶ added in v1.0.0
type GetStreamInfo struct { BaseHandler // contains filtered or unexported fields }
func (*GetStreamInfo) Instance ¶ added in v1.0.0
func (h *GetStreamInfo) Instance() RPCHandler
func (*GetStreamInfo) Process ¶ added in v1.0.0
func (h *GetStreamInfo) Process() (transport.Codec, error)
func (*GetStreamInfo) SetRequestMsg ¶ added in v1.0.0
func (h *GetStreamInfo) SetRequestMsg(data transport.Codec) error
type HeartbeatInfo ¶ added in v1.1.0
type MetaServer ¶
type MetaServer struct {
// contains filtered or unexported fields
}
func NewMetaServer ¶
func NewMetaServer(addr string, store MetaStoreInterface, conf *config.Meta) *MetaServer
func (*MetaServer) Start ¶
func (s *MetaServer) Start() error
func (*MetaServer) Stop ¶
func (s *MetaServer) Stop()
type MetaStoreInterface ¶
type MetaStoreInterface interface { CreateSqlNode(httpAddr string, gossopAddr string) ([]byte, error) IsLeader() bool Join(n *meta.NodeInfo) (*meta.NodeInfo, error) UpdateLoad(b []byte) error GetDownSampleInfo() ([]byte, error) GetRpMstInfos(db, rp string, dataTypes []int64) ([]byte, error) GetUserInfo() ([]byte, error) ShowCluster(body []byte) ([]byte, error) // contains filtered or unexported methods }
type MigrateEvent ¶
type MigrateEvent interface { String() string // contains filtered or unexported methods }
type MigrateStateMachine ¶
type MigrateStateMachine struct {
// contains filtered or unexported fields
}
func NewMigrateStateMachine ¶ added in v1.0.0
func NewMigrateStateMachine() *MigrateStateMachine
func (*MigrateStateMachine) CheckNodeEventExsit ¶ added in v1.1.1
func (m *MigrateStateMachine) CheckNodeEventExsit(nodeIds []uint64) bool
exsit: return true
func (*MigrateStateMachine) Start ¶ added in v1.0.0
func (m *MigrateStateMachine) Start()
func (*MigrateStateMachine) Stop ¶ added in v1.0.0
func (m *MigrateStateMachine) Stop()
type MoveEvent ¶ added in v1.0.0
type MoveEvent struct { BaseEvent // contains filtered or unexported fields }
func NewMoveEvent ¶ added in v1.0.0
func (*MoveEvent) StringForTest ¶ added in v1.1.0
type NextAction ¶
type NextAction int
const ( ActionContinue NextAction = iota ActionWait ActionFinish ActionError )
type Peers ¶
type Peers struct { BaseHandler // contains filtered or unexported fields }
func (*Peers) Instance ¶
func (h *Peers) Instance() RPCHandler
type Ping ¶
type Ping struct { BaseHandler // contains filtered or unexported fields }
func (*Ping) Instance ¶
func (h *Ping) Instance() RPCHandler
type Processor ¶
type Processor struct {
// contains filtered or unexported fields
}
func NewProcessor ¶
func NewProcessor(conf *config.Meta, store MetaStoreInterface) *Processor
type RPCHandler ¶
type RPCHandler interface { SetRequestMsg(transport.Codec) error Process() (transport.Codec, error) Instance() RPCHandler InitHandler(MetaStoreInterface, *config.Meta, chan struct{}) }
func New ¶
func New(typ uint8) RPCHandler
type RaftInterface ¶ added in v1.0.0
type RegisterQueryIDOffset ¶ added in v1.1.0
type RegisterQueryIDOffset struct { BaseHandler // contains filtered or unexported fields }
func (*RegisterQueryIDOffset) Instance ¶ added in v1.1.0
func (h *RegisterQueryIDOffset) Instance() RPCHandler
func (*RegisterQueryIDOffset) Process ¶ added in v1.1.0
func (h *RegisterQueryIDOffset) Process() (transport.Codec, error)
func (*RegisterQueryIDOffset) SetRequestMsg ¶ added in v1.1.0
func (h *RegisterQueryIDOffset) SetRequestMsg(data transport.Codec) error
type Report ¶
type Report struct { BaseHandler // contains filtered or unexported fields }
func (*Report) Instance ¶
func (h *Report) Instance() RPCHandler
type ScheduleType ¶
type ScheduleType int
const ( ScheduleNormal ScheduleType = iota ScheduleRetry ScheduleNone )
type SendSysCtrlToMeta ¶ added in v1.2.0
type SendSysCtrlToMeta struct { BaseHandler // contains filtered or unexported fields }
func (*SendSysCtrlToMeta) Instance ¶ added in v1.2.0
func (h *SendSysCtrlToMeta) Instance() RPCHandler
func (*SendSysCtrlToMeta) Process ¶ added in v1.2.0
func (h *SendSysCtrlToMeta) Process() (transport.Codec, error)
func (*SendSysCtrlToMeta) SetRequestMsg ¶ added in v1.2.0
func (h *SendSysCtrlToMeta) SetRequestMsg(data transport.Codec) error
type Service ¶
type Service struct { RaftListener net.Listener Version string Logger *logger.Logger Node *metaclient.Node // contains filtered or unexported fields }
func NewService ¶
NewService returns a new instance of Service.
func (*Service) GetClusterManager ¶
func (s *Service) GetClusterManager() *ClusterManager
func (*Service) SetStatisticsPusher ¶ added in v1.0.0
func (s *Service) SetStatisticsPusher(pusher *statisticsPusher.StatisticsPusher)
func (*Service) StartReportServer ¶ added in v1.0.0
func (s *Service) StartReportServer()
StartReportServer starts report server.
type ShowCluster ¶ added in v1.3.0
type ShowCluster struct { BaseHandler // contains filtered or unexported fields }
func (*ShowCluster) Instance ¶ added in v1.3.0
func (h *ShowCluster) Instance() RPCHandler
func (*ShowCluster) Process ¶ added in v1.3.0
func (h *ShowCluster) Process() (transport.Codec, error)
func (*ShowCluster) SetRequestMsg ¶ added in v1.3.0
func (h *ShowCluster) SetRequestMsg(data transport.Codec) error
type Snapshot ¶
type Snapshot struct { BaseHandler // contains filtered or unexported fields }
func (*Snapshot) Instance ¶
func (h *Snapshot) Instance() RPCHandler
type SnapshotV2 ¶ added in v1.3.0
type SnapshotV2 struct { BaseHandler // contains filtered or unexported fields }
func (*SnapshotV2) Instance ¶ added in v1.3.0
func (h *SnapshotV2) Instance() RPCHandler
func (*SnapshotV2) Process ¶ added in v1.3.0
func (h *SnapshotV2) Process() (transport.Codec, error)
func (*SnapshotV2) SetRequestMsg ¶ added in v1.3.0
func (h *SnapshotV2) SetRequestMsg(data transport.Codec) error
type Sql2MetaHeartbeat ¶ added in v1.1.0
type Sql2MetaHeartbeat struct { BaseHandler // contains filtered or unexported fields }
func (*Sql2MetaHeartbeat) Instance ¶ added in v1.1.0
func (h *Sql2MetaHeartbeat) Instance() RPCHandler
func (*Sql2MetaHeartbeat) Process ¶ added in v1.1.0
func (h *Sql2MetaHeartbeat) Process() (transport.Codec, error)
func (*Sql2MetaHeartbeat) SetRequestMsg ¶ added in v1.1.0
func (h *Sql2MetaHeartbeat) SetRequestMsg(data transport.Codec) error
type Store ¶
type Store struct { Logger *logger.Logger Node *mclient.Node NetStore interface { GetShardSplitPoints(node *meta.DataNode, database string, pt uint32, shardId uint64, idxes []int64) ([]string, error) DeleteDatabase(node *meta.DataNode, database string, pt uint32) error DeleteRetentionPolicy(node *meta.DataNode, db string, rp string, pt uint32) error DeleteMeasurement(node *meta.DataNode, db string, rp string, name string, shardIds []uint64) error MigratePt(nodeID uint64, data transport.Codec, cb transport.Callback) error SendSegregateNodeCmds(nodeIDs []uint64, address []string) (int, error) } UseIncSyncData bool // contains filtered or unexported fields }
func (*Store) ClearCapStatMap ¶ added in v1.3.0
func (s *Store) ClearCapStatMap()
func (*Store) ClearOpsMap ¶ added in v1.3.0
func (s *Store) ClearOpsMap()
func (*Store) CloneDatabases ¶ added in v1.3.0
func (s *Store) CloneDatabases() map[string]*meta.DatabaseInfo
func (*Store) CreateSqlNode ¶ added in v1.3.0
func (*Store) ExpandGroups ¶ added in v1.0.0
func (*Store) GetClusterManager ¶
func (s *Store) GetClusterManager() *ClusterManager
func (*Store) GetDownSampleInfo ¶ added in v1.0.0
func (*Store) GetNodeTmpIndex ¶ added in v1.3.0
func (*Store) GetRpMstInfos ¶ added in v1.0.0
func (*Store) GetUserInfo ¶ added in v1.0.0
func (*Store) ModifyRepDBMasterPt ¶ added in v1.3.0
func (*Store) RemoveNode ¶ added in v1.1.1
func (*Store) SetClusterManager ¶
func (s *Store) SetClusterManager(cm *ClusterManager)
func (*Store) SetSegregateNodeStatus ¶ added in v1.1.1
func (*Store) ShowCluster ¶ added in v1.3.0
func (*Store) SpecialCtlData ¶ added in v1.1.1
cmd sample: limit|192.168.0.11,192.168.0.12 or unlimit|xxxx or delete|xxxx
func (*Store) TryUpdateNodeTmpIndex ¶ added in v1.3.0
func (*Store) UpLoadCapacityStat ¶ added in v1.3.0
func (s *Store) UpLoadCapacityStat()
func (*Store) UpdateCacheDataV2 ¶ added in v1.3.0
func (s *Store) UpdateCacheDataV2()
func (*Store) UpdateLoad ¶
func (*Store) UpdateNodeTmpIndex ¶ added in v1.3.0
func (*Store) UpdateOpsMapCacheBytes ¶ added in v1.3.0
func (*Store) UpdateSqlNodeStatus ¶ added in v1.3.0
type Update ¶
type Update struct { BaseHandler // contains filtered or unexported fields }
func (*Update) Instance ¶
func (h *Update) Instance() RPCHandler
type VerifyDataNodeStatus ¶ added in v1.1.1
type VerifyDataNodeStatus struct { BaseHandler // contains filtered or unexported fields }
func (*VerifyDataNodeStatus) Instance ¶ added in v1.1.1
func (h *VerifyDataNodeStatus) Instance() RPCHandler
func (*VerifyDataNodeStatus) Process ¶ added in v1.1.1
func (h *VerifyDataNodeStatus) Process() (transport.Codec, error)
func (*VerifyDataNodeStatus) SetRequestMsg ¶ added in v1.1.1
func (h *VerifyDataNodeStatus) SetRequestMsg(data transport.Codec) error
Source Files
¶
- analysis.go
- assign_event.go
- backup.go
- balance_manager.go
- balance_store.go
- cluster_manager.go
- continuous_query.go
- handler.go
- handlers.gen.go
- handlers_process.go
- member_event.go
- member_event_handler.go
- meta_server.go
- migrate_event.go
- migrate_state_machine.go
- move_event.go
- processor.go
- raft_wrapper.go
- raft_wrapper_local.go
- service.go
- snapshot.go
- store.go
- store_debug.go
- store_fsm.go
- validate.go
Click to show internal directories.
Click to hide internal directories.