Details
-
Sub-task
-
Status: Resolved
-
Major
-
Resolution: Not A Bug
-
None
-
None
-
None
Description
I now consistently saw some integration failures on my laptop due to no records ever been produced in 30 / 60 seconds (my laptop only has 4GB and when running the unit test today it is burning all CPUs / memory btw):
org.apache.kafka.streams.integration.JoinIntegrationTest > shouldCountClicksPerRegion FAILED java.lang.AssertionError: Expected 8 but received only 0 records before timeout 30000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:173) at org.apache.kafka.streams.integration.JoinIntegrationTest.shouldCountClicksPerRegion(JoinIntegrationTest.java:258) org.apache.kafka.streams.integration.MapFunctionIntegrationTest > shouldUppercaseTheInput FAILED java.lang.AssertionError: Expected 2 but received only 0 records before timeout 30000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:235) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:209) at org.apache.kafka.streams.integration.MapFunctionIntegrationTest.shouldUppercaseTheInput(MapFunctionIntegrationTest.java:116) org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput FAILED java.lang.AssertionError: Expected 2 but received only 0 records before timeout 30000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:235) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:209) at org.apache.kafka.streams.integration.FanoutIntegrationTest.shouldFanoutTheInput(FanoutIntegrationTest.java:145) org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest > shouldReduce FAILED java.lang.AssertionError: Expected 10 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.receiveMessages(KGroupedStreamIntegrationTest.java:467) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.shouldReduce(KGroupedStreamIntegrationTest.java:141) org.apache.kafka.streams.integration.PassThroughIntegrationTest > shouldWriteTheInputDataAsIsToTheOutputTopic FAILED java.lang.AssertionError: Expected 3 but received only 0 records before timeout 30000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:235) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:209) at org.apache.kafka.streams.integration.PassThroughIntegrationTest.shouldWriteTheInputDataAsIsToTheOutputTopic(PassThroughIntegrationTest.java:103) org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperations FAILED java.lang.AssertionError: Expected 5 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinValuesRecordsReceived(IntegrationTestUtils.java:235) at org.apache.kafka.streams.integration.KStreamRepartitionJoinTest.receiveMessages(KStreamRepartitionJoinTest.java:414) at org.apache.kafka.streams.integration.KStreamRepartitionJoinTest.verifyCorrectOutput(KStreamRepartitionJoinTest.java:326) at org.apache.kafka.streams.integration.KStreamRepartitionJoinTest.shouldCorrectlyRepartitionOnJoinOperations(KStreamRepartitionJoinTest.java:130) org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest > shouldAggregate FAILED java.lang.AssertionError: Expected 10 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.receiveMessages(KGroupedStreamIntegrationTest.java:467) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.shouldAggregate(KGroupedStreamIntegrationTest.java:249) org.apache.kafka.streams.integration.WordCountIntegrationTest > shouldCountWords FAILED java.lang.AssertionError: Expected 5 but received only 0 records before timeout 30000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:173) at org.apache.kafka.streams.integration.WordCountIntegrationTest.shouldCountWords(WordCountIntegrationTest.java:142) org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest > shouldCount FAILED java.lang.AssertionError: Expected 10 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.receiveMessages(KGroupedStreamIntegrationTest.java:467) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.shouldCount(KGroupedStreamIntegrationTest.java:349) org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest > shouldGroupByKey FAILED java.lang.AssertionError: Expected 10 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.receiveMessages(KGroupedStreamIntegrationTest.java:467) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.shouldGroupByKey(KGroupedStreamIntegrationTest.java:391) org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest > shouldReduceWindowed FAILED java.lang.AssertionError: Expected 15 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.receiveMessages(KGroupedStreamIntegrationTest.java:467) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.shouldReduceWindowed(KGroupedStreamIntegrationTest.java:195) org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest > shouldAggregateWindowed FAILED java.lang.AssertionError: Expected 15 but received only 0 records before timeout 60000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.receiveMessages(KGroupedStreamIntegrationTest.java:467) at org.apache.kafka.streams.integration.KGroupedStreamIntegrationTest.shouldAggregateWindowed(KGroupedStreamIntegrationTest.java:298) org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testShouldReadFromRegexAndNamedTopics FAILED java.lang.AssertionError: Expected 6 but received only 0 records before timeout 30000 ms at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:199) at org.apache.kafka.streams.integration.utils.IntegrationTestUtils.waitUntilMinKeyValueRecordsReceived(IntegrationTestUtils.java:173) at org.apache.kafka.streams.integration.RegexSourceIntegrationTest.testShouldReadFromRegexAndNamedTopics(RegexSourceIntegrationTest.java:239) org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenCreated FAILED java.lang.AssertionError: Expected: <[TEST-TOPIC-1, TEST-TOPIC-2]> but: was null at org.hamcrest.MatcherAssert.assertThat(MatcherAssert.java:20) at org.junit.Assert.assertThat(Assert.java:956) at org.junit.Assert.assertThat(Assert.java:923) at org.apache.kafka.streams.integration.RegexSourceIntegrationTest.testRegexMatchesTopicsAWhenCreated(RegexSourceIntegrationTest.java:152) org.apache.kafka.streams.integration.RegexSourceIntegrationTest > testRegexMatchesTopicsAWhenDeleted FAILED java.lang.AssertionError: Expected: <[TEST-TOPIC-B]> but: was null at org.hamcrest.MatcherAssert.assertThat(MatcherAssert.java:20) at org.junit.Assert.assertThat(Assert.java:956) at org.junit.Assert.assertThat(Assert.java:923) at org.apache.kafka.streams.integration.RegexSourceIntegrationTest.testRegexMatchesTopicsAWhenDeleted(RegexSourceIntegrationTest.java:197)