mirror of
				https://github.com/containers/podman.git
				synced 2025-10-25 18:25:59 +08:00 
			
		
		
		
	 4e72aa5860
			
		
	
	4e72aa5860
	
	
	
		
			
			When running a single podman logs this is not really important since we will exit when we finish reading the logs. However for the system service this is very important. Leaking goroutines will cause an increased memory and CPU ussage over time. Both the the event and log backend have goroutine leaks with both the file and journald drivers. The journald backend has the problem that journal.Wait(IndefiniteWait) will block until we get a new journald event. So when a client closes the connection the goroutine would still wait until there is a new journal entry. To fix this we just wait for a maximum of 5 seconds, after that we can check if the client connection was closed and exit correctly in this case. For the file backend we can fix this by waiting for either the log line or context cancel at the same time. Currently it would block waiting for new log lines and only check afterwards if the client closed the connection and thus hang forever if there are no new log lines. [NO NEW TESTS NEEDED] I am open to ideas how we can test memory leaks in CI. To test manually run a container like this: `podman run --log-driver $driver --name test -d alpine sh -c 'i=1; while [ "$i" -ne 1000 ]; do echo "line $i"; i=$((i + 1)); done; sleep inf'` where `$driver` can be either `journald` or `k8s-file`. Then start the podman system service and use: `curl -m 1 --output - --unix-socket $XDG_RUNTIME_DIR/podman/podman.sock -v 'http://d/containers/test/logs?follow=1&since=0&stderr=1&stdout=1' &>/dev/null` to get the logs from the API and then it closes the connection after 1 second. Now run the curl command several times and check the memory usage of the service. Fixes #14879 Signed-off-by: Paul Holzinger <pholzing@redhat.com>
		
			
				
	
	
		
			328 lines
		
	
	
		
			9.1 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
			
		
		
	
	
			328 lines
		
	
	
		
			9.1 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
| //go:build linux && systemd
 | |
| // +build linux,systemd
 | |
| 
 | |
| package libpod
 | |
| 
 | |
| import (
 | |
| 	"context"
 | |
| 	"errors"
 | |
| 	"fmt"
 | |
| 	"strings"
 | |
| 	"time"
 | |
| 
 | |
| 	"github.com/containers/podman/v4/libpod/define"
 | |
| 	"github.com/containers/podman/v4/libpod/events"
 | |
| 	"github.com/containers/podman/v4/libpod/logs"
 | |
| 	"github.com/coreos/go-systemd/v22/journal"
 | |
| 	"github.com/coreos/go-systemd/v22/sdjournal"
 | |
| 	"github.com/sirupsen/logrus"
 | |
| )
 | |
| 
 | |
| const (
 | |
| 	// journaldLogOut is the journald priority signifying stdout
 | |
| 	journaldLogOut = "6"
 | |
| 
 | |
| 	// journaldLogErr is the journald priority signifying stderr
 | |
| 	journaldLogErr = "3"
 | |
| )
 | |
| 
 | |
| func init() {
 | |
| 	logDrivers = append(logDrivers, define.JournaldLogging)
 | |
| }
 | |
| 
 | |
| // initializeJournal will write an empty string to the journal
 | |
| // when a journal is created. This solves a problem when people
 | |
| // attempt to read logs from a container that has never had stdout/stderr
 | |
| func (c *Container) initializeJournal(ctx context.Context) error {
 | |
| 	m := make(map[string]string)
 | |
| 	m["SYSLOG_IDENTIFIER"] = "podman"
 | |
| 	m["PODMAN_ID"] = c.ID()
 | |
| 	history := events.History
 | |
| 	m["PODMAN_EVENT"] = history.String()
 | |
| 	container := events.Container
 | |
| 	m["PODMAN_TYPE"] = container.String()
 | |
| 	m["PODMAN_TIME"] = time.Now().Format(time.RFC3339Nano)
 | |
| 	return journal.Send("", journal.PriInfo, m)
 | |
| }
 | |
| 
 | |
| func (c *Container) readFromJournal(ctx context.Context, options *logs.LogOptions, logChannel chan *logs.LogLine, colorID int64) error {
 | |
| 	// We need the container's events in the same journal to guarantee
 | |
| 	// consistency, see #10323.
 | |
| 	if options.Follow && c.runtime.config.Engine.EventsLogger != "journald" {
 | |
| 		return fmt.Errorf("using --follow with the journald --log-driver but without the journald --events-backend (%s) is not supported", c.runtime.config.Engine.EventsLogger)
 | |
| 	}
 | |
| 
 | |
| 	journal, err := sdjournal.NewJournal()
 | |
| 	if err != nil {
 | |
| 		return err
 | |
| 	}
 | |
| 	// While logs are written to the `logChannel`, we inspect each event
 | |
| 	// and stop once the container has died.  Having logs and events in one
 | |
| 	// stream prevents a race condition that we faced in #10323.
 | |
| 
 | |
| 	// Add the filters for events.
 | |
| 	match := sdjournal.Match{Field: "SYSLOG_IDENTIFIER", Value: "podman"}
 | |
| 	if err := journal.AddMatch(match.String()); err != nil {
 | |
| 		return fmt.Errorf("adding filter to journald logger: %v: %w", match, err)
 | |
| 	}
 | |
| 	match = sdjournal.Match{Field: "PODMAN_ID", Value: c.ID()}
 | |
| 	if err := journal.AddMatch(match.String()); err != nil {
 | |
| 		return fmt.Errorf("adding filter to journald logger: %v: %w", match, err)
 | |
| 	}
 | |
| 
 | |
| 	// Add the filter for logs.  Note the disjunction so that we match
 | |
| 	// either the events or the logs.
 | |
| 	if err := journal.AddDisjunction(); err != nil {
 | |
| 		return fmt.Errorf("adding filter disjunction to journald logger: %w", err)
 | |
| 	}
 | |
| 	match = sdjournal.Match{Field: "CONTAINER_ID_FULL", Value: c.ID()}
 | |
| 	if err := journal.AddMatch(match.String()); err != nil {
 | |
| 		return fmt.Errorf("adding filter to journald logger: %v: %w", match, err)
 | |
| 	}
 | |
| 
 | |
| 	if err := journal.SeekHead(); err != nil {
 | |
| 		return err
 | |
| 	}
 | |
| 	// API requires Next() immediately after SeekHead().
 | |
| 	if _, err := journal.Next(); err != nil {
 | |
| 		return fmt.Errorf("next journal: %w", err)
 | |
| 	}
 | |
| 
 | |
| 	// API requires a next|prev before getting a cursor.
 | |
| 	if _, err := journal.Previous(); err != nil {
 | |
| 		return fmt.Errorf("previous journal: %w", err)
 | |
| 	}
 | |
| 
 | |
| 	// Note that the initial cursor may not yet be ready, so we'll do an
 | |
| 	// exponential backoff.
 | |
| 	var cursor string
 | |
| 	var cursorError error
 | |
| 	var containerCouldBeLogging bool
 | |
| 	for i := 1; i <= 3; i++ {
 | |
| 		cursor, cursorError = journal.GetCursor()
 | |
| 		hundreds := 1
 | |
| 		for j := 1; j < i; j++ {
 | |
| 			hundreds *= 2
 | |
| 		}
 | |
| 		if cursorError != nil {
 | |
| 			time.Sleep(time.Duration(hundreds*100) * time.Millisecond)
 | |
| 			continue
 | |
| 		}
 | |
| 		break
 | |
| 	}
 | |
| 	if cursorError != nil {
 | |
| 		return fmt.Errorf("initial journal cursor: %w", cursorError)
 | |
| 	}
 | |
| 
 | |
| 	options.WaitGroup.Add(1)
 | |
| 	go func() {
 | |
| 		defer func() {
 | |
| 			options.WaitGroup.Done()
 | |
| 			if err := journal.Close(); err != nil {
 | |
| 				logrus.Errorf("Unable to close journal: %v", err)
 | |
| 			}
 | |
| 		}()
 | |
| 
 | |
| 		tailQueue := []*logs.LogLine{} // needed for options.Tail
 | |
| 		doTail := options.Tail >= 0
 | |
| 		doTailFunc := func() {
 | |
| 			// Flush *once* we hit the end of the journal.
 | |
| 			startIndex := int64(len(tailQueue))
 | |
| 			outputLines := int64(0)
 | |
| 			for startIndex > 0 && outputLines < options.Tail {
 | |
| 				startIndex--
 | |
| 				for startIndex > 0 && tailQueue[startIndex].Partial() {
 | |
| 					startIndex--
 | |
| 				}
 | |
| 				outputLines++
 | |
| 			}
 | |
| 			for i := startIndex; i < int64(len(tailQueue)); i++ {
 | |
| 				logChannel <- tailQueue[i]
 | |
| 			}
 | |
| 			tailQueue = nil
 | |
| 			doTail = false
 | |
| 		}
 | |
| 		lastReadCursor := ""
 | |
| 		for {
 | |
| 			select {
 | |
| 			case <-ctx.Done():
 | |
| 				// Remote client may have closed/lost the connection.
 | |
| 				return
 | |
| 			default:
 | |
| 				// Fallthrough
 | |
| 			}
 | |
| 
 | |
| 			if lastReadCursor != "" {
 | |
| 				// Advance to next entry if we read this one.
 | |
| 				if _, err := journal.Next(); err != nil {
 | |
| 					logrus.Errorf("Failed to move journal cursor to next entry: %v", err)
 | |
| 					return
 | |
| 				}
 | |
| 			}
 | |
| 
 | |
| 			// Fetch the location of this entry, presumably either
 | |
| 			// the one that follows the last one we read, or that
 | |
| 			// same last one, if there is no next entry (yet).
 | |
| 			cursor, err = journal.GetCursor()
 | |
| 			if err != nil {
 | |
| 				logrus.Errorf("Failed to get journal cursor: %v", err)
 | |
| 				return
 | |
| 			}
 | |
| 
 | |
| 			// Hit the end of the journal (so far?).
 | |
| 			if cursor == lastReadCursor {
 | |
| 				if doTail {
 | |
| 					doTailFunc()
 | |
| 				}
 | |
| 				// Unless we follow, quit.
 | |
| 				if !options.Follow || !containerCouldBeLogging {
 | |
| 					return
 | |
| 				}
 | |
| 
 | |
| 				// journal.Wait() is blocking, this would cause the goroutine to hang forever
 | |
| 				// if no more journal entries are generated and thus if the client
 | |
| 				// has closed the connection in the meantime to leak memory.
 | |
| 				// Waiting only 5 seconds makes sure we can check if the client closed in the
 | |
| 				// meantime at least every 5 seconds.
 | |
| 				journal.Wait(5 * time.Second)
 | |
| 				continue
 | |
| 			}
 | |
| 			lastReadCursor = cursor
 | |
| 
 | |
| 			// Read the journal entry.
 | |
| 			entry, err := journal.GetEntry()
 | |
| 			if err != nil {
 | |
| 				logrus.Errorf("Failed to get journal entry: %v", err)
 | |
| 				return
 | |
| 			}
 | |
| 
 | |
| 			entryTime := time.Unix(0, int64(entry.RealtimeTimestamp)*int64(time.Microsecond))
 | |
| 			if (entryTime.Before(options.Since) && !options.Since.IsZero()) || (entryTime.After(options.Until) && !options.Until.IsZero()) {
 | |
| 				continue
 | |
| 			}
 | |
| 			// If we're reading an event and the container exited/died,
 | |
| 			// then we're done and can return.
 | |
| 			event, ok := entry.Fields["PODMAN_EVENT"]
 | |
| 			if ok {
 | |
| 				status, err := events.StringToStatus(event)
 | |
| 				if err != nil {
 | |
| 					logrus.Errorf("Failed to translate event: %v", err)
 | |
| 					return
 | |
| 				}
 | |
| 				switch status {
 | |
| 				case events.History, events.Init, events.Start, events.Restart:
 | |
| 					containerCouldBeLogging = true
 | |
| 				case events.Exited:
 | |
| 					containerCouldBeLogging = false
 | |
| 				}
 | |
| 				continue
 | |
| 			}
 | |
| 
 | |
| 			var message string
 | |
| 			var formatError error
 | |
| 
 | |
| 			if options.Multi {
 | |
| 				message, formatError = journalFormatterWithID(entry)
 | |
| 			} else {
 | |
| 				message, formatError = journalFormatter(entry)
 | |
| 			}
 | |
| 
 | |
| 			if formatError != nil {
 | |
| 				logrus.Errorf("Failed to parse journald log entry: %v", formatError)
 | |
| 				return
 | |
| 			}
 | |
| 
 | |
| 			logLine, err := logs.NewJournaldLogLine(message, options.Multi)
 | |
| 			logLine.ColorID = colorID
 | |
| 			if err != nil {
 | |
| 				logrus.Errorf("Failed parse log line: %v", err)
 | |
| 				return
 | |
| 			}
 | |
| 			if options.UseName {
 | |
| 				logLine.CName = c.Name()
 | |
| 			}
 | |
| 			if doTail {
 | |
| 				tailQueue = append(tailQueue, logLine)
 | |
| 				continue
 | |
| 			}
 | |
| 			logChannel <- logLine
 | |
| 		}
 | |
| 	}()
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| func journalFormatterWithID(entry *sdjournal.JournalEntry) (string, error) {
 | |
| 	output, err := formatterPrefix(entry)
 | |
| 	if err != nil {
 | |
| 		return "", err
 | |
| 	}
 | |
| 
 | |
| 	id, ok := entry.Fields["CONTAINER_ID_FULL"]
 | |
| 	if !ok {
 | |
| 		return "", errors.New("no CONTAINER_ID_FULL field present in journal entry")
 | |
| 	}
 | |
| 	if len(id) > 12 {
 | |
| 		id = id[:12]
 | |
| 	}
 | |
| 	output += fmt.Sprintf("%s ", id)
 | |
| 	// Append message
 | |
| 	msg, err := formatterMessage(entry)
 | |
| 	if err != nil {
 | |
| 		return "", err
 | |
| 	}
 | |
| 	output += msg
 | |
| 	return output, nil
 | |
| }
 | |
| 
 | |
| func journalFormatter(entry *sdjournal.JournalEntry) (string, error) {
 | |
| 	output, err := formatterPrefix(entry)
 | |
| 	if err != nil {
 | |
| 		return "", err
 | |
| 	}
 | |
| 	// Append message
 | |
| 	msg, err := formatterMessage(entry)
 | |
| 	if err != nil {
 | |
| 		return "", err
 | |
| 	}
 | |
| 	output += msg
 | |
| 	return output, nil
 | |
| }
 | |
| 
 | |
| func formatterPrefix(entry *sdjournal.JournalEntry) (string, error) {
 | |
| 	usec := entry.RealtimeTimestamp
 | |
| 	tsString := time.Unix(0, int64(usec)*int64(time.Microsecond)).Format(logs.LogTimeFormat)
 | |
| 	output := fmt.Sprintf("%s ", tsString)
 | |
| 	priority, ok := entry.Fields["PRIORITY"]
 | |
| 	if !ok {
 | |
| 		return "", errors.New("no PRIORITY field present in journal entry")
 | |
| 	}
 | |
| 	switch priority {
 | |
| 	case journaldLogOut:
 | |
| 		output += "stdout "
 | |
| 	case journaldLogErr:
 | |
| 		output += "stderr "
 | |
| 	default:
 | |
| 		return "", errors.New("unexpected PRIORITY field in journal entry")
 | |
| 	}
 | |
| 
 | |
| 	// if CONTAINER_PARTIAL_MESSAGE is defined, the log type is "P"
 | |
| 	if _, ok := entry.Fields["CONTAINER_PARTIAL_MESSAGE"]; ok {
 | |
| 		output += fmt.Sprintf("%s ", logs.PartialLogType)
 | |
| 	} else {
 | |
| 		output += fmt.Sprintf("%s ", logs.FullLogType)
 | |
| 	}
 | |
| 
 | |
| 	return output, nil
 | |
| }
 | |
| 
 | |
| func formatterMessage(entry *sdjournal.JournalEntry) (string, error) {
 | |
| 	// Finally, append the message
 | |
| 	msg, ok := entry.Fields["MESSAGE"]
 | |
| 	if !ok {
 | |
| 		return "", errors.New("no MESSAGE field present in journal entry")
 | |
| 	}
 | |
| 	msg = strings.TrimSuffix(msg, "\n")
 | |
| 	return msg, nil
 | |
| }
 |