You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@flink.apache.org by "Yun Gao (Jira)" <ji...@apache.org> on 2022/02/10 07:39:00 UTC

[jira] [Created] (FLINK-26069) KinesisFirehoseSinkITCase failed due to org.testcontainers.containers.ContainerLaunchException: Container startup failed

Yun Gao created FLINK-26069:
-------------------------------

             Summary: KinesisFirehoseSinkITCase failed due to org.testcontainers.containers.ContainerLaunchException: Container startup failed
                 Key: FLINK-26069
                 URL: https://issues.apache.org/jira/browse/FLINK-26069
             Project: Flink
          Issue Type: Bug
          Components: Connectors / Kinesis
    Affects Versions: 1.15.0
            Reporter: Yun Gao



{code:java}
2022-02-09T20:52:36.6208358Z Feb 09 20:52:36 [ERROR] Picked up JAVA_TOOL_OPTIONS: -XX:+HeapDumpOnOutOfMemoryError
2022-02-09T20:52:37.8270432Z Feb 09 20:52:37 [INFO] Running org.apache.flink.connector.firehose.sink.KinesisFirehoseSinkITCase
2022-02-09T20:54:08.9842331Z Feb 09 20:54:08 [ERROR] Tests run: 1, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 91.02 s <<< FAILURE! - in org.apache.flink.connector.firehose.sink.KinesisFirehoseSinkITCase
2022-02-09T20:54:08.9845140Z Feb 09 20:54:08 [ERROR] org.apache.flink.connector.firehose.sink.KinesisFirehoseSinkITCase  Time elapsed: 91.02 s  <<< ERROR!
2022-02-09T20:54:08.9847119Z Feb 09 20:54:08 org.testcontainers.containers.ContainerLaunchException: Container startup failed
2022-02-09T20:54:08.9848834Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.doStart(GenericContainer.java:336)
2022-02-09T20:54:08.9850502Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.start(GenericContainer.java:317)
2022-02-09T20:54:08.9852012Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.starting(GenericContainer.java:1066)
2022-02-09T20:54:08.9853695Z Feb 09 20:54:08 	at org.testcontainers.containers.FailureDetectingExternalResource$1.evaluate(FailureDetectingExternalResource.java:29)
2022-02-09T20:54:08.9855316Z Feb 09 20:54:08 	at org.junit.rules.RunRules.evaluate(RunRules.java:20)
2022-02-09T20:54:08.9856955Z Feb 09 20:54:08 	at org.junit.runners.ParentRunner$3.evaluate(ParentRunner.java:306)
2022-02-09T20:54:08.9858330Z Feb 09 20:54:08 	at org.junit.runners.ParentRunner.run(ParentRunner.java:413)
2022-02-09T20:54:08.9859838Z Feb 09 20:54:08 	at org.junit.runner.JUnitCore.run(JUnitCore.java:137)
2022-02-09T20:54:08.9861123Z Feb 09 20:54:08 	at org.junit.runner.JUnitCore.run(JUnitCore.java:115)
2022-02-09T20:54:08.9862747Z Feb 09 20:54:08 	at org.junit.vintage.engine.execution.RunnerExecutor.execute(RunnerExecutor.java:42)
2022-02-09T20:54:08.9864691Z Feb 09 20:54:08 	at org.junit.vintage.engine.VintageTestEngine.executeAllChildren(VintageTestEngine.java:80)
2022-02-09T20:54:08.9866384Z Feb 09 20:54:08 	at org.junit.vintage.engine.VintageTestEngine.execute(VintageTestEngine.java:72)
2022-02-09T20:54:08.9868138Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.EngineExecutionOrchestrator.execute(EngineExecutionOrchestrator.java:107)
2022-02-09T20:54:08.9869980Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.EngineExecutionOrchestrator.execute(EngineExecutionOrchestrator.java:88)
2022-02-09T20:54:08.9871255Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.EngineExecutionOrchestrator.lambda$execute$0(EngineExecutionOrchestrator.java:54)
2022-02-09T20:54:08.9872602Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.EngineExecutionOrchestrator.withInterceptedStreams(EngineExecutionOrchestrator.java:67)
2022-02-09T20:54:08.9874126Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.EngineExecutionOrchestrator.execute(EngineExecutionOrchestrator.java:52)
2022-02-09T20:54:08.9875899Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.DefaultLauncher.execute(DefaultLauncher.java:114)
2022-02-09T20:54:08.9877109Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.DefaultLauncher.execute(DefaultLauncher.java:86)
2022-02-09T20:54:08.9878367Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.DefaultLauncherSession$DelegatingLauncher.execute(DefaultLauncherSession.java:86)
2022-02-09T20:54:08.9879761Z Feb 09 20:54:08 	at org.junit.platform.launcher.core.SessionPerRequestLauncher.execute(SessionPerRequestLauncher.java:53)
2022-02-09T20:54:08.9881148Z Feb 09 20:54:08 	at org.apache.maven.surefire.junitplatform.JUnitPlatformProvider.execute(JUnitPlatformProvider.java:188)
2022-02-09T20:54:08.9882768Z Feb 09 20:54:08 	at org.apache.maven.surefire.junitplatform.JUnitPlatformProvider.invokeAllTests(JUnitPlatformProvider.java:154)
2022-02-09T20:54:08.9884214Z Feb 09 20:54:08 	at org.apache.maven.surefire.junitplatform.JUnitPlatformProvider.invoke(JUnitPlatformProvider.java:124)
2022-02-09T20:54:08.9885475Z Feb 09 20:54:08 	at org.apache.maven.surefire.booter.ForkedBooter.runSuitesInProcess(ForkedBooter.java:428)
2022-02-09T20:54:08.9886856Z Feb 09 20:54:08 	at org.apache.maven.surefire.booter.ForkedBooter.execute(ForkedBooter.java:162)
2022-02-09T20:54:08.9888037Z Feb 09 20:54:08 	at org.apache.maven.surefire.booter.ForkedBooter.run(ForkedBooter.java:562)
2022-02-09T20:54:08.9889181Z Feb 09 20:54:08 	at org.apache.maven.surefire.booter.ForkedBooter.main(ForkedBooter.java:548)
2022-02-09T20:54:08.9890330Z Feb 09 20:54:08 Caused by: org.rnorth.ducttape.RetryCountExceededException: Retry limit hit with exception
2022-02-09T20:54:08.9891485Z Feb 09 20:54:08 	at org.rnorth.ducttape.unreliables.Unreliables.retryUntilSuccess(Unreliables.java:88)
2022-02-09T20:54:08.9892704Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.doStart(GenericContainer.java:329)
2022-02-09T20:54:08.9893701Z Feb 09 20:54:08 	... 27 more
2022-02-09T20:54:08.9894927Z Feb 09 20:54:08 Caused by: org.testcontainers.containers.ContainerLaunchException: Could not create/start container
2022-02-09T20:54:08.9896924Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.tryStart(GenericContainer.java:525)
2022-02-09T20:54:08.9898077Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.lambda$doStart$0(GenericContainer.java:331)
2022-02-09T20:54:08.9900406Z Feb 09 20:54:08 	at org.rnorth.ducttape.unreliables.Unreliables.retryUntilSuccess(Unreliables.java:81)
2022-02-09T20:54:08.9902108Z Feb 09 20:54:08 	... 28 more
2022-02-09T20:54:08.9903113Z Feb 09 20:54:08 Caused by: org.rnorth.ducttape.TimeoutException: Timeout waiting for result with exception
2022-02-09T20:54:08.9904522Z Feb 09 20:54:08 	at org.rnorth.ducttape.unreliables.Unreliables.retryUntilSuccess(Unreliables.java:54)
2022-02-09T20:54:08.9906132Z Feb 09 20:54:08 	at org.apache.flink.connector.aws.testutils.LocalstackContainer$ListBucketObjectsWaitStrategy.waitUntilReady(LocalstackContainer.java:70)
2022-02-09T20:54:08.9907813Z Feb 09 20:54:08 	at org.testcontainers.containers.wait.strategy.AbstractWaitStrategy.waitUntilReady(AbstractWaitStrategy.java:51)
2022-02-09T20:54:08.9909611Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.waitUntilContainerStarted(GenericContainer.java:929)
2022-02-09T20:54:08.9911042Z Feb 09 20:54:08 	at org.testcontainers.containers.GenericContainer.tryStart(GenericContainer.java:468)
2022-02-09T20:54:08.9912050Z Feb 09 20:54:08 	... 30 more
2022-02-09T20:54:08.9913241Z Feb 09 20:54:08 Caused by: java.util.concurrent.ExecutionException: software.amazon.awssdk.core.exception.SdkClientException: An exception was thrown and did not match any waiter acceptors
2022-02-09T20:54:08.9914974Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:357)
2022-02-09T20:54:08.9916308Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:1908)
2022-02-09T20:54:08.9918149Z Feb 09 20:54:08 	at org.apache.flink.connector.aws.testutils.AWSServicesTestUtils.createBucket(AWSServicesTestUtils.java:112)
2022-02-09T20:54:08.9919961Z Feb 09 20:54:08 	at org.apache.flink.connector.aws.testutils.LocalstackContainer$ListBucketObjectsWaitStrategy.list(LocalstackContainer.java:82)
2022-02-09T20:54:08.9921284Z Feb 09 20:54:08 	at org.rnorth.ducttape.ratelimits.RateLimiter.getWhenReady(RateLimiter.java:51)
2022-02-09T20:54:08.9922741Z Feb 09 20:54:08 	at org.apache.flink.connector.aws.testutils.LocalstackContainer$ListBucketObjectsWaitStrategy.lambda$waitUntilReady$0(LocalstackContainer.java:73)
2022-02-09T20:54:08.9924349Z Feb 09 20:54:08 	at org.rnorth.ducttape.unreliables.Unreliables.lambda$retryUntilSuccess$0(Unreliables.java:43)
2022-02-09T20:54:08.9925981Z Feb 09 20:54:08 	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
2022-02-09T20:54:08.9927176Z Feb 09 20:54:08 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
2022-02-09T20:54:08.9929193Z Feb 09 20:54:08 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
2022-02-09T20:54:08.9930239Z Feb 09 20:54:08 	at java.lang.Thread.run(Thread.java:748)
2022-02-09T20:54:08.9931306Z Feb 09 20:54:08 Caused by: software.amazon.awssdk.core.exception.SdkClientException: An exception was thrown and did not match any waiter acceptors
2022-02-09T20:54:08.9932460Z Feb 09 20:54:08 	at software.amazon.awssdk.core.exception.SdkClientException$BuilderImpl.build(SdkClientException.java:98)
2022-02-09T20:54:08.9933563Z Feb 09 20:54:08 	at software.amazon.awssdk.core.exception.SdkClientException.create(SdkClientException.java:43)
2022-02-09T20:54:08.9935042Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.waiters.WaiterExecutorHelper.lambda$noneMatchException$3(WaiterExecutorHelper.java:94)
2022-02-09T20:54:08.9936698Z Feb 09 20:54:08 	at java.util.Optional.map(Optional.java:215)
2022-02-09T20:54:08.9937704Z Feb 09 20:54:08 	at software.amazon.awssdk.utils.Either.lambda$map$0(Either.java:51)
2022-02-09T20:54:08.9939329Z Feb 09 20:54:08 	at java.util.Optional.orElseGet(Optional.java:267)
2022-02-09T20:54:08.9940462Z Feb 09 20:54:08 	at software.amazon.awssdk.utils.Either.map(Either.java:51)
2022-02-09T20:54:08.9941648Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.waiters.WaiterExecutorHelper.noneMatchException(WaiterExecutorHelper.java:92)
2022-02-09T20:54:08.9943161Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.waiters.AsyncWaiterExecutor.lambda$runAsyncPollingFunction$0(AsyncWaiterExecutor.java:107)
2022-02-09T20:54:08.9944739Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9946146Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9947402Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9948587Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9949929Z Feb 09 20:54:08 	at software.amazon.awssdk.utils.CompletableFutureUtils.lambda$forwardExceptionTo$0(CompletableFutureUtils.java:76)
2022-02-09T20:54:08.9951301Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9952522Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9954082Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9955332Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9956874Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.AsyncApiCallMetricCollectionStage.lambda$execute$0(AsyncApiCallMetricCollectionStage.java:54)
2022-02-09T20:54:08.9958241Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9959746Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9961024Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9962196Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9963560Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.AsyncApiCallTimeoutTrackingStage.lambda$execute$2(AsyncApiCallTimeoutTrackingStage.java:67)
2022-02-09T20:54:08.9965446Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9966855Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9968134Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9969400Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9970771Z Feb 09 20:54:08 	at software.amazon.awssdk.utils.CompletableFutureUtils.lambda$forwardExceptionTo$0(CompletableFutureUtils.java:76)
2022-02-09T20:54:08.9972127Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9973362Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9974823Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9976206Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9977607Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.AsyncRetryableStage$RetryingExecutor.maybeAttemptExecute(AsyncRetryableStage.java:103)
2022-02-09T20:54:08.9979196Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.AsyncRetryableStage$RetryingExecutor.maybeRetryExecute(AsyncRetryableStage.java:181)
2022-02-09T20:54:08.9980707Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.AsyncRetryableStage$RetryingExecutor.lambda$attemptExecute$1(AsyncRetryableStage.java:159)
2022-02-09T20:54:08.9982388Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9983980Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9985284Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9986699Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9988093Z Feb 09 20:54:08 	at software.amazon.awssdk.utils.CompletableFutureUtils.lambda$forwardExceptionTo$0(CompletableFutureUtils.java:76)
2022-02-09T20:54:08.9989391Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9990676Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9991931Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:08.9993243Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:08.9994817Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.MakeAsyncHttpRequestStage.lambda$null$0(MakeAsyncHttpRequestStage.java:104)
2022-02-09T20:54:08.9996420Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
2022-02-09T20:54:08.9997660Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
2022-02-09T20:54:08.9999218Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
2022-02-09T20:54:09.0000400Z Feb 09 20:54:08 	at java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:1990)
2022-02-09T20:54:09.0002048Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.MakeAsyncHttpRequestStage$WrappedErrorForwardingResponseHandler.onError(MakeAsyncHttpRequestStage.java:158)
2022-02-09T20:54:09.0003667Z Feb 09 20:54:08 	at software.amazon.awssdk.http.nio.netty.internal.NettyRequestExecutor.handleFailure(NettyRequestExecutor.java:300)
2022-02-09T20:54:09.0005435Z Feb 09 20:54:08 	at software.amazon.awssdk.http.nio.netty.internal.NettyRequestExecutor.makeRequestListener(NettyRequestExecutor.java:172)
2022-02-09T20:54:09.0006943Z Feb 09 20:54:08 	at io.netty.util.concurrent.DefaultPromise.notifyListener0(DefaultPromise.java:578)
2022-02-09T20:54:09.0008172Z Feb 09 20:54:08 	at io.netty.util.concurrent.DefaultPromise.notifyListenersNow(DefaultPromise.java:552)
2022-02-09T20:54:09.0009340Z Feb 09 20:54:08 	at io.netty.util.concurrent.DefaultPromise.access$200(DefaultPromise.java:35)
2022-02-09T20:54:09.0010537Z Feb 09 20:54:08 	at io.netty.util.concurrent.DefaultPromise$1.run(DefaultPromise.java:502)
2022-02-09T20:54:09.0011739Z Feb 09 20:54:08 	at io.netty.util.concurrent.AbstractEventExecutor.safeExecute(AbstractEventExecutor.java:164)
2022-02-09T20:54:09.0013063Z Feb 09 20:54:08 	at io.netty.util.concurrent.SingleThreadEventExecutor.runAllTasks(SingleThreadEventExecutor.java:469)
2022-02-09T20:54:09.0014384Z Feb 09 20:54:08 	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:500)
2022-02-09T20:54:09.0015694Z Feb 09 20:54:08 	at io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:986)
2022-02-09T20:54:09.0016895Z Feb 09 20:54:08 	at io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
2022-02-09T20:54:09.0017887Z Feb 09 20:54:08 	... 1 more
2022-02-09T20:54:09.0019066Z Feb 09 20:54:08 Caused by: software.amazon.awssdk.core.exception.SdkClientException: Unable to execute HTTP request: The channel was closed before the protocol could be determined.
2022-02-09T20:54:09.0020598Z Feb 09 20:54:08 	at software.amazon.awssdk.core.exception.SdkClientException$BuilderImpl.build(SdkClientException.java:98)
2022-02-09T20:54:09.0021957Z Feb 09 20:54:08 	at software.amazon.awssdk.core.exception.SdkClientException.create(SdkClientException.java:43)
2022-02-09T20:54:09.0023384Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.utils.RetryableStageHelper.setLastException(RetryableStageHelper.java:204)
2022-02-09T20:54:09.0025162Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.utils.RetryableStageHelper.setLastException(RetryableStageHelper.java:200)
2022-02-09T20:54:09.0026874Z Feb 09 20:54:08 	at software.amazon.awssdk.core.internal.http.pipeline.stages.AsyncRetryableStage$RetryingExecutor.maybeRetryExecute(AsyncRetryableStage.java:179)
2022-02-09T20:54:09.0028112Z Feb 09 20:54:08 	... 28 more
2022-02-09T20:54:09.0029066Z Feb 09 20:54:08 Caused by: java.io.IOException: The channel was closed before the protocol could be determined.
2022-02-09T20:54:09.0030456Z Feb 09 20:54:08 	at software.amazon.awssdk.http.nio.netty.internal.http2.Http2SettingsFrameHandler.channelUnregistered(Http2SettingsFrameHandler.java:58)
2022-02-09T20:54:09.0031909Z Feb 09 20:54:08 	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelUnregistered(AbstractChannelHandlerContext.java:198)
2022-02-09T20:54:09.0033353Z Feb 09 20:54:08 	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelUnregistered(AbstractChannelHandlerContext.java:184)
2022-02-09T20:54:09.0034853Z Feb 09 20:54:08 	at io.netty.channel.AbstractChannelHandlerContext.fireChannelUnregistered(AbstractChannelHandlerContext.java:177)
2022-02-09T20:54:09.0036671Z Feb 09 20:54:08 	at io.netty.channel.DefaultChannelPipeline$HeadContext.channelUnregistered(DefaultChannelPipeline.java:1388)
2022-02-09T20:54:09.0038036Z Feb 09 20:54:08 	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelUnregistered(AbstractChannelHandlerContext.java:198)
2022-02-09T20:54:09.0039531Z Feb 09 20:54:08 	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelUnregistered(AbstractChannelHandlerContext.java:184)
2022-02-09T20:54:09.0040889Z Feb 09 20:54:08 	at io.netty.channel.DefaultChannelPipeline.fireChannelUnregistered(DefaultChannelPipeline.java:821)
2022-02-09T20:54:09.0042066Z Feb 09 20:54:08 	at io.netty.channel.AbstractChannel$AbstractUnsafe$8.run(AbstractChannel.java:839)
2022-02-09T20:54:09.0043557Z Feb 09 20:54:08 	at io.netty.util.concurrent.AbstractEventExecutor.safeExecute(AbstractEventExecutor.java:164)
2022-02-09T20:54:09.0044950Z Feb 09 20:54:08 	at io.netty.util.concurrent.SingleThreadEventExecutor.runAllTasks(SingleThreadEventExecutor.java:469)
2022-02-09T20:54:09.0046292Z Feb 09 20:54:08 	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:497)
2022-02-09T20:54:09.0047179Z Feb 09 20:54:08 	... 3 more
{code}
https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=31051&view=logs&j=d44f43ce-542c-597d-bf94-b0718c71e5e8&t=ed165f3f-d0f6-524b-5279-86f8ee7d0e2d&l=44195



--
This message was sent by Atlassian Jira
(v8.20.1#820001)