2015-12-21 00:16:38 +03:00
|
|
|
package main
|
|
|
|
|
|
|
|
import (
|
2016-01-14 08:41:46 +03:00
|
|
|
"container/list"
|
2017-03-16 04:56:25 +03:00
|
|
|
"crypto/sha256"
|
2016-07-10 02:41:06 +03:00
|
|
|
"fmt"
|
2015-12-21 02:10:09 +03:00
|
|
|
"net"
|
2015-12-21 00:16:38 +03:00
|
|
|
"sync"
|
2016-01-14 08:41:46 +03:00
|
|
|
"sync/atomic"
|
2015-12-21 00:16:38 +03:00
|
|
|
"time"
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
"github.com/davecgh/go-spew/spew"
|
2017-04-21 01:45:04 +03:00
|
|
|
"github.com/lightningnetwork/lnd/brontide"
|
2017-05-02 23:04:58 +03:00
|
|
|
|
|
|
|
"github.com/btcsuite/fastsha256"
|
|
|
|
|
|
|
|
"bytes"
|
|
|
|
|
|
|
|
"github.com/go-errors/errors"
|
2017-05-05 02:03:47 +03:00
|
|
|
"github.com/lightningnetwork/lnd/chainntnfs"
|
2016-06-21 22:32:32 +03:00
|
|
|
"github.com/lightningnetwork/lnd/channeldb"
|
2017-05-02 23:04:58 +03:00
|
|
|
"github.com/lightningnetwork/lnd/htlcswitch"
|
2016-08-31 02:52:53 +03:00
|
|
|
"github.com/lightningnetwork/lnd/lnrpc"
|
2016-01-18 06:14:47 +03:00
|
|
|
"github.com/lightningnetwork/lnd/lnwallet"
|
|
|
|
"github.com/lightningnetwork/lnd/lnwire"
|
2016-06-21 22:32:32 +03:00
|
|
|
"github.com/roasbeef/btcd/btcec"
|
2017-01-06 00:56:27 +03:00
|
|
|
"github.com/roasbeef/btcd/chaincfg/chainhash"
|
2017-01-06 00:58:06 +03:00
|
|
|
"github.com/roasbeef/btcd/connmgr"
|
2017-03-25 04:26:09 +03:00
|
|
|
"github.com/roasbeef/btcd/txscript"
|
2016-05-15 17:17:44 +03:00
|
|
|
"github.com/roasbeef/btcd/wire"
|
2016-01-17 06:03:03 +03:00
|
|
|
)
|
|
|
|
|
|
|
|
var (
|
|
|
|
numNodes int32
|
2015-12-21 00:16:38 +03:00
|
|
|
)
|
|
|
|
|
|
|
|
const (
|
2016-06-21 22:32:32 +03:00
|
|
|
// pingInterval is the interval at which ping messages are sent.
|
2017-01-23 01:35:26 +03:00
|
|
|
pingInterval = 1 * time.Minute
|
2016-01-17 06:03:03 +03:00
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// outgoingQueueLen is the buffer size of the channel which houses
|
|
|
|
// messages to be sent across the wire, requested by objects outside
|
|
|
|
// this struct.
|
2016-01-17 06:03:03 +03:00
|
|
|
outgoingQueueLen = 50
|
2015-12-21 00:16:38 +03:00
|
|
|
)
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// outgoinMsg packages an lnwire.Message to be sent out on the wire, along with
|
|
|
|
// a buffered channel which will be sent upon once the write is complete. This
|
|
|
|
// buffered channel acts as a semaphore to be used for synchronization purposes.
|
2016-01-14 08:41:46 +03:00
|
|
|
type outgoinMsg struct {
|
|
|
|
msg lnwire.Message
|
2016-06-21 22:32:32 +03:00
|
|
|
sentChan chan struct{} // MUST be buffered.
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2017-01-24 05:19:54 +03:00
|
|
|
// newChannelMsg packages a lnwallet.LightningChannel with a channel that
|
|
|
|
// allows the receiver of the request to report when the funding transaction
|
|
|
|
// has been confirmed and the channel creation process completed.
|
|
|
|
type newChannelMsg struct {
|
|
|
|
channel *lnwallet.LightningChannel
|
|
|
|
done chan struct{}
|
|
|
|
}
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// chanSnapshotReq is a message sent by outside subsystems to a peer in order
|
2016-06-23 08:22:06 +03:00
|
|
|
// to gain a snapshot of the peer's currently active channels.
|
|
|
|
type chanSnapshotReq struct {
|
|
|
|
resp chan []*channeldb.ChannelSnapshot
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// peer is an active peer on the Lightning Network. This struct is responsible
|
2016-11-11 04:15:25 +03:00
|
|
|
// for managing any channel state related to this peer. To do so, it has
|
|
|
|
// several helper goroutines to handle events such as HTLC timeouts, new
|
|
|
|
// funding workflow, and detecting an uncooperative closure of any active
|
|
|
|
// channels.
|
2016-09-26 20:39:47 +03:00
|
|
|
// TODO(roasbeef): proper reconnection logic
|
2015-12-21 00:16:38 +03:00
|
|
|
type peer struct {
|
2017-01-30 11:53:09 +03:00
|
|
|
// The following fields are only meant to be used *atomically*
|
|
|
|
bytesReceived uint64
|
|
|
|
bytesSent uint64
|
|
|
|
|
|
|
|
// pingTime is a rough estimate of the RTT (round-trip-time) between us
|
|
|
|
// and the connected peer. This time is expressed in micro seconds.
|
|
|
|
// TODO(roasbeef): also use a WMA or EMA?
|
|
|
|
pingTime int64
|
|
|
|
|
|
|
|
// pingLastSend is the Unix time expressed in nanoseconds when we sent
|
|
|
|
// our last ping message.
|
|
|
|
pingLastSend int64
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// MUST be used atomically.
|
2015-12-21 00:16:38 +03:00
|
|
|
started int32
|
2016-01-17 06:03:03 +03:00
|
|
|
disconnect int32
|
2015-12-21 00:16:38 +03:00
|
|
|
|
2016-12-15 05:11:31 +03:00
|
|
|
connReq *connmgr.ConnReq
|
|
|
|
conn net.Conn
|
2015-12-21 00:16:38 +03:00
|
|
|
|
2016-10-28 05:49:10 +03:00
|
|
|
addr *lnwire.NetAddress
|
2017-01-06 00:56:27 +03:00
|
|
|
lightningID chainhash.Hash
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2016-06-23 08:22:06 +03:00
|
|
|
inbound bool
|
|
|
|
id int32
|
2015-12-21 00:16:38 +03:00
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// This mutex protects all the stats below it.
|
2016-01-17 06:03:03 +03:00
|
|
|
sync.RWMutex
|
2016-06-21 22:32:32 +03:00
|
|
|
timeConnected time.Time
|
|
|
|
lastSend time.Time
|
|
|
|
lastRecv time.Time
|
|
|
|
|
|
|
|
// sendQueue is the channel which is used to queue outgoing to be
|
|
|
|
// written onto the wire. Note that this channel is unbuffered.
|
|
|
|
sendQueue chan outgoinMsg
|
|
|
|
|
|
|
|
// outgoingQueue is a buffered channel which allows second/third party
|
|
|
|
// objects to queue messages to be sent out on the wire.
|
2016-01-14 08:41:46 +03:00
|
|
|
outgoingQueue chan outgoinMsg
|
2015-12-21 00:16:38 +03:00
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// sendQueueSync is used as a semaphore to synchronize writes between
|
|
|
|
// the writeHandler and the queueHandler.
|
|
|
|
sendQueueSync chan struct{}
|
2015-12-21 00:16:38 +03:00
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// activeChannels is a map which stores the state machines of all
|
|
|
|
// active channels. Channels are indexed into the map by the txid of
|
|
|
|
// the funding transaction which opened the channel.
|
2016-11-18 05:43:33 +03:00
|
|
|
activeChanMtx sync.RWMutex
|
2017-04-17 01:41:11 +03:00
|
|
|
activeChannels map[lnwire.ChannelID]*lnwallet.LightningChannel
|
2016-06-23 08:22:06 +03:00
|
|
|
chanSnapshotReqs chan *chanSnapshotReq
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
// newChannels is used by the fundingManager to send fully opened
|
|
|
|
// channels to the source peer which handled the funding workflow.
|
2017-01-24 05:19:54 +03:00
|
|
|
newChannels chan *newChannelMsg
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2016-11-11 04:15:25 +03:00
|
|
|
// localCloseChanReqs is a channel in which any local requests to close
|
|
|
|
// a particular channel are sent over.
|
2017-05-02 23:04:58 +03:00
|
|
|
localCloseChanReqs chan *htlcswitch.ChanClose
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-03-25 04:26:09 +03:00
|
|
|
// shutdownChanReqs is used to send the Shutdown messages that initiate
|
|
|
|
// the cooperative close workflow.
|
|
|
|
shutdownChanReqs chan *lnwire.Shutdown
|
|
|
|
|
|
|
|
// closingSignedChanReqs is used to send signatures for proposed
|
|
|
|
// channel close transactions during the cooperative close workflow.
|
|
|
|
closingSignedChanReqs chan *lnwire.ClosingSigned
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
server *server
|
2015-12-21 00:16:38 +03:00
|
|
|
|
2017-02-16 15:39:38 +03:00
|
|
|
// localSharedFeatures is a product of comparison of our and their
|
|
|
|
// local features vectors which consist of features which are present
|
|
|
|
// on both sides.
|
2017-02-23 01:49:04 +03:00
|
|
|
localSharedFeatures *lnwire.SharedFeatures
|
2017-02-16 15:39:38 +03:00
|
|
|
|
|
|
|
// globalSharedFeatures is a product of comparison of our and their
|
|
|
|
// global features vectors which consist of features which are present
|
|
|
|
// on both sides.
|
|
|
|
globalSharedFeatures *lnwire.SharedFeatures
|
|
|
|
|
2015-12-21 00:16:38 +03:00
|
|
|
queueQuit chan struct{}
|
|
|
|
quit chan struct{}
|
2016-01-14 08:41:46 +03:00
|
|
|
wg sync.WaitGroup
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// newPeer creates a new peer from an establish connection object, and a
|
|
|
|
// pointer to the main server.
|
2017-02-22 12:10:07 +03:00
|
|
|
func newPeer(conn net.Conn, connReq *connmgr.ConnReq, server *server,
|
|
|
|
addr *lnwire.NetAddress, inbound bool) (*peer, error) {
|
2016-10-28 05:49:10 +03:00
|
|
|
|
|
|
|
nodePub := addr.IdentityKey
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
p := &peer{
|
|
|
|
conn: conn,
|
2017-03-16 04:56:25 +03:00
|
|
|
lightningID: chainhash.Hash(sha256.Sum256(nodePub.SerializeCompressed())),
|
2016-10-28 05:49:10 +03:00
|
|
|
addr: addr,
|
|
|
|
|
|
|
|
id: atomic.AddInt32(&numNodes, 1),
|
|
|
|
inbound: inbound,
|
2017-02-22 12:10:07 +03:00
|
|
|
connReq: connReq,
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
server: server,
|
2016-01-17 06:03:03 +03:00
|
|
|
|
|
|
|
sendQueueSync: make(chan struct{}, 1),
|
|
|
|
sendQueue: make(chan outgoinMsg, 1),
|
|
|
|
outgoingQueue: make(chan outgoinMsg, outgoingQueueLen),
|
|
|
|
|
2017-04-17 01:41:11 +03:00
|
|
|
activeChannels: make(map[lnwire.ChannelID]*lnwallet.LightningChannel),
|
2016-06-23 08:22:06 +03:00
|
|
|
chanSnapshotReqs: make(chan *chanSnapshotReq),
|
2017-01-24 05:19:54 +03:00
|
|
|
newChannels: make(chan *newChannelMsg, 1),
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
localCloseChanReqs: make(chan *htlcswitch.ChanClose),
|
2017-03-25 04:26:09 +03:00
|
|
|
shutdownChanReqs: make(chan *lnwire.Shutdown),
|
|
|
|
closingSignedChanReqs: make(chan *lnwire.ClosingSigned),
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-02-17 17:28:11 +03:00
|
|
|
localSharedFeatures: nil,
|
|
|
|
globalSharedFeatures: nil,
|
2017-02-16 15:39:38 +03:00
|
|
|
|
2016-01-17 06:03:03 +03:00
|
|
|
queueQuit: make(chan struct{}),
|
|
|
|
quit: make(chan struct{}),
|
|
|
|
}
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
return p, nil
|
|
|
|
}
|
|
|
|
|
2017-04-12 07:59:45 +03:00
|
|
|
// Start starts all helper goroutines the peer needs for normal operations. In
|
|
|
|
// the case this peer has already been started, then this function is a loop.
|
2016-01-17 06:03:03 +03:00
|
|
|
func (p *peer) Start() error {
|
|
|
|
if atomic.AddInt32(&p.started, 1) != 1 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
peerLog.Tracef("peer %v starting", p)
|
2016-01-17 06:03:03 +03:00
|
|
|
|
2017-03-17 05:45:10 +03:00
|
|
|
// Exchange local and global features, the init message should be very
|
|
|
|
// first between two nodes.
|
2017-02-16 15:39:38 +03:00
|
|
|
if err := p.sendInitMsg(); err != nil {
|
2017-04-24 05:24:28 +03:00
|
|
|
return fmt.Errorf("unable to send init msg: %v", err)
|
2017-02-16 15:39:38 +03:00
|
|
|
}
|
|
|
|
|
2017-03-17 05:45:10 +03:00
|
|
|
// Before we launch any of the helper goroutines off the peer struct,
|
2017-04-24 05:24:28 +03:00
|
|
|
// we'll first ensure proper adherence to the p2p protocol. The init
|
2017-03-17 05:45:10 +03:00
|
|
|
// message MUST be sent before any other message.
|
2017-03-30 04:33:20 +03:00
|
|
|
readErr := make(chan error, 1)
|
|
|
|
msgChan := make(chan lnwire.Message, 1)
|
|
|
|
go func() {
|
2017-04-20 02:23:17 +03:00
|
|
|
msg, err := p.readNextMessage()
|
2017-03-30 04:33:20 +03:00
|
|
|
if err != nil {
|
|
|
|
readErr <- err
|
|
|
|
msgChan <- nil
|
|
|
|
}
|
|
|
|
readErr <- nil
|
|
|
|
msgChan <- msg
|
|
|
|
}()
|
|
|
|
|
|
|
|
select {
|
2017-04-12 07:59:45 +03:00
|
|
|
// In order to avoid blocking indefinitely, we'll give the other peer
|
2017-04-14 00:48:38 +03:00
|
|
|
// an upper timeout of 15 seconds to respond before we bail out early.
|
|
|
|
case <-time.After(time.Second * 15):
|
2017-03-30 04:33:20 +03:00
|
|
|
return fmt.Errorf("peer did not complete handshake within 5 " +
|
|
|
|
"seconds")
|
|
|
|
case err := <-readErr:
|
|
|
|
if err != nil {
|
2017-04-24 05:24:28 +03:00
|
|
|
return fmt.Errorf("unable to read init msg: %v", err)
|
2017-03-30 04:33:20 +03:00
|
|
|
}
|
2017-02-16 15:39:38 +03:00
|
|
|
}
|
|
|
|
|
2017-05-11 03:37:59 +03:00
|
|
|
// Once the init message arrives, we can parse it so we can figure out
|
|
|
|
// the negotiation of features for this session.
|
2017-03-30 04:33:20 +03:00
|
|
|
msg := <-msgChan
|
2017-02-16 15:39:38 +03:00
|
|
|
if msg, ok := msg.(*lnwire.Init); ok {
|
|
|
|
if err := p.handleInitMsg(msg); err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
return errors.New("very first message between nodes " +
|
|
|
|
"must be init message")
|
|
|
|
}
|
|
|
|
|
2017-04-24 05:23:15 +03:00
|
|
|
// Fetch and then load all the active channels we have with this remote
|
|
|
|
// peer from the database.
|
|
|
|
activeChans, err := p.server.chanDB.FetchOpenChannels(p.addr.IdentityKey)
|
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("unable to fetch active chans "+
|
|
|
|
"for peer %v: %v", p, err)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Next, load all the active channels we have with this peer,
|
|
|
|
// registering them with the switch and launching the necessary
|
|
|
|
// goroutines required to operate them.
|
|
|
|
peerLog.Debugf("Loaded %v active channels from database with "+
|
|
|
|
"peerID(%v)", len(activeChans), p.id)
|
|
|
|
if err := p.loadActiveChannels(activeChans); err != nil {
|
|
|
|
return fmt.Errorf("unable to load channels: %v", err)
|
|
|
|
}
|
|
|
|
|
2017-05-11 03:37:59 +03:00
|
|
|
p.wg.Add(5)
|
|
|
|
go p.queueHandler()
|
|
|
|
go p.writeHandler()
|
|
|
|
go p.readHandler()
|
|
|
|
go p.channelManager()
|
|
|
|
go p.pingHandler()
|
|
|
|
|
2016-01-17 06:03:03 +03:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-04-24 05:23:15 +03:00
|
|
|
// loadActiveChannels creates indexes within the peer for tracking all active
|
|
|
|
// channels returned by the database.
|
|
|
|
func (p *peer) loadActiveChannels(chans []*channeldb.OpenChannel) error {
|
|
|
|
for _, dbChan := range chans {
|
|
|
|
// If the channel isn't yet open, then we don't need to process
|
|
|
|
// it any further.
|
|
|
|
if dbChan.IsPending {
|
|
|
|
continue
|
|
|
|
}
|
2016-01-17 06:03:03 +03:00
|
|
|
|
2017-05-18 21:55:25 +03:00
|
|
|
lnChan, err := lnwallet.NewLightningChannel(p.server.cc.signer,
|
|
|
|
p.server.cc.chainNotifier, p.server.cc.feeEstimator, dbChan)
|
2017-04-24 05:23:15 +03:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2016-01-17 06:03:03 +03:00
|
|
|
|
2017-04-24 05:23:15 +03:00
|
|
|
chanPoint := *dbChan.ChanID
|
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(&chanPoint)
|
|
|
|
|
|
|
|
p.activeChanMtx.Lock()
|
|
|
|
p.activeChannels[chanID] = lnChan
|
|
|
|
p.activeChanMtx.Unlock()
|
|
|
|
|
|
|
|
peerLog.Infof("peerID(%v) loaded ChannelPoint(%v)", p.id, chanPoint)
|
|
|
|
|
|
|
|
p.server.breachArbiter.newContracts <- lnChan
|
|
|
|
|
|
|
|
// Register this new channel link with the HTLC Switch. This is
|
|
|
|
// necessary to properly route multi-hop payments, and forward
|
|
|
|
// new payments triggered by RPC clients.
|
2017-05-02 23:04:58 +03:00
|
|
|
sphinxDecoder := htlcswitch.NewSphinxDecoder(p.server.sphinx)
|
|
|
|
link := htlcswitch.NewChannelLink(
|
|
|
|
&htlcswitch.ChannelLinkConfig{
|
|
|
|
Peer: p,
|
|
|
|
DecodeOnion: sphinxDecoder.Decode,
|
|
|
|
SettledContracts: p.server.breachArbiter.settledContracts,
|
|
|
|
DebugHTLC: cfg.DebugHTLC,
|
|
|
|
Registry: p.server.invoices,
|
|
|
|
Switch: p.server.htlcSwitch,
|
|
|
|
}, lnChan)
|
|
|
|
|
|
|
|
if err := p.server.htlcSwitch.AddLink(link); err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2017-04-24 05:23:15 +03:00
|
|
|
}
|
2016-01-17 06:03:03 +03:00
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-04-24 05:29:38 +03:00
|
|
|
// WaitForDisconnect waits until the peer has disconnected. A peer may be
|
|
|
|
// disconnected if the local or remote side terminating the connection, or an
|
|
|
|
// irrecoverable protocol error has been encountered.
|
|
|
|
func (p *peer) WaitForDisconnect() {
|
|
|
|
<-p.quit
|
|
|
|
|
|
|
|
}
|
2017-02-21 09:06:16 +03:00
|
|
|
|
2016-07-14 02:40:01 +03:00
|
|
|
// Disconnect terminates the connection with the remote peer. Additionally, a
|
|
|
|
// signal is sent to the server and htlcSwitch indicating the resources
|
|
|
|
// allocated to the peer can now be cleaned up.
|
|
|
|
func (p *peer) Disconnect() {
|
|
|
|
if !atomic.CompareAndSwapInt32(&p.disconnect, 0, 1) {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
peerLog.Tracef("Disconnecting %s", p)
|
2017-02-07 02:04:52 +03:00
|
|
|
|
|
|
|
// Ensure that the TCP connection is properly closed before continuing.
|
|
|
|
p.conn.Close()
|
2016-07-14 02:40:01 +03:00
|
|
|
|
|
|
|
close(p.quit)
|
|
|
|
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// String returns the string representation of this peer.
|
|
|
|
func (p *peer) String() string {
|
|
|
|
return p.conn.RemoteAddr().String()
|
|
|
|
}
|
|
|
|
|
|
|
|
// readNextMessage reads, and returns the next message on the wire along with
|
|
|
|
// any additional raw payload.
|
2017-04-20 02:23:17 +03:00
|
|
|
func (p *peer) readNextMessage() (lnwire.Message, error) {
|
2017-04-21 01:45:04 +03:00
|
|
|
noiseConn, ok := p.conn.(*brontide.Conn)
|
|
|
|
if !ok {
|
|
|
|
return nil, fmt.Errorf("brontide.Conn required to read messages")
|
|
|
|
}
|
|
|
|
|
|
|
|
// First we'll read the next _full_ message. We do this rather than
|
|
|
|
// reading incrementally from the stream as the Lightning wire protocol
|
|
|
|
// is message oriented and allows nodes to pad on additional data to
|
|
|
|
// the message stream.
|
|
|
|
rawMsg, err := noiseConn.ReadNextMessage()
|
|
|
|
atomic.AddUint64(&p.bytesReceived, uint64(len(rawMsg)))
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Next, create a new io.Reader implementation from the raw message,
|
|
|
|
// and use this to decode the message directly from.
|
|
|
|
msgReader := bytes.NewReader(rawMsg)
|
|
|
|
nextMsg, err := lnwire.ReadMessage(msgReader, 0)
|
2016-01-14 08:41:46 +03:00
|
|
|
if err != nil {
|
2017-04-20 02:23:17 +03:00
|
|
|
return nil, err
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// TODO(roasbeef): add message summaries
|
2017-01-15 04:52:05 +03:00
|
|
|
p.logWireMessage(nextMsg, true)
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-04-20 02:23:17 +03:00
|
|
|
return nextMsg, nil
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// readHandler is responsible for reading messages off the wire in series, then
|
2017-01-13 08:01:50 +03:00
|
|
|
// properly dispatching the handling of the message to the proper subsystem.
|
2016-06-21 22:32:32 +03:00
|
|
|
//
|
|
|
|
// NOTE: This method MUST be run as a goroutine.
|
|
|
|
func (p *peer) readHandler() {
|
2017-04-17 01:45:18 +03:00
|
|
|
var activeChanMtx sync.Mutex
|
|
|
|
activeChanStreams := make(map[lnwire.ChannelID]struct{})
|
|
|
|
|
2016-01-14 08:41:46 +03:00
|
|
|
out:
|
|
|
|
for atomic.LoadInt32(&p.disconnect) == 0 {
|
2017-04-20 02:23:17 +03:00
|
|
|
nextMsg, err := p.readNextMessage()
|
2016-01-14 08:41:46 +03:00
|
|
|
if err != nil {
|
2017-01-24 07:33:18 +03:00
|
|
|
peerLog.Infof("unable to read message from %v: %v",
|
|
|
|
p, err)
|
2017-01-17 05:03:34 +03:00
|
|
|
|
|
|
|
switch err.(type) {
|
|
|
|
// If this is just a message we don't yet recognize,
|
|
|
|
// we'll continue processing as normal as this allows
|
|
|
|
// us to introduce new messages in a forwards
|
|
|
|
// compatible manner.
|
|
|
|
case *lnwire.UnknownMessage:
|
|
|
|
continue
|
|
|
|
|
|
|
|
// If the error we encountered wasn't just a message we
|
|
|
|
// didn't recognize, then we'll stop all processing s
|
|
|
|
// this is a fatal error.
|
|
|
|
default:
|
|
|
|
break out
|
|
|
|
}
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2017-02-21 05:10:05 +03:00
|
|
|
var (
|
|
|
|
isChanUpdate bool
|
2017-04-17 01:41:11 +03:00
|
|
|
targetChan lnwire.ChannelID
|
2017-02-21 05:10:05 +03:00
|
|
|
)
|
2016-07-13 03:45:29 +03:00
|
|
|
|
2016-01-14 08:41:46 +03:00
|
|
|
switch msg := nextMsg.(type) {
|
2017-01-26 05:20:55 +03:00
|
|
|
case *lnwire.Pong:
|
|
|
|
// When we receive a Pong message in response to our
|
|
|
|
// last ping message, we'll use the time in which we
|
|
|
|
// sent the ping message to measure a rough estimate of
|
|
|
|
// round trip time.
|
|
|
|
pingSendTime := atomic.LoadInt64(&p.pingLastSend)
|
|
|
|
delay := (time.Now().UnixNano() - pingSendTime) / 1000
|
|
|
|
atomic.StoreInt64(&p.pingTime, delay)
|
|
|
|
|
2016-11-11 04:15:25 +03:00
|
|
|
case *lnwire.Ping:
|
2017-04-17 04:11:39 +03:00
|
|
|
pongBytes := make([]byte, msg.NumPongBytes)
|
|
|
|
p.queueMsg(lnwire.NewPong(pongBytes), nil)
|
2016-11-11 04:15:25 +03:00
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
case *lnwire.SingleFundingRequest:
|
2017-01-13 06:40:38 +03:00
|
|
|
p.server.fundingMgr.processFundingRequest(msg, p.addr)
|
2016-06-21 22:32:32 +03:00
|
|
|
case *lnwire.SingleFundingResponse:
|
2017-01-13 06:40:38 +03:00
|
|
|
p.server.fundingMgr.processFundingResponse(msg, p.addr)
|
2016-06-21 22:32:32 +03:00
|
|
|
case *lnwire.SingleFundingComplete:
|
2017-01-13 06:40:38 +03:00
|
|
|
p.server.fundingMgr.processFundingComplete(msg, p.addr)
|
2016-06-21 22:32:32 +03:00
|
|
|
case *lnwire.SingleFundingSignComplete:
|
2017-01-13 06:40:38 +03:00
|
|
|
p.server.fundingMgr.processFundingSignComplete(msg, p.addr)
|
2017-01-31 05:45:28 +03:00
|
|
|
case *lnwire.FundingLocked:
|
|
|
|
p.server.fundingMgr.processFundingLocked(msg, p.addr)
|
2017-03-25 04:26:09 +03:00
|
|
|
|
|
|
|
case *lnwire.Shutdown:
|
|
|
|
p.shutdownChanReqs <- msg
|
2017-03-09 02:32:11 +03:00
|
|
|
case *lnwire.ClosingSigned:
|
2017-03-25 04:26:09 +03:00
|
|
|
p.closingSignedChanReqs <- msg
|
2016-10-15 16:24:56 +03:00
|
|
|
|
2017-04-17 01:41:11 +03:00
|
|
|
case *lnwire.Error:
|
|
|
|
p.server.fundingMgr.processFundingError(msg, p.addr)
|
2016-12-27 08:42:23 +03:00
|
|
|
|
2017-01-08 07:23:06 +03:00
|
|
|
// TODO(roasbeef): create ChanUpdater interface for the below
|
2017-02-21 05:10:05 +03:00
|
|
|
case *lnwire.UpdateAddHTLC:
|
2016-10-15 16:18:38 +03:00
|
|
|
isChanUpdate = true
|
2017-04-17 01:41:11 +03:00
|
|
|
targetChan = msg.ChanID
|
2017-02-21 05:10:05 +03:00
|
|
|
case *lnwire.UpdateFufillHTLC:
|
2016-10-15 16:18:38 +03:00
|
|
|
isChanUpdate = true
|
2017-04-17 01:41:11 +03:00
|
|
|
targetChan = msg.ChanID
|
2017-02-21 05:10:05 +03:00
|
|
|
case *lnwire.UpdateFailHTLC:
|
2017-01-08 07:23:06 +03:00
|
|
|
isChanUpdate = true
|
2017-04-17 01:41:11 +03:00
|
|
|
targetChan = msg.ChanID
|
2017-02-21 05:10:05 +03:00
|
|
|
case *lnwire.RevokeAndAck:
|
2016-10-15 16:18:38 +03:00
|
|
|
isChanUpdate = true
|
2017-04-17 01:41:11 +03:00
|
|
|
targetChan = msg.ChanID
|
2017-02-21 05:10:05 +03:00
|
|
|
case *lnwire.CommitSig:
|
2016-10-15 16:18:38 +03:00
|
|
|
isChanUpdate = true
|
2017-04-17 01:41:11 +03:00
|
|
|
targetChan = msg.ChanID
|
2016-12-27 08:42:23 +03:00
|
|
|
|
2017-04-20 02:23:17 +03:00
|
|
|
case *lnwire.ChannelUpdate,
|
2016-12-27 08:42:23 +03:00
|
|
|
*lnwire.ChannelAnnouncement,
|
2017-03-28 22:08:14 +03:00
|
|
|
*lnwire.NodeAnnouncement,
|
|
|
|
*lnwire.AnnounceSignatures:
|
2016-12-27 08:42:23 +03:00
|
|
|
|
2017-03-20 00:06:10 +03:00
|
|
|
p.server.discoverSrv.ProcessRemoteAnnouncement(msg,
|
2016-12-27 08:42:23 +03:00
|
|
|
p.addr.IdentityKey)
|
2017-03-28 22:08:14 +03:00
|
|
|
default:
|
2017-03-27 20:25:44 +03:00
|
|
|
peerLog.Errorf("unknown message received from peer "+
|
|
|
|
"%v", p)
|
2016-07-13 03:45:29 +03:00
|
|
|
}
|
|
|
|
|
2016-10-15 16:18:38 +03:00
|
|
|
if isChanUpdate {
|
2017-04-17 01:45:18 +03:00
|
|
|
sendUpdate := func() {
|
2017-05-02 23:04:58 +03:00
|
|
|
// Dispatch the commitment update message to the proper
|
|
|
|
// active goroutine dedicated to this channel.
|
|
|
|
link, err := p.server.htlcSwitch.GetLink(targetChan)
|
|
|
|
if err != nil {
|
2017-04-17 01:45:18 +03:00
|
|
|
peerLog.Errorf("recv'd update for unknown "+
|
|
|
|
"channel %v from %v", targetChan, p)
|
|
|
|
return
|
|
|
|
}
|
2017-05-02 23:04:58 +03:00
|
|
|
link.HandleChannelUpdate(nextMsg)
|
2017-04-17 01:45:18 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
// Check the map of active channel streams, if this map
|
|
|
|
// has an entry, then this means the channel is fully
|
|
|
|
// open. In this case, we can send the channel update
|
|
|
|
// directly without any further waiting.
|
|
|
|
activeChanMtx.Lock()
|
|
|
|
_, ok := activeChanStreams[targetChan]
|
|
|
|
activeChanMtx.Unlock()
|
|
|
|
if ok {
|
|
|
|
sendUpdate()
|
2016-07-13 03:45:29 +03:00
|
|
|
continue
|
|
|
|
}
|
2017-04-17 01:45:18 +03:00
|
|
|
|
|
|
|
// Otherwise, we'll launch a goroutine to synchronize
|
|
|
|
// the processing of this message, with the opening of
|
|
|
|
// the channel as marked by the funding manage.
|
|
|
|
go func() {
|
|
|
|
// Block until the channel is marked open.
|
|
|
|
p.server.fundingMgr.waitUntilChannelOpen(targetChan)
|
|
|
|
|
|
|
|
// Once the channel is open, we'll mark the
|
|
|
|
// stream as active and send the update to the
|
|
|
|
// channel. Marking the stream lets us take the
|
|
|
|
// fast path above, skipping the check to the
|
|
|
|
// funding manager.
|
|
|
|
activeChanMtx.Lock()
|
|
|
|
activeChanStreams[targetChan] = struct{}{}
|
|
|
|
sendUpdate()
|
|
|
|
activeChanMtx.Unlock()
|
|
|
|
}()
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-07-14 02:40:01 +03:00
|
|
|
p.Disconnect()
|
|
|
|
|
2016-01-14 08:41:46 +03:00
|
|
|
p.wg.Done()
|
2016-07-14 02:40:01 +03:00
|
|
|
peerLog.Tracef("readHandler for peer %v done", p)
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2017-01-15 04:52:05 +03:00
|
|
|
// logWireMessage logs the receipt or sending of particular wire message. This
|
|
|
|
// function is used rather than just logging the message in order to produce
|
|
|
|
// less spammy log messages in trace mode by setting the 'Curve" parameter to
|
|
|
|
// nil. Doing this avoids printing out each of the field elements in the curve
|
|
|
|
// parameters for secp256k1.
|
|
|
|
func (p *peer) logWireMessage(msg lnwire.Message, read bool) {
|
|
|
|
switch m := msg.(type) {
|
2017-02-21 05:10:05 +03:00
|
|
|
case *lnwire.RevokeAndAck:
|
2017-01-15 04:52:05 +03:00
|
|
|
m.NextRevocationKey.Curve = nil
|
|
|
|
case *lnwire.NodeAnnouncement:
|
|
|
|
m.NodeID.Curve = nil
|
|
|
|
case *lnwire.ChannelAnnouncement:
|
2017-03-27 18:22:37 +03:00
|
|
|
m.NodeID1.Curve = nil
|
|
|
|
m.NodeID2.Curve = nil
|
|
|
|
m.BitcoinKey1.Curve = nil
|
|
|
|
m.BitcoinKey2.Curve = nil
|
2017-01-15 04:52:05 +03:00
|
|
|
case *lnwire.SingleFundingComplete:
|
|
|
|
m.RevocationKey.Curve = nil
|
|
|
|
case *lnwire.SingleFundingRequest:
|
|
|
|
m.CommitmentKey.Curve = nil
|
|
|
|
m.ChannelDerivationPoint.Curve = nil
|
|
|
|
case *lnwire.SingleFundingResponse:
|
|
|
|
m.ChannelDerivationPoint.Curve = nil
|
|
|
|
m.CommitmentKey.Curve = nil
|
|
|
|
m.RevocationKey.Curve = nil
|
2017-01-31 05:45:28 +03:00
|
|
|
case *lnwire.FundingLocked:
|
|
|
|
m.NextPerCommitmentPoint.Curve = nil
|
2017-01-15 04:52:05 +03:00
|
|
|
}
|
|
|
|
|
2017-01-25 04:43:38 +03:00
|
|
|
prefix := "readMessage from"
|
2017-01-15 04:52:05 +03:00
|
|
|
if !read {
|
2017-01-25 04:43:38 +03:00
|
|
|
prefix = "writeMessage to"
|
2017-01-15 04:52:05 +03:00
|
|
|
}
|
|
|
|
|
2017-01-25 04:43:38 +03:00
|
|
|
peerLog.Tracef(prefix+" %v: %v", p, newLogClosure(func() string {
|
2017-01-15 04:52:05 +03:00
|
|
|
return spew.Sdump(msg)
|
|
|
|
}))
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// writeMessage writes the target lnwire.Message to the remote peer.
|
2016-01-14 08:41:46 +03:00
|
|
|
func (p *peer) writeMessage(msg lnwire.Message) error {
|
|
|
|
// Simply exit if we're shutting down.
|
|
|
|
if atomic.LoadInt32(&p.disconnect) != 0 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// TODO(roasbeef): add message summaries
|
2017-01-15 04:52:05 +03:00
|
|
|
p.logWireMessage(msg, false)
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-04-21 01:45:04 +03:00
|
|
|
// As the Lightning wire protocol is fully message oriented, we only
|
|
|
|
// allows one wire message per outer encapsulated crypto message. So
|
|
|
|
// we'll create a temporary buffer to write the message directly to.
|
|
|
|
var msgPayload [lnwire.MaxMessagePayload]byte
|
|
|
|
b := bytes.NewBuffer(msgPayload[0:0:len(msgPayload)])
|
|
|
|
|
|
|
|
// With the temp buffer created and sliced properly (length zero, full
|
|
|
|
// capacity), we'll now encode the message directly into this buffer.
|
|
|
|
n, err := lnwire.WriteMessage(b, msg, 0)
|
2016-06-21 22:32:32 +03:00
|
|
|
atomic.AddUint64(&p.bytesSent, uint64(n))
|
2016-01-14 08:41:46 +03:00
|
|
|
|
2017-04-21 01:45:04 +03:00
|
|
|
// Finally, write the message itself in a single swoop.
|
|
|
|
_, err = p.conn.Write(b.Bytes())
|
2016-01-14 08:41:46 +03:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// writeHandler is a goroutine dedicated to reading messages off of an incoming
|
|
|
|
// queue, and writing them out to the wire. This goroutine coordinates with the
|
|
|
|
// queueHandler in order to ensure the incoming message queue is quickly drained.
|
|
|
|
//
|
|
|
|
// NOTE: This method MUST be run as a goroutine.
|
|
|
|
func (p *peer) writeHandler() {
|
2017-02-02 04:01:33 +03:00
|
|
|
defer func() {
|
|
|
|
p.wg.Done()
|
|
|
|
peerLog.Tracef("writeHandler for peer %v done", p)
|
|
|
|
}()
|
|
|
|
|
2016-01-14 08:41:46 +03:00
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case outMsg := <-p.sendQueue:
|
2017-01-26 05:20:55 +03:00
|
|
|
switch outMsg.msg.(type) {
|
2017-02-02 04:01:33 +03:00
|
|
|
// If we're about to send a ping message, then log the
|
|
|
|
// exact time in which we send the message so we can
|
|
|
|
// use the delay as a rough estimate of latency to the
|
|
|
|
// remote peer.
|
2017-01-26 05:20:55 +03:00
|
|
|
case *lnwire.Ping:
|
|
|
|
// TODO(roasbeef): do this before the write?
|
|
|
|
// possibly account for processing within func?
|
|
|
|
now := time.Now().UnixNano()
|
|
|
|
atomic.StoreInt64(&p.pingLastSend, now)
|
|
|
|
}
|
|
|
|
|
2017-02-02 04:01:33 +03:00
|
|
|
// Write out the message to the socket, closing the
|
|
|
|
// 'sentChan' if it's non-nil, The 'sentChan' allows
|
|
|
|
// callers to optionally synchronize sends with the
|
|
|
|
// writeHandler.
|
|
|
|
err := p.writeMessage(outMsg.msg)
|
|
|
|
if outMsg.sentChan != nil {
|
|
|
|
close(outMsg.sentChan)
|
|
|
|
}
|
2016-01-14 08:41:46 +03:00
|
|
|
|
2017-02-02 04:01:33 +03:00
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("unable to write message: %v",
|
|
|
|
err)
|
|
|
|
p.Disconnect()
|
|
|
|
return
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
2017-02-02 04:01:33 +03:00
|
|
|
|
|
|
|
case <-p.quit:
|
|
|
|
return
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// queueHandler is responsible for accepting messages from outside subsystems
|
2016-06-21 22:32:32 +03:00
|
|
|
// to be eventually sent out on the wire by the writeHandler.
|
|
|
|
//
|
|
|
|
// NOTE: This method MUST be run as a goroutine.
|
2016-01-14 08:41:46 +03:00
|
|
|
func (p *peer) queueHandler() {
|
2017-02-02 04:01:33 +03:00
|
|
|
defer p.wg.Done()
|
|
|
|
|
2016-01-14 08:41:46 +03:00
|
|
|
pendingMsgs := list.New()
|
|
|
|
for {
|
2017-02-02 04:01:33 +03:00
|
|
|
// Before add a queue'd message our pending message queue,
|
|
|
|
// we'll first try to aggressively empty out our pending list of
|
|
|
|
// messaging.
|
|
|
|
for {
|
|
|
|
// Examine the front of the queue. If this message is
|
|
|
|
// nil, then we've emptied out the queue and can accept
|
|
|
|
// new messages from outside sub-systems.
|
|
|
|
elem := pendingMsgs.Front()
|
|
|
|
if elem == nil {
|
|
|
|
break
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
2017-02-02 04:01:33 +03:00
|
|
|
|
|
|
|
select {
|
|
|
|
case p.sendQueue <- elem.Value.(outgoinMsg):
|
|
|
|
pendingMsgs.Remove(elem)
|
|
|
|
case <-p.quit:
|
|
|
|
return
|
|
|
|
default:
|
|
|
|
break
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
2017-02-02 04:01:33 +03:00
|
|
|
}
|
2016-01-14 08:41:46 +03:00
|
|
|
|
2017-02-02 04:01:33 +03:00
|
|
|
// If there weren't any messages to send, or the writehandler
|
|
|
|
// is still blocked, then we'll accept a new message into the
|
|
|
|
// queue from outside sub-systems.
|
|
|
|
select {
|
2016-01-14 08:41:46 +03:00
|
|
|
case <-p.quit:
|
2017-02-02 04:01:33 +03:00
|
|
|
return
|
|
|
|
case msg := <-p.outgoingQueue:
|
|
|
|
pendingMsgs.PushBack(msg)
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2017-02-02 04:01:33 +03:00
|
|
|
}
|
2015-12-21 00:16:38 +03:00
|
|
|
}
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2016-11-11 04:15:25 +03:00
|
|
|
// pingHandler is responsible for periodically sending ping messages to the
|
|
|
|
// remote peer in order to keep the connection alive and/or determine if the
|
|
|
|
// connection is still active.
|
|
|
|
//
|
|
|
|
// NOTE: This method MUST be run as a goroutine.
|
|
|
|
func (p *peer) pingHandler() {
|
|
|
|
pingTicker := time.NewTicker(pingInterval)
|
|
|
|
defer pingTicker.Stop()
|
|
|
|
|
2017-04-17 04:11:39 +03:00
|
|
|
// TODO(roasbeef): make dynamic in order to create fake cover traffic
|
|
|
|
const numPingBytes = 16
|
2016-11-11 04:15:25 +03:00
|
|
|
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-pingTicker.C:
|
2017-04-17 04:11:39 +03:00
|
|
|
p.queueMsg(lnwire.NewPing(numPingBytes), nil)
|
2016-11-11 04:15:25 +03:00
|
|
|
case <-p.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
p.wg.Done()
|
|
|
|
}
|
|
|
|
|
2017-01-26 05:20:55 +03:00
|
|
|
// PingTime returns the estimated ping time to the peer in microseconds.
|
|
|
|
func (p *peer) PingTime() int64 {
|
|
|
|
return atomic.LoadInt64(&p.pingTime)
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// queueMsg queues a new lnwire.Message to be eventually sent out on the
|
|
|
|
// wire.
|
|
|
|
func (p *peer) queueMsg(msg lnwire.Message, doneChan chan struct{}) {
|
2016-12-20 04:00:18 +03:00
|
|
|
select {
|
|
|
|
case p.outgoingQueue <- outgoinMsg{msg, doneChan}:
|
|
|
|
case <-p.quit:
|
|
|
|
return
|
|
|
|
}
|
2016-06-21 22:32:32 +03:00
|
|
|
}
|
|
|
|
|
2016-11-11 04:15:25 +03:00
|
|
|
// ChannelSnapshots returns a slice of channel snapshots detailing all
|
|
|
|
// currently active channels maintained with the remote peer.
|
2016-06-23 08:22:06 +03:00
|
|
|
func (p *peer) ChannelSnapshots() []*channeldb.ChannelSnapshot {
|
|
|
|
resp := make(chan []*channeldb.ChannelSnapshot, 1)
|
|
|
|
p.chanSnapshotReqs <- &chanSnapshotReq{resp}
|
|
|
|
return <-resp
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// channelManager is goroutine dedicated to handling all requests/signals
|
|
|
|
// pertaining to the opening, cooperative closing, and force closing of all
|
|
|
|
// channels maintained with the remote peer.
|
|
|
|
//
|
|
|
|
// NOTE: This method MUST be run as a goroutine.
|
|
|
|
func (p *peer) channelManager() {
|
2017-03-25 04:26:09 +03:00
|
|
|
// chanShutdowns is a map of channels for which our node has initiated
|
|
|
|
// a cooperative channel close. When an lnwire.Shutdown is received,
|
|
|
|
// this allows the node to determine the next step to be taken in the
|
|
|
|
// workflow.
|
2017-05-02 23:04:58 +03:00
|
|
|
chanShutdowns := make(map[lnwire.ChannelID]*htlcswitch.ChanClose)
|
2017-03-25 04:26:09 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// shutdownSigs is a map of signatures maintained by the responder in a
|
|
|
|
// cooperative channel close. This map enables us to respond to
|
2017-03-25 04:26:09 +03:00
|
|
|
// subsequent steps in the workflow without having to recalculate our
|
|
|
|
// signature for the channel close transaction.
|
|
|
|
shutdownSigs := make(map[lnwire.ChannelID][]byte)
|
2016-06-21 22:32:32 +03:00
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
2016-06-23 08:22:06 +03:00
|
|
|
case req := <-p.chanSnapshotReqs:
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.RLock()
|
2017-04-17 01:41:11 +03:00
|
|
|
snapshots := make([]*channeldb.ChannelSnapshot, 0,
|
|
|
|
len(p.activeChannels))
|
2016-06-23 08:22:06 +03:00
|
|
|
for _, activeChan := range p.activeChannels {
|
|
|
|
snapshot := activeChan.StateSnapshot()
|
|
|
|
snapshots = append(snapshots, snapshot)
|
|
|
|
}
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.RUnlock()
|
2016-06-23 08:22:06 +03:00
|
|
|
req.resp <- snapshots
|
2016-07-14 02:40:01 +03:00
|
|
|
|
2017-01-24 02:33:46 +03:00
|
|
|
case newChanReq := <-p.newChannels:
|
2017-04-17 01:41:11 +03:00
|
|
|
chanPoint := newChanReq.channel.ChannelPoint()
|
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(chanPoint)
|
2016-11-18 05:43:33 +03:00
|
|
|
|
|
|
|
p.activeChanMtx.Lock()
|
2017-04-17 01:41:11 +03:00
|
|
|
p.activeChannels[chanID] = newChanReq.channel
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.Unlock()
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
peerLog.Infof("New channel active ChannelPoint(%v) "+
|
|
|
|
"with peerId(%v)", chanPoint, p.id)
|
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
decoder := htlcswitch.NewSphinxDecoder(p.server.sphinx)
|
|
|
|
link := htlcswitch.NewChannelLink(
|
|
|
|
&htlcswitch.ChannelLinkConfig{
|
|
|
|
Peer: p,
|
|
|
|
DecodeOnion: decoder.Decode,
|
|
|
|
SettledContracts: p.server.breachArbiter.settledContracts,
|
|
|
|
DebugHTLC: cfg.DebugHTLC,
|
|
|
|
Registry: p.server.invoices,
|
|
|
|
Switch: p.server.htlcSwitch,
|
|
|
|
}, newChanReq.channel)
|
|
|
|
|
|
|
|
err := p.server.htlcSwitch.AddLink(link)
|
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("can't register new channel "+
|
|
|
|
"link(%v) with peerId(%v)", chanPoint, p.id)
|
|
|
|
}
|
2017-01-24 02:33:46 +03:00
|
|
|
|
|
|
|
close(newChanReq.done)
|
2016-07-14 02:40:01 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// We've just received a local quest to close an active
|
|
|
|
// channel.
|
2016-06-21 22:32:32 +03:00
|
|
|
case req := <-p.localCloseChanReqs:
|
2017-05-24 01:26:38 +03:00
|
|
|
// So we'll first transition the channel to a state of
|
|
|
|
// pending shutdown.
|
2017-05-02 23:04:58 +03:00
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(req.ChanPoint)
|
2017-03-25 04:26:09 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// We'll only track this shutdown request if this is a
|
|
|
|
// regular close request, and not in response to a
|
|
|
|
// channel breach.
|
2017-05-02 23:04:58 +03:00
|
|
|
if req.CloseType == htlcswitch.CloseRegular {
|
2017-05-24 01:26:38 +03:00
|
|
|
chanShutdowns[chanID] = req
|
|
|
|
}
|
|
|
|
|
|
|
|
// With the state marked as shutting down, we can now
|
|
|
|
// proceed with the channel close workflow. If this is
|
|
|
|
// regular close, we'll send a shutdown. Otherwise,
|
|
|
|
// we'll simply be clearing our indexes.
|
2016-06-21 22:32:32 +03:00
|
|
|
p.handleLocalClose(req)
|
2016-07-14 02:40:01 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// A receipt of a message over this channel indicates that
|
|
|
|
// either a shutdown proposal has been initiated, or a prior
|
|
|
|
// one has been completed, advancing to the next state of
|
|
|
|
// channel closure.
|
2017-03-25 04:26:09 +03:00
|
|
|
case req := <-p.shutdownChanReqs:
|
2017-05-24 01:26:38 +03:00
|
|
|
// We've just received a shutdown request. First, we'll
|
|
|
|
// check in the shutdown map to see if we're the
|
|
|
|
// initiator or not. If we don't have an entry for
|
|
|
|
// this channel, then this means that we're the
|
|
|
|
// responder to the workflow.
|
|
|
|
if _, ok := chanShutdowns[req.ChannelID]; !ok {
|
|
|
|
// In this case, we'll send a shutdown message,
|
|
|
|
// and also prep our closing signature for the
|
|
|
|
// case they fees are immediately agreed upon.
|
2017-03-25 04:26:09 +03:00
|
|
|
closeSig := p.handleShutdownResponse(req)
|
2017-05-24 01:26:38 +03:00
|
|
|
if closeSig != nil {
|
|
|
|
shutdownSigs[req.ChannelID] = closeSig
|
|
|
|
}
|
2017-03-25 04:26:09 +03:00
|
|
|
}
|
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// TODO(roasbeef): should also save their delivery
|
|
|
|
// address within close request after funding change.
|
|
|
|
// * modify complete to include delivery address
|
|
|
|
|
|
|
|
// A receipt of a message over this channel indicates that the
|
|
|
|
// final stage of a channel shutdown workflow has been
|
|
|
|
// completed.
|
2017-03-25 04:26:09 +03:00
|
|
|
case req := <-p.closingSignedChanReqs:
|
2017-05-24 01:26:38 +03:00
|
|
|
// First we'll check if this has an entry in the local
|
|
|
|
// shutdown map.
|
2017-03-25 04:26:09 +03:00
|
|
|
localCloseReq, ok := chanShutdowns[req.ChannelID]
|
2017-05-24 01:26:38 +03:00
|
|
|
|
|
|
|
// If it does, then this means we were the initiator of
|
|
|
|
// the channel shutdown procedure.
|
2017-03-25 04:26:09 +03:00
|
|
|
if ok {
|
2017-05-24 01:26:38 +03:00
|
|
|
// To finalize this shtudown, we'll now send a
|
|
|
|
// matching close signed message to the other
|
|
|
|
// party, and broadcast the closing transaction
|
|
|
|
// to the network.
|
2017-03-25 04:26:09 +03:00
|
|
|
p.handleInitClosingSigned(localCloseReq, req)
|
|
|
|
|
|
|
|
delete(chanShutdowns, req.ChannelID)
|
2017-05-24 01:26:38 +03:00
|
|
|
continue
|
2017-03-25 04:26:09 +03:00
|
|
|
}
|
2016-07-14 02:40:01 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// Otherwise, we're the responder to the channel
|
|
|
|
// shutdown procedure. In this case, we'll mark the
|
|
|
|
// channel as pending close, and watch the network for
|
|
|
|
// the ultimate confirmation of the closing
|
|
|
|
// transaction.
|
|
|
|
responderSig := append(shutdownSigs[req.ChannelID],
|
|
|
|
byte(txscript.SigHashAll))
|
|
|
|
p.handleResponseClosingSigned(req, responderSig)
|
|
|
|
delete(shutdownSigs, req.ChannelID)
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
case <-p.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
p.wg.Done()
|
|
|
|
}
|
|
|
|
|
2016-09-12 22:42:26 +03:00
|
|
|
// handleLocalClose kicks-off the workflow to execute a cooperative or forced
|
2017-01-13 08:01:50 +03:00
|
|
|
// unilateral closure of the channel initiated by a local subsystem.
|
2017-05-24 01:26:38 +03:00
|
|
|
//
|
2016-12-15 05:11:31 +03:00
|
|
|
// TODO(roasbeef): if no more active channels with peer call Remove on connMgr
|
|
|
|
// with peerID
|
2017-05-02 23:04:58 +03:00
|
|
|
func (p *peer) handleLocalClose(req *htlcswitch.ChanClose) {
|
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(req.ChanPoint)
|
2017-04-17 01:41:11 +03:00
|
|
|
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.RLock()
|
2017-05-24 01:21:35 +03:00
|
|
|
channel, ok := p.activeChannels[chanID]
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.RUnlock()
|
2017-05-24 01:21:35 +03:00
|
|
|
if !ok {
|
|
|
|
err := fmt.Errorf("unable to close channel, ChannelID(%v) is "+
|
|
|
|
"unknown", chanID)
|
|
|
|
peerLog.Errorf(err.Error())
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-05-24 01:21:35 +03:00
|
|
|
return
|
|
|
|
}
|
2016-09-12 22:42:26 +03:00
|
|
|
|
2016-11-29 05:44:14 +03:00
|
|
|
switch req.CloseType {
|
|
|
|
// A type of CloseRegular indicates that the user has opted to close
|
2017-05-05 02:03:47 +03:00
|
|
|
// out this channel on-chain, so we execute the cooperative channel
|
2017-02-03 04:05:25 +03:00
|
|
|
// closure workflow.
|
2017-05-02 23:04:58 +03:00
|
|
|
case htlcswitch.CloseRegular:
|
2017-03-25 04:26:09 +03:00
|
|
|
err := p.sendShutdown(channel)
|
|
|
|
if err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-03-25 04:26:09 +03:00
|
|
|
return
|
|
|
|
}
|
2016-11-29 05:44:14 +03:00
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// A type of CloseBreach indicates that the counterparty has breached
|
2017-02-03 04:05:25 +03:00
|
|
|
// the channel therefore we need to clean up our local state.
|
2017-05-02 23:04:58 +03:00
|
|
|
case htlcswitch.CloseBreach:
|
2016-11-29 05:44:14 +03:00
|
|
|
peerLog.Infof("ChannelPoint(%v) has been breached, wiping "+
|
2017-05-02 23:04:58 +03:00
|
|
|
"channel", req.ChanPoint)
|
|
|
|
if err := p.WipeChannel(channel); err != nil {
|
2016-11-29 05:44:14 +03:00
|
|
|
peerLog.Infof("Unable to wipe channel after detected "+
|
|
|
|
"breach: %v", err)
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2016-11-29 05:44:14 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
return
|
2016-09-12 22:42:26 +03:00
|
|
|
}
|
2017-03-25 04:26:09 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
// handleShutdownResponse is called when a responder in a cooperative channel
|
|
|
|
// close workflow receives a Shutdown message. This is the second step in the
|
|
|
|
// cooperative close workflow. This function generates a close transaction with
|
|
|
|
// a proposed fee amount and sends the signed transaction to the initiator.
|
|
|
|
func (p *peer) handleShutdownResponse(msg *lnwire.Shutdown) []byte {
|
|
|
|
p.activeChanMtx.RLock()
|
|
|
|
channel, ok := p.activeChannels[msg.ChannelID]
|
|
|
|
p.activeChanMtx.RUnlock()
|
|
|
|
if !ok {
|
|
|
|
peerLog.Errorf("unable to close channel, ChannelPoint(%v) is "+
|
|
|
|
"unknown", msg.ChannelID)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-05-24 01:22:56 +03:00
|
|
|
// As we just received a shutdown message, we'll also send a shutdown
|
|
|
|
// message with our desired fee so we can start the negotiation.
|
2017-03-25 04:26:09 +03:00
|
|
|
if err := p.sendShutdown(channel); err != nil {
|
|
|
|
peerLog.Errorf("error while sending shutdown message: %v", err)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-05-24 01:22:56 +03:00
|
|
|
// Calculate an initial proposed fee rate for the close transaction.
|
|
|
|
feeRate := p.server.feeEstimator.EstimateFeePerWeight(1) * 1000
|
|
|
|
|
|
|
|
// TODO(roasbeef): actually perform fee negotiation here, only send sig
|
|
|
|
// if we agree to fee
|
|
|
|
|
|
|
|
// Once both sides agree on a fee, we'll create a signature that closes
|
|
|
|
// the channel using the agree upon fee rate.
|
|
|
|
// TODO(roasbeef): remove encoding redundancy
|
|
|
|
closeSig, proposedFee, err := channel.CreateCloseProposal(feeRate)
|
2017-03-25 04:26:09 +03:00
|
|
|
if err != nil {
|
2017-05-24 01:22:56 +03:00
|
|
|
peerLog.Errorf("unable to create close proposal: %v", err)
|
2017-03-25 04:26:09 +03:00
|
|
|
return nil
|
|
|
|
}
|
2017-05-24 01:22:56 +03:00
|
|
|
parsedSig, err := btcec.ParseSignature(closeSig, btcec.S256())
|
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("unable to parse signature: %v", err)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// With the closing signature assembled, we'll send the matching close
|
|
|
|
// signed message to the other party so they can broadcast the closing
|
|
|
|
// transaction.
|
|
|
|
closingSigned := lnwire.NewClosingSigned(msg.ChannelID, proposedFee,
|
|
|
|
parsedSig)
|
|
|
|
p.queueMsg(closingSigned, nil)
|
|
|
|
|
2017-03-25 04:26:09 +03:00
|
|
|
return closeSig
|
|
|
|
}
|
|
|
|
|
|
|
|
// handleInitClosingSigned is called when the initiator in a cooperative
|
|
|
|
// channel close workflow receives a ClosingSigned message from the responder.
|
|
|
|
// This method completes the channel close transaction, sends back a
|
|
|
|
// corresponding ClosingSigned message, then broadcasts the channel close
|
|
|
|
// transaction. It also performs channel cleanup and reports status back to the
|
|
|
|
// caller. This is the initiator's final step in the channel close workflow.
|
|
|
|
//
|
|
|
|
// Following the broadcast, both the initiator and responder in the channel
|
|
|
|
// closure workflow should watch the blockchain for a confirmation of the
|
|
|
|
// closing transaction before considering the channel terminated. In the case
|
|
|
|
// of an unresponsive remote party, the initiator can either choose to execute
|
|
|
|
// a force closure, or backoff for a period of time, and retry the cooperative
|
|
|
|
// closure.
|
2017-05-02 23:04:58 +03:00
|
|
|
func (p *peer) handleInitClosingSigned(req *htlcswitch.ChanClose, msg *lnwire.ClosingSigned) {
|
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(req.ChanPoint)
|
2017-03-25 04:26:09 +03:00
|
|
|
p.activeChanMtx.RLock()
|
2017-05-24 01:21:35 +03:00
|
|
|
channel, ok := p.activeChannels[chanID]
|
2017-03-25 04:26:09 +03:00
|
|
|
p.activeChanMtx.RUnlock()
|
2017-05-24 01:21:35 +03:00
|
|
|
if !ok {
|
|
|
|
err := fmt.Errorf("unable to close channel, ChannelID(%v) is "+
|
|
|
|
"unknown", chanID)
|
|
|
|
peerLog.Errorf(err.Error())
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-05-24 01:21:35 +03:00
|
|
|
return
|
|
|
|
}
|
2017-03-25 04:26:09 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// Calculate a fee rate that we believe to be fair and will ensure a
|
|
|
|
// timely confirmation.
|
|
|
|
//
|
|
|
|
// TODO(bvu): with a dynamic fee implementation, we will compare this
|
|
|
|
// to the fee proposed by the responder in their ClosingSigned message.
|
2017-05-18 02:51:10 +03:00
|
|
|
feeRate := p.server.feeEstimator.EstimateFeePerWeight(1) * 1000
|
|
|
|
|
|
|
|
// We agree with the proposed channel close transaction and fee rate,
|
|
|
|
// so generate our signature.
|
|
|
|
initiatorSig, proposedFee, err := channel.CreateCloseProposal(feeRate)
|
2017-03-25 04:26:09 +03:00
|
|
|
if err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-03-25 04:26:09 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
initSig := append(initiatorSig, byte(txscript.SigHashAll))
|
|
|
|
|
2017-05-18 02:51:10 +03:00
|
|
|
// Complete coop close transaction with the signatures of the close
|
|
|
|
// initiator and responder.
|
2017-03-25 04:26:09 +03:00
|
|
|
responderSig := msg.Signature
|
|
|
|
respSig := append(responderSig.Serialize(), byte(txscript.SigHashAll))
|
|
|
|
closeTx, err := channel.CompleteCooperativeClose(initSig, respSig,
|
2017-05-18 02:51:10 +03:00
|
|
|
feeRate)
|
2016-09-12 22:42:26 +03:00
|
|
|
if err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-03-25 04:26:09 +03:00
|
|
|
// TODO(roasbeef): send ErrorGeneric to other side
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// As we're the initiator of this channel shutdown procedure we'll now
|
|
|
|
// create a mirrored close signed message with our completed signature.
|
2017-03-25 04:26:09 +03:00
|
|
|
parsedSig, err := btcec.ParseSignature(initSig, btcec.S256())
|
2017-05-24 01:26:38 +03:00
|
|
|
if err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-05-24 01:26:38 +03:00
|
|
|
return
|
|
|
|
}
|
2017-03-25 04:26:09 +03:00
|
|
|
closingSigned := lnwire.NewClosingSigned(chanID, proposedFee, parsedSig)
|
|
|
|
p.queueMsg(closingSigned, nil)
|
|
|
|
|
|
|
|
// Finally, broadcast the closure transaction to the network.
|
|
|
|
peerLog.Infof("Broadcasting cooperative close tx: %v",
|
|
|
|
newLogClosure(func() string {
|
|
|
|
return spew.Sdump(closeTx)
|
|
|
|
}))
|
|
|
|
if err := p.server.lnwallet.PublishTransaction(closeTx); err != nil {
|
|
|
|
peerLog.Errorf("channel close tx from "+
|
|
|
|
"ChannelPoint(%v) rejected: %v",
|
2017-05-02 23:04:58 +03:00
|
|
|
req.ChanPoint, err)
|
2017-03-25 04:26:09 +03:00
|
|
|
// TODO(roasbeef): send ErrorGeneric to other side
|
2016-09-12 22:42:26 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2017-05-05 02:03:47 +03:00
|
|
|
// Once we've completed the cooperative channel closure, we'll wipe the
|
|
|
|
// channel so we reject any incoming forward or payment requests via
|
|
|
|
// this channel.
|
2017-05-02 23:04:58 +03:00
|
|
|
p.server.breachArbiter.settledContracts <- req.ChanPoint
|
|
|
|
if err := p.WipeChannel(channel); err != nil {
|
|
|
|
req.Err <- err
|
2017-05-05 02:03:47 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Clear out the current channel state, marking the channel as being
|
|
|
|
// closed within the database.
|
2017-05-24 01:26:38 +03:00
|
|
|
closingTxid := closeTx.TxHash()
|
2017-05-05 02:03:47 +03:00
|
|
|
chanInfo := channel.StateSnapshot()
|
|
|
|
closeSummary := &channeldb.ChannelCloseSummary{
|
2017-05-02 23:04:58 +03:00
|
|
|
ChanPoint: *req.ChanPoint,
|
2017-03-25 04:26:09 +03:00
|
|
|
ClosingTXID: closingTxid,
|
2017-05-15 05:23:51 +03:00
|
|
|
RemotePub: &chanInfo.RemoteIdentity,
|
|
|
|
Capacity: chanInfo.Capacity,
|
|
|
|
SettledBalance: chanInfo.LocalBalance,
|
|
|
|
CloseType: channeldb.CooperativeClose,
|
|
|
|
IsPending: true,
|
2017-05-05 02:03:47 +03:00
|
|
|
}
|
|
|
|
if err := channel.DeleteState(closeSummary); err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-05-05 02:03:47 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2016-11-18 05:43:33 +03:00
|
|
|
// Update the caller with a new event detailing the current pending
|
|
|
|
// state of this request.
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Updates <- &lnrpc.CloseStatusUpdate{
|
2016-08-31 02:52:53 +03:00
|
|
|
Update: &lnrpc.CloseStatusUpdate_ClosePending{
|
|
|
|
ClosePending: &lnrpc.PendingUpdate{
|
2016-09-12 22:42:26 +03:00
|
|
|
Txid: closingTxid[:],
|
2016-08-31 02:52:53 +03:00
|
|
|
},
|
|
|
|
},
|
|
|
|
}
|
|
|
|
|
2017-05-18 21:55:25 +03:00
|
|
|
_, bestHeight, err := p.server.cc.chainIO.GetBestBlock()
|
2017-05-11 03:27:05 +03:00
|
|
|
if err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-05-11 03:27:05 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// Finally, launch a goroutine which will request to be notified by the
|
|
|
|
// ChainNotifier once the closure transaction obtains a single
|
|
|
|
// confirmation.
|
2017-05-18 21:55:25 +03:00
|
|
|
notifier := p.server.cc.chainNotifier
|
|
|
|
go waitForChanToClose(uint32(bestHeight), notifier, req.err,
|
|
|
|
req.ChanPoint, closingTxid, func() {
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-05-11 03:27:05 +03:00
|
|
|
// First, we'll mark the database as being fully closed
|
|
|
|
// so we'll no longer watch for its ultimate closure
|
|
|
|
// upon startup.
|
2017-05-02 23:04:58 +03:00
|
|
|
err := p.server.chanDB.MarkChanFullyClosed(req.ChanPoint)
|
2017-05-11 03:27:05 +03:00
|
|
|
if err != nil {
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Err <- err
|
2017-05-11 03:27:05 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Respond to the local subsystem which requested the
|
|
|
|
// channel closure.
|
2017-05-02 23:04:58 +03:00
|
|
|
req.Updates <- &lnrpc.CloseStatusUpdate{
|
2017-05-11 03:27:05 +03:00
|
|
|
Update: &lnrpc.CloseStatusUpdate_ChanClose{
|
|
|
|
ChanClose: &lnrpc.ChannelCloseUpdate{
|
|
|
|
ClosingTxid: closingTxid[:],
|
|
|
|
Success: true,
|
|
|
|
},
|
2016-08-31 02:52:53 +03:00
|
|
|
},
|
2017-05-11 03:27:05 +03:00
|
|
|
}
|
|
|
|
})
|
2016-06-21 22:32:32 +03:00
|
|
|
}
|
|
|
|
|
2017-03-25 04:26:09 +03:00
|
|
|
// handleResponseClosingSigned is called when the responder in a cooperative
|
|
|
|
// close workflow receives a ClosingSigned message. This function handles the
|
|
|
|
// finalization of the cooperative close from the perspective of the responder.
|
|
|
|
func (p *peer) handleResponseClosingSigned(msg *lnwire.ClosingSigned,
|
|
|
|
respSig []byte) {
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.RLock()
|
2017-05-24 01:21:35 +03:00
|
|
|
channel, ok := p.activeChannels[msg.ChannelID]
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.RUnlock()
|
2017-05-24 01:21:35 +03:00
|
|
|
if !ok {
|
|
|
|
peerLog.Errorf("unable to close channel, ChannelID(%v) is "+
|
|
|
|
"unknown", msg.ChannelID)
|
|
|
|
return
|
|
|
|
}
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2017-03-25 04:26:09 +03:00
|
|
|
// Now that we have the initiator's signature for the closure
|
|
|
|
// transaction, we can assemble the final closure transaction, complete
|
|
|
|
// with our signature.
|
|
|
|
initiatorSig := msg.Signature
|
|
|
|
initSig := append(initiatorSig.Serialize(), byte(txscript.SigHashAll))
|
2017-04-17 01:41:11 +03:00
|
|
|
chanPoint := channel.ChannelPoint()
|
|
|
|
|
2017-05-18 02:51:10 +03:00
|
|
|
// Calculate our expected fee rate.
|
2017-05-24 01:26:38 +03:00
|
|
|
// TODO(roasbeef): should instead use the fee within the message
|
2017-05-18 02:51:10 +03:00
|
|
|
feeRate := p.server.feeEstimator.EstimateFeePerWeight(1) * 1000
|
2017-03-25 04:26:09 +03:00
|
|
|
closeTx, err := channel.CompleteCooperativeClose(respSig, initSig,
|
2017-05-18 02:51:10 +03:00
|
|
|
feeRate)
|
2016-06-21 22:32:32 +03:00
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("unable to complete cooperative "+
|
|
|
|
"close for ChannelPoint(%v): %v",
|
|
|
|
chanPoint, err)
|
|
|
|
// TODO(roasbeef): send ErrorGeneric to other side
|
|
|
|
return
|
|
|
|
}
|
2017-03-25 04:26:09 +03:00
|
|
|
closeTxid := closeTx.TxHash()
|
2017-05-11 03:27:05 +03:00
|
|
|
|
2017-05-18 21:55:25 +03:00
|
|
|
_, bestHeight, err := p.server.cc.chainIO.GetBestBlock()
|
2017-05-11 03:27:05 +03:00
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("unable to get best height: %v", err)
|
|
|
|
}
|
2016-11-29 05:44:14 +03:00
|
|
|
|
2017-03-25 04:26:09 +03:00
|
|
|
// Once we've completed the cooperative channel closure, we'll wipe the
|
|
|
|
// channel so we reject any incoming forward or payment requests via
|
|
|
|
// this channel.
|
2017-05-05 02:03:47 +03:00
|
|
|
p.server.breachArbiter.settledContracts <- chanPoint
|
|
|
|
|
|
|
|
// We've just broadcast the transaction which closes the channel, so
|
|
|
|
// we'll wipe the channel from all our local indexes and also signal to
|
|
|
|
// the switch that this channel is now closed.
|
2017-04-17 01:41:11 +03:00
|
|
|
peerLog.Infof("ChannelPoint(%v) is now closed", chanPoint)
|
2017-05-02 23:04:58 +03:00
|
|
|
if err := p.WipeChannel(channel); err != nil {
|
2016-09-26 20:35:10 +03:00
|
|
|
peerLog.Errorf("unable to wipe channel: %v", err)
|
|
|
|
}
|
2016-11-29 06:43:57 +03:00
|
|
|
|
2017-05-05 02:03:47 +03:00
|
|
|
// Clear out the current channel state, marking the channel as being
|
|
|
|
// closed within the database.
|
|
|
|
chanInfo := channel.StateSnapshot()
|
|
|
|
closeSummary := &channeldb.ChannelCloseSummary{
|
2017-05-15 05:23:51 +03:00
|
|
|
ChanPoint: *chanPoint,
|
|
|
|
ClosingTXID: closeTxid,
|
|
|
|
RemotePub: &chanInfo.RemoteIdentity,
|
|
|
|
Capacity: chanInfo.Capacity,
|
|
|
|
SettledBalance: chanInfo.LocalBalance,
|
|
|
|
CloseType: channeldb.CooperativeClose,
|
|
|
|
IsPending: true,
|
2017-05-05 02:03:47 +03:00
|
|
|
}
|
|
|
|
if err := channel.DeleteState(closeSummary); err != nil {
|
|
|
|
peerLog.Errorf("unable to delete channel state: %v", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Finally, we'll launch a goroutine to watch the network for the
|
|
|
|
// confirmation of the closing transaction, and mark the channel as
|
|
|
|
// such within the database (once it's confirmed").
|
2017-05-18 21:55:25 +03:00
|
|
|
notifier := p.server.cc.chainNotifier
|
2017-05-11 03:27:05 +03:00
|
|
|
go waitForChanToClose(uint32(bestHeight), notifier, nil, chanPoint,
|
|
|
|
&closeTxid, func() {
|
2017-05-05 02:03:47 +03:00
|
|
|
// Now that the closing transaction has been confirmed,
|
|
|
|
// we'll mark the database as being fully closed so now
|
|
|
|
// that we no longer watch for its ultimate closure
|
|
|
|
// upon startup.
|
|
|
|
err := p.server.chanDB.MarkChanFullyClosed(chanPoint)
|
|
|
|
if err != nil {
|
|
|
|
peerLog.Errorf("unable to mark channel as closed: %v", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
},
|
|
|
|
)
|
|
|
|
}
|
|
|
|
|
|
|
|
// waitForChanToClose uses the passed notifier to wait until the channel has
|
|
|
|
// been detected as closed on chain and then concludes by executing the
|
|
|
|
// following actions: the channel point will be sent over the settleChan, and
|
|
|
|
// finally the callback will be executed. If any error is encountered within
|
|
|
|
// the function, then it will be sent over the errChan.
|
2017-05-11 03:27:05 +03:00
|
|
|
func waitForChanToClose(bestHeight uint32, notifier chainntnfs.ChainNotifier,
|
2017-05-05 02:03:47 +03:00
|
|
|
errChan chan error, chanPoint *wire.OutPoint,
|
|
|
|
closingTxID *chainhash.Hash, cb func()) {
|
|
|
|
|
2017-03-25 04:26:09 +03:00
|
|
|
peerLog.Infof("Waiting for confirmation of cooperative close of "+
|
|
|
|
"ChannelPoint(%v) with txid: %v", chanPoint,
|
|
|
|
closingTxID)
|
|
|
|
|
2017-05-05 02:03:47 +03:00
|
|
|
// TODO(roasbeef): add param for num needed confs
|
2017-05-11 03:27:05 +03:00
|
|
|
confNtfn, err := notifier.RegisterConfirmationsNtfn(closingTxID, 1,
|
|
|
|
bestHeight)
|
2017-05-16 03:53:22 +03:00
|
|
|
if err != nil {
|
|
|
|
if errChan != nil {
|
|
|
|
errChan <- err
|
|
|
|
}
|
2017-05-05 02:03:47 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// In the case that the ChainNotifier is shutting down, all subscriber
|
|
|
|
// notification channels will be closed, generating a nil receive.
|
|
|
|
height, ok := <-confNtfn.Confirmed
|
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// The channel has been closed, remove it from any active indexes, and
|
|
|
|
// the database state.
|
|
|
|
srvrLog.Infof("ChannelPoint(%v) is now closed at "+
|
|
|
|
"height %v", chanPoint, height.BlockHeight)
|
|
|
|
|
|
|
|
// Finally, execute the closure call back to mark the confirmation of
|
|
|
|
// the transaction closing the contract.
|
|
|
|
cb()
|
2016-06-23 08:19:24 +03:00
|
|
|
}
|
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// sendShutdown handles the creation and sending of the Shutdown messages sent
|
|
|
|
// between peers to initiate the cooperative channel close workflow. In
|
2017-03-25 04:26:09 +03:00
|
|
|
// addition, sendShutdown also signals to the HTLC switch to stop accepting
|
|
|
|
// HTLCs for the specified channel.
|
|
|
|
func (p *peer) sendShutdown(channel *lnwallet.LightningChannel) error {
|
2017-05-24 01:26:38 +03:00
|
|
|
// In order to construct the shutdown message, we'll need to
|
|
|
|
// reconstruct the channelID, and the current set delivery script for
|
|
|
|
// the channel closure.
|
2017-03-25 04:26:09 +03:00
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(channel.ChannelPoint())
|
2017-05-24 01:26:38 +03:00
|
|
|
addr := lnwire.DeliveryAddress(channel.LocalDeliveryScript)
|
2017-03-25 04:26:09 +03:00
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// With both items constructed we'll now send the shutdown message for
|
|
|
|
// this particular channel, advertising a shutdown request to our
|
|
|
|
// desired closing script.
|
|
|
|
shutdown := lnwire.NewShutdown(chanID, addr)
|
2017-03-25 04:26:09 +03:00
|
|
|
p.queueMsg(shutdown, nil)
|
|
|
|
|
2017-05-24 01:26:38 +03:00
|
|
|
// Finally, we'll unregister the link from the switch in order to
|
|
|
|
// Prevent the HTLC switch from receiving additional HTLCs for this
|
|
|
|
// channel.
|
2017-05-02 23:04:58 +03:00
|
|
|
p.server.htlcSwitch.RemoveLink(chanID)
|
2017-03-25 04:26:09 +03:00
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
// WipeChannel removes the passed channel from all indexes associated with the
|
2016-06-23 08:19:24 +03:00
|
|
|
// peer, and deletes the channel from the database.
|
2017-05-02 23:04:58 +03:00
|
|
|
func (p *peer) WipeChannel(channel *lnwallet.LightningChannel) error {
|
2017-05-15 05:21:17 +03:00
|
|
|
channel.Stop()
|
|
|
|
|
2017-04-17 01:41:11 +03:00
|
|
|
chanID := lnwire.NewChanIDFromOutPoint(channel.ChannelPoint())
|
2016-06-23 08:19:24 +03:00
|
|
|
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.Lock()
|
2017-04-17 01:41:11 +03:00
|
|
|
delete(p.activeChannels, chanID)
|
2016-11-18 05:43:33 +03:00
|
|
|
p.activeChanMtx.Unlock()
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2016-07-10 02:41:06 +03:00
|
|
|
// Instruct the Htlc Switch to close this link as the channel is no
|
|
|
|
// longer active.
|
2016-07-22 03:10:30 +03:00
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
if err := p.server.htlcSwitch.RemoveLink(chanID); err != nil {
|
|
|
|
if err == htlcswitch.ErrChannelLinkNotFound {
|
|
|
|
peerLog.Warnf("unable remove channel link with "+
|
|
|
|
"ChannelPoint(%v): %v", chanID, err)
|
|
|
|
return nil
|
2016-06-21 22:32:32 +03:00
|
|
|
}
|
2017-05-02 23:04:58 +03:00
|
|
|
return err
|
2016-06-21 22:32:32 +03:00
|
|
|
}
|
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
return nil
|
2016-06-21 22:32:32 +03:00
|
|
|
}
|
|
|
|
|
2017-02-16 15:39:38 +03:00
|
|
|
// handleInitMsg handles the incoming init message which contains global and
|
|
|
|
// local features vectors. If feature vectors are incompatible then disconnect.
|
|
|
|
func (p *peer) handleInitMsg(msg *lnwire.Init) error {
|
|
|
|
localSharedFeatures, err := p.server.localFeatures.Compare(msg.LocalFeatures)
|
|
|
|
if err != nil {
|
2017-04-24 05:24:28 +03:00
|
|
|
err := errors.Errorf("can't compare remote and local feature "+
|
2017-02-16 15:39:38 +03:00
|
|
|
"vectors: %v", err)
|
|
|
|
peerLog.Error(err)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
p.localSharedFeatures = localSharedFeatures
|
|
|
|
|
|
|
|
globalSharedFeatures, err := p.server.globalFeatures.Compare(msg.GlobalFeatures)
|
|
|
|
if err != nil {
|
2017-04-24 05:24:28 +03:00
|
|
|
err := errors.Errorf("can't compare remote and global feature "+
|
2017-02-16 15:39:38 +03:00
|
|
|
"vectors: %v", err)
|
|
|
|
peerLog.Error(err)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
p.globalSharedFeatures = globalSharedFeatures
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-03-17 05:45:10 +03:00
|
|
|
// sendInitMsg sends init message to remote peer which contains our currently
|
|
|
|
// supported local and global features.
|
2017-02-16 15:39:38 +03:00
|
|
|
func (p *peer) sendInitMsg() error {
|
|
|
|
msg := lnwire.NewInitMessage(
|
|
|
|
p.server.globalFeatures,
|
|
|
|
p.server.localFeatures,
|
|
|
|
)
|
|
|
|
|
2017-03-17 05:45:10 +03:00
|
|
|
return p.writeMessage(msg)
|
2017-02-16 15:39:38 +03:00
|
|
|
}
|
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
// SendMessage sends message to the remote peer which represented by
|
|
|
|
// this peer.
|
|
|
|
func (p *peer) SendMessage(msg lnwire.Message) error {
|
|
|
|
p.queueMsg(msg, nil)
|
2017-02-21 05:10:05 +03:00
|
|
|
return nil
|
2016-07-22 03:10:30 +03:00
|
|
|
}
|
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
// ID returns the lightning network peer id.
|
|
|
|
func (p *peer) ID() [sha256.Size]byte {
|
|
|
|
return fastsha256.Sum256(p.PubKey())
|
|
|
|
}
|
2016-09-22 05:41:26 +03:00
|
|
|
|
2017-05-02 23:04:58 +03:00
|
|
|
// PubKey returns the peer public key.
|
|
|
|
func (p *peer) PubKey() []byte {
|
|
|
|
return p.addr.IdentityKey.SerializeCompressed()
|
2016-07-13 03:45:29 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// TODO(roasbeef): make all start/stop mutexes a CAS
|