Uploaded image for project: 'Kafka'
  1. Kafka
  2. KAFKA-2872

Error starting KafkaStream caused by sink not being connected to parent source/processor nodes

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • 0.10.0.0
    • 0.10.0.0
    • streams
    • None

    Description

      When starting the KafkaStream I get the following Exception:

      Exception in thread "main" java.util.NoSuchElementException: id: SINK
      at org.apache.kafka.streams.processor.internals.QuickUnion.root(QuickUnion.java:40)
      at org.apache.kafka.streams.processor.TopologyBuilder.makeNodeGroups(TopologyBuilder.java:387)
      at org.apache.kafka.streams.processor.TopologyBuilder.topicGroups(TopologyBuilder.java:339)
      at org.apache.kafka.streams.processor.internals.StreamThread.<init>(StreamThread.java:139)
      at org.apache.kafka.streams.processor.internals.StreamThread.<init>(StreamThread.java:120)
      at org.apache.kafka.streams.KafkaStreaming.<init>(KafkaStreaming.java:110)
      at bbejeck.ProcessorDriver.main(ProcessorDriver.java:35)

      The TopologyBuilder is being built like so:
      topologyBuilder.addSource("SOURCE", new StringDeserializer(), new StringDeserializer(), "src-topic")
      .addProcessor("PROCESS", new GenericProcessorClient(replaceVowels), "SOURCE")
      .addSink("SINK", "dest-topic", new StringSerializer(), new StringSerializer(), "PROCESS");

      Looks to me the cause of the error is that in TopologyBuilder.addSink method the sink is never connected with it's parent.

      Attachments

        Activity

          People

            bbejeck Bill Bejeck
            bbejeck Bill Bejeck
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: