2018-02-05 16:05:59 -05:00
|
|
|
package loggerutils // import "github.com/docker/docker/daemon/logger/loggerutils"
|
2017-07-18 11:54:03 -04:00
|
|
|
|
|
|
|
import (
|
2018-03-12 22:47:24 -04:00
|
|
|
"compress/gzip"
|
2017-07-18 11:54:03 -04:00
|
|
|
"context"
|
2018-03-12 22:47:24 -04:00
|
|
|
"encoding/json"
|
2017-07-18 11:54:03 -04:00
|
|
|
"fmt"
|
|
|
|
"io"
|
|
|
|
"os"
|
2018-07-06 18:48:59 -04:00
|
|
|
"runtime"
|
2017-07-18 11:54:03 -04:00
|
|
|
"strconv"
|
2018-03-12 22:47:24 -04:00
|
|
|
"strings"
|
2017-07-18 11:54:03 -04:00
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/docker/docker/daemon/logger"
|
|
|
|
"github.com/docker/docker/pkg/filenotify"
|
2018-03-12 22:47:24 -04:00
|
|
|
"github.com/docker/docker/pkg/pools"
|
2017-07-18 11:54:03 -04:00
|
|
|
"github.com/docker/docker/pkg/pubsub"
|
|
|
|
"github.com/pkg/errors"
|
|
|
|
"github.com/sirupsen/logrus"
|
|
|
|
)
|
|
|
|
|
2018-03-12 22:47:24 -04:00
|
|
|
const tmpLogfileSuffix = ".tmp"
|
|
|
|
|
|
|
|
// rotateFileMetadata is a metadata of the gzip header of the compressed log file
|
|
|
|
type rotateFileMetadata struct {
|
|
|
|
LastTime time.Time `json:"lastTime,omitempty"`
|
|
|
|
}
|
|
|
|
|
|
|
|
// refCounter is a counter of logfile being referenced
|
|
|
|
type refCounter struct {
|
|
|
|
mu sync.Mutex
|
|
|
|
counter map[string]int
|
|
|
|
}
|
|
|
|
|
|
|
|
// Reference increase the reference counter for specified logfile
|
|
|
|
func (rc *refCounter) GetReference(fileName string, openRefFile func(fileName string, exists bool) (*os.File, error)) (*os.File, error) {
|
|
|
|
rc.mu.Lock()
|
|
|
|
defer rc.mu.Unlock()
|
|
|
|
|
|
|
|
var (
|
|
|
|
file *os.File
|
|
|
|
err error
|
|
|
|
)
|
|
|
|
_, ok := rc.counter[fileName]
|
|
|
|
file, err = openRefFile(fileName, ok)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
if ok {
|
|
|
|
rc.counter[fileName]++
|
|
|
|
} else if file != nil {
|
|
|
|
rc.counter[file.Name()] = 1
|
|
|
|
}
|
|
|
|
|
|
|
|
return file, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Dereference reduce the reference counter for specified logfile
|
|
|
|
func (rc *refCounter) Dereference(fileName string) error {
|
|
|
|
rc.mu.Lock()
|
|
|
|
defer rc.mu.Unlock()
|
|
|
|
|
|
|
|
rc.counter[fileName]--
|
|
|
|
if rc.counter[fileName] <= 0 {
|
|
|
|
delete(rc.counter, fileName)
|
|
|
|
err := os.Remove(fileName)
|
2020-07-15 12:56:28 -04:00
|
|
|
if err != nil && !os.IsNotExist(err) {
|
2018-03-12 22:47:24 -04:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
// LogFile is Logger implementation for default Docker logging.
|
|
|
|
type LogFile struct {
|
2018-03-12 22:47:24 -04:00
|
|
|
mu sync.RWMutex // protects the logfile access
|
|
|
|
f *os.File // store for closing
|
|
|
|
closed bool
|
|
|
|
rotateMu sync.Mutex // blocks the next rotation until the current rotation is completed
|
|
|
|
capacity int64 // maximum size of each file
|
|
|
|
currentSize int64 // current size of the latest file
|
|
|
|
maxFiles int // maximum number of files
|
|
|
|
compress bool // whether old versions of log files are compressed
|
|
|
|
lastTimestamp time.Time // timestamp of the last log
|
|
|
|
filesRefCounter refCounter // keep reference-counted of decompressed files
|
2020-06-12 19:01:37 -04:00
|
|
|
notifyReaders *pubsub.Publisher
|
2018-03-12 22:47:24 -04:00
|
|
|
marshal logger.MarshalFunc
|
2020-04-08 15:24:31 -04:00
|
|
|
createDecoder MakeDecoderFn
|
2018-04-05 12:39:28 -04:00
|
|
|
getTailReader GetTailReaderFunc
|
2018-03-12 22:47:24 -04:00
|
|
|
perms os.FileMode
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
2020-04-08 15:24:31 -04:00
|
|
|
// MakeDecoderFn creates a decoder
|
|
|
|
type MakeDecoderFn func(rdr io.Reader) Decoder
|
|
|
|
|
|
|
|
// Decoder is for reading logs
|
|
|
|
// It is created by the log reader by calling the `MakeDecoderFunc`
|
|
|
|
type Decoder interface {
|
|
|
|
// Reset resets the decoder
|
|
|
|
// Reset is called for certain events, such as log rotations
|
|
|
|
Reset(io.Reader)
|
|
|
|
// Decode decodes the next log messeage from the stream
|
|
|
|
Decode() (*logger.Message, error)
|
|
|
|
// Close signals to the decoder that it can release whatever resources it was using.
|
|
|
|
Close()
|
|
|
|
}
|
2017-07-18 11:54:03 -04:00
|
|
|
|
2018-04-05 12:39:28 -04:00
|
|
|
// SizeReaderAt defines a ReaderAt that also reports its size.
|
|
|
|
// This is used for tailing log files.
|
|
|
|
type SizeReaderAt interface {
|
|
|
|
io.ReaderAt
|
|
|
|
Size() int64
|
|
|
|
}
|
|
|
|
|
|
|
|
// GetTailReaderFunc is used to truncate a reader to only read as much as is required
|
|
|
|
// in order to get the passed in number of log lines.
|
|
|
|
// It returns the sectioned reader, the number of lines that the section reader
|
|
|
|
// contains, and any error that occurs.
|
|
|
|
type GetTailReaderFunc func(ctx context.Context, f SizeReaderAt, nLogLines int) (rdr io.Reader, nLines int, err error)
|
|
|
|
|
2018-05-07 11:25:41 -04:00
|
|
|
// NewLogFile creates new LogFile
|
2020-04-08 15:24:31 -04:00
|
|
|
func NewLogFile(logPath string, capacity int64, maxFiles int, compress bool, marshaller logger.MarshalFunc, decodeFunc MakeDecoderFn, perms os.FileMode, getTailReader GetTailReaderFunc) (*LogFile, error) {
|
2019-09-23 14:09:01 -04:00
|
|
|
log, err := openFile(logPath, os.O_WRONLY|os.O_APPEND|os.O_CREATE, perms)
|
2017-07-18 11:54:03 -04:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2019-11-25 12:53:03 -05:00
|
|
|
size, err := log.Seek(0, io.SeekEnd)
|
2017-07-18 11:54:03 -04:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
return &LogFile{
|
2018-03-12 22:47:24 -04:00
|
|
|
f: log,
|
|
|
|
capacity: capacity,
|
|
|
|
currentSize: size,
|
|
|
|
maxFiles: maxFiles,
|
|
|
|
compress: compress,
|
|
|
|
filesRefCounter: refCounter{counter: make(map[string]int)},
|
2020-06-12 19:01:37 -04:00
|
|
|
notifyReaders: pubsub.NewPublisher(0, 1),
|
2018-03-12 22:47:24 -04:00
|
|
|
marshal: marshaller,
|
|
|
|
createDecoder: decodeFunc,
|
|
|
|
perms: perms,
|
2018-04-05 12:39:28 -04:00
|
|
|
getTailReader: getTailReader,
|
2017-07-18 11:54:03 -04:00
|
|
|
}, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// WriteLogEntry writes the provided log message to the current log file.
|
|
|
|
// This may trigger a rotation event if the max file/capacity limits are hit.
|
|
|
|
func (w *LogFile) WriteLogEntry(msg *logger.Message) error {
|
|
|
|
b, err := w.marshal(msg)
|
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "error marshalling log message")
|
|
|
|
}
|
|
|
|
|
|
|
|
logger.PutMessage(msg)
|
|
|
|
|
|
|
|
w.mu.Lock()
|
|
|
|
if w.closed {
|
|
|
|
w.mu.Unlock()
|
|
|
|
return errors.New("cannot write because the output file was closed")
|
|
|
|
}
|
|
|
|
|
|
|
|
if err := w.checkCapacityAndRotate(); err != nil {
|
|
|
|
w.mu.Unlock()
|
2020-06-12 19:01:37 -04:00
|
|
|
return errors.Wrap(err, "error rotating log file")
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
n, err := w.f.Write(b)
|
|
|
|
if err == nil {
|
|
|
|
w.currentSize += int64(n)
|
2018-03-12 22:47:24 -04:00
|
|
|
w.lastTimestamp = msg.Timestamp
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
2020-06-12 19:01:37 -04:00
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
w.mu.Unlock()
|
2020-06-12 19:01:37 -04:00
|
|
|
return errors.Wrap(err, "error writing log entry")
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
2020-07-15 12:56:28 -04:00
|
|
|
func (w *LogFile) checkCapacityAndRotate() (retErr error) {
|
2017-07-18 11:54:03 -04:00
|
|
|
if w.capacity == -1 {
|
|
|
|
return nil
|
|
|
|
}
|
2020-07-15 12:56:28 -04:00
|
|
|
if w.currentSize < w.capacity {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
w.rotateMu.Lock()
|
2020-06-12 19:01:37 -04:00
|
|
|
noCompress := w.maxFiles <= 1 || !w.compress
|
2020-07-15 12:56:28 -04:00
|
|
|
defer func() {
|
2020-06-12 19:01:37 -04:00
|
|
|
// If we aren't going to run the goroutine to compress the log file, then we need to unlock in this function.
|
|
|
|
// Otherwise the lock will be released in the goroutine that handles compression.
|
|
|
|
if retErr != nil || noCompress {
|
2018-03-12 22:47:24 -04:00
|
|
|
w.rotateMu.Unlock()
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
2020-07-15 12:56:28 -04:00
|
|
|
}()
|
2018-03-12 22:47:24 -04:00
|
|
|
|
2020-07-15 12:56:28 -04:00
|
|
|
fname := w.f.Name()
|
|
|
|
if err := w.f.Close(); err != nil {
|
|
|
|
// if there was an error during a prior rotate, the file could already be closed
|
|
|
|
if !errors.Is(err, os.ErrClosed) {
|
|
|
|
return errors.Wrap(err, "error closing file")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
2020-07-15 12:56:28 -04:00
|
|
|
}
|
2018-03-12 22:47:24 -04:00
|
|
|
|
2020-07-15 12:56:28 -04:00
|
|
|
if err := rotate(fname, w.maxFiles, w.compress); err != nil {
|
2020-06-12 19:01:37 -04:00
|
|
|
logrus.WithError(err).Warn("Error rotating log file, log data may have been lost")
|
|
|
|
} else {
|
|
|
|
var renameErr error
|
|
|
|
for i := 0; i < 10; i++ {
|
|
|
|
if renameErr = os.Rename(fname, fname+".1"); renameErr != nil && !os.IsNotExist(renameErr) {
|
|
|
|
logrus.WithError(renameErr).WithField("file", fname).Debug("Error rotating current container log file, evicting readers and retrying")
|
|
|
|
w.notifyReaders.Publish(renameErr)
|
|
|
|
time.Sleep(100 * time.Millisecond)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
break
|
|
|
|
}
|
|
|
|
if renameErr != nil {
|
|
|
|
logrus.WithError(renameErr).Error("Error renaming current log file")
|
|
|
|
}
|
2020-07-15 12:56:28 -04:00
|
|
|
}
|
2020-06-12 19:01:37 -04:00
|
|
|
|
2020-07-15 12:56:28 -04:00
|
|
|
file, err := openFile(fname, os.O_WRONLY|os.O_TRUNC|os.O_CREATE, w.perms)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
w.f = file
|
|
|
|
w.currentSize = 0
|
|
|
|
|
2020-06-12 19:01:37 -04:00
|
|
|
w.notifyReaders.Publish(struct{}{})
|
|
|
|
|
|
|
|
if noCompress {
|
2020-07-15 12:56:28 -04:00
|
|
|
return nil
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
2020-07-15 12:56:28 -04:00
|
|
|
ts := w.lastTimestamp
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
if err := compressFile(fname+".1", ts); err != nil {
|
|
|
|
logrus.WithError(err).Error("Error compressing log file after rotation")
|
|
|
|
}
|
|
|
|
w.rotateMu.Unlock()
|
|
|
|
}()
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2018-03-12 22:47:24 -04:00
|
|
|
func rotate(name string, maxFiles int, compress bool) error {
|
2017-07-18 11:54:03 -04:00
|
|
|
if maxFiles < 2 {
|
|
|
|
return nil
|
|
|
|
}
|
2018-03-12 22:47:24 -04:00
|
|
|
|
|
|
|
var extension string
|
|
|
|
if compress {
|
|
|
|
extension = ".gz"
|
|
|
|
}
|
2018-05-07 11:25:41 -04:00
|
|
|
|
|
|
|
lastFile := fmt.Sprintf("%s.%d%s", name, maxFiles-1, extension)
|
|
|
|
err := os.Remove(lastFile)
|
|
|
|
if err != nil && !os.IsNotExist(err) {
|
|
|
|
return errors.Wrap(err, "error removing oldest log file")
|
|
|
|
}
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
for i := maxFiles - 1; i > 1; i-- {
|
2018-03-12 22:47:24 -04:00
|
|
|
toPath := name + "." + strconv.Itoa(i) + extension
|
|
|
|
fromPath := name + "." + strconv.Itoa(i-1) + extension
|
2020-06-12 19:01:37 -04:00
|
|
|
logrus.WithField("source", fromPath).WithField("target", toPath).Trace("Rotating log file")
|
2017-07-18 11:54:03 -04:00
|
|
|
if err := os.Rename(fromPath, toPath); err != nil && !os.IsNotExist(err) {
|
2018-03-12 22:47:24 -04:00
|
|
|
return err
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2020-07-15 12:56:28 -04:00
|
|
|
func compressFile(fileName string, lastTimestamp time.Time) (retErr error) {
|
2020-07-15 13:40:21 -04:00
|
|
|
file, err := open(fileName)
|
2018-03-12 22:47:24 -04:00
|
|
|
if err != nil {
|
2020-07-15 12:56:28 -04:00
|
|
|
if os.IsNotExist(err) {
|
|
|
|
logrus.WithField("file", fileName).WithError(err).Debug("Could not open log file to compress")
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
return errors.Wrap(err, "failed to open log file")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
defer func() {
|
|
|
|
file.Close()
|
2020-06-12 19:01:37 -04:00
|
|
|
if retErr == nil {
|
|
|
|
err := os.Remove(fileName)
|
|
|
|
if err != nil && !os.IsNotExist(err) {
|
|
|
|
retErr = errors.Wrap(err, "failed to remove source log file")
|
|
|
|
}
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
2019-09-23 14:09:01 -04:00
|
|
|
outFile, err := openFile(fileName+".gz", os.O_CREATE|os.O_TRUNC|os.O_RDWR, 0640)
|
2018-03-12 22:47:24 -04:00
|
|
|
if err != nil {
|
2020-07-15 12:56:28 -04:00
|
|
|
return errors.Wrap(err, "failed to open or create gzip log file")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
defer func() {
|
|
|
|
outFile.Close()
|
2020-07-15 12:56:28 -04:00
|
|
|
if retErr != nil {
|
|
|
|
if err := os.Remove(fileName + ".gz"); err != nil && !os.IsExist(err) {
|
|
|
|
logrus.WithError(err).Error("Error cleaning up after failed log compression")
|
|
|
|
}
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
compressWriter := gzip.NewWriter(outFile)
|
|
|
|
defer compressWriter.Close()
|
|
|
|
|
2019-09-20 18:50:10 -04:00
|
|
|
// Add the last log entry timestamp to the gzip header
|
2018-03-12 22:47:24 -04:00
|
|
|
extra := rotateFileMetadata{}
|
|
|
|
extra.LastTime = lastTimestamp
|
|
|
|
compressWriter.Header.Extra, err = json.Marshal(&extra)
|
|
|
|
if err != nil {
|
|
|
|
// Here log the error only and don't return since this is just an optimization.
|
2018-05-07 11:25:41 -04:00
|
|
|
logrus.Warningf("Failed to marshal gzip header as JSON: %v", err)
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
_, err = pools.Copy(compressWriter, file)
|
|
|
|
if err != nil {
|
2020-07-15 12:56:28 -04:00
|
|
|
return errors.Wrapf(err, "error compressing log file %s", fileName)
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
2020-07-15 12:56:28 -04:00
|
|
|
|
|
|
|
return nil
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
// MaxFiles return maximum number of files
|
|
|
|
func (w *LogFile) MaxFiles() int {
|
|
|
|
return w.maxFiles
|
|
|
|
}
|
|
|
|
|
|
|
|
// Close closes underlying file and signals all readers to stop.
|
|
|
|
func (w *LogFile) Close() error {
|
|
|
|
w.mu.Lock()
|
|
|
|
defer w.mu.Unlock()
|
|
|
|
if w.closed {
|
|
|
|
return nil
|
|
|
|
}
|
2020-07-15 12:56:28 -04:00
|
|
|
if err := w.f.Close(); err != nil && !errors.Is(err, os.ErrClosed) {
|
2017-07-18 11:54:03 -04:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
w.closed = true
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// ReadLogs decodes entries from log files and sends them the passed in watcher
|
2018-05-07 11:25:41 -04:00
|
|
|
//
|
|
|
|
// Note: Using the follow option can become inconsistent in cases with very frequent rotations and max log files is 1.
|
|
|
|
// TODO: Consider a different implementation which can effectively follow logs under frequent rotations.
|
2017-07-18 11:54:03 -04:00
|
|
|
func (w *LogFile) ReadLogs(config logger.ReadConfig, watcher *logger.LogWatcher) {
|
|
|
|
w.mu.RLock()
|
2020-07-15 13:40:21 -04:00
|
|
|
currentFile, err := open(w.f.Name())
|
2017-07-18 11:54:03 -04:00
|
|
|
if err != nil {
|
|
|
|
w.mu.RUnlock()
|
|
|
|
watcher.Err <- err
|
|
|
|
return
|
|
|
|
}
|
|
|
|
defer currentFile.Close()
|
|
|
|
|
2020-04-08 15:24:31 -04:00
|
|
|
dec := w.createDecoder(nil)
|
|
|
|
defer dec.Close()
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
currentChunk, err := newSectionReader(currentFile)
|
|
|
|
if err != nil {
|
2018-03-12 22:47:24 -04:00
|
|
|
w.mu.RUnlock()
|
2017-07-18 11:54:03 -04:00
|
|
|
watcher.Err <- err
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2020-06-12 19:01:37 -04:00
|
|
|
notifyEvict := w.notifyReaders.SubscribeTopicWithBuffer(func(i interface{}) bool {
|
|
|
|
_, ok := i.(error)
|
|
|
|
return ok
|
|
|
|
}, 1)
|
|
|
|
defer w.notifyReaders.Evict(notifyEvict)
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
if config.Tail != 0 {
|
2018-04-05 12:39:28 -04:00
|
|
|
// TODO(@cpuguy83): Instead of opening every file, only get the files which
|
|
|
|
// are needed to tail.
|
|
|
|
// This is especially costly when compression is enabled.
|
2018-03-12 22:47:24 -04:00
|
|
|
files, err := w.openRotatedFiles(config)
|
2018-04-05 12:39:28 -04:00
|
|
|
w.mu.RUnlock()
|
2018-03-12 22:47:24 -04:00
|
|
|
if err != nil {
|
|
|
|
watcher.Err <- err
|
|
|
|
return
|
|
|
|
}
|
2018-04-05 12:39:28 -04:00
|
|
|
|
|
|
|
closeFiles := func() {
|
|
|
|
for _, f := range files {
|
|
|
|
f.Close()
|
|
|
|
fileName := f.Name()
|
|
|
|
if strings.HasSuffix(fileName, tmpLogfileSuffix) {
|
|
|
|
err := w.filesRefCounter.Dereference(fileName)
|
|
|
|
if err != nil {
|
2020-07-15 12:56:28 -04:00
|
|
|
logrus.WithError(err).WithField("file", fileName).Error("Failed to dereference the log file")
|
2018-04-05 12:39:28 -04:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2018-02-13 15:03:56 -05:00
|
|
|
}
|
2018-04-05 12:39:28 -04:00
|
|
|
|
|
|
|
readers := make([]SizeReaderAt, 0, len(files)+1)
|
2018-03-12 22:47:24 -04:00
|
|
|
for _, f := range files {
|
2018-04-05 12:39:28 -04:00
|
|
|
stat, err := f.Stat()
|
|
|
|
if err != nil {
|
|
|
|
watcher.Err <- errors.Wrap(err, "error reading size of rotated file")
|
|
|
|
closeFiles()
|
|
|
|
return
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
2018-04-05 12:39:28 -04:00
|
|
|
readers = append(readers, io.NewSectionReader(f, 0, stat.Size()))
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
2018-04-05 12:39:28 -04:00
|
|
|
if currentChunk.Size() > 0 {
|
|
|
|
readers = append(readers, currentChunk)
|
|
|
|
}
|
|
|
|
|
2020-06-12 19:01:37 -04:00
|
|
|
ok := tailFiles(readers, watcher, dec, w.getTailReader, config, notifyEvict)
|
2018-04-05 12:39:28 -04:00
|
|
|
closeFiles()
|
2020-06-12 19:01:37 -04:00
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
2018-03-12 22:47:24 -04:00
|
|
|
w.mu.RLock()
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
if !config.Follow || w.closed {
|
|
|
|
w.mu.RUnlock()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
w.mu.RUnlock()
|
|
|
|
|
2020-06-12 19:01:37 -04:00
|
|
|
notifyRotate := w.notifyReaders.SubscribeTopic(func(i interface{}) bool {
|
|
|
|
_, ok := i.(struct{})
|
|
|
|
return ok
|
|
|
|
})
|
|
|
|
defer w.notifyReaders.Evict(notifyRotate)
|
|
|
|
|
|
|
|
followLogs(currentFile, watcher, notifyRotate, notifyEvict, dec, config.Since, config.Until)
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
2018-03-12 22:47:24 -04:00
|
|
|
func (w *LogFile) openRotatedFiles(config logger.ReadConfig) (files []*os.File, err error) {
|
|
|
|
w.rotateMu.Lock()
|
|
|
|
defer w.rotateMu.Unlock()
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
defer func() {
|
|
|
|
if err == nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
for _, f := range files {
|
|
|
|
f.Close()
|
2018-03-12 22:47:24 -04:00
|
|
|
if strings.HasSuffix(f.Name(), tmpLogfileSuffix) {
|
|
|
|
err := os.Remove(f.Name())
|
|
|
|
if err != nil && !os.IsNotExist(err) {
|
2018-07-05 14:51:50 -04:00
|
|
|
logrus.Warnf("Failed to remove logfile: %v", err)
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
}
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
for i := w.maxFiles; i > 1; i-- {
|
2020-07-15 13:40:21 -04:00
|
|
|
f, err := open(fmt.Sprintf("%s.%d", w.f.Name(), i-1))
|
2017-07-18 11:54:03 -04:00
|
|
|
if err != nil {
|
|
|
|
if !os.IsNotExist(err) {
|
2018-05-07 11:25:41 -04:00
|
|
|
return nil, errors.Wrap(err, "error opening rotated log file")
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
2018-03-12 22:47:24 -04:00
|
|
|
|
|
|
|
fileName := fmt.Sprintf("%s.%d.gz", w.f.Name(), i-1)
|
|
|
|
decompressedFileName := fileName + tmpLogfileSuffix
|
|
|
|
tmpFile, err := w.filesRefCounter.GetReference(decompressedFileName, func(refFileName string, exists bool) (*os.File, error) {
|
|
|
|
if exists {
|
2020-07-15 13:40:21 -04:00
|
|
|
return open(refFileName)
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
return decompressfile(fileName, refFileName, config.Since)
|
|
|
|
})
|
|
|
|
|
|
|
|
if err != nil {
|
2020-04-17 06:01:01 -04:00
|
|
|
if !errors.Is(err, os.ErrNotExist) {
|
2018-05-07 11:25:41 -04:00
|
|
|
return nil, errors.Wrap(err, "error getting reference to decompressed log file")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
if tmpFile == nil {
|
|
|
|
// The log before `config.Since` does not need to read
|
|
|
|
break
|
|
|
|
}
|
|
|
|
|
|
|
|
files = append(files, tmpFile)
|
2017-07-18 11:54:03 -04:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
files = append(files, f)
|
|
|
|
}
|
|
|
|
|
|
|
|
return files, nil
|
|
|
|
}
|
|
|
|
|
2018-03-12 22:47:24 -04:00
|
|
|
func decompressfile(fileName, destFileName string, since time.Time) (*os.File, error) {
|
2020-07-15 13:40:21 -04:00
|
|
|
cf, err := open(fileName)
|
2018-03-12 22:47:24 -04:00
|
|
|
if err != nil {
|
2018-05-07 11:25:41 -04:00
|
|
|
return nil, errors.Wrap(err, "error opening file for decompression")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
defer cf.Close()
|
|
|
|
|
|
|
|
rc, err := gzip.NewReader(cf)
|
|
|
|
if err != nil {
|
2018-05-07 11:25:41 -04:00
|
|
|
return nil, errors.Wrap(err, "error making gzip reader for compressed log file")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
defer rc.Close()
|
|
|
|
|
|
|
|
// Extract the last log entry timestramp from the gzip header
|
|
|
|
extra := &rotateFileMetadata{}
|
|
|
|
err = json.Unmarshal(rc.Header.Extra, extra)
|
|
|
|
if err == nil && extra.LastTime.Before(since) {
|
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
|
2019-09-23 14:09:01 -04:00
|
|
|
rs, err := openFile(destFileName, os.O_CREATE|os.O_RDWR, 0640)
|
2018-03-12 22:47:24 -04:00
|
|
|
if err != nil {
|
2018-05-07 11:25:41 -04:00
|
|
|
return nil, errors.Wrap(err, "error creating file for copying decompressed log stream")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
_, err = pools.Copy(rs, rc)
|
|
|
|
if err != nil {
|
|
|
|
rs.Close()
|
|
|
|
rErr := os.Remove(rs.Name())
|
2018-05-07 11:25:41 -04:00
|
|
|
if rErr != nil && !os.IsNotExist(rErr) {
|
2018-07-05 14:51:50 -04:00
|
|
|
logrus.Errorf("Failed to remove logfile: %v", rErr)
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
2018-05-07 11:25:41 -04:00
|
|
|
return nil, errors.Wrap(err, "error while copying decompressed log stream to file")
|
2018-03-12 22:47:24 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
return rs, nil
|
|
|
|
}
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
func newSectionReader(f *os.File) (*io.SectionReader, error) {
|
|
|
|
// seek to the end to get the size
|
|
|
|
// we'll leave this at the end of the file since section reader does not advance the reader
|
2019-11-25 12:53:03 -05:00
|
|
|
size, err := f.Seek(0, io.SeekEnd)
|
2017-07-18 11:54:03 -04:00
|
|
|
if err != nil {
|
|
|
|
return nil, errors.Wrap(err, "error getting current file size")
|
|
|
|
}
|
|
|
|
return io.NewSectionReader(f, 0, size), nil
|
|
|
|
}
|
|
|
|
|
2020-06-12 19:01:37 -04:00
|
|
|
func tailFiles(files []SizeReaderAt, watcher *logger.LogWatcher, dec Decoder, getTailReader GetTailReaderFunc, config logger.ReadConfig, notifyEvict <-chan interface{}) (cont bool) {
|
2018-04-05 12:39:28 -04:00
|
|
|
nLines := config.Tail
|
|
|
|
|
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
|
|
|
defer cancel()
|
2020-06-12 19:01:37 -04:00
|
|
|
|
|
|
|
cont = true
|
2018-04-05 12:39:28 -04:00
|
|
|
// TODO(@cpuguy83): we should plumb a context through instead of dealing with `WatchClose()` here.
|
|
|
|
go func() {
|
|
|
|
select {
|
2020-06-12 19:01:37 -04:00
|
|
|
case err := <-notifyEvict:
|
|
|
|
if err != nil {
|
|
|
|
watcher.Err <- err.(error)
|
|
|
|
cont = false
|
|
|
|
cancel()
|
|
|
|
}
|
2018-04-05 12:39:28 -04:00
|
|
|
case <-ctx.Done():
|
daemon.ContainerLogs(): fix resource leak on follow
When daemon.ContainerLogs() is called with options.follow=true
(as in "docker logs --follow"), the "loggerutils.followLogs()"
function never returns (even then the logs consumer is gone).
As a result, all the resources associated with it (including
an opened file descriptor for the log file being read, two FDs
for a pipe, and two FDs for inotify watch) are never released.
If this is repeated (such as by running "docker logs --follow"
and pressing Ctrl-C a few times), this results in DoS caused by
either hitting the limit of inotify watches, or the limit of
opened files. The only cure is daemon restart.
Apparently, what happens is:
1. logs producer (a container) is gone, calling (*LogWatcher).Close()
for all its readers (daemon/logger/jsonfilelog/jsonfilelog.go:175).
2. WatchClose() is properly handled by a dedicated goroutine in
followLogs(), cancelling the context.
3. Upon receiving the ctx.Done(), the code in followLogs()
(daemon/logger/loggerutils/logfile.go#L626-L638) keeps to
send messages _synchronously_ (which is OK for now).
4. Logs consumer is gone (Ctrl-C is pressed on a terminal running
"docker logs --follow"). Method (*LogWatcher).Close() is properly
called (see daemon/logs.go:114). Since it was called before and
due to to once.Do(), nothing happens (which is kinda good, as
otherwise it will panic on closing a closed channel).
5. A goroutine (see item 3 above) keeps sending log messages
synchronously to the logWatcher.Msg channel. Since the
channel reader is gone, the channel send operation blocks forever,
and resource cleanup set up in defer statements at the beginning
of followLogs() never happens.
Alas, the fix is somewhat complicated:
1. Distinguish between close from logs producer and logs consumer.
To that effect,
- yet another channel is added to LogWatcher();
- {Watch,}Close() are renamed to {Watch,}ProducerGone();
- {Watch,}ConsumerGone() are added;
*NOTE* that ProducerGone()/WatchProducerGone() pair is ONLY needed
in order to stop ConsumerLogs(follow=true) when a container is stopped;
otherwise we're not interested in it. In other words, we're only
using it in followLogs().
2. Code that was doing (logWatcher*).Close() is modified to either call
ProducerGone() or ConsumerGone(), depending on the context.
3. Code that was waiting for WatchClose() is modified to wait for
either ConsumerGone() or ProducerGone(), or both, depending on the
context.
4. followLogs() are modified accordingly:
- context cancellation is happening on WatchProducerGone(),
and once it's received the FileWatcher is closed and waitRead()
returns errDone on EOF (i.e. log rotation handling logic is disabled);
- due to this, code that was writing synchronously to logWatcher.Msg
can be and is removed as the code above it handles this case;
- function returns once ConsumerGone is received, freeing all the
resources -- this is the bugfix itself.
While at it,
1. Let's also remove the ctx usage to simplify the code a bit.
It was introduced by commit a69a59ffc7e3d ("Decouple removing the
fileWatcher from reading") in order to fix a bug. The bug was actually
a deadlock in fsnotify, and the fix was just a workaround. Since then
the fsnofify bug has been fixed, and a new fsnotify was vendored in.
For more details, please see
https://github.com/moby/moby/pull/27782#issuecomment-416794490
2. Since `(*filePoller).Close()` is fixed to remove all the files
being watched, there is no need to explicitly call
fileWatcher.Remove(name) anymore, so get rid of the extra code.
Should fix https://github.com/moby/moby/issues/37391
Signed-off-by: Kir Kolyshkin <kolyshkin@gmail.com>
2018-08-01 00:03:55 -04:00
|
|
|
case <-watcher.WatchConsumerGone():
|
2020-06-12 19:01:37 -04:00
|
|
|
cont = false
|
2018-04-05 12:39:28 -04:00
|
|
|
cancel()
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
readers := make([]io.Reader, 0, len(files))
|
2017-07-18 11:54:03 -04:00
|
|
|
|
|
|
|
if config.Tail > 0 {
|
2018-04-05 12:39:28 -04:00
|
|
|
for i := len(files) - 1; i >= 0 && nLines > 0; i-- {
|
|
|
|
tail, n, err := getTailReader(ctx, files[i], nLines)
|
|
|
|
if err != nil {
|
|
|
|
watcher.Err <- errors.Wrap(err, "error finding file position to start log tailing")
|
|
|
|
return
|
|
|
|
}
|
|
|
|
nLines -= n
|
|
|
|
readers = append([]io.Reader{tail}, readers...)
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
for _, r := range files {
|
|
|
|
readers = append(readers, &wrappedReaderAt{ReaderAt: r})
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-04-05 12:39:28 -04:00
|
|
|
rdr := io.MultiReader(readers...)
|
2020-04-08 15:24:31 -04:00
|
|
|
dec.Reset(rdr)
|
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
for {
|
2020-04-08 15:24:31 -04:00
|
|
|
msg, err := dec.Decode()
|
2017-07-18 11:54:03 -04:00
|
|
|
if err != nil {
|
2020-04-17 06:01:01 -04:00
|
|
|
if !errors.Is(err, io.EOF) {
|
2017-07-18 11:54:03 -04:00
|
|
|
watcher.Err <- err
|
|
|
|
}
|
|
|
|
return
|
|
|
|
}
|
|
|
|
if !config.Since.IsZero() && msg.Timestamp.Before(config.Since) {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
if !config.Until.IsZero() && msg.Timestamp.After(config.Until) {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
select {
|
2018-04-05 12:39:28 -04:00
|
|
|
case <-ctx.Done():
|
2017-07-18 11:54:03 -04:00
|
|
|
return
|
|
|
|
case watcher.Msg <- msg:
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func watchFile(name string) (filenotify.FileWatcher, error) {
|
2018-07-06 18:48:59 -04:00
|
|
|
var fileWatcher filenotify.FileWatcher
|
|
|
|
|
|
|
|
if runtime.GOOS == "windows" {
|
2018-08-26 04:30:40 -04:00
|
|
|
// FileWatcher on Windows files is based on the syscall notifications which has an issue because of file caching.
|
2018-07-06 18:48:59 -04:00
|
|
|
// It is based on ReadDirectoryChangesW() which doesn't detect writes to the cache. It detects writes to disk only.
|
2018-08-26 04:30:40 -04:00
|
|
|
// Because of the OS lazy writing, we don't get notifications for file writes and thereby the watcher
|
2018-07-06 18:48:59 -04:00
|
|
|
// doesn't work. Hence for Windows we will use poll based notifier.
|
|
|
|
fileWatcher = filenotify.NewPollingWatcher()
|
|
|
|
} else {
|
|
|
|
var err error
|
|
|
|
fileWatcher, err = filenotify.New()
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2017-07-18 11:54:03 -04:00
|
|
|
}
|
|
|
|
|
|
|
|
logger := logrus.WithFields(logrus.Fields{
|
|
|
|
"module": "logger",
|
2018-07-31 08:44:46 -04:00
|
|
|
"file": name,
|
2017-07-18 11:54:03 -04:00
|
|
|
})
|
|
|
|
|
|
|
|
if err := fileWatcher.Add(name); err != nil {
|
2018-07-06 18:48:59 -04:00
|
|
|
// we will retry using file poller.
|
2017-07-18 11:54:03 -04:00
|
|
|
logger.WithError(err).Warnf("falling back to file poller")
|
|
|
|
fileWatcher.Close()
|
|
|
|
fileWatcher = filenotify.NewPollingWatcher()
|
|
|
|
|
|
|
|
if err := fileWatcher.Add(name); err != nil {
|
|
|
|
fileWatcher.Close()
|
|
|
|
logger.WithError(err).Debugf("error watching log file for modifications")
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
}
|
2018-07-06 18:48:59 -04:00
|
|
|
|
2017-07-18 11:54:03 -04:00
|
|
|
return fileWatcher, nil
|
|
|
|
}
|
2018-04-05 12:39:28 -04:00
|
|
|
|
|
|
|
type wrappedReaderAt struct {
|
|
|
|
io.ReaderAt
|
|
|
|
pos int64
|
|
|
|
}
|
|
|
|
|
|
|
|
func (r *wrappedReaderAt) Read(p []byte) (int, error) {
|
|
|
|
n, err := r.ReaderAt.ReadAt(p, r.pos)
|
|
|
|
r.pos += int64(n)
|
|
|
|
return n, err
|
|
|
|
}
|