mirror of
https://source.quilibrium.com/quilibrium/ceremonyclient.git
synced 2024-11-11 02:35:18 +00:00
281 lines
7.8 KiB
Go
281 lines
7.8 KiB
Go
|
package ceremony
|
|||
|
|
|||
|
import (
|
|||
|
"crypto"
|
|||
|
"math/big"
|
|||
|
"sync"
|
|||
|
"time"
|
|||
|
|
|||
|
"github.com/pkg/errors"
|
|||
|
"go.uber.org/zap"
|
|||
|
"google.golang.org/protobuf/types/known/anypb"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/nekryptology/pkg/core/curves"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/consensus"
|
|||
|
qcrypto "source.quilibrium.com/quilibrium/monorepo/node/crypto"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/execution"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/keys"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/p2p"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/protobufs"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/store"
|
|||
|
"source.quilibrium.com/quilibrium/monorepo/node/tries"
|
|||
|
)
|
|||
|
|
|||
|
type InclusionMap = map[curves.PairingPoint]*protobufs.InclusionCommitment
|
|||
|
type PolynomialMap = map[curves.PairingPoint][]curves.PairingScalar
|
|||
|
type SyncStatusType int
|
|||
|
|
|||
|
const (
|
|||
|
SyncStatusNotSyncing = iota
|
|||
|
SyncStatusAwaitingResponse
|
|||
|
SyncStatusSynchronizing
|
|||
|
)
|
|||
|
|
|||
|
type CeremonyDataClockConsensusEngine struct {
|
|||
|
frame uint64
|
|||
|
activeFrame *protobufs.ClockFrame
|
|||
|
difficulty uint32
|
|||
|
logger *zap.Logger
|
|||
|
state consensus.EngineState
|
|||
|
clockStore store.ClockStore
|
|||
|
keyStore store.KeyStore
|
|||
|
pubSub p2p.PubSub
|
|||
|
keyManager keys.KeyManager
|
|||
|
provingKey crypto.Signer
|
|||
|
provingKeyBytes []byte
|
|||
|
provingKeyType keys.KeyType
|
|||
|
provingKeyAddress []byte
|
|||
|
lastFrameReceivedAt time.Time
|
|||
|
latestFrameReceived uint64
|
|||
|
frameProverTrie *tries.RollingFrecencyCritbitTrie
|
|||
|
frameSeenProverTrie *tries.RollingFrecencyCritbitTrie
|
|||
|
dependencyMap map[string]*anypb.Any
|
|||
|
pendingCommits chan *anypb.Any
|
|||
|
pendingCommitWorkers int64
|
|||
|
prover *qcrypto.KZGProver
|
|||
|
stagedKeyCommits InclusionMap
|
|||
|
stagedKeyPolynomials PolynomialMap
|
|||
|
stagedLobbyStateTransitions *protobufs.CeremonyLobbyStateTransition
|
|||
|
|
|||
|
frameChan chan *protobufs.ClockFrame
|
|||
|
executionEngines map[string]execution.ExecutionEngine
|
|||
|
filter []byte
|
|||
|
input []byte
|
|||
|
parentSelector []byte
|
|||
|
syncingStatus SyncStatusType
|
|||
|
syncingTarget []byte
|
|||
|
currentDistance *big.Int
|
|||
|
engineMx sync.Mutex
|
|||
|
dependencyMapMx sync.Mutex
|
|||
|
stagedKeyCommitsMx sync.Mutex
|
|||
|
stagedLobbyStateTransitionsMx sync.Mutex
|
|||
|
lastKeyBundleAnnouncementFrame uint64
|
|||
|
}
|
|||
|
|
|||
|
var _ consensus.DataConsensusEngine = (*CeremonyDataClockConsensusEngine)(nil)
|
|||
|
|
|||
|
// Creates a new data clock for ceremony execution – this is a hybrid clock,
|
|||
|
// normally data clocks are bloom sharded and have node-specific proofs along
|
|||
|
// with the public VDF proofs, but in this case it is a proof from the execution
|
|||
|
// across all participating nodes.
|
|||
|
func NewCeremonyDataClockConsensusEngine(
|
|||
|
engineConfig *config.EngineConfig,
|
|||
|
logger *zap.Logger,
|
|||
|
keyManager keys.KeyManager,
|
|||
|
clockStore store.ClockStore,
|
|||
|
keyStore store.KeyStore,
|
|||
|
pubSub p2p.PubSub,
|
|||
|
) *CeremonyDataClockConsensusEngine {
|
|||
|
if logger == nil {
|
|||
|
panic(errors.New("logger is nil"))
|
|||
|
}
|
|||
|
|
|||
|
if engineConfig == nil {
|
|||
|
panic(errors.New("engine config is nil"))
|
|||
|
}
|
|||
|
|
|||
|
if keyManager == nil {
|
|||
|
panic(errors.New("key manager is nil"))
|
|||
|
}
|
|||
|
|
|||
|
if clockStore == nil {
|
|||
|
panic(errors.New("clock store is nil"))
|
|||
|
}
|
|||
|
|
|||
|
if keyStore == nil {
|
|||
|
panic(errors.New("key store is nil"))
|
|||
|
}
|
|||
|
|
|||
|
if pubSub == nil {
|
|||
|
panic(errors.New("pubsub is nil"))
|
|||
|
}
|
|||
|
|
|||
|
e := &CeremonyDataClockConsensusEngine{
|
|||
|
frame: 0,
|
|||
|
difficulty: 10000,
|
|||
|
logger: logger,
|
|||
|
state: consensus.EngineStateStopped,
|
|||
|
clockStore: clockStore,
|
|||
|
keyStore: keyStore,
|
|||
|
keyManager: keyManager,
|
|||
|
pubSub: pubSub,
|
|||
|
frameChan: make(chan *protobufs.ClockFrame),
|
|||
|
executionEngines: map[string]execution.ExecutionEngine{},
|
|||
|
dependencyMap: make(map[string]*anypb.Any),
|
|||
|
parentSelector: []byte{
|
|||
|
0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00,
|
|||
|
0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00,
|
|||
|
0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00,
|
|||
|
0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00, 0x00,
|
|||
|
},
|
|||
|
lastFrameReceivedAt: time.Time{},
|
|||
|
frameProverTrie: &tries.RollingFrecencyCritbitTrie{},
|
|||
|
frameSeenProverTrie: &tries.RollingFrecencyCritbitTrie{},
|
|||
|
pendingCommits: make(chan *anypb.Any),
|
|||
|
pendingCommitWorkers: engineConfig.PendingCommitWorkers,
|
|||
|
prover: qcrypto.DefaultKZGProver(),
|
|||
|
stagedKeyCommits: make(InclusionMap),
|
|||
|
stagedKeyPolynomials: make(PolynomialMap),
|
|||
|
syncingStatus: SyncStatusNotSyncing,
|
|||
|
}
|
|||
|
|
|||
|
logger.Info("constructing consensus engine")
|
|||
|
|
|||
|
signer, keyType, bytes, address := e.GetProvingKey(
|
|||
|
engineConfig,
|
|||
|
)
|
|||
|
|
|||
|
e.provingKey = signer
|
|||
|
e.provingKeyType = keyType
|
|||
|
e.provingKeyBytes = bytes
|
|||
|
e.provingKeyAddress = address
|
|||
|
|
|||
|
return e
|
|||
|
}
|
|||
|
|
|||
|
func (e *CeremonyDataClockConsensusEngine) Start(
|
|||
|
filter []byte,
|
|||
|
seed []byte,
|
|||
|
) <-chan error {
|
|||
|
e.logger.Info("starting ceremony consensus engine")
|
|||
|
e.state = consensus.EngineStateStarting
|
|||
|
errChan := make(chan error)
|
|||
|
|
|||
|
e.filter = filter
|
|||
|
e.input = seed
|
|||
|
e.state = consensus.EngineStateLoading
|
|||
|
|
|||
|
e.logger.Info("loading last seen state")
|
|||
|
latestFrame, err := e.clockStore.GetLatestDataClockFrame(
|
|||
|
e.filter,
|
|||
|
e.frameProverTrie,
|
|||
|
)
|
|||
|
if err != nil && !errors.Is(err, store.ErrNotFound) {
|
|||
|
panic(err)
|
|||
|
}
|
|||
|
|
|||
|
if latestFrame != nil {
|
|||
|
e.setFrame(latestFrame)
|
|||
|
} else {
|
|||
|
latestFrame = e.createGenesisFrame()
|
|||
|
}
|
|||
|
|
|||
|
e.logger.Info("subscribing to pubsub messages")
|
|||
|
e.pubSub.Subscribe(e.filter, e.handleMessage, true)
|
|||
|
e.pubSub.Subscribe(
|
|||
|
append(append([]byte{}, e.filter...), e.pubSub.GetPeerID()...),
|
|||
|
e.handleSync,
|
|||
|
true,
|
|||
|
)
|
|||
|
|
|||
|
e.state = consensus.EngineStateCollecting
|
|||
|
|
|||
|
for i := int64(0); i < e.pendingCommitWorkers; i++ {
|
|||
|
go e.handlePendingCommits(i)
|
|||
|
}
|
|||
|
|
|||
|
go func() {
|
|||
|
for e.state < consensus.EngineStateStopping {
|
|||
|
switch e.state {
|
|||
|
case consensus.EngineStateCollecting:
|
|||
|
if latestFrame, err = e.collect(latestFrame); err != nil {
|
|||
|
e.logger.Error("could not collect", zap.Error(err))
|
|||
|
errChan <- err
|
|||
|
}
|
|||
|
case consensus.EngineStateProving:
|
|||
|
if latestFrame, err = e.prove(latestFrame); err != nil {
|
|||
|
e.logger.Error("could not prove", zap.Error(err))
|
|||
|
errChan <- err
|
|||
|
}
|
|||
|
case consensus.EngineStatePublishing:
|
|||
|
if err = e.publishProof(latestFrame); err != nil {
|
|||
|
e.logger.Error("could not publish", zap.Error(err))
|
|||
|
errChan <- err
|
|||
|
}
|
|||
|
}
|
|||
|
}
|
|||
|
}()
|
|||
|
|
|||
|
go func() {
|
|||
|
errChan <- nil
|
|||
|
}()
|
|||
|
|
|||
|
return errChan
|
|||
|
}
|
|||
|
|
|||
|
func (e *CeremonyDataClockConsensusEngine) Stop(force bool) <-chan error {
|
|||
|
e.logger.Info("stopping ceremony consensus engine")
|
|||
|
e.state = consensus.EngineStateStopping
|
|||
|
errChan := make(chan error)
|
|||
|
|
|||
|
wg := sync.WaitGroup{}
|
|||
|
wg.Add(len(e.executionEngines))
|
|||
|
for name := range e.executionEngines {
|
|||
|
name := name
|
|||
|
go func(name string) {
|
|||
|
err := <-e.UnregisterExecutor(name, e.frame, force)
|
|||
|
if err != nil {
|
|||
|
errChan <- err
|
|||
|
}
|
|||
|
wg.Done()
|
|||
|
}(name)
|
|||
|
}
|
|||
|
|
|||
|
e.logger.Info("waiting for execution engines to stop")
|
|||
|
wg.Wait()
|
|||
|
e.logger.Info("execution engines stopped")
|
|||
|
|
|||
|
e.state = consensus.EngineStateStopped
|
|||
|
|
|||
|
e.engineMx.Lock()
|
|||
|
defer e.engineMx.Unlock()
|
|||
|
go func() {
|
|||
|
errChan <- nil
|
|||
|
}()
|
|||
|
return errChan
|
|||
|
}
|
|||
|
|
|||
|
func (e *CeremonyDataClockConsensusEngine) GetDifficulty() uint32 {
|
|||
|
return e.difficulty
|
|||
|
}
|
|||
|
|
|||
|
func (e *CeremonyDataClockConsensusEngine) GetFrame() uint64 {
|
|||
|
return e.frame
|
|||
|
}
|
|||
|
|
|||
|
func (e *CeremonyDataClockConsensusEngine) GetState() consensus.EngineState {
|
|||
|
return e.state
|
|||
|
}
|
|||
|
|
|||
|
func (
|
|||
|
e *CeremonyDataClockConsensusEngine,
|
|||
|
) GetFrameChannel() <-chan *protobufs.ClockFrame {
|
|||
|
return e.frameChan
|
|||
|
}
|
|||
|
|
|||
|
func (
|
|||
|
e *CeremonyDataClockConsensusEngine,
|
|||
|
) GetActiveFrame() *protobufs.ClockFrame {
|
|||
|
return e.activeFrame
|
|||
|
}
|