502 lines
15 KiB
Go
502 lines
15 KiB
Go
package node
|
|
|
|
import (
|
|
"context"
|
|
"math/big"
|
|
"time"
|
|
|
|
"github.com/ethereum/go-ethereum/accounts/keystore"
|
|
gethcommon "github.com/ethereum/go-ethereum/common"
|
|
"github.com/ethereum/go-ethereum/common/hexutil"
|
|
"github.com/ethereum/go-ethereum/core/types"
|
|
"github.com/ethereum/go-ethereum/les/status"
|
|
"github.com/ethereum/go-ethereum/rlp"
|
|
"github.com/pborman/uuid"
|
|
"github.com/status-im/status-go/geth/common"
|
|
"github.com/status-im/status-go/geth/log"
|
|
"github.com/status-im/status-go/geth/signal"
|
|
)
|
|
|
|
const (
|
|
// EventTransactionQueued is triggered when send transaction request is queued
|
|
EventTransactionQueued = "transaction.queued"
|
|
|
|
// EventTransactionFailed is triggered when send transaction request fails
|
|
EventTransactionFailed = "transaction.failed"
|
|
|
|
// SendTxDefaultErrorCode is sent by default, when error is not nil, but type is unknown/unexpected.
|
|
SendTxDefaultErrorCode = SendTransactionDefaultErrorCode
|
|
)
|
|
|
|
// Send transaction response codes
|
|
const (
|
|
SendTransactionNoErrorCode = "0"
|
|
SendTransactionDefaultErrorCode = "1"
|
|
SendTransactionPasswordErrorCode = "2"
|
|
SendTransactionTimeoutErrorCode = "3"
|
|
SendTransactionDiscardedErrorCode = "4"
|
|
)
|
|
|
|
var txReturnCodes = map[error]string{ // deliberately strings, in case more meaningful codes are to be returned
|
|
nil: SendTransactionNoErrorCode,
|
|
keystore.ErrDecrypt: SendTransactionPasswordErrorCode,
|
|
ErrQueuedTxTimedOut: SendTransactionTimeoutErrorCode,
|
|
ErrQueuedTxDiscarded: SendTransactionDiscardedErrorCode,
|
|
}
|
|
|
|
// TxQueueManager provides means to manage internal Status Backend (injected into LES)
|
|
type TxQueueManager struct {
|
|
nodeManager common.NodeManager
|
|
accountManager common.AccountManager
|
|
txQueue *TxQueue
|
|
}
|
|
|
|
// NewTxQueueManager returns a new TxQueueManager.
|
|
func NewTxQueueManager(nodeManager common.NodeManager, accountManager common.AccountManager) *TxQueueManager {
|
|
return &TxQueueManager{
|
|
nodeManager: nodeManager,
|
|
accountManager: accountManager,
|
|
txQueue: NewTransactionQueue(),
|
|
}
|
|
}
|
|
|
|
// Start starts accepting new transactions into the queue.
|
|
func (m *TxQueueManager) Start() {
|
|
log.Info("start TxQueueManager")
|
|
m.txQueue.Start()
|
|
}
|
|
|
|
// Stop stops accepting new transactions into the queue.
|
|
func (m *TxQueueManager) Stop() {
|
|
log.Info("stop TxQueueManager")
|
|
m.txQueue.Stop()
|
|
}
|
|
|
|
// TransactionQueue returns a reference to the queue.
|
|
func (m *TxQueueManager) TransactionQueue() common.TxQueue {
|
|
return m.txQueue
|
|
}
|
|
|
|
// CreateTransaction returns a transaction object.
|
|
func (m *TxQueueManager) CreateTransaction(ctx context.Context, args common.SendTxArgs) *common.QueuedTx {
|
|
return &common.QueuedTx{
|
|
ID: common.QueuedTxID(uuid.New()),
|
|
Hash: gethcommon.Hash{},
|
|
Context: ctx,
|
|
Args: args,
|
|
Done: make(chan struct{}, 1),
|
|
Discard: make(chan struct{}, 1),
|
|
}
|
|
}
|
|
|
|
// QueueTransaction puts a transaction into the queue.
|
|
func (m *TxQueueManager) QueueTransaction(tx *common.QueuedTx) error {
|
|
to := "<nil>"
|
|
if tx.Args.To != nil {
|
|
to = tx.Args.To.Hex()
|
|
}
|
|
log.Info("queue a new transaction", "id", tx.ID, "from", tx.Args.From.Hex(), "to", to)
|
|
|
|
return m.txQueue.Enqueue(tx)
|
|
}
|
|
|
|
// WaitForTransaction adds a transaction to the queue and blocks
|
|
// until it's completed, discarded or times out.
|
|
func (m *TxQueueManager) WaitForTransaction(tx *common.QueuedTx) error {
|
|
log.Info("wait for transaction", "id", tx.ID)
|
|
|
|
// now wait up until transaction is:
|
|
// - completed (via CompleteQueuedTransaction),
|
|
// - discarded (via DiscardQueuedTransaction)
|
|
// - or times out
|
|
select {
|
|
case <-tx.Done:
|
|
m.NotifyOnQueuedTxReturn(tx, tx.Err)
|
|
return tx.Err
|
|
case <-tx.Discard:
|
|
m.NotifyOnQueuedTxReturn(tx, ErrQueuedTxDiscarded)
|
|
return ErrQueuedTxDiscarded
|
|
case <-time.After(DefaultTxSendCompletionTimeout * time.Second):
|
|
m.NotifyOnQueuedTxReturn(tx, ErrQueuedTxTimedOut)
|
|
return ErrQueuedTxTimedOut
|
|
}
|
|
}
|
|
|
|
// NotifyOnQueuedTxReturn calls a handler when a transaction resolves.
|
|
func (m *TxQueueManager) NotifyOnQueuedTxReturn(queuedTx *common.QueuedTx, err error) {
|
|
m.txQueue.NotifyOnQueuedTxReturn(queuedTx, err)
|
|
}
|
|
|
|
// CompleteTransaction instructs backend to complete sending of a given transaction.
|
|
// TODO(adam): investigate a possible bug that calling this method multiple times with the same Transaction ID
|
|
// results in sending multiple transactions.
|
|
func (m *TxQueueManager) CompleteTransaction(id common.QueuedTxID, password string) (gethcommon.Hash, error) {
|
|
log.Info("complete transaction", "id", id)
|
|
|
|
queuedTx, err := m.txQueue.Get(id)
|
|
if err != nil {
|
|
log.Warn("could not get a queued transaction", "err", err)
|
|
return gethcommon.Hash{}, err
|
|
}
|
|
|
|
if err := m.txQueue.StartProcessing(queuedTx); err != nil {
|
|
return gethcommon.Hash{}, err
|
|
}
|
|
defer m.txQueue.StopProcessing(queuedTx)
|
|
|
|
selectedAccount, err := m.accountManager.SelectedAccount()
|
|
if err != nil {
|
|
log.Warn("failed to get a selected account", "err", err)
|
|
return gethcommon.Hash{}, err
|
|
}
|
|
|
|
// make sure that only account which created the tx can complete it
|
|
if queuedTx.Args.From.Hex() != selectedAccount.Address.Hex() {
|
|
log.Warn("queued transaction does not belong to the selected account", "err", ErrInvalidCompleteTxSender)
|
|
m.NotifyOnQueuedTxReturn(queuedTx, ErrInvalidCompleteTxSender)
|
|
return gethcommon.Hash{}, ErrInvalidCompleteTxSender
|
|
}
|
|
|
|
config, err := m.nodeManager.NodeConfig()
|
|
if err != nil {
|
|
log.Warn("could not get a node config", "err", err)
|
|
return gethcommon.Hash{}, err
|
|
}
|
|
|
|
// Send the transaction finally.
|
|
var hash gethcommon.Hash
|
|
var txErr error
|
|
|
|
if config.UpstreamConfig.Enabled {
|
|
hash, txErr = m.completeRemoteTransaction(queuedTx, password)
|
|
} else {
|
|
hash, txErr = m.completeLocalTransaction(queuedTx, password)
|
|
}
|
|
|
|
// when incorrect sender tries to complete the account,
|
|
// notify and keep tx in queue (so that correct sender can complete)
|
|
if txErr == keystore.ErrDecrypt {
|
|
log.Warn("failed to complete transaction", "err", txErr)
|
|
m.NotifyOnQueuedTxReturn(queuedTx, txErr)
|
|
return hash, txErr
|
|
}
|
|
|
|
log.Info("finally completed transaction", "id", queuedTx.ID, "hash", hash, "err", txErr)
|
|
|
|
queuedTx.Hash = hash
|
|
queuedTx.Err = txErr
|
|
queuedTx.Done <- struct{}{}
|
|
|
|
return hash, txErr
|
|
}
|
|
|
|
func (m *TxQueueManager) completeLocalTransaction(queuedTx *common.QueuedTx, password string) (gethcommon.Hash, error) {
|
|
log.Info("complete transaction using local node", "id", queuedTx.ID)
|
|
|
|
les, err := m.nodeManager.LightEthereumService()
|
|
if err != nil {
|
|
return gethcommon.Hash{}, err
|
|
}
|
|
|
|
return les.StatusBackend.SendTransaction(context.Background(), status.SendTxArgs(queuedTx.Args), password)
|
|
}
|
|
|
|
func (m *TxQueueManager) completeRemoteTransaction(queuedTx *common.QueuedTx, password string) (gethcommon.Hash, error) {
|
|
log.Info("complete transaction using upstream node", "id", queuedTx.ID)
|
|
|
|
var emptyHash gethcommon.Hash
|
|
|
|
config, err := m.nodeManager.NodeConfig()
|
|
if err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
selectedAcct, err := m.accountManager.SelectedAccount()
|
|
if err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
if _, err := m.accountManager.VerifyAccountPassword(
|
|
config.KeyStoreDir,
|
|
selectedAcct.Address.String(),
|
|
password,
|
|
); err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
// We need to request a new transaction nounce from upstream node.
|
|
ctx, cancel := context.WithTimeout(context.Background(), time.Minute)
|
|
defer cancel()
|
|
|
|
var txCount hexutil.Uint
|
|
client := m.nodeManager.RPCClient()
|
|
if err := client.CallContext(ctx, &txCount, "eth_getTransactionCount", queuedTx.Args.From, "pending"); err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
args := queuedTx.Args
|
|
|
|
if args.GasPrice == nil {
|
|
value, err := m.gasPrice()
|
|
if err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
args.GasPrice = value
|
|
}
|
|
|
|
chainID := big.NewInt(int64(config.NetworkID))
|
|
nonce := uint64(txCount)
|
|
gasPrice := (*big.Int)(args.GasPrice)
|
|
data := []byte(args.Data)
|
|
value := (*big.Int)(args.Value)
|
|
toAddr := gethcommon.Address{}
|
|
if args.To != nil {
|
|
toAddr = *args.To
|
|
}
|
|
|
|
gas, err := m.estimateGas(args)
|
|
if err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
log.Info(
|
|
"preparing raw transaction",
|
|
"from", args.From.Hex(),
|
|
"to", toAddr.Hex(),
|
|
"gas", gas,
|
|
"gasPrice", gasPrice,
|
|
"value", value,
|
|
)
|
|
|
|
tx := types.NewTransaction(nonce, toAddr, value, (*big.Int)(gas), gasPrice, data)
|
|
signedTx, err := types.SignTx(tx, types.NewEIP155Signer(chainID), selectedAcct.AccountKey.PrivateKey)
|
|
if err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
txBytes, err := rlp.EncodeToBytes(signedTx)
|
|
if err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
ctx2, cancel2 := context.WithTimeout(context.Background(), time.Minute)
|
|
defer cancel2()
|
|
|
|
if err := client.CallContext(ctx2, nil, "eth_sendRawTransaction", gethcommon.ToHex(txBytes)); err != nil {
|
|
return emptyHash, err
|
|
}
|
|
|
|
return signedTx.Hash(), nil
|
|
}
|
|
|
|
func (m *TxQueueManager) estimateGas(args common.SendTxArgs) (*hexutil.Big, error) {
|
|
if args.Gas != nil {
|
|
return args.Gas, nil
|
|
}
|
|
|
|
client := m.nodeManager.RPCClient()
|
|
ctx, cancel := context.WithTimeout(context.Background(), time.Minute)
|
|
defer cancel()
|
|
|
|
var gasPrice hexutil.Big
|
|
if args.GasPrice != nil {
|
|
gasPrice = (hexutil.Big)(*args.GasPrice)
|
|
}
|
|
|
|
var value hexutil.Big
|
|
if args.Value != nil {
|
|
value = (hexutil.Big)(*args.Value)
|
|
}
|
|
|
|
params := struct {
|
|
From gethcommon.Address `json:"from"`
|
|
To *gethcommon.Address `json:"to"`
|
|
Gas hexutil.Big `json:"gas"`
|
|
GasPrice hexutil.Big `json:"gasPrice"`
|
|
Value hexutil.Big `json:"value"`
|
|
Data hexutil.Bytes `json:"data"`
|
|
}{
|
|
From: args.From,
|
|
To: args.To,
|
|
GasPrice: gasPrice,
|
|
Value: value,
|
|
Data: []byte(args.Data),
|
|
}
|
|
|
|
var estimatedGas hexutil.Big
|
|
if err := client.CallContext(
|
|
ctx,
|
|
&estimatedGas,
|
|
"eth_estimateGas",
|
|
params,
|
|
); err != nil {
|
|
log.Warn("failed to estimate gas", "err", err)
|
|
return nil, err
|
|
}
|
|
|
|
return &estimatedGas, nil
|
|
}
|
|
|
|
func (m *TxQueueManager) gasPrice() (*hexutil.Big, error) {
|
|
client := m.nodeManager.RPCClient()
|
|
ctx, cancel := context.WithTimeout(context.Background(), time.Minute)
|
|
defer cancel()
|
|
|
|
var gasPrice hexutil.Big
|
|
if err := client.CallContext(ctx, &gasPrice, "eth_gasPrice"); err != nil {
|
|
log.Warn("failed to get gas price", "err", err)
|
|
return nil, err
|
|
}
|
|
|
|
return &gasPrice, nil
|
|
}
|
|
|
|
// CompleteTransactions instructs backend to complete sending of multiple transactions
|
|
func (m *TxQueueManager) CompleteTransactions(ids []common.QueuedTxID, password string) map[common.QueuedTxID]common.RawCompleteTransactionResult {
|
|
results := make(map[common.QueuedTxID]common.RawCompleteTransactionResult)
|
|
|
|
for _, txID := range ids {
|
|
txHash, txErr := m.CompleteTransaction(txID, password)
|
|
results[txID] = common.RawCompleteTransactionResult{
|
|
Hash: txHash,
|
|
Error: txErr,
|
|
}
|
|
}
|
|
|
|
return results
|
|
}
|
|
|
|
// DiscardTransaction discards a given transaction from transaction queue
|
|
func (m *TxQueueManager) DiscardTransaction(id common.QueuedTxID) error {
|
|
queuedTx, err := m.txQueue.Get(id)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
// remove from queue, before notifying SendTransaction
|
|
m.txQueue.Remove(queuedTx.ID)
|
|
|
|
// allow SendTransaction to return
|
|
queuedTx.Err = ErrQueuedTxDiscarded
|
|
queuedTx.Discard <- struct{}{} // sendTransaction() waits on this, notify so that it can return
|
|
|
|
return nil
|
|
}
|
|
|
|
// DiscardTransactions discards given multiple transactions from transaction queue
|
|
func (m *TxQueueManager) DiscardTransactions(ids []common.QueuedTxID) map[common.QueuedTxID]common.RawDiscardTransactionResult {
|
|
results := make(map[common.QueuedTxID]common.RawDiscardTransactionResult)
|
|
|
|
for _, txID := range ids {
|
|
err := m.DiscardTransaction(txID)
|
|
if err != nil {
|
|
results[txID] = common.RawDiscardTransactionResult{
|
|
Error: err,
|
|
}
|
|
}
|
|
}
|
|
|
|
return results
|
|
}
|
|
|
|
// SendTransactionEvent is a signal sent on a send transaction request
|
|
type SendTransactionEvent struct {
|
|
ID string `json:"id"`
|
|
Args common.SendTxArgs `json:"args"`
|
|
MessageID string `json:"message_id"`
|
|
}
|
|
|
|
// TransactionQueueHandler returns handler that processes incoming tx queue requests
|
|
func (m *TxQueueManager) TransactionQueueHandler() func(queuedTx *common.QueuedTx) {
|
|
return func(queuedTx *common.QueuedTx) {
|
|
log.Info("calling TransactionQueueHandler")
|
|
signal.Send(signal.Envelope{
|
|
Type: EventTransactionQueued,
|
|
Event: SendTransactionEvent{
|
|
ID: string(queuedTx.ID),
|
|
Args: queuedTx.Args,
|
|
MessageID: common.MessageIDFromContext(queuedTx.Context),
|
|
},
|
|
})
|
|
}
|
|
}
|
|
|
|
// SetTransactionQueueHandler sets a handler that will be called
|
|
// when a new transaction is enqueued.
|
|
func (m *TxQueueManager) SetTransactionQueueHandler(fn common.EnqueuedTxHandler) {
|
|
m.txQueue.SetEnqueueHandler(fn)
|
|
}
|
|
|
|
// ReturnSendTransactionEvent is a JSON returned whenever transaction send is returned
|
|
type ReturnSendTransactionEvent struct {
|
|
ID string `json:"id"`
|
|
Args common.SendTxArgs `json:"args"`
|
|
MessageID string `json:"message_id"`
|
|
ErrorMessage string `json:"error_message"`
|
|
ErrorCode string `json:"error_code"`
|
|
}
|
|
|
|
// TransactionReturnHandler returns handler that processes responses from internal tx manager
|
|
func (m *TxQueueManager) TransactionReturnHandler() func(queuedTx *common.QueuedTx, err error) {
|
|
return func(queuedTx *common.QueuedTx, err error) {
|
|
if err == nil {
|
|
return
|
|
}
|
|
|
|
// discard notifications with empty tx
|
|
if queuedTx == nil {
|
|
return
|
|
}
|
|
|
|
// error occurred, signal up to application
|
|
signal.Send(signal.Envelope{
|
|
Type: EventTransactionFailed,
|
|
Event: ReturnSendTransactionEvent{
|
|
ID: string(queuedTx.ID),
|
|
Args: queuedTx.Args,
|
|
MessageID: common.MessageIDFromContext(queuedTx.Context),
|
|
ErrorMessage: err.Error(),
|
|
ErrorCode: m.sendTransactionErrorCode(err),
|
|
},
|
|
})
|
|
}
|
|
}
|
|
|
|
func (m *TxQueueManager) sendTransactionErrorCode(err error) string {
|
|
if code, ok := txReturnCodes[err]; ok {
|
|
return code
|
|
}
|
|
|
|
return SendTxDefaultErrorCode
|
|
}
|
|
|
|
// SetTransactionReturnHandler sets a handler that will be called
|
|
// when a transaction is about to return or when a recoverable error occured.
|
|
// Recoverable error is, for instance, wrong password.
|
|
func (m *TxQueueManager) SetTransactionReturnHandler(fn common.EnqueuedTxReturnHandler) {
|
|
m.txQueue.SetTxReturnHandler(fn)
|
|
}
|
|
|
|
// SendTransactionRPCHandler is a handler for eth_sendTransaction method.
|
|
// It accepts one param which is a slice with a map of transaction params.
|
|
func (m *TxQueueManager) SendTransactionRPCHandler(ctx context.Context, args ...interface{}) (interface{}, error) {
|
|
log.Info("SendTransactionRPCHandler called")
|
|
|
|
// TODO(adam): it's a hack to parse arguments as common.RPCCall can do that.
|
|
// We should refactor parsing these params to a separate struct.
|
|
rpcCall := common.RPCCall{Params: args}
|
|
|
|
tx := m.CreateTransaction(ctx, rpcCall.ToSendTxArgs())
|
|
|
|
if err := m.QueueTransaction(tx); err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if err := m.WaitForTransaction(tx); err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return tx.Hash.Hex(), nil
|
|
}
|