2014-01-01 17:16:15 +01:00
|
|
|
// Copyright (c) 2013-2014 Conformal Systems LLC.
|
2013-08-06 23:55:22 +02:00
|
|
|
// Use of this source code is governed by an ISC
|
|
|
|
// license that can be found in the LICENSE file.
|
|
|
|
|
|
|
|
package main
|
|
|
|
|
|
|
|
import (
|
|
|
|
"bytes"
|
2013-08-29 21:44:43 +02:00
|
|
|
"container/list"
|
2013-08-08 17:11:03 +02:00
|
|
|
"fmt"
|
2013-08-29 21:44:43 +02:00
|
|
|
"github.com/conformal/btcchain"
|
2013-08-06 23:55:22 +02:00
|
|
|
"github.com/conformal/btcdb"
|
|
|
|
"github.com/conformal/btcutil"
|
|
|
|
"github.com/conformal/btcwire"
|
2013-08-07 20:17:29 +02:00
|
|
|
"github.com/conformal/go-socks"
|
2013-08-06 23:55:22 +02:00
|
|
|
"github.com/davecgh/go-spew/spew"
|
|
|
|
"net"
|
2013-08-07 20:17:29 +02:00
|
|
|
"strconv"
|
2013-08-06 23:55:22 +02:00
|
|
|
"sync"
|
2013-10-02 02:45:21 +02:00
|
|
|
"sync/atomic"
|
2013-08-06 23:55:22 +02:00
|
|
|
"time"
|
|
|
|
)
|
|
|
|
|
2013-09-09 17:58:56 +02:00
|
|
|
const (
|
2013-09-12 19:11:22 +02:00
|
|
|
// outputBufferSize is the number of elements the output channels use.
|
2013-09-09 17:58:56 +02:00
|
|
|
outputBufferSize = 50
|
|
|
|
|
|
|
|
// invTrickleSize is the maximum amount of inventory to send in a single
|
|
|
|
// message when trickling inventory to remote peers.
|
|
|
|
maxInvTrickleSize = 1000
|
|
|
|
|
|
|
|
// maxKnownInventory is the maximum number of items to keep in the known
|
|
|
|
// inventory cache.
|
|
|
|
maxKnownInventory = 20000
|
2013-10-16 16:49:09 +02:00
|
|
|
|
2014-01-18 08:39:31 +01:00
|
|
|
// negotiateTimeoutSeconds is the number of seconds of inactivity before
|
|
|
|
// we timeout a peer that hasn't completed the initial version
|
|
|
|
// negotiation.
|
|
|
|
negotiateTimeoutSeconds = 30
|
|
|
|
|
2013-10-16 16:49:09 +02:00
|
|
|
// idleTimeoutMinutes is the number of minutes of inactivity before
|
|
|
|
// we time out a peer.
|
|
|
|
idleTimeoutMinutes = 5
|
|
|
|
|
|
|
|
// pingTimeoutMinutes is the number of minutes since we last sent a
|
|
|
|
// message requiring a reply before we will ping a host.
|
|
|
|
pingTimeoutMinutes = 2
|
2013-09-09 17:58:56 +02:00
|
|
|
)
|
2013-08-06 23:55:22 +02:00
|
|
|
|
2013-08-08 16:26:18 +02:00
|
|
|
// userAgent is the user agent string used to identify ourselves to other
|
|
|
|
// bitcoin peers.
|
|
|
|
var userAgent = fmt.Sprintf("/btcd:%d.%d.%d/", appMajor, appMinor, appPatch)
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// zeroHash is the zero value hash (all zeros). It is defined as a convenience.
|
|
|
|
var zeroHash btcwire.ShaHash
|
|
|
|
|
|
|
|
// minUint32 is a helper function to return the minimum of two uint32s.
|
|
|
|
// This avoids a math import and the need to cast to floats.
|
|
|
|
func minUint32(a, b uint32) uint32 {
|
|
|
|
if a < b {
|
|
|
|
return a
|
|
|
|
}
|
|
|
|
return b
|
|
|
|
}
|
|
|
|
|
2013-08-07 20:17:29 +02:00
|
|
|
// newNetAddress attempts to extract the IP address and port from the passed
|
|
|
|
// net.Addr interface and create a bitcoin NetAddress structure using that
|
|
|
|
// information.
|
|
|
|
func newNetAddress(addr net.Addr, services btcwire.ServiceFlag) (*btcwire.NetAddress, error) {
|
|
|
|
// addr will be a net.TCPAddr when not using a proxy.
|
|
|
|
if tcpAddr, ok := addr.(*net.TCPAddr); ok {
|
|
|
|
ip := tcpAddr.IP
|
|
|
|
port := uint16(tcpAddr.Port)
|
|
|
|
na := btcwire.NewNetAddressIPPort(ip, port, services)
|
|
|
|
return na, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// addr will be a socks.ProxiedAddr when using a proxy.
|
|
|
|
if proxiedAddr, ok := addr.(*socks.ProxiedAddr); ok {
|
|
|
|
ip := net.ParseIP(proxiedAddr.Host)
|
|
|
|
if ip == nil {
|
|
|
|
ip = net.ParseIP("0.0.0.0")
|
|
|
|
}
|
|
|
|
port := uint16(proxiedAddr.Port)
|
|
|
|
na := btcwire.NewNetAddressIPPort(ip, port, services)
|
|
|
|
return na, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// For the most part, addr should be one of the two above cases, but
|
|
|
|
// to be safe, fall back to trying to parse the information from the
|
|
|
|
// address string as a last resort.
|
|
|
|
host, portStr, err := net.SplitHostPort(addr.String())
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
ip := net.ParseIP(host)
|
|
|
|
port, err := strconv.ParseUint(portStr, 10, 16)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
na := btcwire.NewNetAddressIPPort(ip, uint16(port), services)
|
|
|
|
return na, nil
|
|
|
|
}
|
|
|
|
|
2013-12-24 17:32:20 +01:00
|
|
|
// TODO(davec): Rename and comment this
|
2013-10-11 19:30:14 +02:00
|
|
|
type outMsg struct {
|
|
|
|
msg btcwire.Message
|
2013-10-16 16:49:09 +02:00
|
|
|
doneChan chan bool
|
2013-10-11 19:30:14 +02:00
|
|
|
}
|
|
|
|
|
2013-12-24 17:32:20 +01:00
|
|
|
// peer provides a bitcoin peer for handling bitcoin communications. The
|
|
|
|
// overall data flow is split into 3 goroutines and a separate block manager.
|
|
|
|
// Inbound messages are read via the inHandler goroutine and generally
|
|
|
|
// dispatched to their own handler. For inbound data-related messages such as
|
|
|
|
// blocks, transactions, and inventory, the data is pased on to the block
|
|
|
|
// manager to handle it. Outbound messages are queued via QueueMessage or
|
|
|
|
// QueueInventory. QueueMessage is intended for all messages, including
|
|
|
|
// responses to data such as blocks and transactions. QueueInventory, on the
|
|
|
|
// other hand, is only intended for relaying inventory as it employs a trickling
|
|
|
|
// mechanism to batch the inventory together. The data flow for outbound
|
|
|
|
// messages uses two goroutines, queueHandler and outHandler. The first,
|
|
|
|
// queueHandler, is used as a way for external entities (mainly block manager)
|
|
|
|
// to queue messages quickly regardless of whether the peer is currently
|
|
|
|
// sending or not. It acts as the traffic cop between the external world and
|
|
|
|
// the actual goroutine which writes to the network socket. In addition, the
|
|
|
|
// peer contains several functions which are of the form pushX, that are used
|
|
|
|
// to push messages to the peer. Internally they use QueueMessage.
|
2013-08-06 23:55:22 +02:00
|
|
|
type peer struct {
|
2013-09-18 20:33:54 +02:00
|
|
|
server *server
|
|
|
|
protocolVersion uint32
|
|
|
|
btcnet btcwire.BitcoinNet
|
|
|
|
services btcwire.ServiceFlag
|
2013-10-03 01:33:42 +02:00
|
|
|
started int32
|
2013-09-18 20:33:54 +02:00
|
|
|
conn net.Conn
|
|
|
|
addr string
|
|
|
|
na *btcwire.NetAddress
|
|
|
|
timeConnected time.Time
|
2013-10-21 19:45:30 +02:00
|
|
|
lastSend time.Time
|
|
|
|
lastRecv time.Time
|
2013-09-18 20:33:54 +02:00
|
|
|
inbound bool
|
2013-10-03 00:06:29 +02:00
|
|
|
connected int32
|
2013-10-02 02:45:21 +02:00
|
|
|
disconnect int32 // only to be used atomically
|
2013-09-18 20:33:54 +02:00
|
|
|
persistent bool
|
|
|
|
versionKnown bool
|
|
|
|
knownAddresses map[string]bool
|
|
|
|
knownInventory *MruInventoryMap
|
|
|
|
knownInvMutex sync.Mutex
|
2013-12-24 17:32:20 +01:00
|
|
|
requestedTxns map[btcwire.ShaHash]bool // owned by blockmanager
|
|
|
|
requestedBlocks map[btcwire.ShaHash]bool // owned by blockmanager
|
2013-09-18 20:33:54 +02:00
|
|
|
lastBlock int32
|
2013-12-24 17:32:20 +01:00
|
|
|
retryCount int64
|
|
|
|
prevGetBlocksBegin *btcwire.ShaHash // owned by blockmanager
|
|
|
|
prevGetBlocksStop *btcwire.ShaHash // owned by blockmanager
|
2013-09-18 20:33:54 +02:00
|
|
|
requestQueue *list.List
|
|
|
|
continueHash *btcwire.ShaHash
|
2013-10-11 19:30:14 +02:00
|
|
|
outputQueue chan outMsg
|
2013-12-20 14:06:37 +01:00
|
|
|
sendQueue chan outMsg
|
|
|
|
sendDoneQueue chan bool
|
|
|
|
queueWg sync.WaitGroup // TODO(oga) wg -> single use channel?
|
2013-12-24 17:32:20 +01:00
|
|
|
outputInvChan chan *btcwire.InvVect
|
|
|
|
txProcessed chan bool
|
|
|
|
blockProcessed chan bool
|
|
|
|
quit chan bool
|
|
|
|
userAgent string
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-10-03 03:05:10 +02:00
|
|
|
// String returns the peer's address and directionality as a human-readable
|
|
|
|
// string.
|
|
|
|
func (p *peer) String() string {
|
|
|
|
return fmt.Sprintf("%s (%s)", p.addr, directionString(p.inbound))
|
|
|
|
}
|
|
|
|
|
2013-09-09 17:58:56 +02:00
|
|
|
// isKnownInventory returns whether or not the peer is known to have the passed
|
|
|
|
// inventory. It is safe for concurrent access.
|
|
|
|
func (p *peer) isKnownInventory(invVect *btcwire.InvVect) bool {
|
|
|
|
p.knownInvMutex.Lock()
|
|
|
|
defer p.knownInvMutex.Unlock()
|
|
|
|
|
|
|
|
if p.knownInventory.Exists(invVect) {
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
2013-12-24 17:32:20 +01:00
|
|
|
// AddKnownInventory adds the passed inventory to the cache of known inventory
|
2013-09-09 17:58:56 +02:00
|
|
|
// for the peer. It is safe for concurrent access.
|
2013-12-24 17:32:20 +01:00
|
|
|
func (p *peer) AddKnownInventory(invVect *btcwire.InvVect) {
|
2013-09-09 17:58:56 +02:00
|
|
|
p.knownInvMutex.Lock()
|
|
|
|
defer p.knownInvMutex.Unlock()
|
|
|
|
|
|
|
|
p.knownInventory.Add(invVect)
|
|
|
|
}
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// pushVersionMsg sends a version message to the connected peer using the
|
|
|
|
// current state.
|
|
|
|
func (p *peer) pushVersionMsg() error {
|
|
|
|
_, blockNum, err := p.server.db.NewestSha()
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2013-11-28 18:06:54 +01:00
|
|
|
theirNa := p.na
|
|
|
|
|
|
|
|
// If we are behind a proxy and the connection comes from the proxy then
|
|
|
|
// we return an unroutable address as their address. This is to prevent
|
|
|
|
// leaking the tor proxy address.
|
|
|
|
if cfg.Proxy != "" {
|
|
|
|
proxyaddress, _, err := net.SplitHostPort(cfg.Proxy)
|
|
|
|
// invalid proxy means poorly configured, be on the safe side.
|
|
|
|
if err != nil || p.na.IP.String() == proxyaddress {
|
|
|
|
theirNa = &btcwire.NetAddress{
|
|
|
|
Timestamp: time.Now(),
|
|
|
|
IP: net.IP([]byte{0, 0, 0, 0}),
|
|
|
|
}
|
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-08-07 20:17:29 +02:00
|
|
|
// Version message.
|
2013-11-28 18:06:54 +01:00
|
|
|
msg := btcwire.NewMsgVersion(
|
|
|
|
p.server.addrManager.getBestLocalAddress(p.na), theirNa, p.server.nonce,
|
|
|
|
userAgent, int32(blockNum))
|
2013-08-07 20:17:29 +02:00
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// XXX: bitcoind appears to always enable the full node services flag
|
|
|
|
// of the remote peer netaddress field in the version message regardless
|
|
|
|
// of whether it knows it supports it or not. Also, bitcoind sets
|
|
|
|
// the services field of the local peer to 0 regardless of support.
|
|
|
|
//
|
|
|
|
// Realistically, this should be set as follows:
|
|
|
|
// - For outgoing connections:
|
|
|
|
// - Set the local netaddress services to what the local peer
|
|
|
|
// actually supports
|
|
|
|
// - Set the remote netaddress services to 0 to indicate no services
|
|
|
|
// as they are still unknown
|
|
|
|
// - For incoming connections:
|
|
|
|
// - Set the local netaddress services to what the local peer
|
|
|
|
// actually supports
|
|
|
|
// - Set the remote netaddress services to the what was advertised by
|
|
|
|
// by the remote peer in its version message
|
|
|
|
msg.AddrYou.Services = btcwire.SFNodeNetwork
|
|
|
|
|
|
|
|
// Advertise that we're a full node.
|
|
|
|
msg.Services = btcwire.SFNodeNetwork
|
|
|
|
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(msg, nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// handleVersionMsg is invoked when a peer receives a version bitcoin message
|
|
|
|
// and is used to negotiate the protocol version details as well as kick start
|
|
|
|
// the communications.
|
|
|
|
func (p *peer) handleVersionMsg(msg *btcwire.MsgVersion) {
|
|
|
|
// Detect self connections.
|
|
|
|
if msg.Nonce == p.server.nonce {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Debugf("Disconnecting peer connected to self %s",
|
2013-10-03 00:06:29 +02:00
|
|
|
p.addr)
|
2013-08-09 22:47:06 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Limit to one version message per peer.
|
|
|
|
if p.versionKnown {
|
2013-10-10 21:13:54 +02:00
|
|
|
p.logError("PEER: Only one version message per peer is allowed %s.",
|
2013-10-03 00:06:29 +02:00
|
|
|
p.addr)
|
2013-08-09 22:47:06 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Negotiate the protocol version.
|
|
|
|
p.protocolVersion = minUint32(p.protocolVersion, uint32(msg.ProtocolVersion))
|
|
|
|
p.versionKnown = true
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Debugf("Negotiated protocol version %d for peer %s",
|
2013-10-03 00:06:29 +02:00
|
|
|
p.protocolVersion, p.addr)
|
2013-08-06 23:55:22 +02:00
|
|
|
p.lastBlock = msg.LastBlock
|
|
|
|
|
2013-09-03 23:55:14 +02:00
|
|
|
// Set the supported services for the peer to what the remote peer
|
|
|
|
// advertised.
|
2013-09-03 20:34:27 +02:00
|
|
|
p.services = msg.Services
|
|
|
|
|
2013-10-29 21:25:08 +01:00
|
|
|
// Set the remote peer's user agent.
|
|
|
|
p.userAgent = msg.UserAgent
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// Inbound connections.
|
|
|
|
if p.inbound {
|
2013-11-21 20:05:14 +01:00
|
|
|
// Set up a NetAddress for the peer to be used with AddrManager.
|
|
|
|
// We only do this inbound because outbound set this up
|
|
|
|
// at connection time and no point recomputing.
|
|
|
|
na, err := newNetAddress(p.conn.RemoteAddr(), p.services)
|
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
p.logError("Can't get remote address: %v", err)
|
2013-11-21 20:05:14 +01:00
|
|
|
p.Disconnect()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
p.na = na
|
2013-11-28 18:04:56 +01:00
|
|
|
|
|
|
|
// Send version.
|
|
|
|
err = p.pushVersionMsg()
|
|
|
|
if err != nil {
|
|
|
|
p.logError("Can't send version message: %v", err)
|
|
|
|
p.Disconnect()
|
|
|
|
return
|
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Send verack.
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(btcwire.NewMsgVerAck(), nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
// Outbound connections.
|
|
|
|
if !p.inbound {
|
2013-08-17 22:26:51 +02:00
|
|
|
// TODO(davec): Only do this if not doing the initial block
|
|
|
|
// download and the local address is routable.
|
2013-11-26 01:40:16 +01:00
|
|
|
if !cfg.DisableListen /* && isCurrent? */ {
|
|
|
|
// get address that best matches. p.na
|
|
|
|
lna := p.server.addrManager.getBestLocalAddress(p.na)
|
|
|
|
if Routable(lna) {
|
|
|
|
addresses := []*btcwire.NetAddress{lna}
|
|
|
|
p.pushAddrMsg(addresses)
|
2013-08-17 22:26:51 +02:00
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Request known addresses if the server address manager needs
|
|
|
|
// more and the peer has a protocol version new enough to
|
|
|
|
// include a timestamp with addresses.
|
|
|
|
hasTimestamp := p.protocolVersion >= btcwire.NetAddressTimeVersion
|
|
|
|
if p.server.addrManager.NeedMoreAddresses() && hasTimestamp {
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(btcwire.NewMsgGetAddr(), nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
2013-09-12 21:19:10 +02:00
|
|
|
|
|
|
|
// Mark the address as a known good address.
|
2013-08-01 19:00:14 +02:00
|
|
|
p.server.addrManager.Good(p.na)
|
|
|
|
} else {
|
2013-09-12 21:19:10 +02:00
|
|
|
// A peer might not be advertising the same address that it
|
|
|
|
// actually connected from. One example of why this can happen
|
|
|
|
// is with NAT. Only add the address to the address manager if
|
|
|
|
// the addresses agree.
|
2013-08-01 19:00:14 +02:00
|
|
|
if NetAddressKey(&msg.AddrMe) == NetAddressKey(p.na) {
|
|
|
|
p.server.addrManager.AddAddress(p.na, p.na)
|
|
|
|
p.server.addrManager.Good(p.na)
|
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-03 23:55:14 +02:00
|
|
|
// Signal the block manager this peer is a new sync candidate.
|
2013-10-01 00:53:21 +02:00
|
|
|
p.server.blockManager.NewPeer(p)
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
// TODO: Relay alerts.
|
|
|
|
}
|
|
|
|
|
|
|
|
// pushTxMsg sends a tx message for the provided transaction hash to the
|
2013-10-11 21:12:40 +02:00
|
|
|
// connected peer. An error is returned if the transaction hash is not known.
|
2013-12-20 14:06:37 +01:00
|
|
|
func (p *peer) pushTxMsg(sha *btcwire.ShaHash, doneChan, waitChan chan bool) error {
|
2013-10-11 21:12:40 +02:00
|
|
|
// Attempt to fetch the requested transaction from the pool. A
|
|
|
|
// call could be made to check for existence first, but simply trying
|
|
|
|
// to fetch a missing transaction results in the same behavior.
|
|
|
|
tx, err := p.server.txMemPool.FetchTransaction(sha)
|
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Unable to fetch tx %v from transaction "+
|
2013-10-11 21:12:40 +02:00
|
|
|
"pool: %v", sha, err)
|
|
|
|
return err
|
|
|
|
}
|
2013-12-20 14:06:37 +01:00
|
|
|
|
|
|
|
// Once we have fetched data wait for any previous operation to finish.
|
|
|
|
if waitChan != nil {
|
|
|
|
<-waitChan
|
|
|
|
}
|
|
|
|
|
2013-10-28 21:44:38 +01:00
|
|
|
p.QueueMessage(tx.MsgTx(), doneChan)
|
2013-10-11 21:12:40 +02:00
|
|
|
|
|
|
|
return nil
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// pushBlockMsg sends a block message for the provided block hash to the
|
|
|
|
// connected peer. An error is returned if the block hash is not known.
|
2013-12-20 14:06:37 +01:00
|
|
|
func (p *peer) pushBlockMsg(sha *btcwire.ShaHash, doneChan, waitChan chan bool) error {
|
2013-10-11 21:12:40 +02:00
|
|
|
blk, err := p.server.db.FetchBlockBySha(sha)
|
2013-08-06 23:55:22 +02:00
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Unable to fetch requested block sha %v: %v",
|
2013-10-11 21:12:40 +02:00
|
|
|
sha, err)
|
2013-08-06 23:55:22 +02:00
|
|
|
return err
|
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
|
2013-12-20 14:06:37 +01:00
|
|
|
// Once we have fetched data wait for any previous operation to finish.
|
|
|
|
if waitChan != nil {
|
|
|
|
<-waitChan
|
|
|
|
}
|
|
|
|
|
2013-10-16 16:49:09 +02:00
|
|
|
// We only send the channel for this message if we aren't sending
|
|
|
|
// an inv straight after.
|
|
|
|
var dc chan bool
|
|
|
|
sendInv := p.continueHash != nil && p.continueHash.IsEqual(sha)
|
|
|
|
if !sendInv {
|
|
|
|
dc = doneChan
|
|
|
|
}
|
|
|
|
p.QueueMessage(blk.MsgBlock(), dc)
|
2013-09-05 08:20:48 +02:00
|
|
|
|
|
|
|
// When the peer requests the final block that was advertised in
|
|
|
|
// response to a getblocks message which requested more blocks than
|
|
|
|
// would fit into a single message, send it a new inventory message
|
|
|
|
// to trigger it to issue another getblocks message for the next
|
|
|
|
// batch of inventory.
|
2013-10-11 21:12:40 +02:00
|
|
|
if p.continueHash != nil && p.continueHash.IsEqual(sha) {
|
2013-09-05 08:20:48 +02:00
|
|
|
hash, _, err := p.server.db.NewestSha()
|
|
|
|
if err == nil {
|
|
|
|
invMsg := btcwire.NewMsgInv()
|
2013-10-08 22:55:07 +02:00
|
|
|
iv := btcwire.NewInvVect(btcwire.InvTypeBlock, hash)
|
2013-09-05 08:20:48 +02:00
|
|
|
invMsg.AddInvVect(iv)
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(invMsg, doneChan)
|
2013-09-05 08:20:48 +02:00
|
|
|
p.continueHash = nil
|
2013-10-16 16:49:09 +02:00
|
|
|
} else if doneChan != nil {
|
|
|
|
// Avoid deadlock when caller waits on channel.
|
|
|
|
go func() {
|
|
|
|
doneChan <- false
|
|
|
|
}()
|
2013-09-05 08:20:48 +02:00
|
|
|
}
|
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-10-08 20:34:04 +02:00
|
|
|
// PushGetBlocksMsg sends a getblocks message for the provided block locator
|
2013-09-18 20:33:54 +02:00
|
|
|
// and stop hash. It will ignore back-to-back duplicate requests.
|
2013-09-27 02:41:02 +02:00
|
|
|
func (p *peer) PushGetBlocksMsg(locator btcchain.BlockLocator, stopHash *btcwire.ShaHash) error {
|
2013-09-18 20:33:54 +02:00
|
|
|
// Extract the begin hash from the block locator, if one was specified,
|
|
|
|
// to use for filtering duplicate getblocks requests.
|
|
|
|
// request.
|
|
|
|
var beginHash *btcwire.ShaHash
|
|
|
|
if len(locator) > 0 {
|
|
|
|
beginHash = locator[0]
|
|
|
|
}
|
|
|
|
|
|
|
|
// Filter duplicate getblocks requests.
|
|
|
|
if p.prevGetBlocksStop != nil && p.prevGetBlocksBegin != nil &&
|
|
|
|
beginHash != nil && stopHash.IsEqual(p.prevGetBlocksStop) &&
|
|
|
|
beginHash.IsEqual(p.prevGetBlocksBegin) {
|
|
|
|
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Filtering duplicate [getblocks] with begin "+
|
2013-09-18 20:33:54 +02:00
|
|
|
"hash %v, stop hash %v", beginHash, stopHash)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Construct the getblocks request and queue it to be sent.
|
2013-08-29 21:44:43 +02:00
|
|
|
msg := btcwire.NewMsgGetBlocks(stopHash)
|
|
|
|
for _, hash := range locator {
|
|
|
|
err := msg.AddBlockLocatorHash(hash)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(msg, nil)
|
2013-09-18 20:33:54 +02:00
|
|
|
|
|
|
|
// Update the previous getblocks request information for filtering
|
|
|
|
// duplicates.
|
|
|
|
p.prevGetBlocksBegin = beginHash
|
|
|
|
p.prevGetBlocksStop = stopHash
|
2013-08-29 21:44:43 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-11-16 00:16:51 +01:00
|
|
|
// PushGetHeadersMsg sends a getblocks message for the provided block locator
|
|
|
|
// and stop hash. It will ignore back-to-back duplicate requests.
|
|
|
|
func (p *peer) PushGetHeadersMsg(locator btcchain.BlockLocator) error {
|
|
|
|
// Extract the begin hash from the block locator, if one was specified,
|
|
|
|
// to use for filtering duplicate getblocks requests.
|
|
|
|
// request.
|
|
|
|
var beginHash *btcwire.ShaHash
|
|
|
|
if len(locator) > 0 {
|
|
|
|
beginHash = locator[0]
|
|
|
|
}
|
|
|
|
|
|
|
|
// Filter duplicate getblocks requests.
|
|
|
|
if p.prevGetBlocksBegin != nil &&
|
|
|
|
beginHash != nil &&
|
|
|
|
beginHash.IsEqual(p.prevGetBlocksBegin) {
|
|
|
|
|
|
|
|
peerLog.Tracef("PEER: Filtering duplicate [getblocks] with begin "+
|
|
|
|
"hash %v", beginHash)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Construct the getheaders request and queue it to be sent.
|
|
|
|
msg := btcwire.NewMsgGetHeaders()
|
|
|
|
for _, hash := range locator {
|
|
|
|
err := msg.AddBlockLocatorHash(hash)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
p.QueueMessage(msg, nil)
|
|
|
|
|
|
|
|
// Update the previous getblocks request information for filtering
|
|
|
|
// duplicates.
|
|
|
|
p.prevGetBlocksBegin = beginHash
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-10-08 07:04:51 +02:00
|
|
|
// handleMemPoolMsg is invoked when a peer receives a mempool bitcoin message.
|
|
|
|
// It creates and sends an inventory message with the contents of the memory
|
|
|
|
// pool up to the maximum inventory allowed per message.
|
|
|
|
func (p *peer) handleMemPoolMsg(msg *btcwire.MsgMemPool) {
|
|
|
|
// Generate inventory message with the available transactions in the
|
|
|
|
// transaction memory pool. Limit it to the max allowed inventory
|
2014-01-09 00:46:59 +01:00
|
|
|
// per message. The the NewMsgInvSizeHint function automatically limits
|
|
|
|
// the passed hint to the maximum allowed, so it's safe to pass it
|
|
|
|
// without double checking it here.
|
2013-10-08 07:04:51 +02:00
|
|
|
hashes := p.server.txMemPool.TxShas()
|
2014-01-09 00:46:59 +01:00
|
|
|
invMsg := btcwire.NewMsgInvSizeHint(uint(len(hashes)))
|
2013-10-08 07:04:51 +02:00
|
|
|
for i, hash := range hashes {
|
2013-11-15 23:12:23 +01:00
|
|
|
// Another thread might have removed the transaction from the
|
|
|
|
// pool since the initial query.
|
|
|
|
if !p.server.txMemPool.IsTransactionInPool(hash) {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
2013-10-08 22:55:07 +02:00
|
|
|
iv := btcwire.NewInvVect(btcwire.InvTypeTx, hash)
|
2013-10-08 07:04:51 +02:00
|
|
|
invMsg.AddInvVect(iv)
|
|
|
|
if i+1 >= btcwire.MaxInvPerMsg {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Send the inventory message if there is anything to send.
|
|
|
|
if len(invMsg.InvList) > 0 {
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(invMsg, nil)
|
2013-10-08 07:04:51 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-09-20 19:55:27 +02:00
|
|
|
// handleTxMsg is invoked when a peer receives a tx bitcoin message. It blocks
|
|
|
|
// until the bitcoin transaction has been fully processed. Unlock the block
|
|
|
|
// handler this does not serialize all transactions through a single thread
|
|
|
|
// transactions don't rely on the previous one in a linear fashion like blocks.
|
|
|
|
func (p *peer) handleTxMsg(msg *btcwire.MsgTx) {
|
|
|
|
// Add the transaction to the known inventory for the peer.
|
2013-10-28 21:44:38 +01:00
|
|
|
// Convert the raw MsgTx to a btcutil.Tx which provides some convenience
|
|
|
|
// methods and things such as hash caching.
|
|
|
|
tx := btcutil.NewTx(msg)
|
|
|
|
iv := btcwire.NewInvVect(btcwire.InvTypeTx, tx.Sha())
|
2013-12-24 17:32:20 +01:00
|
|
|
p.AddKnownInventory(iv)
|
2013-09-20 19:55:27 +02:00
|
|
|
|
2013-10-08 17:47:00 +02:00
|
|
|
// Queue the transaction up to be handled by the block manager and
|
|
|
|
// intentionally block further receives until the transaction is fully
|
|
|
|
// processed and known good or bad. This helps prevent a malicious peer
|
|
|
|
// from queueing up a bunch of bad transactions before disconnecting (or
|
|
|
|
// being disconnected) and wasting memory.
|
2013-10-28 21:44:38 +01:00
|
|
|
p.server.blockManager.QueueTx(tx, p)
|
2013-10-08 17:47:00 +02:00
|
|
|
<-p.txProcessed
|
2013-09-20 19:55:27 +02:00
|
|
|
}
|
|
|
|
|
2013-09-09 17:58:56 +02:00
|
|
|
// handleBlockMsg is invoked when a peer receives a block bitcoin message. It
|
|
|
|
// blocks until the bitcoin block has been fully processed.
|
|
|
|
func (p *peer) handleBlockMsg(msg *btcwire.MsgBlock, buf []byte) {
|
2013-10-28 21:44:38 +01:00
|
|
|
// Convert the raw MsgBlock to a btcutil.Block which provides some
|
|
|
|
// convenience methods and things such as hash caching.
|
2013-09-09 17:58:56 +02:00
|
|
|
block := btcutil.NewBlockFromBlockAndBytes(msg, buf)
|
|
|
|
|
|
|
|
// Add the block to the known inventory for the peer.
|
|
|
|
hash, err := block.Sha()
|
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Errorf("Unable to get block hash: %v", err)
|
2013-09-09 17:58:56 +02:00
|
|
|
return
|
|
|
|
}
|
2013-10-08 22:55:07 +02:00
|
|
|
iv := btcwire.NewInvVect(btcwire.InvTypeBlock, hash)
|
2013-12-24 17:32:20 +01:00
|
|
|
p.AddKnownInventory(iv)
|
2013-09-09 17:58:56 +02:00
|
|
|
|
|
|
|
// Queue the block up to be handled by the block
|
|
|
|
// manager and intentionally block further receives
|
|
|
|
// until the bitcoin block is fully processed and known
|
|
|
|
// good or bad. This helps prevent a malicious peer
|
|
|
|
// from queueing up a bunch of bad blocks before
|
|
|
|
// disconnecting (or being disconnected) and wasting
|
|
|
|
// memory. Additionally, this behavior is depended on
|
|
|
|
// by at least the block acceptance test tool as the
|
|
|
|
// reference implementation processes blocks in the same
|
|
|
|
// thread and therefore blocks further messages until
|
|
|
|
// the bitcoin block has been fully processed.
|
|
|
|
p.server.blockManager.QueueBlock(block, p)
|
|
|
|
<-p.blockProcessed
|
|
|
|
}
|
|
|
|
|
2013-08-29 21:44:43 +02:00
|
|
|
// handleInvMsg is invoked when a peer receives an inv bitcoin message and is
|
|
|
|
// used to examine the inventory being advertised by the remote peer and react
|
2013-09-27 02:41:02 +02:00
|
|
|
// accordingly. We pass the message down to blockmanager which will call
|
2013-10-11 19:23:56 +02:00
|
|
|
// QueueMessage with any appropriate responses.
|
2013-08-29 21:44:43 +02:00
|
|
|
func (p *peer) handleInvMsg(msg *btcwire.MsgInv) {
|
2013-09-27 02:41:02 +02:00
|
|
|
p.server.blockManager.QueueInv(msg, p)
|
2013-08-29 21:44:43 +02:00
|
|
|
}
|
|
|
|
|
2013-11-16 00:16:51 +01:00
|
|
|
// handleHeadersMsg is invoked when a peer receives an inv bitcoin message and
|
|
|
|
// is used to examine the inventory being advertised by the remote peer and
|
|
|
|
// react accordingly. We pass the message down to blockmanager which will call
|
|
|
|
// QueueMessage with any appropriate responses.
|
|
|
|
func (p *peer) handleHeadersMsg(msg *btcwire.MsgHeaders) {
|
|
|
|
p.server.blockManager.QueueHeaders(msg, p)
|
|
|
|
}
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// handleGetData is invoked when a peer receives a getdata bitcoin message and
|
|
|
|
// is used to deliver block and transaction information.
|
|
|
|
func (p *peer) handleGetDataMsg(msg *btcwire.MsgGetData) {
|
|
|
|
notFound := btcwire.NewMsgNotFound()
|
|
|
|
|
2013-12-20 14:06:37 +01:00
|
|
|
// We wait on the this wait channel periodically to prevent queueing
|
|
|
|
// far more data than we can send in a reasonable time, wasting memory.
|
|
|
|
// The waiting occurs after the database fetch for the next one to
|
|
|
|
// provide a little pipelining.
|
|
|
|
var waitChan chan bool
|
2013-10-16 16:49:09 +02:00
|
|
|
doneChan := make(chan bool)
|
2013-08-06 23:55:22 +02:00
|
|
|
out:
|
2013-10-16 16:49:09 +02:00
|
|
|
for i, iv := range msg.InvList {
|
|
|
|
var c chan bool
|
|
|
|
// If this will be the last message we send.
|
|
|
|
if i == len(msg.InvList)-1 && len(notFound.InvList) == 0 {
|
|
|
|
c = doneChan
|
2013-12-20 14:06:37 +01:00
|
|
|
} else if i > 0 && i+1%3 == 0 {
|
|
|
|
// buffered so as to not make the send goroutine block.
|
|
|
|
c = make(chan bool, 1)
|
2013-10-16 16:49:09 +02:00
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
var err error
|
|
|
|
switch iv.Type {
|
2013-10-08 22:55:07 +02:00
|
|
|
case btcwire.InvTypeTx:
|
2013-12-20 14:06:37 +01:00
|
|
|
err = p.pushTxMsg(&iv.Hash, c, waitChan)
|
2013-10-08 22:55:07 +02:00
|
|
|
case btcwire.InvTypeBlock:
|
2013-12-20 14:06:37 +01:00
|
|
|
err = p.pushBlockMsg(&iv.Hash, c, waitChan)
|
2013-08-06 23:55:22 +02:00
|
|
|
default:
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Warnf("Unknown type in inventory request %d",
|
2013-08-06 23:55:22 +02:00
|
|
|
iv.Type)
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
if err != nil {
|
|
|
|
notFound.AddInvVect(iv)
|
|
|
|
}
|
2013-12-20 14:06:37 +01:00
|
|
|
waitChan = c
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
if len(notFound.InvList) != 0 {
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(notFound, doneChan)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
|
|
|
|
// Wait for messages to be sent. We can send quite a lot of data at this
|
|
|
|
// point and this will keep the peer busy for a decent amount of time.
|
|
|
|
// We don't process anything else by them in this time so that we
|
|
|
|
// have an idea of when we should hear back from them - else the idle
|
|
|
|
// timeout could fire when we were only half done sending the blocks.
|
|
|
|
<-doneChan
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// handleGetBlocksMsg is invoked when a peer receives a getdata bitcoin message.
|
|
|
|
func (p *peer) handleGetBlocksMsg(msg *btcwire.MsgGetBlocks) {
|
|
|
|
// Return all block hashes to the latest one (up to max per message) if
|
|
|
|
// no stop hash was specified.
|
|
|
|
// Attempt to find the ending index of the stop hash if specified.
|
2013-09-05 08:20:48 +02:00
|
|
|
endIdx := btcdb.AllShas
|
2013-08-06 23:55:22 +02:00
|
|
|
if !msg.HashStop.IsEqual(&zeroHash) {
|
|
|
|
block, err := p.server.db.FetchBlockBySha(&msg.HashStop)
|
2013-09-05 08:20:48 +02:00
|
|
|
if err == nil {
|
|
|
|
endIdx = block.Height() + 1
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-09-05 08:20:48 +02:00
|
|
|
// Find the most recent known block based on the block locator.
|
|
|
|
// Use the block after the genesis block if no other blocks in the
|
|
|
|
// provided locator are known. This does mean the client will start
|
|
|
|
// over with the genesis block if unknown block locators are provided.
|
|
|
|
// This mirrors the behavior in the reference implementation.
|
|
|
|
startIdx := int64(1)
|
2013-08-06 23:55:22 +02:00
|
|
|
for _, hash := range msg.BlockLocatorHashes {
|
|
|
|
block, err := p.server.db.FetchBlockBySha(hash)
|
|
|
|
if err == nil {
|
|
|
|
// Start with the next hash since we know this one.
|
|
|
|
startIdx = block.Height() + 1
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Don't attempt to fetch more than we can put into a single message.
|
2013-09-05 08:20:48 +02:00
|
|
|
autoContinue := false
|
2013-08-29 21:44:43 +02:00
|
|
|
if endIdx-startIdx > btcwire.MaxBlocksPerMsg {
|
|
|
|
endIdx = startIdx + btcwire.MaxBlocksPerMsg
|
2013-09-05 08:20:48 +02:00
|
|
|
autoContinue = true
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-05 08:20:48 +02:00
|
|
|
// Generate inventory message.
|
|
|
|
//
|
|
|
|
// The FetchBlockBySha call is limited to a maximum number of hashes
|
|
|
|
// per invocation. Since the maximum number of inventory per message
|
|
|
|
// might be larger, call it multiple times with the appropriate indices
|
|
|
|
// as needed.
|
|
|
|
invMsg := btcwire.NewMsgInv()
|
|
|
|
for start := startIdx; start < endIdx; {
|
|
|
|
// Fetch the inventory from the block database.
|
|
|
|
hashList, err := p.server.db.FetchHeightRange(start, endIdx)
|
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Warnf("Block lookup failed: %v", err)
|
2013-09-05 08:20:48 +02:00
|
|
|
return
|
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
|
2013-09-05 08:20:48 +02:00
|
|
|
// The database did not return any further hashes. Break out of
|
|
|
|
// the loop now.
|
|
|
|
if len(hashList) == 0 {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add block inventory to the message.
|
|
|
|
for _, hash := range hashList {
|
|
|
|
hashCopy := hash
|
2013-10-08 22:55:07 +02:00
|
|
|
iv := btcwire.NewInvVect(btcwire.InvTypeBlock, &hashCopy)
|
2013-09-05 08:20:48 +02:00
|
|
|
invMsg.AddInvVect(iv)
|
|
|
|
}
|
|
|
|
start += int64(len(hashList))
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-05 08:20:48 +02:00
|
|
|
// Send the inventory message if there is anything to send.
|
|
|
|
if len(invMsg.InvList) > 0 {
|
|
|
|
invListLen := len(invMsg.InvList)
|
|
|
|
if autoContinue && invListLen == btcwire.MaxBlocksPerMsg {
|
|
|
|
// Intentionally use a copy of the final hash so there
|
|
|
|
// is not a reference into the inventory slice which
|
|
|
|
// would prevent the entire slice from being eligible
|
|
|
|
// for GC as soon as it's sent.
|
|
|
|
continueHash := invMsg.InvList[invListLen-1].Hash
|
|
|
|
p.continueHash = &continueHash
|
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(invMsg, nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-10-16 16:49:09 +02:00
|
|
|
// handleGetHeadersMsg is invoked when a peer receives a getheaders bitcoin
|
2013-08-06 23:55:22 +02:00
|
|
|
// message.
|
|
|
|
func (p *peer) handleGetHeadersMsg(msg *btcwire.MsgGetHeaders) {
|
2013-09-05 01:17:42 +02:00
|
|
|
// Attempt to look up the height of the provided stop hash.
|
2013-08-06 23:55:22 +02:00
|
|
|
endIdx := btcdb.AllShas
|
2014-01-19 04:11:35 +01:00
|
|
|
height, err := p.server.db.FetchBlockHeightBySha(&msg.HashStop)
|
2013-09-05 01:17:42 +02:00
|
|
|
if err == nil {
|
2014-01-19 04:11:35 +01:00
|
|
|
endIdx = height + 1
|
2013-09-05 01:17:42 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// There are no block locators so a specific header is being requested
|
|
|
|
// as identified by the stop hash.
|
|
|
|
if len(msg.BlockLocatorHashes) == 0 {
|
|
|
|
// No blocks with the stop hash were found so there is nothing
|
|
|
|
// to do. Just return. This behavior mirrors the reference
|
|
|
|
// implementation.
|
|
|
|
if endIdx == btcdb.AllShas {
|
|
|
|
return
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
2013-09-05 01:17:42 +02:00
|
|
|
|
2014-01-19 04:11:35 +01:00
|
|
|
// Fetch and send the requested block header.
|
|
|
|
header, err := p.server.db.FetchBlockHeaderBySha(&msg.HashStop)
|
|
|
|
if err != nil {
|
|
|
|
peerLog.Warnf("Lookup of known block hash failed: %v",
|
|
|
|
err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2013-09-05 01:17:42 +02:00
|
|
|
headersMsg := btcwire.NewMsgHeaders()
|
2014-01-19 04:11:35 +01:00
|
|
|
headersMsg.AddBlockHeader(header)
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(headersMsg, nil)
|
2013-09-05 01:17:42 +02:00
|
|
|
return
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-05 01:17:42 +02:00
|
|
|
// Find the most recent known block based on the block locator.
|
2013-09-05 08:20:48 +02:00
|
|
|
// Use the block after the genesis block if no other blocks in the
|
2013-09-05 03:24:58 +02:00
|
|
|
// provided locator are known. This does mean the client will start
|
|
|
|
// over with the genesis block if unknown block locators are provided.
|
2013-09-05 08:20:48 +02:00
|
|
|
// This mirrors the behavior in the reference implementation.
|
2013-09-05 03:24:58 +02:00
|
|
|
startIdx := int64(1)
|
2013-08-06 23:55:22 +02:00
|
|
|
for _, hash := range msg.BlockLocatorHashes {
|
2014-01-19 04:11:35 +01:00
|
|
|
height, err := p.server.db.FetchBlockHeightBySha(hash)
|
2013-08-06 23:55:22 +02:00
|
|
|
if err == nil {
|
|
|
|
// Start with the next hash since we know this one.
|
2014-01-19 04:11:35 +01:00
|
|
|
startIdx = height + 1
|
2013-08-06 23:55:22 +02:00
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-09-05 01:17:42 +02:00
|
|
|
// Don't attempt to fetch more than we can put into a single message.
|
|
|
|
if endIdx-startIdx > btcwire.MaxBlockHeadersPerMsg {
|
|
|
|
endIdx = startIdx + btcwire.MaxBlockHeadersPerMsg
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-05 01:17:42 +02:00
|
|
|
// Generate headers message and send it.
|
|
|
|
//
|
2014-01-19 04:11:35 +01:00
|
|
|
// The FetchHeightRange call is limited to a maximum number of hashes
|
2013-09-05 01:17:42 +02:00
|
|
|
// per invocation. Since the maximum number of headers per message
|
|
|
|
// might be larger, call it multiple times with the appropriate indices
|
|
|
|
// as needed.
|
2013-08-06 23:55:22 +02:00
|
|
|
headersMsg := btcwire.NewMsgHeaders()
|
2013-09-05 01:17:42 +02:00
|
|
|
for start := startIdx; start < endIdx; {
|
|
|
|
// Fetch the inventory from the block database.
|
|
|
|
hashList, err := p.server.db.FetchHeightRange(start, endIdx)
|
2013-08-06 23:55:22 +02:00
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Warnf("Header lookup failed: %v", err)
|
2013-09-05 01:17:42 +02:00
|
|
|
return
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
2013-09-05 01:17:42 +02:00
|
|
|
|
|
|
|
// The database did not return any further hashes. Break out of
|
|
|
|
// the loop now.
|
|
|
|
if len(hashList) == 0 {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add headers to the message.
|
|
|
|
for _, hash := range hashList {
|
2014-01-19 04:11:35 +01:00
|
|
|
header, err := p.server.db.FetchBlockHeaderBySha(&hash)
|
2013-09-05 01:17:42 +02:00
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Warnf("Lookup of known block hash "+
|
2013-09-05 01:17:42 +02:00
|
|
|
"failed: %v", err)
|
|
|
|
continue
|
|
|
|
}
|
2014-01-19 04:11:35 +01:00
|
|
|
headersMsg.AddBlockHeader(header)
|
2013-09-05 01:17:42 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Start at the next block header after the latest one on the
|
|
|
|
// next loop iteration.
|
|
|
|
start += int64(len(hashList))
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(headersMsg, nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// handleGetAddrMsg is invoked when a peer receives a getaddr bitcoin message
|
|
|
|
// and is used to provide the peer with known addresses from the address
|
|
|
|
// manager.
|
|
|
|
func (p *peer) handleGetAddrMsg(msg *btcwire.MsgGetAddr) {
|
|
|
|
// Get the current known addresses from the address manager.
|
|
|
|
addrCache := p.server.addrManager.AddressCache()
|
|
|
|
|
|
|
|
// Push the addresses.
|
|
|
|
err := p.pushAddrMsg(addrCache)
|
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
p.logError("Can't push address message: %v", err)
|
2013-08-09 22:47:06 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// pushAddrMsg sends one, or more, addr message(s) to the connected peer using
|
|
|
|
// the provided addresses.
|
2013-09-17 18:24:15 +02:00
|
|
|
func (p *peer) pushAddrMsg(addresses []*btcwire.NetAddress) error {
|
2013-08-06 23:55:22 +02:00
|
|
|
// Nothing to send.
|
|
|
|
if len(addresses) == 0 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
numAdded := 0
|
|
|
|
msg := btcwire.NewMsgAddr()
|
|
|
|
for _, na := range addresses {
|
|
|
|
// Filter addresses the peer already knows about.
|
2013-08-07 07:33:46 +02:00
|
|
|
if p.knownAddresses[NetAddressKey(na)] {
|
2013-08-06 23:55:22 +02:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add the address to the message.
|
|
|
|
err := msg.AddAddress(na)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
numAdded++
|
|
|
|
|
|
|
|
// Split into multiple messages as needed.
|
|
|
|
if numAdded > 0 && numAdded%btcwire.MaxAddrPerMsg == 0 {
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(msg, nil)
|
2013-12-10 16:05:26 +01:00
|
|
|
|
|
|
|
// NOTE: This needs to be a new address message and not
|
|
|
|
// simply call ClearAddresses since the message is a
|
|
|
|
// pointer and queueing it does not make a copy.
|
|
|
|
msg = btcwire.NewMsgAddr()
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Send message with remaining addresses if needed.
|
|
|
|
if numAdded%btcwire.MaxAddrPerMsg != 0 {
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(msg, nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// handleAddrMsg is invoked when a peer receives an addr bitcoin message and
|
|
|
|
// is used to notify the server about advertised addresses.
|
|
|
|
func (p *peer) handleAddrMsg(msg *btcwire.MsgAddr) {
|
|
|
|
// Ignore old style addresses which don't include a timestamp.
|
|
|
|
if p.protocolVersion < btcwire.NetAddressTimeVersion {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// A message that has no addresses is invalid.
|
|
|
|
if len(msg.AddrList) == 0 {
|
2013-11-21 19:03:56 +01:00
|
|
|
p.logError("Command [%s] from %s does not contain any addresses",
|
2013-10-03 00:06:29 +02:00
|
|
|
msg.Command(), p.addr)
|
2013-08-09 22:47:06 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, na := range msg.AddrList {
|
|
|
|
// Don't add more address if we're disconnecting.
|
2013-10-02 02:45:21 +02:00
|
|
|
if atomic.LoadInt32(&p.disconnect) != 0 {
|
2013-08-06 23:55:22 +02:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Set the timestamp to 5 days ago if it's more than 24 hours
|
|
|
|
// in the future so this address is one of the first to be
|
|
|
|
// removed when space is needed.
|
|
|
|
now := time.Now()
|
|
|
|
if na.Timestamp.After(now.Add(time.Minute * 10)) {
|
|
|
|
na.Timestamp = now.Add(-1 * time.Hour * 24 * 5)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add address to known addresses for this peer.
|
2013-08-07 07:33:46 +02:00
|
|
|
p.knownAddresses[NetAddressKey(na)] = true
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Add addresses to server address manager. The address manager handles
|
|
|
|
// the details of things such as preventing duplicate addresses, max
|
|
|
|
// addresses, and last seen updates.
|
2013-09-17 18:24:15 +02:00
|
|
|
// XXX bitcoind gives a 2 hour time penalty here, do we want to do the
|
|
|
|
// same?
|
2013-08-01 19:00:14 +02:00
|
|
|
p.server.addrManager.AddAddresses(msg.AddrList, p.na)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// handlePingMsg is invoked when a peer receives a ping bitcoin message. For
|
|
|
|
// recent clients (protocol version > BIP0031Version), it replies with a pong
|
|
|
|
// message. For older clients, it does nothing and anything other than failure
|
|
|
|
// is considered a successful ping.
|
|
|
|
func (p *peer) handlePingMsg(msg *btcwire.MsgPing) {
|
|
|
|
// Only Reply with pong is message comes from a new enough client.
|
|
|
|
if p.protocolVersion > btcwire.BIP0031Version {
|
|
|
|
// Include nonce from ping so pong can be identified.
|
2013-10-16 16:49:09 +02:00
|
|
|
p.QueueMessage(btcwire.NewMsgPong(msg.Nonce), nil)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// readMessage reads the next bitcoin message from the peer with logging.
|
|
|
|
func (p *peer) readMessage() (msg btcwire.Message, buf []byte, err error) {
|
|
|
|
msg, buf, err = btcwire.ReadMessage(p.conn, p.protocolVersion, p.btcnet)
|
|
|
|
if err != nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Use closures to log expensive operations so they are only run when
|
|
|
|
// the logging level requires it.
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Debugf("%v", newLogClosure(func() string {
|
2013-10-10 21:13:54 +02:00
|
|
|
// Debug summary of message.
|
|
|
|
summary := messageSummary(msg)
|
|
|
|
if len(summary) > 0 {
|
|
|
|
summary = " (" + summary + ")"
|
|
|
|
}
|
2013-11-21 19:03:56 +01:00
|
|
|
return fmt.Sprintf("Received %v%s from %s",
|
2013-10-10 21:13:54 +02:00
|
|
|
msg.Command(), summary, p.addr)
|
|
|
|
}))
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("%v", newLogClosure(func() string {
|
|
|
|
return spew.Sdump(msg)
|
2013-08-06 23:55:22 +02:00
|
|
|
}))
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("%v", newLogClosure(func() string {
|
|
|
|
return spew.Sdump(buf)
|
2013-08-06 23:55:22 +02:00
|
|
|
}))
|
|
|
|
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// writeMessage sends a bitcoin Message to the peer with logging.
|
2013-09-09 17:58:56 +02:00
|
|
|
func (p *peer) writeMessage(msg btcwire.Message) {
|
|
|
|
// Don't do anything if we're disconnecting.
|
2013-10-02 02:45:21 +02:00
|
|
|
if atomic.LoadInt32(&p.disconnect) != 0 {
|
2013-09-09 17:58:56 +02:00
|
|
|
return
|
|
|
|
}
|
2013-10-14 23:02:59 +02:00
|
|
|
if !p.versionKnown {
|
|
|
|
switch msg.(type) {
|
|
|
|
case *btcwire.MsgVersion:
|
|
|
|
// This is OK.
|
|
|
|
default:
|
|
|
|
// We drop all messages other than version if we
|
|
|
|
// haven't done the handshake already.
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
2013-09-09 17:58:56 +02:00
|
|
|
|
2013-10-10 21:13:54 +02:00
|
|
|
// Use closures to log expensive operations so they are only run when
|
|
|
|
// the logging level requires it.
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Debugf("%v", newLogClosure(func() string {
|
2013-10-10 21:13:54 +02:00
|
|
|
// Debug summary of message.
|
|
|
|
summary := messageSummary(msg)
|
|
|
|
if len(summary) > 0 {
|
|
|
|
summary = " (" + summary + ")"
|
|
|
|
}
|
2013-11-21 19:03:56 +01:00
|
|
|
return fmt.Sprintf("Sending %v%s to %s", msg.Command(),
|
2013-10-10 21:13:54 +02:00
|
|
|
summary, p.addr)
|
|
|
|
}))
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("%v", newLogClosure(func() string {
|
|
|
|
return spew.Sdump(msg)
|
2013-08-06 23:55:22 +02:00
|
|
|
}))
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("%v", newLogClosure(func() string {
|
2013-08-06 23:55:22 +02:00
|
|
|
var buf bytes.Buffer
|
|
|
|
err := btcwire.WriteMessage(&buf, msg, p.protocolVersion, p.btcnet)
|
|
|
|
if err != nil {
|
|
|
|
return err.Error()
|
|
|
|
}
|
2013-11-21 19:03:56 +01:00
|
|
|
return spew.Sdump(buf.Bytes())
|
2013-08-06 23:55:22 +02:00
|
|
|
}))
|
|
|
|
|
|
|
|
// Write the message to the peer.
|
|
|
|
err := btcwire.WriteMessage(p.conn, msg, p.protocolVersion, p.btcnet)
|
|
|
|
if err != nil {
|
2013-09-09 17:58:56 +02:00
|
|
|
p.Disconnect()
|
2013-11-21 19:03:56 +01:00
|
|
|
p.logError("Can't send message: %v", err)
|
2013-09-09 17:58:56 +02:00
|
|
|
return
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// isAllowedByRegression returns whether or not the passed error is allowed by
|
|
|
|
// regression tests without disconnecting the peer. In particular, regression
|
|
|
|
// tests need to be allowed to send malformed messages without the peer being
|
|
|
|
// disconnected.
|
|
|
|
func (p *peer) isAllowedByRegression(err error) bool {
|
|
|
|
// Don't allow the error if it's not specifically a malformed message
|
|
|
|
// error.
|
|
|
|
if _, ok := err.(*btcwire.MessageError); !ok {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
|
|
|
// Don't allow the error if it's not coming from localhost or the
|
|
|
|
// hostname can't be determined for some reason.
|
2013-10-03 00:06:29 +02:00
|
|
|
host, _, err := net.SplitHostPort(p.addr)
|
2013-08-06 23:55:22 +02:00
|
|
|
if err != nil {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
|
|
|
if host != "127.0.0.1" && host != "localhost" {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
|
|
|
// Allowed if all checks passed.
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
|
|
|
|
// inHandler handles all incoming messages for the peer. It must be run as a
|
|
|
|
// goroutine.
|
|
|
|
func (p *peer) inHandler() {
|
2014-01-18 08:39:31 +01:00
|
|
|
// Peers must complete the initial version negotiation within a shorter
|
|
|
|
// timeframe than a general idle timeout. The timer is then reset below
|
|
|
|
// to idleTimeoutMinutes for all future messages.
|
|
|
|
idleTimer := time.AfterFunc(negotiateTimeoutSeconds*time.Second, func() {
|
2013-10-16 16:49:09 +02:00
|
|
|
// XXX technically very very very slightly racy, doesn't really
|
|
|
|
// matter.
|
|
|
|
if p.versionKnown {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Warnf("Peer %s no answer for %d minutes, "+
|
2013-10-17 22:58:57 +02:00
|
|
|
"disconnecting", p, idleTimeoutMinutes)
|
2013-10-16 16:49:09 +02:00
|
|
|
}
|
|
|
|
p.Disconnect()
|
|
|
|
})
|
2013-08-06 23:55:22 +02:00
|
|
|
out:
|
2013-10-02 02:45:21 +02:00
|
|
|
for atomic.LoadInt32(&p.disconnect) == 0 {
|
2013-08-06 23:55:22 +02:00
|
|
|
rmsg, buf, err := p.readMessage()
|
2013-10-16 16:49:09 +02:00
|
|
|
// Stop the timer now, if we go around again we will reset it.
|
|
|
|
idleTimer.Stop()
|
2013-08-06 23:55:22 +02:00
|
|
|
if err != nil {
|
|
|
|
// In order to allow regression tests with malformed
|
|
|
|
// messages, don't disconnect the peer when we're in
|
|
|
|
// regression test mode and the error is one of the
|
|
|
|
// allowed errors.
|
|
|
|
if cfg.RegressionTest && p.isAllowedByRegression(err) {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Errorf("Allowed regression test "+
|
2013-09-18 00:39:22 +02:00
|
|
|
"error: %v", err)
|
2013-10-16 16:49:09 +02:00
|
|
|
idleTimer.Reset(idleTimeoutMinutes * time.Minute)
|
2013-08-06 23:55:22 +02:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
// Only log the error if we're not forcibly disconnecting.
|
2013-10-02 02:45:21 +02:00
|
|
|
if atomic.LoadInt32(&p.disconnect) == 0 {
|
2013-10-10 21:13:54 +02:00
|
|
|
p.logError("PEER: Can't read message: %v", err)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
break out
|
|
|
|
}
|
2013-10-18 19:50:43 +02:00
|
|
|
p.lastRecv = time.Now()
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
// Ensure version message comes first.
|
|
|
|
if _, ok := rmsg.(*btcwire.MsgVersion); !ok && !p.versionKnown {
|
2013-10-10 21:13:54 +02:00
|
|
|
p.logError("PEER: A version message must precede all others")
|
2013-08-06 23:55:22 +02:00
|
|
|
break out
|
|
|
|
}
|
|
|
|
|
2013-08-16 20:35:38 +02:00
|
|
|
// Handle each supported message type.
|
2013-09-12 21:19:10 +02:00
|
|
|
markConnected := false
|
2013-08-06 23:55:22 +02:00
|
|
|
switch msg := rmsg.(type) {
|
|
|
|
case *btcwire.MsgVersion:
|
|
|
|
p.handleVersionMsg(msg)
|
2013-08-01 19:00:14 +02:00
|
|
|
markConnected = true
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
case *btcwire.MsgVerAck:
|
|
|
|
// Do nothing.
|
|
|
|
|
|
|
|
case *btcwire.MsgGetAddr:
|
|
|
|
p.handleGetAddrMsg(msg)
|
|
|
|
|
|
|
|
case *btcwire.MsgAddr:
|
|
|
|
p.handleAddrMsg(msg)
|
2013-08-01 19:00:14 +02:00
|
|
|
markConnected = true
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
case *btcwire.MsgPing:
|
|
|
|
p.handlePingMsg(msg)
|
2013-08-01 19:00:14 +02:00
|
|
|
markConnected = true
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
case *btcwire.MsgPong:
|
|
|
|
// Don't do anything, but could try to work out network
|
|
|
|
// timing or similar.
|
|
|
|
|
|
|
|
case *btcwire.MsgAlert:
|
|
|
|
p.server.BroadcastMessage(msg, p)
|
|
|
|
|
2013-10-08 07:04:51 +02:00
|
|
|
case *btcwire.MsgMemPool:
|
|
|
|
p.handleMemPoolMsg(msg)
|
|
|
|
|
2013-09-20 19:55:27 +02:00
|
|
|
case *btcwire.MsgTx:
|
|
|
|
p.handleTxMsg(msg)
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
case *btcwire.MsgBlock:
|
2013-09-09 17:58:56 +02:00
|
|
|
p.handleBlockMsg(msg, buf)
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
case *btcwire.MsgInv:
|
2013-08-29 21:44:43 +02:00
|
|
|
p.handleInvMsg(msg)
|
2013-08-01 19:00:14 +02:00
|
|
|
markConnected = true
|
2013-08-06 23:55:22 +02:00
|
|
|
|
2013-10-15 17:35:42 +02:00
|
|
|
case *btcwire.MsgNotFound:
|
|
|
|
// TODO(davec): Ignore this for now, but ultimately
|
|
|
|
// it should probably be used to detect when something
|
|
|
|
// we requested needs to be re-requested from another
|
|
|
|
// peer.
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
case *btcwire.MsgGetData:
|
|
|
|
p.handleGetDataMsg(msg)
|
2013-08-01 19:00:14 +02:00
|
|
|
markConnected = true
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
case *btcwire.MsgGetBlocks:
|
|
|
|
p.handleGetBlocksMsg(msg)
|
|
|
|
|
|
|
|
case *btcwire.MsgGetHeaders:
|
|
|
|
p.handleGetHeadersMsg(msg)
|
|
|
|
|
2013-11-16 00:16:51 +01:00
|
|
|
case *btcwire.MsgHeaders:
|
|
|
|
p.handleHeadersMsg(msg)
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
default:
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Debugf("Received unhandled message of type %v: Fix Me",
|
2013-08-06 23:55:22 +02:00
|
|
|
rmsg.Command())
|
|
|
|
}
|
2013-09-12 21:19:10 +02:00
|
|
|
|
|
|
|
// Mark the address as currently connected and working as of
|
2013-09-20 19:55:27 +02:00
|
|
|
// now if one of the messages that trigger it was processed.
|
2013-10-02 02:45:21 +02:00
|
|
|
if markConnected && atomic.LoadInt32(&p.disconnect) == 0 {
|
2013-08-01 19:00:14 +02:00
|
|
|
if p.na == nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Warnf("we're getting stuff before we " +
|
2013-08-01 19:00:14 +02:00
|
|
|
"got a version message. that's bad")
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
p.server.addrManager.Connected(p.na)
|
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
// ok we got a message, reset the timer.
|
|
|
|
// timer just calls p.Disconnect() after logging.
|
|
|
|
idleTimer.Reset(idleTimeoutMinutes * time.Minute)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-10-16 16:49:09 +02:00
|
|
|
idleTimer.Stop()
|
|
|
|
|
2013-12-24 17:32:20 +01:00
|
|
|
// Ensure connection is closed and notify the server that the peer is
|
|
|
|
// done.
|
2013-08-09 22:47:06 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
p.server.donePeers <- p
|
2013-12-24 17:32:20 +01:00
|
|
|
|
|
|
|
// Only tell block manager we are gone if we ever told it we existed.
|
2013-10-02 23:49:31 +02:00
|
|
|
if p.versionKnown {
|
|
|
|
p.server.blockManager.DonePeer(p)
|
|
|
|
}
|
2013-08-06 23:55:22 +02:00
|
|
|
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Peer input handler done for %s", p.addr)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-12-20 14:06:37 +01:00
|
|
|
// queueHandler handles the queueing of outgoing data for the peer. This runs
|
|
|
|
// as a muxer for various sources of input so we can ensure that blockmanager
|
|
|
|
// and the server goroutine both will not block on us sending a message.
|
|
|
|
// We then pass the data on to outHandler to be actually written.
|
|
|
|
func (p *peer) queueHandler() {
|
|
|
|
pendingMsgs := list.New()
|
|
|
|
invSendQueue := list.New()
|
|
|
|
trickleTicker := time.NewTicker(time.Second * 10)
|
|
|
|
|
|
|
|
// We keep the waiting flag so that we know if we have a message queued
|
2013-12-24 17:32:20 +01:00
|
|
|
// to the outHandler or not. We could use the presence of a head of
|
|
|
|
// the list for this but then we have rather racy concerns about whether
|
|
|
|
// it has gotten it at cleanup time - and thus who sends on the
|
|
|
|
// message's done channel. To avoid such confusion we keep a different
|
2013-12-20 14:06:37 +01:00
|
|
|
// flag and pendingMsgs only contains messages that we have not yet
|
|
|
|
// passed to outHandler.
|
|
|
|
waiting := false
|
|
|
|
|
|
|
|
// To avoid duplication below.
|
|
|
|
queuePacket := func(msg outMsg, list *list.List, waiting bool) bool {
|
|
|
|
if !waiting {
|
|
|
|
peerLog.Tracef("%s: sending to outHandler", p)
|
|
|
|
p.sendQueue <- msg
|
|
|
|
peerLog.Tracef("%s: sent to outHandler", p)
|
|
|
|
} else {
|
|
|
|
list.PushBack(msg)
|
|
|
|
}
|
|
|
|
// we are always waiting now.
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case msg := <-p.outputQueue:
|
|
|
|
waiting = queuePacket(msg, pendingMsgs, waiting)
|
|
|
|
|
2013-12-24 17:32:20 +01:00
|
|
|
// This channel is notified when a message has been sent across
|
|
|
|
// the network socket.
|
2013-12-20 14:06:37 +01:00
|
|
|
case <-p.sendDoneQueue:
|
|
|
|
peerLog.Tracef("%s: acked by outhandler", p)
|
2013-12-24 17:32:20 +01:00
|
|
|
|
|
|
|
// No longer waiting if there are no more messages
|
|
|
|
// in the pending messages queue.
|
2013-12-20 14:06:37 +01:00
|
|
|
next := pendingMsgs.Front()
|
2013-12-24 17:32:20 +01:00
|
|
|
if next == nil {
|
2013-12-20 14:06:37 +01:00
|
|
|
waiting = false
|
2013-12-24 17:32:20 +01:00
|
|
|
continue
|
2013-12-20 14:06:37 +01:00
|
|
|
}
|
|
|
|
|
2013-12-24 17:32:20 +01:00
|
|
|
// Notify the outHandler about the next item to
|
|
|
|
// asynchronously send.
|
|
|
|
val := pendingMsgs.Remove(next)
|
|
|
|
peerLog.Tracef("%s: sending to outHandler", p)
|
|
|
|
p.sendQueue <- val.(outMsg)
|
|
|
|
peerLog.Tracef("%s: sent to outHandler", p)
|
|
|
|
|
2013-12-20 14:06:37 +01:00
|
|
|
case iv := <-p.outputInvChan:
|
2013-12-24 17:32:20 +01:00
|
|
|
// No handshake? They'll find out soon enough.
|
2013-12-20 14:06:37 +01:00
|
|
|
if p.versionKnown {
|
|
|
|
invSendQueue.PushBack(iv)
|
|
|
|
}
|
|
|
|
|
|
|
|
case <-trickleTicker.C:
|
|
|
|
// Don't send anything if we're disconnecting or there
|
|
|
|
// is no queued inventory.
|
|
|
|
// version is known if send queue has any entries.
|
|
|
|
if atomic.LoadInt32(&p.disconnect) != 0 ||
|
|
|
|
invSendQueue.Len() == 0 {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
// Create and send as many inv messages as needed to
|
|
|
|
// drain the inventory send queue.
|
|
|
|
invMsg := btcwire.NewMsgInv()
|
|
|
|
for e := invSendQueue.Front(); e != nil; e = invSendQueue.Front() {
|
|
|
|
iv := invSendQueue.Remove(e).(*btcwire.InvVect)
|
|
|
|
|
|
|
|
// Don't send inventory that became known after
|
|
|
|
// the initial check.
|
|
|
|
if p.isKnownInventory(iv) {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
invMsg.AddInvVect(iv)
|
|
|
|
if len(invMsg.InvList) >= maxInvTrickleSize {
|
|
|
|
waiting = queuePacket(
|
|
|
|
outMsg{msg: invMsg},
|
|
|
|
pendingMsgs, waiting)
|
|
|
|
invMsg = btcwire.NewMsgInv()
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add the inventory that is being relayed to
|
|
|
|
// the known inventory for the peer.
|
2013-12-24 17:32:20 +01:00
|
|
|
p.AddKnownInventory(iv)
|
2013-12-20 14:06:37 +01:00
|
|
|
}
|
|
|
|
if len(invMsg.InvList) > 0 {
|
|
|
|
waiting = queuePacket(outMsg{msg: invMsg},
|
|
|
|
pendingMsgs, waiting)
|
|
|
|
}
|
|
|
|
|
|
|
|
case <-p.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Drain any wait channels before we go away so we don't leave something
|
|
|
|
// waiting for us.
|
|
|
|
for e := pendingMsgs.Front(); e != nil; e = pendingMsgs.Front() {
|
|
|
|
val := pendingMsgs.Remove(e)
|
|
|
|
msg := val.(outMsg)
|
|
|
|
if msg.doneChan != nil {
|
|
|
|
msg.doneChan <- false
|
|
|
|
}
|
|
|
|
}
|
|
|
|
cleanup:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case msg := <-p.outputQueue:
|
|
|
|
if msg.doneChan != nil {
|
|
|
|
msg.doneChan <- false
|
|
|
|
}
|
|
|
|
case <-p.outputInvChan:
|
|
|
|
// Just drain channel
|
|
|
|
// sendDoneQueue is buffered so doesn't need draining.
|
|
|
|
default:
|
|
|
|
break cleanup
|
|
|
|
}
|
|
|
|
}
|
|
|
|
p.queueWg.Done()
|
|
|
|
peerLog.Tracef("Peer queue handler done for %s", p.addr)
|
|
|
|
}
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// outHandler handles all outgoing messages for the peer. It must be run as a
|
|
|
|
// goroutine. It uses a buffered channel to serialize output messages while
|
|
|
|
// allowing the sender to continue running asynchronously.
|
|
|
|
func (p *peer) outHandler() {
|
2013-10-16 16:49:09 +02:00
|
|
|
pingTimer := time.AfterFunc(pingTimeoutMinutes*time.Minute, func() {
|
|
|
|
nonce, err := btcwire.RandomUint64()
|
|
|
|
if err != nil {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Errorf("Not sending ping on timeout to %s: %v",
|
2013-10-16 16:49:09 +02:00
|
|
|
p, err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
p.QueueMessage(btcwire.NewMsgPing(nonce), nil)
|
|
|
|
})
|
2013-08-06 23:55:22 +02:00
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
2013-12-20 14:06:37 +01:00
|
|
|
case msg := <-p.sendQueue:
|
2013-10-16 16:49:09 +02:00
|
|
|
// If the message is one we should get a reply for
|
|
|
|
// then reset the timer, we only want to send pings
|
|
|
|
// when otherwise we would not recieve a reply from
|
|
|
|
// the peer. We specifically do not count block or inv
|
|
|
|
// messages here since they are not sure of a reply if
|
|
|
|
// the inv is of no interest explicitly solicited invs
|
|
|
|
// should elicit a reply but we don't track them
|
|
|
|
// specially.
|
2013-12-20 14:06:37 +01:00
|
|
|
peerLog.Tracef("%s: recieved from queuehandler", p)
|
2013-10-16 16:49:09 +02:00
|
|
|
reset := true
|
|
|
|
switch msg.msg.(type) {
|
|
|
|
case *btcwire.MsgVersion:
|
|
|
|
// should get an ack
|
|
|
|
case *btcwire.MsgGetAddr:
|
|
|
|
// should get addresses
|
|
|
|
case *btcwire.MsgPing:
|
|
|
|
// expects pong
|
|
|
|
case *btcwire.MsgMemPool:
|
|
|
|
// Should return an inv.
|
|
|
|
case *btcwire.MsgGetData:
|
|
|
|
// Should get us block, tx, or not found.
|
|
|
|
case *btcwire.MsgGetHeaders:
|
|
|
|
// Should get us headers back.
|
|
|
|
|
|
|
|
default:
|
|
|
|
// Not one of the above, no sure reply.
|
|
|
|
// We want to ping if nothing else
|
|
|
|
// interesting happens.
|
|
|
|
reset = false
|
|
|
|
}
|
|
|
|
if reset {
|
|
|
|
pingTimer.Reset(pingTimeoutMinutes * time.Minute)
|
|
|
|
}
|
2013-10-11 19:30:14 +02:00
|
|
|
p.writeMessage(msg.msg)
|
2013-10-18 19:50:43 +02:00
|
|
|
p.lastSend = time.Now()
|
2013-10-11 19:30:14 +02:00
|
|
|
if msg.doneChan != nil {
|
|
|
|
msg.doneChan <- true
|
|
|
|
}
|
2013-12-20 14:06:37 +01:00
|
|
|
peerLog.Tracef("%s: acking queuehandler", p)
|
|
|
|
p.sendDoneQueue <- true
|
|
|
|
peerLog.Tracef("%s: acked queuehandler", p)
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
case <-p.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
2013-10-11 19:30:14 +02:00
|
|
|
|
2013-10-16 16:49:09 +02:00
|
|
|
pingTimer.Stop()
|
|
|
|
|
2013-12-20 14:06:37 +01:00
|
|
|
p.queueWg.Wait()
|
|
|
|
|
2013-10-11 19:30:14 +02:00
|
|
|
// Drain any wait channels before we go away so we don't leave something
|
2013-12-20 14:06:37 +01:00
|
|
|
// waiting for us. We have waited on queueWg and thus we can be sure
|
|
|
|
// that we will not miss anything sent on sendQueue.
|
2013-10-11 19:30:14 +02:00
|
|
|
cleanup:
|
|
|
|
for {
|
|
|
|
select {
|
2013-12-20 14:06:37 +01:00
|
|
|
case msg := <-p.sendQueue:
|
2013-10-11 19:30:14 +02:00
|
|
|
if msg.doneChan != nil {
|
|
|
|
msg.doneChan <- false
|
|
|
|
}
|
2013-12-20 14:06:37 +01:00
|
|
|
// no need to send on sendDoneQueue since queueHandler
|
|
|
|
// has been waited on and already exited.
|
2013-10-11 19:30:14 +02:00
|
|
|
default:
|
|
|
|
break cleanup
|
|
|
|
}
|
|
|
|
}
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Peer output handler done for %s", p.addr)
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// QueueMessage adds the passed bitcoin message to the peer send queue. It
|
|
|
|
// uses a buffered channel to communicate with the output handler goroutine so
|
|
|
|
// it is automatically rate limited and safe for concurrent access.
|
2013-10-16 16:49:09 +02:00
|
|
|
func (p *peer) QueueMessage(msg btcwire.Message, doneChan chan bool) {
|
2013-12-20 14:06:37 +01:00
|
|
|
// Avoid risk of deadlock if goroutine already exited. The goroutine
|
|
|
|
// we will be sending to hangs around until it knows for a fact that
|
|
|
|
// it is marked as disconnected. *then* it drains the channels.
|
|
|
|
if !p.Connected() {
|
|
|
|
// avoid deadlock...
|
|
|
|
if doneChan != nil {
|
|
|
|
go func() {
|
|
|
|
doneChan <- false
|
|
|
|
}()
|
|
|
|
}
|
|
|
|
return
|
|
|
|
}
|
2013-10-16 16:49:09 +02:00
|
|
|
p.outputQueue <- outMsg{msg: msg, doneChan: doneChan}
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-09 17:58:56 +02:00
|
|
|
// QueueInventory adds the passed inventory to the inventory send queue which
|
|
|
|
// might not be sent right away, rather it is trickled to the peer in batches.
|
|
|
|
// Inventory that the peer is already known to have is ignored. It is safe for
|
|
|
|
// concurrent access.
|
|
|
|
func (p *peer) QueueInventory(invVect *btcwire.InvVect) {
|
|
|
|
// Don't add the inventory to the send queue if the peer is
|
|
|
|
// already known to have it.
|
|
|
|
if p.isKnownInventory(invVect) {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2013-12-20 14:06:37 +01:00
|
|
|
// Avoid risk of deadlock if goroutine already exited. The goroutine
|
|
|
|
// we will be sending to hangs around until it knows for a fact that
|
|
|
|
// it is marked as disconnected. *then* it drains the channels.
|
|
|
|
if !p.Connected() {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2013-09-09 17:58:56 +02:00
|
|
|
p.outputInvChan <- invVect
|
|
|
|
}
|
|
|
|
|
2013-10-04 17:44:36 +02:00
|
|
|
// Connected returns whether or not the peer is currently connected.
|
|
|
|
func (p *peer) Connected() bool {
|
|
|
|
return atomic.LoadInt32(&p.connected) != 0 &&
|
|
|
|
atomic.LoadInt32(&p.disconnect) == 0
|
|
|
|
}
|
|
|
|
|
|
|
|
// Disconnect disconnects the peer by closing the connection. It also sets
|
|
|
|
// a flag so the impending shutdown can be detected.
|
|
|
|
func (p *peer) Disconnect() {
|
|
|
|
// did we win the race?
|
|
|
|
if atomic.AddInt32(&p.disconnect, 1) != 1 {
|
|
|
|
return
|
|
|
|
}
|
2013-12-20 14:06:37 +01:00
|
|
|
peerLog.Tracef("disconnecting %s", p.addr)
|
2013-10-04 17:44:36 +02:00
|
|
|
close(p.quit)
|
|
|
|
if atomic.LoadInt32(&p.connected) != 0 {
|
|
|
|
p.conn.Close()
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-08-06 23:55:22 +02:00
|
|
|
// Start begins processing input and output messages. It also sends the initial
|
|
|
|
// version message for outbound connections to start the negotiation process.
|
|
|
|
func (p *peer) Start() error {
|
|
|
|
// Already started?
|
2013-10-03 01:33:42 +02:00
|
|
|
if atomic.AddInt32(&p.started, 1) != 1 {
|
2013-08-06 23:55:22 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Starting peer %s", p.addr)
|
2013-08-06 23:55:22 +02:00
|
|
|
|
|
|
|
// Send an initial version message if this is an outbound connection.
|
|
|
|
if !p.inbound {
|
|
|
|
err := p.pushVersionMsg()
|
|
|
|
if err != nil {
|
2013-10-10 21:13:54 +02:00
|
|
|
p.logError("PEER: Can't send outbound version "+
|
2013-09-18 00:39:22 +02:00
|
|
|
"message %v", err)
|
2013-10-03 00:06:29 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Start processing input and output.
|
|
|
|
go p.inHandler()
|
2013-12-20 14:06:37 +01:00
|
|
|
// queueWg is kept so that outHandler knows when the queue has exited so
|
|
|
|
// it can drain correctly.
|
|
|
|
p.queueWg.Add(1)
|
|
|
|
go p.queueHandler()
|
2013-08-06 23:55:22 +02:00
|
|
|
go p.outHandler()
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-10-06 00:40:54 +02:00
|
|
|
// Shutdown gracefully shuts down the peer by disconnecting it.
|
2013-08-09 22:47:06 +02:00
|
|
|
func (p *peer) Shutdown() {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Tracef("Shutdown peer %s", p.addr)
|
2013-08-09 22:47:06 +02:00
|
|
|
p.Disconnect()
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
|
|
|
|
2013-09-12 21:19:10 +02:00
|
|
|
// newPeerBase returns a new base bitcoin peer for the provided server and
|
|
|
|
// inbound flag. This is used by the newInboundPeer and newOutboundPeer
|
|
|
|
// functions to perform base setup needed by both types of peers.
|
|
|
|
func newPeerBase(s *server, inbound bool) *peer {
|
2013-08-01 19:00:14 +02:00
|
|
|
p := peer{
|
|
|
|
server: s,
|
|
|
|
protocolVersion: btcwire.ProtocolVersion,
|
|
|
|
btcnet: s.btcnet,
|
|
|
|
services: btcwire.SFNodeNetwork,
|
2013-09-12 21:19:10 +02:00
|
|
|
inbound: inbound,
|
2013-08-06 23:55:22 +02:00
|
|
|
knownAddresses: make(map[string]bool),
|
2013-09-09 17:58:56 +02:00
|
|
|
knownInventory: NewMruInventoryMap(maxKnownInventory),
|
2013-10-08 17:47:00 +02:00
|
|
|
requestedTxns: make(map[btcwire.ShaHash]bool),
|
2013-10-01 00:53:21 +02:00
|
|
|
requestedBlocks: make(map[btcwire.ShaHash]bool),
|
2013-08-29 21:44:43 +02:00
|
|
|
requestQueue: list.New(),
|
2013-10-11 19:30:14 +02:00
|
|
|
outputQueue: make(chan outMsg, outputBufferSize),
|
2013-12-24 17:32:20 +01:00
|
|
|
sendQueue: make(chan outMsg, 1), // nonblocking sync
|
|
|
|
sendDoneQueue: make(chan bool, 1), // nonblocking sync
|
2013-09-09 17:58:56 +02:00
|
|
|
outputInvChan: make(chan *btcwire.InvVect, outputBufferSize),
|
2013-10-08 17:47:00 +02:00
|
|
|
txProcessed: make(chan bool, 1),
|
2013-08-16 20:35:38 +02:00
|
|
|
blockProcessed: make(chan bool, 1),
|
2013-08-06 23:55:22 +02:00
|
|
|
quit: make(chan bool),
|
|
|
|
}
|
2013-09-12 21:19:10 +02:00
|
|
|
return &p
|
|
|
|
}
|
|
|
|
|
|
|
|
// newPeer returns a new inbound bitcoin peer for the provided server and
|
|
|
|
// connection. Use Start to begin processing incoming and outgoing messages.
|
|
|
|
func newInboundPeer(s *server, conn net.Conn) *peer {
|
|
|
|
p := newPeerBase(s, true)
|
|
|
|
p.conn = conn
|
|
|
|
p.addr = conn.RemoteAddr().String()
|
2013-10-18 19:48:51 +02:00
|
|
|
p.timeConnected = time.Now()
|
2013-10-03 00:06:29 +02:00
|
|
|
atomic.AddInt32(&p.connected, 1)
|
2013-09-12 21:19:10 +02:00
|
|
|
return p
|
|
|
|
}
|
|
|
|
|
|
|
|
// newOutbountPeer returns a new outbound bitcoin peer for the provided server and
|
|
|
|
// address and connects to it asynchronously. If the connection is successful
|
|
|
|
// then the peer will also be started.
|
|
|
|
func newOutboundPeer(s *server, addr string, persistent bool) *peer {
|
|
|
|
p := newPeerBase(s, false)
|
|
|
|
p.addr = addr
|
|
|
|
p.persistent = persistent
|
|
|
|
|
|
|
|
// Setup p.na with a temporary address that we are connecting to with
|
|
|
|
// faked up service flags. We will replace this with the real one after
|
|
|
|
// version negotiation is successful. The only failure case here would
|
2013-08-01 19:00:14 +02:00
|
|
|
// be if the string was incomplete for connection so can't be split
|
2013-09-12 21:19:10 +02:00
|
|
|
// into address and port, and thus this would be invalid anyway. In
|
|
|
|
// which case we return nil to be handled by the caller. This must be
|
|
|
|
// done before we fork off the goroutine because as soon as this
|
|
|
|
// function returns the peer must have a valid netaddress.
|
2013-11-28 01:11:16 +01:00
|
|
|
host, portStr, err := net.SplitHostPort(addr)
|
2013-08-01 19:00:14 +02:00
|
|
|
if err != nil {
|
2013-10-02 23:49:31 +02:00
|
|
|
p.logError("Tried to create a new outbound peer with invalid "+
|
2013-08-01 19:00:14 +02:00
|
|
|
"address %s: %v", addr, err)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
port, err := strconv.ParseUint(portStr, 10, 16)
|
|
|
|
if err != nil {
|
2013-10-02 23:49:31 +02:00
|
|
|
p.logError("Tried to create a new outbound peer with invalid "+
|
2013-08-01 19:00:14 +02:00
|
|
|
"port %s: %v", portStr, err)
|
|
|
|
return nil
|
|
|
|
}
|
2013-11-28 01:11:16 +01:00
|
|
|
|
|
|
|
p.na, err = hostToNetAddress(host, uint16(port), 0)
|
|
|
|
if err != nil {
|
|
|
|
p.logError("Can not turn host %s into netaddress: %v",
|
|
|
|
host, err)
|
|
|
|
return nil
|
|
|
|
}
|
2013-08-01 19:00:14 +02:00
|
|
|
|
|
|
|
go func() {
|
|
|
|
// Attempt to connect to the peer. If the connection fails and
|
|
|
|
// this is a persistent connection, retry after the retry
|
|
|
|
// interval.
|
2013-10-02 02:45:21 +02:00
|
|
|
for atomic.LoadInt32(&p.disconnect) == 0 {
|
2013-12-17 16:10:59 +01:00
|
|
|
srvrLog.Debugf("Attempting to connect to %s", addr)
|
2014-01-10 08:31:20 +01:00
|
|
|
conn, err := btcdDial("tcp", addr)
|
2013-08-01 19:00:14 +02:00
|
|
|
if err != nil {
|
2013-12-24 17:32:20 +01:00
|
|
|
p.retryCount += 1
|
2013-11-21 19:03:56 +01:00
|
|
|
srvrLog.Debugf("Failed to connect to %s: %v",
|
2013-12-17 16:10:59 +01:00
|
|
|
addr, err)
|
2013-08-01 19:00:14 +02:00
|
|
|
if !persistent {
|
2013-09-12 21:19:10 +02:00
|
|
|
p.server.donePeers <- p
|
2013-08-01 19:00:14 +02:00
|
|
|
return
|
|
|
|
}
|
2013-12-24 17:32:20 +01:00
|
|
|
scaledInterval := connectionRetryInterval.Nanoseconds() * p.retryCount / 2
|
2013-09-26 23:45:10 +02:00
|
|
|
scaledDuration := time.Duration(scaledInterval)
|
2013-11-21 19:03:56 +01:00
|
|
|
srvrLog.Debugf("Retrying connection to %s in "+
|
2013-12-17 16:10:59 +01:00
|
|
|
"%s", addr, scaledDuration)
|
2013-09-26 23:45:10 +02:00
|
|
|
time.Sleep(scaledDuration)
|
2013-08-01 19:00:14 +02:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
2013-09-12 21:19:10 +02:00
|
|
|
// While we were sleeping trying to connect, the server
|
|
|
|
// may have scheduled a shutdown. In that case ditch
|
|
|
|
// the peer immediately.
|
2013-10-02 02:45:21 +02:00
|
|
|
if atomic.LoadInt32(&p.disconnect) == 0 {
|
2013-10-18 19:48:51 +02:00
|
|
|
p.timeConnected = time.Now()
|
2013-08-01 19:00:14 +02:00
|
|
|
p.server.addrManager.Attempt(p.na)
|
|
|
|
|
|
|
|
// Connection was successful so log it and start peer.
|
2013-11-21 19:03:56 +01:00
|
|
|
srvrLog.Debugf("Connected to %s",
|
2013-10-02 23:49:31 +02:00
|
|
|
conn.RemoteAddr())
|
2013-08-01 19:00:14 +02:00
|
|
|
p.conn = conn
|
2013-10-03 00:06:29 +02:00
|
|
|
atomic.AddInt32(&p.connected, 1)
|
2013-12-24 17:32:20 +01:00
|
|
|
p.retryCount = 0
|
2013-08-01 19:00:14 +02:00
|
|
|
p.Start()
|
|
|
|
}
|
2013-09-12 21:19:10 +02:00
|
|
|
|
2013-08-01 19:00:14 +02:00
|
|
|
return
|
|
|
|
}
|
|
|
|
}()
|
2013-09-12 21:19:10 +02:00
|
|
|
return p
|
2013-08-06 23:55:22 +02:00
|
|
|
}
|
2013-10-02 23:49:31 +02:00
|
|
|
|
|
|
|
// logError makes sure that we only log errors loudly on user peers.
|
2013-10-03 02:44:07 +02:00
|
|
|
func (p *peer) logError(fmt string, args ...interface{}) {
|
2013-10-02 23:49:31 +02:00
|
|
|
if p.persistent {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Errorf(fmt, args...)
|
2013-10-02 23:49:31 +02:00
|
|
|
} else {
|
2013-11-21 19:03:56 +01:00
|
|
|
peerLog.Debugf(fmt, args...)
|
2013-10-02 23:49:31 +02:00
|
|
|
}
|
|
|
|
}
|