frp/server/control.go

427 lines
9.9 KiB
Go
Raw Normal View History

2017-03-23 02:01:25 +08:00
// 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.
2017-03-09 02:03:47 +08:00
package server
import (
"fmt"
"io"
2018-05-11 10:42:57 +08:00
"runtime/debug"
2017-03-09 02:03:47 +08:00
"sync"
"time"
2018-04-10 17:46:49 +08:00
"github.com/fatedier/frp/g"
2017-03-09 02:03:47 +08:00
"github.com/fatedier/frp/models/config"
"github.com/fatedier/frp/models/consts"
2018-05-08 02:13:30 +08:00
frpErr "github.com/fatedier/frp/models/errors"
2017-03-09 02:03:47 +08:00
"github.com/fatedier/frp/models/msg"
"github.com/fatedier/frp/utils/net"
"github.com/fatedier/frp/utils/version"
2018-05-08 02:13:30 +08:00
2018-05-08 23:51:13 +08:00
"github.com/fatedier/golib/control/shutdown"
2018-05-08 02:13:30 +08:00
"github.com/fatedier/golib/crypto"
"github.com/fatedier/golib/errors"
2017-03-09 02:03:47 +08:00
)
type Control struct {
// frps service
svr *Service
// login message
loginMsg *msg.Login
// control connection
conn net.Conn
// put a message in this channel to send it over control connection to client
sendCh chan (msg.Message)
// read from this channel to get the next message sent by client
readCh chan (msg.Message)
// work connections
workConnCh chan net.Conn
// proxies in one client
2017-06-11 17:22:05 +08:00
proxies map[string]Proxy
2017-03-09 02:03:47 +08:00
// pool count
poolCount int
2018-01-26 14:56:55 +08:00
// ports used, for limitations
portsUsedNum int
2017-03-09 02:03:47 +08:00
// last time got the Ping message
lastPing time.Time
// A new run id will be generated when a new client login.
// If run id got from login message has same run id, it means it's the same client, so we can
// replace old controller instantly.
runId string
// control status
status string
readerShutdown *shutdown.Shutdown
writerShutdown *shutdown.Shutdown
managerShutdown *shutdown.Shutdown
allShutdown *shutdown.Shutdown
mu sync.RWMutex
}
func NewControl(svr *Service, ctlConn net.Conn, loginMsg *msg.Login) *Control {
return &Control{
svr: svr,
conn: ctlConn,
loginMsg: loginMsg,
sendCh: make(chan msg.Message, 10),
readCh: make(chan msg.Message, 10),
workConnCh: make(chan net.Conn, loginMsg.PoolCount+10),
2017-06-11 17:22:05 +08:00
proxies: make(map[string]Proxy),
2017-03-09 02:03:47 +08:00
poolCount: loginMsg.PoolCount,
2018-01-26 14:56:55 +08:00
portsUsedNum: 0,
2017-03-09 02:03:47 +08:00
lastPing: time.Now(),
runId: loginMsg.RunId,
status: consts.Working,
readerShutdown: shutdown.New(),
writerShutdown: shutdown.New(),
managerShutdown: shutdown.New(),
allShutdown: shutdown.New(),
}
}
// Start send a login success message to client and start working.
func (ctl *Control) Start() {
2017-03-10 01:42:06 +08:00
loginRespMsg := &msg.LoginResp{
2017-10-24 18:20:07 +08:00
Version: version.Full(),
RunId: ctl.runId,
2018-04-10 17:46:49 +08:00
ServerUdpPort: g.GlbServerCfg.BindUdpPort,
2017-10-24 18:20:07 +08:00
Error: "",
2017-03-09 02:03:47 +08:00
}
2017-03-10 01:42:06 +08:00
msg.WriteMsg(ctl.conn, loginRespMsg)
2017-03-09 02:03:47 +08:00
2017-03-10 01:42:06 +08:00
go ctl.writer()
2017-03-09 02:03:47 +08:00
for i := 0; i < ctl.poolCount; i++ {
ctl.sendCh <- &msg.ReqWorkConn{}
}
go ctl.manager()
go ctl.reader()
go ctl.stoper()
}
func (ctl *Control) RegisterWorkConn(conn net.Conn) {
defer func() {
if err := recover(); err != nil {
ctl.conn.Error("panic error: %v", err)
2018-05-11 10:42:57 +08:00
ctl.conn.Error(string(debug.Stack()))
2017-03-09 02:03:47 +08:00
}
}()
select {
case ctl.workConnCh <- conn:
2017-03-12 02:03:24 +08:00
ctl.conn.Debug("new work connection registered")
2017-03-09 02:03:47 +08:00
default:
2017-03-12 02:03:24 +08:00
ctl.conn.Debug("work connection pool is full, discarding")
2017-03-09 02:03:47 +08:00
conn.Close()
}
}
// When frps get one user connection, we get one work connection from the pool and return it.
// If no workConn available in the pool, send message to frpc to get one or more
// and wait until it is available.
// return an error if wait timeout
func (ctl *Control) GetWorkConn() (workConn net.Conn, err error) {
defer func() {
if err := recover(); err != nil {
ctl.conn.Error("panic error: %v", err)
2018-05-11 10:42:57 +08:00
ctl.conn.Error(string(debug.Stack()))
2017-03-09 02:03:47 +08:00
}
}()
var ok bool
// get a work connection from the pool
select {
case workConn, ok = <-ctl.workConnCh:
if !ok {
2018-05-08 02:13:30 +08:00
err = frpErr.ErrCtlClosed
2017-03-09 02:03:47 +08:00
return
}
ctl.conn.Debug("get work connection from pool")
default:
// no work connections available in the poll, send message to frpc to get more
err = errors.PanicToError(func() {
ctl.sendCh <- &msg.ReqWorkConn{}
})
if err != nil {
ctl.conn.Error("%v", err)
return
}
select {
case workConn, ok = <-ctl.workConnCh:
if !ok {
2018-05-08 02:13:30 +08:00
err = frpErr.ErrCtlClosed
2017-03-13 02:44:47 +08:00
ctl.conn.Warn("no work connections avaiable, %v", err)
2017-03-09 02:03:47 +08:00
return
}
2018-04-10 17:46:49 +08:00
case <-time.After(time.Duration(g.GlbServerCfg.UserConnTimeout) * time.Second):
2017-03-09 02:03:47 +08:00
err = fmt.Errorf("timeout trying to get work connection")
ctl.conn.Warn("%v", err)
return
}
}
// When we get a work connection from pool, replace it with a new one.
errors.PanicToError(func() {
ctl.sendCh <- &msg.ReqWorkConn{}
})
return
}
func (ctl *Control) Replaced(newCtl *Control) {
ctl.conn.Info("Replaced by client [%s]", newCtl.runId)
ctl.runId = ""
ctl.allShutdown.Start()
}
func (ctl *Control) writer() {
defer func() {
if err := recover(); err != nil {
ctl.conn.Error("panic error: %v", err)
2018-05-11 10:42:57 +08:00
ctl.conn.Error(string(debug.Stack()))
2017-03-09 02:03:47 +08:00
}
}()
defer ctl.allShutdown.Start()
defer ctl.writerShutdown.Done()
2018-04-10 17:46:49 +08:00
encWriter, err := crypto.NewWriter(ctl.conn, []byte(g.GlbServerCfg.Token))
2017-03-10 01:42:06 +08:00
if err != nil {
ctl.conn.Error("crypto new writer error: %v", err)
ctl.allShutdown.Start()
return
}
2017-03-09 02:03:47 +08:00
for {
if m, ok := <-ctl.sendCh; !ok {
ctl.conn.Info("control writer is closing")
return
} else {
2017-03-10 01:42:06 +08:00
if err := msg.WriteMsg(encWriter, m); err != nil {
2017-03-09 02:03:47 +08:00
ctl.conn.Warn("write message to control connection error: %v", err)
return
}
}
}
}
func (ctl *Control) reader() {
defer func() {
if err := recover(); err != nil {
ctl.conn.Error("panic error: %v", err)
2018-05-11 10:42:57 +08:00
ctl.conn.Error(string(debug.Stack()))
2017-03-09 02:03:47 +08:00
}
}()
defer ctl.allShutdown.Start()
defer ctl.readerShutdown.Done()
2018-04-10 17:46:49 +08:00
encReader := crypto.NewReader(ctl.conn, []byte(g.GlbServerCfg.Token))
2017-03-09 02:03:47 +08:00
for {
2017-03-10 01:42:06 +08:00
if m, err := msg.ReadMsg(encReader); err != nil {
2017-03-09 02:03:47 +08:00
if err == io.EOF {
ctl.conn.Debug("control connection closed")
return
} else {
ctl.conn.Warn("read error: %v", err)
return
}
} else {
ctl.readCh <- m
}
}
}
func (ctl *Control) stoper() {
defer func() {
if err := recover(); err != nil {
ctl.conn.Error("panic error: %v", err)
2018-05-11 10:42:57 +08:00
ctl.conn.Error(string(debug.Stack()))
2017-03-09 02:03:47 +08:00
}
}()
ctl.allShutdown.WaitStart()
close(ctl.readCh)
2018-01-17 01:09:33 +08:00
ctl.managerShutdown.WaitDone()
2017-03-09 02:03:47 +08:00
close(ctl.sendCh)
2018-01-17 01:09:33 +08:00
ctl.writerShutdown.WaitDone()
2017-03-09 02:03:47 +08:00
ctl.conn.Close()
2018-01-17 01:09:33 +08:00
ctl.readerShutdown.WaitDone()
2017-03-09 02:03:47 +08:00
2018-03-19 20:22:15 +08:00
ctl.mu.Lock()
defer ctl.mu.Unlock()
2017-03-09 02:03:47 +08:00
close(ctl.workConnCh)
for workConn := range ctl.workConnCh {
workConn.Close()
}
for _, pxy := range ctl.proxies {
pxy.Close()
2017-03-13 02:44:47 +08:00
ctl.svr.DelProxy(pxy.GetName())
StatsCloseProxy(pxy.GetName(), pxy.GetConf().GetBaseInfo().ProxyType)
2017-03-09 02:03:47 +08:00
}
ctl.allShutdown.Done()
2017-03-10 02:01:17 +08:00
ctl.conn.Info("client exit success")
2017-03-23 02:01:25 +08:00
StatsCloseClient()
2017-03-09 02:03:47 +08:00
}
func (ctl *Control) manager() {
defer func() {
if err := recover(); err != nil {
ctl.conn.Error("panic error: %v", err)
2018-05-11 10:42:57 +08:00
ctl.conn.Error(string(debug.Stack()))
2017-03-09 02:03:47 +08:00
}
}()
defer ctl.allShutdown.Start()
defer ctl.managerShutdown.Done()
heartbeat := time.NewTicker(time.Second)
defer heartbeat.Stop()
for {
select {
case <-heartbeat.C:
2018-04-10 17:46:49 +08:00
if time.Since(ctl.lastPing) > time.Duration(g.GlbServerCfg.HeartBeatTimeout)*time.Second {
2017-03-09 02:03:47 +08:00
ctl.conn.Warn("heartbeat timeout")
2018-03-19 20:22:15 +08:00
return
2017-03-09 02:03:47 +08:00
}
case rawMsg, ok := <-ctl.readCh:
if !ok {
return
}
switch m := rawMsg.(type) {
case *msg.NewProxy:
// register proxy in this control
2018-01-17 14:40:08 +08:00
remoteAddr, err := ctl.RegisterProxy(m)
2017-03-09 02:03:47 +08:00
resp := &msg.NewProxyResp{
ProxyName: m.ProxyName,
}
if err != nil {
resp.Error = err.Error()
ctl.conn.Warn("new proxy [%s] error: %v", m.ProxyName, err)
} else {
2018-01-17 14:40:08 +08:00
resp.RemoteAddr = remoteAddr
2017-03-09 02:03:47 +08:00
ctl.conn.Info("new proxy [%s] success", m.ProxyName)
2017-03-23 02:01:25 +08:00
StatsNewProxy(m.ProxyName, m.ProxyType)
2017-03-09 02:03:47 +08:00
}
ctl.sendCh <- resp
2017-06-11 17:22:05 +08:00
case *msg.CloseProxy:
ctl.CloseProxy(m)
ctl.conn.Info("close proxy [%s] success", m.ProxyName)
2017-03-09 02:03:47 +08:00
case *msg.Ping:
ctl.lastPing = time.Now()
2017-03-27 17:25:25 +08:00
ctl.conn.Debug("receive heartbeat")
2017-03-09 02:03:47 +08:00
ctl.sendCh <- &msg.Pong{}
}
}
}
}
2018-01-17 14:40:08 +08:00
func (ctl *Control) RegisterProxy(pxyMsg *msg.NewProxy) (remoteAddr string, err error) {
2017-03-09 02:03:47 +08:00
var pxyConf config.ProxyConf
// Load configures from NewProxy message and check.
2018-04-10 17:46:49 +08:00
pxyConf, err = config.NewProxyConfFromMsg(pxyMsg)
2017-03-09 02:03:47 +08:00
if err != nil {
2018-01-17 14:40:08 +08:00
return
2017-03-09 02:03:47 +08:00
}
// NewProxy will return a interface Proxy.
// In fact it create different proxies by different proxy type, we just call run() here.
pxy, err := NewProxy(ctl, pxyConf)
if err != nil {
2018-01-17 14:40:08 +08:00
return remoteAddr, err
2017-03-09 02:03:47 +08:00
}
2018-01-26 14:56:55 +08:00
// Check ports used number in each client
2018-04-10 17:46:49 +08:00
if g.GlbServerCfg.MaxPortsPerClient > 0 {
2018-01-26 14:56:55 +08:00
ctl.mu.Lock()
2018-04-10 17:46:49 +08:00
if ctl.portsUsedNum+pxy.GetUsedPortsNum() > int(g.GlbServerCfg.MaxPortsPerClient) {
2018-01-26 14:56:55 +08:00
ctl.mu.Unlock()
err = fmt.Errorf("exceed the max_ports_per_client")
return
}
ctl.portsUsedNum = ctl.portsUsedNum + pxy.GetUsedPortsNum()
ctl.mu.Unlock()
defer func() {
if err != nil {
ctl.mu.Lock()
ctl.portsUsedNum = ctl.portsUsedNum - pxy.GetUsedPortsNum()
ctl.mu.Unlock()
}
}()
}
2018-01-17 14:40:08 +08:00
remoteAddr, err = pxy.Run()
2017-03-09 02:03:47 +08:00
if err != nil {
2018-01-17 14:40:08 +08:00
return
2017-03-09 02:03:47 +08:00
}
defer func() {
if err != nil {
pxy.Close()
}
}()
err = ctl.svr.RegisterProxy(pxyMsg.ProxyName, pxy)
if err != nil {
2018-01-17 14:40:08 +08:00
return
2017-03-09 02:03:47 +08:00
}
2017-06-11 17:22:05 +08:00
ctl.mu.Lock()
ctl.proxies[pxy.GetName()] = pxy
ctl.mu.Unlock()
2018-01-17 14:40:08 +08:00
return
2017-03-09 02:03:47 +08:00
}
2017-06-11 17:22:05 +08:00
func (ctl *Control) CloseProxy(closeMsg *msg.CloseProxy) (err error) {
ctl.mu.Lock()
pxy, ok := ctl.proxies[closeMsg.ProxyName]
if !ok {
2018-01-26 14:56:55 +08:00
ctl.mu.Unlock()
2017-06-11 17:22:05 +08:00
return
}
2018-04-10 17:46:49 +08:00
if g.GlbServerCfg.MaxPortsPerClient > 0 {
2018-01-26 14:56:55 +08:00
ctl.portsUsedNum = ctl.portsUsedNum - pxy.GetUsedPortsNum()
}
2017-06-11 17:22:05 +08:00
pxy.Close()
ctl.svr.DelProxy(pxy.GetName())
2017-06-27 01:59:30 +08:00
delete(ctl.proxies, closeMsg.ProxyName)
2018-01-26 14:56:55 +08:00
ctl.mu.Unlock()
2017-06-11 17:22:05 +08:00
StatsCloseProxy(pxy.GetName(), pxy.GetConf().GetBaseInfo().ProxyType)
return
}