pkg/ directory

Directories

PathSynopsis
pkg/abiPackage abi describes the interface between a kernel and userspace.
pkg/abi/attestationPackage attestation includes definitions needed for gVisor attestation.
pkg/abi/gasketPackage gasket describes the userspace interface for Gasket devices.
pkg/abi/linuxPackage linux contains the constants and types needed to interface with a Linux kernel.
pkg/abi/linux/errnoPackage errno holds errno codes for abi/linux.
pkg/abi/nvgpuPackage nvgpu tracks the ABI of the Nvidia GPU Linux kernel driver: https://github.com/NVIDIA/open-gpu-kernel-modules
pkg/abi/sentryPackage sentry contains ABI-related constants for the gVisor sentry.
pkg/abi/tpuPackage tpu defines constants used to interact with TPUs.
pkg/aioPackage aio provides asynchronous I/O on host file descriptors.
pkg/atomicbitopsPackage atomicbitops provides extensions to the sync/atomic package.
pkg/binaryPackage binary translates between select fixed-sized types and a binary representation.
pkg/bitmapPackage bitmap provides the implementation of bitmap.
pkg/bitsPackage bits includes all bit related types and operations.
pkg/bpfPackage bpf provides tools for working with Berkeley Packet Filter (BPF) programs.
pkg/bufferPackage buffer provides the implementation of a non-contiguous buffer that is reference counted, pooled, and copy-on-write.
pkg/cleanupPackage cleanup provides utilities to clean "stuff" on defers.
pkg/compressioPackage compressio provides parallel compression and decompression, as well as optional SHA-256 hashing.
pkg/contextPackage context defines an internal context type.
pkg/control
pkg/control/clientPackage client provides a basic control client interface.
pkg/control/serverPackage server provides a basic control server interface.
pkg/coretagPackage coretag implements core tagging.
pkg/coveragePackage coverage provides an interface through which Go coverage data can be collected, converted to kcov format, and exposed to userspace.
pkg/cpuidPackage cpuid provides basic functionality for creating and adjusting CPU feature sets.
pkg/cryptoPackage crypto wraps crypto primitives.
pkg/devutilPackage devutil provides device specific utilities.
pkg/erofsPackage erofs provides the ability to access the contents in an EROFS [1] image.
pkg/errorsPackage errors holds the standardized error definition for gVisor.
pkg/errors/linuxerrPackage linuxerr contains syscall error codes exported as an error interface pointers.
pkg/eventchannelPackage eventchannel contains functionality for sending any protobuf message on a socketpair.
pkg/eventfdPackage eventfd wraps Linux's eventfd(2) syscall.
pkg/fdPackage fd provides types for working with file descriptors.
pkg/fdchannelPackage fdchannel implements passing file descriptors between processes over Unix domain sockets.
pkg/fdnotifierPackage fdnotifier contains an adapter that translates IO events (e.g., a file became readable/writable) from native FDs to the notifications in the waiter package.
pkg/flipcallPackage flipcall implements a protocol providing Fast Local Interprocess Procedure Calls between mutually-distrusting processes.
pkg/fspathPackage fspath provides efficient tools for working with file paths in Linux-compatible filesystem implementations.
pkg/fsutilPackage fsutil contains filesystem utilities that can be shared between the sentry and other sandbox components.
pkg/gohacksPackage gohacks contains utilities for subverting the Go compiler.
pkg/goidPackage goid provides the Get function.
pkg/gomaxprocsPackage gomaxprocs synchronizes adjustments to GOMAXPROCS.
pkg/gvisordetectPackage gvisordetect implements a library that callers may use to detect whether they are running on a gVisor kernel, assuming it is configured to expose the gVisor marker file.
pkg/hostarchPackage hostarch contains host arch address operations for user memory.
pkg/hostosPackage hostos contains utility functions for getting information about the host OS.
pkg/hostsyscallPackage hostsyscall provides functions like unix.RawSyscall, but without the overhead of multiple stack frame allocations.
pkg/hosttidPackage hosttid provides the Current function.
pkg/ilistPackage ilist provides the implementation of intrusive linked lists.
pkg/linewriterPackage linewriter provides an io.Writer which calls an emitter on each line.
pkg/lisafsPackage lisafs (LInux SAndbox FileSystem) defines the protocol for filesystem RPCs between an untrusted Sandbox (client) and a trusted filesystem server.
pkg/lisafs/testsuitePackage testsuite provides a integration testing suite for lisafs.
pkg/logPackage log implements a library for logging.
pkg/marshalPackage marshal defines the Marshallable interface for serialize/deserializing go data structures to/from memory, according to the Linux ABI.
pkg/marshal/primitivePackage primitive defines marshal.Marshallable implementations for primitive types.
pkg/memutilPackage memutil provides utilities for working with shared memory files.
pkg/metricPackage metric provides primitives for collecting metrics.
pkg/metric/buckettoolbuckettool prints buckets for distribution metrics.
pkg/p9Package p9 is a 9P2000.L implementation.
pkg/p9/p9testPackage p9test provides standard mocks for p9.
pkg/poolPackage pool provides a trivial integer pool.
pkg/prometheusPackage prometheus contains Prometheus-compliant metric data structures and utilities in pure Go.
pkg/randPackage rand implements a cryptographically secure pseudorandom number generator.
pkg/rawfilePackage rawfile contains utilities for using raw host files on Linux hosts.
pkg/refsPackage refs defines an interface for reference counted objects.
pkg/ring0Package ring0 provides basic operating system-level stubs.
pkg/ring0/pagetablesPackage pagetables provides a generic implementation of pagetables.
pkg/ringdequePackage ringdeque provides the Deque type.
pkg/safecopyPackage safecopy provides an efficient implementation of functions to access memory that may result in SIGSEGV or SIGBUS being sent to the accessor.
pkg/safememPackage safemem provides the Block and BlockSeq types.
pkg/seccompPackage seccomp provides generation of basic seccomp filters.
pkg/seccomp/precompiledseccompprecompile_gen generates a Go library that contains precompiled seccomp programs.
pkg/seccomp/precompiledseccomp/examplePackage example defines two seccomp programs ("example_program1" and "example_program2") to be embedded in the `usage` package in this directory.
pkg/seccomp/precompiledseccomp/example/usagePackage usage shows how to use precompiled seccomp-bpf programs.
pkg/seccomp/victimTest binary used to test that seccomp filters are properly constructed and indeed kill the process on violation.
pkg/secioPackage secio provides support for sectioned I/O.
pkg/segmentPackage segment provides tools for working with collections of segments.
pkg/segment/testPackage segment is a test package.
pkg/sentry
pkg/sentry/archPackage arch provides abstractions around architecture-dependent details, such as syscall calling conventions, native types, etc.
pkg/sentry/arch/fpuPackage fpu provides basic floating point helpers.
pkg/sentry/contexttestPackage contexttest builds a test context.Context.
pkg/sentry/controlPackage control contains types that expose control server methods, and can be used to configure and interact with a running sandbox process.
pkg/sentry/devices
pkg/sentry/devices/memdevPackage memdev implements "mem" character devices, as implemented in Linux by drivers/char/mem.c and drivers/char/random.c.
pkg/sentry/devices/nvproxyPackage nvproxy implements proxying for the Nvidia GPU Linux kernel driver: https://github.com/NVIDIA/open-gpu-kernel-modules.
pkg/sentry/devices/nvproxy/nvconfPackage nvconf provides configuration structures and utilities for nvproxy.
pkg/sentry/devices/tpuproxyPackage tpuproxy contains tpu backend driver proxy implementations and helper functions.
pkg/sentry/devices/tpuproxy/accelPackage accel implements a proxy for gasket based accel devices.
pkg/sentry/devices/tpuproxy/utilPackage util contains helper functions for tpuproxy implementations.
pkg/sentry/devices/tpuproxy/vfioPackage vfio implements a proxy for VFIO devices.
pkg/sentry/devices/ttydevPackage ttydev implements a vfs.Device for /dev/tty.
pkg/sentry/devices/tundevPackage tundev implements the /dev/net/tun device.
pkg/sentry/fdcollectorPackage fdcollector provides a goroutine that reads from a vfs.FileDescription (which may block) into a bytes.Buffer.
pkg/sentry/fdimportPackage fdimport provides the Import function.
pkg/sentry/fsimpl
pkg/sentry/fsimpl/cgroupfsPackage cgroupfs implements cgroupfs.
pkg/sentry/fsimpl/devPackage dev provides a filesystem implementation for /dev.
pkg/sentry/fsimpl/devptsPackage devpts provides a filesystem implementation that behaves like devpts.
pkg/sentry/fsimpl/devtmpfsPackage devtmpfs provides a singleton fsimpl/dev filesystem instance, analogous to Linux's devtmpfs.
pkg/sentry/fsimpl/erofsPackage erofs implements erofs.
pkg/sentry/fsimpl/eventfdPackage eventfd implements event fds.
pkg/sentry/fsimpl/fusePackage fuse implements fusefs.
pkg/sentry/fsimpl/goferPackage gofer provides a filesystem implementation that is backed by a 9p server, interchangeably referred to as "gofers" throughout this package.
pkg/sentry/fsimpl/hostPackage host provides a filesystem implementation for host files imported as file descriptors.
pkg/sentry/fsimpl/iouringfsPackage iouringfs provides a filesystem implementation for IO_URING basing it on anonfs.
pkg/sentry/fsimpl/kernfsPackage kernfs provides the tools to implement inode-based filesystems.
pkg/sentry/fsimpl/lockPackage lock is the API for POSIX-style advisory regional file locks and BSD-style full file locks.
pkg/sentry/fsimpl/mqfsPackage mqfs provides a filesystem implementation to back POSIX message queues.
pkg/sentry/fsimpl/nsfsPackage nsfs provides the filesystem implementation backing Kernel.NsfsMount.
pkg/sentry/fsimpl/overlayPackage overlay provides an overlay filesystem implementation, which synthesizes a filesystem by composing one or more immutable filesystems ("lower layers") with an optional mutable filesystem ("upper layer").
pkg/sentry/fsimpl/pipefsPackage pipefs provides the filesystem implementation backing Kernel.PipeMount.
pkg/sentry/fsimpl/procPackage proc implements a partial in-memory file system for procfs.
pkg/sentry/fsimpl/signalfdPackage signalfd provides basic signalfd file implementations.
pkg/sentry/fsimpl/sockfsPackage sockfs provides a filesystem implementation for anonymous sockets.
pkg/sentry/fsimpl/sysPackage sys implements sysfs.
pkg/sentry/fsimpl/testutilPackage testutil provides common test utilities for kernfs-based filesystems.
pkg/sentry/fsimpl/timerfdPackage timerfd implements timer fds.
pkg/sentry/fsimpl/tmpfsPackage tmpfs provides an in-memory filesystem whose contents are application-mutable, consistent with Linux's tmpfs.
pkg/sentry/fsimpl/userPackage user contains methods for resolving filesystem paths based on the user and their environment.
pkg/sentry/fsmetricPackage fsmetric defines filesystem metrics.
pkg/sentry/fsutilPackage fsutil provides utilities for implementing vfs.FileDescriptionImpl and vfs.FilesystemImpl.
pkg/sentry/hostcpuPackage hostcpu provides utilities for working with CPU information provided by a host Linux kernel.
pkg/sentry/hostfdPackage hostfd provides efficient I/O with host file descriptors.
pkg/sentry/hostmmPackage hostmm provides tools for interacting with the host Linux kernel's virtual memory management subsystem.
pkg/sentry/inetPackage inet defines semantics for IP stacks.
pkg/sentry/kernelPackage kernel provides an emulation of the Linux kernel.
pkg/sentry/kernel/authPackage auth implements an access control model that is a subset of Linux's.
pkg/sentry/kernel/contexttestPackage contexttest provides a test context.Context which includes a dummy kernel pointing to a valid platform.
pkg/sentry/kernel/fasyncPackage fasync provides FIOASYNC related functionality.
pkg/sentry/kernel/futexPackage futex provides an implementation of the futex interface as found in the Linux kernel.
pkg/sentry/kernel/ipcPackage ipc defines functionality and utilities common to sysvipc mechanisms.
pkg/sentry/kernel/memeventPackage memevent implements the memory usage events controller, which periodically emits events via the eventchannel.
pkg/sentry/kernel/mqPackage mq provides an implementation for POSIX message queues.
pkg/sentry/kernel/msgqueuePackage msgqueue implements System V message queues.
pkg/sentry/kernel/pipePackage pipe provides a pipe implementation.
pkg/sentry/kernel/schedPackage sched implements scheduler related features.
pkg/sentry/kernel/semaphorePackage semaphore implements System V semaphores.
pkg/sentry/kernel/shmPackage shm implements sysv shared memory segments.
pkg/sentry/ktimePackage ktime provides an API for clocks and timers implemented by the sentry.
pkg/sentry/limitsPackage limits provides resource limits.
pkg/sentry/loaderPackage loader loads an executable file into a MemoryManager.
pkg/sentry/loader/vdsodataPackage vdsodata contains a compiled VDSO object.
pkg/sentry/memmapPackage memmap defines semantics for memory mappings.
pkg/sentry/mmPackage mm provides a memory management subsystem.
pkg/sentry/pgallocPackage pgalloc contains the page allocator subsystem, which provides allocatable memory that may be mapped into application address spaces.
pkg/sentry/platformPackage platform provides a Platform abstraction.
pkg/sentry/platform/interruptPackage interrupt provides an interrupt helper.
pkg/sentry/platform/kvmPackage kvm provides a kvm-based implementation of the platform interface.
pkg/sentry/platform/kvm/testutilPackage testutil provides common assembly stubs for testing.
pkg/sentry/platform/platformsPackage platforms imports all available platform packages.
pkg/sentry/platform/ptracePackage ptrace provides a ptrace-based implementation of the platform interface.
pkg/sentry/platform/systrapPackage systrap provides a seccomp-based implementation of the platform interface.
pkg/sentry/platform/systrap/sysmsgPackage sysmsg provides a stub signal handler and a communication protocol between stub threads and the Sentry.
pkg/sentry/platform/systrap/usertrapPackage usertrap implements the library to replace syscall instructions with function calls.
pkg/sentry/seccheckPackage seccheck defines a structure for dynamically-configured security checks in the sentry.
pkg/sentry/seccheck/sinks
pkg/sentry/seccheck/sinks/nullPackage null defines a seccheck.Sink that does nothing with the trace points, akin to /dev/null.
pkg/sentry/seccheck/sinks/remotePackage remote defines a seccheck.Sink that serializes points to a remote process.
pkg/sentry/seccheck/sinks/remote/serverPackage server provides a common server implementation that can connect with remote.Remote.
pkg/sentry/seccheck/sinks/remote/testPackage test provides functionality used to test the remote sink.
pkg/sentry/seccheck/sinks/remote/wirePackage wire defines structs used in the wire format for the remote checker.
pkg/sentry/socketPackage socket provides the interfaces that need to be provided by socket implementations and providers, as well as per family demultiplexing of socket creation.
pkg/sentry/socket/controlPackage control provides internal representations of socket control messages.
pkg/sentry/socket/hostinetPackage hostinet implements AF_INET and AF_INET6 sockets using the host's network stack.
pkg/sentry/socket/netfilterPackage netfilter helps the sentry interact with netstack's netfilter capabilities.
pkg/sentry/socket/netlinkPackage netlink provides core functionality for netlink sockets.
pkg/sentry/socket/netlink/nlmsgPackage nlmsg provides helpers to parse and construct netlink messages.
pkg/sentry/socket/netlink/portPackage port provides port ID allocation for netlink sockets.
pkg/sentry/socket/netlink/routePackage route provides a NETLINK_ROUTE socket protocol.
pkg/sentry/socket/netlink/ueventPackage uevent provides a NETLINK_KOBJECT_UEVENT socket protocol.
pkg/sentry/socket/netstackPackage netstack provides an implementation of the socket.Socket interface that is backed by a tcpip.Endpoint.
pkg/sentry/socket/netstack/packetmmapPackage packetmmap contains the packet mmap implementation for netstack.
pkg/sentry/socket/pluginPackage plugin provides a set of interfaces to interact with third-party netstack.
pkg/sentry/socket/plugin/cgoPackage cgo provides interfaces definition to interact with third-party network stack.
pkg/sentry/socket/plugin/stackPackage stack provides an implementation of plugin.PluginStack interface and an implementation of socket.Socket interface.
pkg/sentry/socket/unixPackage unix provides an implementation of the socket.Socket interface for the AF_UNIX protocol family.
pkg/sentry/socket/unix/transportPackage transport contains the implementation of Unix endpoints.
pkg/sentry/statePackage state provides high-level state wrappers.
pkg/sentry/stracePackage strace implements the logic to print out the input and the return value of each traced syscall.
pkg/sentry/syscallsPackage syscalls is the interface from the application to the kernel.
pkg/sentry/syscalls/linuxPackage linux provides syscall tables for amd64 and arm64 Linux.
pkg/sentry/timePackage time provides a calibrated clock synchronized to a system reference clock.
pkg/sentry/unimplPackage unimpl contains interface to emit events about unimplemented features.
pkg/sentry/uniqueidPackage uniqueid defines context.Context keys for obtaining system-wide unique identifiers.
pkg/sentry/usagePackage usage provides representations of resource usage.
pkg/sentry/vfsPackage vfs implements a virtual filesystem layer.
pkg/sentry/vfs/genericfstreePackage genericfstree provides tools for implementing vfs.FilesystemImpls that follow a standard pattern for synchronizing Dentry parent and name.
pkg/sentry/vfs/memxattrPackage memxattr provides a default, in-memory extended attribute implementation.
pkg/sentry/watchdogPackage watchdog is responsible for monitoring the sentry for tasks that may potentially be stuck or looping inderterminally causing hard to debug hangs in the untrusted app.
pkg/shim
pkg/shim/v1Package v1 implements Containerd Shim v2 interface.
pkg/shim/v1/extensionPackage extension provides an extension to the shim.
pkg/shim/v1/procPackage proc is responsible to manage the communication between the shim and the sandbox process running the container.
pkg/shim/v1/runscPackage runsc implements Containerd Shim v2 interface.
pkg/shim/v1/runsccmdPackage runsccmd provides an API to interact with runsc command line.
pkg/shim/v1/runtimeoptionsPackage runtimeoptions contains the runtimeoptions proto for containerd 1.5 and above.
pkg/shim/v1/runtimeoptions/v14Package v14 contains the runtimeoptions proto for containerd 1.4 and earlier.
pkg/shim/v1/utilsPackage utils container miscellaneous utility function used by the shim.
pkg/sigframePackage sigframe implements a mechanism to create a signal frame on the stack and execute a user-defined callback function within that context.
pkg/sighandlingPackage sighandling contains helpers for handling signals to applications.
pkg/sleepPackage sleep allows goroutines to efficiently sleep on multiple sources of notifications (wakers).
pkg/statePackage state provides functionality related to saving and loading object graphs.
pkg/state/prettyPackage pretty is a pretty-printer for state streams.
pkg/state/statefilePackage statefile defines the state file data stream.
pkg/state/testsPackage tests tests the state packages.
pkg/state/wirePackage wire contains a few basic types that can be composed to serialize graph information for the state package.
pkg/syncPackage sync provides synchronization primitives.
pkg/sync/atomicptrPackage seqatomic doesn't exist.
pkg/sync/atomicptrmapPackage atomicptrmap instantiates generic_atomicptrmap for testing.
pkg/synceventPackage syncevent provides efficient primitives for goroutine synchronization based on event bitmasks.
pkg/sync/lockingPackage locking implements lock primitives with the correctness validator.
pkg/sync/seqatomicPackage seqatomic doesn't exist.
pkg/syserrPackage syserr contains sandbox-internal errors.
pkg/tcpipPackage tcpip provides the interfaces and related types that users of the tcpip stack will use in order to create endpoints used to send and receive data over the network stack.
pkg/tcpip/adapters
pkg/tcpip/adapters/gonetPackage gonet provides a Go net package compatible wrapper for a tcpip stack.
pkg/tcpip/checkerPackage checker provides helper functions to check networking packets for validity.
pkg/tcpip/checksumPackage checksum provides the implementation of the encoding and decoding of network protocol headers.
pkg/tcpip/faketimePackage faketime provides a fake clock that implements tcpip.Clock interface.
pkg/tcpip/hash
pkg/tcpip/hash/jenkinsPackage jenkins implements Jenkins's one_at_a_time, non-cryptographic hash functions created by by Bob Jenkins.
pkg/tcpip/headerPackage header provides the implementation of the encoding and decoding of network protocol headers.
pkg/tcpip/header/parsePackage parse provides utilities to parse packets.
pkg/tcpip/internal
pkg/tcpip/link
pkg/tcpip/link/channelPackage channel provides the implementation of channel-based data-link layer endpoints.
pkg/tcpip/link/ethernetPackage ethernet provides an implementation of an ethernet link endpoint that wraps an inner link endpoint.
pkg/tcpip/link/fdbasedPackage fdbased provides the implementation of data-link layer endpoints backed by boundary-preserving file descriptors (e.g., TUN devices, seqpacket/datagram sockets).
pkg/tcpip/link/loopbackPackage loopback provides the implementation of loopback data-link layer endpoints.
pkg/tcpip/link/muxedPackage muxed provides a muxed link endpoints.
pkg/tcpip/link/nestedPackage nested provides helpers to implement the pattern of nested stack.LinkEndpoints.
pkg/tcpip/link/packetsocketPackage packetsocket provides a link endpoint that enables delivery of incoming and outgoing packets to any interested packet sockets.
pkg/tcpip/link/pipePackage pipe provides the implementation of pipe-like data-link layer endpoints.
pkg/tcpip/link/qdisc
pkg/tcpip/link/qdisc/fifoPackage fifo provides the implementation of FIFO queuing discipline that queues all outbound packets and asynchronously dispatches them to the lower link endpoint in the order that they were queued.
pkg/tcpip/link/sharedmemPackage sharedmem provides the implementation of data-link layer endpoints backed by shared memory.
pkg/tcpip/link/sharedmem/pipePackage pipe implements a shared memory ring buffer on which a single reader and a single writer can operate (read/write) concurrently.
pkg/tcpip/link/sharedmem/queuePackage queue provides the implementation of transmit and receive queues based on shared memory ring buffers.
pkg/tcpip/link/snifferPackage sniffer provides the implementation of data-link layer endpoints that wrap another endpoint and logs inbound and outbound packets.
pkg/tcpip/link/stopfdPackage stopfd provides an type that can be used to signal the stop of a dispatcher.
pkg/tcpip/link/tunPackage tun contains methods to open TAP and TUN devices.
pkg/tcpip/link/vethPackage veth provides the implementation of virtual ethernet device pair.
pkg/tcpip/link/waitablePackage waitable provides the implementation of data-link layer endpoints that wrap other endpoints, and can wait for inflight calls to WritePacket or DeliverNetworkPacket to finish (and new ones to be prevented).
pkg/tcpip/link/xdpPackage xdp provides link layer endpoints backed by AF_XDP sockets.
pkg/tcpip/network
pkg/tcpip/network/arpPackage arp implements the ARP network protocol.
pkg/tcpip/network/hashPackage hash contains utility functions for hashing.
pkg/tcpip/network/internal
pkg/tcpip/network/ipv4Package ipv4 contains the implementation of the ipv4 network protocol.
pkg/tcpip/network/ipv6Package ipv6 contains the implementation of the ipv6 network protocol.
pkg/tcpip/nftablesPackage nftables provides the interface to process packets through a netfilter (nf) ruleset and maintain/modify the ruleset accordingly.
pkg/tcpip/portsPackage ports provides PortManager that manages allocating, reserving and releasing ports.
pkg/tcpip/prependablePackage prependable defines a buffer that grows backwards.
pkg/tcpip/sample
pkg/tcpip/sample/tun_tcp_connectThis sample creates a stack with TCP and IPv4 protocols on top of a TUN device, and connects to a peer.
pkg/tcpip/sample/tun_tcp_echoThis sample creates a stack with TCP and IPv4 protocols on top of a TUN device, and listens on a port.
pkg/tcpip/seqnumPackage seqnum defines the types and methods for TCP sequence numbers such that they fit in 32-bit words and work properly when overflows occur.
pkg/tcpip/stackPackage stack provides the glue between networking protocols and the consumers of the networking stack.
pkg/tcpip/stack/groPackage gro implements generic receive offload.
pkg/tcpip/tests
pkg/tcpip/tests/integration
pkg/tcpip/tests/utilsPackage utils holds common testing utilities for tcpip.
pkg/tcpip/testutilPackage testutil provides helper functions for netstack unit tests.
pkg/tcpip/transportPackage transport supports transport protocols.
pkg/tcpip/transport/icmpPackage icmp contains the implementation of the ICMP and IPv6-ICMP transport protocols for use in ping.
pkg/tcpip/transport/internal
pkg/tcpip/transport/packetPackage packet provides the implementation of packet sockets (see packet(7)).
pkg/tcpip/transport/rawPackage raw provides the implementation of raw sockets (see raw(7)).
pkg/tcpip/transport/tcpPackage tcp contains the implementation of the TCP transport protocol.
pkg/tcpip/transport/tcpconntrackPackage tcpconntrack implements a TCP connection tracking object.
pkg/tcpip/transport/tcp/test
pkg/tcpip/transport/tcp/test/e2ePackage e2e contains definitions common to all e2e tcp tests.
pkg/tcpip/transport/tcp/testing
pkg/tcpip/transport/tcp/testing/contextPackage context provides a test context for use in tcp tests.
pkg/tcpip/transport/testing
pkg/tcpip/transport/testing/contextPackage context provides a context used by datagram-based network endpoints tests.
pkg/tcpip/transport/udpPackage udp contains the implementation of the UDP transport protocol.
pkg/test
pkg/test/criutilPackage criutil contains utility functions for interacting with the Container Runtime Interface (CRI), principally via the crictl command line tool.
pkg/test/dockerutilPackage dockerutil is a collection of utility functions.
pkg/test/testutilPackage testutil contains utility functions for runsc tests.
pkg/timingPackage timing provides a way to record the timing of a series of operations across one or more goroutines.
pkg/triePackage trie provides a character-based prefix trie data structure for storing arbitrary payloads in an efficiently retrievable manner.
pkg/unetPackage unet provides a minimal net package based on Unix Domain Sockets.
pkg/urpcPackage urpc provides a minimal RPC package based on unet.
pkg/usermemPackage usermem governs access to user memory.
pkg/waiterPackage waiter provides the implementation of a wait queue, where waiters can be enqueued to be notified when an event of interest happens.
pkg/xdpPackage xdp provides tools for working with AF_XDP sockets.
Version
v0.0.0-20250603074042-45108140e4ad (latest)
Published
Jun 3, 2025
Platform
linux/amd64
Last checked
1 day ago

Tools for package owners.