netbird/signal/server/signal.go

183 lines
7.0 KiB
Go
Raw Normal View History

package server
2021-05-01 12:45:37 +02:00
import (
"context"
"fmt"
2024-06-13 01:20:46 +02:00
"io"
"time"
2021-05-01 12:45:37 +02:00
log "github.com/sirupsen/logrus"
2024-06-13 01:20:46 +02:00
"go.opentelemetry.io/otel/attribute"
"go.opentelemetry.io/otel/metric"
2021-05-01 12:45:37 +02:00
"google.golang.org/grpc/codes"
"google.golang.org/grpc/metadata"
"google.golang.org/grpc/status"
2024-06-13 01:20:46 +02:00
"github.com/netbirdio/netbird/signal/metrics"
"github.com/netbirdio/netbird/signal/peer"
"github.com/netbirdio/netbird/signal/proto"
)
const (
labelType = "type"
labelTypeError = "error"
labelTypeNotConnected = "not_connected"
labelTypeNotRegistered = "not_registered"
2024-07-16 10:14:30 +02:00
labelTypeStream = "stream"
labelTypeMessage = "message"
2024-06-13 01:20:46 +02:00
labelError = "error"
labelErrorMissingId = "missing_id"
labelErrorMissingMeta = "missing_meta"
labelErrorFailedHeader = "failed_header"
labelRegistrionStatus = "status"
labelRegistrationFound = "found"
labelRegistrationNotFound = "not_found"
2021-05-01 12:45:37 +02:00
)
// Server an instance of a Signal server
type Server struct {
2021-05-01 12:45:37 +02:00
registry *peer.Registry
proto.UnimplementedSignalExchangeServer
2024-06-13 01:20:46 +02:00
metrics *metrics.AppMetrics
2021-05-01 12:45:37 +02:00
}
// NewServer creates a new Signal server
2024-06-13 01:20:46 +02:00
func NewServer(meter metric.Meter) (*Server, error) {
appMetrics, err := metrics.NewAppMetrics(meter)
if err != nil {
return nil, fmt.Errorf("creating app metrics: %v", err)
}
s := &Server{
registry: peer.NewRegistry(appMetrics),
metrics: appMetrics,
2021-05-01 12:45:37 +02:00
}
2024-06-13 01:20:46 +02:00
return s, nil
2021-05-01 12:45:37 +02:00
}
// Send forwards a message to the signal peer
func (s *Server) Send(ctx context.Context, msg *proto.EncryptedMessage) (*proto.EncryptedMessage, error) {
if !s.registry.IsPeerRegistered(msg.Key) {
2024-06-13 01:20:46 +02:00
s.metrics.MessageForwardFailures.Add(ctx, 1, metric.WithAttributes(attribute.String(labelType, labelTypeNotRegistered)))
return nil, fmt.Errorf("peer %s is not registered", msg.Key)
2021-05-01 12:45:37 +02:00
}
getRegistrationStart := time.Now()
if dstPeer, found := s.registry.Get(msg.RemoteKey); found {
s.metrics.GetRegistrationDelay.Record(ctx, float64(time.Since(getRegistrationStart).Nanoseconds())/1e6, metric.WithAttributes(attribute.String(labelType, labelTypeMessage), attribute.String(labelRegistrionStatus, labelRegistrationFound)))
2024-07-16 10:14:30 +02:00
start := time.Now()
2021-05-01 12:45:37 +02:00
//forward the message to the target peer
2024-06-13 01:20:46 +02:00
if err := dstPeer.Stream.Send(msg); err != nil {
log.Errorf("error while forwarding message from peer [%s] to peer [%s] %v", msg.Key, msg.RemoteKey, err)
2021-05-01 12:45:37 +02:00
//todo respond to the sender?
2024-06-13 01:20:46 +02:00
s.metrics.MessageForwardFailures.Add(ctx, 1, metric.WithAttributes(attribute.String(labelType, labelTypeError)))
} else {
2024-07-16 10:14:30 +02:00
s.metrics.MessageForwardLatency.Record(ctx, float64(time.Since(start).Nanoseconds())/1e6, metric.WithAttributes(attribute.String(labelType, labelTypeMessage)))
2024-06-13 01:20:46 +02:00
s.metrics.MessagesForwarded.Add(context.Background(), 1)
2021-05-01 12:45:37 +02:00
}
} else {
s.metrics.GetRegistrationDelay.Record(ctx, float64(time.Since(getRegistrationStart).Nanoseconds())/1e6, metric.WithAttributes(attribute.String(labelType, labelTypeMessage), attribute.String(labelRegistrionStatus, labelRegistrationNotFound)))
log.Debugf("message from peer [%s] can't be forwarded to peer [%s] because destination peer is not connected", msg.Key, msg.RemoteKey)
2021-05-01 12:45:37 +02:00
//todo respond to the sender?
2024-06-13 01:20:46 +02:00
s.metrics.MessageForwardFailures.Add(ctx, 1, metric.WithAttributes(attribute.String(labelType, labelTypeNotConnected)))
2021-05-01 12:45:37 +02:00
}
return &proto.EncryptedMessage{}, nil
2021-05-01 12:45:37 +02:00
}
// ConnectStream connects to the exchange stream
func (s *Server) ConnectStream(stream proto.SignalExchange_ConnectStreamServer) error {
2021-05-01 12:45:37 +02:00
p, err := s.connectPeer(stream)
if err != nil {
return err
}
2024-06-13 01:20:46 +02:00
startRegister := time.Now()
s.metrics.ActivePeers.Add(stream.Context(), 1)
defer func() {
log.Infof("peer disconnected [%s] [streamID %d] ", p.Id, p.StreamID)
s.registry.Deregister(p)
2024-06-13 01:20:46 +02:00
s.metrics.PeerConnectionDuration.Record(stream.Context(), int64(time.Since(startRegister).Seconds()))
s.metrics.ActivePeers.Add(context.Background(), -1)
}()
//needed to confirm that the peer has been registered so that the client can proceed
header := metadata.Pairs(proto.HeaderRegistered, "1")
err = stream.SendHeader(header)
if err != nil {
2024-06-13 01:20:46 +02:00
s.metrics.RegistrationFailures.Add(stream.Context(), 1, metric.WithAttributes(attribute.String(labelError, labelErrorFailedHeader)))
return err
}
log.Infof("peer connected [%s] [streamID %d] ", p.Id, p.StreamID)
2021-05-01 12:45:37 +02:00
for {
2024-06-13 01:20:46 +02:00
//read incoming messages
2021-05-01 12:45:37 +02:00
msg, err := stream.Recv()
if err == io.EOF {
break
} else if err != nil {
return err
}
2024-06-13 01:20:46 +02:00
2021-05-01 12:45:37 +02:00
log.Debugf("received a new message from peer [%s] to peer [%s]", p.Id, msg.RemoteKey)
2024-06-13 01:20:46 +02:00
getRegistrationStart := time.Now()
2021-05-01 12:45:37 +02:00
// lookup the target peer where the message is going to
if dstPeer, found := s.registry.Get(msg.RemoteKey); found {
s.metrics.GetRegistrationDelay.Record(stream.Context(), float64(time.Since(getRegistrationStart).Nanoseconds())/1e6, metric.WithAttributes(attribute.String(labelType, labelTypeStream), attribute.String(labelRegistrionStatus, labelRegistrationFound)))
2024-07-16 10:14:30 +02:00
start := time.Now()
2021-05-01 12:45:37 +02:00
//forward the message to the target peer
2024-06-13 01:20:46 +02:00
if err := dstPeer.Stream.Send(msg); err != nil {
log.Errorf("error while forwarding message from peer [%s] to peer [%s] %v", p.Id, msg.RemoteKey, err)
2021-05-01 12:45:37 +02:00
//todo respond to the sender?
2024-07-16 10:14:30 +02:00
s.metrics.MessageForwardFailures.Add(stream.Context(), 1, metric.WithAttributes(attribute.String(labelType, labelTypeError)))
} else {
2024-06-13 01:20:46 +02:00
// in milliseconds
2024-07-16 10:14:30 +02:00
s.metrics.MessageForwardLatency.Record(stream.Context(), float64(time.Since(start).Nanoseconds())/1e6, metric.WithAttributes(attribute.String(labelType, labelTypeStream)))
2024-06-13 01:20:46 +02:00
s.metrics.MessagesForwarded.Add(stream.Context(), 1)
2021-05-01 12:45:37 +02:00
}
} else {
s.metrics.GetRegistrationDelay.Record(stream.Context(), float64(time.Since(getRegistrationStart).Nanoseconds())/1e6, metric.WithAttributes(attribute.String(labelType, labelTypeStream), attribute.String(labelRegistrionStatus, labelRegistrationNotFound)))
s.metrics.MessageForwardFailures.Add(stream.Context(), 1, metric.WithAttributes(attribute.String(labelType, labelTypeNotConnected)))
log.Debugf("message from peer [%s] can't be forwarded to peer [%s] because destination peer is not connected", p.Id, msg.RemoteKey)
2021-05-01 12:45:37 +02:00
//todo respond to the sender?
}
}
<-stream.Context().Done()
return stream.Context().Err()
}
// Handles initial Peer connection.
2021-08-20 22:33:43 +02:00
// Each connection must provide an Id header.
2021-05-01 12:45:37 +02:00
// At this moment the connecting Peer will be registered in the peer.Registry
func (s Server) connectPeer(stream proto.SignalExchange_ConnectStreamServer) (*peer.Peer, error) {
2021-05-01 12:45:37 +02:00
if meta, hasMeta := metadata.FromIncomingContext(stream.Context()); hasMeta {
if id, found := meta[proto.HeaderId]; found {
p := peer.NewPeer(id[0], stream)
2024-06-13 01:20:46 +02:00
2021-05-01 12:45:37 +02:00
s.registry.Register(p)
2024-06-13 01:20:46 +02:00
2021-05-01 12:45:37 +02:00
return p, nil
} else {
2024-06-13 01:20:46 +02:00
s.metrics.RegistrationFailures.Add(stream.Context(), 1, metric.WithAttributes(attribute.String(labelError, labelErrorMissingId)))
2021-05-01 12:45:37 +02:00
return nil, status.Errorf(codes.FailedPrecondition, "missing connection header: "+proto.HeaderId)
}
} else {
2024-06-13 01:20:46 +02:00
s.metrics.RegistrationFailures.Add(stream.Context(), 1, metric.WithAttributes(attribute.String(labelError, labelErrorMissingMeta)))
2021-05-01 12:45:37 +02:00
return nil, status.Errorf(codes.FailedPrecondition, "missing connection stream meta")
}
}