go-libp2p-pubsub/randomsub.go

109 lines
2.2 KiB
Go
Raw Normal View History

package pubsub
2018-10-10 14:17:27 +00:00
import (
"context"
pb "github.com/libp2p/go-libp2p-pubsub/pb"
2018-10-10 14:17:27 +00:00
2019-05-26 16:19:03 +00:00
"github.com/libp2p/go-libp2p-core/host"
"github.com/libp2p/go-libp2p-core/peer"
"github.com/libp2p/go-libp2p-core/protocol"
2018-10-10 14:17:27 +00:00
)
const (
RandomSubID = protocol.ID("/randomsub/1.0.0")
)
var (
RandomSubD = 6
)
2019-01-04 11:09:21 +00:00
// NewRandomSub returns a new PubSub object using RandomSubRouter as the router.
2018-10-10 14:17:27 +00:00
func NewRandomSub(ctx context.Context, h host.Host, opts ...Option) (*PubSub, error) {
rt := &RandomSubRouter{
peers: make(map[peer.ID]protocol.ID),
}
return NewPubSub(ctx, h, rt, opts...)
}
// RandomSubRouter is a router that implements a random propagation strategy.
// For each message, it selects RandomSubD peers and forwards the message to them.
type RandomSubRouter struct {
p *PubSub
peers map[peer.ID]protocol.ID
}
func (rs *RandomSubRouter) Protocols() []protocol.ID {
2018-10-10 14:39:38 +00:00
return []protocol.ID{RandomSubID, FloodSubID}
2018-10-10 14:17:27 +00:00
}
func (rs *RandomSubRouter) Attach(p *PubSub) {
rs.p = p
}
func (rs *RandomSubRouter) AddPeer(p peer.ID, proto protocol.ID) {
rs.peers[p] = proto
}
func (rs *RandomSubRouter) RemovePeer(p peer.ID) {
delete(rs.peers, p)
}
func (rs *RandomSubRouter) HandleRPC(rpc *RPC) {}
func (rs *RandomSubRouter) Publish(from peer.ID, msg *pb.Message) {
tosend := make(map[peer.ID]struct{})
rspeers := make(map[peer.ID]struct{})
src := peer.ID(msg.GetFrom())
for _, topic := range msg.GetTopicIDs() {
tmap, ok := rs.p.topics[topic]
if !ok {
continue
}
for p := range tmap {
if p == from || p == src {
continue
}
if rs.peers[p] == FloodSubID {
tosend[p] = struct{}{}
} else {
rspeers[p] = struct{}{}
}
}
}
if len(rspeers) > RandomSubD {
xpeers := peerMapToList(rspeers)
shufflePeers(xpeers)
xpeers = xpeers[:RandomSubD]
for _, p := range xpeers {
tosend[p] = struct{}{}
}
} else {
for p := range rspeers {
tosend[p] = struct{}{}
}
}
out := rpcWithMessages(msg)
for p := range tosend {
mch, ok := rs.p.peers[p]
if !ok {
continue
}
select {
case mch <- out:
default:
log.Infof("dropping message to peer %s: queue full", p)
}
}
}
func (rs *RandomSubRouter) Join(topic string) {}
func (rs *RandomSubRouter) Leave(topic string) {}