deprecate v1 error message
This commit is contained in:
parent
d5ca359418
commit
0c535e60a2
|
@ -7,22 +7,17 @@ package frontend
|
||||||
|
|
||||||
import (
|
import (
|
||||||
"context"
|
"context"
|
||||||
"encoding/hex"
|
|
||||||
"encoding/json"
|
|
||||||
"errors"
|
"errors"
|
||||||
"io"
|
"io"
|
||||||
"math"
|
|
||||||
"net"
|
"net"
|
||||||
"regexp"
|
"regexp"
|
||||||
"sort"
|
"sort"
|
||||||
"strconv"
|
|
||||||
"strings"
|
"strings"
|
||||||
"sync"
|
"sync"
|
||||||
"sync/atomic"
|
"sync/atomic"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
"github.com/adityapk00/lightwalletd/common"
|
"github.com/adityapk00/lightwalletd/common"
|
||||||
"github.com/adityapk00/lightwalletd/parser"
|
|
||||||
"github.com/adityapk00/lightwalletd/walletrpc"
|
"github.com/adityapk00/lightwalletd/walletrpc"
|
||||||
"github.com/sirupsen/logrus"
|
"github.com/sirupsen/logrus"
|
||||||
"google.golang.org/grpc/metadata"
|
"google.golang.org/grpc/metadata"
|
||||||
|
@ -99,189 +94,19 @@ func (s *lwdStreamer) dailyActiveBlock(height uint64, peerip string) {
|
||||||
|
|
||||||
// GetLatestBlock returns the height of the best chain, according to zcashd.
|
// GetLatestBlock returns the height of the best chain, according to zcashd.
|
||||||
func (s *lwdStreamer) GetLatestBlock(ctx context.Context, placeholder *walletrpc.ChainSpec) (*walletrpc.BlockID, error) {
|
func (s *lwdStreamer) GetLatestBlock(ctx context.Context, placeholder *walletrpc.ChainSpec) (*walletrpc.BlockID, error) {
|
||||||
result, rpcErr := common.RawRequest("getblockchaininfo", []json.RawMessage{})
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
if rpcErr != nil {
|
|
||||||
return nil, rpcErr
|
|
||||||
}
|
|
||||||
var getblockchaininfoReply common.ZcashdRpcReplyGetblockchaininfo
|
|
||||||
err := json.Unmarshal(result, &getblockchaininfoReply)
|
|
||||||
if err != nil {
|
|
||||||
return nil, rpcErr
|
|
||||||
}
|
|
||||||
|
|
||||||
common.Metrics.LatestBlockCounter.Inc()
|
|
||||||
|
|
||||||
// TODO: also return block hashes here
|
|
||||||
return &walletrpc.BlockID{Height: uint64(getblockchaininfoReply.Blocks)}, nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetTaddressTxids is a streaming RPC that returns transaction IDs that have
|
// GetTaddressTxids is a streaming RPC that returns transaction IDs that have
|
||||||
// the given transparent address (taddr) as either an input or output.
|
// the given transparent address (taddr) as either an input or output.
|
||||||
func (s *lwdStreamer) GetTaddressTxids(addressBlockFilter *walletrpc.TransparentAddressBlockFilter, resp walletrpc.CompactTxStreamer_GetTaddressTxidsServer) error {
|
func (s *lwdStreamer) GetTaddressTxids(addressBlockFilter *walletrpc.TransparentAddressBlockFilter, resp walletrpc.CompactTxStreamer_GetTaddressTxidsServer) error {
|
||||||
if err := checkTaddress(addressBlockFilter.Address); err != nil {
|
return errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
return err
|
|
||||||
}
|
|
||||||
|
|
||||||
if addressBlockFilter.Range == nil {
|
|
||||||
return errors.New("Must specify block range")
|
|
||||||
}
|
|
||||||
if addressBlockFilter.Range.Start == nil {
|
|
||||||
return errors.New("Must specify a start block height")
|
|
||||||
}
|
|
||||||
if addressBlockFilter.Range.End == nil {
|
|
||||||
return errors.New("Must specify an end block height")
|
|
||||||
}
|
|
||||||
params := make([]json.RawMessage, 1)
|
|
||||||
request := &common.ZcashdRpcRequestGetaddresstxids{
|
|
||||||
Addresses: []string{addressBlockFilter.Address},
|
|
||||||
Start: addressBlockFilter.Range.Start.Height,
|
|
||||||
End: addressBlockFilter.Range.End.Height,
|
|
||||||
}
|
|
||||||
param, err := json.Marshal(request)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
params[0] = param
|
|
||||||
result, rpcErr := common.RawRequest("getaddresstxids", params)
|
|
||||||
|
|
||||||
// For some reason, the error responses are not JSON
|
|
||||||
if rpcErr != nil {
|
|
||||||
return rpcErr
|
|
||||||
}
|
|
||||||
|
|
||||||
var txids []string
|
|
||||||
err = json.Unmarshal(result, &txids)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
|
|
||||||
timeout, cancel := context.WithTimeout(resp.Context(), 30*time.Second)
|
|
||||||
defer cancel()
|
|
||||||
|
|
||||||
for _, txidstr := range txids {
|
|
||||||
txid, _ := hex.DecodeString(txidstr)
|
|
||||||
// Txid is read as a string, which is in big-endian order. But when converting
|
|
||||||
// to bytes, it should be little-endian
|
|
||||||
tx, err := s.GetTransaction(timeout, &walletrpc.TxFilter{Hash: parser.Reverse(txid)})
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
if err = resp.Send(tx); err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetBlock returns the compact block at the requested height. Requesting a
|
// GetBlock returns the compact block at the requested height. Requesting a
|
||||||
// block by hash is not yet supported.
|
// block by hash is not yet supported.
|
||||||
func (s *lwdStreamer) GetBlock(ctx context.Context, id *walletrpc.BlockID) (*walletrpc.CompactBlock, error) {
|
func (s *lwdStreamer) GetBlock(ctx context.Context, id *walletrpc.BlockID) (*walletrpc.CompactBlock, error) {
|
||||||
if id.Height == 0 && id.Hash == nil {
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
return nil, errors.New("request for unspecified identifier")
|
|
||||||
}
|
|
||||||
|
|
||||||
// Precedence: a hash is more specific than a height. If we have it, use it first.
|
|
||||||
if id.Hash != nil {
|
|
||||||
// TODO: Get block by hash
|
|
||||||
return nil, errors.New("GetBlock by Hash is not yet implemented")
|
|
||||||
}
|
|
||||||
cBlock, err := common.GetBlock(s.cache, int(id.Height))
|
|
||||||
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
|
|
||||||
common.Metrics.TotalBlocksServedConter.Inc()
|
|
||||||
return cBlock, err
|
|
||||||
}
|
|
||||||
|
|
||||||
// GetBlockRange is a streaming RPC that returns blocks, in compact form,
|
|
||||||
// (as also returned by GetBlock) from the block height 'start' to height
|
|
||||||
// 'end' inclusively.
|
|
||||||
func (s *lwdStreamer) GetBlockRange(span *walletrpc.BlockRange, resp walletrpc.CompactTxStreamer_GetBlockRangeServer) error {
|
|
||||||
blockChan := make(chan *walletrpc.CompactBlock)
|
|
||||||
errChan := make(chan error)
|
|
||||||
if span.Start == nil || span.End == nil {
|
|
||||||
return errors.New("Must specify start and end heights")
|
|
||||||
}
|
|
||||||
|
|
||||||
peerip := s.peerIPFromContext(resp.Context())
|
|
||||||
|
|
||||||
// Latency logging
|
|
||||||
go func() {
|
|
||||||
// If there is no ip, ignore
|
|
||||||
if peerip == "unknown" {
|
|
||||||
return
|
|
||||||
}
|
|
||||||
|
|
||||||
// Log only if bulk requesting blocks
|
|
||||||
if span.End.Height-span.Start.Height < 100 {
|
|
||||||
return
|
|
||||||
}
|
|
||||||
|
|
||||||
now := time.Now().UnixNano()
|
|
||||||
s.latencyMutex.Lock()
|
|
||||||
defer s.latencyMutex.Unlock()
|
|
||||||
|
|
||||||
// remove all old entries
|
|
||||||
for ip, entry := range s.latencyCache {
|
|
||||||
if entry.timeNanos+int64(30*math.Pow10(9)) < now { // delete after 30 seconds
|
|
||||||
delete(s.latencyCache, ip)
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
// Look up if this ip address has a previous getblock range
|
|
||||||
if entry, ok := s.latencyCache[peerip]; ok {
|
|
||||||
// Log only continous blocks
|
|
||||||
if entry.lastBlock+1 == span.Start.Height {
|
|
||||||
common.Log.WithFields(logrus.Fields{
|
|
||||||
"method": "GetBlockRangeLatency",
|
|
||||||
"peer_addr": peerip,
|
|
||||||
"num_blocks": entry.totalBlocks,
|
|
||||||
"end_height": entry.lastBlock,
|
|
||||||
"latency_millis": (now - entry.timeNanos) / int64(math.Pow10(6)),
|
|
||||||
}).Info("Service")
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
// Add or update the ip entry
|
|
||||||
s.latencyCache[peerip] = &latencyCacheEntry{
|
|
||||||
lastBlock: span.End.Height,
|
|
||||||
totalBlocks: span.End.Height - span.Start.Height + 1,
|
|
||||||
timeNanos: now,
|
|
||||||
}
|
|
||||||
}()
|
|
||||||
|
|
||||||
// Log a daily active user if the user requests the day's "key block"
|
|
||||||
go func() {
|
|
||||||
for height := span.Start.Height; height <= span.End.Height; height++ {
|
|
||||||
s.dailyActiveBlock(height, peerip)
|
|
||||||
}
|
|
||||||
}()
|
|
||||||
|
|
||||||
common.Log.WithFields(logrus.Fields{
|
|
||||||
"method": "GetBlockRange",
|
|
||||||
"start": span.Start.Height,
|
|
||||||
"end": span.End.Height,
|
|
||||||
"peer_addr": peerip,
|
|
||||||
}).Info("Service")
|
|
||||||
|
|
||||||
go common.GetBlockRange(s.cache, blockChan, errChan, int(span.Start.Height), int(span.End.Height))
|
|
||||||
|
|
||||||
for {
|
|
||||||
select {
|
|
||||||
case err := <-errChan:
|
|
||||||
// this will also catch context.DeadlineExceeded from the timeout
|
|
||||||
//common.Metrics.TotalErrors.Inc()
|
|
||||||
return err
|
|
||||||
case cBlock := <-blockChan:
|
|
||||||
common.Metrics.TotalBlocksServedConter.Inc()
|
|
||||||
err := resp.Send(cBlock)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetTreeState returns the note commitment tree state corresponding to the given block.
|
// GetTreeState returns the note commitment tree state corresponding to the given block.
|
||||||
|
@ -289,215 +114,38 @@ func (s *lwdStreamer) GetBlockRange(span *walletrpc.BlockRange, resp walletrpc.C
|
||||||
// values also (even though they can be obtained using GetBlock).
|
// values also (even though they can be obtained using GetBlock).
|
||||||
// The block can be specified by either height or hash.
|
// The block can be specified by either height or hash.
|
||||||
func (s *lwdStreamer) GetTreeState(ctx context.Context, id *walletrpc.BlockID) (*walletrpc.TreeState, error) {
|
func (s *lwdStreamer) GetTreeState(ctx context.Context, id *walletrpc.BlockID) (*walletrpc.TreeState, error) {
|
||||||
if id.Height == 0 && id.Hash == nil {
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
return nil, errors.New("request for unspecified identifier")
|
|
||||||
}
|
|
||||||
// The Zcash z_gettreestate rpc accepts either a block height or block hash
|
|
||||||
params := make([]json.RawMessage, 1)
|
|
||||||
var hashJSON []byte
|
|
||||||
if id.Height > 0 {
|
|
||||||
heightJSON, err := json.Marshal(strconv.Itoa(int(id.Height)))
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
params[0] = heightJSON
|
|
||||||
} else {
|
|
||||||
// id.Hash is big-endian, keep in big-endian for the rpc
|
|
||||||
hashJSON, err := json.Marshal(hex.EncodeToString(id.Hash))
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
params[0] = hashJSON
|
|
||||||
}
|
|
||||||
var gettreestateReply common.ZcashdRpcReplyGettreestate
|
|
||||||
for {
|
|
||||||
result, rpcErr := common.RawRequest("z_gettreestate", params)
|
|
||||||
if rpcErr != nil {
|
|
||||||
return nil, rpcErr
|
|
||||||
}
|
|
||||||
err := json.Unmarshal(result, &gettreestateReply)
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
if gettreestateReply.Sapling.Commitments.FinalState != "" {
|
|
||||||
break
|
|
||||||
}
|
|
||||||
if gettreestateReply.Sapling.SkipHash == "" {
|
|
||||||
break
|
|
||||||
}
|
|
||||||
hashJSON, err = json.Marshal(gettreestateReply.Sapling.SkipHash)
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
params[0] = hashJSON
|
|
||||||
}
|
|
||||||
if gettreestateReply.Sapling.Commitments.FinalState == "" {
|
|
||||||
return nil, errors.New("zcashd did not return treestate")
|
|
||||||
}
|
|
||||||
return &walletrpc.TreeState{
|
|
||||||
Network: s.chainName,
|
|
||||||
Height: uint64(gettreestateReply.Height),
|
|
||||||
Hash: gettreestateReply.Hash,
|
|
||||||
Time: gettreestateReply.Time,
|
|
||||||
Tree: gettreestateReply.Sapling.Commitments.FinalState,
|
|
||||||
}, nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetTransaction returns the raw transaction bytes that are returned
|
// GetTransaction returns the raw transaction bytes that are returned
|
||||||
// by the zcashd 'getrawtransaction' RPC.
|
// by the zcashd 'getrawtransaction' RPC.
|
||||||
func (s *lwdStreamer) GetTransaction(ctx context.Context, txf *walletrpc.TxFilter) (*walletrpc.RawTransaction, error) {
|
func (s *lwdStreamer) GetTransaction(ctx context.Context, txf *walletrpc.TxFilter) (*walletrpc.RawTransaction, error) {
|
||||||
if txf.Hash != nil {
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
if len(txf.Hash) != 32 {
|
|
||||||
return nil, errors.New("Transaction ID has invalid length")
|
|
||||||
}
|
|
||||||
leHashStringJSON, err := json.Marshal(hex.EncodeToString(parser.Reverse(txf.Hash)))
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
params := []json.RawMessage{
|
|
||||||
leHashStringJSON,
|
|
||||||
json.RawMessage("1"),
|
|
||||||
}
|
|
||||||
result, rpcErr := common.RawRequest("getrawtransaction", params)
|
|
||||||
|
|
||||||
// For some reason, the error responses are not JSON
|
|
||||||
if rpcErr != nil {
|
|
||||||
return nil, rpcErr
|
|
||||||
}
|
|
||||||
// Many other fields are returned, but we need only these two.
|
|
||||||
var txinfo common.ZcashdRpcReplyGetrawtransaction
|
|
||||||
err = json.Unmarshal(result, &txinfo)
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
txBytes, err := hex.DecodeString(txinfo.Hex)
|
|
||||||
if err != nil {
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
return &walletrpc.RawTransaction{
|
|
||||||
Data: txBytes,
|
|
||||||
Height: uint64(txinfo.Height),
|
|
||||||
}, nil
|
|
||||||
}
|
|
||||||
|
|
||||||
if txf.Block != nil && txf.Block.Hash != nil {
|
|
||||||
return nil, errors.New("Can't GetTransaction with a blockhash+num. Please call GetTransaction with txid")
|
|
||||||
}
|
|
||||||
return nil, errors.New("Please call GetTransaction with txid")
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetLightdInfo gets the LightWalletD (this server) info, and includes information
|
// GetLightdInfo gets the LightWalletD (this server) info, and includes information
|
||||||
// it gets from its backend zcashd.
|
// it gets from its backend zcashd.
|
||||||
func (s *lwdStreamer) GetLightdInfo(ctx context.Context, in *walletrpc.Empty) (*walletrpc.LightdInfo, error) {
|
func (s *lwdStreamer) GetLightdInfo(ctx context.Context, in *walletrpc.Empty) (*walletrpc.LightdInfo, error) {
|
||||||
return common.GetLightdInfo()
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
}
|
}
|
||||||
|
|
||||||
// SendTransaction forwards raw transaction bytes to a zcashd instance over JSON-RPC
|
// SendTransaction forwards raw transaction bytes to a zcashd instance over JSON-RPC
|
||||||
func (s *lwdStreamer) SendTransaction(ctx context.Context, rawtx *walletrpc.RawTransaction) (*walletrpc.SendResponse, error) {
|
func (s *lwdStreamer) SendTransaction(ctx context.Context, rawtx *walletrpc.RawTransaction) (*walletrpc.SendResponse, error) {
|
||||||
// sendrawtransaction "hexstring" ( allowhighfees )
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
//
|
|
||||||
// Submits raw transaction (binary) to local node and network.
|
|
||||||
//
|
|
||||||
// Result:
|
|
||||||
// "hex" (string) The transaction hash in hex
|
|
||||||
|
|
||||||
if rawtx == nil || rawtx.Data == nil {
|
|
||||||
return nil, errors.New("Bad Transaction or Data")
|
|
||||||
}
|
|
||||||
|
|
||||||
// Construct raw JSON-RPC params
|
|
||||||
params := make([]json.RawMessage, 1)
|
|
||||||
txJSON, err := json.Marshal(hex.EncodeToString(rawtx.Data))
|
|
||||||
if err != nil {
|
|
||||||
return &walletrpc.SendResponse{}, err
|
|
||||||
}
|
|
||||||
params[0] = txJSON
|
|
||||||
result, rpcErr := common.RawRequest("sendrawtransaction", params)
|
|
||||||
|
|
||||||
var errCode int64
|
|
||||||
var errMsg string
|
|
||||||
|
|
||||||
// For some reason, the error responses are not JSON
|
|
||||||
if rpcErr != nil {
|
|
||||||
errParts := strings.SplitN(rpcErr.Error(), ":", 2)
|
|
||||||
if len(errParts) < 2 {
|
|
||||||
return nil, errors.New("SendTransaction couldn't parse error code")
|
|
||||||
}
|
|
||||||
errMsg = strings.TrimSpace(errParts[1])
|
|
||||||
errCode, err = strconv.ParseInt(errParts[0], 10, 32)
|
|
||||||
if err != nil {
|
|
||||||
// This should never happen. We can't panic here, but it's that class of error.
|
|
||||||
// This is why we need integration testing to work better than regtest currently does. TODO.
|
|
||||||
return nil, errors.New("SendTransaction couldn't parse error code")
|
|
||||||
}
|
|
||||||
} else {
|
|
||||||
errMsg = string(result)
|
|
||||||
}
|
|
||||||
|
|
||||||
// TODO these are called Error but they aren't at the moment.
|
|
||||||
// A success will return code 0 and message txhash.
|
|
||||||
resp := &walletrpc.SendResponse{
|
|
||||||
ErrorCode: int32(errCode),
|
|
||||||
ErrorMessage: errMsg,
|
|
||||||
}
|
|
||||||
|
|
||||||
common.Metrics.SendTransactionsCounter.Inc()
|
|
||||||
|
|
||||||
return resp, nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
func getTaddressBalanceZcashdRpc(addressList []string) (*walletrpc.Balance, error) {
|
func getTaddressBalanceZcashdRpc(addressList []string) (*walletrpc.Balance, error) {
|
||||||
for _, addr := range addressList {
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
if err := checkTaddress(addr); err != nil {
|
|
||||||
return &walletrpc.Balance{}, err
|
|
||||||
}
|
|
||||||
}
|
|
||||||
params := make([]json.RawMessage, 1)
|
|
||||||
addrList := &common.ZcashdRpcRequestGetaddressbalance{
|
|
||||||
Addresses: addressList,
|
|
||||||
}
|
|
||||||
param, err := json.Marshal(addrList)
|
|
||||||
if err != nil {
|
|
||||||
return &walletrpc.Balance{}, err
|
|
||||||
}
|
|
||||||
params[0] = param
|
|
||||||
|
|
||||||
result, rpcErr := common.RawRequest("getaddressbalance", params)
|
|
||||||
if rpcErr != nil {
|
|
||||||
return &walletrpc.Balance{}, rpcErr
|
|
||||||
}
|
|
||||||
var balanceReply common.ZcashdRpcReplyGetaddressbalance
|
|
||||||
err = json.Unmarshal(result, &balanceReply)
|
|
||||||
if err != nil {
|
|
||||||
return &walletrpc.Balance{}, err
|
|
||||||
}
|
|
||||||
return &walletrpc.Balance{ValueZat: balanceReply.Balance}, nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetTaddressBalance returns the total balance for a list of taddrs
|
// GetTaddressBalance returns the total balance for a list of taddrs
|
||||||
func (s *lwdStreamer) GetTaddressBalance(ctx context.Context, addresses *walletrpc.AddressList) (*walletrpc.Balance, error) {
|
func (s *lwdStreamer) GetTaddressBalance(ctx context.Context, addresses *walletrpc.AddressList) (*walletrpc.Balance, error) {
|
||||||
return getTaddressBalanceZcashdRpc(addresses.Addresses)
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
}
|
}
|
||||||
|
|
||||||
// GetTaddressBalanceStream returns the total balance for a list of taddrs
|
// GetTaddressBalanceStream returns the total balance for a list of taddrs
|
||||||
func (s *lwdStreamer) GetTaddressBalanceStream(addresses walletrpc.CompactTxStreamer_GetTaddressBalanceStreamServer) error {
|
func (s *lwdStreamer) GetTaddressBalanceStream(addresses walletrpc.CompactTxStreamer_GetTaddressBalanceStreamServer) error {
|
||||||
addressList := make([]string, 0)
|
return errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
for {
|
|
||||||
addr, err := addresses.Recv()
|
|
||||||
if err == io.EOF {
|
|
||||||
break
|
|
||||||
}
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
addressList = append(addressList, addr.Address)
|
|
||||||
}
|
|
||||||
balance, err := getTaddressBalanceZcashdRpc(addressList)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
addresses.SendAndClose(balance)
|
|
||||||
return nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// Key is 32-byte txid (as a 64-character string), data is pointer to compact tx.
|
// Key is 32-byte txid (as a 64-character string), data is pointer to compact tx.
|
||||||
|
@ -508,78 +156,7 @@ var mempoolList []string
|
||||||
var lastMempool time.Time
|
var lastMempool time.Time
|
||||||
|
|
||||||
func (s *lwdStreamer) GetMempoolTx(exclude *walletrpc.Exclude, resp walletrpc.CompactTxStreamer_GetMempoolTxServer) error {
|
func (s *lwdStreamer) GetMempoolTx(exclude *walletrpc.Exclude, resp walletrpc.CompactTxStreamer_GetMempoolTxServer) error {
|
||||||
if time.Now().Sub(lastMempool).Seconds() >= 2 {
|
return errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
lastMempool = time.Now()
|
|
||||||
// Refresh our copy of the mempool.
|
|
||||||
params := make([]json.RawMessage, 0)
|
|
||||||
result, rpcErr := common.RawRequest("getrawmempool", params)
|
|
||||||
if rpcErr != nil {
|
|
||||||
return rpcErr
|
|
||||||
}
|
|
||||||
err := json.Unmarshal(result, &mempoolList)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
newmempoolMap := make(map[string]*walletrpc.CompactTx)
|
|
||||||
if mempoolMap == nil {
|
|
||||||
mempoolMap = &newmempoolMap
|
|
||||||
}
|
|
||||||
for _, txidstr := range mempoolList {
|
|
||||||
if ctx, ok := (*mempoolMap)[txidstr]; ok {
|
|
||||||
// This ctx has already been fetched, copy pointer to it.
|
|
||||||
newmempoolMap[txidstr] = ctx
|
|
||||||
continue
|
|
||||||
}
|
|
||||||
txidJSON, err := json.Marshal(txidstr)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
// The "0" is because we only need the raw hex, which is returned as
|
|
||||||
// just a hex string, and not even a json string (with quotes).
|
|
||||||
params := []json.RawMessage{txidJSON, json.RawMessage("0")}
|
|
||||||
result, rpcErr := common.RawRequest("getrawtransaction", params)
|
|
||||||
if rpcErr != nil {
|
|
||||||
// Not an error; mempool transactions can disappear
|
|
||||||
continue
|
|
||||||
}
|
|
||||||
// strip the quotes
|
|
||||||
var txStr string
|
|
||||||
err = json.Unmarshal(result, &txStr)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
|
|
||||||
// conver to binary
|
|
||||||
txBytes, err := hex.DecodeString(txStr)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
tx := parser.NewTransaction()
|
|
||||||
txdata, err := tx.ParseFromSlice(txBytes)
|
|
||||||
if len(txdata) > 0 {
|
|
||||||
return errors.New("extra data deserializing transaction")
|
|
||||||
}
|
|
||||||
newmempoolMap[txidstr] = &walletrpc.CompactTx{}
|
|
||||||
if tx.HasSaplingElements() {
|
|
||||||
newmempoolMap[txidstr] = tx.ToCompact( /* height */ 0)
|
|
||||||
}
|
|
||||||
}
|
|
||||||
mempoolMap = &newmempoolMap
|
|
||||||
}
|
|
||||||
excludeHex := make([]string, len(exclude.Txid))
|
|
||||||
for i := 0; i < len(exclude.Txid); i++ {
|
|
||||||
excludeHex[i] = hex.EncodeToString(parser.Reverse(exclude.Txid[i]))
|
|
||||||
}
|
|
||||||
for _, txid := range MempoolFilter(mempoolList, excludeHex) {
|
|
||||||
tx := (*mempoolMap)[txid]
|
|
||||||
if len(tx.Hash) > 0 {
|
|
||||||
err := resp.Send(tx)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// Return the subset of items that aren't excluded, but
|
// Return the subset of items that aren't excluded, but
|
||||||
|
@ -629,81 +206,15 @@ func MempoolFilter(items, exclude []string) []string {
|
||||||
}
|
}
|
||||||
|
|
||||||
func getAddressUtxos(arg *walletrpc.GetAddressUtxosArg, f func(*walletrpc.GetAddressUtxosReply) error) error {
|
func getAddressUtxos(arg *walletrpc.GetAddressUtxosArg, f func(*walletrpc.GetAddressUtxosReply) error) error {
|
||||||
for _, a := range arg.Addresses {
|
return errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
if err := checkTaddress(a); err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
}
|
|
||||||
params := make([]json.RawMessage, 1)
|
|
||||||
addrList := &common.ZcashdRpcRequestGetaddressutxos{
|
|
||||||
Addresses: arg.Addresses,
|
|
||||||
}
|
|
||||||
param, err := json.Marshal(addrList)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
params[0] = param
|
|
||||||
result, rpcErr := common.RawRequest("getaddressutxos", params)
|
|
||||||
if rpcErr != nil {
|
|
||||||
return rpcErr
|
|
||||||
}
|
|
||||||
var utxosReply common.ZcashdRpcReplyGetaddressutxos
|
|
||||||
err = json.Unmarshal(result, &utxosReply)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
n := 0
|
|
||||||
for _, utxo := range utxosReply {
|
|
||||||
if uint64(utxo.Height) < arg.StartHeight {
|
|
||||||
continue
|
|
||||||
}
|
|
||||||
n++
|
|
||||||
if arg.MaxEntries > 0 && uint32(n) > arg.MaxEntries {
|
|
||||||
break
|
|
||||||
}
|
|
||||||
txidBytes, err := hex.DecodeString(utxo.Txid)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
scriptBytes, err := hex.DecodeString(utxo.Script)
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
err = f(&walletrpc.GetAddressUtxosReply{
|
|
||||||
Address: utxo.Address,
|
|
||||||
Txid: parser.Reverse(txidBytes),
|
|
||||||
Index: int32(utxo.OutputIndex),
|
|
||||||
Script: scriptBytes,
|
|
||||||
ValueZat: int64(utxo.Satoshis),
|
|
||||||
Height: uint64(utxo.Height),
|
|
||||||
})
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
func (s *lwdStreamer) GetAddressUtxos(ctx context.Context, arg *walletrpc.GetAddressUtxosArg) (*walletrpc.GetAddressUtxosReplyList, error) {
|
func (s *lwdStreamer) GetAddressUtxos(ctx context.Context, arg *walletrpc.GetAddressUtxosArg) (*walletrpc.GetAddressUtxosReplyList, error) {
|
||||||
addressUtxos := make([]*walletrpc.GetAddressUtxosReply, 0)
|
return nil, errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
err := getAddressUtxos(arg, func(utxo *walletrpc.GetAddressUtxosReply) error {
|
|
||||||
addressUtxos = append(addressUtxos, utxo)
|
|
||||||
return nil
|
|
||||||
})
|
|
||||||
if err != nil {
|
|
||||||
return &walletrpc.GetAddressUtxosReplyList{}, err
|
|
||||||
}
|
|
||||||
return &walletrpc.GetAddressUtxosReplyList{AddressUtxos: addressUtxos}, nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
func (s *lwdStreamer) GetAddressUtxosStream(arg *walletrpc.GetAddressUtxosArg, resp walletrpc.CompactTxStreamer_GetAddressUtxosStreamServer) error {
|
func (s *lwdStreamer) GetAddressUtxosStream(arg *walletrpc.GetAddressUtxosArg, resp walletrpc.CompactTxStreamer_GetAddressUtxosStreamServer) error {
|
||||||
err := getAddressUtxos(arg, func(utxo *walletrpc.GetAddressUtxosReply) error {
|
return errors.New("Your version of Zecwallet Lite is deprecated. Please download the latest version from www.zecwallet.co")
|
||||||
return resp.Send(utxo)
|
|
||||||
})
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
return nil
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// This rpc is used only for testing.
|
// This rpc is used only for testing.
|
||||||
|
|
Loading…
Reference in New Issue