frp/server/proxy/udp.go

244 lines
6.2 KiB
Go
Raw Normal View History

2019-01-15 00:11:08 +08:00
// Copyright 2019 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 (
"context"
"fmt"
2020-09-07 14:57:23 +08:00
"io"
2019-01-15 00:11:08 +08:00
"net"
"time"
2020-09-23 13:49:14 +08:00
"github.com/fatedier/frp/pkg/config"
"github.com/fatedier/frp/pkg/msg"
"github.com/fatedier/frp/pkg/proto/udp"
frpNet "github.com/fatedier/frp/pkg/util/net"
"github.com/fatedier/frp/server/metrics"
2019-01-15 00:11:08 +08:00
"github.com/fatedier/golib/errors"
2020-09-07 14:57:23 +08:00
frpIo "github.com/fatedier/golib/io"
2019-01-15 00:11:08 +08:00
)
2020-05-24 17:48:37 +08:00
type UDPProxy struct {
2019-01-31 16:49:23 +08:00
*BaseProxy
2020-05-24 17:48:37 +08:00
cfg *config.UDPProxyConf
2019-01-15 00:11:08 +08:00
realPort int
// udpConn is the listener of udp packages
udpConn *net.UDPConn
// there are always only one workConn at the same time
// get another one if it closed
workConn net.Conn
// sendCh is used for sending packages to workConn
2020-05-24 17:48:37 +08:00
sendCh chan *msg.UDPPacket
2019-01-15 00:11:08 +08:00
// readCh is used for reading packages from workConn
2020-05-24 17:48:37 +08:00
readCh chan *msg.UDPPacket
2019-01-15 00:11:08 +08:00
// checkCloseCh is used for watching if workConn is closed
checkCloseCh chan int
isClosed bool
}
2020-05-24 17:48:37 +08:00
func (pxy *UDPProxy) Run() (remoteAddr string, err error) {
2019-10-12 20:13:12 +08:00
xl := pxy.xl
2020-05-24 17:48:37 +08:00
pxy.realPort, err = pxy.rc.UDPPortManager.Acquire(pxy.name, pxy.cfg.RemotePort)
2019-01-15 00:11:08 +08:00
if err != nil {
return
}
defer func() {
if err != nil {
2020-05-24 17:48:37 +08:00
pxy.rc.UDPPortManager.Release(pxy.realPort)
2019-01-15 00:11:08 +08:00
}
}()
remoteAddr = fmt.Sprintf(":%d", pxy.realPort)
pxy.cfg.RemotePort = pxy.realPort
addr, errRet := net.ResolveUDPAddr("udp", fmt.Sprintf("%s:%d", pxy.serverCfg.ProxyBindAddr, pxy.realPort))
2019-01-15 00:11:08 +08:00
if errRet != nil {
err = errRet
return
}
udpConn, errRet := net.ListenUDP("udp", addr)
if errRet != nil {
err = errRet
2019-10-12 20:13:12 +08:00
xl.Warn("listen udp port error: %v", err)
2019-01-15 00:11:08 +08:00
return
}
2019-10-12 20:13:12 +08:00
xl.Info("udp proxy listen port [%d]", pxy.cfg.RemotePort)
2019-01-15 00:11:08 +08:00
pxy.udpConn = udpConn
2020-05-24 17:48:37 +08:00
pxy.sendCh = make(chan *msg.UDPPacket, 1024)
pxy.readCh = make(chan *msg.UDPPacket, 1024)
2019-01-15 00:11:08 +08:00
pxy.checkCloseCh = make(chan int)
// read message from workConn, if it returns any error, notify proxy to start a new workConn
workConnReaderFn := func(conn net.Conn) {
for {
var (
rawMsg msg.Message
errRet error
)
2019-10-12 20:13:12 +08:00
xl.Trace("loop waiting message from udp workConn")
2019-01-15 00:11:08 +08:00
// client will send heartbeat in workConn for keeping alive
conn.SetReadDeadline(time.Now().Add(time.Duration(60) * time.Second))
if rawMsg, errRet = msg.ReadMsg(conn); errRet != nil {
2019-10-12 20:13:12 +08:00
xl.Warn("read from workConn for udp error: %v", errRet)
2019-01-15 00:11:08 +08:00
conn.Close()
// notify proxy to start a new work connection
// ignore error here, it means the proxy is closed
errors.PanicToError(func() {
pxy.checkCloseCh <- 1
})
return
}
conn.SetReadDeadline(time.Time{})
switch m := rawMsg.(type) {
case *msg.Ping:
2019-10-12 20:13:12 +08:00
xl.Trace("udp work conn get ping message")
2019-01-15 00:11:08 +08:00
continue
2020-05-24 17:48:37 +08:00
case *msg.UDPPacket:
2019-01-15 00:11:08 +08:00
if errRet := errors.PanicToError(func() {
2019-10-12 20:13:12 +08:00
xl.Trace("get udp message from workConn: %s", m.Content)
2019-01-15 00:11:08 +08:00
pxy.readCh <- m
metrics.Server.AddTrafficOut(
pxy.GetName(),
pxy.GetConf().GetBaseInfo().ProxyType,
int64(len(m.Content)),
)
2019-01-15 00:11:08 +08:00
}); errRet != nil {
conn.Close()
2019-10-12 20:13:12 +08:00
xl.Info("reader goroutine for udp work connection closed")
2019-01-15 00:11:08 +08:00
return
}
}
}
}
// send message to workConn
workConnSenderFn := func(conn net.Conn, ctx context.Context) {
var errRet error
for {
select {
case udpMsg, ok := <-pxy.sendCh:
if !ok {
2019-10-12 20:13:12 +08:00
xl.Info("sender goroutine for udp work connection closed")
2019-01-15 00:11:08 +08:00
return
}
if errRet = msg.WriteMsg(conn, udpMsg); errRet != nil {
2019-10-12 20:13:12 +08:00
xl.Info("sender goroutine for udp work connection closed: %v", errRet)
2019-01-15 00:11:08 +08:00
conn.Close()
return
}
2020-05-24 17:48:37 +08:00
xl.Trace("send message to udp workConn: %s", udpMsg.Content)
metrics.Server.AddTrafficIn(
pxy.GetName(),
pxy.GetConf().GetBaseInfo().ProxyType,
int64(len(udpMsg.Content)),
)
continue
2019-01-15 00:11:08 +08:00
case <-ctx.Done():
2019-10-12 20:13:12 +08:00
xl.Info("sender goroutine for udp work connection closed")
2019-01-15 00:11:08 +08:00
return
}
}
}
go func() {
// Sleep a while for waiting control send the NewProxyResp to client.
time.Sleep(500 * time.Millisecond)
for {
2019-03-29 19:01:18 +08:00
workConn, err := pxy.GetWorkConnFromPool(nil, nil)
2019-01-15 00:11:08 +08:00
if err != nil {
time.Sleep(1 * time.Second)
// check if proxy is closed
select {
case _, ok := <-pxy.checkCloseCh:
if !ok {
return
}
default:
}
continue
}
2020-09-07 14:57:23 +08:00
// close the old workConn and replace it with a new one
2019-01-15 00:11:08 +08:00
if pxy.workConn != nil {
pxy.workConn.Close()
}
2020-09-07 14:57:23 +08:00
var rwc io.ReadWriteCloser = workConn
if pxy.cfg.UseEncryption {
rwc, err = frpIo.WithEncryption(rwc, []byte(pxy.serverCfg.Token))
if err != nil {
xl.Error("create encryption stream error: %v", err)
workConn.Close()
continue
}
}
if pxy.cfg.UseCompression {
rwc = frpIo.WithCompression(rwc)
}
pxy.workConn = frpNet.WrapReadWriteCloserToConn(rwc, workConn)
2019-01-15 00:11:08 +08:00
ctx, cancel := context.WithCancel(context.Background())
2020-09-07 14:57:23 +08:00
go workConnReaderFn(pxy.workConn)
go workConnSenderFn(pxy.workConn, ctx)
2019-01-15 00:11:08 +08:00
_, ok := <-pxy.checkCloseCh
cancel()
if !ok {
return
}
}
}()
// Read from user connections and send wrapped udp message to sendCh (forwarded by workConn).
// Client will transfor udp message to local udp service and waiting for response for a while.
// Response will be wrapped to be forwarded by work connection to server.
// Close readCh and sendCh at the end.
go func() {
2020-05-24 17:48:37 +08:00
udp.ForwardUserConn(udpConn, pxy.readCh, pxy.sendCh, int(pxy.serverCfg.UDPPacketSize))
2019-01-15 00:11:08 +08:00
pxy.Close()
}()
return remoteAddr, nil
}
2020-05-24 17:48:37 +08:00
func (pxy *UDPProxy) GetConf() config.ProxyConf {
2019-01-15 00:11:08 +08:00
return pxy.cfg
}
2020-05-24 17:48:37 +08:00
func (pxy *UDPProxy) Close() {
2019-01-15 00:11:08 +08:00
pxy.mu.Lock()
defer pxy.mu.Unlock()
if !pxy.isClosed {
pxy.isClosed = true
pxy.BaseProxy.Close()
if pxy.workConn != nil {
pxy.workConn.Close()
}
pxy.udpConn.Close()
// all channels only closed here
close(pxy.checkCloseCh)
close(pxy.readCh)
close(pxy.sendCh)
}
2020-05-24 17:48:37 +08:00
pxy.rc.UDPPortManager.Release(pxy.realPort)
2019-01-15 00:11:08 +08:00
}