You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hudi.apache.org by GitBox <gi...@apache.org> on 2021/02/11 20:44:10 UTC

[GitHub] [hudi] pavannpa opened a new issue #2570: [SUPPORT] Unable to write data from AWS EMR to S3 (ClassNotFoundException: org.apache.hadoop.hbase.io.compress.Compression$Algorithm)

pavannpa opened a new issue #2570:
URL: https://github.com/apache/hudi/issues/2570


   **_Tips before filing an issue_**
   
   - Have you gone through our [FAQs](https://cwiki.apache.org/confluence/display/HUDI/FAQ)?
   
   - Join the mailing list to engage in conversations and get faster support at dev-subscribe@hudi.apache.org.
   
   - If you have triaged this as a bug, then file an [issue](https://issues.apache.org/jira/projects/HUDI/issues) directly.
   
   **Describe the problem you faced**
   
   Caused by: java.lang.ClassNotFoundException: org.apache.hadoop.hbase.io.compress.Compression$Algorithm
   	at java.net.URLClassLoader.findClass(URLClassLoader.java:382)
   	at java.lang.ClassLoader.loadClass(ClassLoader.java:418)
   	at java.lang.ClassLoader.loadClass(ClassLoader.java:351)
   	... 108 more
   org.apache.spark.sql.streaming.StreamingQueryException: Query [id = 44e08204-0b65-452a-9cba-4476727da7aa, runId = 38e3c054-078c-4576-b688-31a1852fb490] terminated with exception: Failed to upsert for commit time 20210211203930
     at org.apache.spark.sql.execution.streaming.StreamExecution.org$apache$spark$sql$execution$streaming$StreamExecution$$runStream(StreamExecution.scala:355)
     at org.apache.spark.sql.execution.streaming.StreamExecution$$anon$1.run(StreamExecution.scala:245)
   Caused by: org.apache.hudi.exception.HoodieUpsertException: Failed to upsert for commit time 20210211203930
     at org.apache.hudi.table.action.commit.AbstractWriteHelper.write(AbstractWriteHelper.java:62)
     at org.apache.hudi.table.action.deltacommit.SparkUpsertDeltaCommitActionExecutor.execute(SparkUpsertDeltaCommitActionExecutor.java:46)
     at org.apache.hudi.table.HoodieSparkMergeOnReadTable.upsert(HoodieSparkMergeOnReadTable.java:82)
   
   **Hudi Options**
       Map(
         DataSourceWriteOptions.TABLE_TYPE_OPT_KEY -> "MERGE_ON_READ",
         DataSourceWriteOptions.PRECOMBINE_FIELD_OPT_KEY -> "updated_at",
         DataSourceWriteOptions.RECORDKEY_FIELD_OPT_KEY -> "id",
         DataSourceWriteOptions.OPERATION_OPT_KEY -> "upsert",
         DataSourceWriteOptions.TABLE_NAME_OPT_KEY -> ("users"),
         "hoodie.table.name" -> ("users"),
         "hoodie.upsert.shuffle.parallelism"->  "2",
         "hoodie.insert.shuffle.parallelism"-> "2",
         "hoodie.bulkinsert.shuffle.parallelism"-> "2"
       )
   
   **Write Method**
       finalDf
         .writeStream
         .trigger(Trigger.ProcessingTime("10 seconds"))
         .foreachBatch{ (batchDf: DataFrame, batchId: Long) =>
           batchDf.write
             .format("org.apache.hudi")
             .options(HudiUtils.getHudiOptions())
             .mode(SaveMode.Append)
             .save( outputPath + s"/" + "users" )
         }
         .start()
         .awaitTermination()
   
   **Scala Dependency**
   "org.apache.hudi"               % "hudi-spark-common"               % "0.7.0",
       "org.apache.hudi"               % "hudi-hadoop-mr"                  % "0.7.0",
       ("org.apache.hudi"              % "hudi-spark_2.11"                 % "0.7.0").exclude("com.fasterxml.jackson.module", "jackson-module-scala_2.11")
   
   **AWS EMR version:**
   Spark 3.0.0, Hive 3.1.2, Tez 0.9.2
   
   
   A clear and concise description of the problem.
   
   **To Reproduce**
   
   Steps to reproduce the behavior:
   
   1.
   2.
   3.
   4.
   
   **Expected behavior**
   
   A clear and concise description of what you expected to happen.
   
   **Environment Description**
   
   * Hudi version :
   
   * Spark version :
   
   * Hive version :
   
   * Hadoop version :
   
   * Storage (HDFS/S3/GCS..) :
   
   * Running on Docker? (yes/no) :
   
   
   **Additional context**
   
   Add any other context about the problem here.
   
   **Stacktrace**
   
   ```Add the stacktrace of the error.```
   
   


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



[GitHub] [hudi] pavannpa closed issue #2570: [SUPPORT] Unable to write data from AWS EMR to S3 (ClassNotFoundException: org.apache.hadoop.hbase.io.compress.Compression$Algorithm)

Posted by GitBox <gi...@apache.org>.
pavannpa closed issue #2570:
URL: https://github.com/apache/hudi/issues/2570


   


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