Details
-
Bug
-
Status: Closed
-
Critical
-
Resolution: Fixed
-
1.14.0, 1.15.0, 1.16.0, 1.17.0
Description
Sep 01 15:53:20 [ERROR] Tests run: 23, Failures: 1, Errors: 0, Skipped: 0, Time elapsed: 162.65 s <<< FAILURE! - in org.apache.flink.streaming.connectors.kafka.KafkaITCase Sep 01 15:53:20 [ERROR] testTimestamps Time elapsed: 23.237 s <<< FAILURE! Sep 01 15:53:20 java.lang.AssertionError: Create test topic : tstopic failed, org.apache.kafka.common.errors.TopicExistsException: Topic 'tstopic' already exists. Sep 01 15:53:20 at org.junit.Assert.fail(Assert.java:89) Sep 01 15:53:20 at org.apache.flink.streaming.connectors.kafka.KafkaTestEnvironmentImpl.createTestTopic(KafkaTestEnvironmentImpl.java:226) Sep 01 15:53:20 at org.apache.flink.streaming.connectors.kafka.KafkaTestEnvironment.createTestTopic(KafkaTestEnvironment.java:112) Sep 01 15:53:20 at org.apache.flink.streaming.connectors.kafka.KafkaTestBase.createTestTopic(KafkaTestBase.java:212) Sep 01 15:53:20 at org.apache.flink.streaming.connectors.kafka.KafkaITCase.testTimestamps(KafkaITCase.java:191) Sep 01 15:53:20 at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method) Sep 01 15:53:20 at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62) Sep 01 15:53:20 at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43) Sep 01 15:53:20 at java.lang.reflect.Method.invoke(Method.java:498) Sep 01 15:53:20 at org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:59) Sep 01 15:53:20 at org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:12) Sep 01 15:53:20 at org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:56) Sep 01 15:53:20 at org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:17) Sep 01 15:53:20 at org.junit.internal.runners.statements.FailOnTimeout$CallableStatement.call(FailOnTimeout.java:299) Sep 01 15:53:20 at org.junit.internal.runners.statements.FailOnTimeout$CallableStatement.call(FailOnTimeout.java:293) Sep 01 15:53:20 at java.util.concurrent.FutureTask.run(FutureTask.java:266) Sep 01 15:53:20 at java.lang.Thread.run(Thread.java:748)
Attachments
Issue Links
- depends upon
-
FLINK-25249 Reimplement KafkaSourceTestEnv with KafkaContainer
- Resolved
- duplicates
-
FLINK-29697 Flaky test failure KafkaShuffleExactlyOnceITCase.testAssignedToPartitionFailureRecoveryEventTime
- Closed
- is caused by
-
FLINK-29153 KafkaConsumerThread should catch WakeupException when committing offsets
- Closed
- is duplicated by
-
FLINK-25279 KafkaSourceLegacyITCase.testKeyValueSupport failed on azure due to topic already exists
- Closed
- relates to
-
FLINK-25455 FlinkKafkaInternalProducerITCase.testProducerWhenCommitEmptyPartitionsToOutdatedTxnCoordinator fails on AZP
- Closed
-
FLINK-25438 KafkaProducerExactlyOnceITCase.testMultipleSinkOperators failed due to topic 'exactlyTopicCustomOperator20' already exists
- Closed
-
FLINK-29018 KafkaITCase.testMultipleSourcesOnePartition failed with TopicExistsException
- Closed
-
FLINK-29914 KafkaTableITCase.testKafkaSourceSink fails
- Closed
- Testing discovered
-
FLINK-29956 Kafka-related test infrastructure code is scattered over multiple classes/environments
- Open
- links to