Skip to content

Commit 22f7798

Browse files
committed
fix typos
1 parent 39a4628 commit 22f7798

File tree

18 files changed

+37
-37
lines changed

18 files changed

+37
-37
lines changed

flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/SourceReaderBaseTest.java

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -283,7 +283,7 @@ void testPerSplitWatermark(boolean emitRecordBeforeSplitAddition) throws Excepti
283283
sourceOperator.handleOperatorEvent(addSplitsEvent);
284284

285285
// First 3 records from split A should not generate any watermarks
286-
CommonTestUtils.waitUtil(
286+
CommonTestUtils.waitUntil(
287287
() -> {
288288
try {
289289
sourceOperator.emitNext(output);
@@ -298,7 +298,7 @@ void testPerSplitWatermark(boolean emitRecordBeforeSplitAddition) throws Excepti
298298
"%d out of 3 records are received within timeout", output.numRecords));
299299
assertThat(output.watermarks).isEmpty();
300300

301-
CommonTestUtils.waitUtil(
301+
CommonTestUtils.waitUntil(
302302
() -> {
303303
try {
304304
sourceOperator.emitNext(output);

flink-connectors/flink-connector-base/src/test/java/org/apache/flink/connector/base/source/reader/fetcher/SplitFetcherPauseResumeSplitReaderTest.java

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -254,7 +254,7 @@ public int runUntilRecordsEmitted(
254254
throws Exception {
255255
final AtomicReference<Exception> exception = new AtomicReference<>();
256256
final AtomicInteger numFetches = new AtomicInteger();
257-
CommonTestUtils.waitUtil(
257+
CommonTestUtils.waitUntil(
258258
() -> {
259259
try {
260260
this.fetcherManager.runEachOnce();

flink-runtime/src/test/java/org/apache/flink/runtime/operators/coordination/RecreateOnResetOperatorCoordinatorTest.java

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -116,7 +116,7 @@ void testResetToCheckpointTimeout() throws Exception {
116116
(RecreateOnResetOperatorCoordinator) provider.create(context, closingTimeoutMs);
117117

118118
coordinator.resetToCheckpoint(2L, new byte[0]);
119-
CommonTestUtils.waitUtil(
119+
CommonTestUtils.waitUntil(
120120
context::isJobFailed,
121121
Duration.ofSeconds(5),
122122
"The job should fail due to resetToCheckpoint() timeout.");
@@ -260,7 +260,7 @@ void testConsecutiveResetToCheckpoint() throws Exception {
260260
}
261261
coordinator.close();
262262
TestingOperatorCoordinator internalCoordinator = getInternalCoordinator(coordinator);
263-
CommonTestUtils.waitUtil(
263+
CommonTestUtils.waitUntil(
264264
internalCoordinator::isClosed,
265265
Duration.ofSeconds(5),
266266
"Timed out when waiting for the coordinator to close.");

flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorProviderTest.java

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -117,7 +117,7 @@ void testCallAsyncExceptionFailsJob() throws Exception {
117117
(ignored, e) -> {
118118
throw new RuntimeException();
119119
});
120-
CommonTestUtils.waitUtil(
120+
CommonTestUtils.waitUntil(
121121
context::isJobFailed,
122122
Duration.ofSeconds(10L),
123123
"The job did not fail before timeout.");

flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTest.java

Lines changed: 5 additions & 5 deletions
Original file line numberDiff line numberDiff line change
@@ -66,7 +66,7 @@
6666
import java.util.concurrent.TimeoutException;
6767
import java.util.function.Supplier;
6868

69-
import static org.apache.flink.core.testutils.CommonTestUtils.waitUtil;
69+
import static org.apache.flink.core.testutils.CommonTestUtils.waitUntil;
7070
import static org.apache.flink.runtime.source.coordinator.CoordinatorTestUtils.verifyAssignment;
7171
import static org.apache.flink.runtime.source.coordinator.CoordinatorTestUtils.verifyException;
7272
import static org.assertj.core.api.Assertions.assertThat;
@@ -300,7 +300,7 @@ public void start() {
300300
null)) {
301301

302302
coordinator.start();
303-
waitUtil(
303+
waitUntil(
304304
() -> operatorCoordinatorContext.isJobFailed(),
305305
Duration.ofSeconds(10),
306306
"The job should have failed due to the artificial exception.");
@@ -356,7 +356,7 @@ public void handleSourceEvent(int subtaskId, SourceEvent sourceEvent) {
356356
coordinator.start();
357357
coordinator.handleEventFromOperator(1, 0, new SourceEventWrapper(new SourceEvent() {}));
358358

359-
waitUtil(
359+
waitUntil(
360360
() -> operatorCoordinatorContext.isJobFailed(),
361361
Duration.ofSeconds(10),
362362
"The job should have failed due to the artificial exception.");
@@ -413,7 +413,7 @@ public void handleSourceEvent(int subtaskId, SourceEvent sourceEvent) {
413413
})
414414
.get();
415415

416-
waitUtil(
416+
waitUntil(
417417
splitEnumerator::closed,
418418
Duration.ofSeconds(5),
419419
"Split enumerator was not closed in 5 seconds.");
@@ -532,7 +532,7 @@ public void testSubtaskRestartAndRequestSplitsAgain() throws Exception {
532532
sourceCoordinator.executionAttemptFailed(0, attemptNumber, null);
533533
sourceCoordinator.subtaskReset(0, 99L);
534534

535-
waitUtilNumberReached(() -> getEnumerator().getUnassignedSplits().size(), 2);
535+
waitUntilNumberReached(() -> getEnumerator().getUnassignedSplits().size(), 2);
536536

537537
attemptNumber++;
538538
setReaderTaskReady(sourceCoordinator, 0, attemptNumber);

flink-runtime/src/test/java/org/apache/flink/runtime/source/coordinator/SourceCoordinatorTestBase.java

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -150,12 +150,12 @@ protected void waitForCoordinatorToProcessActions() {
150150
}
151151

152152
void waitForSentEvents(int expectedEventNumber) throws Exception {
153-
waitUtilNumberReached(() -> receivingTasks.getNumberOfSentEvents(), expectedEventNumber);
153+
waitUntilNumberReached(() -> receivingTasks.getNumberOfSentEvents(), expectedEventNumber);
154154
}
155155

156-
static void waitUtilNumberReached(Supplier<Integer> numberSupplier, int expectedNumber)
156+
static void waitUntilNumberReached(Supplier<Integer> numberSupplier, int expectedNumber)
157157
throws Exception {
158-
CommonTestUtils.waitUtil(
158+
CommonTestUtils.waitUntil(
159159
() -> numberSupplier.get() == expectedNumber,
160160
Duration.ofDays(1),
161161
"Not reach expected number within timeout.");

flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/AbstractMaterializedTableStatementITCase.java

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -277,7 +277,7 @@ public void createAndVerifyCreateMaterializedTableWithData(
277277
awaitOperationTermination(service, sessionHandle, materializedTableHandle);
278278

279279
// verify data exists in materialized table
280-
CommonTestUtils.waitUtil(
280+
CommonTestUtils.waitUntil(
281281
() ->
282282
fetchTableData(
283283
sessionHandle,
@@ -318,7 +318,7 @@ public void verifyRefreshJobCreated(
318318
assertThat(jobDetailsInfo.getJobType()).isEqualTo(JobType.BATCH);
319319

320320
// 3. verify the new job is finished
321-
CommonTestUtils.waitUtil(
321+
CommonTestUtils.waitUntil(
322322
() -> {
323323
try {
324324
return JobStatus.FINISHED.equals(

flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/SqlGatewayTest.java

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -104,13 +104,13 @@ void testConfigureSqlGateway() throws Exception {
104104
.newThread(() -> SqlGateway.startSqlGateway(stream, args));
105105
thread.start();
106106

107-
CommonTestUtils.waitUtil(
107+
CommonTestUtils.waitUntil(
108108
() -> MockedSqlGatewayEndpoint.isRunning(id),
109109
Duration.ofSeconds(10),
110110
"Failed to get the endpoint starts.");
111111

112112
thread.interrupt();
113-
CommonTestUtils.waitUtil(
113+
CommonTestUtils.waitUntil(
114114
() -> !thread.isAlive(),
115115
Duration.ofSeconds(10),
116116
"Failed to get the endpoint starts.");

flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointMaterializedTableITCase.java

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -119,7 +119,7 @@ void testStaticPartitionRefreshMaterializedTableViaRestAPI() throws Exception {
119119
OperationHandle operationHandle =
120120
new OperationHandle(UUID.fromString(response.getOperationHandle()));
121121

122-
CommonTestUtils.waitUtil(
122+
CommonTestUtils.waitUntil(
123123
() ->
124124
SQL_GATEWAY_SERVICE_EXTENSION
125125
.getService()
@@ -198,7 +198,7 @@ void testPeriodicRefreshMaterializedTableViaRestAPI() throws Exception {
198198
OperationHandle operationHandle =
199199
new OperationHandle(UUID.fromString(response.getOperationHandle()));
200200

201-
CommonTestUtils.waitUtil(
201+
CommonTestUtils.waitUntil(
202202
() ->
203203
SQL_GATEWAY_SERVICE_EXTENSION
204204
.getService()

flink-table/flink-sql-gateway/src/test/java/org/apache/flink/table/gateway/rest/SqlGatewayRestEndpointStatementITCase.java

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -162,7 +162,7 @@ protected String runSingleStatement(String statement) throws Exception {
162162
.getOperationManager()
163163
.getOperation(operationHandle));
164164

165-
CommonTestUtils.waitUtil(
165+
CommonTestUtils.waitUntil(
166166
() ->
167167
SQL_GATEWAY_SERVICE_EXTENSION
168168
.getService()

0 commit comments

Comments
 (0)