You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@beam.apache.org by "Yohei Onishi (JIRA)" <ji...@apache.org> on 2019/03/22 07:31:00 UTC

[jira] [Created] (BEAM-6884) NoSuchMethodError: descriptors$EnumValueDescriptor when deploying Beam 2.10.0 to Dataflow

Yohei Onishi created BEAM-6884:
----------------------------------

             Summary: NoSuchMethodError: descriptors$EnumValueDescriptor when deploying Beam 2.10.0 to Dataflow
                 Key: BEAM-6884
                 URL: https://issues.apache.org/jira/browse/BEAM-6884
             Project: Beam
          Issue Type: Bug
          Components: beam-model
    Affects Versions: 2.10.0
            Reporter: Yohei Onishi


I tried to change Apache beam version from 2.9.0 to 2.10.0 and deploy it to Dataflow but I got this error. It works with 2.9.0. Am I missing something?

 
{code:java}
Exception in thread "main" java.lang.NoSuchMethodError: org.apache.beam.model.pipeline.v1.RunnerApi$BeamConstants$Constants.getValueDescriptor()Lorg/apache/beam/vendor/grpc/v1p13p1/com/google/protobuf/Descriptors$EnumValueDescriptor;
{code}
My code is in Scala but it should work well.

 

 
{code:java}
  val p = Pipeline.create(options)
    p.apply(s"${bu.name}_ReadFromKafka", KafkaIO.read()
    .withBootstrapServers(options.getBootstreapServers)
    .updateConsumerProperties(config)
    .withTopics(util.Arrays.asList(topicName))
    .withKeyDeserializer(classOf[LongDeserializer])
    .withValueDeserializer(classOf[StringDeserializer])
    .withConsumerFactoryFn(
      new KafkaTLSConsumerFactory(
        projectId, options.getSourceBucket, options.getTrustStoreGCSKey, options.getKeyStoreGCSKey)))
     .apply(s"${bu.name}_Convert", ParDo.of(new ConvertJSONTextToEPCTransaction(bu)))
     .apply(s"${bu.name}_WriteToBQ",  BigQueryIO.write()
      .to(bqDestTable)
      .withSchema(schema)
      .withFormatFunction(new ConvertMessageToTable())
      .withCreateDisposition(BigQueryIO.Write.CreateDisposition.CREATE_NEVER)
      .withWriteDisposition(BigQueryIO.Write.WriteDisposition.WRITE_APPEND))
  }
  p.run
{code}
 

 



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)