2016-09-10 03:13:50 +00:00
|
|
|
package floodsub
|
2016-09-10 00:15:39 +00:00
|
|
|
|
|
|
|
import (
|
|
|
|
"bytes"
|
|
|
|
"context"
|
|
|
|
"fmt"
|
|
|
|
"math/rand"
|
2016-09-14 22:11:41 +00:00
|
|
|
"sort"
|
2016-09-10 00:15:39 +00:00
|
|
|
"testing"
|
|
|
|
"time"
|
|
|
|
|
2016-10-05 19:47:20 +00:00
|
|
|
host "github.com/libp2p/go-libp2p-host"
|
|
|
|
peer "github.com/libp2p/go-libp2p-peer"
|
2016-09-10 15:28:29 +00:00
|
|
|
netutil "github.com/libp2p/go-libp2p/p2p/test/util"
|
2016-09-10 00:15:39 +00:00
|
|
|
)
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
func checkMessageRouting(t *testing.T, topic string, pubs []*PubSub, subs []*Subscription) {
|
2016-09-14 21:11:46 +00:00
|
|
|
data := make([]byte, 16)
|
|
|
|
rand.Read(data)
|
|
|
|
|
|
|
|
for _, p := range pubs {
|
|
|
|
err := p.Publish(topic, data)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, s := range subs {
|
|
|
|
assertReceive(t, s, data)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-09-10 23:03:53 +00:00
|
|
|
func getNetHosts(t *testing.T, ctx context.Context, n int) []host.Host {
|
2016-09-10 00:15:39 +00:00
|
|
|
var out []host.Host
|
|
|
|
|
|
|
|
for i := 0; i < n; i++ {
|
2016-09-10 23:03:53 +00:00
|
|
|
h := netutil.GenHostSwarm(t, ctx)
|
2016-09-10 00:15:39 +00:00
|
|
|
out = append(out, h)
|
|
|
|
}
|
|
|
|
|
|
|
|
return out
|
|
|
|
}
|
|
|
|
|
|
|
|
func connect(t *testing.T, a, b host.Host) {
|
|
|
|
pinfo := a.Peerstore().PeerInfo(a.ID())
|
|
|
|
err := b.Connect(context.Background(), pinfo)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-09-10 23:03:53 +00:00
|
|
|
func sparseConnect(t *testing.T, hosts []host.Host) {
|
|
|
|
for i, a := range hosts {
|
|
|
|
for j := 0; j < 3; j++ {
|
|
|
|
n := rand.Intn(len(hosts))
|
|
|
|
if n == i {
|
|
|
|
j--
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
b := hosts[n]
|
|
|
|
|
|
|
|
connect(t, a, b)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-09-10 00:15:39 +00:00
|
|
|
func connectAll(t *testing.T, hosts []host.Host) {
|
|
|
|
for i, a := range hosts {
|
|
|
|
for j, b := range hosts {
|
|
|
|
if i == j {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
connect(t, a, b)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-09-10 23:03:53 +00:00
|
|
|
func getPubsubs(ctx context.Context, hs []host.Host) []*PubSub {
|
2016-09-10 00:15:39 +00:00
|
|
|
var psubs []*PubSub
|
2016-09-10 23:03:53 +00:00
|
|
|
for _, h := range hs {
|
|
|
|
psubs = append(psubs, NewFloodSub(ctx, h))
|
2016-09-10 00:15:39 +00:00
|
|
|
}
|
2016-09-10 23:03:53 +00:00
|
|
|
return psubs
|
|
|
|
}
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
func assertReceive(t *testing.T, ch *Subscription, exp []byte) {
|
2016-09-12 20:22:16 +00:00
|
|
|
select {
|
2016-10-19 23:01:06 +00:00
|
|
|
case msg := <-ch.ch:
|
2016-09-12 20:22:16 +00:00
|
|
|
if !bytes.Equal(msg.GetData(), exp) {
|
|
|
|
t.Fatalf("got wrong message, expected %s but got %s", string(exp), string(msg.GetData()))
|
|
|
|
}
|
|
|
|
case <-time.After(time.Second * 5):
|
2016-10-19 23:01:06 +00:00
|
|
|
t.Logf("%#v\n", ch)
|
2016-09-12 20:22:16 +00:00
|
|
|
t.Fatal("timed out waiting for message of: ", string(exp))
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-09-10 23:03:53 +00:00
|
|
|
func TestBasicFloodsub(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
hosts := getNetHosts(t, ctx, 20)
|
|
|
|
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
2016-09-10 00:15:39 +00:00
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
var msgs []*Subscription
|
2016-09-10 00:15:39 +00:00
|
|
|
for _, ps := range psubs {
|
2016-11-11 23:47:53 +00:00
|
|
|
subch, err := ps.Subscribe("foobar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-10 00:15:39 +00:00
|
|
|
|
|
|
|
msgs = append(msgs, subch)
|
|
|
|
}
|
|
|
|
|
2016-09-10 23:03:53 +00:00
|
|
|
//connectAll(t, hosts)
|
|
|
|
sparseConnect(t, hosts)
|
2016-09-10 00:15:39 +00:00
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 100)
|
|
|
|
|
|
|
|
for i := 0; i < 100; i++ {
|
|
|
|
msg := []byte(fmt.Sprintf("%d the flooooooood %d", i, i))
|
|
|
|
|
|
|
|
owner := rand.Intn(len(psubs))
|
|
|
|
|
|
|
|
psubs[owner].Publish("foobar", msg)
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
for _, sub := range msgs {
|
2016-11-17 10:27:57 +00:00
|
|
|
got, err := sub.Next(ctx)
|
2016-10-19 23:01:06 +00:00
|
|
|
if err != nil {
|
|
|
|
t.Fatal(sub.err)
|
|
|
|
}
|
2016-09-10 00:15:39 +00:00
|
|
|
if !bytes.Equal(msg, got.Data) {
|
|
|
|
t.Fatal("got wrong message!")
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2016-09-10 23:03:53 +00:00
|
|
|
|
|
|
|
}
|
|
|
|
|
|
|
|
func TestMultihops(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
hosts := getNetHosts(t, ctx, 6)
|
|
|
|
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
|
|
|
connect(t, hosts[0], hosts[1])
|
|
|
|
connect(t, hosts[1], hosts[2])
|
|
|
|
connect(t, hosts[2], hosts[3])
|
|
|
|
connect(t, hosts[3], hosts[4])
|
|
|
|
connect(t, hosts[4], hosts[5])
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
var subs []*Subscription
|
2016-09-10 23:03:53 +00:00
|
|
|
for i := 1; i < 6; i++ {
|
2016-11-11 23:47:53 +00:00
|
|
|
ch, err := psubs[i].Subscribe("foobar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-10-19 23:01:06 +00:00
|
|
|
subs = append(subs, ch)
|
2016-09-10 23:03:53 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 100)
|
|
|
|
|
|
|
|
msg := []byte("i like cats")
|
|
|
|
err := psubs[0].Publish("foobar", msg)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
// last node in the chain should get the message
|
|
|
|
select {
|
2016-10-19 23:01:06 +00:00
|
|
|
case out := <-subs[4].ch:
|
2016-09-10 23:03:53 +00:00
|
|
|
if !bytes.Equal(out.GetData(), msg) {
|
|
|
|
t.Fatal("got wrong data")
|
|
|
|
}
|
|
|
|
case <-time.After(time.Second * 5):
|
|
|
|
t.Fatal("timed out waiting for message")
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func TestReconnects(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
2016-09-12 20:22:16 +00:00
|
|
|
hosts := getNetHosts(t, ctx, 3)
|
2016-09-10 23:03:53 +00:00
|
|
|
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
|
|
|
connect(t, hosts[0], hosts[1])
|
|
|
|
connect(t, hosts[0], hosts[2])
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
A, err := psubs[1].Subscribe("cats")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-10 23:03:53 +00:00
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
B, err := psubs[2].Subscribe("cats")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-10 23:03:53 +00:00
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 100)
|
|
|
|
|
|
|
|
msg := []byte("apples and oranges")
|
2016-11-11 23:47:53 +00:00
|
|
|
err = psubs[0].Publish("cats", msg)
|
2016-09-10 23:03:53 +00:00
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
assertReceive(t, A, msg)
|
|
|
|
assertReceive(t, B, msg)
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
B.Cancel()
|
2016-09-12 20:22:16 +00:00
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 50)
|
2016-09-10 23:03:53 +00:00
|
|
|
|
|
|
|
msg2 := []byte("potato")
|
|
|
|
err = psubs[0].Publish("cats", msg2)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
assertReceive(t, A, msg2)
|
2016-09-12 20:22:16 +00:00
|
|
|
select {
|
2016-10-19 23:01:06 +00:00
|
|
|
case _, ok := <-B.ch:
|
2016-09-12 20:22:16 +00:00
|
|
|
if ok {
|
|
|
|
t.Fatal("shouldnt have gotten data on this channel")
|
|
|
|
}
|
|
|
|
case <-time.After(time.Second):
|
|
|
|
t.Fatal("timed out waiting for B chan to be closed")
|
|
|
|
}
|
2016-09-10 23:03:53 +00:00
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
nSubs := len(psubs[2].myTopics["cats"])
|
|
|
|
if nSubs > 0 {
|
|
|
|
t.Fatal(`B should have 0 subscribers for channel "cats", has`, nSubs)
|
|
|
|
}
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
ch2, err := psubs[2].Subscribe("cats")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-10 23:03:53 +00:00
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
time.Sleep(time.Millisecond * 100)
|
2016-09-12 20:22:16 +00:00
|
|
|
|
|
|
|
nextmsg := []byte("ifps is kul")
|
|
|
|
err = psubs[0].Publish("cats", nextmsg)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
2016-09-10 23:03:53 +00:00
|
|
|
}
|
2016-09-12 20:22:16 +00:00
|
|
|
|
|
|
|
assertReceive(t, ch2, nextmsg)
|
2016-09-10 00:15:39 +00:00
|
|
|
}
|
2016-09-11 20:56:07 +00:00
|
|
|
|
2016-09-12 20:22:16 +00:00
|
|
|
// make sure messages arent routed between nodes who arent subscribed
|
2016-09-11 20:56:07 +00:00
|
|
|
func TestNoConnection(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
hosts := getNetHosts(t, ctx, 10)
|
|
|
|
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
ch, err := psubs[5].Subscribe("foobar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-11 20:56:07 +00:00
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
err = psubs[0].Publish("foobar", []byte("TESTING"))
|
2016-09-11 20:56:07 +00:00
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
select {
|
2016-10-19 23:01:06 +00:00
|
|
|
case <-ch.ch:
|
2016-09-11 20:56:07 +00:00
|
|
|
t.Fatal("shouldnt have gotten a message")
|
|
|
|
case <-time.After(time.Millisecond * 200):
|
|
|
|
}
|
|
|
|
}
|
2016-09-12 20:22:16 +00:00
|
|
|
|
|
|
|
func TestSelfReceive(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
host := getNetHosts(t, ctx, 1)[0]
|
|
|
|
|
|
|
|
psub := NewFloodSub(ctx, host)
|
|
|
|
|
|
|
|
msg := []byte("hello world")
|
|
|
|
|
|
|
|
err := psub.Publish("foobar", msg)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 10)
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
ch, err := psub.Subscribe("foobar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-12 20:22:16 +00:00
|
|
|
|
|
|
|
msg2 := []byte("goodbye world")
|
|
|
|
err = psub.Publish("foobar", msg2)
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
|
|
|
|
assertReceive(t, ch, msg2)
|
|
|
|
}
|
2016-09-14 21:11:46 +00:00
|
|
|
|
|
|
|
func TestOneToOne(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
hosts := getNetHosts(t, ctx, 2)
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
|
|
|
connect(t, hosts[0], hosts[1])
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
ch, err := psubs[1].Subscribe("foobar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-14 21:11:46 +00:00
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 50)
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
checkMessageRouting(t, "foobar", psubs, []*Subscription{ch})
|
2016-09-14 21:11:46 +00:00
|
|
|
}
|
|
|
|
|
2016-09-15 01:07:30 +00:00
|
|
|
func assertPeerLists(t *testing.T, hosts []host.Host, ps *PubSub, has ...int) {
|
2016-10-18 18:13:12 +00:00
|
|
|
peers := ps.ListPeers("")
|
2016-09-15 01:07:30 +00:00
|
|
|
set := make(map[peer.ID]struct{})
|
|
|
|
for _, p := range peers {
|
|
|
|
set[p] = struct{}{}
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, h := range has {
|
|
|
|
if _, ok := set[hosts[h].ID()]; !ok {
|
|
|
|
t.Fatal("expected to have connection to peer: ", h)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-09-14 21:11:46 +00:00
|
|
|
func TestTreeTopology(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
hosts := getNetHosts(t, ctx, 10)
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
|
|
|
connect(t, hosts[0], hosts[1])
|
|
|
|
connect(t, hosts[1], hosts[2])
|
|
|
|
connect(t, hosts[1], hosts[4])
|
|
|
|
connect(t, hosts[2], hosts[3])
|
|
|
|
connect(t, hosts[0], hosts[5])
|
|
|
|
connect(t, hosts[5], hosts[6])
|
|
|
|
connect(t, hosts[5], hosts[8])
|
|
|
|
connect(t, hosts[6], hosts[7])
|
|
|
|
connect(t, hosts[8], hosts[9])
|
|
|
|
|
|
|
|
/*
|
|
|
|
[0] -> [1] -> [2] -> [3]
|
|
|
|
| L->[4]
|
|
|
|
v
|
|
|
|
[5] -> [6] -> [7]
|
|
|
|
|
|
|
|
|
v
|
|
|
|
[8] -> [9]
|
|
|
|
*/
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
var chs []*Subscription
|
2016-09-14 21:11:46 +00:00
|
|
|
for _, ps := range psubs {
|
2016-11-11 23:47:53 +00:00
|
|
|
ch, err := ps.Subscribe("fizzbuzz")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-14 21:11:46 +00:00
|
|
|
|
|
|
|
chs = append(chs, ch)
|
|
|
|
}
|
|
|
|
|
|
|
|
time.Sleep(time.Millisecond * 50)
|
|
|
|
|
2016-09-15 01:07:30 +00:00
|
|
|
assertPeerLists(t, hosts, psubs[0], 1, 5)
|
|
|
|
assertPeerLists(t, hosts, psubs[1], 0, 2, 4)
|
|
|
|
assertPeerLists(t, hosts, psubs[2], 1, 3)
|
|
|
|
|
2016-09-14 21:11:46 +00:00
|
|
|
checkMessageRouting(t, "fizzbuzz", []*PubSub{psubs[9], psubs[3]}, chs)
|
|
|
|
}
|
2016-09-14 22:11:41 +00:00
|
|
|
|
|
|
|
func assertHasTopics(t *testing.T, ps *PubSub, exptopics ...string) {
|
|
|
|
topics := ps.GetTopics()
|
|
|
|
sort.Strings(topics)
|
|
|
|
sort.Strings(exptopics)
|
|
|
|
|
|
|
|
if len(topics) != len(exptopics) {
|
|
|
|
t.Fatalf("expected to have %v, but got %v", exptopics, topics)
|
|
|
|
}
|
|
|
|
|
|
|
|
for i, v := range exptopics {
|
|
|
|
if topics[i] != v {
|
|
|
|
t.Fatalf("expected %s but have %s", v, topics[i])
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func TestSubReporting(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
host := getNetHosts(t, ctx, 1)[0]
|
|
|
|
psub := NewFloodSub(ctx, host)
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
fooSub, err := psub.Subscribe("foo")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-14 22:11:41 +00:00
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
barSub, err := psub.Subscribe("bar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-14 22:11:41 +00:00
|
|
|
|
|
|
|
assertHasTopics(t, psub, "foo", "bar")
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
_, err = psub.Subscribe("baz")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-14 22:11:41 +00:00
|
|
|
|
|
|
|
assertHasTopics(t, psub, "foo", "bar", "baz")
|
|
|
|
|
2016-10-19 23:01:06 +00:00
|
|
|
barSub.Cancel()
|
2016-09-14 22:11:41 +00:00
|
|
|
assertHasTopics(t, psub, "foo", "baz")
|
2016-10-19 23:01:06 +00:00
|
|
|
fooSub.Cancel()
|
2016-09-14 22:11:41 +00:00
|
|
|
assertHasTopics(t, psub, "baz")
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
_, err = psub.Subscribe("fish")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-09-14 22:11:41 +00:00
|
|
|
|
|
|
|
assertHasTopics(t, psub, "baz", "fish")
|
|
|
|
}
|
2016-10-18 18:13:12 +00:00
|
|
|
|
|
|
|
func TestPeerTopicReporting(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
hosts := getNetHosts(t, ctx, 4)
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
|
|
|
connect(t, hosts[0], hosts[1])
|
|
|
|
connect(t, hosts[0], hosts[2])
|
|
|
|
connect(t, hosts[0], hosts[3])
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
_, err := psubs[1].Subscribe("foo")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
_, err = psubs[1].Subscribe("bar")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
_, err = psubs[1].Subscribe("baz")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-10-18 18:13:12 +00:00
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
_, err = psubs[2].Subscribe("foo")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
_, err = psubs[2].Subscribe("ipfs")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-10-18 18:13:12 +00:00
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
_, err = psubs[3].Subscribe("baz")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
_, err = psubs[3].Subscribe("ipfs")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-10-18 18:13:12 +00:00
|
|
|
|
2016-11-13 00:31:02 +00:00
|
|
|
time.Sleep(time.Millisecond * 10)
|
|
|
|
|
2016-10-18 18:13:12 +00:00
|
|
|
peers := psubs[0].ListPeers("ipfs")
|
|
|
|
assertPeerList(t, peers, hosts[2].ID(), hosts[3].ID())
|
|
|
|
|
|
|
|
peers = psubs[0].ListPeers("foo")
|
|
|
|
assertPeerList(t, peers, hosts[1].ID(), hosts[2].ID())
|
|
|
|
|
|
|
|
peers = psubs[0].ListPeers("baz")
|
|
|
|
assertPeerList(t, peers, hosts[1].ID(), hosts[3].ID())
|
|
|
|
|
|
|
|
peers = psubs[0].ListPeers("bar")
|
|
|
|
assertPeerList(t, peers, hosts[1].ID())
|
|
|
|
}
|
|
|
|
|
2016-11-11 15:22:47 +00:00
|
|
|
func TestSubscribeMultipleTimes(t *testing.T) {
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
|
|
|
|
|
|
|
hosts := getNetHosts(t, ctx, 2)
|
|
|
|
psubs := getPubsubs(ctx, hosts)
|
|
|
|
|
|
|
|
connect(t, hosts[0], hosts[1])
|
|
|
|
|
2016-11-11 23:47:53 +00:00
|
|
|
sub1, err := psubs[0].Subscribe("foo")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
|
|
|
sub2, err := psubs[0].Subscribe("foo")
|
|
|
|
if err != nil {
|
|
|
|
t.Fatal(err)
|
|
|
|
}
|
2016-11-11 15:22:47 +00:00
|
|
|
|
|
|
|
// make sure subscribing is finished by the time we publish
|
|
|
|
time.Sleep(1 * time.Millisecond)
|
|
|
|
|
|
|
|
psubs[1].Publish("foo", []byte("bar"))
|
|
|
|
|
2016-11-17 10:27:57 +00:00
|
|
|
msg, err := sub1.Next(ctx)
|
2016-11-11 15:22:47 +00:00
|
|
|
if err != nil {
|
|
|
|
t.Fatalf("unexpected error: %v.", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
data := string(msg.GetData())
|
|
|
|
|
|
|
|
if data != "bar" {
|
|
|
|
t.Fatalf("data is %s, expected %s.", data, "bar")
|
|
|
|
}
|
|
|
|
|
2016-11-17 10:27:57 +00:00
|
|
|
msg, err = sub2.Next(ctx)
|
2016-11-11 15:22:47 +00:00
|
|
|
if err != nil {
|
|
|
|
t.Fatalf("unexpected error: %v.", err)
|
|
|
|
}
|
|
|
|
data = string(msg.GetData())
|
|
|
|
|
|
|
|
if data != "bar" {
|
|
|
|
t.Fatalf("data is %s, expected %s.", data, "bar")
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-10-18 18:13:12 +00:00
|
|
|
func assertPeerList(t *testing.T, peers []peer.ID, expected ...peer.ID) {
|
|
|
|
sort.Sort(peer.IDSlice(peers))
|
|
|
|
sort.Sort(peer.IDSlice(expected))
|
|
|
|
|
|
|
|
if len(peers) != len(expected) {
|
2016-10-20 11:46:52 +00:00
|
|
|
t.Fatalf("mismatch: %s != %s", peers, expected)
|
2016-10-18 18:13:12 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
for i, p := range peers {
|
|
|
|
if expected[i] != p {
|
2016-10-20 11:46:52 +00:00
|
|
|
t.Fatalf("mismatch: %s != %s", peers, expected)
|
2016-10-18 18:13:12 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|