const DefaultSnapshotCount …
const DefaultSnapshotCatchUpEntries …
const StoreClusterPrefix …
const StoreKeysPrefix …
const HealthInterval …
const purgeFileInterval …
const maxInFlightMsgSnap …
const releaseDelayAfterSnapshot …
const maxPendingRevokes …
const recommendedMaxRequestBytes …
const readyPercent …
const DowngradeEnabledPath …
var monitorVersionInterval …
var recommendedMaxRequestBytesString …
var storeMemberAttributeRegexp …
func init() { … }
type Response …
type ServerV2 …
type ServerV3 …
func (s *EtcdServer) ClientCertAuthEnabled() bool { … }
type Server …
type EtcdServer …
type backendHooks …
func (bh *backendHooks) OnPreCommitUnsafe(tx backend.BatchTx) { … }
func (bh *backendHooks) SetConfState(confState *raftpb.ConfState) { … }
func NewServer(cfg config.ServerConfig) (srv *EtcdServer, err error) { … }
func assertNoV2StoreContent(lg *zap.Logger, st v2store.Store, deprecationStage config.V2DeprecationEnum) error { … }
func (s *EtcdServer) Logger() *zap.Logger { … }
func (s *EtcdServer) Config() config.ServerConfig { … }
func tickToDur(ticks int, tickMs uint) string { … }
func (s *EtcdServer) adjustTicks() { … }
func (s *EtcdServer) Start() { … }
func (s *EtcdServer) start() { … }
func (s *EtcdServer) purgeFile() { … }
func (s *EtcdServer) Cluster() api.Cluster { … }
func (s *EtcdServer) ApplyWait() <-chan struct{ … }
type ServerPeer …
func (s *EtcdServer) LeaseHandler() http.Handler { … }
func (s *EtcdServer) RaftHandler() http.Handler { … }
type ServerPeerV2 …
func (s *EtcdServer) DowngradeInfo() *membership.DowngradeInfo { … }
type downgradeEnabledHandler …
func (s *EtcdServer) DowngradeEnabledHandler() http.Handler { … }
func (h *downgradeEnabledHandler) ServeHTTP(w http.ResponseWriter, r *http.Request) { … }
func (s *EtcdServer) Process(ctx context.Context, m raftpb.Message) error { … }
func (s *EtcdServer) IsIDRemoved(id uint64) bool { … }
func (s *EtcdServer) ReportUnreachable(id uint64) { … }
func (s *EtcdServer) ReportSnapshot(id uint64, status raft.SnapshotStatus) { … }
type etcdProgress …
type raftReadyHandler …
func (s *EtcdServer) run() { … }
func (s *EtcdServer) revokeExpiredLeases(leases []*lease.Lease) { … }
func (s *EtcdServer) isActive() bool { … }
func (s *EtcdServer) ensureLeadership() bool { … }
func (s *EtcdServer) Cleanup() { … }
func (s *EtcdServer) applyAll(ep *etcdProgress, apply *apply) { … }
func (s *EtcdServer) applySnapshot(ep *etcdProgress, apply *apply) { … }
func (s *EtcdServer) applyEntries(ep *etcdProgress, apply *apply) { … }
func (s *EtcdServer) triggerSnapshot(ep *etcdProgress) { … }
func (s *EtcdServer) hasMultipleVotingMembers() bool { … }
func (s *EtcdServer) isLeader() bool { … }
func (s *EtcdServer) MoveLeader(ctx context.Context, lead, transferee uint64) error { … }
func (s *EtcdServer) TransferLeadership() error { … }
func (s *EtcdServer) HardStop() { … }
func (s *EtcdServer) Stop() { … }
func (s *EtcdServer) ReadyNotify() <-chan struct{ … }
func (s *EtcdServer) stopWithDelay(d time.Duration, err error) { … }
func (s *EtcdServer) StopNotify() <-chan struct{ … }
func (s *EtcdServer) StoppingNotify() <-chan struct{ … }
func (s *EtcdServer) SelfStats() []byte { … }
func (s *EtcdServer) LeaderStats() []byte { … }
func (s *EtcdServer) StoreStats() []byte { … }
func (s *EtcdServer) checkMembershipOperationPermission(ctx context.Context) error { … }
func (s *EtcdServer) AddMember(ctx context.Context, memb membership.Member) ([]*membership.Member, error) { … }
func (s *EtcdServer) mayAddMember(memb membership.Member) error { … }
func (s *EtcdServer) RemoveMember(ctx context.Context, id uint64) ([]*membership.Member, error) { … }
func (s *EtcdServer) PromoteMember(ctx context.Context, id uint64) ([]*membership.Member, error) { … }
func (s *EtcdServer) promoteMember(ctx context.Context, id uint64) ([]*membership.Member, error) { … }
func (s *EtcdServer) mayPromoteMember(id types.ID) error { … }
func (s *EtcdServer) isLearnerReady(id uint64) error { … }
func (s *EtcdServer) mayRemoveMember(id types.ID) error { … }
func (s *EtcdServer) UpdateMember(ctx context.Context, memb membership.Member) ([]*membership.Member, error) { … }
func (s *EtcdServer) setCommittedIndex(v uint64) { … }
func (s *EtcdServer) getCommittedIndex() uint64 { … }
func (s *EtcdServer) setAppliedIndex(v uint64) { … }
func (s *EtcdServer) getAppliedIndex() uint64 { … }
func (s *EtcdServer) setTerm(v uint64) { … }
func (s *EtcdServer) getTerm() uint64 { … }
func (s *EtcdServer) setLead(v uint64) { … }
func (s *EtcdServer) getLead() uint64 { … }
func (s *EtcdServer) LeaderChangedNotify() <-chan struct{ … }
func (s *EtcdServer) FirstCommitInTermNotify() <-chan struct{ … }
type RaftStatusGetter …
func (s *EtcdServer) ID() types.ID { … }
func (s *EtcdServer) Leader() types.ID { … }
func (s *EtcdServer) Lead() uint64 { … }
func (s *EtcdServer) CommittedIndex() uint64 { … }
func (s *EtcdServer) AppliedIndex() uint64 { … }
func (s *EtcdServer) Term() uint64 { … }
type confChangeResponse …
func (s *EtcdServer) configure(ctx context.Context, cc raftpb.ConfChange) ([]*membership.Member, error) { … }
func (s *EtcdServer) sync(timeout time.Duration) { … }
func (s *EtcdServer) publishV3(timeout time.Duration) { … }
func (s *EtcdServer) publish(timeout time.Duration) { … }
func (s *EtcdServer) sendMergedSnap(merged snap.Message) { … }
func (s *EtcdServer) apply(
es []raftpb.Entry,
confState *raftpb.ConfState,
) (appliedt uint64, appliedi uint64, shouldStop bool) { … }
func (s *EtcdServer) applyEntryNormal(e *raftpb.Entry) { … }
func (s *EtcdServer) notifyAboutFirstCommitInTerm() { … }
func (s *EtcdServer) applyConfChange(cc raftpb.ConfChange, confState *raftpb.ConfState, shouldApplyV3 membership.ShouldApplyV3) (bool, error) { … }
func (s *EtcdServer) snapshot(snapi uint64, confState raftpb.ConfState) { … }
func (s *EtcdServer) CutPeer(id types.ID) { … }
func (s *EtcdServer) MendPeer(id types.ID) { … }
func (s *EtcdServer) PauseSending() { … }
func (s *EtcdServer) ResumeSending() { … }
func (s *EtcdServer) ClusterVersion() *semver.Version { … }
func (s *EtcdServer) monitorVersions() { … }
func (s *EtcdServer) monitorKVHash() { … }
func (s *EtcdServer) monitorCompactHash() { … }
func (s *EtcdServer) updateClusterVersionV2(ver string) { … }
func (s *EtcdServer) updateClusterVersionV3(ver string) { … }
func (s *EtcdServer) monitorDowngrade() { … }
func (s *EtcdServer) parseProposeCtxErr(err error, start time.Time) error { … }
func (s *EtcdServer) KV() mvcc.WatchableKV { … }
func (s *EtcdServer) Backend() backend.Backend { … }
func (s *EtcdServer) AuthStore() auth.AuthStore { … }
func (s *EtcdServer) restoreAlarms() error { … }
func (s *EtcdServer) GoAttach(f func()) { … }
func (s *EtcdServer) Alarms() []*pb.AlarmMember { … }
func (s *EtcdServer) IsLearner() bool { … }
func (s *EtcdServer) IsMemberExist(id types.ID) bool { … }
func (s *EtcdServer) raftStatus() raft.Status { … }
func (s *EtcdServer) getTxPostLockInsideApplyHook() func() { … }
func maybeDefragBackend(cfg config.ServerConfig, be backend.Backend) error { … }
func (s *EtcdServer) CorruptionChecker() CorruptionChecker { … }