density_test.go 18 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566
  1. // +build linux
  2. /*
  3. Copyright 2015 The Kubernetes Authors.
  4. Licensed under the Apache License, Version 2.0 (the "License");
  5. you may not use this file except in compliance with the License.
  6. You may obtain a copy of the License at
  7. http://www.apache.org/licenses/LICENSE-2.0
  8. Unless required by applicable law or agreed to in writing, software
  9. distributed under the License is distributed on an "AS IS" BASIS,
  10. WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  11. See the License for the specific language governing permissions and
  12. limitations under the License.
  13. */
  14. package e2e_node
  15. import (
  16. "fmt"
  17. "sort"
  18. "strconv"
  19. "sync"
  20. "time"
  21. "k8s.io/api/core/v1"
  22. metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
  23. "k8s.io/apimachinery/pkg/labels"
  24. "k8s.io/apimachinery/pkg/runtime"
  25. "k8s.io/apimachinery/pkg/watch"
  26. "k8s.io/client-go/tools/cache"
  27. kubeletconfig "k8s.io/kubernetes/pkg/kubelet/apis/config"
  28. stats "k8s.io/kubernetes/pkg/kubelet/apis/stats/v1alpha1"
  29. kubemetrics "k8s.io/kubernetes/pkg/kubelet/metrics"
  30. "k8s.io/kubernetes/test/e2e/framework"
  31. e2elog "k8s.io/kubernetes/test/e2e/framework/log"
  32. "k8s.io/kubernetes/test/e2e/framework/metrics"
  33. imageutils "k8s.io/kubernetes/test/utils/image"
  34. . "github.com/onsi/ginkgo"
  35. . "github.com/onsi/gomega"
  36. )
  37. const (
  38. kubeletAddr = "localhost:10255"
  39. )
  40. var _ = framework.KubeDescribe("Density [Serial] [Slow]", func() {
  41. const (
  42. // The data collection time of resource collector and the standalone cadvisor
  43. // is not synchronized, so resource collector may miss data or
  44. // collect duplicated data
  45. containerStatsPollingPeriod = 500 * time.Millisecond
  46. )
  47. var (
  48. rc *ResourceCollector
  49. )
  50. f := framework.NewDefaultFramework("density-test")
  51. BeforeEach(func() {
  52. // Start a standalone cadvisor pod using 'createSync', the pod is running when it returns
  53. f.PodClient().CreateSync(getCadvisorPod())
  54. // Resource collector monitors fine-grain CPU/memory usage by a standalone Cadvisor with
  55. // 1s housingkeeping interval
  56. rc = NewResourceCollector(containerStatsPollingPeriod)
  57. })
  58. Context("create a batch of pods", func() {
  59. // TODO(coufon): the values are generous, set more precise limits with benchmark data
  60. // and add more tests
  61. dTests := []densityTest{
  62. {
  63. podsNr: 10,
  64. interval: 0 * time.Millisecond,
  65. cpuLimits: framework.ContainersCPUSummary{
  66. stats.SystemContainerKubelet: {0.50: 0.30, 0.95: 0.50},
  67. stats.SystemContainerRuntime: {0.50: 0.40, 0.95: 0.60},
  68. },
  69. memLimits: framework.ResourceUsagePerContainer{
  70. stats.SystemContainerKubelet: &framework.ContainerResourceUsage{MemoryRSSInBytes: 100 * 1024 * 1024},
  71. stats.SystemContainerRuntime: &framework.ContainerResourceUsage{MemoryRSSInBytes: 500 * 1024 * 1024},
  72. },
  73. // percentile limit of single pod startup latency
  74. podStartupLimits: framework.LatencyMetric{
  75. Perc50: 16 * time.Second,
  76. Perc90: 18 * time.Second,
  77. Perc99: 20 * time.Second,
  78. },
  79. // upbound of startup latency of a batch of pods
  80. podBatchStartupLimit: 25 * time.Second,
  81. },
  82. }
  83. for _, testArg := range dTests {
  84. itArg := testArg
  85. desc := fmt.Sprintf("latency/resource should be within limit when create %d pods with %v interval", itArg.podsNr, itArg.interval)
  86. It(desc, func() {
  87. itArg.createMethod = "batch"
  88. testInfo := getTestNodeInfo(f, itArg.getTestName(), desc)
  89. batchLag, e2eLags := runDensityBatchTest(f, rc, itArg, testInfo, false)
  90. By("Verifying latency")
  91. logAndVerifyLatency(batchLag, e2eLags, itArg.podStartupLimits, itArg.podBatchStartupLimit, testInfo, true)
  92. By("Verifying resource")
  93. logAndVerifyResource(f, rc, itArg.cpuLimits, itArg.memLimits, testInfo, true)
  94. })
  95. }
  96. })
  97. Context("create a batch of pods", func() {
  98. dTests := []densityTest{
  99. {
  100. podsNr: 10,
  101. interval: 0 * time.Millisecond,
  102. },
  103. {
  104. podsNr: 35,
  105. interval: 0 * time.Millisecond,
  106. },
  107. {
  108. podsNr: 105,
  109. interval: 0 * time.Millisecond,
  110. },
  111. {
  112. podsNr: 10,
  113. interval: 100 * time.Millisecond,
  114. },
  115. {
  116. podsNr: 35,
  117. interval: 100 * time.Millisecond,
  118. },
  119. {
  120. podsNr: 105,
  121. interval: 100 * time.Millisecond,
  122. },
  123. {
  124. podsNr: 10,
  125. interval: 300 * time.Millisecond,
  126. },
  127. {
  128. podsNr: 35,
  129. interval: 300 * time.Millisecond,
  130. },
  131. {
  132. podsNr: 105,
  133. interval: 300 * time.Millisecond,
  134. },
  135. }
  136. for _, testArg := range dTests {
  137. itArg := testArg
  138. desc := fmt.Sprintf("latency/resource should be within limit when create %d pods with %v interval [Benchmark][NodeSpecialFeature:Benchmark]", itArg.podsNr, itArg.interval)
  139. It(desc, func() {
  140. itArg.createMethod = "batch"
  141. testInfo := getTestNodeInfo(f, itArg.getTestName(), desc)
  142. batchLag, e2eLags := runDensityBatchTest(f, rc, itArg, testInfo, true)
  143. By("Verifying latency")
  144. logAndVerifyLatency(batchLag, e2eLags, itArg.podStartupLimits, itArg.podBatchStartupLimit, testInfo, false)
  145. By("Verifying resource")
  146. logAndVerifyResource(f, rc, itArg.cpuLimits, itArg.memLimits, testInfo, false)
  147. })
  148. }
  149. })
  150. Context("create a batch of pods with higher API QPS", func() {
  151. dTests := []densityTest{
  152. {
  153. podsNr: 105,
  154. interval: 0 * time.Millisecond,
  155. APIQPSLimit: 60,
  156. },
  157. {
  158. podsNr: 105,
  159. interval: 100 * time.Millisecond,
  160. APIQPSLimit: 60,
  161. },
  162. {
  163. podsNr: 105,
  164. interval: 300 * time.Millisecond,
  165. APIQPSLimit: 60,
  166. },
  167. }
  168. for _, testArg := range dTests {
  169. itArg := testArg
  170. Context("", func() {
  171. desc := fmt.Sprintf("latency/resource should be within limit when create %d pods with %v interval (QPS %d) [Benchmark][NodeSpecialFeature:Benchmark]", itArg.podsNr, itArg.interval, itArg.APIQPSLimit)
  172. // The latency caused by API QPS limit takes a large portion (up to ~33%) of e2e latency.
  173. // It makes the pod startup latency of Kubelet (creation throughput as well) under-estimated.
  174. // Here we set API QPS limit from default 5 to 60 in order to test real Kubelet performance.
  175. // Note that it will cause higher resource usage.
  176. tempSetCurrentKubeletConfig(f, func(cfg *kubeletconfig.KubeletConfiguration) {
  177. e2elog.Logf("Old QPS limit is: %d", cfg.KubeAPIQPS)
  178. // Set new API QPS limit
  179. cfg.KubeAPIQPS = int32(itArg.APIQPSLimit)
  180. })
  181. It(desc, func() {
  182. itArg.createMethod = "batch"
  183. testInfo := getTestNodeInfo(f, itArg.getTestName(), desc)
  184. batchLag, e2eLags := runDensityBatchTest(f, rc, itArg, testInfo, true)
  185. By("Verifying latency")
  186. logAndVerifyLatency(batchLag, e2eLags, itArg.podStartupLimits, itArg.podBatchStartupLimit, testInfo, false)
  187. By("Verifying resource")
  188. logAndVerifyResource(f, rc, itArg.cpuLimits, itArg.memLimits, testInfo, false)
  189. })
  190. })
  191. }
  192. })
  193. Context("create a sequence of pods", func() {
  194. dTests := []densityTest{
  195. {
  196. podsNr: 10,
  197. bgPodsNr: 50,
  198. cpuLimits: framework.ContainersCPUSummary{
  199. stats.SystemContainerKubelet: {0.50: 0.30, 0.95: 0.50},
  200. stats.SystemContainerRuntime: {0.50: 0.40, 0.95: 0.60},
  201. },
  202. memLimits: framework.ResourceUsagePerContainer{
  203. stats.SystemContainerKubelet: &framework.ContainerResourceUsage{MemoryRSSInBytes: 100 * 1024 * 1024},
  204. stats.SystemContainerRuntime: &framework.ContainerResourceUsage{MemoryRSSInBytes: 500 * 1024 * 1024},
  205. },
  206. podStartupLimits: framework.LatencyMetric{
  207. Perc50: 5000 * time.Millisecond,
  208. Perc90: 9000 * time.Millisecond,
  209. Perc99: 10000 * time.Millisecond,
  210. },
  211. },
  212. }
  213. for _, testArg := range dTests {
  214. itArg := testArg
  215. desc := fmt.Sprintf("latency/resource should be within limit when create %d pods with %d background pods", itArg.podsNr, itArg.bgPodsNr)
  216. It(desc, func() {
  217. itArg.createMethod = "sequence"
  218. testInfo := getTestNodeInfo(f, itArg.getTestName(), desc)
  219. batchlag, e2eLags := runDensitySeqTest(f, rc, itArg, testInfo)
  220. By("Verifying latency")
  221. logAndVerifyLatency(batchlag, e2eLags, itArg.podStartupLimits, itArg.podBatchStartupLimit, testInfo, true)
  222. By("Verifying resource")
  223. logAndVerifyResource(f, rc, itArg.cpuLimits, itArg.memLimits, testInfo, true)
  224. })
  225. }
  226. })
  227. Context("create a sequence of pods", func() {
  228. dTests := []densityTest{
  229. {
  230. podsNr: 10,
  231. bgPodsNr: 50,
  232. },
  233. {
  234. podsNr: 30,
  235. bgPodsNr: 50,
  236. },
  237. {
  238. podsNr: 50,
  239. bgPodsNr: 50,
  240. },
  241. }
  242. for _, testArg := range dTests {
  243. itArg := testArg
  244. desc := fmt.Sprintf("latency/resource should be within limit when create %d pods with %d background pods [Benchmark][NodeSpeicalFeature:Benchmark]", itArg.podsNr, itArg.bgPodsNr)
  245. It(desc, func() {
  246. itArg.createMethod = "sequence"
  247. testInfo := getTestNodeInfo(f, itArg.getTestName(), desc)
  248. batchlag, e2eLags := runDensitySeqTest(f, rc, itArg, testInfo)
  249. By("Verifying latency")
  250. logAndVerifyLatency(batchlag, e2eLags, itArg.podStartupLimits, itArg.podBatchStartupLimit, testInfo, false)
  251. By("Verifying resource")
  252. logAndVerifyResource(f, rc, itArg.cpuLimits, itArg.memLimits, testInfo, false)
  253. })
  254. }
  255. })
  256. })
  257. type densityTest struct {
  258. // number of pods
  259. podsNr int
  260. // number of background pods
  261. bgPodsNr int
  262. // interval between creating pod (rate control)
  263. interval time.Duration
  264. // create pods in 'batch' or 'sequence'
  265. createMethod string
  266. // API QPS limit
  267. APIQPSLimit int
  268. // performance limits
  269. cpuLimits framework.ContainersCPUSummary
  270. memLimits framework.ResourceUsagePerContainer
  271. podStartupLimits framework.LatencyMetric
  272. podBatchStartupLimit time.Duration
  273. }
  274. func (dt *densityTest) getTestName() string {
  275. // The current default API QPS limit is 5
  276. // TODO(coufon): is there any way to not hard code this?
  277. APIQPSLimit := 5
  278. if dt.APIQPSLimit > 0 {
  279. APIQPSLimit = dt.APIQPSLimit
  280. }
  281. return fmt.Sprintf("density_create_%s_%d_%d_%d_%d", dt.createMethod, dt.podsNr, dt.bgPodsNr,
  282. dt.interval.Nanoseconds()/1000000, APIQPSLimit)
  283. }
  284. // runDensityBatchTest runs the density batch pod creation test
  285. func runDensityBatchTest(f *framework.Framework, rc *ResourceCollector, testArg densityTest, testInfo map[string]string,
  286. isLogTimeSeries bool) (time.Duration, []framework.PodLatencyData) {
  287. const (
  288. podType = "density_test_pod"
  289. sleepBeforeCreatePods = 30 * time.Second
  290. )
  291. var (
  292. mutex = &sync.Mutex{}
  293. watchTimes = make(map[string]metav1.Time, 0)
  294. stopCh = make(chan struct{})
  295. )
  296. // create test pod data structure
  297. pods := newTestPods(testArg.podsNr, true, imageutils.GetPauseImageName(), podType)
  298. // the controller watches the change of pod status
  299. controller := newInformerWatchPod(f, mutex, watchTimes, podType)
  300. go controller.Run(stopCh)
  301. defer close(stopCh)
  302. // TODO(coufon): in the test we found kubelet starts while it is busy on something, as a result 'syncLoop'
  303. // does not response to pod creation immediately. Creating the first pod has a delay around 5s.
  304. // The node status has already been 'ready' so `wait and check node being ready does not help here.
  305. // Now wait here for a grace period to let 'syncLoop' be ready
  306. time.Sleep(sleepBeforeCreatePods)
  307. rc.Start()
  308. By("Creating a batch of pods")
  309. // It returns a map['pod name']'creation time' containing the creation timestamps
  310. createTimes := createBatchPodWithRateControl(f, pods, testArg.interval)
  311. By("Waiting for all Pods to be observed by the watch...")
  312. Eventually(func() bool {
  313. return len(watchTimes) == testArg.podsNr
  314. }, 10*time.Minute, 10*time.Second).Should(BeTrue())
  315. if len(watchTimes) < testArg.podsNr {
  316. framework.Failf("Timeout reached waiting for all Pods to be observed by the watch.")
  317. }
  318. // Analyze results
  319. var (
  320. firstCreate metav1.Time
  321. lastRunning metav1.Time
  322. init = true
  323. e2eLags = make([]framework.PodLatencyData, 0)
  324. )
  325. for name, create := range createTimes {
  326. watch, ok := watchTimes[name]
  327. Expect(ok).To(Equal(true))
  328. e2eLags = append(e2eLags,
  329. framework.PodLatencyData{Name: name, Latency: watch.Time.Sub(create.Time)})
  330. if !init {
  331. if firstCreate.Time.After(create.Time) {
  332. firstCreate = create
  333. }
  334. if lastRunning.Time.Before(watch.Time) {
  335. lastRunning = watch
  336. }
  337. } else {
  338. init = false
  339. firstCreate, lastRunning = create, watch
  340. }
  341. }
  342. sort.Sort(framework.LatencySlice(e2eLags))
  343. batchLag := lastRunning.Time.Sub(firstCreate.Time)
  344. rc.Stop()
  345. deletePodsSync(f, pods)
  346. // Log time series data.
  347. if isLogTimeSeries {
  348. logDensityTimeSeries(rc, createTimes, watchTimes, testInfo)
  349. }
  350. // Log throughput data.
  351. logPodCreateThroughput(batchLag, e2eLags, testArg.podsNr, testInfo)
  352. deletePodsSync(f, []*v1.Pod{getCadvisorPod()})
  353. return batchLag, e2eLags
  354. }
  355. // runDensitySeqTest runs the density sequential pod creation test
  356. func runDensitySeqTest(f *framework.Framework, rc *ResourceCollector, testArg densityTest, testInfo map[string]string) (time.Duration, []framework.PodLatencyData) {
  357. const (
  358. podType = "density_test_pod"
  359. sleepBeforeCreatePods = 30 * time.Second
  360. )
  361. bgPods := newTestPods(testArg.bgPodsNr, true, imageutils.GetPauseImageName(), "background_pod")
  362. testPods := newTestPods(testArg.podsNr, true, imageutils.GetPauseImageName(), podType)
  363. By("Creating a batch of background pods")
  364. // CreatBatch is synchronized, all pods are running when it returns
  365. f.PodClient().CreateBatch(bgPods)
  366. time.Sleep(sleepBeforeCreatePods)
  367. rc.Start()
  368. // Create pods sequentially (back-to-back). e2eLags have been sorted.
  369. batchlag, e2eLags := createBatchPodSequential(f, testPods)
  370. rc.Stop()
  371. deletePodsSync(f, append(bgPods, testPods...))
  372. // Log throughput data.
  373. logPodCreateThroughput(batchlag, e2eLags, testArg.podsNr, testInfo)
  374. deletePodsSync(f, []*v1.Pod{getCadvisorPod()})
  375. return batchlag, e2eLags
  376. }
  377. // createBatchPodWithRateControl creates a batch of pods concurrently, uses one goroutine for each creation.
  378. // between creations there is an interval for throughput control
  379. func createBatchPodWithRateControl(f *framework.Framework, pods []*v1.Pod, interval time.Duration) map[string]metav1.Time {
  380. createTimes := make(map[string]metav1.Time)
  381. for _, pod := range pods {
  382. createTimes[pod.ObjectMeta.Name] = metav1.Now()
  383. go f.PodClient().Create(pod)
  384. time.Sleep(interval)
  385. }
  386. return createTimes
  387. }
  388. // getPodStartLatency gets prometheus metric 'pod start latency' from kubelet
  389. func getPodStartLatency(node string) (framework.KubeletLatencyMetrics, error) {
  390. latencyMetrics := framework.KubeletLatencyMetrics{}
  391. ms, err := metrics.GrabKubeletMetricsWithoutProxy(node, "/metrics")
  392. Expect(err).NotTo(HaveOccurred(), "Failed to get kubelet metrics without proxy in node %s", node)
  393. for _, samples := range ms {
  394. for _, sample := range samples {
  395. if sample.Metric["__name__"] == kubemetrics.KubeletSubsystem+"_"+kubemetrics.PodStartDurationKey {
  396. quantile, _ := strconv.ParseFloat(string(sample.Metric["quantile"]), 64)
  397. latencyMetrics = append(latencyMetrics,
  398. framework.KubeletLatencyMetric{
  399. Quantile: quantile,
  400. Method: kubemetrics.PodStartDurationKey,
  401. Latency: time.Duration(int(sample.Value)) * time.Microsecond})
  402. }
  403. }
  404. }
  405. return latencyMetrics, nil
  406. }
  407. // newInformerWatchPod creates an informer to check whether all pods are running.
  408. func newInformerWatchPod(f *framework.Framework, mutex *sync.Mutex, watchTimes map[string]metav1.Time, podType string) cache.Controller {
  409. ns := f.Namespace.Name
  410. checkPodRunning := func(p *v1.Pod) {
  411. mutex.Lock()
  412. defer mutex.Unlock()
  413. defer GinkgoRecover()
  414. if p.Status.Phase == v1.PodRunning {
  415. if _, found := watchTimes[p.Name]; !found {
  416. watchTimes[p.Name] = metav1.Now()
  417. }
  418. }
  419. }
  420. _, controller := cache.NewInformer(
  421. &cache.ListWatch{
  422. ListFunc: func(options metav1.ListOptions) (runtime.Object, error) {
  423. options.LabelSelector = labels.SelectorFromSet(labels.Set{"type": podType}).String()
  424. obj, err := f.ClientSet.CoreV1().Pods(ns).List(options)
  425. return runtime.Object(obj), err
  426. },
  427. WatchFunc: func(options metav1.ListOptions) (watch.Interface, error) {
  428. options.LabelSelector = labels.SelectorFromSet(labels.Set{"type": podType}).String()
  429. return f.ClientSet.CoreV1().Pods(ns).Watch(options)
  430. },
  431. },
  432. &v1.Pod{},
  433. 0,
  434. cache.ResourceEventHandlerFuncs{
  435. AddFunc: func(obj interface{}) {
  436. p, ok := obj.(*v1.Pod)
  437. Expect(ok).To(Equal(true))
  438. go checkPodRunning(p)
  439. },
  440. UpdateFunc: func(oldObj, newObj interface{}) {
  441. p, ok := newObj.(*v1.Pod)
  442. Expect(ok).To(Equal(true))
  443. go checkPodRunning(p)
  444. },
  445. },
  446. )
  447. return controller
  448. }
  449. // createBatchPodSequential creates pods back-to-back in sequence.
  450. func createBatchPodSequential(f *framework.Framework, pods []*v1.Pod) (time.Duration, []framework.PodLatencyData) {
  451. batchStartTime := metav1.Now()
  452. e2eLags := make([]framework.PodLatencyData, 0)
  453. for _, pod := range pods {
  454. create := metav1.Now()
  455. f.PodClient().CreateSync(pod)
  456. e2eLags = append(e2eLags,
  457. framework.PodLatencyData{Name: pod.Name, Latency: metav1.Now().Time.Sub(create.Time)})
  458. }
  459. batchLag := metav1.Now().Time.Sub(batchStartTime.Time)
  460. sort.Sort(framework.LatencySlice(e2eLags))
  461. return batchLag, e2eLags
  462. }
  463. // logAndVerifyLatency verifies that whether pod creation latency satisfies the limit.
  464. func logAndVerifyLatency(batchLag time.Duration, e2eLags []framework.PodLatencyData, podStartupLimits framework.LatencyMetric,
  465. podBatchStartupLimit time.Duration, testInfo map[string]string, isVerify bool) {
  466. framework.PrintLatencies(e2eLags, "worst client e2e total latencies")
  467. // TODO(coufon): do not trust 'kubelet' metrics since they are not reset!
  468. latencyMetrics, _ := getPodStartLatency(kubeletAddr)
  469. e2elog.Logf("Kubelet Prometheus metrics (not reset):\n%s", framework.PrettyPrintJSON(latencyMetrics))
  470. podStartupLatency := framework.ExtractLatencyMetrics(e2eLags)
  471. // log latency perf data
  472. logPerfData(getLatencyPerfData(podStartupLatency, testInfo), "latency")
  473. if isVerify {
  474. // check whether e2e pod startup time is acceptable.
  475. framework.ExpectNoError(framework.VerifyLatencyWithinThreshold(podStartupLimits, podStartupLatency, "pod startup"))
  476. // check bactch pod creation latency
  477. if podBatchStartupLimit > 0 {
  478. Expect(batchLag <= podBatchStartupLimit).To(Equal(true), "Batch creation startup time %v exceed limit %v",
  479. batchLag, podBatchStartupLimit)
  480. }
  481. }
  482. }
  483. // logThroughput calculates and logs pod creation throughput.
  484. func logPodCreateThroughput(batchLag time.Duration, e2eLags []framework.PodLatencyData, podsNr int, testInfo map[string]string) {
  485. logPerfData(getThroughputPerfData(batchLag, e2eLags, podsNr, testInfo), "throughput")
  486. }