mirror of
https://github.com/mainflux/mainflux.git
synced 2025-05-01 13:48:56 +08:00

* Initial Commit: Sync Env Veriables With Docker Deployment Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Sync Env Vars With Master Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Initial Commit: Add Tags to Database and Message Bus Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Format Address Well Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Propagate Context Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Update PostgresSQL spans Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Update Message Bus Spans Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Add Tracing To MQTT Adapter Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Add Span Tags to HTTP Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Combine Tracing and PubSub Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Fix Error After Rebase Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Reorder Server Config Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Seperate Tracing Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * shorten span names Signed-off-by: rodneyosodo <blackd0t@protonmail.com> * Fix Issue After Rebase Signed-off-by: rodneyosodo <blackd0t@protonmail.com> --------- Signed-off-by: rodneyosodo <blackd0t@protonmail.com>
97 lines
2.6 KiB
Go
97 lines
2.6 KiB
Go
// Copyright (c) Mainflux
|
|
// SPDX-License-Identifier: Apache-2.0
|
|
package tracing
|
|
|
|
import (
|
|
"context"
|
|
|
|
"github.com/mainflux/mainflux/internal/server"
|
|
"github.com/mainflux/mainflux/pkg/messaging"
|
|
"github.com/mainflux/mainflux/pkg/messaging/tracing"
|
|
"go.opentelemetry.io/otel/trace"
|
|
)
|
|
|
|
// Constants to define different operations to be traced.
|
|
const (
|
|
subscribeOP = "receive"
|
|
unsubscribeOp = "unsubscribe" // This is not specified in the open telemetry spec.
|
|
processOp = "process"
|
|
)
|
|
|
|
var _ messaging.PubSub = (*pubsubMiddleware)(nil)
|
|
|
|
type pubsubMiddleware struct {
|
|
publisherMiddleware
|
|
pubsub messaging.PubSub
|
|
host server.Config
|
|
}
|
|
|
|
// NewPubSub creates a new pubsub middleware that traces pubsub operations.
|
|
func NewPubSub(config server.Config, tracer trace.Tracer, pubsub messaging.PubSub) messaging.PubSub {
|
|
pb := &pubsubMiddleware{
|
|
publisherMiddleware: publisherMiddleware{
|
|
publisher: pubsub,
|
|
tracer: tracer,
|
|
host: config,
|
|
},
|
|
pubsub: pubsub,
|
|
host: config,
|
|
}
|
|
|
|
return pb
|
|
}
|
|
|
|
// Subscribe creates a new subscription and traces the operation.
|
|
func (pm *pubsubMiddleware) Subscribe(ctx context.Context, id string, topic string, handler messaging.MessageHandler) error {
|
|
ctx, span := tracing.CreateSpan(ctx, subscribeOP, id, topic, "", 0, pm.host, trace.SpanKindClient, pm.tracer)
|
|
defer span.End()
|
|
|
|
span.SetAttributes(defaultAttributes...)
|
|
|
|
h := &traceHandler{
|
|
ctx: ctx,
|
|
handler: handler,
|
|
tracer: pm.tracer,
|
|
host: pm.host,
|
|
topic: topic,
|
|
clientID: id,
|
|
}
|
|
|
|
return pm.pubsub.Subscribe(ctx, id, topic, h)
|
|
}
|
|
|
|
// Unsubscribe removes an existing subscription and traces the operation.
|
|
func (pm *pubsubMiddleware) Unsubscribe(ctx context.Context, id string, topic string) error {
|
|
ctx, span := tracing.CreateSpan(ctx, unsubscribeOp, id, topic, "", 0, pm.host, trace.SpanKindInternal, pm.tracer)
|
|
defer span.End()
|
|
|
|
span.SetAttributes(defaultAttributes...)
|
|
|
|
return pm.pubsub.Unsubscribe(ctx, id, topic)
|
|
}
|
|
|
|
// TraceHandler is used to trace the message handling operation.
|
|
type traceHandler struct {
|
|
ctx context.Context
|
|
handler messaging.MessageHandler
|
|
tracer trace.Tracer
|
|
host server.Config
|
|
topic string
|
|
clientID string
|
|
}
|
|
|
|
// Handle instruments the message handling operation.
|
|
func (h *traceHandler) Handle(msg *messaging.Message) error {
|
|
_, span := tracing.CreateSpan(h.ctx, processOp, h.clientID, h.topic, msg.Subtopic, len(msg.Payload), h.host, trace.SpanKindConsumer, h.tracer)
|
|
defer span.End()
|
|
|
|
span.SetAttributes(defaultAttributes...)
|
|
|
|
return h.handler.Handle(msg)
|
|
}
|
|
|
|
// Cancel cancels the message handling operation.
|
|
func (h *traceHandler) Cancel() error {
|
|
return h.handler.Cancel()
|
|
}
|