bitswap.go 8.17 KB
Newer Older
Brian Tiger Chow's avatar
Brian Tiger Chow committed
1 2
// package bitswap implements the IPFS Exchange interface with the BitSwap
// bilateral exchange protocol.
Juan Batiz-Benet's avatar
Juan Batiz-Benet committed
3 4 5
package bitswap

import (
Jeromy's avatar
Jeromy committed
6 7
	"time"

8
	context "github.com/jbenet/go-ipfs/Godeps/_workspace/src/code.google.com/p/go.net/context"
9
	ds "github.com/jbenet/go-ipfs/Godeps/_workspace/src/github.com/jbenet/go-datastore"
Brian Tiger Chow's avatar
Brian Tiger Chow committed
10

Juan Batiz-Benet's avatar
Juan Batiz-Benet committed
11
	blocks "github.com/jbenet/go-ipfs/blocks"
12
	blockstore "github.com/jbenet/go-ipfs/blockstore"
13 14 15 16 17
	exchange "github.com/jbenet/go-ipfs/exchange"
	bsmsg "github.com/jbenet/go-ipfs/exchange/bitswap/message"
	bsnet "github.com/jbenet/go-ipfs/exchange/bitswap/network"
	notifications "github.com/jbenet/go-ipfs/exchange/bitswap/notifications"
	strategy "github.com/jbenet/go-ipfs/exchange/bitswap/strategy"
18
	peer "github.com/jbenet/go-ipfs/peer"
Juan Batiz-Benet's avatar
Juan Batiz-Benet committed
19
	u "github.com/jbenet/go-ipfs/util"
20
	"github.com/jbenet/go-ipfs/util/eventlog"
Juan Batiz-Benet's avatar
Juan Batiz-Benet committed
21 22
)

23
var log = eventlog.Logger("bitswap")
Juan Batiz-Benet's avatar
Juan Batiz-Benet committed
24

25 26 27
// New initializes a BitSwap instance that communicates over the
// provided BitSwapNetwork. This function registers the returned instance as
// the network delegate.
28
// Runs until context is cancelled
29 30
func New(ctx context.Context, p peer.Peer,
	network bsnet.BitSwapNetwork, routing bsnet.Routing,
31
	d ds.ThreadSafeDatastore, nice bool) exchange.Interface {
32

33 34
	notif := notifications.New()
	go func() {
Brian Tiger Chow's avatar
Brian Tiger Chow committed
35 36
		<-ctx.Done()
		notif.Shutdown()
37 38
	}()

39 40
	bs := &bitswap{
		blockstore:    blockstore.NewBlockstore(d),
41
		notifications: notif,
42
		strategy:      strategy.New(nice),
43
		routing:       routing,
Brian Tiger Chow's avatar
Brian Tiger Chow committed
44
		sender:        network,
45
		wantlist:      u.NewKeySet(),
46
		batchRequests: make(chan []u.Key, 32),
47
	}
Brian Tiger Chow's avatar
Brian Tiger Chow committed
48
	network.SetDelegate(bs)
Jeromy's avatar
Jeromy committed
49
	go bs.run(ctx)
50 51 52 53

	return bs
}

54 55
// bitswap instances implement the bitswap protocol.
type bitswap struct {
56

57
	// sender delivers messages on behalf of the session
58
	sender bsnet.BitSwapNetwork
59

60
	// blockstore is the local database
61
	// NB: ensure threadsafety
62
	blockstore blockstore.Blockstore
63

64
	// routing interface for communication
65
	routing bsnet.Routing
66

67
	notifications notifications.PubSub
68

69 70 71 72
	// Requests for a set of related blocks
	// the assumption is made that the same peer is likely to
	// have more than a single block in the set
	batchRequests chan []u.Key
Jeromy's avatar
Jeromy committed
73

74
	// strategy listens to network traffic and makes decisions about how to
75
	// interact with partners.
76 77
	// TODO(brian): save the strategy's state to the datastore
	strategy strategy.Strategy
78

79
	wantlist u.KeySet
80 81
}

82 83
// GetBlock attempts to retrieve a particular block from peers within the
// deadline enforced by the context
84 85
//
// TODO ensure only one active request per key
Jeromy's avatar
Jeromy committed
86
func (bs *bitswap) GetBlock(parent context.Context, k u.Key) (*blocks.Block, error) {
87 88 89 90

	// make sure to derive a new |ctx| and pass it to children. It's correct to
	// listen on |parent| here, but incorrect to pass |parent| to new async
	// functions. This is difficult to enforce. May this comment keep you safe.
91

92
	ctx, cancelFunc := context.WithCancel(parent)
93 94
	defer cancelFunc()

95 96
	ctx = eventlog.ContextWithMetadata(ctx, eventlog.Uuid("GetBlockRequest"))
	log.Event(ctx, "GetBlockRequestBegin", &k)
Brian Tiger Chow's avatar
Brian Tiger Chow committed
97
	defer log.Event(ctx, "GetBlockRequestEnd", &k)
98

99
	bs.wantlist.Add(k)
100
	promise := bs.notifications.Subscribe(ctx, k)
101

Jeromy's avatar
Jeromy committed
102
	select {
103
	case bs.batchRequests <- []u.Key{k}:
Jeromy's avatar
Jeromy committed
104 105 106
	case <-parent.Done():
		return nil, parent.Err()
	}
107 108

	select {
109
	case block := <-promise:
110
		bs.wantlist.Remove(k)
111
		return &block, nil
112 113
	case <-parent.Done():
		return nil, parent.Err()
114 115 116
	}
}

Jeromy's avatar
Jeromy committed
117 118 119 120 121 122
func (bs *bitswap) GetBlocks(parent context.Context, ks []u.Key) (*blocks.Block, error) {
	// TODO: something smart
	return nil, nil
}

func (bs *bitswap) sendWantListTo(ctx context.Context, peers <-chan peer.Peer) error {
Jeromy's avatar
Jeromy committed
123 124 125
	if peers == nil {
		panic("Cant send wantlist to nil peerchan")
	}
Jeromy's avatar
Jeromy committed
126 127 128 129 130
	message := bsmsg.New()
	for _, wanted := range bs.wantlist.Keys() {
		message.AddWanted(wanted)
	}
	for peerToQuery := range peers {
Brian Tiger Chow's avatar
Brian Tiger Chow committed
131
		log.Event(ctx, "PeerToQuery", peerToQuery)
Jeromy's avatar
Jeromy committed
132 133
		go func(p peer.Peer) {

Brian Tiger Chow's avatar
Brian Tiger Chow committed
134
			log.Event(ctx, "DialPeer", p)
Jeromy's avatar
Jeromy committed
135 136
			err := bs.sender.DialPeer(ctx, p)
			if err != nil {
137
				log.Errorf("Error sender.DialPeer(%s): %s", p, err)
Jeromy's avatar
Jeromy committed
138 139 140 141 142 143 144 145 146 147 148 149 150 151 152 153 154 155 156 157 158 159 160 161
				return
			}

			response, err := bs.sender.SendRequest(ctx, p, message)
			if err != nil {
				log.Errorf("Error sender.SendRequest(%s) = %s", p, err)
				return
			}
			// FIXME ensure accounting is handled correctly when
			// communication fails. May require slightly different API to
			// get better guarantees. May need shared sequence numbers.
			bs.strategy.MessageSent(p, message)

			if response == nil {
				return
			}
			bs.ReceiveMessage(ctx, p, response)
		}(peerToQuery)
	}
	return nil
}

func (bs *bitswap) run(ctx context.Context) {

162 163
	// Every so often, we should resend out our current want list
	rebroadcastTime := time.Second * 5
Brian Tiger Chow's avatar
Brian Tiger Chow committed
164

165
	broadcastSignal := time.NewTicker(bs.strategy.GetRebroadcastDelay())
Brian Tiger Chow's avatar
Brian Tiger Chow committed
166

Jeromy's avatar
Jeromy committed
167 168
	for {
		select {
169
		case <-broadcastSignal.C:
Jeromy's avatar
Jeromy committed
170 171 172 173
			wantlist := bs.wantlist.Keys()
			if len(wantlist) == 0 {
				continue
			}
174 175
			providers := bs.routing.FindProvidersAsync(ctx, wantlist[0], maxProvidersPerRequest)

Brian Tiger Chow's avatar
Brian Tiger Chow committed
176
			err := bs.sendWantListTo(ctx, providers)
Jeromy's avatar
Jeromy committed
177
			if err != nil {
Brian Tiger Chow's avatar
Brian Tiger Chow committed
178
				log.Errorf("error sending wantlist: %s", err)
Jeromy's avatar
Jeromy committed
179
			}
180 181 182 183
		case ks := <-bs.batchRequests:
			if len(ks) == 0 {
				log.Warning("Received batch request for zero blocks")
				continue
Jeromy's avatar
Jeromy committed
184
			}
185 186 187 188 189
			providers := bs.routing.FindProvidersAsync(ctx, ks[0], maxProvidersPerRequest)

			err := bs.sendWantListTo(ctx, providers)
			if err != nil {
				log.Errorf("error sending wantlist: %s", err)
Jeromy's avatar
Jeromy committed
190 191 192 193 194 195 196
			}
		case <-ctx.Done():
			return
		}
	}
}

197 198
// HasBlock announces the existance of a block to this bitswap service. The
// service will potentially notify its peers.
199
func (bs *bitswap) HasBlock(ctx context.Context, blk blocks.Block) error {
200
	log.Debugf("Has Block %v", blk.Key())
201
	bs.wantlist.Remove(blk.Key())
202
	bs.sendToPeersThatWant(ctx, blk)
Juan Batiz-Benet's avatar
Juan Batiz-Benet committed
203
	return bs.routing.Provide(ctx, blk.Key())
204 205
}

206
// TODO(brian): handle errors
207 208
func (bs *bitswap) ReceiveMessage(ctx context.Context, p peer.Peer, incoming bsmsg.BitSwapMessage) (
	peer.Peer, bsmsg.BitSwapMessage) {
Jeromy's avatar
Jeromy committed
209
	log.Debugf("ReceiveMessage from %s", p)
210
	log.Debugf("Message wantlist: %v", incoming.Wantlist())
211

212
	if p == nil {
213
		log.Error("Received message from nil peer!")
214 215
		// TODO propagate the error upward
		return nil, nil
216 217
	}
	if incoming == nil {
218
		log.Error("Got nil bitswap message!")
219 220
		// TODO propagate the error upward
		return nil, nil
221
	}
222

223 224 225
	// Record message bytes in ledger
	// TODO: this is bad, and could be easily abused.
	// Should only track *useful* messages in ledger
226
	bs.strategy.MessageReceived(p, incoming) // FIRST
227

228
	for _, block := range incoming.Blocks() {
229
		// TODO verify blocks?
230
		if err := bs.blockstore.Put(&block); err != nil {
Jeromy's avatar
Jeromy committed
231
			log.Criticalf("error putting block: %s", err)
232
			continue // FIXME(brian): err ignored
233
		}
234 235 236 237 238
		bs.notifications.Publish(block)
		err := bs.HasBlock(ctx, block)
		if err != nil {
			log.Warningf("HasBlock errored: %s", err)
		}
239 240
	}

241 242
	message := bsmsg.New()
	for _, wanted := range bs.wantlist.Keys() {
243
		message.AddWanted(wanted)
244
	}
245
	for _, key := range incoming.Wantlist() {
246 247
		// TODO: might be better to check if we have the block before checking
		//			if we should send it to someone
248
		if bs.strategy.ShouldSendBlockToPeer(key, p) {
249 250 251
			if block, errBlockNotFound := bs.blockstore.Get(key); errBlockNotFound != nil {
				continue
			} else {
252
				message.AddBlock(*block)
253
			}
254 255
		}
	}
256

Jeromy's avatar
Jeromy committed
257
	bs.strategy.MessageSent(p, message)
258
	log.Debug("Returning message.")
259 260 261 262
	return p, message
}

func (bs *bitswap) ReceiveError(err error) {
263
	log.Errorf("Bitswap ReceiveError: %s", err)
264 265
	// TODO log the network error
	// TODO bubble the network error up to the parent context/error logger
266
}
267

268 269
// send strives to ensure that accounting is always performed when a message is
// sent
270
func (bs *bitswap) send(ctx context.Context, p peer.Peer, m bsmsg.BitSwapMessage) {
Brian Tiger Chow's avatar
Brian Tiger Chow committed
271
	bs.sender.SendMessage(ctx, p, m)
272
	bs.strategy.MessageSent(p, m)
273 274
}

275
func (bs *bitswap) sendToPeersThatWant(ctx context.Context, block blocks.Block) {
276
	log.Debugf("Sending %v to peers that want it", block.Key())
277

278 279
	for _, p := range bs.strategy.Peers() {
		if bs.strategy.BlockIsWantedByPeer(block.Key(), p) {
280
			log.Debugf("%v wants %v", p, block.Key())
281 282
			if bs.strategy.ShouldSendBlockToPeer(block.Key(), p) {
				message := bsmsg.New()
283
				message.AddBlock(block)
284
				for _, wanted := range bs.wantlist.Keys() {
285
					message.AddWanted(wanted)
286
				}
287
				bs.send(ctx, p, message)
288 289 290 291
			}
		}
	}
}