2016-11-29 06:43:57 +03:00
|
|
|
package main
|
|
|
|
|
|
|
|
import (
|
2017-07-31 03:45:39 +03:00
|
|
|
"fmt"
|
2016-11-29 06:43:57 +03:00
|
|
|
"sync"
|
|
|
|
"sync/atomic"
|
|
|
|
|
|
|
|
"github.com/davecgh/go-spew/spew"
|
|
|
|
"github.com/lightningnetwork/lnd/chainntnfs"
|
|
|
|
"github.com/lightningnetwork/lnd/channeldb"
|
2017-05-02 23:04:58 +03:00
|
|
|
"github.com/lightningnetwork/lnd/htlcswitch"
|
2016-11-29 06:43:57 +03:00
|
|
|
"github.com/lightningnetwork/lnd/lnwallet"
|
2017-01-06 00:56:27 +03:00
|
|
|
"github.com/roasbeef/btcd/chaincfg/chainhash"
|
2016-11-29 06:43:57 +03:00
|
|
|
"github.com/roasbeef/btcd/txscript"
|
|
|
|
"github.com/roasbeef/btcd/wire"
|
|
|
|
"github.com/roasbeef/btcutil"
|
|
|
|
)
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// breachArbiter is a special subsystem which is responsible for watching and
|
2016-11-29 06:43:57 +03:00
|
|
|
// acting on the detection of any attempted uncooperative channel breaches by
|
2017-01-13 08:01:50 +03:00
|
|
|
// channel counterparties. This file essentially acts as deterrence code for
|
2016-11-29 06:43:57 +03:00
|
|
|
// those attempting to launch attacks against the daemon. In practice it's
|
|
|
|
// expected that the logic in this file never gets executed, but it is
|
|
|
|
// important to have it in place just in case we encounter cheating channel
|
2017-01-13 08:01:50 +03:00
|
|
|
// counterparties.
|
|
|
|
// TODO(roasbeef): closures in config for subsystem pointers to decouple?
|
2016-11-29 06:43:57 +03:00
|
|
|
type breachArbiter struct {
|
|
|
|
wallet *lnwallet.LightningWallet
|
|
|
|
db *channeldb.DB
|
|
|
|
notifier chainntnfs.ChainNotifier
|
2017-05-11 03:27:05 +03:00
|
|
|
chainIO lnwallet.BlockChainIO
|
2017-05-01 10:27:12 +03:00
|
|
|
estimator lnwallet.FeeEstimator
|
2017-05-02 23:04:58 +03:00
|
|
|
htlcSwitch *htlcswitch.Switch
|
2016-11-29 06:43:57 +03:00
|
|
|
|
|
|
|
// breachObservers is a map which tracks all the active breach
|
|
|
|
// observers we're currently managing. The key of the map is the
|
|
|
|
// funding outpoint of the channel, and the value is a channel which
|
|
|
|
// will be closed once we detect that the channel has been
|
2017-01-13 08:01:50 +03:00
|
|
|
// cooperatively closed, thereby killing the goroutine and freeing up
|
|
|
|
// resources.
|
2016-11-29 06:43:57 +03:00
|
|
|
breachObservers map[wire.OutPoint]chan struct{}
|
|
|
|
|
|
|
|
// breachedContracts is a channel which is used internally within the
|
|
|
|
// struct to send the necessary information required to punish a
|
2017-01-13 08:01:50 +03:00
|
|
|
// counterparty once a channel breach is detected. Breach observers
|
2016-11-29 06:43:57 +03:00
|
|
|
// use this to communicate with the main contractObserver goroutine.
|
|
|
|
breachedContracts chan *retributionInfo
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// newContracts is a channel which is used by outside subsystems to
|
2016-11-29 06:43:57 +03:00
|
|
|
// notify the breachArbiter of a new contract (a channel) that should
|
|
|
|
// be watched.
|
|
|
|
newContracts chan *lnwallet.LightningChannel
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// settledContracts is a channel by outside subsystems to notify
|
2016-11-29 06:43:57 +03:00
|
|
|
// the breachArbiter that a channel has peacefully been closed. Once a
|
|
|
|
// channel has been closed the arbiter no longer needs to watch for
|
|
|
|
// breach closes.
|
|
|
|
settledContracts chan *wire.OutPoint
|
|
|
|
|
|
|
|
started uint32
|
|
|
|
stopped uint32
|
|
|
|
quit chan struct{}
|
|
|
|
wg sync.WaitGroup
|
|
|
|
}
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// newBreachArbiter creates a new instance of a breachArbiter initialized with
|
|
|
|
// its dependent objects.
|
2016-11-29 06:43:57 +03:00
|
|
|
func newBreachArbiter(wallet *lnwallet.LightningWallet, db *channeldb.DB,
|
2017-05-02 23:04:58 +03:00
|
|
|
notifier chainntnfs.ChainNotifier, h *htlcswitch.Switch,
|
2017-05-01 10:27:12 +03:00
|
|
|
chain lnwallet.BlockChainIO, fe lnwallet.FeeEstimator) *breachArbiter {
|
2016-11-29 06:43:57 +03:00
|
|
|
|
|
|
|
return &breachArbiter{
|
|
|
|
wallet: wallet,
|
|
|
|
db: db,
|
|
|
|
notifier: notifier,
|
2017-05-11 03:27:05 +03:00
|
|
|
chainIO: chain,
|
2016-11-29 06:43:57 +03:00
|
|
|
htlcSwitch: h,
|
2017-05-01 10:27:12 +03:00
|
|
|
estimator: fe,
|
2016-11-29 06:43:57 +03:00
|
|
|
|
|
|
|
breachObservers: make(map[wire.OutPoint]chan struct{}),
|
|
|
|
breachedContracts: make(chan *retributionInfo),
|
|
|
|
newContracts: make(chan *lnwallet.LightningChannel),
|
|
|
|
settledContracts: make(chan *wire.OutPoint),
|
|
|
|
quit: make(chan struct{}),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Start is an idempotent method that officially starts the breachArbiter along
|
|
|
|
// with all other goroutines it needs to perform its functions.
|
|
|
|
func (b *breachArbiter) Start() error {
|
|
|
|
if !atomic.CompareAndSwapUint32(&b.started, 0, 1) {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-01-31 08:45:02 +03:00
|
|
|
brarLog.Tracef("Starting breach arbiter")
|
2016-11-29 06:43:57 +03:00
|
|
|
|
2017-01-15 05:03:45 +03:00
|
|
|
// First we need to query that database state for all currently active
|
|
|
|
// channels, each of these channels will need a goroutine assigned to
|
|
|
|
// it to watch for channel breaches.
|
|
|
|
activeChannels, err := b.db.FetchAllChannels()
|
|
|
|
if err != nil && err != channeldb.ErrNoActiveChannels {
|
2017-05-05 02:08:56 +03:00
|
|
|
brarLog.Errorf("unable to fetch active channels: %v", err)
|
2017-01-15 05:03:45 +03:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
if len(activeChannels) > 0 {
|
|
|
|
brarLog.Infof("Retrieved %v channels from database, watching "+
|
|
|
|
"with vigilance!", len(activeChannels))
|
|
|
|
}
|
|
|
|
|
|
|
|
// For each of the channels read from disk, we'll create a channel
|
|
|
|
// state machine in order to watch for any potential channel closures.
|
2017-07-05 01:52:58 +03:00
|
|
|
channelsToWatch := make([]*lnwallet.LightningChannel, len(activeChannels))
|
2017-01-15 05:03:45 +03:00
|
|
|
for i, chanState := range activeChannels {
|
2017-02-03 04:28:05 +03:00
|
|
|
channel, err := lnwallet.NewLightningChannel(nil, b.notifier,
|
2017-05-01 10:27:12 +03:00
|
|
|
b.estimator, chanState)
|
2017-01-15 05:03:45 +03:00
|
|
|
if err != nil {
|
2017-05-05 02:08:56 +03:00
|
|
|
brarLog.Errorf("unable to load channel from "+
|
|
|
|
"disk: %v", err)
|
2017-01-15 05:03:45 +03:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
channelsToWatch[i] = channel
|
|
|
|
}
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
b.wg.Add(1)
|
2017-01-15 05:03:45 +03:00
|
|
|
go b.contractObserver(channelsToWatch)
|
2016-11-29 06:43:57 +03:00
|
|
|
|
2017-05-11 03:27:05 +03:00
|
|
|
// TODO(roasbeef): instead use closure height of channel
|
|
|
|
_, currentHeight, err := b.chainIO.GetBestBlock()
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2017-05-05 02:12:47 +03:00
|
|
|
// Additionally, we'll also want to retrieve any pending close or force
|
|
|
|
// close transactions to we can properly mark them as resolved in the
|
|
|
|
// database.
|
|
|
|
pendingCloseChans, err := b.db.FetchClosedChannels(true)
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to fetch closing channels: %v", err)
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
for _, pendingClose := range pendingCloseChans {
|
|
|
|
// If this channel was force closed, and we have a non-zero
|
2017-05-15 05:07:08 +03:00
|
|
|
// time-locked balance, then the utxoNursery is currently
|
|
|
|
// watching over it. As a result we don't need to watch over
|
|
|
|
// it.
|
2017-05-05 02:12:47 +03:00
|
|
|
if pendingClose.CloseType == channeldb.ForceClose &&
|
2017-05-15 05:07:08 +03:00
|
|
|
pendingClose.TimeLockedBalance != 0 {
|
2017-05-05 02:12:47 +03:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Infof("Watching for the closure of ChannelPoint(%v)",
|
|
|
|
pendingClose.ChanPoint)
|
|
|
|
|
|
|
|
chanPoint := &pendingClose.ChanPoint
|
|
|
|
closeTXID := &pendingClose.ClosingTXID
|
2017-05-11 03:27:05 +03:00
|
|
|
confNtfn, err := b.notifier.RegisterConfirmationsNtfn(
|
|
|
|
closeTXID, 1, uint32(currentHeight),
|
|
|
|
)
|
2017-05-05 02:12:47 +03:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
// In the case that the ChainNotifier is shutting down,
|
|
|
|
// all subscriber notification channels will be closed,
|
|
|
|
// generating a nil receive.
|
|
|
|
confInfo, ok := <-confNtfn.Confirmed
|
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Infof("ChannelPoint(%v) is fully closed, "+
|
|
|
|
"at height: %v", chanPoint, confInfo.BlockHeight)
|
|
|
|
|
2017-07-31 03:45:39 +03:00
|
|
|
// TODO(roasbeef): need to store UnilateralCloseSummary
|
|
|
|
// on disk so can possibly sweep output here
|
|
|
|
|
2017-05-05 02:12:47 +03:00
|
|
|
if err := b.db.MarkChanFullyClosed(chanPoint); err != nil {
|
|
|
|
brarLog.Errorf("unable to mark chan as closed: %v", err)
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
}
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Stop is an idempotent method that signals the breachArbiter to execute a
|
|
|
|
// graceful shutdown. This function will block until all goroutines spawned by
|
|
|
|
// the breachArbiter have gracefully exited.
|
|
|
|
func (b *breachArbiter) Stop() error {
|
|
|
|
if !atomic.CompareAndSwapUint32(&b.stopped, 0, 1) {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Infof("Breach arbiter shutting down")
|
|
|
|
|
|
|
|
close(b.quit)
|
|
|
|
b.wg.Wait()
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// contractObserver is the primary goroutine for the breachArbiter. This
|
|
|
|
// goroutine is responsible for managing goroutines that watch for breaches for
|
|
|
|
// all current active and newly created channels. If a channel breach is
|
|
|
|
// detected by a spawned child goroutine, then the contractObserver will
|
|
|
|
// execute the retribution logic required to sweep ALL outputs from a contested
|
|
|
|
// channel into the daemon's wallet.
|
|
|
|
//
|
|
|
|
// NOTE: This MUST be run as a goroutine.
|
2017-01-15 05:03:45 +03:00
|
|
|
func (b *breachArbiter) contractObserver(activeChannels []*lnwallet.LightningChannel) {
|
2016-11-29 06:43:57 +03:00
|
|
|
defer b.wg.Done()
|
|
|
|
|
|
|
|
// For each active channel found within the database, we launch a
|
|
|
|
// detected breachObserver goroutine for that channel and also track
|
|
|
|
// the new goroutine within the breachObservers map so we can cancel it
|
|
|
|
// later if necessary.
|
2017-01-15 05:03:45 +03:00
|
|
|
for _, channel := range activeChannels {
|
2016-11-29 06:43:57 +03:00
|
|
|
settleSignal := make(chan struct{})
|
|
|
|
chanPoint := channel.ChannelPoint()
|
|
|
|
b.breachObservers[*chanPoint] = settleSignal
|
|
|
|
|
|
|
|
b.wg.Add(1)
|
|
|
|
go b.breachObserver(channel, settleSignal)
|
|
|
|
}
|
|
|
|
|
2017-05-11 03:27:05 +03:00
|
|
|
// TODO(roasbeef): need to ensure currentHeight passed in doesn't
|
|
|
|
// result in lost notification
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case breachInfo := <-b.breachedContracts:
|
2017-05-11 03:27:05 +03:00
|
|
|
_, currentHeight, err := b.chainIO.GetBestBlock()
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to get best height: %v", err)
|
|
|
|
}
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
// A new channel contract has just been breached! We
|
|
|
|
// first register for a notification to be dispatched
|
|
|
|
// once the breach transaction (the revoked commitment
|
|
|
|
// transaction) has been confirmed in the chain to
|
|
|
|
// ensure we're not dealing with a moving target.
|
|
|
|
breachTXID := &breachInfo.commitHash
|
2017-05-11 03:27:05 +03:00
|
|
|
confChan, err := b.notifier.RegisterConfirmationsNtfn(
|
|
|
|
breachTXID, 1, uint32(currentHeight),
|
|
|
|
)
|
2016-11-29 06:43:57 +03:00
|
|
|
if err != nil {
|
2017-02-10 02:28:32 +03:00
|
|
|
brarLog.Errorf("unable to register for conf for txid: %v",
|
2016-11-29 06:43:57 +03:00
|
|
|
breachTXID)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Warnf("A channel has been breached with tx: %v. "+
|
|
|
|
"Waiting for confirmation, then justice will be served!",
|
|
|
|
breachTXID)
|
|
|
|
|
|
|
|
// With the notification registered, we launch a new
|
|
|
|
// goroutine which will finalize the channel
|
|
|
|
// retribution after the breach transaction has been
|
|
|
|
// confirmed.
|
|
|
|
b.wg.Add(1)
|
|
|
|
go b.exactRetribution(confChan, breachInfo)
|
|
|
|
|
|
|
|
delete(b.breachObservers, breachInfo.chanPoint)
|
|
|
|
case contract := <-b.newContracts:
|
|
|
|
// A new channel has just been opened within the
|
|
|
|
// daemon, so we launch a new breachObserver to handle
|
|
|
|
// the detection of attempted contract breaches.
|
|
|
|
settleSignal := make(chan struct{})
|
|
|
|
chanPoint := contract.ChannelPoint()
|
2016-12-28 02:54:57 +03:00
|
|
|
|
|
|
|
// If the contract is already being watched, then an
|
|
|
|
// additional send indicates we have a stale version of
|
|
|
|
// the contract. So we'll cancel active watcher
|
|
|
|
// goroutine to create a new instance with the latest
|
|
|
|
// contract reference.
|
2016-12-31 03:28:20 +03:00
|
|
|
if oldSignal, ok := b.breachObservers[*chanPoint]; ok {
|
2016-12-28 02:54:57 +03:00
|
|
|
brarLog.Infof("ChannelPoint(%v) is now live, "+
|
|
|
|
"abandoning state contract for live "+
|
|
|
|
"version", chanPoint)
|
2016-12-31 03:28:20 +03:00
|
|
|
close(oldSignal)
|
2016-12-28 02:54:57 +03:00
|
|
|
}
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
b.breachObservers[*chanPoint] = settleSignal
|
|
|
|
|
2016-12-28 02:54:57 +03:00
|
|
|
brarLog.Debugf("New contract detected, launching " +
|
2016-11-29 06:43:57 +03:00
|
|
|
"breachObserver")
|
|
|
|
|
|
|
|
b.wg.Add(1)
|
|
|
|
go b.breachObserver(contract, settleSignal)
|
|
|
|
|
2016-12-28 02:54:57 +03:00
|
|
|
// TODO(roasbeef): add doneChan to signal to peer continue
|
|
|
|
// * peer send over to us on loadActiveChanenls, sync
|
|
|
|
// until we're aware so no state transitions
|
2016-11-29 06:43:57 +03:00
|
|
|
case chanPoint := <-b.settledContracts:
|
|
|
|
// A new channel has been closed either unilaterally or
|
|
|
|
// cooperatively, as a result we no longer need a
|
|
|
|
// breachObserver detected to the channel.
|
|
|
|
killSignal, ok := b.breachObservers[*chanPoint]
|
|
|
|
if !ok {
|
2016-11-29 07:07:58 +03:00
|
|
|
brarLog.Errorf("Unable to find contract: %v",
|
|
|
|
chanPoint)
|
|
|
|
continue
|
2016-11-29 06:43:57 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Debugf("ChannelPoint(%v) has been settled, "+
|
|
|
|
"cancelling breachObserver", chanPoint)
|
|
|
|
|
|
|
|
// If we had a breachObserver active, then we signal it
|
|
|
|
// for exit and also delete its state from our tracking
|
|
|
|
// map.
|
|
|
|
close(killSignal)
|
|
|
|
delete(b.breachObservers, *chanPoint)
|
|
|
|
case <-b.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// exactRetribution is a goroutine which is executed once a contract breach has
|
|
|
|
// been detected by a breachObserver. This function is responsible for
|
2017-01-13 08:01:50 +03:00
|
|
|
// punishing a counterparty for violating the channel contract by sweeping ALL
|
2016-11-29 06:43:57 +03:00
|
|
|
// the lingering funds within the channel into the daemon's wallet.
|
|
|
|
//
|
|
|
|
// NOTE: This MUST be run as a goroutine.
|
|
|
|
func (b *breachArbiter) exactRetribution(confChan *chainntnfs.ConfirmationEvent,
|
|
|
|
breachInfo *retributionInfo) {
|
|
|
|
|
|
|
|
defer b.wg.Done()
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// TODO(roasbeef): state needs to be checkpointed here
|
2016-11-29 06:43:57 +03:00
|
|
|
|
|
|
|
select {
|
|
|
|
case _, ok := <-confChan.Confirmed:
|
|
|
|
// If the second value is !ok, then the channel has been closed
|
|
|
|
// signifying a daemon shutdown, so we exit.
|
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Otherwise, if this is a real confirmation notification, then
|
2017-01-13 08:01:50 +03:00
|
|
|
// we fall through to complete our duty.
|
2016-11-29 06:43:57 +03:00
|
|
|
case <-b.quit:
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Debugf("Breach transaction %v has been confirmed, sweeping "+
|
|
|
|
"revoked funds", breachInfo.commitHash)
|
|
|
|
|
|
|
|
// With the breach transaction confirmed, we now create the justice tx
|
|
|
|
// which will claim ALL the funds within the channel.
|
|
|
|
justiceTx, err := b.createJusticeTx(breachInfo)
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to create justice tx: %v", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
brarLog.Debugf("Broadcasting justice tx: %v", newLogClosure(func() string {
|
|
|
|
return spew.Sdump(justiceTx)
|
|
|
|
}))
|
|
|
|
|
2017-05-11 03:27:05 +03:00
|
|
|
_, currentHeight, err := b.chainIO.GetBestBlock()
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to get current height: %v", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
// Finally, broadcast the transaction, finalizing the channels'
|
2017-01-13 08:01:50 +03:00
|
|
|
// retribution against the cheating counterparty.
|
2016-11-29 06:43:57 +03:00
|
|
|
if err := b.wallet.PublishTransaction(justiceTx); err != nil {
|
|
|
|
brarLog.Errorf("unable to broadcast "+
|
|
|
|
"justice tx: %v", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// As a conclusionary step, we register for a notification to be
|
|
|
|
// dispatched once the justice tx is confirmed. After confirmation we
|
2017-01-13 08:01:50 +03:00
|
|
|
// notify the caller that initiated the retribution workflow that the
|
2016-11-29 06:43:57 +03:00
|
|
|
// deed has been done.
|
2017-01-06 00:56:27 +03:00
|
|
|
justiceTXID := justiceTx.TxHash()
|
2017-05-11 03:27:05 +03:00
|
|
|
confChan, err = b.notifier.RegisterConfirmationsNtfn(&justiceTXID, 1,
|
|
|
|
uint32(currentHeight))
|
2016-11-29 06:43:57 +03:00
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to register for conf for txid: %v",
|
|
|
|
justiceTXID)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
select {
|
|
|
|
case _, ok := <-confChan.Confirmed:
|
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// TODO(roasbeef): factor in HTLCs
|
2016-11-29 06:43:57 +03:00
|
|
|
revokedFunds := breachInfo.revokedOutput.amt
|
|
|
|
totalFunds := revokedFunds + breachInfo.selfOutput.amt
|
|
|
|
|
|
|
|
brarLog.Infof("Justice for ChannelPoint(%v) has "+
|
|
|
|
"been served, %v revoked funds (%v total) "+
|
|
|
|
"have been claimed", breachInfo.chanPoint,
|
|
|
|
revokedFunds, totalFunds)
|
|
|
|
|
2017-05-05 02:10:46 +03:00
|
|
|
// With the channel closed, mark it in the database as such.
|
|
|
|
err := b.db.MarkChanFullyClosed(&breachInfo.chanPoint)
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to mark chan as closed: %v", err)
|
|
|
|
}
|
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
// TODO(roasbeef): add peer to blacklist?
|
|
|
|
|
|
|
|
// TODO(roasbeef): close other active channels with offending peer
|
|
|
|
|
|
|
|
close(breachInfo.doneChan)
|
|
|
|
|
|
|
|
return
|
|
|
|
case <-b.quit:
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// breachObserver notifies the breachArbiter contract observer goroutine that a
|
2017-01-13 08:01:50 +03:00
|
|
|
// channel's contract has been breached by the prior counterparty. Once
|
2016-11-29 06:43:57 +03:00
|
|
|
// notified the breachArbiter will attempt to sweep ALL funds within the
|
|
|
|
// channel using the information provided within the BreachRetribution
|
|
|
|
// generated due to the breach of channel contract. The funds will be swept
|
|
|
|
// only after the breaching transaction receives a necessary number of
|
|
|
|
// confirmations.
|
|
|
|
func (b *breachArbiter) breachObserver(contract *lnwallet.LightningChannel,
|
|
|
|
settleSignal chan struct{}) {
|
|
|
|
|
|
|
|
defer b.wg.Done()
|
|
|
|
|
|
|
|
chanPoint := contract.ChannelPoint()
|
|
|
|
|
|
|
|
brarLog.Debugf("Breach observer for ChannelPoint(%v) started", chanPoint)
|
|
|
|
|
|
|
|
select {
|
|
|
|
// A read from this channel indicates that the contract has been
|
|
|
|
// settled cooperatively so we exit as our duties are no longer needed.
|
|
|
|
case <-settleSignal:
|
2017-02-03 04:28:05 +03:00
|
|
|
contract.Stop()
|
2016-11-29 06:43:57 +03:00
|
|
|
return
|
|
|
|
|
2017-05-05 02:08:56 +03:00
|
|
|
// The channel has been closed by a normal means: force closing with
|
|
|
|
// the latest commitment transaction.
|
|
|
|
case closeInfo := <-contract.UnilateralClose:
|
|
|
|
// Launch a goroutine to cancel out this contract within the
|
|
|
|
// breachArbiter's main goroutine.
|
|
|
|
go func() {
|
|
|
|
b.settledContracts <- chanPoint
|
|
|
|
}()
|
|
|
|
|
|
|
|
// Next, we'll launch a goroutine to wait until the closing
|
|
|
|
// transaction has been confirmed so we can mark the contract
|
|
|
|
// as resolved in the database.
|
|
|
|
//
|
|
|
|
// TODO(roasbeef): also notify utxoNursery, might've had
|
|
|
|
// outbound HTLC's in flight
|
2017-05-11 03:27:05 +03:00
|
|
|
go waitForChanToClose(uint32(closeInfo.SpendingHeight), b.notifier,
|
|
|
|
nil, chanPoint, closeInfo.SpenderTxHash, func() {
|
2017-07-31 03:45:39 +03:00
|
|
|
// As we just detected a channel was closed via
|
|
|
|
// a unilateral commitment broadcast by the
|
|
|
|
// remote party, we'll need to sweep our main
|
|
|
|
// commitment output, and any outstanding
|
|
|
|
// outgoing HTLC we had as well.
|
|
|
|
//
|
|
|
|
// TODO(roasbeef): actually sweep HTLC's *
|
|
|
|
// ensure reliable confirmation
|
|
|
|
if closeInfo.SelfOutPoint != nil {
|
|
|
|
sweepTx, err := b.craftCommitSweepTx(
|
|
|
|
closeInfo,
|
|
|
|
)
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to "+
|
|
|
|
"generate sweep tx: %v", err)
|
|
|
|
goto close
|
|
|
|
}
|
|
|
|
|
|
|
|
err = b.wallet.PublishTransaction(sweepTx)
|
|
|
|
if err != nil {
|
|
|
|
brarLog.Errorf("unable to "+
|
|
|
|
"broadcast tx: %v", err)
|
|
|
|
}
|
|
|
|
}
|
2017-05-05 02:08:56 +03:00
|
|
|
|
2017-07-31 03:45:39 +03:00
|
|
|
close:
|
2017-05-11 03:27:05 +03:00
|
|
|
brarLog.Infof("Force closed ChannelPoint(%v) is "+
|
|
|
|
"fully closed, updating DB", chanPoint)
|
|
|
|
|
|
|
|
if err := b.db.MarkChanFullyClosed(chanPoint); err != nil {
|
|
|
|
brarLog.Errorf("unable to mark chan as closed: %v", err)
|
|
|
|
}
|
|
|
|
})
|
2017-05-05 02:08:56 +03:00
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
// A read from this channel indicates that a channel breach has been
|
|
|
|
// detected! So we notify the main coordination goroutine with the
|
2017-01-13 08:01:50 +03:00
|
|
|
// information needed to bring the counterparty to justice.
|
2016-11-29 06:43:57 +03:00
|
|
|
case breachInfo := <-contract.ContractBreach:
|
|
|
|
brarLog.Warnf("REVOKED STATE #%v FOR ChannelPoint(%v) "+
|
|
|
|
"broadcast, REMOTE PEER IS DOING SOMETHING "+
|
|
|
|
"SKETCHY!!!", breachInfo.RevokedStateNum,
|
|
|
|
chanPoint)
|
|
|
|
|
|
|
|
// Immediately notify the HTLC switch that this link has been
|
|
|
|
// breached in order to ensure any incoming or outgoing
|
2017-01-13 08:01:50 +03:00
|
|
|
// multi-hop HTLCs aren't sent over this link, nor any other
|
2016-11-29 06:43:57 +03:00
|
|
|
// links associated with this peer.
|
2017-05-02 23:04:58 +03:00
|
|
|
b.htlcSwitch.CloseLink(chanPoint, htlcswitch.CloseBreach)
|
2017-05-05 03:04:35 +03:00
|
|
|
chanInfo := contract.StateSnapshot()
|
2017-05-05 02:07:25 +03:00
|
|
|
closeInfo := &channeldb.ChannelCloseSummary{
|
2017-05-15 05:07:08 +03:00
|
|
|
ChanPoint: *chanPoint,
|
|
|
|
ClosingTXID: breachInfo.BreachTransaction.TxHash(),
|
|
|
|
RemotePub: &chanInfo.RemoteIdentity,
|
|
|
|
Capacity: chanInfo.Capacity,
|
|
|
|
SettledBalance: chanInfo.LocalBalance,
|
|
|
|
CloseType: channeldb.BreachClose,
|
|
|
|
IsPending: true,
|
2017-05-05 02:07:25 +03:00
|
|
|
}
|
|
|
|
if err := contract.DeleteState(closeInfo); err != nil {
|
2016-11-29 06:43:57 +03:00
|
|
|
brarLog.Errorf("unable to delete channel state: %v", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
// TODO(roasbeef): need to handle case of remote broadcast
|
|
|
|
// mid-local initiated state-transition, possible false-positive?
|
|
|
|
|
|
|
|
// First we generate the witness generation function which will
|
|
|
|
// be used to sweep the output only we can satisfy on the
|
|
|
|
// commitment transaction. This output is just a regular p2wkh
|
|
|
|
// output.
|
|
|
|
localSignDesc := breachInfo.LocalOutputSignDesc
|
|
|
|
localWitness := func(tx *wire.MsgTx, hc *txscript.TxSigHashes,
|
|
|
|
inputIndex int) ([][]byte, error) {
|
|
|
|
|
|
|
|
desc := localSignDesc
|
|
|
|
desc.SigHashes = hc
|
|
|
|
desc.InputIndex = inputIndex
|
|
|
|
|
2017-07-31 01:55:08 +03:00
|
|
|
return lnwallet.CommitSpendNoDelay(b.wallet.Cfg.Signer, &desc, tx)
|
2016-11-29 06:43:57 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
// Next we create the witness generation function that will be
|
2017-01-13 08:01:50 +03:00
|
|
|
// used to sweep the cheating counterparty's output by taking
|
2016-11-29 06:43:57 +03:00
|
|
|
// advantage of the revocation clause within the output's
|
|
|
|
// witness script.
|
|
|
|
remoteSignDesc := breachInfo.RemoteOutputSignDesc
|
|
|
|
remoteWitness := func(tx *wire.MsgTx, hc *txscript.TxSigHashes,
|
|
|
|
inputIndex int) ([][]byte, error) {
|
|
|
|
|
|
|
|
desc := breachInfo.RemoteOutputSignDesc
|
|
|
|
desc.SigHashes = hc
|
|
|
|
desc.InputIndex = inputIndex
|
|
|
|
|
2017-07-31 01:55:08 +03:00
|
|
|
return lnwallet.CommitSpendRevoke(b.wallet.Cfg.Signer, &desc, tx)
|
2016-11-29 06:43:57 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
// Finally, with the two witness generation funcs created, we
|
|
|
|
// send the retribution information to the utxo nursery.
|
2016-12-28 02:54:57 +03:00
|
|
|
// TODO(roasbeef): populate htlc breaches
|
2016-11-29 06:43:57 +03:00
|
|
|
b.breachedContracts <- &retributionInfo{
|
2017-01-06 00:56:27 +03:00
|
|
|
commitHash: breachInfo.BreachTransaction.TxHash(),
|
2016-11-29 06:43:57 +03:00
|
|
|
chanPoint: *chanPoint,
|
|
|
|
|
|
|
|
selfOutput: &breachedOutput{
|
|
|
|
amt: btcutil.Amount(localSignDesc.Output.Value),
|
|
|
|
outpoint: breachInfo.LocalOutpoint,
|
|
|
|
witnessFunc: localWitness,
|
|
|
|
},
|
|
|
|
|
|
|
|
revokedOutput: &breachedOutput{
|
|
|
|
amt: btcutil.Amount(remoteSignDesc.Output.Value),
|
|
|
|
outpoint: breachInfo.RemoteOutpoint,
|
|
|
|
witnessFunc: remoteWitness,
|
|
|
|
},
|
|
|
|
|
|
|
|
doneChan: make(chan struct{}),
|
|
|
|
}
|
2017-05-05 02:07:25 +03:00
|
|
|
|
2016-11-29 06:43:57 +03:00
|
|
|
case <-b.quit:
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// breachedOutput contains all the information needed to sweep a breached
|
2017-01-13 08:01:50 +03:00
|
|
|
// output. A breached output is an output that we are now entitled to due to a
|
2016-11-29 06:43:57 +03:00
|
|
|
// revoked commitment transaction being broadcast.
|
|
|
|
type breachedOutput struct {
|
|
|
|
amt btcutil.Amount
|
|
|
|
outpoint wire.OutPoint
|
|
|
|
witnessFunc witnessGenerator
|
|
|
|
|
|
|
|
twoStageClaim bool
|
|
|
|
}
|
|
|
|
|
|
|
|
// retributionInfo encapsulates all the data needed to sweep all the contested
|
|
|
|
// funds within a channel whose contract has been breached by the prior
|
2017-01-13 08:01:50 +03:00
|
|
|
// counterparty. This struct is used by the utxoNursery to create the justice
|
2016-11-29 06:43:57 +03:00
|
|
|
// transaction which spends all outputs of the commitment transaction into an
|
|
|
|
// output controlled by the wallet.
|
|
|
|
type retributionInfo struct {
|
2017-01-06 00:56:27 +03:00
|
|
|
commitHash chainhash.Hash
|
2016-11-29 06:43:57 +03:00
|
|
|
chanPoint wire.OutPoint
|
|
|
|
|
|
|
|
selfOutput *breachedOutput
|
|
|
|
|
|
|
|
revokedOutput *breachedOutput
|
|
|
|
|
|
|
|
htlcOutputs *[]breachedOutput
|
|
|
|
|
|
|
|
doneChan chan struct{}
|
|
|
|
}
|
|
|
|
|
|
|
|
// createJusticeTx creates a transaction which exacts "justice" by sweeping ALL
|
|
|
|
// the funds within the channel which we are now entitled to due to a breach of
|
2017-01-13 08:01:50 +03:00
|
|
|
// the channel's contract by the counterparty. This function returns a *fully*
|
2016-11-29 06:43:57 +03:00
|
|
|
// signed transaction with the witness for each input fully in place.
|
|
|
|
func (b *breachArbiter) createJusticeTx(r *retributionInfo) (*wire.MsgTx, error) {
|
|
|
|
// First, we obtain a new public key script from the wallet which we'll
|
|
|
|
// sweep the funds to.
|
|
|
|
// TODO(roasbeef): possibly create many outputs to minimize change in
|
|
|
|
// the future?
|
|
|
|
pkScriptOfJustice, err := newSweepPkScript(b.wallet)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// Before creating the actual TxOut, we'll need to calculate the proper fee
|
2016-11-29 06:43:57 +03:00
|
|
|
// to attach to the transaction to ensure a timely confirmation.
|
|
|
|
// TODO(roasbeef): remove hard-coded fee
|
|
|
|
totalAmt := r.selfOutput.amt + r.revokedOutput.amt
|
|
|
|
sweepedAmt := int64(totalAmt - 5000)
|
|
|
|
|
2017-01-13 08:01:50 +03:00
|
|
|
// With the fee calculated, we can now create the justice transaction
|
2016-11-29 06:43:57 +03:00
|
|
|
// using the information gathered above.
|
2017-01-06 00:56:27 +03:00
|
|
|
justiceTx := wire.NewMsgTx(2)
|
2016-11-29 06:43:57 +03:00
|
|
|
justiceTx.AddTxOut(&wire.TxOut{
|
|
|
|
PkScript: pkScriptOfJustice,
|
|
|
|
Value: sweepedAmt,
|
|
|
|
})
|
|
|
|
justiceTx.AddTxIn(&wire.TxIn{
|
|
|
|
PreviousOutPoint: r.selfOutput.outpoint,
|
|
|
|
})
|
|
|
|
justiceTx.AddTxIn(&wire.TxIn{
|
|
|
|
PreviousOutPoint: r.revokedOutput.outpoint,
|
|
|
|
})
|
|
|
|
|
|
|
|
hashCache := txscript.NewTxSigHashes(justiceTx)
|
|
|
|
|
|
|
|
// Finally, using the witness generation functions attached to the
|
|
|
|
// retribution information, we'll populate the inputs with fully valid
|
2017-01-13 08:01:50 +03:00
|
|
|
// witnesses for both commitment outputs, and all the pending HTLCs at
|
2016-11-29 06:43:57 +03:00
|
|
|
// this state in the channel's history.
|
2017-01-13 08:01:50 +03:00
|
|
|
// TODO(roasbeef): handle the 2-layer HTLCs
|
2016-11-29 06:43:57 +03:00
|
|
|
localWitness, err := r.selfOutput.witnessFunc(justiceTx, hashCache, 0)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
justiceTx.TxIn[0].Witness = localWitness
|
|
|
|
|
|
|
|
remoteWitness, err := r.revokedOutput.witnessFunc(justiceTx, hashCache, 1)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
justiceTx.TxIn[1].Witness = remoteWitness
|
|
|
|
|
|
|
|
return justiceTx, nil
|
|
|
|
}
|
2017-07-31 03:45:39 +03:00
|
|
|
|
|
|
|
// craftCommitmentSweepTx creates a transaction to sweep the non-delayed output
|
|
|
|
// within the commitment transaction that pays to us. We must manually sweep
|
|
|
|
// this output as it uses a tweaked public key in its pkScript, so the wallet
|
|
|
|
// won't immediacy be aware of it.
|
|
|
|
//
|
|
|
|
// TODO(roasbeef): alternative options
|
|
|
|
// * leave the output in the chain, use as input to future funding tx
|
|
|
|
// * leave output in the chain, extend wallet to add knowledge of how to claim
|
|
|
|
func (b *breachArbiter) craftCommitSweepTx(closeInfo *lnwallet.UnilateralCloseSummary) (*wire.MsgTx, error) {
|
|
|
|
// First, we'll fetch a fresh script that we can use to sweep the funds
|
|
|
|
// under the control of the wallet.
|
|
|
|
sweepPkScript, err := newSweepPkScript(b.wallet)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// TODO(roasbeef): use proper fees
|
|
|
|
outputAmt := closeInfo.SelfOutputSignDesc.Output.Value
|
|
|
|
sweepAmt := int64(outputAmt - 5000)
|
|
|
|
|
|
|
|
if sweepAmt <= 0 {
|
|
|
|
// TODO(roasbeef): add output to special pool, can be swept
|
|
|
|
// when: funding a channel, sweeping time locked outputs, or
|
|
|
|
// delivering
|
|
|
|
// justice after a channel breach
|
|
|
|
return nil, fmt.Errorf("output to small to sweep in isolation")
|
|
|
|
}
|
|
|
|
|
|
|
|
// With the amount we're sweeping computed, we can now creating the
|
|
|
|
// sweep transaction itself.
|
|
|
|
sweepTx := wire.NewMsgTx(1)
|
|
|
|
sweepTx.AddTxIn(&wire.TxIn{
|
|
|
|
PreviousOutPoint: *closeInfo.SelfOutPoint,
|
|
|
|
})
|
|
|
|
sweepTx.AddTxOut(&wire.TxOut{
|
|
|
|
PkScript: sweepPkScript,
|
|
|
|
Value: int64(sweepAmt),
|
|
|
|
})
|
|
|
|
|
|
|
|
// Next, we'll generate the signature required to satisfy the p2wkh
|
|
|
|
// witness program.
|
|
|
|
signDesc := closeInfo.SelfOutputSignDesc
|
|
|
|
signDesc.SigHashes = txscript.NewTxSigHashes(sweepTx)
|
|
|
|
signDesc.InputIndex = 0
|
|
|
|
sweepSig, err := b.wallet.Cfg.Signer.SignOutputRaw(sweepTx, signDesc)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Finally, we'll manually craft the witness. The witness here is the
|
|
|
|
// exact same as a regular p2wkh witness, but we'll need to ensure that
|
|
|
|
// we use the tweaked public key as the last item in the witness stack
|
|
|
|
// which was originally used to created the pkScript we're spending.
|
|
|
|
witness := make([][]byte, 2)
|
|
|
|
witness[0] = append(sweepSig, byte(txscript.SigHashAll))
|
|
|
|
witness[1] = lnwallet.TweakPubKeyWithTweak(
|
|
|
|
signDesc.PubKey, signDesc.SingleTweak,
|
|
|
|
).SerializeCompressed()
|
|
|
|
|
|
|
|
sweepTx.TxIn[0].Witness = witness
|
|
|
|
|
|
|
|
brarLog.Infof("Sweeping commitment output with: %v", spew.Sdump(sweepTx))
|
|
|
|
|
|
|
|
return sweepTx, nil
|
|
|
|
}
|