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:37:12 UTC

Failed: TEZ-3942 PreCommit Build #2868

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

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 347.29 KB...]
Running org.apache.tez.dag.history.logging.ats.TestATSV15HistoryLoggingService
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.618 sec
Running org.apache.tez.dag.history.ats.acls.TestATSHistoryV15




{color:red}-1 overall{color}.  Here are the results of testing the latest attachment
  http://issues.apache.org/jira/secure/attachment/12932149/TEZ-3942.003.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
                  org.apache.tez.dag.app.TestRecoveryParser

                                      The following test timeouts occurred in :
 org.apache.tez.runtime.libraryTests

Test results: https://builds.apache.org/job/PreCommit-TEZ-Build/2868//testReport/
Console output: https://builds.apache.org/job/PreCommit-TEZ-Build/2868//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.dag.app.TestRecoveryParser.testLastCorruptedRecoveryRecord

Error Message:
null

Stack Trace:
java.lang.NullPointerException: null
	at org.apache.tez.dag.app.TestRecoveryParser.testLastCorruptedRecoveryRecord(TestRecoveryParser.java:288)


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

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/91a676a3-48fa-4075-ac1d-2e842788ef79_0/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/91a676a3-48fa-4075-ac1d-2e842788ef79_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.basicTest(TestPipelinedSorter.java:151)


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

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/501720bd-8175-4bdf-be75-5eca6b502378_3/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/501720bd-8175-4bdf-be75-5eca6b502378_3/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.testWithLargeKeyValueWithMinBlockSize(TestPipelinedSorter.java:827)


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/3e46b418-a422-4b59-ab8b-d19d327c1886_0/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/3e46b418-a422-4b59-ab8b-d19d327c1886_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.test_with_lazyMemAllocation

Error Message:
File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/8186ce92-e0ef-4cf2-8349-cd271d733aa2_0/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/8186ce92-e0ef-4cf2-8349-cd271d733aa2_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.test_with_lazyMemAllocation(TestPipelinedSorter.java:742)


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

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_29f1101e-84b3-423b-b75a-a80b6e1df6d4/output/29f1101e-84b3-423b-b75a-a80b6e1df6d4_0/file.out.index': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_29f1101e-84b3-423b-b75a-a80b6e1df6d4/output/29f1101e-84b3-423b-b75a-a80b6e1df6d4_0/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.writers.UnorderedPartitionedKVWriter.handleSpillIndex(UnorderedPartitionedKVWriter.java:1147)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.access$1400(UnorderedPartitionedKVWriter.java:89)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter$SpillCallable.callInternal(UnorderedPartitionedKVWriter.java:644)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter$SpillCallable.callInternal(UnorderedPartitionedKVWriter.java:557)
	at org.apache.tez.common.CallableWithNdc.call(CallableWithNdc.java:36)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	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)


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

Error Message:
Mkdirs failed to create /tmp/TestUnorderedPartitionedKVWriter/outDir_40ef4d1d-d36a-44a3-87f4-f2df15a35993/output/40ef4d1d-d36a-44a3-87f4-f2df15a35993_2

Stack Trace:
java.io.IOException: Mkdirs failed to create /tmp/TestUnorderedPartitionedKVWriter/outDir_40ef4d1d-d36a-44a3-87f4-f2df15a35993/output/40ef4d1d-d36a-44a3-87f4-f2df15a35993_2
	at org.apache.hadoop.fs.RawLocalFileSystem.create(RawLocalFileSystem.java:304)
	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$SpillCallable.callInternal(UnorderedPartitionedKVWriter.java:594)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter$SpillCallable.callInternal(UnorderedPartitionedKVWriter.java:557)
	at org.apache.tez.common.CallableWithNdc.call(CallableWithNdc.java:36)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	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)


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

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_fe7cf6be-912a-42bd-ba5b-38d8206dd727/output/fe7cf6be-912a-42bd-ba5b-38d8206dd727_5/file.out': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_fe7cf6be-912a-42bd-ba5b-38d8206dd727/output/fe7cf6be-912a-42bd-ba5b-38d8206dd727_5/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: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:440)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:314)


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

Error Message:
File /tmp/TestUnorderedPartitionedKVWriter/outDir_bb13417c-8d96-4008-8101-a15d48f923ed/output/bb13417c-8d96-4008-8101-a15d48f923ed_1/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/TestUnorderedPartitionedKVWriter/outDir_bb13417c-8d96-4008-8101-a15d48f923ed/output/bb13417c-8d96-4008-8101-a15d48f923ed_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.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:1020)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:757)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:1156)
	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[false, DISABLED]]

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_281a2a5d-3476-498b-a8af-9cdc6954892a': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_281a2a5d-3476-498b-a8af-9cdc6954892a': 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.mkOneDirWithMode(RawLocalFileSystem.java:522)
	at org.apache.hadoop.fs.RawLocalFileSystem.mkdirsWithOptionalPermission(RawLocalFileSystem.java:562)
	at org.apache.hadoop.fs.RawLocalFileSystem.mkdirs(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.mkdirsWithOptionalPermission(RawLocalFileSystem.java:561)
	at org.apache.hadoop.fs.RawLocalFileSystem.mkdirs(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.mkdirsWithOptionalPermission(RawLocalFileSystem.java:561)
	at org.apache.hadoop.fs.RawLocalFileSystem.mkdirs(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.create(RawLocalFileSystem.java:303)
	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.writers.UnorderedPartitionedKVWriter.handleSpillIndex(UnorderedPartitionedKVWriter.java:1147)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.access$1400(UnorderedPartitionedKVWriter.java:89)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter$SpillCallable.callInternal(UnorderedPartitionedKVWriter.java:644)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter$SpillCallable.callInternal(UnorderedPartitionedKVWriter.java:557)
	at org.apache.tez.common.CallableWithNdc.call(CallableWithNdc.java:36)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.finalSpill(UnorderedPartitionedKVWriter.java:908)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:790)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:702)
	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[false, DISABLED]]

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_56abab5e-5b71-4945-ab5a-d93a86996de6/output/56abab5e-5b71-4945-ab5a-d93a86996de6/file.out.index': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_56abab5e-5b71-4945-ab5a-d93a86996de6/output/56abab5e-5b71-4945-ab5a-d93a86996de6/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.mergeAll(UnorderedPartitionedKVWriter.java:1054)
	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.testLargevalues(TestUnorderedPartitionedKVWriter.java:309)


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

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.testTextMixedRecordsWithoutFinalMerge(TestUnorderedPartitionedKVWriter.java:344)


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

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_c435caf8-5fa2-4f41-ac36-d7b2b2dec165/output/c435caf8-5fa2-4f41-ac36-d7b2b2dec165/file.out': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_c435caf8-5fa2-4f41-ac36-d7b2b2dec165/output/c435caf8-5fa2-4f41-ac36-d7b2b2dec165/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.sort.impl.IFile$Writer.<init>(IFile.java:126)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.<init>(UnorderedPartitionedKVWriter.java:282)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter$UnorderedPartitionedKVWriterForTest.<init>(TestUnorderedPartitionedKVWriter.java:1398)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithFinalMergeDisabled(TestUnorderedPartitionedKVWriter.java:915)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoRecords_SinglePartition_WithFinalMergeDisabled(TestUnorderedPartitionedKVWriter.java:877)


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

Error Message:
chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_c213fd85-a5ac-4cef-847e-80c8bb4cddbc/output/c213fd85-a5ac-4cef-847e-80c8bb4cddbc_15/file.out.index': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestUnorderedPartitionedKVWriter/outDir_c213fd85-a5ac-4cef-847e-80c8bb4cddbc/output/c213fd85-a5ac-4cef-847e-80c8bb4cddbc_15/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[true, NONE]]

Error Message:
File /tmp/TestUnorderedPartitionedKVWriter/outDir_6dabce50-2762-4a36-a86c-63f6134d9caf/output/6dabce50-2762-4a36-a86c-63f6134d9caf/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/TestUnorderedPartitionedKVWriter/outDir_6dabce50-2762-4a36-a86c-63f6134d9caf/output/6dabce50-2762-4a36-a86c-63f6134d9caf/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.FilterFileSystem.getFileStatus(FilterFileSystem.java:442)
	at org.apache.hadoop.fs.FileSystem.getContentSummary(FileSystem.java:1726)
	at org.apache.hadoop.fs.ChecksumFileSystem$FSDataBoundedInputStream.getFileLength(ChecksumFileSystem.java:285)
	at org.apache.hadoop.fs.ChecksumFileSystem$FSDataBoundedInputStream.seek(ChecksumFileSystem.java:328)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:535)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys(TestUnorderedPartitionedKVWriter.java:304)

Success: TEZ-3942 PreCommit Build #2869

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Jira: https://issues.apache.org/jira/browse/TEZ-3942
Build: https://builds.apache.org/job/PreCommit-TEZ-Build/2869/

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 376.92 KB...]
[INFO] tez-dist ........................................... SUCCESS [ 48.456 s]
[INFO] Tez ................................................ SUCCESS [  0.048 s]
[INFO] ------------------------------------------------------------------------
[INFO] BUILD SUCCESS
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 01:04 h
[INFO] Finished at: 2018-07-19T17:29:39Z
[INFO] Final Memory: 96M/1647M
[INFO] ------------------------------------------------------------------------




{color:green}+1 overall{color}.  Here are the results of testing the latest attachment
  http://issues.apache.org/jira/secure/attachment/12932149/TEZ-3942.003.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:green}+1 core tests{color}.  The patch passed unit tests in .

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

This message is automatically generated.


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




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


Archiving artifacts
[Fast Archiver] Compressed 4.09 MB of artifacts by 25.2% relative to #2865
[description-setter] Description set: TEZ-3942
Recording test results
Email was triggered for: Success
Sending email for trigger: Success



###################################################################################
############################## FAILED TESTS (if any) ##############################
All tests passed