335 lines
9.6 KiB
Go
Raw Normal View History

2014-11-20 10:46:19 -08:00
// Package dht implements a distributed hash table that satisfies the ipfs routing
// interface. This DHT is modeled after kademlia with Coral and S/Kademlia modifications.
2014-07-23 04:48:30 -07:00
package dht
import (
2014-09-19 08:07:56 -07:00
"bytes"
2014-09-16 00:56:40 -07:00
"errors"
"fmt"
"sync"
"time"
key "github.com/ipfs/go-ipfs/blocks/key"
ci "github.com/ipfs/go-ipfs/p2p/crypto"
host "github.com/ipfs/go-ipfs/p2p/host"
peer "github.com/ipfs/go-ipfs/p2p/peer"
protocol "github.com/ipfs/go-ipfs/p2p/protocol"
routing "github.com/ipfs/go-ipfs/routing"
pb "github.com/ipfs/go-ipfs/routing/dht/pb"
kb "github.com/ipfs/go-ipfs/routing/kbucket"
record "github.com/ipfs/go-ipfs/routing/record"
u "github.com/ipfs/go-ipfs/util"
logging "github.com/ipfs/go-ipfs/vendor/go-log-v1.0.0"
proto "github.com/ipfs/go-ipfs/Godeps/_workspace/src/github.com/gogo/protobuf/proto"
ds "github.com/ipfs/go-ipfs/Godeps/_workspace/src/github.com/jbenet/go-datastore"
goprocess "github.com/ipfs/go-ipfs/Godeps/_workspace/src/github.com/jbenet/goprocess"
goprocessctx "github.com/ipfs/go-ipfs/Godeps/_workspace/src/github.com/jbenet/goprocess/context"
context "github.com/ipfs/go-ipfs/Godeps/_workspace/src/golang.org/x/net/context"
)
var log = logging.Logger("dht")
2015-01-01 12:45:39 -08:00
var ProtocolDHT protocol.ID = "/ipfs/dht"
2014-12-23 22:04:21 -08:00
// NumBootstrapQueries defines the number of random dht queries to do to
// collect members of the routing table.
const NumBootstrapQueries = 5
2014-07-23 04:48:30 -07:00
// TODO. SEE https://github.com/jbenet/node-ipfs/blob/master/submodules/ipfs-dht/index.js
// IpfsDHT is an implementation of Kademlia with Coral and S/Kademlia modifications.
// It is used to implement the base IpfsRouting module.
type IpfsDHT struct {
2015-01-01 12:45:39 -08:00
host host.Host // the network services we need
self peer.ID // Local peer (yourself)
peerstore peer.Peerstore // Peer Registry
datastore ds.ThreadSafeDatastore // Local data
2014-12-16 08:55:46 -08:00
routingTable *kb.RoutingTable // Array of routing tables for differently distanced nodes
providers *ProviderManager
2014-12-16 08:55:46 -08:00
birth time.Time // When this peer started up
diaglock sync.Mutex // lock to make diagnostics work better
Validator record.Validator // record validator funcs
ctx context.Context
proc goprocess.Process
}
2014-08-09 22:28:46 -07:00
// NewDHT creates a new DHT object with the given peer as the 'local' host
2015-01-01 12:45:39 -08:00
func NewDHT(ctx context.Context, h host.Host, dstore ds.ThreadSafeDatastore) *IpfsDHT {
dht := new(IpfsDHT)
2014-08-26 14:24:51 -07:00
dht.datastore = dstore
2015-01-01 12:45:39 -08:00
dht.self = h.ID()
dht.peerstore = h.Peerstore()
dht.host = h
2014-09-16 00:56:40 -07:00
// register for network notifs.
dht.host.Network().Notify((*netNotifiee)(dht))
dht.proc = goprocess.WithTeardown(func() error {
// remove ourselves from network notifs.
dht.host.Network().StopNotify((*netNotifiee)(dht))
return nil
})
dht.ctx = ctx
h.SetStreamHandler(ProtocolDHT, dht.handleNewStream)
dht.providers = NewProviderManager(dht.ctx, dht.self)
dht.proc.AddChild(dht.providers.proc)
goprocessctx.CloseAfterContext(dht.proc, ctx)
2015-01-01 12:45:39 -08:00
dht.routingTable = kb.NewRoutingTable(20, kb.ConvertPeerID(dht.self), time.Minute, dht.peerstore)
dht.birth = time.Now()
dht.Validator = make(record.Validator)
dht.Validator["pk"] = record.PublicKeyValidator
2014-08-10 21:40:17 -07:00
return dht
}
2014-12-18 12:23:09 -08:00
// LocalPeer returns the peer.Peer of the dht.
func (dht *IpfsDHT) LocalPeer() peer.ID {
return dht.self
}
2015-01-05 04:35:54 -08:00
// log returns the dht's logger
func (dht *IpfsDHT) log() logging.EventLogger {
2015-01-24 00:24:44 -08:00
return log // TODO rm
2015-01-05 04:35:54 -08:00
}
2014-12-28 23:46:25 +00:00
// putValueToPeer stores the given key/value pair at the peer 'p'
func (dht *IpfsDHT) putValueToPeer(ctx context.Context, p peer.ID,
key key.Key, rec *pb.Record) error {
2014-09-19 08:07:56 -07:00
pmes := pb.NewMessage(pb.Message_PUT_VALUE, string(key), 0)
pmes.Record = rec
2014-09-19 08:07:56 -07:00
rpmes, err := dht.sendRequest(ctx, p, pmes)
2014-09-17 07:19:40 -07:00
if err != nil {
return err
}
2014-09-19 08:07:56 -07:00
if !bytes.Equal(rpmes.GetRecord().Value, pmes.GetRecord().Value) {
2014-09-19 08:07:56 -07:00
return errors.New("value not put correctly")
}
return nil
2014-09-17 07:19:40 -07:00
}
2014-11-03 03:02:56 +00:00
// putProvider sends a message to peer 'p' saying that the local node
// can provide the value of 'key'
func (dht *IpfsDHT) putProvider(ctx context.Context, p peer.ID, skey string) error {
2014-09-17 07:19:40 -07:00
// add self as the provider
2015-02-02 08:21:45 -08:00
pi := peer.PeerInfo{
ID: dht.self,
Addrs: dht.host.Addrs(),
}
// // only share WAN-friendly addresses ??
// pi.Addrs = addrutil.WANShareableAddrs(pi.Addrs)
if len(pi.Addrs) < 1 {
// log.Infof("%s putProvider: %s for %s error: no wan-friendly addresses", dht.self, p, key.Key(key), pi.Addrs)
return fmt.Errorf("no known addresses for self. cannot put provider.")
}
pmes := pb.NewMessage(pb.Message_ADD_PROVIDER, skey, 0)
2015-02-02 08:21:45 -08:00
pmes.ProviderPeers = pb.RawPeerInfosToPBPeers([]peer.PeerInfo{pi})
err := dht.sendMessage(ctx, p, pmes)
2014-09-17 07:19:40 -07:00
if err != nil {
return err
}
2014-09-19 14:31:10 -07:00
log.Debugf("%s putProvider: %s for %s (%s)", dht.self, p, key.Key(skey), pi.Addrs)
2014-09-19 14:31:10 -07:00
return nil
2014-09-17 07:19:40 -07:00
}
// getValueOrPeers queries a particular peer p for the value for
// key. It returns either the value or a list of closer peers.
// NOTE: it will update the dht's peerstore with any new addresses
// it finds for the given peer.
func (dht *IpfsDHT) getValueOrPeers(ctx context.Context, p peer.ID,
key key.Key) ([]byte, []peer.PeerInfo, error) {
2014-09-16 02:43:11 -07:00
pmes, err := dht.getValueSingle(ctx, p, key)
if err != nil {
return nil, nil, err
}
if record := pmes.GetRecord(); record != nil {
// Success! We were given the value
2014-09-28 00:13:07 -07:00
log.Debug("getValueOrPeers: got value")
// make sure record is valid.
err = dht.verifyRecordOnline(ctx, record)
if err != nil {
2015-01-26 19:12:12 -08:00
log.Info("Received invalid record! (discarded)")
return nil, nil, err
}
return record.GetValue(), nil, nil
2014-08-16 23:03:36 -07:00
}
// Perhaps we were given closer peers
peers := pb.PBPeersToPeerInfos(pmes.GetCloserPeers())
if len(peers) > 0 {
log.Debug("getValueOrPeers: peers")
return nil, peers, nil
}
log.Warning("getValueOrPeers: routing.ErrNotFound")
return nil, nil, routing.ErrNotFound
}
// getValueSingle simply performs the get value RPC with the given parameters
func (dht *IpfsDHT) getValueSingle(ctx context.Context, p peer.ID,
key key.Key) (*pb.Message, error) {
2015-01-15 04:45:34 +00:00
defer log.EventBegin(ctx, "getValueSingle", p, &key).Done()
2014-09-16 02:43:11 -07:00
pmes := pb.NewMessage(pb.Message_GET_VALUE, string(key), 0)
2014-09-16 02:43:11 -07:00
return dht.sendRequest(ctx, p, pmes)
2014-08-09 22:28:46 -07:00
}
// getLocal attempts to retrieve the value from the datastore
func (dht *IpfsDHT) getLocal(key key.Key) ([]byte, error) {
2014-11-11 16:28:20 -08:00
log.Debug("getLocal %s", key)
2014-10-03 15:34:08 -07:00
v, err := dht.datastore.Get(key.DsKey())
if err != nil {
return nil, err
}
2014-11-11 16:28:20 -08:00
log.Debug("found in db")
byt, ok := v.([]byte)
if !ok {
return nil, errors.New("value stored in datastore not []byte")
}
rec := new(pb.Record)
err = proto.Unmarshal(byt, rec)
if err != nil {
return nil, err
}
// TODO: 'if paranoid'
if u.Debug {
err = dht.verifyRecordLocally(rec)
if err != nil {
2015-01-26 19:12:12 -08:00
log.Debugf("local record verify failed: %s (discarded)", err)
return nil, err
}
}
return rec.GetValue(), nil
}
2015-01-16 23:53:56 +00:00
// getOwnPrivateKey attempts to load the local peers private
// key from the peerstore.
func (dht *IpfsDHT) getOwnPrivateKey() (ci.PrivKey, error) {
sk := dht.peerstore.PrivKey(dht.self)
if sk == nil {
2015-01-26 19:12:12 -08:00
log.Warningf("%s dht cannot get own private key!", dht.self)
return nil, fmt.Errorf("cannot get private key to sign record!")
}
return sk, nil
}
// putLocal stores the key value pair in the datastore
func (dht *IpfsDHT) putLocal(key key.Key, rec *pb.Record) error {
data, err := proto.Marshal(rec)
if err != nil {
return err
}
return dht.datastore.Put(key.DsKey(), data)
}
// Update signals the routingTable to Update its last-seen status
2014-09-16 06:40:17 -07:00
// on the given peer.
func (dht *IpfsDHT) Update(ctx context.Context, p peer.ID) {
log.Event(ctx, "updatePeer", p)
dht.routingTable.Update(p)
}
2014-08-09 22:28:46 -07:00
2014-10-11 10:43:54 -07:00
// FindLocal looks for a peer with a given ID connected to this dht and returns the peer and the table it was found in.
2014-12-28 23:46:25 +00:00
func (dht *IpfsDHT) FindLocal(id peer.ID) peer.PeerInfo {
p := dht.routingTable.Find(id)
if p != "" {
2014-12-28 23:46:25 +00:00
return dht.peerstore.PeerInfo(p)
2014-08-09 22:28:46 -07:00
}
2014-12-28 23:46:25 +00:00
return peer.PeerInfo{}
2014-08-09 22:28:46 -07:00
}
2014-11-03 03:02:56 +00:00
// findPeerSingle asks peer 'p' if they know where the peer with id 'id' is
func (dht *IpfsDHT) findPeerSingle(ctx context.Context, p peer.ID, id peer.ID) (*pb.Message, error) {
2015-01-15 04:45:34 +00:00
defer log.EventBegin(ctx, "findPeerSingle", p, id).Done()
pmes := pb.NewMessage(pb.Message_FIND_NODE, string(id), 0)
2014-09-16 07:17:55 -07:00
return dht.sendRequest(ctx, p, pmes)
}
func (dht *IpfsDHT) findProvidersSingle(ctx context.Context, p peer.ID, key key.Key) (*pb.Message, error) {
2015-01-15 04:45:34 +00:00
defer log.EventBegin(ctx, "findProvidersSingle", p, &key).Done()
pmes := pb.NewMessage(pb.Message_GET_PROVIDERS, string(key), 0)
2014-09-16 07:17:55 -07:00
return dht.sendRequest(ctx, p, pmes)
2014-08-14 08:32:17 -07:00
}
// nearestPeersToQuery returns the routing tables closest peers.
func (dht *IpfsDHT) nearestPeersToQuery(pmes *pb.Message, count int) []peer.ID {
key := key.Key(pmes.GetKey())
closer := dht.routingTable.NearestPeers(kb.ConvertKey(key), count)
return closer
}
// betterPeerToQuery returns nearestPeersToQuery, but iff closer than self.
func (dht *IpfsDHT) betterPeersToQuery(pmes *pb.Message, p peer.ID, count int) []peer.ID {
closer := dht.nearestPeersToQuery(pmes, count)
// no node? nil
if closer == nil {
return nil
}
// == to self? thats bad
for _, p := range closer {
if p == dht.self {
2015-02-26 16:13:33 -08:00
log.Debug("Attempted to return self! this shouldnt happen...")
return nil
}
}
var filtered []peer.ID
for _, clp := range closer {
// Dont send a peer back themselves
if p == clp {
continue
}
// must all be closer than self
key := key.Key(pmes.GetKey())
if !kb.Closer(dht.self, clp, key) {
filtered = append(filtered, clp)
}
}
// ok seems like closer nodes
return filtered
}
// Context return dht's context
func (dht *IpfsDHT) Context() context.Context {
return dht.ctx
}
// Process return dht's process
func (dht *IpfsDHT) Process() goprocess.Process {
return dht.proc
}
// Close calls Process Close
func (dht *IpfsDHT) Close() error {
return dht.proc.Close()
}