2021-04-04 17:06:17 +00:00
|
|
|
package main
|
|
|
|
|
|
|
|
import (
|
2022-08-15 18:29:59 +00:00
|
|
|
"chat3/pb"
|
2021-04-28 20:28:45 +00:00
|
|
|
"context"
|
2021-06-10 13:00:16 +00:00
|
|
|
"crypto/sha256"
|
2022-08-15 18:29:59 +00:00
|
|
|
"encoding/hex"
|
|
|
|
"errors"
|
|
|
|
"fmt"
|
|
|
|
"strings"
|
|
|
|
"sync"
|
2021-04-04 17:06:17 +00:00
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/libp2p/go-libp2p-core/peer"
|
2022-08-15 18:29:59 +00:00
|
|
|
"github.com/multiformats/go-multiaddr"
|
|
|
|
"github.com/status-im/go-rln/rln"
|
|
|
|
"github.com/status-im/go-waku/waku/v2/dnsdisc"
|
2021-04-04 17:06:17 +00:00
|
|
|
"github.com/status-im/go-waku/waku/v2/node"
|
2021-06-28 14:14:28 +00:00
|
|
|
"github.com/status-im/go-waku/waku/v2/protocol"
|
|
|
|
"github.com/status-im/go-waku/waku/v2/protocol/filter"
|
2022-08-15 18:29:59 +00:00
|
|
|
"github.com/status-im/go-waku/waku/v2/protocol/lightpush"
|
2021-04-22 00:12:51 +00:00
|
|
|
wpb "github.com/status-im/go-waku/waku/v2/protocol/pb"
|
2021-06-28 14:14:28 +00:00
|
|
|
"github.com/status-im/go-waku/waku/v2/protocol/relay"
|
2022-08-15 18:29:59 +00:00
|
|
|
"github.com/status-im/go-waku/waku/v2/protocol/store"
|
2021-10-12 13:12:54 +00:00
|
|
|
"github.com/status-im/go-waku/waku/v2/utils"
|
2021-06-10 13:00:16 +00:00
|
|
|
"golang.org/x/crypto/pbkdf2"
|
2022-08-15 18:29:59 +00:00
|
|
|
"google.golang.org/protobuf/proto"
|
2021-04-04 17:06:17 +00:00
|
|
|
)
|
|
|
|
|
|
|
|
// Chat represents a subscription to a single PubSub topic. Messages
|
|
|
|
// can be published to the topic with Chat.Publish, and received
|
|
|
|
// messages are pushed to the Messages channel.
|
|
|
|
type Chat struct {
|
2022-08-15 18:29:59 +00:00
|
|
|
ctx context.Context
|
|
|
|
wg sync.WaitGroup
|
|
|
|
node *node.WakuNode
|
|
|
|
ui UI
|
|
|
|
uiReady chan struct{}
|
|
|
|
inputChan chan string
|
|
|
|
options Options
|
|
|
|
|
|
|
|
C chan *protocol.Envelope
|
2021-04-04 17:06:17 +00:00
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
nick string
|
|
|
|
}
|
2021-04-04 17:06:17 +00:00
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func NewChat(ctx context.Context, node *node.WakuNode, options Options) *Chat {
|
2021-06-28 14:14:28 +00:00
|
|
|
chat := &Chat{
|
2022-08-15 18:29:59 +00:00
|
|
|
ctx: ctx,
|
|
|
|
node: node,
|
|
|
|
options: options,
|
|
|
|
nick: options.Nickname,
|
|
|
|
uiReady: make(chan struct{}, 1),
|
|
|
|
inputChan: make(chan string, 100),
|
2021-04-04 17:06:17 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
chat.ui = NewUIModel(chat.uiReady, chat.inputChan)
|
|
|
|
|
|
|
|
if options.Filter.Enable {
|
2021-10-30 14:29:34 +00:00
|
|
|
cf := filter.ContentFilter{
|
2021-11-19 20:01:52 +00:00
|
|
|
Topic: relay.DefaultWakuTopic,
|
2022-08-15 18:29:59 +00:00
|
|
|
ContentTopics: []string{options.ContentTopic},
|
2021-10-30 14:29:34 +00:00
|
|
|
}
|
|
|
|
var err error
|
2022-08-15 18:29:59 +00:00
|
|
|
|
|
|
|
var filterOpt filter.FilterSubscribeOption
|
|
|
|
peerID, err := options.Filter.NodePeerID()
|
2021-10-30 14:29:34 +00:00
|
|
|
if err != nil {
|
2022-08-15 18:29:59 +00:00
|
|
|
filterOpt = filter.WithAutomaticPeerSelection()
|
|
|
|
} else {
|
|
|
|
filterOpt = filter.WithPeer(peerID)
|
|
|
|
chat.ui.InfoMessage(fmt.Sprintf("Subscribing to filter node %s", peerID))
|
|
|
|
}
|
|
|
|
|
|
|
|
_, theFilter, err := node.Filter().Subscribe(ctx, cf, filterOpt)
|
|
|
|
if err != nil {
|
|
|
|
chat.ui.ErrorMessage(err)
|
|
|
|
} else {
|
|
|
|
chat.C = theFilter.Chan
|
2021-10-30 14:29:34 +00:00
|
|
|
}
|
2021-06-28 14:14:28 +00:00
|
|
|
} else {
|
2022-08-15 18:29:59 +00:00
|
|
|
sub, err := node.Relay().Subscribe(ctx)
|
2021-06-28 14:14:28 +00:00
|
|
|
if err != nil {
|
2022-08-15 18:29:59 +00:00
|
|
|
chat.ui.ErrorMessage(err)
|
|
|
|
} else {
|
|
|
|
chat.C = sub.C
|
2021-06-28 14:14:28 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
chat.wg.Add(6)
|
|
|
|
go chat.parseInput()
|
|
|
|
go chat.receiveMessages()
|
|
|
|
|
|
|
|
connectionWg := sync.WaitGroup{}
|
|
|
|
connectionWg.Add(2)
|
|
|
|
|
|
|
|
go chat.welcomeMessage()
|
2021-04-04 17:06:17 +00:00
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
go chat.staticNodes(&connectionWg)
|
|
|
|
go chat.discoverNodes(&connectionWg)
|
|
|
|
go chat.retrieveHistory(&connectionWg)
|
2022-07-06 20:29:20 +00:00
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
return chat
|
2021-04-04 17:06:17 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func (c *Chat) Stop() {
|
|
|
|
c.wg.Wait()
|
|
|
|
close(c.inputChan)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *Chat) receiveMessages() {
|
|
|
|
defer c.wg.Done()
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-c.ctx.Done():
|
|
|
|
return
|
|
|
|
case value := <-c.C:
|
|
|
|
|
|
|
|
msgContentTopic := value.Message().ContentTopic
|
|
|
|
if msgContentTopic != c.options.ContentTopic || (c.options.RLNRelay.Enable && msgContentTopic != c.options.RLNRelay.ContentTopic) {
|
|
|
|
continue // Discard messages from other topics
|
|
|
|
}
|
|
|
|
|
|
|
|
msg, err := decodeMessage(c.options.UsePayloadV1, c.options.ContentTopic, value.Message())
|
|
|
|
if err == nil {
|
|
|
|
// send valid messages to the UI
|
|
|
|
c.ui.ChatMessage(int64(msg.Timestamp), msg.Nick, string(msg.Payload))
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
func (c *Chat) parseInput() {
|
|
|
|
defer c.wg.Done()
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-c.ctx.Done():
|
|
|
|
return
|
|
|
|
case line := <-c.inputChan:
|
|
|
|
c.ui.SetSending(true)
|
|
|
|
go func() {
|
|
|
|
defer c.ui.SetSending(false)
|
|
|
|
|
|
|
|
// bail if requested
|
2022-08-15 23:29:19 +00:00
|
|
|
if line == "/exit" {
|
2022-08-15 18:29:59 +00:00
|
|
|
c.ui.Quit()
|
2022-08-15 23:29:19 +00:00
|
|
|
fmt.Println("Bye!")
|
2022-08-15 18:29:59 +00:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// add peer
|
|
|
|
if strings.HasPrefix(line, "/connect") {
|
|
|
|
peer := strings.TrimPrefix(line, "/connect ")
|
|
|
|
c.wg.Add(1)
|
|
|
|
go func(peer string) {
|
|
|
|
defer c.wg.Done()
|
|
|
|
|
|
|
|
ma, err := multiaddr.NewMultiaddr(peer)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
peerID, err := ma.ValueForProtocol(multiaddr.P_P2P)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Connecting to peer: %s", peerID))
|
|
|
|
ctx, cancel := context.WithTimeout(c.ctx, time.Duration(5)*time.Second)
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
err = c.node.DialPeerWithMultiAddress(ctx, ma)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
} else {
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Connected to %s", peerID))
|
|
|
|
}
|
|
|
|
}(peer)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// list peers
|
|
|
|
if line == "/peers" {
|
|
|
|
peers := c.node.Host().Network().Peers()
|
|
|
|
if len(peers) == 0 {
|
|
|
|
c.ui.InfoMessage("No peers available")
|
|
|
|
} else {
|
|
|
|
peerInfoMsg := "Peers: \n"
|
|
|
|
for _, p := range peers {
|
|
|
|
peerInfo := c.node.Host().Peerstore().PeerInfo(p)
|
|
|
|
peerProtocols, err := c.node.Host().Peerstore().GetProtocols(p)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
peerInfoMsg += fmt.Sprintf(" Protocols: %s\n", strings.Join(peerProtocols, ", "))
|
|
|
|
peerInfoMsg += " Addresses:\n"
|
|
|
|
peerInfoMsg += fmt.Sprintf(" - %s:\n", p.Pretty())
|
|
|
|
for _, addr := range peerInfo.Addrs {
|
|
|
|
peerInfoMsg += fmt.Sprintf(" %s/p2p/%s\n", addr.String(), p.Pretty())
|
|
|
|
}
|
|
|
|
}
|
|
|
|
c.ui.InfoMessage(peerInfoMsg)
|
|
|
|
}
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// change nick
|
|
|
|
if strings.HasPrefix(line, "/nick") {
|
|
|
|
newNick := strings.TrimSpace(strings.TrimPrefix(line, "/nick "))
|
|
|
|
if newNick != "" {
|
|
|
|
c.nick = newNick
|
|
|
|
} else {
|
|
|
|
c.ui.ErrorMessage(errors.New("invalid nickname"))
|
|
|
|
}
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
if line == "/help" {
|
|
|
|
c.ui.InfoMessage(`Available commands:
|
|
|
|
/connect multiaddress - dials a node adding it to the list of connected peers
|
|
|
|
/peers - list of peers connected to this node
|
|
|
|
/nick newNick - change the user's nickname
|
2022-08-15 23:29:19 +00:00
|
|
|
/exit - closes the app`)
|
2022-08-15 18:29:59 +00:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
c.SendMessage(line)
|
|
|
|
}()
|
|
|
|
}
|
|
|
|
}
|
2021-06-10 13:00:16 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func (c *Chat) SendMessage(line string) {
|
|
|
|
tCtx, cancel := context.WithTimeout(c.ctx, 3*time.Second)
|
|
|
|
defer func() {
|
|
|
|
cancel()
|
|
|
|
}()
|
|
|
|
|
|
|
|
err := c.publish(tCtx, line)
|
|
|
|
if err != nil {
|
2022-09-11 21:08:58 +00:00
|
|
|
if err.Error() == "validation failed" {
|
|
|
|
err = errors.New("message rate violation!")
|
|
|
|
}
|
2022-08-15 18:29:59 +00:00
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
}
|
|
|
|
}
|
2021-04-04 17:06:17 +00:00
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func (c *Chat) publish(ctx context.Context, message string) error {
|
2021-04-04 17:06:17 +00:00
|
|
|
msg := &pb.Chat2Message{
|
|
|
|
Timestamp: uint64(time.Now().Unix()),
|
2022-08-15 18:29:59 +00:00
|
|
|
Nick: c.nick,
|
2021-04-04 17:06:17 +00:00
|
|
|
Payload: []byte(message),
|
|
|
|
}
|
|
|
|
|
|
|
|
msgBytes, err := proto.Marshal(msg)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-06-10 13:00:16 +00:00
|
|
|
var version uint32
|
2022-07-06 20:29:20 +00:00
|
|
|
var t = time.Now()
|
|
|
|
var timestamp int64 = utils.GetUnixEpochFrom(t)
|
2021-06-10 13:00:16 +00:00
|
|
|
var keyInfo *node.KeyInfo = &node.KeyInfo{}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
if c.options.UsePayloadV1 { // Use WakuV1 encryption
|
2021-06-10 13:00:16 +00:00
|
|
|
keyInfo.Kind = node.Symmetric
|
2022-08-15 18:29:59 +00:00
|
|
|
keyInfo.SymKey = generateSymKey(c.options.ContentTopic)
|
2021-06-10 13:00:16 +00:00
|
|
|
version = 1
|
|
|
|
} else {
|
|
|
|
keyInfo.Kind = node.None
|
|
|
|
version = 0
|
|
|
|
}
|
2021-04-06 23:27:54 +00:00
|
|
|
|
|
|
|
p := new(node.Payload)
|
|
|
|
p.Data = msgBytes
|
|
|
|
p.Key = keyInfo
|
2021-04-04 17:06:17 +00:00
|
|
|
|
2021-06-10 13:00:16 +00:00
|
|
|
payload, err := p.Encode(version)
|
2021-04-04 17:06:17 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-04-22 00:12:51 +00:00
|
|
|
wakuMsg := &wpb.WakuMessage{
|
2021-04-04 17:06:17 +00:00
|
|
|
Payload: payload,
|
2021-04-07 21:19:39 +00:00
|
|
|
Version: version,
|
2022-08-15 18:29:59 +00:00
|
|
|
ContentTopic: options.ContentTopic,
|
2021-04-07 21:19:39 +00:00
|
|
|
Timestamp: timestamp,
|
2021-04-04 17:06:17 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
if c.options.RLNRelay.Enable {
|
2022-07-06 20:29:20 +00:00
|
|
|
// for future version when we support more than one rln protected content topic,
|
|
|
|
// we should check the message content topic as well
|
2022-08-15 18:29:59 +00:00
|
|
|
err = c.node.RLNRelay().AppendRLNProof(wakuMsg, t)
|
2022-07-06 20:29:20 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2022-08-15 18:29:59 +00:00
|
|
|
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("RLN Epoch: %d", rln.BytesToEpoch(wakuMsg.RateLimitProof.Epoch).Uint64()))
|
2022-07-06 20:29:20 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
if c.options.LightPush.Enable {
|
|
|
|
var lightOpt lightpush.LightPushOption
|
|
|
|
var peerID peer.ID
|
|
|
|
peerID, err = options.LightPush.NodePeerID()
|
|
|
|
if err != nil {
|
|
|
|
lightOpt = lightpush.WithAutomaticPeerSelection()
|
|
|
|
} else {
|
|
|
|
lightOpt = lightpush.WithPeer(peerID)
|
|
|
|
}
|
2021-11-01 14:42:55 +00:00
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
_, err = c.node.Lightpush().Publish(c.ctx, wakuMsg, lightOpt)
|
2021-11-01 14:42:55 +00:00
|
|
|
} else {
|
2022-08-15 18:29:59 +00:00
|
|
|
_, err = c.node.Relay().Publish(ctx, wakuMsg)
|
2021-11-01 14:42:55 +00:00
|
|
|
}
|
2021-04-11 23:45:42 +00:00
|
|
|
|
|
|
|
return err
|
2021-04-04 17:06:17 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func decodeMessage(useV1Payload bool, contentTopic string, wakumsg *wpb.WakuMessage) (*pb.Chat2Message, error) {
|
2021-06-10 13:00:16 +00:00
|
|
|
var keyInfo *node.KeyInfo = &node.KeyInfo{}
|
2022-07-06 20:29:20 +00:00
|
|
|
if useV1Payload { // Use WakuV1 encryption
|
2021-06-10 13:00:16 +00:00
|
|
|
keyInfo.Kind = node.Symmetric
|
2022-07-06 20:29:20 +00:00
|
|
|
keyInfo.SymKey = generateSymKey(contentTopic)
|
2021-06-10 13:00:16 +00:00
|
|
|
} else {
|
|
|
|
keyInfo.Kind = node.None
|
|
|
|
}
|
|
|
|
|
|
|
|
payload, err := node.DecodePayload(wakumsg, keyInfo)
|
2021-04-12 18:03:58 +00:00
|
|
|
if err != nil {
|
2022-07-06 20:29:20 +00:00
|
|
|
return nil, err
|
2021-04-12 18:03:58 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
msg := &pb.Chat2Message{}
|
|
|
|
if err := proto.Unmarshal(payload.Data, msg); err != nil {
|
2022-07-06 20:29:20 +00:00
|
|
|
return nil, err
|
2021-04-12 18:03:58 +00:00
|
|
|
}
|
|
|
|
|
2022-07-06 20:29:20 +00:00
|
|
|
return msg, nil
|
2021-04-12 18:03:58 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func generateSymKey(password string) []byte {
|
|
|
|
// AesKeyLength represents the length (in bytes) of an private key
|
|
|
|
AESKeyLength := 256 / 8
|
|
|
|
return pbkdf2.Key([]byte(password), nil, 65356, AESKeyLength, sha256.New)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *Chat) retrieveHistory(connectionWg *sync.WaitGroup) {
|
|
|
|
defer c.wg.Done()
|
|
|
|
|
|
|
|
connectionWg.Wait() // Wait until node connection operations are done
|
|
|
|
|
|
|
|
if !c.options.Store.Enable {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
var storeOpt store.HistoryRequestOption
|
|
|
|
if c.options.Store.Node == nil {
|
|
|
|
c.ui.InfoMessage("No store node configured. Choosing one at random...")
|
|
|
|
storeOpt = store.WithAutomaticPeerSelection()
|
|
|
|
} else {
|
|
|
|
peerID, err := (*c.options.Store.Node).ValueForProtocol(multiaddr.P_P2P)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
pID, err := peer.Decode(peerID)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
2022-07-06 20:29:20 +00:00
|
|
|
}
|
2022-08-15 18:29:59 +00:00
|
|
|
storeOpt = store.WithPeer(pID)
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Querying historic messages from %s", peerID))
|
|
|
|
|
2022-07-06 20:29:20 +00:00
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
tCtx, cancel := context.WithTimeout(c.ctx, 10*time.Second)
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
q := store.Query{
|
|
|
|
ContentTopics: []string{options.ContentTopic},
|
|
|
|
}
|
|
|
|
|
|
|
|
response, err := c.node.Store().Query(tCtx, q,
|
|
|
|
store.WithAutomaticRequestId(),
|
|
|
|
storeOpt,
|
|
|
|
store.WithPaging(true, 100))
|
|
|
|
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(fmt.Errorf("could not query storenode: %w", err))
|
|
|
|
} else {
|
|
|
|
if len(response.Messages) == 0 {
|
|
|
|
c.ui.InfoMessage("0 historic messages available")
|
|
|
|
} else {
|
|
|
|
for _, msg := range response.Messages {
|
|
|
|
c.C <- protocol.NewEnvelope(msg, msg.Timestamp, relay.DefaultWakuTopic)
|
|
|
|
}
|
2022-07-06 20:29:20 +00:00
|
|
|
}
|
2021-04-12 18:03:58 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
func (c *Chat) staticNodes(connectionWg *sync.WaitGroup) {
|
|
|
|
defer c.wg.Done()
|
|
|
|
defer connectionWg.Done()
|
|
|
|
|
|
|
|
<-c.uiReady // wait until UI is ready
|
|
|
|
|
|
|
|
wg := sync.WaitGroup{}
|
|
|
|
|
|
|
|
wg.Add(len(options.StaticNodes))
|
|
|
|
for _, n := range options.StaticNodes {
|
|
|
|
go func(addr multiaddr.Multiaddr) {
|
|
|
|
defer wg.Done()
|
|
|
|
ctx, cancel := context.WithTimeout(c.ctx, time.Duration(3)*time.Second)
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
peerID, err := addr.ValueForProtocol(multiaddr.P_P2P)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Connecting to %s", addr.String()))
|
|
|
|
|
|
|
|
err = c.node.DialPeerWithMultiAddress(ctx, addr)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
} else {
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Connected to %s", peerID))
|
|
|
|
}
|
|
|
|
}(n)
|
|
|
|
}
|
|
|
|
|
|
|
|
wg.Wait()
|
|
|
|
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *Chat) welcomeMessage() {
|
|
|
|
defer c.wg.Done()
|
|
|
|
|
|
|
|
<-c.uiReady // wait until UI is ready
|
|
|
|
|
2022-08-15 23:29:19 +00:00
|
|
|
c.ui.InfoMessage("Welcome, " + c.nick + "!")
|
2022-08-15 18:29:59 +00:00
|
|
|
c.ui.InfoMessage("type /help to see available commands \n")
|
|
|
|
|
2022-08-15 23:29:19 +00:00
|
|
|
addrMessage := "Listening on:\n"
|
|
|
|
for _, addr := range c.node.ListenAddresses() {
|
|
|
|
addrMessage += " -" + addr.String() + "\n"
|
|
|
|
}
|
|
|
|
c.ui.InfoMessage(addrMessage)
|
|
|
|
|
2022-08-15 18:29:59 +00:00
|
|
|
if !c.options.RLNRelay.Enable {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
idKey := c.node.RLNRelay().MembershipKeyPair().IDKey
|
|
|
|
idCommitment := c.node.RLNRelay().MembershipKeyPair().IDCommitment
|
|
|
|
|
|
|
|
rlnMessage := "RLN config:\n"
|
|
|
|
rlnMessage += fmt.Sprintf("- Your membership index is: %d\n", uint(c.node.RLNRelay().MembershipIndex()))
|
|
|
|
rlnMessage += fmt.Sprintf("- Your rln identity key is: 0x%s\n", hex.EncodeToString(idKey[:]))
|
|
|
|
rlnMessage += fmt.Sprintf("- Your rln identity commitment key is: 0x%s\n", hex.EncodeToString(idCommitment[:]))
|
|
|
|
|
|
|
|
c.ui.InfoMessage(rlnMessage)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *Chat) discoverNodes(connectionWg *sync.WaitGroup) {
|
|
|
|
defer c.wg.Done()
|
|
|
|
defer connectionWg.Done()
|
|
|
|
|
|
|
|
<-c.uiReady // wait until UI is ready
|
|
|
|
|
|
|
|
var dnsDiscoveryUrl string
|
|
|
|
if options.Fleet != fleetNone {
|
|
|
|
if options.Fleet == fleetTest {
|
|
|
|
dnsDiscoveryUrl = "enrtree://AOFTICU2XWDULNLZGRMQS4RIZPAZEHYMV4FYHAPW563HNRAOERP7C@test.waku.nodes.status.im"
|
|
|
|
} else {
|
|
|
|
// Connect to prod by default
|
|
|
|
dnsDiscoveryUrl = "enrtree://ANTL4SLG2COUILKAPE7EF2BYNL2SHSHVCHLRD5J7ZJLN5R3PRJD2Y@prod.waku.nodes.status.im"
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if options.DNSDiscovery.Enable && options.DNSDiscovery.URL != "" {
|
|
|
|
dnsDiscoveryUrl = options.DNSDiscovery.URL
|
|
|
|
}
|
|
|
|
|
|
|
|
if dnsDiscoveryUrl != "" {
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("attempting DNS discovery with %s", dnsDiscoveryUrl))
|
|
|
|
nodes, err := dnsdisc.RetrieveNodes(c.ctx, dnsDiscoveryUrl, dnsdisc.WithNameserver(options.DNSDiscovery.Nameserver))
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(errors.New(err.Error()))
|
|
|
|
} else {
|
|
|
|
var nodeList []multiaddr.Multiaddr
|
|
|
|
for _, n := range nodes {
|
|
|
|
nodeList = append(nodeList, n.Addresses...)
|
|
|
|
}
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Discovered and connecting to %v ", nodeList))
|
|
|
|
wg := sync.WaitGroup{}
|
|
|
|
wg.Add(len(nodeList))
|
|
|
|
for _, n := range nodeList {
|
|
|
|
go func(ctx context.Context, addr multiaddr.Multiaddr) {
|
|
|
|
defer wg.Done()
|
|
|
|
|
|
|
|
peerID, err := addr.ValueForProtocol(multiaddr.P_P2P)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2022-08-27 01:54:25 +00:00
|
|
|
ctx, cancel := context.WithTimeout(ctx, time.Duration(7)*time.Second)
|
2022-08-15 18:29:59 +00:00
|
|
|
defer cancel()
|
|
|
|
err = c.node.DialPeerWithMultiAddress(ctx, addr)
|
|
|
|
if err != nil {
|
|
|
|
c.ui.ErrorMessage(fmt.Errorf("could not connect to %s: %w", peerID, err))
|
|
|
|
} else {
|
|
|
|
c.ui.InfoMessage(fmt.Sprintf("Connected to %s", peerID))
|
|
|
|
}
|
|
|
|
}(c.ctx, n)
|
|
|
|
|
|
|
|
}
|
|
|
|
wg.Wait()
|
2022-07-06 20:29:20 +00:00
|
|
|
}
|
2021-04-04 17:06:17 +00:00
|
|
|
}
|
|
|
|
}
|