Versions in this module Expand all Collapse all v1 v1.1.0 Mar 14, 2022 v1.0.0 Jun 3, 2021 v0 v0.9.0 Jun 23, 2020 Changes in this version + const AffinityConfirmCount + const ClaimBindingTimeout + const ClaimDeletingTimeout + const ClaimProvisionShortTimeout + const ClaimProvisionTimeout + const ClusterHttpPort + const ClusterUdpPort + const CurrentKubeletPerfMetricsVersion + const DefaultCPUProfileSeconds + const DefaultNamespaceDeletionTimeout + const DefaultPodDeletionTimeout + const EndpointHttpPort + const EndpointRegisterTimeout + const EndpointUdpPort + const GCPMaxInstancesInInstanceGroup + const GPUDevicePluginDSYAML + const Gb + const GiB + const JobSelectorKey + const JobTimeout + const Kb + const KiB + const KubeProxyEndpointLagTimeout + const KubeProxyLagTimeout + const LargeClusterMinNodesNumber + const LoadBalancerCleanupTimeout + const LoadBalancerCreateTimeoutDefault + const LoadBalancerCreateTimeoutLarge + const LoadBalancerLagTimeoutAWS + const LoadBalancerLagTimeoutDefault + const LoadBalancerPollInterval + const LoadBalancerPollTimeout + const MaxNodesForEndpointsTests + const Mb + const MiB + const NVIDIAGPUResourceName + const NamespaceCleanupTimeout + const NoCPUConstraint + const NodeReadyInitialTimeout + const NodeStartupThreshold + const PDRetryPollTime + const PDRetryTimeout + const PVBindingTimeout + const PVDeletingTimeout + const PVReclaimingTimeout + const PodCleanupTimeout + const PodDeleteTimeout + const PodEventTimeout + const PodListTimeout + const PodReadyBeforeTimeout + const PodStartShortTimeout + const PodStartTimeout + const Poll + const RestartNodeReadyAgainTimeout + const RestartPodReadyAgainTimeout + const ServiceAccountProvisionTimeout + const ServiceRespondingTimeout + const ServiceStartTimeout + const ServiceTestTimeout + const SessionAffinityChecks + const SingleCallTimeout + const StatefulPodTimeout + const StatefulSetPoll + const StatefulSetTimeout + const Tb + const TestContainerHttpPort + const TiB + const VolumeSelectorKey + const VolumeServerPodStartupTimeout + var BusyBoxImage = imageutils.GetE2EImage(imageutils.BusyBox) + var Factories = map[What]ItemFactory + var ImageWhiteList sets.String + var InterestingApiServerMetrics = []string + var InterestingClusterAutoscalerMetrics = []string + var InterestingControllerManagerMetrics = []string + var InterestingKubeletMetrics = []string + var ItemNotSupported = errors.New("not supported") + var NetexecImageName = imageutils.GetE2EImage(imageutils.Netexec) + var ProvidersWithSSH = []string + var RunId = uuid.NewUUID() + var SELinuxLabel = &v1.SELinuxOptions + var SchedulingLatencyMetricName = model.LabelValue(...) + var ServeHostnameImage = imageutils.GetE2EImage(imageutils.ServeHostname) + var ServiceNodePortRange = utilnet.PortRange + func AddOrUpdateAvoidPodOnNode(c clientset.Interface, nodeName string, avoidPods v1.AvoidPods) + func AddOrUpdateLabelOnNode(c clientset.Interface, nodeName string, labelKey, labelValue string) + func AddOrUpdateLabelOnNodeAndReturnOldValue(c clientset.Interface, nodeName string, labelKey, labelValue string) string + func AddOrUpdateTaintOnNode(c clientset.Interface, nodeName string, taint v1.Taint) + func AfterReadingAllFlags(t *TestContextType) + func AllNodesReady(c clientset.Interface, timeout time.Duration) error + func ApiCallToPerfData(apicalls *APIResponsiveness) *perftype.PerfData + func AssertCleanup(ns string, selectors ...string) + func BindClusterRole(c v1beta1rbac.ClusterRoleBindingsGetter, clusterRole, ns string, ...) + func BindClusterRoleInNamespace(c v1beta1rbac.RoleBindingsGetter, clusterRole, ns string, ...) + func BindRoleInNamespace(c v1beta1rbac.RoleBindingsGetter, role, ns string, ...) + func BlockNetwork(from string, to string) + func CPUUsageToPerfData(usagePerNode NodesCPUSummary) *perftype.PerfData + func CPUUsageToPerfDataWithLabels(usagePerNode NodesCPUSummary, labels map[string]string) *perftype.PerfData + func CheckAffinity(jig *ServiceTestJig, execPod *v1.Pod, targetIp string, targetPort int, ...) bool + func CheckConnectivityToHost(f *Framework, nodeName, podName, host string, pingCmd PingCommand, timeout int) error + func CheckDeploymentRevisionAndImage(c clientset.Interface, ns, deploymentName, revision, image string) error + func CheckForAllJobPodsRunning(c clientset.Interface, ns, jobName string, parallelism int32) (bool, error) + func CheckForControllerManagerHealthy(duration time.Duration) error + func CheckInvariants(events []watch.Event, fns ...InvariantFunc) error + func CheckMasterVersion(c clientset.Interface, want string) error + func CheckNewRSAnnotations(c clientset.Interface, ns, deploymentName string, ...) error + func CheckNodesReady(c clientset.Interface, size int, timeout time.Duration) ([]v1.Node, error) + func CheckNodesVersions(cs clientset.Interface, want string) error + func CheckPodsCondition(c clientset.Interface, ns string, podNames []string, timeout time.Duration, ...) bool + func CheckPodsRunningReady(c clientset.Interface, ns string, podNames []string, timeout time.Duration) bool + func CheckPodsRunningReadyOrSucceeded(c clientset.Interface, ns string, podNames []string, timeout time.Duration) bool + func CheckReachabilityFromPod(expectToBeReachable bool, timeout time.Duration, namespace, pod, target string) + func CheckTestingNSDeletedExcept(c clientset.Interface, skip string) error + func CleanUpVolumeServer(f *Framework, serverPod *v1.Pod) + func CleanUpVolumeServerWithSecret(f *Framework, serverPod *v1.Pod, secret *v1.Secret) + func Cleanup(filePath, ns string, selectors ...string) + func CleanupServiceResources(c clientset.Interface, loadBalancerName, region, zone string) + func ClusterMonitoringModeIs(monitoringModes ...string) bool + func CollectAddresses(nodes *v1.NodeList, addressType v1.NodeAddressType) []string + func ConformanceIt(text string, body interface{}, timeout ...float64) bool + func ContainerInitInvariant(older, newer runtime.Object) error + func CoreDump(dir string) + func CreateClientPod(c clientset.Interface, ns string, pvc *v1.PersistentVolumeClaim) (*v1.Pod, error) + func CreateDeployment(client clientset.Interface, replicas int32, podLabels map[string]string, ...) (*apps.Deployment, error) + func CreateEmptyFileOnPod(namespace string, podName string, filePath string) error + func CreateExecPodOrFail(client clientset.Interface, ns, generateName string, tweak func(*v1.Pod)) string + func CreateGCEVolume() (*v1.PersistentVolumeSource, string) + func CreateJob(c clientset.Interface, ns string, job *batch.Job) (*batch.Job, error) + func CreateManagedInstanceGroup(size int64, zone, template string) error + func CreateNginxPod(client clientset.Interface, namespace string, nodeSelector map[string]string, ...) (*v1.Pod, error) + func CreatePDWithRetry() (string, error) + func CreatePDWithRetryAndZone(zone string) (string, error) + func CreatePV(c clientset.Interface, pv *v1.PersistentVolume) (*v1.PersistentVolume, error) + func CreatePVC(c clientset.Interface, ns string, pvc *v1.PersistentVolumeClaim) (*v1.PersistentVolumeClaim, error) + func CreatePVCPV(c clientset.Interface, pvConfig PersistentVolumeConfig, ...) (*v1.PersistentVolume, *v1.PersistentVolumeClaim, error) + func CreatePVPVC(c clientset.Interface, pvConfig PersistentVolumeConfig, ...) (*v1.PersistentVolume, *v1.PersistentVolumeClaim, error) + func CreatePVSource(zone string) (*v1.PersistentVolumeSource, error) + func CreatePVsPVCs(numpvs, numpvcs int, c clientset.Interface, ns string, ...) (PVMap, PVCMap, error) + func CreatePod(client clientset.Interface, namespace string, nodeSelector map[string]string, ...) (*v1.Pod, error) + func CreatePodOrFail(c clientset.Interface, ns, name string, labels map[string]string, ...) + func CreatePrivilegedPSPBinding(f *Framework, namespace string) + func CreateSecPod(client clientset.Interface, namespace string, ...) (*v1.Pod, error) + func CreateSecPodWithNodeName(client clientset.Interface, namespace string, ...) (*v1.Pod, error) + func CreateServiceSpec(serviceName, externalName string, isHeadless bool, selector map[string]string) *v1.Service + func CreateStatefulSetService(name string, labels map[string]string) *v1.Service + func CreateStorageServer(cs clientset.Interface, config VolumeTestConfig) (pod *v1.Pod, ip string) + func CreateTestingNS(baseName string, c clientset.Interface, labels map[string]string) (*v1.Namespace, error) + func CreateUnschedulablePod(client clientset.Interface, namespace string, nodeSelector map[string]string, ...) (*v1.Pod, error) + func CreateWaitAndDeletePod(f *Framework, c clientset.Interface, ns string, pvc *v1.PersistentVolumeClaim) (err error) + func DeleteAllStatefulSets(c clientset.Interface, ns string) + func DeleteJob(c clientset.Interface, ns, name string) error + func DeleteManagedInstanceGroup(zone string) error + func DeleteNamespaces(c clientset.Interface, deleteFilter, skipFilter []string) ([]string, error) + func DeletePDWithRetry(diskName string) error + func DeletePVCandValidatePV(c clientset.Interface, ns string, pvc *v1.PersistentVolumeClaim, ...) error + func DeletePVCandValidatePVGroup(c clientset.Interface, ns string, pvols PVMap, claims PVCMap, ...) error + func DeletePVSource(pvSource *v1.PersistentVolumeSource) error + func DeletePersistentVolume(c clientset.Interface, pvName string) error + func DeletePersistentVolumeClaim(c clientset.Interface, pvcName string, ns string) error + func DeletePodOrFail(c clientset.Interface, ns, name string) + func DeletePodWithWait(f *Framework, c clientset.Interface, pod *v1.Pod) error + func DeletePodWithWaitByName(f *Framework, c clientset.Interface, podName, podNamespace string) error + func DeleteRCAndWaitForGC(c clientset.Interface, ns, name string) error + func DeleteResourceAndWaitForGC(c clientset.Interface, kind schema.GroupKind, ns, name string) error + func DescribeIng(ns string) + func DescribeSvc(ns string) + func DsFromManifest(url string) (*apps.DaemonSet, error) + func DumpAllNamespaceInfo(c clientset.Interface, namespace string) + func DumpDebugInfo(c clientset.Interface, ns string) + func DumpEventsInNamespace(eventsLister EventsLister, namespace string) + func DumpNodeDebugInfo(c clientset.Interface, nodeNames []string, ...) + func EnableAndDisableInternalLB() (enable func(svc *v1.Service), disable func(svc *v1.Service)) + func EnsureLoadBalancerResourcesDeleted(ip, portRange string) error + func EtcdUpgrade(target_storage, target_version string) error + func ExpectNoError(err error, explain ...interface{}) + func ExpectNoErrorWithOffset(offset int, err error, explain ...interface{}) + func ExpectNoErrorWithRetries(fn func() error, maxRetries int, explain ...interface{}) + func ExpectNodeHasLabel(c clientset.Interface, nodeName string, labelKey string, labelValue string) + func ExpectNodeHasTaint(c clientset.Interface, nodeName string, taint *v1.Taint) + func Failf(format string, args ...interface{}) + func FailfWithOffset(offset int, format string, args ...interface{}) + func FilterNodes(nodeList *v1.NodeList, fn func(node v1.Node) bool) + func FormatRuntimeOperationErrorRate(nodesResult map[string]NodeRuntimeOperationErrorRate) string + func GatherCPUProfile(componentName string, profileBaseName string, wg *sync.WaitGroup) + func GatherCPUProfileForSeconds(componentName string, profileBaseName string, seconds int, wg *sync.WaitGroup) + func GatherMemoryProfile(componentName string, profileBaseName string, wg *sync.WaitGroup) + func GenerateMasterRegexp(prefix string) string + func GetClusterZones(c clientset.Interface) (sets.String, error) + func GetGPUDevicePluginImage() string + func GetGroupNodes(group string) ([]string, error) + func GetHostExternalAddress(client clientset.Interface, p *v1.Pod) (externalAddress string, err error) + func GetIngressPoint(ing *v1.LoadBalancerIngress) string + func GetJob(c clientset.Interface, ns, name string) (*batch.Job, error) + func GetJobPods(c clientset.Interface, ns, jobName string) (*v1.PodList, error) + func GetKubeletHeapStats(c clientset.Interface, nodeName string) (string, error) + func GetKubeletPods(c clientset.Interface, node string) (*v1.PodList, error) + func GetKubeletRunningPods(c clientset.Interface, node string) (*v1.PodList, error) + func GetKubemarkMasterComponentsResourceUsage() map[string]*KubemarkResourceUsage + func GetLogToFileFunc(file *os.File) func(format string, args ...interface{}) + func GetManagedInstanceGroupTemplateName(zone string) (string, error) + func GetMasterAddress(c clientset.Interface) string + func GetMasterAndWorkerNodesOrDie(c clientset.Interface) (sets.String, *v1.NodeList) + func GetMasterHost() string + func GetNodeAddresses(node *v1.Node, addressType v1.NodeAddressType) (ips []string) + func GetNodeExternalIP(node *v1.Node) (string, error) + func GetNodeInternalIP(node *v1.Node) (string, error) + func GetNodePortURL(client clientset.Interface, ns, name string, svcPort int) (string, error) + func GetNodePublicIps(c clientset.Interface) ([]string, error) + func GetNodeTTLAnnotationValue(c clientset.Interface) (time.Duration, error) + func GetPodLogs(c clientset.Interface, namespace, podName, containerName string) (string, error) + func GetPodSecretUpdateTimeout(c clientset.Interface) time.Duration + func GetPodsForDeployment(client clientset.Interface, deployment *apps.Deployment) (*v1.PodList, error) + func GetPodsInNamespace(c clientset.Interface, ns string, ignoreLabels map[string]string) ([]*v1.Pod, error) + func GetPodsScheduled(masterNodes sets.String, pods *v1.PodList) (scheduledPods, notScheduledPods []v1.Pod) + func GetReadyNodesIncludingTaintedOrDie(c clientset.Interface) (nodes *v1.NodeList) + func GetReadySchedulableNodesOrDie(c clientset.Interface) (nodes *v1.NodeList) + func GetServerArchitecture(c clientset.Interface) string + func GetServiceLoadBalancerCreationTimeout(cs clientset.Interface) time.Duration + func GetServicesProxyRequest(c clientset.Interface, request *restclient.Request) (*restclient.Request, error) + func GetSigner(provider string) (ssh.Signer, error) + func GroupSize(group string) (int, error) + func HandleFlags() + func IngressUpgrade(isUpgrade bool) error + func InjectHtml(client clientset.Interface, config VolumeTestConfig, volume v1.VolumeSource, ...) + func IsNodeConditionSetAsExpected(node *v1.Node, conditionType v1.NodeConditionType, wantTrue bool) bool + func IsNodeConditionSetAsExpectedSilent(node *v1.Node, conditionType v1.NodeConditionType, wantTrue bool) bool + func IsNodeConditionUnset(node *v1.Node, conditionType v1.NodeConditionType) bool + func IsPodSecurityPolicyEnabled(f *Framework) bool + func IsRBACEnabled(f *Framework) bool + func IssueSSHCommand(cmd, provider string, node *v1.Node) error + func JobFinishTime(finishedJob *batch.Job) metav1.Time + func KubeDescribe(text string, body func()) bool + func KubectlCmd(args ...string) *exec.Cmd + func KubectlVersion() (*utilversion.Version, error) + func KubectlVersionGTE(v *utilversion.Version) (bool, error) + func LaunchHostExecPod(client clientset.Interface, ns, name string) *v1.Pod + func LaunchWebserverPod(f *Framework, podName, nodeName string) (ip string) + func ListNamespaceEvents(c clientset.Interface, ns string) error + func LoadClientset() (*clientset.Clientset, error) + func LoadConfig() (*restclient.Config, error) + func LoadInternalClientset() (*internalclientset.Clientset, error) + func LogClusterImageSources() + func LogContainersInPodsWithLabels(c clientset.Interface, ns string, match map[string]string, ...) + func LogFailedContainers(c clientset.Interface, ns string, ...) + func LogPodsWithLabels(c clientset.Interface, ns string, match map[string]string, ...) + func LogSSHResult(result SSHResult) + func LogSuspiciousLatency(latencyData []PodLatencyData, latencyDataLag []PodLatencyData, nodeCount int, ...) + func Logf(format string, args ...interface{}) + func LookForString(expectedString string, timeout time.Duration, fn func() string) (result string, err error) + func LookForStringInFile(ns, podName, container, file, expectedString string, timeout time.Duration) (result string, err error) + func LookForStringInLog(ns, podName, container, expectedString string, timeout time.Duration) (result string, err error) + func LookForStringInPodExec(ns, podName string, command []string, expectedString string, ...) (result string, err error) + func MakeDeployment(replicas int32, podLabels map[string]string, nodeSelector map[string]string, ...) *apps.Deployment + func MakeNginxPod(ns string, nodeSelector map[string]string, ...) *v1.Pod + func MakePersistentVolume(pvConfig PersistentVolumeConfig) *v1.PersistentVolume + func MakePersistentVolumeClaim(cfg PersistentVolumeClaimConfig, ns string) *v1.PersistentVolumeClaim + func MakePod(ns string, nodeSelector map[string]string, ...) *v1.Pod + func MakeSecPod(ns string, pvclaims []*v1.PersistentVolumeClaim, isPrivileged bool, ...) *v1.Pod + func MakeWritePod(ns string, pvc *v1.PersistentVolumeClaim) *v1.Pod + func MasterOSDistroIs(supportedMasterOsDistros ...string) bool + func MasterUpgrade(v string) error + func MasterUpgradeGCEWithKubeProxyDaemonSet(v string, enableKubeProxyDaemonSet bool) error + func MigTemplate() (string, error) + func NVIDIADevicePlugin() *v1.Pod + func NewDeployment(deploymentName string, replicas int32, podLabels map[string]string, ...) *apps.Deployment + func NewE2ETestNodePreparer(client clientset.Interface, countToStrategy []testutils.CountToStrategy) testutils.TestNodePreparer + func NewHostExecPodSpec(ns, name string) *v1.Pod + func NewKubectlCommand(args ...string) *kubectlBuilder + func NewReplicaSet(name, namespace string, replicas int32, podLabels map[string]string, ...) *apps.ReplicaSet + func NewStatefulSet(name, ns, governingSvcName string, replicas int32, ...) *apps.StatefulSet + func NewStatefulSetPVC(name string) v1.PersistentVolumeClaim + func NewStatefulSetScale(ss *apps.StatefulSet) *appsV1beta2.Scale + func NewTestJob(behavior, name string, rPol v1.RestartPolicy, parallelism, completions int32, ...) *batch.Job + func NodeAddresses(nodelist *v1.NodeList, addrType v1.NodeAddressType) []string + func NodeHasTaint(c clientset.Interface, nodeName string, taint *v1.Taint) (bool, error) + func NodeOSDistroIs(supportedNodeOsDistros ...string) bool + func NodeProxyRequest(c clientset.Interface, node, endpoint string, port int) (restclient.Result, error) + func NodeSSHHosts(c clientset.Interface) ([]string, error) + func NodeUpgrade(f *Framework, v string, img string) error + func NodeUpgradeGCEWithKubeProxyDaemonSet(f *Framework, v string, img string, enableKubeProxyDaemonSet bool) error + func NumberOfNVIDIAGPUs(node *v1.Node) int64 + func NumberOfReadyNodes(c clientset.Interface) (int, error) + func NumberOfRegisteredNodes(c clientset.Interface) (int, error) + func OpenWebSocketForURL(url *url.URL, config *restclient.Config, protocols []string) (*websocket.Conn, error) + func PVPVCCleanup(c clientset.Interface, ns string, pv *v1.PersistentVolume, ...) []error + func PVPVCMapCleanup(c clientset.Interface, ns string, pvols PVMap, claims PVCMap) []error + func ParseKVLines(output, key string) string + func PickNodeIP(c clientset.Interface) string + func PodProxyResponseChecker(c clientset.Interface, ns string, label labels.Selector, controllerName string, ...) podProxyResponseChecker + func PodStartupLatencyToPerfData(latency *PodStartupLatency) *perftype.PerfData + func PodsCreated(c clientset.Interface, ns, name string, replicas int32) (*v1.PodList, error) + func PodsCreatedByLabel(c clientset.Interface, ns, name string, replicas int32, label labels.Selector) (*v1.PodList, error) + func PodsResponding(c clientset.Interface, ns, name string, wantName bool, pods *v1.PodList) error + func PollURL(route, host string, timeout time.Duration, interval time.Duration, ...) error + func PrettyPrint(item interface{}) string + func PrettyPrintJSON(metrics interface{}) string + func PrintAllKubeletPods(c clientset.Interface, nodeName string) + func PrintLatencies(latencies []PodLatencyData, header string) + func PrintPerfData(p *perftype.PerfData) + func PrintSummaries(summaries []TestDataSummary, testBaseName string) + func PrivilegedPSP(name string) *policy.PodSecurityPolicy + func ProviderIs(providers ...string) bool + func ProxyMode(f *Framework) (string, error) + func RcByNameContainer(name string, replicas int32, image string, labels map[string]string, ...) *v1.ReplicationController + func RcByNamePort(name string, replicas int32, image string, port int, protocol v1.Protocol, ...) *v1.ReplicationController + func RealVersion(s string) (string, error) + func RegisterClusterFlags() + func RegisterCommonFlags() + func RegisterNodeFlags() + func RegisterProvider(name string, factory Factory) + func RemoveAvoidPodsOffNode(c clientset.Interface, nodeName string) + func RemoveCleanupAction(p CleanupActionHandle) + func RemoveLabelOffNode(c clientset.Interface, nodeName string, labelKey string) + func RemoveTaintOffNode(c clientset.Interface, nodeName string, taint v1.Taint) + func ResetMetrics(c clientset.Interface) error + func ResetSchedulerMetrics(c clientset.Interface) error + func ResizeGroup(group string, size int32) error + func ResourceUsageToPerfData(usagePerNode ResourceUsagePerNode) *perftype.PerfData + func ResourceUsageToPerfDataWithLabels(usagePerNode ResourceUsagePerNode, labels map[string]string) *perftype.PerfData + func RestartApiserver(cs clientset.Interface) error + func RestartControllerManager() error + func RestartKubeProxy(host string) error + func RestartKubelet(host string) error + func RestclientConfig(kubeContext string) (*clientcmdapi.Config, error) + func RunCleanupActions() + func RunCmd(command string, args ...string) (string, string, error) + func RunCmdEnv(env []string, command string, args ...string) (string, string, error) + func RunDeployment(config testutils.DeploymentConfig) error + func RunHostCmd(ns, name, cmd string) (string, error) + func RunHostCmdOrDie(ns, name, cmd string) string + func RunHostCmdWithRetries(ns, name, cmd string, interval, timeout time.Duration) (string, error) + func RunIfContainerRuntimeIs(runtimes ...string) + func RunIfSystemSpecNameIs(names ...string) + func RunKubectl(args ...string) (string, error) + func RunKubectlOrDie(args ...string) string + func RunKubectlOrDieInput(data string, args ...string) string + func RunKubemciCmd(args ...string) (string, error) + func RunKubemciWithKubeconfig(args ...string) (string, error) + func RunRC(config testutils.RCConfig) error + func RunReplicaSet(config testutils.ReplicaSetConfig) error + func ScaleDeployment(clientset clientset.Interface, scalesGetter scaleclient.ScalesGetter, ...) error + func ScaleRC(clientset clientset.Interface, scalesGetter scaleclient.ScalesGetter, ...) error + func ScaleRCByLabels(clientset clientset.Interface, scalesGetter scaleclient.ScalesGetter, ...) error + func ScaleResource(clientset clientset.Interface, scalesGetter scaleclient.ScalesGetter, ...) error + func ServerVersionGTE(v *utilversion.Version, c discovery.ServerVersionInterface) (bool, error) + func ServiceResponding(c clientset.Interface, ns, name string) error + func SimpleGET(c *http.Client, url, host string) (string, error) + func SkipIfContainerRuntimeIs(runtimes ...string) + func SkipIfMissingResource(dynamicClient dynamic.Interface, gvr schema.GroupVersionResource, ...) + func SkipIfMultizone(c clientset.Interface) + func SkipIfProviderIs(unsupportedProviders ...string) + func SkipUnlessAtLeast(value int, minValue int, message string) + func SkipUnlessClusterMonitoringModeIs(supportedMonitoring ...string) + func SkipUnlessKubectlVersionGTE(v *utilversion.Version) + func SkipUnlessLocalEphemeralStorageEnabled() + func SkipUnlessMasterOSDistroIs(supportedMasterOsDistros ...string) + func SkipUnlessMultizone(c clientset.Interface) + func SkipUnlessNodeCountIsAtLeast(minNodeCount int) + func SkipUnlessNodeCountIsAtMost(maxNodeCount int) + func SkipUnlessNodeOSDistroIs(supportedNodeOsDistros ...string) + func SkipUnlessPrometheusMonitoringIsEnabled(supportedMonitoring ...string) + func SkipUnlessProviderIs(supportedProviders ...string) + func SkipUnlessSSHKeyPresent() + func SkipUnlessSecretExistsAfterWait(c clientset.Interface, name, namespace string, timeout time.Duration) + func SkipUnlessServerVersionGTE(v *utilversion.Version, c discovery.ServerVersionInterface) + func Skipf(format string, args ...interface{}) + func StartCPUProfileGatherer(componentName string, profileBaseName string, interval time.Duration) chan struct + func StartCmdAndStreamOutput(cmd *exec.Cmd) (stdout, stderr io.ReadCloser, err error) + func StartServeHostnameService(c clientset.Interface, internalClient internalclientset.Interface, ...) ([]string, string, error) + func StartVolumeServer(client clientset.Interface, config VolumeTestConfig) *v1.Pod + func StopServeHostnameService(clientset clientset.Interface, ns, name string) error + func TargetContainers() []string + func TestHitNodesFromOutside(externalIP string, httpPort int32, timeout time.Duration, ...) error + func TestHitNodesFromOutsideWithCount(externalIP string, httpPort int32, timeout time.Duration, ...) error + func TestNotReachableHTTP(ip string, port int) (bool, error) + func TestNotReachableHTTPTimeout(ip string, port int, timeout time.Duration) (bool, error) + func TestNotReachableUDP(ip string, port int, request string) (bool, error) + func TestReachableHTTP(ip string, port int, request string, expect string) (bool, error) + func TestReachableHTTPWithContent(ip string, port int, request string, expect string, content *bytes.Buffer) (bool, error) + func TestReachableHTTPWithContentTimeout(ip string, port int, request string, expect string, content *bytes.Buffer, ...) (bool, error) + func TestReachableHTTPWithContentTimeoutWithRetriableErrorCodes(ip string, port int, request string, expect string, content *bytes.Buffer, ...) (bool, error) + func TestReachableHTTPWithRetriableErrorCodes(ip string, port int, request string, expect string, retriableErrCodes []int) (bool, error) + func TestReachableUDP(ip string, port int, request string, expect string) (bool, error) + func TestUnderTemporaryNetworkFailure(c clientset.Interface, ns string, node *v1.Node, testFunc func()) + func TestVolumeClient(client clientset.Interface, config VolumeTestConfig, fsGroup *int64, ...) + func TryKill(cmd *exec.Cmd) + func UnblockNetwork(from string, to string) + func UpdateDaemonSetWithRetries(c clientset.Interface, namespace, name string, applyUpdate updateDSFunc) (ds *apps.DaemonSet, err error) + func UpdateDeploymentWithRetries(c clientset.Interface, namespace, name string, ...) (*apps.Deployment, error) + func UpdateJob(c clientset.Interface, ns string, job *batch.Job) (*batch.Job, error) + func UpdateJobFunc(c clientset.Interface, ns, name string, updateFn func(job *batch.Job)) + func UpdateJobWithRetries(c clientset.Interface, namespace, name string, applyUpdate updateJobFunc) (job *batch.Job, err error) + func UpdatePodWithRetries(client clientset.Interface, ns, name string, update func(*v1.Pod)) (*v1.Pod, error) + func UpdateReplicaSetWithRetries(c clientset.Interface, namespace, name string, ...) (*apps.ReplicaSet, error) + func UpdateReplicationControllerWithRetries(c clientset.Interface, namespace, name string, applyUpdate updateRcFunc) (*v1.ReplicationController, error) + func UpdateService(c clientset.Interface, namespace, serviceName string, update func(*v1.Service)) (*v1.Service, error) + func UpdateStatefulSetWithRetries(c clientset.Interface, namespace, name string, ...) (statefulSet *apps.StatefulSet, err error) + func ValidateController(c clientset.Interface, containerImage string, replicas int, ...) + func ValidateEndpointsOrFail(c clientset.Interface, namespace, serviceName string, ...) + func VerifyLatencyWithinThreshold(threshold, actual LatencyMetric, metricName string) error + func VerifyPods(c clientset.Interface, ns, name string, wantName bool, replicas int32) error + func VerifyPodsRunning(c clientset.Interface, ns, name string, wantName bool, replicas int32) error + func VerifyServeHostnameServiceDown(c clientset.Interface, host string, serviceIP string, servicePort int) error + func VerifyServeHostnameServiceUp(c clientset.Interface, ns, host string, expectedPods []string, ...) error + func VerifyThatTaintIsGone(c clientset.Interface, nodeName string, taint *v1.Taint) + func VolumeTestCleanup(f *Framework, config VolumeTestConfig) + func WaitAndVerifyBinds(c clientset.Interface, ns string, pvols PVMap, claims PVCMap, ...) error + func WaitForAllJobPodsGone(c clientset.Interface, ns, jobName string) error + func WaitForAllJobPodsRunning(c clientset.Interface, ns, jobName string, parallelism int32) error + func WaitForAllNodesHealthy(c clientset.Interface, timeout time.Duration) error + func WaitForAllNodesSchedulable(c clientset.Interface, timeout time.Duration) error + func WaitForApiserverUp(c clientset.Interface) error + func WaitForAuthorizationUpdate(c v1beta1authorization.SubjectAccessReviewsGetter, ...) error + func WaitForControlledPods(c clientset.Interface, ns, name string, kind schema.GroupKind) (pods *v1.PodList, err error) + func WaitForControlledPodsRunning(c clientset.Interface, ns, name string, kind schema.GroupKind) error + func WaitForControllerManagerUp() error + func WaitForDaemonSets(c clientset.Interface, ns string, allowedNotReadyNodes int32, ...) error + func WaitForDefaultServiceAccountInNamespace(c clientset.Interface, namespace string) error + func WaitForDeploymentComplete(c clientset.Interface, d *apps.Deployment) error + func WaitForDeploymentCompleteAndCheckRolling(c clientset.Interface, d *apps.Deployment) error + func WaitForDeploymentOldRSsNum(c clientset.Interface, ns, deploymentName string, desiredRSNum int) error + func WaitForDeploymentRevision(c clientset.Interface, d *apps.Deployment, targetRevision string) error + func WaitForDeploymentRevisionAndImage(c clientset.Interface, ns, deploymentName string, revision, image string) error + func WaitForDeploymentRollbackCleared(c clientset.Interface, ns, deploymentName string) error + func WaitForDeploymentUpdatedReplicasGTE(c clientset.Interface, ns, deploymentName string, minUpdatedReplicas int32, ...) error + func WaitForDeploymentWithCondition(c clientset.Interface, ns, deploymentName, reason string, ...) error + func WaitForEndpoint(c clientset.Interface, ns, name string) error + func WaitForEvents(c clientset.Interface, ns string, objOrRef runtime.Object, ...) error + func WaitForGroupSize(group string, size int32) error + func WaitForJobComplete(c clientset.Interface, ns, jobName string, completions int32) error + func WaitForJobDeleting(c clientset.Interface, ns, jobName string) error + func WaitForJobFailure(c clientset.Interface, ns, jobName string, timeout time.Duration, ...) error + func WaitForJobFinish(c clientset.Interface, ns, jobName string) error + func WaitForJobGone(c clientset.Interface, ns, jobName string, timeout time.Duration) error + func WaitForKubeletUp(host string) error + func WaitForMasters(masterPrefix string, c clientset.Interface, size int, timeout time.Duration) error + func WaitForMatchPodsCondition(c clientset.Interface, opts metav1.ListOptions, desc string, ...) error + func WaitForNamedAuthorizationUpdate(c v1beta1authorization.SubjectAccessReviewsGetter, ...) error + func WaitForNamespacesDeleted(c clientset.Interface, namespaces []string, timeout time.Duration) error + func WaitForNodeToBe(c clientset.Interface, name string, conditionType v1.NodeConditionType, ...) bool + func WaitForNodeToBeNotReady(c clientset.Interface, name string, timeout time.Duration) bool + func WaitForNodeToBeReady(c clientset.Interface, name string, timeout time.Duration) bool + func WaitForObservedDeployment(c clientset.Interface, ns, deploymentName string, desiredGeneration int64) error + func WaitForPVClaimBoundPhase(client clientset.Interface, pvclaims []*v1.PersistentVolumeClaim, ...) ([]*v1.PersistentVolume, error) + func WaitForPartialEvents(c clientset.Interface, ns string, objOrRef runtime.Object, ...) error + func WaitForPersistentVolumeClaimDeleted(c clientset.Interface, ns string, pvcName string, Poll, timeout time.Duration) error + func WaitForPersistentVolumeClaimPhase(phase v1.PersistentVolumeClaimPhase, c clientset.Interface, ns string, ...) error + func WaitForPersistentVolumeDeleted(c clientset.Interface, pvName string, Poll, timeout time.Duration) error + func WaitForPersistentVolumePhase(phase v1.PersistentVolumePhase, c clientset.Interface, pvName string, ...) error + func WaitForPodCondition(c clientset.Interface, ns, podName, desc string, timeout time.Duration, ...) error + func WaitForPodNameRunningInNamespace(c clientset.Interface, podName, namespace string) error + func WaitForPodNameUnschedulableInNamespace(c clientset.Interface, podName, namespace string) error + func WaitForPodNoLongerRunningInNamespace(c clientset.Interface, podName, namespace string) error + func WaitForPodNotPending(c clientset.Interface, ns, podName string) error + func WaitForPodRunningInNamespace(c clientset.Interface, pod *v1.Pod) error + func WaitForPodSuccessInNamespace(c clientset.Interface, podName string, namespace string) error + func WaitForPodSuccessInNamespaceSlow(c clientset.Interface, podName string, namespace string) error + func WaitForPodToDisappear(c clientset.Interface, ns, podName string, label labels.Selector, ...) error + func WaitForPodsReady(c clientset.Interface, ns, name string, minReadySeconds int) error + func WaitForPodsRunningReady(c clientset.Interface, ns string, minPods, allowedNotReadyPods int32, ...) error + func WaitForPodsSuccess(c clientset.Interface, ns string, successPodLabels map[string]string, ...) error + func WaitForPodsWithLabel(c clientset.Interface, ns string, label labels.Selector) (pods *v1.PodList, err error) + func WaitForPodsWithLabelRunningReady(c clientset.Interface, ns string, label labels.Selector, num int, ...) (pods *v1.PodList, err error) + func WaitForPodsWithLabelScheduled(c clientset.Interface, ns string, label labels.Selector) (pods *v1.PodList, err error) + func WaitForRCPodToDisappear(c clientset.Interface, ns, rcName, podName string) error + func WaitForRCToStabilize(c clientset.Interface, ns, name string, timeout time.Duration) error + func WaitForReadyNodes(c clientset.Interface, size int, timeout time.Duration) error + func WaitForReadyReplicaSet(c clientset.Interface, ns, name string) error + func WaitForReplicaSetDesiredReplicas(rsClient appsclient.ReplicaSetsGetter, replicaSet *apps.ReplicaSet) error + func WaitForReplicaSetTargetAvailableReplicas(c clientset.Interface, replicaSet *apps.ReplicaSet, targetReplicaNum int32) error + func WaitForReplicaSetTargetSpecReplicas(c clientset.Interface, replicaSet *apps.ReplicaSet, targetReplicaNum int32) error + func WaitForReplicationController(c clientset.Interface, namespace, name string, exist bool, ...) error + func WaitForReplicationControllerwithSelector(c clientset.Interface, namespace string, selector labels.Selector, exist bool, ...) error + func WaitForService(c clientset.Interface, namespace, name string, exist bool, ...) error + func WaitForServiceEndpointsNum(c clientset.Interface, namespace, serviceName string, expectNum int, ...) error + func WaitForServiceWithSelector(c clientset.Interface, namespace string, selector labels.Selector, exist bool, ...) error + func WaitForStableCluster(c clientset.Interface, masterNodes sets.String) int + func WaitForStatefulSetReplicasReady(statefulSetName, ns string, c clientset.Interface, Poll, timeout time.Duration) error + func WaitOnPVandPVC(c clientset.Interface, ns string, pv *v1.PersistentVolume, ...) error + func WaitTimeoutForPodEvent(c clientset.Interface, podName, namespace, eventSelector, msg string, ...) error + func WaitTimeoutForPodNoLongerRunningInNamespace(c clientset.Interface, podName, namespace string, timeout time.Duration) error + func WaitTimeoutForPodRunningInNamespace(c clientset.Interface, podName, namespace string, timeout time.Duration) error + func WatchRecreateDeployment(c clientset.Interface, d *apps.Deployment) error + type APICall struct + Count int + Latency LatencyMetric + Resource string + Scope string + Subresource string + Verb string + type APIResponsiveness struct + APICalls []APICall + func HighLatencyRequests(c clientset.Interface, nodeCount int) (int, *APIResponsiveness, error) + func (a *APIResponsiveness) Len() int + func (a *APIResponsiveness) Less(i, j int) bool + func (a *APIResponsiveness) PrintHumanReadable() string + func (a *APIResponsiveness) PrintJSON() string + func (a *APIResponsiveness) SummaryKind() string + func (a *APIResponsiveness) Swap(i, j int) + type Address struct + type CleanCrdFn func() error + type CleanupActionHandle *int + func AddCleanupAction(fn func()) CleanupActionHandle + type ClientConfigGetter func() (*restclient.Config, error) + type CloudConfig struct + ApiEndpoint string + Cluster string + ClusterIPRange string + ClusterTag string + ConfigFile string + MasterName string + MasterTag string + MultiMaster bool + MultiZone bool + Network string + NodeInstanceGroup string + NodeTag string + NumNodes int + ProjectID string + Provider ProviderInterface + Region string + Zone string + type ClusterRoleBindingFactory struct + func (*ClusterRoleBindingFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *ClusterRoleBindingFactory) New() runtime.Object + type ClusterRoleFactory struct + func (*ClusterRoleFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *ClusterRoleFactory) New() runtime.Object + type ClusterVerification struct + func (cl *ClusterVerification) ForEach(podFunc func(v1.Pod)) error + func (cl *ClusterVerification) WaitFor(atLeast int, timeout time.Duration) ([]v1.Pod, error) + func (cl *ClusterVerification) WaitForOrFail(atLeast int, timeout time.Duration) + type ContainerFailures struct + Restarts int + type ContainerResourceGatherer struct + func NewResourceUsageGatherer(c clientset.Interface, options ResourceGathererOptions, pods *v1.PodList) (*ContainerResourceGatherer, error) + func (g *ContainerResourceGatherer) StartGatheringData() + func (g *ContainerResourceGatherer) StopAndSummarize(percentiles []int, constraints map[string]ResourceConstraint) (*ResourceUsageSummary, error) + type ContainerResourceUsage struct + CPUInterval time.Duration + CPUUsageInCores float64 + MemoryRSSInBytes uint64 + MemoryUsageInBytes uint64 + MemoryWorkingSetInBytes uint64 + Name string + Timestamp time.Time + type ContainersCPUSummary map[string]map[float64]float64 + type CreateTestingNSFn func(baseName string, c clientset.Interface, labels map[string]string) (*v1.Namespace, error) + type DaemonSetFactory struct + func (*DaemonSetFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *DaemonSetFactory) New() runtime.Object + type E2ETestNodePreparer struct + func (p *E2ETestNodePreparer) CleanupNodes() error + func (p *E2ETestNodePreparer) PrepareNodes() error + type EtcdMetrics struct + BackendCommitDuration HistogramVec + MaxDatabaseSize float64 + PeerRoundTripTime HistogramVec + SnapshotSaveTotalDuration HistogramVec + WalFsyncDuration HistogramVec + func (l *EtcdMetrics) PrintHumanReadable() string + func (l *EtcdMetrics) PrintJSON() string + func (l *EtcdMetrics) SummaryKind() string + type EtcdMetricsCollector struct + func NewEtcdMetricsCollector() *EtcdMetricsCollector + func (mc *EtcdMetricsCollector) GetMetrics() *EtcdMetrics + func (mc *EtcdMetricsCollector) StartCollecting(interval time.Duration) + func (mc *EtcdMetricsCollector) StopAndSummarize() error + type EventsLister func(opts metav1.ListOptions, ns string) (*v1.EventList, error) + type ExecOptions struct + CaptureStderr bool + CaptureStdout bool + Command []string + ContainerName string + Namespace string + PodName string + PreserveWhitespace bool + Stdin io.Reader + type Factory func() (ProviderInterface, error) + type FlakeReport struct + FlakeCount int + Flakes []string + func NewFlakeReport() *FlakeReport + func (f *FlakeReport) GetFlakeCount() int + func (f *FlakeReport) PrintHumanReadable() string + func (f *FlakeReport) PrintJSON() string + func (f *FlakeReport) RecordFlakeIfError(err error, optionalDescription ...interface{}) + func (f *FlakeReport) SummaryKind() string + type Framework struct + APIExtensionsClientSet apiextensionsclient.Interface + AddonResourceConstraints map[string]ResourceConstraint + AggregatorClient *aggregatorclient.Clientset + BaseName string + CSIClientSet csi.Interface + ClientSet clientset.Interface + DynamicClient dynamic.Interface + InternalClientset *internalclientset.Clientset + KubemarkExternalClusterClientSet clientset.Interface + Namespace *v1.Namespace + NamespaceDeletionTimeout time.Duration + Options FrameworkOptions + ScalesGetter scaleclient.ScalesGetter + SkipNamespaceCreation bool + SkipPrivilegedPSPBinding bool + TestSummaries []TestDataSummary + UniqueName string + func NewDefaultFramework(baseName string) *Framework + func NewFramework(baseName string, options FrameworkOptions, client clientset.Interface) *Framework + func (f *Framework) AddNamespacesToDelete(namespaces ...*v1.Namespace) + func (f *Framework) AfterEach() + func (f *Framework) BeforeEach() + func (f *Framework) CheckFileSizeViaContainer(podName, containerName, path string) (string, error) + func (f *Framework) CreateFromManifests(patch func(item interface{}) error, files ...string) (func(), error) + func (f *Framework) CreateItems(items ...interface{}) (func(), error) + func (f *Framework) CreateNamespace(baseName string, labels map[string]string) (*v1.Namespace, error) + func (f *Framework) CreatePodsPerNodeForSimpleApp(appName string, podSpec func(n v1.Node) v1.PodSpec, maxCount int) map[string]string + func (f *Framework) CreateServiceForSimpleApp(contPort, svcPort int, appName string) *v1.Service + func (f *Framework) CreateServiceForSimpleAppWithPods(contPort int, svcPort int, appName string, podSpec func(n v1.Node) v1.PodSpec, ...) (error, *v1.Service) + func (f *Framework) ExecCommandInContainer(podName, containerName string, cmd ...string) string + func (f *Framework) ExecCommandInContainerWithFullOutput(podName, containerName string, cmd ...string) (string, string, error) + func (f *Framework) ExecCommandInPod(podName string, cmd ...string) string + func (f *Framework) ExecCommandInPodWithFullOutput(podName string, cmd ...string) (string, string, error) + func (f *Framework) ExecShellInContainer(podName, containerName string, cmd string) string + func (f *Framework) ExecShellInPod(podName string, cmd string) string + func (f *Framework) ExecShellInPodWithFullOutput(podName string, cmd string) (string, string, error) + func (f *Framework) ExecWithOptions(options ExecOptions) (string, string, error) + func (f *Framework) LoadFromManifests(files ...string) ([]interface{}, error) + func (f *Framework) MatchContainerOutput(pod *v1.Pod, containerName string, expectedOutput []string, ...) error + func (f *Framework) NewClusterVerification(namespace *v1.Namespace, filter PodStateVerification) *ClusterVerification + func (f *Framework) NewTestPod(name string, requests v1.ResourceList, limits v1.ResourceList) *v1.Pod + func (f *Framework) PatchItems(items ...interface{}) error + func (f *Framework) PatchName(item *string) + func (f *Framework) PatchNamespace(item *string) + func (f *Framework) PodClient() *PodClient + func (f *Framework) PodClientNS(namespace string) *PodClient + func (f *Framework) ReadFileViaContainer(podName, containerName string, path string) (string, error) + func (f *Framework) RecordFlakeIfError(err error, optionalDescription ...interface{}) + func (f *Framework) TestContainerOutput(scenarioName string, pod *v1.Pod, containerIndex int, expectedOutput []string) + func (f *Framework) TestContainerOutputRegexp(scenarioName string, pod *v1.Pod, containerIndex int, expectedOutput []string) + func (f *Framework) WaitForPodNoLongerRunning(podName string) error + func (f *Framework) WaitForPodNotFound(podName string, timeout time.Duration) error + func (f *Framework) WaitForPodReady(podName string) error + func (f *Framework) WaitForPodRunning(podName string) error + func (f *Framework) WaitForPodRunningSlow(podName string) error + func (f *Framework) WaitForPodTerminated(podName, reason string) error + func (f *Framework) WriteFileViaContainer(podName, containerName string, path string, contents string) error + type FrameworkOptions struct + ClientBurst int + ClientQPS float32 + GroupVersion *schema.GroupVersion + type Histogram struct + Buckets map[string]int + Labels map[string]string + type HistogramVec []Histogram + type InvariantFunc func(older, newer runtime.Object) error + type ItemFactory interface + Create func(f *Framework, item interface{}) (func() error, error) + New func() runtime.Object + type KubeCluster struct + Cluster struct{ ... } + Name string + type KubeConfig struct + Clusters []KubeCluster + Contexts []struct{ ... } + Users []KubeUser + func (kc *KubeConfig) FindCluster(name string) *KubeCluster + func (kc *KubeConfig) FindUser(name string) *KubeUser + type KubeUser struct + Name string + User struct{ ... } + type KubeletLatencyMetric struct + Latency time.Duration + Method string + Operation string + Quantile float64 + type KubeletLatencyMetrics []KubeletLatencyMetric + func GetDefaultKubeletLatencyMetrics(ms metrics.KubeletMetrics) KubeletLatencyMetrics + func GetKubeletLatencyMetrics(ms metrics.KubeletMetrics, filterMetricNames sets.String) KubeletLatencyMetrics + func HighLatencyKubeletOperations(c clientset.Interface, threshold time.Duration, nodeName string, ...) (KubeletLatencyMetrics, error) + func (a KubeletLatencyMetrics) Len() int + func (a KubeletLatencyMetrics) Less(i, j int) bool + func (a KubeletLatencyMetrics) Swap(i, j int) + type KubemarkResourceUsage struct + CPUUsageInCores float64 + MemoryWorkingSetInBytes uint64 + Name string + type LatencyMetric struct + Perc100 time.Duration + Perc50 time.Duration + Perc90 time.Duration + Perc99 time.Duration + func ExtractLatencyMetrics(latencies []PodLatencyData) LatencyMetric + type LatencySlice []PodLatencyData + func (a LatencySlice) Len() int + func (a LatencySlice) Less(i, j int) bool + func (a LatencySlice) Swap(i, j int) + type LogSizeDataTimeseries map[string]map[string][]TimestampedSize + type LogSizeGatherer struct + func (g *LogSizeGatherer) Run() + func (g *LogSizeGatherer) Work() bool + type LogsSizeData struct + func (d *LogsSizeData) AddNewData(ip, path string, timestamp time.Time, size int) + type LogsSizeDataSummary map[string]map[string]SingleLogSummary + func (s *LogsSizeDataSummary) PrintHumanReadable() string + func (s *LogsSizeDataSummary) PrintJSON() string + func (s *LogsSizeDataSummary) SummaryKind() string + type LogsSizeVerifier struct + func NewLogsVerifier(c clientset.Interface, stopChannel chan bool) *LogsSizeVerifier + func (s *LogsSizeVerifier) GetSummary() *LogsSizeDataSummary + func (v *LogsSizeVerifier) Run() + type MetricsForE2E metrics.MetricsCollection + func (m *MetricsForE2E) PrintHumanReadable() string + func (m *MetricsForE2E) PrintJSON() string + func (m *MetricsForE2E) SummaryKind() string + type NetworkingTestConfig struct + ClusterIP string + EndpointPods []*v1.Pod + ExternalAddrs []string + HostTestContainerPod *v1.Pod + MaxTries int + Namespace string + NodeHttpPort int + NodeIP string + NodePortService *v1.Service + NodeUdpPort int + Nodes []v1.Node + SessionAffinityService *v1.Service + TestContainerPod *v1.Pod + func NewCoreNetworkingTestConfig(f *Framework) *NetworkingTestConfig + func NewNetworkingTestConfig(f *Framework) *NetworkingTestConfig + func (config *NetworkingTestConfig) DeleteNetProxyPod() + func (config *NetworkingTestConfig) DeleteNodePortService() + func (config *NetworkingTestConfig) DialFromContainer(protocol, containerIP, targetIP string, ...) + func (config *NetworkingTestConfig) DialFromEndpointContainer(protocol, targetIP string, targetPort, maxTries, minTries int, ...) + func (config *NetworkingTestConfig) DialFromNode(protocol, targetIP string, targetPort, maxTries, minTries int, ...) + func (config *NetworkingTestConfig) DialFromTestContainer(protocol, targetIP string, targetPort, maxTries, minTries int, ...) + func (config *NetworkingTestConfig) EndpointHostnames() sets.String + func (config *NetworkingTestConfig) GetEndpointsFromContainer(protocol, containerIP, targetIP string, ...) (sets.String, error) + func (config *NetworkingTestConfig) GetEndpointsFromTestContainer(protocol, targetIP string, targetPort, tries int) (sets.String, error) + func (config *NetworkingTestConfig) GetSelfURL(port int32, path string, expected string) + func (config *NetworkingTestConfig) GetSelfURLStatusCode(port int32, path string, expected string) + type NodeRuntimeOperationErrorRate map[string]*RuntimeOperationErrorRate + type NodeTestContextType struct + ImageDescription string + KubeletConfig kubeletconfig.KubeletConfiguration + NodeConformance bool + NodeE2E bool + NodeName string + PrepullImages bool + SystemSpecName string + type NodesCPUSummary map[string]ContainersCPUSummary + type NodesSet int + const AllNodes + const MasterAndDNSNodes + const MasterNodes + type NullProvider struct + func (n NullProvider) CleanupServiceResources(c clientset.Interface, loadBalancerName, region, zone string) + func (n NullProvider) CreatePD(zone string) (string, error) + func (n NullProvider) CreatePVSource(zone, diskName string) (*v1.PersistentVolumeSource, error) + func (n NullProvider) DeletePD(pdName string) error + func (n NullProvider) DeletePVSource(pvSource *v1.PersistentVolumeSource) error + func (n NullProvider) EnableAndDisableInternalLB() (enable, disable func(svc *v1.Service)) + func (n NullProvider) EnsureLoadBalancerResourcesDeleted(ip, portRange string) error + func (n NullProvider) FrameworkAfterEach(f *Framework) + func (n NullProvider) FrameworkBeforeEach(f *Framework) + func (n NullProvider) GetGroupNodes(group string) ([]string, error) + func (n NullProvider) GroupSize(group string) (int, error) + func (n NullProvider) LoadBalancerSrcRanges() []string + func (n NullProvider) ResizeGroup(string, int32) error + type PVCMap map[types.NamespacedName]pvcval + type PVMap map[string]pvval + type PersistentVolumeClaimConfig struct + AccessModes []v1.PersistentVolumeAccessMode + Annotations map[string]string + Selector *metav1.LabelSelector + StorageClassName *string + VolumeMode *v1.PersistentVolumeMode + type PersistentVolumeConfig struct + Labels labels.Set + NamePrefix string + NodeAffinity *v1.VolumeNodeAffinity + PVSource v1.PersistentVolumeSource + Prebind *v1.PersistentVolumeClaim + ReclaimPolicy v1.PersistentVolumeReclaimPolicy + StorageClassName string + VolumeMode *v1.PersistentVolumeMode + type PingCommand string + const IPv4PingCommand + const IPv6PingCommand + type PodClient struct + func (c *PodClient) Create(pod *v1.Pod) *v1.Pod + func (c *PodClient) CreateBatch(pods []*v1.Pod) []*v1.Pod + func (c *PodClient) CreateEventually(pod *v1.Pod, opts ...interface{}) *v1.Pod + func (c *PodClient) CreateSync(pod *v1.Pod) *v1.Pod + func (c *PodClient) CreateSyncInNamespace(pod *v1.Pod, namespace string) *v1.Pod + func (c *PodClient) DeleteSync(name string, options *metav1.DeleteOptions, timeout time.Duration) + func (c *PodClient) DeleteSyncInNamespace(name string, namespace string, options *metav1.DeleteOptions, ...) + func (c *PodClient) MatchContainerOutput(name string, containerName string, expectedRegexp string) error + func (c *PodClient) PodIsReady(name string) bool + func (c *PodClient) Update(name string, updateFn func(pod *v1.Pod)) + func (c *PodClient) WaitForErrorEventOrSuccess(pod *v1.Pod) (*v1.Event, error) + func (c *PodClient) WaitForFailure(name string, timeout time.Duration) + func (c *PodClient) WaitForSuccess(name string, timeout time.Duration) + type PodLatencyData struct + Latency time.Duration + Name string + Node string + type PodStartupLatency struct + CreateToScheduleLatency LatencyMetric + E2ELatency LatencyMetric + RunToWatchLatency LatencyMetric + ScheduleToRunLatency LatencyMetric + ScheduleToWatchLatency LatencyMetric + func (l *PodStartupLatency) PrintHumanReadable() string + func (l *PodStartupLatency) PrintJSON() string + func (l *PodStartupLatency) SummaryKind() string + type PodStateVerification struct + PodName string + Selectors map[string]string + ValidPhases []v1.PodPhase + Verify func(v1.Pod) (bool, error) + type PortsByPodName map[string][]int + type PortsByPodUID map[types.UID][]int + func GetContainerPortsByPodUID(endpoints *v1.Endpoints) PortsByPodUID + type ProviderInterface interface + CleanupServiceResources func(c clientset.Interface, loadBalancerName, region, zone string) + CreatePD func(zone string) (string, error) + CreatePVSource func(zone, diskName string) (*v1.PersistentVolumeSource, error) + DeletePD func(pdName string) error + DeletePVSource func(pvSource *v1.PersistentVolumeSource) error + EnableAndDisableInternalLB func() (enable, disable func(svc *v1.Service)) + EnsureLoadBalancerResourcesDeleted func(ip, portRange string) error + FrameworkAfterEach func(f *Framework) + FrameworkBeforeEach func(f *Framework) + GetGroupNodes func(group string) ([]string, error) + GroupSize func(group string) (int, error) + LoadBalancerSrcRanges func() []string + ResizeGroup func(group string, size int32) error + func SetupProviderConfig(providerName string) (ProviderInterface, error) + type ResourceConstraint struct + CPUConstraint float64 + MemoryConstraint uint64 + type ResourceGathererOptions struct + InKubemark bool + Nodes NodesSet + PrintVerboseLogs bool + ProbeDuration time.Duration + ResourceDataGatheringPeriod time.Duration + type ResourceMonitor struct + func NewResourceMonitor(c clientset.Interface, containerNames []string, pollingInterval time.Duration) *ResourceMonitor + func (r *ResourceMonitor) FormatCPUSummary(summary NodesCPUSummary) string + func (r *ResourceMonitor) FormatResourceUsage(s ResourceUsagePerNode) string + func (r *ResourceMonitor) GetCPUSummary() NodesCPUSummary + func (r *ResourceMonitor) GetLatest() (ResourceUsagePerNode, error) + func (r *ResourceMonitor) GetMasterNodeCPUSummary(summaryPerNode NodesCPUSummary) NodesCPUSummary + func (r *ResourceMonitor) GetMasterNodeLatest(usagePerNode ResourceUsagePerNode) ResourceUsagePerNode + func (r *ResourceMonitor) LogCPUSummary() + func (r *ResourceMonitor) LogLatest() + func (r *ResourceMonitor) Reset() + func (r *ResourceMonitor) Start() + func (r *ResourceMonitor) Stop() + type ResourceUsagePerContainer map[string]*ContainerResourceUsage + type ResourceUsagePerNode map[string]ResourceUsagePerContainer + type ResourceUsageSummary map[string][]SingleContainerSummary + func (s *ResourceUsageSummary) PrintHumanReadable() string + func (s *ResourceUsageSummary) PrintJSON() string + func (s *ResourceUsageSummary) SummaryKind() string + type RoleBindingFactory struct + func (*RoleBindingFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *RoleBindingFactory) New() runtime.Object + type RoleFactory struct + func (*RoleFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *RoleFactory) New() runtime.Object + type RuntimeOperationErrorRate struct + ErrorRate float64 + TimeoutRate float64 + TotalNumber float64 + type RuntimeOperationMonitor struct + func NewRuntimeOperationMonitor(c clientset.Interface) *RuntimeOperationMonitor + func (m *RuntimeOperationMonitor) GetLatestRuntimeOperationErrorRate() map[string]NodeRuntimeOperationErrorRate + func (m *RuntimeOperationMonitor) GetRuntimeOperationErrorRate() map[string]NodeRuntimeOperationErrorRate + type SSHResult struct + Cmd string + Code int + Host string + Stderr string + Stdout string + User string + func IssueSSHCommandWithResult(cmd, provider string, node *v1.Node) (*SSHResult, error) + func NodeExec(nodeName, cmd string) (SSHResult, error) + func SSH(cmd, host, provider string) (SSHResult, error) + type SaturationTime struct + NumberOfNodes int + NumberOfPods int + Throughput float32 + TimeToSaturate time.Duration + type SchedulingMetrics struct + BindingLatency LatencyMetric + PredicateEvaluationLatency LatencyMetric + PreemptionEvaluationLatency LatencyMetric + PriorityEvaluationLatency LatencyMetric + ThroughputAverage float64 + ThroughputPerc50 float64 + ThroughputPerc90 float64 + ThroughputPerc99 float64 + func VerifySchedulerLatency(c clientset.Interface) (*SchedulingMetrics, error) + func (l *SchedulingMetrics) PrintHumanReadable() string + func (l *SchedulingMetrics) PrintJSON() string + func (l *SchedulingMetrics) SummaryKind() string + type ServiceAccountFactory struct + func (*ServiceAccountFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *ServiceAccountFactory) New() runtime.Object + type ServiceFactory struct + func (*ServiceFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *ServiceFactory) New() runtime.Object + type ServiceTestFixture struct + Client clientset.Interface + Image string + Labels map[string]string + Name string + Namespace string + ServiceName string + TestId string + func NewServerTest(client clientset.Interface, namespace string, serviceName string) *ServiceTestFixture + func (t *ServiceTestFixture) BuildServiceSpec() *v1.Service + func (t *ServiceTestFixture) Cleanup() []error + func (t *ServiceTestFixture) CreateRC(rc *v1.ReplicationController) (*v1.ReplicationController, error) + func (t *ServiceTestFixture) CreateService(service *v1.Service) (*v1.Service, error) + func (t *ServiceTestFixture) CreateWebserverRC(replicas int32) *v1.ReplicationController + func (t *ServiceTestFixture) DeleteService(serviceName string) error + type ServiceTestJig struct + Client clientset.Interface + ID string + Labels map[string]string + Name string + func NewServiceTestJig(client clientset.Interface, name string) *ServiceTestJig + func (j *ServiceTestJig) AddRCAntiAffinity(rc *v1.ReplicationController) + func (j *ServiceTestJig) ChangeServiceNodePortOrFail(namespace, name string, initial int) *v1.Service + func (j *ServiceTestJig) ChangeServiceType(namespace, name string, newType v1.ServiceType, timeout time.Duration) + func (j *ServiceTestJig) CreateExternalNameServiceOrFail(namespace string, tweak func(svc *v1.Service)) *v1.Service + func (j *ServiceTestJig) CreateLoadBalancerService(namespace, serviceName string, timeout time.Duration, ...) *v1.Service + func (j *ServiceTestJig) CreateOnlyLocalLoadBalancerService(namespace, serviceName string, timeout time.Duration, createPod bool, ...) *v1.Service + func (j *ServiceTestJig) CreateOnlyLocalNodePortService(namespace, serviceName string, createPod bool) *v1.Service + func (j *ServiceTestJig) CreatePDBOrFail(namespace string, rc *v1.ReplicationController) *policyv1beta1.PodDisruptionBudget + func (j *ServiceTestJig) CreateServiceWithServicePort(labels map[string]string, namespace string, ports []v1.ServicePort) (*v1.Service, error) + func (j *ServiceTestJig) CreateTCPServiceOrFail(namespace string, tweak func(svc *v1.Service)) *v1.Service + func (j *ServiceTestJig) CreateTCPServiceWithPort(namespace string, tweak func(svc *v1.Service), port int32) *v1.Service + func (j *ServiceTestJig) CreateUDPServiceOrFail(namespace string, tweak func(svc *v1.Service)) *v1.Service + func (j *ServiceTestJig) GetEndpointNodes(svc *v1.Service) map[string][]string + func (j *ServiceTestJig) GetHTTPContent(host string, port int, timeout time.Duration, url string) bytes.Buffer + func (j *ServiceTestJig) GetNodes(maxNodesForTest int) (nodes *v1.NodeList) + func (j *ServiceTestJig) GetNodesNames(maxNodesForTest int) []string + func (j *ServiceTestJig) LaunchEchoserverPodOnNode(f *Framework, nodeName, podName string) + func (j *ServiceTestJig) LaunchNetexecPodOnNode(f *Framework, nodeName, podName string, httpPort, udpPort int32, ...) + func (j *ServiceTestJig) RunOrFail(namespace string, tweak func(rc *v1.ReplicationController)) *v1.ReplicationController + func (j *ServiceTestJig) SanityCheckService(svc *v1.Service, svcType v1.ServiceType) + func (j *ServiceTestJig) TestHTTPHealthCheckNodePort(host string, port int, request string, timeout time.Duration, ...) error + func (j *ServiceTestJig) TestNotReachableHTTP(host string, port int, timeout time.Duration) + func (j *ServiceTestJig) TestNotReachableUDP(host string, port int, timeout time.Duration) + func (j *ServiceTestJig) TestReachableHTTP(host string, port int, timeout time.Duration) + func (j *ServiceTestJig) TestReachableHTTPWithRetriableErrorCodes(host string, port int, retriableErrCodes []int, timeout time.Duration) + func (j *ServiceTestJig) TestReachableUDP(host string, port int, timeout time.Duration) + func (j *ServiceTestJig) UpdateService(namespace, name string, update func(*v1.Service)) (*v1.Service, error) + func (j *ServiceTestJig) UpdateServiceOrFail(namespace, name string, update func(*v1.Service)) *v1.Service + func (j *ServiceTestJig) WaitForEndpointOnNode(namespace, serviceName, nodeName string) + func (j *ServiceTestJig) WaitForLoadBalancerDestroyOrFail(namespace, name string, ip string, port int, timeout time.Duration) *v1.Service + func (j *ServiceTestJig) WaitForLoadBalancerOrFail(namespace, name string, timeout time.Duration) *v1.Service + func (j *ServiceTestJig) WaitForNewIngressIPOrFail(namespace, name, existingIP string, timeout time.Duration) *v1.Service + type SingleContainerSummary struct + Cpu float64 + Mem uint64 + Name string + type SingleLogSummary struct + AverageGenerationRate int + NumberOfProbes int + type StatefulSetFactory struct + func (*StatefulSetFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *StatefulSetFactory) New() runtime.Object + type StatefulSetTester struct + func NewStatefulSetTester(c clientset.Interface) *StatefulSetTester + func (p *StatefulSetTester) CheckServiceName(ss *apps.StatefulSet, expectedServiceName string) error + func (s *StatefulSetTester) BreakHttpProbe(ss *apps.StatefulSet) error + func (s *StatefulSetTester) BreakPodHttpProbe(ss *apps.StatefulSet, pod *v1.Pod) error + func (s *StatefulSetTester) CheckHostname(ss *apps.StatefulSet) error + func (s *StatefulSetTester) CheckMount(ss *apps.StatefulSet, mountPath string) error + func (s *StatefulSetTester) ConfirmStatefulPodCount(count int, ss *apps.StatefulSet, timeout time.Duration, hard bool) + func (s *StatefulSetTester) CreateStatefulSet(manifestPath, ns string) *apps.StatefulSet + func (s *StatefulSetTester) DeleteStatefulPodAtIndex(index int, ss *apps.StatefulSet) + func (s *StatefulSetTester) ExecInStatefulPods(ss *apps.StatefulSet, cmd string) error + func (s *StatefulSetTester) GetPodList(ss *apps.StatefulSet) *v1.PodList + func (s *StatefulSetTester) GetStatefulSet(namespace, name string) *apps.StatefulSet + func (s *StatefulSetTester) PauseNewPods(ss *apps.StatefulSet) + func (s *StatefulSetTester) Restart(ss *apps.StatefulSet) + func (s *StatefulSetTester) RestoreHttpProbe(ss *apps.StatefulSet) error + func (s *StatefulSetTester) RestorePodHttpProbe(ss *apps.StatefulSet, pod *v1.Pod) error + func (s *StatefulSetTester) ResumeNextPod(ss *apps.StatefulSet) + func (s *StatefulSetTester) Saturate(ss *apps.StatefulSet) + func (s *StatefulSetTester) Scale(ss *apps.StatefulSet, count int32) (*apps.StatefulSet, error) + func (s *StatefulSetTester) SetHttpProbe(ss *apps.StatefulSet) + func (s *StatefulSetTester) SortStatefulPods(pods *v1.PodList) + func (s *StatefulSetTester) UpdateReplicas(ss *apps.StatefulSet, count int32) + func (s *StatefulSetTester) VerifyPodAtIndex(index int, ss *apps.StatefulSet, verify VerifyStatefulPodFunc) + func (s *StatefulSetTester) WaitForPartitionedRollingUpdate(set *apps.StatefulSet) (*apps.StatefulSet, *v1.PodList) + func (s *StatefulSetTester) WaitForPodNotReady(set *apps.StatefulSet, podName string) (*apps.StatefulSet, *v1.PodList) + func (s *StatefulSetTester) WaitForPodReady(set *apps.StatefulSet, podName string) (*apps.StatefulSet, *v1.PodList) + func (s *StatefulSetTester) WaitForRollingUpdate(set *apps.StatefulSet) (*apps.StatefulSet, *v1.PodList) + func (s *StatefulSetTester) WaitForRunning(numPodsRunning, numPodsReady int32, ss *apps.StatefulSet) + func (s *StatefulSetTester) WaitForRunningAndNotReady(numStatefulPods int32, ss *apps.StatefulSet) + func (s *StatefulSetTester) WaitForRunningAndReady(numStatefulPods int32, ss *apps.StatefulSet) + func (s *StatefulSetTester) WaitForState(ss *apps.StatefulSet, until func(*apps.StatefulSet, *v1.PodList) (bool, error)) + func (s *StatefulSetTester) WaitForStatus(set *apps.StatefulSet) *apps.StatefulSet + func (s *StatefulSetTester) WaitForStatusReadyReplicas(ss *apps.StatefulSet, expectedReplicas int32) + func (s *StatefulSetTester) WaitForStatusReplicas(ss *apps.StatefulSet, expectedReplicas int32) + type StorageClassFactory struct + func (*StorageClassFactory) Create(f *Framework, i interface{}) (func() error, error) + func (f *StorageClassFactory) New() runtime.Object + type TestContextType struct + AllowGatheringProfiles bool + AllowedNotReadyNodes int + CertDir string + CleanStart bool + CloudConfig CloudConfig + ClusterMonitoringMode string + ContainerRuntime string + ContainerRuntimeEndpoint string + ContainerRuntimePidFile string + ContainerRuntimeProcessName string + CreateTestingNS CreateTestingNSFn + DeleteNamespace bool + DeleteNamespaceOnFailure bool + DisableLogDump bool + DockershimCheckpointDir string + DumpLogsOnFailure bool + EnablePrometheusMonitoring bool + EtcdUpgradeStorage string + EtcdUpgradeVersion string + FeatureGates map[string]bool + GCEUpgradeScript string + GatherKubeSystemResourceUsageData string + GatherLogsSizes bool + GatherMetricsAfterTest string + GatherSuiteMetricsAfterTest bool + Host string + ImageServiceEndpoint string + IncludeClusterAutoscalerMetrics bool + IngressUpgradeImage string + KubeAPIContentType string + KubeConfig string + KubeContext string + KubeVolumeDir string + KubectlPath string + KubernetesAnywherePath string + LogexporterGCSPath string + MasterOSDistro string + MinStartupPods int + NodeOSDistro string + NodeSchedulableTimeout time.Duration + OutputDir string + OutputPrintType string + Prefix string + Provider string + RepoRoot string + ReportDir string + ReportPrefix string + SystemDaemonsetStartupTimeout time.Duration + SystemPodsStartupTimeout time.Duration + SystemdServices string + Tooling string + VerifyServiceAccount bool + var TestContext TestContextType + type TestCrd struct + ApiExtensionClient *crdclientset.Clientset + ApiGroup string + ApiVersion string + CleanUp CleanCrdFn + Crd *apiextensionsv1beta1.CustomResourceDefinition + DynamicClient dynamic.ResourceInterface + Kind string + Name string + func CreateTestCRD(f *Framework) (*TestCrd, error) + func (c *TestCrd) GetListName() string + func (c *TestCrd) GetMetaName() string + func (c *TestCrd) GetPluralName() string + type TestDataSummary interface + PrintHumanReadable func() string + PrintJSON func() string + SummaryKind func() string + type TimestampedSize struct + type VerifyStatefulPodFunc func(*v1.Pod) + type VolumeTest struct + ExpectedContent string + File string + Volume v1.VolumeSource + type VolumeTestConfig struct + ClientNodeName string + Namespace string + NodeSelector map[string]string + Prefix string + ServerArgs []string + ServerCmds []string + ServerImage string + ServerNodeName string + ServerPorts []int + ServerReadyMessage string + ServerVolumes map[string]string + WaitForCompletion bool + func NewGlusterfsServer(cs clientset.Interface, namespace string) (config VolumeTestConfig, pod *v1.Pod, ip string) + func NewISCSIServer(cs clientset.Interface, namespace string) (config VolumeTestConfig, pod *v1.Pod, ip string) + func NewNFSServer(cs clientset.Interface, namespace string, args []string) (config VolumeTestConfig, pod *v1.Pod, ip string) + func NewRBDServer(cs clientset.Interface, namespace string) (config VolumeTestConfig, pod *v1.Pod, secret *v1.Secret, ip string) + type What struct + Kind string + func (in *What) DeepCopy() *What + func (in *What) DeepCopyInto(out *What) + func (in *What) DeepCopyObject() runtime.Object + func (in *What) GetObjectKind() schema.ObjectKind + type WorkItem struct