123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374 |
- // Copyright 2017 fatedier, fatedier@gmail.com
- //
- // Licensed under the Apache License, Version 2.0 (the "License");
- // you may not use this file except in compliance with the License.
- // You may obtain a copy of the License at
- //
- // http://www.apache.org/licenses/LICENSE-2.0
- //
- // Unless required by applicable law or agreed to in writing, software
- // distributed under the License is distributed on an "AS IS" BASIS,
- // WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- // See the License for the specific language governing permissions and
- // limitations under the License.
- package client
- import (
- "fmt"
- "io"
- "runtime"
- "sync"
- "time"
- "github.com/fatedier/frp/models/config"
- "github.com/fatedier/frp/models/msg"
- "github.com/fatedier/frp/utils/crypto"
- "github.com/fatedier/frp/utils/log"
- "github.com/fatedier/frp/utils/net"
- "github.com/fatedier/frp/utils/util"
- "github.com/fatedier/frp/utils/version"
- )
- type Control struct {
- // frpc service
- svr *Service
- // login message to server
- loginMsg *msg.Login
- // proxy configures
- pxyCfgs map[string]config.ProxyConf
- // proxies
- proxies map[string]Proxy
- // control connection
- conn net.Conn
- // put a message in this channel to send it over control connection to server
- sendCh chan (msg.Message)
- // read from this channel to get the next message sent by server
- readCh chan (msg.Message)
- // run id got from server
- runId string
- // connection or other error happens , control will try to reconnect to server
- closed int32
- // goroutines can block by reading from this channel, it will be closed only in reader() when control connection is closed
- closedCh chan int
- // last time got the Pong message
- lastPong time.Time
- mu sync.RWMutex
- log.Logger
- }
- func NewControl(svr *Service, pxyCfgs map[string]config.ProxyConf) *Control {
- loginMsg := &msg.Login{
- Arch: runtime.GOARCH,
- Os: runtime.GOOS,
- PoolCount: config.ClientCommonCfg.PoolCount,
- User: config.ClientCommonCfg.User,
- Version: version.Full(),
- }
- return &Control{
- svr: svr,
- loginMsg: loginMsg,
- pxyCfgs: pxyCfgs,
- proxies: make(map[string]Proxy),
- sendCh: make(chan msg.Message, 10),
- readCh: make(chan msg.Message, 10),
- closedCh: make(chan int),
- Logger: log.NewPrefixLogger(""),
- }
- }
- // 1. login
- // 2. start reader() writer() manager()
- // 3. connection closed
- // 4. In reader(): close closedCh and exit, controler() get it
- // 5. In controler(): close readCh and sendCh, manager() and writer() will exit
- // 6. In controler(): ini readCh, sendCh, closedCh
- // 7. In controler(): start new reader(), writer(), manager()
- // controler() will keep running
- func (ctl *Control) Run() error {
- err := ctl.login()
- if err != nil {
- return err
- }
- go ctl.controler()
- go ctl.manager()
- go ctl.writer()
- go ctl.reader()
- // send NewProxy message for all configured proxies
- for _, cfg := range ctl.pxyCfgs {
- var newProxyMsg msg.NewProxy
- cfg.UnMarshalToMsg(&newProxyMsg)
- ctl.sendCh <- &newProxyMsg
- }
- return nil
- }
- func (ctl *Control) NewWorkConn() {
- workConn, err := net.ConnectTcpServerByHttpProxy(config.ClientCommonCfg.HttpProxy,
- fmt.Sprintf("%s:%d", config.ClientCommonCfg.ServerAddr, config.ClientCommonCfg.ServerPort))
- if err != nil {
- ctl.Warn("start new work connection error: %v", err)
- return
- }
- m := &msg.NewWorkConn{
- RunId: ctl.runId,
- }
- if err = msg.WriteMsg(workConn, m); err != nil {
- ctl.Warn("work connection write to server error: %v", err)
- workConn.Close()
- return
- }
- var startMsg msg.StartWorkConn
- if err = msg.ReadMsgInto(workConn, &startMsg); err != nil {
- ctl.Error("work connection closed, %v", err)
- workConn.Close()
- return
- }
- workConn.AddLogPrefix(startMsg.ProxyName)
- // dispatch this work connection to related proxy
- if pxy, ok := ctl.proxies[startMsg.ProxyName]; ok {
- go pxy.InWorkConn(workConn)
- workConn.Info("start a new work connection")
- }
- }
- func (ctl *Control) init() {
- ctl.sendCh = make(chan msg.Message, 10)
- ctl.readCh = make(chan msg.Message, 10)
- ctl.closedCh = make(chan int)
- }
- // login send a login message to server and wait for a loginResp message.
- func (ctl *Control) login() (err error) {
- if ctl.conn != nil {
- ctl.conn.Close()
- }
- conn, err := net.ConnectTcpServerByHttpProxy(config.ClientCommonCfg.HttpProxy,
- fmt.Sprintf("%s:%d", config.ClientCommonCfg.ServerAddr, config.ClientCommonCfg.ServerPort))
- if err != nil {
- return err
- }
- now := time.Now().Unix()
- ctl.loginMsg.PrivilegeKey = util.GetAuthKey(config.ClientCommonCfg.PrivilegeToken, now)
- ctl.loginMsg.Timestamp = now
- ctl.loginMsg.RunId = ctl.runId
- if err = msg.WriteMsg(conn, ctl.loginMsg); err != nil {
- return err
- }
- var loginRespMsg msg.LoginResp
- if err = msg.ReadMsgInto(conn, &loginRespMsg); err != nil {
- return err
- }
- if loginRespMsg.Error != "" {
- err = fmt.Errorf("%s", loginRespMsg.Error)
- ctl.Error("%s", loginRespMsg.Error)
- return err
- }
- ctl.conn = conn
- // update runId got from server
- ctl.runId = loginRespMsg.RunId
- ctl.ClearLogPrefix()
- ctl.AddLogPrefix(loginRespMsg.RunId)
- ctl.Info("login to server success, get run id [%s]", loginRespMsg.RunId)
- // login success, so we let closedCh available again
- ctl.closedCh = make(chan int)
- ctl.lastPong = time.Now()
- return nil
- }
- func (ctl *Control) reader() {
- defer func() {
- if err := recover(); err != nil {
- ctl.Error("panic error: %v", err)
- }
- }()
- defer close(ctl.closedCh)
- encReader := crypto.NewReader(ctl.conn, []byte(config.ClientCommonCfg.PrivilegeToken))
- for {
- if m, err := msg.ReadMsg(encReader); err != nil {
- if err == io.EOF {
- ctl.Debug("read from control connection EOF")
- return
- } else {
- ctl.Warn("read error: %v", err)
- continue
- }
- } else {
- ctl.readCh <- m
- }
- }
- }
- func (ctl *Control) writer() {
- encWriter, err := crypto.NewWriter(ctl.conn, []byte(config.ClientCommonCfg.PrivilegeToken))
- if err != nil {
- ctl.conn.Error("crypto new writer error: %v", err)
- ctl.conn.Close()
- return
- }
- for {
- if m, ok := <-ctl.sendCh; !ok {
- ctl.Info("control writer is closing")
- return
- } else {
- if err := msg.WriteMsg(encWriter, m); err != nil {
- ctl.Warn("write message to control connection error: %v", err)
- return
- }
- }
- }
- }
- func (ctl *Control) manager() {
- defer func() {
- if err := recover(); err != nil {
- ctl.Error("panic error: %v", err)
- }
- }()
- hbSend := time.NewTicker(time.Duration(config.ClientCommonCfg.HeartBeatInterval) * time.Second)
- defer hbSend.Stop()
- hbCheck := time.NewTicker(time.Second)
- defer hbCheck.Stop()
- for {
- select {
- case <-hbSend.C:
- // send heartbeat to server
- ctl.sendCh <- &msg.Ping{}
- case <-hbCheck.C:
- if time.Since(ctl.lastPong) > time.Duration(config.ClientCommonCfg.HeartBeatTimeout)*time.Second {
- ctl.Warn("heartbeat timeout")
- return
- }
- case rawMsg, ok := <-ctl.readCh:
- if !ok {
- return
- }
- switch m := rawMsg.(type) {
- case *msg.ReqWorkConn:
- go ctl.NewWorkConn()
- case *msg.NewProxyResp:
- // Server will return NewProxyResp message to each NewProxy message.
- // Start a new proxy handler if no error got
- if m.Error != "" {
- ctl.Warn("[%s] start error: %s", m.ProxyName, m.Error)
- continue
- }
- cfg, ok := ctl.pxyCfgs[m.ProxyName]
- if !ok {
- // it will never go to this branch
- ctl.Warn("[%s] no proxy conf found", m.ProxyName)
- continue
- }
- oldPxy, ok := ctl.proxies[m.ProxyName]
- if ok {
- oldPxy.Close()
- }
- pxy := NewProxy(ctl, cfg)
- if err := pxy.Run(); err != nil {
- ctl.Warn("[%s] proxy start running error: %v", m.ProxyName, err)
- continue
- }
- ctl.proxies[m.ProxyName] = pxy
- ctl.Info("[%s] start proxy success", m.ProxyName)
- case *msg.Pong:
- ctl.lastPong = time.Now()
- }
- }
- }
- }
- // control keep watching closedCh, start a new connection if previous control connection is closed
- func (ctl *Control) controler() {
- var err error
- maxDelayTime := 30 * time.Second
- delayTime := time.Second
- checkInterval := 60 * time.Second
- checkProxyTicker := time.NewTicker(checkInterval)
- for {
- select {
- case <-checkProxyTicker.C:
- // Every 60 seconds, check which proxy registered failed and reregister it to server.
- for _, cfg := range ctl.pxyCfgs {
- if _, exist := ctl.proxies[cfg.GetName()]; !exist {
- ctl.Info("try to reregister proxy [%s]", cfg.GetName())
- var newProxyMsg msg.NewProxy
- cfg.UnMarshalToMsg(&newProxyMsg)
- ctl.sendCh <- &newProxyMsg
- }
- }
- case _, ok := <-ctl.closedCh:
- // we won't get any variable from this channel
- if !ok {
- // close related channels
- close(ctl.readCh)
- close(ctl.sendCh)
- time.Sleep(time.Second)
- // loop util reconnect to server success
- for {
- ctl.Info("try to reconnect to server...")
- err = ctl.login()
- if err != nil {
- ctl.Warn("reconnect to server error: %v", err)
- time.Sleep(delayTime)
- delayTime = delayTime * 2
- if delayTime > maxDelayTime {
- delayTime = maxDelayTime
- }
- continue
- }
- // reconnect success, init the delayTime
- delayTime = time.Second
- break
- }
- // init related channels and variables
- ctl.init()
- // previous work goroutines should be closed and start them here
- go ctl.manager()
- go ctl.writer()
- go ctl.reader()
- // send NewProxy message for all configured proxies
- for _, cfg := range ctl.pxyCfgs {
- var newProxyMsg msg.NewProxy
- cfg.UnMarshalToMsg(&newProxyMsg)
- ctl.sendCh <- &newProxyMsg
- }
- checkProxyTicker.Stop()
- checkProxyTicker = time.NewTicker(checkInterval)
- }
- }
- }
- }
|