mirror of
https://source.quilibrium.com/quilibrium/ceremonyclient.git
synced 2024-11-14 04:05:17 +00:00
v1.4.7 (#125)
* move to a message processor channel model for ceremony * switch to goroutine * readjust * cut down volume * keep distance data asserted * bring it back so more bootstrap nodes can exist * bump the version, it's go time
This commit is contained in:
parent
cc568d2af1
commit
cc1e304119
@ -260,18 +260,18 @@ func NewPubSub(ctx context.Context, h host.Host, rt PubSubRouter, opts ...Option
|
|||||||
peerFilter: DefaultPeerFilter,
|
peerFilter: DefaultPeerFilter,
|
||||||
disc: &discover{},
|
disc: &discover{},
|
||||||
maxMessageSize: DefaultMaxMessageSize,
|
maxMessageSize: DefaultMaxMessageSize,
|
||||||
peerOutboundQueueSize: 128,
|
peerOutboundQueueSize: 32,
|
||||||
signID: h.ID(),
|
signID: h.ID(),
|
||||||
signKey: nil,
|
signKey: nil,
|
||||||
signPolicy: StrictSign,
|
signPolicy: StrictSign,
|
||||||
incoming: make(chan *RPC, 128),
|
incoming: make(chan *RPC, 32),
|
||||||
newPeers: make(chan struct{}, 1),
|
newPeers: make(chan struct{}, 1),
|
||||||
newPeersPend: make(map[peer.ID]struct{}),
|
newPeersPend: make(map[peer.ID]struct{}),
|
||||||
newPeerStream: make(chan network.Stream),
|
newPeerStream: make(chan network.Stream),
|
||||||
newPeerError: make(chan peer.ID),
|
newPeerError: make(chan peer.ID),
|
||||||
peerDead: make(chan struct{}, 1),
|
peerDead: make(chan struct{}, 1),
|
||||||
peerDeadPend: make(map[peer.ID]struct{}),
|
peerDeadPend: make(map[peer.ID]struct{}),
|
||||||
deadPeerBackoff: newBackoff(ctx, 128, BackoffCleanupInterval, MaxBackoffAttempts),
|
deadPeerBackoff: newBackoff(ctx, 1000, BackoffCleanupInterval, MaxBackoffAttempts),
|
||||||
cancelCh: make(chan *Subscription),
|
cancelCh: make(chan *Subscription),
|
||||||
getPeers: make(chan *listPeerReq),
|
getPeers: make(chan *listPeerReq),
|
||||||
addSub: make(chan *addSubReq),
|
addSub: make(chan *addSubReq),
|
||||||
@ -280,7 +280,7 @@ func NewPubSub(ctx context.Context, h host.Host, rt PubSubRouter, opts ...Option
|
|||||||
addBitmask: make(chan *addBitmaskReq),
|
addBitmask: make(chan *addBitmaskReq),
|
||||||
rmBitmask: make(chan *rmBitmaskReq),
|
rmBitmask: make(chan *rmBitmaskReq),
|
||||||
getBitmasks: make(chan *bitmaskReq),
|
getBitmasks: make(chan *bitmaskReq),
|
||||||
sendMsg: make(chan *Message, 128),
|
sendMsg: make(chan *Message, 32),
|
||||||
addVal: make(chan *addValReq),
|
addVal: make(chan *addValReq),
|
||||||
rmVal: make(chan *rmValReq),
|
rmVal: make(chan *rmValReq),
|
||||||
eval: make(chan func()),
|
eval: make(chan func()),
|
||||||
@ -979,7 +979,7 @@ func (p *PubSub) notifySubs(msg *Message) {
|
|||||||
for f := range subs {
|
for f := range subs {
|
||||||
select {
|
select {
|
||||||
case f.ch <- msg:
|
case f.ch <- msg:
|
||||||
case <-time.After(15 * time.Millisecond):
|
case <-time.After(5 * time.Millisecond):
|
||||||
// it's unreasonable to immediately fall over because a subscriber didn't
|
// it's unreasonable to immediately fall over because a subscriber didn't
|
||||||
// answer, message delivery sometimes lands next nanosecond and dropping
|
// answer, message delivery sometimes lands next nanosecond and dropping
|
||||||
// it when there's room is absurd.
|
// it when there's room is absurd.
|
||||||
|
@ -14,7 +14,7 @@ func GetMinimumVersion() []byte {
|
|||||||
}
|
}
|
||||||
|
|
||||||
func GetVersion() []byte {
|
func GetVersion() []byte {
|
||||||
return []byte{0x01, 0x04, 0x06}
|
return []byte{0x01, 0x04, 0x07}
|
||||||
}
|
}
|
||||||
|
|
||||||
func GetVersionString() string {
|
func GetVersionString() string {
|
||||||
|
@ -3,16 +3,16 @@ package ceremony
|
|||||||
import (
|
import (
|
||||||
"bytes"
|
"bytes"
|
||||||
"encoding/binary"
|
"encoding/binary"
|
||||||
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
|
||||||
"strings"
|
"strings"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
|
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
||||||
|
|
||||||
"github.com/iden3/go-iden3-crypto/poseidon"
|
"github.com/iden3/go-iden3-crypto/poseidon"
|
||||||
pcrypto "github.com/libp2p/go-libp2p/core/crypto"
|
pcrypto "github.com/libp2p/go-libp2p/core/crypto"
|
||||||
"github.com/libp2p/go-libp2p/core/peer"
|
"github.com/libp2p/go-libp2p/core/peer"
|
||||||
"github.com/pkg/errors"
|
"github.com/pkg/errors"
|
||||||
"go.uber.org/zap"
|
"go.uber.org/zap"
|
||||||
"golang.org/x/sync/errgroup"
|
|
||||||
"google.golang.org/protobuf/proto"
|
"google.golang.org/protobuf/proto"
|
||||||
"google.golang.org/protobuf/types/known/anypb"
|
"google.golang.org/protobuf/types/known/anypb"
|
||||||
"source.quilibrium.com/quilibrium/monorepo/go-libp2p-blossomsub/pb"
|
"source.quilibrium.com/quilibrium/monorepo/go-libp2p-blossomsub/pb"
|
||||||
@ -20,6 +20,98 @@ import (
|
|||||||
"source.quilibrium.com/quilibrium/monorepo/node/protobufs"
|
"source.quilibrium.com/quilibrium/monorepo/node/protobufs"
|
||||||
)
|
)
|
||||||
|
|
||||||
|
func (e *CeremonyDataClockConsensusEngine) runMessageHandler() {
|
||||||
|
for {
|
||||||
|
select {
|
||||||
|
case message := <-e.messageProcessorCh:
|
||||||
|
msg := &protobufs.Message{}
|
||||||
|
|
||||||
|
if err := proto.Unmarshal(message.Data, msg); err != nil {
|
||||||
|
continue
|
||||||
|
}
|
||||||
|
|
||||||
|
for name := range e.executionEngines {
|
||||||
|
name := name
|
||||||
|
go func() error {
|
||||||
|
messages, err := e.executionEngines[name].ProcessMessage(
|
||||||
|
msg.Address,
|
||||||
|
msg,
|
||||||
|
)
|
||||||
|
if err != nil {
|
||||||
|
e.logger.Debug(
|
||||||
|
"could not process message for engine",
|
||||||
|
zap.Error(err),
|
||||||
|
zap.String("engine_name", name),
|
||||||
|
)
|
||||||
|
return nil
|
||||||
|
}
|
||||||
|
|
||||||
|
for _, appMessage := range messages {
|
||||||
|
appMsg := &anypb.Any{}
|
||||||
|
err := proto.Unmarshal(appMessage.Payload, appMsg)
|
||||||
|
if err != nil {
|
||||||
|
e.logger.Error(
|
||||||
|
"could not unmarshal app message",
|
||||||
|
zap.Error(err),
|
||||||
|
zap.String("engine_name", name),
|
||||||
|
)
|
||||||
|
continue
|
||||||
|
}
|
||||||
|
|
||||||
|
switch appMsg.TypeUrl {
|
||||||
|
case protobufs.CeremonyLobbyStateTransitionType:
|
||||||
|
t := &protobufs.CeremonyLobbyStateTransition{}
|
||||||
|
err := proto.Unmarshal(appMsg.Value, t)
|
||||||
|
if err != nil {
|
||||||
|
continue
|
||||||
|
}
|
||||||
|
|
||||||
|
if err := e.handleCeremonyLobbyStateTransition(t); err != nil {
|
||||||
|
continue
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
return nil
|
||||||
|
}()
|
||||||
|
}
|
||||||
|
|
||||||
|
any := &anypb.Any{}
|
||||||
|
if err := proto.Unmarshal(msg.Payload, any); err != nil {
|
||||||
|
continue
|
||||||
|
}
|
||||||
|
|
||||||
|
go func() {
|
||||||
|
switch any.TypeUrl {
|
||||||
|
case protobufs.ClockFrameType:
|
||||||
|
e.peerMapMx.RLock()
|
||||||
|
if peer, ok := e.peerMap[string(message.From)]; !ok ||
|
||||||
|
bytes.Compare(peer.version, config.GetMinimumVersion()) < 0 {
|
||||||
|
return
|
||||||
|
}
|
||||||
|
e.peerMapMx.RUnlock()
|
||||||
|
if err := e.handleClockFrameData(
|
||||||
|
message.From,
|
||||||
|
msg.Address,
|
||||||
|
any,
|
||||||
|
false,
|
||||||
|
); err != nil {
|
||||||
|
return
|
||||||
|
}
|
||||||
|
case protobufs.CeremonyPeerListAnnounceType:
|
||||||
|
if err := e.handleCeremonyPeerListAnnounce(
|
||||||
|
message.From,
|
||||||
|
msg.Address,
|
||||||
|
any,
|
||||||
|
); err != nil {
|
||||||
|
return
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}()
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
func (e *CeremonyDataClockConsensusEngine) handleMessage(
|
func (e *CeremonyDataClockConsensusEngine) handleMessage(
|
||||||
message *pb.Message,
|
message *pb.Message,
|
||||||
) error {
|
) error {
|
||||||
@ -29,96 +121,10 @@ func (e *CeremonyDataClockConsensusEngine) handleMessage(
|
|||||||
zap.Binary("from", message.From),
|
zap.Binary("from", message.From),
|
||||||
zap.Binary("signature", message.Signature),
|
zap.Binary("signature", message.Signature),
|
||||||
)
|
)
|
||||||
msg := &protobufs.Message{}
|
|
||||||
|
|
||||||
if err := proto.Unmarshal(message.Data, msg); err != nil {
|
go func() {
|
||||||
return errors.Wrap(err, "handle message")
|
e.messageProcessorCh <- message
|
||||||
}
|
}()
|
||||||
|
|
||||||
eg := errgroup.Group{}
|
|
||||||
eg.SetLimit(len(e.executionEngines))
|
|
||||||
|
|
||||||
for name := range e.executionEngines {
|
|
||||||
name := name
|
|
||||||
eg.Go(func() error {
|
|
||||||
messages, err := e.executionEngines[name].ProcessMessage(
|
|
||||||
msg.Address,
|
|
||||||
msg,
|
|
||||||
)
|
|
||||||
if err != nil {
|
|
||||||
e.logger.Debug(
|
|
||||||
"could not process message for engine",
|
|
||||||
zap.Error(err),
|
|
||||||
zap.String("engine_name", name),
|
|
||||||
)
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
|
|
||||||
for _, appMessage := range messages {
|
|
||||||
appMsg := &anypb.Any{}
|
|
||||||
err := proto.Unmarshal(appMessage.Payload, appMsg)
|
|
||||||
if err != nil {
|
|
||||||
e.logger.Error(
|
|
||||||
"could not unmarshal app message",
|
|
||||||
zap.Error(err),
|
|
||||||
zap.String("engine_name", name),
|
|
||||||
)
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
|
|
||||||
switch appMsg.TypeUrl {
|
|
||||||
case protobufs.CeremonyLobbyStateTransitionType:
|
|
||||||
t := &protobufs.CeremonyLobbyStateTransition{}
|
|
||||||
err := proto.Unmarshal(appMsg.Value, t)
|
|
||||||
if err != nil {
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
|
|
||||||
if err := e.handleCeremonyLobbyStateTransition(t); err != nil {
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
return nil
|
|
||||||
})
|
|
||||||
}
|
|
||||||
|
|
||||||
if err := eg.Wait(); err != nil {
|
|
||||||
e.logger.Debug("rejecting invalid message", zap.Error(err))
|
|
||||||
return nil
|
|
||||||
}
|
|
||||||
|
|
||||||
any := &anypb.Any{}
|
|
||||||
if err := proto.Unmarshal(msg.Payload, any); err != nil {
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
|
|
||||||
switch any.TypeUrl {
|
|
||||||
case protobufs.ClockFrameType:
|
|
||||||
e.peerMapMx.RLock()
|
|
||||||
if peer, ok := e.peerMap[string(message.From)]; !ok ||
|
|
||||||
bytes.Compare(peer.version, config.GetMinimumVersion()) < 0 {
|
|
||||||
return nil
|
|
||||||
}
|
|
||||||
e.peerMapMx.RUnlock()
|
|
||||||
if err := e.handleClockFrameData(
|
|
||||||
message.From,
|
|
||||||
msg.Address,
|
|
||||||
any,
|
|
||||||
false,
|
|
||||||
); err != nil {
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
case protobufs.CeremonyPeerListAnnounceType:
|
|
||||||
if err := e.handleCeremonyPeerListAnnounce(
|
|
||||||
message.From,
|
|
||||||
msg.Address,
|
|
||||||
any,
|
|
||||||
); err != nil {
|
|
||||||
return errors.Wrap(err, "handle message")
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
@ -16,6 +16,7 @@ import (
|
|||||||
"google.golang.org/grpc"
|
"google.golang.org/grpc"
|
||||||
"google.golang.org/grpc/credentials"
|
"google.golang.org/grpc/credentials"
|
||||||
"google.golang.org/protobuf/types/known/anypb"
|
"google.golang.org/protobuf/types/known/anypb"
|
||||||
|
"source.quilibrium.com/quilibrium/monorepo/go-libp2p-blossomsub/pb"
|
||||||
"source.quilibrium.com/quilibrium/monorepo/nekryptology/pkg/core/curves"
|
"source.quilibrium.com/quilibrium/monorepo/nekryptology/pkg/core/curves"
|
||||||
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
||||||
"source.quilibrium.com/quilibrium/monorepo/node/consensus"
|
"source.quilibrium.com/quilibrium/monorepo/node/consensus"
|
||||||
@ -103,6 +104,7 @@ type CeremonyDataClockConsensusEngine struct {
|
|||||||
lastKeyBundleAnnouncementFrame uint64
|
lastKeyBundleAnnouncementFrame uint64
|
||||||
peerMap map[string]*peerInfo
|
peerMap map[string]*peerInfo
|
||||||
uncooperativePeersMap map[string]*peerInfo
|
uncooperativePeersMap map[string]*peerInfo
|
||||||
|
messageProcessorCh chan *pb.Message
|
||||||
}
|
}
|
||||||
|
|
||||||
var _ consensus.DataConsensusEngine = (*CeremonyDataClockConsensusEngine)(nil)
|
var _ consensus.DataConsensusEngine = (*CeremonyDataClockConsensusEngine)(nil)
|
||||||
@ -233,6 +235,7 @@ func NewCeremonyDataClockConsensusEngine(
|
|||||||
masterTimeReel: masterTimeReel,
|
masterTimeReel: masterTimeReel,
|
||||||
dataTimeReel: dataTimeReel,
|
dataTimeReel: dataTimeReel,
|
||||||
statsClient: statsClient,
|
statsClient: statsClient,
|
||||||
|
messageProcessorCh: make(chan *pb.Message, 128),
|
||||||
}
|
}
|
||||||
|
|
||||||
logger.Info("constructing consensus engine")
|
logger.Info("constructing consensus engine")
|
||||||
@ -270,6 +273,10 @@ func (e *CeremonyDataClockConsensusEngine) Start() <-chan error {
|
|||||||
panic(err)
|
panic(err)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
go func() {
|
||||||
|
e.runLoop()
|
||||||
|
}()
|
||||||
|
|
||||||
e.logger.Info("subscribing to pubsub messages")
|
e.logger.Info("subscribing to pubsub messages")
|
||||||
e.pubSub.Subscribe(e.filter, e.handleMessage, true)
|
e.pubSub.Subscribe(e.filter, e.handleMessage, true)
|
||||||
|
|
||||||
|
@ -4,9 +4,11 @@ import (
|
|||||||
"bytes"
|
"bytes"
|
||||||
"context"
|
"context"
|
||||||
"io"
|
"io"
|
||||||
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
"math/big"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
|
"source.quilibrium.com/quilibrium/monorepo/node/config"
|
||||||
|
|
||||||
"github.com/pkg/errors"
|
"github.com/pkg/errors"
|
||||||
"go.uber.org/zap"
|
"go.uber.org/zap"
|
||||||
"google.golang.org/grpc"
|
"google.golang.org/grpc"
|
||||||
@ -165,7 +167,10 @@ func (e *CeremonyDataClockConsensusEngine) GetMostAheadPeer() (
|
|||||||
_, ok := e.uncooperativePeersMap[string(v.peerId)]
|
_, ok := e.uncooperativePeersMap[string(v.peerId)]
|
||||||
if v.maxFrame > max &&
|
if v.maxFrame > max &&
|
||||||
v.timestamp > config.GetMinimumVersionCutoff().UnixMilli() &&
|
v.timestamp > config.GetMinimumVersionCutoff().UnixMilli() &&
|
||||||
bytes.Compare(v.version, config.GetMinimumVersion()) >= 0 && !ok {
|
bytes.Compare(v.version, config.GetMinimumVersion()) >= 0 &&
|
||||||
|
new(big.Int).SetBytes(
|
||||||
|
v.totalDistance,
|
||||||
|
).Cmp(e.dataTimeReel.GetTotalDistance()) < 0 && !ok {
|
||||||
peer = v.peerId
|
peer = v.peerId
|
||||||
max = v.maxFrame
|
max = v.maxFrame
|
||||||
}
|
}
|
||||||
|
@ -615,6 +615,14 @@ func (d *DataTimeReel) setHead(frame *protobufs.ClockFrame, distance *big.Int) {
|
|||||||
|
|
||||||
d.head = frame
|
d.head = frame
|
||||||
d.totalDistance.Add(d.totalDistance, distance)
|
d.totalDistance.Add(d.totalDistance, distance)
|
||||||
|
|
||||||
|
d.clockStore.SetTotalDistance(
|
||||||
|
d.filter,
|
||||||
|
frame.FrameNumber,
|
||||||
|
selector.FillBytes(make([]byte, 32)),
|
||||||
|
d.totalDistance,
|
||||||
|
)
|
||||||
|
|
||||||
d.headDistance = distance
|
d.headDistance = distance
|
||||||
go func() {
|
go func() {
|
||||||
d.newFrameCh <- frame
|
d.newFrameCh <- frame
|
||||||
@ -623,7 +631,21 @@ func (d *DataTimeReel) setHead(frame *protobufs.ClockFrame, distance *big.Int) {
|
|||||||
|
|
||||||
// tag: dusk – store the distance with the frame
|
// tag: dusk – store the distance with the frame
|
||||||
func (d *DataTimeReel) getTotalDistance(frame *protobufs.ClockFrame) *big.Int {
|
func (d *DataTimeReel) getTotalDistance(frame *protobufs.ClockFrame) *big.Int {
|
||||||
total, err := d.GetDistance(frame)
|
selector, err := frame.GetSelector()
|
||||||
|
if err != nil {
|
||||||
|
panic(err)
|
||||||
|
}
|
||||||
|
|
||||||
|
total, err := d.clockStore.GetTotalDistance(
|
||||||
|
d.filter,
|
||||||
|
frame.FrameNumber,
|
||||||
|
selector.FillBytes(make([]byte, 32)),
|
||||||
|
)
|
||||||
|
if err == nil && total != nil {
|
||||||
|
return total
|
||||||
|
}
|
||||||
|
|
||||||
|
total, err = d.GetDistance(frame)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
panic(err)
|
panic(err)
|
||||||
}
|
}
|
||||||
@ -643,6 +665,13 @@ func (d *DataTimeReel) getTotalDistance(frame *protobufs.ClockFrame) *big.Int {
|
|||||||
total.Add(total, distance)
|
total.Add(total, distance)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
d.clockStore.SetTotalDistance(
|
||||||
|
d.filter,
|
||||||
|
frame.FrameNumber,
|
||||||
|
selector.FillBytes(make([]byte, 32)),
|
||||||
|
total,
|
||||||
|
)
|
||||||
|
|
||||||
return total
|
return total
|
||||||
}
|
}
|
||||||
|
|
||||||
@ -883,6 +912,14 @@ func (d *DataTimeReel) forkChoice(
|
|||||||
"set total distance",
|
"set total distance",
|
||||||
zap.String("total_distance", d.totalDistance.Text(16)),
|
zap.String("total_distance", d.totalDistance.Text(16)),
|
||||||
)
|
)
|
||||||
|
|
||||||
|
d.clockStore.SetTotalDistance(
|
||||||
|
d.filter,
|
||||||
|
frame.FrameNumber,
|
||||||
|
selector.FillBytes(make([]byte, 32)),
|
||||||
|
d.totalDistance,
|
||||||
|
)
|
||||||
|
|
||||||
go func() {
|
go func() {
|
||||||
d.newFrameCh <- frame
|
d.newFrameCh <- frame
|
||||||
}()
|
}()
|
||||||
|
@ -209,6 +209,14 @@ func RunSelfTestIfNeeded(
|
|||||||
|
|
||||||
cores := runtime.GOMAXPROCS(0)
|
cores := runtime.GOMAXPROCS(0)
|
||||||
memory := memory.TotalMemory()
|
memory := memory.TotalMemory()
|
||||||
|
d, err := os.Stat(filepath.Join(configDir, "store"))
|
||||||
|
if d == nil {
|
||||||
|
err := os.Mkdir(filepath.Join(configDir, "store"), 0755)
|
||||||
|
if err != nil {
|
||||||
|
panic(err)
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
f, err := os.Stat(filepath.Join(configDir, "SELF_TEST"))
|
f, err := os.Stat(filepath.Join(configDir, "SELF_TEST"))
|
||||||
|
|
||||||
if f != nil {
|
if f != nil {
|
||||||
|
@ -22,7 +22,6 @@ import (
|
|||||||
"github.com/libp2p/go-libp2p/core/protocol"
|
"github.com/libp2p/go-libp2p/core/protocol"
|
||||||
"github.com/libp2p/go-libp2p/p2p/discovery/routing"
|
"github.com/libp2p/go-libp2p/p2p/discovery/routing"
|
||||||
"github.com/libp2p/go-libp2p/p2p/discovery/util"
|
"github.com/libp2p/go-libp2p/p2p/discovery/util"
|
||||||
"github.com/libp2p/go-libp2p/p2p/net/connmgr"
|
|
||||||
"github.com/mr-tron/base58"
|
"github.com/mr-tron/base58"
|
||||||
"github.com/pkg/errors"
|
"github.com/pkg/errors"
|
||||||
"go.uber.org/zap"
|
"go.uber.org/zap"
|
||||||
@ -107,17 +106,6 @@ func NewBlossomSub(
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
if isBootstrapPeer {
|
|
||||||
mgr, err := connmgr.NewConnManager(512, 8192)
|
|
||||||
if err != nil {
|
|
||||||
panic(err)
|
|
||||||
}
|
|
||||||
|
|
||||||
opts = append(opts,
|
|
||||||
libp2p.ConnectionManager(mgr),
|
|
||||||
)
|
|
||||||
}
|
|
||||||
|
|
||||||
var privKey crypto.PrivKey
|
var privKey crypto.PrivKey
|
||||||
if p2pConfig.PeerPrivKey != "" {
|
if p2pConfig.PeerPrivKey != "" {
|
||||||
peerPrivKey, err := hex.DecodeString(p2pConfig.PeerPrivKey)
|
peerPrivKey, err := hex.DecodeString(p2pConfig.PeerPrivKey)
|
||||||
|
@ -3,6 +3,7 @@ package store
|
|||||||
import (
|
import (
|
||||||
"bytes"
|
"bytes"
|
||||||
"encoding/binary"
|
"encoding/binary"
|
||||||
|
"math/big"
|
||||||
|
|
||||||
"github.com/cockroachdb/pebble"
|
"github.com/cockroachdb/pebble"
|
||||||
"github.com/iden3/go-iden3-crypto/poseidon"
|
"github.com/iden3/go-iden3-crypto/poseidon"
|
||||||
@ -76,6 +77,17 @@ type ClockStore interface {
|
|||||||
masterFilter []byte,
|
masterFilter []byte,
|
||||||
dataFilter []byte,
|
dataFilter []byte,
|
||||||
) error
|
) error
|
||||||
|
GetTotalDistance(
|
||||||
|
filter []byte,
|
||||||
|
frameNumber uint64,
|
||||||
|
selector []byte,
|
||||||
|
) (*big.Int, error)
|
||||||
|
SetTotalDistance(
|
||||||
|
filter []byte,
|
||||||
|
frameNumber uint64,
|
||||||
|
selector []byte,
|
||||||
|
totalDistance *big.Int,
|
||||||
|
) error
|
||||||
}
|
}
|
||||||
|
|
||||||
type PebbleClockStore struct {
|
type PebbleClockStore struct {
|
||||||
@ -268,6 +280,7 @@ const CLOCK_MASTER_FRAME_DATA = 0x00
|
|||||||
const CLOCK_DATA_FRAME_DATA = 0x01
|
const CLOCK_DATA_FRAME_DATA = 0x01
|
||||||
const CLOCK_DATA_FRAME_CANDIDATE_DATA = 0x02
|
const CLOCK_DATA_FRAME_CANDIDATE_DATA = 0x02
|
||||||
const CLOCK_DATA_FRAME_FRECENCY_DATA = 0x03
|
const CLOCK_DATA_FRAME_FRECENCY_DATA = 0x03
|
||||||
|
const CLOCK_DATA_FRAME_DISTANCE_DATA = 0x04
|
||||||
const CLOCK_MASTER_FRAME_INDEX_EARLIEST = 0x10 | CLOCK_MASTER_FRAME_DATA
|
const CLOCK_MASTER_FRAME_INDEX_EARLIEST = 0x10 | CLOCK_MASTER_FRAME_DATA
|
||||||
const CLOCK_MASTER_FRAME_INDEX_LATEST = 0x20 | CLOCK_MASTER_FRAME_DATA
|
const CLOCK_MASTER_FRAME_INDEX_LATEST = 0x20 | CLOCK_MASTER_FRAME_DATA
|
||||||
const CLOCK_MASTER_FRAME_INDEX_PARENT = 0x30 | CLOCK_MASTER_FRAME_DATA
|
const CLOCK_MASTER_FRAME_INDEX_PARENT = 0x30 | CLOCK_MASTER_FRAME_DATA
|
||||||
@ -402,6 +415,18 @@ func clockProverTrieKey(filter []byte, frameNumber uint64) []byte {
|
|||||||
return key
|
return key
|
||||||
}
|
}
|
||||||
|
|
||||||
|
func clockDataTotalDistanceKey(
|
||||||
|
filter []byte,
|
||||||
|
frameNumber uint64,
|
||||||
|
selector []byte,
|
||||||
|
) []byte {
|
||||||
|
key := []byte{CLOCK_FRAME, CLOCK_DATA_FRAME_DISTANCE_DATA}
|
||||||
|
key = binary.BigEndian.AppendUint64(key, frameNumber)
|
||||||
|
key = append(key, filter...)
|
||||||
|
key = append(key, rightAlign(selector, 32)...)
|
||||||
|
return key
|
||||||
|
}
|
||||||
|
|
||||||
func (p *PebbleClockStore) NewTransaction() (Transaction, error) {
|
func (p *PebbleClockStore) NewTransaction() (Transaction, error) {
|
||||||
return p.db.NewBatch(), nil
|
return p.db.NewBatch(), nil
|
||||||
}
|
}
|
||||||
@ -1287,3 +1312,39 @@ func (p *PebbleClockStore) Compact(
|
|||||||
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
|
func (p *PebbleClockStore) GetTotalDistance(
|
||||||
|
filter []byte,
|
||||||
|
frameNumber uint64,
|
||||||
|
selector []byte,
|
||||||
|
) (*big.Int, error) {
|
||||||
|
value, closer, err := p.db.Get(
|
||||||
|
clockDataTotalDistanceKey(filter, frameNumber, selector),
|
||||||
|
)
|
||||||
|
if err != nil {
|
||||||
|
if errors.Is(err, pebble.ErrNotFound) {
|
||||||
|
return nil, ErrNotFound
|
||||||
|
}
|
||||||
|
|
||||||
|
return nil, errors.Wrap(err, "get total distance")
|
||||||
|
}
|
||||||
|
|
||||||
|
defer closer.Close()
|
||||||
|
dist := new(big.Int).SetBytes(value)
|
||||||
|
|
||||||
|
return dist, nil
|
||||||
|
}
|
||||||
|
|
||||||
|
func (p *PebbleClockStore) SetTotalDistance(
|
||||||
|
filter []byte,
|
||||||
|
frameNumber uint64,
|
||||||
|
selector []byte,
|
||||||
|
totalDistance *big.Int,
|
||||||
|
) error {
|
||||||
|
err := p.db.Set(
|
||||||
|
clockDataTotalDistanceKey(filter, frameNumber, selector),
|
||||||
|
totalDistance.Bytes(),
|
||||||
|
)
|
||||||
|
|
||||||
|
return errors.Wrap(err, "set total distance")
|
||||||
|
}
|
||||||
|
Loading…
Reference in New Issue
Block a user