You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@hive.apache.org by "daih123456 (Jira)" <ji...@apache.org> on 2020/07/14 01:42:00 UTC

[jira] [Created] (HIVE-23842) org.apache.hadoop.hive.ql.metadata.HiveException

daih123456 created HIVE-23842:
---------------------------------

             Summary: org.apache.hadoop.hive.ql.metadata.HiveException
                 Key: HIVE-23842
                 URL: https://issues.apache.org/jira/browse/HIVE-23842
             Project: Hive
          Issue Type: Bug
          Components: Beeline, Tez
    Affects Versions: 3.1.1
         Environment: INSERT OVERWRITE TABLE app.app_community_user_tot PARTITION (dt = '""" + run_date + """')
SELECT t2.store_id,
 t2.road_area,
 t2.alias_name,
 t2.house_price,
 t2.store_distanct,
 t2.house_holds,
 COUNT(DISTINCT t2.user_id) AS user_num,
 COUNT(DISTINCT CASE WHEN t2.ord_num = 1 THEN t2.user_id ELSE NULL END) AS once_user_num,
 COUNT(DISTINCT t2.ord_id) AS ord_num,
 SUM(t2.actl_sale_amt),
 cur_timestamp() AS ETL_TM,
 SUM(actl_ori_amt)
FROM (SELECT t.store_id,
 t1.store_name,
 t.user_id,
 t.ord_id,
 t.actl_sale_amt,
 t2.road_area,
 t2.alias_name,
 t2.house_price,
 t2.store_distanct,
 t2.house_holds,
 t2.commty_flg,
 t.actl_ori_amt,
 COUNT(DISTINCT ord_id) over(PARTITION BY t.store_id,t.user_id) AS ord_num
 FROM gdm.gdm_ord_pay_detl t
 JOIN dim.dim_store t1
 ON t.store_id = t1.store_id
 AND t1.valid_flg = 1
 JOIN app.app_community_user_label t2
 ON t.user_id = t2.user_id
 WHERE dt <= '""" + run_date + """'
 ) t2
GROUP BY t2.store_id,
 t2.road_area,
 t2.alias_name,
 t2.house_price,
 t2.store_distanct,
 t2.house_holds
            Reporter: daih123456


2020-07-12 04:48:08,154 [ERROR] [TezChild] |tez.ReduceRecordSource|: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row (tag=0) \{"key":{"reducesinkkey0":12001,"reducesinkkey1":1582},"value":\{"_col0":2120010300000014533,"_col86":22.8,"_col89":11.4,"_col168":null,"_col169":null,"_col170":null,"_col171":null,"_col172":null}}2020-07-12 04:48:08,154 [ERROR] [TezChild] |tez.ReduceRecordSource|: org.apache.hadoop.hive.ql.metadata.HiveException: Hive Runtime Error while processing row (tag=0) \{"key":{"reducesinkkey0":12001,"reducesinkkey1":1582},"value":\{"_col0":2120010300000014533,"_col86":22.8,"_col89":11.4,"_col168":null,"_col169":null,"_col170":null,"_col171":null,"_col172":null}} at org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource$GroupIterator.next(ReduceRecordSource.java:372) at org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource.pushRecord(ReduceRecordSource.java:294) at org.apache.hadoop.hive.ql.exec.tez.ReduceRecordProcessor.run(ReduceRecordProcessor.java:318) at org.apache.hadoop.hive.ql.exec.tez.TezProcessor.initializeAndRunProcessor(TezProcessor.java:267) at org.apache.hadoop.hive.ql.exec.tez.TezProcessor.run(TezProcessor.java:250) at org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:374) at org.apache.tez.runtime.task.TaskRunner2Callable$1.run(TaskRunner2Callable.java:73) at org.apache.tez.runtime.task.TaskRunner2Callable$1.run(TaskRunner2Callable.java:61) at java.security.AccessController.doPrivileged(Native Method) at javax.security.auth.Subject.doAs(Subject.java:422) at org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1729) at org.apache.tez.runtime.task.TaskRunner2Callable.callInternal(TaskRunner2Callable.java:61) at org.apache.tez.runtime.task.TaskRunner2Callable.callInternal(TaskRunner2Callable.java:37) at org.apache.tez.common.CallableWithNdc.call(CallableWithNdc.java:36) at com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:108) at com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:41) at com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:77) at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) at java.lang.Thread.run(Thread.java:748)Caused by: java.lang.NullPointerException at org.apache.hadoop.hive.ql.exec.persistence.PTFRowContainer.first(PTFRowContainer.java:115) at org.apache.hadoop.hive.ql.exec.PTFPartition.iterator(PTFPartition.java:114) at org.apache.hadoop.hive.ql.udf.ptf.BasePartitionEvaluator.getPartitionAgg(BasePartitionEvaluator.java:200) at org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.evaluateFunctionOnPartition(WindowingTableFunction.java:155) at org.apache.hadoop.hive.ql.udf.ptf.WindowingTableFunction.iterator(WindowingTableFunction.java:538) at org.apache.hadoop.hive.ql.exec.PTFOperator$PTFInvocation.finishPartition(PTFOperator.java:349) at org.apache.hadoop.hive.ql.exec.PTFOperator.process(PTFOperator.java:123) at org.apache.hadoop.hive.ql.exec.Operator.baseForward(Operator.java:995) at org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:941) at org.apache.hadoop.hive.ql.exec.Operator.forward(Operator.java:928) at org.apache.hadoop.hive.ql.exec.SelectOperator.process(SelectOperator.java:95) at org.apache.hadoop.hive.ql.exec.tez.ReduceRecordSource$GroupIterator.next(ReduceRecordSource.java:363) ... 19 more



--
This message was sent by Atlassian Jira
(v8.3.4#803005)