frp/server/proxy/proxy.go

290 lines
7.6 KiB
Go
Raw Normal View History

2019-01-15 00:11:08 +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.
package proxy
import (
2019-10-12 20:13:12 +08:00
"context"
2019-01-15 00:11:08 +08:00
"fmt"
"io"
2019-03-29 19:01:18 +08:00
"net"
"strconv"
2019-01-15 00:11:08 +08:00
"sync"
"github.com/fatedier/frp/models/config"
"github.com/fatedier/frp/models/msg"
"github.com/fatedier/frp/server/controller"
"github.com/fatedier/frp/server/metrics"
2019-01-15 00:11:08 +08:00
frpNet "github.com/fatedier/frp/utils/net"
2019-10-12 20:13:12 +08:00
"github.com/fatedier/frp/utils/xlog"
2019-01-15 00:11:08 +08:00
frpIo "github.com/fatedier/golib/io"
)
2019-10-12 20:13:12 +08:00
type GetWorkConnFn func() (net.Conn, error)
2019-01-15 00:11:08 +08:00
type Proxy interface {
2019-10-12 20:13:12 +08:00
Context() context.Context
2019-01-15 00:11:08 +08:00
Run() (remoteAddr string, err error)
GetName() string
GetConf() config.ProxyConf
2019-10-12 20:13:12 +08:00
GetWorkConnFromPool(src, dst net.Addr) (workConn net.Conn, err error)
2019-01-15 00:11:08 +08:00
GetUsedPortsNum() int
Close()
}
type BaseProxy struct {
name string
rc *controller.ResourceController
listeners []net.Listener
usedPortsNum int
poolCount int
getWorkConnFn GetWorkConnFn
serverCfg config.ServerCommonConf
2019-01-15 00:11:08 +08:00
2019-10-12 20:13:12 +08:00
mu sync.RWMutex
xl *xlog.Logger
ctx context.Context
2019-01-15 00:11:08 +08:00
}
func (pxy *BaseProxy) GetName() string {
return pxy.name
}
2019-10-12 20:13:12 +08:00
func (pxy *BaseProxy) Context() context.Context {
return pxy.ctx
}
2019-01-15 00:11:08 +08:00
func (pxy *BaseProxy) GetUsedPortsNum() int {
return pxy.usedPortsNum
}
func (pxy *BaseProxy) Close() {
2019-10-12 20:13:12 +08:00
xl := xlog.FromContextSafe(pxy.ctx)
xl.Info("proxy closing")
2019-01-15 00:11:08 +08:00
for _, l := range pxy.listeners {
l.Close()
}
}
2019-07-31 00:41:58 +08:00
// GetWorkConnFromPool try to get a new work connections from pool
// for quickly response, we immediately send the StartWorkConn message to frpc after take out one from pool
2019-10-12 20:13:12 +08:00
func (pxy *BaseProxy) GetWorkConnFromPool(src, dst net.Addr) (workConn net.Conn, err error) {
xl := xlog.FromContextSafe(pxy.ctx)
2019-01-15 00:11:08 +08:00
// try all connections from the pool
for i := 0; i < pxy.poolCount+1; i++ {
if workConn, err = pxy.getWorkConnFn(); err != nil {
2019-10-12 20:13:12 +08:00
xl.Warn("failed to get work connection: %v", err)
2019-01-15 00:11:08 +08:00
return
}
2019-10-12 20:13:12 +08:00
xl.Info("get a new work connection: [%s]", workConn.RemoteAddr().String())
xl.Spawn().AppendPrefix(pxy.GetName())
workConn = frpNet.NewContextConn(workConn, pxy.ctx)
2019-01-15 00:11:08 +08:00
2019-03-29 19:01:18 +08:00
var (
srcAddr string
dstAddr string
srcPortStr string
dstPortStr string
srcPort int
dstPort int
)
if src != nil {
srcAddr, srcPortStr, _ = net.SplitHostPort(src.String())
srcPort, _ = strconv.Atoi(srcPortStr)
}
if dst != nil {
dstAddr, dstPortStr, _ = net.SplitHostPort(dst.String())
dstPort, _ = strconv.Atoi(dstPortStr)
}
2019-01-15 00:11:08 +08:00
err := msg.WriteMsg(workConn, &msg.StartWorkConn{
ProxyName: pxy.GetName(),
2019-03-29 19:01:18 +08:00
SrcAddr: srcAddr,
SrcPort: uint16(srcPort),
DstAddr: dstAddr,
DstPort: uint16(dstPort),
Error: "",
2019-01-15 00:11:08 +08:00
})
if err != nil {
2019-10-12 20:13:12 +08:00
xl.Warn("failed to send message to work connection from pool: %v, times: %d", err, i)
2019-01-15 00:11:08 +08:00
workConn.Close()
} else {
break
}
}
if err != nil {
2019-10-12 20:13:12 +08:00
xl.Error("try to get work connection failed in the end")
2019-01-15 00:11:08 +08:00
return
}
return
}
// startListenHandler start a goroutine handler for each listener.
// p: p will just be passed to handler(Proxy, frpNet.Conn).
// handler: each proxy type can set different handler function to deal with connections accepted from listeners.
func (pxy *BaseProxy) startListenHandler(p Proxy, handler func(Proxy, net.Conn, config.ServerCommonConf)) {
2019-10-12 20:13:12 +08:00
xl := xlog.FromContextSafe(pxy.ctx)
2019-01-15 00:11:08 +08:00
for _, listener := range pxy.listeners {
2019-10-12 20:13:12 +08:00
go func(l net.Listener) {
2019-01-15 00:11:08 +08:00
for {
// block
// if listener is closed, err returned
c, err := l.Accept()
if err != nil {
2019-10-12 20:13:12 +08:00
xl.Info("listener is closed")
2019-01-15 00:11:08 +08:00
return
}
2019-10-12 20:13:12 +08:00
xl.Debug("get a user connection [%s]", c.RemoteAddr().String())
go handler(p, c, pxy.serverCfg)
2019-01-15 00:11:08 +08:00
}
}(listener)
}
}
func NewProxy(ctx context.Context, runId string, rc *controller.ResourceController, poolCount int,
getWorkConnFn GetWorkConnFn, pxyConf config.ProxyConf, serverCfg config.ServerCommonConf) (pxy Proxy, err error) {
2019-01-15 00:11:08 +08:00
2019-10-12 20:13:12 +08:00
xl := xlog.FromContextSafe(ctx).Spawn().AppendPrefix(pxyConf.GetBaseInfo().ProxyName)
2019-01-15 00:11:08 +08:00
basePxy := BaseProxy{
name: pxyConf.GetBaseInfo().ProxyName,
rc: rc,
listeners: make([]net.Listener, 0),
poolCount: poolCount,
getWorkConnFn: getWorkConnFn,
serverCfg: serverCfg,
xl: xl,
ctx: xlog.NewContext(ctx, xl),
2019-01-15 00:11:08 +08:00
}
switch cfg := pxyConf.(type) {
case *config.TcpProxyConf:
basePxy.usedPortsNum = 1
pxy = &TcpProxy{
2019-01-31 16:49:23 +08:00
BaseProxy: &basePxy,
2019-01-15 00:11:08 +08:00
cfg: cfg,
}
case *config.TcpMuxProxyConf:
pxy = &TcpMuxProxy{
BaseProxy: &basePxy,
cfg: cfg,
}
2019-01-15 00:11:08 +08:00
case *config.HttpProxyConf:
pxy = &HttpProxy{
2019-01-31 16:49:23 +08:00
BaseProxy: &basePxy,
2019-01-15 00:11:08 +08:00
cfg: cfg,
}
case *config.HttpsProxyConf:
pxy = &HttpsProxy{
2019-01-31 16:49:23 +08:00
BaseProxy: &basePxy,
2019-01-15 00:11:08 +08:00
cfg: cfg,
}
case *config.UdpProxyConf:
basePxy.usedPortsNum = 1
pxy = &UdpProxy{
2019-01-31 16:49:23 +08:00
BaseProxy: &basePxy,
2019-01-15 00:11:08 +08:00
cfg: cfg,
}
case *config.StcpProxyConf:
pxy = &StcpProxy{
2019-01-31 16:49:23 +08:00
BaseProxy: &basePxy,
2019-01-15 00:11:08 +08:00
cfg: cfg,
}
case *config.XtcpProxyConf:
pxy = &XtcpProxy{
2019-01-31 16:49:23 +08:00
BaseProxy: &basePxy,
2019-01-15 00:11:08 +08:00
cfg: cfg,
}
default:
return pxy, fmt.Errorf("proxy type not support")
}
return
}
// HandleUserTcpConnection is used for incoming tcp user connections.
// It can be used for tcp, http, https type.
func HandleUserTcpConnection(pxy Proxy, userConn net.Conn, serverCfg config.ServerCommonConf) {
2019-10-12 20:13:12 +08:00
xl := xlog.FromContextSafe(pxy.Context())
2019-01-15 00:11:08 +08:00
defer userConn.Close()
// try all connections from the pool
2019-03-29 19:01:18 +08:00
workConn, err := pxy.GetWorkConnFromPool(userConn.RemoteAddr(), userConn.LocalAddr())
2019-01-15 00:11:08 +08:00
if err != nil {
return
}
defer workConn.Close()
var local io.ReadWriteCloser = workConn
cfg := pxy.GetConf().GetBaseInfo()
2019-10-12 20:13:12 +08:00
xl.Trace("handler user tcp connection, use_encryption: %t, use_compression: %t", cfg.UseEncryption, cfg.UseCompression)
2019-01-15 00:11:08 +08:00
if cfg.UseEncryption {
local, err = frpIo.WithEncryption(local, []byte(serverCfg.Token))
2019-01-15 00:11:08 +08:00
if err != nil {
2019-10-12 20:13:12 +08:00
xl.Error("create encryption stream error: %v", err)
2019-01-15 00:11:08 +08:00
return
}
}
if cfg.UseCompression {
local = frpIo.WithCompression(local)
}
2019-10-12 20:13:12 +08:00
xl.Debug("join connections, workConn(l[%s] r[%s]) userConn(l[%s] r[%s])", workConn.LocalAddr().String(),
2019-01-15 00:11:08 +08:00
workConn.RemoteAddr().String(), userConn.LocalAddr().String(), userConn.RemoteAddr().String())
name := pxy.GetName()
proxyType := pxy.GetConf().GetBaseInfo().ProxyType
metrics.Server.OpenConnection(name, proxyType)
2019-01-15 00:11:08 +08:00
inCount, outCount := frpIo.Join(local, userConn)
metrics.Server.CloseConnection(name, proxyType)
metrics.Server.AddTrafficIn(name, proxyType, inCount)
metrics.Server.AddTrafficOut(name, proxyType, outCount)
2019-10-12 20:13:12 +08:00
xl.Debug("join connections closed")
2019-01-15 00:11:08 +08:00
}
type ProxyManager struct {
// proxies indexed by proxy name
pxys map[string]Proxy
mu sync.RWMutex
}
func NewProxyManager() *ProxyManager {
return &ProxyManager{
pxys: make(map[string]Proxy),
}
}
func (pm *ProxyManager) Add(name string, pxy Proxy) error {
pm.mu.Lock()
defer pm.mu.Unlock()
if _, ok := pm.pxys[name]; ok {
return fmt.Errorf("proxy name [%s] is already in use", name)
}
pm.pxys[name] = pxy
return nil
}
func (pm *ProxyManager) Del(name string) {
pm.mu.Lock()
defer pm.mu.Unlock()
delete(pm.pxys, name)
}
func (pm *ProxyManager) GetByName(name string) (pxy Proxy, ok bool) {
pm.mu.RLock()
defer pm.mu.RUnlock()
pxy, ok = pm.pxys[name]
return
}