torrent/dht/dht.go

1217 lines
26 KiB
Go
Raw Normal View History

// Package DHT implements a DHT for use with the BitTorrent protocol,
// described in BEP 5: http://www.bittorrent.org/beps/bep_0005.html.
//
// Standard use involves creating a NewServer, and calling Announce on it with
// the details of your local torrent client and infohash of interest.
2014-05-24 06:51:56 +00:00
package dht
import (
"crypto"
_ "crypto/sha1"
2014-05-24 06:51:56 +00:00
"encoding/binary"
2014-05-25 11:34:29 +00:00
"errors"
2014-05-24 06:51:56 +00:00
"fmt"
"hash/crc32"
2014-05-24 06:51:56 +00:00
"io"
"log"
"math/big"
"math/rand"
2014-05-24 06:51:56 +00:00
"net"
"os"
2014-05-24 06:51:56 +00:00
"time"
2014-12-28 01:51:09 +00:00
2015-08-03 14:29:01 +00:00
"github.com/anacrolix/missinggo"
"github.com/anacrolix/sync"
2015-04-29 14:31:34 +00:00
"github.com/anacrolix/torrent/bencode"
"github.com/anacrolix/torrent/iplist"
"github.com/anacrolix/torrent/logonce"
"github.com/anacrolix/torrent/util"
2014-05-24 06:51:56 +00:00
)
const (
maxNodes = 320
queryResendEvery = 5 * time.Second
)
// Uniquely identifies a transaction to us.
type transactionKey struct {
RemoteAddr string // host:port
T string // The KRPC transaction ID.
}
2014-05-24 06:51:56 +00:00
type Server struct {
2014-08-21 08:07:06 +00:00
id string
socket net.PacketConn
transactions map[transactionKey]*Transaction
2014-05-24 06:51:56 +00:00
transactionIDInt uint64
nodes map[string]*node // Keyed by dHTAddr.String().
2014-05-27 06:28:56 +00:00
mu sync.Mutex
closed chan struct{}
passive bool // Don't respond to queries.
ipBlockList *iplist.IPList
2014-11-16 19:08:33 +00:00
numConfirmedAnnounces int
bootstrapNodes []string
config ServerConfig
}
2014-08-21 08:07:06 +00:00
type ServerConfig struct {
Addr string // Listen address. Used if Conn is nil.
Conn net.PacketConn
// Don't respond to queries from other nodes.
Passive bool
// DHT Bootstrap nodes
BootstrapNodes []string
// Disable the DHT security extension:
// http://www.libtorrent.org/dht_sec.html.
NoSecurity bool
// Initial IP blocklist to use. Applied before serving and bootstrapping
// begins.
IPBlocklist *iplist.IPList
}
type ServerStats struct {
// Count of nodes in the node table that responded to our last query or
// haven't yet been queried.
GoodNodes int
// Count of nodes in the node table.
Nodes int
// Transactions awaiting a response.
OutstandingTransactions int
// Individual announce_peer requests that got a success response.
ConfirmedAnnounces int
}
// Returns statistics for the server.
func (s *Server) Stats() (ss ServerStats) {
2014-12-07 03:19:02 +00:00
s.mu.Lock()
defer s.mu.Unlock()
for _, n := range s.nodes {
if n.DefinitelyGood() {
ss.GoodNodes++
2014-12-07 03:19:02 +00:00
}
}
ss.Nodes = len(s.nodes)
ss.OutstandingTransactions = len(s.transactions)
ss.ConfirmedAnnounces = s.numConfirmedAnnounces
2014-12-07 03:19:02 +00:00
return
}
// Returns the listen address for the server. Packets arriving to this address
// are processed by the server (unless aliens are involved).
func (s *Server) Addr() net.Addr {
2014-08-21 08:07:06 +00:00
return s.socket.LocalAddr()
}
func makeSocket(addr string) (socket *net.UDPConn, err error) {
addr_, err := net.ResolveUDPAddr("", addr)
if err != nil {
return
}
socket, err = net.ListenUDP("udp", addr_)
return
}
// Create a new DHT server.
2014-08-21 08:07:06 +00:00
func NewServer(c *ServerConfig) (s *Server, err error) {
if c == nil {
c = &ServerConfig{}
}
s = &Server{
config: *c,
ipBlockList: c.IPBlocklist,
}
if c.Conn != nil {
s.socket = c.Conn
} else {
s.socket, err = makeSocket(c.Addr)
if err != nil {
return
}
2014-08-21 08:07:06 +00:00
}
s.passive = c.Passive
s.bootstrapNodes = c.BootstrapNodes
2014-08-21 08:07:06 +00:00
err = s.init()
if err != nil {
return
}
go func() {
err := s.serve()
select {
case <-s.closed:
return
default:
}
if err != nil {
panic(err)
}
2014-08-21 08:07:06 +00:00
}()
go func() {
err := s.bootstrap()
if err != nil {
select {
case <-s.closed:
default:
log.Printf("error bootstrapping DHT: %s", err)
}
2014-08-21 08:07:06 +00:00
}
}()
return
}
// Returns a description of the Server. Python repr-style.
func (s *Server) String() string {
2014-08-21 08:07:06 +00:00
return fmt.Sprintf("dht server on %s", s.socket.LocalAddr())
2014-05-24 06:51:56 +00:00
}
type nodeID struct {
i big.Int
set bool
}
func (nid *nodeID) IsUnset() bool {
return !nid.set
}
func nodeIDFromString(s string) (ret nodeID) {
if s == "" {
return
}
ret.i.SetBytes([]byte(s))
ret.set = true
return
}
func (nid0 *nodeID) Distance(nid1 *nodeID) (ret big.Int) {
if nid0.IsUnset() != nid1.IsUnset() {
ret = maxDistance
return
}
ret.Xor(&nid0.i, &nid1.i)
return
}
func (nid *nodeID) ByteString() string {
var buf [20]byte
b := nid.i.Bytes()
copy(buf[20-len(b):], b)
return string(buf[:])
}
type node struct {
addr dHTAddr
id nodeID
2014-11-16 19:08:33 +00:00
announceToken string
lastGotQuery time.Time
lastGotResponse time.Time
lastSentQuery time.Time
2014-05-24 06:51:56 +00:00
}
func (n *node) IsSecure() bool {
if n.id.IsUnset() {
return false
}
return nodeIdSecure(n.id.ByteString(), n.addr.IP())
}
func (n *node) idString() string {
return n.id.ByteString()
}
func (n *node) SetIDFromBytes(b []byte) {
if len(b) != 20 {
panic(b)
}
n.id.i.SetBytes(b)
n.id.set = true
}
func (n *node) SetIDFromString(s string) {
n.SetIDFromBytes([]byte(s))
}
func (n *node) IDNotSet() bool {
return n.id.i.Int64() == 0
}
func (n *node) NodeInfo() (ret NodeInfo) {
ret.Addr = n.addr
if n := copy(ret.ID[:], n.idString()); n != 20 {
panic(n)
}
return
}
func (n *node) DefinitelyGood() bool {
if len(n.idString()) != 20 {
2014-05-27 06:28:56 +00:00
return false
}
// No reason to think ill of them if they've never been queried.
if n.lastSentQuery.IsZero() {
2014-11-18 00:02:16 +00:00
return true
}
// They answered our last query.
if n.lastSentQuery.Before(n.lastGotResponse) {
2014-11-18 00:02:16 +00:00
return true
}
2014-05-27 06:28:56 +00:00
return true
}
// A wrapper around the unmarshalled KRPC dict that constitutes messages in
// the DHT. There are various helpers for extracting common data from the
// message. In normal use, Msg is abstracted away for you, but it can be of
// interest.
2014-05-24 06:51:56 +00:00
type Msg map[string]interface{}
var _ fmt.Stringer = Msg{}
func (m Msg) String() string {
return fmt.Sprintf("%#v", m)
}
func (m Msg) T() (t string) {
tif, ok := m["t"]
if !ok {
return
}
t, _ = tif.(string)
return
}
func (m Msg) ID() string {
defer func() {
recover()
}()
return m[m["y"].(string)].(map[string]interface{})["id"].(string)
}
// Suggested nodes in a response.
func (m Msg) Nodes() (nodes []NodeInfo) {
b := func() string {
defer func() {
recover()
}()
return m["r"].(map[string]interface{})["nodes"].(string)
}()
if len(b)%26 != 0 {
return
}
for i := 0; i < len(b); i += 26 {
var n NodeInfo
err := n.UnmarshalCompact([]byte(b[i : i+26]))
if err != nil {
continue
}
nodes = append(nodes, n)
}
return
}
2014-11-16 19:08:33 +00:00
type KRPCError struct {
Code int
Msg string
}
func (me KRPCError) Error() string {
return fmt.Sprintf("KRPC error %d: %s", me.Code, me.Msg)
}
var _ error = KRPCError{}
func (m Msg) Error() (ret *KRPCError) {
2014-11-16 19:08:33 +00:00
if m["y"] != "e" {
return
2014-11-16 19:08:33 +00:00
}
ret = &KRPCError{}
switch e := m["e"].(type) {
case []interface{}:
ret.Code = int(e[0].(int64))
ret.Msg = e[1].(string)
case string:
ret.Msg = e
default:
logonce.Stderr.Printf(`KRPC error "e" value has unexpected type: %T`, e)
}
return
2014-11-16 19:08:33 +00:00
}
// Returns the token given in response to a get_peers request for future
// announce_peer requests to that node.
func (m Msg) AnnounceToken() (token string, ok bool) {
2014-11-16 19:08:33 +00:00
defer func() { recover() }()
token, ok = m["r"].(map[string]interface{})["token"].(string)
return
2014-11-16 19:08:33 +00:00
}
type Transaction struct {
mu sync.Mutex
remoteAddr dHTAddr
t string
response chan Msg
onResponse func(Msg) // Called with the server locked.
done chan struct{}
queryPacket []byte
timer *time.Timer
s *Server
retries int
lastSend time.Time
userOnResponse func(Msg)
}
// Set a function to be called with the response.
func (t *Transaction) SetResponseHandler(f func(Msg)) {
t.mu.Lock()
defer t.mu.Unlock()
t.userOnResponse = f
t.tryHandleResponse()
}
func (t *Transaction) tryHandleResponse() {
if t.userOnResponse == nil {
return
}
select {
case r := <-t.response:
t.userOnResponse(r)
// Shouldn't be called more than once.
t.userOnResponse = nil
default:
}
}
func (t *Transaction) key() transactionKey {
return transactionKey{
t.remoteAddr.String(),
t.t,
}
}
func jitterDuration(average time.Duration, plusMinus time.Duration) time.Duration {
return average - plusMinus/2 + time.Duration(rand.Int63n(int64(plusMinus)))
}
func (t *Transaction) startTimer() {
t.timer = time.AfterFunc(jitterDuration(queryResendEvery, time.Second), t.timerCallback)
}
func (t *Transaction) timerCallback() {
t.mu.Lock()
defer t.mu.Unlock()
select {
case <-t.done:
return
default:
}
if t.retries == 2 {
t.timeout()
return
}
t.retries++
t.sendQuery()
if t.timer.Reset(jitterDuration(queryResendEvery, time.Second)) {
panic("timer should have fired to get here")
}
}
func (t *Transaction) sendQuery() error {
err := t.s.writeToNode(t.queryPacket, t.remoteAddr)
if err != nil {
return err
}
t.lastSend = time.Now()
return nil
}
func (t *Transaction) timeout() {
go func() {
t.s.mu.Lock()
defer t.s.mu.Unlock()
t.s.nodeTimedOut(t.remoteAddr)
}()
t.close()
}
func (t *Transaction) close() {
if t.closing() {
return
}
t.queryPacket = nil
close(t.response)
t.tryHandleResponse()
close(t.done)
t.timer.Stop()
go func() {
t.s.mu.Lock()
defer t.s.mu.Unlock()
t.s.deleteTransaction(t)
}()
}
func (t *Transaction) closing() bool {
select {
case <-t.done:
return true
default:
return false
}
}
// Abandon the transaction.
func (t *Transaction) Close() {
t.mu.Lock()
defer t.mu.Unlock()
t.close()
}
func (t *Transaction) handleResponse(m Msg) {
t.mu.Lock()
if t.closing() {
t.mu.Unlock()
return
}
close(t.done)
t.mu.Unlock()
if t.onResponse != nil {
t.s.mu.Lock()
t.onResponse(m)
t.s.mu.Unlock()
}
t.queryPacket = nil
2014-08-25 12:14:10 +00:00
select {
case t.response <- m:
2014-08-25 12:14:10 +00:00
default:
panic("blocked handling response")
}
close(t.response)
t.tryHandleResponse()
2014-05-25 11:34:29 +00:00
}
func maskForIP(ip net.IP) []byte {
switch {
case ip.To4() != nil:
return []byte{0x03, 0x0f, 0x3f, 0xff}
default:
return []byte{0x01, 0x03, 0x07, 0x0f, 0x1f, 0x3f, 0x7f, 0xff}
}
}
// Generate the CRC used to make or validate secure node ID.
func crcIP(ip net.IP, rand uint8) uint32 {
if ip4 := ip.To4(); ip4 != nil {
ip = ip4
}
// Copy IP so we can make changes. Go sux at this.
ip = append(make(net.IP, 0, len(ip)), ip...)
mask := maskForIP(ip)
for i := range mask {
ip[i] &= mask[i]
}
r := rand & 7
ip[0] |= r << 5
return crc32.Checksum(ip[:len(mask)], crc32.MakeTable(crc32.Castagnoli))
}
// Makes a node ID valid, in-place.
func secureNodeId(id []byte, ip net.IP) {
crc := crcIP(ip, id[19])
id[0] = byte(crc >> 24 & 0xff)
id[1] = byte(crc >> 16 & 0xff)
id[2] = byte(crc>>8&0xf8) | id[2]&7
}
// http://www.libtorrent.org/dht_sec.html
func nodeIdSecure(id string, ip net.IP) bool {
if len(id) != 20 {
panic(fmt.Sprintf("%q", id))
}
if ip4 := ip.To4(); ip4 != nil {
ip = ip4
}
crc := crcIP(ip, id[19])
if id[0] != byte(crc>>24&0xff) {
return false
}
if id[1] != byte(crc>>16&0xff) {
return false
}
if id[2]&0xf8 != byte(crc>>8&0xf8) {
return false
}
return true
}
func (s *Server) setDefaults() (err error) {
2014-08-21 08:07:06 +00:00
if s.id == "" {
2014-05-24 06:51:56 +00:00
var id [20]byte
h := crypto.SHA1.New()
ss, err := os.Hostname()
2014-05-24 06:51:56 +00:00
if err != nil {
log.Print(err)
}
2014-08-21 08:07:06 +00:00
ss += s.socket.LocalAddr().String()
h.Write([]byte(ss))
if b := h.Sum(id[:0:20]); len(b) != 20 {
panic(len(b))
}
if len(id) != 20 {
panic(len(id))
2014-05-24 06:51:56 +00:00
}
secureNodeId(id[:], util.AddrIP(s.socket.LocalAddr()))
2014-08-21 08:07:06 +00:00
s.id = string(id[:])
2014-05-24 06:51:56 +00:00
}
s.nodes = make(map[string]*node, maxNodes)
return
2014-05-24 06:51:56 +00:00
}
// Packets to and from any address matching a range in the list are dropped.
func (s *Server) SetIPBlockList(list *iplist.IPList) {
s.mu.Lock()
defer s.mu.Unlock()
s.ipBlockList = list
}
2014-08-21 08:07:06 +00:00
func (s *Server) init() (err error) {
err = s.setDefaults()
if err != nil {
return
}
s.closed = make(chan struct{})
s.transactions = make(map[transactionKey]*Transaction)
return
2014-05-24 06:51:56 +00:00
}
func (s *Server) processPacket(b []byte, addr dHTAddr) {
var d Msg
err := bencode.Unmarshal(b, &d)
if err != nil {
2015-06-29 09:36:08 +00:00
readUnmarshalError.Add(1)
func() {
if se, ok := err.(*bencode.SyntaxError); ok {
// The message was truncated.
if int(se.Offset) == len(b) {
return
}
// Some messages seem to drop to nul chars abrubtly.
if int(se.Offset) < len(b) && b[se.Offset] == 0 {
return
}
// The message isn't bencode from the first.
if se.Offset == 0 {
return
}
}
2015-06-28 06:39:04 +00:00
log.Printf("%s: received bad krpc message from %s: %s: %+q", s, addr, err, b)
}()
return
}
s.mu.Lock()
defer s.mu.Unlock()
if d["y"] == "q" {
2015-06-29 09:36:08 +00:00
readQuery.Add(1)
s.handleQuery(addr, d)
return
}
t := s.findResponseTransaction(d.T(), addr)
if t == nil {
//log.Printf("unexpected message: %#v", d)
return
}
node := s.getNode(addr, d.ID())
node.lastGotResponse = time.Now()
// TODO: Update node ID as this is an authoritative packet.
go t.handleResponse(d)
s.deleteTransaction(t)
}
2014-08-21 08:07:06 +00:00
func (s *Server) serve() error {
var b [0x10000]byte
2014-05-24 06:51:56 +00:00
for {
n, addr, err := s.socket.ReadFrom(b[:])
2014-05-24 06:51:56 +00:00
if err != nil {
return err
}
2015-06-29 09:36:08 +00:00
read.Add(1)
if n == len(b) {
logonce.Stderr.Printf("received dht packet exceeds buffer size")
continue
}
2015-06-02 14:00:25 +00:00
s.mu.Lock()
2015-08-03 14:29:01 +00:00
blocked := s.ipBlocked(missinggo.AddrIP(addr))
2015-06-02 14:00:25 +00:00
s.mu.Unlock()
if blocked {
2015-06-29 09:36:08 +00:00
readBlocked.Add(1)
continue
}
2015-01-11 10:42:57 +00:00
s.processPacket(b[:n], newDHTAddr(addr))
2014-05-27 06:28:56 +00:00
}
}
func (s *Server) ipBlocked(ip net.IP) bool {
if s.ipBlockList == nil {
return false
}
return s.ipBlockList.Lookup(ip) != nil
}
// Adds directly to the node table.
2014-05-27 06:28:56 +00:00
func (s *Server) AddNode(ni NodeInfo) {
s.mu.Lock()
defer s.mu.Unlock()
2014-05-27 06:28:56 +00:00
if s.nodes == nil {
s.nodes = make(map[string]*node)
2014-05-27 06:28:56 +00:00
}
s.getNode(ni.Addr, string(ni.ID[:]))
2014-05-24 06:51:56 +00:00
}
func (s *Server) nodeByID(id string) *node {
for _, node := range s.nodes {
if node.idString() == id {
return node
}
}
return nil
}
func (s *Server) handleQuery(source dHTAddr, m Msg) {
args := m["a"].(map[string]interface{})
node := s.getNode(source, m.ID())
node.SetIDFromString(args["id"].(string))
node.lastGotQuery = time.Now()
// Don't respond.
if s.passive {
return
}
switch m["q"] {
case "ping":
s.reply(source, m["t"].(string), nil)
case "get_peers": // TODO: Extract common behaviour with find_node.
targetID := args["info_hash"].(string)
2014-12-19 23:10:53 +00:00
if len(targetID) != 20 {
break
}
var rNodes []NodeInfo
// TODO: Reply with "values" list if we have peers instead.
for _, node := range s.closestGoodNodes(8, targetID) {
rNodes = append(rNodes, node.NodeInfo())
}
nodesBytes := make([]byte, CompactNodeInfoLen*len(rNodes))
for i, ni := range rNodes {
err := ni.PutCompact(nodesBytes[i*CompactNodeInfoLen : (i+1)*CompactNodeInfoLen])
if err != nil {
panic(err)
}
}
s.reply(source, m["t"].(string), map[string]interface{}{
"nodes": string(nodesBytes),
"token": "hi",
})
case "find_node": // TODO: Extract common behaviour with get_peers.
targetID := args["target"].(string)
if len(targetID) != 20 {
log.Printf("bad DHT query: %v", m)
return
}
var rNodes []NodeInfo
if node := s.nodeByID(targetID); node != nil {
rNodes = append(rNodes, node.NodeInfo())
} else {
for _, node := range s.closestGoodNodes(8, targetID) {
rNodes = append(rNodes, node.NodeInfo())
}
}
nodesBytes := make([]byte, CompactNodeInfoLen*len(rNodes))
for i, ni := range rNodes {
// TODO: Put IPv6 nodes into the correct dict element.
if ni.Addr.UDPAddr().IP.To4() == nil {
continue
}
err := ni.PutCompact(nodesBytes[i*CompactNodeInfoLen : (i+1)*CompactNodeInfoLen])
if err != nil {
log.Printf("error compacting %#v: %s", ni, err)
continue
}
}
s.reply(source, m["t"].(string), map[string]interface{}{
"nodes": string(nodesBytes),
})
case "announce_peer":
2014-07-16 07:10:49 +00:00
// TODO(anacrolix): Implement this lolz.
// log.Print(m)
case "vote":
// TODO(anacrolix): Or reject, I don't think I want this.
default:
log.Printf("%s: not handling received query: q=%s", s, m["q"])
return
}
}
func (s *Server) reply(addr dHTAddr, t string, r map[string]interface{}) {
if r == nil {
r = make(map[string]interface{}, 1)
}
r["id"] = s.ID()
m := map[string]interface{}{
"t": t,
"y": "r",
"r": r,
}
b, err := bencode.Marshal(m)
if err != nil {
panic(err)
}
err = s.writeToNode(b, addr)
if err != nil {
log.Printf("error replying to %s: %s", addr, err)
}
}
// Returns a node struct for the addr. It is taken from the table or created
// and possibly added if required and meets validity constraints.
func (s *Server) getNode(addr dHTAddr, id string) (n *node) {
addrStr := addr.String()
n = s.nodes[addrStr]
if n != nil {
if id != "" {
n.SetIDFromString(id)
}
return
}
n = &node{
addr: addr,
2014-05-24 06:51:56 +00:00
}
2015-06-08 08:16:29 +00:00
if len(id) == 20 {
n.SetIDFromString(id)
}
if len(s.nodes) >= maxNodes {
return
}
if !s.config.NoSecurity && !n.IsSecure() {
return
}
s.nodes[addrStr] = n
2014-05-24 06:51:56 +00:00
return
}
func (s *Server) nodeTimedOut(addr dHTAddr) {
node, ok := s.nodes[addr.String()]
if !ok {
return
}
if node.DefinitelyGood() {
return
}
if len(s.nodes) < maxNodes {
return
}
delete(s.nodes, addr.String())
}
2014-05-24 06:51:56 +00:00
func (s *Server) writeToNode(b []byte, node dHTAddr) (err error) {
if list := s.ipBlockList; list != nil {
2015-08-03 14:29:01 +00:00
if r := list.Lookup(missinggo.AddrIP(node.UDPAddr())); r != nil {
err = fmt.Errorf("write to %s blocked: %s", node, r.Description)
return
}
}
n, err := s.socket.WriteTo(b, node.UDPAddr())
if err != nil {
err = fmt.Errorf("error writing %d bytes to %s: %#v", len(b), node, err)
return
}
if n != len(b) {
err = io.ErrShortWrite
return
}
return
}
func (s *Server) findResponseTransaction(transactionID string, sourceNode dHTAddr) *Transaction {
return s.transactions[transactionKey{
sourceNode.String(),
transactionID}]
2014-05-24 06:51:56 +00:00
}
func (s *Server) nextTransactionID() string {
var b [binary.MaxVarintLen64]byte
n := binary.PutUvarint(b[:], s.transactionIDInt)
s.transactionIDInt++
return string(b[:n])
}
func (s *Server) deleteTransaction(t *Transaction) {
delete(s.transactions, t.key())
2014-05-24 06:51:56 +00:00
}
func (s *Server) addTransaction(t *Transaction) {
if _, ok := s.transactions[t.key()]; ok {
panic("transaction not unique")
}
s.transactions[t.key()] = t
2014-05-24 06:51:56 +00:00
}
// Returns the 20-byte server ID. This is the ID used to communicate with the
// DHT network.
func (s *Server) ID() string {
2014-08-21 08:07:06 +00:00
if len(s.id) != 20 {
2014-05-24 06:51:56 +00:00
panic("bad node id")
}
2014-08-21 08:07:06 +00:00
return s.id
2014-05-24 06:51:56 +00:00
}
func (s *Server) query(node dHTAddr, q string, a map[string]interface{}, onResponse func(Msg)) (t *Transaction, err error) {
2014-05-24 06:51:56 +00:00
tid := s.nextTransactionID()
if a == nil {
2014-11-16 19:08:33 +00:00
a = make(map[string]interface{}, 1)
2014-05-24 06:51:56 +00:00
}
a["id"] = s.ID()
2014-05-24 06:51:56 +00:00
d := map[string]interface{}{
"t": tid,
"y": "q",
"q": q,
"a": a,
}
b, err := bencode.Marshal(d)
if err != nil {
return
}
t = &Transaction{
remoteAddr: node,
t: tid,
response: make(chan Msg, 1),
done: make(chan struct{}),
queryPacket: b,
s: s,
onResponse: onResponse,
}
err = t.sendQuery()
2014-05-24 06:51:56 +00:00
if err != nil {
return
2014-05-24 06:51:56 +00:00
}
s.getNode(node, "").lastSentQuery = time.Now()
t.startTimer()
s.addTransaction(t)
2014-05-24 06:51:56 +00:00
return
}
// The size in bytes of a NodeInfo in its compact binary representation.
2014-05-27 06:28:56 +00:00
const CompactNodeInfoLen = 26
2014-05-25 11:34:29 +00:00
2014-05-27 06:28:56 +00:00
type NodeInfo struct {
2014-05-25 11:34:29 +00:00
ID [20]byte
Addr dHTAddr
2014-05-25 11:34:29 +00:00
}
// Writes the node info to its compact binary representation in b. See
// CompactNodeInfoLen.
2014-05-27 06:28:56 +00:00
func (ni *NodeInfo) PutCompact(b []byte) error {
if n := copy(b[:], ni.ID[:]); n != 20 {
2014-05-25 11:34:29 +00:00
panic(n)
}
2015-08-03 14:29:01 +00:00
ip := missinggo.AddrIP(ni.Addr).To4()
2014-05-25 11:34:29 +00:00
if len(ip) != 4 {
return errors.New("expected ipv4 address")
2014-05-25 11:34:29 +00:00
}
if n := copy(b[20:], ip); n != 4 {
panic(n)
}
2015-08-03 14:29:01 +00:00
binary.BigEndian.PutUint16(b[24:], uint16(missinggo.AddrPort(ni.Addr)))
2014-05-27 06:28:56 +00:00
return nil
2014-05-25 11:34:29 +00:00
}
2014-05-24 06:51:56 +00:00
2014-05-27 06:28:56 +00:00
func (cni *NodeInfo) UnmarshalCompact(b []byte) error {
2014-05-25 11:34:29 +00:00
if len(b) != 26 {
return errors.New("expected 26 bytes")
}
2015-08-03 14:29:01 +00:00
missinggo.CopyExact(cni.ID[:], b[:20])
cni.Addr = newDHTAddr(&net.UDPAddr{
IP: net.IPv4(b[20], b[21], b[22], b[23]),
Port: int(binary.BigEndian.Uint16(b[24:26])),
})
2014-05-25 11:34:29 +00:00
return nil
2014-05-24 06:51:56 +00:00
}
// Sends a ping query to the address given.
func (s *Server) Ping(node *net.UDPAddr) (*Transaction, error) {
2014-08-25 12:14:31 +00:00
s.mu.Lock()
defer s.mu.Unlock()
return s.query(newDHTAddr(node), "ping", nil, nil)
2014-05-24 06:51:56 +00:00
}
2014-05-25 11:34:29 +00:00
func (s *Server) announcePeer(node dHTAddr, infoHash string, port int, token string, impliedPort bool) (err error) {
if port == 0 && !impliedPort {
return errors.New("nothing to announce")
}
_, err = s.query(node, "announce_peer", map[string]interface{}{
2014-11-16 19:08:33 +00:00
"implied_port": func() int {
if impliedPort {
return 1
} else {
return 0
}
}(),
"info_hash": infoHash,
"port": port,
"token": token,
}, func(m Msg) {
2014-11-16 19:08:33 +00:00
if err := m.Error(); err != nil {
logonce.Stderr.Printf("announce_peer response: %s", err)
return
}
s.numConfirmedAnnounces++
2014-11-16 19:08:33 +00:00
})
return
}
2015-01-29 03:17:27 +00:00
// Add response nodes to node table.
func (s *Server) liftNodes(d Msg) {
if d["y"] != "r" {
return
}
for _, cni := range d.Nodes() {
2015-08-03 14:29:01 +00:00
if missinggo.AddrPort(cni.Addr) == 0 {
// TODO: Why would people even do this?
continue
}
2015-08-03 14:29:01 +00:00
if s.ipBlocked(missinggo.AddrIP(cni.Addr)) {
continue
}
n := s.getNode(cni.Addr, string(cni.ID[:]))
n.SetIDFromBytes(cni.ID[:])
}
}
2014-06-24 13:20:07 +00:00
// Sends a find_node query to addr. targetID is the node we're looking for.
func (s *Server) findNode(addr dHTAddr, targetID string) (t *Transaction, err error) {
t, err = s.query(addr, "find_node", map[string]interface{}{"target": targetID}, func(d Msg) {
// Scrape peers from the response to put in the server's table before
// handing the response back to the caller.
s.liftNodes(d)
})
2014-05-25 11:34:29 +00:00
if err != nil {
return
}
return
}
// In a get_peers response, the addresses of torrent clients involved with the
// queried info-hash.
func (m Msg) Values() (vs []util.CompactPeer) {
r, ok := m["r"]
if !ok {
return
}
rd, ok := r.(map[string]interface{})
if !ok {
return
}
v, ok := rd["values"]
if !ok {
return
}
vl, ok := v.([]interface{})
if !ok {
2014-12-01 09:29:06 +00:00
log.Printf("unexpected krpc values type: %T", v)
return
}
2014-08-21 08:07:06 +00:00
vs = make([]util.CompactPeer, 0, len(vl))
for _, i := range vl {
s, ok := i.(string)
2014-05-25 11:34:29 +00:00
if !ok {
panic(i)
2014-05-25 11:34:29 +00:00
}
2014-08-21 08:07:06 +00:00
var cp util.CompactPeer
err := cp.UnmarshalBinary([]byte(s))
if err != nil {
log.Printf("error decoding values list element: %s", err)
continue
}
vs = append(vs, cp)
}
return
}
func (s *Server) getPeers(addr dHTAddr, infoHash string) (t *Transaction, err error) {
if len(infoHash) != 20 {
err = fmt.Errorf("infohash has bad length")
return
}
t, err = s.query(addr, "get_peers", map[string]interface{}{"info_hash": infoHash}, func(m Msg) {
s.liftNodes(m)
at, ok := m.AnnounceToken()
if ok {
s.getNode(addr, m.ID()).announceToken = at
}
})
return
}
func bootstrapAddrs(nodeAddrs []string) (addrs []*net.UDPAddr, err error) {
bootstrapNodes := nodeAddrs
if len(bootstrapNodes) == 0 {
bootstrapNodes = []string{
"router.utorrent.com:6881",
"router.bittorrent.com:6881",
}
}
for _, addrStr := range bootstrapNodes {
udpAddr, err := net.ResolveUDPAddr("udp4", addrStr)
if err != nil {
continue
}
addrs = append(addrs, udpAddr)
}
if len(addrs) == 0 {
err = errors.New("nothing resolved")
}
return
}
// Adds bootstrap nodes directly to table, if there's room. Node ID security
// is bypassed, but the IP blocklist is not.
func (s *Server) addRootNodes() error {
addrs, err := bootstrapAddrs(s.bootstrapNodes)
2014-05-27 06:28:56 +00:00
if err != nil {
return err
}
for _, addr := range addrs {
if len(s.nodes) >= maxNodes {
break
}
if s.nodes[addr.String()] != nil {
continue
}
if s.ipBlocked(addr.IP) {
log.Printf("dht root node is in the blocklist: %s", addr.IP)
continue
}
s.nodes[addr.String()] = &node{
addr: newDHTAddr(addr),
}
2014-05-27 06:28:56 +00:00
}
return nil
}
// Populates the node table.
2014-08-21 08:07:06 +00:00
func (s *Server) bootstrap() (err error) {
2014-05-27 06:28:56 +00:00
s.mu.Lock()
defer s.mu.Unlock()
2014-05-25 11:34:29 +00:00
if len(s.nodes) == 0 {
err = s.addRootNodes()
}
if err != nil {
return
2014-05-27 06:28:56 +00:00
}
for {
var outstanding sync.WaitGroup
for _, node := range s.nodes {
var t *Transaction
2014-08-21 08:07:06 +00:00
t, err = s.findNode(node.addr, s.id)
if err != nil {
2015-01-11 10:42:57 +00:00
err = fmt.Errorf("error sending find_node: %s", err)
return
}
outstanding.Add(1)
t.SetResponseHandler(func(Msg) {
outstanding.Done()
})
}
noOutstanding := make(chan struct{})
go func() {
outstanding.Wait()
close(noOutstanding)
}()
s.mu.Unlock()
select {
case <-s.closed:
s.mu.Lock()
return
case <-time.After(15 * time.Second):
case <-noOutstanding:
}
s.mu.Lock()
// log.Printf("now have %d nodes", len(s.nodes))
if s.numGoodNodes() >= 160 {
break
2014-05-25 11:34:29 +00:00
}
}
2014-05-27 06:28:56 +00:00
return
}
func (s *Server) numGoodNodes() (num int) {
for _, n := range s.nodes {
if n.DefinitelyGood() {
num++
}
}
return
}
// Returns how many nodes are in the node table.
func (s *Server) NumNodes() int {
s.mu.Lock()
defer s.mu.Unlock()
return len(s.nodes)
}
// Exports the current node table.
func (s *Server) Nodes() (nis []NodeInfo) {
2014-05-27 06:28:56 +00:00
s.mu.Lock()
defer s.mu.Unlock()
for _, node := range s.nodes {
// if !node.Good() {
// continue
// }
2014-05-27 06:28:56 +00:00
ni := NodeInfo{
Addr: node.addr,
}
if n := copy(ni.ID[:], node.idString()); n != 20 && n != 0 {
2014-05-27 06:28:56 +00:00
panic(n)
}
nis = append(nis, ni)
2014-05-25 11:34:29 +00:00
}
2014-05-27 06:28:56 +00:00
return
}
// Stops the server network activity. This is all that's required to clean-up a Server.
func (s *Server) Close() {
s.mu.Lock()
select {
case <-s.closed:
default:
close(s.closed)
s.socket.Close()
}
s.mu.Unlock()
2014-05-25 11:34:29 +00:00
}
var maxDistance big.Int
func init() {
var zero big.Int
maxDistance.SetBit(&zero, 160, 1)
}
func (s *Server) closestGoodNodes(k int, targetID string) []*node {
return s.closestNodes(k, nodeIDFromString(targetID), func(n *node) bool { return n.DefinitelyGood() })
2014-11-16 19:08:33 +00:00
}
func (s *Server) closestNodes(k int, target nodeID, filter func(*node) bool) []*node {
sel := newKClosestNodesSelector(k, target)
idNodes := make(map[string]*node, len(s.nodes))
for _, node := range s.nodes {
2014-11-16 19:08:33 +00:00
if !filter(node) {
continue
}
sel.Push(node.id)
idNodes[node.idString()] = node
}
ids := sel.IDs()
ret := make([]*node, 0, len(ids))
for _, id := range ids {
ret = append(ret, idNodes[id.ByteString()])
}
return ret
}