You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/06/04 16:26:29 UTC

[GitHub] [beam] damccorm opened a new issue, #20292: Examples Spark Runner tests failing [Java 11]

damccorm opened a new issue, #20292:
URL: https://github.com/apache/beam/issues/20292

   Gradle *_:examples:java:sparkRunnerPreCommit _*fails during Java 11 Precommit job
   
   Example stack trace:
   ```
   
   > Task :examples:java:sparkRunnerPreCommit
       20/05/26 07:11:13 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator:
   Entering directly-translatable composite transform: 'WordCount.CountWords/Count.PerElement/Combine.perKey(Count)'
   
      20/05/26 07:11:13 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Entering directly-translatable
   composite transform: 'WriteCounts/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle'
   
      20/05/26 07:11:14 INFO org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics
   accumulator: {
         "metrics": {
         }
       }
       20/05/26 07:11:14 INFO org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator:
   Instantiated aggregators accumulator: 
       20/05/26 07:11:14 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator:
   Evaluating Read(CompressedSource)
       20/05/26 07:11:14 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator:
   Evaluating org.apache.beam.examples.WordCount$ExtractWordsFn@174ba402
       20/05/26 07:11:15 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator:
   Evaluating org.apache.beam.sdk.transforms.MapElements$1@4c4d8e23
       20/05/26 07:11:15 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator:
   Entering directly-translatable composite transform: 'WordCount.CountWords/Count.PerElement/Combine.perKey(Count)'
   
      20/05/26 07:11:15 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating Combine.perKey(Count)
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating org.apache.beam.sdk.transforms.MapElements$1@6bfdc26a
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating Window.Assign
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating org.apache.beam.sdk.io.WriteFiles$WriteUnshardedTempFilesFn@57c4b142
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating GroupByKey
   
      20/05/26 07:11:19 WARN org.apache.beam.runners.spark.translation.GroupNonMergingWindowsFunctions:
   Either coder ShardedKeyCoder(VarIntCoder) or GlobalWindow$Coder is not consistent with equals. That
   might cause issues on some runners.
       20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator:
   Evaluating org.apache.beam.sdk.io.WriteFiles$WriteShardsIntoTempFilesFn@3122d00d
       20/05/26 07:11:19
   INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating org.apache.beam.sdk.io.WriteFiles$WriteUnshardedBundlesToTempFiles$1@7639f2af
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating Flatten.PCollections
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating org.apache.beam.sdk.transforms.View$VoidKeyToMultimapMaterialization$VoidKeyToMultimapMaterializationDoFn@bcb712b
   
      20/05/26 07:11:19 INFO org.apache.beam.runners.spark.SparkRunner$Evaluator: Evaluating View.CreatePCollectionView
   
   org.apache.beam.examples.WordCountIT
   > testE2EWordCount FAILED
       java.lang.IllegalArgumentException: Unsupported class file major version
   55
   
   1 test completed, 1 failed
   Finished generating test XML results (0.002 secs) into: /home/jenkins/jenkins-slave/workspace/beam_PreCommit_Java11_Phrase/src/examples/java/build/test-results/sparkRunnerPreCommit
   Generating
   HTML test report...
   Finished generating test html results (0.003 secs) into: /home/jenkins/jenkins-slave/workspace/beam_PreCommit_Java11_Phrase/src/examples/java/build/reports/tests/sparkRunnerPreCommit
   
   ```
   
   
   Imported from Jira [BEAM-10088](https://issues.apache.org/jira/browse/BEAM-10088). Original Jira may contain additional context.
   Reported by: pawel.pasterz.
   Subtask of issue #20290


-- 
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: github-unsubscribe@beam.apache.org.apache.org

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


[GitHub] [beam] mosche closed issue #20292: Examples Spark Runner tests failing [Java 11]

Posted by GitBox <gi...@apache.org>.
mosche closed issue #20292: Examples Spark Runner tests failing [Java 11]
URL: https://github.com/apache/beam/issues/20292


-- 
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: github-unsubscribe@beam.apache.org

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


[GitHub] [beam] mosche commented on issue #20292: Examples Spark Runner tests failing [Java 11]

Posted by GitBox <gi...@apache.org>.
mosche commented on issue #20292:
URL: https://github.com/apache/beam/issues/20292#issuecomment-1286978488

   obsolete


-- 
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: github-unsubscribe@beam.apache.org

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