From 22f779849e501190a71501f29672416a75af1c7a Mon Sep 17 00:00:00 2001 From: "whenzhou.zc" Date: Mon, 29 Sep 2025 10:56:46 +0800 Subject: [PATCH] fix typos --- .../base/source/reader/SourceReaderBaseTest.java | 4 ++-- .../SplitFetcherPauseResumeSplitReaderTest.java | 2 +- .../RecreateOnResetOperatorCoordinatorTest.java | 4 ++-- .../coordinator/SourceCoordinatorProviderTest.java | 2 +- .../source/coordinator/SourceCoordinatorTest.java | 10 +++++----- .../source/coordinator/SourceCoordinatorTestBase.java | 6 +++--- .../AbstractMaterializedTableStatementITCase.java | 4 ++-- .../org/apache/flink/table/gateway/SqlGatewayTest.java | 4 ++-- .../SqlGatewayRestEndpointMaterializedTableITCase.java | 4 ++-- .../rest/SqlGatewayRestEndpointStatementITCase.java | 2 +- .../service/MaterializedTableStatementITCase.java | 2 +- .../table/gateway/service/SqlGatewayServiceITCase.java | 6 +++--- .../service/SqlGatewayServiceStatementITCase.java | 2 +- .../service/operation/OperationManagerTest.java | 4 ++-- .../gateway/service/result/ResultFetcherTest.java | 6 +++--- .../connector/testframe/container/FlinkContainers.java | 2 +- .../apache/flink/core/testutils/CommonTestUtils.java | 8 ++++---- .../test/recovery/ProcessFailureCancelingITCase.java | 2 +- 18 files changed, 37 insertions(+), 37 deletions(-) diff --git a/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/SourceReaderBaseTest.java b/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/SourceReaderBaseTest.java index 53913362e1d87..61a3171216e81 100644 --- a/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/SourceReaderBaseTest.java +++ b/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/SourceReaderBaseTest.java @@ -283,7 +283,7 @@ void testPerSplitWatermark(boolean emitRecordBeforeSplitAddition) throws Excepti sourceOperator.handleOperatorEvent(addSplitsEvent); // First 3 records from split A should not generate any watermarks - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> { try { sourceOperator.emitNext(output); @@ -298,7 +298,7 @@ void testPerSplitWatermark(boolean emitRecordBeforeSplitAddition) throws Excepti "%d out of 3 records are received within timeout", output.numRecords)); assertThat(output.watermarks).isEmpty(); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> { try { sourceOperator.emitNext(output); diff --git a/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/fetcher/SplitFetcherPauseResumeSplitReaderTest.java b/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/fetcher/SplitFetcherPauseResumeSplitReaderTest.java index 1a3c58ac71f83..2c482684ac115 100644 --- a/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/fetcher/SplitFetcherPauseResumeSplitReaderTest.java +++ b/flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/fetcher/SplitFetcherPauseResumeSplitReaderTest.java @@ -254,7 +254,7 @@ public int runUntilRecordsEmitted( throws Exception { final AtomicReference exception = new AtomicReference<>(); final AtomicInteger numFetches = new AtomicInteger(); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> { try { this.fetcherManager.runEachOnce(); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/operators/coordination/RecreateOnResetOperatorCoordinatorTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/operators/coordination/RecreateOnResetOperatorCoordinatorTest.java index bb0fedcf244c0..5eee8b19250ad 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/operators/coordination/RecreateOnResetOperatorCoordinatorTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/operators/coordination/RecreateOnResetOperatorCoordinatorTest.java @@ -116,7 +116,7 @@ void testResetToCheckpointTimeout() throws Exception { (RecreateOnResetOperatorCoordinator) provider.create(context, closingTimeoutMs); coordinator.resetToCheckpoint(2L, new byte[0]); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( context::isJobFailed, Duration.ofSeconds(5), "The job should fail due to resetToCheckpoint() timeout."); @@ -260,7 +260,7 @@ void testConsecutiveResetToCheckpoint() throws Exception { } coordinator.close(); TestingOperatorCoordinator internalCoordinator = getInternalCoordinator(coordinator); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( internalCoordinator::isClosed, Duration.ofSeconds(5), "Timed out when waiting for the coordinator to close."); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorProviderTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorProviderTest.java index 11fefa5b981a4..52704f95b47ed 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorProviderTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorProviderTest.java @@ -117,7 +117,7 @@ void testCallAsyncExceptionFailsJob() throws Exception { (ignored, e) -> { throw new RuntimeException(); }); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( context::isJobFailed, Duration.ofSeconds(10L), "The job did not fail before timeout."); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTest.java index 0bf8e526f3625..5099b349525bf 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTest.java @@ -66,7 +66,7 @@ import java.util.concurrent.TimeoutException; import java.util.function.Supplier; -import static org.apache.flink.core.testutils.CommonTestUtils.waitUtil; +import static org.apache.flink.core.testutils.CommonTestUtils.waitUntil; import static org.apache.flink.runtime.source.coordinator.CoordinatorTestUtils.verifyAssignment; import static org.apache.flink.runtime.source.coordinator.CoordinatorTestUtils.verifyException; import static org.assertj.core.api.Assertions.assertThat; @@ -300,7 +300,7 @@ public void start() { null)) { coordinator.start(); - waitUtil( + waitUntil( () -> operatorCoordinatorContext.isJobFailed(), Duration.ofSeconds(10), "The job should have failed due to the artificial exception."); @@ -356,7 +356,7 @@ public void handleSourceEvent(int subtaskId, SourceEvent sourceEvent) { coordinator.start(); coordinator.handleEventFromOperator(1, 0, new SourceEventWrapper(new SourceEvent() {})); - waitUtil( + waitUntil( () -> operatorCoordinatorContext.isJobFailed(), Duration.ofSeconds(10), "The job should have failed due to the artificial exception."); @@ -413,7 +413,7 @@ public void handleSourceEvent(int subtaskId, SourceEvent sourceEvent) { }) .get(); - waitUtil( + waitUntil( splitEnumerator::closed, Duration.ofSeconds(5), "Split enumerator was not closed in 5 seconds."); @@ -532,7 +532,7 @@ public void testSubtaskRestartAndRequestSplitsAgain() throws Exception { sourceCoordinator.executionAttemptFailed(0, attemptNumber, null); sourceCoordinator.subtaskReset(0, 99L); - waitUtilNumberReached(() -> getEnumerator().getUnassignedSplits().size(), 2); + waitUntilNumberReached(() -> getEnumerator().getUnassignedSplits().size(), 2); attemptNumber++; setReaderTaskReady(sourceCoordinator, 0, attemptNumber); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTestBase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTestBase.java index 61ece5c357fe9..9ae1d84c88410 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTestBase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTestBase.java @@ -150,12 +150,12 @@ protected void waitForCoordinatorToProcessActions() { } void waitForSentEvents(int expectedEventNumber) throws Exception { - waitUtilNumberReached(() -> receivingTasks.getNumberOfSentEvents(), expectedEventNumber); + waitUntilNumberReached(() -> receivingTasks.getNumberOfSentEvents(), expectedEventNumber); } - static void waitUtilNumberReached(Supplier numberSupplier, int expectedNumber) + static void waitUntilNumberReached(Supplier numberSupplier, int expectedNumber) throws Exception { - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> numberSupplier.get() == expectedNumber, Duration.ofDays(1), "Not reach expected number within timeout."); diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/AbstractMaterializedTableStatementITCase.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/AbstractMaterializedTableStatementITCase.java index 7ec2aad15de40..9044e581a74e8 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/AbstractMaterializedTableStatementITCase.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/AbstractMaterializedTableStatementITCase.java @@ -277,7 +277,7 @@ public void createAndVerifyCreateMaterializedTableWithData( awaitOperationTermination(service, sessionHandle, materializedTableHandle); // verify data exists in materialized table - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> fetchTableData( sessionHandle, @@ -318,7 +318,7 @@ public void verifyRefreshJobCreated( assertThat(jobDetailsInfo.getJobType()).isEqualTo(JobType.BATCH); // 3. verify the new job is finished - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> { try { return JobStatus.FINISHED.equals( diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/SqlGatewayTest.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/SqlGatewayTest.java index 83e3efaf7811a..4532c10ffc56d 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/SqlGatewayTest.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/SqlGatewayTest.java @@ -104,13 +104,13 @@ void testConfigureSqlGateway() throws Exception { .newThread(() -> SqlGateway.startSqlGateway(stream, args)); thread.start(); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> MockedSqlGatewayEndpoint.isRunning(id), Duration.ofSeconds(10), "Failed to get the endpoint starts."); thread.interrupt(); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> !thread.isAlive(), Duration.ofSeconds(10), "Failed to get the endpoint starts."); diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointMaterializedTableITCase.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointMaterializedTableITCase.java index 9a019d55ae100..ec264b767f32b 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointMaterializedTableITCase.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointMaterializedTableITCase.java @@ -119,7 +119,7 @@ void testStaticPartitionRefreshMaterializedTableViaRestAPI() throws Exception { OperationHandle operationHandle = new OperationHandle(UUID.fromString(response.getOperationHandle())); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> SQL_GATEWAY_SERVICE_EXTENSION .getService() @@ -198,7 +198,7 @@ void testPeriodicRefreshMaterializedTableViaRestAPI() throws Exception { OperationHandle operationHandle = new OperationHandle(UUID.fromString(response.getOperationHandle())); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> SQL_GATEWAY_SERVICE_EXTENSION .getService() diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointStatementITCase.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointStatementITCase.java index 5a1a4c0f8f9b2..932c5953b33d0 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointStatementITCase.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointStatementITCase.java @@ -162,7 +162,7 @@ protected String runSingleStatement(String statement) throws Exception { .getOperationManager() .getOperation(operationHandle)); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> SQL_GATEWAY_SERVICE_EXTENSION .getService() diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/MaterializedTableStatementITCase.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/MaterializedTableStatementITCase.java index 3358fee9cea14..21f1762c3e848 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/MaterializedTableStatementITCase.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/MaterializedTableStatementITCase.java @@ -431,7 +431,7 @@ void testAlterMaterializedTableRefresh() throws Exception { verifyRefreshJobCreated(restClusterClient, jobId, currentTime); // 2. verify the new job overwrite the data - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> fetchTableData(sessionHandle, "SELECT * FROM my_materialized_table").size() == data.size(), diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceITCase.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceITCase.java index e2536b0447b8b..a3bdaeda01a58 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceITCase.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceITCase.java @@ -375,7 +375,7 @@ void testOperationGetErrorAndFetchError() throws Exception { }); startRunningLatch.await(); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> service.getOperationInfo(sessionHandle, operationHandle) .getStatus() @@ -840,7 +840,7 @@ void testCancelAndCloseOperationInParallel() throws Exception { executor.submit(() -> service.closeOperation(sessionHandle, operationHandle)); } - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> service.getSession(sessionHandle).getOperationManager().getOperationCount() == 0, @@ -965,7 +965,7 @@ void testReleaseLockWhenFailedToSubmitOperation() throws Exception { success.countDown(); return getDefaultResultSet(); }); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> success.getCount() == 0, Duration.ofSeconds(10), "Should come to end."); } diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceStatementITCase.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceStatementITCase.java index a9dc23efd0ab3..dc87c17ea5233 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceStatementITCase.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/SqlGatewayServiceStatementITCase.java @@ -109,7 +109,7 @@ public void after() { protected String runSingleStatement(String statement) throws Exception { OperationHandle operationHandle = service.executeStatement(sessionHandle, statement, -1, new Configuration()); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> service.getOperationInfo(sessionHandle, operationHandle) .getStatus() diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/operation/OperationManagerTest.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/operation/OperationManagerTest.java index fec988939c644..0ebcacecf7eed 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/operation/OperationManagerTest.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/operation/OperationManagerTest.java @@ -144,7 +144,7 @@ void testCancelUninterruptedOperation() throws Exception { isRunning.compareAndSet(false, true); } }); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( isRunning::get, Duration.ofSeconds(10), "Failed to start up the task."); assertThatThrownBy(() -> operationManager.cancelOperation(operationHandle)) .satisfies( @@ -176,7 +176,7 @@ void testCloseUninterruptedOperation() throws Exception { }); }); } - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( isRunning::get, Duration.ofSeconds(10), "Failed to start up the task."); assertThatThrownBy(() -> operationManager.close()) diff --git a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/result/ResultFetcherTest.java b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/result/ResultFetcherTest.java index 286fb94e9ba1c..42d0b43688593 100644 --- a/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/result/ResultFetcherTest.java +++ b/flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/service/result/ResultFetcherTest.java @@ -222,7 +222,7 @@ void testFetchResultsMultipleTimesWithLimitedFetchSizeInOrientation() { void testFetchResultInParallel() throws Exception { ResultFetcher fetcher = buildResultFetcher(Collections.singletonList(data.iterator()), data.size() / 2); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> fetcher.getResultStore().getBufferedRecordSize() > 0, Duration.ofSeconds(10), "Failed to wait the buffer has data."); @@ -328,7 +328,7 @@ void testFetchResultAfterClose() throws Exception { meetEnd.set(true); }); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( meetEnd::get, Duration.ofSeconds(10), "Should get EOS when fetch results from the closed fetcher."); @@ -399,7 +399,7 @@ void testFetchIllegalToken() { void testFetchBeforeWithDifferentSize() throws Exception { ResultFetcher fetcher = buildResultFetcher(Collections.singletonList(data.iterator()), data.size() / 2); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> fetcher.getResultStore().getBufferedRecordSize() > 1, Duration.ofSeconds(10), "Failed to make cached records num larger than 1."); diff --git a/flink-test-utils-parent/flink-connector-test-utils/src/main/java/org/apache/flink/connector/testframe/container/FlinkContainers.java b/flink-test-utils-parent/flink-connector-test-utils/src/main/java/org/apache/flink/connector/testframe/container/FlinkContainers.java index 17d5441bd82ea..f1e5ff1cce0ed 100644 --- a/flink-test-utils-parent/flink-connector-test-utils/src/main/java/org/apache/flink/connector/testframe/container/FlinkContainers.java +++ b/flink-test-utils-parent/flink-connector-test-utils/src/main/java/org/apache/flink/connector/testframe/container/FlinkContainers.java @@ -430,7 +430,7 @@ private void waitUntilAllTaskManagerConnected() throws InterruptedException, Tim checkNotNull( restClusterClient, "REST cluster client should not be null when checking TaskManager status"); - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> { final ClusterOverviewWithVersion clusterOverview; try { diff --git a/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/core/testutils/CommonTestUtils.java b/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/core/testutils/CommonTestUtils.java index 70e474e9e8609..415ee71672d4a 100644 --- a/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/core/testutils/CommonTestUtils.java +++ b/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/core/testutils/CommonTestUtils.java @@ -201,7 +201,7 @@ public static void assertThrows( * @throws InterruptedException if the thread is interrupted. */ @SuppressWarnings("BusyWait") - public static void waitUtil( + public static void waitUntil( Supplier condition, Duration timeout, Duration pause, String errorMsg) throws TimeoutException, InterruptedException { long timeoutMs = timeout.toMillis(); @@ -245,7 +245,7 @@ public static void waitUntilIgnoringExceptions( } }; - waitUtil(safeCondition, timeout, pause, errorMsg); + waitUntil(safeCondition, timeout, pause, errorMsg); } /** @@ -258,8 +258,8 @@ public static void waitUntilIgnoringExceptions( * @throws TimeoutException if the condition is not met before timeout. * @throws InterruptedException if the thread is interrupted. */ - public static void waitUtil(Supplier condition, Duration timeout, String errorMsg) + public static void waitUntil(Supplier condition, Duration timeout, String errorMsg) throws TimeoutException, InterruptedException { - waitUtil(condition, timeout, Duration.ofMillis(1), errorMsg); + waitUntil(condition, timeout, Duration.ofMillis(1), errorMsg); } } diff --git a/flink-tests/src/test/java/org/apache/flink/test/recovery/ProcessFailureCancelingITCase.java b/flink-tests/src/test/java/org/apache/flink/test/recovery/ProcessFailureCancelingITCase.java index fb109741f9454..78acafc643ddf 100644 --- a/flink-tests/src/test/java/org/apache/flink/test/recovery/ProcessFailureCancelingITCase.java +++ b/flink-tests/src/test/java/org/apache/flink/test/recovery/ProcessFailureCancelingITCase.java @@ -257,7 +257,7 @@ public Long map(Long value) throws Exception { private static void waitUntilAtLeastOneTaskHasBeenDeployed(TestProcess taskManagerProcess) throws InterruptedException, TimeoutException { - CommonTestUtils.waitUtil( + CommonTestUtils.waitUntil( () -> taskManagerProcess .getProcessOutput()