2020-05-19 12:57:36 +03:00
|
|
|
package itest
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
"encoding/hex"
|
|
|
|
"fmt"
|
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/btcsuite/btcd/wire"
|
|
|
|
"github.com/btcsuite/btcutil"
|
2020-10-06 21:56:10 +03:00
|
|
|
"github.com/lightningnetwork/lnd/chainreg"
|
2020-05-19 12:57:36 +03:00
|
|
|
"github.com/lightningnetwork/lnd/lnrpc"
|
|
|
|
"github.com/lightningnetwork/lnd/lnrpc/routerrpc"
|
|
|
|
"github.com/lightningnetwork/lnd/lntest"
|
|
|
|
"github.com/lightningnetwork/lnd/routing/route"
|
2020-06-23 17:22:00 +03:00
|
|
|
"github.com/stretchr/testify/require"
|
2020-05-19 12:57:36 +03:00
|
|
|
"google.golang.org/grpc/codes"
|
|
|
|
"google.golang.org/grpc/status"
|
|
|
|
)
|
|
|
|
|
2020-06-24 13:03:00 +03:00
|
|
|
var (
|
|
|
|
customTestKey uint64 = 394829
|
|
|
|
customTestValue = []byte{1, 3, 5}
|
|
|
|
)
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
type interceptorTestCase struct {
|
|
|
|
amountMsat int64
|
2020-11-24 07:17:16 +03:00
|
|
|
payAddr []byte
|
2020-05-19 12:57:36 +03:00
|
|
|
invoice *lnrpc.Invoice
|
|
|
|
shouldHold bool
|
|
|
|
interceptorAction routerrpc.ResolveHoldForwardAction
|
|
|
|
}
|
|
|
|
|
|
|
|
// testForwardInterceptor tests the forward interceptor RPC layer.
|
|
|
|
// The test creates a cluster of 3 connected nodes: Alice -> Bob -> Carol
|
|
|
|
// Alice sends 4 different payments to Carol while the interceptor handles
|
|
|
|
// differently the htlcs.
|
|
|
|
// The test ensures that:
|
|
|
|
// 1. Intercepted failed htlcs result in no payment (invoice is not settled).
|
|
|
|
// 2. Intercepted resumed htlcs result in a payment (invoice is settled).
|
|
|
|
// 3. Intercepted held htlcs result in no payment (invoice is not settled).
|
|
|
|
// 4. When Interceptor disconnects it resumes all held htlcs, which result in
|
|
|
|
// valid payment (invoice is settled).
|
|
|
|
func testForwardInterceptor(net *lntest.NetworkHarness, t *harnessTest) {
|
2020-12-03 21:56:45 +03:00
|
|
|
// Initialize the test context with 3 connected nodes.
|
|
|
|
alice, err := net.NewNode("alice", nil)
|
|
|
|
require.NoError(t.t, err, "unable to create alice")
|
|
|
|
defer shutdownAndAssert(net, t, alice)
|
|
|
|
|
|
|
|
bob, err := net.NewNode("bob", nil)
|
|
|
|
require.NoError(t.t, err, "unable to create bob")
|
|
|
|
defer shutdownAndAssert(net, t, alice)
|
|
|
|
|
|
|
|
carol, err := net.NewNode("carol", nil)
|
|
|
|
require.NoError(t.t, err, "unable to create carol")
|
|
|
|
defer shutdownAndAssert(net, t, alice)
|
|
|
|
|
|
|
|
testContext := newInterceptorTestContext(t, net, alice, bob, carol)
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
const (
|
|
|
|
chanAmt = btcutil.Amount(300000)
|
|
|
|
)
|
|
|
|
|
|
|
|
// Open and wait for channels.
|
|
|
|
testContext.openChannel(testContext.alice, testContext.bob, chanAmt)
|
|
|
|
testContext.openChannel(testContext.bob, testContext.carol, chanAmt)
|
|
|
|
defer testContext.closeChannels()
|
|
|
|
testContext.waitForChannels()
|
|
|
|
|
|
|
|
// Connect the interceptor.
|
|
|
|
ctx := context.Background()
|
|
|
|
ctxt, cancelInterceptor := context.WithTimeout(ctx, defaultTimeout)
|
|
|
|
interceptor, err := testContext.bob.RouterClient.HtlcInterceptor(ctxt)
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(t.t, err, "failed to create HtlcInterceptor")
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
// Prepare the test cases.
|
2020-12-03 21:59:19 +03:00
|
|
|
testCases := testContext.prepareTestCases()
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
// A channel for the interceptor go routine to send the requested packets.
|
|
|
|
interceptedChan := make(chan *routerrpc.ForwardHtlcInterceptRequest,
|
|
|
|
len(testCases))
|
|
|
|
|
|
|
|
// Run the interceptor loop in its own go routine.
|
|
|
|
var wg sync.WaitGroup
|
|
|
|
wg.Add(1)
|
|
|
|
go func() {
|
|
|
|
defer wg.Done()
|
|
|
|
for {
|
|
|
|
request, err := interceptor.Recv()
|
|
|
|
if err != nil {
|
|
|
|
// If it is just the error result of the context cancellation
|
|
|
|
// the we exit silently.
|
|
|
|
status, ok := status.FromError(err)
|
|
|
|
if ok && status.Code() == codes.Canceled {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
// Otherwise it an unexpected error, we fail the test.
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(t.t, err, "unexpected error in interceptor.Recv()")
|
2020-05-19 12:57:36 +03:00
|
|
|
return
|
|
|
|
}
|
|
|
|
interceptedChan <- request
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
// For each test case make sure we initiate a payment from Alice to Carol
|
|
|
|
// routed through Bob. For each payment we also test its final status
|
|
|
|
// according to the interceptorAction specified in the test case.
|
|
|
|
wg.Add(1)
|
|
|
|
go func() {
|
|
|
|
defer wg.Done()
|
|
|
|
for _, tc := range testCases {
|
|
|
|
attempt, err := testContext.sendAliceToCarolPayment(
|
2020-11-24 07:17:16 +03:00
|
|
|
context.Background(), tc.invoice.ValueMsat,
|
|
|
|
tc.invoice.RHash, tc.payAddr,
|
|
|
|
)
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
if t.t.Failed() {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
if err != nil {
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(t.t, err, "failed to send payment")
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
switch tc.interceptorAction {
|
|
|
|
// For 'fail' interceptor action we make sure the payment failed.
|
|
|
|
case routerrpc.ResolveHoldForwardAction_FAIL:
|
2020-12-03 21:59:19 +03:00
|
|
|
require.Equal(t.t, lnrpc.HTLCAttempt_FAILED,
|
|
|
|
attempt.Status, "expected payment to fail")
|
2020-05-19 12:57:36 +03:00
|
|
|
|
2021-04-22 20:39:37 +03:00
|
|
|
// Assert that we get a temporary channel
|
|
|
|
// failure which has a channel update.
|
|
|
|
require.NotNil(t.t, attempt.Failure)
|
|
|
|
require.NotNil(t.t, attempt.Failure.ChannelUpdate)
|
|
|
|
|
|
|
|
require.Equal(t.t,
|
|
|
|
lnrpc.Failure_TEMPORARY_CHANNEL_FAILURE,
|
|
|
|
attempt.Failure.Code)
|
|
|
|
|
2020-01-10 17:27:50 +03:00
|
|
|
// For settle and resume we make sure the payment is successful.
|
2020-05-19 12:57:36 +03:00
|
|
|
case routerrpc.ResolveHoldForwardAction_SETTLE:
|
|
|
|
fallthrough
|
|
|
|
|
|
|
|
case routerrpc.ResolveHoldForwardAction_RESUME:
|
2020-12-03 21:59:19 +03:00
|
|
|
require.Equal(t.t, lnrpc.HTLCAttempt_SUCCEEDED,
|
|
|
|
attempt.Status, "expected payment to succeed")
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
// We make sure here the interceptor has processed all packets before we
|
|
|
|
// check the payment statuses.
|
|
|
|
for i := 0; i < len(testCases); i++ {
|
|
|
|
select {
|
|
|
|
case request := <-interceptedChan:
|
2020-06-23 17:22:00 +03:00
|
|
|
// Assert sanity of informational packet data.
|
|
|
|
require.NotZero(t.t, request.OutgoingRequestedChanId)
|
|
|
|
require.NotZero(t.t, request.IncomingExpiry)
|
|
|
|
require.NotZero(t.t, request.IncomingAmountMsat)
|
|
|
|
|
|
|
|
require.Less(
|
|
|
|
t.t,
|
|
|
|
request.OutgoingExpiry, request.IncomingExpiry,
|
|
|
|
)
|
|
|
|
require.Less(
|
|
|
|
t.t,
|
|
|
|
request.OutgoingAmountMsat,
|
|
|
|
request.IncomingAmountMsat,
|
|
|
|
)
|
|
|
|
|
2020-06-24 13:03:00 +03:00
|
|
|
value, ok := request.CustomRecords[customTestKey]
|
|
|
|
require.True(t.t, ok, "expected custom record")
|
|
|
|
require.Equal(t.t, customTestValue, value)
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
testCase := testCases[i]
|
|
|
|
|
|
|
|
// For held packets we ignore, keeping them in hold status.
|
|
|
|
if testCase.shouldHold {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
// For all other packets we resolve according to the test case.
|
2020-01-10 17:27:50 +03:00
|
|
|
_ = interceptor.Send(&routerrpc.ForwardHtlcInterceptResponse{
|
2020-05-19 12:57:36 +03:00
|
|
|
IncomingCircuitKey: request.IncomingCircuitKey,
|
|
|
|
Action: testCase.interceptorAction,
|
|
|
|
Preimage: testCase.invoice.RPreimage,
|
|
|
|
})
|
|
|
|
case <-time.After(defaultTimeout):
|
|
|
|
t.Fatalf("response from interceptor was not received %v", i)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// At this point we are left with the held packets, we want to make sure
|
|
|
|
// each one of them has a corresponding 'in-flight' payment at
|
|
|
|
// Alice's node.
|
|
|
|
payments, err := testContext.alice.ListPayments(context.Background(),
|
|
|
|
&lnrpc.ListPaymentsRequest{IncludeIncomplete: true})
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(t.t, err, "failed to fetch payment")
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
for _, testCase := range testCases {
|
|
|
|
if testCase.shouldHold {
|
|
|
|
hashStr := hex.EncodeToString(testCase.invoice.RHash)
|
|
|
|
var foundPayment *lnrpc.Payment
|
|
|
|
expectedAmt := testCase.invoice.ValueMsat
|
|
|
|
for _, p := range payments.Payments {
|
|
|
|
if p.PaymentHash == hashStr {
|
|
|
|
foundPayment = p
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NotNil(t.t, foundPayment, fmt.Sprintf("expected "+
|
|
|
|
"to find pending payment for held htlc %v",
|
|
|
|
hashStr))
|
|
|
|
require.Equal(t.t, lnrpc.Payment_IN_FLIGHT,
|
|
|
|
foundPayment.Status, "expected payment to be "+
|
|
|
|
"in flight")
|
|
|
|
require.Equal(t.t, expectedAmt, foundPayment.ValueMsat,
|
|
|
|
"incorrect in flight amount")
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Disconnect interceptor should cause resume held packets.
|
|
|
|
// After that we wait for all go routines to finish, including the one
|
|
|
|
// that tests the payment final status for the held payment.
|
|
|
|
cancelInterceptor()
|
|
|
|
wg.Wait()
|
|
|
|
}
|
|
|
|
|
|
|
|
// interceptorTestContext is a helper struct to hold the test context and
|
|
|
|
// provide the needed functionality.
|
|
|
|
type interceptorTestContext struct {
|
|
|
|
t *harnessTest
|
|
|
|
net *lntest.NetworkHarness
|
|
|
|
|
|
|
|
// Keep a list of all our active channels.
|
|
|
|
networkChans []*lnrpc.ChannelPoint
|
|
|
|
closeChannelFuncs []func()
|
|
|
|
|
|
|
|
alice, bob, carol *lntest.HarnessNode
|
|
|
|
nodes []*lntest.HarnessNode
|
|
|
|
}
|
|
|
|
|
|
|
|
func newInterceptorTestContext(t *harnessTest,
|
2020-12-03 21:56:45 +03:00
|
|
|
net *lntest.NetworkHarness,
|
|
|
|
alice, bob, carol *lntest.HarnessNode) *interceptorTestContext {
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
ctxb := context.Background()
|
|
|
|
|
|
|
|
// Connect nodes
|
2020-12-03 21:59:27 +03:00
|
|
|
nodes := []*lntest.HarnessNode{alice, bob, carol}
|
2020-05-19 12:57:36 +03:00
|
|
|
for i := 0; i < len(nodes); i++ {
|
|
|
|
for j := i + 1; j < len(nodes); j++ {
|
|
|
|
ctxt, _ := context.WithTimeout(ctxb, defaultTimeout)
|
2020-12-03 21:56:45 +03:00
|
|
|
err := net.EnsureConnected(ctxt, nodes[i], nodes[j])
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(t.t, err, "unable to connect nodes")
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
ctx := interceptorTestContext{
|
|
|
|
t: t,
|
|
|
|
net: net,
|
2020-12-03 21:59:27 +03:00
|
|
|
alice: alice,
|
|
|
|
bob: bob,
|
2020-05-19 12:57:36 +03:00
|
|
|
carol: carol,
|
|
|
|
nodes: nodes,
|
|
|
|
}
|
|
|
|
|
|
|
|
return &ctx
|
|
|
|
}
|
|
|
|
|
|
|
|
// prepareTestCases prepares 4 tests:
|
|
|
|
// 1. failed htlc.
|
|
|
|
// 2. resumed htlc.
|
|
|
|
// 3. settling htlc externally.
|
|
|
|
// 4. held htlc that is resumed later.
|
2020-12-03 21:59:19 +03:00
|
|
|
func (c *interceptorTestContext) prepareTestCases() []*interceptorTestCase {
|
2020-05-19 12:57:36 +03:00
|
|
|
cases := []*interceptorTestCase{
|
2020-07-08 11:30:09 +03:00
|
|
|
{amountMsat: 1000, shouldHold: false,
|
2020-05-19 12:57:36 +03:00
|
|
|
interceptorAction: routerrpc.ResolveHoldForwardAction_FAIL},
|
2020-07-08 11:30:09 +03:00
|
|
|
{amountMsat: 1000, shouldHold: false,
|
2020-05-19 12:57:36 +03:00
|
|
|
interceptorAction: routerrpc.ResolveHoldForwardAction_RESUME},
|
2020-07-08 11:30:09 +03:00
|
|
|
{amountMsat: 1000, shouldHold: false,
|
2020-05-19 12:57:36 +03:00
|
|
|
interceptorAction: routerrpc.ResolveHoldForwardAction_SETTLE},
|
2020-07-08 11:30:09 +03:00
|
|
|
{amountMsat: 1000, shouldHold: true,
|
2020-05-19 12:57:36 +03:00
|
|
|
interceptorAction: routerrpc.ResolveHoldForwardAction_RESUME},
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, t := range cases {
|
|
|
|
addResponse, err := c.carol.AddInvoice(context.Background(), &lnrpc.Invoice{
|
|
|
|
ValueMsat: t.amountMsat,
|
|
|
|
})
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(c.t.t, err, "unable to add invoice")
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
invoice, err := c.carol.LookupInvoice(context.Background(), &lnrpc.PaymentHash{
|
|
|
|
RHashStr: hex.EncodeToString(addResponse.RHash),
|
|
|
|
})
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(c.t.t, err, "unable to find invoice")
|
2020-11-24 07:17:16 +03:00
|
|
|
|
|
|
|
// We'll need to also decode the returned invoice so we can
|
|
|
|
// grab the payment address which is now required for ALL
|
|
|
|
// payments.
|
|
|
|
payReq, err := c.carol.DecodePayReq(context.Background(), &lnrpc.PayReqString{
|
|
|
|
PayReq: invoice.PaymentRequest,
|
|
|
|
})
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(c.t.t, err, "unable to decode invoice")
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
t.invoice = invoice
|
2020-11-24 07:17:16 +03:00
|
|
|
t.payAddr = payReq.PaymentAddr
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
2020-12-03 21:59:19 +03:00
|
|
|
return cases
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
|
2020-11-24 07:17:16 +03:00
|
|
|
func (c *interceptorTestContext) openChannel(from, to *lntest.HarnessNode,
|
|
|
|
chanSize btcutil.Amount) {
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
ctxb := context.Background()
|
|
|
|
|
|
|
|
ctxt, _ := context.WithTimeout(ctxb, defaultTimeout)
|
|
|
|
err := c.net.SendCoins(ctxt, btcutil.SatoshiPerBitcoin, from)
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(c.t.t, err, "unable to send coins")
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
ctxt, _ = context.WithTimeout(ctxb, channelOpenTimeout)
|
|
|
|
chanPoint := openChannelAndAssert(
|
|
|
|
ctxt, c.t, c.net, from, to,
|
|
|
|
lntest.OpenChannelParams{
|
|
|
|
Amt: chanSize,
|
|
|
|
},
|
|
|
|
)
|
|
|
|
|
|
|
|
c.closeChannelFuncs = append(c.closeChannelFuncs, func() {
|
|
|
|
ctxt, _ := context.WithTimeout(ctxb, channelCloseTimeout)
|
|
|
|
closeChannelAndAssert(
|
|
|
|
ctxt, c.t, c.net, from, chanPoint, false,
|
|
|
|
)
|
|
|
|
})
|
|
|
|
|
|
|
|
c.networkChans = append(c.networkChans, chanPoint)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *interceptorTestContext) closeChannels() {
|
|
|
|
for _, f := range c.closeChannelFuncs {
|
|
|
|
f()
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *interceptorTestContext) waitForChannels() {
|
|
|
|
ctxb := context.Background()
|
|
|
|
|
|
|
|
// Wait for all nodes to have seen all channels.
|
|
|
|
for _, chanPoint := range c.networkChans {
|
|
|
|
for _, node := range c.nodes {
|
2021-02-13 11:05:33 +03:00
|
|
|
txid, err := lnrpc.GetChanPointFundingTxid(chanPoint)
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(c.t.t, err, "unable to get txid")
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
point := wire.OutPoint{
|
|
|
|
Hash: *txid,
|
|
|
|
Index: chanPoint.OutputIndex,
|
|
|
|
}
|
|
|
|
|
|
|
|
ctxt, _ := context.WithTimeout(ctxb, defaultTimeout)
|
|
|
|
err = node.WaitForNetworkChannelOpen(ctxt, chanPoint)
|
2020-12-03 21:59:19 +03:00
|
|
|
require.NoError(c.t.t, err, fmt.Sprintf("(%d): timeout "+
|
|
|
|
"waiting for channel(%s) open", node.NodeID,
|
|
|
|
point))
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// sendAliceToCarolPayment sends a payment from alice to carol and make an
|
|
|
|
// attempt to pay. The lnrpc.HTLCAttempt is returned.
|
|
|
|
func (c *interceptorTestContext) sendAliceToCarolPayment(ctx context.Context,
|
2020-11-24 07:17:16 +03:00
|
|
|
amtMsat int64,
|
|
|
|
paymentHash, paymentAddr []byte) (*lnrpc.HTLCAttempt, error) {
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
// Build a route from alice to carol.
|
2020-11-24 07:17:16 +03:00
|
|
|
route, err := c.buildRoute(
|
|
|
|
ctx, amtMsat, []*lntest.HarnessNode{c.bob, c.carol},
|
|
|
|
paymentAddr,
|
|
|
|
)
|
2020-05-19 12:57:36 +03:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
sendReq := &routerrpc.SendToRouteRequest{
|
|
|
|
PaymentHash: paymentHash,
|
|
|
|
Route: route,
|
|
|
|
}
|
|
|
|
|
2020-06-24 13:03:00 +03:00
|
|
|
// Send a custom record to the forwarding node.
|
|
|
|
route.Hops[0].CustomRecords = map[uint64][]byte{
|
|
|
|
customTestKey: customTestValue,
|
|
|
|
}
|
|
|
|
|
2020-05-19 12:57:36 +03:00
|
|
|
// Send the payment.
|
|
|
|
return c.alice.RouterClient.SendToRouteV2(ctx, sendReq)
|
|
|
|
}
|
|
|
|
|
|
|
|
// buildRoute is a helper function to build a route with given hops.
|
2020-11-24 07:17:16 +03:00
|
|
|
func (c *interceptorTestContext) buildRoute(ctx context.Context, amtMsat int64,
|
|
|
|
hops []*lntest.HarnessNode, payAddr []byte) (*lnrpc.Route, error) {
|
2020-05-19 12:57:36 +03:00
|
|
|
|
|
|
|
rpcHops := make([][]byte, 0, len(hops))
|
|
|
|
for _, hop := range hops {
|
|
|
|
k := hop.PubKeyStr
|
|
|
|
pubkey, err := route.NewVertexFromStr(k)
|
|
|
|
if err != nil {
|
|
|
|
return nil, fmt.Errorf("error parsing %v: %v",
|
|
|
|
k, err)
|
|
|
|
}
|
|
|
|
rpcHops = append(rpcHops, pubkey[:])
|
|
|
|
}
|
|
|
|
|
|
|
|
req := &routerrpc.BuildRouteRequest{
|
|
|
|
AmtMsat: amtMsat,
|
2020-10-06 21:56:10 +03:00
|
|
|
FinalCltvDelta: chainreg.DefaultBitcoinTimeLockDelta,
|
2020-05-19 12:57:36 +03:00
|
|
|
HopPubkeys: rpcHops,
|
2020-11-24 07:17:16 +03:00
|
|
|
PaymentAddr: payAddr,
|
2020-05-19 12:57:36 +03:00
|
|
|
}
|
|
|
|
|
|
|
|
routeResp, err := c.alice.RouterClient.BuildRoute(ctx, req)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
return routeResp.Route, nil
|
|
|
|
}
|