package cm

import "k8s.io/kubernetes/pkg/kubelet/cm"

Package cm (abbreviation of "container manager") and its subpackages contain all the kubelet code to manage containers. For example, they contain functions to configure containers' cgroups, ensure containers run with the desired QoS, and allocate compute resources like cpus, memory, devices...

Index

Constants

const (

	// Cgroup2MemoryMin is memory.min for cgroup v2
	Cgroup2MemoryMin string = "memory.min"
	// Cgroup2MemoryHigh is memory.high for cgroup v2
	Cgroup2MemoryHigh      string = "memory.high"
	Cgroup2MaxCpuLimit     string = "max"
	Cgroup2MaxSwapFilename string = "memory.swap.max"
)
const (
	// Warning message for the users still using cgroup v1
	CgroupV1MaintenanceModeWarning = "cgroup v1 support is in maintenance mode, please migrate to cgroup v2"

	// Warning message for the users using cgroup v2 on kernel doesn't support root `cpu.stat`.
	// `cpu.stat` was added to root cgroup in kernel 5.8.
	// (ref: https://github.com/torvalds/linux/commit/936f2a70f2077f64fab1dcb3eca71879e82ecd3f)
	CgroupV2KernelWarning = "cgroup v2 is being used on a kernel, which doesn't support root `cpu.stat`." +
		"Kubelet will continue, but may experience instability or wrong behavior"
)
const (
	// These limits are defined in the kernel:
	// https://github.com/torvalds/linux/blob/0bddd227f3dc55975e2b8dfa7fc6f959b062a2c7/kernel/sched/sched.h#L427-L428
	MinShares = 2
	MaxShares = 262144

	SharesPerCPU  = 1024
	MilliCPUToCPU = 1000

	// 100000 microseconds is equivalent to 100ms
	QuotaPeriod = 100000
	// 1000 microseconds is equivalent to 1ms
	// defined here:
	// https://github.com/torvalds/linux/blob/cac03ac368fabff0122853de2422d4e17a32de08/kernel/sched/core.c#L10546
	MinQuotaPeriod = 1000

	// From the inverse of the conversion in MilliCPUToQuota:
	// MinQuotaPeriod * MilliCPUToCPU / QuotaPeriod
	MinMilliCPULimit = 10
)

Variables

var RootCgroupName = CgroupName([]string{})

Functions

func GetKubeletContainer

func GetKubeletContainer(kubeletCgroups string) (string, error)

GetKubeletContainer returns the cgroup the kubelet will use

func GetPodCgroupNameSuffix

func GetPodCgroupNameSuffix(podUID types.UID) string

GetPodCgroupNameSuffix returns the last element of the pod CgroupName identifier

func HugePageLimits

func HugePageLimits(resourceList v1.ResourceList) map[int64]int64

HugePageLimits converts the API representation to a map from huge page size (in bytes) to huge page limit (in bytes).

func IsSystemdStyleName

func IsSystemdStyleName(name string) bool

func MilliCPUToQuota

func MilliCPUToQuota(milliCPU int64, period int64) (quota int64)

MilliCPUToQuota converts milliCPU to CFS quota and period values. Input parameters and resulting value is number of microseconds.

func MilliCPUToShares

func MilliCPUToShares(milliCPU int64) uint64

MilliCPUToShares converts the milliCPU to CFS shares.

func NewFakeInternalContainerLifecycle

func NewFakeInternalContainerLifecycle() *fakeInternalContainerLifecycle

func NodeAllocatableRoot

func NodeAllocatableRoot(cgroupRoot string, cgroupsPerQOS bool, cgroupDriver string) string

NodeAllocatableRoot returns the literal cgroup path for the node allocatable cgroup

func ParseQOSReserved

func ParseQOSReserved(m map[string]string) (*map[v1.ResourceName]int64, error)

ParseQOSReserved parses the --qos-reserved option

Types

type ActivePodsFunc

type ActivePodsFunc func() []*v1.Pod

type CgroupConfig

type CgroupConfig struct {
	// Fully qualified name prior to any driver specific conversions.
	Name CgroupName
	// ResourceParameters contains various cgroups settings to apply.
	ResourceParameters *ResourceConfig
}

CgroupConfig holds the cgroup configuration information. This is common object which is used to specify cgroup information to both systemd and raw cgroup fs implementation of the Cgroup Manager interface.

type CgroupManager

type CgroupManager interface {
	// Create creates and applies the cgroup configurations on the cgroup.
	// It just creates the leaf cgroups.
	// It expects the parent cgroup to already exist.
	Create(*CgroupConfig) error
	// Destroy the cgroup.
	Destroy(*CgroupConfig) error
	// Update cgroup configuration.
	Update(*CgroupConfig) error
	// Validate checks if the cgroup is valid
	Validate(name CgroupName) error
	// Exists checks if the cgroup already exists
	Exists(name CgroupName) bool
	// Name returns the literal cgroupfs name on the host after any driver specific conversions.
	// We would expect systemd implementation to make appropriate name conversion.
	// For example, if we pass {"foo", "bar"}
	// then systemd should convert the name to something like
	// foo.slice/foo-bar.slice
	Name(name CgroupName) string
	// CgroupName converts the literal cgroupfs name on the host to an internal identifier.
	CgroupName(name string) CgroupName
	// Pids scans through all subsystems to find pids associated with specified cgroup.
	Pids(name CgroupName) []int
	// ReduceCPULimits reduces the CPU CFS values to the minimum amount of shares.
	ReduceCPULimits(cgroupName CgroupName) error
	// MemoryUsage returns current memory usage of the specified cgroup, as read from the cgroupfs.
	MemoryUsage(name CgroupName) (int64, error)
	// Get the resource config values applied to the cgroup for specified resource type
	GetCgroupConfig(name CgroupName, resource v1.ResourceName) (*ResourceConfig, error)
	// Set resource config for the specified resource type on the cgroup
	SetCgroupConfig(name CgroupName, resourceConfig *ResourceConfig) error
	// Version of the cgroup implementation on the host
	Version() int
}

CgroupManager allows for cgroup management. Supports Cgroup Creation ,Deletion and Updates.

func NewCgroupManager

func NewCgroupManager(cs *CgroupSubsystems, cgroupDriver string) CgroupManager

NewCgroupManager is a factory method that returns a CgroupManager

func NewCgroupV1Manager

func NewCgroupV1Manager(cs *CgroupSubsystems, cgroupDriver string) CgroupManager

func NewCgroupV2Manager

func NewCgroupV2Manager(cs *CgroupSubsystems, cgroupDriver string) CgroupManager

type CgroupName

type CgroupName []string

CgroupName is the abstract name of a cgroup prior to any driver specific conversion. It is specified as a list of strings from its individual components, such as: {"kubepods", "burstable", "pod1234-abcd-5678-efgh"}

func NewCgroupName

func NewCgroupName(base CgroupName, components ...string) CgroupName

NewCgroupName composes a new cgroup name. Use RootCgroupName as base to start at the root. This function does some basic check for invalid characters at the name.

func ParseCgroupfsToCgroupName

func ParseCgroupfsToCgroupName(name string) CgroupName

func ParseSystemdToCgroupName

func ParseSystemdToCgroupName(name string) CgroupName

func (CgroupName) ToCgroupfs

func (cgroupName CgroupName) ToCgroupfs() string

func (CgroupName) ToSystemd

func (cgroupName CgroupName) ToSystemd() string

cgroupName.ToSystemd converts the internal cgroup name to a systemd name. For example, the name {"kubepods", "burstable", "pod1234-abcd-5678-efgh"} becomes "/kubepods.slice/kubepods-burstable.slice/kubepods-burstable-pod1234_abcd_5678_efgh.slice" This function always expands the systemd name into the cgroupfs form. If only the last part is needed, use path.Base(...) on it to discard the rest.

type CgroupSubsystems

type CgroupSubsystems struct {
	// Cgroup subsystem mounts.
	// e.g.: "/sys/fs/cgroup/cpu" -> ["cpu", "cpuacct"]
	Mounts []libcontainercgroups.Mount

	// Cgroup subsystem to their mount location.
	// e.g.: "cpu" -> "/sys/fs/cgroup/cpu"
	MountPoints map[string]string
}

CgroupSubsystems holds information about the mounted cgroup subsystems

func GetCgroupSubsystems

func GetCgroupSubsystems() (*CgroupSubsystems, error)

GetCgroupSubsystems returns information about the mounted cgroup subsystems

type ContainerManager

type ContainerManager interface {
	// Runs the container manager's housekeeping.
	// - Ensures that the Docker daemon is in a container.
	// - Creates the system container where all non-containerized processes run.
	Start(context.Context, *v1.Node, ActivePodsFunc, GetNodeFunc, config.SourcesReady, status.PodStatusProvider, internalapi.RuntimeService, bool) error

	// SystemCgroupsLimit returns resources allocated to system cgroups in the machine.
	// These cgroups include the system and Kubernetes services.
	SystemCgroupsLimit() v1.ResourceList

	// GetNodeConfig returns a NodeConfig that is being used by the container manager.
	GetNodeConfig() NodeConfig

	// Status returns internal Status.
	Status() Status

	// NewPodContainerManager is a factory method which returns a podContainerManager object
	// Returns a noop implementation if qos cgroup hierarchy is not enabled
	NewPodContainerManager() PodContainerManager

	// GetMountedSubsystems returns the mounted cgroup subsystems on the node
	GetMountedSubsystems() *CgroupSubsystems

	// GetQOSContainersInfo returns the names of top level QoS containers
	GetQOSContainersInfo() QOSContainersInfo

	// GetNodeAllocatableReservation returns the amount of compute resources that have to be reserved from scheduling.
	GetNodeAllocatableReservation() v1.ResourceList

	// GetCapacity returns the amount of compute resources tracked by container manager available on the node.
	GetCapacity(localStorageCapacityIsolation bool) v1.ResourceList

	// GetDevicePluginResourceCapacity returns the node capacity (amount of total device plugin resources),
	// node allocatable (amount of total healthy resources reported by device plugin),
	// and inactive device plugin resources previously registered on the node.
	GetDevicePluginResourceCapacity() (v1.ResourceList, v1.ResourceList, []string)

	// UpdateQOSCgroups performs housekeeping updates to ensure that the top
	// level QoS containers have their desired state in a thread-safe way
	UpdateQOSCgroups() error

	// GetResources returns RunContainerOptions with devices, mounts, and env fields populated for
	// extended resources required by container.
	GetResources(ctx context.Context, pod *v1.Pod, container *v1.Container) (*kubecontainer.RunContainerOptions, error)

	// UpdatePluginResources calls Allocate of device plugin handler for potential
	// requests for device plugin resources, and returns an error if fails.
	// Otherwise, it updates allocatableResource in nodeInfo if necessary,
	// to make sure it is at least equal to the pod's requested capacity for
	// any registered device plugin resource
	UpdatePluginResources(*schedulerframework.NodeInfo, *lifecycle.PodAdmitAttributes) error

	InternalContainerLifecycle() InternalContainerLifecycle

	// GetPodCgroupRoot returns the cgroup which contains all pods.
	GetPodCgroupRoot() string

	// GetPluginRegistrationHandlers returns a set of plugin registration handlers
	// The pluginwatcher's Handlers allow to have a single module for handling
	// registration.
	GetPluginRegistrationHandlers() map[string]cache.PluginHandler

	// GetHealthCheckers returns a set of health checkers for all plugins.
	// These checkers are integrated into the systemd watchdog to monitor the service's health.
	GetHealthCheckers() []healthz.HealthChecker

	// ShouldResetExtendedResourceCapacity returns whether or not the extended resources should be zeroed,
	// due to node recreation.
	ShouldResetExtendedResourceCapacity() bool

	// GetAllocateResourcesPodAdmitHandler returns an instance of a PodAdmitHandler responsible for allocating pod resources.
	GetAllocateResourcesPodAdmitHandler() lifecycle.PodAdmitHandler

	// GetNodeAllocatableAbsolute returns the absolute value of Node Allocatable which is primarily useful for enforcement.
	GetNodeAllocatableAbsolute() v1.ResourceList

	// PrepareDynamicResource prepares dynamic pod resources
	PrepareDynamicResources(context.Context, *v1.Pod) error

	// UnprepareDynamicResources unprepares dynamic pod resources
	UnprepareDynamicResources(context.Context, *v1.Pod) error

	// PodMightNeedToUnprepareResources returns true if the pod with the given UID
	// might need to unprepare resources.
	PodMightNeedToUnprepareResources(UID types.UID) bool

	// UpdateAllocatedResourcesStatus updates the status of allocated resources for the pod.
	UpdateAllocatedResourcesStatus(pod *v1.Pod, status *v1.PodStatus)

	// Updates returns a channel that receives an Update when the device changed its status.
	Updates() <-chan resourceupdates.Update

	// PodHasExclusiveCPUs returns true if the provided pod has containers with exclusive CPUs,
	// This means that at least one sidecar container or one app container has exclusive CPUs allocated.
	PodHasExclusiveCPUs(pod *v1.Pod) bool

	// ContainerHasExclusiveCPUs returns true if the provided container in the pod has exclusive cpu
	ContainerHasExclusiveCPUs(pod *v1.Pod, container *v1.Container) bool

	// Implements the PodResources Provider API
	podresources.CPUsProvider
	podresources.DevicesProvider
	podresources.MemoryProvider
	podresources.DynamicResourcesProvider
}

Manages the containers running on a machine.

func NewContainerManager

func NewContainerManager(mountUtil mount.Interface, cadvisorInterface cadvisor.Interface, nodeConfig NodeConfig, failSwapOn bool, recorder record.EventRecorder, kubeClient clientset.Interface) (ContainerManager, error)

TODO(vmarmol): Add limits to the system containers. Takes the absolute name of the specified containers. Empty container name disables use of the specified container.

func NewStubContainerManager

func NewStubContainerManager() ContainerManager

func NewStubContainerManagerWithDevicePluginResource

func NewStubContainerManagerWithDevicePluginResource(extendedPluginResources v1.ResourceList) ContainerManager

func NewStubContainerManagerWithExtendedResource

func NewStubContainerManagerWithExtendedResource(shouldResetExtendedResourceCapacity bool) ContainerManager

type FakeContainerManager

type FakeContainerManager struct {
	sync.Mutex
	CalledFunctions     []string
	PodContainerManager *FakePodContainerManager
	// contains filtered or unexported fields
}

func NewFakeContainerManager

func NewFakeContainerManager() *FakeContainerManager

func (*FakeContainerManager) ContainerHasExclusiveCPUs

func (cm *FakeContainerManager) ContainerHasExclusiveCPUs(pod *v1.Pod, container *v1.Container) bool

func (*FakeContainerManager) GetAllocatableCPUs

func (cm *FakeContainerManager) GetAllocatableCPUs() []int64

func (*FakeContainerManager) GetAllocatableDevices

func (cm *FakeContainerManager) GetAllocatableDevices() []*podresourcesapi.ContainerDevices

func (*FakeContainerManager) GetAllocatableMemory

func (cm *FakeContainerManager) GetAllocatableMemory() []*podresourcesapi.ContainerMemory

func (*FakeContainerManager) GetAllocateResourcesPodAdmitHandler

func (cm *FakeContainerManager) GetAllocateResourcesPodAdmitHandler() lifecycle.PodAdmitHandler

func (*FakeContainerManager) GetCPUs

func (cm *FakeContainerManager) GetCPUs(_, _ string) []int64

func (*FakeContainerManager) GetCapacity

func (cm *FakeContainerManager) GetCapacity(localStorageCapacityIsolation bool) v1.ResourceList

func (*FakeContainerManager) GetDevicePluginResourceCapacity

func (cm *FakeContainerManager) GetDevicePluginResourceCapacity() (v1.ResourceList, v1.ResourceList, []string)

func (*FakeContainerManager) GetDevices

func (*FakeContainerManager) GetDynamicResources

func (cm *FakeContainerManager) GetDynamicResources(pod *v1.Pod, container *v1.Container) []*podresourcesapi.DynamicResource

func (*FakeContainerManager) GetHealthCheckers

func (cm *FakeContainerManager) GetHealthCheckers() []healthz.HealthChecker

func (*FakeContainerManager) GetMemory

func (*FakeContainerManager) GetMountedSubsystems

func (cm *FakeContainerManager) GetMountedSubsystems() *CgroupSubsystems

func (*FakeContainerManager) GetNodeAllocatableAbsolute

func (cm *FakeContainerManager) GetNodeAllocatableAbsolute() v1.ResourceList

func (*FakeContainerManager) GetNodeAllocatableReservation

func (cm *FakeContainerManager) GetNodeAllocatableReservation() v1.ResourceList

func (*FakeContainerManager) GetNodeConfig

func (cm *FakeContainerManager) GetNodeConfig() NodeConfig

func (*FakeContainerManager) GetPluginRegistrationHandlers

func (cm *FakeContainerManager) GetPluginRegistrationHandlers() map[string]cache.PluginHandler

func (*FakeContainerManager) GetPodCgroupRoot

func (cm *FakeContainerManager) GetPodCgroupRoot() string

func (*FakeContainerManager) GetQOSContainersInfo

func (cm *FakeContainerManager) GetQOSContainersInfo() QOSContainersInfo

func (*FakeContainerManager) GetResources

func (cm *FakeContainerManager) GetResources(ctx context.Context, pod *v1.Pod, container *v1.Container) (*kubecontainer.RunContainerOptions, error)

func (*FakeContainerManager) InternalContainerLifecycle

func (cm *FakeContainerManager) InternalContainerLifecycle() InternalContainerLifecycle

func (*FakeContainerManager) NewPodContainerManager

func (cm *FakeContainerManager) NewPodContainerManager() PodContainerManager

func (*FakeContainerManager) PodHasExclusiveCPUs

func (cm *FakeContainerManager) PodHasExclusiveCPUs(pod *v1.Pod) bool

func (*FakeContainerManager) PodMightNeedToUnprepareResources

func (cm *FakeContainerManager) PodMightNeedToUnprepareResources(UID types.UID) bool

func (*FakeContainerManager) PrepareDynamicResources

func (cm *FakeContainerManager) PrepareDynamicResources(ctx context.Context, pod *v1.Pod) error

func (*FakeContainerManager) ShouldResetExtendedResourceCapacity

func (cm *FakeContainerManager) ShouldResetExtendedResourceCapacity() bool

func (*FakeContainerManager) Start

func (*FakeContainerManager) Status

func (cm *FakeContainerManager) Status() Status

func (*FakeContainerManager) SystemCgroupsLimit

func (cm *FakeContainerManager) SystemCgroupsLimit() v1.ResourceList

func (*FakeContainerManager) UnprepareDynamicResources

func (cm *FakeContainerManager) UnprepareDynamicResources(context.Context, *v1.Pod) error

func (*FakeContainerManager) UpdateAllocatedDevices

func (cm *FakeContainerManager) UpdateAllocatedDevices()

func (*FakeContainerManager) UpdateAllocatedResourcesStatus

func (cm *FakeContainerManager) UpdateAllocatedResourcesStatus(pod *v1.Pod, status *v1.PodStatus)

func (*FakeContainerManager) UpdatePluginResources

func (*FakeContainerManager) UpdateQOSCgroups

func (cm *FakeContainerManager) UpdateQOSCgroups() error

func (*FakeContainerManager) Updates

func (cm *FakeContainerManager) Updates() <-chan resourceupdates.Update

type FakePodContainerManager

type FakePodContainerManager struct {
	sync.Mutex
	CalledFunctions []string
	Cgroups         map[types.UID]CgroupName
}

func NewFakePodContainerManager

func NewFakePodContainerManager() *FakePodContainerManager

func (*FakePodContainerManager) AddPodFromCgroups

func (m *FakePodContainerManager) AddPodFromCgroups(pod *kubecontainer.Pod)

func (*FakePodContainerManager) Destroy

func (m *FakePodContainerManager) Destroy(name CgroupName) error

func (*FakePodContainerManager) EnsureExists

func (m *FakePodContainerManager) EnsureExists(_ *v1.Pod) error

func (*FakePodContainerManager) Exists

func (m *FakePodContainerManager) Exists(_ *v1.Pod) bool

func (*FakePodContainerManager) GetAllPodsFromCgroups

func (m *FakePodContainerManager) GetAllPodsFromCgroups() (map[types.UID]CgroupName, error)

func (*FakePodContainerManager) GetPodCgroupConfig

func (cm *FakePodContainerManager) GetPodCgroupConfig(_ *v1.Pod, _ v1.ResourceName) (*ResourceConfig, error)

func (*FakePodContainerManager) GetPodCgroupMemoryUsage

func (cm *FakePodContainerManager) GetPodCgroupMemoryUsage(_ *v1.Pod) (uint64, error)

func (*FakePodContainerManager) GetPodContainerName

func (m *FakePodContainerManager) GetPodContainerName(_ *v1.Pod) (CgroupName, string)

func (*FakePodContainerManager) IsPodCgroup

func (m *FakePodContainerManager) IsPodCgroup(cgroupfs string) (bool, types.UID)

func (*FakePodContainerManager) ReduceCPULimits

func (m *FakePodContainerManager) ReduceCPULimits(_ CgroupName) error

func (*FakePodContainerManager) SetPodCgroupConfig

func (cm *FakePodContainerManager) SetPodCgroupConfig(pod *v1.Pod, resourceConfig *ResourceConfig) error

type GetNodeFunc

type GetNodeFunc func() (*v1.Node, error)

type InternalContainerLifecycle

type InternalContainerLifecycle interface {
	PreCreateContainer(pod *v1.Pod, container *v1.Container, containerConfig *runtimeapi.ContainerConfig) error
	PreStartContainer(pod *v1.Pod, container *v1.Container, containerID string) error
	PostStopContainer(containerID string) error
}

type KernelTunableBehavior

type KernelTunableBehavior string
const (
	KernelTunableWarn   KernelTunableBehavior = "warn"
	KernelTunableError  KernelTunableBehavior = "error"
	KernelTunableModify KernelTunableBehavior = "modify"
)

type NodeAllocatableConfig

type NodeAllocatableConfig struct {
	KubeReservedCgroupName   string
	SystemReservedCgroupName string
	ReservedSystemCPUs       cpuset.CPUSet
	EnforceNodeAllocatable   sets.Set[string]
	KubeReserved             v1.ResourceList
	SystemReserved           v1.ResourceList
	HardEvictionThresholds   []evictionapi.Threshold
}

type NodeConfig

type NodeConfig struct {
	NodeName              types.NodeName
	RuntimeCgroupsName    string
	SystemCgroupsName     string
	KubeletCgroupsName    string
	KubeletOOMScoreAdj    int32
	ContainerRuntime      string
	CgroupsPerQOS         bool
	CgroupRoot            string
	CgroupDriver          string
	KubeletRootDir        string
	ProtectKernelDefaults bool
	NodeAllocatableConfig
	QOSReserved                  map[v1.ResourceName]int64
	CPUManagerPolicy             string
	CPUManagerPolicyOptions      map[string]string
	TopologyManagerScope         string
	CPUManagerReconcilePeriod    time.Duration
	MemoryManagerPolicy          string
	MemoryManagerReservedMemory  []kubeletconfig.MemoryReservation
	PodPidsLimit                 int64
	EnforceCPULimits             bool
	CPUCFSQuotaPeriod            time.Duration
	TopologyManagerPolicy        string
	TopologyManagerPolicyOptions map[string]string
	CgroupVersion                int
}

type PodContainerManager

type PodContainerManager interface {
	// GetPodContainerName returns the CgroupName identifier, and its literal cgroupfs form on the host.
	GetPodContainerName(*v1.Pod) (CgroupName, string)

	// EnsureExists takes a pod as argument and makes sure that
	// pod cgroup exists if qos cgroup hierarchy flag is enabled.
	// If the pod cgroup doesn't already exist this method creates it.
	EnsureExists(*v1.Pod) error

	// Exists returns true if the pod cgroup exists.
	Exists(*v1.Pod) bool

	// Destroy takes a pod Cgroup name as argument and destroys the pod's container.
	Destroy(name CgroupName) error

	// ReduceCPULimits reduces the CPU CFS values to the minimum amount of shares.
	ReduceCPULimits(name CgroupName) error

	// GetAllPodsFromCgroups enumerates the set of pod uids to their associated cgroup based on state of cgroupfs system.
	GetAllPodsFromCgroups() (map[types.UID]CgroupName, error)

	// IsPodCgroup returns true if the literal cgroupfs name corresponds to a pod
	IsPodCgroup(cgroupfs string) (bool, types.UID)

	// Get value of memory usage for the pod Cgroup
	GetPodCgroupMemoryUsage(pod *v1.Pod) (uint64, error)

	// Get the resource config values applied to the pod cgroup for specified resource type
	GetPodCgroupConfig(pod *v1.Pod, resource v1.ResourceName) (*ResourceConfig, error)

	// Set resource config values for the specified resource type on the pod cgroup
	SetPodCgroupConfig(pod *v1.Pod, resourceConfig *ResourceConfig) error
}

PodContainerManager stores and manages pod level containers The Pod workers interact with the PodContainerManager to create and destroy containers for the pod.

type QOSContainerManager

type QOSContainerManager interface {
	Start(func() v1.ResourceList, ActivePodsFunc) error
	GetQOSContainersInfo() QOSContainersInfo
	UpdateCgroups() error
}

func NewQOSContainerManager

func NewQOSContainerManager(subsystems *CgroupSubsystems, cgroupRoot CgroupName, nodeConfig NodeConfig, cgroupManager CgroupManager) (QOSContainerManager, error)

type QOSContainersInfo

type QOSContainersInfo struct {
	Guaranteed CgroupName
	BestEffort CgroupName
	Burstable  CgroupName
}

QOSContainersInfo stores the names of containers per qos

type ResourceConfig

type ResourceConfig struct {
	// Memory limit (in bytes).
	Memory *int64
	// CPU set (number of CPUs the cgroup has access to).
	CPUSet cpuset.CPUSet
	// CPU shares (relative weight vs. other containers).
	CPUShares *uint64
	// CPU hardcap limit (in usecs). Allowed cpu time in a given period.
	CPUQuota *int64
	// CPU quota period.
	CPUPeriod *uint64
	// HugePageLimit map from page size (in bytes) to limit (in bytes)
	HugePageLimit map[int64]int64
	// Maximum number of pids
	PidsLimit *int64
	// Unified for cgroup v2
	Unified map[string]string
}

ResourceConfig holds information about all the supported cgroup resource parameters.

func ResourceConfigForPod

func ResourceConfigForPod(allocatedPod *v1.Pod, enforceCPULimits bool, cpuPeriod uint64, enforceMemoryQoS bool) *ResourceConfig

ResourceConfigForPod takes the input pod and outputs the cgroup resource config.

type Status

type Status struct {
	// Any soft requirements that were unsatisfied.
	SoftRequirements error
}

Source Files

cgroup_manager_linux.go cgroup_v1_manager_linux.go cgroup_v2_manager_linux.go container_manager.go container_manager_linux.go container_manager_stub.go doc.go fake_container_manager.go fake_internal_container_lifecycle.go fake_pod_container_manager.go helpers.go helpers_linux.go internal_container_lifecycle.go internal_container_lifecycle_linux.go node_container_manager_linux.go pod_container_manager_linux.go pod_container_manager_stub.go qos_container_manager_linux.go types.go

Directories

PathSynopsis
pkg/kubelet/cm/admission
pkg/kubelet/cm/containermap
pkg/kubelet/cm/cpumanager
pkg/kubelet/cm/cpumanager/state
pkg/kubelet/cm/cpumanager/state/testing
pkg/kubelet/cm/cpumanager/topologyPackage topology contains helpers for the CPU manager.
pkg/kubelet/cm/devicemanager
pkg/kubelet/cm/devicemanager/checkpoint
pkg/kubelet/cm/devicemanager/plugin
pkg/kubelet/cm/devicemanager/plugin/v1beta1
pkg/kubelet/cm/dra
pkg/kubelet/cm/dra/plugin
pkg/kubelet/cm/dra/state
pkg/kubelet/cm/memorymanager
pkg/kubelet/cm/memorymanager/state
pkg/kubelet/cm/resourceupdates
pkg/kubelet/cm/testing
pkg/kubelet/cm/topologymanager
pkg/kubelet/cm/topologymanager/bitmask
pkg/kubelet/cm/util
Version
v1.33.0 (latest)
Published
Apr 23, 2025
Platform
linux/amd64
Imports
67 packages
Last checked
3 hours ago

Tools for package owners.