You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@hive.apache.org by "Hive QA (JIRA)" <ji...@apache.org> on 2017/06/28 04:23:00 UTC

[jira] [Commented] (HIVE-16951) ACID Compactor, PartialScanTask, MergeFileTask, ColumnTruncateTask, HCatUtil don't close JobClient

    [ https://issues.apache.org/jira/browse/HIVE-16951?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=16065910#comment-16065910 ] 

Hive QA commented on HIVE-16951:
--------------------------------



Here are the results of testing the latest attachment:
https://issues.apache.org/jira/secure/attachment/12874746/HIVE-16951.1.patch

{color:red}ERROR:{color} -1 due to no test(s) being added or modified.

{color:red}ERROR:{color} -1 due to 16 failed/errored test(s), 10850 tests executed
*Failed tests:*
{noformat}
org.apache.hadoop.hive.cli.TestMiniLlapLocalCliDriver.testCliDriver[columnstats_part_coltype] (batchId=158)
org.apache.hadoop.hive.cli.TestMiniLlapLocalCliDriver.testCliDriver[tez_smb_main] (batchId=150)
org.apache.hadoop.hive.cli.TestMiniLlapLocalCliDriver.testCliDriver[vector_if_expr] (batchId=146)
org.apache.hadoop.hive.cli.TestMiniTezCliDriver.testCliDriver[explainanalyze_2] (batchId=99)
org.apache.hadoop.hive.cli.TestPerfCliDriver.testCliDriver[query14] (batchId=233)
org.apache.hadoop.hive.cli.TestPerfCliDriver.testCliDriver[query16] (batchId=233)
org.apache.hadoop.hive.cli.TestPerfCliDriver.testCliDriver[query23] (batchId=233)
org.apache.hadoop.hive.cli.TestPerfCliDriver.testCliDriver[query94] (batchId=233)
org.apache.hadoop.hive.llap.security.TestLlapSignerImpl.testSigning (batchId=290)
org.apache.hadoop.hive.metastore.TestMetaStoreEndFunctionListener.testEndFunctionListener (batchId=205)
org.apache.hadoop.hive.ql.parse.TestReplicationScenariosAcrossInstances.testBootstrapFunctionReplication (batchId=217)
org.apache.hadoop.hive.ql.parse.TestReplicationScenariosAcrossInstances.testCreateFunctionIncrementalReplication (batchId=217)
org.apache.hadoop.hive.ql.parse.TestReplicationScenariosAcrossInstances.testCreateFunctionWithFunctionBinaryJarsOnHDFS (batchId=217)
org.apache.hive.hcatalog.api.TestHCatClient.testPartitionRegistrationWithCustomSchema (batchId=178)
org.apache.hive.hcatalog.api.TestHCatClient.testPartitionSpecRegistrationWithCustomSchema (batchId=178)
org.apache.hive.hcatalog.api.TestHCatClient.testTableSchemaPropagation (batchId=178)
{noformat}

Test results: https://builds.apache.org/job/PreCommit-HIVE-Build/5797/testReport
Console output: https://builds.apache.org/job/PreCommit-HIVE-Build/5797/console
Test logs: http://104.198.109.242/logs/PreCommit-HIVE-Build-5797/

Messages:
{noformat}
Executing org.apache.hive.ptest.execution.TestCheckPhase
Executing org.apache.hive.ptest.execution.PrepPhase
Executing org.apache.hive.ptest.execution.ExecutionPhase
Executing org.apache.hive.ptest.execution.ReportingPhase
Tests exited with: TestsFailedException: 16 tests failed
{noformat}

This message is automatically generated.

ATTACHMENT ID: 12874746 - PreCommit-HIVE-Build

> ACID Compactor, PartialScanTask, MergeFileTask, ColumnTruncateTask, HCatUtil don't close JobClient
> --------------------------------------------------------------------------------------------------
>
>                 Key: HIVE-16951
>                 URL: https://issues.apache.org/jira/browse/HIVE-16951
>             Project: Hive
>          Issue Type: Bug
>          Components: Transactions
>    Affects Versions: 1.2.2, 2.1.1
>            Reporter: Vaibhav Gumashta
>            Assignee: Vaibhav Gumashta
>         Attachments: HIVE-16951.1.patch
>
>
> When a compaction job is launched, we create a new JobClient everytime we run the MR job:
> {code}
>   private void launchCompactionJob(JobConf job, Path baseDir, CompactionType compactionType,
>                                    StringableList dirsToSearch,
>                                    List<AcidUtils.ParsedDelta> parsedDeltas,
>                                    int curDirNumber, int obsoleteDirNumber, HiveConf hiveConf,
>                                    TxnStore txnHandler, long id, String jobName) throws IOException {
>     job.setBoolean(IS_MAJOR, compactionType == CompactionType.MAJOR);
>     if(dirsToSearch == null) {
>       dirsToSearch = new StringableList();
>     }
>     StringableList deltaDirs = new StringableList();
>     long minTxn = Long.MAX_VALUE;
>     long maxTxn = Long.MIN_VALUE;
>     for (AcidUtils.ParsedDelta delta : parsedDeltas) {
>       LOG.debug("Adding delta " + delta.getPath() + " to directories to search");
>       dirsToSearch.add(delta.getPath());
>       deltaDirs.add(delta.getPath());
>       minTxn = Math.min(minTxn, delta.getMinTransaction());
>       maxTxn = Math.max(maxTxn, delta.getMaxTransaction());
>     }
>     if (baseDir != null) job.set(BASE_DIR, baseDir.toString());
>     job.set(DELTA_DIRS, deltaDirs.toString());
>     job.set(DIRS_TO_SEARCH, dirsToSearch.toString());
>     job.setLong(MIN_TXN, minTxn);
>     job.setLong(MAX_TXN, maxTxn);
>     if (hiveConf.getBoolVar(HiveConf.ConfVars.HIVE_IN_TEST)) {
>       mrJob = job;
>     }
>     LOG.info("Submitting " + compactionType + " compaction job '" +
>       job.getJobName() + "' to " + job.getQueueName() + " queue.  " +
>       "(current delta dirs count=" + curDirNumber +
>       ", obsolete delta dirs count=" + obsoleteDirNumber + ". TxnIdRange[" + minTxn + "," + maxTxn + "]");
>     RunningJob rj = new JobClient(job).submitJob(job);
>     LOG.info("Submitted compaction job '" + job.getJobName() + "' with jobID=" + rj.getID() + " compaction ID=" + id);
>     txnHandler.setHadoopJobId(rj.getID().toString(), id);
>     rj.waitForCompletion();
>     if (!rj.isSuccessful()) {
>       throw new IOException(compactionType == CompactionType.MAJOR ? "Major" : "Minor" +
>           " compactor job failed for " + jobName + "! Hadoop JobId: " + rj.getID() );
>     }
>   }
> {code}
> We should close the JobClient to release resources (cached FS objects etc).
> Similarly for other classes listed above.



--
This message was sent by Atlassian JIRA
(v6.4.14#64029)