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

[jira] [Updated] (FLINK-26272) Elasticsearch7SinkITCase.testWriteJsonToElasticsearch fails with socket timeout

     [ https://issues.apache.org/jira/browse/FLINK-26272?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Flink Jira Bot updated FLINK-26272:
-----------------------------------
    Labels: auto-deprioritized-critical stale-major test-stability  (was: auto-deprioritized-critical test-stability)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help the community manage its development. I see this issues has been marked as Major but is unassigned and neither itself nor its Sub-Tasks have been updated for 60 days. I have gone ahead and added a "stale-major" to the issue". If this ticket is a Major, please either assign yourself or give an update. Afterwards, please remove the label or in 7 days the issue will be deprioritized.


> Elasticsearch7SinkITCase.testWriteJsonToElasticsearch fails with socket timeout
> -------------------------------------------------------------------------------
>
>                 Key: FLINK-26272
>                 URL: https://issues.apache.org/jira/browse/FLINK-26272
>             Project: Flink
>          Issue Type: Bug
>          Components: Connectors / ElasticSearch
>    Affects Versions: 1.15.0
>            Reporter: Matthias Pohl
>            Priority: Major
>              Labels: auto-deprioritized-critical, stale-major, test-stability
>
> We observed a test failure in [this build|https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=31883&view=logs&j=d44f43ce-542c-597d-bf94-b0718c71e5e8&t=ed165f3f-d0f6-524b-5279-86f8ee7d0e2d&l=12917] with {{Elasticsearch7SinkITCase.testWriteJsonToElasticsearch}} failing due to a {{SocketTimeoutException}}:
> {code}
> Feb 18 18:04:20 [ERROR] Tests run: 6, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 80.248 s <<< FAILURE! - in org.apache.flink.connector.elasticsearch.sink.Elasticsearch7SinkITCase
> Feb 18 18:04:20 [ERROR] org.apache.flink.connector.elasticsearch.sink.Elasticsearch7SinkITCase.testWriteJsonToElasticsearch(BiFunction)[1]  Time elapsed: 31.525 s  <<< ERROR!
> Feb 18 18:04:20 org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
> Feb 18 18:04:20 	at org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:144)
> Feb 18 18:04:20 	at org.apache.flink.runtime.minicluster.MiniClusterJobClient.lambda$getJobExecutionResult$3(MiniClusterJobClient.java:141)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:616)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:591)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
> Feb 18 18:04:20 	at org.apache.flink.runtime.rpc.akka.AkkaInvocationHandler.lambda$invokeRpc$1(AkkaInvocationHandler.java:259)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
> Feb 18 18:04:20 	at org.apache.flink.util.concurrent.FutureUtils.doForward(FutureUtils.java:1389)
> Feb 18 18:04:20 	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.lambda$null$1(ClassLoadingUtils.java:93)
> Feb 18 18:04:20 	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.runWithContextClassLoader(ClassLoadingUtils.java:68)
> Feb 18 18:04:20 	at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.lambda$guardCompletionWithContextClassLoader$2(ClassLoadingUtils.java:92)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
> Feb 18 18:04:20 	at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
> Feb 18 18:04:20 	at org.apache.flink.runtime.concurrent.akka.AkkaFutureUtils$1.onComplete(AkkaFutureUtils.java:47)
> Feb 18 18:04:20 	at akka.dispatch.OnComplete.internal(Future.scala:300)
> Feb 18 18:04:20 	at akka.dispatch.OnComplete.internal(Future.scala:297)
> Feb 18 18:04:20 	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:224)
> Feb 18 18:04:20 	at akka.dispatch.japi$CallbackBridge.apply(Future.scala:221)
> Feb 18 18:04:20 	at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:60)
> Feb 18 18:04:20 	at org.apache.flink.runtime.concurrent.akka.AkkaFutureUtils$DirectExecutionContext.execute(AkkaFutureUtils.java:65)
> Feb 18 18:04:20 	at scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:68)
> [...]
> at org.apache.flink.streaming.runtime.tasks.StreamTask.performCheckpoint(StreamTask.java:1241)
> Feb 18 18:04:20 	at org.apache.flink.streaming.runtime.tasks.StreamTask.triggerCheckpointAsyncInMailbox(StreamTask.java:1126)
> Feb 18 18:04:20 	... 13 more
> Feb 18 18:04:20 Caused by: java.net.SocketTimeoutException: 30,000 milliseconds timeout on connection http-outgoing-3 [ACTIVE]
> Feb 18 18:04:20 	at org.apache.http.nio.protocol.HttpAsyncRequestExecutor.timeout(HttpAsyncRequestExecutor.java:387)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.client.InternalIODispatch.onTimeout(InternalIODispatch.java:92)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.client.InternalIODispatch.onTimeout(InternalIODispatch.java:39)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.AbstractIODispatch.timeout(AbstractIODispatch.java:175)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.BaseIOReactor.sessionTimedOut(BaseIOReactor.java:261)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.AbstractIOReactor.timeoutCheck(AbstractIOReactor.java:502)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.BaseIOReactor.validate(BaseIOReactor.java:211)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.AbstractIOReactor.execute(AbstractIOReactor.java:280)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.BaseIOReactor.execute(BaseIOReactor.java:104)
> Feb 18 18:04:20 	at org.apache.http.impl.nio.reactor.AbstractMultiworkerIOReactor$Worker.run(AbstractMultiworkerIOReactor.java:591)
> Feb 18 18:04:20 	... 1 more
> {code}



--
This message was sent by Atlassian Jira
(v8.20.10#820010)