]> Sergey Matveev's repositories - btrtrc.git/blobdiff - client.go
Include count of peer conns in status
[btrtrc.git] / client.go
index e68e80b1cde6c996e54e22ce9759bfb8163c4bfe..3c42fda4bc489fa5afa361f246da8d6bbe82e109 100644 (file)
--- a/client.go
+++ b/client.go
@@ -16,15 +16,16 @@ import (
        "net/netip"
        "sort"
        "strconv"
-       "strings"
        "time"
 
+       "github.com/anacrolix/torrent/internal/panicif"
+
        "github.com/anacrolix/chansync"
        "github.com/anacrolix/chansync/events"
        "github.com/anacrolix/dht/v2"
        "github.com/anacrolix/dht/v2/krpc"
-       "github.com/anacrolix/generics"
        . "github.com/anacrolix/generics"
+       g "github.com/anacrolix/generics"
        "github.com/anacrolix/log"
        "github.com/anacrolix/missinggo/perf"
        "github.com/anacrolix/missinggo/v2"
@@ -38,14 +39,17 @@ import (
        "golang.org/x/time/rate"
 
        "github.com/anacrolix/torrent/bencode"
+       "github.com/anacrolix/torrent/internal/check"
        "github.com/anacrolix/torrent/internal/limiter"
        "github.com/anacrolix/torrent/iplist"
        "github.com/anacrolix/torrent/metainfo"
        "github.com/anacrolix/torrent/mse"
        pp "github.com/anacrolix/torrent/peer_protocol"
+       utHolepunch "github.com/anacrolix/torrent/peer_protocol/ut-holepunch"
        request_strategy "github.com/anacrolix/torrent/request-strategy"
        "github.com/anacrolix/torrent/storage"
        "github.com/anacrolix/torrent/tracker"
+       "github.com/anacrolix/torrent/types/infohash"
        "github.com/anacrolix/torrent/webtorrent"
 )
 
@@ -54,7 +58,7 @@ import (
 type Client struct {
        // An aggregate of stats over all connections. First in struct to ensure 64-bit alignment of
        // fields. See #262.
-       stats ConnStats
+       connStats ConnStats
 
        _mu    lockWithDeferreds
        event  sync.Cond
@@ -87,6 +91,10 @@ type Client struct {
 
        activeAnnounceLimiter limiter.Instance
        httpClient            *http.Client
+
+       undialableWithoutHolepunch                                   map[netip.AddrPort]struct{}
+       undialableWithoutHolepunchDialAttemptedAfterHolepunchConnect map[netip.AddrPort]struct{}
+       dialableOnlyAfterHolepunch                                   map[netip.AddrPort]struct{}
 }
 
 type ipStr string
@@ -146,7 +154,7 @@ func (cl *Client) WriteStatus(_w io.Writer) {
                fmt.Fprintf(w, "%s DHT server at %s:\n", s.Addr().Network(), s.Addr().String())
                writeDhtServerStatus(w, s)
        })
-       spew.Fdump(w, &cl.stats)
+       dumpStats(w, cl.statsLocked())
        torrentsSlice := cl.torrentsAsSlice()
        fmt.Fprintf(w, "# Torrents: %d\n", len(torrentsSlice))
        fmt.Fprintln(w)
@@ -194,7 +202,7 @@ func (cl *Client) announceKey() int32 {
 // Initializes a bare minimum Client. *Client and *ClientConfig must not be nil.
 func (cl *Client) init(cfg *ClientConfig) {
        cl.config = cfg
-       generics.MakeMap(&cl.dopplegangerAddrs)
+       g.MakeMap(&cl.dopplegangerAddrs)
        cl.torrents = make(map[metainfo.Hash]*Torrent)
        cl.dialRateLimiter = rate.NewLimiter(10, 10)
        cl.activeAnnounceLimiter.SlotsPerKey = 2
@@ -297,8 +305,9 @@ func NewClient(cfg *ClientConfig) (cl *Client, err error) {
                        }
                        return t.announceRequest(event), nil
                },
-               Proxy:       cl.config.HTTPProxy,
-               DialContext: cl.config.TrackerDialContext,
+               Proxy:                      cl.config.HTTPProxy,
+               WebsocketTrackerHttpHeader: cl.config.WebsocketTrackerHttpHeader,
+               DialContext:                cl.config.TrackerDialContext,
                OnConn: func(dc datachannel.ReadWriteCloser, dcc webtorrent.DataChannelContext) {
                        cl.lock()
                        defer cl.unlock()
@@ -457,7 +466,7 @@ func (cl *Client) wantConns() bool {
                return true
        }
        for _, t := range cl.torrents {
-               if t.wantConns() {
+               if t.wantIncomingConns() {
                        return true
                }
        }
@@ -643,7 +652,7 @@ func DialFirst(ctx context.Context, addr string, dialers []Dialer) (res DialResu
                        res = <-resCh
                }
        }()
-       // There are still incompleted dials.
+       // There are still uncompleted dials.
        go func() {
                for ; left > 0; left-- {
                        conn := (<-resCh).Conn
@@ -660,8 +669,12 @@ func DialFirst(ctx context.Context, addr string, dialers []Dialer) (res DialResu
 
 func dialFromSocket(ctx context.Context, s Dialer, addr string) net.Conn {
        c, err := s.Dial(ctx, addr)
+       if err != nil {
+               log.Levelf(log.Debug, "error dialing %q: %v", addr, err)
+       }
        // This is a bit optimistic, but it looks non-trivial to thread this through the proxy code. Set
-       // it now in case we close the connection forthwith.
+       // it now in case we close the connection forthwith. Note this is also done in the TCP dialer
+       // code to increase the chance it's done.
        if tc, ok := c.(*net.TCPConn); ok {
                tc.SetLinger(0)
        }
@@ -669,22 +682,29 @@ func dialFromSocket(ctx context.Context, s Dialer, addr string) net.Conn {
        return c
 }
 
-func forgettableDialError(err error) bool {
-       return strings.Contains(err.Error(), "no suitable address found")
-}
-
-func (cl *Client) noLongerHalfOpen(t *Torrent, addr string) {
-       if _, ok := t.halfOpen[addr]; !ok {
-               panic("invariant broken")
+func (cl *Client) noLongerHalfOpen(t *Torrent, addr string, attemptKey outgoingConnAttemptKey) {
+       path := t.getHalfOpenPath(addr, attemptKey)
+       if !path.Exists() {
+               panic("should exist")
        }
-       delete(t.halfOpen, addr)
+       path.Delete()
        cl.numHalfOpen--
+       if cl.numHalfOpen < 0 {
+               panic("should not be possible")
+       }
        for _, t := range cl.torrents {
                t.openNewConns()
        }
 }
 
-// Performs initiator handshakes and returns a connection. Returns nil *connection if no connection
+func (cl *Client) countHalfOpenFromTorrents() (count int) {
+       for _, t := range cl.torrents {
+               count += t.numHalfOpenAttempts()
+       }
+       return
+}
+
+// Performs initiator handshakes and returns a connection. Returns nil *PeerConn if no connection
 // for valid reasons.
 func (cl *Client) initiateProtocolHandshakes(
        ctx context.Context,
@@ -711,8 +731,77 @@ func (cl *Client) initiateProtocolHandshakes(
        return
 }
 
+func (cl *Client) waitForRendezvousConnect(ctx context.Context, rz *utHolepunchRendezvous) error {
+       for {
+               switch {
+               case rz.gotConnect.IsSet():
+                       return nil
+               case len(rz.relays) == 0:
+                       return errors.New("all relays failed")
+               case ctx.Err() != nil:
+                       return context.Cause(ctx)
+               }
+               relayCond := rz.relayCond.Signaled()
+               cl.unlock()
+               select {
+               case <-rz.gotConnect.Done():
+               case <-relayCond:
+               case <-ctx.Done():
+               }
+               cl.lock()
+       }
+}
+
+// Returns nil connection and nil error if no connection could be established for valid reasons.
+func (cl *Client) initiateRendezvousConnect(
+       t *Torrent, holepunchAddr netip.AddrPort,
+) (ok bool, err error) {
+       cl.lock()
+       defer cl.unlock()
+       rz, err := t.startHolepunchRendezvous(holepunchAddr)
+       if err != nil {
+               return
+       }
+       if rz == nil {
+               return
+       }
+       ok = true
+       ctx, cancel := context.WithTimeout(context.Background(), 2*time.Second)
+       defer cancel()
+       err = cl.waitForRendezvousConnect(ctx, rz)
+       delete(t.utHolepunchRendezvous, holepunchAddr)
+       if err != nil {
+               err = fmt.Errorf("waiting for rendezvous connect signal: %w", err)
+       }
+       return
+}
+
 // Returns nil connection and nil error if no connection could be established for valid reasons.
-func (cl *Client) establishOutgoingConnEx(t *Torrent, addr PeerRemoteAddr, obfuscatedHeader bool) (*PeerConn, error) {
+func (cl *Client) establishOutgoingConnEx(
+       opts outgoingConnOpts,
+       obfuscatedHeader bool,
+) (
+       _ *PeerConn, err error,
+) {
+       t := opts.t
+       addr := opts.addr
+       holepunchAddr, err := addrPortFromPeerRemoteAddr(addr)
+       var sentRendezvous bool
+       if err == nil {
+               if !opts.skipHolepunchRendezvous {
+                       sentRendezvous, err = cl.initiateRendezvousConnect(t, holepunchAddr)
+                       if err != nil {
+                               err = fmt.Errorf("initiating rendezvous connect: %w", err)
+                       }
+               }
+       }
+       gotHolepunchConnect := (err == nil && sentRendezvous) || opts.receivedHolepunchConnect
+       if opts.requireRendezvous && !sentRendezvous {
+               return nil, err
+       }
+       if err != nil {
+               t.logger.Print(err)
+       }
        dialCtx, cancel := context.WithTimeout(context.Background(), func() time.Duration {
                cl.rLock()
                defer cl.rUnlock()
@@ -721,21 +810,49 @@ func (cl *Client) establishOutgoingConnEx(t *Torrent, addr PeerRemoteAddr, obfus
        defer cancel()
        dr := cl.dialFirst(dialCtx, addr.String())
        nc := dr.Conn
+       cl.lock()
+       if gotHolepunchConnect && g.MapContains(cl.undialableWithoutHolepunch, holepunchAddr) {
+               g.MakeMapIfNilAndSet(
+                       &cl.undialableWithoutHolepunchDialAttemptedAfterHolepunchConnect,
+                       holepunchAddr,
+                       struct{}{},
+               )
+       }
+       cl.unlock()
        if nc == nil {
+               if !sentRendezvous && !gotHolepunchConnect {
+                       cl.lock()
+                       g.MakeMapIfNilAndSet(&cl.undialableWithoutHolepunch, holepunchAddr, struct{}{})
+                       cl.unlock()
+               }
                if dialCtx.Err() != nil {
                        return nil, fmt.Errorf("dialing: %w", dialCtx.Err())
                }
                return nil, errors.New("dial failed")
        }
+       if gotHolepunchConnect {
+               panicif.False(holepunchAddr.IsValid())
+               cl.lock()
+               if g.MapContains(cl.undialableWithoutHolepunchDialAttemptedAfterHolepunchConnect, holepunchAddr) {
+                       g.MakeMapIfNilAndSet(
+                               &cl.dialableOnlyAfterHolepunch,
+                               holepunchAddr,
+                               struct{}{},
+                       )
+               }
+               cl.unlock()
+       }
        addrIpPort, _ := tryIpPortFromNetAddr(addr)
-       c, err := cl.initiateProtocolHandshakes(context.Background(), nc, t, obfuscatedHeader, newConnectionOpts{
-               outgoing:   true,
-               remoteAddr: addr,
-               // It would be possible to retrieve a public IP from the dialer used here?
-               localPublicAddr: cl.publicAddr(addrIpPort.IP),
-               network:         dr.Dialer.DialerNetwork(),
-               connString:      regularNetConnPeerConnConnString(nc),
-       })
+       c, err := cl.initiateProtocolHandshakes(
+               context.Background(), nc, t, obfuscatedHeader,
+               newConnectionOpts{
+                       outgoing:   true,
+                       remoteAddr: addr,
+                       // It would be possible to retrieve a public IP from the dialer used here?
+                       localPublicAddr: cl.publicAddr(addrIpPort.IP),
+                       network:         dr.Dialer.DialerNetwork(),
+                       connString:      regularNetConnPeerConnConnString(nc),
+               })
        if err != nil {
                nc.Close()
        }
@@ -744,10 +861,10 @@ func (cl *Client) establishOutgoingConnEx(t *Torrent, addr PeerRemoteAddr, obfus
 
 // Returns nil connection and nil error if no connection could be established
 // for valid reasons.
-func (cl *Client) establishOutgoingConn(t *Torrent, addr PeerRemoteAddr) (c *PeerConn, err error) {
+func (cl *Client) establishOutgoingConn(opts outgoingConnOpts) (c *PeerConn, err error) {
        torrent.Add("establish outgoing connection", 1)
        obfuscatedHeaderFirst := cl.config.HeaderObfuscationPolicy.Preferred
-       c, err = cl.establishOutgoingConnEx(t, addr, obfuscatedHeaderFirst)
+       c, err = cl.establishOutgoingConnEx(opts, obfuscatedHeaderFirst)
        if err == nil {
                torrent.Add("initiated conn with preferred header obfuscation", 1)
                return
@@ -759,7 +876,7 @@ func (cl *Client) establishOutgoingConn(t *Torrent, addr PeerRemoteAddr) (c *Pee
                return
        }
        // Try again with encryption if we didn't earlier, or without if we did.
-       c, err = cl.establishOutgoingConnEx(t, addr, !obfuscatedHeaderFirst)
+       c, err = cl.establishOutgoingConnEx(opts, !obfuscatedHeaderFirst)
        if err == nil {
                torrent.Add("initiated conn with fallback header obfuscation", 1)
        }
@@ -767,11 +884,27 @@ func (cl *Client) establishOutgoingConn(t *Torrent, addr PeerRemoteAddr) (c *Pee
        return
 }
 
+type outgoingConnOpts struct {
+       t    *Torrent
+       addr PeerRemoteAddr
+       // Don't attempt to connect unless a connect message is received after initiating a rendezvous.
+       requireRendezvous bool
+       // Don't send rendezvous requests to eligible relays.
+       skipHolepunchRendezvous bool
+       // Outgoing connection attempt is in response to holepunch connect message.
+       receivedHolepunchConnect bool
+}
+
 // Called to dial out and run a connection. The addr we're given is already
 // considered half-open.
-func (cl *Client) outgoingConnection(t *Torrent, addr PeerRemoteAddr, ps PeerSource, trusted bool) {
+func (cl *Client) outgoingConnection(
+       opts outgoingConnOpts,
+       ps PeerSource,
+       trusted bool,
+       attemptKey outgoingConnAttemptKey,
+) {
        cl.dialRateLimiter.Wait(context.Background())
-       c, err := cl.establishOutgoingConn(t, addr)
+       c, err := cl.establishOutgoingConn(opts)
        if err == nil {
                c.conn.SetWriteDeadline(time.Time{})
        }
@@ -779,17 +912,17 @@ func (cl *Client) outgoingConnection(t *Torrent, addr PeerRemoteAddr, ps PeerSou
        defer cl.unlock()
        // Don't release lock between here and addPeerConn, unless it's for
        // failure.
-       cl.noLongerHalfOpen(t, addr.String())
+       cl.noLongerHalfOpen(opts.t, opts.addr.String(), attemptKey)
        if err != nil {
                if cl.config.Debug {
-                       cl.logger.Levelf(log.Debug, "error establishing outgoing connection to %v: %v", addr, err)
+                       cl.logger.Levelf(log.Debug, "error establishing outgoing connection to %v: %v", opts.addr, err)
                }
                return
        }
        defer c.close()
        c.Discovery = ps
        c.trusted = trusted
-       t.runHandshookConnLoggingErr(c)
+       opts.t.runHandshookConnLoggingErr(c)
 }
 
 // The port number for incoming peer connections. 0 if the client isn't listening.
@@ -993,10 +1126,8 @@ func (cl *Client) runHandshookConn(c *PeerConn, t *Torrent) error {
        return nil
 }
 
-const check = false
-
 func (p *Peer) initUpdateRequestsTimer() {
-       if check {
+       if check.Enabled {
                if p.updateRequestsTimer != nil {
                        panic(p.updateRequestsTimer)
                }
@@ -1041,7 +1172,8 @@ func (cl *Client) sendInitialMessages(conn *PeerConn, torrent *Torrent) {
                        ExtendedPayload: func() []byte {
                                msg := pp.ExtendedHandshakeMessage{
                                        M: map[pp.ExtensionName]pp.ExtensionNumber{
-                                               pp.ExtensionNameMetadata: metadataExtendedId,
+                                               pp.ExtensionNameMetadata:  metadataExtendedId,
+                                               utHolepunch.ExtensionName: utHolepunchExtendedId,
                                        },
                                        V:            cl.config.ExtendedHandshakeClientVersion,
                                        Reqq:         localClientReqq,
@@ -1196,8 +1328,6 @@ func (cl *Client) newTorrentOpt(opts AddTorrentOpts) (t *Torrent) {
                },
                conns: make(map[*PeerConn]struct{}, 2*cl.config.EstablishedConnsPerTorrent),
 
-               halfOpen: make(map[string]PeerInfo),
-
                storageOpener:       storageClient,
                maxEstablishedConns: cl.config.EstablishedConnsPerTorrent,
 
@@ -1210,7 +1340,7 @@ func (cl *Client) newTorrentOpt(opts AddTorrentOpts) (t *Torrent) {
        t.smartBanCache.Hash = sha1.Sum
        t.smartBanCache.Init()
        t.networkingEnabled.Set()
-       t.logger = cl.logger.WithContextValue(t).WithNames("torrent", t.infoHash.HexString())
+       t.logger = cl.logger.WithContextValue(t).WithNames("torrent", t.infoHash.HexString()).WithDefaultLevel(log.Debug)
        t.sourcesLogger = t.logger.WithNames("sources")
        if opts.ChunkSize == 0 {
                opts.ChunkSize = defaultChunkSize
@@ -1257,9 +1387,8 @@ func (cl *Client) AddTorrentInfoHashWithStorage(infoHash metainfo.Hash, specStor
        return
 }
 
-// Adds a torrent by InfoHash with a custom Storage implementation.
-// If the torrent already exists then this Storage is ignored and the
-// existing torrent returned with `new` set to `false`
+// Adds a torrent by InfoHash with a custom Storage implementation. If the torrent already exists
+// then this Storage is ignored and the existing torrent returned with `new` set to `false`.
 func (cl *Client) AddTorrentOpt(opts AddTorrentOpts) (t *Torrent, new bool) {
        infoHash := opts.InfoHash
        cl.lock()
@@ -1277,6 +1406,7 @@ func (cl *Client) AddTorrentOpt(opts AddTorrentOpts) (t *Torrent, new bool) {
                }
        })
        cl.torrents[infoHash] = t
+       t.setInfoBytesLocked(opts.InfoBytes)
        cl.clearAcceptLimits()
        t.updateWantPeersEvent()
        // Tickle Client.waitAccept, new torrent may want conns.
@@ -1285,9 +1415,10 @@ func (cl *Client) AddTorrentOpt(opts AddTorrentOpts) (t *Torrent, new bool) {
 }
 
 type AddTorrentOpts struct {
-       InfoHash  InfoHash
+       InfoHash  infohash.T
        Storage   storage.ClientImpl
        ChunkSize pp.Integer
+       InfoBytes []byte
 }
 
 // Add or merge a torrent spec. Returns new if the torrent wasn't already in the client. See also
@@ -1311,13 +1442,6 @@ func (cl *Client) AddTorrentSpec(spec *TorrentSpec) (t *Torrent, new bool, err e
        return
 }
 
-type stringAddr string
-
-var _ net.Addr = stringAddr("")
-
-func (stringAddr) Network() string   { return "" }
-func (me stringAddr) String() string { return string(me) }
-
 // The trackers will be merged with the existing ones. If the Info isn't yet known, it will be set.
 // spec.DisallowDataDownload/Upload will be read and applied
 // The display name is replaced if the new spec provides one. Note that any `Storage` is ignored.
@@ -1342,7 +1466,7 @@ func (t *Torrent) MergeSpec(spec *TorrentSpec) error {
        }
        for _, peerAddr := range spec.PeerAddrs {
                t.addPeer(PeerInfo{
-                       Addr:    stringAddr(peerAddr),
+                       Addr:    StringAddr(peerAddr),
                        Source:  PeerSourceDirect,
                        Trusted: true,
                })
@@ -1465,7 +1589,7 @@ func (cl *Client) banPeerIP(ip net.IP) {
        if !ok {
                panic(ip)
        }
-       generics.MakeMapIfNilAndSet(&cl.badPeerIPs, ipAddr, struct{}{})
+       g.MakeMapIfNilAndSet(&cl.badPeerIPs, ipAddr, struct{}{})
        for _, t := range cl.torrents {
                t.iterPeers(func(p *Peer) {
                        if p.remoteIp().Equal(ip) {
@@ -1504,6 +1628,7 @@ func (cl *Client) newConnection(nc net.Conn, opts newConnectionOpts) (c *PeerCon
                connString: opts.connString,
                conn:       nc,
        }
+       c.peerRequestDataAllocLimiter.Max = cl.config.MaxAllocPeerRequestDataPerConn
        c.initRequestState()
        // TODO: Need to be much more explicit about this, including allowing non-IP bannable addresses.
        if opts.remoteAddr != nil {
@@ -1513,13 +1638,17 @@ func (cl *Client) newConnection(nc net.Conn, opts newConnectionOpts) (c *PeerCon
                }
        }
        c.peerImpl = c
-       c.logger = cl.logger.WithDefaultLevel(log.Warning).WithContextValue(c)
+       c.logger = cl.logger.WithDefaultLevel(log.Warning)
        c.setRW(connStatsReadWriter{nc, c})
        c.r = &rateLimitedReader{
                l: cl.config.DownloadRateLimiter,
                r: c.r,
        }
-       c.logger.WithDefaultLevel(log.Debug).Printf("initialized with remote %v over network %v (outgoing=%t)", opts.remoteAddr, opts.network, opts.outgoing)
+       c.logger.Levelf(
+               log.Debug,
+               "new PeerConn %p [Client %p remoteAddr %v network %v outgoing %t]",
+               c, cl, opts.remoteAddr, opts.network, opts.outgoing,
+       )
        for _, f := range cl.config.Callbacks.NewPeer {
                f(&c.Peer)
        }
@@ -1685,8 +1814,24 @@ func (cl *Client) String() string {
        return fmt.Sprintf("<%[1]T %[1]p>", cl)
 }
 
-// Returns connection-level aggregate stats at the Client level. See the comment on
+// Returns connection-level aggregate connStats at the Client level. See the comment on
 // TorrentStats.ConnStats.
 func (cl *Client) ConnStats() ConnStats {
-       return cl.stats.Copy()
+       return cl.connStats.Copy()
+}
+
+func (cl *Client) Stats() ClientStats {
+       cl.rLock()
+       defer cl.rUnlock()
+       return cl.statsLocked()
+}
+
+func (cl *Client) statsLocked() (stats ClientStats) {
+       stats.ConnStats = cl.connStats.Copy()
+       stats.ActiveHalfOpenAttempts = cl.numHalfOpen
+       stats.NumPeersUndialableWithoutHolepunchDialedAfterHolepunchConnect =
+               len(cl.undialableWithoutHolepunchDialAttemptedAfterHolepunchConnect)
+       stats.NumPeersDialableOnlyAfterHolepunch =
+               len(cl.dialableOnlyAfterHolepunch)
+       return
 }