You are viewing a plain text version of this content. The canonical link for it is here.
Posted to jira@kafka.apache.org by GitBox <gi...@apache.org> on 2021/03/23 17:10:05 UTC

[GitHub] [kafka] chia7712 commented on pull request #10386: MINOR: fix aggregatedJavadoc dep on compileJava

chia7712 commented on pull request #10386:
URL: https://github.com/apache/kafka/pull/10386#issuecomment-805076137


   I run `./gradlew aggregatedJavadocg` with JDK 11 and this patch and it still produces following error message.
   ```
   > Task :aggregatedJavadoc FAILED
   /home/chia7712/kafka/streams/test-utils/src/main/java/org/apache/kafka/streams/TopologyTestDriver.java:44: error: cannot find symbol
   import org.apache.kafka.streams.internals.KeyValueStoreFacade;
                                            ^
     symbol:   class KeyValueStoreFacade
     location: package org.apache.kafka.streams.internals
   /home/chia7712/kafka/streams/test-utils/src/main/java/org/apache/kafka/streams/TopologyTestDriver.java:45: error: cannot find symbol
   import org.apache.kafka.streams.internals.WindowStoreFacade;
                                            ^
     symbol:   class WindowStoreFacade
     location: package org.apache.kafka.streams.internals
   /home/chia7712/kafka/streams/test-utils/src/main/java/org/apache/kafka/streams/TopologyTestDriver.java:69: error: cannot find symbol
   import org.apache.kafka.streams.processor.internals.TestDriverProducer;
                                                      ^
     symbol:   class TestDriverProducer
     location: package org.apache.kafka.streams.processor.internals
   /home/chia7712/kafka/streams/test-utils/src/main/java/org/apache/kafka/streams/TopologyTestDriver.java:226: error: cannot find symbol
       private final TestDriverProducer testDriverProducer;
                     ^
     symbol:   class TestDriverProducer
     location: class TopologyTestDriver
   4 errors
   
   ```
   
   BTW, there is a issue related to this error (https://issues.apache.org/jira/browse/KAFKA-12435)


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org