Versions in this module Expand all Collapse all v1 v1.16.3 Oct 23, 2019 Changes in this version + const ClaimDeletingTimeout + const ClaimProvisionShortTimeout + const ClaimProvisionTimeout + const ClusterHTTPPort + const ClusterUDPPort + const DefaultCPUProfileSeconds + const DefaultNamespaceDeletionTimeout + const DefaultNumNodes + const DefaultPodDeletionTimeout + const EndpointHTTPPort + const EndpointUDPPort + const NamespaceCleanupTimeout + const NoCPUConstraint + const NodeReadyInitialTimeout + const PodDeleteTimeout + const PodEventTimeout + const PodListTimeout + const PodReadyBeforeTimeout + const PodStartShortTimeout + const PodStartTimeout + const Poll + const PollShortTimeout + const RecreateNodeReadyAgainTimeout + const RegexIPv4 + const RegexIPv6 + const RestartNodeReadyAgainTimeout + const RestartPodReadyAgainTimeout + const ServiceAccountProvisionTimeout + const ServiceStartTimeout + const SessionAffinityChecks + const SingleCallTimeout + const SnapshotCreateTimeout + var AgnHostImage = imageutils.GetE2EImage(imageutils.Agnhost) + var BusyBoxImage = imageutils.GetE2EImage(imageutils.BusyBox) + var ImageWhiteList sets.String + var NetexecImageName = imageutils.GetE2EImage(imageutils.Agnhost) + var ProvidersWithSSH = []string + var RunID = uuid.NewUUID() + var ServeHostnameImage = imageutils.GetE2EImage(imageutils.Agnhost) + 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 AfterSuiteActions() + func AllNodesReady(c clientset.Interface, timeout time.Duration) error + func AssertCleanup(ns string, selectors ...string) + func BlockNetwork(from string, to string) + func CheckConnectivityToHost(f *Framework, nodeName, podName, host string, port, timeout int) error + func CheckForControllerManagerHealthy(duration time.Duration) error + func CheckInvariants(events []watch.Event, fns ...InvariantFunc) error + func CheckReachabilityFromPod(expectToBeReachable bool, timeout time.Duration, namespace, pod, target string) + func CheckTestingNSDeletedExcept(c clientset.Interface, skip string) error + func Cleanup(filePath, ns string, selectors ...string) + func CleanupSuite() + func ConformanceIt(text string, body interface{}, timeout ...float64) bool + func ContainerInitInvariant(older, newer runtime.Object) error + func CoreDump(dir string) + func CreateEmptyFileOnPod(namespace string, podName string, filePath string) error + func CreateManagedInstanceGroup(size int64, zone, template string) error + func CreateTestingNS(baseName string, c clientset.Interface, labels map[string]string) (*v1.Namespace, error) + func DeleteManagedInstanceGroup(zone string) error + func DeleteNamespaces(c clientset.Interface, deleteFilter, skipFilter []string) ([]string, error) + func DeleteNodeOnCloudProvider(node *v1.Node) 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 DescribeItem(item interface{}) string + func DsFromManifest(url string) (*appsv1.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 EnsureLoadBalancerResourcesDeleted(ip, portRange string) error + func EtcdUpgrade(targetStorage, targetVersion string) error + func ExpectEqual(actual interface{}, extra interface{}, explain ...interface{}) + func ExpectError(err error, explain ...interface{}) + 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 ExpectNotEqual(actual interface{}, extra interface{}, explain ...interface{}) + func Fail(msg string, callerSkip ...int) + func Failf(format string, args ...interface{}) + func FailfWithOffset(offset int, format string, args ...interface{}) + 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 GetAllMasterAddresses(c clientset.Interface) []string + func GetClusterZones(c clientset.Interface) (sets.String, error) + func GetFileModeRegex(filePath string, mask *int32) string + func GetGroupNodes(group string) ([]string, error) + func GetHostAddress(client clientset.Interface, p *v1.Pod) (string, error) + func GetHostExternalAddress(client clientset.Interface, p *v1.Pod) (externalAddress string, err error) + func GetKubemarkMasterComponentsResourceUsage() map[string]*KubemarkResourceUsage + func GetLogToFileFunc(file *os.File) func(format string, args ...interface{}) + func GetManagedInstanceGroupTemplateName(zone string) (string, error) + func GetMasterHost() string + func GetPodSecretUpdateTimeout(c clientset.Interface) time.Duration + func GetProviders() []string + func GroupSize(group string) (int, error) + func KubeDescribe(text string, body func()) bool + func KubectlCmd(args ...string) *exec.Cmd + func KubectlVersion() (*utilversion.Version, error) + func ListNamespaceEvents(c clientset.Interface, ns string) error + func LoadClientset() (*clientset.Clientset, error) + func LoadConfig() (*restclient.Config, error) + func LogClusterImageSources() + func LogFailedContainers(c clientset.Interface, ns string, ...) + func Logf(format string, args ...interface{}) + func LookForString(expectedString string, timeout time.Duration, fn func() string) (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 MasterOSDistroIs(supportedMasterOsDistros ...string) bool + func MasterUpgrade(v string) error + func MasterUpgradeGCEWithKubeProxyDaemonSet(v string, enableKubeProxyDaemonSet bool) error + func MigTemplate() (string, error) + func NewE2ETestNodePreparer(client clientset.Interface, countToStrategy []testutils.CountToStrategy) testutils.TestNodePreparer + func NodeHasTaint(c clientset.Interface, nodeName string, taint *v1.Taint) (bool, error) + func NodeOSDistroIs(supportedNodeOsDistros ...string) bool + func NodeUpgrade(f *Framework, v string, img string) error + func NodeUpgradeGCEWithKubeProxyDaemonSet(f *Framework, v string, img string, enableKubeProxyDaemonSet bool) error + func OpenWebSocketForURL(url *url.URL, config *restclient.Config, protocols []string) (*websocket.Conn, error) + func ParseKVLines(output, key string) string + func PollURL(route, host string, timeout time.Duration, interval time.Duration, ...) error + func PreconfiguredRuntimeClassHandler() string + func PrettyPrint(item interface{}) string + func PrettyPrintJSON(metrics interface{}) string + func PrintSummaries(summaries []TestDataSummary, testBaseName string) + func ProviderIs(providers ...string) bool + func ProxyMode(f *Framework) (string, error) + func PrunedStack(skip int) string + func RandomSuffix() string + func RcByNameContainer(name string, replicas int32, image string, labels map[string]string, ...) *v1.ReplicationController + func RcByNamePort(name string, replicas int32, image string, containerArgs []string, port int, ...) *v1.ReplicationController + func RegisterClusterFlags(flags *flag.FlagSet) + func RegisterCommonFlags(flags *flag.FlagSet) + func RegisterNodeFlags(flags *flag.FlagSet) + 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 ResizeGroup(group string, size int32) error + 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 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 RunKubectlInput(data string, 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 ScaleRC(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 SetupSuite() + func SetupSuitePerGinkgoNode() + 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 SkipIfNodeOSDistroIs(unsupportedNodeOsDistros ...string) + func SkipIfProviderIs(unsupportedProviders ...string) + func SkipUnlessAtLeast(value int, minValue int, message string) + 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 SkipUnlessServerVersionGTE(v *utilversion.Version, c discovery.ServerVersionInterface) + func SkipUnlessTaintBasedEvictionsEnabled() + 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 TestHitNodesFromOutside(externalIP string, httpPort int32, timeout time.Duration, ...) error + func TestHitNodesFromOutsideWithCount(externalIP string, httpPort int32, timeout time.Duration, ...) error + func TestUnderTemporaryNetworkFailure(c clientset.Interface, ns string, node *v1.Node, testFunc func()) + func TranslateIPv4ToIPv6(ip string) string + func TryKill(cmd *exec.Cmd) + func UnblockNetwork(from string, to string) + func UpdateDaemonSetWithRetries(c clientset.Interface, namespace, name string, applyUpdate updateDSFunc) (ds *appsv1.DaemonSet, err error) + func UpdateReplicationControllerWithRetries(c clientset.Interface, namespace, name string, applyUpdate updateRcFunc) (*v1.ReplicationController, error) + func ValidateController(c clientset.Interface, containerImage string, replicas int, ...) + func WaitForAllNodesSchedulable(c clientset.Interface, timeout time.Duration) error + func WaitForApiserverUp(c clientset.Interface) error + func WaitForControllerManagerUp() error + func WaitForDaemonSets(c clientset.Interface, ns string, allowedNotReadyNodes int32, ...) error + func WaitForDefaultServiceAccountInNamespace(c clientset.Interface, namespace string) error + func WaitForGroupSize(group string, size int32) error + func WaitForKubeletUp(host string) error + func WaitForMasters(masterPrefix string, c clientset.Interface, size int, timeout time.Duration) error + func WaitForNamespacesDeleted(c clientset.Interface, namespaces []string, timeout time.Duration) error + func WaitForNodeHasTaintOrNot(c clientset.Interface, nodeName string, taint *v1.Taint, wantTrue bool, ...) error + func WaitForPersistentVolumeClaimDeleted(c clientset.Interface, ns string, pvcName string, Poll, timeout time.Duration) error + func WaitForPersistentVolumeDeleted(c clientset.Interface, pvName string, Poll, timeout time.Duration) error + func WaitForRCPodToDisappear(c clientset.Interface, ns, rcName, podName string) error + func WaitForRCToStabilize(c clientset.Interface, ns, name string, timeout time.Duration) 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 + 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 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 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 CreateTestingNSFn func(baseName string, c clientset.Interface, labels map[string]string) (*v1.Namespace, error) + type E2ETestNodePreparer struct + func (p *E2ETestNodePreparer) CleanupNodes() error + func (p *E2ETestNodePreparer) PrepareNodes() 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 + AddonResourceConstraints map[string]ResourceConstraint + BaseName string + ClientSet clientset.Interface + DynamicClient dynamic.Interface + KubemarkExternalClusterClientSet clientset.Interface + Namespace *v1.Namespace + NamespaceDeletionTimeout time.Duration + Options Options + ScalesGetter scaleclient.ScalesGetter + SkipNamespaceCreation bool + SkipPrivilegedPSPBinding bool + TestSummaries []TestDataSummary + UniqueName string + func NewDefaultFramework(baseName string) *Framework + func NewFramework(baseName string, options Options, 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, ...) (*v1.Service, error) + 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) 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) NewAgnhostPod(name string, args ...string) *v1.Pod + 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 HTTPPokeParams struct + BodyContains string + ExpectCode int + RetriableCodes []int + Timeout time.Duration + type HTTPPokeResult struct + Body []byte + Code int + Error error + Status HTTPPokeStatus + func PokeHTTP(host string, port int, path string, params *HTTPPokeParams) HTTPPokeResult + type HTTPPokeStatus string + const HTTPBadResponse + const HTTPError + const HTTPRefused + const HTTPRetryCode + const HTTPSuccess + const HTTPTimeout + const HTTPWrongCode + 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 KubectlBuilder struct + func NewKubectlCommand(args ...string) *KubectlBuilder + func (b *KubectlBuilder) WithEnv(env []string) *KubectlBuilder + func (b *KubectlBuilder) WithTimeout(t <-chan time.Time) *KubectlBuilder + func (b KubectlBuilder) Exec() (string, error) + func (b KubectlBuilder) ExecOrDie() string + func (b KubectlBuilder) WithStdinData(data string) *KubectlBuilder + func (b KubectlBuilder) WithStdinReader(reader io.Reader) *KubectlBuilder + type KubemarkResourceUsage struct + CPUUsageInCores float64 + MemoryWorkingSetInBytes uint64 + Name string + type LogSizeDataTimeseries map[string]map[string][]TimestampedSize + type LogSizeGatherer struct + func (g *LogSizeGatherer) Run() + func (g *LogSizeGatherer) Work() bool + type LogsSizeData struct + 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 (s *LogsSizeVerifier) Run() + type NetworkingTestConfig struct + ClusterIP string + EndpointPods []*v1.Pod + ExternalAddrs []string + HostNetwork bool + 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, hostNetwork bool) *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 NodeKiller struct + func NewNodeKiller(config NodeKillerConfig, client clientset.Interface, provider string) *NodeKiller + func (k *NodeKiller) Run(stopCh <-chan struct{}) + type NodeKillerConfig struct + Enabled bool + FailureRatio float64 + Interval time.Duration + JitterFactor float64 + NodeKillerStopCh chan struct{} + SimulatedDowntime time.Duration + type NodeTestContextType struct + ExtraEnvs map[string]string + ImageDescription string + KubeletConfig kubeletconfig.KubeletConfiguration + NodeConformance bool + NodeE2E bool + NodeName string + PrepullImages bool + SystemSpecName string + 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) DeleteNode(node *v1.Node) 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 Options struct + ClientBurst int + ClientQPS float32 + GroupVersion *schema.GroupVersion + 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) WaitForFinish(name string, timeout time.Duration) + func (c *PodClient) WaitForSuccess(name string, timeout time.Duration) + type PodStateVerification struct + PodName string + Selectors map[string]string + ValidPhases []v1.PodPhase + Verify func(v1.Pod) (bool, error) + 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) + DeleteNode func(node *v1.Node) 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 ResourceUsageSummary map[string][]SingleContainerSummary + func (s *ResourceUsageSummary) PrintHumanReadable() string + func (s *ResourceUsageSummary) PrintJSON() string + func (s *ResourceUsageSummary) SummaryKind() string + type SingleContainerSummary struct + CPU float64 + Mem uint64 + Name string + type SingleLogSummary struct + AverageGenerationRate int + NumberOfProbes int + type TestContextType struct + AllowGatheringProfiles bool + AllowedNotReadyNodes int + CertDir string + CleanStart bool + CloudConfig CloudConfig + ClusterDNSDomain string + ClusterMonitoringMode string + ContainerRuntime string + ContainerRuntimeEndpoint string + ContainerRuntimePidFile string + ContainerRuntimeProcessName string + CreateTestingNS CreateTestingNSFn + DeleteNamespace bool + DeleteNamespaceOnFailure bool + DisableLogDump bool + DockershimCheckpointDir string + DumpLogsOnFailure bool + DumpSystemdJournal bool + EnablePrometheusMonitoring bool + EtcdUpgradeStorage string + EtcdUpgradeVersion string + FeatureGates map[string]bool + GCEUpgradeScript string + GatherKubeSystemResourceUsageData string + GatherLogsSizes bool + GatherMetricsAfterTest string + GatherSuiteMetricsAfterTest bool + Host string + IPFamily string + ImageServiceEndpoint string + IncludeClusterAutoscalerMetrics bool + KubeAPIContentType string + KubeConfig string + KubeContext string + KubeVolumeDir string + KubectlPath string + KubernetesAnywherePath string + ListImages bool + LogexporterGCSPath string + MasterOSDistro string + MaxNodesToGather int + MinStartupPods int + NodeKiller NodeKillerConfig + NodeOSDistro string + NodeSchedulableTimeout time.Duration + NonblockingTaints string + 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 + func (tc TestContextType) ClusterIsIPv6() bool + type TestDataSummary interface + PrintHumanReadable func() string + PrintJSON func() string + SummaryKind func() string + type TimestampedSize struct + type UDPPokeParams struct + Response string + Timeout time.Duration + type UDPPokeResult struct + Error error + Response []byte + Status UDPPokeStatus + func PokeUDP(host string, port int, request string, params *UDPPokeParams) UDPPokeResult + type UDPPokeStatus string + const UDPBadResponse + const UDPError + const UDPRefused + const UDPSuccess + const UDPTimeout + 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