2023-05-09 00:20:31 -04:00
|
|
|
// Copyright (c) 2015-2023 MinIO, Inc.
|
2021-04-18 15:41:13 -04:00
|
|
|
//
|
|
|
|
// This file is part of MinIO Object Storage stack
|
|
|
|
//
|
|
|
|
// This program is free software: you can redistribute it and/or modify
|
|
|
|
// it under the terms of the GNU Affero General Public License as published by
|
|
|
|
// the Free Software Foundation, either version 3 of the License, or
|
|
|
|
// (at your option) any later version.
|
|
|
|
//
|
|
|
|
// This program is distributed in the hope that it will be useful
|
|
|
|
// but WITHOUT ANY WARRANTY; without even the implied warranty of
|
|
|
|
// MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the
|
|
|
|
// GNU Affero General Public License for more details.
|
|
|
|
//
|
|
|
|
// You should have received a copy of the GNU Affero General Public License
|
|
|
|
// along with this program. If not, see <http://www.gnu.org/licenses/>.
|
2018-07-19 18:55:06 -04:00
|
|
|
|
2018-11-19 17:47:03 -05:00
|
|
|
package http
|
2018-07-19 18:55:06 -04:00
|
|
|
|
|
|
|
import (
|
|
|
|
"bytes"
|
2020-08-16 13:25:00 -04:00
|
|
|
"context"
|
2018-07-19 18:55:06 -04:00
|
|
|
"encoding/json"
|
|
|
|
"errors"
|
2020-08-16 13:25:00 -04:00
|
|
|
"fmt"
|
2023-03-21 13:50:40 -04:00
|
|
|
"math"
|
2023-09-21 14:24:56 -04:00
|
|
|
"math/rand"
|
2019-07-03 01:34:32 -04:00
|
|
|
"net/http"
|
2023-02-22 00:19:46 -05:00
|
|
|
"net/url"
|
2023-05-09 00:20:31 -04:00
|
|
|
"os"
|
|
|
|
"path/filepath"
|
2022-02-17 14:11:15 -05:00
|
|
|
"sync"
|
2022-11-10 13:20:21 -05:00
|
|
|
"sync/atomic"
|
2020-08-16 13:25:00 -04:00
|
|
|
"time"
|
2019-02-06 15:07:03 -05:00
|
|
|
|
2021-06-01 17:59:40 -04:00
|
|
|
xhttp "github.com/minio/minio/internal/http"
|
2022-02-24 12:05:33 -05:00
|
|
|
"github.com/minio/minio/internal/logger/target/types"
|
2023-05-09 00:20:31 -04:00
|
|
|
"github.com/minio/minio/internal/once"
|
|
|
|
"github.com/minio/minio/internal/store"
|
2023-09-04 15:57:37 -04:00
|
|
|
xnet "github.com/minio/pkg/v2/net"
|
2018-07-19 18:55:06 -04:00
|
|
|
)
|
|
|
|
|
2022-11-10 13:20:21 -05:00
|
|
|
const (
|
|
|
|
// Timeout for the webhook http call
|
2023-08-03 05:47:07 -04:00
|
|
|
webhookCallTimeout = 3 * time.Second
|
2022-11-10 13:20:21 -05:00
|
|
|
|
2023-07-29 15:49:18 -04:00
|
|
|
// maxWorkers is the maximum number of concurrent http loggers
|
2023-03-21 13:50:40 -04:00
|
|
|
maxWorkers = 16
|
2023-05-09 00:20:31 -04:00
|
|
|
|
|
|
|
// the suffix for the configured queue dir where the logs will be persisted.
|
|
|
|
httpLoggerExtension = ".http.log"
|
2023-03-21 13:50:40 -04:00
|
|
|
)
|
|
|
|
|
|
|
|
const (
|
|
|
|
statusOffline = iota
|
|
|
|
statusOnline
|
|
|
|
statusClosed
|
2022-11-10 13:20:21 -05:00
|
|
|
)
|
2021-05-27 12:54:10 -04:00
|
|
|
|
2021-07-13 12:39:13 -04:00
|
|
|
// Config http logger target
|
|
|
|
type Config struct {
|
|
|
|
Enabled bool `json:"enabled"`
|
|
|
|
Name string `json:"name"`
|
|
|
|
UserAgent string `json:"userAgent"`
|
2023-08-03 05:47:07 -04:00
|
|
|
Endpoint *xnet.URL `json:"endpoint"`
|
2021-07-13 12:39:13 -04:00
|
|
|
AuthToken string `json:"authToken"`
|
|
|
|
ClientCert string `json:"clientCert"`
|
|
|
|
ClientKey string `json:"clientKey"`
|
2021-12-20 16:16:53 -05:00
|
|
|
QueueSize int `json:"queueSize"`
|
2023-05-09 00:20:31 -04:00
|
|
|
QueueDir string `json:"queueDir"`
|
2023-02-22 00:19:46 -05:00
|
|
|
Proxy string `json:"string"`
|
2021-07-13 12:39:13 -04:00
|
|
|
Transport http.RoundTripper `json:"-"`
|
|
|
|
|
|
|
|
// Custom logger
|
2022-07-27 12:44:59 -04:00
|
|
|
LogOnce func(ctx context.Context, err error, id string, errKind ...interface{}) `json:"-"`
|
2021-07-13 12:39:13 -04:00
|
|
|
}
|
|
|
|
|
2018-11-19 17:47:03 -05:00
|
|
|
// Target implements logger.Target and sends the json
|
2018-07-19 18:55:06 -04:00
|
|
|
// format of a log entry to the configured http endpoint.
|
|
|
|
// An internal buffer of logs is maintained but when the
|
|
|
|
// buffer is full, new logs are just ignored and an error
|
|
|
|
// is returned to the caller.
|
2018-11-19 17:47:03 -05:00
|
|
|
type Target struct {
|
2022-11-10 13:20:21 -05:00
|
|
|
totalMessages int64
|
|
|
|
failedMessages int64
|
2023-03-21 13:50:40 -04:00
|
|
|
status int32
|
2022-11-10 13:20:21 -05:00
|
|
|
|
|
|
|
// Worker control
|
|
|
|
workers int64
|
|
|
|
workerStartMu sync.Mutex
|
|
|
|
lastStarted time.Time
|
|
|
|
|
2023-03-21 13:50:40 -04:00
|
|
|
wg sync.WaitGroup
|
2022-02-17 14:11:15 -05:00
|
|
|
|
2023-03-21 13:50:40 -04:00
|
|
|
// Channel of log entries.
|
|
|
|
// Reading logCh must hold read lock on logChMu (to avoid read race)
|
|
|
|
// Sending a value on logCh must hold read lock on logChMu (to avoid closing)
|
|
|
|
logCh chan interface{}
|
|
|
|
logChMu sync.RWMutex
|
2018-10-12 15:25:59 -04:00
|
|
|
|
2023-03-21 13:50:40 -04:00
|
|
|
// If the first init fails, this starts a goroutine that
|
|
|
|
// will attempt to establish the connection.
|
|
|
|
revive sync.Once
|
2022-11-28 11:03:26 -05:00
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
// store to persist and replay the logs to the target
|
|
|
|
// to avoid missing events when the target is down.
|
2023-06-07 14:47:00 -04:00
|
|
|
store store.Store[interface{}]
|
|
|
|
storeCtxCancel context.CancelFunc
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
initQueueStoreOnce once.Init
|
|
|
|
|
2021-07-13 12:39:13 -04:00
|
|
|
config Config
|
2022-11-10 13:20:21 -05:00
|
|
|
client *http.Client
|
2018-07-19 18:55:06 -04:00
|
|
|
}
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
// Name returns the name of the target
|
|
|
|
func (h *Target) Name() string {
|
|
|
|
return "minio-http-" + h.config.Name
|
|
|
|
}
|
|
|
|
|
2020-10-02 19:19:44 -04:00
|
|
|
// Endpoint returns the backend endpoint
|
|
|
|
func (h *Target) Endpoint() string {
|
2023-08-03 05:47:07 -04:00
|
|
|
return h.config.Endpoint.String()
|
2020-10-02 19:19:44 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
func (h *Target) String() string {
|
2021-07-13 12:39:13 -04:00
|
|
|
return h.config.Name
|
2020-10-02 19:19:44 -04:00
|
|
|
}
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
// IsOnline returns true if the target is reachable.
|
|
|
|
func (h *Target) IsOnline(ctx context.Context) bool {
|
2023-08-03 05:47:07 -04:00
|
|
|
if err := h.send(ctx, []byte(`{}`), webhookCallTimeout); err != nil {
|
|
|
|
return !xnet.IsNetworkOrHostDown(err, false) && !xnet.IsConnRefusedErr(err)
|
2023-05-17 14:10:33 -04:00
|
|
|
}
|
|
|
|
return true
|
2022-11-28 11:03:26 -05:00
|
|
|
}
|
|
|
|
|
2022-11-10 13:20:21 -05:00
|
|
|
// Stats returns the target statistics.
|
|
|
|
func (h *Target) Stats() types.TargetStats {
|
2023-03-21 13:50:40 -04:00
|
|
|
h.logChMu.RLock()
|
2023-06-07 14:47:00 -04:00
|
|
|
queueLength := len(h.logCh)
|
2023-03-21 13:50:40 -04:00
|
|
|
h.logChMu.RUnlock()
|
|
|
|
stats := types.TargetStats{
|
2022-11-10 13:20:21 -05:00
|
|
|
TotalMessages: atomic.LoadInt64(&h.totalMessages),
|
|
|
|
FailedMessages: atomic.LoadInt64(&h.failedMessages),
|
2023-06-07 14:47:00 -04:00
|
|
|
QueueLength: queueLength,
|
2022-11-10 13:20:21 -05:00
|
|
|
}
|
2023-03-21 13:50:40 -04:00
|
|
|
|
|
|
|
return stats
|
2022-11-10 13:20:21 -05:00
|
|
|
}
|
|
|
|
|
2021-07-13 12:39:13 -04:00
|
|
|
// Init validate and initialize the http target
|
2023-05-09 00:20:31 -04:00
|
|
|
func (h *Target) Init(ctx context.Context) (err error) {
|
|
|
|
if h.config.QueueDir != "" {
|
|
|
|
return h.initQueueStoreOnce.DoWithContext(ctx, h.initQueueStore)
|
|
|
|
}
|
2023-09-21 14:24:56 -04:00
|
|
|
return h.init(ctx)
|
2023-05-09 00:20:31 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
func (h *Target) initQueueStore(ctx context.Context) (err error) {
|
|
|
|
var queueStore store.Store[interface{}]
|
|
|
|
queueDir := filepath.Join(h.config.QueueDir, h.Name())
|
|
|
|
queueStore = store.NewQueueStore[interface{}](queueDir, uint64(h.config.QueueSize), httpLoggerExtension)
|
|
|
|
if err = queueStore.Open(); err != nil {
|
|
|
|
return fmt.Errorf("unable to initialize the queue store of %s webhook: %w", h.Name(), err)
|
|
|
|
}
|
|
|
|
ctx, cancel := context.WithCancel(ctx)
|
|
|
|
h.store = queueStore
|
|
|
|
h.storeCtxCancel = cancel
|
|
|
|
store.StreamItems(h.store, h, ctx.Done(), h.config.LogOnce)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2023-09-21 14:24:56 -04:00
|
|
|
func (h *Target) init(ctx context.Context) (err error) {
|
2023-03-21 13:50:40 -04:00
|
|
|
switch atomic.LoadInt32(&h.status) {
|
|
|
|
case statusOnline:
|
|
|
|
return nil
|
|
|
|
case statusClosed:
|
|
|
|
return errors.New("target is closed")
|
2020-08-16 13:25:00 -04:00
|
|
|
}
|
|
|
|
|
2023-05-17 14:10:33 -04:00
|
|
|
if !h.IsOnline(ctx) {
|
2023-03-21 13:50:40 -04:00
|
|
|
// Start a goroutine that will continue to check if we can reach
|
|
|
|
h.revive.Do(func() {
|
|
|
|
go func() {
|
2023-09-21 14:24:56 -04:00
|
|
|
// Avoid stamping herd, add jitter.
|
|
|
|
t := time.NewTicker(time.Second + time.Duration(rand.Int63n(int64(5*time.Second))))
|
2023-03-21 13:50:40 -04:00
|
|
|
defer t.Stop()
|
2023-09-21 14:24:56 -04:00
|
|
|
|
2023-03-21 13:50:40 -04:00
|
|
|
for range t.C {
|
|
|
|
if atomic.LoadInt32(&h.status) != statusOffline {
|
|
|
|
return
|
|
|
|
}
|
2023-05-17 14:10:33 -04:00
|
|
|
if h.IsOnline(ctx) {
|
2023-03-21 13:50:40 -04:00
|
|
|
// We are online.
|
|
|
|
if atomic.CompareAndSwapInt32(&h.status, statusOffline, statusOnline) {
|
|
|
|
h.workerStartMu.Lock()
|
|
|
|
h.lastStarted = time.Now()
|
|
|
|
h.workerStartMu.Unlock()
|
|
|
|
atomic.AddInt64(&h.workers, 1)
|
2023-05-09 00:20:31 -04:00
|
|
|
go h.startHTTPLogger(ctx)
|
2023-03-21 13:50:40 -04:00
|
|
|
}
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
})
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
if atomic.CompareAndSwapInt32(&h.status, statusOffline, statusOnline) {
|
|
|
|
h.workerStartMu.Lock()
|
|
|
|
h.lastStarted = time.Now()
|
|
|
|
h.workerStartMu.Unlock()
|
2023-04-27 13:51:16 -04:00
|
|
|
atomic.AddInt64(&h.workers, 1)
|
2023-05-09 00:20:31 -04:00
|
|
|
go h.startHTTPLogger(ctx)
|
2023-03-21 13:50:40 -04:00
|
|
|
}
|
2020-08-16 13:25:00 -04:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
func (h *Target) send(ctx context.Context, payload []byte, timeout time.Duration) (err error) {
|
|
|
|
ctx, cancel := context.WithTimeout(ctx, timeout)
|
|
|
|
defer cancel()
|
|
|
|
req, err := http.NewRequestWithContext(ctx, http.MethodPost,
|
2023-08-03 05:47:07 -04:00
|
|
|
h.Endpoint(), bytes.NewReader(payload))
|
2023-05-09 00:20:31 -04:00
|
|
|
if err != nil {
|
2023-08-03 05:47:07 -04:00
|
|
|
return fmt.Errorf("invalid configuration for '%s'; %v", h.Endpoint(), err)
|
2023-05-09 00:20:31 -04:00
|
|
|
}
|
|
|
|
req.Header.Set(xhttp.ContentType, "application/json")
|
|
|
|
req.Header.Set(xhttp.MinIOVersion, xhttp.GlobalMinIOVersion)
|
|
|
|
req.Header.Set(xhttp.MinioDeploymentID, xhttp.GlobalDeploymentID)
|
|
|
|
|
|
|
|
// Set user-agent to indicate MinIO release
|
|
|
|
// version to the configured log endpoint
|
|
|
|
req.Header.Set("User-Agent", h.config.UserAgent)
|
|
|
|
|
|
|
|
if h.config.AuthToken != "" {
|
|
|
|
req.Header.Set("Authorization", h.config.AuthToken)
|
|
|
|
}
|
|
|
|
|
|
|
|
resp, err := h.client.Do(req)
|
|
|
|
if err != nil {
|
2023-08-03 05:47:07 -04:00
|
|
|
return fmt.Errorf("%s returned '%w', please check your endpoint configuration", h.Endpoint(), err)
|
2023-05-09 00:20:31 -04:00
|
|
|
}
|
2021-09-10 17:27:37 -04:00
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
// Drain any response.
|
|
|
|
xhttp.DrainBody(resp.Body)
|
|
|
|
|
|
|
|
switch resp.StatusCode {
|
|
|
|
case http.StatusOK, http.StatusCreated, http.StatusAccepted, http.StatusNoContent:
|
|
|
|
// accepted HTTP status codes.
|
|
|
|
return nil
|
|
|
|
case http.StatusForbidden:
|
2023-08-03 05:47:07 -04:00
|
|
|
return fmt.Errorf("%s returned '%s', please check if your auth token is correctly set", h.Endpoint(), resp.Status)
|
2023-05-09 00:20:31 -04:00
|
|
|
default:
|
2023-08-03 05:47:07 -04:00
|
|
|
return fmt.Errorf("%s returned '%s', please check your endpoint configuration", h.Endpoint(), resp.Status)
|
2023-05-09 00:20:31 -04:00
|
|
|
}
|
2021-09-10 17:27:37 -04:00
|
|
|
}
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
func (h *Target) logEntry(ctx context.Context, entry interface{}) {
|
2022-02-17 14:11:15 -05:00
|
|
|
logJSON, err := json.Marshal(&entry)
|
|
|
|
if err != nil {
|
2022-11-10 13:20:21 -05:00
|
|
|
atomic.AddInt64(&h.failedMessages, 1)
|
2022-02-17 14:11:15 -05:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2023-09-21 14:24:56 -04:00
|
|
|
const maxTries = 3
|
2023-03-21 13:50:40 -04:00
|
|
|
tries := 0
|
2023-09-21 14:24:56 -04:00
|
|
|
for tries < maxTries {
|
|
|
|
if atomic.LoadInt32(&h.status) == statusClosed {
|
|
|
|
// Don't retry when closing...
|
|
|
|
return
|
|
|
|
}
|
|
|
|
// sleep = (tries+2) ^ 2 milliseconds.
|
|
|
|
sleep := time.Duration(math.Pow(float64(tries+2), 2)) * time.Millisecond
|
|
|
|
if sleep > time.Second {
|
|
|
|
sleep = time.Second
|
2023-03-21 13:50:40 -04:00
|
|
|
}
|
2023-09-21 14:24:56 -04:00
|
|
|
time.Sleep(sleep)
|
2023-03-21 13:50:40 -04:00
|
|
|
tries++
|
2023-09-21 14:24:56 -04:00
|
|
|
err := h.send(ctx, logJSON, webhookCallTimeout)
|
|
|
|
if err == nil {
|
2023-05-22 17:53:18 -04:00
|
|
|
return
|
2022-02-17 14:11:15 -05:00
|
|
|
}
|
2023-09-21 14:24:56 -04:00
|
|
|
h.config.LogOnce(ctx, err, h.Endpoint())
|
|
|
|
}
|
|
|
|
if tries == maxTries {
|
|
|
|
// Even with multiple retries, count failed messages as only one.
|
|
|
|
atomic.AddInt64(&h.failedMessages, 1)
|
2022-02-17 14:11:15 -05:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
func (h *Target) startHTTPLogger(ctx context.Context) {
|
2023-03-21 13:50:40 -04:00
|
|
|
h.logChMu.RLock()
|
|
|
|
logCh := h.logCh
|
|
|
|
if logCh != nil {
|
|
|
|
// We are not allowed to add when logCh is nil
|
|
|
|
h.wg.Add(1)
|
|
|
|
defer h.wg.Done()
|
|
|
|
}
|
|
|
|
h.logChMu.RUnlock()
|
|
|
|
|
|
|
|
defer atomic.AddInt64(&h.workers, -1)
|
|
|
|
|
|
|
|
if logCh == nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
// Send messages until channel is closed.
|
|
|
|
for entry := range logCh {
|
|
|
|
atomic.AddInt64(&h.totalMessages, 1)
|
2023-05-09 00:20:31 -04:00
|
|
|
h.logEntry(ctx, entry)
|
2023-03-21 13:50:40 -04:00
|
|
|
}
|
2018-07-19 18:55:06 -04:00
|
|
|
}
|
|
|
|
|
2018-11-19 17:47:03 -05:00
|
|
|
// New initializes a new logger target which
|
2018-07-19 18:55:06 -04:00
|
|
|
// sends log over http to the specified endpoint
|
2021-07-13 12:39:13 -04:00
|
|
|
func New(config Config) *Target {
|
2020-04-01 23:53:07 -04:00
|
|
|
h := &Target{
|
2021-12-20 16:16:53 -05:00
|
|
|
logCh: make(chan interface{}, config.QueueSize),
|
2021-07-13 12:39:13 -04:00
|
|
|
config: config,
|
2023-03-21 13:50:40 -04:00
|
|
|
status: statusOffline,
|
|
|
|
}
|
|
|
|
|
|
|
|
// If proxy available, set the same
|
|
|
|
if h.config.Proxy != "" {
|
|
|
|
proxyURL, _ := url.Parse(h.config.Proxy)
|
|
|
|
transport := h.config.Transport
|
|
|
|
ctransport := transport.(*http.Transport).Clone()
|
|
|
|
ctransport.Proxy = http.ProxyURL(proxyURL)
|
|
|
|
h.config.Transport = ctransport
|
2020-04-01 23:53:07 -04:00
|
|
|
}
|
2023-03-21 13:50:40 -04:00
|
|
|
h.client = &http.Client{Transport: h.config.Transport}
|
2020-04-01 23:53:07 -04:00
|
|
|
|
|
|
|
return h
|
2018-07-19 18:55:06 -04:00
|
|
|
}
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
// SendFromStore - reads the log from store and sends it to webhook.
|
|
|
|
func (h *Target) SendFromStore(key string) (err error) {
|
|
|
|
var eventData interface{}
|
|
|
|
eventData, err = h.store.Get(key)
|
|
|
|
if err != nil {
|
|
|
|
if os.IsNotExist(err) {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
atomic.AddInt64(&h.totalMessages, 1)
|
|
|
|
logJSON, err := json.Marshal(&eventData)
|
|
|
|
if err != nil {
|
|
|
|
atomic.AddInt64(&h.failedMessages, 1)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
if err := h.send(context.Background(), logJSON, webhookCallTimeout); err != nil {
|
|
|
|
atomic.AddInt64(&h.failedMessages, 1)
|
|
|
|
if xnet.IsNetworkOrHostDown(err, true) {
|
|
|
|
return store.ErrNotConnected
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
// Delete the event from store.
|
|
|
|
return h.store.Del(key)
|
|
|
|
}
|
|
|
|
|
2023-07-29 15:49:18 -04:00
|
|
|
// Send the log message 'entry' to the http target.
|
|
|
|
// Messages are queued in the disk if the store is enabled
|
2023-03-21 13:50:40 -04:00
|
|
|
// If Cancel has been called the message is ignored.
|
2023-05-09 00:20:31 -04:00
|
|
|
func (h *Target) Send(ctx context.Context, entry interface{}) error {
|
2023-07-29 15:49:18 -04:00
|
|
|
if atomic.LoadInt32(&h.status) == statusClosed {
|
|
|
|
return nil
|
|
|
|
}
|
2023-05-09 00:20:31 -04:00
|
|
|
if h.store != nil {
|
|
|
|
// save the entry to the queue store which will be replayed to the target.
|
|
|
|
return h.store.Put(entry)
|
|
|
|
}
|
2023-03-21 13:50:40 -04:00
|
|
|
h.logChMu.RLock()
|
|
|
|
defer h.logChMu.RUnlock()
|
|
|
|
if h.logCh == nil {
|
|
|
|
// We are closing...
|
2022-02-17 14:11:15 -05:00
|
|
|
return nil
|
|
|
|
}
|
2023-07-29 15:49:18 -04:00
|
|
|
|
2018-07-19 18:55:06 -04:00
|
|
|
select {
|
|
|
|
case h.logCh <- entry:
|
2023-07-29 15:49:18 -04:00
|
|
|
case <-ctx.Done():
|
2023-08-17 17:53:43 -04:00
|
|
|
// return error only for context timedout.
|
|
|
|
if errors.Is(ctx.Err(), context.DeadlineExceeded) {
|
|
|
|
return ctx.Err()
|
|
|
|
}
|
|
|
|
return nil
|
2018-07-19 18:55:06 -04:00
|
|
|
default:
|
2022-11-10 13:20:21 -05:00
|
|
|
nWorkers := atomic.LoadInt64(&h.workers)
|
|
|
|
if nWorkers < maxWorkers {
|
|
|
|
// Only have one try to start at the same time.
|
|
|
|
h.workerStartMu.Lock()
|
|
|
|
defer h.workerStartMu.Unlock()
|
|
|
|
// Start one max every second.
|
|
|
|
if time.Since(h.lastStarted) > time.Second {
|
|
|
|
if atomic.CompareAndSwapInt64(&h.workers, nWorkers, nWorkers+1) {
|
|
|
|
// Start another logger.
|
|
|
|
h.lastStarted = time.Now()
|
2023-05-09 00:20:31 -04:00
|
|
|
go h.startHTTPLogger(ctx)
|
2022-11-10 13:20:21 -05:00
|
|
|
}
|
|
|
|
}
|
2023-03-21 13:50:40 -04:00
|
|
|
h.logCh <- entry
|
2022-11-10 13:20:21 -05:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
atomic.AddInt64(&h.totalMessages, 1)
|
|
|
|
atomic.AddInt64(&h.failedMessages, 1)
|
2023-07-29 15:49:18 -04:00
|
|
|
return errors.New("log buffer full")
|
2018-07-19 18:55:06 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
2022-02-17 14:11:15 -05:00
|
|
|
|
2023-03-21 13:50:40 -04:00
|
|
|
// Cancel - cancels the target.
|
|
|
|
// All queued messages are flushed and the function returns afterwards.
|
|
|
|
// All messages sent to the target after this function has been called will be dropped.
|
2022-02-17 14:11:15 -05:00
|
|
|
func (h *Target) Cancel() {
|
2023-03-21 13:50:40 -04:00
|
|
|
atomic.StoreInt32(&h.status, statusClosed)
|
|
|
|
|
2023-05-09 00:20:31 -04:00
|
|
|
// If queuestore is configured, cancel it's context to
|
|
|
|
// stop the replay go-routine.
|
|
|
|
if h.store != nil {
|
|
|
|
h.storeCtxCancel()
|
|
|
|
}
|
|
|
|
|
2023-03-21 13:50:40 -04:00
|
|
|
// Set logch to nil and close it.
|
|
|
|
// This will block all Send operations,
|
|
|
|
// and finish the existing ones.
|
|
|
|
// All future ones will be discarded.
|
|
|
|
h.logChMu.Lock()
|
2022-05-16 19:10:51 -04:00
|
|
|
close(h.logCh)
|
2023-03-21 13:50:40 -04:00
|
|
|
h.logCh = nil
|
|
|
|
h.logChMu.Unlock()
|
|
|
|
|
|
|
|
// Wait for messages to be sent...
|
2022-02-17 14:11:15 -05:00
|
|
|
h.wg.Wait()
|
|
|
|
}
|
2022-02-24 12:05:33 -05:00
|
|
|
|
|
|
|
// Type - returns type of the target
|
|
|
|
func (h *Target) Type() types.TargetType {
|
|
|
|
return types.TargetHTTP
|
|
|
|
}
|