forked from TrueCloudLab/neoneo-go
parent
e6f617a43f
commit
c590cc02f4
15 changed files with 333 additions and 101 deletions
111
pkg/network/capability/capability.go
Normal file
111
pkg/network/capability/capability.go
Normal file
|
@ -0,0 +1,111 @@
|
||||||
|
package capability
|
||||||
|
|
||||||
|
import (
|
||||||
|
"errors"
|
||||||
|
|
||||||
|
"github.com/nspcc-dev/neo-go/pkg/io"
|
||||||
|
)
|
||||||
|
|
||||||
|
// MaxCapabilities is the maximum number of capabilities per payload
|
||||||
|
const MaxCapabilities = 32
|
||||||
|
|
||||||
|
// Capabilities is a list of Capability
|
||||||
|
type Capabilities []Capability
|
||||||
|
|
||||||
|
// DecodeBinary implements Serializable interface.
|
||||||
|
func (cs *Capabilities) DecodeBinary(br *io.BinReader) {
|
||||||
|
br.ReadArray(cs, MaxCapabilities)
|
||||||
|
br.Err = cs.checkUniqueCapabilities()
|
||||||
|
}
|
||||||
|
|
||||||
|
// EncodeBinary implements Serializable interface.
|
||||||
|
func (cs *Capabilities) EncodeBinary(br *io.BinWriter) {
|
||||||
|
br.WriteArray(*cs)
|
||||||
|
}
|
||||||
|
|
||||||
|
// checkUniqueCapabilities checks whether payload capabilities have unique type.
|
||||||
|
func (cs Capabilities) checkUniqueCapabilities() error {
|
||||||
|
err := errors.New("capabilities with the same type are not allowed")
|
||||||
|
var isFullNode, isTCP, isWS bool
|
||||||
|
for _, cap := range cs {
|
||||||
|
switch cap.Type {
|
||||||
|
case FullNode:
|
||||||
|
if isFullNode {
|
||||||
|
return err
|
||||||
|
}
|
||||||
|
isFullNode = true
|
||||||
|
case TCPServer:
|
||||||
|
if isTCP {
|
||||||
|
return err
|
||||||
|
}
|
||||||
|
isTCP = true
|
||||||
|
case WSServer:
|
||||||
|
if isWS {
|
||||||
|
return err
|
||||||
|
}
|
||||||
|
isWS = true
|
||||||
|
}
|
||||||
|
}
|
||||||
|
return nil
|
||||||
|
}
|
||||||
|
|
||||||
|
// Capability describes network service available for node
|
||||||
|
type Capability struct {
|
||||||
|
Type Type
|
||||||
|
Data io.Serializable
|
||||||
|
}
|
||||||
|
|
||||||
|
// DecodeBinary implements Serializable interface.
|
||||||
|
func (c *Capability) DecodeBinary(br *io.BinReader) {
|
||||||
|
c.Type = Type(br.ReadB())
|
||||||
|
switch c.Type {
|
||||||
|
case FullNode:
|
||||||
|
c.Data = &Node{}
|
||||||
|
case TCPServer, WSServer:
|
||||||
|
c.Data = &Server{}
|
||||||
|
default:
|
||||||
|
br.Err = errors.New("unknown node capability type")
|
||||||
|
}
|
||||||
|
c.Data.DecodeBinary(br)
|
||||||
|
}
|
||||||
|
|
||||||
|
// EncodeBinary implements Serializable interface.
|
||||||
|
func (c *Capability) EncodeBinary(bw *io.BinWriter) {
|
||||||
|
if c.Data == nil {
|
||||||
|
bw.Err = errors.New("capability has no data")
|
||||||
|
return
|
||||||
|
}
|
||||||
|
bw.WriteB(byte(c.Type))
|
||||||
|
c.Data.EncodeBinary(bw)
|
||||||
|
}
|
||||||
|
|
||||||
|
// Node represents full node capability with start height
|
||||||
|
type Node struct {
|
||||||
|
StartHeight uint32
|
||||||
|
}
|
||||||
|
|
||||||
|
// DecodeBinary implements Serializable interface.
|
||||||
|
func (n *Node) DecodeBinary(br *io.BinReader) {
|
||||||
|
n.StartHeight = br.ReadU32LE()
|
||||||
|
}
|
||||||
|
|
||||||
|
// EncodeBinary implements Serializable interface.
|
||||||
|
func (n *Node) EncodeBinary(bw *io.BinWriter) {
|
||||||
|
bw.WriteU32LE(n.StartHeight)
|
||||||
|
}
|
||||||
|
|
||||||
|
// Server represents TCP or WS server capability with port
|
||||||
|
type Server struct {
|
||||||
|
// Port is the port this server is listening on
|
||||||
|
Port uint16
|
||||||
|
}
|
||||||
|
|
||||||
|
// DecodeBinary implements Serializable interface.
|
||||||
|
func (s *Server) DecodeBinary(br *io.BinReader) {
|
||||||
|
s.Port = br.ReadU16LE()
|
||||||
|
}
|
||||||
|
|
||||||
|
// EncodeBinary implements Serializable interface.
|
||||||
|
func (s *Server) EncodeBinary(bw *io.BinWriter) {
|
||||||
|
bw.WriteU16LE(s.Port)
|
||||||
|
}
|
13
pkg/network/capability/type.go
Normal file
13
pkg/network/capability/type.go
Normal file
|
@ -0,0 +1,13 @@
|
||||||
|
package capability
|
||||||
|
|
||||||
|
// Type represents node capability type
|
||||||
|
type Type byte
|
||||||
|
|
||||||
|
const (
|
||||||
|
// TCPServer represents TCP node capability type
|
||||||
|
TCPServer Type = 0x01
|
||||||
|
// WSServer represents WebSocket node capability type
|
||||||
|
WSServer Type = 0x02
|
||||||
|
// FullNode represents full node capability type
|
||||||
|
FullNode Type = 0x10
|
||||||
|
)
|
|
@ -29,6 +29,9 @@ func (ft *fakeTransp) Accept() {
|
||||||
func (ft *fakeTransp) Proto() string {
|
func (ft *fakeTransp) Proto() string {
|
||||||
return ""
|
return ""
|
||||||
}
|
}
|
||||||
|
func (ft *fakeTransp) Address() string {
|
||||||
|
return ""
|
||||||
|
}
|
||||||
func (ft *fakeTransp) Close() {
|
func (ft *fakeTransp) Close() {
|
||||||
}
|
}
|
||||||
func TestDefaultDiscoverer(t *testing.T) {
|
func TestDefaultDiscoverer(t *testing.T) {
|
||||||
|
|
|
@ -3,9 +3,9 @@ package network
|
||||||
import (
|
import (
|
||||||
"math/rand"
|
"math/rand"
|
||||||
"net"
|
"net"
|
||||||
|
"strconv"
|
||||||
"sync/atomic"
|
"sync/atomic"
|
||||||
"testing"
|
"testing"
|
||||||
"time"
|
|
||||||
|
|
||||||
"github.com/nspcc-dev/neo-go/pkg/config"
|
"github.com/nspcc-dev/neo-go/pkg/config"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/core/block"
|
"github.com/nspcc-dev/neo-go/pkg/core/block"
|
||||||
|
@ -163,15 +163,6 @@ func (d testDiscovery) RequestRemote(n int) {}
|
||||||
func (d testDiscovery) BadPeers() []string { return []string{} }
|
func (d testDiscovery) BadPeers() []string { return []string{} }
|
||||||
func (d testDiscovery) GoodPeers() []string { return []string{} }
|
func (d testDiscovery) GoodPeers() []string { return []string{} }
|
||||||
|
|
||||||
type localTransport struct{}
|
|
||||||
|
|
||||||
func (t localTransport) Dial(addr string, timeout time.Duration) error {
|
|
||||||
return nil
|
|
||||||
}
|
|
||||||
func (t localTransport) Accept() {}
|
|
||||||
func (t localTransport) Proto() string { return "local" }
|
|
||||||
func (t localTransport) Close() {}
|
|
||||||
|
|
||||||
var defaultMessageHandler = func(t *testing.T, msg *Message) {}
|
var defaultMessageHandler = func(t *testing.T, msg *Message) {}
|
||||||
|
|
||||||
type localPeer struct {
|
type localPeer struct {
|
||||||
|
@ -180,6 +171,7 @@ type localPeer struct {
|
||||||
version *payload.Version
|
version *payload.Version
|
||||||
lastBlockIndex uint32
|
lastBlockIndex uint32
|
||||||
handshaked bool
|
handshaked bool
|
||||||
|
isFullNode bool
|
||||||
t *testing.T
|
t *testing.T
|
||||||
messageHandler func(t *testing.T, msg *Message)
|
messageHandler func(t *testing.T, msg *Message)
|
||||||
pingSent int
|
pingSent int
|
||||||
|
@ -240,7 +232,10 @@ func (p *localPeer) HandleVersion(v *payload.Version) error {
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
func (p *localPeer) SendVersion() error {
|
func (p *localPeer) SendVersion() error {
|
||||||
m := p.server.getVersionMsg()
|
m, err := p.server.getVersionMsg()
|
||||||
|
if err != nil {
|
||||||
|
return err
|
||||||
|
}
|
||||||
_ = p.EnqueueMessage(m)
|
_ = p.EnqueueMessage(m)
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
@ -267,11 +262,14 @@ func (p *localPeer) Handshaked() bool {
|
||||||
return p.handshaked
|
return p.handshaked
|
||||||
}
|
}
|
||||||
|
|
||||||
func newTestServer(t *testing.T) *Server {
|
func (p *localPeer) IsFullNode() bool {
|
||||||
return &Server{
|
return p.isFullNode
|
||||||
ServerConfig: ServerConfig{},
|
}
|
||||||
|
|
||||||
|
func newTestServer(t *testing.T, serverConfig ServerConfig) *Server {
|
||||||
|
s := &Server{
|
||||||
|
ServerConfig: serverConfig,
|
||||||
chain: &testChain{},
|
chain: &testChain{},
|
||||||
transport: localTransport{},
|
|
||||||
discovery: testDiscovery{},
|
discovery: testDiscovery{},
|
||||||
id: rand.Uint32(),
|
id: rand.Uint32(),
|
||||||
quit: make(chan struct{}),
|
quit: make(chan struct{}),
|
||||||
|
@ -280,5 +278,6 @@ func newTestServer(t *testing.T) *Server {
|
||||||
peers: make(map[Peer]bool),
|
peers: make(map[Peer]bool),
|
||||||
log: zaptest.NewLogger(t),
|
log: zaptest.NewLogger(t),
|
||||||
}
|
}
|
||||||
|
s.transport = NewTCPTransport(s, net.JoinHostPort(s.ServerConfig.Address, strconv.Itoa(int(s.ServerConfig.Port))), s.log)
|
||||||
|
return s
|
||||||
}
|
}
|
||||||
|
|
|
@ -5,19 +5,7 @@ import (
|
||||||
|
|
||||||
"github.com/nspcc-dev/neo-go/pkg/config"
|
"github.com/nspcc-dev/neo-go/pkg/config"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/io"
|
"github.com/nspcc-dev/neo-go/pkg/io"
|
||||||
)
|
"github.com/nspcc-dev/neo-go/pkg/network/capability"
|
||||||
|
|
||||||
// Size of the payload not counting UserAgent encoding (which is at least 1 byte
|
|
||||||
// for zero-length string).
|
|
||||||
const minVersionSize = 27
|
|
||||||
|
|
||||||
// List of Services offered by the node.
|
|
||||||
const (
|
|
||||||
nodePeerService uint64 = 1
|
|
||||||
// BloomFilerService uint64 = 2 // Not implemented
|
|
||||||
// PrunedNode uint64 = 3 // Not implemented
|
|
||||||
// LightNode uint64 = 4 // Not implemented
|
|
||||||
|
|
||||||
)
|
)
|
||||||
|
|
||||||
// Version payload.
|
// Version payload.
|
||||||
|
@ -26,34 +14,25 @@ type Version struct {
|
||||||
Magic config.NetMode
|
Magic config.NetMode
|
||||||
// currently the version of the protocol is 0
|
// currently the version of the protocol is 0
|
||||||
Version uint32
|
Version uint32
|
||||||
// currently 1
|
|
||||||
Services uint64
|
|
||||||
// timestamp
|
// timestamp
|
||||||
Timestamp uint32
|
Timestamp uint32
|
||||||
// port this server is listening on
|
|
||||||
Port uint16
|
|
||||||
// it's used to distinguish the node from public IP
|
// it's used to distinguish the node from public IP
|
||||||
Nonce uint32
|
Nonce uint32
|
||||||
// client id
|
// client id
|
||||||
UserAgent []byte
|
UserAgent []byte
|
||||||
// Height of the block chain
|
// List of available network services
|
||||||
StartHeight uint32
|
Capabilities capability.Capabilities
|
||||||
// Whether to receive and forward
|
|
||||||
Relay bool
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// NewVersion returns a pointer to a Version payload.
|
// NewVersion returns a pointer to a Version payload.
|
||||||
func NewVersion(magic config.NetMode, id uint32, p uint16, ua string, h uint32, r bool) *Version {
|
func NewVersion(magic config.NetMode, id uint32, ua string, c []capability.Capability) *Version {
|
||||||
return &Version{
|
return &Version{
|
||||||
Magic: magic,
|
Magic: magic,
|
||||||
Version: 0,
|
Version: 0,
|
||||||
Services: nodePeerService,
|
|
||||||
Timestamp: uint32(time.Now().UTC().Unix()),
|
Timestamp: uint32(time.Now().UTC().Unix()),
|
||||||
Port: p,
|
|
||||||
Nonce: id,
|
Nonce: id,
|
||||||
UserAgent: []byte(ua),
|
UserAgent: []byte(ua),
|
||||||
StartHeight: h,
|
Capabilities: c,
|
||||||
Relay: r,
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -61,25 +40,18 @@ func NewVersion(magic config.NetMode, id uint32, p uint16, ua string, h uint32,
|
||||||
func (p *Version) DecodeBinary(br *io.BinReader) {
|
func (p *Version) DecodeBinary(br *io.BinReader) {
|
||||||
p.Magic = config.NetMode(br.ReadU32LE())
|
p.Magic = config.NetMode(br.ReadU32LE())
|
||||||
p.Version = br.ReadU32LE()
|
p.Version = br.ReadU32LE()
|
||||||
p.Services = br.ReadU64LE()
|
|
||||||
p.Timestamp = br.ReadU32LE()
|
p.Timestamp = br.ReadU32LE()
|
||||||
p.Port = br.ReadU16LE()
|
|
||||||
p.Nonce = br.ReadU32LE()
|
p.Nonce = br.ReadU32LE()
|
||||||
p.UserAgent = br.ReadVarBytes()
|
p.UserAgent = br.ReadVarBytes()
|
||||||
p.StartHeight = br.ReadU32LE()
|
p.Capabilities.DecodeBinary(br)
|
||||||
p.Relay = br.ReadBool()
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// EncodeBinary implements Serializable interface.
|
// EncodeBinary implements Serializable interface.
|
||||||
func (p *Version) EncodeBinary(br *io.BinWriter) {
|
func (p *Version) EncodeBinary(bw *io.BinWriter) {
|
||||||
br.WriteU32LE(uint32(p.Magic))
|
bw.WriteU32LE(uint32(p.Magic))
|
||||||
br.WriteU32LE(p.Version)
|
bw.WriteU32LE(p.Version)
|
||||||
br.WriteU64LE(p.Services)
|
bw.WriteU32LE(p.Timestamp)
|
||||||
br.WriteU32LE(p.Timestamp)
|
bw.WriteU32LE(p.Nonce)
|
||||||
br.WriteU16LE(p.Port)
|
bw.WriteVarBytes(p.UserAgent)
|
||||||
br.WriteU32LE(p.Nonce)
|
p.Capabilities.EncodeBinary(bw)
|
||||||
|
|
||||||
br.WriteVarBytes(p.UserAgent)
|
|
||||||
br.WriteU32LE(p.StartHeight)
|
|
||||||
br.WriteBool(p.Relay)
|
|
||||||
}
|
}
|
||||||
|
|
|
@ -5,25 +5,44 @@ import (
|
||||||
|
|
||||||
"github.com/nspcc-dev/neo-go/pkg/config"
|
"github.com/nspcc-dev/neo-go/pkg/config"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/internal/testserdes"
|
"github.com/nspcc-dev/neo-go/pkg/internal/testserdes"
|
||||||
|
"github.com/nspcc-dev/neo-go/pkg/network/capability"
|
||||||
"github.com/stretchr/testify/assert"
|
"github.com/stretchr/testify/assert"
|
||||||
)
|
)
|
||||||
|
|
||||||
func TestVersionEncodeDecode(t *testing.T) {
|
func TestVersionEncodeDecode(t *testing.T) {
|
||||||
var magic config.NetMode = 56753
|
var magic config.NetMode = 56753
|
||||||
var port uint16 = 3000
|
var tcpPort uint16 = 3000
|
||||||
|
var wsPort uint16 = 3001
|
||||||
var id uint32 = 13337
|
var id uint32 = 13337
|
||||||
useragent := "/NEO:0.0.1/"
|
useragent := "/NEO:0.0.1/"
|
||||||
var height uint32 = 100500
|
var height uint32 = 100500
|
||||||
var relay = true
|
var capabilities = []capability.Capability{
|
||||||
|
{
|
||||||
|
Type: capability.TCPServer,
|
||||||
|
Data: &capability.Server{
|
||||||
|
Port: tcpPort,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
{
|
||||||
|
Type: capability.WSServer,
|
||||||
|
Data: &capability.Server{
|
||||||
|
Port: wsPort,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
{
|
||||||
|
Type: capability.FullNode,
|
||||||
|
Data: &capability.Node{
|
||||||
|
StartHeight: height,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
}
|
||||||
|
|
||||||
version := NewVersion(magic, id, port, useragent, height, relay)
|
version := NewVersion(magic, id, useragent, capabilities)
|
||||||
versionDecoded := &Version{}
|
versionDecoded := &Version{}
|
||||||
testserdes.EncodeDecodeBinary(t, version, versionDecoded)
|
testserdes.EncodeDecodeBinary(t, version, versionDecoded)
|
||||||
|
|
||||||
assert.Equal(t, versionDecoded.Nonce, id)
|
assert.Equal(t, versionDecoded.Nonce, id)
|
||||||
assert.Equal(t, versionDecoded.Port, port)
|
assert.ElementsMatch(t, capabilities, versionDecoded.Capabilities)
|
||||||
assert.Equal(t, versionDecoded.UserAgent, []byte(useragent))
|
assert.Equal(t, versionDecoded.UserAgent, []byte(useragent))
|
||||||
assert.Equal(t, versionDecoded.StartHeight, height)
|
|
||||||
assert.Equal(t, versionDecoded.Relay, relay)
|
|
||||||
assert.Equal(t, version, versionDecoded)
|
assert.Equal(t, version, versionDecoded)
|
||||||
}
|
}
|
||||||
|
|
|
@ -51,6 +51,7 @@ type Peer interface {
|
||||||
Version() *payload.Version
|
Version() *payload.Version
|
||||||
LastBlockIndex() uint32
|
LastBlockIndex() uint32
|
||||||
Handshaked() bool
|
Handshaked() bool
|
||||||
|
IsFullNode() bool
|
||||||
|
|
||||||
// SendPing enqueues a ping message to be sent to the peer and does
|
// SendPing enqueues a ping message to be sent to the peer and does
|
||||||
// appropriate protocol handling like timeouts and outstanding pings
|
// appropriate protocol handling like timeouts and outstanding pings
|
||||||
|
|
|
@ -15,6 +15,7 @@ import (
|
||||||
"github.com/nspcc-dev/neo-go/pkg/core/block"
|
"github.com/nspcc-dev/neo-go/pkg/core/block"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/core/blockchainer"
|
"github.com/nspcc-dev/neo-go/pkg/core/blockchainer"
|
||||||
"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/network/capability"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/network/payload"
|
"github.com/nspcc-dev/neo-go/pkg/network/payload"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/util"
|
"github.com/nspcc-dev/neo-go/pkg/util"
|
||||||
"go.uber.org/atomic"
|
"go.uber.org/atomic"
|
||||||
|
@ -346,16 +347,42 @@ func (s *Server) HandshakedPeersCount() int {
|
||||||
}
|
}
|
||||||
|
|
||||||
// getVersionMsg returns current version message.
|
// getVersionMsg returns current version message.
|
||||||
func (s *Server) getVersionMsg() *Message {
|
func (s *Server) getVersionMsg() (*Message, error) {
|
||||||
|
var port uint16
|
||||||
|
_, portStr, err := net.SplitHostPort(s.transport.Address())
|
||||||
|
if err != nil {
|
||||||
|
port = s.Port
|
||||||
|
} else {
|
||||||
|
p, err := strconv.ParseUint(portStr, 10, 16)
|
||||||
|
if err != nil {
|
||||||
|
return nil, err
|
||||||
|
}
|
||||||
|
port = uint16(p)
|
||||||
|
}
|
||||||
|
|
||||||
|
capabilities := []capability.Capability{
|
||||||
|
{
|
||||||
|
Type: capability.TCPServer,
|
||||||
|
Data: &capability.Server{
|
||||||
|
Port: port,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
}
|
||||||
|
if s.Relay {
|
||||||
|
capabilities = append(capabilities, capability.Capability{
|
||||||
|
Type: capability.FullNode,
|
||||||
|
Data: &capability.Node{
|
||||||
|
StartHeight: s.chain.BlockHeight(),
|
||||||
|
},
|
||||||
|
})
|
||||||
|
}
|
||||||
payload := payload.NewVersion(
|
payload := payload.NewVersion(
|
||||||
s.Net,
|
s.Net,
|
||||||
s.id,
|
s.id,
|
||||||
s.Port,
|
|
||||||
s.UserAgent,
|
s.UserAgent,
|
||||||
s.chain.BlockHeight(),
|
capabilities,
|
||||||
s.Relay,
|
|
||||||
)
|
)
|
||||||
return NewMessage(CMDVersion, payload)
|
return NewMessage(CMDVersion, payload), nil
|
||||||
}
|
}
|
||||||
|
|
||||||
// IsInSync answers the question of whether the server is in sync with the
|
// IsInSync answers the question of whether the server is in sync with the
|
||||||
|
@ -835,9 +862,7 @@ func (s *Server) broadcastTxHashes(hs []util.Uint256) {
|
||||||
|
|
||||||
// We need to filter out non-relaying nodes, so plain broadcast
|
// We need to filter out non-relaying nodes, so plain broadcast
|
||||||
// functions don't fit here.
|
// functions don't fit here.
|
||||||
s.iteratePeersWithSendMsg(msg, Peer.EnqueuePacket, func(p Peer) bool {
|
s.iteratePeersWithSendMsg(msg, Peer.EnqueuePacket, Peer.IsFullNode)
|
||||||
return p.Handshaked() && p.Version().Relay
|
|
||||||
})
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// broadcastTxLoop is a loop for batching and sending
|
// broadcastTxLoop is a loop for batching and sending
|
||||||
|
|
|
@ -2,8 +2,11 @@ package network
|
||||||
|
|
||||||
import (
|
import (
|
||||||
"net"
|
"net"
|
||||||
|
"strconv"
|
||||||
"testing"
|
"testing"
|
||||||
|
"time"
|
||||||
|
|
||||||
|
"github.com/nspcc-dev/neo-go/pkg/network/capability"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/network/payload"
|
"github.com/nspcc-dev/neo-go/pkg/network/payload"
|
||||||
"github.com/stretchr/testify/assert"
|
"github.com/stretchr/testify/assert"
|
||||||
"github.com/stretchr/testify/require"
|
"github.com/stretchr/testify/require"
|
||||||
|
@ -11,22 +14,33 @@ import (
|
||||||
|
|
||||||
func TestSendVersion(t *testing.T) {
|
func TestSendVersion(t *testing.T) {
|
||||||
var (
|
var (
|
||||||
s = newTestServer(t)
|
s = newTestServer(t, ServerConfig{Port: 0, UserAgent: "/test/"})
|
||||||
p = newLocalPeer(t, s)
|
p = newLocalPeer(t, s)
|
||||||
)
|
)
|
||||||
s.Port = 3000
|
// we need to set listener at least to handle dynamic port correctly
|
||||||
s.UserAgent = "/test/"
|
go s.transport.Accept()
|
||||||
|
require.Eventually(t, func() bool { return s.transport.Address() != "" }, time.Second, 10*time.Millisecond)
|
||||||
p.messageHandler = func(t *testing.T, msg *Message) {
|
p.messageHandler = func(t *testing.T, msg *Message) {
|
||||||
|
// listener is already set, so Address() gives us proper address with port
|
||||||
|
_, p, err := net.SplitHostPort(s.transport.Address())
|
||||||
|
assert.NoError(t, err)
|
||||||
|
port, err := strconv.ParseUint(p, 10, 16)
|
||||||
|
assert.NoError(t, err)
|
||||||
assert.Equal(t, CMDVersion, msg.Command)
|
assert.Equal(t, CMDVersion, msg.Command)
|
||||||
assert.IsType(t, msg.Payload, &payload.Version{})
|
assert.IsType(t, msg.Payload, &payload.Version{})
|
||||||
version := msg.Payload.(*payload.Version)
|
version := msg.Payload.(*payload.Version)
|
||||||
assert.NotZero(t, version.Nonce)
|
assert.NotZero(t, version.Nonce)
|
||||||
assert.Equal(t, uint16(3000), version.Port)
|
assert.Equal(t, 1, len(version.Capabilities))
|
||||||
assert.Equal(t, uint64(1), version.Services)
|
assert.ElementsMatch(t, []capability.Capability{
|
||||||
|
{
|
||||||
|
Type: capability.TCPServer,
|
||||||
|
Data: &capability.Server{
|
||||||
|
Port: uint16(port),
|
||||||
|
},
|
||||||
|
},
|
||||||
|
}, version.Capabilities)
|
||||||
assert.Equal(t, uint32(0), version.Version)
|
assert.Equal(t, uint32(0), version.Version)
|
||||||
assert.Equal(t, []byte("/test/"), version.UserAgent)
|
assert.Equal(t, []byte("/test/"), version.UserAgent)
|
||||||
assert.Equal(t, uint32(0), version.StartHeight)
|
|
||||||
}
|
}
|
||||||
|
|
||||||
require.NoError(t, p.SendVersion())
|
require.NoError(t, p.SendVersion())
|
||||||
|
@ -35,7 +49,7 @@ func TestSendVersion(t *testing.T) {
|
||||||
// Server should reply with a verack after receiving a valid version.
|
// Server should reply with a verack after receiving a valid version.
|
||||||
func TestVerackAfterHandleVersionCmd(t *testing.T) {
|
func TestVerackAfterHandleVersionCmd(t *testing.T) {
|
||||||
var (
|
var (
|
||||||
s = newTestServer(t)
|
s = newTestServer(t, ServerConfig{})
|
||||||
p = newLocalPeer(t, s)
|
p = newLocalPeer(t, s)
|
||||||
)
|
)
|
||||||
na, _ := net.ResolveTCPAddr("tcp", "0.0.0.0:3000")
|
na, _ := net.ResolveTCPAddr("tcp", "0.0.0.0:3000")
|
||||||
|
@ -45,7 +59,21 @@ func TestVerackAfterHandleVersionCmd(t *testing.T) {
|
||||||
p.messageHandler = func(t *testing.T, msg *Message) {
|
p.messageHandler = func(t *testing.T, msg *Message) {
|
||||||
assert.Equal(t, CMDVerack, msg.Command)
|
assert.Equal(t, CMDVerack, msg.Command)
|
||||||
}
|
}
|
||||||
version := payload.NewVersion(0, 1337, 3000, "/NEO-GO/", 0, true)
|
capabilities := []capability.Capability{
|
||||||
|
{
|
||||||
|
Type: capability.FullNode,
|
||||||
|
Data: &capability.Node{
|
||||||
|
StartHeight: 0,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
{
|
||||||
|
Type: capability.TCPServer,
|
||||||
|
Data: &capability.Server{
|
||||||
|
Port: 3000,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
}
|
||||||
|
version := payload.NewVersion(0, 1337, "/NEO-GO/", capabilities)
|
||||||
|
|
||||||
require.NoError(t, s.handleVersionCmd(p, version))
|
require.NoError(t, s.handleVersionCmd(p, version))
|
||||||
}
|
}
|
||||||
|
@ -54,12 +82,11 @@ func TestVerackAfterHandleVersionCmd(t *testing.T) {
|
||||||
// invalid version and disconnects the peer.
|
// invalid version and disconnects the peer.
|
||||||
func TestServerNotSendsVerack(t *testing.T) {
|
func TestServerNotSendsVerack(t *testing.T) {
|
||||||
var (
|
var (
|
||||||
s = newTestServer(t)
|
s = newTestServer(t, ServerConfig{Net: 56753})
|
||||||
p = newLocalPeer(t, s)
|
p = newLocalPeer(t, s)
|
||||||
p2 = newLocalPeer(t, s)
|
p2 = newLocalPeer(t, s)
|
||||||
)
|
)
|
||||||
s.id = 1
|
s.id = 1
|
||||||
s.Net = 56753
|
|
||||||
finished := make(chan struct{})
|
finished := make(chan struct{})
|
||||||
go func() {
|
go func() {
|
||||||
s.run()
|
s.run()
|
||||||
|
@ -76,8 +103,22 @@ func TestServerNotSendsVerack(t *testing.T) {
|
||||||
p2.netaddr = *na
|
p2.netaddr = *na
|
||||||
s.register <- p
|
s.register <- p
|
||||||
|
|
||||||
|
capabilities := []capability.Capability{
|
||||||
|
{
|
||||||
|
Type: capability.FullNode,
|
||||||
|
Data: &capability.Node{
|
||||||
|
StartHeight: 0,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
{
|
||||||
|
Type: capability.TCPServer,
|
||||||
|
Data: &capability.Server{
|
||||||
|
Port: 3000,
|
||||||
|
},
|
||||||
|
},
|
||||||
|
}
|
||||||
// identical id's
|
// identical id's
|
||||||
version := payload.NewVersion(56753, 1, 3000, "/NEO-GO/", 0, true)
|
version := payload.NewVersion(56753, 1, "/NEO-GO/", capabilities)
|
||||||
err := s.handleVersionCmd(p, version)
|
err := s.handleVersionCmd(p, version)
|
||||||
assert.NotNil(t, err)
|
assert.NotNil(t, err)
|
||||||
assert.Equal(t, errIdenticalID, err)
|
assert.Equal(t, errIdenticalID, err)
|
||||||
|
@ -104,7 +145,7 @@ func TestServerNotSendsVerack(t *testing.T) {
|
||||||
|
|
||||||
func TestRequestHeaders(t *testing.T) {
|
func TestRequestHeaders(t *testing.T) {
|
||||||
var (
|
var (
|
||||||
s = newTestServer(t)
|
s = newTestServer(t, ServerConfig{})
|
||||||
p = newLocalPeer(t, s)
|
p = newLocalPeer(t, s)
|
||||||
)
|
)
|
||||||
p.messageHandler = func(t *testing.T, msg *Message) {
|
p.messageHandler = func(t *testing.T, msg *Message) {
|
||||||
|
|
|
@ -9,6 +9,7 @@ import (
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
"github.com/nspcc-dev/neo-go/pkg/io"
|
"github.com/nspcc-dev/neo-go/pkg/io"
|
||||||
|
"github.com/nspcc-dev/neo-go/pkg/network/capability"
|
||||||
"github.com/nspcc-dev/neo-go/pkg/network/payload"
|
"github.com/nspcc-dev/neo-go/pkg/network/payload"
|
||||||
"go.uber.org/zap"
|
"go.uber.org/zap"
|
||||||
)
|
)
|
||||||
|
@ -48,6 +49,7 @@ type TCPPeer struct {
|
||||||
lock sync.RWMutex
|
lock sync.RWMutex
|
||||||
finale sync.Once
|
finale sync.Once
|
||||||
handShake handShakeStage
|
handShake handShakeStage
|
||||||
|
isFullNode bool
|
||||||
|
|
||||||
done chan struct{}
|
done chan struct{}
|
||||||
sendQ chan []byte
|
sendQ chan []byte
|
||||||
|
@ -229,7 +231,7 @@ func (p *TCPPeer) StartProtocol() {
|
||||||
p.server.log.Info("started protocol",
|
p.server.log.Info("started protocol",
|
||||||
zap.Stringer("addr", p.RemoteAddr()),
|
zap.Stringer("addr", p.RemoteAddr()),
|
||||||
zap.ByteString("userAgent", p.Version().UserAgent),
|
zap.ByteString("userAgent", p.Version().UserAgent),
|
||||||
zap.Uint32("startHeight", p.Version().StartHeight),
|
zap.Uint32("startHeight", p.lastBlockIndex),
|
||||||
zap.Uint32("id", p.Version().Nonce))
|
zap.Uint32("id", p.Version().Nonce))
|
||||||
|
|
||||||
p.server.discovery.RegisterGoodAddr(p.PeerAddr().String())
|
p.server.discovery.RegisterGoodAddr(p.PeerAddr().String())
|
||||||
|
@ -267,18 +269,33 @@ func (p *TCPPeer) StartProtocol() {
|
||||||
func (p *TCPPeer) Handshaked() bool {
|
func (p *TCPPeer) Handshaked() bool {
|
||||||
p.lock.RLock()
|
p.lock.RLock()
|
||||||
defer p.lock.RUnlock()
|
defer p.lock.RUnlock()
|
||||||
|
return p.handshaked()
|
||||||
|
}
|
||||||
|
|
||||||
|
// handshaked is internal unlocked version of Handshaked().
|
||||||
|
func (p *TCPPeer) handshaked() bool {
|
||||||
return p.handShake == (verAckReceived | verAckSent | versionReceived | versionSent)
|
return p.handShake == (verAckReceived | verAckSent | versionReceived | versionSent)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
// IsFullNode returns whether the node has full capability or TCP/WS only.
|
||||||
|
func (p *TCPPeer) IsFullNode() bool {
|
||||||
|
p.lock.RLock()
|
||||||
|
defer p.lock.RUnlock()
|
||||||
|
return p.handshaked() && p.isFullNode
|
||||||
|
}
|
||||||
|
|
||||||
// SendVersion checks for the handshake state and sends a message to the peer.
|
// SendVersion checks for the handshake state and sends a message to the peer.
|
||||||
func (p *TCPPeer) SendVersion() error {
|
func (p *TCPPeer) SendVersion() error {
|
||||||
msg := p.server.getVersionMsg()
|
msg, err := p.server.getVersionMsg()
|
||||||
|
if err != nil {
|
||||||
|
return err
|
||||||
|
}
|
||||||
p.lock.Lock()
|
p.lock.Lock()
|
||||||
defer p.lock.Unlock()
|
defer p.lock.Unlock()
|
||||||
if p.handShake&versionSent != 0 {
|
if p.handShake&versionSent != 0 {
|
||||||
return errors.New("invalid handshake: already sent Version")
|
return errors.New("invalid handshake: already sent Version")
|
||||||
}
|
}
|
||||||
err := p.writeMsg(msg)
|
err = p.writeMsg(msg)
|
||||||
if err == nil {
|
if err == nil {
|
||||||
p.handShake |= versionSent
|
p.handShake |= versionSent
|
||||||
}
|
}
|
||||||
|
@ -293,7 +310,14 @@ func (p *TCPPeer) HandleVersion(version *payload.Version) error {
|
||||||
return errors.New("invalid handshake: already received Version")
|
return errors.New("invalid handshake: already received Version")
|
||||||
}
|
}
|
||||||
p.version = version
|
p.version = version
|
||||||
p.lastBlockIndex = version.StartHeight
|
for _, cap := range version.Capabilities {
|
||||||
|
if cap.Type == capability.FullNode {
|
||||||
|
p.isFullNode = true
|
||||||
|
p.lastBlockIndex = cap.Data.(*capability.Node).StartHeight
|
||||||
|
break
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
p.handShake |= versionReceived
|
p.handShake |= versionReceived
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
@ -352,7 +376,16 @@ func (p *TCPPeer) PeerAddr() net.Addr {
|
||||||
if err != nil {
|
if err != nil {
|
||||||
return p.RemoteAddr()
|
return p.RemoteAddr()
|
||||||
}
|
}
|
||||||
addrString := net.JoinHostPort(host, strconv.Itoa(int(p.version.Port)))
|
var port uint16
|
||||||
|
for _, cap := range p.version.Capabilities {
|
||||||
|
if cap.Type == capability.TCPServer {
|
||||||
|
port = cap.Data.(*capability.Server).Port
|
||||||
|
}
|
||||||
|
}
|
||||||
|
if port == 0 {
|
||||||
|
return p.RemoteAddr()
|
||||||
|
}
|
||||||
|
addrString := net.JoinHostPort(host, strconv.Itoa(int(port)))
|
||||||
tcpAddr, err := net.ResolveTCPAddr("tcp", addrString)
|
tcpAddr, err := net.ResolveTCPAddr("tcp", addrString)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
return p.RemoteAddr()
|
return p.RemoteAddr()
|
||||||
|
|
|
@ -18,8 +18,8 @@ func connReadStub(conn net.Conn) {
|
||||||
func TestPeerHandshake(t *testing.T) {
|
func TestPeerHandshake(t *testing.T) {
|
||||||
server, client := net.Pipe()
|
server, client := net.Pipe()
|
||||||
|
|
||||||
tcpS := NewTCPPeer(server, newTestServer(t))
|
tcpS := NewTCPPeer(server, newTestServer(t, ServerConfig{}))
|
||||||
tcpC := NewTCPPeer(client, newTestServer(t))
|
tcpC := NewTCPPeer(client, newTestServer(t, ServerConfig{}))
|
||||||
|
|
||||||
// Something should read things written into the pipe.
|
// Something should read things written into the pipe.
|
||||||
go connReadStub(tcpS.conn)
|
go connReadStub(tcpS.conn)
|
||||||
|
|
|
@ -3,6 +3,7 @@ package network
|
||||||
import (
|
import (
|
||||||
"net"
|
"net"
|
||||||
"regexp"
|
"regexp"
|
||||||
|
"sync"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
"go.uber.org/zap"
|
"go.uber.org/zap"
|
||||||
|
@ -14,6 +15,7 @@ type TCPTransport struct {
|
||||||
server *Server
|
server *Server
|
||||||
listener net.Listener
|
listener net.Listener
|
||||||
bindAddr string
|
bindAddr string
|
||||||
|
lock sync.RWMutex
|
||||||
}
|
}
|
||||||
|
|
||||||
var reClosedNetwork = regexp.MustCompile(".* use of closed network connection")
|
var reClosedNetwork = regexp.MustCompile(".* use of closed network connection")
|
||||||
|
@ -47,7 +49,9 @@ func (t *TCPTransport) Accept() {
|
||||||
return
|
return
|
||||||
}
|
}
|
||||||
|
|
||||||
|
t.lock.Lock()
|
||||||
t.listener = l
|
t.listener = l
|
||||||
|
t.lock.Unlock()
|
||||||
|
|
||||||
for {
|
for {
|
||||||
conn, err := l.Accept()
|
conn, err := l.Accept()
|
||||||
|
@ -84,3 +88,13 @@ func (t *TCPTransport) Close() {
|
||||||
func (t *TCPTransport) Proto() string {
|
func (t *TCPTransport) Proto() string {
|
||||||
return "tcp"
|
return "tcp"
|
||||||
}
|
}
|
||||||
|
|
||||||
|
// Address implements the Transporter interface.
|
||||||
|
func (t *TCPTransport) Address() string {
|
||||||
|
t.lock.RLock()
|
||||||
|
defer t.lock.RUnlock()
|
||||||
|
if t.listener != nil {
|
||||||
|
return t.listener.Addr().String()
|
||||||
|
}
|
||||||
|
return ""
|
||||||
|
}
|
||||||
|
|
|
@ -8,5 +8,6 @@ type Transporter interface {
|
||||||
Dial(addr string, timeout time.Duration) error
|
Dial(addr string, timeout time.Duration) error
|
||||||
Accept()
|
Accept()
|
||||||
Proto() string
|
Proto() string
|
||||||
|
Address() string
|
||||||
Close()
|
Close()
|
||||||
}
|
}
|
||||||
|
|
|
@ -894,7 +894,7 @@ var rpcClientTestCases = map[string][]rpcClientTestCase{
|
||||||
invoke: func(c *Client) (interface{}, error) {
|
invoke: func(c *Client) (interface{}, error) {
|
||||||
return c.GetVersion()
|
return c.GetVersion()
|
||||||
},
|
},
|
||||||
serverResponse: `{"id":1,"jsonrpc":"2.0","result":{"port":20332,"nonce":2153672787,"useragent":"/NEO-GO:0.73.1-pre-273-ge381358/"}}`,
|
serverResponse: `{"id":1,"jsonrpc":"2.0","result":{"tcp_port":20332,"nonce":2153672787,"useragent":"/NEO-GO:0.73.1-pre-273-ge381358/"}}`,
|
||||||
result: func(c *Client) interface{} {
|
result: func(c *Client) interface{} {
|
||||||
return &result.Version{
|
return &result.Version{
|
||||||
Port: uint16(20332),
|
Port: uint16(20332),
|
||||||
|
|
|
@ -4,7 +4,7 @@ type (
|
||||||
// Version model used for reporting server version
|
// Version model used for reporting server version
|
||||||
// info.
|
// info.
|
||||||
Version struct {
|
Version struct {
|
||||||
Port uint16 `json:"port"`
|
Port uint16 `json:"tcp_port"`
|
||||||
Nonce uint32 `json:"nonce"`
|
Nonce uint32 `json:"nonce"`
|
||||||
UserAgent string `json:"useragent"`
|
UserAgent string `json:"useragent"`
|
||||||
}
|
}
|
||||||
|
|
Loading…
Reference in a new issue