Skip to content

Commit

Permalink
fix: avoid panic when peer is blacklisted after connection
Browse files Browse the repository at this point in the history
  • Loading branch information
iand authored and vyzo committed Jul 19, 2021
1 parent 3b98004 commit 079d897
Show file tree
Hide file tree
Showing 3 changed files with 51 additions and 2 deletions.
1 change: 0 additions & 1 deletion blacklist_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@ func TestMapBlacklist(t *testing.T) {
if !b.Contains(p) {
t.Fatal("peer not in the blacklist")
}

}

func TestTimeCachedBlacklist(t *testing.T) {
Expand Down
3 changes: 2 additions & 1 deletion pubsub.go
Original file line number Diff line number Diff line change
Expand Up @@ -493,8 +493,8 @@ func (p *PubSub) processLoop(ctx context.Context) {

case s := <-p.newPeerStream:
pid := s.Conn().RemotePeer()

ch, ok := p.peers[pid]

if !ok {
log.Warn("new stream for unknown peer: ", pid)
s.Reset()
Expand All @@ -504,6 +504,7 @@ func (p *PubSub) processLoop(ctx context.Context) {
if p.blacklist.Contains(pid) {
log.Warn("closing stream for blacklisted peer: ", pid)
close(ch)
delete(p.peers, pid)
s.Reset()
continue
}
Expand Down
49 changes: 49 additions & 0 deletions pubsub_test.go
Original file line number Diff line number Diff line change
@@ -0,0 +1,49 @@
package pubsub

import (
"context"
"testing"
"time"
)

// See https://github.com/libp2p/go-libp2p-pubsub/issues/426
func TestPubSubRemovesBlacklistedPeer(t *testing.T) {
ctx, cancel := context.WithCancel(context.Background())

hosts := getNetHosts(t, ctx, 2)

bl := NewMapBlacklist()

psubs0 := getPubsub(ctx, hosts[0])
psubs1 := getPubsub(ctx, hosts[1], WithBlacklist(bl))
connect(t, hosts[0], hosts[1])

// Bad peer is blacklisted after it has connected.
// Calling p.BlacklistPeer directly does the right thing but we should also clean
// up the peer if it has been added the the blacklist by another means.
bl.Add(hosts[0].ID())

_, err := psubs0.Subscribe("test")
if err != nil {
t.Fatal(err)
}

sub1, err := psubs1.Subscribe("test")
if err != nil {
t.Fatal(err)
}

time.Sleep(time.Millisecond * 100)

psubs0.Publish("test", []byte("message"))

wctx, cancel2 := context.WithTimeout(ctx, 1*time.Second)
defer cancel2()

_, _ = sub1.Next(wctx)

// Explicitly cancel context so PubSub cleans up peer channels.
// Issue 426 reports a panic due to a peer channel being closed twice.
cancel()
time.Sleep(time.Millisecond * 100)
}

0 comments on commit 079d897

Please sign in to comment.