[#1170] pkg/morph: Change HTTP for WS client

Updated client now supports subscription to chain notifications and RPC
switch between provided RPC endpoints.

Signed-off-by: Pavel Karpy <carpawell@nspcc.ru>
This commit is contained in:
Pavel Karpy 2021-02-09 20:52:10 +03:00 committed by Alex Vanin
parent 71c75dc7e8
commit 402f488bec
7 changed files with 661 additions and 327 deletions

View file

@ -61,7 +61,7 @@ func initMorphComponents(c *cfg) {
if err := cli.SetGroupSignerScope(); err != nil { if err := cli.SetGroupSignerScope(); err != nil {
c.log.Info("failed to set group signer scope, continue with Global", zap.Error(err)) c.log.Info("failed to set group signer scope, continue with Global", zap.Error(err))
} }
c.cfgMorph.client = cli c.cfgMorph.client = cli
c.cfgMorph.notaryEnabled = cli.ProbeNotary() c.cfgMorph.notaryEnabled = cli.ProbeNotary()

View file

@ -24,11 +24,15 @@ import (
"go.uber.org/zap" "go.uber.org/zap"
) )
// Client is a wrapper over multiple neo-go clients // Client is a wrapper over web socket neo-go client
// that provides smart-contract invocation interface. // that provides smart-contract invocation interface
// and notification subscription functionality.
// //
// Each operation accesses all nodes in turn until the first success, // On connection lost tries establishing new connection
// and returns the error of the very first client on failure. // to the next RPC (if any). If no RPC node available,
// switches to inactive mode: any RPC call leads to immediate
// return with ErrConnectionLost error, notification channel
// returned from Client.NotificationChannel is closed.
// //
// Working client must be created via constructor New. // Working client must be created via constructor New.
// Using the Client that has been created with new(Client) // Using the Client that has been created with new(Client)
@ -37,48 +41,55 @@ import (
type Client struct { type Client struct {
cache cache
// two mutual exclusive modes, exactly one must be non-nil
*singleClient // works with single neo-go client
*multiClient // creates and caches single clients
}
type cache struct {
// mtx protects primitive values.
mtx sync.RWMutex
nnsHash util.Uint160
groupKey *keys.PublicKey
// txHeights is a thread-safe LRU cache for transaction heights.
txHeights *lru.Cache
}
type singleClient struct {
logger *logger.Logger // logging component logger *logger.Logger // logging component
client *client.Client // neo-go client client *client.WSClient // neo-go websocket client
acc *wallet.Account // neo account acc *wallet.Account // neo account
waitInterval time.Duration
signer *transaction.Signer signer *transaction.Signer
notary *notary notary *notary
cfg cfg
endpoints *endpoints
// switching between rpc endpoint lock
switchLock *sync.RWMutex
// channel for ws notifications
notifications chan client.Notification
// channel for internal stop
closeChan chan struct{}
// cached subscription information
subscribedEvents map[util.Uint160]string
subscribedNotaryEvents map[util.Uint160]string
subscribedToNewBlocks bool
// indicates that Client is not able to
// establish connection to any of the
// provided RPC endpoints
inactive bool
} }
func blankSingleClient(cli *client.Client, w *wallet.Account, cfg *cfg) *singleClient { type cache struct {
return &singleClient{ nnsHash util.Uint160
logger: cfg.logger, groupKey *keys.PublicKey
client: cli, txHeights *lru.Cache
acc: w,
waitInterval: cfg.waitInterval,
signer: cfg.signer,
}
} }
// ErrNilClient is returned by functions that expect var (
// a non-nil Client pointer, but received nil. // ErrNilClient is returned by functions that expect
var ErrNilClient = errors.New("client is nil") // a non-nil Client pointer, but received nil.
ErrNilClient = errors.New("client is nil")
// ErrConnectionLost is returned when client lost web socket connection
// to the RPC node and has not been able to establish a new one since.
ErrConnectionLost = errors.New("connection to the RPC node has been lost")
)
// HaltState returned if TestInvoke function processed without panic. // HaltState returned if TestInvoke function processed without panic.
const HaltState = "HALT" const HaltState = "HALT"
@ -123,10 +134,11 @@ func unwrapNeoFSError(err error) error {
// Invoke invokes contract method by sending transaction into blockchain. // Invoke invokes contract method by sending transaction into blockchain.
// Supported args types: int64, string, util.Uint160, []byte and bool. // Supported args types: int64, string, util.Uint160, []byte and bool.
func (c *Client) Invoke(contract util.Uint160, fee fixedn.Fixed8, method string, args ...interface{}) error { func (c *Client) Invoke(contract util.Uint160, fee fixedn.Fixed8, method string, args ...interface{}) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.Invoke(contract, fee, method, args...)
}) if c.inactive {
return ErrConnectionLost
} }
params := make([]sc.Parameter, 0, len(args)) params := make([]sc.Parameter, 0, len(args))
@ -188,11 +200,11 @@ func (c *Client) Invoke(contract util.Uint160, fee fixedn.Fixed8, method string,
// TestInvoke invokes contract method locally in neo-go node. This method should // TestInvoke invokes contract method locally in neo-go node. This method should
// be used to read data from smart-contract. // be used to read data from smart-contract.
func (c *Client) TestInvoke(contract util.Uint160, method string, args ...interface{}) (res []stackitem.Item, err error) { func (c *Client) TestInvoke(contract util.Uint160, method string, args ...interface{}) (res []stackitem.Item, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.TestInvoke(contract, method, args...)
return err if c.inactive {
}) return nil, ErrConnectionLost
} }
var params = make([]sc.Parameter, 0, len(args)) var params = make([]sc.Parameter, 0, len(args))
@ -227,10 +239,11 @@ func (c *Client) TestInvoke(contract util.Uint160, method string, args ...interf
// TransferGas to the receiver from local wallet // TransferGas to the receiver from local wallet
func (c *Client) TransferGas(receiver util.Uint160, amount fixedn.Fixed8) error { func (c *Client) TransferGas(receiver util.Uint160, amount fixedn.Fixed8) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.TransferGas(receiver, amount)
}) if c.inactive {
return ErrConnectionLost
} }
gas, err := c.client.GetNativeContractHash(nativenames.Gas) gas, err := c.client.GetNativeContractHash(nativenames.Gas)
@ -255,10 +268,11 @@ func (c *Client) TransferGas(receiver util.Uint160, amount fixedn.Fixed8) error
// //
// Returns only connection errors. // Returns only connection errors.
func (c *Client) Wait(ctx context.Context, n uint32) error { func (c *Client) Wait(ctx context.Context, n uint32) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.Wait(ctx, n)
}) if c.inactive {
return ErrConnectionLost
} }
var ( var (
@ -291,17 +305,17 @@ func (c *Client) Wait(ctx context.Context, n uint32) error {
return nil return nil
} }
time.Sleep(c.waitInterval) time.Sleep(c.cfg.waitInterval)
} }
} }
// GasBalance returns GAS amount in the client's wallet. // GasBalance returns GAS amount in the client's wallet.
func (c *Client) GasBalance() (res int64, err error) { func (c *Client) GasBalance() (res int64, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.GasBalance()
return err if c.inactive {
}) return 0, ErrConnectionLost
} }
gas, err := c.client.GetNativeContractHash(nativenames.Gas) gas, err := c.client.GetNativeContractHash(nativenames.Gas)
@ -314,11 +328,11 @@ func (c *Client) GasBalance() (res int64, err error) {
// Committee returns keys of chain committee from neo native contract. // Committee returns keys of chain committee from neo native contract.
func (c *Client) Committee() (res keys.PublicKeys, err error) { func (c *Client) Committee() (res keys.PublicKeys, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.Committee()
return err if c.inactive {
}) return nil, ErrConnectionLost
} }
return c.client.GetCommittee() return c.client.GetCommittee()
@ -326,11 +340,11 @@ func (c *Client) Committee() (res keys.PublicKeys, err error) {
// TxHalt returns true if transaction has been successfully executed and persisted. // TxHalt returns true if transaction has been successfully executed and persisted.
func (c *Client) TxHalt(h util.Uint256) (res bool, err error) { func (c *Client) TxHalt(h util.Uint256) (res bool, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.TxHalt(h)
return err if c.inactive {
}) return false, ErrConnectionLost
} }
trig := trigger.Application trig := trigger.Application
@ -343,11 +357,11 @@ func (c *Client) TxHalt(h util.Uint256) (res bool, err error) {
// TxHeight returns true if transaction has been successfully executed and persisted. // TxHeight returns true if transaction has been successfully executed and persisted.
func (c *Client) TxHeight(h util.Uint256) (res uint32, err error) { func (c *Client) TxHeight(h util.Uint256) (res uint32, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.TxHeight(h)
return err if c.inactive {
}) return 0, ErrConnectionLost
} }
return c.client.GetTransactionHeight(h) return c.client.GetTransactionHeight(h)
@ -357,11 +371,11 @@ func (c *Client) TxHeight(h util.Uint256) (res uint32, err error) {
// stores alphabet node keys of inner ring there, however side chain stores both // stores alphabet node keys of inner ring there, however side chain stores both
// alphabet and non alphabet node keys of inner ring. // alphabet and non alphabet node keys of inner ring.
func (c *Client) NeoFSAlphabetList() (res keys.PublicKeys, err error) { func (c *Client) NeoFSAlphabetList() (res keys.PublicKeys, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.NeoFSAlphabetList()
return err if c.inactive {
}) return nil, ErrConnectionLost
} }
list, err := c.roleList(noderoles.NeoFSAlphabet) list, err := c.roleList(noderoles.NeoFSAlphabet)
@ -374,11 +388,11 @@ func (c *Client) NeoFSAlphabetList() (res keys.PublicKeys, err error) {
// GetDesignateHash returns hash of the native `RoleManagement` contract. // GetDesignateHash returns hash of the native `RoleManagement` contract.
func (c *Client) GetDesignateHash() (res util.Uint160, err error) { func (c *Client) GetDesignateHash() (res util.Uint160, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.GetDesignateHash()
return err if c.inactive {
}) return util.Uint160{}, ErrConnectionLost
} }
return c.client.GetNativeContractHash(nativenames.Designation) return c.client.GetNativeContractHash(nativenames.Designation)
@ -457,11 +471,11 @@ func toStackParameter(value interface{}) (sc.Parameter, error) {
// //
// Returns 0 in case of connection problems. // Returns 0 in case of connection problems.
func (c *Client) MagicNumber() (res uint64, err error) { func (c *Client) MagicNumber() (res uint64, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.MagicNumber()
return err if c.inactive {
}) return 0, ErrConnectionLost
} }
return uint64(c.client.GetNetwork()), nil return uint64(c.client.GetNetwork()), nil
@ -470,11 +484,11 @@ func (c *Client) MagicNumber() (res uint64, err error) {
// BlockCount returns block count of the network // BlockCount returns block count of the network
// to which the underlying RPC node client is connected. // to which the underlying RPC node client is connected.
func (c *Client) BlockCount() (res uint32, err error) { func (c *Client) BlockCount() (res uint32, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.BlockCount()
return err if c.inactive {
}) return 0, ErrConnectionLost
} }
return c.client.GetBlockCount() return c.client.GetBlockCount()
@ -482,11 +496,11 @@ func (c *Client) BlockCount() (res uint32, err error) {
// MsPerBlock returns MillisecondsPerBlock network parameter. // MsPerBlock returns MillisecondsPerBlock network parameter.
func (c *Client) MsPerBlock() (res int64, err error) { func (c *Client) MsPerBlock() (res int64, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.MsPerBlock()
return err if c.inactive {
}) return 0, ErrConnectionLost
} }
v, err := c.client.GetVersion() v, err := c.client.GetVersion()
@ -499,11 +513,11 @@ func (c *Client) MsPerBlock() (res int64, err error) {
// IsValidScript returns true if invocation script executes with HALT state. // IsValidScript returns true if invocation script executes with HALT state.
func (c *Client) IsValidScript(script []byte, signers []transaction.Signer) (res bool, err error) { func (c *Client) IsValidScript(script []byte, signers []transaction.Signer) (res bool, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.IsValidScript(script, signers)
return err if c.inactive {
}) return false, ErrConnectionLost
} }
result, err := c.client.InvokeScript(script, signers) result, err := c.client.InvokeScript(script, signers)
@ -513,3 +527,21 @@ func (c *Client) IsValidScript(script []byte, signers []transaction.Signer) (res
return result.State == vm.HaltState.String(), nil return result.State == vm.HaltState.String(), nil
} }
// NotificationChannel returns channel than receives subscribed
// notification from the connected RPC node.
// Channel is closed when connection to the RPC node has been
// lost without the possibility of recovery.
func (c *Client) NotificationChannel() <-chan client.Notification {
return c.notifications
}
// inactiveMode switches Client to an inactive mode:
// - notification channel is closed;
// - all the new RPC request would return ErrConnectionLost.
//
// Note: must be called only with held write switchLock.
func (c *Client) inactiveMode() {
close(c.notifications)
c.inactive = true
}

View file

@ -2,12 +2,15 @@ package client
import ( import (
"context" "context"
"fmt"
"sync"
"time" "time"
lru "github.com/hashicorp/golang-lru" lru "github.com/hashicorp/golang-lru"
"github.com/nspcc-dev/neo-go/pkg/core/transaction" "github.com/nspcc-dev/neo-go/pkg/core/transaction"
"github.com/nspcc-dev/neo-go/pkg/crypto/keys" "github.com/nspcc-dev/neo-go/pkg/crypto/keys"
"github.com/nspcc-dev/neo-go/pkg/rpc/client" "github.com/nspcc-dev/neo-go/pkg/rpc/client"
"github.com/nspcc-dev/neo-go/pkg/util"
"github.com/nspcc-dev/neo-go/pkg/wallet" "github.com/nspcc-dev/neo-go/pkg/wallet"
"github.com/nspcc-dev/neofs-node/pkg/util/logger" "github.com/nspcc-dev/neofs-node/pkg/util/logger"
"go.uber.org/zap" "go.uber.org/zap"
@ -30,15 +33,12 @@ type cfg struct {
extraEndpoints []string extraEndpoints []string
maxConnPerHost int singleCli *client.WSClient // neo-go client for single client mode
singleCli *client.Client // neo-go client for single client mode
} }
const ( const (
defaultDialTimeout = 5 * time.Second defaultDialTimeout = 5 * time.Second
defaultWaitInterval = 500 * time.Millisecond defaultWaitInterval = 500 * time.Millisecond
defaultMaxConnPerHost = 10
) )
func defaultConfig() *cfg { func defaultConfig() *cfg {
@ -50,7 +50,6 @@ func defaultConfig() *cfg {
signer: &transaction.Signer{ signer: &transaction.Signer{
Scopes: transaction.Global, Scopes: transaction.Global,
}, },
maxConnPerHost: defaultMaxConnPerHost,
} }
} }
@ -64,6 +63,8 @@ func defaultConfig() *cfg {
// * client context: Background; // * client context: Background;
// * dial timeout: 5s; // * dial timeout: 5s;
// * blockchain network type: netmode.PrivNet; // * blockchain network type: netmode.PrivNet;
// * signer with the global scope;
// * wait interval: 500ms;
// * logger: zap.L(). // * logger: zap.L().
// //
// If desired option satisfies the default value, it can be omitted. // If desired option satisfies the default value, it can be omitted.
@ -82,27 +83,58 @@ func New(key *keys.PrivateKey, endpoint string, opts ...Option) (*Client, error)
opt(cfg) opt(cfg)
} }
if cfg.singleCli != nil { cli := &Client{
return &Client{ cache: initClientCache(),
cache: newClientCache(), logger: cfg.logger,
singleClient: blankSingleClient(cfg.singleCli, wallet.NewAccountFromPrivateKey(key), cfg), acc: wallet.NewAccountFromPrivateKey(key),
}, nil signer: cfg.signer,
cfg: *cfg,
switchLock: &sync.RWMutex{},
notifications: make(chan client.Notification),
subscribedEvents: make(map[util.Uint160]string),
subscribedNotaryEvents: make(map[util.Uint160]string),
closeChan: make(chan struct{}),
} }
endpoints := append(cfg.extraEndpoints, endpoint) if cfg.singleCli != nil {
// return client in single RPC node mode that uses
// predefined WS client
//
// in case of the closing web socket connection:
// if extra endpoints were provided via options,
// they will be used in switch process, otherwise
// inactive mode will be enabled
cli.client = cfg.singleCli
cli.endpoints = newEndpoints(cfg.extraEndpoints)
} else {
ws, err := newWSClient(*cfg, endpoint)
if err != nil {
return nil, fmt.Errorf("could not create morph client: %w", err)
}
return &Client{ err = ws.Init()
cache: newClientCache(), if err != nil {
multiClient: &multiClient{ return nil, fmt.Errorf("could not init morph client: %w", err)
cfg: *cfg, }
account: wallet.NewAccountFromPrivateKey(key),
endpoints: endpoints, cli.client = ws
clients: make(map[string]*Client, len(endpoints)), cli.endpoints = newEndpoints(append([]string{endpoint}, cfg.extraEndpoints...))
}, }
}, nil
go cli.notificationLoop()
return cli, nil
} }
func newClientCache() cache { func newWSClient(cfg cfg, endpoint string) (*client.WSClient, error) {
return client.NewWS(
cfg.ctx,
endpoint,
client.Options{DialTimeout: cfg.dialTimeout},
)
}
func initClientCache() cache {
c, _ := lru.New(100) // returns error only if size is negative c, _ := lru.New(100) // returns error only if size is negative
return cache{ return cache{
txHeights: c, txHeights: c,
@ -169,29 +201,18 @@ func WithSigner(signer *transaction.Signer) Option {
// WithExtraEndpoints returns a client constructor option // WithExtraEndpoints returns a client constructor option
// that specifies additional Neo rpc endpoints. // that specifies additional Neo rpc endpoints.
//
// Has no effect if WithSingleClient is provided.
func WithExtraEndpoints(endpoints []string) Option { func WithExtraEndpoints(endpoints []string) Option {
return func(c *cfg) { return func(c *cfg) {
c.extraEndpoints = append(c.extraEndpoints, endpoints...) c.extraEndpoints = append(c.extraEndpoints, endpoints...)
} }
} }
// WithMaxConnectionPerHost returns a client constructor
// option that specifies Neo client's maximum opened
// connection per one host.
func WithMaxConnectionPerHost(m int) Option {
return func(c *cfg) {
c.maxConnPerHost = m
}
}
// WithSingleClient returns a client constructor option // WithSingleClient returns a client constructor option
// that specifies single neo-go client and forces Client // that specifies single neo-go client and forces Client
// to use it and only it for requests. // to use it for requests.
// //
// Passed client must already be initialized. // Passed client must already be initialized.
func WithSingleClient(cli *client.Client) Option { func WithSingleClient(cli *client.WSClient) Option {
return func(c *cfg) { return func(c *cfg) {
c.singleCli = cli c.singleCli = cli
} }

View file

@ -1,117 +1,157 @@
package client package client
import ( import (
"sync"
"github.com/nspcc-dev/neo-go/pkg/rpc/client"
"github.com/nspcc-dev/neo-go/pkg/wallet"
"go.uber.org/zap" "go.uber.org/zap"
) )
type multiClient struct { type endpoints struct {
cfg cfg curr int
list []string
account *wallet.Account
sharedNotary *notary // notary config needed for single client construction
endpoints []string
clientsMtx sync.RWMutex
// lastSuccess is an index in endpoints array relating to a last
// used endpoint.
lastSuccess int
clients map[string]*Client
} }
// createForAddress creates single Client instance using provided endpoint. func newEndpoints(ee []string) *endpoints {
func (x *multiClient) createForAddress(addr string) (*Client, error) { return &endpoints{
cli, err := client.New(x.cfg.ctx, addr, client.Options{ curr: 0,
DialTimeout: x.cfg.dialTimeout, list: ee,
MaxConnsPerHost: x.cfg.maxConnPerHost,
})
if err != nil {
return nil, err
} }
err = cli.Init() // magic number is set there based on RPC node answer
if err != nil {
return nil, err
}
var c *Client
x.clientsMtx.Lock()
// While creating 2 clients in parallel is ok, we don't want to
// use a client missing from `x.clients` map as it can lead
// to unexpected bugs.
if x.clients[addr] == nil {
sCli := blankSingleClient(cli, x.account, &x.cfg)
sCli.notary = x.sharedNotary
c = &Client{
cache: newClientCache(),
singleClient: sCli,
}
x.clients[addr] = c
} else {
c = x.clients[addr]
}
x.clientsMtx.Unlock()
return c, nil
} }
// iterateClients executes f on each client until nil error is returned. // next returns the next endpoint and its index
// When nil error is returned, lastSuccess field is updated. // to try to connect to.
// The iteration order is non-deterministic and shouldn't be relied upon. // Returns -1 index if there is no known RPC endpoints.
func (x *multiClient) iterateClients(f func(*Client) error) error { func (e *endpoints) next() (string, int) {
var ( if len(e.list) == 0 {
firstErr error return "", -1
err error }
)
x.clientsMtx.RLock() next := e.curr + 1
start := x.lastSuccess if next == len(e.list) {
x.clientsMtx.RUnlock() next = 0
}
for i := 0; i < len(x.endpoints); i++ { e.curr = next
index := (start + i) % len(x.endpoints)
x.clientsMtx.RLock() return e.list[next], next
c, cached := x.clients[x.endpoints[index]] }
x.clientsMtx.RUnlock()
if !cached { // current returns an endpoint and its index the Client
c, err = x.createForAddress(x.endpoints[index]) // is connected to.
// Returns -1 index if there is no known RPC endpoints
func (e *endpoints) current() (string, int) {
if len(e.list) == 0 {
return "", -1
}
return e.list[e.curr], e.curr
}
func (c *Client) switchRPC() bool {
c.switchLock.Lock()
defer c.switchLock.Unlock()
c.client.Close()
_, currEndpointIndex := c.endpoints.current()
if currEndpointIndex == -1 {
// there are no known RPC endpoints to try
// to connect to => do not switch
return false
}
for {
newEndpoint, index := c.endpoints.next()
if index == currEndpointIndex {
// all the endpoint have been tried
// for connection unsuccessfully
return false
} }
if !cached && err != nil { cli, err := newWSClient(c.cfg, newEndpoint)
x.cfg.logger.Error("could not open morph client connection", if err != nil {
zap.String("endpoint", x.endpoints[index]), c.logger.Warn("could not establish connection to the switched RPC node",
zap.String("err", err.Error()), zap.String("endpoint", newEndpoint),
zap.Error(err),
) )
} else {
err = f(c) continue
} }
if err == nil { err = cli.Init()
if i != 0 { if err != nil {
x.clientsMtx.Lock() cli.Close()
x.lastSuccess = index c.logger.Warn("could not init the switched RPC node",
x.clientsMtx.Unlock() zap.String("endpoint", newEndpoint),
zap.Error(err),
)
continue
}
c.client = cli
return true
}
}
func (c *Client) notificationLoop() {
for {
select {
case <-c.cfg.ctx.Done():
_ = c.UnsubscribeAll()
c.close()
return
case <-c.closeChan:
_ = c.UnsubscribeAll()
c.close()
return
case n, ok := <-c.client.Notifications:
// notification channel is used as a connection
// state: if it is closed, the connection is
// considered to be lost
if !ok {
c.logger.Warn("switching to the next RPC node")
if !c.switchRPC() {
c.logger.Error("could not establish connection to any RPC node")
// could not connect to all endpoints =>
// switch client to inactive mode
c.inactiveMode()
return
}
newEndpoint, _ := c.endpoints.current()
c.logger.Warn("connection to the new RPC node has been established",
zap.String("endpoint", newEndpoint),
)
if !c.restoreSubscriptions() {
// new WS client does not allow
// restoring subscription, client
// could not work correctly =>
// closing connection to RPC node
// to switch to another one
c.client.Close()
}
// TODO(@carpawell): call here some callback retrieved in constructor
// of the client to allow checking chain state since during switch
// process some notification could be lost
continue
} }
return nil
}
// we dont need to continue the process after the logical error was encountered c.notifications <- n
if errNeoFS := unwrapNeoFSError(err); errNeoFS != nil {
return errNeoFS
}
// set first error once
if firstErr == nil {
firstErr = err
} }
} }
}
return firstErr
// close closes notification channel and wrapped WS client
func (c *Client) close() {
close(c.notifications)
c.client.Close()
} }

View file

@ -55,11 +55,11 @@ func NNSAlphabetContractName(index int) string {
// in NNS contract. // in NNS contract.
// If script hash has not been found, returns ErrNNSRecordNotFound. // If script hash has not been found, returns ErrNNSRecordNotFound.
func (c *Client) NNSContractAddress(name string) (sh util.Uint160, err error) { func (c *Client) NNSContractAddress(name string) (sh util.Uint160, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return sh, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
sh, err = c.NNSContractAddress(name)
return err if c.inactive {
}) return util.Uint160{}, ErrConnectionLost
} }
nnsHash, err := c.NNSHash() nnsHash, err := c.NNSHash()
@ -76,13 +76,11 @@ func (c *Client) NNSContractAddress(name string) (sh util.Uint160, err error) {
// NNSHash returns NNS contract hash. // NNSHash returns NNS contract hash.
func (c *Client) NNSHash() (util.Uint160, error) { func (c *Client) NNSHash() (util.Uint160, error) {
if c.multiClient != nil { c.switchLock.RLock()
var sh util.Uint160 defer c.switchLock.RUnlock()
return sh, c.multiClient.iterateClients(func(c *Client) error {
var err error if c.inactive {
sh, err = c.NNSHash() return util.Uint160{}, ErrConnectionLost
return err
})
} }
c.mtx.RLock() c.mtx.RLock()
@ -101,7 +99,7 @@ func (c *Client) NNSHash() (util.Uint160, error) {
return nnsHash, nil return nnsHash, nil
} }
func nnsResolveItem(c *client.Client, nnsHash util.Uint160, domain string) (stackitem.Item, error) { func nnsResolveItem(c *client.WSClient, nnsHash util.Uint160, domain string) (stackitem.Item, error) {
found, err := exists(c, nnsHash, domain) found, err := exists(c, nnsHash, domain)
if err != nil { if err != nil {
return nil, fmt.Errorf("could not check presence in NNS contract for %s: %w", domain, err) return nil, fmt.Errorf("could not check presence in NNS contract for %s: %w", domain, err)
@ -133,7 +131,7 @@ func nnsResolveItem(c *client.Client, nnsHash util.Uint160, domain string) (stac
return result.Stack[0], nil return result.Stack[0], nil
} }
func nnsResolve(c *client.Client, nnsHash util.Uint160, domain string) (util.Uint160, error) { func nnsResolve(c *client.WSClient, nnsHash util.Uint160, domain string) (util.Uint160, error) {
res, err := nnsResolveItem(c, nnsHash, domain) res, err := nnsResolveItem(c, nnsHash, domain)
if err != nil { if err != nil {
return util.Uint160{}, err return util.Uint160{}, err
@ -155,7 +153,7 @@ func nnsResolve(c *client.Client, nnsHash util.Uint160, domain string) (util.Uin
return util.Uint160DecodeStringLE(string(bs)) return util.Uint160DecodeStringLE(string(bs))
} }
func exists(c *client.Client, nnsHash util.Uint160, domain string) (bool, error) { func exists(c *client.WSClient, nnsHash util.Uint160, domain string) (bool, error) {
result, err := c.InvokeFunction(nnsHash, "isAvailable", []smartcontract.Parameter{ result, err := c.InvokeFunction(nnsHash, "isAvailable", []smartcontract.Parameter{
{ {
Type: smartcontract.StringType, Type: smartcontract.StringType,
@ -185,10 +183,11 @@ func exists(c *client.Client, nnsHash util.Uint160, domain string) (bool, error)
// SetGroupSignerScope makes the default signer scope include all NeoFS contracts. // SetGroupSignerScope makes the default signer scope include all NeoFS contracts.
// Should be called for side-chain client only. // Should be called for side-chain client only.
func (c *Client) SetGroupSignerScope() error { func (c *Client) SetGroupSignerScope() error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return wrapNeoFSError(c.SetGroupSignerScope())
}) if c.inactive {
return ErrConnectionLost
} }
pub, err := c.contractGroupKey() pub, err := c.contractGroupKey()

View file

@ -73,6 +73,13 @@ func defaultNotaryConfig(c *Client) *notaryCfg {
// ability for client to get alphabet keys from committee or provided source // ability for client to get alphabet keys from committee or provided source
// and use proxy contract script hash to create tx for notary contract. // and use proxy contract script hash to create tx for notary contract.
func (c *Client) EnableNotarySupport(opts ...NotaryOption) error { func (c *Client) EnableNotarySupport(opts ...NotaryOption) error {
c.switchLock.RLock()
defer c.switchLock.RUnlock()
if c.inactive {
return ErrConnectionLost
}
cfg := defaultNotaryConfig(c) cfg := defaultNotaryConfig(c)
for _, opt := range opts { for _, opt := range opts {
@ -98,56 +105,23 @@ func (c *Client) EnableNotarySupport(opts ...NotaryOption) error {
var err error var err error
getNotaryHashFunc := func(c *Client) error { notaryCfg.notary, err = c.client.GetNativeContractHash(nativenames.Notary)
notaryCfg.notary, err = c.client.GetNativeContractHash(nativenames.Notary) if err != nil {
if err != nil { return fmt.Errorf("can't get notary contract script hash: %w", err)
return fmt.Errorf("can't get notary contract script hash: %w", err)
}
return nil
} }
if c.multiClient == nil { c.notary = notaryCfg
// single client case
err = getNotaryHashFunc(c)
if err != nil {
return err
}
c.notary = notaryCfg
return nil
}
// multi client case
if err = c.iterateClients(getNotaryHashFunc); err != nil {
return err
}
c.clientsMtx.Lock()
c.sharedNotary = notaryCfg
// update client cache
for _, cached := range c.clients {
cached.notary = c.sharedNotary
}
c.clientsMtx.Unlock()
return nil return nil
} }
// ProbeNotary checks if native `Notary` contract is presented on chain. // ProbeNotary checks if native `Notary` contract is presented on chain.
func (c *Client) ProbeNotary() (res bool) { func (c *Client) ProbeNotary() (res bool) {
if c.multiClient != nil { c.switchLock.RLock()
_ = c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res = c.ProbeNotary()
return nil
})
return if c.inactive {
return false
} }
_, err := c.client.GetNativeContractHash(nativenames.Notary) _, err := c.client.GetNativeContractHash(nativenames.Notary)
@ -162,11 +136,11 @@ func (c *Client) ProbeNotary() (res bool) {
// //
// This function must be invoked with notary enabled otherwise it throws panic. // This function must be invoked with notary enabled otherwise it throws panic.
func (c *Client) DepositNotary(amount fixedn.Fixed8, delta uint32) (res util.Uint256, err error) { func (c *Client) DepositNotary(amount fixedn.Fixed8, delta uint32) (res util.Uint256, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.DepositNotary(amount, delta)
return err if c.inactive {
}) return util.Uint256{}, ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {
@ -219,11 +193,11 @@ func (c *Client) DepositNotary(amount fixedn.Fixed8, delta uint32) (res util.Uin
// //
// This function must be invoked with notary enabled otherwise it throws panic. // This function must be invoked with notary enabled otherwise it throws panic.
func (c *Client) GetNotaryDeposit() (res int64, err error) { func (c *Client) GetNotaryDeposit() (res int64, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return res, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
res, err = c.GetNotaryDeposit()
return err if c.inactive {
}) return 0, ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {
@ -271,10 +245,11 @@ func (u *UpdateNotaryListPrm) SetHash(hash util.Uint256) {
// //
// This function must be invoked with notary enabled otherwise it throws panic. // This function must be invoked with notary enabled otherwise it throws panic.
func (c *Client) UpdateNotaryList(prm UpdateNotaryListPrm) error { func (c *Client) UpdateNotaryList(prm UpdateNotaryListPrm) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.UpdateNotaryList(prm)
}) if c.inactive {
return ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {
@ -318,10 +293,11 @@ func (u *UpdateAlphabetListPrm) SetHash(hash util.Uint256) {
// //
// This function must be invoked with notary enabled otherwise it throws panic. // This function must be invoked with notary enabled otherwise it throws panic.
func (c *Client) UpdateNeoFSAlphabetList(prm UpdateAlphabetListPrm) error { func (c *Client) UpdateNeoFSAlphabetList(prm UpdateAlphabetListPrm) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.UpdateNeoFSAlphabetList(prm)
}) if c.inactive {
return ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {
@ -348,10 +324,11 @@ func (c *Client) UpdateNeoFSAlphabetList(prm UpdateAlphabetListPrm) error {
// //
// `nonce` and `vub` are used only if notary is enabled. // `nonce` and `vub` are used only if notary is enabled.
func (c *Client) NotaryInvoke(contract util.Uint160, fee fixedn.Fixed8, nonce uint32, vub *uint32, method string, args ...interface{}) error { func (c *Client) NotaryInvoke(contract util.Uint160, fee fixedn.Fixed8, nonce uint32, vub *uint32, method string, args ...interface{}) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.NotaryInvoke(contract, fee, nonce, vub, method, args...)
}) if c.inactive {
return ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {
@ -367,10 +344,11 @@ func (c *Client) NotaryInvoke(contract util.Uint160, fee fixedn.Fixed8, nonce ui
// //
// Considered to be used by non-IR nodes. // Considered to be used by non-IR nodes.
func (c *Client) NotaryInvokeNotAlpha(contract util.Uint160, fee fixedn.Fixed8, method string, args ...interface{}) error { func (c *Client) NotaryInvokeNotAlpha(contract util.Uint160, fee fixedn.Fixed8, method string, args ...interface{}) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.NotaryInvokeNotAlpha(contract, fee, method, args...)
}) if c.inactive {
return ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {
@ -385,10 +363,11 @@ func (c *Client) NotaryInvokeNotAlpha(contract util.Uint160, fee fixedn.Fixed8,
// NOTE: does not fallback to simple `Invoke()`. Expected to be used only for // NOTE: does not fallback to simple `Invoke()`. Expected to be used only for
// TXs retrieved from the received notary requests. // TXs retrieved from the received notary requests.
func (c *Client) NotarySignAndInvokeTX(mainTx *transaction.Transaction) error { func (c *Client) NotarySignAndInvokeTX(mainTx *transaction.Transaction) error {
if c.multiClient != nil { c.switchLock.RLock()
return c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
return c.NotarySignAndInvokeTX(mainTx)
}) if c.inactive {
return ErrConnectionLost
} }
alphabetList, err := c.notary.alphabetSource() alphabetList, err := c.notary.alphabetSource()
@ -865,11 +844,11 @@ func CalculateNotaryDepositAmount(c *Client, gasMul, gasDiv int64) (fixedn.Fixed
// CalculateNonceAndVUB calculates nonce and ValidUntilBlock values // CalculateNonceAndVUB calculates nonce and ValidUntilBlock values
// based on transaction hash. Uses MurmurHash3. // based on transaction hash. Uses MurmurHash3.
func (c *Client) CalculateNonceAndVUB(hash util.Uint256) (nonce uint32, vub uint32, err error) { func (c *Client) CalculateNonceAndVUB(hash util.Uint256) (nonce uint32, vub uint32, err error) {
if c.multiClient != nil { c.switchLock.RLock()
return nonce, vub, c.multiClient.iterateClients(func(c *Client) error { defer c.switchLock.RUnlock()
nonce, vub, err = c.CalculateNonceAndVUB(hash)
return err if c.inactive {
}) return 0, 0, ErrConnectionLost
} }
if c.notary == nil { if c.notary == nil {

View file

@ -0,0 +1,263 @@
package client
import (
"github.com/nspcc-dev/neo-go/pkg/util"
"go.uber.org/zap"
)
// Close closes connection to the remote side making
// this client instance unusable. Closes notification
// channel returned from Client.NotificationChannel(),
// Removes all subscription.
func (c *Client) Close() {
// closing should be done via the channel
// to prevent switching to another RPC node
// in the notification loop
c.closeChan <- struct{}{}
}
// SubscribeForExecutionNotifications adds subscription for notifications
// generated during contract transaction execution to this instance of client.
//
// Returns ErrConnectionLost if client has not been able to establish
// connection to any of passed RPC endpoints.
func (c *Client) SubscribeForExecutionNotifications(contract util.Uint160) error {
c.switchLock.Lock()
defer c.switchLock.Unlock()
if c.inactive {
return ErrConnectionLost
}
_, subscribed := c.subscribedEvents[contract]
if subscribed {
// no need to subscribe one more time
return nil
}
id, err := c.client.SubscribeForExecutionNotifications(&contract, nil)
if err != nil {
return err
}
c.subscribedEvents[contract] = id
return nil
}
// SubscribeForNewBlocks adds subscription for new block events to this
// instance of client.
//
// Returns ErrConnectionLost if client has not been able to establish
// connection to any of passed RPC endpoints.
func (c *Client) SubscribeForNewBlocks() error {
c.switchLock.Lock()
defer c.switchLock.Unlock()
if c.inactive {
return ErrConnectionLost
}
if c.subscribedToNewBlocks {
// no need to subscribe one more time
return nil
}
_, err := c.client.SubscribeForNewBlocks(nil)
if err != nil {
return err
}
c.subscribedToNewBlocks = true
return nil
}
// SubscribeForNotaryRequests adds subscription for notary request payloads
// addition or removal events to this instance of client. Passed txSigner is
// used as filter: subscription is only for the notary requests that must be
// signed by txSigner.
//
// Returns ErrConnectionLost if client has not been able to establish
// connection to any of passed RPC endpoints.
func (c *Client) SubscribeForNotaryRequests(txSigner util.Uint160) error {
if c.notary == nil {
panic(notaryNotEnabledPanicMsg)
}
c.switchLock.Lock()
defer c.switchLock.Unlock()
if c.inactive {
return ErrConnectionLost
}
_, subscribed := c.subscribedNotaryEvents[txSigner]
if subscribed {
// no need to subscribe one more time
return nil
}
id, err := c.client.SubscribeForNotaryRequests(nil, &txSigner)
if err != nil {
return err
}
c.subscribedNotaryEvents[txSigner] = id
return nil
}
// UnsubscribeContract removes subscription for given contract event stream.
//
// Returns ErrConnectionLost if client has not been able to establish
// connection to any of passed RPC endpoints.
func (c *Client) UnsubscribeContract(contract util.Uint160) error {
c.switchLock.Lock()
defer c.switchLock.Unlock()
if c.inactive {
return ErrConnectionLost
}
_, subscribed := c.subscribedEvents[contract]
if !subscribed {
// no need to unsubscribe contract
// without subscription
return nil
}
err := c.client.Unsubscribe(c.subscribedEvents[contract])
if err != nil {
return err
}
delete(c.subscribedEvents, contract)
return nil
}
// UnsubscribeNotaryRequest removes subscription for given notary requests
// signer.
//
// Returns ErrConnectionLost if client has not been able to establish
// connection to any of passed RPC endpoints.
func (c *Client) UnsubscribeNotaryRequest(signer util.Uint160) error {
if c.notary == nil {
panic(notaryNotEnabledPanicMsg)
}
c.switchLock.Lock()
defer c.switchLock.Unlock()
if c.inactive {
return ErrConnectionLost
}
_, subscribed := c.subscribedNotaryEvents[signer]
if !subscribed {
// no need to unsubscribe signer's
// requests without subscription
return nil
}
err := c.client.Unsubscribe(c.subscribedNotaryEvents[signer])
if err != nil {
return err
}
delete(c.subscribedNotaryEvents, signer)
return nil
}
// UnsubscribeAll removes all active subscriptions of current client.
//
// Returns ErrConnectionLost if client has not been able to establish
// connection to any of passed RPC endpoints.
func (c *Client) UnsubscribeAll() error {
c.switchLock.Lock()
defer c.switchLock.Unlock()
if c.inactive {
return ErrConnectionLost
}
// no need to unsubscribe if there are
// no active subscriptions
if len(c.subscribedEvents) == 0 && len(c.subscribedNotaryEvents) == 0 &&
!c.subscribedToNewBlocks {
return nil
}
err := c.client.UnsubscribeAll()
if err != nil {
return err
}
c.subscribedEvents = make(map[util.Uint160]string)
c.subscribedNotaryEvents = make(map[util.Uint160]string)
c.subscribedToNewBlocks = false
return nil
}
// restoreSubscriptions restores subscriptions according to
// cached information about them.
func (c *Client) restoreSubscriptions() bool {
var (
err error
id string
endpoint, _ = c.endpoints.current()
)
c.switchLock.Lock()
defer c.switchLock.Unlock()
// new block events restoration
if c.subscribedToNewBlocks {
_, err = c.client.SubscribeForNewBlocks(nil)
if err != nil {
c.logger.Error("could not restore block subscription after RPC switch",
zap.String("endpoint", endpoint),
zap.Error(err),
)
return false
}
}
// notification events restoration
for contract := range c.subscribedEvents {
id, err = c.client.SubscribeForExecutionNotifications(&contract, nil)
if err != nil {
c.logger.Error("could not restore notification subscription after RPC switch",
zap.String("endpoint", endpoint),
zap.Error(err),
)
return false
}
c.subscribedEvents[contract] = id
}
// notary notification events restoration
if c.notary != nil {
for signer := range c.subscribedNotaryEvents {
id, err = c.client.SubscribeForNotaryRequests(nil, &signer)
if err != nil {
c.logger.Error("could not restore notary notification subscription after RPC switch",
zap.String("endpoint", endpoint),
zap.Error(err),
)
return false
}
c.subscribedNotaryEvents[signer] = id
}
}
return true
}