torrent/client.go

2526 lines
60 KiB
Go
Raw Normal View History

2013-09-26 09:49:15 +00:00
package torrent
import (
"bufio"
"bytes"
"crypto/rand"
"crypto/sha1"
2015-03-12 09:06:23 +00:00
"encoding/hex"
2013-09-26 09:49:15 +00:00
"errors"
"expvar"
"fmt"
2013-09-26 09:49:15 +00:00
"io"
"log"
"math/big"
2014-03-16 15:30:10 +00:00
mathRand "math/rand"
"net"
2015-03-10 15:41:41 +00:00
"net/url"
2013-09-26 09:49:15 +00:00
"os"
"path/filepath"
"sort"
2015-03-18 07:21:00 +00:00
"strconv"
2014-09-13 17:50:15 +00:00
"strings"
"time"
2015-08-05 22:56:36 +00:00
"github.com/anacrolix/missinggo"
. "github.com/anacrolix/missinggo"
"github.com/anacrolix/missinggo/bitmap"
2016-03-06 06:26:04 +00:00
"github.com/anacrolix/missinggo/pproffd"
"github.com/anacrolix/missinggo/pubsub"
2015-03-20 12:52:53 +00:00
"github.com/anacrolix/sync"
"github.com/anacrolix/utp"
"github.com/edsrzf/mmap-go"
2015-04-28 05:24:17 +00:00
"github.com/anacrolix/torrent/bencode"
filePkg "github.com/anacrolix/torrent/data/file"
"github.com/anacrolix/torrent/dht"
"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"
"github.com/anacrolix/torrent/tracker"
2013-09-26 09:49:15 +00:00
)
// I could move a lot of these counters to their own file, but I suspect they
// may be attached to a Client someday.
var (
2015-06-22 09:48:30 +00:00
unwantedChunksReceived = expvar.NewInt("chunksReceivedUnwanted")
unexpectedChunksReceived = expvar.NewInt("chunksReceivedUnexpected")
chunksReceived = expvar.NewInt("chunksReceived")
2015-06-28 06:41:51 +00:00
peersAddedBySource = expvar.NewMap("peersAddedBySource")
2015-06-28 06:41:51 +00:00
uploadChunksPosted = expvar.NewInt("uploadChunksPosted")
unexpectedCancels = expvar.NewInt("unexpectedCancels")
postedCancels = expvar.NewInt("postedCancels")
duplicateConnsAvoided = expvar.NewInt("duplicateConnsAvoided")
pieceHashedCorrect = expvar.NewInt("pieceHashedCorrect")
pieceHashedNotCorrect = expvar.NewInt("pieceHashedNotCorrect")
unsuccessfulDials = expvar.NewInt("dialSuccessful")
successfulDials = expvar.NewInt("dialUnsuccessful")
2015-06-29 14:35:47 +00:00
acceptUTP = expvar.NewInt("acceptUTP")
acceptTCP = expvar.NewInt("acceptTCP")
acceptReject = expvar.NewInt("acceptReject")
peerExtensions = expvar.NewMap("peerExtensions")
completedHandshakeConnectionFlags = expvar.NewMap("completedHandshakeConnectionFlags")
// Count of connections to peer with same client ID.
connsToSelf = expvar.NewInt("connsToSelf")
// Number of completed connections to a client we're already connected with.
duplicateClientConns = expvar.NewInt("duplicateClientConns")
receivedMessageTypes = expvar.NewMap("receivedMessageTypes")
receivedKeepalives = expvar.NewInt("receivedKeepalives")
supportedExtensionMessages = expvar.NewMap("supportedExtensionMessages")
2016-02-09 13:45:47 +00:00
postedMessageTypes = expvar.NewMap("postedMessageTypes")
postedKeepalives = expvar.NewInt("postedKeepalives")
// Requests received for pieces we don't have.
requestsReceivedForMissingPieces = expvar.NewInt("requestsReceivedForMissingPieces")
)
const (
// Justification for set bits follows.
//
2015-08-01 17:53:37 +00:00
// Extension protocol ([5]|=0x10):
// http://www.bittorrent.org/beps/bep_0010.html
//
// Fast Extension ([7]|=0x04):
// http://bittorrent.org/beps/bep_0006.html.
// Disabled until AllowedFast is implemented.
//
// DHT ([7]|=1):
// http://www.bittorrent.org/beps/bep_0005.html
2015-03-18 07:21:00 +00:00
defaultExtensionBytes = "\x00\x00\x00\x00\x00\x10\x00\x01"
2015-06-29 14:46:43 +00:00
socketsPerTorrent = 80
2015-02-21 03:56:17 +00:00
torrentPeersHighWater = 200
torrentPeersLowWater = 50
// Limit how long handshake can take. This is to reduce the lingering
// impact of a few bad apples. 4s loses 1% of successful handshakes that
// are obtained with 60s timeout, and 5% of unsuccessful handshakes.
btHandshakeTimeout = 4 * time.Second
handshakesTimeout = 20 * time.Second
2015-06-28 06:40:46 +00:00
// These are our extended message IDs.
metadataExtendedId = iota + 1 // 0 is reserved for deleting keys
pexExtendedId
2015-06-28 06:40:46 +00:00
// Updated occasionally to when there's been some changes to client
// behaviour in case other clients are assuming anything of us. See also
// `bep20`.
extendedHandshakeClientVersion = "go.torrent dev 20150624"
)
2014-03-16 15:30:10 +00:00
// Currently doesn't really queue, but should in the future.
func (cl *Client) queuePieceCheck(t *torrent, pieceIndex int) {
piece := &t.Pieces[pieceIndex]
if piece.QueuedForHash {
return
}
piece.QueuedForHash = true
t.publishPieceChange(int(pieceIndex))
go cl.verifyPiece(t, int(pieceIndex))
}
2015-02-24 14:34:57 +00:00
// Queue a piece check if one isn't already queued, and the piece has never
// been checked before.
2014-09-13 17:50:15 +00:00
func (cl *Client) queueFirstHash(t *torrent, piece int) {
p := &t.Pieces[piece]
2015-03-10 15:41:21 +00:00
if p.EverHashed || p.Hashing || p.QueuedForHash || t.pieceComplete(piece) {
2014-09-13 17:50:15 +00:00
return
}
cl.queuePieceCheck(t, piece)
2014-09-13 17:50:15 +00:00
}
2015-06-03 03:30:55 +00:00
// Clients contain zero or more Torrents. A client manages a blocklist, the
// TCP/UDP protocol ports, and DHT as desired.
2013-10-06 07:01:39 +00:00
type Client struct {
halfOpenLimit int
peerID [20]byte
listeners []net.Listener
utpSock *utp.Socket
dHT *dht.Server
ipBlockList iplist.Ranger
bannedTorrents map[InfoHash]struct{}
config Config
pruneTimer *time.Timer
extensionBytes peerExtensionBytes
// 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{}
torrentDataOpener TorrentDataOpener
mu sync.RWMutex
event sync.Cond
closed missinggo.Event
torrents map[InfoHash]*torrent
}
func (me *Client) IPBlockList() iplist.Ranger {
me.mu.Lock()
defer me.mu.Unlock()
return me.ipBlockList
2013-09-26 09:49:15 +00:00
}
func (me *Client) SetIPBlockList(list iplist.Ranger) {
me.mu.Lock()
defer me.mu.Unlock()
me.ipBlockList = list
2014-11-30 02:33:17 +00:00
if me.dHT != nil {
me.dHT.SetIPBlockList(list)
}
}
func (me *Client) PeerID() string {
return string(me.peerID[:])
}
2014-11-16 19:16:26 +00:00
func (me *Client) ListenAddr() (addr net.Addr) {
for _, l := range me.listeners {
addr = l.Addr()
break
2014-11-16 19:16:26 +00:00
}
return
2014-08-21 08:07:06 +00:00
}
type hashSorter struct {
Hashes []InfoHash
}
func (me hashSorter) Len() int {
return len(me.Hashes)
}
func (me hashSorter) Less(a, b int) bool {
return (&big.Int{}).SetBytes(me.Hashes[a][:]).Cmp((&big.Int{}).SetBytes(me.Hashes[b][:])) < 0
}
func (me hashSorter) Swap(a, b int) {
me.Hashes[a], me.Hashes[b] = me.Hashes[b], me.Hashes[a]
}
func (cl *Client) sortedTorrents() (ret []*torrent) {
var hs hashSorter
for ih := range cl.torrents {
hs.Hashes = append(hs.Hashes, ih)
}
sort.Sort(hs)
for _, ih := range hs.Hashes {
ret = append(ret, cl.torrent(ih))
}
return
}
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.RLock()
defer cl.mu.RUnlock()
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", cl.ListenAddr())
} else {
2015-03-10 15:39:01 +00:00
fmt.Fprintln(w, "Not listening!")
2015-02-25 03:52:19 +00:00
}
2015-06-22 09:46:26 +00:00
fmt.Fprintf(w, "Peer ID: %+q\n", cl.peerID)
2014-08-21 08:07:06 +00:00
if cl.dHT != nil {
2014-12-07 03:19:02 +00:00
dhtStats := cl.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", cl.dHT.ID())
2016-03-21 05:02:36 +00:00
fmt.Fprintf(w, "DHT port: %d\n", missinggo.AddrPort(cl.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.torrents))
fmt.Fprintln(w)
for _, t := range cl.sortedTorrents() {
2014-11-18 20:32:51 +00:00
if t.Name() == "" {
fmt.Fprint(w, "<unknown name>")
} else {
fmt.Fprint(w, t.Name())
}
2015-02-21 03:57:37 +00:00
fmt.Fprint(w, "\n")
2014-11-18 20:32:51 +00:00
if t.haveInfo() {
fmt.Fprintf(w, "%f%% of %d bytes", 100*(1-float64(t.bytesLeft())/float64(t.length)), t.length)
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")
2015-06-16 06:57:47 +00:00
t.writeStatus(w, cl)
fmt.Fprintln(w)
}
}
// Calculates the number of pieces to set to Readahead priority, after the
// Now, and Next pieces.
func readaheadPieces(readahead, pieceLength int64) (ret int) {
// Expand the readahead to fit any partial pieces. Subtract 1 for the
// "next" piece that is assigned.
ret = int((readahead+pieceLength-1)/pieceLength - 1)
// Lengthen the "readahead tail" to smooth blockiness that occurs when the
// piece length is much larger than the readahead.
if ret < 2 {
ret++
}
return
}
2014-12-01 22:39:09 +00:00
func (cl *Client) configDir() string {
if cl.config.ConfigDir == "" {
return filepath.Join(os.Getenv("HOME"), ".config/torrent")
}
return cl.config.ConfigDir
2014-12-01 22:39:09 +00:00
}
2015-06-22 09:48:50 +00:00
// The directory where the Client expects to find and store configuration
// data. Defaults to $HOME/.config/torrent.
func (cl *Client) ConfigDir() string {
return cl.configDir()
}
func loadPackedBlocklist(filename string) (ret iplist.Ranger, err error) {
f, err := os.Open(filename)
if os.IsNotExist(err) {
err = nil
return
}
if err != nil {
return
}
defer f.Close()
mm, err := mmap.Map(f, mmap.RDONLY, 0)
if err != nil {
return
}
ret = iplist.NewFromPacked(mm)
return
}
func (cl *Client) setEnvBlocklist() (err error) {
filename := os.Getenv("TORRENT_BLOCKLIST_FILE")
defaultBlocklist := filename == ""
if defaultBlocklist {
cl.ipBlockList, err = loadPackedBlocklist(filepath.Join(cl.configDir(), "packed-blocklist"))
if err != nil {
return
}
if cl.ipBlockList != nil {
return
}
2014-12-01 22:39:09 +00:00
filename = filepath.Join(cl.configDir(), "blocklist")
}
f, err := os.Open(filename)
if err != nil {
if defaultBlocklist {
err = nil
}
return
}
defer f.Close()
cl.ipBlockList, err = iplist.NewFromReader(f)
return
}
2014-12-01 22:39:09 +00:00
func (cl *Client) initBannedTorrents() error {
f, err := os.Open(filepath.Join(cl.configDir(), "banned_infohashes"))
if err != nil {
if os.IsNotExist(err) {
return nil
}
return fmt.Errorf("error opening banned infohashes file: %s", err)
}
defer f.Close()
scanner := bufio.NewScanner(f)
cl.bannedTorrents = make(map[InfoHash]struct{})
for scanner.Scan() {
2015-03-18 07:35:52 +00:00
if strings.HasPrefix(strings.TrimSpace(scanner.Text()), "#") {
continue
}
2014-12-01 22:39:09 +00:00
var ihs string
n, err := fmt.Sscanf(scanner.Text(), "%x", &ihs)
if err != nil {
return fmt.Errorf("error reading infohash: %s", err)
}
if n != 1 {
continue
}
if len(ihs) != 20 {
return errors.New("bad infohash")
}
var ih InfoHash
CopyExact(&ih, ihs)
cl.bannedTorrents[ih] = struct{}{}
}
if err := scanner.Err(); err != nil {
return fmt.Errorf("error scanning file: %s", err)
}
return nil
}
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{}
}
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: socketsPerTorrent,
config: *cfg,
torrentDataOpener: func(md *metainfo.Info) Data {
return filePkg.TorrentData(md, cfg.DataDir)
},
dopplegangerAddrs: make(map[string]struct{}),
torrents: make(map[InfoHash]*torrent),
2014-08-21 08:07:06 +00:00
}
CopyExact(&cl.extensionBytes, defaultExtensionBytes)
2014-08-21 08:07:06 +00:00
cl.event.L = &cl.mu
2015-02-25 04:41:13 +00:00
if cfg.TorrentDataOpener != nil {
cl.torrentDataOpener = cfg.TorrentDataOpener
}
if cfg.IPBlocklist != nil {
cl.ipBlockList = cfg.IPBlocklist
} else if !cfg.NoDefaultBlocklist {
err = cl.setEnvBlocklist()
if err != nil {
return
}
}
2014-08-21 08:07:06 +00:00
2014-12-01 22:39:09 +00:00
if err = cl.initBannedTorrents(); err != nil {
err = fmt.Errorf("error initing banned torrents: %s", err)
return
}
if cfg.PeerID != "" {
CopyExact(&cl.peerID, cfg.PeerID)
} else {
2015-03-08 06:28:14 +00:00
o := copy(cl.peerID[:], bep20)
_, err = rand.Read(cl.peerID[o:])
if err != nil {
panic("error generating peer id")
}
}
2014-08-21 08:07:06 +00:00
// Returns the laddr string to listen on for the next Listen call.
listenAddr := func() string {
if addr := cl.ListenAddr(); addr != nil {
return addr.String()
}
if cfg.ListenAddr == "" {
return ":50007"
}
return cfg.ListenAddr
}
if !cl.config.DisableTCP {
var l net.Listener
2015-08-04 16:41:50 +00:00
l, err = net.Listen(func() string {
if cl.config.DisableIPv6 {
return "tcp4"
} else {
return "tcp"
}
}(), listenAddr())
if err != nil {
return
}
cl.listeners = append(cl.listeners, l)
go cl.acceptConnections(l, false)
}
if !cl.config.DisableUTP {
2015-08-04 16:41:50 +00:00
cl.utpSock, err = utp.NewSocket(func() string {
if cl.config.DisableIPv6 {
return "udp4"
} else {
return "udp"
}
}(), listenAddr())
if err != nil {
return
}
2015-01-10 13:16:19 +00:00
cl.listeners = append(cl.listeners, cl.utpSock)
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
}
if dhtCfg.Addr == "" {
dhtCfg.Addr = listenAddr()
2014-11-20 02:02:20 +00:00
}
2015-01-10 13:16:19 +00:00
if dhtCfg.Conn == nil && cl.utpSock != nil {
dhtCfg.Conn = cl.utpSock
}
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
}
}
return
}
// Stops the client. All connections to peers are closed and all activity will
// come to a halt.
2015-03-08 06:28:14 +00:00
func (me *Client) Close() {
me.mu.Lock()
2015-02-09 13:21:50 +00:00
defer me.mu.Unlock()
me.closed.Set()
if me.dHT != nil {
me.dHT.Close()
}
for _, l := range me.listeners {
l.Close()
}
for _, t := range me.torrents {
t.close()
}
me.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() {
cl.mu.Lock()
defer cl.mu.Unlock()
for {
for _, t := range cl.torrents {
if cl.wantConns(t) {
return
}
}
if cl.closed.IsSet() {
return
}
cl.event.Wait()
}
}
func (cl *Client) acceptConnections(l net.Listener, utp bool) {
for {
cl.waitAccept()
conn, err := l.Accept()
2016-03-06 06:26:04 +00:00
conn = pproffd.WrapNetConn(conn)
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)
}
cl.mu.RLock()
doppleganger := cl.dopplegangerAddr(conn.RemoteAddr().String())
_, blocked := cl.ipBlockRange(AddrIP(conn.RemoteAddr()))
cl.mu.RUnlock()
if blocked || doppleganger {
2015-06-29 14:35:47 +00:00
acceptReject.Add(1)
2015-03-12 09:04:44 +00:00
// log.Printf("inbound connection from %s blocked by %s", conn.RemoteAddr(), blockRange)
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)
}
c := newConnection()
c.conn = nc
c.rw = nc
c.Discovery = peerSourceIncoming
c.uTP = utp
err := cl.runReceivedConn(c)
if err != nil {
// log.Print(err)
}
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.
2016-01-05 08:42:26 +00:00
func (cl *Client) Torrent(ih InfoHash) (T Torrent, ok bool) {
cl.mu.Lock()
defer cl.mu.Unlock()
t, ok := cl.torrents[ih]
if !ok {
return
}
T = Torrent{cl, t}
return
}
func (me *Client) torrent(ih InfoHash) *torrent {
2015-03-08 06:28:14 +00:00
return me.torrents[ih]
}
type dialResult struct {
Conn net.Conn
UTP bool
}
func doDial(dial func(addr string, t *torrent) (net.Conn, error), ch chan dialResult, utp bool, addr string, t *torrent) {
conn, err := dial(addr, t)
2014-11-18 00:04:33 +00:00
if err != nil {
2014-12-26 06:18:36 +00:00
if conn != nil {
conn.Close()
}
2014-11-18 00:04:33 +00:00
conn = nil // Pedantic
}
ch <- dialResult{conn, utp}
if err == nil {
successfulDials.Add(1)
return
}
unsuccessfulDials.Add(1)
}
2014-11-19 03:53:00 +00:00
func reducedDialTimeout(max time.Duration, halfOpenLimit int, pendingPeers int) (ret time.Duration) {
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 (me *Client) dopplegangerAddr(addr string) bool {
_, ok := me.dopplegangerAddrs[addr]
return ok
}
// Start the process of connecting to the given peer for the given torrent if
// appropriate.
func (me *Client) initiateConn(peer Peer, t *torrent) {
2014-08-21 08:07:06 +00:00
if peer.Id == me.peerID {
return
}
addr := net.JoinHostPort(peer.IP.String(), fmt.Sprintf("%d", peer.Port))
if me.dopplegangerAddr(addr) || t.addrActive(addr) {
duplicateConnsAvoided.Add(1)
return
}
if r, ok := me.ipBlockRange(peer.IP); ok {
2014-11-30 02:33:17 +00:00
log.Printf("outbound connect to %s blocked by IP blocklist rule %s", peer.IP, r)
return
}
t.HalfOpen[addr] = struct{}{}
go me.outgoingConnection(t, addr, peer.Source)
}
func (me *Client) dialTimeout(t *torrent) time.Duration {
2015-03-30 12:10:37 +00:00
me.mu.Lock()
pendingPeers := len(t.Peers)
me.mu.Unlock()
return reducedDialTimeout(nominalDialTimeout, me.halfOpenLimit, pendingPeers)
}
func (me *Client) dialTCP(addr string, t *torrent) (c net.Conn, err error) {
c, err = net.DialTimeout("tcp", addr, me.dialTimeout(t))
if err == nil {
c.(*net.TCPConn).SetLinger(0)
}
return
}
func (me *Client) dialUTP(addr string, t *torrent) (c net.Conn, err error) {
return me.utpSock.DialTimeout(addr, me.dialTimeout(t))
}
// Returns a connection over UTP or TCP, whichever is first to connect.
func (me *Client) dialFirst(addr string, t *torrent) (conn net.Conn, utp bool) {
// Initiate connections via TCP and UTP simultaneously. Use the first one
// that succeeds.
left := 0
if !me.config.DisableUTP {
left++
}
if !me.config.DisableTCP {
left++
}
resCh := make(chan dialResult, left)
if !me.config.DisableUTP {
go doDial(me.dialUTP, resCh, true, addr, t)
}
if !me.config.DisableTCP {
go doDial(me.dialTCP, resCh, false, addr, t)
}
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
return
}
func (me *Client) noLongerHalfOpen(t *torrent, addr string) {
if _, ok := t.HalfOpen[addr]; !ok {
panic("invariant broken")
}
delete(t.HalfOpen, addr)
me.openNewConns(t)
}
// Performs initiator handshakes and returns a connection. Returns nil
// *connection if no connection for valid reasons.
func (me *Client) handshakesConnection(nc net.Conn, t *torrent, encrypted, utp bool) (c *connection, err error) {
c = newConnection()
c.conn = nc
c.rw = nc
c.encrypted = encrypted
c.uTP = utp
err = nc.SetDeadline(time.Now().Add(handshakesTimeout))
if err != nil {
return
}
ok, err := me.initiateHandshakes(c, t)
if !ok {
c = nil
}
return
}
// Returns nil connection and nil error if no connection could be established
// for valid reasons.
func (me *Client) establishOutgoingConn(t *torrent, addr string) (c *connection, err error) {
nc, utp := me.dialFirst(addr, t)
if nc == nil {
return
}
c, err = me.handshakesConnection(nc, t, !me.config.DisableEncryption, utp)
if err != nil {
nc.Close()
return
} else if c != nil {
return
}
nc.Close()
if me.config.DisableEncryption {
// We already tried without encryption.
return
}
2015-08-01 17:53:37 +00:00
// Try again without encryption, using whichever protocol type worked last
// time.
if utp {
nc, err = me.dialUTP(addr, t)
} else {
nc, err = me.dialTCP(addr, t)
}
if err != nil {
err = fmt.Errorf("error dialing for unencrypted connection: %s", err)
return
}
c, err = me.handshakesConnection(nc, t, false, utp)
if err != nil || c == nil {
nc.Close()
}
return
}
// Called to dial out and run a connection. The addr we're given is already
// considered half-open.
func (me *Client) outgoingConnection(t *torrent, addr string, ps peerSource) {
c, err := me.establishOutgoingConn(t, addr)
me.mu.Lock()
defer me.mu.Unlock()
// Don't release lock between here and addConnection, unless it's for
// failure.
me.noLongerHalfOpen(t, addr)
if err != nil {
return
}
if c == nil {
return
}
defer c.Close()
c.Discovery = ps
err = me.runInitiatedHandshookConn(c, t)
if err != nil {
// log.Print(err)
}
}
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 {
2014-11-16 19:16:26 +00:00
listenAddr := cl.ListenAddr()
if listenAddr == nil {
return 0
}
2016-03-21 05:02:36 +00:00
return missinggo.AddrPort(listenAddr)
}
2014-11-16 19:16:26 +00:00
// Convert a net.Addr to its compact IP representation. Either 4 or 16 bytes
// per "yourip" field of http://www.bittorrent.org/beps/bep_0010.html.
func addrCompactIP(addr net.Addr) (string, error) {
2014-11-16 19:16:26 +00:00
host, _, err := net.SplitHostPort(addr.String())
if err != nil {
return "", err
}
ip := net.ParseIP(host)
if v4 := ip.To4(); v4 != nil {
if len(v4) != 4 {
panic(v4)
}
2014-11-16 19:16:26 +00:00
return string(v4), nil
}
2014-11-16 19:16:26 +00:00
return string(ip.To16()), nil
}
func handshakeWriter(w io.Writer, bb <-chan []byte, done chan<- error) {
var err error
for b := range bb {
_, err = w.Write(b)
if err != nil {
break
}
}
done <- err
}
2015-03-12 09:04:44 +00:00
type (
peerExtensionBytes [8]byte
peerID [20]byte
)
func (me *peerExtensionBytes) SupportsExtended() bool {
return me[5]&0x10 != 0
}
func (me *peerExtensionBytes) SupportsDHT() bool {
return me[7]&0x01 != 0
}
func (me *peerExtensionBytes) SupportsFast() bool {
return me[7]&0x04 != 0
}
type handshakeResult struct {
peerExtensionBytes
peerID
InfoHash
}
2015-02-09 13:16:01 +00:00
// ih is nil if we expect the peer to declare the InfoHash, such as when the
// peer initiated the connection. Returns ok if the handshake was successful,
// and err if there was an unexpected condition other than the peer simply
// abandoning the handshake.
func handshake(sock io.ReadWriter, ih *InfoHash, peerID [20]byte, extensions peerExtensionBytes) (res handshakeResult, ok bool, err error) {
// Bytes to be sent to the peer. Should never block the sender.
postCh := make(chan []byte, 4)
// A single error value sent when the writer completes.
writeDone := make(chan error, 1)
// Performs writes to the socket and ensures posts don't block.
go handshakeWriter(sock, postCh, writeDone)
defer func() {
close(postCh) // Done writing.
if !ok {
return
}
if err != nil {
panic(err)
}
// Wait until writes complete before returning from handshake.
err = <-writeDone
if err != nil {
err = fmt.Errorf("error writing: %s", err)
}
}()
post := func(bb []byte) {
select {
case postCh <- bb:
default:
panic("mustn't block while posting")
}
2014-03-20 13:14:17 +00:00
}
post([]byte(pp.Protocol))
post(extensions[:])
if ih != nil { // We already know what we want.
post(ih[:])
post(peerID[:])
}
var b [68]byte
_, err = io.ReadFull(sock, b[:68])
if err != nil {
err = nil
return
}
if string(b[:20]) != pp.Protocol {
return
}
CopyExact(&res.peerExtensionBytes, b[20:28])
CopyExact(&res.InfoHash, b[28:48])
CopyExact(&res.peerID, b[48:68])
2015-03-12 09:06:23 +00:00
peerExtensions.Add(hex.EncodeToString(res.peerExtensionBytes[:]), 1)
2015-03-12 09:06:23 +00:00
// TODO: Maybe we can just drop peers here if we're not interested. This
// could prevent them trying to reconnect, falsely believing there was
// just a problem.
if ih == nil { // We were waiting for the peer to tell us what they wanted.
post(res.InfoHash[:])
post(peerID[:])
}
ok = true
return
}
2015-02-21 03:58:28 +00:00
// Wraps a raw connection and provides the interface we want for using the
// connection in the message loop.
type deadlineReader struct {
nc net.Conn
r io.Reader
}
func (me deadlineReader) Read(b []byte) (n int, err error) {
2014-11-20 02:02:20 +00:00
// Keep-alives should be received every 2 mins. Give a bit of gracetime.
err = me.nc.SetReadDeadline(time.Now().Add(150 * time.Second))
if err != nil {
2015-01-21 13:42:13 +00:00
err = fmt.Errorf("error setting read deadline: %s", err)
}
n, err = me.r.Read(b)
2015-02-21 03:58:28 +00:00
// Convert common errors into io.EOF.
// if err != nil {
// if opError, ok := err.(*net.OpError); ok && opError.Op == "read" && opError.Err == syscall.ECONNRESET {
// err = io.EOF
// } else if netErr, ok := err.(net.Error); ok && netErr.Timeout() {
// if n != 0 {
// panic(n)
// }
// err = io.EOF
// }
// }
return
}
type readWriter struct {
io.Reader
io.Writer
}
func maybeReceiveEncryptedHandshake(rw io.ReadWriter, skeys [][]byte) (ret io.ReadWriter, encrypted bool, err error) {
var protocol [len(pp.Protocol)]byte
_, err = io.ReadFull(rw, protocol[:])
if err != nil {
return
}
ret = readWriter{
io.MultiReader(bytes.NewReader(protocol[:]), rw),
rw,
}
if string(protocol[:]) == pp.Protocol {
return
}
encrypted = true
ret, err = mse.ReceiveHandshake(ret, skeys)
return
}
func (cl *Client) receiveSkeys() (ret [][]byte) {
for ih := range cl.torrents {
ret = append(ret, ih[:])
}
return
}
func (me *Client) initiateHandshakes(c *connection, t *torrent) (ok bool, err error) {
if c.encrypted {
c.rw, err = mse.InitiateHandshake(c.rw, t.InfoHash[:], nil)
if err != nil {
return
}
}
ih, ok, err := me.connBTHandshake(c, &t.InfoHash)
if ih != t.InfoHash {
ok = false
}
return
}
2015-03-27 04:37:58 +00:00
// Do encryption and bittorrent handshakes as receiver.
func (cl *Client) receiveHandshakes(c *connection) (t *torrent, err error) {
cl.mu.Lock()
skeys := cl.receiveSkeys()
cl.mu.Unlock()
2015-04-20 07:30:22 +00:00
if !cl.config.DisableEncryption {
c.rw, c.encrypted, err = maybeReceiveEncryptedHandshake(c.rw, skeys)
if err != nil {
if err == mse.ErrNoSecretKeyMatch {
err = nil
}
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 *InfoHash) (ret InfoHash, ok bool, err error) {
res, ok, err := handshake(c.rw, ih, cl.peerID, cl.extensionBytes)
if err != nil || !ok {
return
}
ret = res.InfoHash
c.PeerExtensionBytes = res.peerExtensionBytes
c.PeerID = res.peerID
c.completedHandshake = time.Now()
return
}
func (cl *Client) runInitiatedHandshookConn(c *connection, t *torrent) (err error) {
if c.PeerID == cl.peerID {
// Only if we initiated the connection is the remote address a
// listen addr for a doppleganger.
connsToSelf.Add(1)
addr := c.conn.RemoteAddr().String()
cl.dopplegangerAddrs[addr] = struct{}{}
return
}
return cl.runHandshookConn(c, t)
}
func (cl *Client) runReceivedConn(c *connection) (err error) {
err = c.conn.SetDeadline(time.Now().Add(handshakesTimeout))
if err != nil {
return
}
t, err := cl.receiveHandshakes(c)
if err != nil {
2015-03-27 04:37:58 +00:00
err = fmt.Errorf("error receiving handshakes: %s", err)
return
}
if t == nil {
return
}
cl.mu.Lock()
defer cl.mu.Unlock()
if c.PeerID == cl.peerID {
return
}
return cl.runHandshookConn(c, t)
}
func (cl *Client) runHandshookConn(c *connection, t *torrent) (err error) {
c.conn.SetWriteDeadline(time.Time{})
c.rw = readWriter{
deadlineReader{c.conn, c.rw},
c.rw,
}
completedHandshakeConnectionFlags.Add(c.connectionFlags(), 1)
if !cl.addConnection(t, c) {
2014-03-16 15:30:10 +00:00
return
}
defer cl.dropConnection(t, c)
go c.writer()
go c.writeOptimizer(time.Minute)
cl.sendInitialMessages(c, t)
err = cl.connectionLoop(t, c)
if err != nil {
err = fmt.Errorf("error during connection loop: %s", err)
}
return
}
func (me *Client) sendInitialMessages(conn *connection, torrent *torrent) {
if conn.PeerExtensionBytes.SupportsExtended() && me.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 !me.config.DisablePEX {
ret["ut_pex"] = pexExtendedId
}
return
}(),
"v": 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 !me.config.DisableEncryption {
d["e"] = 1
2014-06-28 09:38:31 +00:00
}
if torrent.metadataSizeKnown() {
d["metadata_size"] = torrent.metadataSize()
}
if p := me.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 me.extensionBytes.SupportsFast() && conn.PeerExtensionBytes.SupportsFast() {
conn.Post(pp.Message{
Type: pp.HaveNone,
})
}
if conn.PeerExtensionBytes.SupportsDHT() && me.extensionBytes.SupportsDHT() && me.dHT != nil {
2014-08-25 12:12:16 +00:00
conn.Post(pp.Message{
Type: pp.Port,
Port: uint16(AddrPort(me.dHT.Addr())),
2014-08-25 12:12:16 +00:00
})
}
}
func (me *Client) peerUnchoked(torrent *torrent, conn *connection) {
conn.updateRequests()
}
func (cl *Client) connCancel(t *torrent, cn *connection, r request) (ok bool) {
ok = cn.Cancel(r)
if ok {
2014-08-23 17:10:47 +00:00
postedCancels.Add(1)
}
return
}
2015-06-22 09:48:30 +00:00
func (cl *Client) connDeleteRequest(t *torrent, cn *connection, r request) bool {
if !cn.RequestPending(r) {
2015-06-22 09:48:30 +00:00
return false
}
delete(cn.Requests, r)
2015-06-22 09:48:30 +00:00
return true
}
func (cl *Client) requestPendingMetadata(t *torrent, c *connection) {
if t.haveInfo() {
return
}
if c.PeerExtensionIDs["ut_metadata"] == 0 {
// Peer doesn't support this.
return
}
// Request metadata pieces that we don't have in a random order.
var pending []int
for index := 0; index < t.metadataPieceCount(); index++ {
if !t.haveMetadataPiece(index) && !c.requestedMetadataPiece(index) {
pending = append(pending, index)
}
}
for _, i := range mathRand.Perm(len(pending)) {
c.requestMetadataPiece(pending[i])
}
}
2014-06-28 09:38:31 +00:00
func (cl *Client) completedMetadata(t *torrent) {
h := sha1.New()
h.Write(t.MetaData)
var ih InfoHash
CopyExact(&ih, h.Sum(nil))
2014-06-28 09:38:31 +00:00
if ih != t.InfoHash {
log.Print("bad metadata")
t.invalidateMetadata()
2014-06-28 09:38:31 +00:00
return
}
var info metainfo.Info
err := bencode.Unmarshal(t.MetaData, &info)
if err != nil {
log.Printf("error unmarshalling metadata: %s", err)
t.invalidateMetadata()
2014-06-28 09:38:31 +00:00
return
}
// TODO(anacrolix): If this fails, I think something harsher should be
// done.
err = cl.setMetaData(t, &info, t.MetaData)
if err != nil {
log.Printf("error setting metadata: %s", err)
t.invalidateMetadata()
return
}
2015-09-17 02:40:35 +00:00
if cl.config.Debug {
log.Printf("%s: got metadata from peers", t)
}
2014-06-28 09:38:31 +00:00
}
// Process incoming ut_metadata message.
2014-06-28 09:38:31 +00:00
func (cl *Client) gotMetadataExtensionMsg(payload []byte, t *torrent, c *connection) (err error) {
var d map[string]int
err = bencode.Unmarshal(payload, &d)
if err != nil {
2014-06-30 14:05:28 +00:00
err = fmt.Errorf("error unmarshalling payload: %s: %q", err, payload)
2014-06-28 09:38:31 +00:00
return
}
msgType, ok := d["msg_type"]
if !ok {
err = errors.New("missing msg_type field")
return
}
piece := d["piece"]
switch msgType {
case pp.DataMetadataExtensionMsgType:
if t.haveInfo() {
break
}
begin := len(payload) - metadataPieceSize(d["total_size"], piece)
if begin < 0 || begin >= len(payload) {
log.Printf("got bad metadata piece")
break
}
if !c.requestedMetadataPiece(piece) {
log.Printf("got unexpected metadata piece %d", piece)
break
}
c.metadataRequests[piece] = false
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()
if !t.haveAllMetadataPieces() {
2014-06-28 09:38:31 +00:00
break
}
cl.completedMetadata(t)
case pp.RequestMetadataExtensionMsgType:
if !t.haveMetadataPiece(piece) {
c.Post(t.newMetadataExtensionMessage(c, pp.RejectMetadataExtensionMsgType, d["piece"], nil))
2014-06-28 09:38:31 +00:00
break
}
start := (1 << 14) * piece
c.Post(t.newMetadataExtensionMessage(c, pp.DataMetadataExtensionMsgType, piece, t.MetaData[start:start+t.metadataPieceSize(piece)]))
2014-06-28 09:38:31 +00:00
case pp.RejectMetadataExtensionMsgType:
default:
err = errors.New("unknown msg_type value")
}
return
}
2015-03-12 09:06:23 +00:00
func (cl *Client) peerHasAll(t *torrent, cn *connection) {
cn.peerHasAll = true
cn.PeerPieces = nil
if t.haveInfo() {
for i := 0; i < t.numPieces(); i++ {
cn.peerGotPiece(i)
2015-03-12 09:06:23 +00:00
}
}
}
2015-06-16 06:57:47 +00:00
func (me *Client) upload(t *torrent, c *connection) {
if me.config.NoUpload {
return
}
if !c.PeerInterested {
return
}
seeding := me.seeding(t)
if !seeding && !t.connHasWantedPieces(c) {
2015-06-16 06:57:47 +00:00
return
}
another:
for seeding || c.chunksSent < c.UsefulChunksReceived+6 {
2015-06-16 06:57:47 +00:00
c.Unchoke()
for r := range c.PeerRequests {
err := me.sendChunk(t, c, r)
if err != nil {
if t.pieceComplete(int(r.Index)) && err == io.ErrUnexpectedEOF {
// We had the piece, but not anymore.
} else {
log.Printf("error sending chunk %+v to peer: %s", r, err)
}
// If we failed to send a chunk, choke the peer to ensure they
// flush all their requests. We've probably dropped a piece,
// but there's no way to communicate this to the peer. If they
// ask for it again, we'll kick them to allow us to send them
// an updated bitfield.
break another
2015-06-16 06:57:47 +00:00
}
delete(c.PeerRequests, r)
goto another
}
return
}
c.Choke()
}
func (me *Client) sendChunk(t *torrent, c *connection, r request) 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 err
2015-06-16 06:57:47 +00:00
}
c.Post(pp.Message{
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 nil
}
2014-07-24 03:43:45 +00:00
// Processes incoming bittorrent messages. The client lock is held upon entry
// and exit.
func (me *Client) connectionLoop(t *torrent, c *connection) error {
decoder := pp.Decoder{
R: bufio.NewReader(c.rw),
MaxLength: 256 * 1024,
}
for {
me.mu.Unlock()
var msg pp.Message
err := decoder.Decode(&msg)
me.mu.Lock()
if me.closed.IsSet() || c.closed.IsSet() || err == io.EOF {
return nil
}
if err != nil {
return err
}
c.lastMessageReceived = time.Now()
if msg.Keepalive {
receivedKeepalives.Add(1)
continue
}
receivedMessageTypes.Add(strconv.FormatInt(int64(msg.Type), 10), 1)
switch msg.Type {
case pp.Choke:
c.PeerChoked = true
c.Requests = nil
// We can then reset our interest.
c.updateRequests()
2015-03-12 09:06:23 +00:00
case pp.Reject:
me.connDeleteRequest(t, c, newRequest(msg.Index, msg.Begin, msg.Length))
c.updateRequests()
case pp.Unchoke:
c.PeerChoked = false
me.peerUnchoked(t, c)
case pp.Interested:
c.PeerInterested = true
2015-06-16 06:57:47 +00:00
me.upload(t, c)
case pp.NotInterested:
c.PeerInterested = false
c.Choke()
case pp.Have:
c.peerGotPiece(int(msg.Index))
case pp.Request:
2015-06-02 14:03:43 +00:00
if c.Choked {
break
}
2015-06-16 06:57:47 +00:00
if !c.PeerInterested {
err = errors.New("peer sent request but isn't interested")
break
}
if !t.havePiece(msg.Index.Int()) {
// This isn't necessarily them screwing up. We can drop pieces
// from our storage, and can't communicate this to peers
// except by reconnecting.
requestsReceivedForMissingPieces.Add(1)
err = errors.New("peer requested piece we don't have")
break
}
2015-06-16 06:57:47 +00:00
if c.PeerRequests == nil {
c.PeerRequests = make(map[request]struct{}, maxRequests)
}
2015-06-16 06:57:47 +00:00
c.PeerRequests[newRequest(msg.Index, msg.Begin, msg.Length)] = struct{}{}
me.upload(t, c)
case pp.Cancel:
2014-04-16 07:33:33 +00:00
req := newRequest(msg.Index, msg.Begin, msg.Length)
if !c.PeerCancel(req) {
2014-08-22 07:47:44 +00:00
unexpectedCancels.Add(1)
2014-04-16 07:33:33 +00:00
}
case pp.Bitfield:
2015-03-12 09:06:23 +00:00
if c.PeerPieces != nil || c.peerHasAll {
err = errors.New("received unexpected bitfield")
break
}
if t.haveInfo() {
if len(msg.Bitfield) < t.numPieces() {
err = errors.New("received invalid bitfield")
break
}
msg.Bitfield = msg.Bitfield[:t.numPieces()]
}
c.PeerPieces = msg.Bitfield
for index, has := range c.PeerPieces {
if has {
c.peerGotPiece(index)
}
}
2015-03-12 09:06:23 +00:00
case pp.HaveAll:
if c.PeerPieces != nil || c.peerHasAll {
err = errors.New("unexpected have-all")
break
}
me.peerHasAll(t, c)
case pp.HaveNone:
if c.peerHasAll || c.PeerPieces != nil {
err = errors.New("unexpected have-none")
break
}
c.PeerPieces = make([]bool, func() int {
if t.haveInfo() {
return t.numPieces()
} else {
return 0
}
}())
case pp.Piece:
me.downloadedChunk(t, c, &msg)
case pp.Extended:
switch msg.ExtendedID {
case pp.HandshakeExtendedID:
// TODO: Create a bencode struct for this.
var d map[string]interface{}
err = bencode.Unmarshal(msg.ExtendedPayload, &d)
if err != nil {
err = fmt.Errorf("error decoding extended message payload: %s", err)
break
}
// log.Printf("got handshake from %q: %#v", c.Socket.RemoteAddr().String(), d)
if reqq, ok := d["reqq"]; ok {
if i, ok := reqq.(int64); ok {
c.PeerMaxRequests = int(i)
}
}
if v, ok := d["v"]; ok {
c.PeerClientName = v.(string)
}
m, ok := d["m"]
if !ok {
err = errors.New("handshake missing m item")
break
}
mTyped, ok := m.(map[string]interface{})
if !ok {
err = errors.New("handshake m value is not dict")
break
}
if c.PeerExtensionIDs == nil {
c.PeerExtensionIDs = make(map[string]byte, len(mTyped))
}
for name, v := range mTyped {
id, ok := v.(int64)
if !ok {
log.Printf("bad handshake m item extension ID type: %T", v)
continue
}
if id == 0 {
delete(c.PeerExtensionIDs, name)
} else {
2015-03-18 07:37:26 +00:00
if c.PeerExtensionIDs[name] == 0 {
supportedExtensionMessages.Add(name, 1)
}
c.PeerExtensionIDs[name] = byte(id)
}
}
metadata_sizeUntyped, ok := d["metadata_size"]
if ok {
metadata_size, ok := metadata_sizeUntyped.(int64)
if !ok {
log.Printf("bad metadata_size type: %T", metadata_sizeUntyped)
} else {
t.setMetadataSize(metadata_size, me)
}
}
if _, ok := c.PeerExtensionIDs["ut_metadata"]; ok {
me.requestPendingMetadata(t, c)
}
case metadataExtendedId:
2014-06-28 09:38:31 +00:00
err = me.gotMetadataExtensionMsg(msg.ExtendedPayload, t, c)
2014-06-30 14:05:28 +00:00
if err != nil {
err = fmt.Errorf("error handling metadata extension message: %s", err)
}
case pexExtendedId:
if me.config.DisablePEX {
break
}
2014-06-29 09:07:43 +00:00
var pexMsg peerExchangeMessage
err := bencode.Unmarshal(msg.ExtendedPayload, &pexMsg)
if err != nil {
err = fmt.Errorf("error unmarshalling PEX message: %s", err)
break
}
go func() {
2015-03-08 06:28:14 +00:00
me.mu.Lock()
me.addPeers(t, func() (ret []Peer) {
2015-03-18 07:37:26 +00:00
for i, cp := range pexMsg.Added {
2014-06-29 09:07:43 +00:00
p := Peer{
IP: make([]byte, 4),
Port: int(cp.Port),
Source: peerSourcePEX,
2014-06-29 09:07:43 +00:00
}
2015-03-18 07:37:26 +00:00
if i < len(pexMsg.AddedFlags) && pexMsg.AddedFlags[i]&0x01 != 0 {
p.SupportsEncryption = true
2014-06-29 09:07:43 +00:00
}
2015-03-18 07:37:26 +00:00
CopyExact(p.IP, cp.IP[:])
2014-06-29 09:07:43 +00:00
ret = append(ret, p)
}
return
}())
2015-03-08 06:28:14 +00:00
me.mu.Unlock()
2014-06-29 09:07:43 +00:00
}()
2014-06-28 09:38:31 +00:00
default:
2014-07-09 16:59:37 +00:00
err = fmt.Errorf("unexpected extended message ID: %v", msg.ExtendedID)
}
if err != nil {
// That client uses its own extension IDs for outgoing message
// types, which is incorrect.
if bytes.HasPrefix(c.PeerID[:], []byte("-SD0100-")) ||
strings.HasPrefix(string(c.PeerID[:]), "-XL0012-") {
return nil
}
}
2014-08-25 12:12:16 +00:00
case pp.Port:
if me.dHT == nil {
break
}
pingAddr, err := net.ResolveUDPAddr("", c.remoteAddr().String())
2014-11-16 19:16:26 +00:00
if err != nil {
panic(err)
}
if msg.Port != 0 {
pingAddr.Port = int(msg.Port)
}
_, err = me.dHT.Ping(pingAddr)
default:
2014-05-21 07:42:06 +00:00
err = fmt.Errorf("received unknown message type: %#v", msg.Type)
}
if err != nil {
return err
}
}
}
// Returns true if connection is removed from torrent.Conns.
func (me *Client) deleteConnection(t *torrent, c *connection) bool {
for i0, _c := range t.Conns {
if _c != c {
continue
}
i1 := len(t.Conns) - 1
if i0 != i1 {
t.Conns[i0] = t.Conns[i1]
}
t.Conns = t.Conns[:i1]
return true
}
return false
}
func (me *Client) dropConnection(t *torrent, c *connection) {
me.event.Broadcast()
c.Close()
if me.deleteConnection(t, c) {
me.openNewConns(t)
}
}
// Returns true if the connection is added.
func (me *Client) addConnection(t *torrent, c *connection) bool {
if me.closed.IsSet() {
return false
}
select {
case <-t.ceasingNetworking:
return false
default:
}
if !me.wantConns(t) {
return false
}
2014-03-16 15:30:10 +00:00
for _, c0 := range t.Conns {
if c.PeerID == c0.PeerID {
2014-05-21 07:42:06 +00:00
// Already connected to a client with that ID.
2015-03-18 07:37:26 +00:00
duplicateClientConns.Add(1)
return false
}
}
if len(t.Conns) >= socketsPerTorrent {
c := t.worstBadConn(me)
if c == nil {
return false
}
if me.config.Debug && missinggo.CryHeard() {
2015-08-05 22:56:36 +00:00
log.Printf("%s: dropping connection to make room for new one:\n %s", t, c)
}
c.Close()
me.deleteConnection(t, c)
}
if len(t.Conns) >= socketsPerTorrent {
panic(len(t.Conns))
}
t.Conns = append(t.Conns, c)
c.t = t
return true
}
func (t *torrent) readerPieces() (ret bitmap.Bitmap) {
t.forReaderOffsetPieces(func(begin, end int) bool {
ret.AddRange(begin, end)
return true
})
return
}
func (t *torrent) needData() bool {
if !t.haveInfo() {
return true
}
if t.pendingPieces.Len() != 0 {
return true
}
return !t.readerPieces().IterTyped(func(piece int) bool {
return t.pieceComplete(piece)
})
}
2015-06-16 06:57:47 +00:00
func (cl *Client) usefulConn(t *torrent, c *connection) bool {
if c.closed.IsSet() {
return false
}
if !t.haveInfo() {
return c.supportsExtension("ut_metadata")
2015-06-16 06:57:47 +00:00
}
if cl.seeding(t) {
return c.PeerInterested
}
2015-06-16 06:57:47 +00:00
return t.connHasWantedPieces(c)
}
func (me *Client) wantConns(t *torrent) bool {
2015-06-16 06:57:47 +00:00
if !me.seeding(t) && !t.needData() {
return false
}
if len(t.Conns) < socketsPerTorrent {
return true
}
return t.worstBadConn(me) != nil
}
func (me *Client) openNewConns(t *torrent) {
select {
case <-t.ceasingNetworking:
return
default:
}
for len(t.Peers) != 0 {
if !me.wantConns(t) {
return
}
if len(t.HalfOpen) >= me.halfOpenLimit {
return
}
var (
k peersKey
p Peer
)
for k, p = range t.Peers {
break
}
delete(t.Peers, k)
me.initiateConn(p, t)
}
t.wantPeers.Broadcast()
}
func (me *Client) addPeers(t *torrent, peers []Peer) {
2015-03-08 06:28:14 +00:00
for _, p := range peers {
2015-09-17 02:54:03 +00:00
if me.dopplegangerAddr(net.JoinHostPort(
p.IP.String(),
strconv.FormatInt(int64(p.Port), 10),
)) {
continue
}
if _, ok := me.ipBlockRange(p.IP); ok {
2014-11-30 02:33:17 +00:00
continue
}
2015-06-02 14:03:43 +00:00
if p.Port == 0 {
2015-09-17 02:39:51 +00:00
// The spec says to scrub these yourselves. Fine.
2015-06-02 14:03:43 +00:00
continue
}
t.addPeer(p, me)
2014-11-30 02:33:17 +00:00
}
}
func (cl *Client) cachedMetaInfoFilename(ih InfoHash) string {
2014-12-01 22:39:09 +00:00
return filepath.Join(cl.configDir(), "torrents", ih.HexString()+".torrent")
}
func (cl *Client) saveTorrentFile(t *torrent) error {
path := cl.cachedMetaInfoFilename(t.InfoHash)
2014-12-01 22:39:09 +00:00
os.MkdirAll(filepath.Dir(path), 0777)
f, err := os.OpenFile(path, os.O_WRONLY|os.O_CREATE|os.O_TRUNC, 0666)
if err != nil {
return fmt.Errorf("error opening file: %s", err)
}
defer f.Close()
e := bencode.NewEncoder(f)
err = e.Encode(t.MetaInfo())
if err != nil {
return fmt.Errorf("error marshalling metainfo: %s", err)
}
mi, err := cl.torrentCacheMetaInfo(t.InfoHash)
if err != nil {
// For example, a script kiddy makes us load too many files, and we're
// able to save the torrent, but not load it again to check it.
return nil
}
if !bytes.Equal(mi.Info.Hash, t.InfoHash[:]) {
log.Fatalf("%x != %x", mi.Info.Hash, t.InfoHash[:])
}
2014-12-01 22:39:09 +00:00
return nil
}
func (cl *Client) setStorage(t *torrent, td Data) (err error) {
t.setStorage(td)
cl.event.Broadcast()
return
}
type TorrentDataOpener func(*metainfo.Info) Data
2015-02-27 01:45:55 +00:00
func (cl *Client) setMetaData(t *torrent, md *metainfo.Info, bytes []byte) (err error) {
err = t.setMetadata(md, bytes)
if err != nil {
return
}
if !cl.config.DisableMetainfoCache {
if err := cl.saveTorrentFile(t); err != nil {
log.Printf("error saving torrent file for %s: %s", t, err)
}
}
cl.event.Broadcast()
close(t.gotMetainfo)
td := cl.torrentDataOpener(md)
err = cl.setStorage(t, td)
return
}
// Prepare a Torrent without any attachment to a Client. That means we can
// initialize fields all fields that don't require the Client without locking
// it.
func newTorrent(ih InfoHash) (t *torrent) {
t = &torrent{
InfoHash: ih,
chunkSize: defaultChunkSize,
Peers: make(map[peersKey]Peer),
closing: make(chan struct{}),
ceasingNetworking: make(chan struct{}),
gotMetainfo: make(chan struct{}),
HalfOpen: make(map[string]struct{}),
pieceStateChanges: pubsub.NewPubSub(),
}
return
}
2014-12-01 09:32:17 +00:00
func init() {
// For shuffling the tracker tiers.
mathRand.Seed(time.Now().Unix())
}
2016-02-07 07:49:35 +00:00
type trackerTier []string
// The trackers within each tier must be shuffled before use.
// http://stackoverflow.com/a/12267471/149482
// http://www.bittorrent.org/beps/bep_0012.html#order-of-processing
2016-02-07 07:49:35 +00:00
func shuffleTier(tier trackerTier) {
for i := range tier {
j := mathRand.Intn(i + 1)
tier[i], tier[j] = tier[j], tier[i]
}
}
2016-02-07 07:49:35 +00:00
func copyTrackers(base []trackerTier) (copy []trackerTier) {
for _, tier := range base {
2016-02-07 07:49:35 +00:00
copy = append(copy, append(trackerTier(nil), tier...))
}
return
}
2016-02-07 07:49:35 +00:00
func mergeTier(tier trackerTier, newURLs []string) trackerTier {
nextURL:
for _, url := range newURLs {
2016-02-07 07:49:35 +00:00
for _, trURL := range tier {
if trURL == url {
continue nextURL
2014-03-16 15:30:10 +00:00
}
}
2016-02-07 07:49:35 +00:00
tier = append(tier, url)
2014-03-16 15:30:10 +00:00
}
return tier
}
func (t *torrent) addTrackers(announceList [][]string) {
newTrackers := copyTrackers(t.Trackers)
for tierIndex, tier := range announceList {
if tierIndex < len(newTrackers) {
newTrackers[tierIndex] = mergeTier(newTrackers[tierIndex], tier)
} else {
newTrackers = append(newTrackers, mergeTier(nil, tier))
}
shuffleTier(newTrackers[tierIndex])
}
t.Trackers = newTrackers
2014-03-16 15:30:10 +00:00
}
2015-03-25 06:32:42 +00:00
// Don't call this before the info is available.
2015-07-21 12:54:02 +00:00
func (t *torrent) bytesCompleted() int64 {
2015-03-25 06:32:42 +00:00
if !t.haveInfo() {
return 0
}
return t.Info.TotalLength() - t.bytesLeft()
}
// 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
}
2015-01-27 14:12:36 +00:00
// Returns handles to the files in the torrent. This requires the metainfo is
// available first.
func (t Torrent) Files() (ret []File) {
t.cl.mu.Lock()
2015-04-28 05:24:17 +00:00
info := t.Info()
t.cl.mu.Unlock()
if info == nil {
return
}
2015-01-27 14:12:36 +00:00
var offset int64
for _, fi := range info.UpvertedFiles() {
2015-01-27 14:12:36 +00:00
ret = append(ret, File{
t,
strings.Join(append([]string{info.Name}, fi.Path...), "/"),
2015-01-27 14:12:36 +00:00
offset,
fi.Length,
2015-02-09 13:18:59 +00:00
fi,
2015-01-27 14:12:36 +00:00
})
offset += fi.Length
}
return
}
func (t Torrent) AddPeers(pp []Peer) error {
2015-03-08 06:28:14 +00:00
cl := t.cl
cl.mu.Lock()
defer cl.mu.Unlock()
cl.addPeers(t.torrent, pp)
return nil
}
2015-04-28 05:24:17 +00:00
// Marks the entire torrent for download. Requires the info first, see
// GotInfo.
func (t Torrent) DownloadAll() {
t.cl.mu.Lock()
2015-03-19 23:52:01 +00:00
defer t.cl.mu.Unlock()
t.torrent.pendPieceRange(0, t.torrent.numPieces())
}
// Returns nil metainfo if it isn't in the cache. Checks that the retrieved
// metainfo has the correct infohash.
func (cl *Client) torrentCacheMetaInfo(ih InfoHash) (mi *metainfo.MetaInfo, err error) {
if cl.config.DisableMetainfoCache {
return
}
f, err := os.Open(cl.cachedMetaInfoFilename(ih))
if err != nil {
if os.IsNotExist(err) {
err = nil
}
return
}
defer f.Close()
dec := bencode.NewDecoder(f)
err = dec.Decode(&mi)
if err != nil {
return
}
if !bytes.Equal(mi.Info.Hash, ih[:]) {
err = fmt.Errorf("cached torrent has wrong infohash: %x != %x", mi.Info.Hash, ih[:])
return
}
return
}
2015-03-20 12:52:53 +00:00
// Specifies a new torrent for adding to a client. There are helpers for
// magnet URIs and torrent metainfo files.
type TorrentSpec struct {
// The tiered tracker URIs.
Trackers [][]string
InfoHash InfoHash
Info *metainfo.InfoEx
// The name to use if the Name field from the Info isn't available.
DisplayName string
// The chunk size to use for outbound requests. Defaults to 16KiB if not
// set.
ChunkSize int
}
func TorrentSpecFromMagnetURI(uri string) (spec *TorrentSpec, err error) {
m, err := ParseMagnetURI(uri)
2013-09-26 09:49:15 +00:00
if err != nil {
return
2013-09-26 09:49:15 +00:00
}
spec = &TorrentSpec{
Trackers: [][]string{m.Trackers},
DisplayName: m.DisplayName,
2015-04-01 03:34:57 +00:00
InfoHash: m.InfoHash,
}
return
}
func TorrentSpecFromMetaInfo(mi *metainfo.MetaInfo) (spec *TorrentSpec) {
spec = &TorrentSpec{
Trackers: mi.AnnounceList,
Info: &mi.Info,
DisplayName: mi.Info.Name,
}
2015-10-10 12:31:02 +00:00
if len(spec.Trackers) == 0 {
spec.Trackers = [][]string{[]string{mi.Announce}}
} else {
spec.Trackers[0] = append(spec.Trackers[0], mi.Announce)
}
CopyExact(&spec.InfoHash, &mi.Info.Hash)
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.
func (cl *Client) AddTorrentSpec(spec *TorrentSpec) (T Torrent, new bool, err error) {
T.cl = cl
cl.mu.Lock()
defer cl.mu.Unlock()
t, ok := cl.torrents[spec.InfoHash]
if !ok {
new = true
if _, ok := cl.bannedTorrents[spec.InfoHash]; ok {
err = errors.New("banned torrent")
return
}
// TODO: Tidy this up?
t = newTorrent(spec.InfoHash)
t.cl = cl
t.wantPeers.L = &cl.mu
if spec.ChunkSize != 0 {
t.chunkSize = pp.Integer(spec.ChunkSize)
}
}
if spec.DisplayName != "" {
2015-12-12 03:03:04 +00:00
t.setDisplayName(spec.DisplayName)
}
// Try to merge in info we have on the torrent. Any err left will
// terminate the function.
if t.Info == nil {
if spec.Info != nil {
err = cl.setMetaData(t, &spec.Info.Info, spec.Info.Bytes)
} else {
var mi *metainfo.MetaInfo
mi, err = cl.torrentCacheMetaInfo(spec.InfoHash)
if err != nil {
log.Printf("error getting cached metainfo: %s", err)
err = nil
} else if mi != nil {
t.addTrackers(mi.AnnounceList)
err = cl.setMetaData(t, &mi.Info.Info, mi.Info.Bytes)
}
}
}
if err != nil {
return
}
t.addTrackers(spec.Trackers)
cl.torrents[spec.InfoHash] = t
T.torrent = t
// From this point onwards, we can consider the torrent a part of the
// client.
if new {
if !cl.config.DisableTrackers {
go cl.announceTorrentTrackers(T.torrent)
}
if cl.dHT != nil {
go cl.announceTorrentDHT(T.torrent, true)
}
}
return
}
func (me *Client) dropTorrent(infoHash InfoHash) (err error) {
t, ok := me.torrents[infoHash]
if !ok {
err = fmt.Errorf("no such torrent")
return
}
err = t.close()
if err != nil {
panic(err)
}
delete(me.torrents, infoHash)
return
}
// Returns true when peers are required, or false if the torrent is closing.
func (cl *Client) waitWantPeers(t *torrent) bool {
cl.mu.Lock()
defer cl.mu.Unlock()
2014-07-11 09:30:20 +00:00
for {
select {
case <-t.ceasingNetworking:
return false
default:
}
2015-05-14 22:39:53 +00:00
if len(t.Peers) > torrentPeersLowWater {
goto wait
}
if t.needData() || cl.seeding(t) {
return true
}
2015-05-14 22:39:53 +00:00
wait:
t.wantPeers.Wait()
}
}
2015-05-14 22:39:53 +00:00
// Returns whether the client should make effort to seed the torrent.
func (cl *Client) seeding(t *torrent) bool {
2015-06-16 06:57:47 +00:00
if cl.config.NoUpload {
return false
}
if !cl.config.Seed {
return false
}
if t.needData() {
return false
}
return true
2015-05-14 22:39:53 +00:00
}
func (cl *Client) announceTorrentDHT(t *torrent, impliedPort bool) {
for cl.waitWantPeers(t) {
2015-08-01 18:01:41 +00:00
// log.Printf("getting peers for %q from DHT", t)
ps, err := cl.dHT.Announce(string(t.InfoHash[:]), cl.incomingPeerPort(), impliedPort)
2014-07-11 09:30:20 +00:00
if err != nil {
log.Printf("error getting peers from dht: %s", err)
return
}
2015-08-01 17:53:37 +00:00
// Count all the unique addresses we got during this announce.
2014-12-08 22:57:42 +00:00
allAddrs := make(map[string]struct{})
2014-07-11 09:30:20 +00:00
getPeers:
for {
select {
case v, ok := <-ps.Peers:
2014-07-11 09:30:20 +00:00
if !ok {
break getPeers
}
addPeers := make([]Peer, 0, len(v.Peers))
for _, cp := range v.Peers {
if cp.Port == 0 {
// Can't do anything with this.
continue
}
addPeers = append(addPeers, Peer{
IP: cp.IP[:],
Port: int(cp.Port),
Source: peerSourceDHT,
})
key := (&net.UDPAddr{
IP: cp.IP[:],
Port: int(cp.Port),
}).String()
allAddrs[key] = struct{}{}
2014-12-08 22:57:42 +00:00
}
cl.mu.Lock()
cl.addPeers(t, addPeers)
numPeers := len(t.Peers)
cl.mu.Unlock()
if numPeers >= torrentPeersHighWater {
2014-07-11 09:30:20 +00:00
break getPeers
}
case <-t.ceasingNetworking:
ps.Close()
return
2014-07-11 09:30:20 +00:00
}
}
ps.Close()
2015-08-01 18:01:41 +00:00
// log.Printf("finished DHT peer scrape for %s: %d peers", t, len(allAddrs))
2014-07-11 09:30:20 +00:00
}
}
2016-02-07 07:49:35 +00:00
func (cl *Client) trackerBlockedUnlocked(trRawURL string) (blocked bool, err error) {
url_, err := url.Parse(trRawURL)
2015-03-10 15:41:41 +00:00
if err != nil {
return
}
host, _, err := net.SplitHostPort(url_.Host)
if err != nil {
host = url_.Host
}
addr, err := net.ResolveIPAddr("ip", host)
if err != nil {
return
}
cl.mu.RLock()
_, blocked = cl.ipBlockRange(addr.IP)
cl.mu.RUnlock()
2015-03-10 15:41:41 +00:00
return
}
2016-02-07 07:49:35 +00:00
func (cl *Client) announceTorrentSingleTracker(tr string, req *tracker.AnnounceRequest, t *torrent) error {
2015-03-10 15:41:41 +00:00
blocked, err := cl.trackerBlockedUnlocked(tr)
if err != nil {
return fmt.Errorf("error determining if tracker blocked: %s", err)
}
if blocked {
return fmt.Errorf("tracker blocked: %s", tr)
}
2016-02-07 07:49:35 +00:00
resp, err := tracker.Announce(tr, req)
2014-12-01 09:33:52 +00:00
if err != nil {
return fmt.Errorf("error announcing: %s", err)
}
var peers []Peer
for _, peer := range resp.Peers {
peers = append(peers, Peer{
IP: peer.IP,
Port: peer.Port,
})
}
2015-03-08 06:28:14 +00:00
cl.mu.Lock()
cl.addPeers(t, peers)
cl.mu.Unlock()
2015-03-12 09:04:44 +00:00
2015-08-01 18:01:41 +00:00
// log.Printf("%s: %d new peers from %s", t, len(peers), tr)
2014-12-01 09:33:52 +00:00
time.Sleep(time.Second * time.Duration(resp.Interval))
return nil
}
2016-02-07 07:49:35 +00:00
func (cl *Client) announceTorrentTrackersFastStart(req *tracker.AnnounceRequest, trackers []trackerTier, t *torrent) (atLeastOne bool) {
2014-12-01 09:33:52 +00:00
oks := make(chan bool)
outstanding := 0
for _, tier := range trackers {
for _, tr := range tier {
outstanding++
2016-02-07 07:49:35 +00:00
go func(tr string) {
2014-12-01 09:33:52 +00:00
err := cl.announceTorrentSingleTracker(tr, req, t)
oks <- err == nil
}(tr)
}
}
for outstanding > 0 {
ok := <-oks
outstanding--
if ok {
atLeastOne = true
}
}
return
}
2014-11-30 02:33:45 +00:00
// Announce torrent to its trackers.
func (cl *Client) announceTorrentTrackers(t *torrent) {
2014-03-16 15:30:10 +00:00
req := tracker.AnnounceRequest{
Event: tracker.Started,
NumWant: -1,
Port: uint16(cl.incomingPeerPort()),
2014-08-21 08:07:06 +00:00
PeerId: cl.peerID,
InfoHash: t.InfoHash,
2014-03-16 15:30:10 +00:00
}
2015-02-21 04:02:06 +00:00
if !cl.waitWantPeers(t) {
return
}
2014-12-01 09:33:52 +00:00
cl.mu.RLock()
req.Left = uint64(t.bytesLeft())
2014-12-01 09:33:52 +00:00
trackers := t.Trackers
cl.mu.RUnlock()
if cl.announceTorrentTrackersFastStart(&req, trackers, t) {
req.Event = tracker.None
}
2014-03-16 15:30:10 +00:00
newAnnounce:
for cl.waitWantPeers(t) {
2014-11-30 02:33:45 +00:00
cl.mu.RLock()
req.Left = uint64(t.bytesLeft())
2014-12-01 09:33:52 +00:00
trackers = t.Trackers
2014-11-30 02:33:45 +00:00
cl.mu.RUnlock()
2014-12-26 06:17:49 +00:00
numTrackersTried := 0
for _, tier := range trackers {
2014-03-16 15:30:10 +00:00
for trIndex, tr := range tier {
2014-12-26 06:17:49 +00:00
numTrackersTried++
2014-12-01 09:33:52 +00:00
err := cl.announceTorrentSingleTracker(tr, &req, t)
if err != nil {
continue
2014-03-16 15:30:10 +00:00
}
2014-12-01 09:33:52 +00:00
// Float the successful announce to the top of the tier. If
// the trackers list has been changed, we'll be modifying an
// old copy so it won't matter.
2014-11-30 02:33:45 +00:00
cl.mu.Lock()
2014-03-16 15:30:10 +00:00
tier[0], tier[trIndex] = tier[trIndex], tier[0]
2014-11-30 02:33:45 +00:00
cl.mu.Unlock()
req.Event = tracker.None
2014-03-16 15:30:10 +00:00
continue newAnnounce
}
}
2014-12-26 06:17:49 +00:00
if numTrackersTried != 0 {
log.Printf("%s: all trackers failed", t)
}
// TODO: Wait until trackers are added if there are none.
time.Sleep(10 * time.Second)
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 (me *Client) WaitAll() bool {
me.mu.Lock()
defer me.mu.Unlock()
2014-03-16 15:30:10 +00:00
for !me.allTorrentsCompleted() {
if me.closed.IsSet() {
return false
}
me.event.Wait()
}
return true
2013-09-26 09:49:15 +00:00
}
2014-08-27 23:32:49 +00:00
// Handle a received chunk from a peer.
func (me *Client) downloadedChunk(t *torrent, c *connection, msg *pp.Message) {
2015-06-22 09:48:30 +00:00
chunksReceived.Add(1)
req := newRequest(msg.Index, msg.Begin, pp.Integer(len(msg.Piece)))
// Request has been satisfied.
2015-06-22 09:48:30 +00:00
if me.connDeleteRequest(t, c, req) {
defer c.updateRequests()
2015-06-22 09:48:30 +00:00
} else {
unexpectedChunksReceived.Add(1)
}
index := int(req.Index)
piece := &t.Pieces[index]
2015-03-10 15:39:01 +00:00
// Do we actually want this chunk?
if !t.wantChunk(req) {
2015-06-22 09:48:30 +00:00
unwantedChunksReceived.Add(1)
c.UnwantedChunksReceived++
return
}
2014-08-27 23:32:49 +00:00
c.UsefulChunksReceived++
c.lastUsefulChunkReceived = time.Now()
2015-06-16 06:57:47 +00:00
me.upload(t, c)
// Need to record that it hasn't been written yet, before we attempt to do
// anything with it.
piece.incrementPendingWrites()
// Record that we have the chunk.
piece.unpendChunkIndex(chunkIndex(req.chunkSpec, t.chunkSize))
// Cancel pending requests for this chunk.
for _, c := range t.Conns {
if me.connCancel(t, c, req) {
c.updateRequests()
}
}
me.mu.Unlock()
// Write the chunk out.
err := t.writeChunk(int(msg.Index), int64(msg.Begin), msg.Piece)
me.mu.Lock()
piece.decrementPendingWrites()
if err != nil {
log.Printf("error writing chunk: %s", err)
t.pendRequest(req)
return
}
// It's important that the piece is potentially queued before we check if
// the piece is still wanted, because if it is queued, it won't be wanted.
if t.pieceAllDirty(index) {
me.queuePieceCheck(t, int(req.Index))
}
if c.peerTouchedPieces == nil {
c.peerTouchedPieces = make(map[int]struct{})
}
c.peerTouchedPieces[index] = struct{}{}
me.event.Broadcast()
t.publishPieceChange(int(req.Index))
return
}
// Return the connections that touched a piece, and clear the entry while
// doing it.
func (me *Client) reapPieceTouches(t *torrent, piece int) (ret []*connection) {
for _, c := range t.Conns {
if _, ok := c.peerTouchedPieces[piece]; ok {
ret = append(ret, c)
delete(c.peerTouchedPieces, piece)
}
}
return
}
func (me *Client) pieceHashed(t *torrent, piece int, correct bool) {
p := &t.Pieces[piece]
2015-06-28 06:41:51 +00:00
if p.EverHashed {
// Don't score the first time a piece is hashed, it could be an
// initial check.
2015-06-28 06:41:51 +00:00
if correct {
pieceHashedCorrect.Add(1)
} else {
log.Printf("%s: piece %d failed hash", t, piece)
pieceHashedNotCorrect.Add(1)
}
2014-09-13 17:57:51 +00:00
}
p.EverHashed = true
touchers := me.reapPieceTouches(t, int(piece))
2015-02-27 01:45:55 +00:00
if correct {
2015-06-02 14:03:43 +00:00
err := t.data.PieceCompleted(int(piece))
if err != nil {
log.Printf("%T: error completing piece %d: %s", t.data, piece, err)
2015-02-27 01:45:55 +00:00
}
t.updatePieceCompletion(piece)
} else if len(touchers) != 0 {
log.Printf("dropping %d conns that touched piece", len(touchers))
for _, c := range touchers {
me.dropConnection(t, c)
}
2015-02-27 01:45:55 +00:00
}
2015-03-10 15:41:21 +00:00
me.pieceChanged(t, int(piece))
}
func (me *Client) onCompletedPiece(t *torrent, piece int) {
2016-01-31 14:46:28 +00:00
t.pendingPieces.Remove(piece)
t.pendAllChunkSpecs(piece)
for _, conn := range t.Conns {
conn.Have(piece)
for r := range conn.Requests {
if int(r.Index) == piece {
conn.Cancel(r)
}
}
// Could check here if peer doesn't have piece, but due to caching
// some peers may have said they have a piece but they don't.
me.upload(t, conn)
}
}
func (me *Client) onFailedPiece(t *torrent, piece int) {
if t.pieceAllDirty(piece) {
t.pendAllChunkSpecs(piece)
}
if !t.wantPiece(piece) {
return
}
me.openNewConns(t)
for _, conn := range t.Conns {
if conn.PeerHasPiece(piece) {
conn.updateRequests()
2013-09-26 09:49:15 +00:00
}
}
}
func (me *Client) pieceChanged(t *torrent, piece int) {
correct := t.pieceComplete(piece)
defer me.event.Broadcast()
if correct {
me.onCompletedPiece(t, piece)
} else {
me.onFailedPiece(t, piece)
}
if t.updatePiecePriority(piece) {
t.piecePriorityChanged(piece)
}
t.publishPieceChange(piece)
}
func (cl *Client) verifyPiece(t *torrent, piece int) {
cl.mu.Lock()
defer cl.mu.Unlock()
p := &t.Pieces[piece]
for p.Hashing || t.data == nil {
cl.event.Wait()
}
2015-02-27 01:45:55 +00:00
p.QueuedForHash = false
if t.isClosed() || t.pieceComplete(piece) {
t.updatePiecePriority(piece)
t.publishPieceChange(piece)
return
}
p.Hashing = true
2016-02-06 14:21:12 +00:00
t.publishPieceChange(piece)
cl.mu.Unlock()
sum := t.hashPiece(piece)
cl.mu.Lock()
select {
case <-t.closing:
return
default:
}
p.Hashing = false
cl.pieceHashed(t, piece, sum == p.Hash)
2013-09-26 09:49:15 +00:00
}
2013-10-06 07:01:39 +00:00
2015-03-08 06:28:14 +00:00
// Returns handles to all the torrents loaded in the Client.
2016-01-05 08:42:26 +00:00
func (me *Client) Torrents() (ret []Torrent) {
me.mu.Lock()
for _, t := range me.torrents {
ret = append(ret, Torrent{me, t})
}
me.mu.Unlock()
2013-10-06 07:01:39 +00:00
return
}
2016-01-05 08:42:26 +00:00
func (me *Client) AddMagnet(uri string) (T Torrent, err error) {
spec, err := TorrentSpecFromMagnetURI(uri)
if err != nil {
return
}
T, _, err = me.AddTorrentSpec(spec)
return
}
2016-01-05 08:42:26 +00:00
func (me *Client) AddTorrent(mi *metainfo.MetaInfo) (T Torrent, err error) {
T, _, err = me.AddTorrentSpec(TorrentSpecFromMetaInfo(mi))
var ss []string
missinggo.CastSlice(&ss, mi.Nodes)
me.AddDHTNodes(ss)
return
}
2016-01-05 08:42:26 +00:00
func (me *Client) AddTorrentFromFile(filename string) (T Torrent, err error) {
mi, err := metainfo.LoadFromFile(filename)
if err != nil {
return
}
return me.AddTorrent(mi)
}
func (me *Client) DHT() *dht.Server {
return me.dHT
}
func (me *Client) AddDHTNodes(nodes []string) {
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 := dht.NodeInfo{
Addr: dht.NewAddr(&net.UDPAddr{
IP: ip,
Port: hmp.Port,
}),
}
me.DHT().AddNode(ni)
}
}