etcdraft

package
v2.1.1+incompatible Latest Latest
Warning

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

Go to latest
Published: Jun 1, 2020 License: Apache-2.0 Imports: 41 Imported by: 390

Documentation

Index

Constants

View Source
const (
	BYTE = 1 << (10 * iota)
	KILOBYTE
	MEGABYTE
	GIGABYTE
	TERABYTE
)
View Source
const (
	// DefaultSnapshotCatchUpEntries is the default number of entries
	// to preserve in memory when a snapshot is taken. This is for
	// slow followers to catch up.
	DefaultSnapshotCatchUpEntries = uint64(4)

	// DefaultSnapshotIntervalSize is the default snapshot interval. It is
	// used if SnapshotIntervalSize is not provided in channel config options.
	// It is needed to enforce snapshot being set.
	DefaultSnapshotIntervalSize = 16 * MEGABYTE

	// DefaultEvictionSuspicion is the threshold that a node will start
	// suspecting its own eviction if it has been leaderless for this
	// period of time.
	DefaultEvictionSuspicion = time.Minute * 10

	// DefaultLeaderlessCheckInterval is the interval that a chain checks
	// its own leadership status.
	DefaultLeaderlessCheckInterval = time.Second * 10
)

Variables

View Source
var (
	ActiveNodesOpts = metrics.GaugeOpts{
		Namespace:    "consensus",
		Subsystem:    "etcdraft",
		Name:         "active_nodes",
		Help:         "Number of active nodes in this channel.",
		LabelNames:   []string{"channel"},
		StatsdFormat: "%{#fqname}.%{channel}",
	}
)
View Source
var MaxSnapshotFiles = 4

MaxSnapshotFiles defines max number of etcd/raft snapshot files to retain on filesystem. Snapshot files are read from newest to oldest, until first intact file is found. The more snapshot files we keep around, the more we mitigate the impact of a corrupted snapshots. This is exported for testing purpose. This MUST be greater equal than 1.

Functions

func CheckConfigMetadata added in v1.4.1

func CheckConfigMetadata(metadata *etcdraft.ConfigMetadata) error

CheckConfigMetadata validates Raft config metadata

func ConfChange added in v1.4.1

func ConfChange(blockMetadata *etcdraft.BlockMetadata, confState *raftpb.ConfState) *raftpb.ConfChange

ConfChange computes Raft configuration changes based on current Raft configuration state and consenters IDs stored in RaftMetadata.

func ConfigChannelHeader added in v1.4.1

func ConfigChannelHeader(block *common.Block) (hdr *common.ChannelHeader, err error)

ConfigChannelHeader expects a config block and returns the header type of the config envelope wrapped in it, e.g. HeaderType_ORDERER_TRANSACTION

func ConfigEnvelopeFromBlock added in v1.4.0

func ConfigEnvelopeFromBlock(block *common.Block) (*common.Envelope, error)

ConfigEnvelopeFromBlock extracts configuration envelope from the block based on the config type, i.e. HeaderType_ORDERER_TRANSACTION or HeaderType_CONFIG

func ConsensusMetadataFromConfigBlock added in v1.4.0

func ConsensusMetadataFromConfigBlock(block *common.Block) (*etcdraft.ConfigMetadata, error)

ConsensusMetadataFromConfigBlock reads consensus metadata updates from the configuration block

func ConsentersToMap added in v1.4.0

func ConsentersToMap(consenters []*etcdraft.Consenter) map[string]struct{}

ConsentersToMap maps consenters into set where key is client TLS certificate

func CreateConsentersMap

func CreateConsentersMap(blockMetadata *etcdraft.BlockMetadata, configMetadata *etcdraft.ConfigMetadata) map[uint64]*etcdraft.Consenter

CreateConsentersMap creates a map of Raft Node IDs to Consenter given the block metadata and the config metadata.

func EndpointconfigFromSupport

func EndpointconfigFromSupport(support consensus.ConsenterSupport, bccsp bccsp.BCCSP) ([]cluster.EndpointCriteria, error)

EndpointconfigFromSupport extracts TLS CA certificates and endpoints from the ConsenterSupport

func ListSnapshots added in v1.4.1

func ListSnapshots(logger *flogging.FabricLogger, snapDir string) []uint64

ListSnapshots returns a list of RaftIndex of snapshots stored on disk. If a file is corrupted, rename the file.

func MembershipByCert added in v1.4.0

func MembershipByCert(consenters map[uint64]*etcdraft.Consenter) map[string]uint64

MembershipByCert convert consenters map into set encapsulated by map where key is client TLS certificate

func MetadataFromConfigUpdate added in v1.4.0

func MetadataFromConfigUpdate(update *common.ConfigUpdate) (*etcdraft.ConfigMetadata, error)

MetadataFromConfigUpdate extracts consensus metadata from config update

func MetadataFromConfigValue added in v1.4.0

func MetadataFromConfigValue(configValue *common.ConfigValue) (*etcdraft.ConfigMetadata, error)

MetadataFromConfigValue reads and translates configuration updates from config value into raft metadata

func MetadataHasDuplication added in v1.4.1

func MetadataHasDuplication(md *etcdraft.ConfigMetadata) error

MetadataHasDuplication returns an error if the metadata has duplication of consenters. A duplication is defined by having a server or a client TLS certificate that is found in two different consenters, regardless of the type of certificate (client/server).

func NodeExists added in v1.4.1

func NodeExists(id uint64, nodes []uint64) bool

NodeExists returns trues if node id exists in the slice and false otherwise

func RaftPeers added in v1.4.0

func RaftPeers(consenterIDs []uint64) []raft.Peer

RaftPeers maps consenters to slice of raft.Peer

func ReadBlockMetadata added in v1.4.1

func ReadBlockMetadata(blockMetadata *common.Metadata, configMetadata *etcdraft.ConfigMetadata) (*etcdraft.BlockMetadata, error)

ReadBlockMetadata attempts to read raft metadata from block metadata, if available. otherwise, it reads raft metadata from config metadata supplied.

Types

type BlockPuller added in v1.4.0

type BlockPuller interface {
	PullBlock(seq uint64) *common.Block
	HeightsByEndpoints() (map[string]uint64, error)
	Close()
}

BlockPuller is used to pull blocks from other OSN

func NewBlockPuller

func NewBlockPuller(support consensus.ConsenterSupport,
	baseDialer *cluster.PredicateDialer,
	clusterConfig localconfig.Cluster,
	bccsp bccsp.BCCSP,
) (BlockPuller, error)

NewBlockPuller creates a new block puller

type Chain

type Chain struct {
	ActiveNodes atomic.Value

	// this is exported so that test can use `Node.Status()` to get raft node status.
	Node *node

	Metrics *Metrics

	// BCCSP instane
	CryptoProvider bccsp.BCCSP
	// contains filtered or unexported fields
}

Chain implements consensus.Chain interface.

func NewChain

func NewChain(
	support consensus.ConsenterSupport,
	opts Options,
	conf Configurator,
	rpc RPC,
	cryptoProvider bccsp.BCCSP,
	f CreateBlockPuller,
	haltCallback func(),
	observeC chan<- raft.SoftState,
) (*Chain, error)

NewChain constructs a chain object.

func (*Chain) Configure

func (c *Chain) Configure(env *common.Envelope, configSeq uint64) error

Configure submits config type transactions for ordering.

func (*Chain) Consensus added in v1.4.1

func (c *Chain) Consensus(req *orderer.ConsensusRequest, sender uint64) error

Consensus passes the given ConsensusRequest message to the raft.Node instance

func (*Chain) Errored

func (c *Chain) Errored() <-chan struct{}

Errored returns a channel that closes when the chain stops.

func (*Chain) Halt

func (c *Chain) Halt()

Halt stops the chain.

func (*Chain) Order

func (c *Chain) Order(env *common.Envelope, configSeq uint64) error

Order submits normal type transactions for ordering.

func (*Chain) Start

func (c *Chain) Start()

Start instructs the orderer to begin serving the chain and keep it current.

func (*Chain) Submit

func (c *Chain) Submit(req *orderer.SubmitRequest, sender uint64) error

Submit forwards the incoming request to: - the local run goroutine if this is leader - the actual leader via the transport mechanism The call fails if there's no leader elected yet.

func (*Chain) ValidateConsensusMetadata

func (c *Chain) ValidateConsensusMetadata(oldMetadataBytes, newMetadataBytes []byte, newChannel bool) error

ValidateConsensusMetadata determines the validity of a ConsensusMetadata update during config updates on the channel.

func (*Chain) WaitReady

func (c *Chain) WaitReady() error

WaitReady blocks when the chain: - is catching up with other nodes using snapshot

In any other case, it returns right away.

type ChainGetter added in v1.4.0

type ChainGetter interface {
	// GetChain obtains the ChainSupport for the given channel.
	// Returns nil, false when the ChainSupport for the given channel
	// isn't found.
	GetChain(chainID string) *multichannel.ChainSupport
}

ChainGetter obtains instances of ChainSupport for the given channel

type Config added in v1.4.0

type Config struct {
	WALDir            string // WAL data of <my-channel> is stored in WALDir/<my-channel>
	SnapDir           string // Snapshots of <my-channel> are stored in SnapDir/<my-channel>
	EvictionSuspicion string // Duration threshold that the node samples in order to suspect its eviction from the channel.
}

Config contains etcdraft configurations

type Configurator added in v1.4.0

type Configurator interface {
	Configure(channel string, newNodes []cluster.RemoteNode)
}

Configurator is used to configure the communication layer when the chain starts.

type Consenter added in v1.4.0

type Consenter struct {
	CreateChain           func(chainName string)
	InactiveChainRegistry InactiveChainRegistry
	Dialer                *cluster.PredicateDialer
	Communication         cluster.Communicator
	*Dispatcher
	Chains         ChainGetter
	Logger         *flogging.FabricLogger
	EtcdRaftConfig Config
	OrdererConfig  localconfig.TopLevel
	Cert           []byte
	Metrics        *Metrics
	BCCSP          bccsp.BCCSP
}

Consenter implements etcdraft consenter

func New added in v1.4.0

func New(
	clusterDialer *cluster.PredicateDialer,
	conf *localconfig.TopLevel,
	srvConf comm.ServerConfig,
	srv *comm.GRPCServer,
	r *multichannel.Registrar,
	icr InactiveChainRegistry,
	metricsProvider metrics.Provider,
	bccsp bccsp.BCCSP,
) *Consenter

New creates a etcdraft Consenter

func (*Consenter) HandleChain added in v1.4.0

func (c *Consenter) HandleChain(support consensus.ConsenterSupport, metadata *common.Metadata) (consensus.Chain, error)

HandleChain returns a new Chain instance or an error upon failure

func (*Consenter) ReceiverByChain added in v1.4.0

func (c *Consenter) ReceiverByChain(channelID string) MessageReceiver

ReceiverByChain returns the MessageReceiver for the given channelID or nil if not found.

func (*Consenter) TargetChannel added in v1.4.0

func (c *Consenter) TargetChannel(message proto.Message) string

TargetChannel extracts the channel from the given proto.Message. Returns an empty string on failure.

type ConsenterCertificate added in v1.4.0

type ConsenterCertificate struct {
	ConsenterCertificate []byte
	CryptoProvider       bccsp.BCCSP
}

ConsenterCertificate denotes a TLS certificate of a consenter

func (ConsenterCertificate) IsConsenterOfChannel added in v1.4.0

func (conCert ConsenterCertificate) IsConsenterOfChannel(configBlock *common.Block) error

IsConsenterOfChannel returns whether the caller is a consenter of a channel by inspecting the given configuration block. It returns nil if true, else returns an error.

type CreateBlockPuller added in v1.4.1

type CreateBlockPuller func() (BlockPuller, error)

CreateBlockPuller is a function to create BlockPuller on demand. It is passed into chain initializer so that tests could mock this.

type Dispatcher

type Dispatcher struct {
	Logger        *flogging.FabricLogger
	ChainSelector ReceiverGetter
}

Dispatcher dispatches Submit and Step requests to the designated per chain instances

func (*Dispatcher) OnConsensus added in v1.4.1

func (d *Dispatcher) OnConsensus(channel string, sender uint64, request *orderer.ConsensusRequest) error

OnConsensus notifies the Dispatcher for a reception of a StepRequest from a given sender on a given channel

func (*Dispatcher) OnSubmit

func (d *Dispatcher) OnSubmit(channel string, sender uint64, request *orderer.SubmitRequest) error

OnSubmit notifies the Dispatcher for a reception of a SubmitRequest from a given sender on a given channel

type Disseminator

type Disseminator struct {
	RPC
	// contains filtered or unexported fields
}

Disseminator piggybacks cluster metadata, if any, to egress messages.

func (*Disseminator) SendConsensus

func (d *Disseminator) SendConsensus(dest uint64, msg *orderer.ConsensusRequest) error

func (*Disseminator) UpdateMetadata

func (d *Disseminator) UpdateMetadata(m []byte)

type InactiveChainRegistry added in v1.4.1

type InactiveChainRegistry interface {
	// TrackChain tracks a chain with the given name, and calls the given callback
	// when this chain should be created.
	TrackChain(chainName string, genesisBlock *common.Block, createChain func())
}

InactiveChainRegistry registers chains that are inactive

type LedgerBlockPuller added in v1.4.1

type LedgerBlockPuller struct {
	BlockPuller
	BlockRetriever cluster.BlockRetriever
	Height         func() uint64
}

LedgerBlockPuller pulls blocks upon demand, or fetches them from the ledger

func (*LedgerBlockPuller) PullBlock added in v1.4.1

func (lp *LedgerBlockPuller) PullBlock(seq uint64) *common.Block

type MembershipChanges added in v1.4.0

type MembershipChanges struct {
	NewBlockMetadata *etcdraft.BlockMetadata
	NewConsenters    map[uint64]*etcdraft.Consenter
	AddedNodes       []*etcdraft.Consenter
	RemovedNodes     []*etcdraft.Consenter
	ConfChange       *raftpb.ConfChange
	RotatedNode      uint64
}

MembershipChanges keeps information about membership changes introduced during configuration update

func ComputeMembershipChanges added in v1.4.0

func ComputeMembershipChanges(oldMetadata *etcdraft.BlockMetadata, oldConsenters map[uint64]*etcdraft.Consenter, newConsenters []*etcdraft.Consenter, ordererConfig channelconfig.Orderer) (mc *MembershipChanges, err error)

ComputeMembershipChanges computes membership update based on information about new consenters, returns two slices: a slice of added consenters and a slice of consenters to be removed

func (*MembershipChanges) Changed added in v1.4.1

func (mc *MembershipChanges) Changed() bool

Changed indicates whether these changes actually do anything

func (*MembershipChanges) Rotated added in v1.4.1

func (mc *MembershipChanges) Rotated() bool

Rotated indicates whether the change was a rotation

func (*MembershipChanges) String added in v1.4.1

func (mc *MembershipChanges) String() string

Stringer implements fmt.Stringer interface

func (*MembershipChanges) UnacceptableQuorumLoss

func (mc *MembershipChanges) UnacceptableQuorumLoss(active []uint64) bool

UnacceptableQuorumLoss returns true if membership change will result in avoidable quorum loss, given current number of active nodes in cluster. Avoidable means that more nodes can be started to prevent quorum loss. Sometimes, quorum loss is inevitable, for example expanding 1-node cluster.

type MemoryStorage added in v1.4.0

type MemoryStorage interface {
	raft.Storage
	Append(entries []raftpb.Entry) error
	SetHardState(st raftpb.HardState) error
	CreateSnapshot(i uint64, cs *raftpb.ConfState, data []byte) (raftpb.Snapshot, error)
	Compact(compactIndex uint64) error
	ApplySnapshot(snap raftpb.Snapshot) error
}

MemoryStorage is currently backed by etcd/raft.MemoryStorage. This interface is defined to expose dependencies of fsm so that it may be swapped in the future. TODO(jay) Add other necessary methods to this interface once we need them in implementation, e.g. ApplySnapshot.

type MessageReceiver

type MessageReceiver interface {
	// Consensus passes the given ConsensusRequest message to the MessageReceiver
	Consensus(req *orderer.ConsensusRequest, sender uint64) error

	// Submit passes the given SubmitRequest message to the MessageReceiver
	Submit(req *orderer.SubmitRequest, sender uint64) error
}

MessageReceiver receives messages

type Metrics added in v1.4.1

type Metrics struct {
	ClusterSize             metrics.Gauge
	IsLeader                metrics.Gauge
	ActiveNodes             metrics.Gauge
	CommittedBlockNumber    metrics.Gauge
	SnapshotBlockNumber     metrics.Gauge
	LeaderChanges           metrics.Counter
	ProposalFailures        metrics.Counter
	DataPersistDuration     metrics.Histogram
	NormalProposalsReceived metrics.Counter
	ConfigProposalsReceived metrics.Counter
}

func NewMetrics added in v1.4.1

func NewMetrics(p metrics.Provider) *Metrics

type Options

type Options struct {
	RaftID uint64

	Clock clock.Clock

	WALDir               string
	SnapDir              string
	SnapshotIntervalSize uint32

	// This is configurable mainly for testing purpose. Users are not
	// expected to alter this. Instead, DefaultSnapshotCatchUpEntries is used.
	SnapshotCatchUpEntries uint64

	MemoryStorage MemoryStorage
	Logger        *flogging.FabricLogger

	TickInterval      time.Duration
	ElectionTick      int
	HeartbeatTick     int
	MaxSizePerMsg     uint64
	MaxInflightBlocks int

	// BlockMetdata and Consenters should only be modified while under lock
	// of raftMetadataLock
	BlockMetadata *etcdraft.BlockMetadata
	Consenters    map[uint64]*etcdraft.Consenter

	// MigrationInit is set when the node starts right after consensus-type migration
	MigrationInit bool

	Metrics *Metrics
	Cert    []byte

	EvictionSuspicion   time.Duration
	LeaderCheckInterval time.Duration
}

Options contains all the configurations relevant to the chain.

type PeriodicCheck added in v1.4.1

type PeriodicCheck struct {
	Logger        *flogging.FabricLogger
	CheckInterval time.Duration
	Condition     func() bool
	Report        func(cumulativePeriod time.Duration)
	// contains filtered or unexported fields
}

PeriodicCheck checks periodically a condition, and reports the cumulative consecutive period the condition was fulfilled.

func (*PeriodicCheck) Run added in v1.4.1

func (pc *PeriodicCheck) Run()

Run runs the PeriodicCheck

func (*PeriodicCheck) Stop added in v1.4.1

func (pc *PeriodicCheck) Stop()

Stop stops the periodic checks

type RPC added in v1.4.0

type RPC interface {
	SendConsensus(dest uint64, msg *orderer.ConsensusRequest) error
	SendSubmit(dest uint64, request *orderer.SubmitRequest) error
}

RPC is used to mock the transport layer in tests.

type RaftStorage added in v1.4.0

type RaftStorage struct {
	SnapshotCatchUpEntries uint64
	// contains filtered or unexported fields
}

RaftStorage encapsulates storages needed for etcd/raft data, i.e. memory, wal

func CreateStorage added in v1.4.0

func CreateStorage(
	lg *flogging.FabricLogger,
	walDir string,
	snapDir string,
	ram MemoryStorage,
) (*RaftStorage, error)

CreateStorage attempts to create a storage to persist etcd/raft data. If data presents in specified disk, they are loaded to reconstruct storage state.

func (*RaftStorage) ApplySnapshot added in v1.4.0

func (rs *RaftStorage) ApplySnapshot(snap raftpb.Snapshot)

ApplySnapshot applies snapshot to local memory storage

func (*RaftStorage) Close added in v1.4.0

func (rs *RaftStorage) Close() error

Close closes storage

func (*RaftStorage) Snapshot added in v1.4.0

func (rs *RaftStorage) Snapshot() raftpb.Snapshot

Snapshot returns the latest snapshot stored in memory

func (*RaftStorage) Store added in v1.4.0

func (rs *RaftStorage) Store(entries []raftpb.Entry, hardstate raftpb.HardState, snapshot raftpb.Snapshot) error

Store persists etcd/raft data

func (*RaftStorage) TakeSnapshot added in v1.4.0

func (rs *RaftStorage) TakeSnapshot(i uint64, cs raftpb.ConfState, data []byte) error

TakeSnapshot takes a snapshot at index i from MemoryStorage, and persists it to wal and disk.

type ReceiverGetter

type ReceiverGetter interface {
	// ReceiverByChain returns the MessageReceiver if it exists, or nil if it doesn't
	ReceiverByChain(channelID string) MessageReceiver
}

ReceiverGetter obtains instances of MessageReceiver given a channel ID

type Tracker

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

Tracker periodically poll Raft Status, and update disseminator so that status is populated to followers.

func (*Tracker) Check

func (t *Tracker) Check(status *raft.Status)

Directories

Path Synopsis
Code generated by counterfeiter.
Code generated by counterfeiter.

Jump to

Keyboard shortcuts

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