123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554 |
- // 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 (
- "bytes"
- "context"
- "fmt"
- "io"
- "net"
- "strconv"
- "sync"
- "time"
- "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/pkg/util/util"
- "github.com/fatedier/frp/pkg/util/xlog"
- "github.com/fatedier/golib/errors"
- frpIo "github.com/fatedier/golib/io"
- "github.com/fatedier/golib/pool"
- fmux "github.com/hashicorp/yamux"
- )
- // Visitor is used for forward traffics from local port tot remote service.
- type Visitor interface {
- Run() error
- Close()
- }
- func NewVisitor(ctx context.Context, ctl *Control, cfg config.VisitorConf) (visitor Visitor) {
- xl := xlog.FromContextSafe(ctx).Spawn().AppendPrefix(cfg.GetBaseInfo().ProxyName)
- baseVisitor := BaseVisitor{
- ctl: ctl,
- ctx: xlog.NewContext(ctx, xl),
- }
- switch cfg := cfg.(type) {
- case *config.STCPVisitorConf:
- visitor = &STCPVisitor{
- BaseVisitor: &baseVisitor,
- cfg: cfg,
- }
- case *config.XTCPVisitorConf:
- visitor = &XTCPVisitor{
- BaseVisitor: &baseVisitor,
- cfg: cfg,
- }
- case *config.SUDPVisitorConf:
- visitor = &SUDPVisitor{
- BaseVisitor: &baseVisitor,
- cfg: cfg,
- checkCloseCh: make(chan struct{}),
- }
- }
- return
- }
- type BaseVisitor struct {
- ctl *Control
- l net.Listener
- closed bool
- mu sync.RWMutex
- ctx context.Context
- }
- type STCPVisitor struct {
- *BaseVisitor
- cfg *config.STCPVisitorConf
- }
- func (sv *STCPVisitor) Run() (err error) {
- sv.l, err = net.Listen("tcp", net.JoinHostPort(sv.cfg.BindAddr, strconv.Itoa(sv.cfg.BindPort)))
- if err != nil {
- return
- }
- go sv.worker()
- return
- }
- func (sv *STCPVisitor) Close() {
- sv.l.Close()
- }
- func (sv *STCPVisitor) worker() {
- xl := xlog.FromContextSafe(sv.ctx)
- for {
- conn, err := sv.l.Accept()
- if err != nil {
- xl.Warn("stcp local listener closed")
- return
- }
- go sv.handleConn(conn)
- }
- }
- func (sv *STCPVisitor) handleConn(userConn net.Conn) {
- xl := xlog.FromContextSafe(sv.ctx)
- defer userConn.Close()
- xl.Debug("get a new stcp user connection")
- visitorConn, err := sv.ctl.connectServer()
- if err != nil {
- return
- }
- defer visitorConn.Close()
- now := time.Now().Unix()
- newVisitorConnMsg := &msg.NewVisitorConn{
- ProxyName: sv.cfg.ServerName,
- SignKey: util.GetAuthKey(sv.cfg.Sk, now),
- Timestamp: now,
- UseEncryption: sv.cfg.UseEncryption,
- UseCompression: sv.cfg.UseCompression,
- }
- err = msg.WriteMsg(visitorConn, newVisitorConnMsg)
- if err != nil {
- xl.Warn("send newVisitorConnMsg to server error: %v", err)
- return
- }
- var newVisitorConnRespMsg msg.NewVisitorConnResp
- visitorConn.SetReadDeadline(time.Now().Add(10 * time.Second))
- err = msg.ReadMsgInto(visitorConn, &newVisitorConnRespMsg)
- if err != nil {
- xl.Warn("get newVisitorConnRespMsg error: %v", err)
- return
- }
- visitorConn.SetReadDeadline(time.Time{})
- if newVisitorConnRespMsg.Error != "" {
- xl.Warn("start new visitor connection error: %s", newVisitorConnRespMsg.Error)
- return
- }
- var remote io.ReadWriteCloser
- remote = visitorConn
- if sv.cfg.UseEncryption {
- remote, err = frpIo.WithEncryption(remote, []byte(sv.cfg.Sk))
- if err != nil {
- xl.Error("create encryption stream error: %v", err)
- return
- }
- }
- if sv.cfg.UseCompression {
- remote = frpIo.WithCompression(remote)
- }
- frpIo.Join(userConn, remote)
- }
- type XTCPVisitor struct {
- *BaseVisitor
- cfg *config.XTCPVisitorConf
- }
- func (sv *XTCPVisitor) Run() (err error) {
- sv.l, err = net.Listen("tcp", net.JoinHostPort(sv.cfg.BindAddr, strconv.Itoa(sv.cfg.BindPort)))
- if err != nil {
- return
- }
- go sv.worker()
- return
- }
- func (sv *XTCPVisitor) Close() {
- sv.l.Close()
- }
- func (sv *XTCPVisitor) worker() {
- xl := xlog.FromContextSafe(sv.ctx)
- for {
- conn, err := sv.l.Accept()
- if err != nil {
- xl.Warn("xtcp local listener closed")
- return
- }
- go sv.handleConn(conn)
- }
- }
- func (sv *XTCPVisitor) handleConn(userConn net.Conn) {
- xl := xlog.FromContextSafe(sv.ctx)
- defer userConn.Close()
- xl.Debug("get a new xtcp user connection")
- if sv.ctl.serverUDPPort == 0 {
- xl.Error("xtcp is not supported by server")
- return
- }
- raddr, err := net.ResolveUDPAddr("udp",
- fmt.Sprintf("%s:%d", sv.ctl.clientCfg.ServerAddr, sv.ctl.serverUDPPort))
- if err != nil {
- xl.Error("resolve server UDP addr error")
- return
- }
- visitorConn, err := net.DialUDP("udp", nil, raddr)
- if err != nil {
- xl.Warn("dial server udp addr error: %v", err)
- return
- }
- defer visitorConn.Close()
- now := time.Now().Unix()
- natHoleVisitorMsg := &msg.NatHoleVisitor{
- ProxyName: sv.cfg.ServerName,
- SignKey: util.GetAuthKey(sv.cfg.Sk, now),
- Timestamp: now,
- }
- err = msg.WriteMsg(visitorConn, natHoleVisitorMsg)
- if err != nil {
- xl.Warn("send natHoleVisitorMsg to server error: %v", err)
- return
- }
- // Wait for client address at most 10 seconds.
- var natHoleRespMsg msg.NatHoleResp
- visitorConn.SetReadDeadline(time.Now().Add(10 * time.Second))
- buf := pool.GetBuf(1024)
- n, err := visitorConn.Read(buf)
- if err != nil {
- xl.Warn("get natHoleRespMsg error: %v", err)
- return
- }
- err = msg.ReadMsgInto(bytes.NewReader(buf[:n]), &natHoleRespMsg)
- if err != nil {
- xl.Warn("get natHoleRespMsg error: %v", err)
- return
- }
- visitorConn.SetReadDeadline(time.Time{})
- pool.PutBuf(buf)
- if natHoleRespMsg.Error != "" {
- xl.Error("natHoleRespMsg get error info: %s", natHoleRespMsg.Error)
- return
- }
- xl.Trace("get natHoleRespMsg, sid [%s], client address [%s], visitor address [%s]", natHoleRespMsg.Sid, natHoleRespMsg.ClientAddr, natHoleRespMsg.VisitorAddr)
- // Close visitorConn, so we can use it's local address.
- visitorConn.Close()
- // send sid message to client
- laddr, _ := net.ResolveUDPAddr("udp", visitorConn.LocalAddr().String())
- daddr, err := net.ResolveUDPAddr("udp", natHoleRespMsg.ClientAddr)
- if err != nil {
- xl.Error("resolve client udp address error: %v", err)
- return
- }
- lConn, err := net.DialUDP("udp", laddr, daddr)
- if err != nil {
- xl.Error("dial client udp address error: %v", err)
- return
- }
- defer lConn.Close()
- lConn.Write([]byte(natHoleRespMsg.Sid))
- // read ack sid from client
- sidBuf := pool.GetBuf(1024)
- lConn.SetReadDeadline(time.Now().Add(8 * time.Second))
- n, err = lConn.Read(sidBuf)
- if err != nil {
- xl.Warn("get sid from client error: %v", err)
- return
- }
- lConn.SetReadDeadline(time.Time{})
- if string(sidBuf[:n]) != natHoleRespMsg.Sid {
- xl.Warn("incorrect sid from client")
- return
- }
- pool.PutBuf(sidBuf)
- xl.Info("nat hole connection make success, sid [%s]", natHoleRespMsg.Sid)
- // wrap kcp connection
- var remote io.ReadWriteCloser
- remote, err = frpNet.NewKCPConnFromUDP(lConn, true, natHoleRespMsg.ClientAddr)
- if err != nil {
- xl.Error("create kcp connection from udp connection error: %v", err)
- return
- }
- fmuxCfg := fmux.DefaultConfig()
- fmuxCfg.KeepAliveInterval = 5 * time.Second
- fmuxCfg.LogOutput = io.Discard
- sess, err := fmux.Client(remote, fmuxCfg)
- if err != nil {
- xl.Error("create yamux session error: %v", err)
- return
- }
- defer sess.Close()
- muxConn, err := sess.Open()
- if err != nil {
- xl.Error("open yamux stream error: %v", err)
- return
- }
- var muxConnRWCloser io.ReadWriteCloser = muxConn
- if sv.cfg.UseEncryption {
- muxConnRWCloser, err = frpIo.WithEncryption(muxConnRWCloser, []byte(sv.cfg.Sk))
- if err != nil {
- xl.Error("create encryption stream error: %v", err)
- return
- }
- }
- if sv.cfg.UseCompression {
- muxConnRWCloser = frpIo.WithCompression(muxConnRWCloser)
- }
- frpIo.Join(userConn, muxConnRWCloser)
- xl.Debug("join connections closed")
- }
- type SUDPVisitor struct {
- *BaseVisitor
- checkCloseCh chan struct{}
- // udpConn is the listener of udp packet
- udpConn *net.UDPConn
- readCh chan *msg.UDPPacket
- sendCh chan *msg.UDPPacket
- cfg *config.SUDPVisitorConf
- }
- // SUDP Run start listen a udp port
- func (sv *SUDPVisitor) Run() (err error) {
- xl := xlog.FromContextSafe(sv.ctx)
- addr, err := net.ResolveUDPAddr("udp", net.JoinHostPort(sv.cfg.BindAddr, strconv.Itoa(sv.cfg.BindPort)))
- if err != nil {
- return fmt.Errorf("sudp ResolveUDPAddr error: %v", err)
- }
- sv.udpConn, err = net.ListenUDP("udp", addr)
- if err != nil {
- return fmt.Errorf("listen udp port %s error: %v", addr.String(), err)
- }
- sv.sendCh = make(chan *msg.UDPPacket, 1024)
- sv.readCh = make(chan *msg.UDPPacket, 1024)
- xl.Info("sudp start to work, listen on %s", addr)
- go sv.dispatcher()
- go udp.ForwardUserConn(sv.udpConn, sv.readCh, sv.sendCh, int(sv.ctl.clientCfg.UDPPacketSize))
- return
- }
- func (sv *SUDPVisitor) dispatcher() {
- xl := xlog.FromContextSafe(sv.ctx)
- for {
- // loop for get frpc to frps tcp conn
- // setup worker
- // wait worker to finished
- // retry or exit
- visitorConn, err := sv.getNewVisitorConn()
- if err != nil {
- // check if proxy is closed
- // if checkCloseCh is close, we will return, other case we will continue to reconnect
- select {
- case <-sv.checkCloseCh:
- xl.Info("frpc sudp visitor proxy is closed")
- return
- default:
- }
- time.Sleep(3 * time.Second)
- xl.Warn("newVisitorConn to frps error: %v, try to reconnect", err)
- continue
- }
- sv.worker(visitorConn)
- select {
- case <-sv.checkCloseCh:
- return
- default:
- }
- }
- }
- func (sv *SUDPVisitor) worker(workConn net.Conn) {
- xl := xlog.FromContextSafe(sv.ctx)
- xl.Debug("starting sudp proxy worker")
- wg := &sync.WaitGroup{}
- wg.Add(2)
- closeCh := make(chan struct{})
- // udp service -> frpc -> frps -> frpc visitor -> user
- workConnReaderFn := func(conn net.Conn) {
- defer func() {
- conn.Close()
- close(closeCh)
- wg.Done()
- }()
- for {
- var (
- rawMsg msg.Message
- errRet error
- )
- // frpc will send heartbeat in workConn to frpc visitor for keeping alive
- conn.SetReadDeadline(time.Now().Add(60 * time.Second))
- if rawMsg, errRet = msg.ReadMsg(conn); errRet != nil {
- xl.Warn("read from workconn for user udp conn error: %v", errRet)
- return
- }
- conn.SetReadDeadline(time.Time{})
- switch m := rawMsg.(type) {
- case *msg.Ping:
- xl.Debug("frpc visitor get ping message from frpc")
- continue
- case *msg.UDPPacket:
- if errRet := errors.PanicToError(func() {
- sv.readCh <- m
- xl.Trace("frpc visitor get udp packet from workConn: %s", m.Content)
- }); errRet != nil {
- xl.Info("reader goroutine for udp work connection closed")
- return
- }
- }
- }
- }
- // udp service <- frpc <- frps <- frpc visitor <- user
- workConnSenderFn := func(conn net.Conn) {
- defer func() {
- conn.Close()
- wg.Done()
- }()
- var errRet error
- for {
- select {
- case udpMsg, ok := <-sv.sendCh:
- if !ok {
- xl.Info("sender goroutine for udp work connection closed")
- return
- }
- if errRet = msg.WriteMsg(conn, udpMsg); errRet != nil {
- xl.Warn("sender goroutine for udp work connection closed: %v", errRet)
- return
- }
- xl.Trace("send udp package to workConn: %s", udpMsg.Content)
- case <-closeCh:
- return
- }
- }
- }
- go workConnReaderFn(workConn)
- go workConnSenderFn(workConn)
- wg.Wait()
- xl.Info("sudp worker is closed")
- }
- func (sv *SUDPVisitor) getNewVisitorConn() (net.Conn, error) {
- xl := xlog.FromContextSafe(sv.ctx)
- visitorConn, err := sv.ctl.connectServer()
- if err != nil {
- return nil, fmt.Errorf("frpc connect frps error: %v", err)
- }
- now := time.Now().Unix()
- newVisitorConnMsg := &msg.NewVisitorConn{
- ProxyName: sv.cfg.ServerName,
- SignKey: util.GetAuthKey(sv.cfg.Sk, now),
- Timestamp: now,
- UseEncryption: sv.cfg.UseEncryption,
- UseCompression: sv.cfg.UseCompression,
- }
- err = msg.WriteMsg(visitorConn, newVisitorConnMsg)
- if err != nil {
- return nil, fmt.Errorf("frpc send newVisitorConnMsg to frps error: %v", err)
- }
- var newVisitorConnRespMsg msg.NewVisitorConnResp
- visitorConn.SetReadDeadline(time.Now().Add(10 * time.Second))
- err = msg.ReadMsgInto(visitorConn, &newVisitorConnRespMsg)
- if err != nil {
- return nil, fmt.Errorf("frpc read newVisitorConnRespMsg error: %v", err)
- }
- visitorConn.SetReadDeadline(time.Time{})
- if newVisitorConnRespMsg.Error != "" {
- return nil, fmt.Errorf("start new visitor connection error: %s", newVisitorConnRespMsg.Error)
- }
- var remote io.ReadWriteCloser
- remote = visitorConn
- if sv.cfg.UseEncryption {
- remote, err = frpIo.WithEncryption(remote, []byte(sv.cfg.Sk))
- if err != nil {
- xl.Error("create encryption stream error: %v", err)
- return nil, err
- }
- }
- if sv.cfg.UseCompression {
- remote = frpIo.WithCompression(remote)
- }
- return frpNet.WrapReadWriteCloserToConn(remote, visitorConn), nil
- }
- func (sv *SUDPVisitor) Close() {
- sv.mu.Lock()
- defer sv.mu.Unlock()
- select {
- case <-sv.checkCloseCh:
- return
- default:
- close(sv.checkCloseCh)
- }
- if sv.udpConn != nil {
- sv.udpConn.Close()
- }
- close(sv.readCh)
- close(sv.sendCh)
- }
|