You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@flink.apache.org by Abdul Salam Shaikh <ab...@gmail.com> on 2017/04/24 15:56:40 UTC

Regarding exception relating to FlinkKafkaConsumer09

Hi,

I am using 1.2-SNAPSHOT of Apache Flink and 1.3-SNAPSHOT
of flink-connector-kafka-0.9_2.11.

It was executing without any errors before but it is giving the following
exception at the moment:

​java.lang.NoSuchMethodError:
org.apache.flink.util.PropertiesUtil.getBoolean(Ljava/util/Properties;Ljava/lang/String;Z)Z
at
org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09.getIsAutoCommitEnabled(FlinkKafkaConsumer09.java:235)
at
org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase.open(FlinkKafkaConsumerBase.java:330)
at
org.apache.flink.api.common.functions.util.FunctionUtils.openFunction(FunctionUtils.java:36)
at
org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator.open(AbstractUdfStreamOperator.java:157)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.openAllOperators(StreamTask.java:383)
at
org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:259)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:654)
at java.lang.Thread.run(Thread.java:745)

Has anything change recently on this front ?

Thanks in anticipation!​

Re: Regarding exception relating to FlinkKafkaConsumer09

Posted by "Tzu-Li (Gordon) Tai" <tz...@apache.org>.
Hi!

The `PropertiesUtil.getBoolean` currently only exists in `1.3-SNAPSHOT`. The method was added along with one of the Kafka consumer changes recently.

Generally, you should always use matching versions of the Flink installation and the library, otherwise these kind of errors can always be expected.

Cheers,
Gordon


On 24 April 2017 at 11:56:44 PM, Abdul Salam Shaikh (abd.salam.shaikh@gmail.com) wrote:

Hi, 

I am using 1.2-SNAPSHOT of Apache Flink and 1.3-SNAPSHOT of flink-connector-kafka-0.9_2.11. 

It was executing without any errors before but it is giving the following exception at the moment: 

​java.lang.NoSuchMethodError: org.apache.flink.util.PropertiesUtil.getBoolean(Ljava/util/Properties;Ljava/lang/String;Z)Z
at org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09.getIsAutoCommitEnabled(FlinkKafkaConsumer09.java:235)
at org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase.open(FlinkKafkaConsumerBase.java:330)
at org.apache.flink.api.common.functions.util.FunctionUtils.openFunction(FunctionUtils.java:36)
at org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator.open(AbstractUdfStreamOperator.java:157)
at org.apache.flink.streaming.runtime.tasks.StreamTask.openAllOperators(StreamTask.java:383)
at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:259)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:654)
at java.lang.Thread.run(Thread.java:745)

Has anything change recently on this front ? 

Thanks in anticipation!​