You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@flink.apache.org by "Matthias Pohl (Jira)" <ji...@apache.org> on 2023/02/06 08:01:00 UTC

[jira] [Created] (FLINK-30911) KafkaSinkE2ECase.testStartFromSavepoint fails with TimeoutException because the topic doesn't become available in the meta file

Matthias Pohl created FLINK-30911:
-------------------------------------

             Summary: KafkaSinkE2ECase.testStartFromSavepoint fails with TimeoutException because the topic doesn't become available in the meta file
                 Key: FLINK-30911
                 URL: https://issues.apache.org/jira/browse/FLINK-30911
             Project: Flink
          Issue Type: Bug
          Components: Connectors / Kafka
    Affects Versions: 1.16.1
            Reporter: Matthias Pohl


{{KafkaSinkE2ECasetestStartFromSavepoint}} with timeout exception after the topic didn't end up in the meta file after 60s.
https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=45722&view=logs&j=f8e16326-dc75-5ba0-3e95-6178dd55bf6c&t=15c1d318-5ca8-529f-77a2-d113a700ec34&l=15563

{code}
Feb 05 05:28:58 Caused by: org.apache.flink.util.FlinkRuntimeException: Failed to send data to Kafka kafka-single-topic-9151082293470264886--1@-1 with FlinkKafkaInternalProducer{transactionalId='null', inTransaction=false, closed=false} 
Feb 05 05:28:58 	at org.apache.flink.connector.kafka.sink.KafkaWriter$WriterCallback.throwException(KafkaWriter.java:436)
Feb 05 05:28:58 	at org.apache.flink.connector.kafka.sink.KafkaWriter$WriterCallback.lambda$onCompletion$0(KafkaWriter.java:417)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.runThrowing(StreamTaskActionExecutor.java:50)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.mailbox.Mail.run(Mail.java:90)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMail(MailboxProcessor.java:398)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.processMailsNonBlocking(MailboxProcessor.java:383)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.processMail(MailboxProcessor.java:345)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:229)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:831)
Feb 05 05:28:58 	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:780)
Feb 05 05:28:58 	at org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:935)
Feb 05 05:28:58 	at org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:914)
Feb 05 05:28:58 	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:728)
Feb 05 05:28:58 	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:550)
Feb 05 05:28:58 	at java.lang.Thread.run(Thread.java:750)
Feb 05 05:28:58 Caused by: org.apache.kafka.common.errors.TimeoutException: Topic kafka-single-topic-9151082293470264886 not present in metadata after 60000 ms.
[...]
{code}



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