2017-05-10 02:44:13 -07:00
|
|
|
// Copyright 2017 The Prometheus 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
|
2017-10-16 18:26:38 -07:00
|
|
|
// limitations under the License.
|
2017-05-10 02:44:13 -07:00
|
|
|
|
|
|
|
package remote
|
|
|
|
|
|
|
|
import (
|
2018-05-29 01:51:29 -07:00
|
|
|
"context"
|
2022-07-01 09:59:50 -07:00
|
|
|
"errors"
|
2017-05-10 02:44:13 -07:00
|
|
|
"net/http"
|
|
|
|
"net/http/httptest"
|
|
|
|
"net/url"
|
|
|
|
"strings"
|
|
|
|
"testing"
|
|
|
|
"time"
|
|
|
|
|
2024-08-27 23:23:54 -07:00
|
|
|
"github.com/gogo/protobuf/proto"
|
|
|
|
"github.com/golang/snappy"
|
2018-01-11 07:10:25 -08:00
|
|
|
config_util "github.com/prometheus/common/config"
|
2017-05-10 02:44:13 -07:00
|
|
|
"github.com/prometheus/common/model"
|
2020-10-29 02:43:23 -07:00
|
|
|
"github.com/stretchr/testify/require"
|
2024-08-27 23:23:54 -07:00
|
|
|
|
|
|
|
"github.com/prometheus/prometheus/config"
|
|
|
|
"github.com/prometheus/prometheus/prompb"
|
|
|
|
"github.com/prometheus/prometheus/tsdb/chunkenc"
|
2017-05-10 02:44:13 -07:00
|
|
|
)
|
|
|
|
|
|
|
|
var longErrMessage = strings.Repeat("error message", maxErrMsgLen)
|
|
|
|
|
|
|
|
func TestStoreHTTPErrorHandling(t *testing.T) {
|
|
|
|
tests := []struct {
|
|
|
|
code int
|
|
|
|
err error
|
|
|
|
}{
|
|
|
|
{
|
|
|
|
code: 200,
|
|
|
|
err: nil,
|
|
|
|
},
|
|
|
|
{
|
|
|
|
code: 300,
|
2019-03-25 16:01:12 -07:00
|
|
|
err: errors.New("server returned HTTP status 300 Multiple Choices: " + longErrMessage[:maxErrMsgLen]),
|
2017-05-10 02:44:13 -07:00
|
|
|
},
|
|
|
|
{
|
|
|
|
code: 404,
|
2019-03-25 16:01:12 -07:00
|
|
|
err: errors.New("server returned HTTP status 404 Not Found: " + longErrMessage[:maxErrMsgLen]),
|
2017-05-10 02:44:13 -07:00
|
|
|
},
|
|
|
|
{
|
|
|
|
code: 500,
|
2021-02-10 14:25:37 -08:00
|
|
|
err: RecoverableError{errors.New("server returned HTTP status 500 Internal Server Error: " + longErrMessage[:maxErrMsgLen]), defaultBackoff},
|
2017-05-10 02:44:13 -07:00
|
|
|
},
|
|
|
|
}
|
|
|
|
|
2020-10-22 02:00:08 -07:00
|
|
|
for _, test := range tests {
|
2017-05-10 02:44:13 -07:00
|
|
|
server := httptest.NewServer(
|
|
|
|
http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
|
|
|
|
http.Error(w, longErrMessage, test.code)
|
|
|
|
}),
|
|
|
|
)
|
|
|
|
|
|
|
|
serverURL, err := url.Parse(server.URL)
|
2020-10-29 02:43:23 -07:00
|
|
|
require.NoError(t, err)
|
2017-05-10 02:44:13 -07:00
|
|
|
|
2019-12-12 12:47:23 -08:00
|
|
|
conf := &ClientConfig{
|
Refactor SD configuration to remove `config` dependency (#3629)
* refactor: move targetGroup struct and CheckOverflow() to their own package
* refactor: move auth and security related structs to a utility package, fix import error in utility package
* refactor: Azure SD, remove SD struct from config
* refactor: DNS SD, remove SD struct from config into dns package
* refactor: ec2 SD, move SD struct from config into the ec2 package
* refactor: file SD, move SD struct from config to file discovery package
* refactor: gce, move SD struct from config to gce discovery package
* refactor: move HTTPClientConfig and URL into util/config, fix import error in httputil
* refactor: consul, move SD struct from config into consul discovery package
* refactor: marathon, move SD struct from config into marathon discovery package
* refactor: triton, move SD struct from config to triton discovery package, fix test
* refactor: zookeeper, move SD structs from config to zookeeper discovery package
* refactor: openstack, remove SD struct from config, move into openstack discovery package
* refactor: kubernetes, move SD struct from config into kubernetes discovery package
* refactor: notifier, use targetgroup package instead of config
* refactor: tests for file, marathon, triton SD - use targetgroup package instead of config.TargetGroup
* refactor: retrieval, use targetgroup package instead of config.TargetGroup
* refactor: storage, use config util package
* refactor: discovery manager, use targetgroup package instead of config.TargetGroup
* refactor: use HTTPClient and TLS config from configUtil instead of config
* refactor: tests, use targetgroup package instead of config.TargetGroup
* refactor: fix tagetgroup.Group pointers that were removed by mistake
* refactor: openstack, kubernetes: drop prefixes
* refactor: remove import aliases forced due to vscode bug
* refactor: move main SD struct out of config into discovery/config
* refactor: rename configUtil to config_util
* refactor: rename yamlUtil to yaml_config
* refactor: kubernetes, remove prefixes
* refactor: move the TargetGroup package to discovery/
* refactor: fix order of imports
2017-12-29 12:01:34 -08:00
|
|
|
URL: &config_util.URL{URL: serverURL},
|
2017-10-23 06:53:43 -07:00
|
|
|
Timeout: model.Duration(time.Second),
|
2017-10-09 08:53:24 -07:00
|
|
|
}
|
2017-05-10 02:44:13 -07:00
|
|
|
|
2019-12-12 12:47:23 -08:00
|
|
|
hash, err := toHash(conf)
|
2020-10-29 02:43:23 -07:00
|
|
|
require.NoError(t, err)
|
2020-06-24 06:41:52 -07:00
|
|
|
c, err := NewWriteClient(hash, conf)
|
2020-10-29 02:43:23 -07:00
|
|
|
require.NoError(t, err)
|
2019-12-12 12:47:23 -08:00
|
|
|
|
2024-07-19 10:53:40 -07:00
|
|
|
_, err = c.Store(context.Background(), []byte{}, 0)
|
2020-10-22 02:00:08 -07:00
|
|
|
if test.err != nil {
|
2020-10-29 02:43:23 -07:00
|
|
|
require.EqualError(t, err, test.err.Error())
|
2020-10-22 02:00:08 -07:00
|
|
|
} else {
|
2020-10-29 02:43:23 -07:00
|
|
|
require.NoError(t, err)
|
2020-10-22 02:00:08 -07:00
|
|
|
}
|
2017-05-10 02:44:13 -07:00
|
|
|
|
|
|
|
server.Close()
|
|
|
|
}
|
|
|
|
}
|
2021-02-10 14:25:37 -08:00
|
|
|
|
2021-02-11 09:24:49 -08:00
|
|
|
func TestClientRetryAfter(t *testing.T) {
|
2023-09-07 07:36:29 -07:00
|
|
|
setupServer := func(statusCode int) *httptest.Server {
|
|
|
|
return httptest.NewServer(
|
|
|
|
http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
|
2023-09-07 07:42:00 -07:00
|
|
|
w.Header().Set("Retry-After", "5")
|
2023-09-07 07:36:29 -07:00
|
|
|
http.Error(w, longErrMessage, statusCode)
|
|
|
|
}),
|
|
|
|
)
|
|
|
|
}
|
|
|
|
|
|
|
|
getClientConfig := func(serverURL *url.URL, retryOnRateLimit bool) *ClientConfig {
|
|
|
|
return &ClientConfig{
|
|
|
|
URL: &config_util.URL{URL: serverURL},
|
|
|
|
Timeout: model.Duration(time.Second),
|
|
|
|
RetryOnRateLimit: retryOnRateLimit,
|
|
|
|
}
|
|
|
|
}
|
2021-02-11 09:24:49 -08:00
|
|
|
|
|
|
|
getClient := func(conf *ClientConfig) WriteClient {
|
|
|
|
hash, err := toHash(conf)
|
|
|
|
require.NoError(t, err)
|
|
|
|
c, err := NewWriteClient(hash, conf)
|
|
|
|
require.NoError(t, err)
|
|
|
|
return c
|
|
|
|
}
|
|
|
|
|
2023-09-07 07:36:29 -07:00
|
|
|
testCases := []struct {
|
|
|
|
name string
|
|
|
|
statusCode int
|
|
|
|
retryOnRateLimit bool
|
|
|
|
expectedRecoverable bool
|
2023-09-07 07:42:00 -07:00
|
|
|
expectedRetryAfter model.Duration
|
2023-09-07 07:36:29 -07:00
|
|
|
}{
|
2023-09-07 07:42:00 -07:00
|
|
|
{"TooManyRequests - No Retry", http.StatusTooManyRequests, false, false, 0},
|
|
|
|
{"TooManyRequests - With Retry", http.StatusTooManyRequests, true, true, 5 * model.Duration(time.Second)},
|
|
|
|
{"InternalServerError", http.StatusInternalServerError, false, true, 5 * model.Duration(time.Second)}, // HTTP 5xx errors do not depend on retryOnRateLimit.
|
2021-02-11 09:24:49 -08:00
|
|
|
}
|
|
|
|
|
2023-09-07 07:36:29 -07:00
|
|
|
for _, tc := range testCases {
|
|
|
|
t.Run(tc.name, func(t *testing.T) {
|
|
|
|
server := setupServer(tc.statusCode)
|
|
|
|
defer server.Close()
|
2023-03-08 12:58:09 -08:00
|
|
|
|
2023-09-07 07:36:29 -07:00
|
|
|
serverURL, err := url.Parse(server.URL)
|
|
|
|
require.NoError(t, err)
|
2021-02-11 09:24:49 -08:00
|
|
|
|
2023-09-07 07:36:29 -07:00
|
|
|
c := getClient(getClientConfig(serverURL, tc.retryOnRateLimit))
|
2021-02-11 09:24:49 -08:00
|
|
|
|
2023-09-07 07:36:29 -07:00
|
|
|
var recErr RecoverableError
|
2024-07-19 10:53:40 -07:00
|
|
|
_, err = c.Store(context.Background(), []byte{}, 0)
|
2023-09-07 07:36:29 -07:00
|
|
|
require.Equal(t, tc.expectedRecoverable, errors.As(err, &recErr), "Mismatch in expected recoverable error status.")
|
2023-09-07 07:42:00 -07:00
|
|
|
if tc.expectedRecoverable {
|
2023-10-31 04:15:30 -07:00
|
|
|
require.Equal(t, tc.expectedRetryAfter, recErr.retryAfter)
|
2023-09-07 07:42:00 -07:00
|
|
|
}
|
2023-09-07 07:36:29 -07:00
|
|
|
})
|
|
|
|
}
|
2021-02-11 09:24:49 -08:00
|
|
|
}
|
|
|
|
|
2021-02-10 14:25:37 -08:00
|
|
|
func TestRetryAfterDuration(t *testing.T) {
|
|
|
|
tc := []struct {
|
|
|
|
name string
|
|
|
|
tInput string
|
|
|
|
expected model.Duration
|
|
|
|
}{
|
|
|
|
{
|
|
|
|
name: "seconds",
|
|
|
|
tInput: "120",
|
|
|
|
expected: model.Duration(time.Second * 120),
|
|
|
|
},
|
|
|
|
{
|
|
|
|
name: "date-time default",
|
|
|
|
tInput: time.RFC1123, // Expected layout is http.TimeFormat, hence an error.
|
|
|
|
expected: defaultBackoff,
|
|
|
|
},
|
|
|
|
{
|
|
|
|
name: "retry-after not provided",
|
|
|
|
tInput: "", // Expected layout is http.TimeFormat, hence an error.
|
|
|
|
expected: defaultBackoff,
|
|
|
|
},
|
|
|
|
}
|
|
|
|
for _, c := range tc {
|
|
|
|
require.Equal(t, c.expected, retryAfterDuration(c.tInput), c.name)
|
|
|
|
}
|
|
|
|
}
|
2023-11-09 06:38:35 -08:00
|
|
|
|
2024-07-19 10:53:40 -07:00
|
|
|
func TestClientCustomHeaders(t *testing.T) {
|
2023-11-09 06:38:35 -08:00
|
|
|
headersToSend := map[string]string{"Foo": "Bar", "Baz": "qux"}
|
|
|
|
|
|
|
|
var called bool
|
|
|
|
server := httptest.NewServer(
|
|
|
|
http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
|
|
|
|
called = true
|
|
|
|
receivedHeaders := r.Header
|
|
|
|
for name, value := range headersToSend {
|
|
|
|
require.Equal(
|
|
|
|
t,
|
|
|
|
[]string{value},
|
|
|
|
receivedHeaders.Values(name),
|
|
|
|
"expected %v to be part of the received headers %v",
|
|
|
|
headersToSend,
|
|
|
|
receivedHeaders,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
}),
|
|
|
|
)
|
|
|
|
defer server.Close()
|
|
|
|
|
|
|
|
serverURL, err := url.Parse(server.URL)
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
conf := &ClientConfig{
|
|
|
|
URL: &config_util.URL{URL: serverURL},
|
|
|
|
Timeout: model.Duration(time.Second),
|
|
|
|
Headers: headersToSend,
|
|
|
|
}
|
|
|
|
|
|
|
|
c, err := NewWriteClient("c", conf)
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
2024-07-19 10:53:40 -07:00
|
|
|
_, err = c.Store(context.Background(), []byte{}, 0)
|
2023-11-09 06:38:35 -08:00
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
require.True(t, called, "The remote server wasn't called")
|
|
|
|
}
|
2024-08-27 23:23:54 -07:00
|
|
|
|
|
|
|
func TestReadClient(t *testing.T) {
|
|
|
|
tests := []struct {
|
|
|
|
name string
|
|
|
|
query *prompb.Query
|
|
|
|
httpHandler http.HandlerFunc
|
|
|
|
expectedLabels []map[string]string
|
|
|
|
expectedSamples [][]model.SamplePair
|
|
|
|
expectedErrorContains string
|
|
|
|
sortSeries bool
|
|
|
|
}{
|
|
|
|
{
|
|
|
|
name: "sorted sampled response",
|
|
|
|
httpHandler: sampledResponseHTTPHandler(t),
|
|
|
|
expectedLabels: []map[string]string{
|
|
|
|
{"foo1": "bar"},
|
|
|
|
{"foo2": "bar"},
|
|
|
|
},
|
|
|
|
expectedSamples: [][]model.SamplePair{
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(0), Value: model.SampleValue(3)},
|
|
|
|
{Timestamp: model.Time(5), Value: model.SampleValue(4)},
|
|
|
|
},
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(0), Value: model.SampleValue(1)},
|
|
|
|
{Timestamp: model.Time(5), Value: model.SampleValue(2)},
|
|
|
|
},
|
|
|
|
},
|
|
|
|
expectedErrorContains: "",
|
|
|
|
sortSeries: true,
|
|
|
|
},
|
|
|
|
{
|
|
|
|
name: "unsorted sampled response",
|
|
|
|
httpHandler: sampledResponseHTTPHandler(t),
|
|
|
|
expectedLabels: []map[string]string{
|
|
|
|
{"foo2": "bar"},
|
|
|
|
{"foo1": "bar"},
|
|
|
|
},
|
|
|
|
expectedSamples: [][]model.SamplePair{
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(0), Value: model.SampleValue(1)},
|
|
|
|
{Timestamp: model.Time(5), Value: model.SampleValue(2)},
|
|
|
|
},
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(0), Value: model.SampleValue(3)},
|
|
|
|
{Timestamp: model.Time(5), Value: model.SampleValue(4)},
|
|
|
|
},
|
|
|
|
},
|
|
|
|
expectedErrorContains: "",
|
|
|
|
sortSeries: false,
|
|
|
|
},
|
|
|
|
{
|
|
|
|
name: "chunked response",
|
|
|
|
query: &prompb.Query{
|
|
|
|
StartTimestampMs: 4000,
|
|
|
|
EndTimestampMs: 12000,
|
|
|
|
},
|
|
|
|
httpHandler: http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
|
|
|
|
w.Header().Set("Content-Type", "application/x-streamed-protobuf; proto=prometheus.ChunkedReadResponse")
|
|
|
|
|
|
|
|
flusher, ok := w.(http.Flusher)
|
|
|
|
require.True(t, ok)
|
|
|
|
|
|
|
|
cw := NewChunkedWriter(w, flusher)
|
|
|
|
l := []prompb.Label{
|
|
|
|
{Name: "foo", Value: "bar"},
|
|
|
|
}
|
|
|
|
|
|
|
|
chunks := buildTestChunks(t)
|
|
|
|
for i, c := range chunks {
|
|
|
|
cSeries := prompb.ChunkedSeries{Labels: l, Chunks: []prompb.Chunk{c}}
|
|
|
|
readResp := prompb.ChunkedReadResponse{
|
|
|
|
ChunkedSeries: []*prompb.ChunkedSeries{&cSeries},
|
|
|
|
QueryIndex: int64(i),
|
|
|
|
}
|
|
|
|
|
|
|
|
b, err := proto.Marshal(&readResp)
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
_, err = cw.Write(b)
|
|
|
|
require.NoError(t, err)
|
|
|
|
}
|
|
|
|
}),
|
|
|
|
expectedLabels: []map[string]string{
|
|
|
|
{"foo": "bar"},
|
|
|
|
{"foo": "bar"},
|
|
|
|
{"foo": "bar"},
|
|
|
|
},
|
|
|
|
// This is the output of buildTestChunks minus the samples outside the query range.
|
|
|
|
expectedSamples: [][]model.SamplePair{
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(4000), Value: model.SampleValue(4)},
|
|
|
|
},
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(5000), Value: model.SampleValue(1)},
|
|
|
|
{Timestamp: model.Time(6000), Value: model.SampleValue(2)},
|
|
|
|
{Timestamp: model.Time(7000), Value: model.SampleValue(3)},
|
|
|
|
{Timestamp: model.Time(8000), Value: model.SampleValue(4)},
|
|
|
|
{Timestamp: model.Time(9000), Value: model.SampleValue(5)},
|
|
|
|
},
|
|
|
|
{
|
|
|
|
{Timestamp: model.Time(10000), Value: model.SampleValue(2)},
|
|
|
|
{Timestamp: model.Time(11000), Value: model.SampleValue(3)},
|
|
|
|
{Timestamp: model.Time(12000), Value: model.SampleValue(4)},
|
|
|
|
},
|
|
|
|
},
|
|
|
|
expectedErrorContains: "",
|
|
|
|
},
|
|
|
|
{
|
|
|
|
name: "unsupported content type",
|
|
|
|
httpHandler: http.HandlerFunc(func(w http.ResponseWriter, r *http.Request) {
|
|
|
|
w.Header().Set("Content-Type", "foobar")
|
|
|
|
}),
|
|
|
|
expectedErrorContains: "unsupported content type",
|
|
|
|
},
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, test := range tests {
|
|
|
|
t.Run(test.name, func(t *testing.T) {
|
|
|
|
server := httptest.NewServer(test.httpHandler)
|
|
|
|
defer server.Close()
|
|
|
|
|
|
|
|
u, err := url.Parse(server.URL)
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
conf := &ClientConfig{
|
|
|
|
URL: &config_util.URL{URL: u},
|
|
|
|
Timeout: model.Duration(5 * time.Second),
|
|
|
|
ChunkedReadLimit: config.DefaultChunkedReadLimit,
|
|
|
|
}
|
|
|
|
c, err := NewReadClient("test", conf)
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
query := &prompb.Query{}
|
|
|
|
if test.query != nil {
|
|
|
|
query = test.query
|
|
|
|
}
|
|
|
|
|
|
|
|
ss, err := c.Read(context.Background(), query, test.sortSeries)
|
|
|
|
if test.expectedErrorContains != "" {
|
|
|
|
require.ErrorContains(t, err, test.expectedErrorContains)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
i := 0
|
|
|
|
|
|
|
|
for ss.Next() {
|
|
|
|
require.NoError(t, ss.Err())
|
|
|
|
s := ss.At()
|
|
|
|
|
|
|
|
l := s.Labels()
|
|
|
|
require.Len(t, test.expectedLabels[i], l.Len())
|
|
|
|
for k, v := range test.expectedLabels[i] {
|
|
|
|
require.True(t, l.Has(k))
|
|
|
|
require.Equal(t, v, l.Get(k))
|
|
|
|
}
|
|
|
|
|
|
|
|
it := s.Iterator(nil)
|
|
|
|
j := 0
|
|
|
|
|
|
|
|
for valType := it.Next(); valType != chunkenc.ValNone; valType = it.Next() {
|
|
|
|
require.NoError(t, it.Err())
|
|
|
|
|
|
|
|
ts, v := it.At()
|
|
|
|
expectedSample := test.expectedSamples[i][j]
|
|
|
|
|
|
|
|
require.Equal(t, int64(expectedSample.Timestamp), ts)
|
|
|
|
require.Equal(t, float64(expectedSample.Value), v)
|
|
|
|
|
|
|
|
j++
|
|
|
|
}
|
|
|
|
|
|
|
|
require.Len(t, test.expectedSamples[i], j)
|
|
|
|
|
|
|
|
i++
|
|
|
|
}
|
|
|
|
|
|
|
|
require.NoError(t, ss.Err())
|
|
|
|
})
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func sampledResponseHTTPHandler(t *testing.T) http.HandlerFunc {
|
|
|
|
return func(w http.ResponseWriter, r *http.Request) {
|
|
|
|
w.Header().Set("Content-Type", "application/x-protobuf")
|
|
|
|
|
|
|
|
resp := prompb.ReadResponse{
|
|
|
|
Results: []*prompb.QueryResult{
|
|
|
|
{
|
|
|
|
Timeseries: []*prompb.TimeSeries{
|
|
|
|
{
|
|
|
|
Labels: []prompb.Label{
|
|
|
|
{Name: "foo2", Value: "bar"},
|
|
|
|
},
|
|
|
|
Samples: []prompb.Sample{
|
|
|
|
{Value: float64(1), Timestamp: int64(0)},
|
|
|
|
{Value: float64(2), Timestamp: int64(5)},
|
|
|
|
},
|
|
|
|
Exemplars: []prompb.Exemplar{},
|
|
|
|
},
|
|
|
|
{
|
|
|
|
Labels: []prompb.Label{
|
|
|
|
{Name: "foo1", Value: "bar"},
|
|
|
|
},
|
|
|
|
Samples: []prompb.Sample{
|
|
|
|
{Value: float64(3), Timestamp: int64(0)},
|
|
|
|
{Value: float64(4), Timestamp: int64(5)},
|
|
|
|
},
|
|
|
|
Exemplars: []prompb.Exemplar{},
|
|
|
|
},
|
|
|
|
},
|
|
|
|
},
|
|
|
|
},
|
|
|
|
}
|
|
|
|
b, err := proto.Marshal(&resp)
|
|
|
|
require.NoError(t, err)
|
|
|
|
|
|
|
|
_, err = w.Write(snappy.Encode(nil, b))
|
|
|
|
require.NoError(t, err)
|
|
|
|
}
|
|
|
|
}
|