You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by GitBox <gi...@apache.org> on 2022/01/21 12:09:58 UTC

[GitHub] [flink] XW512 opened a new pull request #18441: Release 1.14 error in consumer kafka message

XW512 opened a new pull request #18441:
URL: https://github.com/apache/flink/pull/18441


   flink version: 1.14.3
   
   consumer code:  
   
   KafkaSource<String> kafkaSource = KafkaSource.<String>builder()
                   .setBootstrapServers("xxx:9092,xxx:9092,xxx:9092")
                   .setGroupId("consumer")
                   .setTopics("logs")
                   .setStartingOffsets(OffsetsInitializer.latest())
                   .setValueOnlyDeserializer(new SimpleStringSchema())
                   .build();
   DataStream<String> inputStream = env.fromSource(kafkaSource, WatermarkStrategy.noWatermarks(), "kafka-source");
   
   When I submit a task to the Flink cluster, the following error occurs
   
   2022-01-21 19:58:22,593 INFO  org.apache.flink.streaming.runtime.tasks.StreamTask          [] - Using job/cluster config to configure application-defined state backend: EmbeddedRocksDBStateBackend{, localRocksDbDirectories=null, enableIncrementalCheckpointing=UNDEFINED, numberOfTransferThreads=-1, writeBatchSize=-1}
   2022-01-21 19:58:22,593 INFO  org.apache.flink.contrib.streaming.state.EmbeddedRocksDBStateBackend [] - Using predefined options: DEFAULT.
   2022-01-21 19:58:22,593 WARN  org.apache.flink.runtime.taskmanager.Task                    [] - Source: kafka-source -> Filter -> Map -> Timestamps/Watermarks -> Sink: Unnamed (2/4)#48 (3b4734745a62c15ec94f5d29f86516e4) switched from INITIALIZING to FAILED with failure cause: java.lang.NoSuchMethodError: org.apache.flink.api.connector.source.SourceReaderContext.metricGroup()Lorg/apache/flink/metrics/MetricGroup;
   	at org.apache.flink.connector.kafka.source.KafkaSource.createReader(KafkaSource.java:149)
   	at org.apache.flink.connector.kafka.source.KafkaSource.createReader(KafkaSource.java:127)
   	at org.apache.flink.streaming.api.operators.SourceOperator.initReader(SourceOperator.java:264)
   	at org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.init(SourceOperatorStreamTask.java:70)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restoreInternal(StreamTask.java:677)
   	at org.apache.flink.streaming.runtime.tasks.StreamTask.restore(StreamTask.java:654)
   	at org.apache.flink.runtime.taskmanager.Task.runWithSystemExitMonitoring(Task.java:958)
   	at org.apache.flink.runtime.taskmanager.Task.restoreAndInvoke(Task.java:927)
   	at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:766)
   	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:575)
   	at java.lang.Thread.run(Thread.java:748)
   
   I guess it's the lack of the Flink package. I copy the Flink core to the Lib of the Flink cluster, but I still can't start the task
   
   How should I solve this problem
   


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #18441:
URL: https://github.com/apache/flink/pull/18441#issuecomment-1018454853


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29896",
       "triggerID" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "triggerType" : "PUSH"
     }, {
       "hash" : "142a5ee8b4f02994c40d894ab0ed54abc36b5efd",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29908",
       "triggerID" : "142a5ee8b4f02994c40d894ab0ed54abc36b5efd",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 303e3064f27d8d648f6b745a62ec12707f3c5cf6 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29896) 
   * 142a5ee8b4f02994c40d894ab0ed54abc36b5efd Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29908) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run azure` re-run the last Azure build
   </details>


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] zentol commented on pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
zentol commented on pull request #18441:
URL: https://github.com/apache/flink/pull/18441#issuecomment-1018734448


   [This is not the right place to ask question.](https://flink.apache.org/gettinghelp.html)


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] zentol closed pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
zentol closed pull request #18441:
URL: https://github.com/apache/flink/pull/18441


   


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot commented on pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
flinkbot commented on pull request #18441:
URL: https://github.com/apache/flink/pull/18441#issuecomment-1018454083


   Thanks a lot for your contribution to the Apache Flink project. I'm the @flinkbot. I help the community
   to review your pull request. We will use this comment to track the progress of the review.
   
   
   ## Automated Checks
   Last check on commit 303e3064f27d8d648f6b745a62ec12707f3c5cf6 (Fri Jan 21 12:14:24 UTC 2022)
   
   **Warnings:**
    * **44 pom.xml files were touched**: Check for build and licensing issues.
    * **Invalid pull request title: No valid Jira ID provided**
   
   
   <sub>Mention the bot in a comment to re-run the automated checks.</sub>
   ## Review Progress
   
   * ❓ 1. The [description] looks good.
   * ❓ 2. There is [consensus] that the contribution should go into to Flink.
   * ❓ 3. Needs [attention] from.
   * ❓ 4. The change fits into the overall [architecture].
   * ❓ 5. Overall code [quality] is good.
   
   Please see the [Pull Request Review Guide](https://flink.apache.org/contributing/reviewing-prs.html) for a full explanation of the review process.<details>
    The Bot is tracking the review progress through labels. Labels are applied according to the order of the review items. For consensus, approval by a Flink committer of PMC member is required <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot approve description` to approve one or more aspects (aspects: `description`, `consensus`, `architecture` and `quality`)
    - `@flinkbot approve all` to approve all aspects
    - `@flinkbot approve-until architecture` to approve everything until `architecture`
    - `@flinkbot attention @username1 [@username2 ..]` to require somebody's attention
    - `@flinkbot disapprove architecture` to remove an approval you gave earlier
   </details>


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot commented on pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
flinkbot commented on pull request #18441:
URL: https://github.com/apache/flink/pull/18441#issuecomment-1018454853


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 303e3064f27d8d648f6b745a62ec12707f3c5cf6 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run azure` re-run the last Azure build
   </details>


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #18441:
URL: https://github.com/apache/flink/pull/18441#issuecomment-1018454853


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29896",
       "triggerID" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "triggerType" : "PUSH"
     }, {
       "hash" : "142a5ee8b4f02994c40d894ab0ed54abc36b5efd",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "142a5ee8b4f02994c40d894ab0ed54abc36b5efd",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 303e3064f27d8d648f6b745a62ec12707f3c5cf6 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29896) 
   * 142a5ee8b4f02994c40d894ab0ed54abc36b5efd UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run azure` re-run the last Azure build
   </details>


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #18441: Release 1.14 error in consumer kafka message

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #18441:
URL: https://github.com/apache/flink/pull/18441#issuecomment-1018454853


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29896",
       "triggerID" : "303e3064f27d8d648f6b745a62ec12707f3c5cf6",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 303e3064f27d8d648f6b745a62ec12707f3c5cf6 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=29896) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run azure` re-run the last Azure build
   </details>


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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