mirror of
https://github.com/apernet/hysteria.git
synced 2025-04-03 04:27:39 +03:00
feat(trafficlogger): dump streams stats
This commit is contained in:
parent
a2c7b8fd19
commit
0681638568
5 changed files with 277 additions and 4 deletions
|
@ -22,3 +22,33 @@ func (t *AtomicTime) Set(new time.Time) {
|
||||||
func (t *AtomicTime) Get() time.Time {
|
func (t *AtomicTime) Get() time.Time {
|
||||||
return t.v.Load().(time.Time)
|
return t.v.Load().(time.Time)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
type Atomic[T any] struct {
|
||||||
|
v atomic.Value
|
||||||
|
}
|
||||||
|
|
||||||
|
func (a *Atomic[T]) Load() T {
|
||||||
|
value := a.v.Load()
|
||||||
|
if value == nil {
|
||||||
|
var zero T
|
||||||
|
return zero
|
||||||
|
}
|
||||||
|
return value.(T)
|
||||||
|
}
|
||||||
|
|
||||||
|
func (a *Atomic[T]) Store(value T) {
|
||||||
|
a.v.Store(value)
|
||||||
|
}
|
||||||
|
|
||||||
|
func (a *Atomic[T]) Swap(new T) T {
|
||||||
|
old := a.v.Swap(new)
|
||||||
|
if old == nil {
|
||||||
|
var zero T
|
||||||
|
return zero
|
||||||
|
}
|
||||||
|
return old.(T)
|
||||||
|
}
|
||||||
|
|
||||||
|
func (a *Atomic[T]) CompareAndSwap(old, new T) bool {
|
||||||
|
return a.v.CompareAndSwap(old, new)
|
||||||
|
}
|
||||||
|
|
|
@ -4,8 +4,11 @@ import (
|
||||||
"crypto/tls"
|
"crypto/tls"
|
||||||
"net"
|
"net"
|
||||||
"net/http"
|
"net/http"
|
||||||
|
"sync/atomic"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
|
"github.com/apernet/hysteria/core/v2/internal/utils"
|
||||||
|
|
||||||
"github.com/apernet/hysteria/core/v2/errors"
|
"github.com/apernet/hysteria/core/v2/errors"
|
||||||
"github.com/apernet/hysteria/core/v2/internal/pmtud"
|
"github.com/apernet/hysteria/core/v2/internal/pmtud"
|
||||||
"github.com/apernet/quic-go"
|
"github.com/apernet/quic-go"
|
||||||
|
@ -212,4 +215,66 @@ type EventLogger interface {
|
||||||
type TrafficLogger interface {
|
type TrafficLogger interface {
|
||||||
LogTraffic(id string, tx, rx uint64) (ok bool)
|
LogTraffic(id string, tx, rx uint64) (ok bool)
|
||||||
LogOnlineState(id string, online bool)
|
LogOnlineState(id string, online bool)
|
||||||
|
TraceStream(stream quic.Stream, stats *StreamStats)
|
||||||
|
UntraceStream(stream quic.Stream)
|
||||||
|
}
|
||||||
|
|
||||||
|
type StreamState int
|
||||||
|
|
||||||
|
const (
|
||||||
|
// StreamStateInitial indicates the initial state of a stream.
|
||||||
|
// Client has opened the stream, but we have not received the proxy request yet.
|
||||||
|
StreamStateInitial StreamState = iota
|
||||||
|
|
||||||
|
// StreamStateHooking indicates that the hook (usually sniff) is processing.
|
||||||
|
// Client has sent the proxy request, but sniff requires more data to complete.
|
||||||
|
StreamStateHooking
|
||||||
|
|
||||||
|
// StreamStateConnecting indicates that we are connecting to the proxy target.
|
||||||
|
StreamStateConnecting
|
||||||
|
|
||||||
|
// StreamStateEstablished indicates the proxy is established.
|
||||||
|
StreamStateEstablished
|
||||||
|
|
||||||
|
// StreamStateClosed indicates the stream is closed.
|
||||||
|
StreamStateClosed
|
||||||
|
)
|
||||||
|
|
||||||
|
func (s StreamState) String() string {
|
||||||
|
switch s {
|
||||||
|
case StreamStateInitial:
|
||||||
|
return "init"
|
||||||
|
case StreamStateHooking:
|
||||||
|
return "hook"
|
||||||
|
case StreamStateConnecting:
|
||||||
|
return "connect"
|
||||||
|
case StreamStateEstablished:
|
||||||
|
return "estab"
|
||||||
|
case StreamStateClosed:
|
||||||
|
return "closed"
|
||||||
|
default:
|
||||||
|
return "unknown"
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
type StreamStats struct {
|
||||||
|
State utils.Atomic[StreamState]
|
||||||
|
|
||||||
|
AuthID string
|
||||||
|
ConnID uint32
|
||||||
|
InitialTime time.Time
|
||||||
|
|
||||||
|
ReqAddr utils.Atomic[string]
|
||||||
|
HookedReqAddr utils.Atomic[string]
|
||||||
|
|
||||||
|
Tx atomic.Uint64
|
||||||
|
Rx atomic.Uint64
|
||||||
|
|
||||||
|
LastActiveTime utils.Atomic[time.Time]
|
||||||
|
}
|
||||||
|
|
||||||
|
func (s *StreamStats) setHookedReqAddr(addr string) {
|
||||||
|
if addr != s.ReqAddr.Load() {
|
||||||
|
s.HookedReqAddr.Store(addr)
|
||||||
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -3,6 +3,7 @@ package server
|
||||||
import (
|
import (
|
||||||
"errors"
|
"errors"
|
||||||
"io"
|
"io"
|
||||||
|
"time"
|
||||||
)
|
)
|
||||||
|
|
||||||
var errDisconnect = errors.New("traffic logger requested disconnect")
|
var errDisconnect = errors.New("traffic logger requested disconnect")
|
||||||
|
@ -31,15 +32,19 @@ func copyBufferLog(dst io.Writer, src io.Reader, log func(n uint64) bool) error
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
func copyTwoWayWithLogger(id string, serverRw, remoteRw io.ReadWriter, l TrafficLogger) error {
|
func copyTwoWayWithLogger(id string, serverRw, remoteRw io.ReadWriter, l TrafficLogger, stats *StreamStats) error {
|
||||||
errChan := make(chan error, 2)
|
errChan := make(chan error, 2)
|
||||||
go func() {
|
go func() {
|
||||||
errChan <- copyBufferLog(serverRw, remoteRw, func(n uint64) bool {
|
errChan <- copyBufferLog(serverRw, remoteRw, func(n uint64) bool {
|
||||||
|
stats.LastActiveTime.Store(time.Now())
|
||||||
|
stats.Rx.Add(n)
|
||||||
return l.LogTraffic(id, 0, n)
|
return l.LogTraffic(id, 0, n)
|
||||||
})
|
})
|
||||||
}()
|
}()
|
||||||
go func() {
|
go func() {
|
||||||
errChan <- copyBufferLog(remoteRw, serverRw, func(n uint64) bool {
|
errChan <- copyBufferLog(remoteRw, serverRw, func(n uint64) bool {
|
||||||
|
stats.LastActiveTime.Store(time.Now())
|
||||||
|
stats.Tx.Add(n)
|
||||||
return l.LogTraffic(id, n, 0)
|
return l.LogTraffic(id, n, 0)
|
||||||
})
|
})
|
||||||
}()
|
}()
|
||||||
|
|
|
@ -3,8 +3,10 @@ package server
|
||||||
import (
|
import (
|
||||||
"context"
|
"context"
|
||||||
"crypto/tls"
|
"crypto/tls"
|
||||||
|
"math/rand"
|
||||||
"net/http"
|
"net/http"
|
||||||
"sync"
|
"sync"
|
||||||
|
"time"
|
||||||
|
|
||||||
"github.com/apernet/quic-go"
|
"github.com/apernet/quic-go"
|
||||||
"github.com/apernet/quic-go/http3"
|
"github.com/apernet/quic-go/http3"
|
||||||
|
@ -100,6 +102,7 @@ type h3sHandler struct {
|
||||||
authenticated bool
|
authenticated bool
|
||||||
authMutex sync.Mutex
|
authMutex sync.Mutex
|
||||||
authID string
|
authID string
|
||||||
|
connID uint32 // a random id for dump streams
|
||||||
|
|
||||||
udpSM *udpSessionManager // Only set after authentication
|
udpSM *udpSessionManager // Only set after authentication
|
||||||
}
|
}
|
||||||
|
@ -108,6 +111,7 @@ func newH3sHandler(config *Config, conn quic.Connection) *h3sHandler {
|
||||||
return &h3sHandler{
|
return &h3sHandler{
|
||||||
config: config,
|
config: config,
|
||||||
conn: conn,
|
conn: conn,
|
||||||
|
connID: rand.Uint32(),
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -205,12 +209,29 @@ func (h *h3sHandler) ProxyStreamHijacker(ft http3.FrameType, id quic.ConnectionT
|
||||||
}
|
}
|
||||||
|
|
||||||
func (h *h3sHandler) handleTCPRequest(stream quic.Stream) {
|
func (h *h3sHandler) handleTCPRequest(stream quic.Stream) {
|
||||||
|
trafficLogger := h.config.TrafficLogger
|
||||||
|
streamStats := &StreamStats{
|
||||||
|
AuthID: h.authID,
|
||||||
|
ConnID: h.connID,
|
||||||
|
InitialTime: time.Now(),
|
||||||
|
}
|
||||||
|
streamStats.State.Store(StreamStateInitial)
|
||||||
|
streamStats.LastActiveTime.Store(time.Now())
|
||||||
|
defer func() {
|
||||||
|
streamStats.State.Store(StreamStateClosed)
|
||||||
|
}()
|
||||||
|
if trafficLogger != nil {
|
||||||
|
trafficLogger.TraceStream(stream, streamStats)
|
||||||
|
defer trafficLogger.UntraceStream(stream)
|
||||||
|
}
|
||||||
|
|
||||||
// Read request
|
// Read request
|
||||||
reqAddr, err := protocol.ReadTCPRequest(stream)
|
reqAddr, err := protocol.ReadTCPRequest(stream)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
_ = stream.Close()
|
_ = stream.Close()
|
||||||
return
|
return
|
||||||
}
|
}
|
||||||
|
streamStats.ReqAddr.Store(reqAddr)
|
||||||
// Call the hook if set
|
// Call the hook if set
|
||||||
var putback []byte
|
var putback []byte
|
||||||
var hooked bool
|
var hooked bool
|
||||||
|
@ -220,12 +241,14 @@ func (h *h3sHandler) handleTCPRequest(stream quic.Stream) {
|
||||||
// so that the client will send whatever request the hook wants to see.
|
// so that the client will send whatever request the hook wants to see.
|
||||||
// This is essentially a server-side fast-open.
|
// This is essentially a server-side fast-open.
|
||||||
if hooked {
|
if hooked {
|
||||||
|
streamStats.State.Store(StreamStateHooking)
|
||||||
_ = protocol.WriteTCPResponse(stream, true, "RequestHook enabled")
|
_ = protocol.WriteTCPResponse(stream, true, "RequestHook enabled")
|
||||||
putback, err = h.config.RequestHook.TCP(stream, &reqAddr)
|
putback, err = h.config.RequestHook.TCP(stream, &reqAddr)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
_ = stream.Close()
|
_ = stream.Close()
|
||||||
return
|
return
|
||||||
}
|
}
|
||||||
|
streamStats.setHookedReqAddr(reqAddr)
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
// Log the event
|
// Log the event
|
||||||
|
@ -233,6 +256,7 @@ func (h *h3sHandler) handleTCPRequest(stream quic.Stream) {
|
||||||
h.config.EventLogger.TCPRequest(h.conn.RemoteAddr(), h.authID, reqAddr)
|
h.config.EventLogger.TCPRequest(h.conn.RemoteAddr(), h.authID, reqAddr)
|
||||||
}
|
}
|
||||||
// Dial target
|
// Dial target
|
||||||
|
streamStats.State.Store(StreamStateConnecting)
|
||||||
tConn, err := h.config.Outbound.TCP(reqAddr)
|
tConn, err := h.config.Outbound.TCP(reqAddr)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
if !hooked {
|
if !hooked {
|
||||||
|
@ -248,13 +272,15 @@ func (h *h3sHandler) handleTCPRequest(stream quic.Stream) {
|
||||||
if !hooked {
|
if !hooked {
|
||||||
_ = protocol.WriteTCPResponse(stream, true, "Connected")
|
_ = protocol.WriteTCPResponse(stream, true, "Connected")
|
||||||
}
|
}
|
||||||
|
streamStats.State.Store(StreamStateEstablished)
|
||||||
// Put back the data if the hook requested
|
// Put back the data if the hook requested
|
||||||
if len(putback) > 0 {
|
if len(putback) > 0 {
|
||||||
_, _ = tConn.Write(putback)
|
n, _ := tConn.Write(putback)
|
||||||
|
streamStats.Tx.Add(uint64(n))
|
||||||
}
|
}
|
||||||
// Start proxying
|
// Start proxying
|
||||||
if h.config.TrafficLogger != nil {
|
if trafficLogger != nil {
|
||||||
err = copyTwoWayWithLogger(h.authID, stream, tConn, h.config.TrafficLogger)
|
err = copyTwoWayWithLogger(h.authID, stream, tConn, trafficLogger, streamStats)
|
||||||
} else {
|
} else {
|
||||||
// Use the fast path if no traffic logger is set
|
// Use the fast path if no traffic logger is set
|
||||||
err = copyTwoWay(stream, tConn)
|
err = copyTwoWay(stream, tConn)
|
||||||
|
|
|
@ -1,10 +1,17 @@
|
||||||
package trafficlogger
|
package trafficlogger
|
||||||
|
|
||||||
import (
|
import (
|
||||||
|
"cmp"
|
||||||
"encoding/json"
|
"encoding/json"
|
||||||
|
"fmt"
|
||||||
"net/http"
|
"net/http"
|
||||||
|
"slices"
|
||||||
"strconv"
|
"strconv"
|
||||||
|
"strings"
|
||||||
"sync"
|
"sync"
|
||||||
|
"time"
|
||||||
|
|
||||||
|
"github.com/apernet/quic-go"
|
||||||
|
|
||||||
"github.com/apernet/hysteria/core/v2/server"
|
"github.com/apernet/hysteria/core/v2/server"
|
||||||
)
|
)
|
||||||
|
@ -25,6 +32,7 @@ func NewTrafficStatsServer(secret string) TrafficStatsServer {
|
||||||
StatsMap: make(map[string]*trafficStatsEntry),
|
StatsMap: make(map[string]*trafficStatsEntry),
|
||||||
KickMap: make(map[string]struct{}),
|
KickMap: make(map[string]struct{}),
|
||||||
OnlineMap: make(map[string]int),
|
OnlineMap: make(map[string]int),
|
||||||
|
StreamMap: make(map[quic.Stream]*server.StreamStats),
|
||||||
Secret: secret,
|
Secret: secret,
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -33,6 +41,7 @@ type trafficStatsServerImpl struct {
|
||||||
Mutex sync.RWMutex
|
Mutex sync.RWMutex
|
||||||
StatsMap map[string]*trafficStatsEntry
|
StatsMap map[string]*trafficStatsEntry
|
||||||
OnlineMap map[string]int
|
OnlineMap map[string]int
|
||||||
|
StreamMap map[quic.Stream]*server.StreamStats
|
||||||
KickMap map[string]struct{}
|
KickMap map[string]struct{}
|
||||||
Secret string
|
Secret string
|
||||||
}
|
}
|
||||||
|
@ -78,6 +87,20 @@ func (s *trafficStatsServerImpl) LogOnlineState(id string, online bool) {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
func (s *trafficStatsServerImpl) TraceStream(stream quic.Stream, stats *server.StreamStats) {
|
||||||
|
s.Mutex.Lock()
|
||||||
|
defer s.Mutex.Unlock()
|
||||||
|
|
||||||
|
s.StreamMap[stream] = stats
|
||||||
|
}
|
||||||
|
|
||||||
|
func (s *trafficStatsServerImpl) UntraceStream(stream quic.Stream) {
|
||||||
|
s.Mutex.Lock()
|
||||||
|
defer s.Mutex.Unlock()
|
||||||
|
|
||||||
|
delete(s.StreamMap, stream)
|
||||||
|
}
|
||||||
|
|
||||||
func (s *trafficStatsServerImpl) ServeHTTP(w http.ResponseWriter, r *http.Request) {
|
func (s *trafficStatsServerImpl) ServeHTTP(w http.ResponseWriter, r *http.Request) {
|
||||||
if s.Secret != "" && r.Header.Get("Authorization") != s.Secret {
|
if s.Secret != "" && r.Header.Get("Authorization") != s.Secret {
|
||||||
http.Error(w, "unauthorized", http.StatusUnauthorized)
|
http.Error(w, "unauthorized", http.StatusUnauthorized)
|
||||||
|
@ -99,6 +122,10 @@ func (s *trafficStatsServerImpl) ServeHTTP(w http.ResponseWriter, r *http.Reques
|
||||||
s.getOnline(w, r)
|
s.getOnline(w, r)
|
||||||
return
|
return
|
||||||
}
|
}
|
||||||
|
if r.Method == http.MethodGet && r.URL.Path == "/dump/streams" {
|
||||||
|
s.getDumpStreams(w, r)
|
||||||
|
return
|
||||||
|
}
|
||||||
http.NotFound(w, r)
|
http.NotFound(w, r)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -137,6 +164,126 @@ func (s *trafficStatsServerImpl) getOnline(w http.ResponseWriter, r *http.Reques
|
||||||
_, _ = w.Write(jb)
|
_, _ = w.Write(jb)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
type dumpStreamEntry struct {
|
||||||
|
State string `json:"state"`
|
||||||
|
|
||||||
|
Auth string `json:"auth"`
|
||||||
|
Connection uint32 `json:"connection"`
|
||||||
|
Stream uint64 `json:"stream"`
|
||||||
|
|
||||||
|
ReqAddr string `json:"req_addr"`
|
||||||
|
HookedReqAddr string `json:"hooked_req_addr"`
|
||||||
|
|
||||||
|
Tx uint64 `json:"tx"`
|
||||||
|
Rx uint64 `json:"rx"`
|
||||||
|
|
||||||
|
InitialAt string `json:"initial_at"`
|
||||||
|
LastActiveAt string `json:"last_active_at"`
|
||||||
|
|
||||||
|
// for text/plain output
|
||||||
|
initialTime time.Time
|
||||||
|
lastActiveTime time.Time
|
||||||
|
}
|
||||||
|
|
||||||
|
func (e *dumpStreamEntry) fromStreamStats(stream quic.Stream, s *server.StreamStats) {
|
||||||
|
e.State = s.State.Load().String()
|
||||||
|
e.Auth = s.AuthID
|
||||||
|
e.Connection = s.ConnID
|
||||||
|
e.Stream = uint64(stream.StreamID())
|
||||||
|
e.ReqAddr = s.ReqAddr.Load()
|
||||||
|
e.HookedReqAddr = s.HookedReqAddr.Load()
|
||||||
|
e.Tx = s.Tx.Load()
|
||||||
|
e.Rx = s.Rx.Load()
|
||||||
|
e.initialTime = s.InitialTime
|
||||||
|
e.lastActiveTime = s.LastActiveTime.Load()
|
||||||
|
e.InitialAt = e.initialTime.Format(time.RFC3339Nano)
|
||||||
|
e.LastActiveAt = e.lastActiveTime.Format(time.RFC3339Nano)
|
||||||
|
}
|
||||||
|
|
||||||
|
func formatDumpStreamLine(state, auth, connection, stream, reqAddr, hookedReqAddr, tx, rx, lifetime, lastActive string) string {
|
||||||
|
return fmt.Sprintf("%-8s %-12s %12s %8s %12s %12s %12s %12s %-16s %s", state, auth, connection, stream, tx, rx, lifetime, lastActive, reqAddr, hookedReqAddr)
|
||||||
|
}
|
||||||
|
|
||||||
|
func (e *dumpStreamEntry) String() string {
|
||||||
|
stateText := strings.ToUpper(e.State)
|
||||||
|
connectionText := fmt.Sprintf("%08X", e.Connection)
|
||||||
|
streamText := strconv.FormatUint(e.Stream, 10)
|
||||||
|
reqAddrText := e.ReqAddr
|
||||||
|
if reqAddrText == "" {
|
||||||
|
reqAddrText = "-"
|
||||||
|
}
|
||||||
|
hookedReqAddrText := e.HookedReqAddr
|
||||||
|
if hookedReqAddrText == "" {
|
||||||
|
hookedReqAddrText = "-"
|
||||||
|
}
|
||||||
|
txText := strconv.FormatUint(e.Tx, 10)
|
||||||
|
rxText := strconv.FormatUint(e.Rx, 10)
|
||||||
|
lifetime := time.Now().Sub(e.initialTime)
|
||||||
|
if lifetime < 10*time.Minute {
|
||||||
|
lifetime = lifetime.Round(time.Millisecond)
|
||||||
|
} else {
|
||||||
|
lifetime = lifetime.Round(time.Second)
|
||||||
|
}
|
||||||
|
lastActive := time.Now().Sub(e.lastActiveTime)
|
||||||
|
if lastActive < 10*time.Minute {
|
||||||
|
lastActive = lastActive.Round(time.Millisecond)
|
||||||
|
} else {
|
||||||
|
lastActive = lastActive.Round(time.Second)
|
||||||
|
}
|
||||||
|
|
||||||
|
return formatDumpStreamLine(stateText, e.Auth, connectionText, streamText, reqAddrText, hookedReqAddrText, txText, rxText, lifetime.String(), lastActive.String())
|
||||||
|
}
|
||||||
|
|
||||||
|
func (s *trafficStatsServerImpl) getDumpStreams(w http.ResponseWriter, r *http.Request) {
|
||||||
|
var entries []dumpStreamEntry
|
||||||
|
|
||||||
|
s.Mutex.RLock()
|
||||||
|
entries = make([]dumpStreamEntry, len(s.StreamMap))
|
||||||
|
index := 0
|
||||||
|
for stream, stats := range s.StreamMap {
|
||||||
|
entries[index].fromStreamStats(stream, stats)
|
||||||
|
index++
|
||||||
|
}
|
||||||
|
s.Mutex.RUnlock()
|
||||||
|
|
||||||
|
slices.SortFunc(entries, func(lhs, rhs dumpStreamEntry) int {
|
||||||
|
if ret := cmp.Compare(lhs.Auth, rhs.Auth); ret != 0 {
|
||||||
|
return ret
|
||||||
|
}
|
||||||
|
if ret := cmp.Compare(lhs.Connection, rhs.Connection); ret != 0 {
|
||||||
|
return ret
|
||||||
|
}
|
||||||
|
if ret := cmp.Compare(lhs.Stream, rhs.Stream); ret != 0 {
|
||||||
|
return ret
|
||||||
|
}
|
||||||
|
return 0
|
||||||
|
})
|
||||||
|
|
||||||
|
accept := r.Header.Get("Accept")
|
||||||
|
|
||||||
|
if strings.Contains(accept, "text/plain") {
|
||||||
|
// Generate netstat-like output for humans
|
||||||
|
w.Header().Set("Content-Type", "text/plain; charset=utf-8")
|
||||||
|
|
||||||
|
// Print table header
|
||||||
|
_, _ = fmt.Fprintln(w, formatDumpStreamLine("State", "Auth", "Connection", "Stream", "Req-Addr", "Hooked-Req-Addr", "TX-Bytes", "RX-Bytes", "Lifetime", "Last-Active"))
|
||||||
|
for _, entry := range entries {
|
||||||
|
_, _ = fmt.Fprintln(w, entry.String())
|
||||||
|
}
|
||||||
|
return
|
||||||
|
}
|
||||||
|
|
||||||
|
// Response with json by default
|
||||||
|
wrapper := struct {
|
||||||
|
Streams []dumpStreamEntry `json:"streams"`
|
||||||
|
}{entries}
|
||||||
|
w.Header().Set("Content-Type", "application/json; charset=utf-8")
|
||||||
|
err := json.NewEncoder(w).Encode(&wrapper)
|
||||||
|
if err != nil {
|
||||||
|
http.Error(w, err.Error(), http.StatusInternalServerError)
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
func (s *trafficStatsServerImpl) kick(w http.ResponseWriter, r *http.Request) {
|
func (s *trafficStatsServerImpl) kick(w http.ResponseWriter, r *http.Request) {
|
||||||
var ids []string
|
var ids []string
|
||||||
err := json.NewDecoder(r.Body).Decode(&ids)
|
err := json.NewDecoder(r.Body).Decode(&ids)
|
||||||
|
|
Loading…
Add table
Add a link
Reference in a new issue