2015-12-26 09:09:17 +03:00
|
|
|
package main
|
2016-01-14 08:41:46 +03:00
|
|
|
|
|
|
|
import (
|
2016-01-17 06:07:44 +03:00
|
|
|
"encoding/hex"
|
2016-01-14 08:41:46 +03:00
|
|
|
"fmt"
|
|
|
|
"net"
|
|
|
|
"sync"
|
|
|
|
"sync/atomic"
|
|
|
|
|
2016-07-06 04:48:35 +03:00
|
|
|
"github.com/btcsuite/fastsha256"
|
2016-03-23 04:49:22 +03:00
|
|
|
"github.com/lightningnetwork/lnd/channeldb"
|
2016-01-17 06:07:44 +03:00
|
|
|
"github.com/lightningnetwork/lnd/lndc"
|
2016-01-16 21:38:48 +03:00
|
|
|
"github.com/lightningnetwork/lnd/lnwallet"
|
2016-05-15 17:17:44 +03:00
|
|
|
"github.com/roasbeef/btcd/btcec"
|
2016-06-21 21:52:09 +03:00
|
|
|
"github.com/roasbeef/btcd/wire"
|
|
|
|
"github.com/roasbeef/btcutil"
|
2016-01-14 08:41:46 +03:00
|
|
|
|
2016-05-15 17:17:44 +03:00
|
|
|
"github.com/roasbeef/btcwallet/waddrmgr"
|
2016-01-14 08:41:46 +03:00
|
|
|
)
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// server is the main server of the Lightning Network Daemon. The server
|
|
|
|
// houses global state pertianing to the wallet, database, and the rpcserver.
|
|
|
|
// Additionally, the server is also used as a central messaging bus to interact
|
|
|
|
// with any of its companion objects.
|
2016-01-14 08:41:46 +03:00
|
|
|
type server struct {
|
|
|
|
started int32 // atomic
|
|
|
|
shutdown int32 // atomic
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// identityPriv is the private key used to authenticate any incoming
|
|
|
|
// connections.
|
|
|
|
identityPriv *btcec.PrivateKey
|
2016-01-17 06:07:44 +03:00
|
|
|
|
2016-07-06 04:48:35 +03:00
|
|
|
// lightningID is the sha256 of the public key corresponding to our
|
|
|
|
// long-term identity private key.
|
|
|
|
lightningID [32]byte
|
|
|
|
|
2016-01-17 06:07:44 +03:00
|
|
|
listeners []net.Listener
|
|
|
|
peers map[int32]*peer
|
2016-01-14 08:41:46 +03:00
|
|
|
|
|
|
|
rpcServer *rpcServer
|
2016-06-21 21:52:09 +03:00
|
|
|
// TODO(roasbeef): add chan notifier also
|
|
|
|
lnwallet *lnwallet.LightningWallet
|
|
|
|
|
|
|
|
// TODO(roasbeef): add to constructor
|
|
|
|
fundingMgr *fundingManager
|
|
|
|
chanDB *channeldb.DB
|
2016-01-14 08:41:46 +03:00
|
|
|
|
2016-07-10 02:36:25 +03:00
|
|
|
htlcSwitch *htlcSwitch
|
2016-07-13 03:14:07 +03:00
|
|
|
invoices *invoiceRegistry
|
2016-07-10 02:36:25 +03:00
|
|
|
|
2016-01-14 08:41:46 +03:00
|
|
|
newPeers chan *peer
|
|
|
|
donePeers chan *peer
|
2016-01-17 06:07:44 +03:00
|
|
|
queries chan interface{}
|
2016-01-14 08:41:46 +03:00
|
|
|
|
|
|
|
wg sync.WaitGroup
|
|
|
|
quit chan struct{}
|
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// newServer creates a new instance of the server which is to listen using the
|
|
|
|
// passed listener address.
|
2016-03-23 04:49:22 +03:00
|
|
|
func newServer(listenAddrs []string, wallet *lnwallet.LightningWallet,
|
|
|
|
chanDB *channeldb.DB) (*server, error) {
|
|
|
|
|
|
|
|
privKey, err := getIdentityPrivKey(chanDB, wallet)
|
2016-01-17 06:07:44 +03:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
listeners := make([]net.Listener, len(listenAddrs))
|
|
|
|
for i, addr := range listenAddrs {
|
|
|
|
listeners[i], err = lndc.NewListener(privKey, addr)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2016-07-06 04:48:35 +03:00
|
|
|
serializedPubKey := privKey.PubKey().SerializeCompressed()
|
2016-01-17 06:07:44 +03:00
|
|
|
s := &server{
|
2016-03-23 04:49:22 +03:00
|
|
|
chanDB: chanDB,
|
2016-06-21 21:52:09 +03:00
|
|
|
fundingMgr: newFundingManager(wallet),
|
2016-07-10 02:36:25 +03:00
|
|
|
htlcSwitch: newHtlcSwitch(),
|
2016-07-13 03:14:07 +03:00
|
|
|
invoices: newInvoiceRegistry(),
|
2016-06-21 21:52:09 +03:00
|
|
|
lnwallet: wallet,
|
|
|
|
identityPriv: privKey,
|
2016-07-06 04:48:35 +03:00
|
|
|
lightningID: fastsha256.Sum256(serializedPubKey),
|
2016-01-17 06:07:44 +03:00
|
|
|
listeners: listeners,
|
|
|
|
peers: make(map[int32]*peer),
|
|
|
|
newPeers: make(chan *peer, 100),
|
|
|
|
donePeers: make(chan *peer, 100),
|
|
|
|
queries: make(chan interface{}),
|
|
|
|
quit: make(chan struct{}),
|
|
|
|
}
|
|
|
|
|
2016-07-13 03:14:07 +03:00
|
|
|
// TODO(roasbeef): remove
|
|
|
|
s.invoices.addInvoice(1000*1e8, *debugPre)
|
|
|
|
|
2016-01-17 06:07:44 +03:00
|
|
|
s.rpcServer = newRpcServer(s)
|
|
|
|
|
|
|
|
return s, nil
|
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// Start starts the main daemon server, all requested listeners, and any helper
|
|
|
|
// goroutines.
|
|
|
|
func (s *server) Start() {
|
|
|
|
// Already running?
|
|
|
|
if atomic.AddInt32(&s.started, 1) != 1 {
|
2016-01-17 06:09:02 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// Start all the listeners.
|
|
|
|
for _, l := range s.listeners {
|
|
|
|
s.wg.Add(1)
|
|
|
|
go s.listener(l)
|
2016-01-17 06:09:02 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
s.fundingMgr.Start()
|
2016-07-10 02:36:25 +03:00
|
|
|
s.htlcSwitch.Start()
|
2016-06-21 21:52:09 +03:00
|
|
|
|
|
|
|
s.wg.Add(2)
|
|
|
|
go s.peerManager()
|
|
|
|
go s.queryHandler()
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// Stop gracefully shutsdown the main daemon server. This function will signal
|
|
|
|
// any active goroutines, or helper objects to exit, then blocks until they've
|
|
|
|
// all successfully exited. Additionally, any/all listeners are closed.
|
|
|
|
func (s *server) Stop() error {
|
|
|
|
// Bail if we're already shutting down.
|
|
|
|
if atomic.AddInt32(&s.shutdown, 1) != 1 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Stop all the listeners.
|
|
|
|
for _, listener := range s.listeners {
|
|
|
|
if err := listener.Close(); err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Shutdown the wallet, funding manager, and the rpc server.
|
|
|
|
s.rpcServer.Stop()
|
|
|
|
s.lnwallet.Shutdown()
|
|
|
|
s.fundingMgr.Stop()
|
|
|
|
|
|
|
|
// Signal all the lingering goroutines to quit.
|
|
|
|
close(s.quit)
|
|
|
|
s.wg.Wait()
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// WaitForShutdown blocks all goroutines have been stopped.
|
|
|
|
func (s *server) WaitForShutdown() {
|
|
|
|
s.wg.Wait()
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// peerManager handles any requests to modify the server's internal state of
|
|
|
|
// all active peers. Additionally, any queries directed at peers will be
|
|
|
|
// handled by this goroutine.
|
|
|
|
//
|
|
|
|
// NOTE: This MUST be run as a goroutine.
|
2016-01-14 08:41:46 +03:00
|
|
|
func (s *server) peerManager() {
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
// New peers.
|
|
|
|
case p := <-s.newPeers:
|
|
|
|
s.addPeer(p)
|
|
|
|
// Finished peers.
|
|
|
|
case p := <-s.donePeers:
|
|
|
|
s.removePeer(p)
|
|
|
|
case <-s.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
s.wg.Done()
|
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// addPeer adds the passed peer to the server's global state of all active
|
|
|
|
// peers.
|
|
|
|
func (s *server) addPeer(p *peer) {
|
|
|
|
if p == nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Ignore new peers if we're shutting down.
|
|
|
|
if atomic.LoadInt32(&s.shutdown) != 0 {
|
|
|
|
p.Stop()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
s.peers[p.id] = p
|
|
|
|
}
|
|
|
|
|
|
|
|
// removePeer removes the passed peer from the server's state of all active
|
|
|
|
// peers.
|
|
|
|
func (s *server) removePeer(p *peer) {
|
|
|
|
if p == nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Ignore deleting peers if we're shutting down.
|
|
|
|
if atomic.LoadInt32(&s.shutdown) != 0 {
|
|
|
|
p.Stop()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
delete(s.peers, p.id)
|
|
|
|
}
|
|
|
|
|
|
|
|
// connectPeerMsg is a message requesting the server to open a connection to a
|
|
|
|
// particular peer. This message also houses an error channel which will be
|
|
|
|
// used to report success/failure.
|
2016-01-17 06:09:02 +03:00
|
|
|
type connectPeerMsg struct {
|
2016-06-21 21:52:09 +03:00
|
|
|
addr *lndc.LNAdr
|
|
|
|
resp chan int32
|
|
|
|
err chan error
|
2016-01-17 06:09:02 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// listPeersMsg is a message sent to the server in order to obtain a listing
|
|
|
|
// of all currently active channels.
|
|
|
|
type listPeersMsg struct {
|
|
|
|
resp chan []*peer
|
|
|
|
}
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
// openChanReq is a message sent to the server in order to request the
|
|
|
|
// initiation of a channel funding workflow to the peer with the specified
|
|
|
|
// node ID.
|
|
|
|
type openChanReq struct {
|
|
|
|
targetNodeID int32
|
|
|
|
targetNode *lndc.LNAdr
|
|
|
|
|
|
|
|
// TODO(roasbeef): make enums in lnwire
|
|
|
|
channelType uint8
|
|
|
|
coinType uint64
|
|
|
|
|
|
|
|
localFundingAmt btcutil.Amount
|
|
|
|
remoteFundingAmt btcutil.Amount
|
|
|
|
|
|
|
|
numConfs uint32
|
|
|
|
|
|
|
|
resp chan *openChanResp
|
|
|
|
err chan error
|
|
|
|
}
|
|
|
|
|
|
|
|
// openChanResp is the response to an openChanReq, it contains the channel
|
|
|
|
// point, or outpoint of the broadcast funding transaction.
|
|
|
|
type openChanResp struct {
|
|
|
|
chanPoint *wire.OutPoint
|
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// queryHandler is a a goroutine dedicated to handling an queries or requests
|
|
|
|
// to mutate the server's global state.
|
|
|
|
//
|
|
|
|
// NOTE: This MUST be run as a goroutine.
|
2016-01-14 08:41:46 +03:00
|
|
|
func (s *server) queryHandler() {
|
2016-06-21 21:52:09 +03:00
|
|
|
// TODO(roabeef): consolidate with peerManager
|
2016-01-14 08:41:46 +03:00
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
2016-01-17 06:09:02 +03:00
|
|
|
case query := <-s.queries:
|
2016-06-21 21:52:09 +03:00
|
|
|
// TODO(roasbeef): make all goroutines?
|
2016-01-17 06:09:02 +03:00
|
|
|
switch msg := query.(type) {
|
|
|
|
case *connectPeerMsg:
|
2016-06-21 21:52:09 +03:00
|
|
|
s.handleConnectPeer(msg)
|
|
|
|
case *listPeersMsg:
|
|
|
|
s.handleListPeers(msg)
|
2016-06-21 22:32:32 +03:00
|
|
|
case *openChanReq:
|
|
|
|
s.handleOpenChanReq(msg)
|
2016-01-17 06:09:02 +03:00
|
|
|
}
|
2016-01-14 08:41:46 +03:00
|
|
|
case <-s.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
s.wg.Done()
|
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// handleListPeers sends a lice of all currently active peers to the original
|
|
|
|
// caller.
|
2016-06-21 21:52:09 +03:00
|
|
|
func (s *server) handleListPeers(msg *listPeersMsg) {
|
|
|
|
peers := make([]*peer, 0, len(s.peers))
|
|
|
|
for _, peer := range s.peers {
|
|
|
|
peers = append(peers, peer)
|
|
|
|
}
|
2016-01-17 06:09:02 +03:00
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
msg.resp <- peers
|
2016-01-17 06:09:02 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// handleConnectPeer attempts to establish a connection to the address enclosed
|
|
|
|
// within the passed connectPeerMsg. This function is *async*, a goroutine will
|
|
|
|
// be spawned in order to finish the request, and respond to the caller.
|
|
|
|
func (s *server) handleConnectPeer(msg *connectPeerMsg) {
|
|
|
|
addr := msg.addr
|
|
|
|
|
|
|
|
// Ensure we're not already connected to this
|
|
|
|
// peer.
|
|
|
|
for _, peer := range s.peers {
|
|
|
|
if peer.lightningAddr.String() ==
|
|
|
|
addr.String() {
|
|
|
|
msg.err <- fmt.Errorf(
|
|
|
|
"already connected to peer: %v",
|
|
|
|
peer.lightningAddr,
|
|
|
|
)
|
|
|
|
msg.resp <- -1
|
|
|
|
}
|
|
|
|
}
|
2016-01-14 08:41:46 +03:00
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// Launch a goroutine to connect to the requested
|
|
|
|
// peer so we can continue to handle queries.
|
|
|
|
// TODO(roasbeef): semaphore to limit the number of goroutines for
|
|
|
|
// async requests.
|
|
|
|
go func() {
|
|
|
|
// For the lndc crypto handshake, we
|
|
|
|
// either need a compressed pubkey, or a
|
|
|
|
// 20-byte pkh.
|
|
|
|
var remoteId []byte
|
|
|
|
if addr.PubKey == nil {
|
|
|
|
remoteId = addr.Base58Adr.ScriptAddress()
|
|
|
|
} else {
|
|
|
|
remoteId = addr.PubKey.SerializeCompressed()
|
|
|
|
}
|
|
|
|
|
|
|
|
srvrLog.Debugf("connecting to %v", hex.EncodeToString(remoteId))
|
|
|
|
// Attempt to connect to the remote
|
|
|
|
// node. If the we can't make the
|
|
|
|
// connection, or the crypto negotation
|
|
|
|
// breaks down, then return an error to the
|
|
|
|
// caller.
|
|
|
|
ipAddr := addr.NetAddr.String()
|
|
|
|
conn := lndc.NewConn(nil)
|
|
|
|
if err := conn.Dial(
|
|
|
|
s.identityPriv, ipAddr, remoteId); err != nil {
|
|
|
|
msg.err <- err
|
|
|
|
msg.resp <- -1
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Now that we've established a connection,
|
|
|
|
// create a peer, and it to the set of
|
|
|
|
// currently active peers.
|
|
|
|
peer, err := newPeer(conn, s, activeNetParams.Net, false)
|
2016-01-14 08:41:46 +03:00
|
|
|
if err != nil {
|
2016-06-21 21:52:09 +03:00
|
|
|
srvrLog.Errorf("unable to create peer %v", err)
|
|
|
|
msg.resp <- -1
|
|
|
|
msg.err <- err
|
|
|
|
return
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
2016-01-17 06:09:02 +03:00
|
|
|
|
|
|
|
peer.Start()
|
2016-05-23 23:54:34 +03:00
|
|
|
s.newPeers <- peer
|
2016-06-21 21:52:09 +03:00
|
|
|
|
|
|
|
msg.resp <- peer.id
|
|
|
|
msg.err <- nil
|
|
|
|
}()
|
|
|
|
}
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
// handleOpenChanReq first locates the target peer, and if found hands off the
|
|
|
|
// request to the funding manager allowing it to initiate the channel funding
|
|
|
|
// workflow.
|
|
|
|
func (s *server) handleOpenChanReq(req *openChanReq) {
|
|
|
|
// First attempt to locate the target peer to open a channel with, if
|
|
|
|
// we're unable to locate the peer then this request will fail.
|
|
|
|
target := req.targetNodeID
|
|
|
|
var targetPeer *peer
|
|
|
|
for _, peer := range s.peers { // TODO(roasbeef): threadsafe api
|
|
|
|
// We found the the target
|
|
|
|
if target == peer.id {
|
|
|
|
targetPeer = peer
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if targetPeer == nil {
|
|
|
|
req.resp <- nil
|
|
|
|
req.err <- fmt.Errorf("unable to find peer %v", target)
|
|
|
|
return
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// Spawn a goroutine to send the funding workflow request to the funding
|
|
|
|
// manager. This allows the server to continue handling queries instead of
|
|
|
|
// blocking on this request which is exporeted as a synchronous request to
|
|
|
|
// the outside world.
|
|
|
|
go func() {
|
|
|
|
// TODO(roasbeef): server semaphore to restrict num goroutines
|
|
|
|
fundingID, err := s.fundingMgr.initFundingWorkflow(targetPeer, req)
|
|
|
|
|
|
|
|
req.resp <- &openChanResp{fundingID}
|
|
|
|
req.err <- err
|
|
|
|
}()
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 22:32:32 +03:00
|
|
|
// ConnectToPeer requests that the server connect to a Lightning Network peer
|
|
|
|
// at the specified address. This function will *block* until either a
|
|
|
|
// connection is established, or the initial handshake process fails.
|
|
|
|
func (s *server) ConnectToPeer(addr *lndc.LNAdr) (int32, error) {
|
|
|
|
reply := make(chan int32, 1)
|
|
|
|
errChan := make(chan error, 1)
|
|
|
|
|
|
|
|
s.queries <- &connectPeerMsg{addr, reply, errChan}
|
|
|
|
|
|
|
|
return <-reply, <-errChan
|
|
|
|
}
|
|
|
|
|
|
|
|
// OpenChannel sends a request to the server to open a channel to the specified
|
|
|
|
// peer identified by ID with the passed channel funding paramters.
|
|
|
|
func (s *server) OpenChannel(nodeID int32, localAmt, remoteAmt btcutil.Amount,
|
2016-07-08 01:30:55 +03:00
|
|
|
numConfs uint32) (chan *openChanResp, chan error) {
|
2016-06-21 22:32:32 +03:00
|
|
|
|
|
|
|
errChan := make(chan error, 1)
|
|
|
|
respChan := make(chan *openChanResp, 1)
|
|
|
|
|
|
|
|
s.queries <- &openChanReq{
|
|
|
|
targetNodeID: nodeID,
|
|
|
|
localFundingAmt: localAmt,
|
|
|
|
remoteFundingAmt: remoteAmt,
|
|
|
|
numConfs: numConfs,
|
|
|
|
|
|
|
|
resp: respChan,
|
|
|
|
err: errChan,
|
|
|
|
}
|
2016-07-08 01:30:55 +03:00
|
|
|
// TODO(roasbeef): hook in "progress" channel
|
2016-06-21 22:32:32 +03:00
|
|
|
|
2016-07-08 01:30:55 +03:00
|
|
|
return respChan, errChan
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
|
|
|
|
2016-06-21 21:52:09 +03:00
|
|
|
// Peers returns a slice of all active peers.
|
|
|
|
func (s *server) Peers() []*peer {
|
|
|
|
resp := make(chan []*peer)
|
|
|
|
|
|
|
|
s.queries <- &listPeersMsg{resp}
|
|
|
|
|
|
|
|
return <-resp
|
|
|
|
}
|
|
|
|
|
|
|
|
// listener is a goroutine dedicated to accepting in coming peer connections
|
|
|
|
// from the passed listener.
|
|
|
|
//
|
|
|
|
// NOTE: This MUST be run as a goroutine.
|
|
|
|
func (s *server) listener(l net.Listener) {
|
|
|
|
srvrLog.Infof("Server listening on %s", l.Addr())
|
|
|
|
for atomic.LoadInt32(&s.shutdown) == 0 {
|
|
|
|
conn, err := l.Accept()
|
|
|
|
if err != nil {
|
|
|
|
// Only log the error message if we aren't currently
|
|
|
|
// shutting down.
|
|
|
|
if atomic.LoadInt32(&s.shutdown) == 0 {
|
|
|
|
srvrLog.Errorf("Can't accept connection: %v", err)
|
|
|
|
}
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
srvrLog.Tracef("New inbound connection from %v", conn.RemoteAddr())
|
|
|
|
peer, err := newPeer(conn, s, activeNetParams.Net, true)
|
|
|
|
if err != nil {
|
|
|
|
srvrLog.Errorf("unable to create peer: %v", err)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
peer.Start()
|
|
|
|
s.newPeers <- peer
|
|
|
|
}
|
|
|
|
|
|
|
|
s.wg.Done()
|
2016-01-14 08:41:46 +03:00
|
|
|
}
|
2016-01-17 06:05:13 +03:00
|
|
|
|
|
|
|
// getIdentityPrivKey gets the identity private key out of the wallet DB.
|
2016-06-21 21:52:09 +03:00
|
|
|
func getIdentityPrivKey(c *channeldb.DB,
|
|
|
|
w *lnwallet.LightningWallet) (*btcec.PrivateKey, error) {
|
|
|
|
|
|
|
|
// First retrieve the current identity address for this peer.
|
2016-03-23 04:49:22 +03:00
|
|
|
adr, err := c.GetIdAdr()
|
2016-01-17 06:05:13 +03:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2016-06-21 21:52:09 +03:00
|
|
|
|
|
|
|
// Using the ID address, request the private key coresponding to the
|
|
|
|
// address from the wallet's address manager.
|
2016-03-23 04:49:22 +03:00
|
|
|
adr2, err := w.Manager.Address(adr)
|
2016-01-17 06:05:13 +03:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2016-06-21 21:52:09 +03:00
|
|
|
|
|
|
|
serializedKey := adr2.(waddrmgr.ManagedPubKeyAddress).PubKey().SerializeCompressed()
|
|
|
|
keyEncoded := hex.EncodeToString(serializedKey)
|
|
|
|
ltndLog.Infof("identity address: %v", adr)
|
|
|
|
ltndLog.Infof("identity pubkey retrieved: %v", keyEncoded)
|
|
|
|
|
2016-01-17 06:05:13 +03:00
|
|
|
priv, err := adr2.(waddrmgr.ManagedPubKeyAddress).PrivKey()
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
return priv, nil
|
|
|
|
}
|