mirror of
https://gitlab.com/pulsechaincom/prysm-pulse.git
synced 2024-12-25 04:47:18 +00:00
07e7e030d9
* Update pubsub and fix topicIDs * WIP filter * Add suggested code from @bidlocode * add tests and fix bugs * more tests * Wait until state initialized to accept pubsub filtering * rename for clarity and clarify comment * fix test builds * Autofix issues in 2 files Resolved issues in the following files via DeepSource Autofix: 1. beacon-chain/p2p/pubsub_filter.go 2. beacon-chain/p2p/pubsub_filter_test.go * @nisdas pr feedback * pr feedback and fuzz fix * Update beacon-chain/p2p/pubsub_filter.go * Must have protocol suffix * Must have protocol suffix * gofmt * rm test, fix panic * Fix tests * Add isInitialized check * Add a few more tests for better coverage * cache fork digest, make pubsub filter part of the p2p service * rename service * gofmt * Add comment * fix Co-authored-by: deepsource-autofix[bot] <62050782+deepsource-autofix[bot]@users.noreply.github.com> Co-authored-by: Nishant Das <nishdas93@gmail.com> Co-authored-by: prylabs-bulldozer[bot] <58059840+prylabs-bulldozer[bot]@users.noreply.github.com>
96 lines
2.6 KiB
Go
96 lines
2.6 KiB
Go
package p2p
|
|
|
|
import (
|
|
"context"
|
|
"time"
|
|
|
|
pubsub "github.com/libp2p/go-libp2p-pubsub"
|
|
pubsub_pb "github.com/libp2p/go-libp2p-pubsub/pb"
|
|
"github.com/prysmaticlabs/prysm/shared/featureconfig"
|
|
"github.com/prysmaticlabs/prysm/shared/hashutil"
|
|
)
|
|
|
|
// JoinTopic will join PubSub topic, if not already joined.
|
|
func (s *Service) JoinTopic(topic string, opts ...pubsub.TopicOpt) (*pubsub.Topic, error) {
|
|
s.joinedTopicsLock.Lock()
|
|
defer s.joinedTopicsLock.Unlock()
|
|
|
|
if _, ok := s.joinedTopics[topic]; !ok {
|
|
topicHandle, err := s.pubsub.Join(topic, opts...)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
s.joinedTopics[topic] = topicHandle
|
|
}
|
|
|
|
return s.joinedTopics[topic], nil
|
|
}
|
|
|
|
// LeaveTopic closes topic and removes corresponding handler from list of joined topics.
|
|
// This method will return error if there are outstanding event handlers or subscriptions.
|
|
func (s *Service) LeaveTopic(topic string) error {
|
|
s.joinedTopicsLock.Lock()
|
|
defer s.joinedTopicsLock.Unlock()
|
|
|
|
if t, ok := s.joinedTopics[topic]; ok {
|
|
if err := t.Close(); err != nil {
|
|
return err
|
|
}
|
|
delete(s.joinedTopics, topic)
|
|
}
|
|
return nil
|
|
}
|
|
|
|
// PublishToTopic joins (if necessary) and publishes a message to a PubSub topic.
|
|
func (s *Service) PublishToTopic(ctx context.Context, topic string, data []byte, opts ...pubsub.PubOpt) error {
|
|
topicHandle, err := s.JoinTopic(topic)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
// If feature flag isn't enabled, don't wait for peers to be present.
|
|
if !featureconfig.Get().EnableAttBroadcastDiscoveryAttempts {
|
|
return topicHandle.Publish(ctx, data, opts...)
|
|
}
|
|
|
|
// Wait for at least 1 peer to be available to receive the published message.
|
|
for {
|
|
if len(topicHandle.ListPeers()) > 0 {
|
|
return topicHandle.Publish(ctx, data, opts...)
|
|
}
|
|
select {
|
|
case <-ctx.Done():
|
|
return ctx.Err()
|
|
default:
|
|
time.Sleep(100 * time.Millisecond)
|
|
}
|
|
}
|
|
}
|
|
|
|
// SubscribeToTopic joins (if necessary) and subscribes to PubSub topic.
|
|
func (s *Service) SubscribeToTopic(topic string, opts ...pubsub.SubOpt) (*pubsub.Subscription, error) {
|
|
s.awaitStateInitialized() // Genesis time and genesis validator root are required to subscribe.
|
|
|
|
topicHandle, err := s.JoinTopic(topic)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
return topicHandle.Subscribe(opts...)
|
|
}
|
|
|
|
// Content addressable ID function.
|
|
//
|
|
// ETH2 spec defines the message ID as:
|
|
// message-id: SHA256(message.data)
|
|
func msgIDFunction(pmsg *pubsub_pb.Message) string {
|
|
h := hashutil.Hash(pmsg.Data)
|
|
return string(h[:])
|
|
}
|
|
|
|
func setPubSubParameters() {
|
|
pubsub.GossipSubDlo = 5
|
|
pubsub.GossipSubHeartbeatInterval = 700 * time.Millisecond
|
|
pubsub.GossipSubHistoryLength = 6
|
|
pubsub.GossipSubHistoryGossip = 3
|
|
}
|