You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@tez.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2018/07/18 23:51:36 UTC

Failed: TEZ-3694 PreCommit Build #2867

Jira: https://issues.apache.org/jira/browse/TEZ-3694
Build: https://builds.apache.org/job/PreCommit-TEZ-Build/2867/

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 122.90 KB...]
======================================================================


  Running tests 
  /home/jenkins/tools/maven/latest/bin/mvn clean install -fn -DTezPatchProcess
cat: /home/jenkins/jenkins-slave/workspace/PreCommit-TEZ-Build/../patchprocess/testrun.txt: No such file or directory
awk: cannot open /home/jenkins/jenkins-slave/workspace/PreCommit-TEZ-Build/../patchprocess/testrun.txt (No such file or directory)




{color:red}-1 overall{color}.  Here are the results of testing the latest attachment
  http://issues.apache.org/jira/secure/attachment/12932130/TEZ-3694.2.patch
  against master revision 7e397b4.

    {color:green}+1 @author{color}.  The patch does not contain any @author tags.

    {color:green}+1 tests included{color}.  The patch appears to include 1 new or modified test files.

    {color:green}+1 javac{color}.  The applied patch does not increase the total number of javac compiler warnings.

    {color:green}+1 javadoc{color}.  There were no new javadoc warning messages.

    {color:green}+1 findbugs{color}.  The patch does not introduce any new Findbugs (version 3.0.1) warnings.

    {color:green}+1 release audit{color}.  The applied patch does not increase the total number of release audit warnings.

    {color:red}-1 core tests{color}.  The patch failed these unit tests in :
                   org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter
                  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter

Test results: https://builds.apache.org/job/PreCommit-TEZ-Build/2867//testReport/
Console output: https://builds.apache.org/job/PreCommit-TEZ-Build/2867//console

This message is automatically generated.


======================================================================
======================================================================
    Adding comment to Jira.
======================================================================
======================================================================




======================================================================
======================================================================
    Finished build.
======================================================================
======================================================================


Build step 'Execute shell' marked build as failure
Archiving artifacts
[description-setter] Could not determine description.
Recording test results
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any



###################################################################################
############################## FAILED TESTS (if any) ##############################
15 tests failed.
FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testMultipleSpills

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/b41db472-95a2-4e62-a22f-f9b7d76599b1_0/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/b41db472-95a2-4e62-a22f-f9b7d76599b1_0/file.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:641)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:867)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:631)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:211)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:949)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:403)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:760)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:699)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:147)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:791)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:880)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:874)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:842)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testMultipleSpills(TestPipelinedSorter.java:438)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testMultipleSpills_WithRLE

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/c7db87dd-2aab-4085-842a-a867e83002ff_0/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/c7db87dd-2aab-4085-842a-a867e83002ff_0/file.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:641)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:867)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:631)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:211)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:949)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:403)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:760)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:699)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:147)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:791)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:880)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeSimilarKeys(TestPipelinedSorter.java:860)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testMultipleSpills_WithRLE(TestPipelinedSorter.java:491)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testExceedsKVWithMultiplePartitions

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/3346c1ac-a79b-4faf-b44d-64eb694a3557_1/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/3346c1ac-a79b-4faf-b44d-64eb694a3557_1/file.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:641)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:867)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:631)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:211)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:949)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:403)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:760)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:699)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:147)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:791)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:880)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:874)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:842)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testExceedsKVWithMultiplePartitions(TestPipelinedSorter.java:279)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithCustomComparator

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/099abdc9-f65a-434f-a78a-2d7e0e0d0dc4_0/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/099abdc9-f65a-434f-a78a-2d7e0e0d0dc4_0/file.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:641)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:867)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:631)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:211)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:949)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:403)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:760)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:699)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:147)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:791)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:880)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:874)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:842)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.basicTest(TestPipelinedSorter.java:534)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithCustomComparator(TestPipelinedSorter.java:390)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithVariableKVLength1

Error Message:
chmod: cannot access '/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/2b173f70-159d-4d9b-b14a-825a29dafd87_1/file.out.index': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/2b173f70-159d-4d9b-b14a-825a29dafd87_1/file.out.index': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:994)
	at org.apache.hadoop.util.Shell.run(Shell.java:887)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:1212)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1306)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1288)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:777)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileOutputStream.<init>(RawLocalFileSystem.java:239)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileOutputStream.<init>(RawLocalFileSystem.java:219)
	at org.apache.hadoop.fs.RawLocalFileSystem.createOutputStreamWithMode(RawLocalFileSystem.java:318)
	at org.apache.hadoop.fs.RawLocalFileSystem.create(RawLocalFileSystem.java:307)
	at org.apache.hadoop.fs.RawLocalFileSystem.create(RawLocalFileSystem.java:292)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:1083)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:972)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:960)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.writeToFile(TezSpillRecord.java:129)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.writeToFile(TezSpillRecord.java:122)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.spillSingleRecord(PipelinedSorter.java:532)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.collect(PipelinedSorter.java:426)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.collect(PipelinedSorter.java:432)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.collect(PipelinedSorter.java:432)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.write(PipelinedSorter.java:379)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData2(TestPipelinedSorter.java:517)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.basicTest2(TestPipelinedSorter.java:504)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithVariableKVLength1(TestPipelinedSorter.java:361)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs_WithPipelinedShuffle[test[false, PRECISE]]

Error Message:
null

Stack Trace:
java.lang.AssertionError: null
	at org.junit.Assert.fail(Assert.java:86)
	at org.junit.Assert.assertTrue(Assert.java:41)
	at org.junit.Assert.assertTrue(Assert.java:52)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:472)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:642)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecordsWithoutFinalMerge[test[false, PRECISE]]

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_1552b697-70ad-4f9a-85bf-c0155af75fd5/output/1552b697-70ad-4f9a-85bf-c0155af75fd5_17/file.out.index': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_1552b697-70ad-4f9a-85bf-c0155af75fd5/output/1552b697-70ad-4f9a-85bf-c0155af75fd5_17/file.out.index': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:994)
	at org.apache.hadoop.util.Shell.run(Shell.java:887)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:1212)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1306)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1288)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:777)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.writeToFile(TezSpillRecord.java:146)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.writeToFile(TezSpillRecord.java:122)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.handleSpillIndex(UnorderedPartitionedKVWriter.java:1147)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.writeLargeRecord(UnorderedPartitionedKVWriter.java:1125)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:412)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:368)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:424)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecordsWithoutFinalMerge(TestUnorderedPartitionedKVWriter.java:344)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys[test[false, PRECISE]]

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_06c0609c-e794-4419-829d-4b39dd665362/output/06c0609c-e794-4419-829d-4b39dd665362_4/file.out': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_06c0609c-e794-4419-829d-4b39dd665362/output/06c0609c-e794-4419-829d-4b39dd665362_4/file.out': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:994)
	at org.apache.hadoop.util.Shell.run(Shell.java:887)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:1212)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1306)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1288)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.writeLargeRecord(UnorderedPartitionedKVWriter.java:1086)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:393)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:368)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:408)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys(TestUnorderedPartitionedKVWriter.java:304)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[true, DISABLED]]

Error Message:
null

Stack Trace:
java.lang.AssertionError: null
	at org.junit.Assert.fail(Assert.java:86)
	at org.junit.Assert.assertTrue(Assert.java:41)
	at org.junit.Assert.assertTrue(Assert.java:52)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:805)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:616)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions[test[true, DISABLED]]

Error Message:
test timed out after 10000 milliseconds

Stack Trace:
java.lang.Exception: test timed out after 10000 milliseconds
	at sun.misc.Unsafe.park(Native Method)
	at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
	at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
	at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getNextAvailableBuffer(UnorderedPartitionedKVWriter.java:545)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:470)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:416)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:368)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:1153)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:1097)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:288)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle[test[true, DISABLED]]

Error Message:
Could not find any valid local directory for output/c5292377-a125-495d-a833-10e7da666be1_2/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/c5292377-a125-495d-a833-10e7da666be1_2/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:442)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:152)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:133)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:211)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:803)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:621)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues[test[true, DISABLED]]

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_efc5bd20-500d-420c-ae36-45e7ea4b330a/output/efc5bd20-500d-420c-ae36-45e7ea4b330a_3/file.out': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_efc5bd20-500d-420c-ae36-45e7ea4b330a/output/efc5bd20-500d-420c-ae36-45e7ea4b330a_3/file.out': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:994)
	at org.apache.hadoop.util.Shell.run(Shell.java:887)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:1212)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1306)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1288)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:777)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileOutputStream.<init>(RawLocalFileSystem.java:239)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileOutputStream.<init>(RawLocalFileSystem.java:219)
	at org.apache.hadoop.fs.RawLocalFileSystem.createOutputStreamWithMode(RawLocalFileSystem.java:318)
	at org.apache.hadoop.fs.RawLocalFileSystem.create(RawLocalFileSystem.java:307)
	at org.apache.hadoop.fs.RawLocalFileSystem.create(RawLocalFileSystem.java:292)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:1083)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:972)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:960)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.writeLargeRecord(UnorderedPartitionedKVWriter.java:1084)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:412)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:368)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:424)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues(TestUnorderedPartitionedKVWriter.java:309)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithFinalMergeDisabled[test[true, DISABLED]]

Error Message:
test timed out after 10000 milliseconds

Stack Trace:
java.lang.Exception: test timed out after 10000 milliseconds
	at sun.misc.Unsafe.park(Native Method)
	at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
	at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
	at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getNextAvailableBuffer(UnorderedPartitionedKVWriter.java:545)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:470)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:416)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:368)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithFinalMergeDisabled(TestUnorderedPartitionedKVWriter.java:933)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithFinalMergeDisabled(TestUnorderedPartitionedKVWriter.java:882)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[true, DISABLED]]

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_9d2044c8-d1fa-4673-85bf-bbc708bc285c/output/9d2044c8-d1fa-4673-85bf-bbc708bc285c/file.out': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_9d2044c8-d1fa-4673-85bf-bbc708bc285c/output/9d2044c8-d1fa-4673-85bf-bbc708bc285c/file.out': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:994)
	at org.apache.hadoop.util.Shell.run(Shell.java:887)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:1212)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1306)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:1288)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:995)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:757)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:448)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:299)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithFinalMergeDisabled[test[true, DISABLED]]

Error Message:
test timed out after 10000 milliseconds

Stack Trace:
java.lang.Exception: test timed out after 10000 milliseconds
	at sun.misc.Unsafe.park(Native Method)
	at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
	at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
	at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getNextAvailableBuffer(UnorderedPartitionedKVWriter.java:545)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:470)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:416)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:368)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithFinalMergeDisabled(TestUnorderedPartitionedKVWriter.java:933)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithFinalMergeDisabled(TestUnorderedPartitionedKVWriter.java:867)