utils

package
v1.14.9 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Nov 9, 2019 License: Apache-2.0 Imports: 54 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

func AddLabelsToNode added in v1.5.0

func AddLabelsToNode(c clientset.Interface, nodeName string, labels map[string]string) error

func CheckDeploymentRevisionAndImage added in v1.9.0

func CheckDeploymentRevisionAndImage(c clientset.Interface, ns, deploymentName, revision, image string) error

CheckDeploymentRevisionAndImage checks if the input deployment's and its new replica set's revision and image are as expected.

func CheckForDuplicates added in v1.14.0

func CheckForDuplicates(el auditinternal.EventList) (auditinternal.EventList, error)

CheckForDuplicates checks a list for duplicate events

func CreateConfigMapWithRetries added in v1.10.0

func CreateConfigMapWithRetries(c clientset.Interface, namespace string, obj *v1.ConfigMap) error

func CreateDaemonSetWithRetries added in v1.10.0

func CreateDaemonSetWithRetries(c clientset.Interface, namespace string, obj *apps.DaemonSet) error

func CreateDeploymentWithRetries added in v1.10.0

func CreateDeploymentWithRetries(c clientset.Interface, namespace string, obj *apps.Deployment) error

func CreateJobWithRetries added in v1.10.0

func CreateJobWithRetries(c clientset.Interface, namespace string, obj *batch.Job) error

func CreatePod added in v1.8.0

func CreatePod(client clientset.Interface, namespace string, podCount int, podTemplate *v1.Pod) error

func CreatePodWithRetries added in v1.10.0

func CreatePodWithRetries(c clientset.Interface, namespace string, obj *v1.Pod) error

func CreateRCWithRetries added in v1.10.0

func CreateRCWithRetries(c clientset.Interface, namespace string, obj *v1.ReplicationController) error

func CreateReplicaSetWithRetries added in v1.10.0

func CreateReplicaSetWithRetries(c clientset.Interface, namespace string, obj *apps.ReplicaSet) error

func CreateResourceQuotaWithRetries added in v1.10.0

func CreateResourceQuotaWithRetries(c clientset.Interface, namespace string, obj *v1.ResourceQuota) error

func CreateSecretWithRetries added in v1.10.0

func CreateSecretWithRetries(c clientset.Interface, namespace string, obj *v1.Secret) error

func CreateServiceWithRetries added in v1.10.0

func CreateServiceWithRetries(c clientset.Interface, namespace string, obj *v1.Service) error

func DeleteResourceWithRetries added in v1.10.0

func DeleteResourceWithRetries(c clientset.Interface, kind schema.GroupKind, namespace, name string, options *metav1.DeleteOptions) error

func DoCleanupNode added in v1.5.0

func DoCleanupNode(client clientset.Interface, nodeName string, strategy PrepareNodeStrategy) error

func DoPrepareNode added in v1.5.0

func DoPrepareNode(client clientset.Interface, node *v1.Node, strategy PrepareNodeStrategy) error

func FailedContainers added in v1.4.5

func FailedContainers(pod *v1.Pod) map[string]ContainerFailures

FailedContainers inspects all containers in a pod and returns failure information for containers that have failed or been restarted. A map is returned where the key is the containerID and the value is a struct containing the restart and failure information

func GetCAdvisorRootDir added in v1.11.0

func GetCAdvisorRootDir() (string, error)

GetCAdvisorRootDir returns the root directory for cAdvisor, if present in the gopath.

func GetK8sBuildOutputDir added in v1.11.0

func GetK8sBuildOutputDir() (string, error)

GetK8sBuildOutputDir returns the build output directory for k8s

func GetK8sRootDir added in v1.11.0

func GetK8sRootDir() (string, error)

GetK8sRootDir returns the root directory for kubernetes, if present in the gopath.

func GetNodeCondition added in v1.14.0

func GetNodeCondition(status *v1.NodeStatus, conditionType v1.NodeConditionType) (int, *v1.NodeCondition)

GetNodeCondition extracts the provided condition from the given status and returns that. Returns nil and -1 if the condition is not present, and the index of the located condition.

func IsRetryableAPIError added in v1.10.0

func IsRetryableAPIError(err error) bool

func LogPodsOfDeployment added in v1.7.0

func LogPodsOfDeployment(c clientset.Interface, deployment *apps.Deployment, rsList []*apps.ReplicaSet, logf LogfFn)

func LogReplicaSetsOfDeployment added in v1.7.0

func LogReplicaSetsOfDeployment(deployment *apps.Deployment, allOldRSs []*apps.ReplicaSet, newRS *apps.ReplicaSet, logf LogfFn)

func MakePodSpec added in v1.5.0

func MakePodSpec() v1.PodSpec

func MakeTempDirOrDie

func MakeTempDirOrDie(prefix string, baseDir string) string

func PodNotReady added in v1.4.5

func PodNotReady(p *v1.Pod) (bool, error)

PodNotReady checks whether pod p's has a ready condition of status false.

func PodRunningReady added in v1.4.5

func PodRunningReady(p *v1.Pod) (bool, error)

PodRunningReady checks whether pod p's phase is running and it has a ready condition of status true.

func PodRunningReadyOrSucceeded added in v1.4.5

func PodRunningReadyOrSucceeded(p *v1.Pod) (bool, error)

func RemoveLabelOffNode added in v1.5.0

func RemoveLabelOffNode(c clientset.Interface, nodeName string, labelKeys []string) error

RemoveLabelOffNode is for cleaning up labels temporarily added to node, won't fail if target label doesn't exist or has been removed.

func RetryErrorCondition added in v1.11.0

func RetryErrorCondition(condition wait.ConditionFunc) wait.ConditionFunc

func RetryWithExponentialBackOff added in v1.10.0

func RetryWithExponentialBackOff(fn wait.ConditionFunc) error

Utility for retrying the given function with exponential backoff.

func RootDir added in v1.11.0

func RootDir() (string, error)

RootDir gets the on-disk kubernetes source directory, returning an error is none is found

func RunDeployment added in v1.5.0

func RunDeployment(config DeploymentConfig) error

RunDeployment Launches (and verifies correctness) of a Deployment and will wait for all pods it spawns to become "Running". It's the caller's responsibility to clean up externally (i.e. use the namespace lifecycle for handling Cleanup).

func RunJob added in v1.6.0

func RunJob(config JobConfig) error

RunJob baunches (and verifies correctness) of a Job and will wait for all pods it spawns to become "Running". It's the caller's responsibility to clean up externally (i.e. use the namespace lifecycle for handling Cleanup).

func RunPodAndGetNodeName added in v1.6.0

func RunPodAndGetNodeName(c clientset.Interface, pod *v1.Pod, timeout time.Duration) (string, error)

func RunRC added in v1.5.0

func RunRC(config RCConfig) error

RunRC Launches (and verifies correctness) of a Replication Controller and will wait for all pods it spawns to become "Running". It's the caller's responsibility to clean up externally (i.e. use the namespace lifecycle for handling Cleanup).

func RunReplicaSet added in v1.5.0

func RunReplicaSet(config ReplicaSetConfig) error

RunReplicaSet launches (and verifies correctness) of a ReplicaSet and waits until all the pods it launches to reach the "Running" state. It's the caller's responsibility to clean up externally (i.e. use the namespace lifecycle for handling Cleanup).

func ScaleResourceWithRetries added in v1.10.0

func ScaleResourceWithRetries(scalesGetter scale.ScalesGetter, namespace, name string, size uint, gr schema.GroupResource) error

func StartPods added in v1.5.0

func StartPods(c clientset.Interface, replicas int, namespace string, podNamePrefix string,
	pod v1.Pod, waitForRunning bool, logFunc func(fmt string, args ...interface{})) error

Simplified version of RunRC, that does not create RC, but creates plain Pods. Optionally waits for pods to start running (if waitForRunning == true). The number of replicas must be non-zero.

func TerminatedContainers added in v1.4.5

func TerminatedContainers(pod *v1.Pod) map[string]string

TerminatedContainers inspects all containers in a pod and returns a map of "container name: termination reason", for all currently terminated containers.

func UpdateDeploymentWithRetries added in v1.8.0

func UpdateDeploymentWithRetries(c clientset.Interface, namespace, name string, applyUpdate UpdateDeploymentFunc, logf LogfFn, pollInterval, pollTimeout time.Duration) (*apps.Deployment, error)

func UpdateReplicaSetStatusWithRetries added in v1.10.0

func UpdateReplicaSetStatusWithRetries(c clientset.Interface, namespace, name string, applyUpdate UpdateReplicaSetFunc, logf LogfFn, pollInterval, pollTimeout time.Duration) (*apps.ReplicaSet, error)

func UpdateReplicaSetWithRetries added in v1.9.0

func UpdateReplicaSetWithRetries(c clientset.Interface, namespace, name string, applyUpdate UpdateReplicaSetFunc, logf LogfFn, pollInterval, pollTimeout time.Duration) (*apps.ReplicaSet, error)

func VerifyLabelsRemoved added in v1.5.0

func VerifyLabelsRemoved(c clientset.Interface, nodeName string, labelKeys []string) error

VerifyLabelsRemoved checks if Node for given nodeName does not have any of labels from labelKeys. Return non-nil error if it does.

func WaitForDeploymentComplete added in v1.9.0

func WaitForDeploymentComplete(c clientset.Interface, d *apps.Deployment, logf LogfFn, pollInterval, pollTimeout time.Duration) error

Waits for the deployment to complete, and don't check if rolling update strategy is broken. Rolling update strategy is used only during a rolling update, and can be violated in other situations, such as shortly after a scaling event or the deployment is just created.

func WaitForDeploymentCompleteAndCheckRolling added in v1.9.0

func WaitForDeploymentCompleteAndCheckRolling(c clientset.Interface, d *apps.Deployment, logf LogfFn, pollInterval, pollTimeout time.Duration) error

Waits for the deployment to complete, and check rolling update strategy isn't broken at any times. Rolling update strategy should not be broken during a rolling update.

func WaitForDeploymentRevisionAndImage added in v1.7.0

func WaitForDeploymentRevisionAndImage(c clientset.Interface, ns, deploymentName string, revision, image string, logf LogfFn, pollInterval, pollTimeout time.Duration) error

WaitForDeploymentRevisionAndImage waits for the deployment's and its new RS's revision and container image to match the given revision and image. Note that deployment revision and its new RS revision should be updated shortly, so we only wait for 1 minute here to fail early.

func WaitForDeploymentRollbackCleared added in v1.9.0

func WaitForDeploymentRollbackCleared(c clientset.Interface, ns, deploymentName string, pollInterval, pollTimeout time.Duration) error

WaitForDeploymentRollbackCleared waits for given deployment either started rolling back or doesn't need to rollback.

func WaitForDeploymentUpdatedReplicasGTE added in v1.10.0

func WaitForDeploymentUpdatedReplicasGTE(c clientset.Interface, ns, deploymentName string, minUpdatedReplicas int32, desiredGeneration int64, pollInterval, pollTimeout time.Duration) error

WaitForDeploymentUpdatedReplicasGTE waits for given deployment to be observed by the controller and has at least a number of updatedReplicas

func WaitForDeploymentWithCondition added in v1.9.0

func WaitForDeploymentWithCondition(c clientset.Interface, ns, deploymentName, reason string, condType apps.DeploymentConditionType, logf LogfFn, pollInterval, pollTimeout time.Duration) error

func WaitForEnoughPodsWithLabelRunning added in v1.10.0

func WaitForEnoughPodsWithLabelRunning(c clientset.Interface, ns string, label labels.Selector, replicas int) error

Wait up to 10 minutes for at least 'replicas' many pods to be Running and at least one matching pod exists. If 'replicas' is < 0, wait for all matching pods running.

func WaitForObservedDeployment added in v1.8.0

func WaitForObservedDeployment(c clientset.Interface, ns, deploymentName string, desiredGeneration int64) error

func WaitForPodsWithLabelRunning added in v1.5.0

func WaitForPodsWithLabelRunning(c clientset.Interface, ns string, label labels.Selector) error

Wait up to 10 minutes for all matching pods to become Running and at least one matching pod exists.

func WaitRSStable added in v1.9.0

func WaitRSStable(t *testing.T, clientSet clientset.Interface, rs *apps.ReplicaSet, pollInterval, pollTimeout time.Duration) error

Verify .Status.Replicas is equal to .Spec.Replicas

func WaitUntilPodIsScheduled added in v1.6.0

func WaitUntilPodIsScheduled(c clientset.Interface, name, namespace string, timeout time.Duration) (*v1.Pod, error)

Types

type AuditEvent added in v1.12.0

type AuditEvent struct {
	ID                 types.UID
	Level              auditinternal.Level
	Stage              auditinternal.Stage
	RequestURI         string
	Verb               string
	Code               int32
	User               string
	ImpersonatedUser   string
	ImpersonatedGroups string
	Resource           string
	Namespace          string
	RequestObject      bool
	ResponseObject     bool
	AuthorizeDecision  string
}

AuditEvent is a simplified representation of an audit event for testing purposes

func CheckAuditList added in v1.14.0

func CheckAuditList(el auditinternal.EventList, expected []AuditEvent) (missing []AuditEvent, err error)

CheckAuditList searches an audit event list for the expected audit events.

type AuditTestServer added in v1.14.0

type AuditTestServer struct {
	Name            string
	LockedEventList *LockedEventList
	Server          *httptest.Server
	// contains filtered or unexported fields
}

AuditTestServer is a helper server for dynamic audit testing

func NewAuditTestServer added in v1.14.0

func NewAuditTestServer(t *testing.T, name string) *AuditTestServer

NewAuditTestServer returns a new audit test server

func (*AuditTestServer) AppendEvents added in v1.14.0

func (a *AuditTestServer) AppendEvents(events []auditinternal.Event)

AppendEvents will add the given events to the internal event list

func (*AuditTestServer) BuildSinkConfiguration added in v1.14.0

func (a *AuditTestServer) BuildSinkConfiguration() *auditregv1alpha1.AuditSink

BuildSinkConfiguration creates a generic audit sink configuration for this server

func (*AuditTestServer) Close added in v1.14.0

func (a *AuditTestServer) Close()

Close the server

func (*AuditTestServer) GetEventList added in v1.14.0

func (a *AuditTestServer) GetEventList() auditinternal.EventList

GetEventList safely returns the internal event list

func (*AuditTestServer) Health added in v1.14.0

func (a *AuditTestServer) Health() error

Health polls the server healthcheck until successful or the 30s timeout has been reached

func (*AuditTestServer) ResetEventList added in v1.14.0

func (a *AuditTestServer) ResetEventList()

ResetEventList resets the internal event list

func (*AuditTestServer) WaitForEvents added in v1.14.0

func (a *AuditTestServer) WaitForEvents(expected []AuditEvent) ([]AuditEvent, error)

WaitForEvents waits for the given events to arrive in the server or the 30s timeout is reached

func (*AuditTestServer) WaitForNumEvents added in v1.14.0

func (a *AuditTestServer) WaitForNumEvents(numEvents int) error

WaitForNumEvents checks that at least the given number of events has arrived or the 30s timeout is reached

type ConfigMapConfig added in v1.7.0

type ConfigMapConfig struct {
	Content   map[string]string
	Client    clientset.Interface
	Name      string
	Namespace string
	// If set this function will be used to print log lines instead of klog.
	LogFunc func(fmt string, args ...interface{})
}

func (*ConfigMapConfig) Run added in v1.7.0

func (config *ConfigMapConfig) Run() error

func (*ConfigMapConfig) Stop added in v1.7.0

func (config *ConfigMapConfig) Stop() error

type ContainerFailures added in v1.4.5

type ContainerFailures struct {
	Restarts int
	// contains filtered or unexported fields
}

type CountToPodStrategy added in v1.5.0

type CountToPodStrategy struct {
	Count    int
	Strategy TestPodCreateStrategy
}

type CountToStrategy added in v1.5.0

type CountToStrategy struct {
	Count    int
	Strategy PrepareNodeStrategy
}

type DaemonConfig added in v1.6.0

type DaemonConfig struct {
	Client    clientset.Interface
	Name      string
	Namespace string
	Image     string
	// If set this function will be used to print log lines instead of klog.
	LogFunc func(fmt string, args ...interface{})
	// How long we wait for DaemonSet to become running.
	Timeout time.Duration
}

func (*DaemonConfig) Run added in v1.6.0

func (config *DaemonConfig) Run() error

type DeploymentConfig added in v1.5.0

type DeploymentConfig struct {
	RCConfig
}

func (*DeploymentConfig) GetGroupResource added in v1.10.0

func (config *DeploymentConfig) GetGroupResource() schema.GroupResource

func (*DeploymentConfig) GetKind added in v1.6.0

func (config *DeploymentConfig) GetKind() schema.GroupKind

func (*DeploymentConfig) Run added in v1.6.0

func (config *DeploymentConfig) Run() error

type JobConfig added in v1.6.0

type JobConfig struct {
	RCConfig
}

func (*JobConfig) GetGroupResource added in v1.10.0

func (config *JobConfig) GetGroupResource() schema.GroupResource

func (*JobConfig) GetKind added in v1.6.0

func (config *JobConfig) GetKind() schema.GroupKind

func (*JobConfig) Run added in v1.6.0

func (config *JobConfig) Run() error

type LabelNodePrepareStrategy added in v1.5.0

type LabelNodePrepareStrategy struct {
	// contains filtered or unexported fields
}

func NewLabelNodePrepareStrategy added in v1.5.0

func NewLabelNodePrepareStrategy(labelKey string, labelValue string) *LabelNodePrepareStrategy

func (*LabelNodePrepareStrategy) CleanupNode added in v1.5.0

func (s *LabelNodePrepareStrategy) CleanupNode(node *v1.Node) *v1.Node

func (*LabelNodePrepareStrategy) PreparePatch added in v1.5.0

func (s *LabelNodePrepareStrategy) PreparePatch(*v1.Node) []byte

type LockedEventList added in v1.14.0

type LockedEventList struct {
	*sync.RWMutex
	EventList auditinternal.EventList
}

LockedEventList is an event list with a lock for concurrent access

func NewLockedEventList added in v1.14.0

func NewLockedEventList() *LockedEventList

NewLockedEventList returns a new LockedEventList

type LogfFn added in v1.7.0

type LogfFn func(format string, args ...interface{})

type MissingEventsReport added in v1.14.0

type MissingEventsReport struct {
	FirstEventChecked *auditinternal.Event
	LastEventChecked  *auditinternal.Event
	NumEventsChecked  int
	MissingEvents     []AuditEvent
}

MissingEventsReport provides an analysis if any events are missing

func CheckAuditLines added in v1.12.0

func CheckAuditLines(stream io.Reader, expected []AuditEvent, version schema.GroupVersion) (missingReport *MissingEventsReport, err error)

CheckAuditLines searches the audit log for the expected audit lines.

func (*MissingEventsReport) String added in v1.14.0

func (m *MissingEventsReport) String() string

String returns a human readable string representation of the report

type PodDiff added in v1.5.0

type PodDiff map[string]*podInfo

PodDiff is a map of pod name to podInfos

func Diff added in v1.5.0

func Diff(oldPods []*v1.Pod, curPods []*v1.Pod) PodDiff

Diff computes a PodDiff given 2 lists of pods.

func (PodDiff) DeletedPods added in v1.13.0

func (p PodDiff) DeletedPods() []string

DeletedPods returns a slice of pods that were present at the beginning and then disappeared.

func (PodDiff) String added in v1.5.0

func (p PodDiff) String(ignorePhases sets.String) string

Print formats and prints the give PodDiff.

type PodStore added in v1.5.0

type PodStore struct {
	cache.Store

	Reflector *cache.Reflector
	// contains filtered or unexported fields
}

Convenient wrapper around cache.Store that returns list of v1.Pod instead of interface{}.

func NewPodStore added in v1.5.0

func NewPodStore(c clientset.Interface, namespace string, label labels.Selector, field fields.Selector) (*PodStore, error)

func (*PodStore) List added in v1.5.0

func (s *PodStore) List() []*v1.Pod

func (*PodStore) Stop added in v1.5.0

func (s *PodStore) Stop()

type PrepareNodeStrategy added in v1.5.0

type PrepareNodeStrategy interface {
	PreparePatch(node *v1.Node) []byte
	CleanupNode(node *v1.Node) *v1.Node
}

type RCConfig added in v1.5.0

type RCConfig struct {
	Affinity          *v1.Affinity
	Client            clientset.Interface
	InternalClient    internalclientset.Interface
	ScalesGetter      scaleclient.ScalesGetter
	Image             string
	Command           []string
	Name              string
	Namespace         string
	PollInterval      time.Duration
	Timeout           time.Duration
	PodStatusFile     *os.File
	Replicas          int
	CpuRequest        int64 // millicores
	CpuLimit          int64 // millicores
	MemRequest        int64 // bytes
	MemLimit          int64 // bytes
	GpuLimit          int64 // count
	ReadinessProbe    *v1.Probe
	DNSPolicy         *v1.DNSPolicy
	PriorityClassName string

	// Env vars, set the same for every pod.
	Env map[string]string

	// Extra labels and annotations added to every pod.
	Labels      map[string]string
	Annotations map[string]string

	// Node selector for pods in the RC.
	NodeSelector map[string]string

	// Tolerations for pods in the RC.
	Tolerations []v1.Toleration

	// Ports to declare in the container (map of name to containerPort).
	Ports map[string]int
	// Ports to declare in the container as host and container ports.
	HostPorts map[string]int

	Volumes      []v1.Volume
	VolumeMounts []v1.VolumeMount

	// Pointer to a list of pods; if non-nil, will be set to a list of pods
	// created by this RC by RunRC.
	CreatedPods *[]*v1.Pod

	// Maximum allowable container failures. If exceeded, RunRC returns an error.
	// Defaults to replicas*0.1 if unspecified.
	MaxContainerFailures *int

	// If set to false starting RC will print progress, otherwise only errors will be printed.
	Silent bool

	// If set this function will be used to print log lines instead of klog.
	LogFunc func(fmt string, args ...interface{})
	// If set those functions will be used to gather data from Nodes - in integration tests where no
	// kubelets are running those variables should be nil.
	NodeDumpFunc      func(c clientset.Interface, nodeNames []string, logFunc func(fmt string, args ...interface{}))
	ContainerDumpFunc func(c clientset.Interface, ns string, logFunc func(ftm string, args ...interface{}))

	// Names of the secrets and configmaps to mount.
	SecretNames    []string
	ConfigMapNames []string

	ServiceAccountTokenProjections int
}

func (*RCConfig) GetClient added in v1.6.0

func (config *RCConfig) GetClient() clientset.Interface

func (*RCConfig) GetGroupResource added in v1.10.0

func (config *RCConfig) GetGroupResource() schema.GroupResource

func (*RCConfig) GetInternalClient added in v1.6.0

func (config *RCConfig) GetInternalClient() internalclientset.Interface

func (*RCConfig) GetKind added in v1.6.0

func (config *RCConfig) GetKind() schema.GroupKind

func (*RCConfig) GetLabelValue added in v1.8.0

func (config *RCConfig) GetLabelValue(key string) (string, bool)

func (*RCConfig) GetName added in v1.6.0

func (config *RCConfig) GetName() string

func (*RCConfig) GetNamespace added in v1.6.0

func (config *RCConfig) GetNamespace() string

func (*RCConfig) GetReplicas added in v1.6.0

func (config *RCConfig) GetReplicas() int

func (*RCConfig) GetScalesGetter added in v1.10.0

func (config *RCConfig) GetScalesGetter() scaleclient.ScalesGetter

func (*RCConfig) RCConfigLog added in v1.5.0

func (rc *RCConfig) RCConfigLog(fmt string, args ...interface{})

func (*RCConfig) Run added in v1.6.0

func (config *RCConfig) Run() error

func (*RCConfig) SetClient added in v1.6.0

func (config *RCConfig) SetClient(c clientset.Interface)

func (*RCConfig) SetInternalClient added in v1.6.0

func (config *RCConfig) SetInternalClient(c internalclientset.Interface)

func (*RCConfig) SetScalesClient added in v1.10.0

func (config *RCConfig) SetScalesClient(getter scaleclient.ScalesGetter)

type RCStartupStatus added in v1.5.0

type RCStartupStatus struct {
	Expected              int
	Terminating           int
	Running               int
	RunningButNotReady    int
	Waiting               int
	Pending               int
	Scheduled             int
	Unknown               int
	Inactive              int
	FailedContainers      int
	Created               []*v1.Pod
	ContainerRestartNodes sets.String
}

func ComputeRCStartupStatus added in v1.5.0

func ComputeRCStartupStatus(pods []*v1.Pod, expected int) RCStartupStatus

func (*RCStartupStatus) String added in v1.5.0

func (s *RCStartupStatus) String(name string) string

type ReplicaSetConfig added in v1.5.0

type ReplicaSetConfig struct {
	RCConfig
}

func (*ReplicaSetConfig) GetGroupResource added in v1.10.0

func (config *ReplicaSetConfig) GetGroupResource() schema.GroupResource

func (*ReplicaSetConfig) GetKind added in v1.6.0

func (config *ReplicaSetConfig) GetKind() schema.GroupKind

func (*ReplicaSetConfig) Run added in v1.6.0

func (config *ReplicaSetConfig) Run() error

type RunObjectConfig added in v1.6.0

type RunObjectConfig interface {
	Run() error
	GetName() string
	GetNamespace() string
	GetKind() schema.GroupKind
	GetClient() clientset.Interface
	GetInternalClient() internalclientset.Interface
	GetScalesGetter() scaleclient.ScalesGetter
	SetClient(clientset.Interface)
	SetInternalClient(internalclientset.Interface)
	SetScalesClient(scaleclient.ScalesGetter)
	GetReplicas() int
	GetLabelValue(string) (string, bool)
	GetGroupResource() schema.GroupResource
}

type SecretConfig added in v1.6.0

type SecretConfig struct {
	Content   map[string]string
	Client    clientset.Interface
	Name      string
	Namespace string
	// If set this function will be used to print log lines instead of klog.
	LogFunc func(fmt string, args ...interface{})
}

func (*SecretConfig) Run added in v1.6.0

func (config *SecretConfig) Run() error

func (*SecretConfig) Stop added in v1.6.0

func (config *SecretConfig) Stop() error

type TestNodePreparer added in v1.5.0

type TestNodePreparer interface {
	PrepareNodes() error
	CleanupNodes() error
}

type TestPodCreateStrategy added in v1.5.0

type TestPodCreateStrategy func(client clientset.Interface, namespace string, podCount int) error

func NewCustomCreatePodStrategy added in v1.5.0

func NewCustomCreatePodStrategy(podTemplate *v1.Pod) TestPodCreateStrategy

func NewSimpleCreatePodStrategy added in v1.5.0

func NewSimpleCreatePodStrategy() TestPodCreateStrategy

func NewSimpleWithControllerCreatePodStrategy added in v1.5.0

func NewSimpleWithControllerCreatePodStrategy(controllerName string) TestPodCreateStrategy

type TestPodCreator added in v1.5.0

type TestPodCreator struct {
	Client clientset.Interface
	// namespace -> count -> strategy
	Config *TestPodCreatorConfig
}

func NewTestPodCreator added in v1.5.0

func NewTestPodCreator(client clientset.Interface, config *TestPodCreatorConfig) *TestPodCreator

func (*TestPodCreator) CreatePods added in v1.5.0

func (c *TestPodCreator) CreatePods() error

type TestPodCreatorConfig added in v1.5.0

type TestPodCreatorConfig map[string][]CountToPodStrategy

func NewTestPodCreatorConfig added in v1.5.0

func NewTestPodCreatorConfig() *TestPodCreatorConfig

func (*TestPodCreatorConfig) AddStrategy added in v1.5.0

func (c *TestPodCreatorConfig) AddStrategy(
	namespace string, podCount int, strategy TestPodCreateStrategy)

type TrivialNodePrepareStrategy added in v1.5.0

type TrivialNodePrepareStrategy struct{}

func (*TrivialNodePrepareStrategy) CleanupNode added in v1.5.0

func (*TrivialNodePrepareStrategy) CleanupNode(node *v1.Node) *v1.Node

func (*TrivialNodePrepareStrategy) PreparePatch added in v1.5.0

func (*TrivialNodePrepareStrategy) PreparePatch(*v1.Node) []byte

type UpdateDeploymentFunc added in v1.8.0

type UpdateDeploymentFunc func(d *apps.Deployment)

type UpdateReplicaSetFunc added in v1.9.0

type UpdateReplicaSetFunc func(d *apps.ReplicaSet)

Directories

Path Synopsis
Package junit provides data structures to allow easy XML encoding and decoding of JUnit test results.
Package junit provides data structures to allow easy XML encoding and decoding of JUnit test results.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL