torrent/client.go

1291 lines
30 KiB
Go
Raw Normal View History

2013-09-26 09:49:15 +00:00
package torrent
import (
"bufio"
"context"
"crypto/rand"
2013-09-26 09:49:15 +00:00
"errors"
"expvar"
"fmt"
2013-09-26 09:49:15 +00:00
"io"
"net"
2015-03-10 15:41:41 +00:00
"net/url"
2015-03-18 07:21:00 +00:00
"strconv"
2014-09-13 17:50:15 +00:00
"strings"
"time"
2018-01-28 05:07:11 +00:00
"github.com/anacrolix/log"
2017-01-01 00:01:41 +00:00
"github.com/anacrolix/dht"
"github.com/anacrolix/dht/krpc"
2015-08-05 22:56:36 +00:00
"github.com/anacrolix/missinggo"
2016-03-06 06:26:04 +00:00
"github.com/anacrolix/missinggo/pproffd"
"github.com/anacrolix/missinggo/pubsub"
2016-07-12 06:40:14 +00:00
"github.com/anacrolix/missinggo/slices"
2015-03-20 12:52:53 +00:00
"github.com/anacrolix/sync"
"github.com/dustin/go-humanize"
"golang.org/x/time/rate"
2015-04-28 05:24:17 +00:00
"github.com/anacrolix/torrent/bencode"
"github.com/anacrolix/torrent/iplist"
2015-04-28 05:24:17 +00:00
"github.com/anacrolix/torrent/metainfo"
"github.com/anacrolix/torrent/mse"
pp "github.com/anacrolix/torrent/peer_protocol"
2016-03-28 09:38:30 +00:00
"github.com/anacrolix/torrent/storage"
2013-09-26 09:49:15 +00:00
)
2016-05-03 04:58:26 +00:00
// Clients contain zero or more Torrents. A Client manages a blocklist, the
2015-06-03 03:30:55 +00:00
// TCP/UDP protocol ports, and DHT as desired.
2013-10-06 07:01:39 +00:00
type Client struct {
2016-10-09 13:04:14 +00:00
mu sync.RWMutex
event sync.Cond
closed missinggo.Event
config Config
logger *log.Logger
2016-10-09 13:04:14 +00:00
halfOpenLimit int
peerID PeerID
2016-10-09 13:04:14 +00:00
defaultStorage *storage.Client
onClose []func()
tcpListener net.Listener
2017-06-16 08:08:24 +00:00
utpSock utpSocket
dHT *dht.Server
ipBlockList iplist.Ranger
2016-10-09 13:04:14 +00:00
// Our BitTorrent protocol extension bytes, sent in our BT handshakes.
extensionBytes peerExtensionBytes
2016-10-09 13:04:14 +00:00
// The net.Addr.String part that should be common to all active listeners.
2016-10-10 06:29:39 +00:00
listenAddr string
uploadLimit *rate.Limiter
downloadLimit *rate.Limiter
2016-10-09 13:04:14 +00:00
// Set of addresses that have our client ID. This intentionally will
// include ourselves if we end up trying to connect to our own address
// through legitimate channels.
dopplegangerAddrs map[string]struct{}
badPeerIPs map[string]struct{}
2016-10-09 13:04:14 +00:00
torrents map[metainfo.Hash]*Torrent
}
func (cl *Client) BadPeerIPs() []string {
cl.mu.RLock()
defer cl.mu.RUnlock()
return cl.badPeerIPsLocked()
}
func (cl *Client) badPeerIPsLocked() []string {
return slices.FromMapKeys(cl.badPeerIPs).([]string)
}
func (cl *Client) IPBlockList() iplist.Ranger {
cl.mu.Lock()
defer cl.mu.Unlock()
return cl.ipBlockList
2013-09-26 09:49:15 +00:00
}
func (cl *Client) SetIPBlockList(list iplist.Ranger) {
cl.mu.Lock()
defer cl.mu.Unlock()
cl.ipBlockList = list
if cl.dHT != nil {
cl.dHT.SetIPBlockList(list)
2014-11-30 02:33:17 +00:00
}
}
func (cl *Client) PeerID() PeerID {
2017-11-08 08:28:37 +00:00
return cl.peerID
}
type torrentAddr string
2017-01-01 00:03:02 +00:00
func (torrentAddr) Network() string { return "" }
func (me torrentAddr) String() string { return string(me) }
func (cl *Client) ListenAddr() net.Addr {
if cl.listenAddr == "" {
return nil
2014-11-16 19:16:26 +00:00
}
return torrentAddr(cl.listenAddr)
2014-08-21 08:07:06 +00:00
}
2015-03-08 06:28:14 +00:00
// Writes out a human readable status of the client, such as for writing to a
// HTTP status page.
func (cl *Client) WriteStatus(_w io.Writer) {
cl.mu.Lock()
defer cl.mu.Unlock()
w := bufio.NewWriter(_w)
defer w.Flush()
2015-02-25 03:52:19 +00:00
if addr := cl.ListenAddr(); addr != nil {
fmt.Fprintf(w, "Listening on %s\n", addr)
2015-02-25 03:52:19 +00:00
} else {
2015-03-10 15:39:01 +00:00
fmt.Fprintln(w, "Not listening!")
2015-02-25 03:52:19 +00:00
}
fmt.Fprintf(w, "Peer ID: %+q\n", cl.PeerID())
fmt.Fprintf(w, "Banned IPs: %d\n", len(cl.badPeerIPsLocked()))
if dht := cl.DHT(); dht != nil {
dhtStats := dht.Stats()
fmt.Fprintf(w, "DHT nodes: %d (%d good, %d banned)\n", dhtStats.Nodes, dhtStats.GoodNodes, dhtStats.BadNodes)
fmt.Fprintf(w, "DHT Server ID: %x\n", dht.ID())
fmt.Fprintf(w, "DHT port: %d\n", missinggo.AddrPort(dht.Addr()))
fmt.Fprintf(w, "DHT announces: %d\n", dhtStats.ConfirmedAnnounces)
fmt.Fprintf(w, "Outstanding transactions: %d\n", dhtStats.OutstandingTransactions)
}
fmt.Fprintf(w, "# Torrents: %d\n", len(cl.torrentsAsSlice()))
fmt.Fprintln(w)
for _, t := range slices.Sort(cl.torrentsAsSlice(), func(l, r *Torrent) bool {
return l.InfoHash().AsString() < r.InfoHash().AsString()
}).([]*Torrent) {
if t.name() == "" {
2014-11-18 20:32:51 +00:00
fmt.Fprint(w, "<unknown name>")
} else {
fmt.Fprint(w, t.name())
2014-11-18 20:32:51 +00:00
}
2015-02-21 03:57:37 +00:00
fmt.Fprint(w, "\n")
2017-08-29 05:16:53 +00:00
if t.info != nil {
fmt.Fprintf(w, "%f%% of %d bytes (%s)", 100*(1-float64(t.bytesMissingLocked())/float64(t.info.TotalLength())), t.length, humanize.Bytes(uint64(t.info.TotalLength())))
2015-02-21 03:57:37 +00:00
} else {
w.WriteString("<missing metainfo>")
2014-11-18 20:32:51 +00:00
}
fmt.Fprint(w, "\n")
t.writeStatus(w)
fmt.Fprintln(w)
}
}
2017-06-16 08:08:24 +00:00
func listenUTP(networkSuffix, addr string) (utpSocket, error) {
return NewUtpSocket("udp"+networkSuffix, addr)
}
func listenTCP(networkSuffix, addr string) (net.Listener, error) {
return net.Listen("tcp"+networkSuffix, addr)
}
2017-06-16 08:08:24 +00:00
func listenBothSameDynamicPort(networkSuffix, host string) (tcpL net.Listener, utpSock utpSocket, listenedAddr string, err error) {
for {
tcpL, err = listenTCP(networkSuffix, net.JoinHostPort(host, "0"))
if err != nil {
return
}
listenedAddr = tcpL.Addr().String()
utpSock, err = listenUTP(networkSuffix, listenedAddr)
if err == nil {
return
}
tcpL.Close()
if !strings.Contains(err.Error(), "address already in use") {
return
}
}
}
2016-05-24 09:45:42 +00:00
// Listen to enabled protocols, ensuring ports match.
2017-06-16 08:08:24 +00:00
func listen(tcp, utp bool, networkSuffix, addr string) (tcpL net.Listener, utpSock utpSocket, listenedAddr string, err error) {
if addr == "" {
addr = ":50007"
}
if tcp && utp {
var host string
var port int
host, port, err = missinggo.ParseHostPort(addr)
if err != nil {
return
}
if port == 0 {
// If both protocols are active, they need to have the same port.
return listenBothSameDynamicPort(networkSuffix, host)
}
}
2016-05-24 09:45:42 +00:00
defer func() {
if err != nil {
listenedAddr = ""
}
}()
if tcp {
tcpL, err = listenTCP(networkSuffix, addr)
if err != nil {
return
}
2016-05-24 09:45:42 +00:00
defer func() {
if err != nil {
tcpL.Close()
}
}()
listenedAddr = tcpL.Addr().String()
}
if utp {
utpSock, err = listenUTP(networkSuffix, addr)
2016-05-24 09:45:42 +00:00
if err != nil {
return
}
listenedAddr = utpSock.Addr().String()
}
return
}
const debugLogValue = "debug"
func (cl *Client) debugLogFilter(m *log.Msg) bool {
if !cl.config.Debug {
_, ok := m.Values()[debugLogValue]
return !ok
}
return true
}
func (cl *Client) initLogger() {
cl.logger = log.Default.Clone().AddValue(cl).AddFilter(log.NewFilter(cl.debugLogFilter))
}
2015-06-03 03:30:55 +00:00
// Creates a new client.
2014-08-21 08:07:06 +00:00
func NewClient(cfg *Config) (cl *Client, err error) {
if cfg == nil {
cfg = &Config{
DHTConfig: dht.ServerConfig{
StartingNodes: dht.GlobalBootstrapAddrs,
},
}
}
if cfg == nil {
cfg = &Config{}
}
cfg.setDefaults()
2014-08-21 08:07:06 +00:00
defer func() {
if err != nil {
cl = nil
}
}()
2014-08-21 08:07:06 +00:00
cl = &Client{
halfOpenLimit: cfg.HalfOpenConnsPerTorrent,
2016-03-28 09:38:30 +00:00
config: *cfg,
dopplegangerAddrs: make(map[string]struct{}),
torrents: make(map[metainfo.Hash]*Torrent),
2014-08-21 08:07:06 +00:00
}
cl.initLogger()
defer func() {
if err == nil {
return
}
cl.Close()
}()
if cfg.UploadRateLimiter == nil {
cl.uploadLimit = rate.NewLimiter(rate.Inf, 0)
} else {
cl.uploadLimit = cfg.UploadRateLimiter
}
2016-10-10 06:29:39 +00:00
if cfg.DownloadRateLimiter == nil {
cl.downloadLimit = rate.NewLimiter(rate.Inf, 0)
} else {
cl.downloadLimit = cfg.DownloadRateLimiter
}
2016-03-30 08:11:55 +00:00
missinggo.CopyExact(&cl.extensionBytes, defaultExtensionBytes)
2014-08-21 08:07:06 +00:00
cl.event.L = &cl.mu
storageImpl := cfg.DefaultStorage
if storageImpl == nil {
2017-09-16 14:45:12 +00:00
// We'd use mmap but HFS+ doesn't support sparse files.
storageImpl = storage.NewFile(cfg.DataDir)
cl.onClose = append(cl.onClose, func() {
if err := storageImpl.Close(); err != nil {
log.Printf("error closing default storage: %s", err)
}
})
2015-02-25 04:41:13 +00:00
}
cl.defaultStorage = storage.NewClient(storageImpl)
if cfg.IPBlocklist != nil {
cl.ipBlockList = cfg.IPBlocklist
2014-12-01 22:39:09 +00:00
}
if cfg.PeerID != "" {
2016-03-30 08:11:55 +00:00
missinggo.CopyExact(&cl.peerID, cfg.PeerID)
} else {
o := copy(cl.peerID[:], cfg.Bep20)
_, err = rand.Read(cl.peerID[o:])
if err != nil {
panic("error generating peer id")
}
}
2014-08-21 08:07:06 +00:00
cl.tcpListener, cl.utpSock, cl.listenAddr, err = listen(
!cl.config.DisableTCP,
!cl.config.DisableUTP,
func() string {
2015-08-04 16:41:50 +00:00
if cl.config.DisableIPv6 {
return "4"
2015-08-04 16:41:50 +00:00
} else {
return ""
2015-08-04 16:41:50 +00:00
}
}(),
cl.config.ListenAddr)
if err != nil {
return
}
go cl.forwardPort()
if cl.tcpListener != nil {
go cl.acceptConnections(cl.tcpListener, false)
}
if cl.utpSock != nil {
2015-01-10 13:16:19 +00:00
go cl.acceptConnections(cl.utpSock, true)
}
2014-08-21 08:07:06 +00:00
if !cfg.NoDHT {
dhtCfg := cfg.DHTConfig
if dhtCfg.IPBlocklist == nil {
dhtCfg.IPBlocklist = cl.ipBlockList
2014-11-20 02:02:20 +00:00
}
2017-07-20 14:40:49 +00:00
if dhtCfg.Conn == nil {
if cl.utpSock != nil {
dhtCfg.Conn = cl.utpSock
} else {
dhtCfg.Conn, err = net.ListenPacket("udp", firstNonEmptyString(cl.listenAddr, cl.config.ListenAddr))
if err != nil {
return
}
}
}
if dhtCfg.OnAnnouncePeer == nil {
dhtCfg.OnAnnouncePeer = cl.onDHTAnnouncePeer
}
2016-01-16 13:12:53 +00:00
cl.dHT, err = dht.NewServer(&dhtCfg)
2014-08-21 08:07:06 +00:00
if err != nil {
return
}
2017-08-10 01:18:48 +00:00
go func() {
if _, err := cl.dHT.Bootstrap(); err != nil {
log.Printf("error bootstrapping dht: %s", err)
}
}()
2014-08-21 08:07:06 +00:00
}
return
}
func firstNonEmptyString(ss ...string) string {
for _, s := range ss {
if s != "" {
return s
}
}
return ""
}
// Stops the client. All connections to peers are closed and all activity will
// come to a halt.
func (cl *Client) Close() {
cl.mu.Lock()
defer cl.mu.Unlock()
cl.closed.Set()
if cl.dHT != nil {
cl.dHT.Close()
}
if cl.utpSock != nil {
2017-06-16 08:08:24 +00:00
cl.utpSock.Close()
}
if cl.tcpListener != nil {
cl.tcpListener.Close()
}
for _, t := range cl.torrents {
t.close()
}
for _, f := range cl.onClose {
f()
}
cl.event.Broadcast()
}
2014-12-01 09:27:11 +00:00
var ipv6BlockRange = iplist.Range{Description: "non-IPv4 address"}
func (cl *Client) ipBlockRange(ip net.IP) (r iplist.Range, blocked bool) {
if cl.ipBlockList == nil {
2014-11-30 02:33:17 +00:00
return
}
ip4 := ip.To4()
// If blocklists are enabled, then block non-IPv4 addresses, because
// blocklists do not yet support IPv6.
if ip4 == nil {
if missinggo.CryHeard() {
log.Printf("blocking non-IPv4 address: %s", ip)
}
r = ipv6BlockRange
blocked = true
2014-12-01 09:27:11 +00:00
return
}
return cl.ipBlockList.Lookup(ip4)
}
func (cl *Client) waitAccept() {
for {
for _, t := range cl.torrents {
if t.wantConns() {
return
}
}
if cl.closed.IsSet() {
return
}
cl.event.Wait()
}
}
func (cl *Client) acceptConnections(l net.Listener, utp bool) {
cl.mu.Lock()
defer cl.mu.Unlock()
for {
cl.waitAccept()
cl.mu.Unlock()
conn, err := l.Accept()
2016-03-06 06:26:04 +00:00
conn = pproffd.WrapNetConn(conn)
cl.mu.Lock()
if cl.closed.IsSet() {
if conn != nil {
conn.Close()
}
return
}
if err != nil {
log.Print(err)
// I think something harsher should happen here? Our accept
// routine just fucked off.
return
}
2015-06-29 14:35:47 +00:00
if utp {
acceptUTP.Add(1)
} else {
acceptTCP.Add(1)
}
2016-09-21 11:00:18 +00:00
if cl.config.Debug {
log.Printf("accepted connection from %s", conn.RemoteAddr())
}
reject := cl.badPeerIPPort(
missinggo.AddrIP(conn.RemoteAddr()),
missinggo.AddrPort(conn.RemoteAddr()))
if reject {
2016-09-21 11:00:18 +00:00
if cl.config.Debug {
log.Printf("rejecting connection from %s", conn.RemoteAddr())
}
2015-06-29 14:35:47 +00:00
acceptReject.Add(1)
2014-12-26 06:18:36 +00:00
conn.Close()
continue
}
go cl.incomingConnection(conn, utp)
}
}
func (cl *Client) incomingConnection(nc net.Conn, utp bool) {
defer nc.Close()
if tc, ok := nc.(*net.TCPConn); ok {
tc.SetLinger(0)
}
2016-10-10 05:55:56 +00:00
c := cl.newConnection(nc)
c.Discovery = peerSourceIncoming
c.uTP = utp
cl.runReceivedConn(c)
2013-09-26 09:49:15 +00:00
}
2015-03-19 23:52:01 +00:00
// Returns a handle to the given torrent, if it's present in the client.
func (cl *Client) Torrent(ih metainfo.Hash) (t *Torrent, ok bool) {
cl.mu.Lock()
defer cl.mu.Unlock()
2016-04-03 08:40:43 +00:00
t, ok = cl.torrents[ih]
return
}
func (cl *Client) torrent(ih metainfo.Hash) *Torrent {
return cl.torrents[ih]
}
type dialResult struct {
Conn net.Conn
UTP bool
}
func countDialResult(err error) {
if err == nil {
successfulDials.Add(1)
} else {
unsuccessfulDials.Add(1)
}
}
func reducedDialTimeout(minDialTimeout, max time.Duration, halfOpenLimit int, pendingPeers int) (ret time.Duration) {
2014-11-19 03:53:00 +00:00
ret = max / time.Duration((pendingPeers+halfOpenLimit)/halfOpenLimit)
if ret < minDialTimeout {
ret = minDialTimeout
}
return
}
2015-09-17 02:54:03 +00:00
// Returns whether an address is known to connect to a client with our own ID.
func (cl *Client) dopplegangerAddr(addr string) bool {
_, ok := cl.dopplegangerAddrs[addr]
return ok
}
// Start the process of connecting to the given peer for the given torrent if
// appropriate.
func (cl *Client) initiateConn(peer Peer, t *Torrent) {
if peer.Id == cl.peerID {
return
}
if cl.badPeerIPPort(peer.IP, peer.Port) {
return
}
addr := net.JoinHostPort(peer.IP.String(), fmt.Sprintf("%d", peer.Port))
if t.addrActive(addr) {
return
}
t.halfOpen[addr] = peer
go cl.outgoingConnection(t, addr, peer.Source)
}
func (cl *Client) dialTCP(ctx context.Context, addr string) (c net.Conn, err error) {
2017-08-16 05:48:30 +00:00
d := net.Dialer{
2018-01-06 05:37:40 +00:00
// LocalAddr: cl.tcpListener.Addr(),
2017-08-16 05:48:30 +00:00
}
c, err = d.DialContext(ctx, "tcp", addr)
countDialResult(err)
if err == nil {
c.(*net.TCPConn).SetLinger(0)
}
c = pproffd.WrapNetConn(c)
return
}
func (cl *Client) dialUTP(ctx context.Context, addr string) (c net.Conn, err error) {
c, err = cl.utpSock.DialContext(ctx, addr)
countDialResult(err)
return
}
var (
dialledFirstUtp = expvar.NewInt("dialledFirstUtp")
dialledFirstNotUtp = expvar.NewInt("dialledFirstNotUtp")
)
// Returns a connection over UTP or TCP, whichever is first to connect.
func (cl *Client) dialFirst(ctx context.Context, addr string) (conn net.Conn, utp bool) {
ctx, cancel := context.WithCancel(ctx)
// As soon as we return one connection, cancel the others.
defer cancel()
left := 0
resCh := make(chan dialResult, left)
if !cl.config.DisableUTP {
2017-08-16 00:32:25 +00:00
left++
go func() {
c, _ := cl.dialUTP(ctx, addr)
resCh <- dialResult{c, true}
}()
}
if !cl.config.DisableTCP {
2017-08-16 00:32:25 +00:00
left++
go func() {
c, _ := cl.dialTCP(ctx, addr)
resCh <- dialResult{c, false}
}()
}
var res dialResult
// Wait for a successful connection.
for ; left > 0 && res.Conn == nil; left-- {
res = <-resCh
}
if left > 0 {
// There are still incompleted dials.
go func() {
for ; left > 0; left-- {
conn := (<-resCh).Conn
if conn != nil {
conn.Close()
}
}
}()
}
conn = res.Conn
utp = res.UTP
if conn != nil {
if utp {
dialledFirstUtp.Add(1)
} else {
dialledFirstNotUtp.Add(1)
}
}
return
}
func (cl *Client) noLongerHalfOpen(t *Torrent, addr string) {
if _, ok := t.halfOpen[addr]; !ok {
panic("invariant broken")
}
delete(t.halfOpen, addr)
cl.openNewConns(t)
}
// Performs initiator handshakes and returns a connection. Returns nil
// *connection if no connection for valid reasons.
func (cl *Client) handshakesConnection(ctx context.Context, nc net.Conn, t *Torrent, encryptHeader, utp bool) (c *connection, err error) {
2016-10-10 05:55:56 +00:00
c = cl.newConnection(nc)
c.headerEncrypted = encryptHeader
c.uTP = utp
ctx, cancel := context.WithTimeout(ctx, cl.config.HandshakesTimeout)
defer cancel()
dl, ok := ctx.Deadline()
if !ok {
panic(ctx)
}
err = nc.SetDeadline(dl)
if err != nil {
panic(err)
}
ok, err = cl.initiateHandshakes(c, t)
if !ok {
c = nil
}
return
}
var (
initiatedConnWithPreferredHeaderEncryption = expvar.NewInt("initiatedConnWithPreferredHeaderEncryption")
initiatedConnWithFallbackHeaderEncryption = expvar.NewInt("initiatedConnWithFallbackHeaderEncryption")
)
// Returns nil connection and nil error if no connection could be established
// for valid reasons.
func (cl *Client) establishOutgoingConn(t *Torrent, addr string) (c *connection, err error) {
ctx, cancel := context.WithTimeout(context.Background(), time.Minute)
defer cancel()
nc, utp := cl.dialFirst(ctx, addr)
if nc == nil {
return
}
obfuscatedHeaderFirst := !cl.config.DisableEncryption && !cl.config.PreferNoEncryption
c, err = cl.handshakesConnection(ctx, nc, t, obfuscatedHeaderFirst, utp)
if err != nil {
2017-09-15 02:56:54 +00:00
// log.Printf("error initiating connection handshakes: %s", err)
nc.Close()
return
} else if c != nil {
initiatedConnWithPreferredHeaderEncryption.Add(1)
return
}
nc.Close()
if cl.config.ForceEncryption {
// We should have just tried with an obfuscated header. A plaintext
// header can't result in an encrypted connection, so we're done.
if !obfuscatedHeaderFirst {
panic(cl.config.EncryptionPolicy)
}
return
}
2016-09-16 02:42:41 +00:00
// Try again with encryption if we didn't earlier, or without if we did,
// using whichever protocol type worked last time.
if utp {
nc, err = cl.dialUTP(ctx, addr)
} else {
nc, err = cl.dialTCP(ctx, addr)
}
if err != nil {
2017-09-15 02:56:54 +00:00
err = fmt.Errorf("error dialing for header encryption fallback: %s", err)
return
}
c, err = cl.handshakesConnection(ctx, nc, t, !obfuscatedHeaderFirst, utp)
if err != nil || c == nil {
nc.Close()
}
if err == nil && c != nil {
initiatedConnWithFallbackHeaderEncryption.Add(1)
}
return
}
// 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 string, ps peerSource) {
c, err := cl.establishOutgoingConn(t, addr)
cl.mu.Lock()
defer cl.mu.Unlock()
// Don't release lock between here and addConnection, unless it's for
// failure.
cl.noLongerHalfOpen(t, addr)
if err != nil {
if cl.config.Debug {
2016-03-22 02:10:18 +00:00
log.Printf("error establishing outgoing connection: %s", err)
}
return
}
if c == nil {
return
}
defer c.Close()
c.Discovery = ps
cl.runInitiatedHandshookConn(c, t)
}
2014-11-16 19:16:26 +00:00
// The port number for incoming peer connections. 0 if the client isn't
// listening.
func (cl *Client) incomingPeerPort() int {
if cl.listenAddr == "" {
return 0
}
_, port, err := missinggo.ParseHostPort(cl.listenAddr)
if err != nil {
panic(err)
}
return port
}
func (cl *Client) initiateHandshakes(c *connection, t *Torrent) (ok bool, err error) {
if c.headerEncrypted {
var rw io.ReadWriter
rw, err = mse.InitiateHandshake(
struct {
io.Reader
io.Writer
}{c.r, c.w},
t.infoHash[:],
nil,
func() uint32 {
switch {
case cl.config.ForceEncryption:
return mse.CryptoMethodRC4
case cl.config.DisableEncryption:
return mse.CryptoMethodPlaintext
default:
return mse.AllSupportedCrypto
}
}(),
)
c.setRW(rw)
if err != nil {
return
}
}
ih, ok, err := cl.connBTHandshake(c, &t.infoHash)
2016-04-03 08:40:43 +00:00
if ih != t.infoHash {
ok = false
}
return
}
// Calls f with any secret keys.
func (cl *Client) forSkeys(f func([]byte) bool) {
cl.mu.Lock()
defer cl.mu.Unlock()
for ih := range cl.torrents {
if !f(ih[:]) {
break
}
}
}
2015-03-27 04:37:58 +00:00
// Do encryption and bittorrent handshakes as receiver.
2016-04-03 08:40:43 +00:00
func (cl *Client) receiveHandshakes(c *connection) (t *Torrent, err error) {
var rw io.ReadWriter
rw, c.headerEncrypted, c.cryptoMethod, err = handleEncryption(c.rw(), cl.forSkeys, cl.config.EncryptionPolicy)
c.setRW(rw)
if err != nil {
if err == mse.ErrNoSecretKeyMatch {
err = nil
}
return
}
if cl.config.ForceEncryption && !c.headerEncrypted {
2016-09-16 02:42:41 +00:00
err = errors.New("connection not encrypted")
return
}
ih, ok, err := cl.connBTHandshake(c, nil)
if err != nil {
2015-06-28 06:39:04 +00:00
err = fmt.Errorf("error during bt handshake: %s", err)
return
}
if !ok {
return
}
cl.mu.Lock()
t = cl.torrents[ih]
cl.mu.Unlock()
return
}
// Returns !ok if handshake failed for valid reasons.
func (cl *Client) connBTHandshake(c *connection, ih *metainfo.Hash) (ret metainfo.Hash, ok bool, err error) {
res, ok, err := handshake(c.rw(), ih, cl.peerID, cl.extensionBytes)
if err != nil || !ok {
return
}
ret = res.Hash
c.PeerExtensionBytes = res.peerExtensionBytes
c.PeerID = res.PeerID
c.completedHandshake = time.Now()
return
}
func (cl *Client) runInitiatedHandshookConn(c *connection, t *Torrent) {
if c.PeerID == cl.peerID {
connsToSelf.Add(1)
addr := c.conn.RemoteAddr().String()
cl.dopplegangerAddrs[addr] = struct{}{}
return
}
cl.runHandshookConn(c, t, true)
}
func (cl *Client) runReceivedConn(c *connection) {
err := c.conn.SetDeadline(time.Now().Add(cl.config.HandshakesTimeout))
if err != nil {
panic(err)
}
t, err := cl.receiveHandshakes(c)
if err != nil {
if cl.config.Debug {
log.Printf("error receiving handshakes: %s", err)
}
return
}
if t == nil {
return
}
cl.mu.Lock()
defer cl.mu.Unlock()
if c.PeerID == cl.peerID {
// Because the remote address is not necessarily the same as its
// client's torrent listen address, we won't record the remote address
// as a doppleganger. Instead, the initiator can record *us* as the
// doppleganger.
return
}
cl.runHandshookConn(c, t, false)
}
func (cl *Client) runHandshookConn(c *connection, t *Torrent, outgoing bool) {
c.conn.SetWriteDeadline(time.Time{})
c.r = deadlineReader{c.conn, c.r}
completedHandshakeConnectionFlags.Add(c.connectionFlags(), 1)
if !t.addConnection(c, outgoing) {
2014-03-16 15:30:10 +00:00
return
}
defer t.dropConnection(c)
go c.writer(time.Minute)
cl.sendInitialMessages(c, t)
err := c.mainReadLoop()
if err != nil && cl.config.Debug {
2018-01-25 02:10:52 +00:00
log.Printf("error during connection main read loop: %s", err)
}
}
func (cl *Client) sendInitialMessages(conn *connection, torrent *Torrent) {
if conn.PeerExtensionBytes.SupportsExtended() && cl.extensionBytes.SupportsExtended() {
conn.Post(pp.Message{
Type: pp.Extended,
ExtendedID: pp.HandshakeExtendedID,
ExtendedPayload: func() []byte {
2014-06-28 09:38:31 +00:00
d := map[string]interface{}{
2015-03-25 04:49:27 +00:00
"m": func() (ret map[string]int) {
ret = make(map[string]int, 2)
ret["ut_metadata"] = metadataExtendedId
if !cl.config.DisablePEX {
2015-03-25 04:49:27 +00:00
ret["ut_pex"] = pexExtendedId
}
return
}(),
"v": cl.config.ExtendedHandshakeClientVersion,
// No upload queue is implemented yet.
2015-05-14 22:39:53 +00:00
"reqq": 64,
2015-04-20 07:30:22 +00:00
}
if !cl.config.DisableEncryption {
2015-04-20 07:30:22 +00:00
d["e"] = 1
2014-06-28 09:38:31 +00:00
}
if torrent.metadataSizeKnown() {
d["metadata_size"] = torrent.metadataSize()
}
if p := cl.incomingPeerPort(); p != 0 {
d["p"] = p
}
yourip, err := addrCompactIP(conn.remoteAddr())
if err != nil {
log.Printf("error calculating yourip field value in extension handshake: %s", err)
} else {
d["yourip"] = yourip
}
2014-07-24 03:43:45 +00:00
// log.Printf("sending %v", d)
2014-06-28 09:38:31 +00:00
b, err := bencode.Marshal(d)
if err != nil {
panic(err)
}
return b
}(),
})
}
if torrent.haveAnyPieces() {
conn.Bitfield(torrent.bitfield())
} else if cl.extensionBytes.SupportsFast() && conn.PeerExtensionBytes.SupportsFast() {
conn.Post(pp.Message{
Type: pp.HaveNone,
})
}
if conn.PeerExtensionBytes.SupportsDHT() && cl.extensionBytes.SupportsDHT() && cl.dHT != nil {
2014-08-25 12:12:16 +00:00
conn.Post(pp.Message{
Type: pp.Port,
Port: uint16(missinggo.AddrPort(cl.dHT.Addr())),
2014-08-25 12:12:16 +00:00
})
}
}
// Process incoming ut_metadata message.
func (cl *Client) gotMetadataExtensionMsg(payload []byte, t *Torrent, c *connection) error {
2014-06-28 09:38:31 +00:00
var d map[string]int
err := bencode.Unmarshal(payload, &d)
2014-06-28 09:38:31 +00:00
if err != nil {
return fmt.Errorf("error unmarshalling payload: %s: %q", err, payload)
2014-06-28 09:38:31 +00:00
}
msgType, ok := d["msg_type"]
if !ok {
return errors.New("missing msg_type field")
2014-06-28 09:38:31 +00:00
}
piece := d["piece"]
switch msgType {
case pp.DataMetadataExtensionMsgType:
if !c.requestedMetadataPiece(piece) {
return fmt.Errorf("got unexpected piece %d", piece)
2014-06-28 09:38:31 +00:00
}
c.metadataRequests[piece] = false
begin := len(payload) - metadataPieceSize(d["total_size"], piece)
if begin < 0 || begin >= len(payload) {
return fmt.Errorf("data has bad offset in payload: %d", begin)
}
2015-03-19 23:52:01 +00:00
t.saveMetadataPiece(piece, payload[begin:])
2014-12-01 09:32:17 +00:00
c.UsefulChunksReceived++
c.lastUsefulChunkReceived = time.Now()
return t.maybeCompleteMetadata()
2014-06-28 09:38:31 +00:00
case pp.RequestMetadataExtensionMsgType:
if !t.haveMetadataPiece(piece) {
c.Post(t.newMetadataExtensionMessage(c, pp.RejectMetadataExtensionMsgType, d["piece"], nil))
return nil
2014-06-28 09:38:31 +00:00
}
start := (1 << 14) * piece
c.Post(t.newMetadataExtensionMessage(c, pp.DataMetadataExtensionMsgType, piece, t.metadataBytes[start:start+t.metadataPieceSize(piece)]))
return nil
2014-06-28 09:38:31 +00:00
case pp.RejectMetadataExtensionMsgType:
return nil
2014-06-28 09:38:31 +00:00
default:
return errors.New("unknown msg_type value")
2014-06-28 09:38:31 +00:00
}
}
func (cl *Client) sendChunk(t *Torrent, c *connection, r request, msg func(pp.Message) bool) (more bool, err error) {
// Count the chunk being sent, even if it isn't.
2015-06-16 06:57:47 +00:00
b := make([]byte, r.Length)
p := t.info.Piece(int(r.Index))
n, err := t.readAt(b, p.Offset()+int64(r.Begin))
2015-06-16 06:57:47 +00:00
if n != len(b) {
2016-02-20 03:40:28 +00:00
if err == nil {
panic("expected error")
}
return
2017-11-06 03:01:07 +00:00
} else if err == io.EOF {
err = nil
2015-06-16 06:57:47 +00:00
}
more = msg(pp.Message{
2015-06-16 06:57:47 +00:00
Type: pp.Piece,
Index: r.Index,
Begin: r.Begin,
Piece: b,
})
c.chunksSent++
2015-06-16 06:57:47 +00:00
uploadChunksPosted.Add(1)
c.lastChunkSent = time.Now()
return
2015-06-16 06:57:47 +00:00
}
func (cl *Client) openNewConns(t *Torrent) {
defer t.updateWantPeersEvent()
for len(t.peers) != 0 {
if !t.wantConns() {
return
}
if len(t.halfOpen) >= cl.halfOpenLimit {
return
}
var (
k peersKey
p Peer
)
for k, p = range t.peers {
break
}
delete(t.peers, k)
cl.initiateConn(p, t)
}
}
func (cl *Client) badPeerIPPort(ip net.IP, port int) bool {
if port == 0 {
return true
}
if cl.dopplegangerAddr(net.JoinHostPort(ip.String(), strconv.FormatInt(int64(port), 10))) {
return true
}
if _, ok := cl.ipBlockRange(ip); ok {
return true
}
if _, ok := cl.badPeerIPs[ip.String()]; ok {
return true
}
return false
}
// Return a Torrent ready for insertion into a Client.
func (cl *Client) newTorrent(ih metainfo.Hash, specStorage storage.ClientImpl) (t *Torrent) {
// use provided storage, if provided
storageClient := cl.defaultStorage
if specStorage != nil {
storageClient = storage.NewClient(specStorage)
}
2016-04-03 08:40:43 +00:00
t = &Torrent{
cl: cl,
infoHash: ih,
peers: make(map[peersKey]Peer),
conns: make(map[*connection]struct{}, 2*cl.config.EstablishedConnsPerTorrent),
halfOpen: make(map[string]Peer),
pieceStateChanges: pubsub.NewPubSub(),
storageOpener: storageClient,
maxEstablishedConns: cl.config.EstablishedConnsPerTorrent,
networkingEnabled: true,
requestStrategy: 2,
metadataChanged: sync.Cond{
L: &cl.mu,
},
}
t.logger = cl.logger.Clone().AddValue(t)
t.setChunkSize(defaultChunkSize)
return
}
// A file-like handle to some torrent data resource.
type Handle interface {
io.Reader
io.Seeker
io.Closer
2015-03-04 02:06:33 +00:00
io.ReaderAt
}
func (cl *Client) AddTorrentInfoHash(infoHash metainfo.Hash) (t *Torrent, new bool) {
return cl.AddTorrentInfoHashWithStorage(infoHash, nil)
}
// 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) AddTorrentInfoHashWithStorage(infoHash metainfo.Hash, specStorage storage.ClientImpl) (t *Torrent, new bool) {
cl.mu.Lock()
defer cl.mu.Unlock()
t, ok := cl.torrents[infoHash]
if ok {
return
}
new = true
t = cl.newTorrent(infoHash, specStorage)
2016-05-09 05:47:39 +00:00
if cl.dHT != nil {
go t.dhtAnnouncer()
2016-05-09 05:47:39 +00:00
}
cl.torrents[infoHash] = t
t.updateWantPeersEvent()
// Tickle Client.waitAccept, new torrent may want conns.
cl.event.Broadcast()
return
}
// Add or merge a torrent spec. If the torrent is already present, the
// trackers will be merged with the existing ones. If the Info isn't yet
// known, it will be set. The display name is replaced if the new spec
// provides one. Returns new if the torrent wasn't already in the client.
// Note that any `Storage` defined on the spec will be ignored if the
// torrent is already present (i.e. `new` return value is `true`)
2016-04-03 08:40:43 +00:00
func (cl *Client) AddTorrentSpec(spec *TorrentSpec) (t *Torrent, new bool, err error) {
t, new = cl.AddTorrentInfoHashWithStorage(spec.InfoHash, spec.Storage)
if spec.DisplayName != "" {
2016-05-09 05:47:39 +00:00
t.SetDisplayName(spec.DisplayName)
}
if spec.InfoBytes != nil {
err = t.SetInfoBytes(spec.InfoBytes)
2016-05-09 05:47:39 +00:00
if err != nil {
return
}
}
2016-05-09 05:47:39 +00:00
cl.mu.Lock()
defer cl.mu.Unlock()
if spec.ChunkSize != 0 {
t.setChunkSize(pp.Integer(spec.ChunkSize))
}
t.addTrackers(spec.Trackers)
t.maybeNewConns()
return
}
func (cl *Client) dropTorrent(infoHash metainfo.Hash) (err error) {
t, ok := cl.torrents[infoHash]
if !ok {
err = fmt.Errorf("no such torrent")
return
}
err = t.close()
if err != nil {
panic(err)
}
delete(cl.torrents, infoHash)
return
}
func (cl *Client) prepareTrackerAnnounceUnlocked(announceURL string) (blocked bool, urlToUse string, host string, err error) {
_url, err := url.Parse(announceURL)
2015-03-10 15:41:41 +00:00
if err != nil {
return
}
hmp := missinggo.SplitHostMaybePort(_url.Host)
if hmp.Err != nil {
err = hmp.Err
return
2015-03-10 15:41:41 +00:00
}
addr, err := net.ResolveIPAddr("ip", hmp.Host)
2015-03-10 15:41:41 +00:00
if err != nil {
return
}
cl.mu.RLock()
_, blocked = cl.ipBlockRange(addr.IP)
cl.mu.RUnlock()
host = _url.Host
hmp.Host = addr.String()
_url.Host = hmp.String()
urlToUse = _url.String()
2015-03-10 15:41:41 +00:00
return
}
2014-03-16 15:30:10 +00:00
func (cl *Client) allTorrentsCompleted() bool {
for _, t := range cl.torrents {
2014-09-14 17:25:53 +00:00
if !t.haveInfo() {
return false
}
if t.numPiecesCompleted() != t.numPieces() {
2014-03-16 15:30:10 +00:00
return false
}
}
return true
}
// Returns true when all torrents are completely downloaded and false if the
// client is stopped before that.
func (cl *Client) WaitAll() bool {
cl.mu.Lock()
defer cl.mu.Unlock()
for !cl.allTorrentsCompleted() {
if cl.closed.IsSet() {
return false
}
cl.event.Wait()
}
return true
2013-09-26 09:49:15 +00:00
}
2015-03-08 06:28:14 +00:00
// Returns handles to all the torrents loaded in the Client.
func (cl *Client) Torrents() []*Torrent {
cl.mu.Lock()
defer cl.mu.Unlock()
return cl.torrentsAsSlice()
}
func (cl *Client) torrentsAsSlice() (ret []*Torrent) {
for _, t := range cl.torrents {
2016-04-03 08:40:43 +00:00
ret = append(ret, t)
}
2013-10-06 07:01:39 +00:00
return
}
func (cl *Client) AddMagnet(uri string) (T *Torrent, err error) {
spec, err := TorrentSpecFromMagnetURI(uri)
if err != nil {
return
}
T, _, err = cl.AddTorrentSpec(spec)
return
}
func (cl *Client) AddTorrent(mi *metainfo.MetaInfo) (T *Torrent, err error) {
T, _, err = cl.AddTorrentSpec(TorrentSpecFromMetaInfo(mi))
var ss []string
2016-07-12 06:40:14 +00:00
slices.MakeInto(&ss, mi.Nodes)
cl.AddDHTNodes(ss)
return
}
func (cl *Client) AddTorrentFromFile(filename string) (T *Torrent, err error) {
mi, err := metainfo.LoadFromFile(filename)
if err != nil {
return
}
return cl.AddTorrent(mi)
}
func (cl *Client) DHT() *dht.Server {
return cl.dHT
}
func (cl *Client) AddDHTNodes(nodes []string) {
2017-06-29 01:49:55 +00:00
if cl.DHT() == nil {
return
}
for _, n := range nodes {
hmp := missinggo.SplitHostMaybePort(n)
ip := net.ParseIP(hmp.Host)
if ip == nil {
log.Printf("won't add DHT node with bad IP: %q", hmp.Host)
continue
}
ni := krpc.NodeInfo{
Addr: &net.UDPAddr{
IP: ip,
Port: hmp.Port,
},
}
cl.DHT().AddNode(ni)
}
}
func (cl *Client) banPeerIP(ip net.IP) {
if cl.badPeerIPs == nil {
cl.badPeerIPs = make(map[string]struct{})
}
cl.badPeerIPs[ip.String()] = struct{}{}
}
2016-10-10 05:55:56 +00:00
func (cl *Client) newConnection(nc net.Conn) (c *connection) {
c = &connection{
conn: nc,
Choked: true,
PeerChoked: true,
PeerMaxRequests: 250,
}
c.writerCond.L = &cl.mu
2016-10-10 05:55:56 +00:00
c.setRW(connStatsReadWriter{nc, &cl.mu, c})
c.r = &rateLimitedReader{
l: cl.downloadLimit,
r: c.r,
}
2016-10-10 05:55:56 +00:00
return
}
func (cl *Client) onDHTAnnouncePeer(ih metainfo.Hash, p dht.Peer) {
cl.mu.Lock()
defer cl.mu.Unlock()
t := cl.torrent(ih)
if t == nil {
return
}
t.addPeers([]Peer{{
IP: p.IP,
Port: p.Port,
Source: peerSourceDHTAnnouncePeer,
}})
}