添加链接
link管理
链接快照平台
  • 输入网页链接,自动生成快照
  • 标签化管理网页链接

Package zapcore defines and implements the low-level interfaces upon which zap is built. By providing alternate implementations of these interfaces, external packages can extend zap's capabilities.

Index

  • Constants
  • Variables
  • func CapitalColorLevelEncoder(l Level, enc PrimitiveArrayEncoder) func CapitalLevelEncoder(l Level, enc PrimitiveArrayEncoder) func EpochMillisTimeEncoder(t time.Time, enc PrimitiveArrayEncoder) func EpochNanosTimeEncoder(t time.Time, enc PrimitiveArrayEncoder) func EpochTimeEncoder(t time.Time, enc PrimitiveArrayEncoder) func FullCallerEncoder(caller EntryCaller, enc PrimitiveArrayEncoder) func FullNameEncoder(loggerName string, enc PrimitiveArrayEncoder) func ISO8601TimeEncoder(t time.Time, enc PrimitiveArrayEncoder) func LowercaseColorLevelEncoder(l Level, enc PrimitiveArrayEncoder) func LowercaseLevelEncoder(l Level, enc PrimitiveArrayEncoder) func MillisDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder) func NanosDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder) func RFC3339NanoTimeEncoder(t time.Time, enc PrimitiveArrayEncoder) func RFC3339TimeEncoder(t time.Time, enc PrimitiveArrayEncoder) func SecondsDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder) func ShortCallerEncoder(caller EntryCaller, enc PrimitiveArrayEncoder) func StringDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder) type ArrayEncoder type ArrayMarshaler type ArrayMarshalerFunc func (f ArrayMarshalerFunc) MarshalLogArray(enc ArrayEncoder) error type BufferedWriteSyncer func (s *BufferedWriteSyncer) Stop() (err error) func (s *BufferedWriteSyncer) Sync() error func (s *BufferedWriteSyncer) Write(bs []byte) (int, error) type CallerEncoder func (e *CallerEncoder) UnmarshalText(text []byte) error type CheckWriteAction func (a CheckWriteAction) OnWrite(ce *CheckedEntry, _ []Field) type CheckWriteHook type CheckedEntry func (ce *CheckedEntry) AddCore(ent Entry, core Core) *CheckedEntry func (ce *CheckedEntry) After(ent Entry, hook CheckWriteHook) *CheckedEntry func (ce *CheckedEntry) Should(ent Entry, should CheckWriteAction) *CheckedEntry deprecated func (ce *CheckedEntry) Write(fields ...Field) type Clock type Core func NewCore(enc Encoder, ws WriteSyncer, enab LevelEnabler) Core func NewIncreaseLevelCore(core Core, level LevelEnabler) (Core, error) func NewLazyWith(core Core, fields []Field) Core func NewNopCore() Core func NewSampler(core Core, tick time.Duration, first, thereafter int) Core deprecated func NewSamplerWithOptions(core Core, tick time.Duration, first, thereafter int, opts ...SamplerOption) Core func NewTee(cores ...Core) Core func RegisterHooks(core Core, hooks ...func(Entry) error) Core type DurationEncoder func (e *DurationEncoder) UnmarshalText(text []byte) error type Encoder func NewConsoleEncoder(cfg EncoderConfig) Encoder func NewJSONEncoder(cfg EncoderConfig) Encoder type EncoderConfig type Entry type EntryCaller func NewEntryCaller(pc uintptr, file string, line int, ok bool) EntryCaller func (ec EntryCaller) FullPath() string func (ec EntryCaller) String() string func (ec EntryCaller) TrimmedPath() string type Field func (f Field) AddTo(enc ObjectEncoder) func (f Field) Equals(other Field) bool type FieldType type Level func LevelOf(enab LevelEnabler) Level func ParseLevel(text string) (Level, error) func (l Level) CapitalString() string func (l Level) Enabled(lvl Level) bool func (l *Level) Get() interface{} func (l Level) MarshalText() ([]byte, error) func (l *Level) Set(s string) error func (l Level) String() string func (l *Level) UnmarshalText(text []byte) error type LevelEnabler type LevelEncoder func (e *LevelEncoder) UnmarshalText(text []byte) error type MapObjectEncoder func NewMapObjectEncoder() *MapObjectEncoder func (m *MapObjectEncoder) AddArray(key string, v ArrayMarshaler) error func (m *MapObjectEncoder) AddBinary(k string, v []byte) func (m *MapObjectEncoder) AddBool(k string, v bool) func (m *MapObjectEncoder) AddByteString(k string, v []byte) func (m *MapObjectEncoder) AddComplex128(k string, v complex128) func (m *MapObjectEncoder) AddComplex64(k string, v complex64) func (m MapObjectEncoder) AddDuration(k string, v time.Duration) func (m *MapObjectEncoder) AddFloat32(k string, v float32) func (m *MapObjectEncoder) AddFloat64(k string, v float64) func (m *MapObjectEncoder) AddInt(k string, v int) func (m *MapObjectEncoder) AddInt16(k string, v int16) func (m *MapObjectEncoder) AddInt32(k string, v int32) func (m *MapObjectEncoder) AddInt64(k string, v int64) func (m *MapObjectEncoder) AddInt8(k string, v int8) func (m *MapObjectEncoder) AddObject(k string, v ObjectMarshaler) error func (m *MapObjectEncoder) AddReflected(k string, v interface{}) error func (m *MapObjectEncoder) AddString(k string, v string) func (m MapObjectEncoder) AddTime(k string, v time.Time) func (m *MapObjectEncoder) AddUint(k string, v uint) func (m *MapObjectEncoder) AddUint16(k string, v uint16) func (m *MapObjectEncoder) AddUint32(k string, v uint32) func (m *MapObjectEncoder) AddUint64(k string, v uint64) func (m *MapObjectEncoder) AddUint8(k string, v uint8) func (m *MapObjectEncoder) AddUintptr(k string, v uintptr) func (m *MapObjectEncoder) OpenNamespace(k string) type NameEncoder func (e *NameEncoder) UnmarshalText(text []byte) error type ObjectEncoder type ObjectMarshaler type ObjectMarshalerFunc func (f ObjectMarshalerFunc) MarshalLogObject(enc ObjectEncoder) error type PrimitiveArrayEncoder type ReflectedEncoder type SamplerOption func SamplerHook(hook func(entry Entry, dec SamplingDecision)) SamplerOption type SamplingDecision type TimeEncoder func TimeEncoderOfLayout(layout string) TimeEncoder func (e *TimeEncoder) UnmarshalJSON(data []byte) error func (e *TimeEncoder) UnmarshalText(text []byte) error func (e *TimeEncoder) UnmarshalYAML(unmarshal func(interface{}) error) error type WriteSyncer func AddSync(w io.Writer) WriteSyncer func Lock(ws WriteSyncer) WriteSyncer func NewMultiWriteSyncer(ws ...WriteSyncer) WriteSyncer

    Constants

    View Source
    const DefaultLineEnding = "\n"

    DefaultLineEnding defines the default line ending when writing logs. Alternate line endings specified in EncoderConfig can override this behavior. View Source

    const OmitKey = ""

    OmitKey defines the key to use when callers want to remove a key from log output.

    Variables

    View Source
    var DefaultClock = systemClock{}

    DefaultClock is the default clock used by Zap in operations that require time. This clock uses the system clock for all operations.

    Functions

    func CapitalColorLevelEncoder(l Level, enc PrimitiveArrayEncoder)

    CapitalColorLevelEncoder serializes a Level to an all-caps string and adds color. For example, InfoLevel is serialized to "INFO" and colored blue.

    func CapitalLevelEncoder(l Level, enc PrimitiveArrayEncoder)

    CapitalLevelEncoder serializes a Level to an all-caps string. For example, InfoLevel is serialized to "INFO".

    func EpochMillisTimeEncoder(t time.Time, enc PrimitiveArrayEncoder)

    EpochMillisTimeEncoder serializes a time.Time to a floating-point number of milliseconds since the Unix epoch.

    func EpochNanosTimeEncoder(t time.Time, enc PrimitiveArrayEncoder)

    EpochNanosTimeEncoder serializes a time.Time to an integer number of nanoseconds since the Unix epoch.

    func EpochTimeEncoder(t time.Time, enc PrimitiveArrayEncoder)

    EpochTimeEncoder serializes a time.Time to a floating-point number of seconds since the Unix epoch.

    func FullCallerEncoder(caller EntryCaller, enc PrimitiveArrayEncoder)

    FullCallerEncoder serializes a caller in /full/path/to/package/file:line format.

    func ISO8601TimeEncoder(t time.Time, enc PrimitiveArrayEncoder)

    ISO8601TimeEncoder serializes a time.Time to an ISO8601-formatted string with millisecond precision.

    If enc supports AppendTimeLayout(t time.Time,layout string), it's used instead of appending a pre-formatted string value.

    func LowercaseColorLevelEncoder(l Level, enc PrimitiveArrayEncoder)

    LowercaseColorLevelEncoder serializes a Level to a lowercase string and adds coloring. For example, InfoLevel is serialized to "info" and colored blue.

    func LowercaseLevelEncoder(l Level, enc PrimitiveArrayEncoder)

    LowercaseLevelEncoder serializes a Level to a lowercase string. For example, InfoLevel is serialized to "info".

    func MillisDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder)

    MillisDurationEncoder serializes a time.Duration to an integer number of milliseconds elapsed.

    func NanosDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder)

    NanosDurationEncoder serializes a time.Duration to an integer number of nanoseconds elapsed.

    func RFC3339NanoTimeEncoder(t time.Time, enc PrimitiveArrayEncoder)

    RFC3339NanoTimeEncoder serializes a time.Time to an RFC3339-formatted string with nanosecond precision.

    If enc supports AppendTimeLayout(t time.Time,layout string), it's used instead of appending a pre-formatted string value.

    func RFC3339TimeEncoder(t time.Time, enc PrimitiveArrayEncoder)

    RFC3339TimeEncoder serializes a time.Time to an RFC3339-formatted string.

    If enc supports AppendTimeLayout(t time.Time,layout string), it's used instead of appending a pre-formatted string value.

    func ShortCallerEncoder(caller EntryCaller, enc PrimitiveArrayEncoder)

    ShortCallerEncoder serializes a caller in package/file:line format, trimming all but the final directory from the full path.

    func StringDurationEncoder(d time.Duration, enc PrimitiveArrayEncoder)

    StringDurationEncoder serializes a time.Duration using its built-in String method. // Logging-specific marshalers. AppendArray( ArrayMarshaler ) error AppendObject( ObjectMarshaler ) error // AppendReflected uses reflection to serialize arbitrary objects, so it's // slow and allocation-heavy. AppendReflected(value interface{}) error

    ArrayEncoder is a strongly-typed, encoding-agnostic interface for adding array-like objects to the logging context. Of note, it supports mixed-type arrays even though they aren't typical in Go. Like slices, ArrayEncoders aren't safe for concurrent use (though typical use shouldn't require locks).

    ArrayMarshaler allows user-defined types to efficiently add themselves to the logging context, and to selectively omit information which shouldn't be included in logs (e.g., passwords).

    Note: ArrayMarshaler is only used when zap.Array is used or when passed directly to zap.Any. It is not used when reflection-based encoding is used.

    type ArrayMarshalerFunc func(ArrayEncoder) error

    ArrayMarshalerFunc is a type adapter that turns a function into an ArrayMarshaler.

    type BufferedWriteSyncer struct {
    	// WS is the WriteSyncer around which BufferedWriteSyncer will buffer
    	// writes.
    	// This field is required.
    	WS WriteSyncer
    	// Size specifies the maximum amount of data the writer will buffered
    	// before flushing.
    	// Defaults to 256 kB if unspecified.
    	Size int
    	// FlushInterval specifies how often the writer should flush data if
    	// there have been no writes.
    	// Defaults to 30 seconds if unspecified.
    	FlushInterval time.Duration
    	// Clock, if specified, provides control of the source of time for the
    	// writer.
    	// Defaults to the system clock.
    	Clock Clock
    	// contains filtered or unexported fields
      

    A BufferedWriteSyncer is a WriteSyncer that buffers writes in-memory before flushing them to a wrapped WriteSyncer after reaching some limit, or at some fixed interval--whichever comes first.

    BufferedWriteSyncer is safe for concurrent use. You don't need to use zapcore.Lock for WriteSyncers with BufferedWriteSyncer.

    To set up a BufferedWriteSyncer, construct a WriteSyncer for your log destination (*os.File is a valid WriteSyncer), wrap it with BufferedWriteSyncer, and defer a Stop() call for when you no longer need the object.

     func main() {
       ws := ... // your log destination
       bws := &zapcore.BufferedWriteSyncer{WS: ws}
       defer bws.Stop()
       // ...
       core := zapcore.NewCore(enc, bws, lvl)
       logger := zap.New(core)
       // ...
    

    By default, a BufferedWriteSyncer will buffer up to 256 kilobytes of logs, waiting at most 30 seconds between flushes. You can customize these parameters by setting the Size or FlushInterval fields. For example, the following buffers up to 512 kB of logs before flushing them to Stderr, with a maximum of one minute between each flush.

    ws := &BufferedWriteSyncer{
      WS:            os.Stderr,
      Size:          512 * 1024, // 512 kB
      FlushInterval: time.Minute,
    defer ws.Stop()
          
    func (s *BufferedWriteSyncer) Stop() (err error)

    Stop closes the buffer, cleans up background goroutines, and flushes remaining unwritten data.

    func (s *BufferedWriteSyncer) Write(bs []byte) (int, error)

    Write writes log data into buffer syncer directly, multiple Write calls will be batched, and log data will be flushed to disk when the buffer is full or periodically.

    type CallerEncoder func(EntryCaller, PrimitiveArrayEncoder)

    A CallerEncoder serializes an EntryCaller to a primitive type.

    This function must make exactly one call to a PrimitiveArrayEncoder's Append* method.

    func (e *CallerEncoder) UnmarshalText(text []byte) error

    UnmarshalText unmarshals text to a CallerEncoder. "full" is unmarshaled to FullCallerEncoder and anything else is unmarshaled to ShortCallerEncoder.

    type CheckWriteAction uint8

    CheckWriteAction indicates what action to take after a log entry is processed. Actions are ordered in increasing severity.

    const (
    	// WriteThenNoop indicates that nothing special needs to be done. It's the
    	// default behavior.
    	WriteThenNoop CheckWriteAction = iota
    	// WriteThenGoexit runs runtime.Goexit after Write.
    	WriteThenGoexit
    	// WriteThenPanic causes a panic after Write.
    	WriteThenPanic
    	// WriteThenFatal causes an os.Exit(1) after Write.
    	WriteThenFatal
          
    func (a CheckWriteAction) OnWrite(ce *CheckedEntry, _ []Field)

    OnWrite implements the OnWrite method to keep CheckWriteAction compatible with the new CheckWriteHook interface which deprecates CheckWriteAction.

    type CheckWriteHook interface {
    	// OnWrite is invoked with the CheckedEntry that was written and a list
    	// of fields added with that entry.
    	// The list of fields DOES NOT include fields that were already added
    	// to the logger with the With method.
    	OnWrite(*CheckedEntry, []Field)
      

    CheckWriteHook is a custom action that may be executed after an entry is written.

    Register one on a CheckedEntry with the After method.

    if ce := logger.Check(...); ce != nil {
      ce = ce.After(hook)
      ce.Write(...)
    

    You can configure the hook for Fatal log statements at the logger level with the zap.WithFatalHook option.

    CheckedEntry is an Entry together with a collection of Cores that have already agreed to log it.

    CheckedEntry references should be created by calling AddCore or After on a nil *CheckedEntry. References are returned to a pool after Write, and MUST NOT be retained after calling their Write method.

    func (ce *CheckedEntry) AddCore(ent Entry, core Core) *CheckedEntry

    AddCore adds a Core that has agreed to log this CheckedEntry. It's intended to be used by Core.Check implementations, and is safe to call on nil CheckedEntry references.

    func (ce *CheckedEntry) After(ent Entry, hook CheckWriteHook) *CheckedEntry

    After sets this CheckEntry's CheckWriteHook, which will be called after this log entry has been written. It's safe to call this on nil CheckedEntry references.

    func (ce *CheckedEntry) Should(ent Entry, should CheckWriteAction) *CheckedEntry

    Should sets this CheckedEntry's CheckWriteAction, which controls whether a Core will panic or fatal after writing this log entry. Like AddCore, it's safe to call on nil CheckedEntry references.

    Deprecated: Use CheckedEntry.After instead.

    func (ce *CheckedEntry) Write(fields ...Field)

    Write writes the entry to the stored Cores, returns any errors, and returns the CheckedEntry reference to a pool for immediate re-use. Finally, it executes any required CheckWriteAction. // NewTicker returns *time.Ticker that holds a channel // that delivers "ticks" of a clock. NewTicker(time.Duration) *time.Ticker

    Clock is a source of time for logged entries. // With adds structured context to the Core. With([]Field) Core // Check determines whether the supplied Entry should be logged (using the // embedded LevelEnabler and possibly some extra logic). If the entry // should be logged, the Core adds itself to the CheckedEntry and returns // the result. // Callers must use Check before calling Write. Check(Entry, *CheckedEntry) *CheckedEntry // Write serializes the Entry and any Fields supplied at the log site and // writes them to their destination. // If called, Write should always log the Entry and Fields; it should not // replicate the logic of Check. Write(Entry, []Field) error // Sync flushes buffered logs (if any). Sync() error

    Core is a minimal, fast logger interface. It's designed for library authors to wrap in a more user-friendly API.

    func NewIncreaseLevelCore(core Core, level LevelEnabler) (Core, error)

    NewIncreaseLevelCore creates a core that can be used to increase the level of an existing Core. It cannot be used to decrease the logging level, as it acts as a filter before calling the underlying core. If level decreases the log level, an error is returned.

    func NewLazyWith(core Core, fields []Field) Core

    NewLazyWith wraps a Core with a "lazy" Core that will only encode fields if the logger is written to (or is further chained in a lon-lazy manner).

    func NewSampler(core Core, tick time.Duration, first, thereafter int) Core

    NewSampler creates a Core that samples incoming entries, which caps the CPU and I/O load of logging while attempting to preserve a representative subset of your logs.

    Zap samples by logging the first N entries with a given level and message each tick. If more Entries with the same level and message are seen during the same interval, every Mth message is logged and the rest are dropped.

    Keep in mind that zap's sampling implementation is optimized for speed over absolute precision; under load, each tick may be slightly over- or under-sampled.

    Deprecated: use NewSamplerWithOptions.

    func NewSamplerWithOptions(core Core, tick time.Duration, first, thereafter int, opts ...SamplerOption) Core

    NewSamplerWithOptions creates a Core that samples incoming entries, which caps the CPU and I/O load of logging while attempting to preserve a representative subset of your logs.

    Zap samples by logging the first N entries with a given level and message each tick. If more Entries with the same level and message are seen during the same interval, every Mth message is logged and the rest are dropped.

    For example,

    core = NewSamplerWithOptions(core, time.Second, 10, 5)
    

    This will log the first 10 log entries with the same level and message in a one second interval as-is. Following that, it will allow through every 5th log entry with the same level and message in that interval.

    If thereafter is zero, the Core will drop all log entries after the first N in that interval.

    Sampler can be configured to report sampling decisions with the SamplerHook option.

    Keep in mind that Zap's sampling implementation is optimized for speed over absolute precision; under load, each tick may be slightly over- or under-sampled.

    func NewTee(cores ...Core) Core

    NewTee creates a Core that duplicates log entries into two or more underlying Cores.

    Calling it with a single Core returns the input unchanged, and calling it with no input returns a no-op Core.

    func RegisterHooks(core Core, hooks ...func(Entry) error) Core

    RegisterHooks wraps a Core and runs a collection of user-defined callback hooks each time a message is logged. Execution of the callbacks is blocking.

    This offers users an easy way to register simple callbacks (e.g., metrics collection) without implementing the full Core interface.

    type DurationEncoder func(time.Duration, PrimitiveArrayEncoder)

    A DurationEncoder serializes a time.Duration to a primitive type.

    This function must make exactly one call to a PrimitiveArrayEncoder's Append* method.

    func (e *DurationEncoder) UnmarshalText(text []byte) error

    UnmarshalText unmarshals text to a DurationEncoder. "string" is unmarshaled to StringDurationEncoder, and anything else is unmarshaled to NanosDurationEncoder. ObjectEncoder // Clone copies the encoder, ensuring that adding fields to the copy doesn't // affect the original. Clone() Encoder // EncodeEntry encodes an entry and fields, along with any accumulated // context, into a byte buffer and returns it. Any fields that are empty, // including fields on the `Entry` type, should be omitted. EncodeEntry(Entry, []Field) (*buffer.Buffer, error)

    Encoder is a format-agnostic interface for all log entry marshalers. Since log encoders don't need to support the same wide range of use cases as general-purpose marshalers, it's possible to make them faster and lower-allocation.

    Implementations of the ObjectEncoder interface's methods can, of course, freely modify the receiver. However, the Clone and EncodeEntry methods will be called concurrently and shouldn't modify the receiver.

    func NewConsoleEncoder(cfg EncoderConfig) Encoder

    NewConsoleEncoder creates an encoder whose output is designed for human - rather than machine - consumption. It serializes the core log entry data (message, level, timestamp, etc.) in a plain-text format and leaves the structured context as JSON.

    Note that although the console encoder doesn't use the keys specified in the encoder configuration, it will omit any element whose key is set to the empty string.

    func NewJSONEncoder(cfg EncoderConfig) Encoder

    NewJSONEncoder creates a fast, low-allocation JSON encoder. The encoder appropriately escapes all field keys and values.

    Note that the encoder doesn't deduplicate keys, so it's possible to produce a message like

    {"foo":"bar","foo":"baz"}
    

    This is permitted by the JSON specification, but not encouraged. Many libraries will ignore duplicate key-value pairs (typically keeping the last pair) when unmarshaling, but users should attempt to avoid adding duplicate keys.

    type EncoderConfig struct {
    	// Set the keys used for each log entry. If any key is empty, that portion
    	// of the entry is omitted.
    	MessageKey     string `json:"messageKey" yaml:"messageKey"`
    	LevelKey       string `json:"levelKey" yaml:"levelKey"`
    	TimeKey        string `json:"timeKey" yaml:"timeKey"`
    	NameKey        string `json:"nameKey" yaml:"nameKey"`
    	CallerKey      string `json:"callerKey" yaml:"callerKey"`
    	FunctionKey    string `json:"functionKey" yaml:"functionKey"`
    	StacktraceKey  string `json:"stacktraceKey" yaml:"stacktraceKey"`
    	SkipLineEnding bool   `json:"skipLineEnding" yaml:"skipLineEnding"`
    	LineEnding     string `json:"lineEnding" yaml:"lineEnding"`
    	// Configure the primitive representations of common complex types. For
    	// example, some users may want all time.Times serialized as floating-point
    	// seconds since epoch, while others may prefer ISO8601 strings.
    	EncodeLevel    LevelEncoder    `json:"levelEncoder" yaml:"levelEncoder"`
    	EncodeTime     TimeEncoder     `json:"timeEncoder" yaml:"timeEncoder"`
    	EncodeDuration DurationEncoder `json:"durationEncoder" yaml:"durationEncoder"`
    	EncodeCaller   CallerEncoder   `json:"callerEncoder" yaml:"callerEncoder"`
    	// Unlike the other primitive type encoders, EncodeName is optional. The
    	// zero value falls back to FullNameEncoder.
    	EncodeName NameEncoder `json:"nameEncoder" yaml:"nameEncoder"`
    	// Configure the encoder for interface{} type objects.
    	// If not provided, objects are encoded using json.Encoder
    	NewReflectedEncoder func(io.Writer) ReflectedEncoder `json:"-" yaml:"-"`
    	// Configures the field separator used by the console encoder. Defaults
    	// to tab.
    	ConsoleSeparator string `json:"consoleSeparator" yaml:"consoleSeparator"`
      

    An EncoderConfig allows users to configure the concrete encoders supplied by zapcore.

    An Entry represents a complete log message. The entry's structured context is already serialized, but the log level, time, message, and call site information are available for inspection and modification. Any fields left empty will be omitted when encoding.

    Entries are pooled, so any functions that accept them MUST be careful not to retain references to them.

    func NewEntryCaller(pc uintptr, file string, line int, ok bool) EntryCaller

    NewEntryCaller makes an EntryCaller from the return signature of runtime.Caller.

    func (ec EntryCaller) FullPath() string

    FullPath returns a /full/path/to/package/file:line description of the caller.

    func (ec EntryCaller) TrimmedPath() string

    TrimmedPath returns a package/file:line description of the caller, preserving only the leaf directory name and file name.

    A Field is a marshaling operation used to add a key-value pair to a logger's context. Most fields are lazily marshaled, so it's inexpensive to add fields to disabled debug-level log statements.

    func (f Field) AddTo(enc ObjectEncoder)

    AddTo exports a field through the ObjectEncoder interface. It's primarily useful to library authors, and shouldn't be necessary in most applications.

    func (f Field) Equals(other Field) bool

    Equals returns whether two fields are equal. For non-primitive types such as errors, marshalers, or reflect types, it uses reflect.DeepEqual.

    type FieldType uint8

    A FieldType indicates which member of the Field union struct should be used and how it should be serialized.

    const (
    	// UnknownType is the default field type. Attempting to add it to an encoder will panic.
    	UnknownType FieldType = iota
    	// ArrayMarshalerType indicates that the field carries an ArrayMarshaler.
    	ArrayMarshalerType
    	// ObjectMarshalerType indicates that the field carries an ObjectMarshaler.
    	ObjectMarshalerType
    	// BinaryType indicates that the field carries an opaque binary blob.
    	BinaryType
    	// BoolType indicates that the field carries a bool.
    	BoolType
    	// ByteStringType indicates that the field carries UTF-8 encoded bytes.
    	ByteStringType
    	// Complex128Type indicates that the field carries a complex128.
    	Complex128Type
    	// Complex64Type indicates that the field carries a complex64.
    	Complex64Type
    	// DurationType indicates that the field carries a time.Duration.
    	DurationType
    	// Float64Type indicates that the field carries a float64.
    	Float64Type
    	// Float32Type indicates that the field carries a float32.
    	Float32Type
    	// Int64Type indicates that the field carries an int64.
    	Int64Type
    	// Int32Type indicates that the field carries an int32.
    	Int32Type
    	// Int16Type indicates that the field carries an int16.
    	Int16Type
    	// Int8Type indicates that the field carries an int8.
    	Int8Type
    	// StringType indicates that the field carries a string.
    	StringType
    	// TimeType indicates that the field carries a time.Time that is
    	// representable by a UnixNano() stored as an int64.
    	TimeType
    	// TimeFullType indicates that the field carries a time.Time stored as-is.
    	TimeFullType
    	// Uint64Type indicates that the field carries a uint64.
    	Uint64Type
    	// Uint32Type indicates that the field carries a uint32.
    	Uint32Type
    	// Uint16Type indicates that the field carries a uint16.
    	Uint16Type
    	// Uint8Type indicates that the field carries a uint8.
    	Uint8Type
    	// UintptrType indicates that the field carries a uintptr.
    	UintptrType
    	// ReflectType indicates that the field carries an interface{}, which should
    	// be serialized using reflection.
    	ReflectType
    	// NamespaceType signals the beginning of an isolated namespace. All
    	// subsequent fields should be added to the new namespace.
    	NamespaceType
    	// StringerType indicates that the field carries a fmt.Stringer.
    	StringerType
    	// ErrorType indicates that the field carries an error.
    	ErrorType
    	// SkipType indicates that the field is a no-op.
    	SkipType
    	// InlineMarshalerType indicates that the field carries an ObjectMarshaler
    	// that should be inlined.
    	InlineMarshalerType
          
    const (
    	// DebugLevel logs are typically voluminous, and are usually disabled in
    	// production.
    	DebugLevel Level = iota - 1
    	// InfoLevel is the default logging priority.
    	InfoLevel
    	// WarnLevel logs are more important than Info, but don't need individual
    	// human review.
    	WarnLevel
    	// ErrorLevel logs are high-priority. If an application is running smoothly,
    	// it shouldn't generate any error-level logs.
    	ErrorLevel
    	// DPanicLevel logs are particularly important errors. In development the
    	// logger panics after writing the message.
    	DPanicLevel
    	// PanicLevel logs a message, then panics.
    	PanicLevel
    	// FatalLevel logs a message, then calls os.Exit(1).
    	FatalLevel
    	// InvalidLevel is an invalid value for Level.
    	// Core implementations may panic if they see messages of this level.
    	InvalidLevel = _maxLevel + 1
          
    func LevelOf(enab LevelEnabler) Level

    LevelOf reports the minimum enabled log level for the given LevelEnabler from Zap's supported log levels, or InvalidLevel if none of them are enabled.

    A LevelEnabler may implement a 'Level() Level' method to override the behavior of this function.

    func (c *core) Level() Level {
    	return c.currentLevel
    

    It is recommended that Core implementations that wrap other cores use LevelOf to retrieve the level of the wrapped core. For example,

    func (c *coreWrapper) Level() Level {
    	return zapcore.LevelOf(c.wrappedCore)
          
    func ParseLevel(text string) (Level, error)

    ParseLevel parses a level based on the lower-case or all-caps ASCII representation of the log level. If the provided ASCII representation is invalid an error is returned.

    This is particularly useful when dealing with text input to configure log levels.

    func (l Level) MarshalText() ([]byte, error)

    MarshalText marshals the Level to text. Note that the text representation drops the -Level suffix (see example).

    func (l *Level) UnmarshalText(text []byte) error

    UnmarshalText unmarshals text to a level. Like MarshalText, UnmarshalText expects the text representation of a Level to drop the -Level suffix (see example).

    In particular, this makes it easy to configure logging levels using YAML, TOML, or JSON files.

    LevelEnabler decides whether a given logging level is enabled when logging a message.

    Enablers are intended to be used to implement deterministic filters; concerns like sampling are better implemented as a Core.

    Each concrete Level value implements a static LevelEnabler which returns true for itself and all higher logging levels. For example WarnLevel.Enabled() will return true for WarnLevel, ErrorLevel, DPanicLevel, PanicLevel, and FatalLevel, but return false for InfoLevel and DebugLevel.

    type LevelEncoder func(Level, PrimitiveArrayEncoder)

    A LevelEncoder serializes a Level to a primitive type.

    This function must make exactly one call to a PrimitiveArrayEncoder's Append* method.

    func (e *LevelEncoder) UnmarshalText(text []byte) error

    UnmarshalText unmarshals text to a LevelEncoder. "capital" is unmarshaled to CapitalLevelEncoder, "coloredCapital" is unmarshaled to CapitalColorLevelEncoder, "colored" is unmarshaled to LowercaseColorLevelEncoder, and anything else is unmarshaled to LowercaseLevelEncoder.

    type MapObjectEncoder struct {
    	// Fields contains the entire encoded log context.
    	Fields map[string]interface{}
    	// contains filtered or unexported fields
      

    MapObjectEncoder is an ObjectEncoder backed by a simple map[string]interface{}. It's not fast enough for production use, but it's helpful in tests.

    type NameEncoder func(string, PrimitiveArrayEncoder)

    A NameEncoder serializes a period-separated logger name to a primitive type.

    This function must make exactly one call to a PrimitiveArrayEncoder's Append* method.

    func (e *NameEncoder) UnmarshalText(text []byte) error

    UnmarshalText unmarshals text to a NameEncoder. Currently, everything is unmarshaled to FullNameEncoder.

    type ObjectEncoder interface {
    	// Logging-specific marshalers.
    	AddArray(key string, marshaler ArrayMarshaler) error
    	AddObject(key string, marshaler ObjectMarshaler) error
    	// Built-in types.
    	AddBinary(key string, value []byte)     // for arbitrary bytes
    	AddByteString(key string, value []byte) // for UTF-8 encoded bytes
    	AddBool(key string, value bool)
    	AddComplex128(key string, value complex128)
    	AddComplex64(key string, value complex64)
    	AddDuration(key string, value time.Duration)
    	AddFloat64(key string, value float64)
    	AddFloat32(key string, value float32)
    	AddInt(key string, value int)
    	AddInt64(key string, value int64)
    	AddInt32(key string, value int32)
    	AddInt16(key string, value int16)
    	AddInt8(key string, value int8)
    	AddString(key, value string)
    	AddTime(key string, value time.Time)
    	AddUint(key string, value uint)
    	AddUint64(key string, value uint64)
    	AddUint32(key string, value uint32)
    	AddUint16(key string, value uint16)
    	AddUint8(key string, value uint8)
    	AddUintptr(key string, value uintptr)
    	// AddReflected uses reflection to serialize arbitrary objects, so it can be
    	// slow and allocation-heavy.
    	AddReflected(key string, value interface{}) error
    	// OpenNamespace opens an isolated namespace where all subsequent fields will
    	// be added. Applications can use namespaces to prevent key collisions when
    	// injecting loggers into sub-components or third-party libraries.
    	OpenNamespace(key string)
      

    ObjectEncoder is a strongly-typed, encoding-agnostic interface for adding a map- or struct-like object to the logging context. Like maps, ObjectEncoders aren't safe for concurrent use (though typical use shouldn't require locks).

    ObjectMarshaler allows user-defined types to efficiently add themselves to the logging context, and to selectively omit information which shouldn't be included in logs (e.g., passwords).

    Note: ObjectMarshaler is only used when zap.Object is used or when passed directly to zap.Any. It is not used when reflection-based encoding is used.

    type ObjectMarshalerFunc func(ObjectEncoder) error

    ObjectMarshalerFunc is a type adapter that turns a function into an ObjectMarshaler. // Built-in types. AppendBool(bool) AppendByteString([]byte) // for UTF-8 encoded bytes AppendComplex128(complex128) AppendComplex64(complex64) AppendFloat64(float64) AppendFloat32(float32) AppendInt(int) AppendInt64(int64) AppendInt32(int32) AppendInt16(int16) AppendInt8(int8) AppendString(string) AppendUint(uint) AppendUint64(uint64) AppendUint32(uint32) AppendUint16(uint16) AppendUint8(uint8) AppendUintptr(uintptr)

    PrimitiveArrayEncoder is the subset of the ArrayEncoder interface that deals only in Go's built-in types. It's included only so that Duration- and TimeEncoders cannot trigger infinite recursion.

    type ReflectedEncoder interface {
    	// Encode encodes and writes to the underlying data stream.
    	Encode(interface{}) error
      

    ReflectedEncoder serializes log fields that can't be serialized with Zap's JSON encoder. These have the ReflectType field type. Use EncoderConfig.NewReflectedEncoder to set this.

    func SamplerHook(hook func(entry Entry, dec SamplingDecision)) SamplerOption

    SamplerHook registers a function which will be called when Sampler makes a decision.

    This hook may be used to get visibility into the performance of the sampler. For example, use it to track metrics of dropped versus sampled logs.

    var dropped atomic.Int64
    zapcore.SamplerHook(func(ent zapcore.Entry, dec zapcore.SamplingDecision) {
      if dec&zapcore.LogDropped > 0 {
        dropped.Inc()
          
    type SamplingDecision uint32

    SamplingDecision is a decision represented as a bit field made by sampler. More decisions may be added in the future.

    const (
    	// LogDropped indicates that the Sampler dropped a log entry.
    	LogDropped SamplingDecision = 1 << iota
    	// LogSampled indicates that the Sampler sampled a log entry.
    	LogSampled
          
    type TimeEncoder func(time.Time, PrimitiveArrayEncoder)

    A TimeEncoder serializes a time.Time to a primitive type.

    This function must make exactly one call to a PrimitiveArrayEncoder's Append* method.

    func TimeEncoderOfLayout(layout string) TimeEncoder

    TimeEncoderOfLayout returns TimeEncoder which serializes a time.Time using given layout.

    func (e *TimeEncoder) UnmarshalText(text []byte) error

    UnmarshalText unmarshals text to a TimeEncoder. "rfc3339nano" and "RFC3339Nano" are unmarshaled to RFC3339NanoTimeEncoder. "rfc3339" and "RFC3339" are unmarshaled to RFC3339TimeEncoder. "iso8601" and "ISO8601" are unmarshaled to ISO8601TimeEncoder. "millis" is unmarshaled to EpochMillisTimeEncoder. "nanos" is unmarshaled to EpochNanosEncoder. Anything else is unmarshaled to EpochTimeEncoder.

    func (e *TimeEncoder) UnmarshalYAML(unmarshal func(interface{}) error) error

    UnmarshalYAML unmarshals YAML to a TimeEncoder. If value is an object with a "layout" field, it will be unmarshaled to TimeEncoder with given layout.

    timeEncoder:
      layout: 06/01/02 03:04pm
    

    If value is string, it uses UnmarshalText.

    timeEncoder: iso8601
          
    func AddSync(w io.Writer) WriteSyncer

    AddSync converts an io.Writer to a WriteSyncer. It attempts to be intelligent: if the concrete type of the io.Writer implements WriteSyncer, we'll use the existing Sync method. If it doesn't, we'll add a no-op Sync.

    func Lock(ws WriteSyncer) WriteSyncer

    Lock wraps a WriteSyncer in a mutex to make it safe for concurrent use. In particular, *os.Files must be locked before use.

    func NewMultiWriteSyncer(ws ...WriteSyncer) WriteSyncer

    NewMultiWriteSyncer creates a WriteSyncer that duplicates its writes and sync calls, much like io.MultiWriter.

    go.dev uses cookies from Google to deliver and enhance the quality of its services and to analyze traffic. Learn more.