tryng to structure the client code similar to the server code
This commit is contained in:
parent
9c927464b0
commit
662f623f4c
@ -3,7 +3,7 @@ package main
|
||||
import "fmt"
|
||||
import "net"
|
||||
|
||||
func NewClientPeerConn(r *ClientRoute, c *net.TCPConn, id uint32) (*ClientPeerConn) {
|
||||
func NewClientPeerConn(r *ClientRoute, c net.Conn, id uint32) (*ClientPeerConn) {
|
||||
var cpc ClientPeerConn
|
||||
|
||||
cpc.route = r
|
||||
|
465
client.go
465
client.go
@ -15,7 +15,7 @@ import "os/signal"
|
||||
import "sync"
|
||||
import "sync/atomic"
|
||||
import "syscall"
|
||||
//import "time"
|
||||
import "time"
|
||||
|
||||
//import "github.com/google/uuid"
|
||||
import "google.golang.org/grpc"
|
||||
@ -25,7 +25,7 @@ const PTC_LIMIT = 8192
|
||||
|
||||
type PacketStreamClient grpc.BidiStreamingClient[Packet, Packet]
|
||||
|
||||
type ServerConnMap = map[*net.TCPAddr]*ServerConn
|
||||
type ServerConnMap = map[net.Addr]*ServerConn
|
||||
type ClientPeerConnMap = map[uint32]*ClientPeerConn
|
||||
type ClientRouteMap = map[uint32]*ClientRoute
|
||||
|
||||
@ -36,47 +36,48 @@ type ClientConfig struct {
|
||||
}
|
||||
|
||||
type Client struct {
|
||||
cfg *ClientConfig
|
||||
tlscfg *tls.Config
|
||||
saddr *net.TCPAddr
|
||||
ctx context.Context
|
||||
ctx_cancel context.CancelFunc
|
||||
tlscfg *tls.Config
|
||||
|
||||
sc *grpc.ClientConn // main control connection to the server
|
||||
sg HoduClient
|
||||
psc PacketStreamClient
|
||||
psc_mtx sync.Mutex
|
||||
cts_mtx sync.Mutex
|
||||
cts_map ServerConnMap
|
||||
|
||||
cts_mtx sync.Mutex
|
||||
cts_map ServerConnMap
|
||||
wg sync.WaitGroup
|
||||
stop_req atomic.Bool
|
||||
wg sync.WaitGroup
|
||||
stop_req atomic.Bool
|
||||
stop_chan chan bool
|
||||
}
|
||||
|
||||
|
||||
type ClientPeerConn struct {
|
||||
route *ClientRoute
|
||||
conn_id uint32
|
||||
conn *net.TCPConn
|
||||
conn net.Conn
|
||||
remot_conn_id uint32
|
||||
|
||||
addr string // peer address
|
||||
stop_req atomic.Bool
|
||||
stop_chan chan bool
|
||||
}
|
||||
|
||||
// client connection to server
|
||||
type ServerConn struct {
|
||||
cli *Client
|
||||
cfg *ClientConfig
|
||||
saddr *net.TCPAddr // server address that is connected to
|
||||
psc Hodu_PacketStreamClient
|
||||
|
||||
conn *grpc.ClientConn // grpc connection to the server
|
||||
hdc HoduClient
|
||||
psc Hodu_PacketStreamClient // grpc stream
|
||||
psc_mtx sync.Mutex
|
||||
|
||||
route_mtx sync.Mutex
|
||||
routes ClientRouteMap
|
||||
route_map ClientRouteMap
|
||||
//route_wg sync.WaitGroup
|
||||
|
||||
//cw_mtx sync.Mutex
|
||||
|
||||
wg sync.WaitGroup
|
||||
//wg sync.WaitGroup
|
||||
stop_req atomic.Bool
|
||||
greeted bool
|
||||
stop_chan chan bool
|
||||
}
|
||||
|
||||
type ClientRoute struct {
|
||||
@ -90,6 +91,9 @@ type ClientRoute struct {
|
||||
ptc_limit int
|
||||
ptc_last_id uint32
|
||||
ptc_wg sync.WaitGroup
|
||||
|
||||
stop_req atomic.Bool
|
||||
stop_chan chan bool
|
||||
}
|
||||
|
||||
|
||||
@ -104,27 +108,55 @@ func NewClientRoute(cts *ServerConn, id uint32, addr *net.TCPAddr, proto ROUTE_P
|
||||
r.ptc_last_id = 0
|
||||
r.proto = proto
|
||||
r.peer_addr = addr
|
||||
r.stop_req.Store(false)
|
||||
r.stop_chan = make(chan bool, 1)
|
||||
|
||||
return &r;
|
||||
}
|
||||
|
||||
func (r *ClientRoute) RunTask() {
|
||||
// this task on the route object isn't actually necessary.
|
||||
// most useful works are triggered by ReportEvent() and done by ConnectToPeer()
|
||||
|
||||
main_loop:
|
||||
for {
|
||||
select {
|
||||
case <- r.stop_chan:
|
||||
break main_loop
|
||||
}
|
||||
}
|
||||
fmt.Printf ("*** End fo Client Roue Task\n")
|
||||
}
|
||||
|
||||
func (r *ClientRoute) StopTask() {
|
||||
// TODO:
|
||||
fmt.Printf ("ClientRoute StopTask not implemented yet\n")
|
||||
// TOOD: stop all peer connection jobs
|
||||
func (r *ClientRoute) ReqStop() {
|
||||
if r.stop_req.CompareAndSwap(false, true) {
|
||||
var ptc *ClientPeerConn
|
||||
for _, ptc = range r.ptc_map {
|
||||
ptc.ReqStop()
|
||||
}
|
||||
|
||||
r.stop_chan <- true
|
||||
}
|
||||
fmt.Printf ("*** Sent stop request to Route..\n");
|
||||
}
|
||||
|
||||
func (r* ClientRoute) ConnectToPeer(pts_id uint32) {
|
||||
var err error
|
||||
var conn *net.TCPConn
|
||||
var conn net.Conn
|
||||
var ptc *ClientPeerConn
|
||||
var d net.Dialer
|
||||
var ctx context.Context
|
||||
//var cancel context.CancelFunc
|
||||
|
||||
// MAKE thesse into a separte go rountine... so it doesn't block
|
||||
conn, err = net.DialTCP("tcp", nil, r.peer_addr);
|
||||
// TODO: how to abort blocking DialTCP()? call cancellation funtion?
|
||||
// TODO: make timeuot value configurable
|
||||
// TODO: fire the cancellation function upon stop request???
|
||||
ctx, _ = context.WithTimeout(r.cts.cli.ctx, 10 * time.Second)
|
||||
//defer cancel():
|
||||
|
||||
d.LocalAddr = nil // TOOD: use this if local address is specified
|
||||
conn, err = d.DialContext(ctx, "tcp", r.peer_addr.String());
|
||||
//conn, err = net.DialTCP("tcp", nil, r.peer_addr);
|
||||
if err != nil {
|
||||
fmt.Printf ("failed to connect to %s - %s\n", r.peer_addr.String(), err.Error())
|
||||
return
|
||||
@ -139,9 +171,10 @@ func (r* ClientRoute) ConnectToPeer(pts_id uint32) {
|
||||
}
|
||||
fmt.Printf("STARTED NEW SERVER PEER STAK\n")
|
||||
|
||||
r.ptc_wg.Add(1)
|
||||
go ptc.RunTask()
|
||||
r.ptc_wg.Wait()
|
||||
//r.ptc_wg.Add(1)
|
||||
//go ptc.RunTask()
|
||||
//r.ptc_wg.Wait()
|
||||
ptc.RunTask()
|
||||
conn.Close() // don't care about double close. it could have been closed in StopTask
|
||||
}
|
||||
|
||||
@ -162,15 +195,15 @@ func (cts *ServerConn) AddNewClientRoute(route_id uint32, addr *net.TCPAddr, pro
|
||||
var r *ClientRoute
|
||||
|
||||
cts.route_mtx.Lock()
|
||||
if cts.routes[route_id] != nil {
|
||||
if cts.route_map[route_id] != nil {
|
||||
cts.route_mtx.Unlock()
|
||||
return nil, fmt.Errorf ("existent route id - %d", route_id)
|
||||
}
|
||||
r = NewClientRoute(cts, route_id, addr, proto)
|
||||
cts.routes[route_id] = r
|
||||
cts.route_map[route_id] = r
|
||||
cts.route_mtx.Unlock()
|
||||
|
||||
fmt.Printf ("added client route.... %d -> %d\n", route_id, len(cts.routes))
|
||||
fmt.Printf ("added client route.... %d -> %d\n", route_id, len(cts.route_map))
|
||||
go r.RunTask()
|
||||
return r, nil
|
||||
}
|
||||
@ -180,15 +213,15 @@ func (cts *ServerConn) RemoveClientRoute (route_id uint32) error {
|
||||
var ok bool
|
||||
|
||||
cts.route_mtx.Lock()
|
||||
r, ok = cts.routes[route_id]
|
||||
r, ok = cts.route_map[route_id]
|
||||
if (!ok) {
|
||||
cts.route_mtx.Unlock()
|
||||
return fmt.Errorf ("non-existent route id - %d", route_id)
|
||||
}
|
||||
delete(cts.routes, route_id)
|
||||
delete(cts.route_map, route_id)
|
||||
cts.route_mtx.Unlock()
|
||||
|
||||
r.StopTask() // TODO: make this unblocking or blocking?
|
||||
r.ReqStop() // TODO: make this unblocking or blocking?
|
||||
return nil;
|
||||
}
|
||||
|
||||
@ -218,8 +251,8 @@ func (cts *ServerConn) AddClientRoutes (peer_addrs []string) error {
|
||||
}
|
||||
}
|
||||
|
||||
for _, r = range cts.routes {
|
||||
err = cts.cli.psc.Send(MakeRouteStartPacket(r.id, r.proto, addr.String()))
|
||||
for _, r = range cts.route_map {
|
||||
err = cts.psc.Send(MakeRouteStartPacket(r.id, r.proto, addr.String()))
|
||||
if err != nil {
|
||||
return fmt.Errorf("unable to send route-start packet - %s", err.Error())
|
||||
}
|
||||
@ -228,165 +261,74 @@ func (cts *ServerConn) AddClientRoutes (peer_addrs []string) error {
|
||||
return nil;
|
||||
}
|
||||
|
||||
func (cts *ServerConn) ReportEvent (route_id uint32, pts_id uint32, event_type PACKET_KIND, event_data []byte) error {
|
||||
var r *ClientRoute
|
||||
var ok bool
|
||||
|
||||
cts.route_mtx.Lock()
|
||||
r, ok = cts.routes[route_id]
|
||||
if (!ok) {
|
||||
cts.route_mtx.Unlock()
|
||||
return fmt.Errorf ("non-existent route id - %d", route_id)
|
||||
}
|
||||
cts.route_mtx.Unlock()
|
||||
|
||||
return r.ReportEvent(pts_id, event_type, event_data)
|
||||
}
|
||||
// --------------------------------------------------------------------
|
||||
|
||||
func (r *ClientRoute) AddNewClientPeerConn (c* net.TCPConn) (*ClientPeerConn, error) {
|
||||
var ptc *ClientPeerConn
|
||||
var ok bool
|
||||
var start_id uint32
|
||||
|
||||
r.ptc_mtx.Lock()
|
||||
defer r.ptc_mtx.Unlock()
|
||||
|
||||
if len(r.ptc_map) >= r.ptc_limit {
|
||||
return nil, fmt.Errorf("peer-to-client connection table full")
|
||||
}
|
||||
|
||||
start_id = r.ptc_last_id
|
||||
for {
|
||||
_, ok = r.ptc_map[r.ptc_last_id]
|
||||
if !ok {
|
||||
break
|
||||
}
|
||||
r.ptc_last_id++
|
||||
if r.ptc_last_id == start_id {
|
||||
// unlikely to happen but it cycled through the whole range.
|
||||
return nil, fmt.Errorf("failed to assign peer-to-table connection id")
|
||||
func (cts *ServerConn) ReqStop() {
|
||||
if cts.stop_req.CompareAndSwap(false, true) {
|
||||
var r *ClientRoute
|
||||
for _, r = range cts.route_map {
|
||||
r.ReqStop()
|
||||
}
|
||||
|
||||
// TODO: notify the server.. send term command???
|
||||
cts.stop_chan <- true
|
||||
}
|
||||
|
||||
ptc = NewClientPeerConn(r, c, r.ptc_last_id)
|
||||
r.ptc_map[ptc.conn_id] = ptc
|
||||
r.ptc_last_id++
|
||||
|
||||
return ptc, nil
|
||||
}
|
||||
// --------------------------------------------------------------------
|
||||
|
||||
func (c *Client) AddNewServerConn(addr *net.TCPAddr, psc Hodu_PacketStreamClient) (*ServerConn, error) {
|
||||
var cts ServerConn
|
||||
var ok bool
|
||||
|
||||
cts.cli = c
|
||||
cts.routes = make(ClientRouteMap)
|
||||
cts.saddr = addr
|
||||
cts.psc = psc
|
||||
|
||||
cts.stop_req.Store(false)
|
||||
cts.greeted = false
|
||||
|
||||
c.cts_mtx.Lock()
|
||||
defer c.cts_mtx.Unlock()
|
||||
|
||||
_, ok = c.cts_map[addr]
|
||||
if ok {
|
||||
return nil, fmt.Errorf("existing server - %s", addr.String())
|
||||
}
|
||||
|
||||
c.cts_map[addr] = &cts;
|
||||
fmt.Printf ("ADD total servers %d\n", len(c.cts_map));
|
||||
return &cts, nil
|
||||
fmt.Printf ("*** Sent stop request to ServerConn..\n");
|
||||
}
|
||||
|
||||
func (c *Client) RemoveServerConn(cts *ServerConn) {
|
||||
c.cts_mtx.Lock()
|
||||
delete(c.cts_map, cts.saddr)
|
||||
fmt.Printf ("REMOVE total servers %d\n", len(c.cts_map));
|
||||
c.cts_mtx.Unlock()
|
||||
}
|
||||
|
||||
// --------------------------------------------------------------------
|
||||
func NewClient(cfg *ClientConfig, tlscfg *tls.Config) (*Client, error) {
|
||||
var c Client
|
||||
var saddr *net.TCPAddr
|
||||
func (cts *ServerConn) RunTask(wg *sync.WaitGroup) {
|
||||
var conn *grpc.ClientConn = nil
|
||||
var hdc HoduClient
|
||||
var psc PacketStreamClient
|
||||
var err error
|
||||
|
||||
if len(cfg.peer_addrs) < 0 || len(cfg.peer_addrs) > int(^uint16(0)) { // TODO: change this check... not really right...
|
||||
return nil, fmt.Errorf("no peer addresses or too many peer addresses")
|
||||
}
|
||||
|
||||
saddr, err = net.ResolveTCPAddr(NET_TYPE_TCP, cfg.server_addr)
|
||||
if err != nil {
|
||||
return nil, fmt.Errorf("unable to resolve %s - %s", cfg.server_addr, err.Error())
|
||||
}
|
||||
|
||||
c.cfg = cfg
|
||||
c.tlscfg = tlscfg
|
||||
c.saddr = saddr
|
||||
c.cts_map = make(ServerConnMap) // TODO: make it configurable...
|
||||
c.stop_req.Store(false)
|
||||
|
||||
return &c, nil
|
||||
}
|
||||
|
||||
func (c *Client) RunTask(ctx context.Context) {
|
||||
var conn *grpc.ClientConn
|
||||
var cts *ServerConn
|
||||
var err error
|
||||
|
||||
defer c.wg.Done();
|
||||
defer wg.Done(); // arrange to call at the end of this function
|
||||
|
||||
// TODO: HANDLE connection timeout..
|
||||
// ctx, _/*cancel*/ := context.WithTimeout(context.Background(), time.Second)
|
||||
conn, err = grpc.NewClient(c.saddr.String(), grpc.WithTransportCredentials(insecure.NewCredentials()))
|
||||
conn, err = grpc.NewClient(cts.saddr.String(), grpc.WithTransportCredentials(insecure.NewCredentials()))
|
||||
if err != nil {
|
||||
// TODO: logging
|
||||
fmt.Printf("ERROR - unable to connect to %s - %s", c.cfg.server_addr, err.Error())
|
||||
return
|
||||
fmt.Printf("ERROR - unable to connect to %s - %s", cts.cfg.server_addr, err.Error())
|
||||
goto done
|
||||
}
|
||||
|
||||
c.sc = conn
|
||||
c.sg = NewHoduClient(conn)
|
||||
|
||||
c.psc, err = c.sg.PacketStream(ctx) // TODO: accept external context and use it.L
|
||||
hdc = NewHoduClient(conn)
|
||||
psc, err = hdc.PacketStream(cts.cli.ctx) // TODO: accept external context and use it.L
|
||||
if err != nil {
|
||||
conn.Close()
|
||||
fmt.Printf ("failed to get the packet stream - %s", err.Error())
|
||||
return
|
||||
goto done
|
||||
}
|
||||
|
||||
cts, err = c.AddNewServerConn(c.saddr, c.psc)
|
||||
cts.conn = conn
|
||||
cts.hdc = hdc
|
||||
cts.psc = psc
|
||||
|
||||
// the connection structure to a server is ready.
|
||||
// let's add routes to the client-side peers.
|
||||
err = cts.AddClientRoutes(cts.cfg.peer_addrs)
|
||||
if err != nil {
|
||||
conn.Close()
|
||||
fmt.Printf ("failed to register connection to server - %s", err.Error())
|
||||
return
|
||||
}
|
||||
|
||||
err = cts.AddClientRoutes(c.cfg.peer_addrs)
|
||||
if err != nil {
|
||||
conn.Close()
|
||||
fmt.Printf("unable to make client routes - %s", err.Error())
|
||||
return
|
||||
fmt.Printf ("unable to add routes to client-side peers - %s", err.Error())
|
||||
goto done
|
||||
}
|
||||
|
||||
main_loop:
|
||||
for {
|
||||
var pkt *Packet
|
||||
|
||||
select {
|
||||
case <-ctx.Done():
|
||||
fmt.Printf("context doine... error - %s\n", ctx.Err().Error())
|
||||
case <-cts.cli.ctx.Done():
|
||||
fmt.Printf("context doine... error - %s\n", cts.cli.ctx.Err().Error())
|
||||
break main_loop
|
||||
|
||||
case <-cts.stop_chan:
|
||||
break main_loop
|
||||
|
||||
default:
|
||||
// no other case is ready.
|
||||
// without the default case, the select construct would block
|
||||
}
|
||||
|
||||
pkt, err = c.psc.Recv()
|
||||
pkt, err = psc.Recv()
|
||||
if err == io.EOF {
|
||||
// return will close stream from server side
|
||||
fmt.Printf("server disconnected\n")
|
||||
break
|
||||
}
|
||||
@ -397,6 +339,7 @@ func (c *Client) RunTask(ctx context.Context) {
|
||||
|
||||
switch pkt.Kind {
|
||||
case PACKET_KIND_ROUTE_STARTED:
|
||||
// the server side managed to set up the route the client requested
|
||||
var x *Packet_Route
|
||||
var ok bool
|
||||
x, ok = pkt.U.(*Packet_Route)
|
||||
@ -477,20 +420,165 @@ func (c *Client) RunTask(ctx context.Context) {
|
||||
}
|
||||
}
|
||||
|
||||
//done:
|
||||
c.ReqStop() // just in case...
|
||||
c.sc.Close()
|
||||
done:
|
||||
fmt.Printf ("^^^^^^^^^^^^^^^^^^^^ Server Coon RunTask ending...\n")
|
||||
if conn != nil {
|
||||
conn.Close()
|
||||
// TODO: need to reset c.sc, c.sg, c.psc to nil?
|
||||
// for this we need to ensure that everyone is ending
|
||||
}
|
||||
}
|
||||
|
||||
syscall.Kill(syscall.Getpid(), syscall.SIGTERM) // TODO: find a better to terminate the signal handler...
|
||||
func (cts *ServerConn) ReportEvent (route_id uint32, pts_id uint32, event_type PACKET_KIND, event_data []byte) error {
|
||||
var r *ClientRoute
|
||||
var ok bool
|
||||
|
||||
cts.route_mtx.Lock()
|
||||
r, ok = cts.route_map[route_id]
|
||||
if (!ok) {
|
||||
cts.route_mtx.Unlock()
|
||||
return fmt.Errorf ("non-existent route id - %d", route_id)
|
||||
}
|
||||
cts.route_mtx.Unlock()
|
||||
|
||||
return r.ReportEvent(pts_id, event_type, event_data)
|
||||
}
|
||||
// --------------------------------------------------------------------
|
||||
|
||||
func (r *ClientRoute) AddNewClientPeerConn (c net.Conn) (*ClientPeerConn, error) {
|
||||
var ptc *ClientPeerConn
|
||||
var ok bool
|
||||
var start_id uint32
|
||||
|
||||
r.ptc_mtx.Lock()
|
||||
defer r.ptc_mtx.Unlock()
|
||||
|
||||
if len(r.ptc_map) >= r.ptc_limit {
|
||||
return nil, fmt.Errorf("peer-to-client connection table full")
|
||||
}
|
||||
|
||||
start_id = r.ptc_last_id
|
||||
for {
|
||||
_, ok = r.ptc_map[r.ptc_last_id]
|
||||
if !ok {
|
||||
break
|
||||
}
|
||||
r.ptc_last_id++
|
||||
if r.ptc_last_id == start_id {
|
||||
// unlikely to happen but it cycled through the whole range.
|
||||
return nil, fmt.Errorf("failed to assign peer-to-table connection id")
|
||||
}
|
||||
}
|
||||
|
||||
ptc = NewClientPeerConn(r, c, r.ptc_last_id)
|
||||
r.ptc_map[ptc.conn_id] = ptc
|
||||
r.ptc_last_id++
|
||||
|
||||
return ptc, nil
|
||||
}
|
||||
// --------------------------------------------------------------------
|
||||
|
||||
func NewClient(ctx context.Context, tlscfg *tls.Config) *Client {
|
||||
var c Client
|
||||
|
||||
c.ctx, c.ctx_cancel = context.WithCancel(ctx)
|
||||
c.tlscfg = tlscfg
|
||||
c.cts_map = make(ServerConnMap) // TODO: make it configurable...
|
||||
c.stop_req.Store(false)
|
||||
c.stop_chan = make(chan bool, 1)
|
||||
|
||||
return &c
|
||||
}
|
||||
|
||||
func (c *Client) AddNewServerConn(addr *net.TCPAddr, cfg *ClientConfig) (*ServerConn, error) {
|
||||
var cts ServerConn
|
||||
var ok bool
|
||||
|
||||
cts.cli = c
|
||||
cts.route_map = make(ClientRouteMap)
|
||||
cts.saddr = addr
|
||||
cts.cfg = cfg
|
||||
//cts.conn = conn
|
||||
//cts.hdc = hdc
|
||||
//cts.psc = psc
|
||||
cts.stop_req.Store(false)
|
||||
cts.stop_chan = make(chan bool, 1)
|
||||
|
||||
c.cts_mtx.Lock()
|
||||
defer c.cts_mtx.Unlock()
|
||||
|
||||
_, ok = c.cts_map[addr]
|
||||
if ok {
|
||||
return nil, fmt.Errorf("existing server - %s", addr.String())
|
||||
}
|
||||
|
||||
c.cts_map[addr] = &cts;
|
||||
fmt.Printf ("ADD total servers %d\n", len(c.cts_map));
|
||||
return &cts, nil
|
||||
}
|
||||
|
||||
func (c *Client) RemoveServerConn(cts *ServerConn) {
|
||||
c.cts_mtx.Lock()
|
||||
delete(c.cts_map, cts.saddr)
|
||||
fmt.Printf ("REMOVE total servers %d\n", len(c.cts_map));
|
||||
c.cts_mtx.Unlock()
|
||||
}
|
||||
|
||||
func (c *Client) ReqStop() {
|
||||
if c.stop_req.CompareAndSwap(false, true) {
|
||||
var cts *ServerConn
|
||||
for _, cts = range c.cts_map {
|
||||
cts.ReqStop()
|
||||
}
|
||||
|
||||
// TODO: notify the server.. send term command???
|
||||
c.sc.Close()
|
||||
c.stop_chan <- true
|
||||
c.ctx_cancel()
|
||||
}
|
||||
fmt.Printf ("*** Sent stop request to client..\n");
|
||||
}
|
||||
|
||||
// naming convention:
|
||||
// RunService - returns after having executed another go routine
|
||||
// RunTask - supposed to be detached as a go routine
|
||||
func (c *Client) RunService(cfg *ClientConfig) {
|
||||
var saddr *net.TCPAddr
|
||||
var cts *ServerConn
|
||||
var err error
|
||||
|
||||
if len(cfg.peer_addrs) < 0 || len(cfg.peer_addrs) > int(^uint16(0)) { // TODO: change this check... not really right...
|
||||
fmt.Printf("no peer addresses or too many peer addresses")
|
||||
return
|
||||
}
|
||||
|
||||
saddr, err = net.ResolveTCPAddr(NET_TYPE_TCP, cfg.server_addr)
|
||||
if err != nil {
|
||||
fmt.Printf("unable to resolve %s - %s", cfg.server_addr, err.Error())
|
||||
return
|
||||
}
|
||||
|
||||
cts, err = c.AddNewServerConn(saddr, cfg)
|
||||
if err != nil {
|
||||
fmt.Printf("unable to add server connection structure to %s - %s", cfg.server_addr, err.Error())
|
||||
return
|
||||
}
|
||||
|
||||
c.wg.Add(1)
|
||||
go cts.RunTask(&c.wg)
|
||||
}
|
||||
|
||||
func (c *Client) WaitForTermination() {
|
||||
|
||||
fmt.Printf ("Waiting for task top stop\n")
|
||||
// waiting for tasks to stop
|
||||
c.wg.Wait()
|
||||
fmt.Printf ("XXXXXXXXXXXX Waiting for task top stop\n")
|
||||
|
||||
// TOOD: find a better way to stop the signal handling loop.
|
||||
// above all the signal handler must not be with a single client,
|
||||
// but with the whole app.
|
||||
syscall.Kill(syscall.Getpid(), syscall.SIGTERM) // TODO: find a better to terminate the signal handler...
|
||||
}
|
||||
|
||||
// --------------------------------------------------------------------
|
||||
|
||||
@ -522,8 +610,7 @@ chan_loop:
|
||||
break chan_loop
|
||||
}
|
||||
}
|
||||
|
||||
fmt.Printf ("end of signal handler...\n");
|
||||
fmt.Printf("end of signal handler\n")
|
||||
}
|
||||
|
||||
// --------------------------------------------------------------------
|
||||
@ -545,7 +632,6 @@ BAMCA0gAMEUCIEKzVMF3JqjQjuM2rX7Rx8hancI5KJhwfeKu1xbyR7XaAiEA2UT7
|
||||
|
||||
func client_main(server_addr string, peer_addrs []string) error {
|
||||
var c *Client
|
||||
var err error
|
||||
var cert_pool *x509.CertPool
|
||||
var tlscfg *tls.Config
|
||||
var cc ClientConfig
|
||||
@ -555,23 +641,26 @@ func client_main(server_addr string, peer_addrs []string) error {
|
||||
if !ok {
|
||||
log.Fatal("failed to parse root certificate")
|
||||
}
|
||||
tlscfg = &tls.Config{RootCAs: cert_pool, ServerName: "localhost", InsecureSkipVerify: true}
|
||||
tlscfg = &tls.Config{
|
||||
RootCAs: cert_pool,
|
||||
ServerName: "localhost",
|
||||
InsecureSkipVerify: true,
|
||||
}
|
||||
|
||||
c = NewClient(context.Background(), tlscfg)
|
||||
|
||||
c.wg.Add(1)
|
||||
go c.handle_os_signals()
|
||||
|
||||
cc.server_addr = server_addr
|
||||
cc.peer_addrs = peer_addrs
|
||||
c, err = NewClient(&cc, tlscfg)
|
||||
if err != nil {
|
||||
fmt.Printf("failed create client - %s\n", err.Error())
|
||||
return err
|
||||
}
|
||||
c.RunService(&cc)
|
||||
|
||||
fmt.Printf ("XXXXXXXXXXXXXXXXXXXXXXXXXXXX\n");
|
||||
c.wg.Add(1)
|
||||
go c.handle_os_signals()
|
||||
c.wg.Add(1)
|
||||
go c.RunTask(context.Background());
|
||||
c.wg.Wait();
|
||||
fmt.Printf ("YYYYYYYYYYYYYYYYYYYYYYYYYYYYYYYYYY\n");
|
||||
//cc.server_addr = "some other address..."
|
||||
//cc.peer_addrs = peer_addrs
|
||||
//c.RunService(&cc)
|
||||
|
||||
c.WaitForTermination()
|
||||
|
||||
return nil
|
||||
}
|
||||
|
Loading…
Reference in New Issue
Block a user