mirror of
https://github.com/fnproject/fn.git
synced 2022-10-28 21:29:17 +03:00
* update vendor directory, add go.opencensus.io * update imports * oops * s/opentracing/opencensus/ & remove prometheus / zipkin stuff & remove old stats * the dep train rides again * fix gin build * deps from last guy * start in on the agent metrics * she builds * remove tags for now, cardinality error is fussing. subscribe instead of register * update to patched version of opencensus to proceed for now TODO switch to a release * meh fix imports * println debug the bad boys * lace it with the tags * update deps again * fix all inconsistent cardinality errors * add our own logger * fix init * fix oom measure * remove bugged removal code * fix s3 measures * fix prom handler nil
440 lines
13 KiB
Go
440 lines
13 KiB
Go
// Copyright 2017, OpenCensus Authors
|
|
//
|
|
// 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 stackdriver
|
|
|
|
import (
|
|
"context"
|
|
"errors"
|
|
"fmt"
|
|
"log"
|
|
"net/url"
|
|
"os"
|
|
"path"
|
|
"reflect"
|
|
"strconv"
|
|
"strings"
|
|
"sync"
|
|
"time"
|
|
|
|
"go.opencensus.io/internal"
|
|
"go.opencensus.io/stats/view"
|
|
"go.opencensus.io/tag"
|
|
|
|
monitoring "cloud.google.com/go/monitoring/apiv3"
|
|
timestamp "github.com/golang/protobuf/ptypes/timestamp"
|
|
"google.golang.org/api/option"
|
|
"google.golang.org/api/support/bundler"
|
|
distributionpb "google.golang.org/genproto/googleapis/api/distribution"
|
|
labelpb "google.golang.org/genproto/googleapis/api/label"
|
|
"google.golang.org/genproto/googleapis/api/metric"
|
|
metricpb "google.golang.org/genproto/googleapis/api/metric"
|
|
monitoredrespb "google.golang.org/genproto/googleapis/api/monitoredres"
|
|
monitoringpb "google.golang.org/genproto/googleapis/monitoring/v3"
|
|
"google.golang.org/grpc"
|
|
"google.golang.org/grpc/codes"
|
|
)
|
|
|
|
const maxTimeSeriesPerUpload = 200
|
|
const opencensusTaskKey = "opencensus_task"
|
|
const opencensusTaskDescription = "Opencensus task identifier"
|
|
|
|
// statsExporter exports stats to the Stackdriver Monitoring.
|
|
type statsExporter struct {
|
|
bundler *bundler.Bundler
|
|
o Options
|
|
|
|
createdViewsMu sync.Mutex
|
|
createdViews map[string]*metricpb.MetricDescriptor // Views already created remotely
|
|
|
|
c *monitoring.MetricClient
|
|
taskValue string
|
|
}
|
|
|
|
// Enforces the singleton on NewExporter per projectID per process
|
|
// lest there will be races with Stackdriver.
|
|
var (
|
|
seenProjectsMu sync.Mutex
|
|
seenProjects = make(map[string]bool)
|
|
)
|
|
|
|
var (
|
|
errBlankProjectID = errors.New("expecting a non-blank ProjectID")
|
|
errSingletonExporter = errors.New("only one exporter can be created per unique ProjectID per process")
|
|
)
|
|
|
|
// newStatsExporter returns an exporter that uploads stats data to Stackdriver Monitoring.
|
|
// Only one Stackdriver exporter should be created per ProjectID per process, any subsequent
|
|
// invocations of NewExporter with the same ProjectID will return an error.
|
|
func newStatsExporter(o Options) (*statsExporter, error) {
|
|
if strings.TrimSpace(o.ProjectID) == "" {
|
|
return nil, errBlankProjectID
|
|
}
|
|
|
|
seenProjectsMu.Lock()
|
|
defer seenProjectsMu.Unlock()
|
|
_, seen := seenProjects[o.ProjectID]
|
|
if seen {
|
|
return nil, errSingletonExporter
|
|
}
|
|
|
|
seenProjects[o.ProjectID] = true
|
|
|
|
opts := append(o.ClientOptions, option.WithUserAgent(internal.UserAgent))
|
|
client, err := monitoring.NewMetricClient(context.Background(), opts...)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
e := &statsExporter{
|
|
c: client,
|
|
o: o,
|
|
createdViews: make(map[string]*metricpb.MetricDescriptor),
|
|
taskValue: getTaskValue(),
|
|
}
|
|
e.bundler = bundler.NewBundler((*view.Data)(nil), func(bundle interface{}) {
|
|
vds := bundle.([]*view.Data)
|
|
e.handleUpload(vds...)
|
|
})
|
|
e.bundler.DelayThreshold = e.o.BundleDelayThreshold
|
|
e.bundler.BundleCountThreshold = e.o.BundleCountThreshold
|
|
return e, nil
|
|
}
|
|
|
|
// ExportView exports to the Stackdriver Monitoring if view data
|
|
// has one or more rows.
|
|
func (e *statsExporter) ExportView(vd *view.Data) {
|
|
if len(vd.Rows) == 0 {
|
|
return
|
|
}
|
|
err := e.bundler.Add(vd, 1)
|
|
switch err {
|
|
case nil:
|
|
return
|
|
case bundler.ErrOversizedItem:
|
|
go e.handleUpload(vd)
|
|
case bundler.ErrOverflow:
|
|
e.onError(errors.New("failed to upload: buffer full"))
|
|
default:
|
|
e.onError(err)
|
|
}
|
|
}
|
|
|
|
// getTaskValue returns a task label value in the format of
|
|
// "go-<pid>@<hostname>".
|
|
func getTaskValue() string {
|
|
hostname, err := os.Hostname()
|
|
if err != nil {
|
|
hostname = "localhost"
|
|
}
|
|
return "go-" + strconv.Itoa(os.Getpid()) + "@" + hostname
|
|
}
|
|
|
|
// handleUpload handles uploading a slice
|
|
// of Data, as well as error handling.
|
|
func (e *statsExporter) handleUpload(vds ...*view.Data) {
|
|
if err := e.upload(vds); err != nil {
|
|
e.onError(err)
|
|
}
|
|
}
|
|
|
|
// Flush waits for exported view data to be uploaded.
|
|
//
|
|
// This is useful if your program is ending and you do not
|
|
// want to lose recent spans.
|
|
func (e *statsExporter) Flush() {
|
|
e.bundler.Flush()
|
|
}
|
|
|
|
func (e *statsExporter) onError(err error) {
|
|
if e.o.OnError != nil {
|
|
e.o.OnError(err)
|
|
return
|
|
}
|
|
log.Printf("Failed to export to Stackdriver Monitoring: %v", err)
|
|
}
|
|
|
|
func (e *statsExporter) upload(vds []*view.Data) error {
|
|
ctx := context.Background()
|
|
|
|
for _, vd := range vds {
|
|
if err := e.createMeasure(ctx, vd); err != nil {
|
|
return err
|
|
}
|
|
}
|
|
for _, req := range e.makeReq(vds, maxTimeSeriesPerUpload) {
|
|
if err := e.c.CreateTimeSeries(ctx, req); err != nil {
|
|
// TODO(jbd): Don't fail fast here, batch errors?
|
|
return err
|
|
}
|
|
}
|
|
return nil
|
|
}
|
|
|
|
func (e *statsExporter) makeReq(vds []*view.Data, limit int) []*monitoringpb.CreateTimeSeriesRequest {
|
|
var reqs []*monitoringpb.CreateTimeSeriesRequest
|
|
var timeSeries []*monitoringpb.TimeSeries
|
|
|
|
resource := e.o.Resource
|
|
if resource == nil {
|
|
resource = &monitoredrespb.MonitoredResource{
|
|
Type: "global",
|
|
}
|
|
}
|
|
|
|
for _, vd := range vds {
|
|
for _, row := range vd.Rows {
|
|
ts := &monitoringpb.TimeSeries{
|
|
Metric: &metricpb.Metric{
|
|
Type: namespacedViewName(vd.View.Name(), false),
|
|
Labels: newLabels(row.Tags, e.taskValue),
|
|
},
|
|
Resource: resource,
|
|
Points: []*monitoringpb.Point{newPoint(vd.View, row, vd.Start, vd.End)},
|
|
}
|
|
timeSeries = append(timeSeries, ts)
|
|
if len(timeSeries) == limit {
|
|
reqs = append(reqs, &monitoringpb.CreateTimeSeriesRequest{
|
|
Name: monitoring.MetricProjectPath(e.o.ProjectID),
|
|
TimeSeries: timeSeries,
|
|
})
|
|
timeSeries = []*monitoringpb.TimeSeries{}
|
|
}
|
|
}
|
|
}
|
|
if len(timeSeries) > 0 {
|
|
reqs = append(reqs, &monitoringpb.CreateTimeSeriesRequest{
|
|
Name: monitoring.MetricProjectPath(e.o.ProjectID),
|
|
TimeSeries: timeSeries,
|
|
})
|
|
}
|
|
return reqs
|
|
}
|
|
|
|
// createMeasure creates a MetricDescriptor for the given view data in Stackdriver Monitoring.
|
|
// An error will be returned if there is already a metric descriptor created with the same name
|
|
// but it has a different aggregation or keys.
|
|
func (e *statsExporter) createMeasure(ctx context.Context, vd *view.Data) error {
|
|
e.createdViewsMu.Lock()
|
|
defer e.createdViewsMu.Unlock()
|
|
|
|
m := vd.View.Measure()
|
|
agg := vd.View.Aggregation()
|
|
tagKeys := vd.View.TagKeys()
|
|
viewName := vd.View.Name()
|
|
|
|
if md, ok := e.createdViews[viewName]; ok {
|
|
return equalAggTagKeys(md, agg, tagKeys)
|
|
}
|
|
|
|
metricName := monitoring.MetricMetricDescriptorPath(e.o.ProjectID, namespacedViewName(viewName, true))
|
|
md, err := getMetricDescriptor(ctx, e.c, &monitoringpb.GetMetricDescriptorRequest{
|
|
Name: metricName,
|
|
})
|
|
if err == nil {
|
|
if err := equalAggTagKeys(md, agg, tagKeys); err != nil {
|
|
return err
|
|
}
|
|
e.createdViews[viewName] = md
|
|
return nil
|
|
}
|
|
if grpc.Code(err) != codes.NotFound {
|
|
return err
|
|
}
|
|
|
|
var metricKind metricpb.MetricDescriptor_MetricKind
|
|
var valueType metricpb.MetricDescriptor_ValueType
|
|
|
|
switch agg.(type) {
|
|
case view.CountAggregation:
|
|
valueType = metricpb.MetricDescriptor_INT64
|
|
case view.SumAggregation:
|
|
valueType = metricpb.MetricDescriptor_DOUBLE
|
|
case view.MeanAggregation:
|
|
valueType = metricpb.MetricDescriptor_DISTRIBUTION
|
|
case view.DistributionAggregation:
|
|
valueType = metricpb.MetricDescriptor_DISTRIBUTION
|
|
default:
|
|
return fmt.Errorf("unsupported aggregation type: %T", agg)
|
|
}
|
|
|
|
metricKind = metricpb.MetricDescriptor_CUMULATIVE
|
|
|
|
md, err = createMetricDescriptor(ctx, e.c, &monitoringpb.CreateMetricDescriptorRequest{
|
|
Name: monitoring.MetricProjectPath(e.o.ProjectID),
|
|
MetricDescriptor: &metricpb.MetricDescriptor{
|
|
DisplayName: path.Join("OpenCensus", viewName),
|
|
Description: m.Description(),
|
|
Unit: m.Unit(),
|
|
Type: namespacedViewName(viewName, false),
|
|
MetricKind: metricKind,
|
|
ValueType: valueType,
|
|
Labels: newLabelDescriptors(vd.View.TagKeys()),
|
|
},
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
e.createdViews[viewName] = md
|
|
return nil
|
|
}
|
|
|
|
func newPoint(v *view.View, row *view.Row, start, end time.Time) *monitoringpb.Point {
|
|
return &monitoringpb.Point{
|
|
Interval: &monitoringpb.TimeInterval{
|
|
StartTime: ×tamp.Timestamp{
|
|
Seconds: start.Unix(),
|
|
Nanos: int32(start.Nanosecond()),
|
|
},
|
|
EndTime: ×tamp.Timestamp{
|
|
Seconds: end.Unix(),
|
|
Nanos: int32(end.Nanosecond()),
|
|
},
|
|
},
|
|
Value: newTypedValue(v, row),
|
|
}
|
|
}
|
|
|
|
func newTypedValue(vd *view.View, r *view.Row) *monitoringpb.TypedValue {
|
|
switch v := r.Data.(type) {
|
|
case *view.CountData:
|
|
return &monitoringpb.TypedValue{Value: &monitoringpb.TypedValue_Int64Value{
|
|
Int64Value: int64(*v),
|
|
}}
|
|
case *view.SumData:
|
|
return &monitoringpb.TypedValue{Value: &monitoringpb.TypedValue_DoubleValue{
|
|
DoubleValue: float64(*v),
|
|
}}
|
|
case *view.MeanData:
|
|
return &monitoringpb.TypedValue{Value: &monitoringpb.TypedValue_DistributionValue{
|
|
DistributionValue: &distributionpb.Distribution{
|
|
Count: int64(v.Count),
|
|
Mean: v.Mean,
|
|
SumOfSquaredDeviation: 0,
|
|
BucketOptions: &distributionpb.Distribution_BucketOptions{
|
|
Options: &distributionpb.Distribution_BucketOptions_ExplicitBuckets{
|
|
ExplicitBuckets: &distributionpb.Distribution_BucketOptions_Explicit{
|
|
Bounds: []float64{0},
|
|
},
|
|
},
|
|
},
|
|
BucketCounts: []int64{0, int64(v.Count)},
|
|
},
|
|
}}
|
|
case *view.DistributionData:
|
|
bounds := vd.Aggregation().(view.DistributionAggregation)
|
|
return &monitoringpb.TypedValue{Value: &monitoringpb.TypedValue_DistributionValue{
|
|
DistributionValue: &distributionpb.Distribution{
|
|
Count: v.Count,
|
|
Mean: v.Mean,
|
|
SumOfSquaredDeviation: v.SumOfSquaredDev,
|
|
// TODO(songya): uncomment this once Stackdriver supports min/max.
|
|
// Range: &distributionpb.Distribution_Range{
|
|
// Min: v.Min,
|
|
// Max: v.Max,
|
|
// },
|
|
BucketOptions: &distributionpb.Distribution_BucketOptions{
|
|
Options: &distributionpb.Distribution_BucketOptions_ExplicitBuckets{
|
|
ExplicitBuckets: &distributionpb.Distribution_BucketOptions_Explicit{
|
|
Bounds: []float64(bounds),
|
|
},
|
|
},
|
|
},
|
|
BucketCounts: v.CountPerBucket,
|
|
},
|
|
}}
|
|
}
|
|
return nil
|
|
}
|
|
|
|
func namespacedViewName(v string, escaped bool) string {
|
|
p := path.Join("opencensus", v)
|
|
if escaped {
|
|
p = url.PathEscape(p)
|
|
}
|
|
return path.Join("custom.googleapis.com", p)
|
|
}
|
|
|
|
func newLabels(tags []tag.Tag, taskValue string) map[string]string {
|
|
labels := make(map[string]string)
|
|
for _, tag := range tags {
|
|
labels[internal.Sanitize(tag.Key.Name())] = tag.Value
|
|
}
|
|
labels[opencensusTaskKey] = taskValue
|
|
return labels
|
|
}
|
|
|
|
func newLabelDescriptors(keys []tag.Key) []*labelpb.LabelDescriptor {
|
|
labelDescriptors := make([]*labelpb.LabelDescriptor, len(keys)+1)
|
|
for i, key := range keys {
|
|
labelDescriptors[i] = &labelpb.LabelDescriptor{
|
|
Key: internal.Sanitize(key.Name()),
|
|
ValueType: labelpb.LabelDescriptor_STRING, // We only use string tags
|
|
}
|
|
}
|
|
// Add a specific open census task id label.
|
|
labelDescriptors[len(keys)] = &labelpb.LabelDescriptor{
|
|
Key: opencensusTaskKey,
|
|
ValueType: labelpb.LabelDescriptor_STRING,
|
|
Description: opencensusTaskDescription,
|
|
}
|
|
return labelDescriptors
|
|
}
|
|
|
|
func equalAggTagKeys(md *metricpb.MetricDescriptor, agg view.Aggregation, keys []tag.Key) error {
|
|
aggType := reflect.TypeOf(agg)
|
|
if aggType.Kind() == reflect.Ptr { // if pointer, find out the concrete type
|
|
aggType = reflect.ValueOf(agg).Elem().Type()
|
|
}
|
|
var aggTypeMatch bool
|
|
switch md.ValueType {
|
|
case metricpb.MetricDescriptor_INT64:
|
|
aggTypeMatch = aggType == reflect.TypeOf(view.CountAggregation{})
|
|
case metricpb.MetricDescriptor_DOUBLE:
|
|
aggTypeMatch = aggType == reflect.TypeOf(view.SumAggregation{})
|
|
case metricpb.MetricDescriptor_DISTRIBUTION:
|
|
aggTypeMatch = aggType == reflect.TypeOf(view.MeanAggregation{}) || aggType == reflect.TypeOf(view.DistributionAggregation{})
|
|
}
|
|
|
|
if !aggTypeMatch {
|
|
return fmt.Errorf("stackdriver metric descriptor was not created with aggregation type %T", aggType)
|
|
}
|
|
|
|
if len(md.Labels) != len(keys)+1 {
|
|
return errors.New("stackdriver metric descriptor was not created with the view labels")
|
|
}
|
|
|
|
labels := make(map[string]struct{}, len(keys)+1)
|
|
for _, k := range keys {
|
|
labels[internal.Sanitize(k.Name())] = struct{}{}
|
|
}
|
|
labels[opencensusTaskKey] = struct{}{}
|
|
|
|
for _, k := range md.Labels {
|
|
if _, ok := labels[k.Key]; !ok {
|
|
return fmt.Errorf("stackdriver metric descriptor was not created with label %q", k)
|
|
}
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
var createMetricDescriptor = func(ctx context.Context, c *monitoring.MetricClient, mdr *monitoringpb.CreateMetricDescriptorRequest) (*metric.MetricDescriptor, error) {
|
|
return c.CreateMetricDescriptor(ctx, mdr)
|
|
}
|
|
|
|
var getMetricDescriptor = func(ctx context.Context, c *monitoring.MetricClient, mdr *monitoringpb.GetMetricDescriptorRequest) (*metric.MetricDescriptor, error) {
|
|
return c.GetMetricDescriptor(ctx, mdr)
|
|
}
|