mirror of
https://source.quilibrium.com/quilibrium/ceremonyclient.git
synced 2024-11-10 18:25:17 +00:00
130 lines
3.0 KiB
Go
130 lines
3.0 KiB
Go
package main
|
|
|
|
import (
|
|
"bufio"
|
|
"context"
|
|
"flag"
|
|
"fmt"
|
|
"os"
|
|
"sync"
|
|
|
|
"github.com/libp2p/go-libp2p"
|
|
dht "github.com/libp2p/go-libp2p-kad-dht"
|
|
pubsub "github.com/libp2p/go-libp2p-pubsub"
|
|
"github.com/libp2p/go-libp2p/core/host"
|
|
"github.com/libp2p/go-libp2p/core/peer"
|
|
drouting "github.com/libp2p/go-libp2p/p2p/discovery/routing"
|
|
dutil "github.com/libp2p/go-libp2p/p2p/discovery/util"
|
|
)
|
|
|
|
var (
|
|
topicNameFlag = flag.String("topicName", "applesauce", "name of topic to join")
|
|
)
|
|
|
|
func main() {
|
|
flag.Parse()
|
|
ctx := context.Background()
|
|
|
|
h, err := libp2p.New(libp2p.ListenAddrStrings("/ip4/0.0.0.0/tcp/0"))
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
go discoverPeers(ctx, h)
|
|
|
|
ps, err := pubsub.NewGossipSub(ctx, h)
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
topic, err := ps.Join(*topicNameFlag)
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
go streamConsoleTo(ctx, topic)
|
|
|
|
sub, err := topic.Subscribe()
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
printMessagesFrom(ctx, sub)
|
|
}
|
|
|
|
func initDHT(ctx context.Context, h host.Host) *dht.IpfsDHT {
|
|
// Start a DHT, for use in peer discovery. We can't just make a new DHT
|
|
// client because we want each peer to maintain its own local copy of the
|
|
// DHT, so that the bootstrapping node of the DHT can go down without
|
|
// inhibiting future peer discovery.
|
|
kademliaDHT, err := dht.New(ctx, h)
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
if err = kademliaDHT.Bootstrap(ctx); err != nil {
|
|
panic(err)
|
|
}
|
|
var wg sync.WaitGroup
|
|
for _, peerAddr := range dht.DefaultBootstrapPeers {
|
|
peerinfo, _ := peer.AddrInfoFromP2pAddr(peerAddr)
|
|
wg.Add(1)
|
|
go func() {
|
|
defer wg.Done()
|
|
if err := h.Connect(ctx, *peerinfo); err != nil {
|
|
fmt.Println("Bootstrap warning:", err)
|
|
}
|
|
}()
|
|
}
|
|
wg.Wait()
|
|
|
|
return kademliaDHT
|
|
}
|
|
|
|
func discoverPeers(ctx context.Context, h host.Host) {
|
|
kademliaDHT := initDHT(ctx, h)
|
|
routingDiscovery := drouting.NewRoutingDiscovery(kademliaDHT)
|
|
dutil.Advertise(ctx, routingDiscovery, *topicNameFlag)
|
|
|
|
// Look for others who have announced and attempt to connect to them
|
|
anyConnected := false
|
|
for !anyConnected {
|
|
fmt.Println("Searching for peers...")
|
|
peerChan, err := routingDiscovery.FindPeers(ctx, *topicNameFlag)
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
for peer := range peerChan {
|
|
if peer.ID == h.ID() {
|
|
continue // No self connection
|
|
}
|
|
err := h.Connect(ctx, peer)
|
|
if err != nil {
|
|
fmt.Printf("Failed connecting to %s, error: %s\n", peer.ID, err)
|
|
} else {
|
|
fmt.Println("Connected to:", peer.ID)
|
|
anyConnected = true
|
|
}
|
|
}
|
|
}
|
|
fmt.Println("Peer discovery complete")
|
|
}
|
|
|
|
func streamConsoleTo(ctx context.Context, topic *pubsub.Topic) {
|
|
reader := bufio.NewReader(os.Stdin)
|
|
for {
|
|
s, err := reader.ReadString('\n')
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
if err := topic.Publish(ctx, []byte(s)); err != nil {
|
|
fmt.Println("### Publish error:", err)
|
|
}
|
|
}
|
|
}
|
|
|
|
func printMessagesFrom(ctx context.Context, sub *pubsub.Subscription) {
|
|
for {
|
|
m, err := sub.Next(ctx)
|
|
if err != nil {
|
|
panic(err)
|
|
}
|
|
fmt.Println(m.ReceivedFrom, ": ", string(m.Message.Data))
|
|
}
|
|
}
|