Revamp funding workflow to match p2p workflow

* Now more closely mirrors Joseph’s photos
* 3 step dance: init, theirFunds, theirSigs -> complete
* Currently missing any concept of reserve funds for CLTV
* Many lingering TODO’s still, once addressed will move onto Commitment
TX update, and HTLC workflow
This commit is contained in:
Olaoluwa Osuntokun 2015-11-05 12:36:19 -08:00
parent ce8be70c74
commit ca40a2d924
1 changed files with 406 additions and 60 deletions

View File

@ -1,16 +1,18 @@
package wallet
import (
"encoding/hex"
"errors"
"fmt"
"sync"
"sync/atomic"
"github.com/btcsuite/btcd/btcec"
"github.com/btcsuite/btcd/btcjson"
"github.com/btcsuite/btcd/chaincfg"
"github.com/btcsuite/btcd/txscript"
"github.com/btcsuite/btcd/wire"
"github.com/btcsuite/btcutil"
"github.com/btcsuite/btcutil/coinset"
"github.com/btcsuite/btcutil/txsort"
"github.com/btcsuite/btcwallet/waddrmgr"
btcwallet "github.com/btcsuite/btcwallet/wallet"
"github.com/btcsuite/btcwallet/walletdb"
@ -21,46 +23,150 @@ var (
lightningNamespaceKey = []byte("lightning")
// Error types
ErrInsufficientFunds = errors.New("not enough available outputs to create funding transaction")
ErrInsufficientFunds = errors.New("not enough available outputs to " +
"create funding transaction")
// Which bitcoin network are we using?
ActiveNetParams = &chaincfg.TestNet3Params
)
// FundingRequest...
type FundingReserveRequest struct {
type FundingType uint16
const (
//Use SIGHASH_NOINPUT, assumes CSV
SIGHASH FundingType = iota
//Use CSV without reserve
CSV
// Use CSV with reserve
// Reserve is a permanent amount of funds locked and the capacity.
CSV_RESERVE
// CLTV with reserve.
CLTV_RESERVE
)
// partialFundingState...
type partialFundingState struct {
fundingType FundingType
fundingAmount btcutil.Amount
reserveAmount btcutil.Amount
minFeePerKb btcutil.Amount
theirInputs []*wire.TxIn
ourInputs []*wire.TxIn
theirChange []*wire.TxOut
ourChange []*wire.TxOut
ourKey *btcec.PrivateKey
theirKey *btcec.PublicKey
theirSigs [][]byte
ourSigs [][]byte
normalizedTxID wire.ShaHash
fundingTx *wire.MsgTx
// TODO(roasbef): time locks, who pays fee etc.
// TODO(roasbeef): record Bob's ln-ID?
}
// newPartialFundingState...
func newPartialFundingState(t FundingType, fundingAmt btcutil.Amount, minFeeRate btcutil.Amount) *partialFundingState {
return &partialFundingState{
fundingType: t,
fundingAmount: fundingAmt,
minFeePerKb: minFeeRate,
}
}
// completedFundingState...
type completedFundingState struct {
partialFundingState
regularTxID wire.ShaHash
}
// initFundingReserveReq...
type initFundingReserveMsg struct {
fundingAmount btcutil.Amount
fundingType FundingType
minFeeRate btcutil.Amount
// TODO(roasbeef): optional reserve for CLTV, etc.
// Insuffcient funds etc..
err chan error // Buffered
resp chan *FundingReserveResponse // Buffered
resp chan *FundingReservation // Buffered
}
// FundingResponse...
type FundingReserveResponse struct {
fundingInputs []*wire.TxIn
changeOutputs []*wire.TxOut
type FundingReservation struct {
FundingInputs []*wire.TxIn
ChangeOutputs []*wire.TxOut
FundingAmount btcutil.Amount
// To be used in the 2-of-2 output.
OurKey *btcec.PrivateKey
ReservationID uint64
}
// FundingReserveCancelMsg...
type FundingReserveCancelMsg struct {
reserveToCancel *FundingReserveResponse
type fundingReserveCancelMsg struct {
pendingFundingID uint64
// Buffered, used for optionally synchronization.
err chan error // Buffered
done chan struct{} // Buffered
}
// FundingReserveRequest...
type FundingCompleteRequest struct {
fundingReservation *FundingReserveResponse
// addCounterPartySigsMsg...
type addCounterPartyFundsMsg struct {
pendingFundingID uint64
theirInputs []*wire.TxIn // Includes sig-script to redeem.
// TODO(roasbeef): Should also carry SPV proofs in we're in SPV mode
theirInputs []*wire.TxIn
theirChangeOutputs []*wire.TxOut
theirKey *btcec.PublicKey
err chan error // Buffered
resp chan FundingCompleteResponse // Buffered
err chan error // Buffered
resp chan *PartiallySignedFundingState // Buffered
}
// FundingCompleteResponse....
type FundingCompleteResponse struct {
fundingTx *btcutil.Tx
type PartiallySignedFundingState struct {
ReservationID uint64
// In order of sorted inputs that are ours. Sorting is done in accordance
// to BIP-69: https://github.com/bitcoin/bips/blob/master/bip-0069.mediawiki.
OurSigs [][]byte
NormalizedTxID wire.ShaHash
}
// addCounterPartySigsMsg...
type addCounterPartySigsMsg struct {
pendingFundingID uint64
// Should be order of sorted inputs that are theirs. Sorting is done in accordance
// to BIP-69: https://github.com/bitcoin/bips/blob/master/bip-0069.mediawiki.
theirSigs [][]byte
err chan error // Buffered
resp chan *FinalizedFundingState // Buffered
}
// FundingCompleteResp...
type FinalizedFundingState struct {
FundingTxId wire.ShaHash
NormalizedFundingTXID wire.ShaHash
CompletedFundingTx *btcutil.Tx
}
// LightningWallet....
@ -134,10 +240,14 @@ out:
select {
case m := <-l.msgChan:
switch msg := m.(type) {
case *FundingReserveRequest:
case *initFundingReserveMsg:
l.handleFundingReserveRequest(msg)
case *FundingReserveCancelMsg:
case *fundingReserveCancelMsg:
l.handleFundingCancelRequest(msg)
case *addCounterPartyFundsMsg:
l.handleFundingCounterPartyFunds(msg)
case *addCounterPartySigsMsg:
l.handleFundingCounterPartySigs(msg)
}
case <-l.quit:
// TODO: do some clean up
@ -148,9 +258,30 @@ out:
l.wg.Done()
}
// RequestFundingReservation...
func (l *LightningWallet) RequestFundingReservation(a btcutil.Amount, t FundingType) (*FundingReservation, error) {
errChan := make(chan error, 1)
respChan := make(chan *FundingReservation, 1)
l.msgChan <- &initFundingReserveMsg{
fundingAmount: a,
fundingType: t,
err: errChan,
resp: respChan,
}
return <-respChan, <-errChan
}
// handleFundingReserveRequest...
func (l *LightningWallet) handleFundingReserveRequest(req *FundingReserveRequest) {
fundingAmt := req.fundingAmount
func (l *LightningWallet) handleFundingReserveRequest(req *initFundingReserveMsg) {
// Create a limbo and record entry for this newly pending funding request.
partialState := newPartialFundingState(req.fundingType, req.fundingAmount, req.minFeeRate)
l.limboMtx.Lock()
id := l.nextFundingID
l.nextFundingID++
l.fundingLimbo[id] = partialState
l.limboMtx.Unlock()
// Find all unlocked unspent outputs with greater than 6 confirmations.
maxConfs := ^int32(0)
@ -180,12 +311,12 @@ func (l *LightningWallet) handleFundingReserveRequest(req *FundingReserveRequest
MaxInputs: 10,
MinChangeAmount: 10000,
}
selectedCoins, err := selector.CoinSelect(fundingAmt, coins)
selectedCoins, err := selector.CoinSelect(req.fundingAmount, coins)
// Lock the selected coins. These coins are now "reserved", this
// prevents concurrent funding requests from referring to and this
// double-spending the same set of coins.
fundingInputs := make([]*wire.TxIn, len(selectedCoins.Coins()))
partialState.ourInputs = make([]*wire.TxIn, len(selectedCoins.Coins()))
for i, coin := range selectedCoins.Coins() {
txout := wire.NewOutPoint(coin.Hash(), coin.Index())
l.LockOutpoint(*txout)
@ -193,70 +324,285 @@ func (l *LightningWallet) handleFundingReserveRequest(req *FundingReserveRequest
// Empty sig script, we'll actually sign if this reservation is
// queued up to be completed (the other side accepts).
outPoint := wire.NewOutPoint(coin.Hash(), coin.Index())
fundingInputs[i] = wire.NewTxIn(outPoint, nil)
partialState.ourInputs[i] = wire.NewTxIn(outPoint, nil)
}
// Create some possibly neccessary change outputs.
selectedTotalValue := coinset.NewCoinSet(coins).TotalValue()
changeOutputs := make([]*wire.TxOut, 0, len(selectedCoins.Coins()))
if selectedTotalValue > fundingAmt {
partialState.ourChange = make([]*wire.TxOut, 0, len(selectedCoins.Coins()))
if selectedTotalValue > req.fundingAmount {
// Change is necessary. Query for an available change address to
// send the remainder to.
changeAmount := selectedTotalValue - fundingAmt
changeAmount := selectedTotalValue - req.fundingAmount
changeAddr, err := l.NewChangeAddress(waddrmgr.DefaultAccountNum)
if err != nil {
req.err <- err
req.resp <- nil
return
}
changeOutputs = append(changeOutputs,
partialState.ourChange = append(partialState.ourChange,
wire.NewTxOut(int64(changeAmount), changeAddr.ScriptAddress()))
}
// TODO(roasbeef): re-calculate fees here to minFeePerKB
multiSigKey, err := l.keyPool.getNextMultiSigKey()
if err != nil {
req.err <- err
req.resp <- nil
return
}
// Funding reservation request succesfully handled. The funding inputs
// will be marked as unavailable until the reservation is either
// completed, or cancecled.
req.err <- nil
req.resp <- &FundingReserveResponse{
fundingInputs: fundingInputs,
changeOutputs: changeOutputs,
req.resp <- &FundingReservation{
FundingInputs: partialState.ourInputs,
ChangeOutputs: partialState.ourChange,
FundingAmount: partialState.fundingAmount,
OurKey: multiSigKey,
}
}
// lnCoin...
// to adhere to the coinset.Coin interface
type lnCoin struct {
hash *wire.ShaHash
index uint32
value btcutil.Amount
pkScript []byte
numConfs int64
valueAge int64
}
}
if err != nil {
}
if err != nil {
}
// RequestFundingReserveCancellation...
func (l *LightningWallet) CancelFundingReservation(reservationID uint64) {
doneChan := make(chan struct{}, 1)
l.msgChan <- &fundingReserveCancelMsg{
pendingFundingID: reservationID,
done: doneChan,
}
<-doneChan
}
// handleFundingReserveCancel...
func (l *LightningWallet) handleFundingCancelRequest(req *FundingReserveCancelMsg) {
prevReservation := req.reserveToCancel
func (l *LightningWallet) handleFundingCancelRequest(req *fundingReserveCancelMsg) {
// TODO(roasbeef): holding lock too long
l.limboMtx.Lock()
defer l.limboMtx.Unlock()
for _, unusedInput := range prevReservation.fundingInputs {
pendingReservation, ok := l.fundingLimbo[req.pendingFundingID]
if !ok {
// TODO(roasbeef): make new error, "unkown funding state" or something
req.err <- fmt.Errorf("attempted to cancel non-existant funding state")
req.done <- struct{}{}
return
}
// Mark all previously locked outpoints as usuable for future funding
// requests.
for _, unusedInput := range pendingReservation.ourInputs {
l.UnlockOutpoint(unusedInput.PreviousOutPoint)
}
// Return the unused multi-sig key back to the pool.
l.keyPool.releaseMultiSigKey(pendingReservation.ourKey)
// TODO(roasbeef): Is it possible to mark the unused change also as
// available?
delete(l.fundingLimbo, req.pendingFundingID)
req.err <- nil
req.done <- struct{}{}
}
// AddCounterPartyFunds...
func (l *LightningWallet) AddCounterPartyFundsForReservation(
reservationId uint64,
theirInputs []*wire.TxIn,
theirChangeOutputs []*wire.TxOut,
multiSigKey *btcec.PublicKey) (*FinalizedFundingState, error) {
errChan := make(chan error, 1)
respChan := make(chan *FinalizedFundingState, 1)
l.msgChan <- &addCounterPartyFundsMsg{
pendingFundingID: reservationId,
theirInputs: theirInputs,
theirChangeOutputs: theirChangeOutputs,
theirKey: multiSigKey,
}
return <-respChan, <-errChan
}
// handleFundingCounterPartyFunds...
func (l *LightningWallet) handleFundingCounterPartyFunds(req *addCounterPartyFundsMsg) {
l.RLock()
pendingReservation, ok := l.fundingLimbo[req.pendingFundingID]
l.RUnlock()
if !ok {
req.err <- fmt.Errorf("attempted to update non-existant funding state")
return
}
// Create a blank, fresh transaction. Soon to be a complete funding
// transaction which will allow opening a lightning channel.
pendingReservation.fundingTx = wire.NewMsgTx()
// First, add all multi-party inputs to the transaction
// TODO(roasbeef); handle case that tx doesn't exist, fake input
// TODO(roasbeef): validate SPV proof from other side if in SPV mode.
for _, ourInput := range pendingReservation.ourInputs {
pendingReservation.fundingTx.AddTxIn(ourInput)
}
pendingReservation.theirInputs = req.theirInputs
for _, theirInput := range pendingReservation.theirInputs {
pendingReservation.fundingTx.AddTxIn(theirInput)
}
// Next, add all multi-party outputs to the transaction. This includes
// change outputs for both side.
for _, ourChangeOutput := range pendingReservation.ourChange {
pendingReservation.fundingTx.AddTxOut(ourChangeOutput)
}
pendingReservation.theirChange = req.theirChangeOutputs
for _, theirChangeOutput := range pendingReservation.theirChange {
pendingReservation.fundingTx.AddTxOut(theirChangeOutput)
}
// Finally, add the 2-of-2 multi-sig output which will set up the lightning
// channel. TODO(roasbeef): Cannonical sorting of keys here?
keys := make([]*btcutil.AddressPubKey, 2)
ourKey := pendingReservation.ourKey.PubKey().SerializeCompressed()
keys[0], _ = btcutil.NewAddressPubKey(ourKey, ActiveNetParams)
pendingReservation.theirKey = req.theirKey
keys[1], _ = btcutil.NewAddressPubKey(pendingReservation.theirKey.SerializeCompressed(), ActiveNetParams)
multiSigScript, err := txscript.MultiSigScript(keys, 2)
if err != nil {
req.err <- err
req.resp <- nil
return
}
multiSigOut := wire.NewTxOut(int64(pendingReservation.fundingAmount),
multiSigScript)
pendingReservation.fundingTx.AddTxOut(multiSigOut)
// Sort the transaction. Since both side agree to a cannonical
// ordering, by sorting we no longer need to send the entire
// transaction. Only signatures will be exchanged.
txsort.InPlaceSort(pendingReservation.fundingTx)
// Now that the transaction has been cannonically sorted, compute the
// normalized transation ID before we attach our signatures.
pendingReservation.normalizedTxID = pendingReservation.fundingTx.TxSha()
// Now, sign all inputs that are ours, collecting the signatures in
// order of the inputs.
pendingReservation.ourSigs = make([][]byte, len(pendingReservation.ourInputs))
for i, txIn := range pendingReservation.fundingTx.TxIn {
// Does the wallet know about the txin?
txDetail, _ := l.TxStore.TxDetails(&txIn.PreviousOutPoint.Hash)
if txDetail == nil {
continue
}
// Is this our txin? TODO(roasbeef): assumes all inputs are P2PKH...
prevIndex := txIn.PreviousOutPoint.Index
prevOut := txDetail.TxRecord.MsgTx.TxOut[prevIndex]
_, addrs, _, _ := txscript.ExtractPkScriptAddrs(prevOut.PkScript, ActiveNetParams)
apkh, ok := addrs[0].(*btcutil.AddressPubKeyHash)
if !ok {
req.err <- btcwallet.ErrUnsupportedTransactionType
req.resp <- nil
return
}
ai, err := l.Manager.Address(apkh)
if err != nil {
req.err <- fmt.Errorf("cannot get address info: %v", err)
req.resp <- nil
return
}
pka := ai.(waddrmgr.ManagedPubKeyAddress)
privkey, err := pka.PrivKey()
if err != nil {
req.err <- fmt.Errorf("cannot get private key: %v", err)
req.resp <- nil
return
}
sigscript, err := txscript.SignatureScript(pendingReservation.fundingTx, i,
prevOut.PkScript, txscript.SigHashAll, privkey,
ai.Compressed())
if err != nil {
req.err <- fmt.Errorf("cannot create sigscript: %s", err)
req.resp <- nil
return
}
pendingReservation.fundingTx.TxIn[i].SignatureScript = sigscript
pendingReservation.ourSigs[i] = sigscript
}
// Import the key we're using for the 2-of-2 multi-sig into the wallet,
// so we can sign to spend from the funding tx later.
// TODO(roasbeef): remove this after drawing pool key from HD.
wif, _ := btcutil.NewWIF(pendingReservation.ourKey, ActiveNetParams, true)
if _, err := l.ImportPrivateKey(wif, nil, false); err != nil {
req.err <- err
req.resp <- nil
return
}
req.err <- nil
req.resp <- &PartiallySignedFundingState{
OurSigs: pendingReservation.ourSigs,
NormalizedTxID: pendingReservation.normalizedTxID,
}
}
// CompleteFundingReservation...
func (l *LightningWallet) CompleteFundingReservation(reservationID uint64, theirSigs [][]byte) (*FinalizedFundingState, error) {
errChan := make(chan error, 1)
respChan := make(chan *FinalizedFundingState, 1)
l.msgChan <- &addCounterPartySigsMsg{
pendingFundingID: reservationID,
theirSigs: theirSigs,
err: errChan,
resp: respChan,
}
return <-respChan, <-errChan
}
// handleFundingCounterPartySigs...
func (l *LightningWallet) handleFundingCounterPartySigs(msg *addCounterPartySigsMsg) {
l.RLock()
pendingReservation, ok := l.fundingLimbo[msg.pendingFundingID]
l.RUnlock()
if !ok {
msg.err <- fmt.Errorf("attempted to update non-existant funding state")
msg.resp <- nil
return
}
// Now we can complete the funding transaction by adding their
// signatures to their inputs.
i := 0
pendingReservation.theirSigs = msg.theirSigs
for _, txin := range pendingReservation.fundingTx.TxIn {
if txin.SignatureScript == nil {
// TODO(roasbeef): use txscript.Engine to make sure each sig is
// valid, txn complete.
txin.SignatureScript = pendingReservation.theirSigs[i]
i++
}
}
// Now that all signatures are in place and valid record the regular txid
finalTxID := pendingReservation.fundingTx.TxSha()
msg.err <- nil
msg.resp <- &FinalizedFundingState{
FundingTxId: finalTxID,
NormalizedFundingTXID: pendingReservation.normalizedTxID,
CompletedFundingTx: btcutil.NewTx(pendingReservation.fundingTx),
}
// TODO(roasbeef): write the funding transaction to disk, delete from pending
}