From 5ba0e57ee0a6b427f0dc4603b4cb4717451524d8 Mon Sep 17 00:00:00 2001 From: ivcosla Date: Fri, 6 Sep 2019 18:21:58 +0200 Subject: [PATCH 01/14] still need to integrate transport discovery and setup node --- cmd/hypervisor/commands/root.go | 11 ++++--- go.sum | 1 + pkg/hypervisor/config.go | 30 +++++++++++++---- pkg/hypervisor/hypervisor.go | 58 +++++++++++++++++++++------------ pkg/visor/config.go | 2 +- pkg/visor/visor.go | 22 +++++-------- 6 files changed, 79 insertions(+), 45 deletions(-) diff --git a/cmd/hypervisor/commands/root.go b/cmd/hypervisor/commands/root.go index c15fd83e1..fdccee3cc 100644 --- a/cmd/hypervisor/commands/root.go +++ b/cmd/hypervisor/commands/root.go @@ -2,15 +2,14 @@ package commands import ( "fmt" - "net" "net/http" "os" "github.com/skycoin/skycoin/src/util/logging" - "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/hypervisor" + "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/spf13/cobra" ) const configEnv = "SW_HYPERVISOR_CONFIG" @@ -62,7 +61,11 @@ var rootCmd = &cobra.Command{ log.Infof("serving RPC on '%s'", rpcAddr) go func() { - l, err := net.Listen("tcp", rpcAddr) + _, rpcPort, err := config.Interfaces.SplitRPCAddr() + if err != nil { + log.Fatalln("Failed to parse rpc port from rpc address:", err) + } + l, err := m.Network.Listen(snet.DmsgType, rpcPort) if err != nil { log.Fatalln("Failed to bind tcp port:", err) } diff --git a/go.sum b/go.sum index 60f365b04..8d30a3d1a 100644 --- a/go.sum +++ b/go.sum @@ -148,6 +148,7 @@ golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb/go.mod h1:h1NjWce9XRLGQEsW7w golang.org/x/sys v0.0.0-20190801041406-cbf593c0f2f3 h1:4y9KwBHBgBNwDbtu44R5o1fdOCQUEXhbk/P4A9WmJq0= golang.org/x/sys v0.0.0-20190801041406-cbf593c0f2f3/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= +golang.org/x/text v0.3.2 h1:tW2bmiBqwgJj/UpqtC8EpXEZVYOwU0yG4iWbprSVAcs= golang.org/x/text v0.3.2/go.mod h1:bEr9sfX3Q8Zfm5fL9x+3itogRgK3+ptLWKqgva+5dAk= golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= golang.org/x/tools v0.0.0-20190627182818-9947fec5c3ab/go.mod h1:/rFqwRUd4F7ZHNgwSSTFct+R/Kf4OFW1sUzUTQQTgfc= diff --git a/pkg/hypervisor/config.go b/pkg/hypervisor/config.go index 0e82b9145..4ea28eeb4 100644 --- a/pkg/hypervisor/config.go +++ b/pkg/hypervisor/config.go @@ -4,8 +4,10 @@ import ( "encoding/hex" "encoding/json" "net/http" + "net/url" "os" "path/filepath" + "strconv" "time" "github.com/skycoin/dmsg/cipher" @@ -35,12 +37,13 @@ func (hk *Key) UnmarshalText(text []byte) error { // Config configures the hypervisor. type Config struct { - PK cipher.PubKey `json:"public_key"` - SK cipher.SecKey `json:"secret_key"` - DBPath string `json:"db_path"` // Path to store database file. - EnableAuth bool `json:"enable_auth"` // Whether to enable user management. - Cookies CookieConfig `json:"cookies"` // Configures cookies (for session management). - Interfaces InterfaceConfig `json:"interfaces"` // Configures exposed interfaces. + PK cipher.PubKey `json:"public_key"` + SK cipher.SecKey `json:"secret_key"` + DBPath string `json:"db_path"` // Path to store database file. + EnableAuth bool `json:"enable_auth"` // Whether to enable user management. + Cookies CookieConfig `json:"cookies"` // Configures cookies (for session management). + Interfaces InterfaceConfig `json:"interfaces"` // Configures exposed interfaces. + MessagingDiscovery string `json:"messaging_discovery"` // MessagingDiscovery address for dmsg usage } func makeConfig() Config { @@ -134,3 +137,18 @@ func (c *InterfaceConfig) FillDefaults() { c.HTTPAddr = ":8080" c.RPCAddr = ":7080" } + +// SplitRPCAddr returns host and port and whatever error results from parsing the rpc address interface +func (c *InterfaceConfig) SplitRPCAddr() (host string, port uint16, err error) { + addr, err := url.Parse(c.RPCAddr) + if err != nil { + return + } + + uint64port, err := strconv.ParseUint(addr.Port(), 10, 16) + if err != nil { + return + } + + return addr.Host, uint16(uint64port), nil +} diff --git a/pkg/hypervisor/hypervisor.go b/pkg/hypervisor/hypervisor.go index cf7c135bd..87945422e 100644 --- a/pkg/hypervisor/hypervisor.go +++ b/pkg/hypervisor/hypervisor.go @@ -2,11 +2,11 @@ package hypervisor import ( + "context" "encoding/hex" "errors" "fmt" "math/rand" - "net" "net/http" "net/rpc" "strconv" @@ -16,9 +16,10 @@ import ( "github.com/go-chi/chi" "github.com/go-chi/chi/middleware" "github.com/google/uuid" + "github.com/skycoin/dmsg" "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/noise" "github.com/skycoin/skycoin/src/util/logging" + "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/skywire/pkg/app" "github.com/skycoin/skywire/pkg/httputil" @@ -32,42 +33,59 @@ var ( ) type appNodeConn struct { - Addr *noise.Addr + Addr dmsg.Addr Client visor.RPCClient } // Node manages AppNodes. type Node struct { - c Config - nodes map[cipher.PubKey]appNodeConn // connected remote nodes. - users *UserManager - mu *sync.RWMutex + c Config + nodes map[cipher.PubKey]appNodeConn // connected remote nodes. + users *UserManager + mu *sync.RWMutex + Network *snet.Network } // NewNode creates a new Node. func NewNode(config Config) (*Node, error) { + ctx := context.Background() + boltUserDB, err := NewBoltUserStore(config.DBPath) if err != nil { return nil, err } singleUserDB := NewSingleUserStore("admin", boltUserDB) + dmsgConf := snet.Config{ + PubKey: config.PK, + SecKey: config.SK, + TpNetworks: []string{snet.DmsgType}, + + DmsgDiscAddr: config.MessagingDiscovery, + DmsgMinSrvs: 1, + } + + network := snet.New(dmsgConf) + if err := network.Init(ctx); err != nil { + return nil, fmt.Errorf("failed to init network: %v", err) + } return &Node{ - c: config, - nodes: make(map[cipher.PubKey]appNodeConn), - users: NewUserManager(singleUserDB, config.Cookies), - mu: new(sync.RWMutex), + c: config, + nodes: make(map[cipher.PubKey]appNodeConn), + users: NewUserManager(singleUserDB, config.Cookies), + mu: new(sync.RWMutex), + Network: network, }, nil } // ServeRPC serves RPC of a Node. -func (m *Node) ServeRPC(lis net.Listener) error { +func (m *Node) ServeRPC(lis *snet.Listener) error { for { - conn, err := noise.WrapListener(lis, m.c.PK, m.c.SK, false, noise.HandshakeXK).Accept() + conn, err := lis.AcceptConn() if err != nil { return err } - addr := conn.RemoteAddr().(*noise.Addr) + addr := conn.RemoteAddr().(dmsg.Addr) m.mu.Lock() m.nodes[addr.PK] = appNodeConn{ Addr: addr, @@ -100,9 +118,9 @@ func (m *Node) AddMockData(config MockConfig) error { } m.mu.Lock() m.nodes[pk] = appNodeConn{ - Addr: &noise.Addr{ + Addr: dmsg.Addr{ PK: pk, - Addr: mockAddr(fmt.Sprintf("0.0.0.0:%d", i)), + Port: uint16(i), }, Client: client, } @@ -246,7 +264,7 @@ func (m *Node) getNodes() http.HandlerFunc { summary = &visor.Summary{PubKey: pk} } summaries = append(summaries, summaryResp{ - TCPAddr: c.Addr.Addr.String(), + TCPAddr: c.Addr.String(), Summary: summary, }) } @@ -264,7 +282,7 @@ func (m *Node) getNode() http.HandlerFunc { return } httputil.WriteJSON(w, r, http.StatusOK, summaryResp{ - TCPAddr: ctx.Addr.Addr.String(), + TCPAddr: ctx.Addr.String(), Summary: summary, }) }) @@ -573,7 +591,7 @@ func (m *Node) getLoops() http.HandlerFunc { <<< Helper functions >>> */ -func (m *Node) client(pk cipher.PubKey) (*noise.Addr, visor.RPCClient, bool) { +func (m *Node) client(pk cipher.PubKey) (dmsg.Addr, visor.RPCClient, bool) { m.mu.RLock() conn, ok := m.nodes[pk] m.mu.RUnlock() @@ -583,7 +601,7 @@ func (m *Node) client(pk cipher.PubKey) (*noise.Addr, visor.RPCClient, bool) { type httpCtx struct { // Node PK cipher.PubKey - Addr *noise.Addr + Addr dmsg.Addr RPC visor.RPCClient // App diff --git a/pkg/visor/config.go b/pkg/visor/config.go index 36451dd6d..d1b9b7442 100644 --- a/pkg/visor/config.go +++ b/pkg/visor/config.go @@ -168,7 +168,7 @@ func ensureDir(path string) (string, error) { // HypervisorConfig represents hypervisor configuration. type HypervisorConfig struct { PubKey cipher.PubKey `json:"public_key"` - Addr string `json:"address"` + Port uint16 `json:"port"` } // DmsgConfig represents dmsg configuration. diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index 375d1ee67..1d626dc17 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -207,15 +207,6 @@ func NewNode(config *Config, masterLogger *logging.MasterLogger) (*Node, error) } node.rpcListener = l } - node.rpcDialers = make([]*noise.RPCClientDialer, len(config.Hypervisors)) - for i, entry := range config.Hypervisors { - node.rpcDialers[i] = noise.NewRPCClientDialer(entry.Addr, noise.HandshakeXK, noise.Config{ - LocalPK: pk, - LocalSK: sk, - RemotePK: entry.PubKey, - Initiator: true, - }) - } return node, err } @@ -247,12 +238,15 @@ func (node *Node) Start() error { node.logger.Info("Starting RPC interface on ", node.rpcListener.Addr()) go rpcSvr.Accept(node.rpcListener) } - for _, dialer := range node.rpcDialers { - go func(dialer *noise.RPCClientDialer) { - if err := dialer.Run(rpcSvr, time.Second); err != nil { - node.logger.Errorf("Dialer exited with error: %v", err) + for _, hypervisor := range node.config.Hypervisors { + go func(hypervisor HypervisorConfig) { + conn, err := node.n.Dial(snet.DmsgType, hypervisor.PubKey, hypervisor.Port) + if err != nil { + node.logger.Errorf("Hypervisor dmsg Dial exited with error: %v", err) + } else { + rpcSvr.ServeConn(conn) } - }(dialer) + }(hypervisor) } node.logger.Info("Starting packet router") From b6eb2d1bb241c49cb5bf8dad58b54800506ba88b Mon Sep 17 00:00:00 2001 From: ivcosla Date: Fri, 6 Sep 2019 19:34:25 +0200 Subject: [PATCH 02/14] removed unused code --- go.mod | 2 +- pkg/visor/visor.go | 9 --------- vendor/modules.txt | 2 +- 3 files changed, 2 insertions(+), 11 deletions(-) diff --git a/go.mod b/go.mod index e292f1728..1dc07542c 100644 --- a/go.mod +++ b/go.mod @@ -29,4 +29,4 @@ require ( ) // Uncomment for tests with alternate branches of 'dmsg' -//replace github.com/skycoin/dmsg => ../dmsg +// replace github.com/skycoin/dmsg => ../dmsg diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index 1d626dc17..19a21b32f 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -23,7 +23,6 @@ import ( "github.com/skycoin/dmsg" "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/noise" "github.com/skycoin/skycoin/src/util/logging" "github.com/skycoin/skywire/pkg/app" @@ -109,7 +108,6 @@ type Node struct { pidMu sync.Mutex rpcListener net.Listener - rpcDialers []*noise.RPCClientDialer } // NewNode constructs new Node. @@ -328,13 +326,6 @@ func (node *Node) Close() (err error) { node.logger.Info("RPC interface stopped successfully") } } - for i, dialer := range node.rpcDialers { - if err = dialer.Close(); err != nil { - node.logger.WithError(err).Errorf("(%d) failed to stop RPC dialer", i) - } else { - node.logger.Infof("(%d) RPC dialer closed successfully", i) - } - } node.startedMu.Lock() for a, bind := range node.startedApps { if err = node.stopApp(a, bind); err != nil { diff --git a/vendor/modules.txt b/vendor/modules.txt index ecea517de..a27cae2ea 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -66,8 +66,8 @@ github.com/sirupsen/logrus/hooks/syslog github.com/skycoin/dmsg/cipher github.com/skycoin/dmsg github.com/skycoin/dmsg/disc -github.com/skycoin/dmsg/noise github.com/skycoin/dmsg/ioutil +github.com/skycoin/dmsg/noise # github.com/skycoin/skycoin v0.26.0 github.com/skycoin/skycoin/src/util/logging github.com/skycoin/skycoin/src/cipher From 5512d1b2498b36403dbce9af52b46d010beaf1ca Mon Sep 17 00:00:00 2001 From: Evan Lin Date: Fri, 6 Sep 2019 22:34:03 +0800 Subject: [PATCH 03/14] Began work to fix bug where visor node restart does not reestablish routes. --- pkg/setup/config.go | 4 +- pkg/setup/node.go | 71 +++++++++++++++--------------- pkg/transport/managed_transport.go | 3 +- pkg/transport/manager.go | 21 --------- 4 files changed, 39 insertions(+), 60 deletions(-) diff --git a/pkg/setup/config.go b/pkg/setup/config.go index ccb4ddad3..e30becc02 100644 --- a/pkg/setup/config.go +++ b/pkg/setup/config.go @@ -8,8 +8,8 @@ import ( // Various timeouts for setup node. const ( - ServeTransportTimeout = time.Second * 30 - ReadTimeout = time.Second * 10 + RequestTimeout = time.Second * 30 + ReadTimeout = time.Second * 10 ) // Config defines configuration parameters for setup Node. diff --git a/pkg/setup/node.go b/pkg/setup/node.go index 5577b2b2a..f37e0c1c9 100644 --- a/pkg/setup/node.go +++ b/pkg/setup/node.go @@ -5,7 +5,6 @@ import ( "encoding/json" "errors" "fmt" - "sync" "time" "github.com/google/uuid" @@ -78,15 +77,15 @@ func (sn *Node) Serve(ctx context.Context) error { return err } go func(conn *dmsg.Transport) { - if err := sn.serveTransport(ctx, conn); err != nil { + if err := sn.handleRequest(ctx, conn); err != nil { sn.Logger.Warnf("Failed to serve Transport: %s", err) } }(conn) } } -func (sn *Node) serveTransport(ctx context.Context, tr *dmsg.Transport) error { - ctx, cancel := context.WithTimeout(ctx, ServeTransportTimeout) +func (sn *Node) handleRequest(ctx context.Context, tr *dmsg.Transport) error { + ctx, cancel := context.WithTimeout(ctx, RequestTimeout) defer cancel() proto := NewSetupProtocol(tr) @@ -95,36 +94,44 @@ func (sn *Node) serveTransport(ctx context.Context, tr *dmsg.Transport) error { return err } - sn.Logger.Infof("Got new Setup request with type %s: %s", sp, string(data)) - defer sn.Logger.Infof("Completed Setup request with type %s: %s", sp, string(data)) + log := sn.Logger.WithField("requester", tr.RemotePK()).WithField("reqType", sp) + log.Infof("Received request.") startTime := time.Now() + switch sp { case PacketCreateLoop: var ld routing.LoopDescriptor - if err = json.Unmarshal(data, &ld); err == nil { - err = sn.createLoop(ctx, ld) + if err = json.Unmarshal(data, &ld); err != nil { + break } + ldJson, _ := json.MarshalIndent(ld, "", "\t") + log.Infof("CreateLoop loop descriptor: %s", string(ldJson)) + err = sn.createLoop(ctx, ld) + case PacketCloseLoop: var ld routing.LoopData - if err = json.Unmarshal(data, &ld); err == nil { - err = sn.closeLoop(ctx, ld.Loop.Remote.PubKey, routing.LoopData{ - Loop: routing.Loop{ - Remote: ld.Loop.Local, - Local: ld.Loop.Remote, - }, - }) + if err = json.Unmarshal(data, &ld); err != nil { + break } + err = sn.closeLoop(ctx, ld.Loop.Remote.PubKey, routing.LoopData{ + Loop: routing.Loop{ + Remote: ld.Loop.Local, + Local: ld.Loop.Remote, + }, + }) + default: err = errors.New("unknown foundation packet") } sn.metrics.Record(time.Since(startTime), err != nil) if err != nil { - sn.Logger.Infof("Setup request with type %s failed: %s", sp, err) + log.WithError(err).Warnf("Request completed with error.") return proto.WritePacket(RespFailure, err) } + log.Infof("Request completed successfully.") return proto.WritePacket(RespSuccess, nil) } @@ -215,13 +222,12 @@ func (sn *Node) createLoop(ctx context.Context, ld routing.LoopDescriptor) error // // During the setup process each error received along the way causes all the procedure to be canceled. RouteID received // from the 1st step connecting to the initiating node is used as the ID for the overall rule, thus being returned. -func (sn *Node) createRoute(ctx context.Context, keepAlive time.Duration, route routing.Route, - rport, lport routing.Port) (routing.RouteID, error) { +func (sn *Node) createRoute(ctx context.Context, keepAlive time.Duration, route routing.Route, rPort, lPort routing.Port) (routing.RouteID, error) { if len(route) == 0 { return 0, nil } - sn.Logger.Infof("Creating new Route %s", route) + sn.Logger.Infof("Creating a new Route %s", route) // add the initiating node to the start of the route. We need to loop over all the visor nodes // along the route to apply rules including the initiating one @@ -251,7 +257,7 @@ func (sn *Node) createRoute(ctx context.Context, keepAlive time.Duration, route resultingRouteIDCh := make(chan routing.RouteID, 2) // context to cancel rule setup in case of errors - cancellableCtx, cancel := context.WithCancel(ctx) + ctx, cancel := context.WithCancel(ctx) for i := len(r) - 1; i >= 0; i-- { var reqIDChIn, reqIDChOut chan routing.RouteID // goroutine[0] doesn't need to pass the route ID from the 1st step to anyone @@ -268,12 +274,11 @@ func (sn *Node) createRoute(ctx context.Context, keepAlive time.Duration, route nextTpID = r[i+1].Transport rule = routing.ForwardRule(keepAlive, 0, nextTpID, 0) } else { - rule = routing.AppRule(keepAlive, 0, 0, init, lport, rport) + rule = routing.AppRule(keepAlive, 0, 0, init, lPort, rPort) } - go func(i int, pk cipher.PubKey, rule routing.Rule, reqIDChIn <-chan routing.RouteID, - reqIDChOut chan<- routing.RouteID) { - routeID, err := sn.setupRule(cancellableCtx, pk, rule, reqIDChIn, reqIDChOut) + go func(i int, pk cipher.PubKey, rule routing.Rule, reqIDChIn <-chan routing.RouteID, reqIDChOut chan<- routing.RouteID) { + routeID, err := sn.setupRule(ctx, pk, rule, reqIDChIn, reqIDChOut) // adding rule for initiator must result with a route ID for the overall route // it doesn't matter for now if there was an error, this result will be fetched only if there wasn't one if i == 0 { @@ -295,17 +300,16 @@ func (sn *Node) createRoute(ctx context.Context, keepAlive time.Duration, route } var rulesSetupErr error - var cancelOnce sync.Once // check for any errors occurred so far for range r { // filter out context cancellation errors if err := <-rulesSetupErrs; err != nil && err != context.Canceled { // rules setup failed, cancel further setup - cancelOnce.Do(cancel) + cancel() rulesSetupErr = err } } - cancelOnce.Do(cancel) + cancel() // close chan to avoid leaks close(rulesSetupErrs) @@ -349,11 +353,7 @@ func (sn *Node) Close() error { } func (sn *Node) closeLoop(ctx context.Context, on cipher.PubKey, ld routing.LoopData) error { - fmt.Printf(">>> BEGIN: closeLoop(%s, ld)\n", on) - defer fmt.Printf(">>> END: closeLoop(%s, ld)\n", on) - proto, err := sn.dialAndCreateProto(ctx, on) - fmt.Println(">>> *****: closeLoop() dialed:", err) if err != nil { return err } @@ -367,10 +367,9 @@ func (sn *Node) closeLoop(ctx context.Context, on cipher.PubKey, ld routing.Loop return nil } -func (sn *Node) setupRule(ctx context.Context, pk cipher.PubKey, rule routing.Rule, - reqIDChIn <-chan routing.RouteID, reqIDChOut chan<- routing.RouteID) (routing.RouteID, error) { - sn.Logger.Debugf("trying to setup setup rule: %v with %s\n", rule, pk) - requestRouteID, err := sn.requestRouteID(ctx, pk) +func (sn *Node) setupRule(ctx context.Context, pk cipher.PubKey, rule routing.Rule, reqIDChIn <-chan routing.RouteID, reqIDChOut chan<- routing.RouteID) (routing.RouteID, error) { + sn.Logger.Debugf("trying to setup setup rule: %v with %s", rule, pk) + requestRouteID, err := sn.requestRouteID(ctx, pk) // take this. if err != nil { return 0, err } @@ -386,7 +385,7 @@ func (sn *Node) setupRule(ctx context.Context, pk cipher.PubKey, rule routing.Ru rule.SetRequestRouteID(requestRouteID) - sn.Logger.Debugf("dialing to %s to setup rule: %v\n", pk, rule) + sn.Logger.Debugf("dialing to %s to setup rule: %v", pk, rule) if err := sn.addRule(ctx, pk, rule); err != nil { return 0, err diff --git a/pkg/transport/managed_transport.go b/pkg/transport/managed_transport.go index a4f7470e1..a61869fdf 100644 --- a/pkg/transport/managed_transport.go +++ b/pkg/transport/managed_transport.go @@ -108,6 +108,7 @@ func (mt *ManagedTransport) Serve(readCh chan<- routing.Packet, done <-chan stru mt.connMx.Unlock() }() + // Read loop. go func() { defer func() { mt.log.Infof("closed readPacket loop.") @@ -133,6 +134,7 @@ func (mt *ManagedTransport) Serve(readCh chan<- routing.Packet, done <-chan stru } }() + // Redial loop. for { select { case <-mt.done: @@ -225,7 +227,6 @@ func (mt *ManagedTransport) Dial(ctx context.Context) error { return mt.dial(ctx) } -// TODO: Figure out where this fella is called. func (mt *ManagedTransport) dial(ctx context.Context) error { tp, err := mt.n.Dial(mt.netName, mt.rPK, snet.TransportPort) if err != nil { diff --git a/pkg/transport/manager.go b/pkg/transport/manager.go index 206aa407f..ccc246207 100644 --- a/pkg/transport/manager.go +++ b/pkg/transport/manager.go @@ -116,27 +116,6 @@ func (tm *Manager) serve(ctx context.Context) { } } -// TODO(nkryuchkov): either use or remove if unused -// func (tm *Manager) initTransports(ctx context.Context) { -// tm.mx.Lock() -// defer tm.mx.Unlock() -// -// entries, err := tm.conf.DiscoveryClient.GetTransportsByEdge(ctx, tm.conf.PubKey) -// if err != nil { -// log.Warnf("No transports found for local node: %v", err) -// } -// for _, entry := range entries { -// var ( -// tpType = entry.Entry.Type -// remote = entry.Entry.RemoteEdge(tm.conf.PubKey) -// tpID = entry.Entry.ID -// ) -// if _, err := tm.saveTransport(remote, tpType); err != nil { -// tm.Logger.Warnf("INIT: failed to init tp: type(%s) remote(%s) tpID(%s)", tpType, remote, tpID) -// } -// } -// } - func (tm *Manager) acceptTransport(ctx context.Context, lis *snet.Listener) error { conn, err := lis.AcceptConn() // TODO: tcp panic. if err != nil { From add2e38a9e2144973030bddff7e5270f0f5c3eed Mon Sep 17 00:00:00 2001 From: Evan Lin Date: Mon, 9 Sep 2019 01:52:59 +0800 Subject: [PATCH 04/14] Changed behaviour of setup. * Reserving route IDs and adding rules to visors is now split into two communication steps. * Improved readability and testability of the setup procedure but splitting responsibilities to additional structures; setup.idReservoir, setup.RulesMap * Improved logging for setup procedure. * Slightly tweaked setup.Protocol to accommodate aforementioned changes. --- pkg/router/route_manager.go | 20 +- pkg/router/route_manager_test.go | 12 +- pkg/routing/rule.go | 18 +- pkg/setup/idreservoir.go | 164 ++++++++ pkg/setup/node.go | 339 ++++------------ pkg/setup/node_test.go | 657 ++++++++++++++++--------------- pkg/setup/protocol.go | 29 +- pkg/visor/rpc_client.go | 1 + 8 files changed, 637 insertions(+), 603 deletions(-) create mode 100644 pkg/setup/idreservoir.go diff --git a/pkg/router/route_manager.go b/pkg/router/route_manager.go index 25faf40d0..b1717b18a 100644 --- a/pkg/router/route_manager.go +++ b/pkg/router/route_manager.go @@ -127,7 +127,7 @@ func (rm *routeManager) handleSetupConn(conn net.Conn) error { case setup.PacketLoopClosed: err = rm.loopClosed(body) case setup.PacketRequestRouteID: - respBody, err = rm.occupyRouteID() + respBody, err = rm.occupyRouteID(body) default: err = errors.New("unknown foundation packet") } @@ -312,12 +312,20 @@ func (rm *routeManager) loopClosed(data []byte) error { return rm.conf.OnLoopClosed(ld.Loop) } -func (rm *routeManager) occupyRouteID() ([]routing.RouteID, error) { - rule := routing.ForwardRule(DefaultRouteKeepAlive, 0, uuid.UUID{}, 0) - routeID, err := rm.rt.AddRule(rule) - if err != nil { +func (rm *routeManager) occupyRouteID(data []byte) ([]routing.RouteID, error) { + var n uint8 + if err := json.Unmarshal(data, &n); err != nil { return nil, err } - return []routing.RouteID{routeID}, nil + var ids = make([]routing.RouteID, n) + for i := range ids { + rule := routing.ForwardRule(DefaultRouteKeepAlive, 0, uuid.UUID{}, 0) + routeID, err := rm.rt.AddRule(rule) + if err != nil { + return nil, err + } + ids[i] = routeID + } + return ids, nil } diff --git a/pkg/router/route_manager_test.go b/pkg/router/route_manager_test.go index f40bc5e24..729e2c699 100644 --- a/pkg/router/route_manager_test.go +++ b/pkg/router/route_manager_test.go @@ -114,26 +114,26 @@ func TestNewRouteManager(t *testing.T) { }() // Emulate SetupNode sending RequestRegistrationID request. - id, err := setup.RequestRouteID(context.TODO(), setup.NewSetupProtocol(requestIDIn)) + ids, err := setup.RequestRouteIDs(context.TODO(), setup.NewSetupProtocol(requestIDIn), 1) require.NoError(t, err) // Emulate SetupNode sending AddRule request. - rule := routing.ForwardRule(10*time.Minute, 3, uuid.New(), id) - err = setup.AddRule(context.TODO(), setup.NewSetupProtocol(addIn), rule) + rule := routing.ForwardRule(10*time.Minute, 3, uuid.New(), ids[0]) + err = setup.AddRules(context.TODO(), setup.NewSetupProtocol(addIn), []routing.Rule{rule}) require.NoError(t, err) // Check routing table state after AddRule. assert.Equal(t, 1, rt.Count()) - r, err := rt.Rule(id) + r, err := rt.Rule(ids[0]) require.NoError(t, err) assert.Equal(t, rule, r) // Emulate SetupNode sending RemoveRule request. - require.NoError(t, setup.DeleteRule(context.TODO(), setup.NewSetupProtocol(delIn), id)) + require.NoError(t, setup.DeleteRule(context.TODO(), setup.NewSetupProtocol(delIn), ids[0])) // Check routing table state after DeleteRule. assert.Equal(t, 0, rt.Count()) - r, err = rt.Rule(id) + r, err = rt.Rule(ids[0]) assert.Error(t, err) assert.Nil(t, r) } diff --git a/pkg/routing/rule.go b/pkg/routing/rule.go index ba23bbc4c..a47b9b89f 100644 --- a/pkg/routing/rule.go +++ b/pkg/routing/rule.go @@ -114,14 +114,22 @@ func (r Rule) SetRequestRouteID(id RouteID) { } func (r Rule) String() string { - if r.Type() == RuleApp { - return fmt.Sprintf("App: ", - r.RouteID(), r.RemotePK(), r.RemotePort(), r.LocalPort()) + switch r.Type() { + case RuleApp: + return fmt.Sprintf("APP(keyRtID:%d, resRtID:%d, rPK:%s, rPort:%d, lPort:%d)", + r.RequestRouteID(), r.RouteID(), r.RemotePK(), r.RemotePort(), r.LocalPort()) + case RuleForward: + return fmt.Sprintf("FWD(keyRtID:%d, nxtRtID:%d, nxtTpID:%s)", + r.RequestRouteID(), r.RouteID(), r.TransportID()) + default: + return "invalid rule" } - - return fmt.Sprintf("Forward: ", r.RouteID(), r.TransportID()) } +//func (r Rule) MarshalJSON() ([]byte, error) { +// return json.Marshal(r.String()) +//} + // RuleAppFields summarizes App fields of a RoutingRule. type RuleAppFields struct { RespRID RouteID `json:"resp_rid"` diff --git a/pkg/setup/idreservoir.go b/pkg/setup/idreservoir.go new file mode 100644 index 000000000..467192c6c --- /dev/null +++ b/pkg/setup/idreservoir.go @@ -0,0 +1,164 @@ +package setup + +import ( + "context" + "encoding/json" + "errors" + "fmt" + "sync" + "time" + + "github.com/skycoin/dmsg/cipher" + + "github.com/skycoin/skywire/pkg/routing" +) + +type idReservoir struct { + rec map[cipher.PubKey]uint8 + ids map[cipher.PubKey][]routing.RouteID + mx sync.Mutex +} + +func newIDReservoir(routes ...routing.Route) (*idReservoir, int) { + rec := make(map[cipher.PubKey]uint8) + var total int + + for _, rt := range routes { + if len(rt) == 0 { + continue + } + rec[rt[0].From]++ + for _, hop := range rt { + rec[hop.To]++ + } + total += len(rt) + 1 + } + + return &idReservoir{ + rec: rec, + ids: make(map[cipher.PubKey][]routing.RouteID), + }, total +} + +func (idr *idReservoir) ReserveIDs(ctx context.Context, reserve func(ctx context.Context, pk cipher.PubKey, n uint8) ([]routing.RouteID, error)) error { + ctx, cancel := context.WithCancel(ctx) + defer cancel() + + errCh := make(chan error, len(idr.rec)) + defer close(errCh) + + for pk, n := range idr.rec { + pk, n := pk, n + go func() { + ids, err := reserve(ctx, pk, n) + if err != nil { + errCh <- fmt.Errorf("reserve routeID from %s failed: %v", pk, err) + return + } + idr.mx.Lock() + idr.ids[pk] = ids + idr.mx.Unlock() + errCh <- nil + }() + } + + return finalError(len(idr.rec), errCh) +} + +func (idr *idReservoir) PopID(pk cipher.PubKey) (routing.RouteID, bool) { + idr.mx.Lock() + defer idr.mx.Unlock() + + ids, ok := idr.ids[pk] + if !ok || len(ids) == 0 { + return 0, false + } + + idr.ids[pk] = ids[1:] + return ids[0], true +} + +// RulesMap associates a slice of rules to a visor's public key. +type RulesMap map[cipher.PubKey][]routing.Rule + +func (rm RulesMap) String() string { + out := make(map[cipher.PubKey][]string, len(rm)) + for pk, rules := range rm { + str := make([]string, len(rules)) + for i, rule := range rules { + str[i] = rule.String() + } + out[pk] = str + } + jb, err := json.MarshalIndent(out, "", "\t") + if err != nil { + panic(err) + } + return string(jb) +} + +// GenerateRules generates rules for a given LoopDescriptor. +// The outputs are as follows: +// - rules: a map that relates a slice of routing rules to a given visor's public key. +// - srcAppRID: the initiating node's route ID that references the FWD rule. +// - dstAppRID: the responding node's route ID that references the FWD rule. +// - err: an error (if any). +func GenerateRules(idc *idReservoir, ld routing.LoopDescriptor) (rules RulesMap, srcFwdRID, dstFwdRID routing.RouteID, err error) { + rules = make(RulesMap) + src, dst := ld.Loop.Local, ld.Loop.Remote + + firstFwdRID, lastFwdRID, err := SaveForwardRules(rules, idc, ld.KeepAlive, ld.Forward) + if err != nil { + return nil, 0, 0, err + } + firstRevRID, lastRevRID, err := SaveForwardRules(rules, idc, ld.KeepAlive, ld.Reverse) + if err != nil { + return nil, 0, 0, err + } + + rules[src.PubKey] = append(rules[src.PubKey], + routing.AppRule(ld.KeepAlive, firstRevRID, lastFwdRID, dst.PubKey, src.Port, dst.Port)) + rules[dst.PubKey] = append(rules[dst.PubKey], + routing.AppRule(ld.KeepAlive, firstFwdRID, lastRevRID, src.PubKey, dst.Port, src.Port)) + + return rules, firstFwdRID, firstRevRID, nil +} + +// SaveForwardRules creates the rules of the given route, and saves them in the 'rules' input. +// Note that the last rule for the route is always an APP rule, and so is not created here. +// The outputs are as follows: +// - firstRID: the first visor's route ID. +// - lastRID: the last visor's route ID (note that there is no rule set for this ID yet). +// - err: an error (if any). +func SaveForwardRules(rules RulesMap, idc *idReservoir, keepAlive time.Duration, route routing.Route) (firstRID, lastRID routing.RouteID, err error) { + + // 'firstRID' is the first visor's key routeID - this is to be returned. + var ok bool + if firstRID, ok = idc.PopID(route[0].From); !ok { + return 0, 0, errors.New("fucked up") + } + + var rID = firstRID + for _, hop := range route { + nxtRID, ok := idc.PopID(hop.To) + if !ok { + return 0, 0, errors.New("fucked up") + } + rule := routing.ForwardRule(keepAlive, nxtRID, hop.Transport, rID) + rules[hop.From] = append(rules[hop.From], rule) + + rID = nxtRID + } + + return firstRID, rID, nil +} + +func finalError(n int, errCh <-chan error) error { + var finalErr error + for i := 0; i < n; i++ { + if err := <-errCh; err != nil { + finalErr = err + } + } + return finalErr +} diff --git a/pkg/setup/node.go b/pkg/setup/node.go index f37e0c1c9..c522a7329 100644 --- a/pkg/setup/node.go +++ b/pkg/setup/node.go @@ -7,8 +7,6 @@ import ( "fmt" "time" - "github.com/google/uuid" - "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/dmsg" @@ -67,6 +65,14 @@ func NewNode(conf *Config, metrics metrics.Recorder) (*Node, error) { }, nil } +// Close closes underlying dmsg client. +func (sn *Node) Close() error { + if sn == nil { + return nil + } + return sn.dmsgC.Close() +} + // Serve starts transport listening loop. func (sn *Node) Serve(ctx context.Context) error { sn.Logger.Info("serving setup node") @@ -105,16 +111,19 @@ func (sn *Node) handleRequest(ctx context.Context, tr *dmsg.Transport) error { if err = json.Unmarshal(data, &ld); err != nil { break } - ldJson, _ := json.MarshalIndent(ld, "", "\t") - log.Infof("CreateLoop loop descriptor: %s", string(ldJson)) - err = sn.createLoop(ctx, ld) + ldJSON, jErr := json.MarshalIndent(ld, "", "\t") + if jErr != nil { + panic(jErr) + } + log.Infof("CreateLoop loop descriptor: %s", string(ldJSON)) + err = sn.handleCreateLoop(ctx, ld) case PacketCloseLoop: var ld routing.LoopData if err = json.Unmarshal(data, &ld); err != nil { break } - err = sn.closeLoop(ctx, ld.Loop.Remote.PubKey, routing.LoopData{ + err = sn.handleCloseLoop(ctx, ld.Loop.Remote.PubKey, routing.LoopData{ Loop: routing.Loop{ Remote: ld.Loop.Local, Local: ld.Loop.Remote, @@ -135,224 +144,107 @@ func (sn *Node) handleRequest(ctx context.Context, tr *dmsg.Transport) error { return proto.WritePacket(RespSuccess, nil) } -func (sn *Node) createLoop(ctx context.Context, ld routing.LoopDescriptor) error { - sn.Logger.Infof("Creating new Loop %s", ld) - rRouteID, err := sn.createRoute(ctx, ld.KeepAlive, ld.Reverse, ld.Loop.Local.Port, ld.Loop.Remote.Port) +func (sn *Node) handleCreateLoop(ctx context.Context, ld routing.LoopDescriptor) error { + src := ld.Loop.Local + dst := ld.Loop.Remote + + // Reserve route IDs from visors. + idr, err := sn.reserveRouteIDs(ctx, ld.Forward, ld.Reverse) if err != nil { return err } - fRouteID, err := sn.createRoute(ctx, ld.KeepAlive, ld.Forward, ld.Loop.Remote.Port, ld.Loop.Local.Port) + // Determine the rules to send to visors using loop descriptor and reserved route IDs. + rulesMap, srcFwdRID, dstFwdRID, err := GenerateRules(idr, ld) if err != nil { return err } + sn.Logger.Infof("generated rules: %v", rulesMap) - if len(ld.Forward) == 0 || len(ld.Reverse) == 0 { - return nil - } - - initiator := ld.Initiator() - responder := ld.Responder() - - ldR := routing.LoopData{ - Loop: routing.Loop{ - Remote: routing.Addr{ - PubKey: initiator, - Port: ld.Loop.Local.Port, - }, - Local: routing.Addr{ - PubKey: responder, - Port: ld.Loop.Remote.Port, - }, - }, - RouteID: rRouteID, - } - if err := sn.connectLoop(ctx, responder, ldR); err != nil { - sn.Logger.Warnf("Failed to confirm loop with responder: %s", err) - return fmt.Errorf("loop connect: %s", err) - } - - ldI := routing.LoopData{ - Loop: routing.Loop{ - Remote: routing.Addr{ - PubKey: responder, - Port: ld.Loop.Remote.Port, - }, - Local: routing.Addr{ - PubKey: initiator, - Port: ld.Loop.Local.Port, - }, - }, - RouteID: fRouteID, - } - if err := sn.connectLoop(ctx, initiator, ldI); err != nil { - sn.Logger.Warnf("Failed to confirm loop with initiator: %s", err) - if err := sn.closeLoop(ctx, responder, ldR); err != nil { - sn.Logger.Warnf("Failed to close loop: %s", err) - } - return fmt.Errorf("loop connect: %s", err) - } - - sn.Logger.Infof("Created Loop %s", ld) - return nil -} - -// createRoute setups the route. Route setup involves applying routing rules to each visor node along the route. -// Each rule applying procedure consists of two steps: -// 1. Request free route ID from the visor node -// 2. Apply the rule, using route ID from the step 1 to register this rule inside the visor node -// -// Route ID received as a response after 1st step is used in two rules. 1st, it's used in the rule being applied -// to the current visor node as a route ID to register this rule within the visor node. -// 2nd, it's used in the rule being applied to the previous visor node along the route as a `respRouteID/nextRouteID`. -// For this reason, each 2nd step must wait for completion of its 1st step and the 1st step of the next visor node -// along the route to be able to obtain route ID from there. IDs serving as `respRouteID/nextRouteID` are being -// passed in a fan-like fashion. -// -// Example. Let's say, we have N visor nodes along the route. Visor[0] is the initiator. Setup node sends N requests to -// each visor along the route according to the 1st step and gets N route IDs in response. Then we assemble N rules to -// be applied. We construct each rule as the following: -// - Rule[0..N-1] are of type `ForwardRule`; -// - Rule[N] is of type `AppRule`; -// - For i = 0..N-1 rule[i] takes `nextTransportID` from the rule[i+1]; -// - For i = 0..N-1 rule[i] takes `respRouteID/nextRouteID` from rule[i+1] (after [i+1] request for free route ID -// completes; -// - Rule[N] has `respRouteID/nextRouteID` equal to 0; -// Rule[0..N] use their route ID retrieved from the 1st step to be registered within the corresponding visor node. -// -// During the setup process each error received along the way causes all the procedure to be canceled. RouteID received -// from the 1st step connecting to the initiating node is used as the ID for the overall rule, thus being returned. -func (sn *Node) createRoute(ctx context.Context, keepAlive time.Duration, route routing.Route, rPort, lPort routing.Port) (routing.RouteID, error) { - if len(route) == 0 { - return 0, nil - } - - sn.Logger.Infof("Creating a new Route %s", route) - - // add the initiating node to the start of the route. We need to loop over all the visor nodes - // along the route to apply rules including the initiating one - r := make(routing.Route, len(route)+1) - r[0] = &routing.Hop{ - Transport: route[0].Transport, - To: route[0].From, - } - copy(r[1:], route) - - init := route[0].From - - // indicate errors occurred during rules setup - rulesSetupErrs := make(chan error, len(r)) - // reqIDsCh is an array of chans used to pass the requested route IDs around the goroutines. - // We do it in a fan fashion here. We create as many goroutines as there are rules to be applied. - // Goroutine[i] requests visor node for a free route ID. It passes this route ID through a chan to - // a goroutine[i-1]. In turn, goroutine[i-1] waits for a route ID from chan[i]. - // Thus, goroutine[len(r)] doesn't get a route ID and uses 0 instead, goroutine[0] doesn't pass - // its route ID to anyone - reqIDsCh := make([]chan routing.RouteID, 0, len(r)) - for range r { - reqIDsCh = append(reqIDsCh, make(chan routing.RouteID, 2)) - } - - // chan to receive the resulting route ID from a goroutine - resultingRouteIDCh := make(chan routing.RouteID, 2) - - // context to cancel rule setup in case of errors - ctx, cancel := context.WithCancel(ctx) - for i := len(r) - 1; i >= 0; i-- { - var reqIDChIn, reqIDChOut chan routing.RouteID - // goroutine[0] doesn't need to pass the route ID from the 1st step to anyone - if i > 0 { - reqIDChOut = reqIDsCh[i-1] - } - var ( - nextTpID uuid.UUID - rule routing.Rule - ) - // goroutine[len(r)-1] uses 0 as the route ID from the 1st step - if i != len(r)-1 { - reqIDChIn = reqIDsCh[i] - nextTpID = r[i+1].Transport - rule = routing.ForwardRule(keepAlive, 0, nextTpID, 0) - } else { - rule = routing.AppRule(keepAlive, 0, 0, init, lPort, rPort) - } + // Add rules to visors. + errCh := make(chan error, len(rulesMap)) + defer close(errCh) + for pk, rules := range rulesMap { + pk, rules := pk, rules + go func() { + log := sn.Logger.WithField("remote", pk) - go func(i int, pk cipher.PubKey, rule routing.Rule, reqIDChIn <-chan routing.RouteID, reqIDChOut chan<- routing.RouteID) { - routeID, err := sn.setupRule(ctx, pk, rule, reqIDChIn, reqIDChOut) - // adding rule for initiator must result with a route ID for the overall route - // it doesn't matter for now if there was an error, this result will be fetched only if there wasn't one - if i == 0 { - resultingRouteIDCh <- routeID - } + proto, err := sn.dialAndCreateProto(ctx, pk) if err != nil { - // filter out context cancellation errors - if err == context.Canceled { - rulesSetupErrs <- err - } else { - rulesSetupErrs <- fmt.Errorf("rule setup: %s", err) - } - + log.WithError(err).Warn("failed to create proto") + errCh <- err return } + defer sn.closeProto(proto) + log.Debug("proto created successfully") - rulesSetupErrs <- nil - }(i, r[i].To, rule, reqIDChIn, reqIDChOut) + if err := AddRules(ctx, proto, rules); err != nil { + log.WithError(err).Warn("failed to add rules") + errCh <- err + return + } + log.Debug("rules added") + errCh <- nil + }() + } + if err := finalError(len(rulesMap), errCh); err != nil { + return err } - var rulesSetupErr error - // check for any errors occurred so far - for range r { - // filter out context cancellation errors - if err := <-rulesSetupErrs; err != nil && err != context.Canceled { - // rules setup failed, cancel further setup - cancel() - rulesSetupErr = err + // Confirm loop with responding visor. + err = func() error { + proto, err := sn.dialAndCreateProto(ctx, dst.PubKey) + if err != nil { + return err } - } - cancel() + defer sn.closeProto(proto) - // close chan to avoid leaks - close(rulesSetupErrs) - for _, ch := range reqIDsCh { - close(ch) - } - if rulesSetupErr != nil { - return 0, rulesSetupErr + data := routing.LoopData{Loop: routing.Loop{Local: dst, Remote: src}, RouteID: dstFwdRID} + return ConfirmLoop(ctx, proto, data) + }() + if err != nil { + return fmt.Errorf("failed to confirm loop with destination visor: %v", err) } - // value gets passed to the chan only if no errors occurred during the route establishment - // errors are being filtered above, so at the moment we get to this part, the value is - // guaranteed to be in the channel - routeID := <-resultingRouteIDCh - close(resultingRouteIDCh) - - return routeID, nil -} + // Confirm loop with initiating visor. + err = func() error { + proto, err := sn.dialAndCreateProto(ctx, src.PubKey) + if err != nil { + return err + } + defer sn.closeProto(proto) -func (sn *Node) connectLoop(ctx context.Context, on cipher.PubKey, ld routing.LoopData) error { - proto, err := sn.dialAndCreateProto(ctx, on) + data := routing.LoopData{Loop: routing.Loop{Local: src, Remote: dst}, RouteID: srcFwdRID} + return ConfirmLoop(ctx, proto, data) + }() if err != nil { - return err + return fmt.Errorf("failed to confirm loop with destination visor: %v", err) } - defer sn.closeProto(proto) - if err := ConfirmLoop(ctx, proto, ld); err != nil { - return err - } - - sn.Logger.Infof("Confirmed loop on %s with %s. RemotePort: %d. LocalPort: %d", on, ld.Loop.Remote.PubKey, ld.Loop.Remote.Port, ld.Loop.Local.Port) return nil } -// Close closes underlying dmsg client. -func (sn *Node) Close() error { - if sn == nil { - return nil +func (sn *Node) reserveRouteIDs(ctx context.Context, fwd, rev routing.Route) (*idReservoir, error) { + idc, total := newIDReservoir(fwd, rev) + sn.Logger.Infof("There are %d route IDs to reserve.", total) + + err := idc.ReserveIDs(ctx, func(ctx context.Context, pk cipher.PubKey, n uint8) ([]routing.RouteID, error) { + proto, err := sn.dialAndCreateProto(ctx, pk) + if err != nil { + return nil, err + } + defer sn.closeProto(proto) + return RequestRouteIDs(ctx, proto, n) + }) + if err != nil { + sn.Logger.WithError(err).Warnf("Failed to reserve route IDs.") + return nil, err } - return sn.dmsgC.Close() + sn.Logger.Infof("Successfully reserved route IDs.") + return idc, err } -func (sn *Node) closeLoop(ctx context.Context, on cipher.PubKey, ld routing.LoopData) error { +func (sn *Node) handleCloseLoop(ctx context.Context, on cipher.PubKey, ld routing.LoopData) error { proto, err := sn.dialAndCreateProto(ctx, on) if err != nil { return err @@ -367,64 +259,7 @@ func (sn *Node) closeLoop(ctx context.Context, on cipher.PubKey, ld routing.Loop return nil } -func (sn *Node) setupRule(ctx context.Context, pk cipher.PubKey, rule routing.Rule, reqIDChIn <-chan routing.RouteID, reqIDChOut chan<- routing.RouteID) (routing.RouteID, error) { - sn.Logger.Debugf("trying to setup setup rule: %v with %s", rule, pk) - requestRouteID, err := sn.requestRouteID(ctx, pk) // take this. - if err != nil { - return 0, err - } - - if reqIDChOut != nil { - reqIDChOut <- requestRouteID - } - var nextRouteID routing.RouteID - if reqIDChIn != nil { - nextRouteID = <-reqIDChIn - rule.SetRouteID(nextRouteID) - } - - rule.SetRequestRouteID(requestRouteID) - - sn.Logger.Debugf("dialing to %s to setup rule: %v", pk, rule) - - if err := sn.addRule(ctx, pk, rule); err != nil { - return 0, err - } - - sn.Logger.Infof("Set rule of type %s on %s", rule.Type(), pk) - - return requestRouteID, nil -} - -func (sn *Node) requestRouteID(ctx context.Context, pk cipher.PubKey) (routing.RouteID, error) { - proto, err := sn.dialAndCreateProto(ctx, pk) - if err != nil { - return 0, err - } - defer sn.closeProto(proto) - - requestRouteID, err := RequestRouteID(ctx, proto) - if err != nil { - return 0, err - } - - sn.Logger.Infof("Received route ID %d from %s", requestRouteID, pk) - - return requestRouteID, nil -} - -func (sn *Node) addRule(ctx context.Context, pk cipher.PubKey, rule routing.Rule) error { - proto, err := sn.dialAndCreateProto(ctx, pk) - if err != nil { - return err - } - defer sn.closeProto(proto) - - return AddRule(ctx, proto, rule) -} - func (sn *Node) dialAndCreateProto(ctx context.Context, pk cipher.PubKey) (*Protocol, error) { - sn.Logger.Debugf("dialing to %s\n", pk) tr, err := sn.dmsgC.Dial(ctx, pk, snet.AwaitSetupPort) if err != nil { return nil, fmt.Errorf("transport: %s", err) diff --git a/pkg/setup/node_test.go b/pkg/setup/node_test.go index 78b5567fc..7f765e2e3 100644 --- a/pkg/setup/node_test.go +++ b/pkg/setup/node_test.go @@ -3,9 +3,24 @@ package setup import ( + "context" + "encoding/json" + "errors" + "fmt" "log" "os" "testing" + "time" + + "github.com/skycoin/dmsg" + "github.com/skycoin/dmsg/cipher" + "github.com/skycoin/dmsg/disc" + "github.com/stretchr/testify/require" + "golang.org/x/net/nettest" + + "github.com/skycoin/skywire/pkg/metrics" + "github.com/skycoin/skywire/pkg/routing" + "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/skycoin/src/util/logging" ) @@ -40,324 +55,324 @@ func TestMain(m *testing.M) { // 3. Hanging may be not the problem of the DMSG. Probably some of the communication part here is wrong. // The reason I think so is that - if we ensure read timeouts, why doesn't this test constantly fail? // Maybe some wrapper for DMSG is wrong, or some internal operations before the actual communication behave bad -//func TestNode(t *testing.T) { -// // Prepare mock dmsg discovery. -// discovery := disc.NewMock() -// -// // Prepare dmsg server. -// server, serverErr := createServer(t, discovery) -// defer func() { -// require.NoError(t, server.Close()) -// require.NoError(t, errWithTimeout(serverErr)) -// }() -// -// type clientWithDMSGAddrAndListener struct { -// *dmsg.Client -// Addr dmsg.Addr -// Listener *dmsg.Listener -// } -// -// // CLOSURE: sets up dmsg clients. -// prepClients := func(n int) ([]clientWithDMSGAddrAndListener, func()) { -// clients := make([]clientWithDMSGAddrAndListener, n) -// for i := 0; i < n; i++ { -// var port uint16 -// // setup node -// if i == 0 { -// port = snet.SetupPort -// } else { -// port = snet.AwaitSetupPort -// } -// pk, sk, err := cipher.GenerateDeterministicKeyPair([]byte{byte(i)}) -// require.NoError(t, err) -// t.Logf("client[%d] PK: %s\n", i, pk) -// c := dmsg.NewClient(pk, sk, discovery, dmsg.SetLogger(logging.MustGetLogger(fmt.Sprintf("client_%d:%s:%d", i, pk, port)))) -// require.NoError(t, c.InitiateServerConnections(context.TODO(), 1)) -// listener, err := c.Listen(port) -// require.NoError(t, err) -// clients[i] = clientWithDMSGAddrAndListener{ -// Client: c, -// Addr: dmsg.Addr{ -// PK: pk, -// Port: port, -// }, -// Listener: listener, -// } -// } -// return clients, func() { -// for _, c := range clients { -// //require.NoError(t, c.Listener.Close()) -// require.NoError(t, c.Close()) -// } -// } -// } -// -// // CLOSURE: sets up setup node. -// prepSetupNode := func(c *dmsg.Client, listener *dmsg.Listener) (*Node, func()) { -// sn := &Node{ -// Logger: logging.MustGetLogger("setup_node"), -// dmsgC: c, -// dmsgL: listener, -// metrics: metrics.NewDummy(), -// } -// go func() { -// if err := sn.Serve(context.TODO()); err != nil { -// sn.Logger.WithError(err).Error("Failed to serve") -// } -// }() -// return sn, func() { -// require.NoError(t, sn.Close()) -// } -// } -// -// // TEST: Emulates the communication between 4 visor nodes and a setup node, -// // where the first client node initiates a loop to the last. -// t.Run("CreateLoop", func(t *testing.T) { -// // client index 0 is for setup node. -// // clients index 1 to 4 are for visor nodes. -// clients, closeClients := prepClients(5) -// defer closeClients() -// -// // prepare and serve setup node (using client 0). -// _, closeSetup := prepSetupNode(clients[0].Client, clients[0].Listener) -// setupPK := clients[0].Addr.PK -// setupPort := clients[0].Addr.Port -// defer closeSetup() -// -// // prepare loop creation (client_1 will use this to request loop creation with setup node). -// ld := routing.LoopDescriptor{ -// Loop: routing.Loop{ -// Local: routing.Addr{PubKey: clients[1].Addr.PK, Port: 1}, -// Remote: routing.Addr{PubKey: clients[4].Addr.PK, Port: 1}, -// }, -// Reverse: routing.Route{ -// &routing.Hop{From: clients[1].Addr.PK, To: clients[2].Addr.PK, Transport: uuid.New()}, -// &routing.Hop{From: clients[2].Addr.PK, To: clients[3].Addr.PK, Transport: uuid.New()}, -// &routing.Hop{From: clients[3].Addr.PK, To: clients[4].Addr.PK, Transport: uuid.New()}, -// }, -// Forward: routing.Route{ -// &routing.Hop{From: clients[4].Addr.PK, To: clients[3].Addr.PK, Transport: uuid.New()}, -// &routing.Hop{From: clients[3].Addr.PK, To: clients[2].Addr.PK, Transport: uuid.New()}, -// &routing.Hop{From: clients[2].Addr.PK, To: clients[1].Addr.PK, Transport: uuid.New()}, -// }, -// KeepAlive: 1 * time.Hour, -// } -// -// // client_1 initiates loop creation with setup node. -// iTp, err := clients[1].Dial(context.TODO(), setupPK, setupPort) -// require.NoError(t, err) -// iTpErrs := make(chan error, 2) -// go func() { -// iTpErrs <- CreateLoop(context.TODO(), NewSetupProtocol(iTp), ld) -// iTpErrs <- iTp.Close() -// close(iTpErrs) -// }() -// defer func() { -// i := 0 -// for err := range iTpErrs { -// require.NoError(t, err, i) -// i++ -// } -// }() -// -// var addRuleDone sync.WaitGroup -// var nextRouteID uint32 -// // CLOSURE: emulates how a visor node should react when expecting an AddRules packet. -// expectAddRules := func(client int, expRule routing.RuleType) { -// conn, err := clients[client].Listener.Accept() -// require.NoError(t, err) -// -// fmt.Printf("client %v:%v accepted\n", client, clients[client].Addr) -// -// proto := NewSetupProtocol(conn) -// -// pt, _, err := proto.ReadPacket() -// require.NoError(t, err) -// require.Equal(t, PacketRequestRouteID, pt) -// -// fmt.Printf("client %v:%v got PacketRequestRouteID\n", client, clients[client].Addr) -// -// routeID := atomic.AddUint32(&nextRouteID, 1) -// -// // TODO: This error is not checked due to a bug in dmsg. -// _ = proto.WritePacket(RespSuccess, []routing.RouteID{routing.RouteID(routeID)}) // nolint:errcheck -// require.NoError(t, err) -// -// fmt.Printf("client %v:%v responded to with registration ID: %v\n", client, clients[client].Addr, routeID) -// -// require.NoError(t, conn.Close()) -// -// conn, err = clients[client].Listener.Accept() -// require.NoError(t, err) -// -// fmt.Printf("client %v:%v accepted 2nd time\n", client, clients[client].Addr) -// -// proto = NewSetupProtocol(conn) -// -// pt, pp, err := proto.ReadPacket() -// require.NoError(t, err) -// require.Equal(t, PacketAddRules, pt) -// -// fmt.Printf("client %v:%v got PacketAddRules\n", client, clients[client].Addr) -// -// var rs []routing.Rule -// require.NoError(t, json.Unmarshal(pp, &rs)) -// -// for _, r := range rs { -// require.Equal(t, expRule, r.Type()) -// } -// -// // TODO: This error is not checked due to a bug in dmsg. -// err = proto.WritePacket(RespSuccess, nil) -// _ = err -// -// fmt.Printf("client %v:%v responded for PacketAddRules\n", client, clients[client].Addr) -// -// require.NoError(t, conn.Close()) -// -// addRuleDone.Done() -// } -// -// // CLOSURE: emulates how a visor node should react when expecting an OnConfirmLoop packet. -// expectConfirmLoop := func(client int) { -// tp, err := clients[client].Listener.AcceptTransport() -// require.NoError(t, err) -// -// proto := NewSetupProtocol(tp) -// -// pt, pp, err := proto.ReadPacket() -// require.NoError(t, err) -// require.Equal(t, PacketConfirmLoop, pt) -// -// var d routing.LoopData -// require.NoError(t, json.Unmarshal(pp, &d)) -// -// switch client { -// case 1: -// require.Equal(t, ld.Loop, d.Loop) -// case 4: -// require.Equal(t, ld.Loop.Local, d.Loop.Remote) -// require.Equal(t, ld.Loop.Remote, d.Loop.Local) -// default: -// t.Fatalf("We shouldn't be receiving a OnConfirmLoop packet from client %d", client) -// } -// -// // TODO: This error is not checked due to a bug in dmsg. -// err = proto.WritePacket(RespSuccess, nil) -// _ = err -// -// require.NoError(t, tp.Close()) -// } -// -// // since the route establishment is asynchronous, -// // we must expect all the messages in parallel -// addRuleDone.Add(4) -// go expectAddRules(4, routing.RuleApp) -// go expectAddRules(3, routing.RuleForward) -// go expectAddRules(2, routing.RuleForward) -// go expectAddRules(1, routing.RuleForward) -// addRuleDone.Wait() -// fmt.Println("FORWARD ROUTE DONE") -// addRuleDone.Add(4) -// go expectAddRules(1, routing.RuleApp) -// go expectAddRules(2, routing.RuleForward) -// go expectAddRules(3, routing.RuleForward) -// go expectAddRules(4, routing.RuleForward) -// addRuleDone.Wait() -// fmt.Println("REVERSE ROUTE DONE") -// expectConfirmLoop(1) -// expectConfirmLoop(4) -// }) -// -// // TEST: Emulates the communication between 2 visor nodes and a setup nodes, -// // where a route is already established, -// // and the first client attempts to tear it down. -// t.Run("CloseLoop", func(t *testing.T) { -// // client index 0 is for setup node. -// // clients index 1 and 2 are for visor nodes. -// clients, closeClients := prepClients(3) -// defer closeClients() -// -// // prepare and serve setup node. -// _, closeSetup := prepSetupNode(clients[0].Client, clients[0].Listener) -// setupPK := clients[0].Addr.PK -// setupPort := clients[0].Addr.Port -// defer closeSetup() -// -// // prepare loop data describing the loop that is to be closed. -// ld := routing.LoopData{ -// Loop: routing.Loop{ -// Local: routing.Addr{ -// PubKey: clients[1].Addr.PK, -// Port: 1, -// }, -// Remote: routing.Addr{ -// PubKey: clients[2].Addr.PK, -// Port: 2, -// }, -// }, -// RouteID: 3, -// } -// -// // client_1 initiates close loop with setup node. -// iTp, err := clients[1].Dial(context.TODO(), setupPK, setupPort) -// require.NoError(t, err) -// iTpErrs := make(chan error, 2) -// go func() { -// iTpErrs <- CloseLoop(context.TODO(), NewSetupProtocol(iTp), ld) -// iTpErrs <- iTp.Close() -// close(iTpErrs) -// }() -// defer func() { -// i := 0 -// for err := range iTpErrs { -// require.NoError(t, err, i) -// i++ -// } -// }() -// -// // client_2 accepts close request. -// tp, err := clients[2].Listener.AcceptTransport() -// require.NoError(t, err) -// defer func() { require.NoError(t, tp.Close()) }() -// -// proto := NewSetupProtocol(tp) -// -// pt, pp, err := proto.ReadPacket() -// require.NoError(t, err) -// require.Equal(t, PacketLoopClosed, pt) -// -// var d routing.LoopData -// require.NoError(t, json.Unmarshal(pp, &d)) -// require.Equal(t, ld.Loop.Remote, d.Loop.Local) -// require.Equal(t, ld.Loop.Local, d.Loop.Remote) -// -// // TODO: This error is not checked due to a bug in dmsg. -// err = proto.WritePacket(RespSuccess, nil) -// _ = err -// }) -//} -// -//func createServer(t *testing.T, dc disc.APIClient) (srv *dmsg.Server, srvErr <-chan error) { -// pk, sk, err := cipher.GenerateDeterministicKeyPair([]byte("s")) -// require.NoError(t, err) -// l, err := nettest.NewLocalListener("tcp") -// require.NoError(t, err) -// srv, err = dmsg.NewServer(pk, sk, "", l, dc) -// require.NoError(t, err) -// errCh := make(chan error, 1) -// go func() { -// errCh <- srv.Serve() -// close(errCh) -// }() -// return srv, errCh -//} -// -//func errWithTimeout(ch <-chan error) error { -// select { -// case err := <-ch: -// return err -// case <-time.After(5 * time.Second): -// return errors.New("timeout") -// } -//} +func TestNode(t *testing.T) { + // Prepare mock dmsg discovery. + discovery := disc.NewMock() + + // Prepare dmsg server. + server, serverErr := createServer(t, discovery) + defer func() { + require.NoError(t, server.Close()) + require.NoError(t, errWithTimeout(serverErr)) + }() + + type clientWithDMSGAddrAndListener struct { + *dmsg.Client + Addr dmsg.Addr + Listener *dmsg.Listener + } + + // CLOSURE: sets up dmsg clients. + prepClients := func(n int) ([]clientWithDMSGAddrAndListener, func()) { + clients := make([]clientWithDMSGAddrAndListener, n) + for i := 0; i < n; i++ { + var port uint16 + // setup node + if i == 0 { + port = snet.SetupPort + } else { + port = snet.AwaitSetupPort + } + pk, sk, err := cipher.GenerateDeterministicKeyPair([]byte{byte(i)}) + require.NoError(t, err) + t.Logf("client[%d] PK: %s\n", i, pk) + c := dmsg.NewClient(pk, sk, discovery, dmsg.SetLogger(logging.MustGetLogger(fmt.Sprintf("client_%d:%s:%d", i, pk, port)))) + require.NoError(t, c.InitiateServerConnections(context.TODO(), 1)) + listener, err := c.Listen(port) + require.NoError(t, err) + clients[i] = clientWithDMSGAddrAndListener{ + Client: c, + Addr: dmsg.Addr{ + PK: pk, + Port: port, + }, + Listener: listener, + } + } + return clients, func() { + for _, c := range clients { + //require.NoError(t, c.Listener.Close()) + require.NoError(t, c.Close()) + } + } + } + + // CLOSURE: sets up setup node. + prepSetupNode := func(c *dmsg.Client, listener *dmsg.Listener) (*Node, func()) { + sn := &Node{ + Logger: logging.MustGetLogger("setup_node"), + dmsgC: c, + dmsgL: listener, + metrics: metrics.NewDummy(), + } + go func() { + if err := sn.Serve(context.TODO()); err != nil { + sn.Logger.WithError(err).Error("Failed to serve") + } + }() + return sn, func() { + require.NoError(t, sn.Close()) + } + } + + //// TEST: Emulates the communication between 4 visor nodes and a setup node, + //// where the first client node initiates a loop to the last. + //t.Run("CreateLoop", func(t *testing.T) { + // // client index 0 is for setup node. + // // clients index 1 to 4 are for visor nodes. + // clients, closeClients := prepClients(5) + // defer closeClients() + // + // // prepare and serve setup node (using client 0). + // _, closeSetup := prepSetupNode(clients[0].Client, clients[0].Listener) + // setupPK := clients[0].Addr.PK + // setupPort := clients[0].Addr.Port + // defer closeSetup() + // + // // prepare loop creation (client_1 will use this to request loop creation with setup node). + // ld := routing.LoopDescriptor{ + // Loop: routing.Loop{ + // Local: routing.Addr{PubKey: clients[1].Addr.PK, Port: 1}, + // Remote: routing.Addr{PubKey: clients[4].Addr.PK, Port: 1}, + // }, + // Reverse: routing.Route{ + // &routing.Hop{From: clients[1].Addr.PK, To: clients[2].Addr.PK, Transport: uuid.New()}, + // &routing.Hop{From: clients[2].Addr.PK, To: clients[3].Addr.PK, Transport: uuid.New()}, + // &routing.Hop{From: clients[3].Addr.PK, To: clients[4].Addr.PK, Transport: uuid.New()}, + // }, + // Forward: routing.Route{ + // &routing.Hop{From: clients[4].Addr.PK, To: clients[3].Addr.PK, Transport: uuid.New()}, + // &routing.Hop{From: clients[3].Addr.PK, To: clients[2].Addr.PK, Transport: uuid.New()}, + // &routing.Hop{From: clients[2].Addr.PK, To: clients[1].Addr.PK, Transport: uuid.New()}, + // }, + // KeepAlive: 1 * time.Hour, + // } + // + // // client_1 initiates loop creation with setup node. + // iTp, err := clients[1].Dial(context.TODO(), setupPK, setupPort) + // require.NoError(t, err) + // iTpErrs := make(chan error, 2) + // go func() { + // iTpErrs <- CreateLoop(context.TODO(), NewSetupProtocol(iTp), ld) + // iTpErrs <- iTp.Close() + // close(iTpErrs) + // }() + // defer func() { + // i := 0 + // for err := range iTpErrs { + // require.NoError(t, err, i) + // i++ + // } + // }() + // + // var addRuleDone sync.WaitGroup + // var nextRouteID uint32 + // // CLOSURE: emulates how a visor node should react when expecting an AddRules packet. + // expectAddRules := func(client int, expRule routing.RuleType) { + // conn, err := clients[client].Listener.Accept() + // require.NoError(t, err) + // + // fmt.Printf("client %v:%v accepted\n", client, clients[client].Addr) + // + // proto := NewSetupProtocol(conn) + // + // pt, _, err := proto.ReadPacket() + // require.NoError(t, err) + // require.Equal(t, PacketRequestRouteID, pt) + // + // fmt.Printf("client %v:%v got PacketRequestRouteID\n", client, clients[client].Addr) + // + // routeID := atomic.AddUint32(&nextRouteID, 1) + // + // // TODO: This error is not checked due to a bug in dmsg. + // _ = proto.WritePacket(RespSuccess, []routing.RouteID{routing.RouteID(routeID)}) // nolint:errcheck + // require.NoError(t, err) + // + // fmt.Printf("client %v:%v responded to with registration ID: %v\n", client, clients[client].Addr, routeID) + // + // require.NoError(t, conn.Close()) + // + // conn, err = clients[client].Listener.Accept() + // require.NoError(t, err) + // + // fmt.Printf("client %v:%v accepted 2nd time\n", client, clients[client].Addr) + // + // proto = NewSetupProtocol(conn) + // + // pt, pp, err := proto.ReadPacket() + // require.NoError(t, err) + // require.Equal(t, PacketAddRules, pt) + // + // fmt.Printf("client %v:%v got PacketAddRules\n", client, clients[client].Addr) + // + // var rs []routing.Rule + // require.NoError(t, json.Unmarshal(pp, &rs)) + // + // for _, r := range rs { + // require.Equal(t, expRule, r.Type()) + // } + // + // // TODO: This error is not checked due to a bug in dmsg. + // err = proto.WritePacket(RespSuccess, nil) + // _ = err + // + // fmt.Printf("client %v:%v responded for PacketAddRules\n", client, clients[client].Addr) + // + // require.NoError(t, conn.Close()) + // + // addRuleDone.Done() + // } + // + // // CLOSURE: emulates how a visor node should react when expecting an OnConfirmLoop packet. + // expectConfirmLoop := func(client int) { + // tp, err := clients[client].Listener.AcceptTransport() + // require.NoError(t, err) + // + // proto := NewSetupProtocol(tp) + // + // pt, pp, err := proto.ReadPacket() + // require.NoError(t, err) + // require.Equal(t, PacketConfirmLoop, pt) + // + // var d routing.LoopData + // require.NoError(t, json.Unmarshal(pp, &d)) + // + // switch client { + // case 1: + // require.Equal(t, ld.Loop, d.Loop) + // case 4: + // require.Equal(t, ld.Loop.Local, d.Loop.Remote) + // require.Equal(t, ld.Loop.Remote, d.Loop.Local) + // default: + // t.Fatalf("We shouldn't be receiving a OnConfirmLoop packet from client %d", client) + // } + // + // // TODO: This error is not checked due to a bug in dmsg. + // err = proto.WritePacket(RespSuccess, nil) + // _ = err + // + // require.NoError(t, tp.Close()) + // } + // + // // since the route establishment is asynchronous, + // // we must expect all the messages in parallel + // addRuleDone.Add(4) + // go expectAddRules(4, routing.RuleApp) + // go expectAddRules(3, routing.RuleForward) + // go expectAddRules(2, routing.RuleForward) + // go expectAddRules(1, routing.RuleForward) + // addRuleDone.Wait() + // fmt.Println("FORWARD ROUTE DONE") + // addRuleDone.Add(4) + // go expectAddRules(1, routing.RuleApp) + // go expectAddRules(2, routing.RuleForward) + // go expectAddRules(3, routing.RuleForward) + // go expectAddRules(4, routing.RuleForward) + // addRuleDone.Wait() + // fmt.Println("REVERSE ROUTE DONE") + // expectConfirmLoop(1) + // expectConfirmLoop(4) + //}) + + // TEST: Emulates the communication between 2 visor nodes and a setup nodes, + // where a route is already established, + // and the first client attempts to tear it down. + t.Run("CloseLoop", func(t *testing.T) { + // client index 0 is for setup node. + // clients index 1 and 2 are for visor nodes. + clients, closeClients := prepClients(3) + defer closeClients() + + // prepare and serve setup node. + _, closeSetup := prepSetupNode(clients[0].Client, clients[0].Listener) + setupPK := clients[0].Addr.PK + setupPort := clients[0].Addr.Port + defer closeSetup() + + // prepare loop data describing the loop that is to be closed. + ld := routing.LoopData{ + Loop: routing.Loop{ + Local: routing.Addr{ + PubKey: clients[1].Addr.PK, + Port: 1, + }, + Remote: routing.Addr{ + PubKey: clients[2].Addr.PK, + Port: 2, + }, + }, + RouteID: 3, + } + + // client_1 initiates close loop with setup node. + iTp, err := clients[1].Dial(context.TODO(), setupPK, setupPort) + require.NoError(t, err) + iTpErrs := make(chan error, 2) + go func() { + iTpErrs <- CloseLoop(context.TODO(), NewSetupProtocol(iTp), ld) + iTpErrs <- iTp.Close() + close(iTpErrs) + }() + defer func() { + i := 0 + for err := range iTpErrs { + require.NoError(t, err, i) + i++ + } + }() + + // client_2 accepts close request. + tp, err := clients[2].Listener.AcceptTransport() + require.NoError(t, err) + defer func() { require.NoError(t, tp.Close()) }() + + proto := NewSetupProtocol(tp) + + pt, pp, err := proto.ReadPacket() + require.NoError(t, err) + require.Equal(t, PacketLoopClosed, pt) + + var d routing.LoopData + require.NoError(t, json.Unmarshal(pp, &d)) + require.Equal(t, ld.Loop.Remote, d.Loop.Local) + require.Equal(t, ld.Loop.Local, d.Loop.Remote) + + // TODO: This error is not checked due to a bug in dmsg. + err = proto.WritePacket(RespSuccess, nil) + _ = err + }) +} + +func createServer(t *testing.T, dc disc.APIClient) (srv *dmsg.Server, srvErr <-chan error) { + pk, sk, err := cipher.GenerateDeterministicKeyPair([]byte("s")) + require.NoError(t, err) + l, err := nettest.NewLocalListener("tcp") + require.NoError(t, err) + srv, err = dmsg.NewServer(pk, sk, "", l, dc) + require.NoError(t, err) + errCh := make(chan error, 1) + go func() { + errCh <- srv.Serve() + close(errCh) + }() + return srv, errCh +} + +func errWithTimeout(ch <-chan error) error { + select { + case err := <-ch: + return err + case <-time.After(5 * time.Second): + return errors.New("timeout") + } +} diff --git a/pkg/setup/protocol.go b/pkg/setup/protocol.go index 8167c27be..8421406d9 100644 --- a/pkg/setup/protocol.go +++ b/pkg/setup/protocol.go @@ -34,7 +34,7 @@ func (sp PacketType) String() string { case RespFailure: return "Failure" case PacketRequestRouteID: - return "RequestRouteID" + return "RequestRouteIDs" } return fmt.Sprintf("Unknown(%d)", sp) } @@ -52,7 +52,7 @@ const ( PacketCloseLoop // PacketLoopClosed represents OnLoopClosed foundation packet. PacketLoopClosed - // PacketRequestRouteID represents RequestRouteID foundation packet. + // PacketRequestRouteID represents RequestRouteIDs foundation packet. PacketRequestRouteID // RespFailure represents failure response for a foundation packet. @@ -113,24 +113,24 @@ func (p *Protocol) Close() error { return nil } -// RequestRouteID sends RequestRouteID request. -func RequestRouteID(ctx context.Context, p *Protocol) (routing.RouteID, error) { - if err := p.WritePacket(PacketRequestRouteID, nil); err != nil { - return 0, err +// RequestRouteIDs sends RequestRouteIDs request. +func RequestRouteIDs(ctx context.Context, p *Protocol, n uint8) ([]routing.RouteID, error) { + if err := p.WritePacket(PacketRequestRouteID, n); err != nil { + return nil, err } var res []routing.RouteID if err := readAndDecodePacketWithTimeout(ctx, p, &res); err != nil { - return 0, err + return nil, err } - if len(res) == 0 { - return 0, errors.New("empty response") + if len(res) != int(n) { + return nil, errors.New("invalid response: wrong number of routeIDs") } - return res[0], nil + return res, nil } -// AddRule sends AddRule setup request. -func AddRule(ctx context.Context, p *Protocol, rule routing.Rule) error { - if err := p.WritePacket(PacketAddRules, []routing.Rule{rule}); err != nil { +// AddRules sends AddRule setup request. +func AddRules(ctx context.Context, p *Protocol, rules []routing.Rule) error { + if err := p.WritePacket(PacketAddRules, rules); err != nil { return err } return readAndDecodePacketWithTimeout(ctx, p, nil) @@ -197,6 +197,9 @@ func readAndDecodePacketWithTimeout(ctx context.Context, p *Protocol, v interfac case <-ctx.Done(): return ctx.Err() case <-done: + if err == io.ErrClosedPipe { + return nil + } return err } } diff --git a/pkg/visor/rpc_client.go b/pkg/visor/rpc_client.go index a2e0c8e95..c9464b55a 100644 --- a/pkg/visor/rpc_client.go +++ b/pkg/visor/rpc_client.go @@ -12,6 +12,7 @@ import ( "github.com/google/uuid" "github.com/skycoin/dmsg/cipher" "github.com/skycoin/skycoin/src/util/logging" + "github.com/skycoin/skywire/pkg/app" "github.com/skycoin/skywire/pkg/router" "github.com/skycoin/skywire/pkg/routing" From 660908ff9d89e00066a7a14469a9562cdc949a16 Mon Sep 17 00:00:00 2001 From: Evan Lin Date: Mon, 9 Sep 2019 02:50:28 +0800 Subject: [PATCH 05/14] Re-added initTransports for transport.Manager This was removed for some reason, but it needs to exist in order to reestablish transports on visor restart. --- pkg/transport/manager.go | 22 ++++++++++++++++++++++ 1 file changed, 22 insertions(+) diff --git a/pkg/transport/manager.go b/pkg/transport/manager.go index ccc246207..3b2b1307e 100644 --- a/pkg/transport/manager.go +++ b/pkg/transport/manager.go @@ -100,6 +100,8 @@ func (tm *Manager) serve(ctx context.Context) { } }() } + + tm.initTransports(ctx) tm.Logger.Info("transport manager is serving.") // closing logic @@ -116,6 +118,26 @@ func (tm *Manager) serve(ctx context.Context) { } } +func (tm *Manager) initTransports(ctx context.Context) { + tm.mx.Lock() + defer tm.mx.Unlock() + + entries, err := tm.conf.DiscoveryClient.GetTransportsByEdge(ctx, tm.conf.PubKey) + if err != nil { + log.Warnf("No transports found for local node: %v", err) + } + for _, entry := range entries { + var ( + tpType = entry.Entry.Type + remote = entry.Entry.RemoteEdge(tm.conf.PubKey) + tpID = entry.Entry.ID + ) + if _, err := tm.saveTransport(remote, tpType); err != nil { + tm.Logger.Warnf("INIT: failed to init tp: type(%s) remote(%s) tpID(%s)", tpType, remote, tpID) + } + } +} + func (tm *Manager) acceptTransport(ctx context.Context, lis *snet.Listener) error { conn, err := lis.AcceptConn() // TODO: tcp panic. if err != nil { From 5a66ea661348681e353c87dcde20b2c3a515e95c Mon Sep 17 00:00:00 2001 From: ivcosla Date: Mon, 9 Sep 2019 11:11:04 +0200 Subject: [PATCH 06/14] fixed tests, moved network listener to cmd, renamed disc address --- cmd/hypervisor/commands/root.go | 19 +++++++++++++++++- pkg/hypervisor/config.go | 14 ++++++------- pkg/hypervisor/hypervisor.go | 35 +++++++++------------------------ 3 files changed, 34 insertions(+), 34 deletions(-) diff --git a/cmd/hypervisor/commands/root.go b/cmd/hypervisor/commands/root.go index fdccee3cc..05df184cb 100644 --- a/cmd/hypervisor/commands/root.go +++ b/cmd/hypervisor/commands/root.go @@ -1,6 +1,7 @@ package commands import ( + "context" "fmt" "net/http" "os" @@ -65,7 +66,23 @@ var rootCmd = &cobra.Command{ if err != nil { log.Fatalln("Failed to parse rpc port from rpc address:", err) } - l, err := m.Network.Listen(snet.DmsgType, rpcPort) + + dmsgConf := snet.Config{ + PubKey: config.PK, + SecKey: config.SK, + TpNetworks: []string{snet.DmsgType}, + + DmsgDiscAddr: config.DmsgDiscovery, + DmsgMinSrvs: 1, + } + + network := snet.New(dmsgConf) + + ctx := context.Background() + if err := network.Init(ctx); err != nil { + log.Fatalln("failed to init network: %v", err) + } + l, err := network.Listen(snet.DmsgType, rpcPort) if err != nil { log.Fatalln("Failed to bind tcp port:", err) } diff --git a/pkg/hypervisor/config.go b/pkg/hypervisor/config.go index 4ea28eeb4..beba50a16 100644 --- a/pkg/hypervisor/config.go +++ b/pkg/hypervisor/config.go @@ -37,13 +37,13 @@ func (hk *Key) UnmarshalText(text []byte) error { // Config configures the hypervisor. type Config struct { - PK cipher.PubKey `json:"public_key"` - SK cipher.SecKey `json:"secret_key"` - DBPath string `json:"db_path"` // Path to store database file. - EnableAuth bool `json:"enable_auth"` // Whether to enable user management. - Cookies CookieConfig `json:"cookies"` // Configures cookies (for session management). - Interfaces InterfaceConfig `json:"interfaces"` // Configures exposed interfaces. - MessagingDiscovery string `json:"messaging_discovery"` // MessagingDiscovery address for dmsg usage + PK cipher.PubKey `json:"public_key"` + SK cipher.SecKey `json:"secret_key"` + DBPath string `json:"db_path"` // Path to store database file. + EnableAuth bool `json:"enable_auth"` // Whether to enable user management. + Cookies CookieConfig `json:"cookies"` // Configures cookies (for session management). + Interfaces InterfaceConfig `json:"interfaces"` // Configures exposed interfaces. + DmsgDiscovery string `json:"dmsg_discovery"` // DmsgDiscovery address for dmsg usage } func makeConfig() Config { diff --git a/pkg/hypervisor/hypervisor.go b/pkg/hypervisor/hypervisor.go index 87945422e..43ff31a6f 100644 --- a/pkg/hypervisor/hypervisor.go +++ b/pkg/hypervisor/hypervisor.go @@ -2,7 +2,6 @@ package hypervisor import ( - "context" "encoding/hex" "errors" "fmt" @@ -39,47 +38,31 @@ type appNodeConn struct { // Node manages AppNodes. type Node struct { - c Config - nodes map[cipher.PubKey]appNodeConn // connected remote nodes. - users *UserManager - mu *sync.RWMutex - Network *snet.Network + c Config + nodes map[cipher.PubKey]appNodeConn // connected remote nodes. + users *UserManager + mu *sync.RWMutex } // NewNode creates a new Node. func NewNode(config Config) (*Node, error) { - ctx := context.Background() - boltUserDB, err := NewBoltUserStore(config.DBPath) if err != nil { return nil, err } singleUserDB := NewSingleUserStore("admin", boltUserDB) - dmsgConf := snet.Config{ - PubKey: config.PK, - SecKey: config.SK, - TpNetworks: []string{snet.DmsgType}, - - DmsgDiscAddr: config.MessagingDiscovery, - DmsgMinSrvs: 1, - } - - network := snet.New(dmsgConf) - if err := network.Init(ctx); err != nil { - return nil, fmt.Errorf("failed to init network: %v", err) - } return &Node{ - c: config, - nodes: make(map[cipher.PubKey]appNodeConn), - users: NewUserManager(singleUserDB, config.Cookies), - mu: new(sync.RWMutex), - Network: network, + c: config, + nodes: make(map[cipher.PubKey]appNodeConn), + users: NewUserManager(singleUserDB, config.Cookies), + mu: new(sync.RWMutex), }, nil } // ServeRPC serves RPC of a Node. func (m *Node) ServeRPC(lis *snet.Listener) error { + for { conn, err := lis.AcceptConn() if err != nil { From c7dbfda277c3df59ae3a871158056849efe8eb91 Mon Sep 17 00:00:00 2001 From: ivcosla Date: Tue, 10 Sep 2019 12:44:28 +0200 Subject: [PATCH 07/14] fixed minor error, updated postman and added retrial --- cmd/hypervisor/commands/root.go | 21 +- .../hypervisor.postman_collection.json | 1827 ++++++++++------- pkg/app/log_store_test.go | 1 - pkg/hypervisor/hypervisor.go | 8 +- pkg/visor/visor.go | 10 +- 5 files changed, 1060 insertions(+), 807 deletions(-) diff --git a/cmd/hypervisor/commands/root.go b/cmd/hypervisor/commands/root.go index 05df184cb..0ea9dfa31 100644 --- a/cmd/hypervisor/commands/root.go +++ b/cmd/hypervisor/commands/root.go @@ -6,9 +6,10 @@ import ( "net/http" "os" + "github.com/skycoin/dmsg" + "github.com/skycoin/dmsg/disc" "github.com/skycoin/skycoin/src/util/logging" "github.com/skycoin/skywire/pkg/hypervisor" - "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/skywire/pkg/util/pathutil" "github.com/spf13/cobra" ) @@ -67,25 +68,17 @@ var rootCmd = &cobra.Command{ log.Fatalln("Failed to parse rpc port from rpc address:", err) } - dmsgConf := snet.Config{ - PubKey: config.PK, - SecKey: config.SK, - TpNetworks: []string{snet.DmsgType}, - - DmsgDiscAddr: config.DmsgDiscovery, - DmsgMinSrvs: 1, - } - - network := snet.New(dmsgConf) + dmsgC := dmsg.NewClient(config.PK, config.SK, disc.NewHTTP(config.DmsgDiscovery)) ctx := context.Background() - if err := network.Init(ctx); err != nil { - log.Fatalln("failed to init network: %v", err) + if err = dmsgC.InitiateServerConnections(ctx, 1); err != nil { + log.Fatalln("failed to initiate dmsg server connections:", err) } - l, err := network.Listen(snet.DmsgType, rpcPort) + l, err := dmsgC.Listen(rpcPort) if err != nil { log.Fatalln("Failed to bind tcp port:", err) } + if err := m.ServeRPC(l); err != nil { log.Fatalln("Failed to serve RPC:", err) } diff --git a/cmd/hypervisor/hypervisor.postman_collection.json b/cmd/hypervisor/hypervisor.postman_collection.json index 665b29e9a..53fe1ffb2 100644 --- a/cmd/hypervisor/hypervisor.postman_collection.json +++ b/cmd/hypervisor/hypervisor.postman_collection.json @@ -1,788 +1,1041 @@ { - "info": { - "_postman_id": "daa8ec31-db75-4e92-b637-c5117644bfa8", - "name": "Skywire Hypervisor", - "schema": "https://schema.getpostman.com/json/collection/v2.1.0/collection.json" - }, - "item": [ - { - "name": "/api/nodes", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes" - ] - }, - "description": "Provides a summary of all connected app nodes." - }, - "response": [ - { - "name": "/api/nodes", - "originalRequest": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 00:43:57 GMT" - }, - { - "key": "Transfer-Encoding", - "value": "chunked" - } - ], - "cookie": [], - "body": "[\n {\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"3fb65ceb-0cd3-484c-8a9c-21617a06c6dd\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"028825991ec52e8f135b9cf9c9f740698644ea2f2144e43a537ad416601ee1d905\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"4cf57b61-8a31-4c8f-b328-b2533978c4e1\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02af5570345c43715442aabdc72de8faecbccc38058fa3be88da8d85afb95762e6\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"0d2d208f-8e10-4bb4-ada5-58ffa4256723\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"034b60e92c40f566e38753fd0e4bc680a0811d25bee949cb5fee4006e42599d6cd\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b1afc8fd-cb62-4993-9b5e-79267cdcf557\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02add975773c2b1429368c961b9159c14de7662f8185ac5cbf173161e4b9f32937\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"43301e4e-594a-422a-b7b1-7a27e39050a8\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"029e32e79f1a57aa42704d3d88618ef8458b12a8f897dbbb7eecec0a411820f7d4\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"2d92ce65-8e2f-45b9-be29-3057951f4821\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"037f94a6071e7cb5edd8039cef0269ba43e48ab290e6144c4195d05478d5b446fb\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"1046b7a7-50ec-4795-91cd-a2fed648f305\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"021a12b4514cadb248f65cb4c3b3c9eb32f631e1b9470509c44cd05758021cc32a\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n },\n {\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"2c3b35b3-866d-4931-b7b5-a67d59e3df42\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"03371b181c5faee70eb040c038c006e6642aa432d8072047348ae087519f3cc684\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"1744577b-e36b-468f-ba34-93d2614ff6e0\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"0289b6e477ebcda18a190e2a545e4606a70abdb724b676a60cea496f3a170334bc\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"c744dd91-d309-451a-b3aa-b452795e6551\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"02de6056801854c18538dde4b1be096f3fae25c7fe9092d86ad3cd9812a4d91630\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"24a6a15c-ae24-4e5d-826f-789d7c564016\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"0302f17f7dec96e7750ce771937e689e26ffd9366e7bd4d34832c8572d1d8a320e\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"5011d6cb-0a46-4131-aa2a-a78b2e02e269\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"0200730f65fd7b15a184de1d68305f3e7ca813ef7b7678cbead104b59459a44a49\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b5a795d8-ac72-497b-baa3-454adf6e036d\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"03fa52ac4e875d61d4e12bee02264b8030b927194e8ecb41ebc7e6e97c1de542e6\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"97b7ff16-a06d-4bb3-b22f-56550ce81bcf\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"03bf84c5cd8cdc85406bee299001b6e2991920118a978e186bb9d7f7adf4b9a22b\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n },\n {\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"fdb47e4e-64a4-4001-9213-4b7e53560dc1\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"0207ddf45bb57b4ef7a5c7b76b89464677569dcb585cf8627c788f3d44a3870e5e\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b0294a2f-6f57-4f2b-8624-c1ae5b347b31\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"032dbd4f2b2531db9fbd23f3e53365c7ade63d08154025af7d94e7a7b6d715f4d8\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"81579b6e-d8a7-4cab-b2f2-3ba72a8eae83\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"02b4bcabcaaef410f6b9744715a77e8442e7849452e7202a408daccc4b1c63622b\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"bee8e0ad-8190-4c8b-8323-9680bda05580\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"03f2cf69c598c4981a12f665e3b288f9a39d260a883217ed278b0bfc9871faecb4\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"339c3342-0285-454f-b1af-d328a2790767\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"02017acb7de8041df23508a82ed2d49ded03f000d19bc000eb120db80a793664f6\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"8be92ca7-795b-44f6-9c3c-b364cff45bd4\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"03bd2e96d3b56037bfd179b400a5f4953d46467e4913d1c4322c66c1bec11158be\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n },\n {\n \"local_pk\": \"03e26b70fa8de90444128d78909e10331683be7d304452def6f88ef13d19e2e22d\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": null\n },\n {\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"f40a8665-8687-461d-971a-2c93d234a449\",\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"remote_pk\": \"03455586704d340771740533b3b5fff25656877e5f1b9118245e3d7a9f1cd46fb8\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"a350e9e0-4cf9-4121-b5a6-65733264f7a4\",\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"remote_pk\": \"02bcd9e9540b7779b189841baa73cde2aaff4ae734acd4873155d9f578c69eb5d5\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"f7852f53-6758-40c5-b42d-d94331f3d82a\",\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"remote_pk\": \"0392ff06c76763808a9a3d43e5cdc8dfbbbd01efb7b58c1fc315208498cc95807c\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n }\n]" - } - ] - }, - { - "name": "/api/nodes/{pk}", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02" - ], - "query": [ - { - "key": "", - "value": "", - "disabled": true - } - ] - }, - "description": "Provides a summary of a given connected app node of public key." - }, - "response": [ - { - "name": "/api/nodes/:pk", - "originalRequest": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2" - ], - "query": [ - { - "key": "", - "value": "", - "disabled": true - } - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 00:47:03 GMT" - }, - { - "key": "Transfer-Encoding", - "value": "chunked" - } - ], - "cookie": [], - "body": "{\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"3fb65ceb-0cd3-484c-8a9c-21617a06c6dd\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"028825991ec52e8f135b9cf9c9f740698644ea2f2144e43a537ad416601ee1d905\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"4cf57b61-8a31-4c8f-b328-b2533978c4e1\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02af5570345c43715442aabdc72de8faecbccc38058fa3be88da8d85afb95762e6\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"0d2d208f-8e10-4bb4-ada5-58ffa4256723\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"034b60e92c40f566e38753fd0e4bc680a0811d25bee949cb5fee4006e42599d6cd\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b1afc8fd-cb62-4993-9b5e-79267cdcf557\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02add975773c2b1429368c961b9159c14de7662f8185ac5cbf173161e4b9f32937\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"43301e4e-594a-422a-b7b1-7a27e39050a8\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"029e32e79f1a57aa42704d3d88618ef8458b12a8f897dbbb7eecec0a411820f7d4\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"2d92ce65-8e2f-45b9-be29-3057951f4821\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"037f94a6071e7cb5edd8039cef0269ba43e48ab290e6144c4195d05478d5b446fb\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"1046b7a7-50ec-4795-91cd-a2fed648f305\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"021a12b4514cadb248f65cb4c3b3c9eb32f631e1b9470509c44cd05758021cc32a\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n}" - } - ] - }, - { - "name": "/api/nodes/{pk}/apps", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02/apps", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02", - "apps" - ] - }, - "description": "Provides a summary of an AppNode's apps." - }, - "response": [ - { - "name": "/api/nodes/:pk/apps", - "originalRequest": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2/apps", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2", - "apps" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 00:48:55 GMT" - }, - { - "key": "Content-Length", - "value": "119" - } - ], - "cookie": [], - "body": "[\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n]" - } - ] - }, - { - "name": "/api/nodes/{pk}/apps/{app}", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02/apps/foo.v1.0", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02", - "apps", - "foo.v1.0" - ] - }, - "description": "Starts an app on an AppNode." - }, - "response": [ - { - "name": "/api/nodes/:pk/apps/:app/start", - "originalRequest": { - "method": "POST", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2/apps/foo.v1.0/start", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2", - "apps", - "foo.v1.0", - "start" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 00:50:40 GMT" - }, - { - "key": "Content-Length", - "value": "130" - } - ], - "cookie": [], - "body": "{\n \"node\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"app\": \"foo.v1.0\",\n \"command\": \"StartApp\",\n \"success\": true\n}" - } - ] - }, - { - "name": "/api/nodes/{pk}/apps/{app}", - "request": { - "method": "PUT", - "header": [ - { - "key": "Content-Type", - "name": "Content-Type", - "value": "application/json", - "type": "text" - } - ], - "body": { - "mode": "raw", - "raw": "{\n\t\"autostart\": true,\n\t\"status\": 1\n}" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/apps/foo.v1.0", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "apps", - "foo.v1.0" - ] - }, - "description": "Starts an app on an AppNode." - }, - "response": [ - { - "name": "/api/nodes/{pk}/apps/{app}", - "originalRequest": { - "method": "PUT", - "header": [ - { - "key": "Content-Type", - "name": "Content-Type", - "value": "application/json", - "type": "text" - } - ], - "body": { - "mode": "raw", - "raw": "{\n\t\"autostart\": true,\n\t\"status\": 1\n}" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/apps/foo.v1.0", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "apps", - "foo.v1.0" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json" - }, - { - "key": "Date", - "value": "Sun, 17 Feb 2019 10:37:17 GMT" - }, - { - "key": "Content-Length", - "value": "58" - } - ], - "cookie": [], - "body": "{\n \"name\": \"foo.v1.0\",\n \"autostart\": true,\n \"port\": 10,\n \"status\": 0\n}" - } - ] - }, - { - "name": "/api/nodes/{pk}/transport-types", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transport-types", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "transport-types" - ] - }, - "description": "Lists supported transport types of the given AppNode." - }, - "response": [ - { - "name": "/api/nodes/:pk/transport-types", - "originalRequest": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transport-types", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", - "transport-types" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 01:14:08 GMT" - }, - { - "key": "Content-Length", - "value": "22" - } - ], - "cookie": [], - "body": "[\n \"messaging\",\n \"native\"\n]" - } - ] - }, - { - "name": "/api/nodes/{pk}/transports", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports?logs=true", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "transports" - ], - "query": [ - { - "key": "logs", - "value": "true", - "description": "whether to show with logs." - } - ] - }, - "description": "List transports of given AppNode." - }, - "response": [ - { - "name": "/api/nodes/:pk/transports", - "originalRequest": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports?logs=true", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", - "transports" - ], - "query": [ - { - "key": "logs", - "value": "true", - "description": "whether to show with logs." - } - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 01:15:50 GMT" - }, - { - "key": "Transfer-Encoding", - "value": "chunked" - } - ], - "cookie": [], - "body": "[\n {\n \"id\": \"e86f4d67-eb22-4d1c-8c27-8f021051a5cf\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"028684d27d1c9bc36406da560d3f75a295a54ad0649d54eb3437655d8524bbe279\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"2ff2d608-fe14-4c17-938c-3af8afd053ae\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02a2f9b005ce53b77499e73eb4b67d60807a32d1616615809408150d2ff2631da8\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"50142ec9-027d-490d-ba86-e335b6ffffa0\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02d2b79b0e37671e8da948ddb7a51b24096a7b7fe3a64403f78ab031816b3009f3\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"85a60d18-f1a3-45b1-b7cc-8906c95dfdb0\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02c5015450d929bb38c496505f3781d671a11f108cecc0ef6f4a9ff6cf841e5bcf\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"16575562-14c4-492d-9112-dc9f9d3f201d\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"0206ad1343becba521d66ce58b72b2fd8592c998f05ce6fb82a8ab44f3583f9023\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"d0fa7457-e887-406e-ac84-e009fe6df490\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"026202dd7119e8f0635ff1adb52e826fc107472319033db47dbff428b66d3474ae\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"236d2c10-5d92-4d64-b66a-42e2a60ac231\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"020906cf03d1037149150f3d4d06b242d3fa5a3ee6fc25edef6373061176ad5279\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"03c845c9-57b0-4b84-a184-70f952497a8a\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"0254cffd054fa00fa4c89f2b9d2ee3a52b69641bfd4a9e5ce59f5c086adf8d2e1e\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n]" - } - ] - }, - { - "name": "/api/nodes/{pk}/transports", - "request": { - "method": "POST", - "header": [ - { - "key": "Content-Type", - "name": "Content-Type", - "value": "application/json", - "type": "text" - } - ], - "body": { - "mode": "raw", - "raw": "{\n\t\"remote_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n\t\"transport_type\": \"native\",\n\t\"public\": true\n}" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "transports" - ] - }, - "description": "Adds a transport to a given AppNode." - }, - "response": [ - { - "name": "POST /api/nodes/transports", - "originalRequest": { - "method": "POST", - "header": [ - { - "key": "Content-Type", - "name": "Content-Type", - "value": "application/json", - "type": "text" - } - ], - "body": { - "mode": "raw", - "raw": "{\n\t\"remote_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n\t\"transport_type\": \"native\",\n\t\"public\": true\n}" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", - "transports" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 01:19:01 GMT" - }, - { - "key": "Content-Length", - "value": "258" - } - ], - "cookie": [], - "body": "{\n \"id\": \"7a4236d4-8ae4-478c-acd7-e3577d730a49\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n}" - } - ] - }, - { - "name": "/api/nodes/{pk}/transports/{tid}", - "request": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports/70836b44-f6e5-4c17-a5e8-e1cbef89a10f", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "transports", - "70836b44-f6e5-4c17-a5e8-e1cbef89a10f" - ] - }, - "description": "Obtains summary of transport of given TransportID and AppNode." - }, - "response": [ - { - "name": "/api/nodes/:pk/transports/:tid", - "originalRequest": { - "method": "GET", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports/2ff2d608-fe14-4c17-938c-3af8afd053ae", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", - "transports", - "2ff2d608-fe14-4c17-938c-3af8afd053ae" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 01:23:06 GMT" - }, - { - "key": "Content-Length", - "value": "261" - } - ], - "cookie": [], - "body": "{\n \"id\": \"2ff2d608-fe14-4c17-938c-3af8afd053ae\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02a2f9b005ce53b77499e73eb4b67d60807a32d1616615809408150d2ff2631da8\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n}" - } - ] - }, - { - "name": "DELETE /api/nodes/{pk}/transports/{tid}", - "request": { - "method": "DELETE", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports/d5ace20e-06c8-4867-bda2-9449459a9e5a", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", - "transports", - "d5ace20e-06c8-4867-bda2-9449459a9e5a" - ] - }, - "description": "Removes transport of given TransportID and AppNode." - }, - "response": [ - { - "name": "DELETE /api/nodes/:pk/transports/:tid", - "originalRequest": { - "method": "DELETE", - "header": [], - "body": { - "mode": "raw", - "raw": "" - }, - "url": { - "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports/2ff2d608-fe14-4c17-938c-3af8afd053ae", - "protocol": "http", - "host": [ - "localhost" - ], - "port": "8080", - "path": [ - "api", - "nodes", - "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", - "transports", - "2ff2d608-fe14-4c17-938c-3af8afd053ae" - ] - } - }, - "status": "OK", - "code": 200, - "_postman_previewlanguage": "json", - "header": [ - { - "key": "Content-Type", - "value": "application/json; charset=utf-8" - }, - { - "key": "Date", - "value": "Wed, 13 Feb 2019 01:24:20 GMT" - }, - { - "key": "Content-Length", - "value": "171" - } - ], - "cookie": [], - "body": "{\n \"node\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"transport\": \"2ff2d608-fe14-4c17-938c-3af8afd053ae\",\n \"command\": \"RemoveTransport\",\n \"success\": true\n}" - } - ] - } - ] -} + "info": { + "_postman_id": "dfdba35b-6b4f-4658-80e1-d57526f1059f", + "name": "Skywire Hypervisor", + "schema": "https://schema.getpostman.com/json/collection/v2.1.0/collection.json" + }, + "item": [ + { + "name": "/api/nodes", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes" + ] + }, + "description": "Provides a summary of all connected app nodes." + }, + "response": [ + { + "name": "/api/nodes", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 00:43:57 GMT" + }, + { + "key": "Transfer-Encoding", + "value": "chunked" + } + ], + "cookie": [], + "body": "[\n {\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"3fb65ceb-0cd3-484c-8a9c-21617a06c6dd\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"028825991ec52e8f135b9cf9c9f740698644ea2f2144e43a537ad416601ee1d905\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"4cf57b61-8a31-4c8f-b328-b2533978c4e1\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02af5570345c43715442aabdc72de8faecbccc38058fa3be88da8d85afb95762e6\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"0d2d208f-8e10-4bb4-ada5-58ffa4256723\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"034b60e92c40f566e38753fd0e4bc680a0811d25bee949cb5fee4006e42599d6cd\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b1afc8fd-cb62-4993-9b5e-79267cdcf557\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02add975773c2b1429368c961b9159c14de7662f8185ac5cbf173161e4b9f32937\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"43301e4e-594a-422a-b7b1-7a27e39050a8\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"029e32e79f1a57aa42704d3d88618ef8458b12a8f897dbbb7eecec0a411820f7d4\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"2d92ce65-8e2f-45b9-be29-3057951f4821\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"037f94a6071e7cb5edd8039cef0269ba43e48ab290e6144c4195d05478d5b446fb\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"1046b7a7-50ec-4795-91cd-a2fed648f305\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"021a12b4514cadb248f65cb4c3b3c9eb32f631e1b9470509c44cd05758021cc32a\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n },\n {\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"2c3b35b3-866d-4931-b7b5-a67d59e3df42\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"03371b181c5faee70eb040c038c006e6642aa432d8072047348ae087519f3cc684\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"1744577b-e36b-468f-ba34-93d2614ff6e0\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"0289b6e477ebcda18a190e2a545e4606a70abdb724b676a60cea496f3a170334bc\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"c744dd91-d309-451a-b3aa-b452795e6551\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"02de6056801854c18538dde4b1be096f3fae25c7fe9092d86ad3cd9812a4d91630\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"24a6a15c-ae24-4e5d-826f-789d7c564016\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"0302f17f7dec96e7750ce771937e689e26ffd9366e7bd4d34832c8572d1d8a320e\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"5011d6cb-0a46-4131-aa2a-a78b2e02e269\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"0200730f65fd7b15a184de1d68305f3e7ca813ef7b7678cbead104b59459a44a49\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b5a795d8-ac72-497b-baa3-454adf6e036d\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"03fa52ac4e875d61d4e12bee02264b8030b927194e8ecb41ebc7e6e97c1de542e6\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"97b7ff16-a06d-4bb3-b22f-56550ce81bcf\",\n \"local_pk\": \"03d9ea0420cb9750b475e23f3f629a0eb521f9d94e1cc544abd76b87bf42ad71a5\",\n \"remote_pk\": \"03bf84c5cd8cdc85406bee299001b6e2991920118a978e186bb9d7f7adf4b9a22b\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n },\n {\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"fdb47e4e-64a4-4001-9213-4b7e53560dc1\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"0207ddf45bb57b4ef7a5c7b76b89464677569dcb585cf8627c788f3d44a3870e5e\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b0294a2f-6f57-4f2b-8624-c1ae5b347b31\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"032dbd4f2b2531db9fbd23f3e53365c7ade63d08154025af7d94e7a7b6d715f4d8\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"81579b6e-d8a7-4cab-b2f2-3ba72a8eae83\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"02b4bcabcaaef410f6b9744715a77e8442e7849452e7202a408daccc4b1c63622b\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"bee8e0ad-8190-4c8b-8323-9680bda05580\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"03f2cf69c598c4981a12f665e3b288f9a39d260a883217ed278b0bfc9871faecb4\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"339c3342-0285-454f-b1af-d328a2790767\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"02017acb7de8041df23508a82ed2d49ded03f000d19bc000eb120db80a793664f6\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"8be92ca7-795b-44f6-9c3c-b364cff45bd4\",\n \"local_pk\": \"0301b27adf2954a9f97c443c478e48253a707e7b467d0c0c0ba7a2091fa8ec6145\",\n \"remote_pk\": \"03bd2e96d3b56037bfd179b400a5f4953d46467e4913d1c4322c66c1bec11158be\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n },\n {\n \"local_pk\": \"03e26b70fa8de90444128d78909e10331683be7d304452def6f88ef13d19e2e22d\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": null\n },\n {\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"f40a8665-8687-461d-971a-2c93d234a449\",\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"remote_pk\": \"03455586704d340771740533b3b5fff25656877e5f1b9118245e3d7a9f1cd46fb8\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"a350e9e0-4cf9-4121-b5a6-65733264f7a4\",\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"remote_pk\": \"02bcd9e9540b7779b189841baa73cde2aaff4ae734acd4873155d9f578c69eb5d5\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"f7852f53-6758-40c5-b42d-d94331f3d82a\",\n \"local_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"remote_pk\": \"0392ff06c76763808a9a3d43e5cdc8dfbbbd01efb7b58c1fc315208498cc95807c\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n }\n]" + } + ] + }, + { + "name": "/api/nodes/{pk}", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02?", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02" + ], + "query": [ + { + "key": "", + "value": "", + "disabled": true + } + ] + }, + "description": "Provides a summary of a given connected app node of public key." + }, + "response": [ + { + "name": "/api/nodes/:pk", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2?", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2" + ], + "query": [ + { + "key": "", + "value": "", + "disabled": true + } + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 00:47:03 GMT" + }, + { + "key": "Transfer-Encoding", + "value": "chunked" + } + ], + "cookie": [], + "body": "{\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"apps\": [\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n ],\n \"transports\": [\n {\n \"id\": \"3fb65ceb-0cd3-484c-8a9c-21617a06c6dd\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"028825991ec52e8f135b9cf9c9f740698644ea2f2144e43a537ad416601ee1d905\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"4cf57b61-8a31-4c8f-b328-b2533978c4e1\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02af5570345c43715442aabdc72de8faecbccc38058fa3be88da8d85afb95762e6\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"0d2d208f-8e10-4bb4-ada5-58ffa4256723\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"034b60e92c40f566e38753fd0e4bc680a0811d25bee949cb5fee4006e42599d6cd\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"b1afc8fd-cb62-4993-9b5e-79267cdcf557\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"02add975773c2b1429368c961b9159c14de7662f8185ac5cbf173161e4b9f32937\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"43301e4e-594a-422a-b7b1-7a27e39050a8\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"029e32e79f1a57aa42704d3d88618ef8458b12a8f897dbbb7eecec0a411820f7d4\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"2d92ce65-8e2f-45b9-be29-3057951f4821\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"037f94a6071e7cb5edd8039cef0269ba43e48ab290e6144c4195d05478d5b446fb\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"1046b7a7-50ec-4795-91cd-a2fed648f305\",\n \"local_pk\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"remote_pk\": \"021a12b4514cadb248f65cb4c3b3c9eb32f631e1b9470509c44cd05758021cc32a\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n ]\n}" + } + ] + }, + { + "name": "/api/nodes/{pk}/apps", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02/apps", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02", + "apps" + ] + }, + "description": "Provides a summary of an AppNode's apps." + }, + "response": [ + { + "name": "/api/nodes/:pk/apps", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2/apps", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2", + "apps" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 00:48:55 GMT" + }, + { + "key": "Content-Length", + "value": "119" + } + ], + "cookie": [], + "body": "[\n {\n \"name\": \"foo.v1.0\",\n \"autostart\": false,\n \"port\": 10,\n \"status\": 0\n },\n {\n \"name\": \"bar.v2.0\",\n \"autostart\": false,\n \"port\": 20,\n \"status\": 0\n }\n]" + } + ] + }, + { + "name": "/api/nodes/{pk}/apps/{app}", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02/apps/foo.v1.0", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "021c535e45756c63151820c8f31bfbb0efd6d7d49305e133e1650aae889d60ff02", + "apps", + "foo.v1.0" + ] + }, + "description": "Starts an app on an AppNode." + }, + "response": [ + { + "name": "/api/nodes/:pk/apps/:app/start", + "originalRequest": { + "method": "POST", + "header": [], + "body": { + "mode": "raw", + "raw": "" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2/apps/foo.v1.0/start", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2", + "apps", + "foo.v1.0", + "start" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 00:50:40 GMT" + }, + { + "key": "Content-Length", + "value": "130" + } + ], + "cookie": [], + "body": "{\n \"node\": \"02500488fc25814e55e6c740537ed14ca677aebe8a883681bae718a36516a7b0a2\",\n \"app\": \"foo.v1.0\",\n \"command\": \"StartApp\",\n \"success\": true\n}" + } + ] + }, + { + "name": "/api/nodes/{pk}/apps/{app}", + "request": { + "method": "PUT", + "header": [ + { + "key": "Content-Type", + "name": "Content-Type", + "value": "application/json", + "type": "text" + } + ], + "body": { + "mode": "raw", + "raw": "{\n\t\"autostart\": true,\n\t\"status\": 1\n}" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/apps/foo.v1.0", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "apps", + "foo.v1.0" + ] + }, + "description": "Starts an app on an AppNode." + }, + "response": [ + { + "name": "/api/nodes/{pk}/apps/{app}", + "originalRequest": { + "method": "PUT", + "header": [ + { + "key": "Content-Type", + "name": "Content-Type", + "value": "application/json", + "type": "text" + } + ], + "body": { + "mode": "raw", + "raw": "{\n\t\"autostart\": true,\n\t\"status\": 1\n}" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/apps/foo.v1.0", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "apps", + "foo.v1.0" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json" + }, + { + "key": "Date", + "value": "Sun, 17 Feb 2019 10:37:17 GMT" + }, + { + "key": "Content-Length", + "value": "58" + } + ], + "cookie": [], + "body": "{\n \"name\": \"foo.v1.0\",\n \"autostart\": true,\n \"port\": 10,\n \"status\": 0\n}" + } + ] + }, + { + "name": "/api/nodes/{pk}/transport-types", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transport-types", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "transport-types" + ] + }, + "description": "Lists supported transport types of the given AppNode." + }, + "response": [ + { + "name": "/api/nodes/:pk/transport-types", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transport-types", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", + "transport-types" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 01:14:08 GMT" + }, + { + "key": "Content-Length", + "value": "22" + } + ], + "cookie": [], + "body": "[\n \"messaging\",\n \"native\"\n]" + } + ] + }, + { + "name": "/api/nodes/{pk}/transports", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports?logs=true", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "transports" + ], + "query": [ + { + "key": "logs", + "value": "true", + "description": "whether to show with logs." + } + ] + }, + "description": "List transports of given AppNode." + }, + "response": [ + { + "name": "/api/nodes/:pk/transports", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports?logs=true", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", + "transports" + ], + "query": [ + { + "key": "logs", + "value": "true", + "description": "whether to show with logs." + } + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 01:15:50 GMT" + }, + { + "key": "Transfer-Encoding", + "value": "chunked" + } + ], + "cookie": [], + "body": "[\n {\n \"id\": \"e86f4d67-eb22-4d1c-8c27-8f021051a5cf\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"028684d27d1c9bc36406da560d3f75a295a54ad0649d54eb3437655d8524bbe279\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"2ff2d608-fe14-4c17-938c-3af8afd053ae\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02a2f9b005ce53b77499e73eb4b67d60807a32d1616615809408150d2ff2631da8\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"50142ec9-027d-490d-ba86-e335b6ffffa0\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02d2b79b0e37671e8da948ddb7a51b24096a7b7fe3a64403f78ab031816b3009f3\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"85a60d18-f1a3-45b1-b7cc-8906c95dfdb0\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02c5015450d929bb38c496505f3781d671a11f108cecc0ef6f4a9ff6cf841e5bcf\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"16575562-14c4-492d-9112-dc9f9d3f201d\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"0206ad1343becba521d66ce58b72b2fd8592c998f05ce6fb82a8ab44f3583f9023\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"d0fa7457-e887-406e-ac84-e009fe6df490\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"026202dd7119e8f0635ff1adb52e826fc107472319033db47dbff428b66d3474ae\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"236d2c10-5d92-4d64-b66a-42e2a60ac231\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"020906cf03d1037149150f3d4d06b242d3fa5a3ee6fc25edef6373061176ad5279\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n },\n {\n \"id\": \"03c845c9-57b0-4b84-a184-70f952497a8a\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"0254cffd054fa00fa4c89f2b9d2ee3a52b69641bfd4a9e5ce59f5c086adf8d2e1e\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n }\n]" + } + ] + }, + { + "name": "/api/nodes/{pk}/transports", + "request": { + "method": "POST", + "header": [ + { + "key": "Content-Type", + "name": "Content-Type", + "value": "application/json", + "type": "text" + } + ], + "body": { + "mode": "raw", + "raw": "{\n\t\"remote_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n\t\"transport_type\": \"native\",\n\t\"public\": true\n}" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "transports" + ] + }, + "description": "Adds a transport to a given AppNode." + }, + "response": [ + { + "name": "POST /api/nodes/transports", + "originalRequest": { + "method": "POST", + "header": [ + { + "key": "Content-Type", + "name": "Content-Type", + "value": "application/json", + "type": "text" + } + ], + "body": { + "mode": "raw", + "raw": "{\n\t\"remote_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n\t\"transport_type\": \"native\",\n\t\"public\": true\n}" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", + "transports" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 01:19:01 GMT" + }, + { + "key": "Content-Length", + "value": "258" + } + ], + "cookie": [], + "body": "{\n \"id\": \"7a4236d4-8ae4-478c-acd7-e3577d730a49\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"03c497380efd87e19208bb484ee322ede1e091b2a0b653e6d25475f641602376a9\",\n \"type\": \"native\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n}" + } + ] + }, + { + "name": "/api/nodes/{pk}/transports/{tid}", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports/70836b44-f6e5-4c17-a5e8-e1cbef89a10f", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "transports", + "70836b44-f6e5-4c17-a5e8-e1cbef89a10f" + ] + }, + "description": "Obtains summary of transport of given TransportID and AppNode." + }, + "response": [ + { + "name": "/api/nodes/:pk/transports/:tid", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports/2ff2d608-fe14-4c17-938c-3af8afd053ae", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", + "transports", + "2ff2d608-fe14-4c17-938c-3af8afd053ae" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 01:23:06 GMT" + }, + { + "key": "Content-Length", + "value": "261" + } + ], + "cookie": [], + "body": "{\n \"id\": \"2ff2d608-fe14-4c17-938c-3af8afd053ae\",\n \"local_pk\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"remote_pk\": \"02a2f9b005ce53b77499e73eb4b67d60807a32d1616615809408150d2ff2631da8\",\n \"type\": \"messaging\",\n \"log\": {\n \"received\": null,\n \"sent\": null\n }\n}" + } + ] + }, + { + "name": "DELETE /api/nodes/{pk}/transports/{tid}", + "request": { + "method": "DELETE", + "header": [], + "body": { + "mode": "raw", + "raw": "" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64/transports/d5ace20e-06c8-4867-bda2-9449459a9e5a", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "023ab9f45c0eb3625f9848a9ff6822c6d0965a94d3e7955f1869f38153df0e5b64", + "transports", + "d5ace20e-06c8-4867-bda2-9449459a9e5a" + ] + }, + "description": "Removes transport of given TransportID and AppNode." + }, + "response": [ + { + "name": "DELETE /api/nodes/:pk/transports/:tid", + "originalRequest": { + "method": "DELETE", + "header": [], + "body": { + "mode": "raw", + "raw": "" + }, + "url": { + "raw": "http://localhost:8080/api/nodes/039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2/transports/2ff2d608-fe14-4c17-938c-3af8afd053ae", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2", + "transports", + "2ff2d608-fe14-4c17-938c-3af8afd053ae" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json; charset=utf-8" + }, + { + "key": "Date", + "value": "Wed, 13 Feb 2019 01:24:20 GMT" + }, + { + "key": "Content-Length", + "value": "171" + } + ], + "cookie": [], + "body": "{\n \"node\": \"039337a306ffbd6a7495f79b65aec91ce65756e4fd1cb2cd726840b2eee4fa59c2\",\n \"transport\": \"2ff2d608-fe14-4c17-938c-3af8afd053ae\",\n \"command\": \"RemoveTransport\",\n \"success\": true\n}" + } + ] + }, + { + "name": "http://localhost:8080/api/create-account", + "request": { + "method": "POST", + "header": [ + { + "key": "", + "value": "", + "type": "text", + "disabled": true + }, + { + "key": "Content-Type", + "name": "Content-Type", + "value": "application/json", + "type": "text" + } + ], + "body": { + "mode": "raw", + "raw": "{\"username\":\"admin\", \"password\":\"123456\"}" + }, + "url": { + "raw": "http://localhost:8080/api/create-account", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "create-account" + ] + } + }, + "response": [ + { + "name": "http://localhost:8080/api/create-account", + "originalRequest": { + "method": "POST", + "header": [ + { + "key": "", + "value": "", + "type": "text", + "disabled": true + }, + { + "key": "Content-Type", + "name": "Content-Type", + "value": "application/json", + "type": "text" + } + ], + "body": { + "mode": "raw", + "raw": "{\"username\":\"admin\", \"password\":\"123456\"}" + }, + "url": { + "raw": "http://localhost:8080/api/login", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "login" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json" + }, + { + "key": "Set-Cookie", + "value": "swm-session=MTU2NjkxNjE0N3xRZUlIRXpMRGwzWlNwNE01QzE0WnAxd3ZEb3pvNEZLSEhCYjd0eWI4dzZhWFEzWHRTUTdRQkVyTUI5cHVoOExGX0ttODJfMWF8AIoAT1RkzoPxb38uTg67eDdz26QqWIdvM_9lEXWCt8Q=; Expires=Wed, 28 Aug 2019 02:29:07 GMT; HttpOnly; Secure; SameSite" + }, + { + "key": "Date", + "value": "Tue, 27 Aug 2019 14:29:07 GMT" + }, + { + "key": "Content-Length", + "value": "5" + } + ], + "cookie": [], + "body": "true" + } + ] + }, + { + "name": "/api/nodes/{pk}/uptime", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7/uptime", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7", + "uptime" + ] + }, + "description": "Provides given node's uptime in seconds" + }, + "response": [ + { + "name": "/api/nodes/{pk}/uptime", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7/uptime", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7", + "uptime" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json" + }, + { + "key": "Date", + "value": "Tue, 10 Sep 2019 09:30:53 GMT" + }, + { + "key": "Content-Length", + "value": "13" + } + ], + "cookie": [], + "body": "12.846401599" + } + ] + }, + { + "name": "http://localhost:8080/api/nodes/{pk}/health", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7/health", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7", + "health" + ] + }, + "description": "Returns health information about the requested visor" + }, + "response": [ + { + "name": "http://localhost:8080/api/nodes/{pk}/health", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7/health", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7", + "health" + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json" + }, + { + "key": "Date", + "value": "Tue, 10 Sep 2019 09:40:08 GMT" + }, + { + "key": "Content-Length", + "value": "77" + } + ], + "cookie": [], + "body": "{\n \"status\": 200,\n \"transport_discovery\": 200,\n \"route_finder\": 200,\n \"setup_node\": 200\n}" + } + ] + }, + { + "name": "http://localhost:8080/api/nodes/{pk}/apps/{app}/logs?since={timestamp}", + "request": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7/apps/skychat/logs?since=2019-09-10T11:30:41.097351631+02:00", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7", + "apps", + "skychat", + "logs" + ], + "query": [ + { + "key": "since", + "value": "2019-09-10T11:30:41.097351631+02:00" + } + ] + }, + "description": "Returns given app's logs in given node since given timestamp. The given timestamp log is not included in the results.\n\nFor optimal performance, the last request's timestamp should be used in the next request as value for since.\n\nIf there is an error in the timestamp format or since is empty all the logs from the beginning will be returned." + }, + "response": [ + { + "name": "http://localhost:8080/api/nodes/{pk}/apps/{app}/logs?since={timestamp}", + "originalRequest": { + "method": "GET", + "header": [], + "url": { + "raw": "http://localhost:8080/api/nodes/024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7/apps/skychat/logs?since=2019-09-10T11:30:41.097351631+02:00", + "protocol": "http", + "host": [ + "localhost" + ], + "port": "8080", + "path": [ + "api", + "nodes", + "024ec47420176680816e0406250e7156465e4531f5b26057c9f6297bb0303558c7", + "apps", + "skychat", + "logs" + ], + "query": [ + { + "key": "since", + "value": "2019-09-10T11:30:41.097351631+02:00" + } + ] + } + }, + "status": "OK", + "code": 200, + "_postman_previewlanguage": "json", + "header": [ + { + "key": "Content-Type", + "value": "application/json" + }, + { + "key": "Date", + "value": "Tue, 10 Sep 2019 10:25:28 GMT" + }, + { + "key": "Content-Length", + "value": "216" + } + ], + "cookie": [], + "body": "{\n \"last_log_timestamp\": \"2019-09-10T12:23:33.916965349+02:00\",\n \"logs\": [\n \"[2019-09-10T12:13:48.532319632+02:00] INFO []: Serving HTTP on :8000\\n\",\n \"[2019-09-10T12:23:33.916965349+02:00] INFO []: Serving HTTP on :8000\\n\"\n ]\n}" + } + ] + } + ] +} \ No newline at end of file diff --git a/pkg/app/log_store_test.go b/pkg/app/log_store_test.go index 8ff172d1f..b1f7556f2 100644 --- a/pkg/app/log_store_test.go +++ b/pkg/app/log_store_test.go @@ -29,7 +29,6 @@ func TestLogStore(t *testing.T) { require.NoError(t, err) err = ls.Store(t1, "bar") - fmt.Println("original: ", t1.Format(time.RFC3339Nano)) require.NoError(t, err) t2, err := time.Parse(time.RFC3339, "2000-02-01T00:00:00Z") diff --git a/pkg/hypervisor/hypervisor.go b/pkg/hypervisor/hypervisor.go index 43ff31a6f..ae481ac61 100644 --- a/pkg/hypervisor/hypervisor.go +++ b/pkg/hypervisor/hypervisor.go @@ -9,6 +9,7 @@ import ( "net/http" "net/rpc" "strconv" + "strings" "sync" "time" @@ -18,7 +19,6 @@ import ( "github.com/skycoin/dmsg" "github.com/skycoin/dmsg/cipher" "github.com/skycoin/skycoin/src/util/logging" - "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/skywire/pkg/app" "github.com/skycoin/skywire/pkg/httputil" @@ -61,10 +61,9 @@ func NewNode(config Config) (*Node, error) { } // ServeRPC serves RPC of a Node. -func (m *Node) ServeRPC(lis *snet.Listener) error { - +func (m *Node) ServeRPC(lis *dmsg.Listener) error { for { - conn, err := lis.AcceptConn() + conn, err := lis.Accept() if err != nil { return err } @@ -339,6 +338,7 @@ type LogsRes struct { func (m *Node) appLogsSince() http.HandlerFunc { return m.withCtx(m.appCtx, func(w http.ResponseWriter, r *http.Request, ctx *httpCtx) { since := r.URL.Query().Get("since") + since = strings.Replace(since, " ", "+", 1) // we need to put '+' again that was replaced in the query string // if time is not parseable or empty default to return all logs t, err := time.Parse(time.RFC3339Nano, since) diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index 19a21b32f..763368aa0 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -25,6 +25,7 @@ import ( "github.com/skycoin/dmsg/cipher" "github.com/skycoin/skycoin/src/util/logging" + "github.com/skycoin/skywire/internal/netutil" "github.com/skycoin/skywire/pkg/app" routeFinder "github.com/skycoin/skywire/pkg/route-finder/client" "github.com/skycoin/skywire/pkg/router" @@ -34,6 +35,7 @@ import ( ) var log = logging.MustGetLogger("node") +var retrier = netutil.NewRetrier(200*time.Millisecond, 5, 2) // AppStatus defines running status of an App. type AppStatus int @@ -238,7 +240,13 @@ func (node *Node) Start() error { } for _, hypervisor := range node.config.Hypervisors { go func(hypervisor HypervisorConfig) { - conn, err := node.n.Dial(snet.DmsgType, hypervisor.PubKey, hypervisor.Port) + var conn net.Conn + var err error + + err = retrier.Do(func() error { + conn, err = node.n.Dial(snet.DmsgType, hypervisor.PubKey, hypervisor.Port) + return err + }) if err != nil { node.logger.Errorf("Hypervisor dmsg Dial exited with error: %v", err) } else { From fe5d2fa4e05e73eabb14d702f778ce1392e213b1 Mon Sep 17 00:00:00 2001 From: Evan Lin Date: Wed, 11 Sep 2019 11:40:17 +0800 Subject: [PATCH 08/14] Merge mainnet-milestone2 --- cmd/hypervisor/commands/root.go | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/cmd/hypervisor/commands/root.go b/cmd/hypervisor/commands/root.go index 0ea9dfa31..217c3ac1e 100644 --- a/cmd/hypervisor/commands/root.go +++ b/cmd/hypervisor/commands/root.go @@ -9,9 +9,10 @@ import ( "github.com/skycoin/dmsg" "github.com/skycoin/dmsg/disc" "github.com/skycoin/skycoin/src/util/logging" + "github.com/spf13/cobra" + "github.com/skycoin/skywire/pkg/hypervisor" "github.com/skycoin/skywire/pkg/util/pathutil" - "github.com/spf13/cobra" ) const configEnv = "SW_HYPERVISOR_CONFIG" From 1e5a8fbd8a190142640d5bd95cf7b9538fcb4387 Mon Sep 17 00:00:00 2001 From: ivcosla Date: Wed, 11 Sep 2019 17:06:16 +0200 Subject: [PATCH 09/14] added rpcclientdialer --- pkg/visor/rpc_client.go | 107 ++++++++++++++++++++++++++++++++++++++++ pkg/visor/visor.go | 23 ++++----- 2 files changed, 117 insertions(+), 13 deletions(-) diff --git a/pkg/visor/rpc_client.go b/pkg/visor/rpc_client.go index a2e0c8e95..91a17bc97 100644 --- a/pkg/visor/rpc_client.go +++ b/pkg/visor/rpc_client.go @@ -2,22 +2,32 @@ package visor import ( "encoding/binary" + "errors" "fmt" "math/rand" + "net" "net/http" "net/rpc" "sync" "time" "github.com/google/uuid" + "github.com/skycoin/dmsg" "github.com/skycoin/dmsg/cipher" "github.com/skycoin/skycoin/src/util/logging" "github.com/skycoin/skywire/pkg/app" "github.com/skycoin/skywire/pkg/router" "github.com/skycoin/skywire/pkg/routing" + "github.com/skycoin/skywire/pkg/snet" "github.com/skycoin/skywire/pkg/transport" ) +var ( + // ErrAlreadyServing is returned when an operation fails due to an operation + // that is currently running. + ErrAlreadyServing = errors.New("already serving") +) + // RPCClient represents a RPC Client implementation. type RPCClient interface { Summary() (*Summary, error) @@ -212,6 +222,103 @@ func (rc *rpcClient) Loops() ([]LoopInfo, error) { return loops, err } +// RPCClientDialer keeps track of an rpc connection and retries to connect if it fails at some point +type RPCClientDialer struct { + dialer *snet.Network + pk cipher.PubKey + port uint16 + conn net.Conn + mu sync.Mutex + done chan struct{} // nil: loop is not running, non-nil: loop is running. +} + +// NewRPCClientDialer creates a new RPCDialer to the given address +func NewRPCClientDialer(dialer *snet.Network, pk cipher.PubKey, port uint16) *RPCClientDialer { + return &RPCClientDialer{ + dialer: dialer, + pk: pk, + port: port, + } +} + +// Run repeatedly dials to remote until a successful connection is established. +// It exposes a RPC Server. +// It will return if Close is called or crypto fails. +func (d *RPCClientDialer) Run(srv *rpc.Server, retry time.Duration) error { + if ok := d.setDone(); !ok { + return ErrAlreadyServing + } + for { + if err := d.establishConn(); err != nil { + // Only return if not network error. + if err != dmsg.ErrRequestRejected { + return err + } + } else { + // Only serve when then dial succeeds. + srv.ServeConn(d.conn) + d.setConn(nil) + } + select { + case <-d.done: + d.clearDone() + return nil + case <-time.After(retry): + } + } +} + +// Close closes the handler. +func (d *RPCClientDialer) Close() (err error) { + if d == nil { + return nil + } + d.mu.Lock() + if d.done != nil { + close(d.done) + } + if d.conn != nil { + err = d.conn.Close() + } + d.mu.Unlock() + return +} + +// This operation should be atomic, hence protected by mutex. +func (d *RPCClientDialer) establishConn() error { + d.mu.Lock() + defer d.mu.Unlock() + + conn, err := d.dialer.Dial(snet.DmsgType, d.pk, d.port) + if err != nil { + return err + } + + d.conn = conn + return nil +} + +func (d *RPCClientDialer) setConn(conn net.Conn) { + d.mu.Lock() + d.conn = conn + d.mu.Unlock() +} + +func (d *RPCClientDialer) setDone() (ok bool) { + d.mu.Lock() + if ok = d.done == nil; ok { + d.done = make(chan struct{}) + } + d.mu.Unlock() + return +} + +func (d *RPCClientDialer) clearDone() { + d.mu.Lock() + d.done = nil + d.mu.Unlock() +} + // MockRPCClient mocks RPCClient. type mockRPCClient struct { startedAt time.Time diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index 763368aa0..43ca0ecd9 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -110,6 +110,7 @@ type Node struct { pidMu sync.Mutex rpcListener net.Listener + rpcDialers []*RPCClientDialer } // NewNode constructs new Node. @@ -208,6 +209,11 @@ func NewNode(config *Config, masterLogger *logging.MasterLogger) (*Node, error) node.rpcListener = l } + node.rpcDialers = make([]*RPCClientDialer, len(config.Hypervisors)) + for i, entry := range config.Hypervisors { + node.rpcDialers[i] = NewRPCClientDialer(node.n, entry.PubKey, entry.Port) + } + return node, err } @@ -238,21 +244,12 @@ func (node *Node) Start() error { node.logger.Info("Starting RPC interface on ", node.rpcListener.Addr()) go rpcSvr.Accept(node.rpcListener) } - for _, hypervisor := range node.config.Hypervisors { - go func(hypervisor HypervisorConfig) { - var conn net.Conn - var err error - - err = retrier.Do(func() error { - conn, err = node.n.Dial(snet.DmsgType, hypervisor.PubKey, hypervisor.Port) - return err - }) - if err != nil { + for _, dialer := range node.rpcDialers { + go func(dialer *RPCClientDialer) { + if err := dialer.Run(rpcSvr, time.Second); err != nil { node.logger.Errorf("Hypervisor dmsg Dial exited with error: %v", err) - } else { - rpcSvr.ServeConn(conn) } - }(hypervisor) + }(dialer) } node.logger.Info("Starting packet router") From 095dbffa75b66be3a1bdb044d843e33454231610 Mon Sep 17 00:00:00 2001 From: ivcosla Date: Wed, 11 Sep 2019 17:07:39 +0200 Subject: [PATCH 10/14] removed retrier --- pkg/visor/visor.go | 2 -- 1 file changed, 2 deletions(-) diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index 43ca0ecd9..71a6d3667 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -25,7 +25,6 @@ import ( "github.com/skycoin/dmsg/cipher" "github.com/skycoin/skycoin/src/util/logging" - "github.com/skycoin/skywire/internal/netutil" "github.com/skycoin/skywire/pkg/app" routeFinder "github.com/skycoin/skywire/pkg/route-finder/client" "github.com/skycoin/skywire/pkg/router" @@ -35,7 +34,6 @@ import ( ) var log = logging.MustGetLogger("node") -var retrier = netutil.NewRetrier(200*time.Millisecond, 5, 2) // AppStatus defines running status of an App. type AppStatus int From 34a7f5852a2566255ca16f8f01738ce634556d8d Mon Sep 17 00:00:00 2001 From: ivcosla Date: Wed, 11 Sep 2019 23:55:09 +0200 Subject: [PATCH 11/14] added unfinished test --- pkg/visor/rpc_test.go | 103 ++++++++++++++++++++++++++++++++++++++++++ 1 file changed, 103 insertions(+) diff --git a/pkg/visor/rpc_test.go b/pkg/visor/rpc_test.go index b04428e59..40e755bea 100644 --- a/pkg/visor/rpc_test.go +++ b/pkg/visor/rpc_test.go @@ -134,6 +134,109 @@ func TestStartStopApp(t *testing.T) { node.startedMu.Unlock() } +type TestRPC struct{} + +type AddIn struct{ A, B int } + +func (r *TestRPC) Add(in *AddIn, out *int) error { + *out = in.A + in.B + return nil +} + +// TODO: Implement correctly +/* +func TestRPCClientDialer(t *testing.T) { + svr := rpc.NewServer() + require.NoError(t, svr.Register(new(TestRPC))) + + lPK, lSK := cipher.GenerateKeyPair() + var l *snet.Listener + var port uint16 + var listenerN *snet.Network + discMock := disc.NewMock() + + sPK, sSK := cipher.GenerateKeyPair() + sl, err := net.Listen("tcp", ":0") + require.NoError(t, err) + log.Info("here: ", sl.Addr().String()) + server, err := dmsg.NewServer(sPK, sSK, fmt.Sprintf(":%d", sl.Addr().(*net.TCPAddr).Port), sl, discMock) + require.NoError(t, err) + go func() { + log.Fatal("server error is !!!!!!!!!1 ---->>> ", server.Serve()) + }() + + setup := func() { + var err error + + listenerN = snet.NewRaw(snet.Config{ + PubKey: lPK, + SecKey: lSK, + TpNetworks: []string{snet.DmsgType}, + DmsgMinSrvs: 1, + }, dmsg.NewClient(lPK, lSK, discMock), nil) + + require.NoError(t, listenerN.Init(context.Background())) + l, err = listenerN.Listen(snet.DmsgType, 9999) + require.NoError(t, err) + + lAddr := l.Addr().(dmsg.Addr).String() + t.Logf("Listening on %s", lAddr) + + port = l.Addr().(dmsg.Addr).Port + } + + teardown := func() { + require.NoError(t, l.Close()) + require.NoError(t, listenerN.Close()) + l = nil + } + + t.Run("RunRetry", func(t *testing.T) { + setup() + defer teardown() // Just in case of failure. + + const reconCount = 5 + const retry = time.Second / 4 + + dPK, dSK := cipher.GenerateKeyPair() + n := snet.NewRaw(snet.Config{ + PubKey: dPK, + SecKey: dSK, + TpNetworks: []string{snet.DmsgType}, + DmsgMinSrvs: 1, + }, dmsg.NewClient(dPK, dSK, discMock), nil) + require.NoError(t, n.Init(context.Background())) + + d := NewRPCClientDialer(n, lPK, port) + dDone := make(chan error, 1) + + go func() { + err := d.Run(svr, retry) + dDone <- err + close(dDone) + }() + + for i := 0; i < reconCount; i++ { + teardown() + time.Sleep(retry * 2) // Dialer shouldn't quit retrying in this time. + setup() + + conn, err := l.Accept() + require.NoError(t, err) + + in, out := &AddIn{A: i, B: i}, new(int) + require.NoError(t, rpc.NewClient(conn).Call("TestRPC.Add", in, out)) + require.Equal(t, in.A+in.B, *out) + require.NoError(t, conn.Close()) // NOTE: also closes d, as it's the same connection + } + + // The same connection is closed above (conn.Close()), and hence, this may return an error. + _ = d.Close() // nolint: errcheck + require.NoError(t, <-dDone) + }) +} +/* + /* TODO(evanlinjin): Fix these tests. These tests have been commented out for the following reasons: From 2941695c9f6f576725517a77decd37ce463c9523 Mon Sep 17 00:00:00 2001 From: ivcosla Date: Tue, 17 Sep 2019 13:41:02 +0200 Subject: [PATCH 12/14] moved to SkycoinProject --- Makefile | 6 +- README.md | 4 +- ci_scripts/go_mod_replace.sh | 2 +- ci_scripts/run-internal-tests.sh | 58 +++---- ci_scripts/run-pkg-tests.sh | 146 +++++++++--------- cmd/apps/helloworld/helloworld.go | 6 +- cmd/apps/skychat/chat.go | 8 +- .../therealproxy-client.go | 10 +- cmd/apps/therealproxy/therealproxy.go | 4 +- .../therealssh-client/therealssh-client.go | 6 +- cmd/apps/therealssh/therealssh.go | 6 +- cmd/hypervisor/commands/gen-config.go | 4 +- cmd/hypervisor/commands/root.go | 6 +- cmd/hypervisor/hypervisor.go | 2 +- cmd/messaging-server/commands/root.go | 8 +- cmd/messaging-server/messaging-server.go | 2 +- cmd/setup-node/commands/root.go | 6 +- cmd/setup-node/setup-node.go | 2 +- cmd/skywire-cli/commands/mdisc/root.go | 4 +- cmd/skywire-cli/commands/node/app.go | 4 +- cmd/skywire-cli/commands/node/gen-config.go | 12 +- cmd/skywire-cli/commands/node/root.go | 4 +- cmd/skywire-cli/commands/node/routes.go | 8 +- cmd/skywire-cli/commands/node/transports.go | 8 +- cmd/skywire-cli/commands/root.go | 8 +- cmd/skywire-cli/commands/rtfind/root.go | 6 +- cmd/skywire-cli/commands/tpdisc/root.go | 8 +- cmd/skywire-cli/internal/internal.go | 4 +- cmd/skywire-cli/skywire-cli.go | 2 +- cmd/skywire-visor/commands/root.go | 6 +- cmd/skywire-visor/skywire-visor.go | 2 +- cmd/therealssh-cli/commands/root.go | 4 +- cmd/therealssh-cli/therealssh-cli.go | 2 +- docs/Tests.Detection-of-unstable-tests.md | 50 +++--- go.mod | 8 +- go.sum | 8 +- internal/httpauth/auth.go | 2 +- internal/httpauth/client.go | 4 +- internal/httpauth/client_test.go | 4 +- internal/therealproxy/client.go | 2 +- internal/therealproxy/server_test.go | 2 +- pkg/app/app.go | 4 +- pkg/app/app_test.go | 8 +- pkg/app/packet.go | 2 +- pkg/app/packet_test.go | 4 +- pkg/httputil/httputil.go | 2 +- pkg/hypervisor/config.go | 6 +- pkg/hypervisor/hypervisor.go | 12 +- pkg/hypervisor/hypervisor_test.go | 2 +- pkg/hypervisor/user.go | 2 +- pkg/hypervisor/user_manager.go | 2 +- pkg/route-finder/client/client.go | 6 +- pkg/route-finder/client/mock.go | 6 +- pkg/router/app_manager.go | 6 +- pkg/router/app_manager_test.go | 10 +- pkg/router/loop_list.go | 2 +- pkg/router/managed_routing_table.go | 2 +- pkg/router/managed_routing_table_test.go | 2 +- pkg/router/port_list.go | 4 +- pkg/router/port_manager.go | 4 +- pkg/router/port_manager_test.go | 6 +- pkg/router/route_manager.go | 6 +- pkg/router/route_manager_test.go | 8 +- pkg/router/router.go | 18 +-- pkg/router/router_test.go | 18 +-- pkg/routing/addr.go | 2 +- pkg/routing/boltdb_routing_table.go | 2 +- pkg/routing/loop.go | 2 +- pkg/routing/route.go | 2 +- pkg/routing/routing_table_test.go | 2 +- pkg/routing/rule.go | 2 +- pkg/routing/rule_test.go | 2 +- pkg/setup/config.go | 2 +- pkg/setup/node.go | 16 +- pkg/setup/node_test.go | 12 +- pkg/setup/protocol.go | 2 +- pkg/therealssh/auth.go | 2 +- pkg/therealssh/auth_test.go | 2 +- pkg/therealssh/channel.go | 4 +- pkg/therealssh/channel_pty_test.go | 4 +- pkg/therealssh/channel_test.go | 6 +- pkg/therealssh/client.go | 6 +- pkg/therealssh/client_test.go | 4 +- pkg/therealssh/dialer.go | 2 +- pkg/therealssh/pty_test.go | 4 +- pkg/therealssh/server.go | 6 +- pkg/therealssh/server_test.go | 6 +- pkg/therealssh/session.go | 2 +- pkg/transport-discovery/client/client.go | 8 +- pkg/transport-discovery/client/client_test.go | 8 +- pkg/transport/discovery.go | 2 +- pkg/transport/discovery_test.go | 4 +- pkg/transport/dmsg/dmsg.go | 24 +-- pkg/transport/dmsg/testing.go | 8 +- pkg/transport/entry.go | 2 +- pkg/transport/entry_test.go | 4 +- pkg/transport/handshake.go | 2 +- pkg/transport/handshake_test.go | 2 +- pkg/transport/log_test.go | 2 +- pkg/transport/managed_transport.go | 8 +- pkg/transport/manager.go | 6 +- pkg/transport/manager_test.go | 10 +- pkg/transport/mock.go | 2 +- pkg/transport/tcp_transport.go | 2 +- pkg/transport/tcp_transport_test.go | 4 +- pkg/transport/transport.go | 4 +- pkg/util/pathutil/configpath.go | 6 +- pkg/util/pathutil/homedir.go | 2 +- pkg/visor/config.go | 12 +- pkg/visor/config_test.go | 6 +- pkg/visor/rpc.go | 6 +- pkg/visor/rpc_client.go | 8 +- pkg/visor/rpc_test.go | 10 +- pkg/visor/visor.go | 20 +-- pkg/visor/visor_test.go | 18 +-- .../github.com/skycoin/dmsg/cipher/cipher.go | 4 +- vendor/github.com/skycoin/dmsg/client.go | 8 +- vendor/github.com/skycoin/dmsg/disc/client.go | 4 +- vendor/github.com/skycoin/dmsg/disc/entry.go | 2 +- .../github.com/skycoin/dmsg/disc/testing.go | 2 +- vendor/github.com/skycoin/dmsg/frame.go | 4 +- vendor/github.com/skycoin/dmsg/go.mod | 4 +- .../github.com/skycoin/dmsg/ioutil/logging.go | 2 +- vendor/github.com/skycoin/dmsg/noise/dh.go | 2 +- vendor/github.com/skycoin/dmsg/noise/net.go | 2 +- vendor/github.com/skycoin/dmsg/noise/noise.go | 4 +- .../skycoin/dmsg/noise/read_writer.go | 4 +- vendor/github.com/skycoin/dmsg/server.go | 8 +- vendor/github.com/skycoin/dmsg/transport.go | 6 +- .../skycoin/skycoin/src/cipher/address.go | 2 +- .../skycoin/skycoin/src/cipher/bitcoin.go | 2 +- .../skycoin/skycoin/src/cipher/crypto.go | 4 +- .../src/cipher/secp256k1-go/secp256k1.go | 2 +- vendor/modules.txt | 26 ++-- 134 files changed, 483 insertions(+), 483 deletions(-) diff --git a/Makefile b/Makefile index 1e2f303b1..44818638d 100644 --- a/Makefile +++ b/Makefile @@ -73,9 +73,9 @@ install-linters: ## Install linters ${OPTS} go get -u golang.org/x/tools/cmd/goimports format: ## Formats the code. Must have goimports installed (use make install-linters). - ${OPTS} goimports -w -local github.com/skycoin/skywire ./pkg - ${OPTS} goimports -w -local github.com/skycoin/skywire ./cmd - ${OPTS} goimports -w -local github.com/skycoin/skywire ./internal + ${OPTS} goimports -w -local github.com/SkycoinProject/skywire ./pkg + ${OPTS} goimports -w -local github.com/SkycoinProject/skywire ./cmd + ${OPTS} goimports -w -local github.com/SkycoinProject/skywire ./internal dep: ## Sorts dependencies ${OPTS} go mod vendor -v diff --git a/README.md b/README.md index 6323a37f8..4dfbd1ac2 100644 --- a/README.md +++ b/README.md @@ -70,7 +70,7 @@ Skywire requires a version of [golang](https://golang.org/) with [go modules](ht ```bash # Clone. -$ git clone https://github.com/skycoin/skywire +$ git clone https://github.com/SkycoinProject/skywire $ cd skywire $ git checkout mainnet # Build @@ -247,7 +247,7 @@ $ sudo cat /tmp/syslog/messages ## collected logs from NodeA, NodeB, NodeC insta ## Updater -This software comes with an updater, which is located in this repo: . Follow the instructions in the README.md for further information. It can be used with a CLI for now and will be usable with the manager interface. +This software comes with an updater, which is located in this repo: . Follow the instructions in the README.md for further information. It can be used with a CLI for now and will be usable with the manager interface. ## Running skywire in docker containers diff --git a/ci_scripts/go_mod_replace.sh b/ci_scripts/go_mod_replace.sh index b7890cc86..19557c50f 100755 --- a/ci_scripts/go_mod_replace.sh +++ b/ci_scripts/go_mod_replace.sh @@ -9,7 +9,7 @@ action=$1 filename=$2 # Line to comment/uncomment in go.mod -line="replace github.com\/skycoin\/dmsg => ..\/dmsg" +line="replace github.com\/SkycoinProject\/dmsg => ..\/dmsg" function print_usage() { echo $"Usage: $0 (comment|uncomment) " diff --git a/ci_scripts/run-internal-tests.sh b/ci_scripts/run-internal-tests.sh index b15a3d365..619c5db9e 100644 --- a/ci_scripts/run-internal-tests.sh +++ b/ci_scripts/run-internal-tests.sh @@ -1,34 +1,34 @@ # commit a70894c8c4223424151cdff7441b1fb2e6bad309 -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriter >> ./logs/internal/TestAckReadWriter.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterCRCFailure >> ./logs/internal/TestAckReadWriterCRCFailure.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterFlushOnClose >> ./logs/internal/TestAckReadWriterFlushOnClose.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterPartialRead >> ./logs/internal/TestAckReadWriterPartialRead.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterReadError >> ./logs/internal/TestAckReadWriterReadError.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestLenReadWriter >> ./logs/internal/TestLenReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriter >> ./logs/internal/TestAckReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterCRCFailure >> ./logs/internal/TestAckReadWriterCRCFailure.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterFlushOnClose >> ./logs/internal/TestAckReadWriterFlushOnClose.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterPartialRead >> ./logs/internal/TestAckReadWriterPartialRead.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterReadError >> ./logs/internal/TestAckReadWriterReadError.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestLenReadWriter >> ./logs/internal/TestLenReadWriter.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestRPCClientDialer >> ./logs/internal/TestRPCClientDialer.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestConn >> ./logs/internal/TestConn.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestListener >> ./logs/internal/TestListener.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestKKAndSecp256k1 >> ./logs/internal/TestKKAndSecp256k1.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestXKAndSecp256k1 >> ./logs/internal/TestXKAndSecp256k1.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestReadWriterKKPattern >> ./logs/internal/TestReadWriterKKPattern.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestReadWriterXKPattern >> ./logs/internal/TestReadWriterXKPattern.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/noise -run TestReadWriterConcurrentTCP >> ./logs/internal/TestReadWriterConcurrentTCP.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestRPCClientDialer >> ./logs/internal/TestRPCClientDialer.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestConn >> ./logs/internal/TestConn.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestListener >> ./logs/internal/TestListener.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestKKAndSecp256k1 >> ./logs/internal/TestKKAndSecp256k1.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestXKAndSecp256k1 >> ./logs/internal/TestXKAndSecp256k1.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestReadWriterKKPattern >> ./logs/internal/TestReadWriterKKPattern.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestReadWriterXKPattern >> ./logs/internal/TestReadWriterXKPattern.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestReadWriterConcurrentTCP >> ./logs/internal/TestReadWriterConcurrentTCP.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealproxy -run TestProxy >> ./logs/internal/TestProxy.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealproxy -run TestProxy >> ./logs/internal/TestProxy.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestListAuthorizer >> ./logs/internal/TestListAuthorizer.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestFileAuthorizer >> ./logs/internal/TestFileAuthorizer.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestChannelServe >> ./logs/internal/TestChannelServe.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestChannelSendWrite >> ./logs/internal/TestChannelSendWrite.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestChannelRead >> ./logs/internal/TestChannelRead.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestChannelRequest >> ./logs/internal/TestChannelRequest.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestChannelServeSocket >> ./logs/internal/TestChannelServeSocket.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestClientOpenChannel >> ./logs/internal/TestClientOpenChannel.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestClientHandleResponse >> ./logs/internal/TestClientHandleResponse.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestClientHandleData >> ./logs/internal/TestClientHandleData.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestServerOpenChannel >> ./logs/internal/TestServerOpenChannel.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestServerHandleRequest >> ./logs/internal/TestServerHandleRequest.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/therealssh -run TestServerHandleData >> ./logs/internal/TestServerHandleData.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestListAuthorizer >> ./logs/internal/TestListAuthorizer.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestFileAuthorizer >> ./logs/internal/TestFileAuthorizer.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelServe >> ./logs/internal/TestChannelServe.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelSendWrite >> ./logs/internal/TestChannelSendWrite.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelRead >> ./logs/internal/TestChannelRead.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelRequest >> ./logs/internal/TestChannelRequest.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelServeSocket >> ./logs/internal/TestChannelServeSocket.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestClientOpenChannel >> ./logs/internal/TestClientOpenChannel.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestClientHandleResponse >> ./logs/internal/TestClientHandleResponse.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestClientHandleData >> ./logs/internal/TestClientHandleData.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestServerOpenChannel >> ./logs/internal/TestServerOpenChannel.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestServerHandleRequest >> ./logs/internal/TestServerHandleRequest.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestServerHandleData >> ./logs/internal/TestServerHandleData.log diff --git a/ci_scripts/run-pkg-tests.sh b/ci_scripts/run-pkg-tests.sh index 96d4c8800..9ab34cf5a 100644 --- a/ci_scripts/run-pkg-tests.sh +++ b/ci_scripts/run-pkg-tests.sh @@ -1,80 +1,80 @@ # commit a70894c8c4223424151cdff7441b1fb2e6bad309 -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppDial >> ./logs/pkg/TestAppDial.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppAccept >> ./logs/pkg/TestAppAccept.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppWrite >> ./logs/pkg/TestAppWrite.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppRead >> ./logs/pkg/TestAppRead.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppSetup >> ./logs/pkg/TestAppSetup.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppCloseConn >> ./logs/pkg/TestAppCloseConn.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppClose >> ./logs/pkg/TestAppClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestAppCommand >> ./logs/pkg/TestAppCommand.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestPipeConn >> ./logs/pkg/TestPipeConn.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestProtocol >> ./logs/pkg/TestProtocol.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/app -run TestProtocolParallel >> ./logs/pkg/TestProtocolParallel.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppDial >> ./logs/pkg/TestAppDial.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppAccept >> ./logs/pkg/TestAppAccept.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppWrite >> ./logs/pkg/TestAppWrite.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppRead >> ./logs/pkg/TestAppRead.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppSetup >> ./logs/pkg/TestAppSetup.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppCloseConn >> ./logs/pkg/TestAppCloseConn.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppClose >> ./logs/pkg/TestAppClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppCommand >> ./logs/pkg/TestAppCommand.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestPipeConn >> ./logs/pkg/TestPipeConn.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestProtocol >> ./logs/pkg/TestProtocol.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestProtocolParallel >> ./logs/pkg/TestProtocolParallel.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/hypervisor -run TestNewNode >> ./logs/pkg/TestNewNode.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/hypervisor -run TestNewNode >> ./logs/pkg/TestNewNode.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestMessagingDiscovery >> ./logs/pkg/TestMessagingDiscovery.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestTransportDiscovery >> ./logs/pkg/TestTransportDiscovery.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestTransportLogStore >> ./logs/pkg/TestTransportLogStore.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestAppsConfig >> ./logs/pkg/TestAppsConfig.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestAppsDir >> ./logs/pkg/TestAppsDir.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestLocalDir >> ./logs/pkg/TestLocalDir.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestNewNode >> ./logs/pkg/TestNewNode.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestNodeStartClose >> ./logs/pkg/TestNodeStartClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestNodeSpawnApp >> ./logs/pkg/TestNodeSpawnApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestNodeSpawnAppValidations >> ./logs/pkg/TestNodeSpawnAppValidations.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestListApps >> ./logs/pkg/TestListApps.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestStartStopApp >> ./logs/pkg/TestStartStopApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/node -run TestRPC >> ./logs/pkg/TestRPC.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestMessagingDiscovery >> ./logs/pkg/TestMessagingDiscovery.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestTransportDiscovery >> ./logs/pkg/TestTransportDiscovery.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestTransportLogStore >> ./logs/pkg/TestTransportLogStore.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestAppsConfig >> ./logs/pkg/TestAppsConfig.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestAppsDir >> ./logs/pkg/TestAppsDir.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestLocalDir >> ./logs/pkg/TestLocalDir.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNewNode >> ./logs/pkg/TestNewNode.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNodeStartClose >> ./logs/pkg/TestNodeStartClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNodeSpawnApp >> ./logs/pkg/TestNodeSpawnApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNodeSpawnAppValidations >> ./logs/pkg/TestNodeSpawnAppValidations.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestListApps >> ./logs/pkg/TestListApps.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestStartStopApp >> ./logs/pkg/TestStartStopApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestRPC >> ./logs/pkg/TestRPC.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestAppManagerInit >> ./logs/pkg/TestAppManagerInit.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestAppManagerSetupLoop >> ./logs/pkg/TestAppManagerSetupLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestAppManagerCloseLoop >> ./logs/pkg/TestAppManagerCloseLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestAppManagerForward >> ./logs/pkg/TestAppManagerForward.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestManagedRoutingTableCleanup >> ./logs/pkg/TestManagedRoutingTableCleanup.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestPortManager >> ./logs/pkg/TestPortManager.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouteManagerGetRule >> ./logs/pkg/TestRouteManagerGetRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouteManagerRemoveLoopRule >> ./logs/pkg/TestRouteManagerRemoveLoopRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouteManagerAddRemoveRule >> ./logs/pkg/TestRouteManagerAddRemoveRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouteManagerDeleteRules >> ./logs/pkg/TestRouteManagerDeleteRules.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouteManagerConfirmLoop >> ./logs/pkg/TestRouteManagerConfirmLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouteManagerLoopClosed >> ./logs/pkg/TestRouteManagerLoopClosed.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterForwarding >> ./logs/pkg/TestRouterForwarding.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterAppInit >> ./logs/pkg/TestRouterAppInit.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterApp >> ./logs/pkg/TestRouterApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterLocalApp >> ./logs/pkg/TestRouterLocalApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterSetup >> ./logs/pkg/TestRouterSetup.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterSetupLoop >> ./logs/pkg/TestRouterSetupLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterSetupLoopLocal >> ./logs/pkg/TestRouterSetupLoopLocal.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterCloseLoop >> ./logs/pkg/TestRouterCloseLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterCloseLoopOnAppClose >> ./logs/pkg/TestRouterCloseLoopOnAppClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterCloseLoopOnRouterClose >> ./logs/pkg/TestRouterCloseLoopOnRouterClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/router -run TestRouterRouteExpiration >> ./logs/pkg/TestRouterRouteExpiration.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerInit >> ./logs/pkg/TestAppManagerInit.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerSetupLoop >> ./logs/pkg/TestAppManagerSetupLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerCloseLoop >> ./logs/pkg/TestAppManagerCloseLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerForward >> ./logs/pkg/TestAppManagerForward.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestManagedRoutingTableCleanup >> ./logs/pkg/TestManagedRoutingTableCleanup.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestPortManager >> ./logs/pkg/TestPortManager.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerGetRule >> ./logs/pkg/TestRouteManagerGetRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerRemoveLoopRule >> ./logs/pkg/TestRouteManagerRemoveLoopRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerAddRemoveRule >> ./logs/pkg/TestRouteManagerAddRemoveRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerDeleteRules >> ./logs/pkg/TestRouteManagerDeleteRules.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerConfirmLoop >> ./logs/pkg/TestRouteManagerConfirmLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerLoopClosed >> ./logs/pkg/TestRouteManagerLoopClosed.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterForwarding >> ./logs/pkg/TestRouterForwarding.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterAppInit >> ./logs/pkg/TestRouterAppInit.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterApp >> ./logs/pkg/TestRouterApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterLocalApp >> ./logs/pkg/TestRouterLocalApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterSetup >> ./logs/pkg/TestRouterSetup.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterSetupLoop >> ./logs/pkg/TestRouterSetupLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterSetupLoopLocal >> ./logs/pkg/TestRouterSetupLoopLocal.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterCloseLoop >> ./logs/pkg/TestRouterCloseLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterCloseLoopOnAppClose >> ./logs/pkg/TestRouterCloseLoopOnAppClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterCloseLoopOnRouterClose >> ./logs/pkg/TestRouterCloseLoopOnRouterClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterRouteExpiration >> ./logs/pkg/TestRouterRouteExpiration.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/routing -run TestBoltDBRoutingTable >> ./logs/pkg/TestBoltDBRoutingTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/routing -run TestMakePacket >> ./logs/pkg/TestMakePacket.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/routing -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/routing -run TestAppRule >> ./logs/pkg/TestAppRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/routing -run TestForwardRule >> ./logs/pkg/TestForwardRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestBoltDBRoutingTable >> ./logs/pkg/TestBoltDBRoutingTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestMakePacket >> ./logs/pkg/TestMakePacket.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestAppRule >> ./logs/pkg/TestAppRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestForwardRule >> ./logs/pkg/TestForwardRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/setup -run TestNewProtocol >> ./logs/pkg/TestNewProtocol.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/setup -run TestNewProtocol >> ./logs/pkg/TestNewProtocol.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestSettlementHandshake >> ./logs/pkg/TestSettlementHandshake.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestSettlementHandshakeInvalidSig >> ./logs/pkg/TestSettlementHandshakeInvalidSig.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestSettlementHandshakePrivate >> ./logs/pkg/TestSettlementHandshakePrivate.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestSettlementHandshakeExistingTransport >> ./logs/pkg/TestSettlementHandshakeExistingTransport.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestValidateEntry >> ./logs/pkg/TestValidateEntry.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestInMemoryTransportLogStore >> ./logs/pkg/TestInMemoryTransportLogStore.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestFileTransportLogStore >> ./logs/pkg/TestFileTransportLogStore.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestTransportManager >> ./logs/pkg/TestTransportManager.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestTransportManagerReEstablishTransports >> ./logs/pkg/TestTransportManagerReEstablishTransports.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestTransportManagerLogs >> ./logs/pkg/TestTransportManagerLogs.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestTCPFactory >> ./logs/pkg/TestTCPFactory.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport -run TestFilePKTable >> ./logs/pkg/TestFilePKTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport-discovery/client -run TestClientAuth >> ./logs/pkg/TestClientAuth.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport-discovery/client -run TestRegisterTransportResponses >> ./logs/pkg/TestRegisterTransportResponses.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport-discovery/client -run TestRegisterTransports >> ./logs/pkg/TestRegisterTransports.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport-discovery/client -run TestGetTransportByID >> ./logs/pkg/TestGetTransportByID.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport-discovery/client -run TestGetTransportsByEdge >> ./logs/pkg/TestGetTransportsByEdge.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/pkg/transport-discovery/client -run TestUpdateStatuses >> ./logs/pkg/TestUpdateStatuses.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshake >> ./logs/pkg/TestSettlementHandshake.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshakeInvalidSig >> ./logs/pkg/TestSettlementHandshakeInvalidSig.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshakePrivate >> ./logs/pkg/TestSettlementHandshakePrivate.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshakeExistingTransport >> ./logs/pkg/TestSettlementHandshakeExistingTransport.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestValidateEntry >> ./logs/pkg/TestValidateEntry.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestInMemoryTransportLogStore >> ./logs/pkg/TestInMemoryTransportLogStore.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestFileTransportLogStore >> ./logs/pkg/TestFileTransportLogStore.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTransportManager >> ./logs/pkg/TestTransportManager.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTransportManagerReEstablishTransports >> ./logs/pkg/TestTransportManagerReEstablishTransports.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTransportManagerLogs >> ./logs/pkg/TestTransportManagerLogs.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTCPFactory >> ./logs/pkg/TestTCPFactory.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestFilePKTable >> ./logs/pkg/TestFilePKTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestClientAuth >> ./logs/pkg/TestClientAuth.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestRegisterTransportResponses >> ./logs/pkg/TestRegisterTransportResponses.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestRegisterTransports >> ./logs/pkg/TestRegisterTransports.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestGetTransportByID >> ./logs/pkg/TestGetTransportByID.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestGetTransportsByEdge >> ./logs/pkg/TestGetTransportsByEdge.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestUpdateStatuses >> ./logs/pkg/TestUpdateStatuses.log diff --git a/cmd/apps/helloworld/helloworld.go b/cmd/apps/helloworld/helloworld.go index 6bd4e94ab..7846695db 100644 --- a/cmd/apps/helloworld/helloworld.go +++ b/cmd/apps/helloworld/helloworld.go @@ -7,10 +7,10 @@ import ( "log" "os" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) func main() { diff --git a/cmd/apps/skychat/chat.go b/cmd/apps/skychat/chat.go index 4e8eb994b..fb8754f26 100644 --- a/cmd/apps/skychat/chat.go +++ b/cmd/apps/skychat/chat.go @@ -15,11 +15,11 @@ import ( "sync" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/internal/netutil" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/netutil" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) var addr = flag.String("addr", ":8000", "address to bind") diff --git a/cmd/apps/therealproxy-client/therealproxy-client.go b/cmd/apps/therealproxy-client/therealproxy-client.go index 26366ea4f..84c75e580 100644 --- a/cmd/apps/therealproxy-client/therealproxy-client.go +++ b/cmd/apps/therealproxy-client/therealproxy-client.go @@ -9,12 +9,12 @@ import ( "net" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/internal/netutil" - "github.com/skycoin/skywire/internal/therealproxy" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/netutil" + "github.com/SkycoinProject/skywire/internal/therealproxy" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) const socksPort = 3 diff --git a/cmd/apps/therealproxy/therealproxy.go b/cmd/apps/therealproxy/therealproxy.go index f3f1fb038..b5c853274 100644 --- a/cmd/apps/therealproxy/therealproxy.go +++ b/cmd/apps/therealproxy/therealproxy.go @@ -7,8 +7,8 @@ import ( "flag" "log" - "github.com/skycoin/skywire/internal/therealproxy" - "github.com/skycoin/skywire/pkg/app" + "github.com/SkycoinProject/skywire/internal/therealproxy" + "github.com/SkycoinProject/skywire/pkg/app" ) func main() { diff --git a/cmd/apps/therealssh-client/therealssh-client.go b/cmd/apps/therealssh-client/therealssh-client.go index 88c547b98..5658ad959 100644 --- a/cmd/apps/therealssh-client/therealssh-client.go +++ b/cmd/apps/therealssh-client/therealssh-client.go @@ -9,10 +9,10 @@ import ( "net/http" "github.com/sirupsen/logrus" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/app" - ssh "github.com/skycoin/skywire/pkg/therealssh" + "github.com/SkycoinProject/skywire/pkg/app" + ssh "github.com/SkycoinProject/skywire/pkg/therealssh" ) func main() { diff --git a/cmd/apps/therealssh/therealssh.go b/cmd/apps/therealssh/therealssh.go index 59e244e8a..8409d486c 100644 --- a/cmd/apps/therealssh/therealssh.go +++ b/cmd/apps/therealssh/therealssh.go @@ -9,10 +9,10 @@ import ( "github.com/mitchellh/go-homedir" "github.com/sirupsen/logrus" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/app" - ssh "github.com/skycoin/skywire/pkg/therealssh" + "github.com/SkycoinProject/skywire/pkg/app" + ssh "github.com/SkycoinProject/skywire/pkg/therealssh" ) func main() { diff --git a/cmd/hypervisor/commands/gen-config.go b/cmd/hypervisor/commands/gen-config.go index 7ece3102f..813f421cc 100644 --- a/cmd/hypervisor/commands/gen-config.go +++ b/cmd/hypervisor/commands/gen-config.go @@ -6,8 +6,8 @@ import ( "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/hypervisor" - "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/pkg/hypervisor" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" ) var ( diff --git a/cmd/hypervisor/commands/root.go b/cmd/hypervisor/commands/root.go index 2e77d3683..698d70375 100644 --- a/cmd/hypervisor/commands/root.go +++ b/cmd/hypervisor/commands/root.go @@ -6,11 +6,11 @@ import ( "net/http" "os" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/hypervisor" - "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/pkg/hypervisor" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" ) const configEnv = "SW_HYPERVISOR_CONFIG" diff --git a/cmd/hypervisor/hypervisor.go b/cmd/hypervisor/hypervisor.go index b3f5d88d2..380ccb2b1 100644 --- a/cmd/hypervisor/hypervisor.go +++ b/cmd/hypervisor/hypervisor.go @@ -3,7 +3,7 @@ skywire hypervisor */ package main -import "github.com/skycoin/skywire/cmd/hypervisor/commands" +import "github.com/SkycoinProject/skywire/cmd/hypervisor/commands" func main() { commands.Execute() diff --git a/cmd/messaging-server/commands/root.go b/cmd/messaging-server/commands/root.go index d4d6674c7..b5fefff01 100644 --- a/cmd/messaging-server/commands/root.go +++ b/cmd/messaging-server/commands/root.go @@ -13,10 +13,10 @@ import ( "github.com/prometheus/client_golang/prometheus/promhttp" logrussyslog "github.com/sirupsen/logrus/hooks/syslog" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/spf13/cobra" ) diff --git a/cmd/messaging-server/messaging-server.go b/cmd/messaging-server/messaging-server.go index 9b40d7141..d7c0ba577 100644 --- a/cmd/messaging-server/messaging-server.go +++ b/cmd/messaging-server/messaging-server.go @@ -1,6 +1,6 @@ package main -import "github.com/skycoin/skywire/cmd/messaging-server/commands" +import "github.com/SkycoinProject/skywire/cmd/messaging-server/commands" func main() { commands.Execute() diff --git a/cmd/setup-node/commands/root.go b/cmd/setup-node/commands/root.go index 7de9a7384..1e6a1c19d 100644 --- a/cmd/setup-node/commands/root.go +++ b/cmd/setup-node/commands/root.go @@ -12,11 +12,11 @@ import ( "github.com/prometheus/client_golang/prometheus/promhttp" logrussyslog "github.com/sirupsen/logrus/hooks/syslog" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/metrics" - "github.com/skycoin/skywire/pkg/setup" + "github.com/SkycoinProject/skywire/pkg/metrics" + "github.com/SkycoinProject/skywire/pkg/setup" ) var ( diff --git a/cmd/setup-node/setup-node.go b/cmd/setup-node/setup-node.go index bd5a86d97..f64c1f6df 100644 --- a/cmd/setup-node/setup-node.go +++ b/cmd/setup-node/setup-node.go @@ -1,6 +1,6 @@ package main -import "github.com/skycoin/skywire/cmd/setup-node/commands" +import "github.com/SkycoinProject/skywire/cmd/setup-node/commands" func main() { commands.Execute() diff --git a/cmd/skywire-cli/commands/mdisc/root.go b/cmd/skywire-cli/commands/mdisc/root.go index 1ad525398..fca7df79f 100644 --- a/cmd/skywire-cli/commands/mdisc/root.go +++ b/cmd/skywire-cli/commands/mdisc/root.go @@ -7,10 +7,10 @@ import ( "text/tabwriter" "time" - "github.com/skycoin/dmsg/disc" + "github.com/SkycoinProject/dmsg/disc" "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" ) var mdAddr string diff --git a/cmd/skywire-cli/commands/node/app.go b/cmd/skywire-cli/commands/node/app.go index 00f267fd0..473138f87 100644 --- a/cmd/skywire-cli/commands/node/app.go +++ b/cmd/skywire-cli/commands/node/app.go @@ -8,8 +8,8 @@ import ( "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/internal" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire/pkg/visor" ) func init() { diff --git a/cmd/skywire-cli/commands/node/gen-config.go b/cmd/skywire-cli/commands/node/gen-config.go index ab132ea19..0b084d74a 100644 --- a/cmd/skywire-cli/commands/node/gen-config.go +++ b/cmd/skywire-cli/commands/node/gen-config.go @@ -6,11 +6,11 @@ import ( "path/filepath" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/util/pathutil" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/pkg/visor" ) func init() { @@ -68,9 +68,9 @@ func homeConfig() *visor.Config { func localConfig() *visor.Config { c := defaultConfig() - c.AppsPath = "/usr/local/skycoin/skywire/apps" - c.Transport.LogStore.Location = "/usr/local/skycoin/skywire/transport_logs" - c.Routing.Table.Location = "/usr/local/skycoin/skywire/routing.db" + c.AppsPath = "/usr/local/SkycoinProject/skywire/apps" + c.Transport.LogStore.Location = "/usr/local/SkycoinProject/skywire/transport_logs" + c.Routing.Table.Location = "/usr/local/SkycoinProject/skywire/routing.db" return c } diff --git a/cmd/skywire-cli/commands/node/root.go b/cmd/skywire-cli/commands/node/root.go index 75d29467a..d11eb982f 100644 --- a/cmd/skywire-cli/commands/node/root.go +++ b/cmd/skywire-cli/commands/node/root.go @@ -3,10 +3,10 @@ package node import ( "net/rpc" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/pkg/visor" ) var log = logging.MustGetLogger("skywire-cli") diff --git a/cmd/skywire-cli/commands/node/routes.go b/cmd/skywire-cli/commands/node/routes.go index 0d8012ce5..7e5141e41 100644 --- a/cmd/skywire-cli/commands/node/routes.go +++ b/cmd/skywire-cli/commands/node/routes.go @@ -11,10 +11,10 @@ import ( "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/internal" - "github.com/skycoin/skywire/pkg/router" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire/pkg/router" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/visor" ) func init() { diff --git a/cmd/skywire-cli/commands/node/transports.go b/cmd/skywire-cli/commands/node/transports.go index 43b198ba8..a410c26b8 100644 --- a/cmd/skywire-cli/commands/node/transports.go +++ b/cmd/skywire-cli/commands/node/transports.go @@ -7,12 +7,12 @@ import ( "text/tabwriter" "time" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/internal" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire/pkg/visor" ) func init() { diff --git a/cmd/skywire-cli/commands/root.go b/cmd/skywire-cli/commands/root.go index 2c03ffb3d..3c0562469 100644 --- a/cmd/skywire-cli/commands/root.go +++ b/cmd/skywire-cli/commands/root.go @@ -5,10 +5,10 @@ import ( "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/commands/mdisc" - "github.com/skycoin/skywire/cmd/skywire-cli/commands/node" - "github.com/skycoin/skywire/cmd/skywire-cli/commands/rtfind" - "github.com/skycoin/skywire/cmd/skywire-cli/commands/tpdisc" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/mdisc" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/node" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/rtfind" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/tpdisc" ) var rootCmd = &cobra.Command{ diff --git a/cmd/skywire-cli/commands/rtfind/root.go b/cmd/skywire-cli/commands/rtfind/root.go index 719b76ef9..a1623fddc 100644 --- a/cmd/skywire-cli/commands/rtfind/root.go +++ b/cmd/skywire-cli/commands/rtfind/root.go @@ -4,11 +4,11 @@ import ( "fmt" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/internal" - "github.com/skycoin/skywire/pkg/route-finder/client" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire/pkg/route-finder/client" ) var frAddr string diff --git a/cmd/skywire-cli/commands/tpdisc/root.go b/cmd/skywire-cli/commands/tpdisc/root.go index 295b400f4..6fe45d58f 100644 --- a/cmd/skywire-cli/commands/tpdisc/root.go +++ b/cmd/skywire-cli/commands/tpdisc/root.go @@ -9,12 +9,12 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/skycoin/skywire/cmd/skywire-cli/internal" - "github.com/skycoin/skywire/pkg/transport" - "github.com/skycoin/skywire/pkg/transport-discovery/client" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport-discovery/client" ) var ( diff --git a/cmd/skywire-cli/internal/internal.go b/cmd/skywire-cli/internal/internal.go index 839bd3129..8b25341d9 100644 --- a/cmd/skywire-cli/internal/internal.go +++ b/cmd/skywire-cli/internal/internal.go @@ -4,8 +4,8 @@ import ( "fmt" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("skywire-cli") diff --git a/cmd/skywire-cli/skywire-cli.go b/cmd/skywire-cli/skywire-cli.go index 0d2da60de..5e3a89c34 100644 --- a/cmd/skywire-cli/skywire-cli.go +++ b/cmd/skywire-cli/skywire-cli.go @@ -4,7 +4,7 @@ CLI for skywire visor package main import ( - "github.com/skycoin/skywire/cmd/skywire-cli/commands" + "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands" ) func main() { diff --git a/cmd/skywire-visor/commands/root.go b/cmd/skywire-visor/commands/root.go index e07395451..2501c2438 100644 --- a/cmd/skywire-visor/commands/root.go +++ b/cmd/skywire-visor/commands/root.go @@ -19,11 +19,11 @@ import ( "github.com/pkg/profile" logrussyslog "github.com/sirupsen/logrus/hooks/syslog" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/spf13/cobra" - "github.com/skycoin/skywire/pkg/util/pathutil" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/pkg/visor" ) const configEnv = "SW_CONFIG" diff --git a/cmd/skywire-visor/skywire-visor.go b/cmd/skywire-visor/skywire-visor.go index d4aa990b7..5a49f330b 100644 --- a/cmd/skywire-visor/skywire-visor.go +++ b/cmd/skywire-visor/skywire-visor.go @@ -4,7 +4,7 @@ skywire visor package main import ( - "github.com/skycoin/skywire/cmd/skywire-visor/commands" + "github.com/SkycoinProject/skywire/cmd/skywire-visor/commands" ) func main() { diff --git a/cmd/therealssh-cli/commands/root.go b/cmd/therealssh-cli/commands/root.go index 84d6a91d2..e64b533a6 100644 --- a/cmd/therealssh-cli/commands/root.go +++ b/cmd/therealssh-cli/commands/root.go @@ -14,11 +14,11 @@ import ( "time" "github.com/creack/pty" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" "golang.org/x/crypto/ssh/terminal" - ssh "github.com/skycoin/skywire/pkg/therealssh" + ssh "github.com/SkycoinProject/skywire/pkg/therealssh" ) var ( diff --git a/cmd/therealssh-cli/therealssh-cli.go b/cmd/therealssh-cli/therealssh-cli.go index 56dd20d10..c45136644 100644 --- a/cmd/therealssh-cli/therealssh-cli.go +++ b/cmd/therealssh-cli/therealssh-cli.go @@ -4,7 +4,7 @@ CLI for SSH app package main import ( - "github.com/skycoin/skywire/cmd/therealssh-cli/commands" + "github.com/SkycoinProject/skywire/cmd/therealssh-cli/commands" ) func main() { diff --git a/docs/Tests.Detection-of-unstable-tests.md b/docs/Tests.Detection-of-unstable-tests.md index 1d3a9c0e2..8f2581d0a 100644 --- a/docs/Tests.Detection-of-unstable-tests.md +++ b/docs/Tests.Detection-of-unstable-tests.md @@ -21,15 +21,15 @@ You will get output similar to: ```text TestClient -ok github.com/skycoin/skywire/internal/httpauth 0.043s -? github.com/skycoin/skywire/internal/httputil [no test files] +ok github.com/SkycoinProject/skywire/internal/httpauth 0.043s +? github.com/SkycoinProject/skywire/internal/httputil [no test files] TestAckReadWriter TestAckReadWriterCRCFailure TestAckReadWriterFlushOnClose TestAckReadWriterPartialRead TestAckReadWriterReadError TestLenReadWriter -ok github.com/skycoin/skywire/internal/ioutil 0.049s +ok github.com/SkycoinProject/skywire/internal/ioutil 0.049s ``` Filter lines with `[no test files]`. @@ -37,14 +37,14 @@ Filter lines with `[no test files]`. Transform this output to: ```bash -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log - -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriter >>./logs/internal/TestAckReadWriter.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterCRCFailure >>./logs/internal/TestAckReadWriterCRCFailure.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterFlushOnClose >>./logs/internal/TestAckReadWriterFlushOnClose.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterPartialRead >>./logs/internal/TestAckReadWriterPartialRead.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestAckReadWriterReadError >>./logs/internal/TestAckReadWriterReadError.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/skycoin/skywire/internal/ioutil -run TestLenReadWriter >>./logs/internal/TestLenReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log + +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriter >>./logs/internal/TestAckReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterCRCFailure >>./logs/internal/TestAckReadWriterCRCFailure.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterFlushOnClose >>./logs/internal/TestAckReadWriterFlushOnClose.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterPartialRead >>./logs/internal/TestAckReadWriterPartialRead.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterReadError >>./logs/internal/TestAckReadWriterReadError.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestLenReadWriter >>./logs/internal/TestLenReadWriter.log ``` Notes: @@ -79,10 +79,10 @@ If you see something like: ```sh $ grep "FAIL" ./logs/pkg/*.log -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/skycoin/skywire/pkg/messaging 300.838s -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/skycoin/skywire/pkg/messaging 300.849s -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/skycoin/skywire/pkg/messaging 300.844s -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/skycoin/skywire/pkg/messaging 300.849s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.838s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.849s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.844s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.849s ``` (note 300s for FAILs) @@ -91,12 +91,12 @@ And: ```sh $ grep "coverage" ./logs/pkg/TestClientConnectInitialServers.log -# ok github.com/skycoin/skywire/pkg/messaging 3.049s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire/pkg/messaging 3.049s coverage: 39.5% of statements # coverage: 38.0% of statements -# ok github.com/skycoin/skywire/pkg/messaging 3.072s coverage: 39.5% of statements -# ok github.com/skycoin/skywire/pkg/messaging 3.073s coverage: 39.5% of statements -# ok github.com/skycoin/skywire/pkg/messaging 3.071s coverage: 39.5% of statements -# ok github.com/skycoin/skywire/pkg/messaging 3.050s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire/pkg/messaging 3.072s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire/pkg/messaging 3.073s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire/pkg/messaging 3.071s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire/pkg/messaging 3.050s coverage: 39.5% of statements # coverage: 38.0% of statements ``` @@ -129,11 +129,11 @@ Temporary solution: test was moved to `./pkg/messaging/client_test.go` and tagge ```sh $ grep coverage ./logs/internal/*.log # ./logs/internal/TestReadWriterConcurrentTCP.log -# 1:ok github.com/skycoin/skywire/internal/noise 1.545s coverage: 0.0% of statements -# 2:ok github.com/skycoin/skywire/internal/noise 1.427s coverage: 0.0% of statements -# 3:ok github.com/skycoin/skywire/internal/noise 1.429s coverage: 0.0% of statements -# 4:ok github.com/skycoin/skywire/internal/noise 1.429s coverage: 0.0% of statements -# 5:ok github.com/skycoin/skywire/internal/noise 1.436s coverage: 0.0% of statements +# 1:ok github.com/SkycoinProject/skywire/internal/noise 1.545s coverage: 0.0% of statements +# 2:ok github.com/SkycoinProject/skywire/internal/noise 1.427s coverage: 0.0% of statements +# 3:ok github.com/SkycoinProject/skywire/internal/noise 1.429s coverage: 0.0% of statements +# 4:ok github.com/SkycoinProject/skywire/internal/noise 1.429s coverage: 0.0% of statements +# 5:ok github.com/SkycoinProject/skywire/internal/noise 1.436s coverage: 0.0% of statements ``` Note 0.0% coverage diff --git a/go.mod b/go.mod index 849ed6757..b42a521b1 100644 --- a/go.mod +++ b/go.mod @@ -1,4 +1,4 @@ -module github.com/skycoin/skywire +module github.com/SkycoinProject/skywire go 1.12 @@ -16,8 +16,8 @@ require ( github.com/prometheus/client_golang v1.0.0 github.com/prometheus/common v0.4.1 github.com/sirupsen/logrus v1.4.2 - github.com/skycoin/dmsg v0.0.0-20190805065636-70f4c32a994f - github.com/skycoin/skycoin v0.26.0 + github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f + github.com/SkycoinProject/SkycoinProject v0.26.0 github.com/spf13/cobra v0.0.5 github.com/stretchr/testify v1.3.0 go.etcd.io/bbolt v1.3.3 @@ -28,4 +28,4 @@ require ( ) // Uncomment for tests with alternate branches of 'dmsg' -//replace github.com/skycoin/dmsg => ../dmsg +//replace github.com/SkycoinProject/dmsg => ../dmsg diff --git a/go.sum b/go.sum index 9a133695e..59277a77a 100644 --- a/go.sum +++ b/go.sum @@ -88,10 +88,10 @@ github.com/russross/blackfriday v1.5.2/go.mod h1:JO/DiYxRf+HjHt06OyowR9PTA263kcR github.com/sirupsen/logrus v1.2.0/go.mod h1:LxeOpSwHxABJmUn/MG1IvRgCAasNZTLOkJPxbbu5VWo= github.com/sirupsen/logrus v1.4.2 h1:SPIRibHv4MatM3XXNO2BJeFLZwZ2LvZgfQ5+UNI2im4= github.com/sirupsen/logrus v1.4.2/go.mod h1:tLMulIdttU9McNUspp0xgXVQah82FyeX6MwdIuYE2rE= -github.com/skycoin/dmsg v0.0.0-20190805065636-70f4c32a994f h1:WWjaxOXoj6oYelm67MNtJbg51HQALjKAyhs2WAHgpZs= -github.com/skycoin/dmsg v0.0.0-20190805065636-70f4c32a994f/go.mod h1:obZYZp8eKR7Xqz+KNhJdUE6Gvp6rEXbDO8YTlW2YXgU= -github.com/skycoin/skycoin v0.26.0 h1:xDxe2r8AclMntZ550Y/vUQgwgLtwrf9Wu5UYiYcN5/o= -github.com/skycoin/skycoin v0.26.0/go.mod h1:78nHjQzd8KG0jJJVL/j0xMmrihXi70ti63fh8vXScJw= +github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f h1:WWjaxOXoj6oYelm67MNtJbg51HQALjKAyhs2WAHgpZs= +github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f/go.mod h1:obZYZp8eKR7Xqz+KNhJdUE6Gvp6rEXbDO8YTlW2YXgU= +github.com/SkycoinProject/SkycoinProject v0.26.0 h1:xDxe2r8AclMntZ550Y/vUQgwgLtwrf9Wu5UYiYcN5/o= +github.com/SkycoinProject/SkycoinProject v0.26.0/go.mod h1:78nHjQzd8KG0jJJVL/j0xMmrihXi70ti63fh8vXScJw= github.com/spf13/afero v1.1.2/go.mod h1:j4pytiNVoe2o6bmDsKpLACNPDBIoEAkihy7loJ1B0CQ= github.com/spf13/cast v1.3.0/go.mod h1:Qx5cxh0v+4UWYiBimWS+eyWzqEqokIECu5etghLkUJE= github.com/spf13/cobra v0.0.5 h1:f0B+LkLX6DtmRH1isoNA9VTtNUK9K8xYd28JNNfOv/s= diff --git a/internal/httpauth/auth.go b/internal/httpauth/auth.go index a3417faca..c742e387f 100644 --- a/internal/httpauth/auth.go +++ b/internal/httpauth/auth.go @@ -6,7 +6,7 @@ import ( "net/http" "strconv" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Nonce is used to sign requests in order to avoid replay attack diff --git a/internal/httpauth/client.go b/internal/httpauth/client.go index 3a6625585..00e30b14b 100644 --- a/internal/httpauth/client.go +++ b/internal/httpauth/client.go @@ -14,8 +14,8 @@ import ( "strings" "sync/atomic" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) const ( diff --git a/internal/httpauth/client_test.go b/internal/httpauth/client_test.go index cd74a577b..eb6fabec7 100644 --- a/internal/httpauth/client_test.go +++ b/internal/httpauth/client_test.go @@ -12,8 +12,8 @@ import ( "strconv" "testing" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/internal/therealproxy/client.go b/internal/therealproxy/client.go index c7f6efbf9..5740e111f 100644 --- a/internal/therealproxy/client.go +++ b/internal/therealproxy/client.go @@ -6,7 +6,7 @@ import ( "net" "github.com/hashicorp/yamux" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("therealproxy") diff --git a/internal/therealproxy/server_test.go b/internal/therealproxy/server_test.go index 1fd51ab46..4262b6607 100644 --- a/internal/therealproxy/server_test.go +++ b/internal/therealproxy/server_test.go @@ -10,7 +10,7 @@ import ( "testing" "time" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" "golang.org/x/net/nettest" diff --git a/pkg/app/app.go b/pkg/app/app.go index e2be01015..0eae87118 100644 --- a/pkg/app/app.go +++ b/pkg/app/app.go @@ -14,9 +14,9 @@ import ( "path/filepath" "sync" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) const ( diff --git a/pkg/app/app_test.go b/pkg/app/app_test.go index 54759563a..74a8c513a 100644 --- a/pkg/app/app_test.go +++ b/pkg/app/app_test.go @@ -9,13 +9,13 @@ import ( "testing" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/testhelpers" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/testhelpers" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestMain(m *testing.M) { diff --git a/pkg/app/packet.go b/pkg/app/packet.go index f77ada615..c8ee58f4e 100644 --- a/pkg/app/packet.go +++ b/pkg/app/packet.go @@ -1,6 +1,6 @@ package app -import "github.com/skycoin/skywire/pkg/routing" +import "github.com/SkycoinProject/skywire/pkg/routing" // Packet represents message exchanged between App and Node. type Packet struct { diff --git a/pkg/app/packet_test.go b/pkg/app/packet_test.go index 7990a166b..11ac0f0d0 100644 --- a/pkg/app/packet_test.go +++ b/pkg/app/packet_test.go @@ -3,9 +3,9 @@ package app import ( "fmt" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) func ExamplePacket() { diff --git a/pkg/httputil/httputil.go b/pkg/httputil/httputil.go index 30b796a17..3c57e4190 100644 --- a/pkg/httputil/httputil.go +++ b/pkg/httputil/httputil.go @@ -8,7 +8,7 @@ import ( "net/http" "github.com/gorilla/handlers" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("httputil") diff --git a/pkg/hypervisor/config.go b/pkg/hypervisor/config.go index 0e82b9145..3e9c601a8 100644 --- a/pkg/hypervisor/config.go +++ b/pkg/hypervisor/config.go @@ -8,9 +8,9 @@ import ( "path/filepath" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" ) // Key allows a byte slice to be marshaled or unmarshaled from a hex string. @@ -76,7 +76,7 @@ func GenerateHomeConfig() Config { // GenerateLocalConfig generates a config with default values and uses db from shared folder. func GenerateLocalConfig() Config { c := makeConfig() - c.DBPath = "/usr/local/skycoin/hypervisor/users.db" + c.DBPath = "/usr/local/SkycoinProject/hypervisor/users.db" return c } diff --git a/pkg/hypervisor/hypervisor.go b/pkg/hypervisor/hypervisor.go index d7203b5b6..b7f69327d 100644 --- a/pkg/hypervisor/hypervisor.go +++ b/pkg/hypervisor/hypervisor.go @@ -16,13 +16,13 @@ import ( "github.com/go-chi/chi" "github.com/go-chi/chi/middleware" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/noise" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/noise" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/httputil" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/visor" + "github.com/SkycoinProject/skywire/pkg/httputil" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/visor" ) var ( diff --git a/pkg/hypervisor/hypervisor_test.go b/pkg/hypervisor/hypervisor_test.go index 74becc374..aabad6fcc 100644 --- a/pkg/hypervisor/hypervisor_test.go +++ b/pkg/hypervisor/hypervisor_test.go @@ -13,7 +13,7 @@ import ( "strings" "testing" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/pkg/hypervisor/user.go b/pkg/hypervisor/user.go index 7237a20ef..898eb48ea 100644 --- a/pkg/hypervisor/user.go +++ b/pkg/hypervisor/user.go @@ -8,7 +8,7 @@ import ( "regexp" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "go.etcd.io/bbolt" ) diff --git a/pkg/hypervisor/user_manager.go b/pkg/hypervisor/user_manager.go index cee03b559..09ee85c12 100644 --- a/pkg/hypervisor/user_manager.go +++ b/pkg/hypervisor/user_manager.go @@ -10,7 +10,7 @@ import ( "github.com/google/uuid" "github.com/gorilla/securecookie" - "github.com/skycoin/skywire/pkg/httputil" + "github.com/SkycoinProject/skywire/pkg/httputil" ) const ( diff --git a/pkg/route-finder/client/client.go b/pkg/route-finder/client/client.go index 6fa5b5335..7aa8e7715 100644 --- a/pkg/route-finder/client/client.go +++ b/pkg/route-finder/client/client.go @@ -11,10 +11,10 @@ import ( "strings" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) const defaultContextTimeout = 10 * time.Second diff --git a/pkg/route-finder/client/mock.go b/pkg/route-finder/client/mock.go index 3184b2b91..f13e15222 100644 --- a/pkg/route-finder/client/mock.go +++ b/pkg/route-finder/client/mock.go @@ -1,10 +1,10 @@ package client import ( - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" ) // MockClient implements mock route finder client. diff --git a/pkg/router/app_manager.go b/pkg/router/app_manager.go index e2decc11f..4b9d07593 100644 --- a/pkg/router/app_manager.go +++ b/pkg/router/app_manager.go @@ -6,10 +6,10 @@ import ( "errors" "time" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) const supportedProtocolVersion = "0.0.1" diff --git a/pkg/router/app_manager_test.go b/pkg/router/app_manager_test.go index 3133eee35..cd16f6e18 100644 --- a/pkg/router/app_manager_test.go +++ b/pkg/router/app_manager_test.go @@ -5,14 +5,14 @@ import ( "net" "testing" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/testhelpers" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/testhelpers" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestAppManagerInit(t *testing.T) { diff --git a/pkg/router/loop_list.go b/pkg/router/loop_list.go index 4a4ad08ba..5e0f15dba 100644 --- a/pkg/router/loop_list.go +++ b/pkg/router/loop_list.go @@ -5,7 +5,7 @@ import ( "github.com/google/uuid" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) type loop struct { diff --git a/pkg/router/managed_routing_table.go b/pkg/router/managed_routing_table.go index 91362f1b5..570c078fa 100644 --- a/pkg/router/managed_routing_table.go +++ b/pkg/router/managed_routing_table.go @@ -4,7 +4,7 @@ import ( "sync" "time" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) var routeKeepalive = 10 * time.Minute // interval to keep active expired routes diff --git a/pkg/router/managed_routing_table_test.go b/pkg/router/managed_routing_table_test.go index 0d0de7579..7ff02f706 100644 --- a/pkg/router/managed_routing_table_test.go +++ b/pkg/router/managed_routing_table_test.go @@ -8,7 +8,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestManagedRoutingTableCleanup(t *testing.T) { diff --git a/pkg/router/port_list.go b/pkg/router/port_list.go index 5652d8de6..3bdd76816 100644 --- a/pkg/router/port_list.go +++ b/pkg/router/port_list.go @@ -4,8 +4,8 @@ import ( "math" "sync" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) type portBind struct { diff --git a/pkg/router/port_manager.go b/pkg/router/port_manager.go index 87dcab4eb..fe4ae4648 100644 --- a/pkg/router/port_manager.go +++ b/pkg/router/port_manager.go @@ -4,8 +4,8 @@ import ( "errors" "fmt" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) type portManager struct { diff --git a/pkg/router/port_manager_test.go b/pkg/router/port_manager_test.go index 9a548ce99..6213a36cc 100644 --- a/pkg/router/port_manager_test.go +++ b/pkg/router/port_manager_test.go @@ -5,12 +5,12 @@ import ( "sort" "testing" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestPortManager(t *testing.T) { diff --git a/pkg/router/route_manager.go b/pkg/router/route_manager.go index a7d8a7fa3..1d49b4085 100644 --- a/pkg/router/route_manager.go +++ b/pkg/router/route_manager.go @@ -7,10 +7,10 @@ import ( "io" "time" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/setup" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/setup" ) type setupCallbacks struct { diff --git a/pkg/router/route_manager_test.go b/pkg/router/route_manager_test.go index 80f2372ae..d8b8f09d5 100644 --- a/pkg/router/route_manager_test.go +++ b/pkg/router/route_manager_test.go @@ -7,13 +7,13 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/setup" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/setup" ) func TestRouteManagerGetRule(t *testing.T) { diff --git a/pkg/router/router.go b/pkg/router/router.go index 248edd6f5..1af27631f 100644 --- a/pkg/router/router.go +++ b/pkg/router/router.go @@ -10,15 +10,15 @@ import ( "sync" "time" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" - - "github.com/skycoin/skywire/pkg/app" - routeFinder "github.com/skycoin/skywire/pkg/route-finder/client" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/setup" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" + + "github.com/SkycoinProject/skywire/pkg/app" + routeFinder "github.com/SkycoinProject/skywire/pkg/route-finder/client" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/setup" + "github.com/SkycoinProject/skywire/pkg/transport" ) const ( diff --git a/pkg/router/router_test.go b/pkg/router/router_test.go index 766c5192e..b54c0aac6 100644 --- a/pkg/router/router_test.go +++ b/pkg/router/router_test.go @@ -10,18 +10,18 @@ import ( "time" "github.com/sirupsen/logrus" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/testhelpers" - "github.com/skycoin/skywire/pkg/app" - routeFinder "github.com/skycoin/skywire/pkg/route-finder/client" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/setup" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/internal/testhelpers" + "github.com/SkycoinProject/skywire/pkg/app" + routeFinder "github.com/SkycoinProject/skywire/pkg/route-finder/client" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/setup" + "github.com/SkycoinProject/skywire/pkg/transport" ) func TestMain(m *testing.M) { diff --git a/pkg/routing/addr.go b/pkg/routing/addr.go index ff72a137d..c41e230c3 100644 --- a/pkg/routing/addr.go +++ b/pkg/routing/addr.go @@ -3,7 +3,7 @@ package routing import ( "fmt" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Port is a network port number diff --git a/pkg/routing/boltdb_routing_table.go b/pkg/routing/boltdb_routing_table.go index 1e85ea6a9..1ecd3879b 100644 --- a/pkg/routing/boltdb_routing_table.go +++ b/pkg/routing/boltdb_routing_table.go @@ -6,7 +6,7 @@ import ( "fmt" "math" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "go.etcd.io/bbolt" ) diff --git a/pkg/routing/loop.go b/pkg/routing/loop.go index 5fc8fc097..1f1d09044 100644 --- a/pkg/routing/loop.go +++ b/pkg/routing/loop.go @@ -4,7 +4,7 @@ import ( "fmt" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Loop defines a loop over a pair of addresses. diff --git a/pkg/routing/route.go b/pkg/routing/route.go index 86a962748..ec2de3907 100644 --- a/pkg/routing/route.go +++ b/pkg/routing/route.go @@ -6,7 +6,7 @@ import ( "fmt" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Hop defines a route hop between 2 nodes. diff --git a/pkg/routing/routing_table_test.go b/pkg/routing/routing_table_test.go index a0459c99f..eeeaf46d5 100644 --- a/pkg/routing/routing_table_test.go +++ b/pkg/routing/routing_table_test.go @@ -6,7 +6,7 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/pkg/routing/rule.go b/pkg/routing/rule.go index 49d555750..e996b6c09 100644 --- a/pkg/routing/rule.go +++ b/pkg/routing/rule.go @@ -7,7 +7,7 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // RuleHeaderSize represents the base size of a rule. diff --git a/pkg/routing/rule_test.go b/pkg/routing/rule_test.go index 2e8432c1b..5554bed6b 100644 --- a/pkg/routing/rule_test.go +++ b/pkg/routing/rule_test.go @@ -5,7 +5,7 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" ) diff --git a/pkg/setup/config.go b/pkg/setup/config.go index ccb4ddad3..e33c4b3b3 100644 --- a/pkg/setup/config.go +++ b/pkg/setup/config.go @@ -3,7 +3,7 @@ package setup import ( "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Various timeouts for setup node. diff --git a/pkg/setup/node.go b/pkg/setup/node.go index b5d16164c..29943651c 100644 --- a/pkg/setup/node.go +++ b/pkg/setup/node.go @@ -7,14 +7,14 @@ import ( "fmt" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/skycoin/src/util/logging" - - "github.com/skycoin/skywire/pkg/metrics" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" - "github.com/skycoin/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" + + "github.com/SkycoinProject/skywire/pkg/metrics" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport/dmsg" ) // Hop is a wrapper around transport hop to add functionality diff --git a/pkg/setup/node_test.go b/pkg/setup/node_test.go index a46ebad16..e6178c106 100644 --- a/pkg/setup/node_test.go +++ b/pkg/setup/node_test.go @@ -11,16 +11,16 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" "github.com/stretchr/testify/require" "golang.org/x/net/nettest" - "github.com/skycoin/skywire/pkg/metrics" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire/pkg/metrics" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport/dmsg" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) func TestMain(m *testing.M) { diff --git a/pkg/setup/protocol.go b/pkg/setup/protocol.go index 6532a7e63..05ca56c9c 100644 --- a/pkg/setup/protocol.go +++ b/pkg/setup/protocol.go @@ -9,7 +9,7 @@ import ( "fmt" "io" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) // PacketType defines type of a setup packet diff --git a/pkg/therealssh/auth.go b/pkg/therealssh/auth.go index 45cfd8fde..99fcbc4a6 100644 --- a/pkg/therealssh/auth.go +++ b/pkg/therealssh/auth.go @@ -7,7 +7,7 @@ import ( "os" "path/filepath" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Authorizer defines interface for authorization providers. diff --git a/pkg/therealssh/auth_test.go b/pkg/therealssh/auth_test.go index 8871d2452..2dd2d3791 100644 --- a/pkg/therealssh/auth_test.go +++ b/pkg/therealssh/auth_test.go @@ -5,7 +5,7 @@ import ( "os" "testing" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/require" ) diff --git a/pkg/therealssh/channel.go b/pkg/therealssh/channel.go index a6e129a0f..a9356edfd 100644 --- a/pkg/therealssh/channel.go +++ b/pkg/therealssh/channel.go @@ -13,9 +13,9 @@ import ( "sync" "github.com/creack/pty" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) // Port reserved for SSH app diff --git a/pkg/therealssh/channel_pty_test.go b/pkg/therealssh/channel_pty_test.go index e255d1d1e..8af93976c 100644 --- a/pkg/therealssh/channel_pty_test.go +++ b/pkg/therealssh/channel_pty_test.go @@ -8,11 +8,11 @@ import ( "testing" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestChannelServe(t *testing.T) { diff --git a/pkg/therealssh/channel_test.go b/pkg/therealssh/channel_test.go index f05a7323b..33058d735 100644 --- a/pkg/therealssh/channel_test.go +++ b/pkg/therealssh/channel_test.go @@ -9,12 +9,12 @@ import ( "testing" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/testhelpers" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/testhelpers" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestChannelSendWrite(t *testing.T) { diff --git a/pkg/therealssh/client.go b/pkg/therealssh/client.go index 86a5207d8..456e0a5cc 100644 --- a/pkg/therealssh/client.go +++ b/pkg/therealssh/client.go @@ -11,10 +11,10 @@ import ( "time" "github.com/creack/pty" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/internal/netutil" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/netutil" + "github.com/SkycoinProject/skywire/pkg/routing" ) var r = netutil.NewRetrier(50*time.Millisecond, 5, 2) diff --git a/pkg/therealssh/client_test.go b/pkg/therealssh/client_test.go index 9402246f7..a981188ea 100644 --- a/pkg/therealssh/client_test.go +++ b/pkg/therealssh/client_test.go @@ -5,11 +5,11 @@ import ( "net" "testing" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestClientOpenChannel(t *testing.T) { diff --git a/pkg/therealssh/dialer.go b/pkg/therealssh/dialer.go index 7e5da3a9b..46706f4cc 100644 --- a/pkg/therealssh/dialer.go +++ b/pkg/therealssh/dialer.go @@ -3,7 +3,7 @@ package therealssh import ( "net" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) // dialer dials to a remote node. diff --git a/pkg/therealssh/pty_test.go b/pkg/therealssh/pty_test.go index 053cf9a15..c6560bb8e 100644 --- a/pkg/therealssh/pty_test.go +++ b/pkg/therealssh/pty_test.go @@ -10,10 +10,10 @@ import ( "testing" "github.com/creack/pty" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestRunRPC(t *testing.T) { diff --git a/pkg/therealssh/server.go b/pkg/therealssh/server.go index 1602d5c15..7baed9a3b 100644 --- a/pkg/therealssh/server.go +++ b/pkg/therealssh/server.go @@ -7,10 +7,10 @@ import ( "io" "net" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) // CommandType represents global protocol messages. diff --git a/pkg/therealssh/server_test.go b/pkg/therealssh/server_test.go index 1c9f2b65e..e6dca0225 100644 --- a/pkg/therealssh/server_test.go +++ b/pkg/therealssh/server_test.go @@ -6,12 +6,12 @@ import ( "os" "testing" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestMain(m *testing.M) { diff --git a/pkg/therealssh/session.go b/pkg/therealssh/session.go index 06bd1bd3c..0abb2ecc3 100644 --- a/pkg/therealssh/session.go +++ b/pkg/therealssh/session.go @@ -11,7 +11,7 @@ import ( "syscall" "github.com/creack/pty" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("therealssh") diff --git a/pkg/transport-discovery/client/client.go b/pkg/transport-discovery/client/client.go index 02c0f967d..532746861 100644 --- a/pkg/transport-discovery/client/client.go +++ b/pkg/transport-discovery/client/client.go @@ -12,11 +12,11 @@ import ( "net/http" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/internal/httpauth" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/internal/httpauth" + "github.com/SkycoinProject/skywire/pkg/transport" ) var log = logging.MustGetLogger("transport-discovery") diff --git a/pkg/transport-discovery/client/client_test.go b/pkg/transport-discovery/client/client_test.go index c231a0880..f5855a8cb 100644 --- a/pkg/transport-discovery/client/client_test.go +++ b/pkg/transport-discovery/client/client_test.go @@ -11,13 +11,13 @@ import ( "sync" "testing" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/httpauth" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/internal/httpauth" + "github.com/SkycoinProject/skywire/pkg/transport" ) func TestMain(m *testing.M) { diff --git a/pkg/transport/discovery.go b/pkg/transport/discovery.go index 682503678..4d88c0227 100644 --- a/pkg/transport/discovery.go +++ b/pkg/transport/discovery.go @@ -7,7 +7,7 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // DiscoveryClient performs Transport discovery operations. diff --git a/pkg/transport/discovery_test.go b/pkg/transport/discovery_test.go index de633dd8d..cd016ee05 100644 --- a/pkg/transport/discovery_test.go +++ b/pkg/transport/discovery_test.go @@ -6,9 +6,9 @@ import ( "github.com/stretchr/testify/require" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport" ) func TestNewDiscoveryMock(t *testing.T) { diff --git a/pkg/transport/dmsg/dmsg.go b/pkg/transport/dmsg/dmsg.go index d3d95466f..1701e5823 100644 --- a/pkg/transport/dmsg/dmsg.go +++ b/pkg/transport/dmsg/dmsg.go @@ -5,16 +5,16 @@ import ( "net" "time" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport" ) const ( - // Type is a wrapper type for "github.com/skycoin/dmsg".Type + // Type is a wrapper type for "github.com/SkycoinProject/dmsg".Type Type = dmsg.Type ) @@ -35,32 +35,32 @@ func NewServer(pk cipher.PubKey, sk cipher.SecKey, addr string, l net.Listener, return dmsg.NewServer(pk, sk, addr, l, dc) } -// ClientOption is a wrapper type for "github.com/skycoin/dmsg".ClientOption +// ClientOption is a wrapper type for "github.com/SkycoinProject/dmsg".ClientOption type ClientOption = dmsg.ClientOption -// Client is a wrapper type for "github.com/skycoin/dmsg".Client +// Client is a wrapper type for "github.com/SkycoinProject/dmsg".Client type Client struct { *dmsg.Client } -// NewClient is a wrapper type for "github.com/skycoin/dmsg".NewClient +// NewClient is a wrapper type for "github.com/SkycoinProject/dmsg".NewClient func NewClient(pk cipher.PubKey, sk cipher.SecKey, dc disc.APIClient, opts ...ClientOption) *Client { return &Client{ Client: dmsg.NewClient(pk, sk, dc, opts...), } } -// Accept is a wrapper type for "github.com/skycoin/dmsg".Accept +// Accept is a wrapper type for "github.com/SkycoinProject/dmsg".Accept func (c *Client) Accept(ctx context.Context) (transport.Transport, error) { return c.Client.Accept(ctx) } -// Dial is a wrapper type for "github.com/skycoin/dmsg".Dial +// Dial is a wrapper type for "github.com/SkycoinProject/dmsg".Dial func (c *Client) Dial(ctx context.Context, remote cipher.PubKey) (transport.Transport, error) { return c.Client.Dial(ctx, remote) } -// SetLogger is a wrapper type for "github.com/skycoin/dmsg".SetLogger +// SetLogger is a wrapper type for "github.com/SkycoinProject/dmsg".SetLogger func SetLogger(log *logging.Logger) ClientOption { return dmsg.SetLogger(log) } diff --git a/pkg/transport/dmsg/testing.go b/pkg/transport/dmsg/testing.go index a681035af..04629c7fc 100644 --- a/pkg/transport/dmsg/testing.go +++ b/pkg/transport/dmsg/testing.go @@ -5,10 +5,10 @@ import ( "fmt" "testing" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/require" "golang.org/x/net/nettest" ) diff --git a/pkg/transport/entry.go b/pkg/transport/entry.go index 1c4dd0fe6..2ddd3595c 100644 --- a/pkg/transport/entry.go +++ b/pkg/transport/entry.go @@ -5,7 +5,7 @@ import ( "strings" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // Entry is the unsigned representation of a Transport. diff --git a/pkg/transport/entry_test.go b/pkg/transport/entry_test.go index bcc91ad68..70fb72918 100644 --- a/pkg/transport/entry_test.go +++ b/pkg/transport/entry_test.go @@ -6,9 +6,9 @@ import ( "github.com/stretchr/testify/assert" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport" ) func TestNewEntry(t *testing.T) { diff --git a/pkg/transport/handshake.go b/pkg/transport/handshake.go index aa590bb5b..b62593af1 100644 --- a/pkg/transport/handshake.go +++ b/pkg/transport/handshake.go @@ -7,7 +7,7 @@ import ( "fmt" "io" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) func makeEntry(pk1, pk2 cipher.PubKey, tpType string) Entry { diff --git a/pkg/transport/handshake_test.go b/pkg/transport/handshake_test.go index 134346224..bc0d4da79 100644 --- a/pkg/transport/handshake_test.go +++ b/pkg/transport/handshake_test.go @@ -6,7 +6,7 @@ import ( "net" "testing" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/require" ) diff --git a/pkg/transport/log_test.go b/pkg/transport/log_test.go index ad0cdce10..3bc17ef66 100644 --- a/pkg/transport/log_test.go +++ b/pkg/transport/log_test.go @@ -11,7 +11,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport" ) func testTransportLogStore(t *testing.T, logStore transport.LogStore) { diff --git a/pkg/transport/managed_transport.go b/pkg/transport/managed_transport.go index 5f97a5f88..826810e6d 100644 --- a/pkg/transport/managed_transport.go +++ b/pkg/transport/managed_transport.go @@ -9,11 +9,11 @@ import ( "sync/atomic" "time" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/skycoin/dmsg" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) const logWriteInterval = time.Second * 3 diff --git a/pkg/transport/manager.go b/pkg/transport/manager.go index f63311074..bf984856c 100644 --- a/pkg/transport/manager.go +++ b/pkg/transport/manager.go @@ -7,11 +7,11 @@ import ( "strings" "sync" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/routing" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) // ManagerConfig configures a Manager. diff --git a/pkg/transport/manager_test.go b/pkg/transport/manager_test.go index 0d01dc90d..3702dc53e 100644 --- a/pkg/transport/manager_test.go +++ b/pkg/transport/manager_test.go @@ -8,14 +8,14 @@ import ( "testing" "time" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" - "github.com/skycoin/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport/dmsg" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/pkg/transport/mock.go b/pkg/transport/mock.go index f57360629..5b6f308aa 100644 --- a/pkg/transport/mock.go +++ b/pkg/transport/mock.go @@ -7,7 +7,7 @@ import ( "net" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // ErrTransportCommunicationTimeout represent timeout error for a mock transport. diff --git a/pkg/transport/tcp_transport.go b/pkg/transport/tcp_transport.go index e5d112fc5..39bff4d27 100644 --- a/pkg/transport/tcp_transport.go +++ b/pkg/transport/tcp_transport.go @@ -9,7 +9,7 @@ import ( "path/filepath" "strings" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // ErrUnknownRemote returned for connection attempts for remotes diff --git a/pkg/transport/tcp_transport_test.go b/pkg/transport/tcp_transport_test.go index 97919889c..33cdd3311 100644 --- a/pkg/transport/tcp_transport_test.go +++ b/pkg/transport/tcp_transport_test.go @@ -8,11 +8,11 @@ import ( "os" "testing" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport" ) func TestTCPFactory(t *testing.T) { diff --git a/pkg/transport/transport.go b/pkg/transport/transport.go index ee35cf75b..d12d64ca4 100644 --- a/pkg/transport/transport.go +++ b/pkg/transport/transport.go @@ -9,8 +9,8 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("transport") diff --git a/pkg/util/pathutil/configpath.go b/pkg/util/pathutil/configpath.go index 591ba23da..5142e9290 100644 --- a/pkg/util/pathutil/configpath.go +++ b/pkg/util/pathutil/configpath.go @@ -6,7 +6,7 @@ import ( "os" "path/filepath" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("pathutil") @@ -78,7 +78,7 @@ func NodeDefaults() ConfigPaths { paths[WorkingDirLoc] = filepath.Join(wd, "skywire-config.json") } paths[HomeLoc] = filepath.Join(HomeDir(), ".skycoin/skywire/skywire-config.json") - paths[LocalLoc] = "/usr/local/skycoin/skywire/skywire-config.json" + paths[LocalLoc] = "/usr/local/SkycoinProject/skywire/skywire-config.json" return paths } @@ -89,7 +89,7 @@ func HypervisorDefaults() ConfigPaths { paths[WorkingDirLoc] = filepath.Join(wd, "hypervisor-config.json") } paths[HomeLoc] = filepath.Join(HomeDir(), ".skycoin/hypervisor/hypervisor-config.json") - paths[LocalLoc] = "/usr/local/skycoin/hypervisor/hypervisor-config.json" + paths[LocalLoc] = "/usr/local/SkycoinProject/hypervisor/hypervisor-config.json" return paths } diff --git a/pkg/util/pathutil/homedir.go b/pkg/util/pathutil/homedir.go index b814615c0..454afc0da 100644 --- a/pkg/util/pathutil/homedir.go +++ b/pkg/util/pathutil/homedir.go @@ -7,7 +7,7 @@ import ( "path/filepath" "runtime" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // HomeDir obtains the path to the user's home directory via ENVs. diff --git a/pkg/visor/config.go b/pkg/visor/config.go index bb8210424..cbecbadca 100644 --- a/pkg/visor/config.go +++ b/pkg/visor/config.go @@ -8,13 +8,13 @@ import ( "path/filepath" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" - trClient "github.com/skycoin/skywire/pkg/transport-discovery/client" - "github.com/skycoin/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" + trClient "github.com/SkycoinProject/skywire/pkg/transport-discovery/client" + "github.com/SkycoinProject/skywire/pkg/transport/dmsg" ) // Config defines configuration parameters for Node. diff --git a/pkg/visor/config_test.go b/pkg/visor/config_test.go index 0a278bdf4..d85b4c8c5 100644 --- a/pkg/visor/config_test.go +++ b/pkg/visor/config_test.go @@ -10,12 +10,12 @@ import ( "testing" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/httpauth" - "github.com/skycoin/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/internal/httpauth" + "github.com/SkycoinProject/skywire/pkg/routing" ) func TestMessagingDiscovery(t *testing.T) { diff --git a/pkg/visor/rpc.go b/pkg/visor/rpc.go index 701a1ff1f..c734605a9 100644 --- a/pkg/visor/rpc.go +++ b/pkg/visor/rpc.go @@ -6,10 +6,10 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" ) const ( diff --git a/pkg/visor/rpc_client.go b/pkg/visor/rpc_client.go index a0dfcadc5..66be44ea4 100644 --- a/pkg/visor/rpc_client.go +++ b/pkg/visor/rpc_client.go @@ -9,11 +9,11 @@ import ( "time" "github.com/google/uuid" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" ) // RPCClient represents a RPC Client implementation. diff --git a/pkg/visor/rpc_test.go b/pkg/visor/rpc_test.go index 3f151ea60..ff20ccdfe 100644 --- a/pkg/visor/rpc_test.go +++ b/pkg/visor/rpc_test.go @@ -9,14 +9,14 @@ import ( "testing" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" - "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" ) func TestListApps(t *testing.T) { diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index 5806fd810..e21a37ee3 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -19,16 +19,16 @@ import ( "syscall" "time" - "github.com/skycoin/dmsg/noise" - "github.com/skycoin/skycoin/src/util/logging" - - "github.com/skycoin/skywire/pkg/app" - routeFinder "github.com/skycoin/skywire/pkg/route-finder/client" - "github.com/skycoin/skywire/pkg/router" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" - "github.com/skycoin/skywire/pkg/transport/dmsg" - "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/dmsg/noise" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" + + "github.com/SkycoinProject/skywire/pkg/app" + routeFinder "github.com/SkycoinProject/skywire/pkg/route-finder/client" + "github.com/SkycoinProject/skywire/pkg/router" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" ) var log = logging.MustGetLogger("node") diff --git a/pkg/visor/visor_test.go b/pkg/visor/visor_test.go index f9a76c98a..b3c407db0 100644 --- a/pkg/visor/visor_test.go +++ b/pkg/visor/visor_test.go @@ -14,18 +14,18 @@ import ( "testing" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/skycoin/skywire/internal/httpauth" - "github.com/skycoin/skywire/pkg/app" - "github.com/skycoin/skywire/pkg/routing" - "github.com/skycoin/skywire/pkg/transport" - "github.com/skycoin/skywire/pkg/transport/dmsg" - "github.com/skycoin/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire/internal/httpauth" + "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire/pkg/util/pathutil" ) var masterLogger *logging.MasterLogger diff --git a/vendor/github.com/skycoin/dmsg/cipher/cipher.go b/vendor/github.com/skycoin/dmsg/cipher/cipher.go index 86f567538..9c22b344b 100644 --- a/vendor/github.com/skycoin/dmsg/cipher/cipher.go +++ b/vendor/github.com/skycoin/dmsg/cipher/cipher.go @@ -1,5 +1,5 @@ // Package cipher implements common golang encoding interfaces for -// github.com/skycoin/skycoin/src/cipher +// github.com/SkycoinProject/SkycoinProject/src/cipher package cipher import ( @@ -7,7 +7,7 @@ import ( "fmt" "strings" - "github.com/skycoin/skycoin/src/cipher" + "github.com/SkycoinProject/SkycoinProject/src/cipher" ) func init() { diff --git a/vendor/github.com/skycoin/dmsg/client.go b/vendor/github.com/skycoin/dmsg/client.go index 8e6a20fed..13282e14f 100644 --- a/vendor/github.com/skycoin/dmsg/client.go +++ b/vendor/github.com/skycoin/dmsg/client.go @@ -9,11 +9,11 @@ import ( "time" "github.com/sirupsen/logrus" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/dmsg/noise" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/dmsg/noise" ) var log = logging.MustGetLogger("dmsg") diff --git a/vendor/github.com/skycoin/dmsg/disc/client.go b/vendor/github.com/skycoin/dmsg/disc/client.go index 9f3d4c2ad..624426147 100644 --- a/vendor/github.com/skycoin/dmsg/disc/client.go +++ b/vendor/github.com/skycoin/dmsg/disc/client.go @@ -11,9 +11,9 @@ import ( "sync" "time" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) var log = logging.MustGetLogger("disc") diff --git a/vendor/github.com/skycoin/dmsg/disc/entry.go b/vendor/github.com/skycoin/dmsg/disc/entry.go index afebaabcd..bdeafb528 100644 --- a/vendor/github.com/skycoin/dmsg/disc/entry.go +++ b/vendor/github.com/skycoin/dmsg/disc/entry.go @@ -7,7 +7,7 @@ import ( "strings" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) const currentVersion = "0.0.1" diff --git a/vendor/github.com/skycoin/dmsg/disc/testing.go b/vendor/github.com/skycoin/dmsg/disc/testing.go index dd2eeab9d..8dc40964c 100644 --- a/vendor/github.com/skycoin/dmsg/disc/testing.go +++ b/vendor/github.com/skycoin/dmsg/disc/testing.go @@ -7,7 +7,7 @@ import ( "sync" "time" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) // MockClient is an APIClient mock. The mock doesn't reply with the same errors as the diff --git a/vendor/github.com/skycoin/dmsg/frame.go b/vendor/github.com/skycoin/dmsg/frame.go index 78e10edf5..d00833647 100644 --- a/vendor/github.com/skycoin/dmsg/frame.go +++ b/vendor/github.com/skycoin/dmsg/frame.go @@ -8,9 +8,9 @@ import ( "sync/atomic" "time" - "github.com/skycoin/dmsg/ioutil" + "github.com/SkycoinProject/dmsg/ioutil" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) const ( diff --git a/vendor/github.com/skycoin/dmsg/go.mod b/vendor/github.com/skycoin/dmsg/go.mod index a24455c1f..2e573d695 100644 --- a/vendor/github.com/skycoin/dmsg/go.mod +++ b/vendor/github.com/skycoin/dmsg/go.mod @@ -1,4 +1,4 @@ -module github.com/skycoin/dmsg +module github.com/SkycoinProject/dmsg go 1.12 @@ -9,7 +9,7 @@ require ( github.com/mattn/go-colorable v0.1.2 // indirect github.com/mgutz/ansi v0.0.0-20170206155736-9520e82c474b // indirect github.com/sirupsen/logrus v1.4.2 - github.com/skycoin/skycoin v0.26.0 + github.com/SkycoinProject/SkycoinProject v0.26.0 github.com/stretchr/testify v1.3.0 golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4 // indirect golang.org/x/net v0.0.0-20190620200207-3b0461eec859 diff --git a/vendor/github.com/skycoin/dmsg/ioutil/logging.go b/vendor/github.com/skycoin/dmsg/ioutil/logging.go index 71c97a40e..6a904fe71 100644 --- a/vendor/github.com/skycoin/dmsg/ioutil/logging.go +++ b/vendor/github.com/skycoin/dmsg/ioutil/logging.go @@ -1,7 +1,7 @@ package ioutil import ( - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" ) var log = logging.MustGetLogger("ioutil") diff --git a/vendor/github.com/skycoin/dmsg/noise/dh.go b/vendor/github.com/skycoin/dmsg/noise/dh.go index 6da7ab693..e627bc095 100644 --- a/vendor/github.com/skycoin/dmsg/noise/dh.go +++ b/vendor/github.com/skycoin/dmsg/noise/dh.go @@ -4,7 +4,7 @@ import ( "io" "github.com/flynn/noise" - "github.com/skycoin/skycoin/src/cipher" + "github.com/SkycoinProject/SkycoinProject/src/cipher" ) // Secp256k1 implements `noise.DHFunc`. diff --git a/vendor/github.com/skycoin/dmsg/noise/net.go b/vendor/github.com/skycoin/dmsg/noise/net.go index e065daff6..5759a77f8 100644 --- a/vendor/github.com/skycoin/dmsg/noise/net.go +++ b/vendor/github.com/skycoin/dmsg/noise/net.go @@ -11,7 +11,7 @@ import ( "github.com/flynn/noise" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) var ( diff --git a/vendor/github.com/skycoin/dmsg/noise/noise.go b/vendor/github.com/skycoin/dmsg/noise/noise.go index 3b36cdf79..e9121a7a5 100644 --- a/vendor/github.com/skycoin/dmsg/noise/noise.go +++ b/vendor/github.com/skycoin/dmsg/noise/noise.go @@ -4,11 +4,11 @@ import ( "crypto/rand" "encoding/binary" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" "github.com/flynn/noise" - "github.com/skycoin/dmsg/cipher" + "github.com/SkycoinProject/dmsg/cipher" ) var noiseLogger = logging.MustGetLogger("noise") // TODO: initialize properly or remove diff --git a/vendor/github.com/skycoin/dmsg/noise/read_writer.go b/vendor/github.com/skycoin/dmsg/noise/read_writer.go index 0a17acf5a..355f1cfbe 100644 --- a/vendor/github.com/skycoin/dmsg/noise/read_writer.go +++ b/vendor/github.com/skycoin/dmsg/noise/read_writer.go @@ -8,8 +8,8 @@ import ( "sync" "time" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/ioutil" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/ioutil" ) // ReadWriter implements noise encrypted read writer. diff --git a/vendor/github.com/skycoin/dmsg/server.go b/vendor/github.com/skycoin/dmsg/server.go index 4433b65cd..92f492cc3 100644 --- a/vendor/github.com/skycoin/dmsg/server.go +++ b/vendor/github.com/skycoin/dmsg/server.go @@ -9,11 +9,11 @@ import ( "sync/atomic" "time" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/disc" - "github.com/skycoin/dmsg/noise" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/disc" + "github.com/SkycoinProject/dmsg/noise" ) // ErrListenerAlreadyWrappedToNoise occurs when the provided net.Listener is already wrapped with noise.Listener diff --git a/vendor/github.com/skycoin/dmsg/transport.go b/vendor/github.com/skycoin/dmsg/transport.go index 734983de9..8bfdd573f 100644 --- a/vendor/github.com/skycoin/dmsg/transport.go +++ b/vendor/github.com/skycoin/dmsg/transport.go @@ -8,10 +8,10 @@ import ( "net" "sync" - "github.com/skycoin/skycoin/src/util/logging" + "github.com/SkycoinProject/SkycoinProject/src/util/logging" - "github.com/skycoin/dmsg/cipher" - "github.com/skycoin/dmsg/ioutil" + "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/dmsg/ioutil" ) // Errors related to REQUEST frames. diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/address.go b/vendor/github.com/skycoin/skycoin/src/cipher/address.go index b5d93275b..9693d3356 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/address.go +++ b/vendor/github.com/skycoin/skycoin/src/cipher/address.go @@ -4,7 +4,7 @@ import ( "errors" "log" - "github.com/skycoin/skycoin/src/cipher/base58" + "github.com/SkycoinProject/SkycoinProject/src/cipher/base58" ) var ( diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go b/vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go index e601d5a2c..769ae6989 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go +++ b/vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go @@ -5,7 +5,7 @@ import ( "errors" "log" - "github.com/skycoin/skycoin/src/cipher/base58" + "github.com/SkycoinProject/SkycoinProject/src/cipher/base58" ) var ( diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/crypto.go b/vendor/github.com/skycoin/skycoin/src/cipher/crypto.go index 94499df00..6c0e31a31 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/crypto.go +++ b/vendor/github.com/skycoin/skycoin/src/cipher/crypto.go @@ -24,8 +24,8 @@ import ( "log" "time" - "github.com/skycoin/skycoin/src/cipher/ripemd160" - secp256k1 "github.com/skycoin/skycoin/src/cipher/secp256k1-go" + "github.com/SkycoinProject/SkycoinProject/src/cipher/ripemd160" + secp256k1 "github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go" ) var ( diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go b/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go index f4b8fa93d..de8947815 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go +++ b/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go @@ -9,7 +9,7 @@ import ( "encoding/hex" "log" - secp "github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1-go2" + secp "github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go/secp256k1-go2" ) // DebugPrint enable debug print statements diff --git a/vendor/modules.txt b/vendor/modules.txt index ed78a2a16..442ed25b5 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -62,19 +62,19 @@ github.com/prometheus/procfs/internal/fs # github.com/sirupsen/logrus v1.4.2 github.com/sirupsen/logrus github.com/sirupsen/logrus/hooks/syslog -# github.com/skycoin/dmsg v0.0.0-20190805065636-70f4c32a994f -github.com/skycoin/dmsg/cipher -github.com/skycoin/dmsg -github.com/skycoin/dmsg/disc -github.com/skycoin/dmsg/noise -github.com/skycoin/dmsg/ioutil -# github.com/skycoin/skycoin v0.26.0 -github.com/skycoin/skycoin/src/util/logging -github.com/skycoin/skycoin/src/cipher -github.com/skycoin/skycoin/src/cipher/base58 -github.com/skycoin/skycoin/src/cipher/ripemd160 -github.com/skycoin/skycoin/src/cipher/secp256k1-go -github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1-go2 +# github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f +github.com/SkycoinProject/dmsg/cipher +github.com/SkycoinProject/dmsg +github.com/SkycoinProject/dmsg/disc +github.com/SkycoinProject/dmsg/noise +github.com/SkycoinProject/dmsg/ioutil +# github.com/SkycoinProject/SkycoinProject v0.26.0 +github.com/SkycoinProject/SkycoinProject/src/util/logging +github.com/SkycoinProject/SkycoinProject/src/cipher +github.com/SkycoinProject/SkycoinProject/src/cipher/base58 +github.com/SkycoinProject/SkycoinProject/src/cipher/ripemd160 +github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go +github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go/secp256k1-go2 # github.com/spf13/cobra v0.0.5 github.com/spf13/cobra # github.com/spf13/pflag v1.0.3 From 5856b4263ce28095c38e39a9d9b06c22a2abeefc Mon Sep 17 00:00:00 2001 From: ivcosla Date: Wed, 18 Sep 2019 01:32:29 +0200 Subject: [PATCH 13/14] imported SkycoinProject dmsg, builds and pass tests --- ci_scripts/run-internal-tests.sh | 58 +++---- ci_scripts/run-pkg-tests.sh | 146 +++++++++--------- cmd/apps/helloworld/helloworld.go | 4 +- cmd/apps/skychat/chat.go | 6 +- .../therealproxy-client.go | 8 +- cmd/apps/therealproxy/therealproxy.go | 4 +- .../therealssh-client/therealssh-client.go | 6 +- cmd/apps/therealssh/therealssh.go | 6 +- cmd/hypervisor/commands/gen-config.go | 4 +- cmd/hypervisor/commands/root.go | 6 +- cmd/hypervisor/hypervisor.go | 2 +- cmd/messaging-server/commands/root.go | 2 +- cmd/messaging-server/messaging-server.go | 2 +- cmd/setup-node/commands/root.go | 6 +- cmd/setup-node/setup-node.go | 2 +- cmd/skywire-cli/commands/mdisc/root.go | 2 +- cmd/skywire-cli/commands/node/app.go | 4 +- cmd/skywire-cli/commands/node/gen-config.go | 10 +- cmd/skywire-cli/commands/node/root.go | 4 +- cmd/skywire-cli/commands/node/routes.go | 8 +- cmd/skywire-cli/commands/node/transports.go | 4 +- cmd/skywire-cli/commands/root.go | 8 +- cmd/skywire-cli/commands/rtfind/root.go | 4 +- cmd/skywire-cli/commands/tpdisc/root.go | 6 +- cmd/skywire-cli/internal/internal.go | 2 +- cmd/skywire-cli/skywire-cli.go | 2 +- cmd/skywire-visor/commands/root.go | 6 +- cmd/skywire-visor/skywire-visor.go | 2 +- cmd/therealssh-cli/commands/root.go | 2 +- cmd/therealssh-cli/therealssh-cli.go | 2 +- docs/Tests.Detection-of-unstable-tests.md | 50 +++--- go.mod | 6 +- go.sum | 15 +- internal/httpauth/client.go | 2 +- internal/httpauth/client_test.go | 2 +- internal/therealproxy/client.go | 2 +- internal/therealproxy/server_test.go | 2 +- pkg/app/app.go | 4 +- pkg/app/app_test.go | 6 +- pkg/app/packet.go | 2 +- pkg/app/packet_test.go | 2 +- pkg/httputil/httputil.go | 2 +- pkg/hypervisor/config.go | 2 +- pkg/hypervisor/hypervisor.go | 8 +- pkg/hypervisor/hypervisor_test.go | 2 +- pkg/hypervisor/user_manager.go | 2 +- pkg/route-finder/client/client.go | 4 +- pkg/route-finder/client/mock.go | 4 +- pkg/router/app_manager.go | 6 +- pkg/router/app_manager_test.go | 8 +- pkg/router/loop_list.go | 2 +- pkg/router/managed_routing_table.go | 2 +- pkg/router/managed_routing_table_test.go | 2 +- pkg/router/port_list.go | 4 +- pkg/router/port_manager.go | 4 +- pkg/router/port_manager_test.go | 4 +- pkg/router/route_manager.go | 6 +- pkg/router/route_manager_test.go | 6 +- pkg/router/router.go | 12 +- pkg/router/router_test.go | 14 +- pkg/routing/boltdb_routing_table.go | 2 +- pkg/routing/routing_table_test.go | 2 +- pkg/setup/node.go | 10 +- pkg/setup/node_test.go | 8 +- pkg/setup/protocol.go | 2 +- pkg/therealssh/channel.go | 2 +- pkg/therealssh/channel_pty_test.go | 2 +- pkg/therealssh/channel_test.go | 4 +- pkg/therealssh/client.go | 4 +- pkg/therealssh/client_test.go | 2 +- pkg/therealssh/dialer.go | 2 +- pkg/therealssh/pty_test.go | 2 +- pkg/therealssh/server.go | 4 +- pkg/therealssh/server_test.go | 4 +- pkg/therealssh/session.go | 2 +- pkg/transport-discovery/client/client.go | 6 +- pkg/transport-discovery/client/client_test.go | 6 +- pkg/transport/discovery_test.go | 2 +- pkg/transport/dmsg/dmsg.go | 4 +- pkg/transport/dmsg/testing.go | 2 +- pkg/transport/entry_test.go | 2 +- pkg/transport/log_test.go | 2 +- pkg/transport/managed_transport.go | 4 +- pkg/transport/manager.go | 4 +- pkg/transport/manager_test.go | 8 +- pkg/transport/tcp_transport_test.go | 2 +- pkg/transport/transport.go | 2 +- pkg/util/pathutil/configpath.go | 4 +- pkg/visor/config.go | 8 +- pkg/visor/config_test.go | 4 +- pkg/visor/rpc.go | 4 +- pkg/visor/rpc_client.go | 6 +- pkg/visor/rpc_test.go | 8 +- pkg/visor/visor.go | 18 +-- pkg/visor/visor_test.go | 14 +- .../dmsg/.gitignore | 0 .../dmsg/.golangci.yml | 0 .../dmsg/.travis.yml | 0 .../{skycoin => SkycoinProject}/dmsg/Makefile | 2 +- .../dmsg/README.md | 0 .../dmsg/TESTING.md | 0 .../dmsg/cipher/cipher.go | 4 +- .../dmsg/client.go | 2 +- .../dmsg/disc/client.go | 2 +- .../dmsg/disc/entry.go | 0 .../dmsg/disc/http_message.go | 0 .../dmsg/disc/testing.go | 0 .../{skycoin => SkycoinProject}/dmsg/frame.go | 0 .../{skycoin => SkycoinProject}/dmsg/go.mod | 5 +- .../{skycoin => SkycoinProject}/dmsg/go.sum | 10 +- .../dmsg/ioutil/ack_waiter.go | 0 .../dmsg/ioutil/atomic_bool.go | 0 .../dmsg/ioutil/buf_read.go | 0 .../dmsg/ioutil/logging.go | 2 +- .../dmsg/noise/dh.go | 2 +- .../dmsg/noise/net.go | 0 .../dmsg/noise/noise.go | 2 +- .../dmsg/noise/read_writer.go | 0 .../dmsg/server.go | 2 +- .../dmsg/testing.go | 0 .../dmsg/transport.go | 2 +- .../skycoin/src/cipher/address.go | 2 +- .../skycoin/src/cipher/bitcoin.go | 2 +- .../skycoin/src/cipher/crypto.go | 4 +- .../skycoin/src/cipher/hash.go | 0 .../skycoin/src/util/logging/formatter.go | 0 .../skycoin/src/util/logging/hooks.go | 0 .../skycoin/src/util/logging/logger.go | 0 .../skycoin/src/util/logging/logging.go | 0 .../src/cipher/secp256k1-go/secp256k1.go | 2 +- vendor/modules.txt | 27 ++-- 131 files changed, 375 insertions(+), 374 deletions(-) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/.gitignore (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/.golangci.yml (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/.travis.yml (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/Makefile (95%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/README.md (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/TESTING.md (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/cipher/cipher.go (98%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/client.go (99%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/disc/client.go (98%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/disc/entry.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/disc/http_message.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/disc/testing.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/frame.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/go.mod (81%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/go.sum (84%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/ioutil/ack_waiter.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/ioutil/atomic_bool.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/ioutil/buf_read.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/ioutil/logging.go (53%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/noise/dh.go (92%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/noise/net.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/noise/noise.go (98%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/noise/read_writer.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/server.go (99%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/testing.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/dmsg/transport.go (99%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/cipher/address.go (98%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/cipher/bitcoin.go (98%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/cipher/crypto.go (99%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/cipher/hash.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/util/logging/formatter.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/util/logging/hooks.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/util/logging/logger.go (100%) rename vendor/github.com/{skycoin => SkycoinProject}/skycoin/src/util/logging/logging.go (100%) diff --git a/ci_scripts/run-internal-tests.sh b/ci_scripts/run-internal-tests.sh index 619c5db9e..57be9caf4 100644 --- a/ci_scripts/run-internal-tests.sh +++ b/ci_scripts/run-internal-tests.sh @@ -1,34 +1,34 @@ # commit a70894c8c4223424151cdff7441b1fb2e6bad309 -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriter >> ./logs/internal/TestAckReadWriter.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterCRCFailure >> ./logs/internal/TestAckReadWriterCRCFailure.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterFlushOnClose >> ./logs/internal/TestAckReadWriterFlushOnClose.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterPartialRead >> ./logs/internal/TestAckReadWriterPartialRead.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterReadError >> ./logs/internal/TestAckReadWriterReadError.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestLenReadWriter >> ./logs/internal/TestLenReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriter >> ./logs/internal/TestAckReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterCRCFailure >> ./logs/internal/TestAckReadWriterCRCFailure.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterFlushOnClose >> ./logs/internal/TestAckReadWriterFlushOnClose.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterPartialRead >> ./logs/internal/TestAckReadWriterPartialRead.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterReadError >> ./logs/internal/TestAckReadWriterReadError.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestLenReadWriter >> ./logs/internal/TestLenReadWriter.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestRPCClientDialer >> ./logs/internal/TestRPCClientDialer.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestConn >> ./logs/internal/TestConn.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestListener >> ./logs/internal/TestListener.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestKKAndSecp256k1 >> ./logs/internal/TestKKAndSecp256k1.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestXKAndSecp256k1 >> ./logs/internal/TestXKAndSecp256k1.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestReadWriterKKPattern >> ./logs/internal/TestReadWriterKKPattern.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestReadWriterXKPattern >> ./logs/internal/TestReadWriterXKPattern.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/noise -run TestReadWriterConcurrentTCP >> ./logs/internal/TestReadWriterConcurrentTCP.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestRPCClientDialer >> ./logs/internal/TestRPCClientDialer.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestConn >> ./logs/internal/TestConn.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestListener >> ./logs/internal/TestListener.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestKKAndSecp256k1 >> ./logs/internal/TestKKAndSecp256k1.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestXKAndSecp256k1 >> ./logs/internal/TestXKAndSecp256k1.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestReadWriterKKPattern >> ./logs/internal/TestReadWriterKKPattern.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestReadWriterXKPattern >> ./logs/internal/TestReadWriterXKPattern.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/noise -run TestReadWriterConcurrentTCP >> ./logs/internal/TestReadWriterConcurrentTCP.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealproxy -run TestProxy >> ./logs/internal/TestProxy.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealproxy -run TestProxy >> ./logs/internal/TestProxy.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestListAuthorizer >> ./logs/internal/TestListAuthorizer.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestFileAuthorizer >> ./logs/internal/TestFileAuthorizer.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelServe >> ./logs/internal/TestChannelServe.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelSendWrite >> ./logs/internal/TestChannelSendWrite.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelRead >> ./logs/internal/TestChannelRead.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelRequest >> ./logs/internal/TestChannelRequest.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestChannelServeSocket >> ./logs/internal/TestChannelServeSocket.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestClientOpenChannel >> ./logs/internal/TestClientOpenChannel.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestClientHandleResponse >> ./logs/internal/TestClientHandleResponse.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestClientHandleData >> ./logs/internal/TestClientHandleData.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestServerOpenChannel >> ./logs/internal/TestServerOpenChannel.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestServerHandleRequest >> ./logs/internal/TestServerHandleRequest.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/therealssh -run TestServerHandleData >> ./logs/internal/TestServerHandleData.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestListAuthorizer >> ./logs/internal/TestListAuthorizer.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestFileAuthorizer >> ./logs/internal/TestFileAuthorizer.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestChannelServe >> ./logs/internal/TestChannelServe.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestChannelSendWrite >> ./logs/internal/TestChannelSendWrite.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestChannelRead >> ./logs/internal/TestChannelRead.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestChannelRequest >> ./logs/internal/TestChannelRequest.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestChannelServeSocket >> ./logs/internal/TestChannelServeSocket.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestClientOpenChannel >> ./logs/internal/TestClientOpenChannel.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestClientHandleResponse >> ./logs/internal/TestClientHandleResponse.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestClientHandleData >> ./logs/internal/TestClientHandleData.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestServerOpenChannel >> ./logs/internal/TestServerOpenChannel.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestServerHandleRequest >> ./logs/internal/TestServerHandleRequest.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/therealssh -run TestServerHandleData >> ./logs/internal/TestServerHandleData.log diff --git a/ci_scripts/run-pkg-tests.sh b/ci_scripts/run-pkg-tests.sh index 9ab34cf5a..f365da7be 100644 --- a/ci_scripts/run-pkg-tests.sh +++ b/ci_scripts/run-pkg-tests.sh @@ -1,80 +1,80 @@ # commit a70894c8c4223424151cdff7441b1fb2e6bad309 -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppDial >> ./logs/pkg/TestAppDial.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppAccept >> ./logs/pkg/TestAppAccept.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppWrite >> ./logs/pkg/TestAppWrite.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppRead >> ./logs/pkg/TestAppRead.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppSetup >> ./logs/pkg/TestAppSetup.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppCloseConn >> ./logs/pkg/TestAppCloseConn.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppClose >> ./logs/pkg/TestAppClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestAppCommand >> ./logs/pkg/TestAppCommand.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestPipeConn >> ./logs/pkg/TestPipeConn.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestProtocol >> ./logs/pkg/TestProtocol.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/app -run TestProtocolParallel >> ./logs/pkg/TestProtocolParallel.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppDial >> ./logs/pkg/TestAppDial.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppAccept >> ./logs/pkg/TestAppAccept.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppWrite >> ./logs/pkg/TestAppWrite.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppRead >> ./logs/pkg/TestAppRead.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppSetup >> ./logs/pkg/TestAppSetup.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppCloseConn >> ./logs/pkg/TestAppCloseConn.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppClose >> ./logs/pkg/TestAppClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestAppCommand >> ./logs/pkg/TestAppCommand.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestPipeConn >> ./logs/pkg/TestPipeConn.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestProtocol >> ./logs/pkg/TestProtocol.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/app -run TestProtocolParallel >> ./logs/pkg/TestProtocolParallel.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/hypervisor -run TestNewNode >> ./logs/pkg/TestNewNode.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/hypervisor -run TestNewNode >> ./logs/pkg/TestNewNode.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestMessagingDiscovery >> ./logs/pkg/TestMessagingDiscovery.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestTransportDiscovery >> ./logs/pkg/TestTransportDiscovery.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestTransportLogStore >> ./logs/pkg/TestTransportLogStore.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestAppsConfig >> ./logs/pkg/TestAppsConfig.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestAppsDir >> ./logs/pkg/TestAppsDir.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestLocalDir >> ./logs/pkg/TestLocalDir.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNewNode >> ./logs/pkg/TestNewNode.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNodeStartClose >> ./logs/pkg/TestNodeStartClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNodeSpawnApp >> ./logs/pkg/TestNodeSpawnApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestNodeSpawnAppValidations >> ./logs/pkg/TestNodeSpawnAppValidations.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestListApps >> ./logs/pkg/TestListApps.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestStartStopApp >> ./logs/pkg/TestStartStopApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/node -run TestRPC >> ./logs/pkg/TestRPC.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestMessagingDiscovery >> ./logs/pkg/TestMessagingDiscovery.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestTransportDiscovery >> ./logs/pkg/TestTransportDiscovery.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestTransportLogStore >> ./logs/pkg/TestTransportLogStore.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestAppsConfig >> ./logs/pkg/TestAppsConfig.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestAppsDir >> ./logs/pkg/TestAppsDir.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestLocalDir >> ./logs/pkg/TestLocalDir.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestNewNode >> ./logs/pkg/TestNewNode.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestNodeStartClose >> ./logs/pkg/TestNodeStartClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestNodeSpawnApp >> ./logs/pkg/TestNodeSpawnApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestNodeSpawnAppValidations >> ./logs/pkg/TestNodeSpawnAppValidations.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestListApps >> ./logs/pkg/TestListApps.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestStartStopApp >> ./logs/pkg/TestStartStopApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/node -run TestRPC >> ./logs/pkg/TestRPC.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerInit >> ./logs/pkg/TestAppManagerInit.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerSetupLoop >> ./logs/pkg/TestAppManagerSetupLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerCloseLoop >> ./logs/pkg/TestAppManagerCloseLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestAppManagerForward >> ./logs/pkg/TestAppManagerForward.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestManagedRoutingTableCleanup >> ./logs/pkg/TestManagedRoutingTableCleanup.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestPortManager >> ./logs/pkg/TestPortManager.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerGetRule >> ./logs/pkg/TestRouteManagerGetRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerRemoveLoopRule >> ./logs/pkg/TestRouteManagerRemoveLoopRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerAddRemoveRule >> ./logs/pkg/TestRouteManagerAddRemoveRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerDeleteRules >> ./logs/pkg/TestRouteManagerDeleteRules.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerConfirmLoop >> ./logs/pkg/TestRouteManagerConfirmLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouteManagerLoopClosed >> ./logs/pkg/TestRouteManagerLoopClosed.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterForwarding >> ./logs/pkg/TestRouterForwarding.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterAppInit >> ./logs/pkg/TestRouterAppInit.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterApp >> ./logs/pkg/TestRouterApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterLocalApp >> ./logs/pkg/TestRouterLocalApp.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterSetup >> ./logs/pkg/TestRouterSetup.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterSetupLoop >> ./logs/pkg/TestRouterSetupLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterSetupLoopLocal >> ./logs/pkg/TestRouterSetupLoopLocal.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterCloseLoop >> ./logs/pkg/TestRouterCloseLoop.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterCloseLoopOnAppClose >> ./logs/pkg/TestRouterCloseLoopOnAppClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterCloseLoopOnRouterClose >> ./logs/pkg/TestRouterCloseLoopOnRouterClose.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/router -run TestRouterRouteExpiration >> ./logs/pkg/TestRouterRouteExpiration.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestAppManagerInit >> ./logs/pkg/TestAppManagerInit.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestAppManagerSetupLoop >> ./logs/pkg/TestAppManagerSetupLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestAppManagerCloseLoop >> ./logs/pkg/TestAppManagerCloseLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestAppManagerForward >> ./logs/pkg/TestAppManagerForward.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestManagedRoutingTableCleanup >> ./logs/pkg/TestManagedRoutingTableCleanup.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestPortManager >> ./logs/pkg/TestPortManager.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouteManagerGetRule >> ./logs/pkg/TestRouteManagerGetRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouteManagerRemoveLoopRule >> ./logs/pkg/TestRouteManagerRemoveLoopRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouteManagerAddRemoveRule >> ./logs/pkg/TestRouteManagerAddRemoveRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouteManagerDeleteRules >> ./logs/pkg/TestRouteManagerDeleteRules.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouteManagerConfirmLoop >> ./logs/pkg/TestRouteManagerConfirmLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouteManagerLoopClosed >> ./logs/pkg/TestRouteManagerLoopClosed.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterForwarding >> ./logs/pkg/TestRouterForwarding.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterAppInit >> ./logs/pkg/TestRouterAppInit.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterApp >> ./logs/pkg/TestRouterApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterLocalApp >> ./logs/pkg/TestRouterLocalApp.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterSetup >> ./logs/pkg/TestRouterSetup.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterSetupLoop >> ./logs/pkg/TestRouterSetupLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterSetupLoopLocal >> ./logs/pkg/TestRouterSetupLoopLocal.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterCloseLoop >> ./logs/pkg/TestRouterCloseLoop.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterCloseLoopOnAppClose >> ./logs/pkg/TestRouterCloseLoopOnAppClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterCloseLoopOnRouterClose >> ./logs/pkg/TestRouterCloseLoopOnRouterClose.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/router -run TestRouterRouteExpiration >> ./logs/pkg/TestRouterRouteExpiration.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestBoltDBRoutingTable >> ./logs/pkg/TestBoltDBRoutingTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestMakePacket >> ./logs/pkg/TestMakePacket.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestAppRule >> ./logs/pkg/TestAppRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/routing -run TestForwardRule >> ./logs/pkg/TestForwardRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/routing -run TestBoltDBRoutingTable >> ./logs/pkg/TestBoltDBRoutingTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/routing -run TestMakePacket >> ./logs/pkg/TestMakePacket.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/routing -run TestRoutingTable >> ./logs/pkg/TestRoutingTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/routing -run TestAppRule >> ./logs/pkg/TestAppRule.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/routing -run TestForwardRule >> ./logs/pkg/TestForwardRule.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/setup -run TestNewProtocol >> ./logs/pkg/TestNewProtocol.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/setup -run TestNewProtocol >> ./logs/pkg/TestNewProtocol.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshake >> ./logs/pkg/TestSettlementHandshake.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshakeInvalidSig >> ./logs/pkg/TestSettlementHandshakeInvalidSig.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshakePrivate >> ./logs/pkg/TestSettlementHandshakePrivate.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestSettlementHandshakeExistingTransport >> ./logs/pkg/TestSettlementHandshakeExistingTransport.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestValidateEntry >> ./logs/pkg/TestValidateEntry.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestInMemoryTransportLogStore >> ./logs/pkg/TestInMemoryTransportLogStore.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestFileTransportLogStore >> ./logs/pkg/TestFileTransportLogStore.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTransportManager >> ./logs/pkg/TestTransportManager.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTransportManagerReEstablishTransports >> ./logs/pkg/TestTransportManagerReEstablishTransports.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTransportManagerLogs >> ./logs/pkg/TestTransportManagerLogs.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestTCPFactory >> ./logs/pkg/TestTCPFactory.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport -run TestFilePKTable >> ./logs/pkg/TestFilePKTable.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestClientAuth >> ./logs/pkg/TestClientAuth.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestRegisterTransportResponses >> ./logs/pkg/TestRegisterTransportResponses.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestRegisterTransports >> ./logs/pkg/TestRegisterTransports.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestGetTransportByID >> ./logs/pkg/TestGetTransportByID.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestGetTransportsByEdge >> ./logs/pkg/TestGetTransportsByEdge.log -go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/pkg/transport-discovery/client -run TestUpdateStatuses >> ./logs/pkg/TestUpdateStatuses.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestSettlementHandshake >> ./logs/pkg/TestSettlementHandshake.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestSettlementHandshakeInvalidSig >> ./logs/pkg/TestSettlementHandshakeInvalidSig.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestSettlementHandshakePrivate >> ./logs/pkg/TestSettlementHandshakePrivate.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestSettlementHandshakeExistingTransport >> ./logs/pkg/TestSettlementHandshakeExistingTransport.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestValidateEntry >> ./logs/pkg/TestValidateEntry.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestInMemoryTransportLogStore >> ./logs/pkg/TestInMemoryTransportLogStore.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestFileTransportLogStore >> ./logs/pkg/TestFileTransportLogStore.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestTransportManager >> ./logs/pkg/TestTransportManager.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestTransportManagerReEstablishTransports >> ./logs/pkg/TestTransportManagerReEstablishTransports.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestTransportManagerLogs >> ./logs/pkg/TestTransportManagerLogs.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestTCPFactory >> ./logs/pkg/TestTCPFactory.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport -run TestFilePKTable >> ./logs/pkg/TestFilePKTable.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client -run TestClientAuth >> ./logs/pkg/TestClientAuth.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client -run TestRegisterTransportResponses >> ./logs/pkg/TestRegisterTransportResponses.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client -run TestRegisterTransports >> ./logs/pkg/TestRegisterTransports.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client -run TestGetTransportByID >> ./logs/pkg/TestGetTransportByID.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client -run TestGetTransportsByEdge >> ./logs/pkg/TestGetTransportsByEdge.log +go clean -testcache &> /dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client -run TestUpdateStatuses >> ./logs/pkg/TestUpdateStatuses.log diff --git a/cmd/apps/helloworld/helloworld.go b/cmd/apps/helloworld/helloworld.go index 7846695db..226186995 100644 --- a/cmd/apps/helloworld/helloworld.go +++ b/cmd/apps/helloworld/helloworld.go @@ -9,8 +9,8 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func main() { diff --git a/cmd/apps/skychat/chat.go b/cmd/apps/skychat/chat.go index fb8754f26..0f9c8e649 100644 --- a/cmd/apps/skychat/chat.go +++ b/cmd/apps/skychat/chat.go @@ -17,9 +17,9 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/internal/netutil" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/netutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) var addr = flag.String("addr", ":8000", "address to bind") diff --git a/cmd/apps/therealproxy-client/therealproxy-client.go b/cmd/apps/therealproxy-client/therealproxy-client.go index 84c75e580..93ebb2bfe 100644 --- a/cmd/apps/therealproxy-client/therealproxy-client.go +++ b/cmd/apps/therealproxy-client/therealproxy-client.go @@ -11,10 +11,10 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/internal/netutil" - "github.com/SkycoinProject/skywire/internal/therealproxy" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/netutil" + "github.com/SkycoinProject/skywire-mainnet/internal/therealproxy" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) const socksPort = 3 diff --git a/cmd/apps/therealproxy/therealproxy.go b/cmd/apps/therealproxy/therealproxy.go index b5c853274..4e0965072 100644 --- a/cmd/apps/therealproxy/therealproxy.go +++ b/cmd/apps/therealproxy/therealproxy.go @@ -7,8 +7,8 @@ import ( "flag" "log" - "github.com/SkycoinProject/skywire/internal/therealproxy" - "github.com/SkycoinProject/skywire/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/internal/therealproxy" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" ) func main() { diff --git a/cmd/apps/therealssh-client/therealssh-client.go b/cmd/apps/therealssh-client/therealssh-client.go index 5658ad959..11e1b41d8 100644 --- a/cmd/apps/therealssh-client/therealssh-client.go +++ b/cmd/apps/therealssh-client/therealssh-client.go @@ -9,10 +9,10 @@ import ( "net/http" "github.com/sirupsen/logrus" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/app" - ssh "github.com/SkycoinProject/skywire/pkg/therealssh" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + ssh "github.com/SkycoinProject/skywire-mainnet/pkg/therealssh" ) func main() { diff --git a/cmd/apps/therealssh/therealssh.go b/cmd/apps/therealssh/therealssh.go index 8409d486c..781f6dde4 100644 --- a/cmd/apps/therealssh/therealssh.go +++ b/cmd/apps/therealssh/therealssh.go @@ -9,10 +9,10 @@ import ( "github.com/mitchellh/go-homedir" "github.com/sirupsen/logrus" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/app" - ssh "github.com/SkycoinProject/skywire/pkg/therealssh" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + ssh "github.com/SkycoinProject/skywire-mainnet/pkg/therealssh" ) func main() { diff --git a/cmd/hypervisor/commands/gen-config.go b/cmd/hypervisor/commands/gen-config.go index 813f421cc..4956e04e1 100644 --- a/cmd/hypervisor/commands/gen-config.go +++ b/cmd/hypervisor/commands/gen-config.go @@ -6,8 +6,8 @@ import ( "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/pkg/hypervisor" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/hypervisor" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) var ( diff --git a/cmd/hypervisor/commands/root.go b/cmd/hypervisor/commands/root.go index 698d70375..eb1982f87 100644 --- a/cmd/hypervisor/commands/root.go +++ b/cmd/hypervisor/commands/root.go @@ -6,11 +6,11 @@ import ( "net/http" "os" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/pkg/hypervisor" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/hypervisor" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) const configEnv = "SW_HYPERVISOR_CONFIG" diff --git a/cmd/hypervisor/hypervisor.go b/cmd/hypervisor/hypervisor.go index 380ccb2b1..cde4e7977 100644 --- a/cmd/hypervisor/hypervisor.go +++ b/cmd/hypervisor/hypervisor.go @@ -3,7 +3,7 @@ skywire hypervisor */ package main -import "github.com/SkycoinProject/skywire/cmd/hypervisor/commands" +import "github.com/SkycoinProject/skywire-mainnet/cmd/hypervisor/commands" func main() { commands.Execute() diff --git a/cmd/messaging-server/commands/root.go b/cmd/messaging-server/commands/root.go index b5fefff01..9a4017c59 100644 --- a/cmd/messaging-server/commands/root.go +++ b/cmd/messaging-server/commands/root.go @@ -16,7 +16,7 @@ import ( "github.com/SkycoinProject/dmsg" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/spf13/cobra" ) diff --git a/cmd/messaging-server/messaging-server.go b/cmd/messaging-server/messaging-server.go index d7c0ba577..4db968bea 100644 --- a/cmd/messaging-server/messaging-server.go +++ b/cmd/messaging-server/messaging-server.go @@ -1,6 +1,6 @@ package main -import "github.com/SkycoinProject/skywire/cmd/messaging-server/commands" +import "github.com/SkycoinProject/skywire-mainnet/cmd/messaging-server/commands" func main() { commands.Execute() diff --git a/cmd/setup-node/commands/root.go b/cmd/setup-node/commands/root.go index 1e6a1c19d..98013074c 100644 --- a/cmd/setup-node/commands/root.go +++ b/cmd/setup-node/commands/root.go @@ -12,11 +12,11 @@ import ( "github.com/prometheus/client_golang/prometheus/promhttp" logrussyslog "github.com/sirupsen/logrus/hooks/syslog" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/pkg/metrics" - "github.com/SkycoinProject/skywire/pkg/setup" + "github.com/SkycoinProject/skywire-mainnet/pkg/metrics" + "github.com/SkycoinProject/skywire-mainnet/pkg/setup" ) var ( diff --git a/cmd/setup-node/setup-node.go b/cmd/setup-node/setup-node.go index f64c1f6df..e882d663e 100644 --- a/cmd/setup-node/setup-node.go +++ b/cmd/setup-node/setup-node.go @@ -1,6 +1,6 @@ package main -import "github.com/SkycoinProject/skywire/cmd/setup-node/commands" +import "github.com/SkycoinProject/skywire-mainnet/cmd/setup-node/commands" func main() { commands.Execute() diff --git a/cmd/skywire-cli/commands/mdisc/root.go b/cmd/skywire-cli/commands/mdisc/root.go index fca7df79f..b500045f0 100644 --- a/cmd/skywire-cli/commands/mdisc/root.go +++ b/cmd/skywire-cli/commands/mdisc/root.go @@ -10,7 +10,7 @@ import ( "github.com/SkycoinProject/dmsg/disc" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/internal" ) var mdAddr string diff --git a/cmd/skywire-cli/commands/node/app.go b/cmd/skywire-cli/commands/node/app.go index 473138f87..fee30857a 100644 --- a/cmd/skywire-cli/commands/node/app.go +++ b/cmd/skywire-cli/commands/node/app.go @@ -8,8 +8,8 @@ import ( "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) func init() { diff --git a/cmd/skywire-cli/commands/node/gen-config.go b/cmd/skywire-cli/commands/node/gen-config.go index 0b084d74a..75659e03e 100644 --- a/cmd/skywire-cli/commands/node/gen-config.go +++ b/cmd/skywire-cli/commands/node/gen-config.go @@ -9,8 +9,8 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) func init() { @@ -68,9 +68,9 @@ func homeConfig() *visor.Config { func localConfig() *visor.Config { c := defaultConfig() - c.AppsPath = "/usr/local/SkycoinProject/skywire/apps" - c.Transport.LogStore.Location = "/usr/local/SkycoinProject/skywire/transport_logs" - c.Routing.Table.Location = "/usr/local/SkycoinProject/skywire/routing.db" + c.AppsPath = "/usr/local/SkycoinProject/skywire-mainnet/apps" + c.Transport.LogStore.Location = "/usr/local/SkycoinProject/skywire-mainnet/transport_logs" + c.Routing.Table.Location = "/usr/local/SkycoinProject/skywire-mainnet/routing.db" return c } diff --git a/cmd/skywire-cli/commands/node/root.go b/cmd/skywire-cli/commands/node/root.go index d11eb982f..f75085c7a 100644 --- a/cmd/skywire-cli/commands/node/root.go +++ b/cmd/skywire-cli/commands/node/root.go @@ -3,10 +3,10 @@ package node import ( "net/rpc" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) var log = logging.MustGetLogger("skywire-cli") diff --git a/cmd/skywire-cli/commands/node/routes.go b/cmd/skywire-cli/commands/node/routes.go index 7e5141e41..63c1426db 100644 --- a/cmd/skywire-cli/commands/node/routes.go +++ b/cmd/skywire-cli/commands/node/routes.go @@ -11,10 +11,10 @@ import ( "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" - "github.com/SkycoinProject/skywire/pkg/router" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire-mainnet/pkg/router" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) func init() { diff --git a/cmd/skywire-cli/commands/node/transports.go b/cmd/skywire-cli/commands/node/transports.go index a410c26b8..d6c4fc375 100644 --- a/cmd/skywire-cli/commands/node/transports.go +++ b/cmd/skywire-cli/commands/node/transports.go @@ -11,8 +11,8 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) func init() { diff --git a/cmd/skywire-cli/commands/root.go b/cmd/skywire-cli/commands/root.go index 3c0562469..ba2a9774c 100644 --- a/cmd/skywire-cli/commands/root.go +++ b/cmd/skywire-cli/commands/root.go @@ -5,10 +5,10 @@ import ( "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/mdisc" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/node" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/rtfind" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands/tpdisc" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/commands/mdisc" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/commands/node" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/commands/rtfind" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/commands/tpdisc" ) var rootCmd = &cobra.Command{ diff --git a/cmd/skywire-cli/commands/rtfind/root.go b/cmd/skywire-cli/commands/rtfind/root.go index a1623fddc..a05f9502d 100644 --- a/cmd/skywire-cli/commands/rtfind/root.go +++ b/cmd/skywire-cli/commands/rtfind/root.go @@ -7,8 +7,8 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" - "github.com/SkycoinProject/skywire/pkg/route-finder/client" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire-mainnet/pkg/route-finder/client" ) var frAddr string diff --git a/cmd/skywire-cli/commands/tpdisc/root.go b/cmd/skywire-cli/commands/tpdisc/root.go index 6fe45d58f..129220e09 100644 --- a/cmd/skywire-cli/commands/tpdisc/root.go +++ b/cmd/skywire-cli/commands/tpdisc/root.go @@ -12,9 +12,9 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/cmd/skywire-cli/internal" - "github.com/SkycoinProject/skywire/pkg/transport" - "github.com/SkycoinProject/skywire/pkg/transport-discovery/client" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/internal" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client" ) var ( diff --git a/cmd/skywire-cli/internal/internal.go b/cmd/skywire-cli/internal/internal.go index 8b25341d9..783c35bd4 100644 --- a/cmd/skywire-cli/internal/internal.go +++ b/cmd/skywire-cli/internal/internal.go @@ -5,7 +5,7 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("skywire-cli") diff --git a/cmd/skywire-cli/skywire-cli.go b/cmd/skywire-cli/skywire-cli.go index 5e3a89c34..66d50e0a3 100644 --- a/cmd/skywire-cli/skywire-cli.go +++ b/cmd/skywire-cli/skywire-cli.go @@ -4,7 +4,7 @@ CLI for skywire visor package main import ( - "github.com/SkycoinProject/skywire/cmd/skywire-cli/commands" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-cli/commands" ) func main() { diff --git a/cmd/skywire-visor/commands/root.go b/cmd/skywire-visor/commands/root.go index 2501c2438..a4bda640d 100644 --- a/cmd/skywire-visor/commands/root.go +++ b/cmd/skywire-visor/commands/root.go @@ -19,11 +19,11 @@ import ( "github.com/pkg/profile" logrussyslog "github.com/sirupsen/logrus/hooks/syslog" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/spf13/cobra" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) const configEnv = "SW_CONFIG" diff --git a/cmd/skywire-visor/skywire-visor.go b/cmd/skywire-visor/skywire-visor.go index 5a49f330b..282da4c41 100644 --- a/cmd/skywire-visor/skywire-visor.go +++ b/cmd/skywire-visor/skywire-visor.go @@ -4,7 +4,7 @@ skywire visor package main import ( - "github.com/SkycoinProject/skywire/cmd/skywire-visor/commands" + "github.com/SkycoinProject/skywire-mainnet/cmd/skywire-visor/commands" ) func main() { diff --git a/cmd/therealssh-cli/commands/root.go b/cmd/therealssh-cli/commands/root.go index e64b533a6..d4c8b54f0 100644 --- a/cmd/therealssh-cli/commands/root.go +++ b/cmd/therealssh-cli/commands/root.go @@ -18,7 +18,7 @@ import ( "github.com/spf13/cobra" "golang.org/x/crypto/ssh/terminal" - ssh "github.com/SkycoinProject/skywire/pkg/therealssh" + ssh "github.com/SkycoinProject/skywire-mainnet/pkg/therealssh" ) var ( diff --git a/cmd/therealssh-cli/therealssh-cli.go b/cmd/therealssh-cli/therealssh-cli.go index c45136644..410fcf4ec 100644 --- a/cmd/therealssh-cli/therealssh-cli.go +++ b/cmd/therealssh-cli/therealssh-cli.go @@ -4,7 +4,7 @@ CLI for SSH app package main import ( - "github.com/SkycoinProject/skywire/cmd/therealssh-cli/commands" + "github.com/SkycoinProject/skywire-mainnet/cmd/therealssh-cli/commands" ) func main() { diff --git a/docs/Tests.Detection-of-unstable-tests.md b/docs/Tests.Detection-of-unstable-tests.md index 8f2581d0a..ba93b2e11 100644 --- a/docs/Tests.Detection-of-unstable-tests.md +++ b/docs/Tests.Detection-of-unstable-tests.md @@ -21,15 +21,15 @@ You will get output similar to: ```text TestClient -ok github.com/SkycoinProject/skywire/internal/httpauth 0.043s -? github.com/SkycoinProject/skywire/internal/httputil [no test files] +ok github.com/SkycoinProject/skywire-mainnet/internal/httpauth 0.043s +? github.com/SkycoinProject/skywire-mainnet/internal/httputil [no test files] TestAckReadWriter TestAckReadWriterCRCFailure TestAckReadWriterFlushOnClose TestAckReadWriterPartialRead TestAckReadWriterReadError TestLenReadWriter -ok github.com/SkycoinProject/skywire/internal/ioutil 0.049s +ok github.com/SkycoinProject/skywire-mainnet/internal/ioutil 0.049s ``` Filter lines with `[no test files]`. @@ -37,14 +37,14 @@ Filter lines with `[no test files]`. Transform this output to: ```bash -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log - -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriter >>./logs/internal/TestAckReadWriter.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterCRCFailure >>./logs/internal/TestAckReadWriterCRCFailure.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterFlushOnClose >>./logs/internal/TestAckReadWriterFlushOnClose.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterPartialRead >>./logs/internal/TestAckReadWriterPartialRead.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestAckReadWriterReadError >>./logs/internal/TestAckReadWriterReadError.log -go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire/internal/ioutil -run TestLenReadWriter >>./logs/internal/TestLenReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/httpauth -run TestClient >> ./logs/internal/TestClient.log + +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriter >>./logs/internal/TestAckReadWriter.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterCRCFailure >>./logs/internal/TestAckReadWriterCRCFailure.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterFlushOnClose >>./logs/internal/TestAckReadWriterFlushOnClose.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterPartialRead >>./logs/internal/TestAckReadWriterPartialRead.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestAckReadWriterReadError >>./logs/internal/TestAckReadWriterReadError.log +go clean -testcache &>/dev/null || go test -race -tags no_ci -cover -timeout=5m github.com/SkycoinProject/skywire-mainnet/internal/ioutil -run TestLenReadWriter >>./logs/internal/TestLenReadWriter.log ``` Notes: @@ -79,10 +79,10 @@ If you see something like: ```sh $ grep "FAIL" ./logs/pkg/*.log -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.838s -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.849s -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.844s -# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire/pkg/messaging 300.849s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire-mainnet/pkg/messaging 300.838s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire-mainnet/pkg/messaging 300.849s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire-mainnet/pkg/messaging 300.844s +# ./logs/pkg/TestClientConnectInitialServers.log:FAIL github.com/SkycoinProject/skywire-mainnet/pkg/messaging 300.849s ``` (note 300s for FAILs) @@ -91,12 +91,12 @@ And: ```sh $ grep "coverage" ./logs/pkg/TestClientConnectInitialServers.log -# ok github.com/SkycoinProject/skywire/pkg/messaging 3.049s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire-mainnet/pkg/messaging 3.049s coverage: 39.5% of statements # coverage: 38.0% of statements -# ok github.com/SkycoinProject/skywire/pkg/messaging 3.072s coverage: 39.5% of statements -# ok github.com/SkycoinProject/skywire/pkg/messaging 3.073s coverage: 39.5% of statements -# ok github.com/SkycoinProject/skywire/pkg/messaging 3.071s coverage: 39.5% of statements -# ok github.com/SkycoinProject/skywire/pkg/messaging 3.050s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire-mainnet/pkg/messaging 3.072s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire-mainnet/pkg/messaging 3.073s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire-mainnet/pkg/messaging 3.071s coverage: 39.5% of statements +# ok github.com/SkycoinProject/skywire-mainnet/pkg/messaging 3.050s coverage: 39.5% of statements # coverage: 38.0% of statements ``` @@ -129,11 +129,11 @@ Temporary solution: test was moved to `./pkg/messaging/client_test.go` and tagge ```sh $ grep coverage ./logs/internal/*.log # ./logs/internal/TestReadWriterConcurrentTCP.log -# 1:ok github.com/SkycoinProject/skywire/internal/noise 1.545s coverage: 0.0% of statements -# 2:ok github.com/SkycoinProject/skywire/internal/noise 1.427s coverage: 0.0% of statements -# 3:ok github.com/SkycoinProject/skywire/internal/noise 1.429s coverage: 0.0% of statements -# 4:ok github.com/SkycoinProject/skywire/internal/noise 1.429s coverage: 0.0% of statements -# 5:ok github.com/SkycoinProject/skywire/internal/noise 1.436s coverage: 0.0% of statements +# 1:ok github.com/SkycoinProject/skywire-mainnet/internal/noise 1.545s coverage: 0.0% of statements +# 2:ok github.com/SkycoinProject/skywire-mainnet/internal/noise 1.427s coverage: 0.0% of statements +# 3:ok github.com/SkycoinProject/skywire-mainnet/internal/noise 1.429s coverage: 0.0% of statements +# 4:ok github.com/SkycoinProject/skywire-mainnet/internal/noise 1.429s coverage: 0.0% of statements +# 5:ok github.com/SkycoinProject/skywire-mainnet/internal/noise 1.436s coverage: 0.0% of statements ``` Note 0.0% coverage diff --git a/go.mod b/go.mod index b42a521b1..ad35fc248 100644 --- a/go.mod +++ b/go.mod @@ -1,8 +1,10 @@ -module github.com/SkycoinProject/skywire +module github.com/SkycoinProject/skywire-mainnet go 1.12 require ( + github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb + github.com/SkycoinProject/skycoin v0.26.0 github.com/armon/go-socks5 v0.0.0-20160902184237-e75332964ef5 github.com/creack/pty v1.1.7 github.com/go-chi/chi v4.0.2+incompatible @@ -16,8 +18,6 @@ require ( github.com/prometheus/client_golang v1.0.0 github.com/prometheus/common v0.4.1 github.com/sirupsen/logrus v1.4.2 - github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f - github.com/SkycoinProject/SkycoinProject v0.26.0 github.com/spf13/cobra v0.0.5 github.com/stretchr/testify v1.3.0 go.etcd.io/bbolt v1.3.3 diff --git a/go.sum b/go.sum index 59277a77a..0c1b09f1d 100644 --- a/go.sum +++ b/go.sum @@ -1,4 +1,12 @@ github.com/BurntSushi/toml v0.3.1/go.mod h1:xHWCNGjB5oqiDr8zfno3MHue2Ht5sIBksp03qcyfWMU= +github.com/SkycoinProject/SkycoinProject v0.26.0 h1:xDxe2r8AclMntZ550Y/vUQgwgLtwrf9Wu5UYiYcN5/o= +github.com/SkycoinProject/SkycoinProject v0.26.0/go.mod h1:78nHjQzd8KG0jJJVL/j0xMmrihXi70ti63fh8vXScJw= +github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f h1:WWjaxOXoj6oYelm67MNtJbg51HQALjKAyhs2WAHgpZs= +github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f/go.mod h1:obZYZp8eKR7Xqz+KNhJdUE6Gvp6rEXbDO8YTlW2YXgU= +github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb h1:bAKk+ypvaiD5YuIkOmWhh2FJVX2XQpJPR4TgQKsYD8Y= +github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb/go.mod h1:FwzixIUE0zAT9J1cfWU5WsN9JiI49oQ6dHlNZcpq23s= +github.com/SkycoinProject/skycoin v0.26.0 h1:8/ZRZb2VM2DM4YTIitRJMZ3Yo/3H1FFmbCMx5o6ekmA= +github.com/SkycoinProject/skycoin v0.26.0/go.mod h1:xqPLOKh5B6GBZlGA7B5IJfQmCy7mwimD9NlqxR3gMXo= github.com/alecthomas/template v0.0.0-20160405071501-a0175ee3bccc h1:cAKDfWh5VpdgMhJosfJnn5/FoN2SRZ4p7fJNX58YPaU= github.com/alecthomas/template v0.0.0-20160405071501-a0175ee3bccc/go.mod h1:LOuyumcjzFXgccqObfd/Ljyb9UuFJ6TxHnclSeseNhc= github.com/alecthomas/units v0.0.0-20151022065526-2efee857e7cf h1:qet1QNfXsQxTZqLG4oE62mJzwPIB8+Tee4RNCL9ulrY= @@ -43,6 +51,7 @@ github.com/inconshreveable/mousetrap v1.0.0 h1:Z8tu5sraLXCXIcARxBp/8cbvlwVa7Z1NH github.com/inconshreveable/mousetrap v1.0.0/go.mod h1:PxqpIevigyE2G7u3NXJIT2ANytuPF1OarO4DADm73n8= github.com/json-iterator/go v1.1.6/go.mod h1:+SdeFBvtyEkXs7REEP0seUULqWtbJapLOCVDaaPEHmU= github.com/julienschmidt/httprouter v1.2.0/go.mod h1:SYymIcj16QtmaHHD7aYtjjsJG7VTCxuUUipMqKk8s4w= +github.com/konsorten/go-windows-terminal-sequences v1.0.1 h1:mweAR1A6xJ3oS2pRaGiHgQ4OO8tzTaLawm8vnODuwDk= github.com/konsorten/go-windows-terminal-sequences v1.0.1/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= github.com/konsorten/go-windows-terminal-sequences v1.0.2 h1:DB17ag19krx9CFsz4o3enTrPXyIXCl+2iCXH/aMAp9s= github.com/konsorten/go-windows-terminal-sequences v1.0.2/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= @@ -88,10 +97,8 @@ github.com/russross/blackfriday v1.5.2/go.mod h1:JO/DiYxRf+HjHt06OyowR9PTA263kcR github.com/sirupsen/logrus v1.2.0/go.mod h1:LxeOpSwHxABJmUn/MG1IvRgCAasNZTLOkJPxbbu5VWo= github.com/sirupsen/logrus v1.4.2 h1:SPIRibHv4MatM3XXNO2BJeFLZwZ2LvZgfQ5+UNI2im4= github.com/sirupsen/logrus v1.4.2/go.mod h1:tLMulIdttU9McNUspp0xgXVQah82FyeX6MwdIuYE2rE= -github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f h1:WWjaxOXoj6oYelm67MNtJbg51HQALjKAyhs2WAHgpZs= -github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f/go.mod h1:obZYZp8eKR7Xqz+KNhJdUE6Gvp6rEXbDO8YTlW2YXgU= -github.com/SkycoinProject/SkycoinProject v0.26.0 h1:xDxe2r8AclMntZ550Y/vUQgwgLtwrf9Wu5UYiYcN5/o= -github.com/SkycoinProject/SkycoinProject v0.26.0/go.mod h1:78nHjQzd8KG0jJJVL/j0xMmrihXi70ti63fh8vXScJw= +github.com/skycoin/skycoin v0.26.0 h1:xDxe2r8AclMntZ550Y/vUQgwgLtwrf9Wu5UYiYcN5/o= +github.com/skycoin/skycoin v0.26.0/go.mod h1:78nHjQzd8KG0jJJVL/j0xMmrihXi70ti63fh8vXScJw= github.com/spf13/afero v1.1.2/go.mod h1:j4pytiNVoe2o6bmDsKpLACNPDBIoEAkihy7loJ1B0CQ= github.com/spf13/cast v1.3.0/go.mod h1:Qx5cxh0v+4UWYiBimWS+eyWzqEqokIECu5etghLkUJE= github.com/spf13/cobra v0.0.5 h1:f0B+LkLX6DtmRH1isoNA9VTtNUK9K8xYd28JNNfOv/s= diff --git a/internal/httpauth/client.go b/internal/httpauth/client.go index 00e30b14b..88739a1d3 100644 --- a/internal/httpauth/client.go +++ b/internal/httpauth/client.go @@ -15,7 +15,7 @@ import ( "sync/atomic" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) const ( diff --git a/internal/httpauth/client_test.go b/internal/httpauth/client_test.go index eb6fabec7..2b0ed48df 100644 --- a/internal/httpauth/client_test.go +++ b/internal/httpauth/client_test.go @@ -13,7 +13,7 @@ import ( "testing" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/internal/therealproxy/client.go b/internal/therealproxy/client.go index 5740e111f..4756eff2a 100644 --- a/internal/therealproxy/client.go +++ b/internal/therealproxy/client.go @@ -6,7 +6,7 @@ import ( "net" "github.com/hashicorp/yamux" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("therealproxy") diff --git a/internal/therealproxy/server_test.go b/internal/therealproxy/server_test.go index 4262b6607..00e564af7 100644 --- a/internal/therealproxy/server_test.go +++ b/internal/therealproxy/server_test.go @@ -10,7 +10,7 @@ import ( "testing" "time" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" "golang.org/x/net/nettest" diff --git a/pkg/app/app.go b/pkg/app/app.go index 0eae87118..c874e4aba 100644 --- a/pkg/app/app.go +++ b/pkg/app/app.go @@ -14,9 +14,9 @@ import ( "path/filepath" "sync" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) const ( diff --git a/pkg/app/app_test.go b/pkg/app/app_test.go index 74a8c513a..034dfbe0a 100644 --- a/pkg/app/app_test.go +++ b/pkg/app/app_test.go @@ -10,12 +10,12 @@ import ( "time" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/testhelpers" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/testhelpers" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestMain(m *testing.M) { diff --git a/pkg/app/packet.go b/pkg/app/packet.go index c8ee58f4e..539d26438 100644 --- a/pkg/app/packet.go +++ b/pkg/app/packet.go @@ -1,6 +1,6 @@ package app -import "github.com/SkycoinProject/skywire/pkg/routing" +import "github.com/SkycoinProject/skywire-mainnet/pkg/routing" // Packet represents message exchanged between App and Node. type Packet struct { diff --git a/pkg/app/packet_test.go b/pkg/app/packet_test.go index 11ac0f0d0..b9d5d8f4e 100644 --- a/pkg/app/packet_test.go +++ b/pkg/app/packet_test.go @@ -5,7 +5,7 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func ExamplePacket() { diff --git a/pkg/httputil/httputil.go b/pkg/httputil/httputil.go index 3c57e4190..8dcb7fcd7 100644 --- a/pkg/httputil/httputil.go +++ b/pkg/httputil/httputil.go @@ -8,7 +8,7 @@ import ( "net/http" "github.com/gorilla/handlers" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("httputil") diff --git a/pkg/hypervisor/config.go b/pkg/hypervisor/config.go index 3e9c601a8..b49dad3b5 100644 --- a/pkg/hypervisor/config.go +++ b/pkg/hypervisor/config.go @@ -10,7 +10,7 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) // Key allows a byte slice to be marshaled or unmarshaled from a hex string. diff --git a/pkg/hypervisor/hypervisor.go b/pkg/hypervisor/hypervisor.go index b7f69327d..f0bdf762a 100644 --- a/pkg/hypervisor/hypervisor.go +++ b/pkg/hypervisor/hypervisor.go @@ -18,11 +18,11 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/noise" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/httputil" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/visor" + "github.com/SkycoinProject/skywire-mainnet/pkg/httputil" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/visor" ) var ( diff --git a/pkg/hypervisor/hypervisor_test.go b/pkg/hypervisor/hypervisor_test.go index aabad6fcc..a5f181e53 100644 --- a/pkg/hypervisor/hypervisor_test.go +++ b/pkg/hypervisor/hypervisor_test.go @@ -13,7 +13,7 @@ import ( "strings" "testing" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/pkg/hypervisor/user_manager.go b/pkg/hypervisor/user_manager.go index 09ee85c12..733657c94 100644 --- a/pkg/hypervisor/user_manager.go +++ b/pkg/hypervisor/user_manager.go @@ -10,7 +10,7 @@ import ( "github.com/google/uuid" "github.com/gorilla/securecookie" - "github.com/SkycoinProject/skywire/pkg/httputil" + "github.com/SkycoinProject/skywire-mainnet/pkg/httputil" ) const ( diff --git a/pkg/route-finder/client/client.go b/pkg/route-finder/client/client.go index 7aa8e7715..a096a953a 100644 --- a/pkg/route-finder/client/client.go +++ b/pkg/route-finder/client/client.go @@ -12,9 +12,9 @@ import ( "time" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) const defaultContextTimeout = 10 * time.Second diff --git a/pkg/route-finder/client/mock.go b/pkg/route-finder/client/mock.go index f13e15222..0ebdba97e 100644 --- a/pkg/route-finder/client/mock.go +++ b/pkg/route-finder/client/mock.go @@ -3,8 +3,8 @@ package client import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) // MockClient implements mock route finder client. diff --git a/pkg/router/app_manager.go b/pkg/router/app_manager.go index 4b9d07593..50d9413d7 100644 --- a/pkg/router/app_manager.go +++ b/pkg/router/app_manager.go @@ -6,10 +6,10 @@ import ( "errors" "time" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) const supportedProtocolVersion = "0.0.1" diff --git a/pkg/router/app_manager_test.go b/pkg/router/app_manager_test.go index cd16f6e18..87d6cf694 100644 --- a/pkg/router/app_manager_test.go +++ b/pkg/router/app_manager_test.go @@ -6,13 +6,13 @@ import ( "testing" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/testhelpers" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/testhelpers" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestAppManagerInit(t *testing.T) { diff --git a/pkg/router/loop_list.go b/pkg/router/loop_list.go index 5e0f15dba..a435399ea 100644 --- a/pkg/router/loop_list.go +++ b/pkg/router/loop_list.go @@ -5,7 +5,7 @@ import ( "github.com/google/uuid" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) type loop struct { diff --git a/pkg/router/managed_routing_table.go b/pkg/router/managed_routing_table.go index 570c078fa..7003cb6cf 100644 --- a/pkg/router/managed_routing_table.go +++ b/pkg/router/managed_routing_table.go @@ -4,7 +4,7 @@ import ( "sync" "time" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) var routeKeepalive = 10 * time.Minute // interval to keep active expired routes diff --git a/pkg/router/managed_routing_table_test.go b/pkg/router/managed_routing_table_test.go index 7ff02f706..4629a7c1d 100644 --- a/pkg/router/managed_routing_table_test.go +++ b/pkg/router/managed_routing_table_test.go @@ -8,7 +8,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestManagedRoutingTableCleanup(t *testing.T) { diff --git a/pkg/router/port_list.go b/pkg/router/port_list.go index 3bdd76816..98447ccda 100644 --- a/pkg/router/port_list.go +++ b/pkg/router/port_list.go @@ -4,8 +4,8 @@ import ( "math" "sync" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) type portBind struct { diff --git a/pkg/router/port_manager.go b/pkg/router/port_manager.go index fe4ae4648..c2c2a84b0 100644 --- a/pkg/router/port_manager.go +++ b/pkg/router/port_manager.go @@ -4,8 +4,8 @@ import ( "errors" "fmt" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) type portManager struct { diff --git a/pkg/router/port_manager_test.go b/pkg/router/port_manager_test.go index 6213a36cc..bd9eb184c 100644 --- a/pkg/router/port_manager_test.go +++ b/pkg/router/port_manager_test.go @@ -9,8 +9,8 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestPortManager(t *testing.T) { diff --git a/pkg/router/route_manager.go b/pkg/router/route_manager.go index 1d49b4085..41282f49e 100644 --- a/pkg/router/route_manager.go +++ b/pkg/router/route_manager.go @@ -7,10 +7,10 @@ import ( "io" "time" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/setup" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/setup" ) type setupCallbacks struct { diff --git a/pkg/router/route_manager_test.go b/pkg/router/route_manager_test.go index d8b8f09d5..ad79cbeb7 100644 --- a/pkg/router/route_manager_test.go +++ b/pkg/router/route_manager_test.go @@ -8,12 +8,12 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/setup" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/setup" ) func TestRouteManagerGetRule(t *testing.T) { diff --git a/pkg/router/router.go b/pkg/router/router.go index 1af27631f..f6d1aa377 100644 --- a/pkg/router/router.go +++ b/pkg/router/router.go @@ -12,13 +12,13 @@ import ( "github.com/SkycoinProject/dmsg" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/app" - routeFinder "github.com/SkycoinProject/skywire/pkg/route-finder/client" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/setup" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + routeFinder "github.com/SkycoinProject/skywire-mainnet/pkg/route-finder/client" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/setup" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) const ( diff --git a/pkg/router/router_test.go b/pkg/router/router_test.go index b54c0aac6..9fb9b2872 100644 --- a/pkg/router/router_test.go +++ b/pkg/router/router_test.go @@ -12,16 +12,16 @@ import ( "github.com/sirupsen/logrus" "github.com/SkycoinProject/dmsg" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/testhelpers" - "github.com/SkycoinProject/skywire/pkg/app" - routeFinder "github.com/SkycoinProject/skywire/pkg/route-finder/client" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/setup" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/internal/testhelpers" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + routeFinder "github.com/SkycoinProject/skywire-mainnet/pkg/route-finder/client" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/setup" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) func TestMain(m *testing.M) { diff --git a/pkg/routing/boltdb_routing_table.go b/pkg/routing/boltdb_routing_table.go index 1ecd3879b..b2ecca811 100644 --- a/pkg/routing/boltdb_routing_table.go +++ b/pkg/routing/boltdb_routing_table.go @@ -6,7 +6,7 @@ import ( "fmt" "math" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "go.etcd.io/bbolt" ) diff --git a/pkg/routing/routing_table_test.go b/pkg/routing/routing_table_test.go index eeeaf46d5..5b17ded4e 100644 --- a/pkg/routing/routing_table_test.go +++ b/pkg/routing/routing_table_test.go @@ -6,7 +6,7 @@ import ( "time" "github.com/google/uuid" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" ) diff --git a/pkg/setup/node.go b/pkg/setup/node.go index 29943651c..0dd22ea8e 100644 --- a/pkg/setup/node.go +++ b/pkg/setup/node.go @@ -9,12 +9,12 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/metrics" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" - "github.com/SkycoinProject/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire-mainnet/pkg/metrics" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport/dmsg" ) // Hop is a wrapper around transport hop to add functionality diff --git a/pkg/setup/node_test.go b/pkg/setup/node_test.go index e6178c106..cc762b8ca 100644 --- a/pkg/setup/node_test.go +++ b/pkg/setup/node_test.go @@ -16,11 +16,11 @@ import ( "github.com/stretchr/testify/require" "golang.org/x/net/nettest" - "github.com/SkycoinProject/skywire/pkg/metrics" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire-mainnet/pkg/metrics" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport/dmsg" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) func TestMain(m *testing.M) { diff --git a/pkg/setup/protocol.go b/pkg/setup/protocol.go index 05ca56c9c..466bd87e9 100644 --- a/pkg/setup/protocol.go +++ b/pkg/setup/protocol.go @@ -9,7 +9,7 @@ import ( "fmt" "io" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) // PacketType defines type of a setup packet diff --git a/pkg/therealssh/channel.go b/pkg/therealssh/channel.go index a9356edfd..a5ef85ae3 100644 --- a/pkg/therealssh/channel.go +++ b/pkg/therealssh/channel.go @@ -15,7 +15,7 @@ import ( "github.com/creack/pty" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) // Port reserved for SSH app diff --git a/pkg/therealssh/channel_pty_test.go b/pkg/therealssh/channel_pty_test.go index 8af93976c..a5721f810 100644 --- a/pkg/therealssh/channel_pty_test.go +++ b/pkg/therealssh/channel_pty_test.go @@ -12,7 +12,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestChannelServe(t *testing.T) { diff --git a/pkg/therealssh/channel_test.go b/pkg/therealssh/channel_test.go index 33058d735..9fffed7eb 100644 --- a/pkg/therealssh/channel_test.go +++ b/pkg/therealssh/channel_test.go @@ -13,8 +13,8 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/testhelpers" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/testhelpers" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestChannelSendWrite(t *testing.T) { diff --git a/pkg/therealssh/client.go b/pkg/therealssh/client.go index 456e0a5cc..4b1428b40 100644 --- a/pkg/therealssh/client.go +++ b/pkg/therealssh/client.go @@ -13,8 +13,8 @@ import ( "github.com/creack/pty" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/internal/netutil" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/netutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) var r = netutil.NewRetrier(50*time.Millisecond, 5, 2) diff --git a/pkg/therealssh/client_test.go b/pkg/therealssh/client_test.go index a981188ea..c0a437c8d 100644 --- a/pkg/therealssh/client_test.go +++ b/pkg/therealssh/client_test.go @@ -9,7 +9,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestClientOpenChannel(t *testing.T) { diff --git a/pkg/therealssh/dialer.go b/pkg/therealssh/dialer.go index 46706f4cc..d49c78889 100644 --- a/pkg/therealssh/dialer.go +++ b/pkg/therealssh/dialer.go @@ -3,7 +3,7 @@ package therealssh import ( "net" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) // dialer dials to a remote node. diff --git a/pkg/therealssh/pty_test.go b/pkg/therealssh/pty_test.go index c6560bb8e..9de66e91e 100644 --- a/pkg/therealssh/pty_test.go +++ b/pkg/therealssh/pty_test.go @@ -13,7 +13,7 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestRunRPC(t *testing.T) { diff --git a/pkg/therealssh/server.go b/pkg/therealssh/server.go index 7baed9a3b..e9fbf09d6 100644 --- a/pkg/therealssh/server.go +++ b/pkg/therealssh/server.go @@ -8,9 +8,9 @@ import ( "net" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) // CommandType represents global protocol messages. diff --git a/pkg/therealssh/server_test.go b/pkg/therealssh/server_test.go index e6dca0225..4c22d53dc 100644 --- a/pkg/therealssh/server_test.go +++ b/pkg/therealssh/server_test.go @@ -7,11 +7,11 @@ import ( "testing" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestMain(m *testing.M) { diff --git a/pkg/therealssh/session.go b/pkg/therealssh/session.go index 0abb2ecc3..1e230699c 100644 --- a/pkg/therealssh/session.go +++ b/pkg/therealssh/session.go @@ -11,7 +11,7 @@ import ( "syscall" "github.com/creack/pty" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("therealssh") diff --git a/pkg/transport-discovery/client/client.go b/pkg/transport-discovery/client/client.go index 532746861..a2e315278 100644 --- a/pkg/transport-discovery/client/client.go +++ b/pkg/transport-discovery/client/client.go @@ -13,10 +13,10 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/internal/httpauth" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/internal/httpauth" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) var log = logging.MustGetLogger("transport-discovery") diff --git a/pkg/transport-discovery/client/client_test.go b/pkg/transport-discovery/client/client_test.go index f5855a8cb..cb2f66da3 100644 --- a/pkg/transport-discovery/client/client_test.go +++ b/pkg/transport-discovery/client/client_test.go @@ -12,12 +12,12 @@ import ( "testing" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/httpauth" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/internal/httpauth" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) func TestMain(m *testing.M) { diff --git a/pkg/transport/discovery_test.go b/pkg/transport/discovery_test.go index cd016ee05..0d9a810b6 100644 --- a/pkg/transport/discovery_test.go +++ b/pkg/transport/discovery_test.go @@ -8,7 +8,7 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) func TestNewDiscoveryMock(t *testing.T) { diff --git a/pkg/transport/dmsg/dmsg.go b/pkg/transport/dmsg/dmsg.go index 1701e5823..43b5dc1ec 100644 --- a/pkg/transport/dmsg/dmsg.go +++ b/pkg/transport/dmsg/dmsg.go @@ -8,9 +8,9 @@ import ( "github.com/SkycoinProject/dmsg" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) const ( diff --git a/pkg/transport/dmsg/testing.go b/pkg/transport/dmsg/testing.go index 04629c7fc..f2916c220 100644 --- a/pkg/transport/dmsg/testing.go +++ b/pkg/transport/dmsg/testing.go @@ -8,7 +8,7 @@ import ( "github.com/SkycoinProject/dmsg" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/require" "golang.org/x/net/nettest" ) diff --git a/pkg/transport/entry_test.go b/pkg/transport/entry_test.go index 70fb72918..06e5fb39e 100644 --- a/pkg/transport/entry_test.go +++ b/pkg/transport/entry_test.go @@ -8,7 +8,7 @@ import ( "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) func TestNewEntry(t *testing.T) { diff --git a/pkg/transport/log_test.go b/pkg/transport/log_test.go index 3bc17ef66..45e166b8f 100644 --- a/pkg/transport/log_test.go +++ b/pkg/transport/log_test.go @@ -11,7 +11,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) func testTransportLogStore(t *testing.T, logStore transport.LogStore) { diff --git a/pkg/transport/managed_transport.go b/pkg/transport/managed_transport.go index 826810e6d..dee7c73e3 100644 --- a/pkg/transport/managed_transport.go +++ b/pkg/transport/managed_transport.go @@ -9,11 +9,11 @@ import ( "sync/atomic" "time" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" "github.com/SkycoinProject/dmsg" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) const logWriteInterval = time.Second * 3 diff --git a/pkg/transport/manager.go b/pkg/transport/manager.go index bf984856c..2b21dfb2a 100644 --- a/pkg/transport/manager.go +++ b/pkg/transport/manager.go @@ -7,11 +7,11 @@ import ( "strings" "sync" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) // ManagerConfig configures a Manager. diff --git a/pkg/transport/manager_test.go b/pkg/transport/manager_test.go index 3702dc53e..78e51656a 100644 --- a/pkg/transport/manager_test.go +++ b/pkg/transport/manager_test.go @@ -8,11 +8,11 @@ import ( "testing" "time" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" - "github.com/SkycoinProject/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport/dmsg" "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" diff --git a/pkg/transport/tcp_transport_test.go b/pkg/transport/tcp_transport_test.go index 33cdd3311..7a627c4b8 100644 --- a/pkg/transport/tcp_transport_test.go +++ b/pkg/transport/tcp_transport_test.go @@ -12,7 +12,7 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) func TestTCPFactory(t *testing.T) { diff --git a/pkg/transport/transport.go b/pkg/transport/transport.go index d12d64ca4..e48d30069 100644 --- a/pkg/transport/transport.go +++ b/pkg/transport/transport.go @@ -10,7 +10,7 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("transport") diff --git a/pkg/util/pathutil/configpath.go b/pkg/util/pathutil/configpath.go index 5142e9290..823e675df 100644 --- a/pkg/util/pathutil/configpath.go +++ b/pkg/util/pathutil/configpath.go @@ -6,7 +6,7 @@ import ( "os" "path/filepath" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("pathutil") @@ -78,7 +78,7 @@ func NodeDefaults() ConfigPaths { paths[WorkingDirLoc] = filepath.Join(wd, "skywire-config.json") } paths[HomeLoc] = filepath.Join(HomeDir(), ".skycoin/skywire/skywire-config.json") - paths[LocalLoc] = "/usr/local/SkycoinProject/skywire/skywire-config.json" + paths[LocalLoc] = "/usr/local/SkycoinProject/skywire-mainnet/skywire-config.json" return paths } diff --git a/pkg/visor/config.go b/pkg/visor/config.go index cbecbadca..a5a138b29 100644 --- a/pkg/visor/config.go +++ b/pkg/visor/config.go @@ -11,10 +11,10 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" - trClient "github.com/SkycoinProject/skywire/pkg/transport-discovery/client" - "github.com/SkycoinProject/skywire/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + trClient "github.com/SkycoinProject/skywire-mainnet/pkg/transport-discovery/client" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport/dmsg" ) // Config defines configuration parameters for Node. diff --git a/pkg/visor/config_test.go b/pkg/visor/config_test.go index d85b4c8c5..1c6345f44 100644 --- a/pkg/visor/config_test.go +++ b/pkg/visor/config_test.go @@ -14,8 +14,8 @@ import ( "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/httpauth" - "github.com/SkycoinProject/skywire/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/internal/httpauth" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" ) func TestMessagingDiscovery(t *testing.T) { diff --git a/pkg/visor/rpc.go b/pkg/visor/rpc.go index c734605a9..87aae80e7 100644 --- a/pkg/visor/rpc.go +++ b/pkg/visor/rpc.go @@ -8,8 +8,8 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) const ( diff --git a/pkg/visor/rpc_client.go b/pkg/visor/rpc_client.go index 66be44ea4..94b710ac4 100644 --- a/pkg/visor/rpc_client.go +++ b/pkg/visor/rpc_client.go @@ -10,10 +10,10 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) // RPCClient represents a RPC Client implementation. diff --git a/pkg/visor/rpc_test.go b/pkg/visor/rpc_test.go index ff20ccdfe..d9539e04f 100644 --- a/pkg/visor/rpc_test.go +++ b/pkg/visor/rpc_test.go @@ -10,13 +10,13 @@ import ( "time" "github.com/SkycoinProject/dmsg/cipher" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) func TestListApps(t *testing.T) { diff --git a/pkg/visor/visor.go b/pkg/visor/visor.go index e21a37ee3..be9631c18 100644 --- a/pkg/visor/visor.go +++ b/pkg/visor/visor.go @@ -20,15 +20,15 @@ import ( "time" "github.com/SkycoinProject/dmsg/noise" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" - - "github.com/SkycoinProject/skywire/pkg/app" - routeFinder "github.com/SkycoinProject/skywire/pkg/route-finder/client" - "github.com/SkycoinProject/skywire/pkg/router" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" - "github.com/SkycoinProject/skywire/pkg/transport/dmsg" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skycoin/src/util/logging" + + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + routeFinder "github.com/SkycoinProject/skywire-mainnet/pkg/route-finder/client" + "github.com/SkycoinProject/skywire-mainnet/pkg/router" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) var log = logging.MustGetLogger("node") diff --git a/pkg/visor/visor_test.go b/pkg/visor/visor_test.go index b3c407db0..4c8506b41 100644 --- a/pkg/visor/visor_test.go +++ b/pkg/visor/visor_test.go @@ -16,16 +16,16 @@ import ( "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/stretchr/testify/assert" "github.com/stretchr/testify/require" - "github.com/SkycoinProject/skywire/internal/httpauth" - "github.com/SkycoinProject/skywire/pkg/app" - "github.com/SkycoinProject/skywire/pkg/routing" - "github.com/SkycoinProject/skywire/pkg/transport" - "github.com/SkycoinProject/skywire/pkg/transport/dmsg" - "github.com/SkycoinProject/skywire/pkg/util/pathutil" + "github.com/SkycoinProject/skywire-mainnet/internal/httpauth" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" + "github.com/SkycoinProject/skywire-mainnet/pkg/routing" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport" + "github.com/SkycoinProject/skywire-mainnet/pkg/transport/dmsg" + "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) var masterLogger *logging.MasterLogger diff --git a/vendor/github.com/skycoin/dmsg/.gitignore b/vendor/github.com/SkycoinProject/dmsg/.gitignore similarity index 100% rename from vendor/github.com/skycoin/dmsg/.gitignore rename to vendor/github.com/SkycoinProject/dmsg/.gitignore diff --git a/vendor/github.com/skycoin/dmsg/.golangci.yml b/vendor/github.com/SkycoinProject/dmsg/.golangci.yml similarity index 100% rename from vendor/github.com/skycoin/dmsg/.golangci.yml rename to vendor/github.com/SkycoinProject/dmsg/.golangci.yml diff --git a/vendor/github.com/skycoin/dmsg/.travis.yml b/vendor/github.com/SkycoinProject/dmsg/.travis.yml similarity index 100% rename from vendor/github.com/skycoin/dmsg/.travis.yml rename to vendor/github.com/SkycoinProject/dmsg/.travis.yml diff --git a/vendor/github.com/skycoin/dmsg/Makefile b/vendor/github.com/SkycoinProject/dmsg/Makefile similarity index 95% rename from vendor/github.com/skycoin/dmsg/Makefile rename to vendor/github.com/SkycoinProject/dmsg/Makefile index f7ee1e651..c9c376c6c 100644 --- a/vendor/github.com/skycoin/dmsg/Makefile +++ b/vendor/github.com/SkycoinProject/dmsg/Makefile @@ -27,7 +27,7 @@ install-linters: ## Install linters ${OPTS} go get -u golang.org/x/tools/cmd/goimports format: ## Formats the code. Must have goimports installed (use make install-linters). - ${OPTS} goimports -w -local github.com/skycoin/dmsg . + ${OPTS} goimports -w -local github.com/SkycoinProject/dmsg . dep: ## Sorts dependencies ${OPTS} go mod download diff --git a/vendor/github.com/skycoin/dmsg/README.md b/vendor/github.com/SkycoinProject/dmsg/README.md similarity index 100% rename from vendor/github.com/skycoin/dmsg/README.md rename to vendor/github.com/SkycoinProject/dmsg/README.md diff --git a/vendor/github.com/skycoin/dmsg/TESTING.md b/vendor/github.com/SkycoinProject/dmsg/TESTING.md similarity index 100% rename from vendor/github.com/skycoin/dmsg/TESTING.md rename to vendor/github.com/SkycoinProject/dmsg/TESTING.md diff --git a/vendor/github.com/skycoin/dmsg/cipher/cipher.go b/vendor/github.com/SkycoinProject/dmsg/cipher/cipher.go similarity index 98% rename from vendor/github.com/skycoin/dmsg/cipher/cipher.go rename to vendor/github.com/SkycoinProject/dmsg/cipher/cipher.go index 9c22b344b..c62f6d1a7 100644 --- a/vendor/github.com/skycoin/dmsg/cipher/cipher.go +++ b/vendor/github.com/SkycoinProject/dmsg/cipher/cipher.go @@ -1,5 +1,5 @@ // Package cipher implements common golang encoding interfaces for -// github.com/SkycoinProject/SkycoinProject/src/cipher +// github.com/SkycoinProject/skycoin/src/cipher package cipher import ( @@ -7,7 +7,7 @@ import ( "fmt" "strings" - "github.com/SkycoinProject/SkycoinProject/src/cipher" + "github.com/SkycoinProject/skycoin/src/cipher" ) func init() { diff --git a/vendor/github.com/skycoin/dmsg/client.go b/vendor/github.com/SkycoinProject/dmsg/client.go similarity index 99% rename from vendor/github.com/skycoin/dmsg/client.go rename to vendor/github.com/SkycoinProject/dmsg/client.go index 13282e14f..2fdc6136f 100644 --- a/vendor/github.com/skycoin/dmsg/client.go +++ b/vendor/github.com/SkycoinProject/dmsg/client.go @@ -9,7 +9,7 @@ import ( "time" "github.com/sirupsen/logrus" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" diff --git a/vendor/github.com/skycoin/dmsg/disc/client.go b/vendor/github.com/SkycoinProject/dmsg/disc/client.go similarity index 98% rename from vendor/github.com/skycoin/dmsg/disc/client.go rename to vendor/github.com/SkycoinProject/dmsg/disc/client.go index 624426147..a7238320f 100644 --- a/vendor/github.com/skycoin/dmsg/disc/client.go +++ b/vendor/github.com/SkycoinProject/dmsg/disc/client.go @@ -11,7 +11,7 @@ import ( "sync" "time" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/SkycoinProject/dmsg/cipher" ) diff --git a/vendor/github.com/skycoin/dmsg/disc/entry.go b/vendor/github.com/SkycoinProject/dmsg/disc/entry.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/disc/entry.go rename to vendor/github.com/SkycoinProject/dmsg/disc/entry.go diff --git a/vendor/github.com/skycoin/dmsg/disc/http_message.go b/vendor/github.com/SkycoinProject/dmsg/disc/http_message.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/disc/http_message.go rename to vendor/github.com/SkycoinProject/dmsg/disc/http_message.go diff --git a/vendor/github.com/skycoin/dmsg/disc/testing.go b/vendor/github.com/SkycoinProject/dmsg/disc/testing.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/disc/testing.go rename to vendor/github.com/SkycoinProject/dmsg/disc/testing.go diff --git a/vendor/github.com/skycoin/dmsg/frame.go b/vendor/github.com/SkycoinProject/dmsg/frame.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/frame.go rename to vendor/github.com/SkycoinProject/dmsg/frame.go diff --git a/vendor/github.com/skycoin/dmsg/go.mod b/vendor/github.com/SkycoinProject/dmsg/go.mod similarity index 81% rename from vendor/github.com/skycoin/dmsg/go.mod rename to vendor/github.com/SkycoinProject/dmsg/go.mod index 2e573d695..7efd7a29d 100644 --- a/vendor/github.com/skycoin/dmsg/go.mod +++ b/vendor/github.com/SkycoinProject/dmsg/go.mod @@ -3,18 +3,17 @@ module github.com/SkycoinProject/dmsg go 1.12 require ( + github.com/SkycoinProject/skycoin v0.26.0 github.com/flynn/noise v0.0.0-20180327030543-2492fe189ae6 github.com/konsorten/go-windows-terminal-sequences v1.0.2 // indirect github.com/kr/pretty v0.1.0 // indirect github.com/mattn/go-colorable v0.1.2 // indirect github.com/mgutz/ansi v0.0.0-20170206155736-9520e82c474b // indirect github.com/sirupsen/logrus v1.4.2 - github.com/SkycoinProject/SkycoinProject v0.26.0 + github.com/skycoin/skycoin v0.26.0 // indirect github.com/stretchr/testify v1.3.0 golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4 // indirect golang.org/x/net v0.0.0-20190620200207-3b0461eec859 golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb // indirect - golang.org/x/text v0.3.2 // indirect - golang.org/x/tools v0.0.0-20190627182818-9947fec5c3ab // indirect gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127 // indirect ) diff --git a/vendor/github.com/skycoin/dmsg/go.sum b/vendor/github.com/SkycoinProject/dmsg/go.sum similarity index 84% rename from vendor/github.com/skycoin/dmsg/go.sum rename to vendor/github.com/SkycoinProject/dmsg/go.sum index c6a730a9e..9bd02b3dd 100644 --- a/vendor/github.com/skycoin/dmsg/go.sum +++ b/vendor/github.com/SkycoinProject/dmsg/go.sum @@ -1,9 +1,10 @@ +github.com/SkycoinProject/skycoin v0.26.0 h1:8/ZRZb2VM2DM4YTIitRJMZ3Yo/3H1FFmbCMx5o6ekmA= +github.com/SkycoinProject/skycoin v0.26.0/go.mod h1:xqPLOKh5B6GBZlGA7B5IJfQmCy7mwimD9NlqxR3gMXo= github.com/davecgh/go-spew v1.1.0/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/davecgh/go-spew v1.1.1 h1:vj9j/u1bqnvCEfJOwUhtlOARqs3+rkHYY13jYWTU97c= github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/flynn/noise v0.0.0-20180327030543-2492fe189ae6 h1:u/UEqS66A5ckRmS4yNpjmVH56sVtS/RfclBAYocb4as= github.com/flynn/noise v0.0.0-20180327030543-2492fe189ae6/go.mod h1:1i71OnUq3iUe1ma7Lr6yG6/rjvM3emb6yoL7xLFzcVQ= -github.com/konsorten/go-windows-terminal-sequences v1.0.1 h1:mweAR1A6xJ3oS2pRaGiHgQ4OO8tzTaLawm8vnODuwDk= github.com/konsorten/go-windows-terminal-sequences v1.0.1/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= github.com/konsorten/go-windows-terminal-sequences v1.0.2 h1:DB17ag19krx9CFsz4o3enTrPXyIXCl+2iCXH/aMAp9s= github.com/konsorten/go-windows-terminal-sequences v1.0.2/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= @@ -32,22 +33,15 @@ github.com/stretchr/testify v1.3.0/go.mod h1:M5WIy9Dh21IEIfnGCwXGc5bZfKNJtfHm1UV golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4 h1:ydJNl0ENAG67pFbB+9tfhiL2pYqLhfoaZFw/cjLhY4A= golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= -golang.org/x/net v0.0.0-20190311183353-d8887717615a/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190620200207-3b0461eec859 h1:R/3boaszxrf1GEUWTVDzSKVwLmSJpwZ1yqXm8j0v2QI= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= -golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190222072716-a9d3bda3a223/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20190422165155-953cdadca894/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb h1:fgwFCsaw9buMuxNd6+DQfAuSFqbNiQZpcgJQAgJsK6k= golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= -golang.org/x/text v0.3.0 h1:g61tztE5qeGQ89tm6NTjjM9VPIm088od1l6aSorWRWg= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= -golang.org/x/text v0.3.2/go.mod h1:bEr9sfX3Q8Zfm5fL9x+3itogRgK3+ptLWKqgva+5dAk= -golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= -golang.org/x/tools v0.0.0-20190627182818-9947fec5c3ab h1:uOzhX2fm3C4BmBwW2a7lnJQD7qel2+4uhmTc8czKBCU= -golang.org/x/tools v0.0.0-20190627182818-9947fec5c3ab/go.mod h1:/rFqwRUd4F7ZHNgwSSTFct+R/Kf4OFW1sUzUTQQTgfc= gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127 h1:qIbj1fsPNlZgppZ+VLlY7N33q108Sa+fhmuc+sWQYwY= gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= diff --git a/vendor/github.com/skycoin/dmsg/ioutil/ack_waiter.go b/vendor/github.com/SkycoinProject/dmsg/ioutil/ack_waiter.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/ioutil/ack_waiter.go rename to vendor/github.com/SkycoinProject/dmsg/ioutil/ack_waiter.go diff --git a/vendor/github.com/skycoin/dmsg/ioutil/atomic_bool.go b/vendor/github.com/SkycoinProject/dmsg/ioutil/atomic_bool.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/ioutil/atomic_bool.go rename to vendor/github.com/SkycoinProject/dmsg/ioutil/atomic_bool.go diff --git a/vendor/github.com/skycoin/dmsg/ioutil/buf_read.go b/vendor/github.com/SkycoinProject/dmsg/ioutil/buf_read.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/ioutil/buf_read.go rename to vendor/github.com/SkycoinProject/dmsg/ioutil/buf_read.go diff --git a/vendor/github.com/skycoin/dmsg/ioutil/logging.go b/vendor/github.com/SkycoinProject/dmsg/ioutil/logging.go similarity index 53% rename from vendor/github.com/skycoin/dmsg/ioutil/logging.go rename to vendor/github.com/SkycoinProject/dmsg/ioutil/logging.go index 6a904fe71..cc42d0d4e 100644 --- a/vendor/github.com/skycoin/dmsg/ioutil/logging.go +++ b/vendor/github.com/SkycoinProject/dmsg/ioutil/logging.go @@ -1,7 +1,7 @@ package ioutil import ( - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" ) var log = logging.MustGetLogger("ioutil") diff --git a/vendor/github.com/skycoin/dmsg/noise/dh.go b/vendor/github.com/SkycoinProject/dmsg/noise/dh.go similarity index 92% rename from vendor/github.com/skycoin/dmsg/noise/dh.go rename to vendor/github.com/SkycoinProject/dmsg/noise/dh.go index e627bc095..dfd9e49fc 100644 --- a/vendor/github.com/skycoin/dmsg/noise/dh.go +++ b/vendor/github.com/SkycoinProject/dmsg/noise/dh.go @@ -4,7 +4,7 @@ import ( "io" "github.com/flynn/noise" - "github.com/SkycoinProject/SkycoinProject/src/cipher" + "github.com/SkycoinProject/skycoin/src/cipher" ) // Secp256k1 implements `noise.DHFunc`. diff --git a/vendor/github.com/skycoin/dmsg/noise/net.go b/vendor/github.com/SkycoinProject/dmsg/noise/net.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/noise/net.go rename to vendor/github.com/SkycoinProject/dmsg/noise/net.go diff --git a/vendor/github.com/skycoin/dmsg/noise/noise.go b/vendor/github.com/SkycoinProject/dmsg/noise/noise.go similarity index 98% rename from vendor/github.com/skycoin/dmsg/noise/noise.go rename to vendor/github.com/SkycoinProject/dmsg/noise/noise.go index e9121a7a5..3c0f0cf1b 100644 --- a/vendor/github.com/skycoin/dmsg/noise/noise.go +++ b/vendor/github.com/SkycoinProject/dmsg/noise/noise.go @@ -4,7 +4,7 @@ import ( "crypto/rand" "encoding/binary" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/flynn/noise" diff --git a/vendor/github.com/skycoin/dmsg/noise/read_writer.go b/vendor/github.com/SkycoinProject/dmsg/noise/read_writer.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/noise/read_writer.go rename to vendor/github.com/SkycoinProject/dmsg/noise/read_writer.go diff --git a/vendor/github.com/skycoin/dmsg/server.go b/vendor/github.com/SkycoinProject/dmsg/server.go similarity index 99% rename from vendor/github.com/skycoin/dmsg/server.go rename to vendor/github.com/SkycoinProject/dmsg/server.go index 92f492cc3..0cf4cad1f 100644 --- a/vendor/github.com/skycoin/dmsg/server.go +++ b/vendor/github.com/SkycoinProject/dmsg/server.go @@ -9,7 +9,7 @@ import ( "sync/atomic" "time" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/disc" diff --git a/vendor/github.com/skycoin/dmsg/testing.go b/vendor/github.com/SkycoinProject/dmsg/testing.go similarity index 100% rename from vendor/github.com/skycoin/dmsg/testing.go rename to vendor/github.com/SkycoinProject/dmsg/testing.go diff --git a/vendor/github.com/skycoin/dmsg/transport.go b/vendor/github.com/SkycoinProject/dmsg/transport.go similarity index 99% rename from vendor/github.com/skycoin/dmsg/transport.go rename to vendor/github.com/SkycoinProject/dmsg/transport.go index 8bfdd573f..613aa7cb9 100644 --- a/vendor/github.com/skycoin/dmsg/transport.go +++ b/vendor/github.com/SkycoinProject/dmsg/transport.go @@ -8,7 +8,7 @@ import ( "net" "sync" - "github.com/SkycoinProject/SkycoinProject/src/util/logging" + "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/dmsg/ioutil" diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/address.go b/vendor/github.com/SkycoinProject/skycoin/src/cipher/address.go similarity index 98% rename from vendor/github.com/skycoin/skycoin/src/cipher/address.go rename to vendor/github.com/SkycoinProject/skycoin/src/cipher/address.go index 9693d3356..b5d93275b 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/address.go +++ b/vendor/github.com/SkycoinProject/skycoin/src/cipher/address.go @@ -4,7 +4,7 @@ import ( "errors" "log" - "github.com/SkycoinProject/SkycoinProject/src/cipher/base58" + "github.com/skycoin/skycoin/src/cipher/base58" ) var ( diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go b/vendor/github.com/SkycoinProject/skycoin/src/cipher/bitcoin.go similarity index 98% rename from vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go rename to vendor/github.com/SkycoinProject/skycoin/src/cipher/bitcoin.go index 769ae6989..e601d5a2c 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/bitcoin.go +++ b/vendor/github.com/SkycoinProject/skycoin/src/cipher/bitcoin.go @@ -5,7 +5,7 @@ import ( "errors" "log" - "github.com/SkycoinProject/SkycoinProject/src/cipher/base58" + "github.com/skycoin/skycoin/src/cipher/base58" ) var ( diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/crypto.go b/vendor/github.com/SkycoinProject/skycoin/src/cipher/crypto.go similarity index 99% rename from vendor/github.com/skycoin/skycoin/src/cipher/crypto.go rename to vendor/github.com/SkycoinProject/skycoin/src/cipher/crypto.go index 6c0e31a31..94499df00 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/crypto.go +++ b/vendor/github.com/SkycoinProject/skycoin/src/cipher/crypto.go @@ -24,8 +24,8 @@ import ( "log" "time" - "github.com/SkycoinProject/SkycoinProject/src/cipher/ripemd160" - secp256k1 "github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go" + "github.com/skycoin/skycoin/src/cipher/ripemd160" + secp256k1 "github.com/skycoin/skycoin/src/cipher/secp256k1-go" ) var ( diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/hash.go b/vendor/github.com/SkycoinProject/skycoin/src/cipher/hash.go similarity index 100% rename from vendor/github.com/skycoin/skycoin/src/cipher/hash.go rename to vendor/github.com/SkycoinProject/skycoin/src/cipher/hash.go diff --git a/vendor/github.com/skycoin/skycoin/src/util/logging/formatter.go b/vendor/github.com/SkycoinProject/skycoin/src/util/logging/formatter.go similarity index 100% rename from vendor/github.com/skycoin/skycoin/src/util/logging/formatter.go rename to vendor/github.com/SkycoinProject/skycoin/src/util/logging/formatter.go diff --git a/vendor/github.com/skycoin/skycoin/src/util/logging/hooks.go b/vendor/github.com/SkycoinProject/skycoin/src/util/logging/hooks.go similarity index 100% rename from vendor/github.com/skycoin/skycoin/src/util/logging/hooks.go rename to vendor/github.com/SkycoinProject/skycoin/src/util/logging/hooks.go diff --git a/vendor/github.com/skycoin/skycoin/src/util/logging/logger.go b/vendor/github.com/SkycoinProject/skycoin/src/util/logging/logger.go similarity index 100% rename from vendor/github.com/skycoin/skycoin/src/util/logging/logger.go rename to vendor/github.com/SkycoinProject/skycoin/src/util/logging/logger.go diff --git a/vendor/github.com/skycoin/skycoin/src/util/logging/logging.go b/vendor/github.com/SkycoinProject/skycoin/src/util/logging/logging.go similarity index 100% rename from vendor/github.com/skycoin/skycoin/src/util/logging/logging.go rename to vendor/github.com/SkycoinProject/skycoin/src/util/logging/logging.go diff --git a/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go b/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go index de8947815..f4b8fa93d 100644 --- a/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go +++ b/vendor/github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1.go @@ -9,7 +9,7 @@ import ( "encoding/hex" "log" - secp "github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go/secp256k1-go2" + secp "github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1-go2" ) // DebugPrint enable debug print statements diff --git a/vendor/modules.txt b/vendor/modules.txt index 442ed25b5..8df6b0256 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -1,3 +1,12 @@ +# github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb +github.com/SkycoinProject/dmsg/cipher +github.com/SkycoinProject/dmsg +github.com/SkycoinProject/dmsg/disc +github.com/SkycoinProject/dmsg/noise +github.com/SkycoinProject/dmsg/ioutil +# github.com/SkycoinProject/skycoin v0.26.0 +github.com/SkycoinProject/skycoin/src/util/logging +github.com/SkycoinProject/skycoin/src/cipher # github.com/alecthomas/template v0.0.0-20160405071501-a0175ee3bccc github.com/alecthomas/template github.com/alecthomas/template/parse @@ -62,19 +71,11 @@ github.com/prometheus/procfs/internal/fs # github.com/sirupsen/logrus v1.4.2 github.com/sirupsen/logrus github.com/sirupsen/logrus/hooks/syslog -# github.com/SkycoinProject/dmsg v0.0.0-20190805065636-70f4c32a994f -github.com/SkycoinProject/dmsg/cipher -github.com/SkycoinProject/dmsg -github.com/SkycoinProject/dmsg/disc -github.com/SkycoinProject/dmsg/noise -github.com/SkycoinProject/dmsg/ioutil -# github.com/SkycoinProject/SkycoinProject v0.26.0 -github.com/SkycoinProject/SkycoinProject/src/util/logging -github.com/SkycoinProject/SkycoinProject/src/cipher -github.com/SkycoinProject/SkycoinProject/src/cipher/base58 -github.com/SkycoinProject/SkycoinProject/src/cipher/ripemd160 -github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go -github.com/SkycoinProject/SkycoinProject/src/cipher/secp256k1-go/secp256k1-go2 +# github.com/skycoin/skycoin v0.26.0 +github.com/skycoin/skycoin/src/cipher/base58 +github.com/skycoin/skycoin/src/cipher/ripemd160 +github.com/skycoin/skycoin/src/cipher/secp256k1-go +github.com/skycoin/skycoin/src/cipher/secp256k1-go/secp256k1-go2 # github.com/spf13/cobra v0.0.5 github.com/spf13/cobra # github.com/spf13/pflag v1.0.3 From d44422df4795d4d8f8ae41623b74c44f96b86821 Mon Sep 17 00:00:00 2001 From: ivcosla Date: Wed, 18 Sep 2019 20:33:10 +0200 Subject: [PATCH 14/14] fixed imports --- go.mod | 13 +- go.sum | 32 +- pkg/transport/handshake.go | 1 + pkg/visor/rpc.go | 1 + pkg/visor/rpc_client.go | 2 + pkg/visor/rpc_test.go | 2 - vendor/github.com/SkycoinProject/dmsg/addr.go | 26 ++ .../github.com/SkycoinProject/dmsg/client.go | 338 ++---------------- .../SkycoinProject/dmsg/client_conn.go | 301 ++++++++++++++++ .../github.com/SkycoinProject/dmsg/frame.go | 17 + vendor/github.com/SkycoinProject/dmsg/go.mod | 5 +- vendor/github.com/SkycoinProject/dmsg/go.sum | 15 +- .../SkycoinProject/dmsg/listener.go | 123 +++++++ .../SkycoinProject/dmsg/port_manager.go | 72 ++++ .../github.com/SkycoinProject/dmsg/server.go | 11 +- .../github.com/SkycoinProject/dmsg/testing.go | 11 +- .../SkycoinProject/dmsg/transport.go | 44 ++- vendor/github.com/mattn/go-isatty/go.mod | 2 +- vendor/github.com/mattn/go-isatty/go.sum | 4 +- .../golang.org/x/net/internal/socks/socks.go | 2 +- vendor/golang.org/x/sys/cpu/byteorder.go | 38 +- vendor/golang.org/x/sys/cpu/cpu_linux.go | 2 +- .../golang.org/x/sys/unix/affinity_linux.go | 46 +-- vendor/golang.org/x/sys/unix/ioctl.go | 41 ++- vendor/golang.org/x/sys/unix/mkerrors.sh | 42 ++- vendor/golang.org/x/sys/unix/syscall_aix.go | 39 +- .../golang.org/x/sys/unix/syscall_aix_ppc.go | 4 + .../x/sys/unix/syscall_aix_ppc64.go | 4 + vendor/golang.org/x/sys/unix/syscall_bsd.go | 2 - .../golang.org/x/sys/unix/syscall_darwin.go | 38 -- .../x/sys/unix/syscall_darwin_386.go | 7 + .../x/sys/unix/syscall_darwin_amd64.go | 7 + .../x/sys/unix/syscall_darwin_arm.go | 12 + .../x/sys/unix/syscall_darwin_arm64.go | 12 + .../x/sys/unix/syscall_dragonfly.go | 39 +- .../x/sys/unix/syscall_dragonfly_amd64.go | 4 + .../golang.org/x/sys/unix/syscall_freebsd.go | 39 +- .../x/sys/unix/syscall_freebsd_386.go | 4 + .../x/sys/unix/syscall_freebsd_amd64.go | 4 + .../x/sys/unix/syscall_freebsd_arm.go | 4 + .../x/sys/unix/syscall_freebsd_arm64.go | 4 + vendor/golang.org/x/sys/unix/syscall_linux.go | 130 +++++-- .../x/sys/unix/syscall_linux_386.go | 4 + .../x/sys/unix/syscall_linux_amd64.go | 4 + .../x/sys/unix/syscall_linux_arm.go | 4 + .../x/sys/unix/syscall_linux_arm64.go | 4 + .../x/sys/unix/syscall_linux_mips64x.go | 4 + .../x/sys/unix/syscall_linux_mipsx.go | 4 + .../x/sys/unix/syscall_linux_ppc64x.go | 4 + .../x/sys/unix/syscall_linux_riscv64.go | 4 + .../x/sys/unix/syscall_linux_s390x.go | 4 + .../x/sys/unix/syscall_linux_sparc64.go | 4 + .../golang.org/x/sys/unix/syscall_netbsd.go | 39 +- .../x/sys/unix/syscall_netbsd_386.go | 4 + .../x/sys/unix/syscall_netbsd_amd64.go | 4 + .../x/sys/unix/syscall_netbsd_arm.go | 4 + .../x/sys/unix/syscall_netbsd_arm64.go | 4 + .../golang.org/x/sys/unix/syscall_openbsd.go | 39 +- .../x/sys/unix/syscall_openbsd_386.go | 4 + .../x/sys/unix/syscall_openbsd_amd64.go | 4 + .../x/sys/unix/syscall_openbsd_arm.go | 4 + .../x/sys/unix/syscall_openbsd_arm64.go | 4 + .../golang.org/x/sys/unix/syscall_solaris.go | 30 -- .../x/sys/unix/syscall_solaris_amd64.go | 4 + .../x/sys/unix/zerrors_linux_386.go | 116 +++++- .../x/sys/unix/zerrors_linux_amd64.go | 116 +++++- .../x/sys/unix/zerrors_linux_arm.go | 116 +++++- .../x/sys/unix/zerrors_linux_arm64.go | 118 +++++- .../x/sys/unix/zerrors_linux_mips.go | 116 +++++- .../x/sys/unix/zerrors_linux_mips64.go | 116 +++++- .../x/sys/unix/zerrors_linux_mips64le.go | 116 +++++- .../x/sys/unix/zerrors_linux_mipsle.go | 116 +++++- .../x/sys/unix/zerrors_linux_ppc64.go | 116 +++++- .../x/sys/unix/zerrors_linux_ppc64le.go | 116 +++++- .../x/sys/unix/zerrors_linux_riscv64.go | 116 +++++- .../x/sys/unix/zerrors_linux_s390x.go | 116 +++++- .../x/sys/unix/zerrors_linux_sparc64.go | 116 +++++- .../x/sys/unix/zsyscall_darwin_386.1_11.go | 20 +- .../x/sys/unix/zsyscall_darwin_386.go | 87 +++-- .../x/sys/unix/zsyscall_darwin_386.s | 10 +- .../x/sys/unix/zsyscall_darwin_amd64.1_11.go | 52 +-- .../x/sys/unix/zsyscall_darwin_amd64.go | 72 ++-- .../x/sys/unix/zsyscall_darwin_amd64.s | 8 +- .../x/sys/unix/zsyscall_darwin_arm.1_11.go | 26 -- .../x/sys/unix/zsyscall_darwin_arm.go | 51 +-- .../x/sys/unix/zsyscall_darwin_arm.s | 2 - .../x/sys/unix/zsyscall_darwin_arm64.1_11.go | 26 -- .../x/sys/unix/zsyscall_darwin_arm64.go | 51 +-- .../x/sys/unix/zsyscall_darwin_arm64.s | 6 +- .../x/sys/unix/zsysnum_linux_386.go | 2 + .../x/sys/unix/zsysnum_linux_amd64.go | 2 + .../x/sys/unix/zsysnum_linux_arm.go | 2 + .../x/sys/unix/zsysnum_linux_arm64.go | 1 + .../x/sys/unix/zsysnum_linux_mips.go | 1 + .../x/sys/unix/zsysnum_linux_mips64.go | 1 + .../x/sys/unix/zsysnum_linux_mips64le.go | 1 + .../x/sys/unix/zsysnum_linux_mipsle.go | 1 + .../x/sys/unix/zsysnum_linux_ppc64.go | 2 + .../x/sys/unix/zsysnum_linux_ppc64le.go | 2 + .../x/sys/unix/zsysnum_linux_riscv64.go | 2 + .../x/sys/unix/zsysnum_linux_s390x.go | 2 + .../x/sys/unix/zsysnum_linux_sparc64.go | 1 + .../golang.org/x/sys/unix/ztypes_linux_386.go | 71 ++++ .../x/sys/unix/ztypes_linux_amd64.go | 71 ++++ .../golang.org/x/sys/unix/ztypes_linux_arm.go | 71 ++++ .../x/sys/unix/ztypes_linux_arm64.go | 71 ++++ .../x/sys/unix/ztypes_linux_mips.go | 71 ++++ .../x/sys/unix/ztypes_linux_mips64.go | 71 ++++ .../x/sys/unix/ztypes_linux_mips64le.go | 71 ++++ .../x/sys/unix/ztypes_linux_mipsle.go | 71 ++++ .../x/sys/unix/ztypes_linux_ppc64.go | 71 ++++ .../x/sys/unix/ztypes_linux_ppc64le.go | 71 ++++ .../x/sys/unix/ztypes_linux_riscv64.go | 72 ++++ .../x/sys/unix/ztypes_linux_s390x.go | 71 ++++ .../x/sys/unix/ztypes_linux_sparc64.go | 71 ++++ .../x/sys/windows/security_windows.go | 44 ++- vendor/golang.org/x/sys/windows/service.go | 4 + .../x/sys/windows/syscall_windows.go | 22 +- .../golang.org/x/sys/windows/types_windows.go | 87 +++++ .../x/sys/windows/zsyscall_windows.go | 184 ++++++++++ vendor/modules.txt | 10 +- 121 files changed, 3897 insertions(+), 1047 deletions(-) create mode 100644 vendor/github.com/SkycoinProject/dmsg/addr.go create mode 100644 vendor/github.com/SkycoinProject/dmsg/client_conn.go create mode 100644 vendor/github.com/SkycoinProject/dmsg/listener.go create mode 100644 vendor/github.com/SkycoinProject/dmsg/port_manager.go diff --git a/go.mod b/go.mod index 963fe3b6c..f07074954 100644 --- a/go.mod +++ b/go.mod @@ -3,7 +3,7 @@ module github.com/SkycoinProject/skywire-mainnet go 1.12 require ( - github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb + github.com/SkycoinProject/dmsg v0.0.0-20190918181704-b7cccca1451e github.com/SkycoinProject/skycoin v0.26.0 github.com/alecthomas/template v0.0.0-20190718012654-fb15b899a751 // indirect github.com/alecthomas/units v0.0.0-20190910110746-680d30ca3117 // indirect @@ -14,6 +14,8 @@ require ( github.com/gorilla/handlers v1.4.2 github.com/gorilla/securecookie v1.1.1 github.com/hashicorp/yamux v0.0.0-20181012175058-2f1d1f20f75d + github.com/kr/pty v1.1.8 // indirect + github.com/mattn/go-isatty v0.0.9 // indirect github.com/mitchellh/go-homedir v1.1.0 github.com/modern-go/concurrent v0.0.0-20180306012644-bacd9c7ef1dd // indirect github.com/modern-go/reflect2 v1.0.1 // indirect @@ -21,11 +23,16 @@ require ( github.com/prometheus/client_golang v1.1.0 github.com/prometheus/common v0.6.0 github.com/sirupsen/logrus v1.4.2 + github.com/skycoin/dmsg v0.0.0-20190805065636-70f4c32a994f // indirect github.com/spf13/cobra v0.0.5 + github.com/stretchr/objx v0.2.0 // indirect github.com/stretchr/testify v1.4.0 go.etcd.io/bbolt v1.3.3 - golang.org/x/crypto v0.0.0-20190829043050-9756ffdc2472 - golang.org/x/net v0.0.0-20190827160401-ba9fcec4b297 + golang.org/x/crypto v0.0.0-20190911031432-227b76d455e7 + golang.org/x/net v0.0.0-20190918130420-a8b05e9114ab + golang.org/x/sync v0.0.0-20190911185100-cd5d95a43a6e // indirect + golang.org/x/sys v0.0.0-20190916202348-b4ddaad3f8a3 // indirect + golang.org/x/tools v0.0.0-20190918181022-2c18af7e64b2 // indirect ) // Uncomment for tests with alternate branches of 'dmsg' diff --git a/go.sum b/go.sum index 912d194ae..bea634b84 100644 --- a/go.sum +++ b/go.sum @@ -1,6 +1,7 @@ github.com/BurntSushi/toml v0.3.1/go.mod h1:xHWCNGjB5oqiDr8zfno3MHue2Ht5sIBksp03qcyfWMU= -github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb h1:bAKk+ypvaiD5YuIkOmWhh2FJVX2XQpJPR4TgQKsYD8Y= -github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb/go.mod h1:FwzixIUE0zAT9J1cfWU5WsN9JiI49oQ6dHlNZcpq23s= +github.com/SkycoinProject/dmsg v0.0.0-20190918162505-cc37af88b8bf/go.mod h1:WiVS8uAqzFsuWcRlDBsjrxqAiD41ftxS7S7CDTXZpko= +github.com/SkycoinProject/dmsg v0.0.0-20190918181704-b7cccca1451e h1:JMIfHAjNSJLvKdnwXpUudbnYG627qD5d6aye+gmDups= +github.com/SkycoinProject/dmsg v0.0.0-20190918181704-b7cccca1451e/go.mod h1:iB171maaQybaYptTK/mhzb02uonVRKQ8oCsJ7blquRw= github.com/SkycoinProject/skycoin v0.26.0 h1:8/ZRZb2VM2DM4YTIitRJMZ3Yo/3H1FFmbCMx5o6ekmA= github.com/SkycoinProject/skycoin v0.26.0/go.mod h1:xqPLOKh5B6GBZlGA7B5IJfQmCy7mwimD9NlqxR3gMXo= github.com/alecthomas/template v0.0.0-20160405071501-a0175ee3bccc/go.mod h1:LOuyumcjzFXgccqObfd/Ljyb9UuFJ6TxHnclSeseNhc= @@ -61,12 +62,14 @@ github.com/konsorten/go-windows-terminal-sequences v1.0.2/go.mod h1:T0+1ngSBFLxv github.com/kr/logfmt v0.0.0-20140226030751-b84e30acd515/go.mod h1:+0opPa2QZZtGFBFZlji/RkVcI2GknAs/DXo4wKdlNEc= github.com/kr/pretty v0.1.0/go.mod h1:dAy3ld7l9f0ibDNOQOHHMYYIIbhfbHSm3C4ZsoJORNo= github.com/kr/pty v1.1.1/go.mod h1:pFQYn66WHrOpPYNljwOMqo10TkYh1fy3cYio2l3bCsQ= +github.com/kr/pty v1.1.8/go.mod h1:O1sed60cT9XZ5uDucP5qwvh+TE3NnUj51EiZO/lmSfw= github.com/kr/text v0.1.0/go.mod h1:4Jbv+DJW3UT/LiOwJeYQe1efqtUx/iVham/4vfdArNI= github.com/magiconair/properties v1.8.0/go.mod h1:PppfXfuXeibc/6YijjN8zIbojt8czPbwD3XqdrwzmxQ= github.com/mattn/go-colorable v0.1.2 h1:/bC9yWikZXAL9uJdulbSfyVNIR3n3trXl+v8+1sx8mU= github.com/mattn/go-colorable v0.1.2/go.mod h1:U0ppj6V5qS13XJ6of8GYAs25YV2eR4EVcfRqFIhoBtE= -github.com/mattn/go-isatty v0.0.8 h1:HLtExJ+uU2HOZ+wI0Tt5DtUDrx8yhUqDcp7fYERX4CE= github.com/mattn/go-isatty v0.0.8/go.mod h1:Iq45c/XA43vh69/j3iqttzPXn0bhXyGjM0Hdxcsrc5s= +github.com/mattn/go-isatty v0.0.9 h1:d5US/mDsogSGW37IV293h//ZFaeajb69h+EHFsv2xGg= +github.com/mattn/go-isatty v0.0.9/go.mod h1:YNRxwqDuOph6SZLI9vUUz6OYw3QyUt7WiY2yME+cCiQ= github.com/matttproud/golang_protobuf_extensions v1.0.1 h1:4hp9jkHxhMHkqkrB3Ix0jegS5sx/RkqARlsWZ6pIwiU= github.com/matttproud/golang_protobuf_extensions v1.0.1/go.mod h1:D8He9yQNgCq6Z5Ld7szi9bcBfOoFv/3dc6xSMkL2PC0= github.com/mgutz/ansi v0.0.0-20170206155736-9520e82c474b h1:j7+1HpAFS1zy5+Q4qx1fWh90gTKwiN4QCGoY9TWyyO4= @@ -103,6 +106,7 @@ github.com/russross/blackfriday v1.5.2/go.mod h1:JO/DiYxRf+HjHt06OyowR9PTA263kcR github.com/sirupsen/logrus v1.2.0/go.mod h1:LxeOpSwHxABJmUn/MG1IvRgCAasNZTLOkJPxbbu5VWo= github.com/sirupsen/logrus v1.4.2 h1:SPIRibHv4MatM3XXNO2BJeFLZwZ2LvZgfQ5+UNI2im4= github.com/sirupsen/logrus v1.4.2/go.mod h1:tLMulIdttU9McNUspp0xgXVQah82FyeX6MwdIuYE2rE= +github.com/skycoin/dmsg v0.0.0-20190805065636-70f4c32a994f/go.mod h1:obZYZp8eKR7Xqz+KNhJdUE6Gvp6rEXbDO8YTlW2YXgU= github.com/skycoin/skycoin v0.26.0 h1:xDxe2r8AclMntZ550Y/vUQgwgLtwrf9Wu5UYiYcN5/o= github.com/skycoin/skycoin v0.26.0/go.mod h1:78nHjQzd8KG0jJJVL/j0xMmrihXi70ti63fh8vXScJw= github.com/spf13/afero v1.1.2/go.mod h1:j4pytiNVoe2o6bmDsKpLACNPDBIoEAkihy7loJ1B0CQ= @@ -115,6 +119,7 @@ github.com/spf13/pflag v1.0.3/go.mod h1:DYY7MBk1bdzusC3SYhjObp+wFpr4gzcvqqNjLnIn github.com/spf13/viper v1.3.2/go.mod h1:ZiWeW+zYFKm7srdB9IoDzzZXaJaI5eL9QjNiN/DMA2s= github.com/stretchr/objx v0.1.0/go.mod h1:HFkY916IF+rwdDfMAkV7OtwuqBVzrE8GR6GFx+wExME= github.com/stretchr/objx v0.1.1/go.mod h1:HFkY916IF+rwdDfMAkV7OtwuqBVzrE8GR6GFx+wExME= +github.com/stretchr/objx v0.2.0/go.mod h1:qt09Ya8vawLte6SNmTgCsAVtYtaKzEcn8ATUoHMkEqE= github.com/stretchr/testify v1.2.2/go.mod h1:a8OnRcib4nhh0OaRAV+Yts87kKdq0PP7pXfy6kDkUVs= github.com/stretchr/testify v1.3.0/go.mod h1:M5WIy9Dh21IEIfnGCwXGc5bZfKNJtfHm1UVUgZn+9EI= github.com/stretchr/testify v1.4.0 h1:2E4SXV/wtOkTonXsotYi4li6zVWxYlZuYNCXe9XRJyk= @@ -127,16 +132,19 @@ golang.org/x/crypto v0.0.0-20180904163835-0709b304e793/go.mod h1:6SG95UA2DQfeDnf golang.org/x/crypto v0.0.0-20181203042331-505ab145d0a9/go.mod h1:6SG95UA2DQfeDnfUPMdvaQW0Q7yPrPDi9nlGo2tz2b4= golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= -golang.org/x/crypto v0.0.0-20190829043050-9756ffdc2472 h1:Gv7RPwsi3eZ2Fgewe3CBsuOebPwO27PoXzRpJPsvSSM= -golang.org/x/crypto v0.0.0-20190829043050-9756ffdc2472/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= +golang.org/x/crypto v0.0.0-20190911031432-227b76d455e7 h1:0hQKqeLdqlt5iIwVOBErRisrHJAN57yOiPRQItI20fU= +golang.org/x/crypto v0.0.0-20190911031432-227b76d455e7/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= golang.org/x/net v0.0.0-20181114220301-adae6a3d119a/go.mod h1:mL1N/T3taQHkDXs73rZJwtUhF3w3ftmwwsq0BUmARs4= +golang.org/x/net v0.0.0-20190311183353-d8887717615a/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190613194153-d28f0bde5980/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= -golang.org/x/net v0.0.0-20190827160401-ba9fcec4b297 h1:k7pJ2yAPLPgbskkFdhRCsA77k2fySZ1zf2zCjvQCiIM= -golang.org/x/net v0.0.0-20190827160401-ba9fcec4b297/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= +golang.org/x/net v0.0.0-20190918130420-a8b05e9114ab h1:h5tBRKZ1aY/bo6GNqe/4zWC8GkaLOFQ5wPKIOQ0i2sA= +golang.org/x/net v0.0.0-20190918130420-a8b05e9114ab/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sync v0.0.0-20181221193216-37e7f081c4d4/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20190423024810-112230192c58/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= +golang.org/x/sync v0.0.0-20190911185100-cd5d95a43a6e/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= golang.org/x/sys v0.0.0-20180905080454-ebe1bf3edb33/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20181116152217-5ac8a444bdc5/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20181205085412-a5c9d58dba9a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= @@ -145,13 +153,21 @@ golang.org/x/sys v0.0.0-20190222072716-a9d3bda3a223/go.mod h1:STP8DvDyc/dI5b8T5h golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20190422165155-953cdadca894/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= -golang.org/x/sys v0.0.0-20190801041406-cbf593c0f2f3 h1:4y9KwBHBgBNwDbtu44R5o1fdOCQUEXhbk/P4A9WmJq0= golang.org/x/sys v0.0.0-20190801041406-cbf593c0f2f3/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20190813064441-fde4db37ae7a/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20190916202348-b4ddaad3f8a3 h1:7TYNF4UdlohbFwpNH04CoPMp1cHUZgO1Ebq5r2hIjfo= +golang.org/x/sys v0.0.0-20190916202348-b4ddaad3f8a3/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= +golang.org/x/text v0.3.2/go.mod h1:bEr9sfX3Q8Zfm5fL9x+3itogRgK3+ptLWKqgva+5dAk= +golang.org/x/tools v0.0.0-20180917221912-90fa682c2a6e/go.mod h1:n7NCudcB/nEzxVGmLbDWY5pfWTLqBcC2KZ6jyYvM4mQ= +golang.org/x/tools v0.0.0-20190627182818-9947fec5c3ab/go.mod h1:/rFqwRUd4F7ZHNgwSSTFct+R/Kf4OFW1sUzUTQQTgfc= +golang.org/x/tools v0.0.0-20190918181022-2c18af7e64b2/go.mod h1:b+2E5dAYhXwXZwtnZ6UAqBI28+e2cm9otk0dWdXHAEo= +golang.org/x/xerrors v0.0.0-20190717185122-a985d3407aa7/go.mod h1:I/5z698sn9Ka8TeJc9MKroUUfqBBauWjQqLJ2OPfmY0= gopkg.in/alecthomas/kingpin.v2 v2.2.6 h1:jMFz6MfLP0/4fUyZle81rXUoxOBFi19VUFKVDOQfozc= gopkg.in/alecthomas/kingpin.v2 v2.2.6/go.mod h1:FMv+mEhP44yOT+4EoQTLFTRgOQ1FBLkstjWtayDeSgw= gopkg.in/check.v1 v0.0.0-20161208181325-20d25e280405/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= +gopkg.in/check.v1 v1.0.0-20190902080502-41f04d3bba15/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= gopkg.in/yaml.v2 v2.2.1/go.mod h1:hI93XBmqTisBFMUTm0b8Fm+jr3Dg1NNxqwp+5A1VGuI= gopkg.in/yaml.v2 v2.2.2 h1:ZCJp+EgiOT7lHqUV2J862kp8Qj64Jo6az82+3Td9dZw= gopkg.in/yaml.v2 v2.2.2/go.mod h1:hI93XBmqTisBFMUTm0b8Fm+jr3Dg1NNxqwp+5A1VGuI= diff --git a/pkg/transport/handshake.go b/pkg/transport/handshake.go index 567411c63..aa5180c5a 100644 --- a/pkg/transport/handshake.go +++ b/pkg/transport/handshake.go @@ -7,6 +7,7 @@ import ( "fmt" "io" + "github.com/SkycoinProject/skywire-mainnet/pkg/snet" "github.com/SkycoinProject/dmsg/cipher" ) diff --git a/pkg/visor/rpc.go b/pkg/visor/rpc.go index e9955c745..bc6daf17b 100644 --- a/pkg/visor/rpc.go +++ b/pkg/visor/rpc.go @@ -10,6 +10,7 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" "github.com/SkycoinProject/skywire-mainnet/pkg/routing" "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) diff --git a/pkg/visor/rpc_client.go b/pkg/visor/rpc_client.go index edd429bb7..0c9f271b0 100644 --- a/pkg/visor/rpc_client.go +++ b/pkg/visor/rpc_client.go @@ -3,6 +3,7 @@ package visor import ( "encoding/binary" "fmt" + "github.com/SkycoinProject/skywire-mainnet/pkg/router" "math/rand" "net/http" "net/rpc" @@ -12,6 +13,7 @@ import ( "github.com/google/uuid" "github.com/SkycoinProject/dmsg/cipher" "github.com/SkycoinProject/skycoin/src/util/logging" + "github.com/SkycoinProject/skywire-mainnet/pkg/app" "github.com/SkycoinProject/skywire-mainnet/pkg/routing" "github.com/SkycoinProject/skywire-mainnet/pkg/transport" ) diff --git a/pkg/visor/rpc_test.go b/pkg/visor/rpc_test.go index dd4d54eea..ca1a694b2 100644 --- a/pkg/visor/rpc_test.go +++ b/pkg/visor/rpc_test.go @@ -14,8 +14,6 @@ import ( "github.com/SkycoinProject/skywire-mainnet/pkg/routing" "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" - "github.com/SkycoinProject/skywire-mainnet/pkg/routing" - "github.com/SkycoinProject/skywire-mainnet/pkg/util/pathutil" ) func TestHealth(t *testing.T) { diff --git a/vendor/github.com/SkycoinProject/dmsg/addr.go b/vendor/github.com/SkycoinProject/dmsg/addr.go new file mode 100644 index 000000000..2f291177e --- /dev/null +++ b/vendor/github.com/SkycoinProject/dmsg/addr.go @@ -0,0 +1,26 @@ +package dmsg + +import ( + "fmt" + + "github.com/SkycoinProject/dmsg/cipher" +) + +// Addr implements net.Addr for skywire addresses. +type Addr struct { + PK cipher.PubKey + Port uint16 +} + +// Network returns "dmsg" +func (Addr) Network() string { + return Type +} + +// String returns public key and port of node split by colon. +func (a Addr) String() string { + if a.Port == 0 { + return fmt.Sprintf("%s:~", a.PK) + } + return fmt.Sprintf("%s:%d", a.PK, a.Port) +} diff --git a/vendor/github.com/SkycoinProject/dmsg/client.go b/vendor/github.com/SkycoinProject/dmsg/client.go index 2fdc6136f..d945aad9c 100644 --- a/vendor/github.com/SkycoinProject/dmsg/client.go +++ b/vendor/github.com/SkycoinProject/dmsg/client.go @@ -8,7 +8,6 @@ import ( "sync" "time" - "github.com/sirupsen/logrus" "github.com/SkycoinProject/skycoin/src/util/logging" "github.com/SkycoinProject/dmsg/cipher" @@ -31,270 +30,6 @@ var ( ErrClientAcceptMaxed = errors.New("client accepts buffer maxed") ) -// ClientConn represents a connection between a dmsg.Client and dmsg.Server from a client's perspective. -type ClientConn struct { - log *logging.Logger - - net.Conn // conn to dmsg server - local cipher.PubKey // local client's pk - remoteSrv cipher.PubKey // dmsg server's public key - - // nextInitID keeps track of unused tp_ids to assign a future locally-initiated tp. - // locally-initiated tps use an even tp_id between local and intermediary dms_server. - nextInitID uint16 - - // Transports: map of transports to remote dms_clients (key: tp_id, val: transport). - tps map[uint16]*Transport - mx sync.RWMutex // to protect tps - - done chan struct{} - once sync.Once - wg sync.WaitGroup -} - -// NewClientConn creates a new ClientConn. -func NewClientConn(log *logging.Logger, conn net.Conn, local, remote cipher.PubKey) *ClientConn { - cc := &ClientConn{ - log: log, - Conn: conn, - local: local, - remoteSrv: remote, - nextInitID: randID(true), - tps: make(map[uint16]*Transport), - done: make(chan struct{}), - } - cc.wg.Add(1) - return cc -} - -// RemotePK returns the remote Server's PK that the ClientConn is connected to. -func (c *ClientConn) RemotePK() cipher.PubKey { return c.remoteSrv } - -func (c *ClientConn) getNextInitID(ctx context.Context) (uint16, error) { - for { - select { - case <-c.done: - return 0, ErrClientClosed - case <-ctx.Done(): - return 0, ctx.Err() - default: - if ch := c.tps[c.nextInitID]; ch != nil && !ch.IsClosed() { - c.nextInitID += 2 - continue - } - c.tps[c.nextInitID] = nil - id := c.nextInitID - c.nextInitID = id + 2 - return id, nil - } - } -} - -func (c *ClientConn) addTp(ctx context.Context, clientPK cipher.PubKey) (*Transport, error) { - c.mx.Lock() - defer c.mx.Unlock() - - id, err := c.getNextInitID(ctx) - if err != nil { - return nil, err - } - tp := NewTransport(c.Conn, c.log, c.local, clientPK, id, c.delTp) - c.tps[id] = tp - return tp, nil -} - -func (c *ClientConn) setTp(tp *Transport) { - c.mx.Lock() - c.tps[tp.id] = tp - c.mx.Unlock() -} - -func (c *ClientConn) delTp(id uint16) { - c.mx.Lock() - c.tps[id] = nil - c.mx.Unlock() -} - -func (c *ClientConn) getTp(id uint16) (*Transport, bool) { - c.mx.RLock() - tp := c.tps[id] - c.mx.RUnlock() - ok := tp != nil && !tp.IsClosed() - return tp, ok -} - -func (c *ClientConn) setNextInitID(nextInitID uint16) { - c.mx.Lock() - c.nextInitID = nextInitID - c.mx.Unlock() -} - -func (c *ClientConn) readOK() error { - fr, err := readFrame(c.Conn) - if err != nil { - return errors.New("failed to get OK from server") - } - - ft, _, _ := fr.Disassemble() - if ft != OkType { - return fmt.Errorf("wrong frame from server: %v", ft) - } - - return nil -} - -func (c *ClientConn) handleRequestFrame(accept chan<- *Transport, id uint16, p []byte) (cipher.PubKey, error) { - // remotely-initiated tps should: - // - have a payload structured as 'init_pk:resp_pk'. - // - resp_pk should be of local client. - // - use an odd tp_id with the intermediary dmsg_server. - initPK, respPK, ok := splitPKs(p) - if !ok || respPK != c.local || isInitiatorID(id) { - if err := writeCloseFrame(c.Conn, id, 0); err != nil { - return initPK, err - } - return initPK, ErrRequestCheckFailed - } - - tp := NewTransport(c.Conn, c.log, c.local, initPK, id, c.delTp) - - select { - case <-c.done: - if err := tp.Close(); err != nil { - log.WithError(err).Warn("Failed to close transport") - } - return initPK, ErrClientClosed - default: - select { - case accept <- tp: - c.setTp(tp) - if err := tp.WriteAccept(); err != nil { - return initPK, err - } - go tp.Serve() - return initPK, nil - - default: - if err := tp.Close(); err != nil { - log.WithError(err).Warn("Failed to close transport") - } - return initPK, ErrClientAcceptMaxed - } - } -} - -// Serve handles incoming frames. -// Remote-initiated tps that are successfully created are pushing into 'accept' and exposed via 'Client.Accept()'. -func (c *ClientConn) Serve(ctx context.Context, accept chan<- *Transport) (err error) { - log := c.log.WithField("remoteServer", c.remoteSrv) - log.WithField("connCount", incrementServeCount()).Infoln("ServingConn") - defer func() { - c.close() - log.WithError(err).WithField("connCount", decrementServeCount()).Infoln("ConnectionClosed") - c.wg.Done() - }() - - for { - f, err := readFrame(c.Conn) - if err != nil { - return fmt.Errorf("read failed: %s", err) - } - log = log.WithField("received", f) - - ft, id, p := f.Disassemble() - - // If tp of tp_id exists, attempt to forward frame to tp. - // delete tp on any failure. - - if tp, ok := c.getTp(id); ok { - if err := tp.HandleFrame(f); err != nil { - log.WithError(err).Warnf("Rejected [%s]: Transport closed.", ft) - } - continue - } - - // if tp does not exist, frame should be 'REQUEST'. - // otherwise, handle any unexpected frames accordingly. - - c.delTp(id) // rm tp in case closed tp is not fully removed. - - switch ft { - case RequestType: - c.wg.Add(1) - go func(log *logrus.Entry) { - defer c.wg.Done() - initPK, err := c.handleRequestFrame(accept, id, p) - if err != nil { - log.WithField("remoteClient", initPK).WithError(err).Infoln("Rejected [REQUEST]") - if isWriteError(err) || err == ErrClientClosed { - err := c.Close() - log.WithError(err).Warn("ClosingConnection") - } - return - } - log.WithField("remoteClient", initPK).Infoln("Accepted [REQUEST]") - }(log) - - default: - log.Debugf("Ignored [%s]: No transport of given ID.", ft) - if ft != CloseType { - if err := writeCloseFrame(c.Conn, id, 0); err != nil { - return err - } - } - } - } -} - -// DialTransport dials a transport to remote dms_client. -func (c *ClientConn) DialTransport(ctx context.Context, clientPK cipher.PubKey) (*Transport, error) { - tp, err := c.addTp(ctx, clientPK) - if err != nil { - return nil, err - } - if err := tp.WriteRequest(); err != nil { - return nil, err - } - if err := tp.ReadAccept(ctx); err != nil { - return nil, err - } - go tp.Serve() - return tp, nil -} - -func (c *ClientConn) close() (closed bool) { - if c == nil { - return false - } - c.once.Do(func() { - closed = true - c.log.WithField("remoteServer", c.remoteSrv).Infoln("ClosingConnection") - close(c.done) - c.mx.Lock() - for _, tp := range c.tps { - tp := tp - go func() { - if err := tp.Close(); err != nil { - log.WithError(err).Warn("Failed to close transport") - } - }() - } - if err := c.Conn.Close(); err != nil { - log.WithError(err).Warn("Failed to close connection") - } - c.mx.Unlock() - }) - return closed -} - -// Close closes the connection to dms_server. -func (c *ClientConn) Close() error { - if c.close() { - c.wg.Wait() - } - return nil -} - // ClientOption represents an optional argument for Client. type ClientOption func(c *Client) error @@ -320,21 +55,25 @@ type Client struct { conns map[cipher.PubKey]*ClientConn // conns with messaging servers. Key: pk of server mx sync.RWMutex - accept chan *Transport - done chan struct{} - once sync.Once + pm *PortManager + + // accept map[uint16]chan *transport + done chan struct{} + once sync.Once } // NewClient creates a new Client. func NewClient(pk cipher.PubKey, sk cipher.SecKey, dc disc.APIClient, opts ...ClientOption) *Client { c := &Client{ - log: logging.MustGetLogger("dmsg_client"), - pk: pk, - sk: sk, - dc: dc, - conns: make(map[cipher.PubKey]*ClientConn), - accept: make(chan *Transport, AcceptBufferSize), - done: make(chan struct{}), + log: logging.MustGetLogger("dmsg_client"), + pk: pk, + sk: sk, + dc: dc, + conns: make(map[cipher.PubKey]*ClientConn), + pm: newPortManager(), + // accept: make(chan *transport, AcceptBufferSize), + // accept: make(map[uint16]chan *transport), + done: make(chan struct{}), } for _, opt := range opts { if err := opt(c); err != nil { @@ -419,7 +158,7 @@ func (c *Client) findServerEntries(ctx context.Context) ([]*disc.Entry, error) { return nil, fmt.Errorf("dms_servers are not available: %s", err) default: retry := time.Second - c.log.WithError(err).Warnf("no dms_servers found: trying again in %d second...", retry) + c.log.WithError(err).Warnf("no dms_servers found: trying again in %v...", retry) time.Sleep(retry) continue } @@ -474,7 +213,7 @@ func (c *Client) findOrConnectToServer(ctx context.Context, srvPK cipher.PubKey) return nil, err } - conn := NewClientConn(c.log, nc, c.pk, srvPK) + conn := NewClientConn(c.log, nc, c.pk, srvPK, c.pm) if err := conn.readOK(); err != nil { return nil, err } @@ -482,7 +221,7 @@ func (c *Client) findOrConnectToServer(ctx context.Context, srvPK cipher.PubKey) c.setConn(ctx, conn) go func() { - err := conn.Serve(ctx, c.accept) + err := conn.Serve(ctx) conn.log.WithError(err).WithField("remoteServer", srvPK).Warn("connected with server closed") c.delConn(ctx, srvPK) @@ -503,23 +242,17 @@ func (c *Client) findOrConnectToServer(ctx context.Context, srvPK cipher.PubKey) return conn, nil } -// Accept accepts remotely-initiated tps. -func (c *Client) Accept(ctx context.Context) (*Transport, error) { - select { - case tp, ok := <-c.accept: - if !ok { - return nil, ErrClientClosed - } - return tp, nil - case <-c.done: - return nil, ErrClientClosed - case <-ctx.Done(): - return nil, ctx.Err() +// Listen creates a listener on a given port, adds it to port manager and returns the listener. +func (c *Client) Listen(port uint16) (*Listener, error) { + l, ok := c.pm.NewListener(c.pk, port) + if !ok { + return nil, errors.New("port is busy") } + return l, nil } // Dial dials a transport to remote dms_client. -func (c *Client) Dial(ctx context.Context, remote cipher.PubKey) (*Transport, error) { +func (c *Client) Dial(ctx context.Context, remote cipher.PubKey, port uint16) (*Transport, error) { entry, err := c.dc.Entry(ctx, remote) if err != nil { return nil, fmt.Errorf("get entry failure: %s", err) @@ -536,14 +269,16 @@ func (c *Client) Dial(ctx context.Context, remote cipher.PubKey) (*Transport, er c.log.WithError(err).Warn("failed to connect to server") continue } - return conn.DialTransport(ctx, remote) + return conn.DialTransport(ctx, remote, port) } return nil, errors.New("failed to find dms_servers for given client pk") } -// Local returns the local dms_client's public key. -func (c *Client) Local() cipher.PubKey { - return c.pk +// Addr returns the local dms_client's public key. +func (c *Client) Addr() net.Addr { + return Addr{ + PK: c.pk, + } } // Type returns the transport type. @@ -570,14 +305,13 @@ func (c *Client) Close() error { c.conns = make(map[cipher.PubKey]*ClientConn) c.mx.Unlock() - for { - select { - case <-c.accept: - default: - close(c.accept) - return - } + c.pm.mu.Lock() + defer c.pm.mu.Unlock() + + for _, lis := range c.pm.listeners { + lis.close() } }) + return nil } diff --git a/vendor/github.com/SkycoinProject/dmsg/client_conn.go b/vendor/github.com/SkycoinProject/dmsg/client_conn.go new file mode 100644 index 000000000..fd439df4e --- /dev/null +++ b/vendor/github.com/SkycoinProject/dmsg/client_conn.go @@ -0,0 +1,301 @@ +package dmsg + +import ( + "context" + "encoding/json" + "errors" + "fmt" + "net" + "sync" + + "github.com/sirupsen/logrus" + "github.com/SkycoinProject/skycoin/src/util/logging" + + "github.com/SkycoinProject/dmsg/cipher" +) + +// ClientConn represents a connection between a dmsg.Client and dmsg.Server from a client's perspective. +type ClientConn struct { + log *logging.Logger + + net.Conn // conn to dmsg server + local cipher.PubKey // local client's pk + remoteSrv cipher.PubKey // dmsg server's public key + + // nextInitID keeps track of unused tp_ids to assign a future locally-initiated tp. + // locally-initiated tps use an even tp_id between local and intermediary dms_server. + nextInitID uint16 + + // Transports: map of transports to remote dms_clients (key: tp_id, val: transport). + tps map[uint16]*Transport + mx sync.RWMutex // to protect tps + + pm *PortManager + + done chan struct{} + once sync.Once + wg sync.WaitGroup +} + +// NewClientConn creates a new ClientConn. +func NewClientConn(log *logging.Logger, conn net.Conn, local, remote cipher.PubKey, pm *PortManager) *ClientConn { + cc := &ClientConn{ + log: log, + Conn: conn, + local: local, + remoteSrv: remote, + nextInitID: randID(true), + tps: make(map[uint16]*Transport), + pm: pm, + done: make(chan struct{}), + } + cc.wg.Add(1) + return cc +} + +// RemotePK returns the remote Server's PK that the ClientConn is connected to. +func (c *ClientConn) RemotePK() cipher.PubKey { return c.remoteSrv } + +func (c *ClientConn) getNextInitID(ctx context.Context) (uint16, error) { + for { + select { + case <-c.done: + return 0, ErrClientClosed + case <-ctx.Done(): + return 0, ctx.Err() + default: + if ch := c.tps[c.nextInitID]; ch != nil && !ch.IsClosed() { + c.nextInitID += 2 + continue + } + c.tps[c.nextInitID] = nil + id := c.nextInitID + c.nextInitID = id + 2 + return id, nil + } + } +} + +func (c *ClientConn) addTp(ctx context.Context, rPK cipher.PubKey, lPort, rPort uint16) (*Transport, error) { + c.mx.Lock() + defer c.mx.Unlock() + + id, err := c.getNextInitID(ctx) + if err != nil { + return nil, err + } + tp := NewTransport(c.Conn, c.log, Addr{c.local, lPort}, Addr{rPK, rPort}, id, c.delTp) + c.tps[id] = tp + return tp, nil +} + +func (c *ClientConn) setTp(tp *Transport) { + c.mx.Lock() + c.tps[tp.id] = tp + c.mx.Unlock() +} + +func (c *ClientConn) delTp(id uint16) { + c.mx.Lock() + c.tps[id] = nil + c.mx.Unlock() +} + +func (c *ClientConn) getTp(id uint16) (*Transport, bool) { + c.mx.RLock() + tp := c.tps[id] + c.mx.RUnlock() + ok := tp != nil && !tp.IsClosed() + return tp, ok +} + +func (c *ClientConn) setNextInitID(nextInitID uint16) { + c.mx.Lock() + c.nextInitID = nextInitID + c.mx.Unlock() +} + +func (c *ClientConn) readOK() error { + fr, err := readFrame(c.Conn) + if err != nil { + return errors.New("failed to get OK from server") + } + + ft, _, _ := fr.Disassemble() + if ft != OkType { + return fmt.Errorf("wrong frame from server: %v", ft) + } + + return nil +} + +func (c *ClientConn) handleRequestFrame(id uint16, p []byte) (cipher.PubKey, error) { + // remotely-initiated tps should: + // - have a payload structured as HandshakePayload marshaled to JSON. + // - resp_pk should be of local client. + // - use an odd tp_id with the intermediary dmsg_server. + payload, err := unmarshalHandshakePayload(p) + if err != nil { + // TODO(nkryuchkov): When implementing reasons, send that payload format is incorrect. + if err := writeCloseFrame(c.Conn, id, PlaceholderReason); err != nil { + return cipher.PubKey{}, err + } + return cipher.PubKey{}, ErrRequestCheckFailed + } + + if payload.RespPK != c.local || isInitiatorID(id) { + // TODO(nkryuchkov): When implementing reasons, send that payload is malformed. + if err := writeCloseFrame(c.Conn, id, PlaceholderReason); err != nil { + return payload.InitPK, err + } + return payload.InitPK, ErrRequestCheckFailed + } + + lis, ok := c.pm.Listener(payload.Port) + if !ok { + // TODO(nkryuchkov): When implementing reasons, send that port is not listening + if err := writeCloseFrame(c.Conn, id, PlaceholderReason); err != nil { + return payload.InitPK, err + } + return payload.InitPK, ErrPortNotListening + } + + tp := NewTransport(c.Conn, c.log, Addr{c.local, payload.Port}, Addr{payload.InitPK, 0}, id, c.delTp) // TODO: Have proper remote port. + + select { + case <-c.done: + if err := tp.Close(); err != nil { + log.WithError(err).Warn("Failed to close transport") + } + return payload.InitPK, ErrClientClosed + + default: + err := lis.IntroduceTransport(tp) + if err == nil || err == ErrClientAcceptMaxed { + c.setTp(tp) + } + return payload.InitPK, err + } +} + +// Serve handles incoming frames. +// Remote-initiated tps that are successfully created are pushing into 'accept' and exposed via 'Client.Accept()'. +func (c *ClientConn) Serve(ctx context.Context) (err error) { + log := c.log.WithField("remoteServer", c.remoteSrv) + log.WithField("connCount", incrementServeCount()).Infoln("ServingConn") + defer func() { + c.close() + log.WithError(err).WithField("connCount", decrementServeCount()).Infoln("ConnectionClosed") + c.wg.Done() + }() + + for { + f, err := readFrame(c.Conn) + if err != nil { + return fmt.Errorf("read failed: %s", err) + } + log = log.WithField("received", f) + + ft, id, p := f.Disassemble() + + // If tp of tp_id exists, attempt to forward frame to tp. + // delete tp on any failure. + + if tp, ok := c.getTp(id); ok { + if err := tp.HandleFrame(f); err != nil { + log.WithError(err).Warnf("Rejected [%s]: Transport closed.", ft) + } + continue + } + + // if tp does not exist, frame should be 'REQUEST'. + // otherwise, handle any unexpected frames accordingly. + + c.delTp(id) // rm tp in case closed tp is not fully removed. + + switch ft { + case RequestType: + c.wg.Add(1) + go func(log *logrus.Entry) { + defer c.wg.Done() + initPK, err := c.handleRequestFrame(id, p) + if err != nil { + log.WithField("remoteClient", initPK).WithError(err).Infoln("Rejected [REQUEST]") + if isWriteError(err) || err == ErrClientClosed { + err := c.Close() + log.WithError(err).Warn("ClosingConnection") + } + return + } + log.WithField("remoteClient", initPK).Infoln("Accepted [REQUEST]") + }(log) + + default: + log.Debugf("Ignored [%s]: No transport of given ID.", ft) + if ft != CloseType { + if err := writeCloseFrame(c.Conn, id, PlaceholderReason); err != nil { + return err + } + } + } + } +} + +// DialTransport dials a transport to remote dms_client. +func (c *ClientConn) DialTransport(ctx context.Context, clientPK cipher.PubKey, port uint16) (*Transport, error) { + tp, err := c.addTp(ctx, clientPK, 0, port) // TODO: Have proper local port. + if err != nil { + return nil, err + } + if err := tp.WriteRequest(port); err != nil { + return nil, err + } + if err := tp.ReadAccept(ctx); err != nil { + return nil, err + } + go tp.Serve() + return tp, nil +} + +func (c *ClientConn) close() (closed bool) { + if c == nil { + return false + } + c.once.Do(func() { + closed = true + c.log.WithField("remoteServer", c.remoteSrv).Infoln("ClosingConnection") + close(c.done) + c.mx.Lock() + for _, tp := range c.tps { + tp := tp + go func() { + if err := tp.Close(); err != nil { + log.WithError(err).Warn("Failed to close transport") + } + }() + } + if err := c.Conn.Close(); err != nil { + log.WithError(err).Warn("Failed to close connection") + } + c.mx.Unlock() + }) + return closed +} + +// Close closes the connection to dms_server. +func (c *ClientConn) Close() error { + if c.close() { + c.wg.Wait() + } + return nil +} + +func marshalHandshakePayload(p HandshakePayload) ([]byte, error) { + return json.Marshal(p) +} + +func unmarshalHandshakePayload(b []byte) (HandshakePayload, error) { + var p HandshakePayload + err := json.Unmarshal(b, &p) + return p, err +} diff --git a/vendor/github.com/SkycoinProject/dmsg/frame.go b/vendor/github.com/SkycoinProject/dmsg/frame.go index d00833647..f0ef1fb17 100644 --- a/vendor/github.com/SkycoinProject/dmsg/frame.go +++ b/vendor/github.com/SkycoinProject/dmsg/frame.go @@ -16,6 +16,9 @@ import ( const ( // Type returns the transport type string. Type = "dmsg" + // HandshakePayloadVersion contains payload version to maintain compatibility with future versions + // of HandshakePayload format. + HandshakePayloadVersion = "1" tpBufCap = math.MaxUint16 tpBufFrameCap = math.MaxUint8 @@ -31,6 +34,15 @@ var ( AcceptBufferSize = 20 ) +// HandshakePayload represents format of payload sent with REQUEST frames. +// TODO(evanlinjin): Use 'dmsg.Addr' for PK:Port pair. +type HandshakePayload struct { + Version string `json:"version"` // just in case the struct changes. + InitPK cipher.PubKey `json:"init_pk"` + RespPK cipher.PubKey `json:"resp_pk"` + Port uint16 `json:"port"` +} + func isInitiatorID(tpID uint16) bool { return tpID%2 == 0 } func randID(initiator bool) uint16 { @@ -76,6 +88,11 @@ const ( AckType = FrameType(0xb) ) +// Reasons for closing frames +const ( + PlaceholderReason = iota +) + // Frame is the dmsg data unit. type Frame []byte diff --git a/vendor/github.com/SkycoinProject/dmsg/go.mod b/vendor/github.com/SkycoinProject/dmsg/go.mod index 7efd7a29d..cdadb37b6 100644 --- a/vendor/github.com/SkycoinProject/dmsg/go.mod +++ b/vendor/github.com/SkycoinProject/dmsg/go.mod @@ -5,15 +5,12 @@ go 1.12 require ( github.com/SkycoinProject/skycoin v0.26.0 github.com/flynn/noise v0.0.0-20180327030543-2492fe189ae6 - github.com/konsorten/go-windows-terminal-sequences v1.0.2 // indirect github.com/kr/pretty v0.1.0 // indirect github.com/mattn/go-colorable v0.1.2 // indirect github.com/mgutz/ansi v0.0.0-20170206155736-9520e82c474b // indirect github.com/sirupsen/logrus v1.4.2 github.com/skycoin/skycoin v0.26.0 // indirect github.com/stretchr/testify v1.3.0 - golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4 // indirect golang.org/x/net v0.0.0-20190620200207-3b0461eec859 - golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb // indirect - gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127 // indirect + gopkg.in/check.v1 v1.0.0-20190902080502-41f04d3bba15 // indirect ) diff --git a/vendor/github.com/SkycoinProject/dmsg/go.sum b/vendor/github.com/SkycoinProject/dmsg/go.sum index 9bd02b3dd..c6215aab0 100644 --- a/vendor/github.com/SkycoinProject/dmsg/go.sum +++ b/vendor/github.com/SkycoinProject/dmsg/go.sum @@ -5,9 +5,8 @@ github.com/davecgh/go-spew v1.1.1 h1:vj9j/u1bqnvCEfJOwUhtlOARqs3+rkHYY13jYWTU97c github.com/davecgh/go-spew v1.1.1/go.mod h1:J7Y8YcW2NihsgmVo/mv3lAwl/skON4iLHjSsI+c5H38= github.com/flynn/noise v0.0.0-20180327030543-2492fe189ae6 h1:u/UEqS66A5ckRmS4yNpjmVH56sVtS/RfclBAYocb4as= github.com/flynn/noise v0.0.0-20180327030543-2492fe189ae6/go.mod h1:1i71OnUq3iUe1ma7Lr6yG6/rjvM3emb6yoL7xLFzcVQ= +github.com/konsorten/go-windows-terminal-sequences v1.0.1 h1:mweAR1A6xJ3oS2pRaGiHgQ4OO8tzTaLawm8vnODuwDk= github.com/konsorten/go-windows-terminal-sequences v1.0.1/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= -github.com/konsorten/go-windows-terminal-sequences v1.0.2 h1:DB17ag19krx9CFsz4o3enTrPXyIXCl+2iCXH/aMAp9s= -github.com/konsorten/go-windows-terminal-sequences v1.0.2/go.mod h1:T0+1ngSBFLxvqU3pZ+m/2kptfBszLMUkC4ZK/EgS/cQ= github.com/kr/pretty v0.1.0 h1:L/CwN0zerZDmRFUapSPitk6f+Q3+0za1rQkzVuMiMFI= github.com/kr/pretty v0.1.0/go.mod h1:dAy3ld7l9f0ibDNOQOHHMYYIIbhfbHSm3C4ZsoJORNo= github.com/kr/pty v1.1.1/go.mod h1:pFQYn66WHrOpPYNljwOMqo10TkYh1fy3cYio2l3bCsQ= @@ -30,18 +29,14 @@ github.com/stretchr/objx v0.1.1/go.mod h1:HFkY916IF+rwdDfMAkV7OtwuqBVzrE8GR6GFx+ github.com/stretchr/testify v1.2.2/go.mod h1:a8OnRcib4nhh0OaRAV+Yts87kKdq0PP7pXfy6kDkUVs= github.com/stretchr/testify v1.3.0 h1:TivCn/peBQ7UY8ooIcPgZFpTNSz0Q2U6UrFlUfqbe0Q= github.com/stretchr/testify v1.3.0/go.mod h1:M5WIy9Dh21IEIfnGCwXGc5bZfKNJtfHm1UVUgZn+9EI= +golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2 h1:VklqNMn3ovrHsnt90PveolxSbWFaJdECFbxSq0Mqo2M= golang.org/x/crypto v0.0.0-20190308221718-c2843e01d9a2/go.mod h1:djNgcEr1/C05ACkg1iLfiJU5Ep61QUkGW8qpdssI0+w= -golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4 h1:ydJNl0ENAG67pFbB+9tfhiL2pYqLhfoaZFw/cjLhY4A= -golang.org/x/crypto v0.0.0-20190621222207-cc06ce4a13d4/go.mod h1:yigFU9vqHzYiE8UmvKecakEJjdnWj3jj499lnFckfCI= -golang.org/x/net v0.0.0-20190404232315-eb5bcb51f2a3/go.mod h1:t9HGtf8HONx5eT2rtn7q6eTqICYqUVnKs3thJo3Qplg= golang.org/x/net v0.0.0-20190620200207-3b0461eec859 h1:R/3boaszxrf1GEUWTVDzSKVwLmSJpwZ1yqXm8j0v2QI= golang.org/x/net v0.0.0-20190620200207-3b0461eec859/go.mod h1:z5CRVTTTmAJ677TzLLGU+0bjPO0LkuOLi4/5GtJWs/s= golang.org/x/sys v0.0.0-20190215142949-d0b11bdaac8a/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= golang.org/x/sys v0.0.0-20190222072716-a9d3bda3a223/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= -golang.org/x/sys v0.0.0-20190412213103-97732733099d/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= +golang.org/x/sys v0.0.0-20190422165155-953cdadca894 h1:Cz4ceDQGXuKRnVBDTS23GTn/pU5OE2C0WrNTOYK1Uuc= golang.org/x/sys v0.0.0-20190422165155-953cdadca894/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= -golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb h1:fgwFCsaw9buMuxNd6+DQfAuSFqbNiQZpcgJQAgJsK6k= -golang.org/x/sys v0.0.0-20190626221950-04f50cda93cb/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= golang.org/x/text v0.3.0/go.mod h1:NqM8EUOU14njkJ3fqMW+pc6Ldnwhi/IjpwHt7yyuwOQ= -gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127 h1:qIbj1fsPNlZgppZ+VLlY7N33q108Sa+fhmuc+sWQYwY= -gopkg.in/check.v1 v1.0.0-20180628173108-788fd7840127/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= +gopkg.in/check.v1 v1.0.0-20190902080502-41f04d3bba15 h1:YR8cESwS4TdDjEe65xsg0ogRM/Nc3DYOhEAlW+xobZo= +gopkg.in/check.v1 v1.0.0-20190902080502-41f04d3bba15/go.mod h1:Co6ibVJAznAaIkqp8huTwlJQCZ016jof/cbN4VW5Yz0= diff --git a/vendor/github.com/SkycoinProject/dmsg/listener.go b/vendor/github.com/SkycoinProject/dmsg/listener.go new file mode 100644 index 000000000..942893570 --- /dev/null +++ b/vendor/github.com/SkycoinProject/dmsg/listener.go @@ -0,0 +1,123 @@ +package dmsg + +import ( + "net" + "sync" + + "github.com/SkycoinProject/dmsg/cipher" +) + +// Listener listens for remote-initiated transports. +type Listener struct { + pk cipher.PubKey + port uint16 + mx sync.Mutex // protects 'accept' + accept chan *Transport + done chan struct{} + once sync.Once +} + +func newListener(pk cipher.PubKey, port uint16) *Listener { + return &Listener{ + pk: pk, + port: port, + accept: make(chan *Transport, AcceptBufferSize), + done: make(chan struct{}), + } +} + +// Accept accepts a connection. +func (l *Listener) Accept() (net.Conn, error) { + return l.AcceptTransport() +} + +// Close closes the listener. +func (l *Listener) Close() error { + if l.close() { + return nil + } + return ErrClientClosed +} + +func (l *Listener) close() (closed bool) { + l.once.Do(func() { + closed = true + + l.mx.Lock() + defer l.mx.Unlock() + + close(l.done) + for { + select { + case <-l.accept: + default: + close(l.accept) + return + } + } + }) + return closed +} + +func (l *Listener) isClosed() bool { + select { + case <-l.done: + return true + default: + return false + } +} + +// Addr returns the listener's address. +func (l *Listener) Addr() net.Addr { + return Addr{ + PK: l.pk, + Port: l.port, + } +} + +// AcceptTransport accepts a transport connection. +func (l *Listener) AcceptTransport() (*Transport, error) { + select { + case <-l.done: + return nil, ErrClientClosed + case tp, ok := <-l.accept: + if !ok { + return nil, ErrClientClosed + } + return tp, nil + } +} + +// Type returns the transport type. +func (l *Listener) Type() string { + return Type +} + +// IntroduceTransport handles a transport after receiving a REQUEST frame. +func (l *Listener) IntroduceTransport(tp *Transport) error { + l.mx.Lock() + defer l.mx.Unlock() + + if l.isClosed() { + return ErrClientClosed + } + + select { + case <-l.done: + return ErrClientClosed + + case l.accept <- tp: + if err := tp.WriteAccept(); err != nil { + return err + } + go tp.Serve() + return nil + + default: + if err := tp.Close(); err != nil { + log.WithError(err).Warn("Failed to close transport") + } + return ErrClientAcceptMaxed + } +} diff --git a/vendor/github.com/SkycoinProject/dmsg/port_manager.go b/vendor/github.com/SkycoinProject/dmsg/port_manager.go new file mode 100644 index 000000000..eb7445752 --- /dev/null +++ b/vendor/github.com/SkycoinProject/dmsg/port_manager.go @@ -0,0 +1,72 @@ +package dmsg + +import ( + "math/rand" + "sync" + "time" + + "github.com/SkycoinProject/dmsg/cipher" +) + +const ( + firstEphemeralPort = 49152 + lastEphemeralPort = 65535 +) + +// PortManager manages ports of nodes. +type PortManager struct { + mu sync.RWMutex + rand *rand.Rand + listeners map[uint16]*Listener +} + +func newPortManager() *PortManager { + return &PortManager{ + rand: rand.New(rand.NewSource(time.Now().UnixNano())), + listeners: make(map[uint16]*Listener), + } +} + +// Listener returns a listener assigned to a given port. +func (pm *PortManager) Listener(port uint16) (*Listener, bool) { + pm.mu.RLock() + defer pm.mu.RUnlock() + + l, ok := pm.listeners[port] + return l, ok +} + +// NewListener assigns listener to port if port is available. +func (pm *PortManager) NewListener(pk cipher.PubKey, port uint16) (*Listener, bool) { + pm.mu.Lock() + defer pm.mu.Unlock() + if _, ok := pm.listeners[port]; ok { + return nil, false + } + l := newListener(pk, port) + pm.listeners[port] = l + return l, true +} + +// RemoveListener removes listener assigned to port. +func (pm *PortManager) RemoveListener(port uint16) { + pm.mu.Lock() + defer pm.mu.Unlock() + + delete(pm.listeners, port) +} + +// NextEmptyEphemeralPort returns next random ephemeral port. +// It has a value between firstEphemeralPort and lastEphemeralPort. +func (pm *PortManager) NextEmptyEphemeralPort() uint16 { + for { + port := pm.randomEphemeralPort() + if _, ok := pm.Listener(port); !ok { + return port + } + } +} + +func (pm *PortManager) randomEphemeralPort() uint16 { + return uint16(firstEphemeralPort + pm.rand.Intn(lastEphemeralPort-firstEphemeralPort)) +} diff --git a/vendor/github.com/SkycoinProject/dmsg/server.go b/vendor/github.com/SkycoinProject/dmsg/server.go index 0cf4cad1f..0d01a1c10 100644 --- a/vendor/github.com/SkycoinProject/dmsg/server.go +++ b/vendor/github.com/SkycoinProject/dmsg/server.go @@ -143,6 +143,7 @@ func (c *ServerConn) Serve(ctx context.Context, getConn getConnFunc) (err error) log.WithError(err).Warn("Failed to close connection") } }() + log.WithField("connCount", incrementServeCount()).Infoln("ServingConn") err = c.writeOK() @@ -155,7 +156,7 @@ func (c *ServerConn) Serve(ctx context.Context, getConn getConnFunc) (err error) if err != nil { return fmt.Errorf("read failed: %s", err) } - log = log.WithField("received", f) + log := log.WithField("received", f) ft, id, p := f.Disassemble() @@ -200,7 +201,7 @@ func (c *ServerConn) Serve(ctx context.Context, getConn getConnFunc) (err error) func (c *ServerConn) delChan(id uint16, why byte) error { c.delNext(id) - if err := writeFrame(c.Conn, MakeFrame(CloseType, id, []byte{why})); err != nil { + if err := writeCloseFrame(c.Conn, id, why); err != nil { return fmt.Errorf("failed to write frame: %s", err) } return nil @@ -227,11 +228,11 @@ func (c *ServerConn) forwardFrame(ft FrameType, id uint16, p []byte) (*NextConn, // nolint:unparam func (c *ServerConn) handleRequest(ctx context.Context, getLink getConnFunc, id uint16, p []byte) (*NextConn, byte, bool) { - initPK, respPK, ok := splitPKs(p) - if !ok || initPK != c.PK() { + payload, err := unmarshalHandshakePayload(p) + if err != nil || payload.InitPK != c.PK() { return nil, 0, false } - respL, ok := getLink(respPK) + respL, ok := getLink(payload.RespPK) if !ok { return nil, 0, false } diff --git a/vendor/github.com/SkycoinProject/dmsg/testing.go b/vendor/github.com/SkycoinProject/dmsg/testing.go index ef9095b9f..49a181b75 100644 --- a/vendor/github.com/SkycoinProject/dmsg/testing.go +++ b/vendor/github.com/SkycoinProject/dmsg/testing.go @@ -4,6 +4,7 @@ import ( "errors" "fmt" "io" + "net" "testing" "time" @@ -42,10 +43,12 @@ func checkConnCount(t *testing.T, delay time.Duration, count int, ccs ...connCou })) } -func checkTransportsClosed(t *testing.T, transports ...*Transport) { - for _, transport := range transports { - assert.False(t, isDoneChanOpen(transport.done)) - assert.False(t, isReadChanOpen(transport.inCh)) +func checkTransportsClosed(t *testing.T, transports ...net.Conn) { + for _, tr := range transports { + if tr, ok := tr.(*Transport); ok && tr != nil { + assert.False(t, isDoneChanOpen(tr.done)) + assert.False(t, isReadChanOpen(tr.inCh)) + } } } diff --git a/vendor/github.com/SkycoinProject/dmsg/transport.go b/vendor/github.com/SkycoinProject/dmsg/transport.go index 613aa7cb9..023699fe0 100644 --- a/vendor/github.com/SkycoinProject/dmsg/transport.go +++ b/vendor/github.com/SkycoinProject/dmsg/transport.go @@ -19,16 +19,18 @@ var ( ErrRequestRejected = errors.New("failed to create transport: request rejected") ErrRequestCheckFailed = errors.New("failed to create transport: request check failed") ErrAcceptCheckFailed = errors.New("failed to create transport: accept check failed") + ErrPortNotListening = errors.New("failed to create transport: port not listening") ) -// Transport represents a connection from dmsg.Client to remote dmsg.Client (via dmsg.Server intermediary). +// Transport represents communication between two nodes via a single hop: +// a connection from dmsg.Client to remote dmsg.Client (via dmsg.Server intermediary). type Transport struct { net.Conn // underlying connection to dmsg.Server log *logging.Logger - id uint16 // tp ID that identifies this dmsg.Transport - local cipher.PubKey // local PK - remote cipher.PubKey // remote PK + id uint16 // tp ID that identifies this dmsg.transport + local Addr // local PK + remote Addr // remote PK inCh chan Frame // handles incoming frames (from dmsg.Client) inMx sync.Mutex // protects 'inCh' @@ -49,7 +51,7 @@ type Transport struct { } // NewTransport creates a new dms_tp. -func NewTransport(conn net.Conn, log *logging.Logger, local, remote cipher.PubKey, id uint16, doneFunc func(id uint16)) *Transport { +func NewTransport(conn net.Conn, log *logging.Logger, local, remote Addr, id uint16, doneFunc func(id uint16)) *Transport { tp := &Transport{ Conn: conn, log: log, @@ -113,7 +115,7 @@ func (tp *Transport) close() (closed bool) { // Close closes the dmsg_tp. func (tp *Transport) Close() error { if tp.close() { - if err := writeFrame(tp.Conn, MakeFrame(CloseType, tp.id, []byte{0})); err != nil { + if err := writeCloseFrame(tp.Conn, tp.id, PlaceholderReason); err != nil { log.WithError(err).Warn("Failed to write frame") } } @@ -132,14 +134,20 @@ func (tp *Transport) IsClosed() bool { // LocalPK returns the local public key of the transport. func (tp *Transport) LocalPK() cipher.PubKey { - return tp.local + return tp.local.PK } // RemotePK returns the remote public key of the transport. func (tp *Transport) RemotePK() cipher.PubKey { - return tp.remote + return tp.remote.PK } +// LocalAddr returns local address in from : +func (tp *Transport) LocalAddr() net.Addr { return tp.local } + +// RemoteAddr returns remote address in form : +func (tp *Transport) RemoteAddr() net.Addr { return tp.remote } + // Type returns the transport type. func (tp *Transport) Type() string { return Type @@ -162,8 +170,18 @@ func (tp *Transport) HandleFrame(f Frame) error { } // WriteRequest writes a REQUEST frame to dmsg_server to be forwarded to associated client. -func (tp *Transport) WriteRequest() error { - f := MakeFrame(RequestType, tp.id, combinePKs(tp.local, tp.remote)) +func (tp *Transport) WriteRequest(port uint16) error { + payload := HandshakePayload{ + Version: HandshakePayloadVersion, + InitPK: tp.local.PK, + RespPK: tp.remote.PK, + Port: port, + } + payloadBytes, err := marshalHandshakePayload(payload) + if err != nil { + return err + } + f := MakeFrame(RequestType, tp.id, payloadBytes) if err := writeFrame(tp.Conn, f); err != nil { tp.log.WithError(err).Error("HandshakeFailed") tp.close() @@ -182,7 +200,7 @@ func (tp *Transport) WriteAccept() (err error) { } }() - f := MakeFrame(AcceptType, tp.id, combinePKs(tp.remote, tp.local)) + f := MakeFrame(AcceptType, tp.id, combinePKs(tp.remote.PK, tp.local.PK)) if err = writeFrame(tp.Conn, f); err != nil { tp.close() return err @@ -225,7 +243,7 @@ func (tp *Transport) ReadAccept(ctx context.Context) (err error) { // - resp_pk should be of remote client. // - use an even number with the intermediary dmsg_server. initPK, respPK, ok := splitPKs(p) - if !ok || initPK != tp.local || respPK != tp.remote || !isInitiatorID(id) { + if !ok || initPK != tp.local.PK || respPK != tp.remote.PK || !isInitiatorID(id) { if err := tp.Close(); err != nil { log.WithError(err).Warn("Failed to close transport") } @@ -257,7 +275,7 @@ func (tp *Transport) Serve() { // also write CLOSE frame if this is the first time 'close' is triggered defer func() { if tp.close() { - if err := writeCloseFrame(tp.Conn, tp.id, 0); err != nil { + if err := writeCloseFrame(tp.Conn, tp.id, PlaceholderReason); err != nil { log.WithError(err).Warn("Failed to write close frame") } } diff --git a/vendor/github.com/mattn/go-isatty/go.mod b/vendor/github.com/mattn/go-isatty/go.mod index f310320c3..3b9b9abfb 100644 --- a/vendor/github.com/mattn/go-isatty/go.mod +++ b/vendor/github.com/mattn/go-isatty/go.mod @@ -1,3 +1,3 @@ module github.com/mattn/go-isatty -require golang.org/x/sys v0.0.0-20190222072716-a9d3bda3a223 +require golang.org/x/sys v0.0.0-20190813064441-fde4db37ae7a diff --git a/vendor/github.com/mattn/go-isatty/go.sum b/vendor/github.com/mattn/go-isatty/go.sum index 426c8973c..b1bd14d21 100644 --- a/vendor/github.com/mattn/go-isatty/go.sum +++ b/vendor/github.com/mattn/go-isatty/go.sum @@ -1,2 +1,2 @@ -golang.org/x/sys v0.0.0-20190222072716-a9d3bda3a223 h1:DH4skfRX4EBpamg7iV4ZlCpblAHI6s6TDM39bFZumv8= -golang.org/x/sys v0.0.0-20190222072716-a9d3bda3a223/go.mod h1:STP8DvDyc/dI5b8T5hshtkjS+E42TnysNCUPdjciGhY= +golang.org/x/sys v0.0.0-20190813064441-fde4db37ae7a h1:aYOabOQFp6Vj6W1F80affTUvO9UxmJRx8K0gsfABByQ= +golang.org/x/sys v0.0.0-20190813064441-fde4db37ae7a/go.mod h1:h1NjWce9XRLGQEsW7wpKNCjG9DtNlClVuFLEZdDNbEs= diff --git a/vendor/golang.org/x/net/internal/socks/socks.go b/vendor/golang.org/x/net/internal/socks/socks.go index 6929a9fd5..97db2340e 100644 --- a/vendor/golang.org/x/net/internal/socks/socks.go +++ b/vendor/golang.org/x/net/internal/socks/socks.go @@ -127,7 +127,7 @@ type Dialer struct { // establishing the transport connection. ProxyDial func(context.Context, string, string) (net.Conn, error) - // AuthMethods specifies the list of request authention + // AuthMethods specifies the list of request authentication // methods. // If empty, SOCKS client requests only AuthMethodNotRequired. AuthMethods []AuthMethod diff --git a/vendor/golang.org/x/sys/cpu/byteorder.go b/vendor/golang.org/x/sys/cpu/byteorder.go index da6b9e436..ed8da8dea 100644 --- a/vendor/golang.org/x/sys/cpu/byteorder.go +++ b/vendor/golang.org/x/sys/cpu/byteorder.go @@ -5,26 +5,56 @@ package cpu import ( - "encoding/binary" "runtime" ) +// byteOrder is a subset of encoding/binary.ByteOrder. +type byteOrder interface { + Uint32([]byte) uint32 + Uint64([]byte) uint64 +} + +type littleEndian struct{} +type bigEndian struct{} + +func (littleEndian) Uint32(b []byte) uint32 { + _ = b[3] // bounds check hint to compiler; see golang.org/issue/14808 + return uint32(b[0]) | uint32(b[1])<<8 | uint32(b[2])<<16 | uint32(b[3])<<24 +} + +func (littleEndian) Uint64(b []byte) uint64 { + _ = b[7] // bounds check hint to compiler; see golang.org/issue/14808 + return uint64(b[0]) | uint64(b[1])<<8 | uint64(b[2])<<16 | uint64(b[3])<<24 | + uint64(b[4])<<32 | uint64(b[5])<<40 | uint64(b[6])<<48 | uint64(b[7])<<56 +} + +func (bigEndian) Uint32(b []byte) uint32 { + _ = b[3] // bounds check hint to compiler; see golang.org/issue/14808 + return uint32(b[3]) | uint32(b[2])<<8 | uint32(b[1])<<16 | uint32(b[0])<<24 +} + +func (bigEndian) Uint64(b []byte) uint64 { + _ = b[7] // bounds check hint to compiler; see golang.org/issue/14808 + return uint64(b[7]) | uint64(b[6])<<8 | uint64(b[5])<<16 | uint64(b[4])<<24 | + uint64(b[3])<<32 | uint64(b[2])<<40 | uint64(b[1])<<48 | uint64(b[0])<<56 +} + // hostByteOrder returns binary.LittleEndian on little-endian machines and // binary.BigEndian on big-endian machines. -func hostByteOrder() binary.ByteOrder { +func hostByteOrder() byteOrder { switch runtime.GOARCH { case "386", "amd64", "amd64p32", "arm", "arm64", "mipsle", "mips64le", "mips64p32le", "ppc64le", "riscv", "riscv64": - return binary.LittleEndian + return littleEndian{} case "armbe", "arm64be", "mips", "mips64", "mips64p32", "ppc", "ppc64", "s390", "s390x", "sparc", "sparc64": - return binary.BigEndian + return bigEndian{} } panic("unknown architecture") } diff --git a/vendor/golang.org/x/sys/cpu/cpu_linux.go b/vendor/golang.org/x/sys/cpu/cpu_linux.go index 76b5f507f..10e712dc5 100644 --- a/vendor/golang.org/x/sys/cpu/cpu_linux.go +++ b/vendor/golang.org/x/sys/cpu/cpu_linux.go @@ -2,7 +2,7 @@ // Use of this source code is governed by a BSD-style // license that can be found in the LICENSE file. -//+build !amd64,!amd64p32,!386 +// +build !amd64,!amd64p32,!386 package cpu diff --git a/vendor/golang.org/x/sys/unix/affinity_linux.go b/vendor/golang.org/x/sys/unix/affinity_linux.go index 14e4d5caa..6e5c81acd 100644 --- a/vendor/golang.org/x/sys/unix/affinity_linux.go +++ b/vendor/golang.org/x/sys/unix/affinity_linux.go @@ -7,6 +7,7 @@ package unix import ( + "math/bits" "unsafe" ) @@ -79,50 +80,7 @@ func (s *CPUSet) IsSet(cpu int) bool { func (s *CPUSet) Count() int { c := 0 for _, b := range s { - c += onesCount64(uint64(b)) + c += bits.OnesCount64(uint64(b)) } return c } - -// onesCount64 is a copy of Go 1.9's math/bits.OnesCount64. -// Once this package can require Go 1.9, we can delete this -// and update the caller to use bits.OnesCount64. -func onesCount64(x uint64) int { - const m0 = 0x5555555555555555 // 01010101 ... - const m1 = 0x3333333333333333 // 00110011 ... - const m2 = 0x0f0f0f0f0f0f0f0f // 00001111 ... - - // Unused in this function, but definitions preserved for - // documentation purposes: - // - // const m3 = 0x00ff00ff00ff00ff // etc. - // const m4 = 0x0000ffff0000ffff - // - // Implementation: Parallel summing of adjacent bits. - // See "Hacker's Delight", Chap. 5: Counting Bits. - // The following pattern shows the general approach: - // - // x = x>>1&(m0&m) + x&(m0&m) - // x = x>>2&(m1&m) + x&(m1&m) - // x = x>>4&(m2&m) + x&(m2&m) - // x = x>>8&(m3&m) + x&(m3&m) - // x = x>>16&(m4&m) + x&(m4&m) - // x = x>>32&(m5&m) + x&(m5&m) - // return int(x) - // - // Masking (& operations) can be left away when there's no - // danger that a field's sum will carry over into the next - // field: Since the result cannot be > 64, 8 bits is enough - // and we can ignore the masks for the shifts by 8 and up. - // Per "Hacker's Delight", the first line can be simplified - // more, but it saves at best one instruction, so we leave - // it alone for clarity. - const m = 1<<64 - 1 - x = x>>1&(m0&m) + x&(m0&m) - x = x>>2&(m1&m) + x&(m1&m) - x = (x>>4 + x) & (m2 & m) - x += x >> 8 - x += x >> 16 - x += x >> 32 - return int(x) & (1<<7 - 1) -} diff --git a/vendor/golang.org/x/sys/unix/ioctl.go b/vendor/golang.org/x/sys/unix/ioctl.go index f121a8d64..3559e5dcb 100644 --- a/vendor/golang.org/x/sys/unix/ioctl.go +++ b/vendor/golang.org/x/sys/unix/ioctl.go @@ -6,7 +6,19 @@ package unix -import "runtime" +import ( + "runtime" + "unsafe" +) + +// ioctl itself should not be exposed directly, but additional get/set +// functions for specific types are permissible. + +// IoctlSetInt performs an ioctl operation which sets an integer value +// on fd, using the specified request number. +func IoctlSetInt(fd int, req uint, value int) error { + return ioctl(fd, req, uintptr(value)) +} // IoctlSetWinsize performs an ioctl on fd with a *Winsize argument. // @@ -14,7 +26,7 @@ import "runtime" func IoctlSetWinsize(fd int, req uint, value *Winsize) error { // TODO: if we get the chance, remove the req parameter and // hardcode TIOCSWINSZ. - err := ioctlSetWinsize(fd, req, value) + err := ioctl(fd, req, uintptr(unsafe.Pointer(value))) runtime.KeepAlive(value) return err } @@ -24,7 +36,30 @@ func IoctlSetWinsize(fd int, req uint, value *Winsize) error { // The req value will usually be TCSETA or TIOCSETA. func IoctlSetTermios(fd int, req uint, value *Termios) error { // TODO: if we get the chance, remove the req parameter. - err := ioctlSetTermios(fd, req, value) + err := ioctl(fd, req, uintptr(unsafe.Pointer(value))) runtime.KeepAlive(value) return err } + +// IoctlGetInt performs an ioctl operation which gets an integer value +// from fd, using the specified request number. +// +// A few ioctl requests use the return value as an output parameter; +// for those, IoctlRetInt should be used instead of this function. +func IoctlGetInt(fd int, req uint) (int, error) { + var value int + err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) + return value, err +} + +func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { + var value Winsize + err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) + return &value, err +} + +func IoctlGetTermios(fd int, req uint) (*Termios, error) { + var value Termios + err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) + return &value, err +} diff --git a/vendor/golang.org/x/sys/unix/mkerrors.sh b/vendor/golang.org/x/sys/unix/mkerrors.sh index 14624b953..8a2dcfa51 100644 --- a/vendor/golang.org/x/sys/unix/mkerrors.sh +++ b/vendor/golang.org/x/sys/unix/mkerrors.sh @@ -183,20 +183,26 @@ struct ltchars { #include #include #include +#include #include +#include #include +#include +#include +#include +#include +#include +#include +#include #include +#include #include #include #include #include #include #include -#include -#include -#include -#include -#include +#include #include #include #include @@ -206,26 +212,23 @@ struct ltchars { #include #include #include +#include #include +#include #include #include +#include #include -#include #include #include -#include -#include -#include #include -#include -#include +#include #include -#include +#include +#include +#include #include -#include -#include -#include -#include + #include #include @@ -264,6 +267,11 @@ struct ltchars { #define FS_KEY_DESC_PREFIX "fscrypt:" #define FS_KEY_DESC_PREFIX_SIZE 8 #define FS_MAX_KEY_SIZE 64 + +// The code generator produces -0x1 for (~0), but an unsigned value is necessary +// for the tipc_subscr timeout __u32 field. +#undef TIPC_WAIT_FOREVER +#define TIPC_WAIT_FOREVER 0xffffffff ' includes_NetBSD=' @@ -451,6 +459,7 @@ ccflags="$@" $2 ~ /^SYSCTL_VERS/ || $2 !~ "MNT_BITS" && $2 ~ /^(MS|MNT|UMOUNT)_/ || + $2 ~ /^NS_GET_/ || $2 ~ /^TUN(SET|GET|ATTACH|DETACH)/ || $2 ~ /^(O|F|[ES]?FD|NAME|S|PTRACE|PT)_/ || $2 ~ /^KEXEC_/ || @@ -506,6 +515,7 @@ ccflags="$@" $2 ~ /^XDP_/ || $2 ~ /^(HDIO|WIN|SMART)_/ || $2 ~ /^CRYPTO_/ || + $2 ~ /^TIPC_/ || $2 !~ "WMESGLEN" && $2 ~ /^W[A-Z0-9]+$/ || $2 ~/^PPPIOC/ || diff --git a/vendor/golang.org/x/sys/unix/syscall_aix.go b/vendor/golang.org/x/sys/unix/syscall_aix.go index 1aa065f9c..9ad8a0d4a 100644 --- a/vendor/golang.org/x/sys/unix/syscall_aix.go +++ b/vendor/golang.org/x/sys/unix/syscall_aix.go @@ -350,49 +350,12 @@ func (w WaitStatus) Signal() Signal { func (w WaitStatus) Continued() bool { return w&0x01000000 != 0 } -func (w WaitStatus) CoreDump() bool { return w&0x200 != 0 } +func (w WaitStatus) CoreDump() bool { return w&0x80 == 0x80 } func (w WaitStatus) TrapCause() int { return -1 } //sys ioctl(fd int, req uint, arg uintptr) (err error) -// ioctl itself should not be exposed directly, but additional get/set -// functions for specific types are permissible. - -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - // fcntl must never be called with cmd=F_DUP2FD because it doesn't work on AIX // There is no way to create a custom fcntl and to keep //sys fcntl easily, // Therefore, the programmer must call dup2 instead of fcntl in this case. diff --git a/vendor/golang.org/x/sys/unix/syscall_aix_ppc.go b/vendor/golang.org/x/sys/unix/syscall_aix_ppc.go index bf05603f1..b3c8e3301 100644 --- a/vendor/golang.org/x/sys/unix/syscall_aix_ppc.go +++ b/vendor/golang.org/x/sys/unix/syscall_aix_ppc.go @@ -29,6 +29,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_aix_ppc64.go b/vendor/golang.org/x/sys/unix/syscall_aix_ppc64.go index 13d4321f4..9a6e02417 100644 --- a/vendor/golang.org/x/sys/unix/syscall_aix_ppc64.go +++ b/vendor/golang.org/x/sys/unix/syscall_aix_ppc64.go @@ -29,6 +29,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_bsd.go b/vendor/golang.org/x/sys/unix/syscall_bsd.go index 97a8eef6f..3e6671426 100644 --- a/vendor/golang.org/x/sys/unix/syscall_bsd.go +++ b/vendor/golang.org/x/sys/unix/syscall_bsd.go @@ -413,8 +413,6 @@ func Kevent(kq int, changes, events []Kevent_t, timeout *Timespec) (n int, err e return kevent(kq, change, len(changes), event, len(events), timeout) } -//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL - // sysctlmib translates name to mib number and appends any additional args. func sysctlmib(name string, args ...int) ([]_C_int, error) { // Translate name to mib number. diff --git a/vendor/golang.org/x/sys/unix/syscall_darwin.go b/vendor/golang.org/x/sys/unix/syscall_darwin.go index 216b4ac9e..f26a19ebd 100644 --- a/vendor/golang.org/x/sys/unix/syscall_darwin.go +++ b/vendor/golang.org/x/sys/unix/syscall_darwin.go @@ -89,7 +89,6 @@ func direntNamlen(buf []byte) (uint64, bool) { return readInt(buf, unsafe.Offsetof(Dirent{}.Namlen), unsafe.Sizeof(Dirent{}.Namlen)) } -//sys ptrace(request int, pid int, addr uintptr, data uintptr) (err error) func PtraceAttach(pid int) (err error) { return ptrace(PT_ATTACH, pid, 0, 0) } func PtraceDetach(pid int) (err error) { return ptrace(PT_DETACH, pid, 0, 0) } @@ -340,43 +339,6 @@ func Kill(pid int, signum syscall.Signal) (err error) { return kill(pid, int(sig //sys ioctl(fd int, req uint, arg uintptr) (err error) -// ioctl itself should not be exposed directly, but additional get/set -// functions for specific types are permissible. - -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - func Uname(uname *Utsname) error { mib := []_C_int{CTL_KERN, KERN_OSTYPE} n := unsafe.Sizeof(uname.Sysname) diff --git a/vendor/golang.org/x/sys/unix/syscall_darwin_386.go b/vendor/golang.org/x/sys/unix/syscall_darwin_386.go index 489726fa9..cf1bec6a3 100644 --- a/vendor/golang.org/x/sys/unix/syscall_darwin_386.go +++ b/vendor/golang.org/x/sys/unix/syscall_darwin_386.go @@ -10,6 +10,9 @@ import ( "syscall" ) +//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL +//sys ptrace(request int, pid int, addr uintptr, data uintptr) (err error) + func setTimespec(sec, nsec int64) Timespec { return Timespec{Sec: int32(sec), Nsec: int32(nsec)} } @@ -43,6 +46,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_darwin_amd64.go b/vendor/golang.org/x/sys/unix/syscall_darwin_amd64.go index 914b89bde..5867ed00b 100644 --- a/vendor/golang.org/x/sys/unix/syscall_darwin_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_darwin_amd64.go @@ -10,6 +10,9 @@ import ( "syscall" ) +//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL +//sys ptrace(request int, pid int, addr uintptr, data uintptr) (err error) + func setTimespec(sec, nsec int64) Timespec { return Timespec{Sec: sec, Nsec: nsec} } @@ -43,6 +46,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_darwin_arm.go b/vendor/golang.org/x/sys/unix/syscall_darwin_arm.go index 4a284cf50..e199e12a5 100644 --- a/vendor/golang.org/x/sys/unix/syscall_darwin_arm.go +++ b/vendor/golang.org/x/sys/unix/syscall_darwin_arm.go @@ -8,6 +8,14 @@ import ( "syscall" ) +func ptrace(request int, pid int, addr uintptr, data uintptr) error { + return ENOTSUP +} + +func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) error { + return ENOTSUP +} + func setTimespec(sec, nsec int64) Timespec { return Timespec{Sec: int32(sec), Nsec: int32(nsec)} } @@ -41,6 +49,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_darwin_arm64.go b/vendor/golang.org/x/sys/unix/syscall_darwin_arm64.go index 52dcd88f6..2c50ca901 100644 --- a/vendor/golang.org/x/sys/unix/syscall_darwin_arm64.go +++ b/vendor/golang.org/x/sys/unix/syscall_darwin_arm64.go @@ -10,6 +10,14 @@ import ( "syscall" ) +func ptrace(request int, pid int, addr uintptr, data uintptr) error { + return ENOTSUP +} + +func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) error { + return ENOTSUP +} + func setTimespec(sec, nsec int64) Timespec { return Timespec{Sec: sec, Nsec: nsec} } @@ -43,6 +51,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_dragonfly.go b/vendor/golang.org/x/sys/unix/syscall_dragonfly.go index 260a400f9..99d875624 100644 --- a/vendor/golang.org/x/sys/unix/syscall_dragonfly.go +++ b/vendor/golang.org/x/sys/unix/syscall_dragonfly.go @@ -14,6 +14,8 @@ package unix import "unsafe" +//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL + // SockaddrDatalink implements the Sockaddr interface for AF_LINK type sockets. type SockaddrDatalink struct { Len uint8 @@ -150,43 +152,6 @@ func setattrlistTimes(path string, times []Timespec, flags int) error { //sys ioctl(fd int, req uint, arg uintptr) (err error) -// ioctl itself should not be exposed directly, but additional get/set -// functions for specific types are permissible. - -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - func sysctlUname(mib []_C_int, old *byte, oldlen *uintptr) error { err := sysctl(mib, old, oldlen, nil, 0) if err != nil { diff --git a/vendor/golang.org/x/sys/unix/syscall_dragonfly_amd64.go b/vendor/golang.org/x/sys/unix/syscall_dragonfly_amd64.go index 9babb31ea..a6b4830ac 100644 --- a/vendor/golang.org/x/sys/unix/syscall_dragonfly_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_dragonfly_amd64.go @@ -33,6 +33,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_freebsd.go b/vendor/golang.org/x/sys/unix/syscall_freebsd.go index 329d240b9..b62231bca 100644 --- a/vendor/golang.org/x/sys/unix/syscall_freebsd.go +++ b/vendor/golang.org/x/sys/unix/syscall_freebsd.go @@ -36,6 +36,8 @@ var ( // INO64_FIRST from /usr/src/lib/libc/sys/compat-ino64.h const _ino64First = 1200031 +//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL + func supportsABI(ver uint32) bool { osreldateOnce.Do(func() { osreldate, _ = SysctlUint32("kern.osreldate") }) return osreldate >= ver @@ -201,43 +203,6 @@ func setattrlistTimes(path string, times []Timespec, flags int) error { //sys ioctl(fd int, req uint, arg uintptr) (err error) -// ioctl itself should not be exposed directly, but additional get/set -// functions for specific types are permissible. - -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - func Uname(uname *Utsname) error { mib := []_C_int{CTL_KERN, KERN_OSTYPE} n := unsafe.Sizeof(uname.Sysname) diff --git a/vendor/golang.org/x/sys/unix/syscall_freebsd_386.go b/vendor/golang.org/x/sys/unix/syscall_freebsd_386.go index 21e03958c..dcc56457a 100644 --- a/vendor/golang.org/x/sys/unix/syscall_freebsd_386.go +++ b/vendor/golang.org/x/sys/unix/syscall_freebsd_386.go @@ -33,6 +33,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_freebsd_amd64.go b/vendor/golang.org/x/sys/unix/syscall_freebsd_amd64.go index 9c945a657..321c3bace 100644 --- a/vendor/golang.org/x/sys/unix/syscall_freebsd_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_freebsd_amd64.go @@ -33,6 +33,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_freebsd_arm.go b/vendor/golang.org/x/sys/unix/syscall_freebsd_arm.go index 5cd6243f2..697700831 100644 --- a/vendor/golang.org/x/sys/unix/syscall_freebsd_arm.go +++ b/vendor/golang.org/x/sys/unix/syscall_freebsd_arm.go @@ -33,6 +33,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_freebsd_arm64.go b/vendor/golang.org/x/sys/unix/syscall_freebsd_arm64.go index a31805487..dbbbfd603 100644 --- a/vendor/golang.org/x/sys/unix/syscall_freebsd_arm64.go +++ b/vendor/golang.org/x/sys/unix/syscall_freebsd_arm64.go @@ -33,6 +33,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux.go b/vendor/golang.org/x/sys/unix/syscall_linux.go index 637b5017b..e538bb567 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux.go @@ -71,6 +71,17 @@ func Fchmodat(dirfd int, path string, mode uint32, flags int) (err error) { // ioctl itself should not be exposed directly, but additional get/set // functions for specific types are permissible. +// IoctlRetInt performs an ioctl operation specified by req on a device +// associated with opened file descriptor fd, and returns a non-negative +// integer that is returned by the ioctl syscall. +func IoctlRetInt(fd int, req uint) (int, error) { + ret, _, err := Syscall(SYS_IOCTL, uintptr(fd), uintptr(req), 0) + if err != 0 { + return 0, err + } + return int(ret), nil +} + // IoctlSetPointerInt performs an ioctl operation which sets an // integer value on fd, using the specified request number. The ioctl // argument is called with a pointer to the integer value, rather than @@ -80,52 +91,18 @@ func IoctlSetPointerInt(fd int, req uint, value int) error { return ioctl(fd, req, uintptr(unsafe.Pointer(&v))) } -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - func IoctlSetRTCTime(fd int, value *RTCTime) error { err := ioctl(fd, RTC_SET_TIME, uintptr(unsafe.Pointer(value))) runtime.KeepAlive(value) return err } -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - func IoctlGetUint32(fd int, req uint) (uint32, error) { var value uint32 err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) return value, err } -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - func IoctlGetRTCTime(fd int) (*RTCTime, error) { var value RTCTime err := ioctl(fd, RTC_RD_TIME, uintptr(unsafe.Pointer(&value))) @@ -798,6 +775,70 @@ func (sa *SockaddrPPPoE) sockaddr() (unsafe.Pointer, _Socklen, error) { return unsafe.Pointer(&sa.raw), SizeofSockaddrPPPoX, nil } +// SockaddrTIPC implements the Sockaddr interface for AF_TIPC type sockets. +// For more information on TIPC, see: http://tipc.sourceforge.net/. +type SockaddrTIPC struct { + // Scope is the publication scopes when binding service/service range. + // Should be set to TIPC_CLUSTER_SCOPE or TIPC_NODE_SCOPE. + Scope int + + // Addr is the type of address used to manipulate a socket. Addr must be + // one of: + // - *TIPCSocketAddr: "id" variant in the C addr union + // - *TIPCServiceRange: "nameseq" variant in the C addr union + // - *TIPCServiceName: "name" variant in the C addr union + // + // If nil, EINVAL will be returned when the structure is used. + Addr TIPCAddr + + raw RawSockaddrTIPC +} + +// TIPCAddr is implemented by types that can be used as an address for +// SockaddrTIPC. It is only implemented by *TIPCSocketAddr, *TIPCServiceRange, +// and *TIPCServiceName. +type TIPCAddr interface { + tipcAddrtype() uint8 + tipcAddr() [12]byte +} + +func (sa *TIPCSocketAddr) tipcAddr() [12]byte { + var out [12]byte + copy(out[:], (*(*[unsafe.Sizeof(TIPCSocketAddr{})]byte)(unsafe.Pointer(sa)))[:]) + return out +} + +func (sa *TIPCSocketAddr) tipcAddrtype() uint8 { return TIPC_SOCKET_ADDR } + +func (sa *TIPCServiceRange) tipcAddr() [12]byte { + var out [12]byte + copy(out[:], (*(*[unsafe.Sizeof(TIPCServiceRange{})]byte)(unsafe.Pointer(sa)))[:]) + return out +} + +func (sa *TIPCServiceRange) tipcAddrtype() uint8 { return TIPC_SERVICE_RANGE } + +func (sa *TIPCServiceName) tipcAddr() [12]byte { + var out [12]byte + copy(out[:], (*(*[unsafe.Sizeof(TIPCServiceName{})]byte)(unsafe.Pointer(sa)))[:]) + return out +} + +func (sa *TIPCServiceName) tipcAddrtype() uint8 { return TIPC_SERVICE_ADDR } + +func (sa *SockaddrTIPC) sockaddr() (unsafe.Pointer, _Socklen, error) { + if sa.Addr == nil { + return nil, 0, EINVAL + } + + sa.raw.Family = AF_TIPC + sa.raw.Scope = int8(sa.Scope) + sa.raw.Addrtype = sa.Addr.tipcAddrtype() + sa.raw.Addr = sa.Addr.tipcAddr() + + return unsafe.Pointer(&sa.raw), SizeofSockaddrTIPC, nil +} + func anyToSockaddr(fd int, rsa *RawSockaddrAny) (Sockaddr, error) { switch rsa.Addr.Family { case AF_NETLINK: @@ -923,6 +964,27 @@ func anyToSockaddr(fd int, rsa *RawSockaddrAny) (Sockaddr, error) { break } } + return sa, nil + case AF_TIPC: + pp := (*RawSockaddrTIPC)(unsafe.Pointer(rsa)) + + sa := &SockaddrTIPC{ + Scope: int(pp.Scope), + } + + // Determine which union variant is present in pp.Addr by checking + // pp.Addrtype. + switch pp.Addrtype { + case TIPC_SERVICE_RANGE: + sa.Addr = (*TIPCServiceRange)(unsafe.Pointer(&pp.Addr)) + case TIPC_SERVICE_ADDR: + sa.Addr = (*TIPCServiceName)(unsafe.Pointer(&pp.Addr)) + case TIPC_SOCKET_ADDR: + sa.Addr = (*TIPCSocketAddr)(unsafe.Pointer(&pp.Addr)) + default: + return nil, EINVAL + } + return sa, nil } return nil, EAFNOSUPPORT diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_386.go b/vendor/golang.org/x/sys/unix/syscall_linux_386.go index e2f8cf6e5..e7fa665e6 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_386.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_386.go @@ -372,6 +372,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_amd64.go b/vendor/golang.org/x/sys/unix/syscall_linux_amd64.go index 87a30744d..088ce0f93 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_amd64.go @@ -163,6 +163,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_arm.go b/vendor/golang.org/x/sys/unix/syscall_linux_arm.go index f62679443..11930fc8f 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_arm.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_arm.go @@ -252,6 +252,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_arm64.go b/vendor/golang.org/x/sys/unix/syscall_linux_arm64.go index cb20b15d5..251e2d971 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_arm64.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_arm64.go @@ -180,6 +180,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_mips64x.go b/vendor/golang.org/x/sys/unix/syscall_linux_mips64x.go index b3b21ec1e..7562fe97b 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_mips64x.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_mips64x.go @@ -208,6 +208,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_mipsx.go b/vendor/golang.org/x/sys/unix/syscall_linux_mipsx.go index 5144d4e13..a939ff8f2 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_mipsx.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_mipsx.go @@ -220,6 +220,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_ppc64x.go b/vendor/golang.org/x/sys/unix/syscall_linux_ppc64x.go index 0a100b66a..28d6d0f22 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_ppc64x.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_ppc64x.go @@ -91,6 +91,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_riscv64.go b/vendor/golang.org/x/sys/unix/syscall_linux_riscv64.go index 6230f6405..6798c2625 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_riscv64.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_riscv64.go @@ -179,6 +179,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_s390x.go b/vendor/golang.org/x/sys/unix/syscall_linux_s390x.go index f81dbdc9c..eb5cb1a71 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_s390x.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_s390x.go @@ -120,6 +120,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_linux_sparc64.go b/vendor/golang.org/x/sys/unix/syscall_linux_sparc64.go index b69565616..37321c12e 100644 --- a/vendor/golang.org/x/sys/unix/syscall_linux_sparc64.go +++ b/vendor/golang.org/x/sys/unix/syscall_linux_sparc64.go @@ -107,6 +107,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint64(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint64(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_netbsd.go b/vendor/golang.org/x/sys/unix/syscall_netbsd.go index 5ef309040..3e3f07507 100644 --- a/vendor/golang.org/x/sys/unix/syscall_netbsd.go +++ b/vendor/golang.org/x/sys/unix/syscall_netbsd.go @@ -18,6 +18,8 @@ import ( "unsafe" ) +//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL + // SockaddrDatalink implements the Sockaddr interface for AF_LINK type sockets. type SockaddrDatalink struct { Len uint8 @@ -187,43 +189,6 @@ func setattrlistTimes(path string, times []Timespec, flags int) error { //sys ioctl(fd int, req uint, arg uintptr) (err error) -// ioctl itself should not be exposed directly, but additional get/set -// functions for specific types are permissible. - -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - func IoctlGetPtmget(fd int, req uint) (*Ptmget, error) { var value Ptmget err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) diff --git a/vendor/golang.org/x/sys/unix/syscall_netbsd_386.go b/vendor/golang.org/x/sys/unix/syscall_netbsd_386.go index 24f74e58c..24da8b524 100644 --- a/vendor/golang.org/x/sys/unix/syscall_netbsd_386.go +++ b/vendor/golang.org/x/sys/unix/syscall_netbsd_386.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_netbsd_amd64.go b/vendor/golang.org/x/sys/unix/syscall_netbsd_amd64.go index 6878bf7ff..25a0ac825 100644 --- a/vendor/golang.org/x/sys/unix/syscall_netbsd_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_netbsd_amd64.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_netbsd_arm.go b/vendor/golang.org/x/sys/unix/syscall_netbsd_arm.go index dbbfcf71d..21591ecd4 100644 --- a/vendor/golang.org/x/sys/unix/syscall_netbsd_arm.go +++ b/vendor/golang.org/x/sys/unix/syscall_netbsd_arm.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_netbsd_arm64.go b/vendor/golang.org/x/sys/unix/syscall_netbsd_arm64.go index f3434465a..804749635 100644 --- a/vendor/golang.org/x/sys/unix/syscall_netbsd_arm64.go +++ b/vendor/golang.org/x/sys/unix/syscall_netbsd_arm64.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_openbsd.go b/vendor/golang.org/x/sys/unix/syscall_openbsd.go index 1a074b2fe..035c043a7 100644 --- a/vendor/golang.org/x/sys/unix/syscall_openbsd.go +++ b/vendor/golang.org/x/sys/unix/syscall_openbsd.go @@ -18,6 +18,8 @@ import ( "unsafe" ) +//sys sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) = SYS___SYSCTL + // SockaddrDatalink implements the Sockaddr interface for AF_LINK type sockets. type SockaddrDatalink struct { Len uint8 @@ -178,43 +180,6 @@ func setattrlistTimes(path string, times []Timespec, flags int) error { //sys ioctl(fd int, req uint, arg uintptr) (err error) -// ioctl itself should not be exposed directly, but additional get/set -// functions for specific types are permissible. - -// IoctlSetInt performs an ioctl operation which sets an integer value -// on fd, using the specified request number. -func IoctlSetInt(fd int, req uint, value int) error { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) error { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -// IoctlGetInt performs an ioctl operation which gets an integer value -// from fd, using the specified request number. -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - //sys ppoll(fds *PollFd, nfds int, timeout *Timespec, sigmask *Sigset_t) (n int, err error) func Ppoll(fds []PollFd, timeout *Timespec, sigmask *Sigset_t) (n int, err error) { diff --git a/vendor/golang.org/x/sys/unix/syscall_openbsd_386.go b/vendor/golang.org/x/sys/unix/syscall_openbsd_386.go index d62da60d1..42b5a0e51 100644 --- a/vendor/golang.org/x/sys/unix/syscall_openbsd_386.go +++ b/vendor/golang.org/x/sys/unix/syscall_openbsd_386.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_openbsd_amd64.go b/vendor/golang.org/x/sys/unix/syscall_openbsd_amd64.go index 9a35334cb..6ea4b4883 100644 --- a/vendor/golang.org/x/sys/unix/syscall_openbsd_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_openbsd_amd64.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_openbsd_arm.go b/vendor/golang.org/x/sys/unix/syscall_openbsd_arm.go index 5d812aaea..1c3d26fa2 100644 --- a/vendor/golang.org/x/sys/unix/syscall_openbsd_arm.go +++ b/vendor/golang.org/x/sys/unix/syscall_openbsd_arm.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_openbsd_arm64.go b/vendor/golang.org/x/sys/unix/syscall_openbsd_arm64.go index 0fb39cf5e..a8c458cb0 100644 --- a/vendor/golang.org/x/sys/unix/syscall_openbsd_arm64.go +++ b/vendor/golang.org/x/sys/unix/syscall_openbsd_arm64.go @@ -28,6 +28,10 @@ func (msghdr *Msghdr) SetControllen(length int) { msghdr.Controllen = uint32(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = uint32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/syscall_solaris.go b/vendor/golang.org/x/sys/unix/syscall_solaris.go index 0153a316d..1610f551d 100644 --- a/vendor/golang.org/x/sys/unix/syscall_solaris.go +++ b/vendor/golang.org/x/sys/unix/syscall_solaris.go @@ -553,40 +553,10 @@ func Minor(dev uint64) uint32 { //sys ioctl(fd int, req uint, arg uintptr) (err error) -func IoctlSetInt(fd int, req uint, value int) (err error) { - return ioctl(fd, req, uintptr(value)) -} - -func ioctlSetWinsize(fd int, req uint, value *Winsize) (err error) { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - -func ioctlSetTermios(fd int, req uint, value *Termios) (err error) { - return ioctl(fd, req, uintptr(unsafe.Pointer(value))) -} - func IoctlSetTermio(fd int, req uint, value *Termio) (err error) { return ioctl(fd, req, uintptr(unsafe.Pointer(value))) } -func IoctlGetInt(fd int, req uint) (int, error) { - var value int - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return value, err -} - -func IoctlGetWinsize(fd int, req uint) (*Winsize, error) { - var value Winsize - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - -func IoctlGetTermios(fd int, req uint) (*Termios, error) { - var value Termios - err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) - return &value, err -} - func IoctlGetTermio(fd int, req uint) (*Termio, error) { var value Termio err := ioctl(fd, req, uintptr(unsafe.Pointer(&value))) diff --git a/vendor/golang.org/x/sys/unix/syscall_solaris_amd64.go b/vendor/golang.org/x/sys/unix/syscall_solaris_amd64.go index 91c32ddf0..b22a34d7a 100644 --- a/vendor/golang.org/x/sys/unix/syscall_solaris_amd64.go +++ b/vendor/golang.org/x/sys/unix/syscall_solaris_amd64.go @@ -18,6 +18,10 @@ func (iov *Iovec) SetLen(length int) { iov.Len = uint64(length) } +func (msghdr *Msghdr) SetIovlen(length int) { + msghdr.Iovlen = int32(length) +} + func (cmsg *Cmsghdr) SetLen(length int) { cmsg.Len = uint32(length) } diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_386.go b/vendor/golang.org/x/sys/unix/zerrors_linux_386.go index 5213d820a..1875f4595 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_386.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_386.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -722,6 +726,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -987,6 +992,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1085,6 +1091,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1097,6 +1114,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1406,6 +1425,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0xb703 + NS_GET_OWNER_UID = 0xb704 + NS_GET_PARENT = 0xb702 + NS_GET_USERNS = 0xb701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1671,6 +1694,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1686,6 +1711,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x19 PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 @@ -1724,6 +1750,10 @@ const ( PTRACE_SINGLEBLOCK = 0x21 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_SYSEMU = 0x1f PTRACE_SYSEMU_SINGLESTEP = 0x20 PTRACE_TRACEME = 0x0 @@ -1784,7 +1814,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1857,6 +1887,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1881,6 +1912,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1888,7 +1920,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1900,6 +1932,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1908,8 +1941,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1994,6 +2027,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2132,6 +2167,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2432,6 +2468,71 @@ const ( TIOCSTI = 0x5412 TIOCSWINSZ = 0x5414 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2445,7 +2546,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2644,6 +2745,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2660,6 +2763,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_amd64.go b/vendor/golang.org/x/sys/unix/zerrors_linux_amd64.go index 39b630cc5..4af5477da 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_amd64.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_amd64.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -722,6 +726,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -987,6 +992,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1085,6 +1091,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1097,6 +1114,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1406,6 +1425,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0xb703 + NS_GET_OWNER_UID = 0xb704 + NS_GET_PARENT = 0xb702 + NS_GET_USERNS = 0xb701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1672,6 +1695,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1687,6 +1712,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x19 PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 @@ -1725,6 +1751,10 @@ const ( PTRACE_SINGLEBLOCK = 0x21 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_SYSEMU = 0x1f PTRACE_SYSEMU_SINGLESTEP = 0x20 PTRACE_TRACEME = 0x0 @@ -1785,7 +1815,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1858,6 +1888,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1882,6 +1913,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1889,7 +1921,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1901,6 +1933,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1909,8 +1942,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1995,6 +2028,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2133,6 +2168,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2433,6 +2469,71 @@ const ( TIOCSTI = 0x5412 TIOCSWINSZ = 0x5414 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2446,7 +2547,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2644,6 +2745,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2660,6 +2763,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_arm.go b/vendor/golang.org/x/sys/unix/zerrors_linux_arm.go index c59a1beb3..eb2191994 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_arm.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_arm.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0xb703 + NS_GET_OWNER_UID = 0xb704 + NS_GET_PARENT = 0xb702 + NS_GET_USERNS = 0xb701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1669,6 +1692,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1690,6 +1715,7 @@ const ( PTRACE_GETSIGMASK = 0x420a PTRACE_GETVFPREGS = 0x1b PTRACE_GETWMMXREGS = 0x12 + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x16 PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 @@ -1730,6 +1756,10 @@ const ( PTRACE_SET_SYSCALL = 0x17 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 PT_DATA_ADDR = 0x10004 PT_TEXT_ADDR = 0x10000 @@ -1791,7 +1821,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1864,6 +1894,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1888,6 +1919,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1895,7 +1927,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1907,6 +1939,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1915,8 +1948,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -2001,6 +2034,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2139,6 +2174,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2439,6 +2475,71 @@ const ( TIOCSTI = 0x5412 TIOCSWINSZ = 0x5414 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2452,7 +2553,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2650,6 +2751,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2666,6 +2769,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_arm64.go b/vendor/golang.org/x/sys/unix/zerrors_linux_arm64.go index 5f35c19d1..fba8ad48e 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_arm64.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_arm64.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -561,6 +564,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -724,6 +728,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -989,6 +994,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1087,6 +1093,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1099,6 +1116,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1407,6 +1426,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0xb703 + NS_GET_OWNER_UID = 0xb704 + NS_GET_PARENT = 0xb702 + NS_GET_USERNS = 0xb701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1672,6 +1695,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1685,6 +1710,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 PTRACE_LISTEN = 0x4208 @@ -1717,6 +1743,12 @@ const ( PTRACE_SETSIGMASK = 0x420b PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 + PTRACE_SYSEMU = 0x1f + PTRACE_SYSEMU_SINGLESTEP = 0x20 PTRACE_TRACEME = 0x0 QNX4_SUPER_MAGIC = 0x2f QNX6_SUPER_MAGIC = 0x68191122 @@ -1775,7 +1807,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1848,6 +1880,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1872,6 +1905,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1879,7 +1913,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1891,6 +1925,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1899,8 +1934,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1985,6 +2020,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2123,6 +2160,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2424,6 +2462,71 @@ const ( TIOCSTI = 0x5412 TIOCSWINSZ = 0x5414 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2437,7 +2540,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2635,6 +2738,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2651,6 +2756,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_mips.go b/vendor/golang.org/x/sys/unix/zerrors_linux_mips.go index 7f1b7bef2..995a7645a 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_mips.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_mips.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1669,6 +1692,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1683,6 +1708,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x19 PTRACE_GET_THREAD_AREA_3264 = 0xc4 PTRACE_GET_WATCH_REGS = 0xd0 @@ -1726,6 +1752,10 @@ const ( PTRACE_SET_WATCH_REGS = 0xd1 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 QNX4_SUPER_MAGIC = 0x2f QNX6_SUPER_MAGIC = 0x68191122 @@ -1784,7 +1814,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1857,6 +1887,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1881,6 +1912,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1888,7 +1920,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1900,6 +1932,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1908,8 +1941,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1994,6 +2027,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2132,6 +2167,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x1029 SO_DONTROUTE = 0x10 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2434,6 +2470,71 @@ const ( TIOCSTI = 0x5472 TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x8000 TPACKET_ALIGNMENT = 0x10 @@ -2447,7 +2548,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2646,6 +2747,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2662,6 +2765,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_mips64.go b/vendor/golang.org/x/sys/unix/zerrors_linux_mips64.go index 603d88b8b..2a38e1034 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_mips64.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_mips64.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1669,6 +1692,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1683,6 +1708,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x19 PTRACE_GET_THREAD_AREA_3264 = 0xc4 PTRACE_GET_WATCH_REGS = 0xd0 @@ -1726,6 +1752,10 @@ const ( PTRACE_SET_WATCH_REGS = 0xd1 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 QNX4_SUPER_MAGIC = 0x2f QNX6_SUPER_MAGIC = 0x68191122 @@ -1784,7 +1814,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1857,6 +1887,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1881,6 +1912,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1888,7 +1920,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1900,6 +1932,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1908,8 +1941,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1994,6 +2027,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2132,6 +2167,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x1029 SO_DONTROUTE = 0x10 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2434,6 +2470,71 @@ const ( TIOCSTI = 0x5472 TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x8000 TPACKET_ALIGNMENT = 0x10 @@ -2447,7 +2548,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2646,6 +2747,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2662,6 +2765,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_mips64le.go b/vendor/golang.org/x/sys/unix/zerrors_linux_mips64le.go index ed178f8a7..d1df93831 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_mips64le.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_mips64le.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1669,6 +1692,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1683,6 +1708,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x19 PTRACE_GET_THREAD_AREA_3264 = 0xc4 PTRACE_GET_WATCH_REGS = 0xd0 @@ -1726,6 +1752,10 @@ const ( PTRACE_SET_WATCH_REGS = 0xd1 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 QNX4_SUPER_MAGIC = 0x2f QNX6_SUPER_MAGIC = 0x68191122 @@ -1784,7 +1814,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1857,6 +1887,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1881,6 +1912,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1888,7 +1920,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1900,6 +1932,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1908,8 +1941,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1994,6 +2027,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2132,6 +2167,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x1029 SO_DONTROUTE = 0x10 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2434,6 +2470,71 @@ const ( TIOCSTI = 0x5472 TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x8000 TPACKET_ALIGNMENT = 0x10 @@ -2447,7 +2548,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2646,6 +2747,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2662,6 +2765,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_mipsle.go b/vendor/golang.org/x/sys/unix/zerrors_linux_mipsle.go index 080b78933..b92e3a589 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_mipsle.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_mipsle.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1669,6 +1692,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1683,6 +1708,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_GET_THREAD_AREA = 0x19 PTRACE_GET_THREAD_AREA_3264 = 0xc4 PTRACE_GET_WATCH_REGS = 0xd0 @@ -1726,6 +1752,10 @@ const ( PTRACE_SET_WATCH_REGS = 0xd1 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 QNX4_SUPER_MAGIC = 0x2f QNX6_SUPER_MAGIC = 0x68191122 @@ -1784,7 +1814,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1857,6 +1887,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1881,6 +1912,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1888,7 +1920,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1900,6 +1932,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1908,8 +1941,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1994,6 +2027,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2132,6 +2167,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x1029 SO_DONTROUTE = 0x10 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2434,6 +2470,71 @@ const ( TIOCSTI = 0x5472 TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x8000 TPACKET_ALIGNMENT = 0x10 @@ -2447,7 +2548,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2646,6 +2747,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2662,6 +2765,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64.go b/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64.go index 961e8eabe..72fd7995f 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1405,6 +1424,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80000000 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1671,6 +1694,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1690,6 +1715,7 @@ const ( PTRACE_GETVRREGS = 0x12 PTRACE_GETVSRREGS = 0x1b PTRACE_GET_DEBUGREG = 0x19 + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 PTRACE_LISTEN = 0x4208 @@ -1729,6 +1755,10 @@ const ( PTRACE_SINGLEBLOCK = 0x100 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_SYSEMU = 0x1d PTRACE_SYSEMU_SINGLESTEP = 0x1e PTRACE_TRACEME = 0x0 @@ -1842,7 +1872,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1915,6 +1945,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1939,6 +1970,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1946,7 +1978,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1958,6 +1990,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1966,8 +1999,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -2052,6 +2085,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2190,6 +2225,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2494,6 +2530,71 @@ const ( TIOCSTOP = 0x2000746f TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x400000 TPACKET_ALIGNMENT = 0x10 @@ -2507,7 +2608,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2705,6 +2806,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2721,6 +2824,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0xc00 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64le.go b/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64le.go index 6e0538f22..d9d5837eb 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64le.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_ppc64le.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1405,6 +1424,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80000000 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1671,6 +1694,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1690,6 +1715,7 @@ const ( PTRACE_GETVRREGS = 0x12 PTRACE_GETVSRREGS = 0x1b PTRACE_GET_DEBUGREG = 0x19 + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 PTRACE_LISTEN = 0x4208 @@ -1729,6 +1755,10 @@ const ( PTRACE_SINGLEBLOCK = 0x100 PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_SYSEMU = 0x1d PTRACE_SYSEMU_SINGLESTEP = 0x1e PTRACE_TRACEME = 0x0 @@ -1842,7 +1872,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1915,6 +1945,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1939,6 +1970,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1946,7 +1978,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1958,6 +1990,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1966,8 +1999,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -2052,6 +2085,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2190,6 +2225,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2494,6 +2530,71 @@ const ( TIOCSTOP = 0x2000746f TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x400000 TPACKET_ALIGNMENT = 0x10 @@ -2507,7 +2608,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2705,6 +2806,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2721,6 +2824,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0xc00 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_riscv64.go b/vendor/golang.org/x/sys/unix/zerrors_linux_riscv64.go index 06c0148c1..11810c85b 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_riscv64.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_riscv64.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0xb703 + NS_GET_OWNER_UID = 0xb704 + NS_GET_PARENT = 0xb702 + NS_GET_USERNS = 0xb701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1669,6 +1692,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1682,6 +1707,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 PTRACE_LISTEN = 0x4208 @@ -1714,6 +1740,10 @@ const ( PTRACE_SETSIGMASK = 0x420b PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 QNX4_SUPER_MAGIC = 0x2f QNX6_SUPER_MAGIC = 0x68191122 @@ -1772,7 +1802,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1845,6 +1875,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1869,6 +1900,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1876,7 +1908,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1888,6 +1920,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1896,8 +1929,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -1982,6 +2015,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2120,6 +2155,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2420,6 +2456,71 @@ const ( TIOCSTI = 0x5412 TIOCSWINSZ = 0x5414 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2433,7 +2534,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2631,6 +2732,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2647,6 +2750,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_s390x.go b/vendor/golang.org/x/sys/unix/zerrors_linux_s390x.go index 39875095c..70090835c 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_s390x.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_s390x.go @@ -253,6 +253,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -304,9 +305,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -460,6 +462,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -560,6 +563,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -721,6 +725,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x0 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -986,6 +991,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1084,6 +1090,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1096,6 +1113,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1404,6 +1423,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0xb703 + NS_GET_OWNER_UID = 0xb704 + NS_GET_PARENT = 0xb702 + NS_GET_USERNS = 0xb701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1671,6 +1694,8 @@ const ( PTRACE_DETACH = 0x11 PTRACE_DISABLE_TE = 0x5010 PTRACE_ENABLE_TE = 0x5009 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1685,6 +1710,7 @@ const ( PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a PTRACE_GET_LAST_BREAK = 0x5006 + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 PTRACE_LISTEN = 0x4208 @@ -1728,6 +1754,10 @@ const ( PTRACE_SINGLEBLOCK = 0xc PTRACE_SINGLESTEP = 0x9 PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TE_ABORT_RAND = 0x5011 PTRACE_TRACEME = 0x0 PT_ACR0 = 0x90 @@ -1845,7 +1875,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1918,6 +1948,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1942,6 +1973,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1949,7 +1981,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1961,6 +1993,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1969,8 +2002,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -2055,6 +2088,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2193,6 +2228,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x44 SO_DOMAIN = 0x27 SO_DONTROUTE = 0x5 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2493,6 +2529,71 @@ const ( TIOCSTI = 0x5412 TIOCSWINSZ = 0x5414 TIOCVHANGUP = 0x5437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2506,7 +2607,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2704,6 +2805,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2720,6 +2823,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 ) diff --git a/vendor/golang.org/x/sys/unix/zerrors_linux_sparc64.go b/vendor/golang.org/x/sys/unix/zerrors_linux_sparc64.go index 8d80f99bc..99b5e165b 100644 --- a/vendor/golang.org/x/sys/unix/zerrors_linux_sparc64.go +++ b/vendor/golang.org/x/sys/unix/zerrors_linux_sparc64.go @@ -256,6 +256,7 @@ const ( BPF_F_STACK_BUILD_ID = 0x20 BPF_F_STRICT_ALIGNMENT = 0x1 BPF_F_SYSCTL_BASE_NAME = 0x1 + BPF_F_TEST_RND_HI32 = 0x4 BPF_F_TUNINFO_IPV6 = 0x1 BPF_F_USER_BUILD_ID = 0x800 BPF_F_USER_STACK = 0x100 @@ -307,9 +308,10 @@ const ( BPF_RET = 0x6 BPF_RSH = 0x70 BPF_SK_STORAGE_GET_F_CREATE = 0x1 - BPF_SOCK_OPS_ALL_CB_FLAGS = 0x7 + BPF_SOCK_OPS_ALL_CB_FLAGS = 0xf BPF_SOCK_OPS_RETRANS_CB_FLAG = 0x2 BPF_SOCK_OPS_RTO_CB_FLAG = 0x1 + BPF_SOCK_OPS_RTT_CB_FLAG = 0x8 BPF_SOCK_OPS_STATE_CB_FLAG = 0x4 BPF_ST = 0x2 BPF_STX = 0x3 @@ -463,6 +465,7 @@ const ( DAXFS_MAGIC = 0x64646178 DEBUGFS_MAGIC = 0x64626720 DEVPTS_SUPER_MAGIC = 0x1cd1 + DMA_BUF_MAGIC = 0x444d4142 DT_BLK = 0x6 DT_CHR = 0x2 DT_DIR = 0x4 @@ -564,6 +567,7 @@ const ( ETH_P_IRDA = 0x17 ETH_P_LAT = 0x6004 ETH_P_LINK_CTL = 0x886c + ETH_P_LLDP = 0x88cc ETH_P_LOCALTALK = 0x9 ETH_P_LOOP = 0x60 ETH_P_LOOPBACK = 0x9000 @@ -725,6 +729,7 @@ const ( F_OFD_SETLKW = 0x26 F_OK = 0x0 F_RDLCK = 0x1 + F_SEAL_FUTURE_WRITE = 0x10 F_SEAL_GROW = 0x4 F_SEAL_SEAL = 0x1 F_SEAL_SHRINK = 0x2 @@ -990,6 +995,7 @@ const ( IPV6_RECVRTHDR = 0x38 IPV6_RECVTCLASS = 0x42 IPV6_ROUTER_ALERT = 0x16 + IPV6_ROUTER_ALERT_ISOLATE = 0x1e IPV6_RTHDR = 0x39 IPV6_RTHDRDSTOPTS = 0x37 IPV6_RTHDR_LOOSE = 0x0 @@ -1088,6 +1094,17 @@ const ( KEXEC_PRESERVE_CONTEXT = 0x2 KEXEC_SEGMENT_MAX = 0x10 KEYCTL_ASSUME_AUTHORITY = 0x10 + KEYCTL_CAPABILITIES = 0x1f + KEYCTL_CAPS0_BIG_KEY = 0x10 + KEYCTL_CAPS0_CAPABILITIES = 0x1 + KEYCTL_CAPS0_DIFFIE_HELLMAN = 0x4 + KEYCTL_CAPS0_INVALIDATE = 0x20 + KEYCTL_CAPS0_MOVE = 0x80 + KEYCTL_CAPS0_PERSISTENT_KEYRINGS = 0x2 + KEYCTL_CAPS0_PUBLIC_KEY = 0x8 + KEYCTL_CAPS0_RESTRICT_KEYRING = 0x40 + KEYCTL_CAPS1_NS_KEYRING_NAME = 0x1 + KEYCTL_CAPS1_NS_KEY_TAG = 0x2 KEYCTL_CHOWN = 0x4 KEYCTL_CLEAR = 0x7 KEYCTL_DESCRIBE = 0x6 @@ -1100,6 +1117,8 @@ const ( KEYCTL_INVALIDATE = 0x15 KEYCTL_JOIN_SESSION_KEYRING = 0x1 KEYCTL_LINK = 0x8 + KEYCTL_MOVE = 0x1e + KEYCTL_MOVE_EXCL = 0x1 KEYCTL_NEGATE = 0xd KEYCTL_PKEY_DECRYPT = 0x1a KEYCTL_PKEY_ENCRYPT = 0x19 @@ -1408,6 +1427,10 @@ const ( NLM_F_ROOT = 0x100 NOFLSH = 0x80 NSFS_MAGIC = 0x6e736673 + NS_GET_NSTYPE = 0x2000b703 + NS_GET_OWNER_UID = 0x2000b704 + NS_GET_PARENT = 0x2000b702 + NS_GET_USERNS = 0x2000b701 OCFS2_SUPER_MAGIC = 0x7461636f OCRNL = 0x8 OFDEL = 0x80 @@ -1673,6 +1696,8 @@ const ( PTRACE_ATTACH = 0x10 PTRACE_CONT = 0x7 PTRACE_DETACH = 0x11 + PTRACE_EVENTMSG_SYSCALL_ENTRY = 0x1 + PTRACE_EVENTMSG_SYSCALL_EXIT = 0x2 PTRACE_EVENT_CLONE = 0x3 PTRACE_EVENT_EXEC = 0x4 PTRACE_EVENT_EXIT = 0x6 @@ -1690,6 +1715,7 @@ const ( PTRACE_GETREGSET = 0x4204 PTRACE_GETSIGINFO = 0x4202 PTRACE_GETSIGMASK = 0x420a + PTRACE_GET_SYSCALL_INFO = 0x420e PTRACE_INTERRUPT = 0x4207 PTRACE_KILL = 0x8 PTRACE_LISTEN = 0x4208 @@ -1729,6 +1755,10 @@ const ( PTRACE_SINGLESTEP = 0x9 PTRACE_SPARC_DETACH = 0xb PTRACE_SYSCALL = 0x18 + PTRACE_SYSCALL_INFO_ENTRY = 0x1 + PTRACE_SYSCALL_INFO_EXIT = 0x2 + PTRACE_SYSCALL_INFO_NONE = 0x0 + PTRACE_SYSCALL_INFO_SECCOMP = 0x3 PTRACE_TRACEME = 0x0 PTRACE_WRITEDATA = 0x11 PTRACE_WRITETEXT = 0x13 @@ -1837,7 +1867,7 @@ const ( RTAX_UNSPEC = 0x0 RTAX_WINDOW = 0x3 RTA_ALIGNTO = 0x4 - RTA_MAX = 0x1d + RTA_MAX = 0x1e RTCF_DIRECTSRC = 0x4000000 RTCF_DOREDIRECT = 0x1000000 RTCF_LOG = 0x2000000 @@ -1910,6 +1940,7 @@ const ( RTM_DELMDB = 0x55 RTM_DELNEIGH = 0x1d RTM_DELNETCONF = 0x51 + RTM_DELNEXTHOP = 0x69 RTM_DELNSID = 0x59 RTM_DELQDISC = 0x25 RTM_DELROUTE = 0x19 @@ -1934,6 +1965,7 @@ const ( RTM_GETNEIGH = 0x1e RTM_GETNEIGHTBL = 0x42 RTM_GETNETCONF = 0x52 + RTM_GETNEXTHOP = 0x6a RTM_GETNSID = 0x5a RTM_GETQDISC = 0x26 RTM_GETROUTE = 0x1a @@ -1941,7 +1973,7 @@ const ( RTM_GETSTATS = 0x5e RTM_GETTCLASS = 0x2a RTM_GETTFILTER = 0x2e - RTM_MAX = 0x67 + RTM_MAX = 0x6b RTM_NEWACTION = 0x30 RTM_NEWADDR = 0x14 RTM_NEWADDRLABEL = 0x48 @@ -1953,6 +1985,7 @@ const ( RTM_NEWNEIGH = 0x1c RTM_NEWNEIGHTBL = 0x40 RTM_NEWNETCONF = 0x50 + RTM_NEWNEXTHOP = 0x68 RTM_NEWNSID = 0x58 RTM_NEWPREFIX = 0x34 RTM_NEWQDISC = 0x24 @@ -1961,8 +1994,8 @@ const ( RTM_NEWSTATS = 0x5c RTM_NEWTCLASS = 0x28 RTM_NEWTFILTER = 0x2c - RTM_NR_FAMILIES = 0x16 - RTM_NR_MSGTYPES = 0x58 + RTM_NR_FAMILIES = 0x17 + RTM_NR_MSGTYPES = 0x5c RTM_SETDCB = 0x4f RTM_SETLINK = 0x13 RTM_SETNEIGHTBL = 0x43 @@ -2047,6 +2080,8 @@ const ( SIOCDRARP = 0x8960 SIOCETHTOOL = 0x8946 SIOCGARP = 0x8954 + SIOCGETLINKNAME = 0x89e0 + SIOCGETNODEID = 0x89e1 SIOCGHWTSTAMP = 0x89b1 SIOCGIFADDR = 0x8915 SIOCGIFBR = 0x8940 @@ -2185,6 +2220,7 @@ const ( SO_DEBUG = 0x1 SO_DETACH_BPF = 0x1b SO_DETACH_FILTER = 0x1b + SO_DETACH_REUSEPORT_BPF = 0x47 SO_DOMAIN = 0x1029 SO_DONTROUTE = 0x10 SO_EE_CODE_TXTIME_INVALID_PARAM = 0x1 @@ -2482,6 +2518,71 @@ const ( TIOCSTOP = 0x2000746f TIOCSWINSZ = 0x80087467 TIOCVHANGUP = 0x20005437 + TIPC_ADDR_ID = 0x3 + TIPC_ADDR_MCAST = 0x1 + TIPC_ADDR_NAME = 0x2 + TIPC_ADDR_NAMESEQ = 0x1 + TIPC_CFG_SRV = 0x0 + TIPC_CLUSTER_BITS = 0xc + TIPC_CLUSTER_MASK = 0xfff000 + TIPC_CLUSTER_OFFSET = 0xc + TIPC_CLUSTER_SIZE = 0xfff + TIPC_CONN_SHUTDOWN = 0x5 + TIPC_CONN_TIMEOUT = 0x82 + TIPC_CRITICAL_IMPORTANCE = 0x3 + TIPC_DESTNAME = 0x3 + TIPC_DEST_DROPPABLE = 0x81 + TIPC_ERRINFO = 0x1 + TIPC_ERR_NO_NAME = 0x1 + TIPC_ERR_NO_NODE = 0x3 + TIPC_ERR_NO_PORT = 0x2 + TIPC_ERR_OVERLOAD = 0x4 + TIPC_GROUP_JOIN = 0x87 + TIPC_GROUP_LEAVE = 0x88 + TIPC_GROUP_LOOPBACK = 0x1 + TIPC_GROUP_MEMBER_EVTS = 0x2 + TIPC_HIGH_IMPORTANCE = 0x2 + TIPC_IMPORTANCE = 0x7f + TIPC_LINK_STATE = 0x2 + TIPC_LOW_IMPORTANCE = 0x0 + TIPC_MAX_BEARER_NAME = 0x20 + TIPC_MAX_IF_NAME = 0x10 + TIPC_MAX_LINK_NAME = 0x44 + TIPC_MAX_MEDIA_NAME = 0x10 + TIPC_MAX_USER_MSG_SIZE = 0x101d0 + TIPC_MCAST_BROADCAST = 0x85 + TIPC_MCAST_REPLICAST = 0x86 + TIPC_MEDIUM_IMPORTANCE = 0x1 + TIPC_NODEID_LEN = 0x10 + TIPC_NODE_BITS = 0xc + TIPC_NODE_MASK = 0xfff + TIPC_NODE_OFFSET = 0x0 + TIPC_NODE_RECVQ_DEPTH = 0x83 + TIPC_NODE_SIZE = 0xfff + TIPC_NODE_STATE = 0x0 + TIPC_OK = 0x0 + TIPC_PUBLISHED = 0x1 + TIPC_RESERVED_TYPES = 0x40 + TIPC_RETDATA = 0x2 + TIPC_SERVICE_ADDR = 0x2 + TIPC_SERVICE_RANGE = 0x1 + TIPC_SOCKET_ADDR = 0x3 + TIPC_SOCK_RECVQ_DEPTH = 0x84 + TIPC_SOCK_RECVQ_USED = 0x89 + TIPC_SRC_DROPPABLE = 0x80 + TIPC_SUBSCR_TIMEOUT = 0x3 + TIPC_SUB_CANCEL = 0x4 + TIPC_SUB_PORTS = 0x1 + TIPC_SUB_SERVICE = 0x2 + TIPC_TOP_SRV = 0x1 + TIPC_WAIT_FOREVER = 0xffffffff + TIPC_WITHDRAWN = 0x2 + TIPC_ZONE_BITS = 0x8 + TIPC_ZONE_CLUSTER_MASK = 0xfffff000 + TIPC_ZONE_MASK = 0xff000000 + TIPC_ZONE_OFFSET = 0x18 + TIPC_ZONE_SCOPE = 0x1 + TIPC_ZONE_SIZE = 0xff TMPFS_MAGIC = 0x1021994 TOSTOP = 0x100 TPACKET_ALIGNMENT = 0x10 @@ -2495,7 +2596,7 @@ const ( TP_STATUS_LOSING = 0x4 TP_STATUS_SENDING = 0x2 TP_STATUS_SEND_REQUEST = 0x1 - TP_STATUS_TS_RAW_HARDWARE = -0x80000000 + TP_STATUS_TS_RAW_HARDWARE = 0x80000000 TP_STATUS_TS_SOFTWARE = 0x20000000 TP_STATUS_TS_SYS_HARDWARE = 0x40000000 TP_STATUS_USER = 0x1 @@ -2693,6 +2794,8 @@ const ( XDP_FLAGS_SKB_MODE = 0x2 XDP_FLAGS_UPDATE_IF_NOEXIST = 0x1 XDP_MMAP_OFFSETS = 0x1 + XDP_OPTIONS = 0x8 + XDP_OPTIONS_ZEROCOPY = 0x1 XDP_PACKET_HEADROOM = 0x100 XDP_PGOFF_RX_RING = 0x0 XDP_PGOFF_TX_RING = 0x80000000 @@ -2709,6 +2812,7 @@ const ( XENFS_SUPER_MAGIC = 0xabba1974 XFS_SUPER_MAGIC = 0x58465342 XTABS = 0x1800 + Z3FOLD_MAGIC = 0x33 ZSMALLOC_MAGIC = 0x58295829 __TIOCFLUSH = 0x80047410 ) diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.1_11.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.1_11.go index c4ec7ff87..dd5ea36ee 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.1_11.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.1_11.go @@ -377,16 +377,6 @@ func Munlockall() (err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := Syscall6(SYS_PTRACE, uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := Syscall6(SYS_GETATTRLIST, uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { @@ -1691,6 +1681,16 @@ func writelen(fd int, buf *byte, nbuf int) (n int, err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { + _, _, e1 := Syscall6(SYS_PTRACE, uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func gettimeofday(tp *Timeval) (sec int32, usec int32, err error) { r0, r1, e1 := RawSyscall(SYS_GETTIMEOFDAY, uintptr(unsafe.Pointer(tp)), 0, 0) sec = int32(r0) diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.go index 23346dc68..5ab9a8277 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.go @@ -304,27 +304,6 @@ func libc_kevent_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := syscall_syscall6(funcPC(libc___sysctl_trampoline), uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc___sysctl_trampoline() - -//go:linkname libc___sysctl libc___sysctl -//go:cgo_import_dynamic libc___sysctl __sysctl "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -527,21 +506,6 @@ func libc_munlockall_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := syscall_syscall6(funcPC(libc_ptrace_trampoline), uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc_ptrace_trampoline() - -//go:linkname libc_ptrace libc_ptrace -//go:cgo_import_dynamic libc_ptrace ptrace "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := syscall_syscall6(funcPC(libc_getattrlist_trampoline), uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { @@ -943,6 +907,21 @@ func libc_chroot_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func ClockGettime(clockid int32, time *Timespec) (err error) { + _, _, e1 := syscall_syscall(funcPC(libc_clock_gettime_trampoline), uintptr(clockid), uintptr(unsafe.Pointer(time)), 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc_clock_gettime_trampoline() + +//go:linkname libc_clock_gettime libc_clock_gettime +//go:cgo_import_dynamic libc_clock_gettime clock_gettime "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func Close(fd int) (err error) { _, _, e1 := syscall_syscall(funcPC(libc_close_trampoline), uintptr(fd), 0, 0) if e1 != 0 { @@ -2341,6 +2320,42 @@ func writelen(fd int, buf *byte, nbuf int) (n int, err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { + var _p0 unsafe.Pointer + if len(mib) > 0 { + _p0 = unsafe.Pointer(&mib[0]) + } else { + _p0 = unsafe.Pointer(&_zero) + } + _, _, e1 := syscall_syscall6(funcPC(libc___sysctl_trampoline), uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc___sysctl_trampoline() + +//go:linkname libc___sysctl libc___sysctl +//go:cgo_import_dynamic libc___sysctl __sysctl "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + +func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { + _, _, e1 := syscall_syscall6(funcPC(libc_ptrace_trampoline), uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc_ptrace_trampoline() + +//go:linkname libc_ptrace libc_ptrace +//go:cgo_import_dynamic libc_ptrace ptrace "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func gettimeofday(tp *Timeval) (sec int32, usec int32, err error) { r0, r1, e1 := syscall_rawSyscall(funcPC(libc_gettimeofday_trampoline), uintptr(unsafe.Pointer(tp)), 0, 0) sec = int32(r0) diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.s b/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.s index 37b85b4f6..c6557b135 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.s +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_386.s @@ -40,8 +40,6 @@ TEXT ·libc_sendmsg_trampoline(SB),NOSPLIT,$0-0 JMP libc_sendmsg(SB) TEXT ·libc_kevent_trampoline(SB),NOSPLIT,$0-0 JMP libc_kevent(SB) -TEXT ·libc___sysctl_trampoline(SB),NOSPLIT,$0-0 - JMP libc___sysctl(SB) TEXT ·libc_utimes_trampoline(SB),NOSPLIT,$0-0 JMP libc_utimes(SB) TEXT ·libc_futimes_trampoline(SB),NOSPLIT,$0-0 @@ -64,8 +62,6 @@ TEXT ·libc_munlock_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlock(SB) TEXT ·libc_munlockall_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlockall(SB) -TEXT ·libc_ptrace_trampoline(SB),NOSPLIT,$0-0 - JMP libc_ptrace(SB) TEXT ·libc_getattrlist_trampoline(SB),NOSPLIT,$0-0 JMP libc_getattrlist(SB) TEXT ·libc_pipe_trampoline(SB),NOSPLIT,$0-0 @@ -108,6 +104,8 @@ TEXT ·libc_chown_trampoline(SB),NOSPLIT,$0-0 JMP libc_chown(SB) TEXT ·libc_chroot_trampoline(SB),NOSPLIT,$0-0 JMP libc_chroot(SB) +TEXT ·libc_clock_gettime_trampoline(SB),NOSPLIT,$0-0 + JMP libc_clock_gettime(SB) TEXT ·libc_close_trampoline(SB),NOSPLIT,$0-0 JMP libc_close(SB) TEXT ·libc_dup_trampoline(SB),NOSPLIT,$0-0 @@ -264,6 +262,10 @@ TEXT ·libc_mmap_trampoline(SB),NOSPLIT,$0-0 JMP libc_mmap(SB) TEXT ·libc_munmap_trampoline(SB),NOSPLIT,$0-0 JMP libc_munmap(SB) +TEXT ·libc___sysctl_trampoline(SB),NOSPLIT,$0-0 + JMP libc___sysctl(SB) +TEXT ·libc_ptrace_trampoline(SB),NOSPLIT,$0-0 + JMP libc_ptrace(SB) TEXT ·libc_gettimeofday_trampoline(SB),NOSPLIT,$0-0 JMP libc_gettimeofday(SB) TEXT ·libc_fstat64_trampoline(SB),NOSPLIT,$0-0 diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.1_11.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.1_11.go index 2581e8960..985f33888 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.1_11.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.1_11.go @@ -214,22 +214,6 @@ func kevent(kq int, change unsafe.Pointer, nchange int, event unsafe.Pointer, ne // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := Syscall6(SYS___SYSCTL, uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -377,16 +361,6 @@ func Munlockall() (err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := Syscall6(SYS_PTRACE, uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := Syscall6(SYS_GETATTRLIST, uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { @@ -1691,6 +1665,32 @@ func writelen(fd int, buf *byte, nbuf int) (n int, err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { + var _p0 unsafe.Pointer + if len(mib) > 0 { + _p0 = unsafe.Pointer(&mib[0]) + } else { + _p0 = unsafe.Pointer(&_zero) + } + _, _, e1 := Syscall6(SYS___SYSCTL, uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + +func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { + _, _, e1 := Syscall6(SYS_PTRACE, uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func gettimeofday(tp *Timeval) (sec int64, usec int32, err error) { r0, r1, e1 := RawSyscall(SYS_GETTIMEOFDAY, uintptr(unsafe.Pointer(tp)), 0, 0) sec = int64(r0) diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.go index c142e33e9..22163ef40 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.go @@ -304,27 +304,6 @@ func libc_kevent_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := syscall_syscall6(funcPC(libc___sysctl_trampoline), uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc___sysctl_trampoline() - -//go:linkname libc___sysctl libc___sysctl -//go:cgo_import_dynamic libc___sysctl __sysctl "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -527,21 +506,6 @@ func libc_munlockall_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := syscall_syscall6(funcPC(libc_ptrace_trampoline), uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc_ptrace_trampoline() - -//go:linkname libc_ptrace libc_ptrace -//go:cgo_import_dynamic libc_ptrace ptrace "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := syscall_syscall6(funcPC(libc_getattrlist_trampoline), uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { @@ -2356,6 +2320,42 @@ func writelen(fd int, buf *byte, nbuf int) (n int, err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { + var _p0 unsafe.Pointer + if len(mib) > 0 { + _p0 = unsafe.Pointer(&mib[0]) + } else { + _p0 = unsafe.Pointer(&_zero) + } + _, _, e1 := syscall_syscall6(funcPC(libc___sysctl_trampoline), uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc___sysctl_trampoline() + +//go:linkname libc___sysctl libc___sysctl +//go:cgo_import_dynamic libc___sysctl __sysctl "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + +func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { + _, _, e1 := syscall_syscall6(funcPC(libc_ptrace_trampoline), uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc_ptrace_trampoline() + +//go:linkname libc_ptrace libc_ptrace +//go:cgo_import_dynamic libc_ptrace ptrace "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func gettimeofday(tp *Timeval) (sec int64, usec int32, err error) { r0, r1, e1 := syscall_rawSyscall(funcPC(libc_gettimeofday_trampoline), uintptr(unsafe.Pointer(tp)), 0, 0) sec = int64(r0) diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.s b/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.s index 1a3915197..ad410cfbc 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.s +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_amd64.s @@ -40,8 +40,6 @@ TEXT ·libc_sendmsg_trampoline(SB),NOSPLIT,$0-0 JMP libc_sendmsg(SB) TEXT ·libc_kevent_trampoline(SB),NOSPLIT,$0-0 JMP libc_kevent(SB) -TEXT ·libc___sysctl_trampoline(SB),NOSPLIT,$0-0 - JMP libc___sysctl(SB) TEXT ·libc_utimes_trampoline(SB),NOSPLIT,$0-0 JMP libc_utimes(SB) TEXT ·libc_futimes_trampoline(SB),NOSPLIT,$0-0 @@ -64,8 +62,6 @@ TEXT ·libc_munlock_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlock(SB) TEXT ·libc_munlockall_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlockall(SB) -TEXT ·libc_ptrace_trampoline(SB),NOSPLIT,$0-0 - JMP libc_ptrace(SB) TEXT ·libc_getattrlist_trampoline(SB),NOSPLIT,$0-0 JMP libc_getattrlist(SB) TEXT ·libc_pipe_trampoline(SB),NOSPLIT,$0-0 @@ -266,6 +262,10 @@ TEXT ·libc_mmap_trampoline(SB),NOSPLIT,$0-0 JMP libc_mmap(SB) TEXT ·libc_munmap_trampoline(SB),NOSPLIT,$0-0 JMP libc_munmap(SB) +TEXT ·libc___sysctl_trampoline(SB),NOSPLIT,$0-0 + JMP libc___sysctl(SB) +TEXT ·libc_ptrace_trampoline(SB),NOSPLIT,$0-0 + JMP libc_ptrace(SB) TEXT ·libc_gettimeofday_trampoline(SB),NOSPLIT,$0-0 JMP libc_gettimeofday(SB) TEXT ·libc_fstat64_trampoline(SB),NOSPLIT,$0-0 diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.1_11.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.1_11.go index f8caecef0..0e47deb78 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.1_11.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.1_11.go @@ -214,22 +214,6 @@ func kevent(kq int, change unsafe.Pointer, nchange int, event unsafe.Pointer, ne // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := Syscall6(SYS___SYSCTL, uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -377,16 +361,6 @@ func Munlockall() (err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := Syscall6(SYS_PTRACE, uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := Syscall6(SYS_GETATTRLIST, uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.go index 01cffbf46..bbc18c4f6 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.go @@ -304,27 +304,6 @@ func libc_kevent_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := syscall_syscall6(funcPC(libc___sysctl_trampoline), uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc___sysctl_trampoline() - -//go:linkname libc___sysctl libc___sysctl -//go:cgo_import_dynamic libc___sysctl __sysctl "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -527,21 +506,6 @@ func libc_munlockall_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := syscall_syscall6(funcPC(libc_ptrace_trampoline), uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc_ptrace_trampoline() - -//go:linkname libc_ptrace libc_ptrace -//go:cgo_import_dynamic libc_ptrace ptrace "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := syscall_syscall6(funcPC(libc_getattrlist_trampoline), uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { @@ -943,6 +907,21 @@ func libc_chroot_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func ClockGettime(clockid int32, time *Timespec) (err error) { + _, _, e1 := syscall_syscall(funcPC(libc_clock_gettime_trampoline), uintptr(clockid), uintptr(unsafe.Pointer(time)), 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc_clock_gettime_trampoline() + +//go:linkname libc_clock_gettime libc_clock_gettime +//go:cgo_import_dynamic libc_clock_gettime clock_gettime "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func Close(fd int) (err error) { _, _, e1 := syscall_syscall(funcPC(libc_close_trampoline), uintptr(fd), 0, 0) if e1 != 0 { diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.s b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.s index 994056f35..66af9f480 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.s +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm.s @@ -64,8 +64,6 @@ TEXT ·libc_munlock_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlock(SB) TEXT ·libc_munlockall_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlockall(SB) -TEXT ·libc_ptrace_trampoline(SB),NOSPLIT,$0-0 - JMP libc_ptrace(SB) TEXT ·libc_getattrlist_trampoline(SB),NOSPLIT,$0-0 JMP libc_getattrlist(SB) TEXT ·libc_pipe_trampoline(SB),NOSPLIT,$0-0 diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.1_11.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.1_11.go index 3fd0f3c85..3f4cc0f34 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.1_11.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.1_11.go @@ -214,22 +214,6 @@ func kevent(kq int, change unsafe.Pointer, nchange int, event unsafe.Pointer, ne // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := Syscall6(SYS___SYSCTL, uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -377,16 +361,6 @@ func Munlockall() (err error) { // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := Syscall6(SYS_PTRACE, uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := Syscall6(SYS_GETATTRLIST, uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.go b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.go index 8f2691dee..43356c832 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.go +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.go @@ -304,27 +304,6 @@ func libc_kevent_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func sysctl(mib []_C_int, old *byte, oldlen *uintptr, new *byte, newlen uintptr) (err error) { - var _p0 unsafe.Pointer - if len(mib) > 0 { - _p0 = unsafe.Pointer(&mib[0]) - } else { - _p0 = unsafe.Pointer(&_zero) - } - _, _, e1 := syscall_syscall6(funcPC(libc___sysctl_trampoline), uintptr(_p0), uintptr(len(mib)), uintptr(unsafe.Pointer(old)), uintptr(unsafe.Pointer(oldlen)), uintptr(unsafe.Pointer(new)), uintptr(newlen)) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc___sysctl_trampoline() - -//go:linkname libc___sysctl libc___sysctl -//go:cgo_import_dynamic libc___sysctl __sysctl "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func utimes(path string, timeval *[2]Timeval) (err error) { var _p0 *byte _p0, err = BytePtrFromString(path) @@ -527,21 +506,6 @@ func libc_munlockall_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT -func ptrace(request int, pid int, addr uintptr, data uintptr) (err error) { - _, _, e1 := syscall_syscall6(funcPC(libc_ptrace_trampoline), uintptr(request), uintptr(pid), uintptr(addr), uintptr(data), 0, 0) - if e1 != 0 { - err = errnoErr(e1) - } - return -} - -func libc_ptrace_trampoline() - -//go:linkname libc_ptrace libc_ptrace -//go:cgo_import_dynamic libc_ptrace ptrace "/usr/lib/libSystem.B.dylib" - -// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT - func getattrlist(path *byte, list unsafe.Pointer, buf unsafe.Pointer, size uintptr, options int) (err error) { _, _, e1 := syscall_syscall6(funcPC(libc_getattrlist_trampoline), uintptr(unsafe.Pointer(path)), uintptr(list), uintptr(buf), uintptr(size), uintptr(options), 0) if e1 != 0 { @@ -943,6 +907,21 @@ func libc_chroot_trampoline() // THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT +func ClockGettime(clockid int32, time *Timespec) (err error) { + _, _, e1 := syscall_syscall(funcPC(libc_clock_gettime_trampoline), uintptr(clockid), uintptr(unsafe.Pointer(time)), 0) + if e1 != 0 { + err = errnoErr(e1) + } + return +} + +func libc_clock_gettime_trampoline() + +//go:linkname libc_clock_gettime libc_clock_gettime +//go:cgo_import_dynamic libc_clock_gettime clock_gettime "/usr/lib/libSystem.B.dylib" + +// THIS FILE IS GENERATED BY THE COMMAND AT THE TOP; DO NOT EDIT + func Close(fd int) (err error) { _, _, e1 := syscall_syscall(funcPC(libc_close_trampoline), uintptr(fd), 0, 0) if e1 != 0 { diff --git a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.s b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.s index 61dc0d4c1..96ab9877e 100644 --- a/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.s +++ b/vendor/golang.org/x/sys/unix/zsyscall_darwin_arm64.s @@ -40,8 +40,6 @@ TEXT ·libc_sendmsg_trampoline(SB),NOSPLIT,$0-0 JMP libc_sendmsg(SB) TEXT ·libc_kevent_trampoline(SB),NOSPLIT,$0-0 JMP libc_kevent(SB) -TEXT ·libc___sysctl_trampoline(SB),NOSPLIT,$0-0 - JMP libc___sysctl(SB) TEXT ·libc_utimes_trampoline(SB),NOSPLIT,$0-0 JMP libc_utimes(SB) TEXT ·libc_futimes_trampoline(SB),NOSPLIT,$0-0 @@ -64,8 +62,6 @@ TEXT ·libc_munlock_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlock(SB) TEXT ·libc_munlockall_trampoline(SB),NOSPLIT,$0-0 JMP libc_munlockall(SB) -TEXT ·libc_ptrace_trampoline(SB),NOSPLIT,$0-0 - JMP libc_ptrace(SB) TEXT ·libc_getattrlist_trampoline(SB),NOSPLIT,$0-0 JMP libc_getattrlist(SB) TEXT ·libc_pipe_trampoline(SB),NOSPLIT,$0-0 @@ -108,6 +104,8 @@ TEXT ·libc_chown_trampoline(SB),NOSPLIT,$0-0 JMP libc_chown(SB) TEXT ·libc_chroot_trampoline(SB),NOSPLIT,$0-0 JMP libc_chroot(SB) +TEXT ·libc_clock_gettime_trampoline(SB),NOSPLIT,$0-0 + JMP libc_clock_gettime(SB) TEXT ·libc_close_trampoline(SB),NOSPLIT,$0-0 JMP libc_close(SB) TEXT ·libc_dup_trampoline(SB),NOSPLIT,$0-0 diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_386.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_386.go index e869c0603..7aae554f2 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_386.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_386.go @@ -429,4 +429,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_amd64.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_amd64.go index 4917b8ab6..7968439a9 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_amd64.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_amd64.go @@ -351,4 +351,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_arm.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_arm.go index f85fcb4f8..3c663c69d 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_arm.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_arm.go @@ -393,4 +393,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_arm64.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_arm64.go index 678a119bc..753def987 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_arm64.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_arm64.go @@ -296,4 +296,5 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_mips.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_mips.go index 222c9f9a2..ac86bd544 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_mips.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_mips.go @@ -414,4 +414,5 @@ const ( SYS_FSCONFIG = 4431 SYS_FSMOUNT = 4432 SYS_FSPICK = 4433 + SYS_PIDFD_OPEN = 4434 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64.go index 28e6d0e9d..1f5705b58 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64.go @@ -344,4 +344,5 @@ const ( SYS_FSCONFIG = 5431 SYS_FSMOUNT = 5432 SYS_FSPICK = 5433 + SYS_PIDFD_OPEN = 5434 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64le.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64le.go index e643c6f63..d9ed95326 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64le.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_mips64le.go @@ -344,4 +344,5 @@ const ( SYS_FSCONFIG = 5431 SYS_FSMOUNT = 5432 SYS_FSPICK = 5433 + SYS_PIDFD_OPEN = 5434 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_mipsle.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_mipsle.go index 01d93c420..94266b65a 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_mipsle.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_mipsle.go @@ -414,4 +414,5 @@ const ( SYS_FSCONFIG = 4431 SYS_FSMOUNT = 4432 SYS_FSPICK = 4433 + SYS_PIDFD_OPEN = 4434 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64.go index 5744149eb..52e3da649 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64.go @@ -393,4 +393,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64le.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64le.go index 21c832042..6141f90a8 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64le.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_ppc64le.go @@ -393,4 +393,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_riscv64.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_riscv64.go index c1bb6d8f2..4f7261a88 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_riscv64.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_riscv64.go @@ -295,4 +295,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_s390x.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_s390x.go index bc3cc6b5b..f47014ac0 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_s390x.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_s390x.go @@ -358,4 +358,6 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 + SYS_CLONE3 = 435 ) diff --git a/vendor/golang.org/x/sys/unix/zsysnum_linux_sparc64.go b/vendor/golang.org/x/sys/unix/zsysnum_linux_sparc64.go index 0a2841ba8..dd78abb0d 100644 --- a/vendor/golang.org/x/sys/unix/zsysnum_linux_sparc64.go +++ b/vendor/golang.org/x/sys/unix/zsysnum_linux_sparc64.go @@ -373,4 +373,5 @@ const ( SYS_FSCONFIG = 431 SYS_FSMOUNT = 432 SYS_FSPICK = 433 + SYS_PIDFD_OPEN = 434 ) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_386.go b/vendor/golang.org/x/sys/unix/ztypes_linux_386.go index 50bc4128f..d02a18350 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_386.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_386.go @@ -285,6 +285,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -425,6 +432,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x8 SizeofIPMreq = 0x8 @@ -614,6 +622,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -664,6 +673,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2521,3 +2537,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_amd64.go b/vendor/golang.org/x/sys/unix/ztypes_linux_amd64.go index 055eaa76a..f347457e9 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_amd64.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_amd64.go @@ -285,6 +285,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -426,6 +433,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -615,6 +623,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -665,6 +674,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2535,3 +2551,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_arm.go b/vendor/golang.org/x/sys/unix/ztypes_linux_arm.go index 66019c9cf..d53d575b8 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_arm.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_arm.go @@ -289,6 +289,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]uint8 @@ -429,6 +436,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x8 SizeofIPMreq = 0x8 @@ -618,6 +626,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -668,6 +677,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2512,3 +2528,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]uint8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]uint8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]uint8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_arm64.go b/vendor/golang.org/x/sys/unix/ztypes_linux_arm64.go index 3104798c4..aa41189bd 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_arm64.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_arm64.go @@ -286,6 +286,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -427,6 +434,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -616,6 +624,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -666,6 +675,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2514,3 +2530,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_mips.go b/vendor/golang.org/x/sys/unix/ztypes_linux_mips.go index 46c86021b..913efd616 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_mips.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_mips.go @@ -288,6 +288,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -428,6 +435,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x8 SizeofIPMreq = 0x8 @@ -617,6 +625,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -667,6 +676,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2518,3 +2534,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_mips64.go b/vendor/golang.org/x/sys/unix/ztypes_linux_mips64.go index c2fe1a62a..860fb5dae 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_mips64.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_mips64.go @@ -286,6 +286,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -427,6 +434,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -616,6 +624,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -666,6 +675,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2516,3 +2532,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_mips64le.go b/vendor/golang.org/x/sys/unix/ztypes_linux_mips64le.go index f1eb0d397..12138089a 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_mips64le.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_mips64le.go @@ -286,6 +286,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -427,6 +434,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -616,6 +624,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -666,6 +675,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2516,3 +2532,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_mipsle.go b/vendor/golang.org/x/sys/unix/ztypes_linux_mipsle.go index 8759bc36b..2498796fd 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_mipsle.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_mipsle.go @@ -288,6 +288,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -428,6 +435,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x8 SizeofIPMreq = 0x8 @@ -617,6 +625,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -667,6 +676,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2518,3 +2534,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64.go b/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64.go index a81200541..17b83f758 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64.go @@ -287,6 +287,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]uint8 @@ -428,6 +435,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -617,6 +625,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -667,6 +676,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2524,3 +2540,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]uint8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]uint8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]uint8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64le.go b/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64le.go index 74b7a9199..d289725b6 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64le.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_ppc64le.go @@ -287,6 +287,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]uint8 @@ -428,6 +435,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -617,6 +625,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -667,6 +676,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2524,3 +2540,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]uint8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]uint8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]uint8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_riscv64.go b/vendor/golang.org/x/sys/unix/ztypes_linux_riscv64.go index 8344583e7..7546c1340 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_riscv64.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_riscv64.go @@ -286,6 +286,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]uint8 @@ -427,6 +434,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -616,6 +624,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -666,6 +675,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -808,6 +824,7 @@ type Ustat_t struct { type EpollEvent struct { Events uint32 + _ int32 Fd int32 Pad int32 } @@ -2541,3 +2558,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]uint8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]uint8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]uint8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_s390x.go b/vendor/golang.org/x/sys/unix/ztypes_linux_s390x.go index d8fc0bc1c..8907bc74b 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_s390x.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_s390x.go @@ -285,6 +285,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -426,6 +433,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -615,6 +623,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -665,6 +674,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2538,3 +2554,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/unix/ztypes_linux_sparc64.go b/vendor/golang.org/x/sys/unix/ztypes_linux_sparc64.go index 5e0ab9329..5efa151eb 100644 --- a/vendor/golang.org/x/sys/unix/ztypes_linux_sparc64.go +++ b/vendor/golang.org/x/sys/unix/ztypes_linux_sparc64.go @@ -289,6 +289,13 @@ type RawSockaddrXDP struct { type RawSockaddrPPPoX [0x1e]byte +type RawSockaddrTIPC struct { + Family uint16 + Addrtype uint8 + Scope int8 + Addr [12]byte +} + type RawSockaddr struct { Family uint16 Data [14]int8 @@ -430,6 +437,7 @@ const ( SizeofSockaddrVM = 0x10 SizeofSockaddrXDP = 0x10 SizeofSockaddrPPPoX = 0x1e + SizeofSockaddrTIPC = 0x10 SizeofLinger = 0x8 SizeofIovec = 0x10 SizeofIPMreq = 0x8 @@ -619,6 +627,7 @@ const ( SizeofRtAttr = 0x4 SizeofIfInfomsg = 0x10 SizeofIfAddrmsg = 0x8 + SizeofIfaCacheinfo = 0x10 SizeofRtMsg = 0xc SizeofRtNexthop = 0x8 SizeofNdUseroptmsg = 0x10 @@ -669,6 +678,13 @@ type IfAddrmsg struct { Index uint32 } +type IfaCacheinfo struct { + Prefered uint32 + Valid uint32 + Cstamp uint32 + Tstamp uint32 +} + type RtMsg struct { Family uint8 Dst_len uint8 @@ -2519,3 +2535,58 @@ type LoopInfo64 struct { Encrypt_key [32]uint8 Init [2]uint64 } + +type TIPCSocketAddr struct { + Ref uint32 + Node uint32 +} + +type TIPCServiceRange struct { + Type uint32 + Lower uint32 + Upper uint32 +} + +type TIPCServiceName struct { + Type uint32 + Instance uint32 + Domain uint32 +} + +type TIPCSubscr struct { + Seq TIPCServiceRange + Timeout uint32 + Filter uint32 + Handle [8]int8 +} + +type TIPCEvent struct { + Event uint32 + Lower uint32 + Upper uint32 + Port TIPCSocketAddr + S TIPCSubscr +} + +type TIPCGroupReq struct { + Type uint32 + Instance uint32 + Scope uint32 + Flags uint32 +} + +type TIPCSIOCLNReq struct { + Peer uint32 + Id uint32 + Linkname [68]int8 +} + +type TIPCSIOCNodeIDReq struct { + Peer uint32 + Id [16]int8 +} + +const ( + TIPC_CLUSTER_SCOPE = 0x2 + TIPC_NODE_SCOPE = 0x3 +) diff --git a/vendor/golang.org/x/sys/windows/security_windows.go b/vendor/golang.org/x/sys/windows/security_windows.go index 61b49647b..7b2cfb9e0 100644 --- a/vendor/golang.org/x/sys/windows/security_windows.go +++ b/vendor/golang.org/x/sys/windows/security_windows.go @@ -644,6 +644,8 @@ func (tml *Tokenmandatorylabel) Size() uint32 { //sys DuplicateTokenEx(existingToken Token, desiredAccess uint32, tokenAttributes *SecurityAttributes, impersonationLevel uint32, tokenType uint32, newToken *Token) (err error) = advapi32.DuplicateTokenEx //sys GetUserProfileDirectory(t Token, dir *uint16, dirLen *uint32) (err error) = userenv.GetUserProfileDirectoryW //sys getSystemDirectory(dir *uint16, dirLen uint32) (len uint32, err error) = kernel32.GetSystemDirectoryW +//sys getWindowsDirectory(dir *uint16, dirLen uint32) (len uint32, err error) = kernel32.GetWindowsDirectoryW +//sys getSystemWindowsDirectory(dir *uint16, dirLen uint32) (len uint32, err error) = kernel32.GetSystemWindowsDirectoryW // An access token contains the security information for a logon session. // The system creates an access token when a user logs on, and every @@ -664,7 +666,7 @@ func OpenCurrentProcessToken() (Token, error) { return 0, e } var t Token - e = OpenProcessToken(p, TOKEN_QUERY, &t) + e = OpenProcessToken(p, TOKEN_QUERY|TOKEN_DUPLICATE, &t) if e != nil { return 0, e } @@ -785,8 +787,8 @@ func (token Token) GetLinkedToken() (Token, error) { return linkedToken, nil } -// GetSystemDirectory retrieves path to current location of the system -// directory, which is typically, though not always, C:\Windows\System32. +// GetSystemDirectory retrieves the path to current location of the system +// directory, which is typically, though not always, `C:\Windows\System32`. func GetSystemDirectory() (string, error) { n := uint32(MAX_PATH) for { @@ -802,6 +804,42 @@ func GetSystemDirectory() (string, error) { } } +// GetWindowsDirectory retrieves the path to current location of the Windows +// directory, which is typically, though not always, `C:\Windows`. This may +// be a private user directory in the case that the application is running +// under a terminal server. +func GetWindowsDirectory() (string, error) { + n := uint32(MAX_PATH) + for { + b := make([]uint16, n) + l, e := getWindowsDirectory(&b[0], n) + if e != nil { + return "", e + } + if l <= n { + return UTF16ToString(b[:l]), nil + } + n = l + } +} + +// GetSystemWindowsDirectory retrieves the path to current location of the +// Windows directory, which is typically, though not always, `C:\Windows`. +func GetSystemWindowsDirectory() (string, error) { + n := uint32(MAX_PATH) + for { + b := make([]uint16, n) + l, e := getSystemWindowsDirectory(&b[0], n) + if e != nil { + return "", e + } + if l <= n { + return UTF16ToString(b[:l]), nil + } + n = l + } +} + // IsMember reports whether the access token t is a member of the provided SID. func (t Token) IsMember(sid *SID) (bool, error) { var b int32 diff --git a/vendor/golang.org/x/sys/windows/service.go b/vendor/golang.org/x/sys/windows/service.go index 03383f1df..847e00bc9 100644 --- a/vendor/golang.org/x/sys/windows/service.go +++ b/vendor/golang.org/x/sys/windows/service.go @@ -159,6 +159,10 @@ type SERVICE_DESCRIPTION struct { Description *uint16 } +type SERVICE_DELAYED_AUTO_START_INFO struct { + IsDelayedAutoStartUp uint32 +} + type SERVICE_STATUS_PROCESS struct { ServiceType uint32 CurrentState uint32 diff --git a/vendor/golang.org/x/sys/windows/syscall_windows.go b/vendor/golang.org/x/sys/windows/syscall_windows.go index b23050924..ed36134b2 100644 --- a/vendor/golang.org/x/sys/windows/syscall_windows.go +++ b/vendor/golang.org/x/sys/windows/syscall_windows.go @@ -257,6 +257,10 @@ func NewCallbackCDecl(fn interface{}) uintptr { //sys SetEvent(event Handle) (err error) = kernel32.SetEvent //sys ResetEvent(event Handle) (err error) = kernel32.ResetEvent //sys PulseEvent(event Handle) (err error) = kernel32.PulseEvent +//sys CreateMutex(mutexAttrs *SecurityAttributes, initialOwner bool, name *uint16) (handle Handle, err error) = kernel32.CreateMutexW +//sys CreateMutexEx(mutexAttrs *SecurityAttributes, name *uint16, flags uint32, desiredAccess uint32) (handle Handle, err error) = kernel32.CreateMutexExW +//sys OpenMutex(desiredAccess uint32, inheritHandle bool, name *uint16) (handle Handle, err error) = kernel32.OpenMutexW +//sys ReleaseMutex(mutex Handle) (err error) = kernel32.ReleaseMutex //sys SleepEx(milliseconds uint32, alertable bool) (ret uint32) = kernel32.SleepEx //sys CreateJobObject(jobAttr *SecurityAttributes, name *uint16) (handle Handle, err error) = kernel32.CreateJobObjectW //sys AssignProcessToJobObject(job Handle, process Handle) (err error) = kernel32.AssignProcessToJobObject @@ -269,6 +273,7 @@ func NewCallbackCDecl(fn interface{}) uintptr { //sys GenerateConsoleCtrlEvent(ctrlEvent uint32, processGroupID uint32) (err error) //sys GetProcessId(process Handle) (id uint32, err error) //sys OpenThread(desiredAccess uint32, inheritHandle bool, threadId uint32) (handle Handle, err error) +//sys SetProcessPriorityBoost(process Handle, disable bool) (err error) = kernel32.SetProcessPriorityBoost // Volume Management Functions //sys DefineDosDevice(flags uint32, deviceName *uint16, targetPath *uint16) (err error) = DefineDosDeviceW @@ -291,11 +296,16 @@ func NewCallbackCDecl(fn interface{}) uintptr { //sys SetVolumeLabel(rootPathName *uint16, volumeName *uint16) (err error) = SetVolumeLabelW //sys SetVolumeMountPoint(volumeMountPoint *uint16, volumeName *uint16) (err error) = SetVolumeMountPointW //sys MessageBox(hwnd Handle, text *uint16, caption *uint16, boxtype uint32) (ret int32, err error) [failretval==0] = user32.MessageBoxW +//sys ExitWindowsEx(flags uint32, reason uint32) (err error) = user32.ExitWindowsEx +//sys InitiateSystemShutdownEx(machineName *uint16, message *uint16, timeout uint32, forceAppsClosed bool, rebootAfterShutdown bool, reason uint32) (err error) = advapi32.InitiateSystemShutdownExW +//sys SetProcessShutdownParameters(level uint32, flags uint32) (err error) = kernel32.SetProcessShutdownParameters +//sys GetProcessShutdownParameters(level *uint32, flags *uint32) (err error) = kernel32.GetProcessShutdownParameters //sys clsidFromString(lpsz *uint16, pclsid *GUID) (ret error) = ole32.CLSIDFromString //sys stringFromGUID2(rguid *GUID, lpsz *uint16, cchMax int32) (chars int32) = ole32.StringFromGUID2 //sys coCreateGuid(pguid *GUID) (ret error) = ole32.CoCreateGuid //sys CoTaskMemFree(address unsafe.Pointer) = ole32.CoTaskMemFree //sys rtlGetVersion(info *OsVersionInfoEx) (ret error) = ntdll.RtlGetVersion +//sys rtlGetNtVersionNumbers(majorVersion *uint32, minorVersion *uint32, buildNumber *uint32) = ntdll.RtlGetNtVersionNumbers // syscall interface implementation for other packages @@ -1306,8 +1316,8 @@ func (t Token) KnownFolderPath(folderID *KNOWNFOLDERID, flags uint32) (string, e return UTF16ToString((*[(1 << 30) - 1]uint16)(unsafe.Pointer(p))[:]), nil } -// RtlGetVersion returns the true version of the underlying operating system, ignoring -// any manifesting or compatibility layers on top of the win32 layer. +// RtlGetVersion returns the version of the underlying operating system, ignoring +// manifest semantics but is affected by the application compatibility layer. func RtlGetVersion() *OsVersionInfoEx { info := &OsVersionInfoEx{} info.osVersionInfoSize = uint32(unsafe.Sizeof(*info)) @@ -1318,3 +1328,11 @@ func RtlGetVersion() *OsVersionInfoEx { _ = rtlGetVersion(info) return info } + +// RtlGetNtVersionNumbers returns the version of the underlying operating system, +// ignoring manifest semantics and the application compatibility layer. +func RtlGetNtVersionNumbers() (majorVersion, minorVersion, buildNumber uint32) { + rtlGetNtVersionNumbers(&majorVersion, &minorVersion, &buildNumber) + buildNumber &= 0xffff + return +} diff --git a/vendor/golang.org/x/sys/windows/types_windows.go b/vendor/golang.org/x/sys/windows/types_windows.go index 1e3947f0f..a9c1c506d 100644 --- a/vendor/golang.org/x/sys/windows/types_windows.go +++ b/vendor/golang.org/x/sys/windows/types_windows.go @@ -1190,6 +1190,28 @@ const ( REG_QWORD = REG_QWORD_LITTLE_ENDIAN ) +const ( + EVENT_MODIFY_STATE = 0x0002 + EVENT_ALL_ACCESS = STANDARD_RIGHTS_REQUIRED | SYNCHRONIZE | 0x3 + + MUTANT_QUERY_STATE = 0x0001 + MUTANT_ALL_ACCESS = STANDARD_RIGHTS_REQUIRED | SYNCHRONIZE | MUTANT_QUERY_STATE + + SEMAPHORE_MODIFY_STATE = 0x0002 + SEMAPHORE_ALL_ACCESS = STANDARD_RIGHTS_REQUIRED | SYNCHRONIZE | 0x3 + + TIMER_QUERY_STATE = 0x0001 + TIMER_MODIFY_STATE = 0x0002 + TIMER_ALL_ACCESS = STANDARD_RIGHTS_REQUIRED | SYNCHRONIZE | TIMER_QUERY_STATE | TIMER_MODIFY_STATE + + MUTEX_MODIFY_STATE = MUTANT_QUERY_STATE + MUTEX_ALL_ACCESS = MUTANT_ALL_ACCESS + + CREATE_EVENT_MANUAL_RESET = 0x1 + CREATE_EVENT_INITIAL_SET = 0x2 + CREATE_MUTEX_INITIAL_OWNER = 0x1 +) + type AddrinfoW struct { Flags int32 Family int32 @@ -1666,3 +1688,68 @@ type OsVersionInfoEx struct { ProductType byte _ byte } + +const ( + EWX_LOGOFF = 0x00000000 + EWX_SHUTDOWN = 0x00000001 + EWX_REBOOT = 0x00000002 + EWX_FORCE = 0x00000004 + EWX_POWEROFF = 0x00000008 + EWX_FORCEIFHUNG = 0x00000010 + EWX_QUICKRESOLVE = 0x00000020 + EWX_RESTARTAPPS = 0x00000040 + EWX_HYBRID_SHUTDOWN = 0x00400000 + EWX_BOOTOPTIONS = 0x01000000 + + SHTDN_REASON_FLAG_COMMENT_REQUIRED = 0x01000000 + SHTDN_REASON_FLAG_DIRTY_PROBLEM_ID_REQUIRED = 0x02000000 + SHTDN_REASON_FLAG_CLEAN_UI = 0x04000000 + SHTDN_REASON_FLAG_DIRTY_UI = 0x08000000 + SHTDN_REASON_FLAG_USER_DEFINED = 0x40000000 + SHTDN_REASON_FLAG_PLANNED = 0x80000000 + SHTDN_REASON_MAJOR_OTHER = 0x00000000 + SHTDN_REASON_MAJOR_NONE = 0x00000000 + SHTDN_REASON_MAJOR_HARDWARE = 0x00010000 + SHTDN_REASON_MAJOR_OPERATINGSYSTEM = 0x00020000 + SHTDN_REASON_MAJOR_SOFTWARE = 0x00030000 + SHTDN_REASON_MAJOR_APPLICATION = 0x00040000 + SHTDN_REASON_MAJOR_SYSTEM = 0x00050000 + SHTDN_REASON_MAJOR_POWER = 0x00060000 + SHTDN_REASON_MAJOR_LEGACY_API = 0x00070000 + SHTDN_REASON_MINOR_OTHER = 0x00000000 + SHTDN_REASON_MINOR_NONE = 0x000000ff + SHTDN_REASON_MINOR_MAINTENANCE = 0x00000001 + SHTDN_REASON_MINOR_INSTALLATION = 0x00000002 + SHTDN_REASON_MINOR_UPGRADE = 0x00000003 + SHTDN_REASON_MINOR_RECONFIG = 0x00000004 + SHTDN_REASON_MINOR_HUNG = 0x00000005 + SHTDN_REASON_MINOR_UNSTABLE = 0x00000006 + SHTDN_REASON_MINOR_DISK = 0x00000007 + SHTDN_REASON_MINOR_PROCESSOR = 0x00000008 + SHTDN_REASON_MINOR_NETWORKCARD = 0x00000009 + SHTDN_REASON_MINOR_POWER_SUPPLY = 0x0000000a + SHTDN_REASON_MINOR_CORDUNPLUGGED = 0x0000000b + SHTDN_REASON_MINOR_ENVIRONMENT = 0x0000000c + SHTDN_REASON_MINOR_HARDWARE_DRIVER = 0x0000000d + SHTDN_REASON_MINOR_OTHERDRIVER = 0x0000000e + SHTDN_REASON_MINOR_BLUESCREEN = 0x0000000F + SHTDN_REASON_MINOR_SERVICEPACK = 0x00000010 + SHTDN_REASON_MINOR_HOTFIX = 0x00000011 + SHTDN_REASON_MINOR_SECURITYFIX = 0x00000012 + SHTDN_REASON_MINOR_SECURITY = 0x00000013 + SHTDN_REASON_MINOR_NETWORK_CONNECTIVITY = 0x00000014 + SHTDN_REASON_MINOR_WMI = 0x00000015 + SHTDN_REASON_MINOR_SERVICEPACK_UNINSTALL = 0x00000016 + SHTDN_REASON_MINOR_HOTFIX_UNINSTALL = 0x00000017 + SHTDN_REASON_MINOR_SECURITYFIX_UNINSTALL = 0x00000018 + SHTDN_REASON_MINOR_MMC = 0x00000019 + SHTDN_REASON_MINOR_SYSTEMRESTORE = 0x0000001a + SHTDN_REASON_MINOR_TERMSRV = 0x00000020 + SHTDN_REASON_MINOR_DC_PROMOTION = 0x00000021 + SHTDN_REASON_MINOR_DC_DEMOTION = 0x00000022 + SHTDN_REASON_UNKNOWN = SHTDN_REASON_MINOR_NONE + SHTDN_REASON_LEGACY_API = SHTDN_REASON_MAJOR_LEGACY_API | SHTDN_REASON_FLAG_PLANNED + SHTDN_REASON_VALID_BIT_MASK = 0xc0ffffff + + SHUTDOWN_NORETRY = 0x1 +) diff --git a/vendor/golang.org/x/sys/windows/zsyscall_windows.go b/vendor/golang.org/x/sys/windows/zsyscall_windows.go index d461bed98..4a9893242 100644 --- a/vendor/golang.org/x/sys/windows/zsyscall_windows.go +++ b/vendor/golang.org/x/sys/windows/zsyscall_windows.go @@ -197,6 +197,10 @@ var ( procSetEvent = modkernel32.NewProc("SetEvent") procResetEvent = modkernel32.NewProc("ResetEvent") procPulseEvent = modkernel32.NewProc("PulseEvent") + procCreateMutexW = modkernel32.NewProc("CreateMutexW") + procCreateMutexExW = modkernel32.NewProc("CreateMutexExW") + procOpenMutexW = modkernel32.NewProc("OpenMutexW") + procReleaseMutex = modkernel32.NewProc("ReleaseMutex") procSleepEx = modkernel32.NewProc("SleepEx") procCreateJobObjectW = modkernel32.NewProc("CreateJobObjectW") procAssignProcessToJobObject = modkernel32.NewProc("AssignProcessToJobObject") @@ -209,6 +213,7 @@ var ( procGenerateConsoleCtrlEvent = modkernel32.NewProc("GenerateConsoleCtrlEvent") procGetProcessId = modkernel32.NewProc("GetProcessId") procOpenThread = modkernel32.NewProc("OpenThread") + procSetProcessPriorityBoost = modkernel32.NewProc("SetProcessPriorityBoost") procDefineDosDeviceW = modkernel32.NewProc("DefineDosDeviceW") procDeleteVolumeMountPointW = modkernel32.NewProc("DeleteVolumeMountPointW") procFindFirstVolumeW = modkernel32.NewProc("FindFirstVolumeW") @@ -229,11 +234,16 @@ var ( procSetVolumeLabelW = modkernel32.NewProc("SetVolumeLabelW") procSetVolumeMountPointW = modkernel32.NewProc("SetVolumeMountPointW") procMessageBoxW = moduser32.NewProc("MessageBoxW") + procExitWindowsEx = moduser32.NewProc("ExitWindowsEx") + procInitiateSystemShutdownExW = modadvapi32.NewProc("InitiateSystemShutdownExW") + procSetProcessShutdownParameters = modkernel32.NewProc("SetProcessShutdownParameters") + procGetProcessShutdownParameters = modkernel32.NewProc("GetProcessShutdownParameters") procCLSIDFromString = modole32.NewProc("CLSIDFromString") procStringFromGUID2 = modole32.NewProc("StringFromGUID2") procCoCreateGuid = modole32.NewProc("CoCreateGuid") procCoTaskMemFree = modole32.NewProc("CoTaskMemFree") procRtlGetVersion = modntdll.NewProc("RtlGetVersion") + procRtlGetNtVersionNumbers = modntdll.NewProc("RtlGetNtVersionNumbers") procWSAStartup = modws2_32.NewProc("WSAStartup") procWSACleanup = modws2_32.NewProc("WSACleanup") procWSAIoctl = modws2_32.NewProc("WSAIoctl") @@ -303,6 +313,8 @@ var ( procDuplicateTokenEx = modadvapi32.NewProc("DuplicateTokenEx") procGetUserProfileDirectoryW = moduserenv.NewProc("GetUserProfileDirectoryW") procGetSystemDirectoryW = modkernel32.NewProc("GetSystemDirectoryW") + procGetWindowsDirectoryW = modkernel32.NewProc("GetWindowsDirectoryW") + procGetSystemWindowsDirectoryW = modkernel32.NewProc("GetSystemWindowsDirectoryW") procWTSQueryUserToken = modwtsapi32.NewProc("WTSQueryUserToken") procWTSEnumerateSessionsW = modwtsapi32.NewProc("WTSEnumerateSessionsW") procWTSFreeMemory = modwtsapi32.NewProc("WTSFreeMemory") @@ -2105,6 +2117,69 @@ func PulseEvent(event Handle) (err error) { return } +func CreateMutex(mutexAttrs *SecurityAttributes, initialOwner bool, name *uint16) (handle Handle, err error) { + var _p0 uint32 + if initialOwner { + _p0 = 1 + } else { + _p0 = 0 + } + r0, _, e1 := syscall.Syscall(procCreateMutexW.Addr(), 3, uintptr(unsafe.Pointer(mutexAttrs)), uintptr(_p0), uintptr(unsafe.Pointer(name))) + handle = Handle(r0) + if handle == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func CreateMutexEx(mutexAttrs *SecurityAttributes, name *uint16, flags uint32, desiredAccess uint32) (handle Handle, err error) { + r0, _, e1 := syscall.Syscall6(procCreateMutexExW.Addr(), 4, uintptr(unsafe.Pointer(mutexAttrs)), uintptr(unsafe.Pointer(name)), uintptr(flags), uintptr(desiredAccess), 0, 0) + handle = Handle(r0) + if handle == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func OpenMutex(desiredAccess uint32, inheritHandle bool, name *uint16) (handle Handle, err error) { + var _p0 uint32 + if inheritHandle { + _p0 = 1 + } else { + _p0 = 0 + } + r0, _, e1 := syscall.Syscall(procOpenMutexW.Addr(), 3, uintptr(desiredAccess), uintptr(_p0), uintptr(unsafe.Pointer(name))) + handle = Handle(r0) + if handle == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func ReleaseMutex(mutex Handle) (err error) { + r1, _, e1 := syscall.Syscall(procReleaseMutex.Addr(), 1, uintptr(mutex), 0, 0) + if r1 == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + func SleepEx(milliseconds uint32, alertable bool) (ret uint32) { var _p0 uint32 if alertable { @@ -2255,6 +2330,24 @@ func OpenThread(desiredAccess uint32, inheritHandle bool, threadId uint32) (hand return } +func SetProcessPriorityBoost(process Handle, disable bool) (err error) { + var _p0 uint32 + if disable { + _p0 = 1 + } else { + _p0 = 0 + } + r1, _, e1 := syscall.Syscall(procSetProcessPriorityBoost.Addr(), 2, uintptr(process), uintptr(_p0), 0) + if r1 == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + func DefineDosDevice(flags uint32, deviceName *uint16, targetPath *uint16) (err error) { r1, _, e1 := syscall.Syscall(procDefineDosDeviceW.Addr(), 3, uintptr(flags), uintptr(unsafe.Pointer(deviceName)), uintptr(unsafe.Pointer(targetPath))) if r1 == 0 { @@ -2495,6 +2588,66 @@ func MessageBox(hwnd Handle, text *uint16, caption *uint16, boxtype uint32) (ret return } +func ExitWindowsEx(flags uint32, reason uint32) (err error) { + r1, _, e1 := syscall.Syscall(procExitWindowsEx.Addr(), 2, uintptr(flags), uintptr(reason), 0) + if r1 == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func InitiateSystemShutdownEx(machineName *uint16, message *uint16, timeout uint32, forceAppsClosed bool, rebootAfterShutdown bool, reason uint32) (err error) { + var _p0 uint32 + if forceAppsClosed { + _p0 = 1 + } else { + _p0 = 0 + } + var _p1 uint32 + if rebootAfterShutdown { + _p1 = 1 + } else { + _p1 = 0 + } + r1, _, e1 := syscall.Syscall6(procInitiateSystemShutdownExW.Addr(), 6, uintptr(unsafe.Pointer(machineName)), uintptr(unsafe.Pointer(message)), uintptr(timeout), uintptr(_p0), uintptr(_p1), uintptr(reason)) + if r1 == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func SetProcessShutdownParameters(level uint32, flags uint32) (err error) { + r1, _, e1 := syscall.Syscall(procSetProcessShutdownParameters.Addr(), 2, uintptr(level), uintptr(flags), 0) + if r1 == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func GetProcessShutdownParameters(level *uint32, flags *uint32) (err error) { + r1, _, e1 := syscall.Syscall(procGetProcessShutdownParameters.Addr(), 2, uintptr(unsafe.Pointer(level)), uintptr(unsafe.Pointer(flags)), 0) + if r1 == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + func clsidFromString(lpsz *uint16, pclsid *GUID) (ret error) { r0, _, _ := syscall.Syscall(procCLSIDFromString.Addr(), 2, uintptr(unsafe.Pointer(lpsz)), uintptr(unsafe.Pointer(pclsid)), 0) if r0 != 0 { @@ -2530,6 +2683,11 @@ func rtlGetVersion(info *OsVersionInfoEx) (ret error) { return } +func rtlGetNtVersionNumbers(majorVersion *uint32, minorVersion *uint32, buildNumber *uint32) { + syscall.Syscall(procRtlGetNtVersionNumbers.Addr(), 3, uintptr(unsafe.Pointer(majorVersion)), uintptr(unsafe.Pointer(minorVersion)), uintptr(unsafe.Pointer(buildNumber))) + return +} + func WSAStartup(verreq uint32, data *WSAData) (sockerr error) { r0, _, _ := syscall.Syscall(procWSAStartup.Addr(), 2, uintptr(verreq), uintptr(unsafe.Pointer(data)), 0) if r0 != 0 { @@ -3307,6 +3465,32 @@ func getSystemDirectory(dir *uint16, dirLen uint32) (len uint32, err error) { return } +func getWindowsDirectory(dir *uint16, dirLen uint32) (len uint32, err error) { + r0, _, e1 := syscall.Syscall(procGetWindowsDirectoryW.Addr(), 2, uintptr(unsafe.Pointer(dir)), uintptr(dirLen), 0) + len = uint32(r0) + if len == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + +func getSystemWindowsDirectory(dir *uint16, dirLen uint32) (len uint32, err error) { + r0, _, e1 := syscall.Syscall(procGetSystemWindowsDirectoryW.Addr(), 2, uintptr(unsafe.Pointer(dir)), uintptr(dirLen), 0) + len = uint32(r0) + if len == 0 { + if e1 != 0 { + err = errnoErr(e1) + } else { + err = syscall.EINVAL + } + } + return +} + func WTSQueryUserToken(session uint32, token *Token) (err error) { r1, _, e1 := syscall.Syscall(procWTSQueryUserToken.Addr(), 2, uintptr(session), uintptr(unsafe.Pointer(token)), 0) if r1 == 0 { diff --git a/vendor/modules.txt b/vendor/modules.txt index d2f314634..8df6b4d95 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -1,4 +1,4 @@ -# github.com/SkycoinProject/dmsg v0.0.0-20190917230949-27f4fd2f25fb +# github.com/SkycoinProject/dmsg v0.0.0-20190918181704-b7cccca1451e github.com/SkycoinProject/dmsg/cipher github.com/SkycoinProject/dmsg github.com/SkycoinProject/dmsg/disc @@ -41,7 +41,7 @@ github.com/inconshreveable/mousetrap github.com/konsorten/go-windows-terminal-sequences # github.com/mattn/go-colorable v0.1.2 github.com/mattn/go-colorable -# github.com/mattn/go-isatty v0.0.8 +# github.com/mattn/go-isatty v0.0.9 github.com/mattn/go-isatty # github.com/matttproud/golang_protobuf_extensions v1.0.1 github.com/matttproud/golang_protobuf_extensions/pbutil @@ -85,7 +85,7 @@ github.com/stretchr/testify/require github.com/stretchr/testify/assert # go.etcd.io/bbolt v1.3.3 go.etcd.io/bbolt -# golang.org/x/crypto v0.0.0-20190829043050-9756ffdc2472 +# golang.org/x/crypto v0.0.0-20190911031432-227b76d455e7 golang.org/x/crypto/ssh/terminal golang.org/x/crypto/blake2b golang.org/x/crypto/blake2s @@ -94,12 +94,12 @@ golang.org/x/crypto/curve25519 golang.org/x/crypto/internal/chacha20 golang.org/x/crypto/internal/subtle golang.org/x/crypto/poly1305 -# golang.org/x/net v0.0.0-20190827160401-ba9fcec4b297 +# golang.org/x/net v0.0.0-20190918130420-a8b05e9114ab golang.org/x/net/nettest golang.org/x/net/context golang.org/x/net/proxy golang.org/x/net/internal/socks -# golang.org/x/sys v0.0.0-20190801041406-cbf593c0f2f3 +# golang.org/x/sys v0.0.0-20190916202348-b4ddaad3f8a3 golang.org/x/sys/unix golang.org/x/sys/windows golang.org/x/sys/windows/svc/eventlog