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 2016/11/18 22:45:03 UTC

Failed: TEZ-1869 PreCommit Build #2113

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

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 5749 lines...]

    {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.TestTezMerger
                  org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter
                  org.apache.tez.runtime.library.common.sort.impl.dflt.TestDefaultSorter
                  org.apache.tez.runtime.library.common.sort.impl.TestIFile
                  org.apache.tez.runtime.library.common.shuffle.orderedgrouped.TestMergeManager
                  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter
                  org.apache.tez.dag.app.TestDAGAppMaster
                  org.apache.tez.mapreduce.processor.map.TestMapProcessor
                  org.apache.tez.mapreduce.processor.reduce.TestReduceProcessor
                  org.apache.hadoop.mapred.split.TestGroupedSplits

                                      The following test timeouts occurred in :
 org.apache.tez.runtime.api.impl.TestProcessorContext
org.apache.tez.runtime.common.objectrTests
org.apache.tez.dag.library.vertexmanager.TestInputReadyVertexManager
org.apache.tez.dag.library.vertexmanager.TestFairShuffleVerteTests
org.apache.tez.dag.library.vertexmanager.TestShuffleVertexManageTests
org.apache.tez.runtime.library.output.TestUnordTests
org.apache.tez.runtime.library.output.TestOnFilTests
org.apache.tez.runtime.library.output.TestOrderedPartitionedKVOutput2
org.apache.tez.runtime.library.input.TestOrdeTests
org.apache.tez.dag.history.logging.ats.TestATSHistoryWithMiniCluster

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

This message is automatically generated.


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


Comment added.
e4fdb16cc76b2fe0d6ddeab79805675987cf6042 logged out


======================================================================
======================================================================
    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) ##############################
95 tests failed.
FAILED:  org.apache.tez.dag.app.TestDAGAppMaster.testInvalidSession

Error Message:
java.io.FileNotFoundException: /tmp/TestDAGAppMaster/tez.session.local-resources.pb (No such file or directory)

Stack Trace:
org.apache.hadoop.service.ServiceStateException: java.io.FileNotFoundException: /tmp/TestDAGAppMaster/tez.session.local-resources.pb (No such file or directory)
	at java.io.FileInputStream.open(Native Method)
	at java.io.FileInputStream.<init>(FileInputStream.java:146)
	at org.apache.tez.dag.app.DAGAppMaster.serviceInit(DAGAppMaster.java:615)
	at org.apache.tez.dag.app.TestDAGAppMaster$DAGAppMasterForTest.serviceInit(TestDAGAppMaster.java:575)
	at org.apache.hadoop.service.AbstractService.init(AbstractService.java:163)
	at org.apache.tez.dag.app.TestDAGAppMaster.testInvalidSession(TestDAGAppMaster.java:115)


FAILED:  org.apache.hadoop.mapred.split.TestGroupedSplits.testFormat

Error Message:
chmod: cannot access '/tmp/TestCombineTextInputFormat/test_1.txt': No such file or directory


Stack Trace:
org.apache.hadoop.util.Shell$ExitCodeException: chmod: cannot access '/tmp/TestCombineTextInputFormat/test_1.txt': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:538)
	at org.apache.hadoop.util.Shell.run(Shell.java:455)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:715)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:808)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:791)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:656)
	at org.apache.hadoop.fs.FilterFileSystem.setPermission(FilterFileSystem.java:490)
	at org.apache.hadoop.fs.ChecksumFileSystem.create(ChecksumFileSystem.java:462)
	at org.apache.hadoop.fs.ChecksumFileSystem.create(ChecksumFileSystem.java:428)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:908)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:889)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:786)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:775)
	at org.apache.hadoop.mapred.split.TestGroupedSplits.createFiles(TestGroupedSplits.java:192)
	at org.apache.hadoop.mapred.split.TestGroupedSplits.testFormat(TestGroupedSplits.java:107)


FAILED:  org.apache.tez.mapreduce.processor.map.TestMapProcessor.testMapProcessorProgress

Error Message:
Checksum error: file:/tmp/TestMapProcessor/map0 at 2620416

Stack Trace:
org.apache.hadoop.fs.ChecksumException: Checksum error: file:/tmp/TestMapProcessor/map0 at 2620416
	at org.apache.hadoop.fs.ChecksumFileSystem$ChecksumFSInputChecker.readChunk(ChecksumFileSystem.java:254)
	at org.apache.hadoop.fs.FSInputChecker.readChecksumChunk(FSInputChecker.java:276)
	at org.apache.hadoop.fs.FSInputChecker.fill(FSInputChecker.java:214)
	at org.apache.hadoop.fs.FSInputChecker.read1(FSInputChecker.java:232)
	at org.apache.hadoop.fs.FSInputChecker.read(FSInputChecker.java:196)
	at java.io.DataInputStream.readFully(DataInputStream.java:195)
	at org.apache.hadoop.io.DataOutputBuffer$Buffer.write(DataOutputBuffer.java:70)
	at org.apache.hadoop.io.DataOutputBuffer.write(DataOutputBuffer.java:120)
	at org.apache.hadoop.io.SequenceFile$Reader.next(SequenceFile.java:2359)
	at org.apache.hadoop.io.SequenceFile$Reader.next(SequenceFile.java:2491)
	at org.apache.hadoop.mapred.SequenceFileRecordReader.next(SequenceFileRecordReader.java:82)
	at org.apache.tez.mapreduce.processor.map.MapProcessor$OldRecordReader.next(MapProcessor.java:329)
	at org.apache.hadoop.mapred.MapRunner.run(MapRunner.java:52)
	at org.apache.tez.mapreduce.processor.map.MapProcessor.runOldMapper(MapProcessor.java:194)
	at org.apache.tez.mapreduce.processor.map.MapProcessor.run(MapProcessor.java:137)
	at org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:370)
	at org.apache.tez.mapreduce.processor.map.TestMapProcessor.testMapProcessorProgress(TestMapProcessor.java:258)


FAILED:  org.apache.tez.mapreduce.processor.reduce.TestReduceProcessor.testReduceProcessor

Error Message:
File file:/tmp/TestReduceProcessor/localized-resources/job.splitmetainfo does not exist

Stack Trace:
java.io.FileNotFoundException: File file:/tmp/TestReduceProcessor/localized-resources/job.splitmetainfo does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:747)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:524)
	at org.apache.hadoop.fs.FilterFileSystem.getFileStatus(FilterFileSystem.java:409)
	at org.apache.hadoop.mapreduce.split.SplitMetaInfoReaderTez.readSplitMetaInfo(SplitMetaInfoReaderTez.java:77)
	at org.apache.tez.mapreduce.lib.MRInputUtils.readSplits(MRInputUtils.java:52)
	at org.apache.tez.mapreduce.input.MRInput.initializeInternal(MRInput.java:493)
	at org.apache.tez.mapreduce.input.MRInputLegacy.init(MRInputLegacy.java:113)
	at org.apache.tez.mapreduce.processor.map.MapProcessor.run(MapProcessor.java:116)
	at org.apache.tez.runtime.LogicalIOProcessorRuntimeTask.run(LogicalIOProcessorRuntimeTask.java:370)
	at org.apache.tez.mapreduce.processor.reduce.TestReduceProcessor.testReduceProcessor(TestReduceProcessor.java:164)


FAILED:  org.apache.tez.runtime.library.common.shuffle.orderedgrouped.TestMergeManager.testLocalDiskMergeMultipleTasks

Error Message:
file:/tmp/TestMergeManager/srcData/attemptsrc1.out

Stack Trace:
java.io.FileNotFoundException: file:/tmp/TestMergeManager/srcData/attemptsrc1.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:753)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:149)
	at org.apache.tez.runtime.library.common.shuffle.orderedgrouped.MergeManager$OnDiskMerger.merge(MergeManager.java:951)
	at org.apache.tez.runtime.library.common.shuffle.orderedgrouped.TestMergeManager.testLocalDiskMergeMultipleTasks(TestMergeManager.java:854)
	at org.apache.tez.runtime.library.common.shuffle.orderedgrouped.TestMergeManager.testLocalDiskMergeMultipleTasks(TestMergeManager.java:627)


FAILED:  org.apache.tez.runtime.library.common.shuffle.orderedgrouped.TestMergeManager.testOnDiskMergerFilenames

Error Message:
Could not find any valid local directory for d55bc196-99dd-4f22-9226-a5c4cf34f4fd_src_0_spill_-1

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for d55bc196-99dd-4f22-9226-a5c4cf34f4fd_src_0_spill_-1
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.shuffle.orderedgrouped.MergeManager$OnDiskMerger.merge(MergeManager.java:941)
	at org.apache.tez.runtime.library.common.shuffle.orderedgrouped.TestMergeManager.testOnDiskMergerFilenames(TestMergeManager.java:688)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testAppendValues

Error Message:
Premature EOF from inputStream

Stack Trace:
java.io.IOException: Premature EOF from inputStream
	at org.apache.hadoop.io.IOUtils.readFully(IOUtils.java:194)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.isCompressedFlagEnabled(IFile.java:843)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.readToMemory(IFile.java:612)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readFileUsingInMemoryReader(TestIFile.java:569)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readAndVerifyData(TestIFile.java:551)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testAppendValues(TestIFile.java:379)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testAppendKeyValues

Error Message:
chmod: cannot access '/tmp/org.apache.tez.runtime.library.common.sort.impl.TestIFile/ifile.out': 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.TestIFile/ifile.out': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:538)
	at org.apache.hadoop.util.Shell.run(Shell.java:455)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:715)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:808)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:791)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:656)
	at org.apache.hadoop.fs.FilterFileSystem.setPermission(FilterFileSystem.java:490)
	at org.apache.hadoop.fs.ChecksumFileSystem.create(ChecksumFileSystem.java:462)
	at org.apache.hadoop.fs.ChecksumFileSystem.create(ChecksumFileSystem.java:428)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:908)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:889)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:786)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:775)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Writer.<init>(IFile.java:125)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testAppendKeyValues(TestIFile.java:395)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testAppendValueWithDataInputBuffer

Error Message:
Checksum Error:  CurrentOffset=122, offset=122, off=122, dataLength=133, origLen=189, len=11, length=137, checksumSize=4

Stack Trace:
org.apache.hadoop.fs.ChecksumException: Checksum Error:  CurrentOffset=122, offset=122, off=122, dataLength=133, origLen=189, len=11, length=137, checksumSize=4
	at org.apache.tez.runtime.library.common.sort.impl.IFileInputStream.doRead(IFileInputStream.java:255)
	at org.apache.tez.runtime.library.common.sort.impl.IFileInputStream.read(IFileInputStream.java:185)
	at org.apache.hadoop.io.IOUtils.readFully(IOUtils.java:192)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.readToMemory(IFile.java:629)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readFileUsingInMemoryReader(TestIFile.java:569)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readAndVerifyData(TestIFile.java:551)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testAppendValueWithDataInputBuffer(TestIFile.java:432)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithEmptyIFile

Error Message:
Premature EOF from inputStream

Stack Trace:
java.io.IOException: Premature EOF from inputStream
	at org.apache.hadoop.io.IOUtils.readFully(IOUtils.java:194)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.isCompressedFlagEnabled(IFile.java:843)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.<init>(IFile.java:547)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.<init>(IFile.java:527)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readUsingIFileReader(TestIFile.java:593)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readAndVerifyData(TestIFile.java:552)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWriterAndReader(TestIFile.java:483)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithEmptyIFile(TestIFile.java:107)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testReadToDisk

Error Message:
Checksum error: file:/tmp/org.apache.tez.runtime.library.common.sort.impl.TestIFile/ifile.out at 0 exp: 1751872868 got: -2076936909

Stack Trace:
org.apache.hadoop.fs.ChecksumException: Checksum error: file:/tmp/org.apache.tez.runtime.library.common.sort.impl.TestIFile/ifile.out at 0 exp: 1751872868 got: -2076936909
	at org.apache.hadoop.fs.FSInputChecker.verifySums(FSInputChecker.java:323)
	at org.apache.hadoop.fs.FSInputChecker.readChecksumChunk(FSInputChecker.java:279)
	at org.apache.hadoop.fs.FSInputChecker.fill(FSInputChecker.java:214)
	at org.apache.hadoop.fs.FSInputChecker.read1(FSInputChecker.java:232)
	at org.apache.hadoop.fs.FSInputChecker.read(FSInputChecker.java:196)
	at java.io.DataInputStream.read(DataInputStream.java:149)
	at org.apache.hadoop.io.IOUtils.readFully(IOUtils.java:192)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.readToDisk(IFile.java:677)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testReadToDisk(TestIFile.java:464)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithSortedData

Error Message:
Premature EOF from inputStream

Stack Trace:
java.io.IOException: Premature EOF from inputStream
	at org.apache.hadoop.io.IOUtils.readFully(IOUtils.java:194)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.isCompressedFlagEnabled(IFile.java:843)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.<init>(IFile.java:547)
	at org.apache.tez.runtime.library.common.sort.impl.IFile$Reader.<init>(IFile.java:527)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readUsingIFileReader(TestIFile.java:593)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.readAndVerifyData(TestIFile.java:552)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWriterAndReader(TestIFile.java:483)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithSortedData(TestIFile.java:168)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithUniqueKeys

Error Message:
chmod: cannot access '/tmp/org.apache.tez.runtime.library.common.sort.impl.TestIFile/ifile.out': 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.TestIFile/ifile.out': No such file or directory

	at org.apache.hadoop.util.Shell.runCommand(Shell.java:538)
	at org.apache.hadoop.util.Shell.run(Shell.java:455)
	at org.apache.hadoop.util.Shell$ShellCommandExecutor.execute(Shell.java:715)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:808)
	at org.apache.hadoop.util.Shell.execCommand(Shell.java:791)
	at org.apache.hadoop.fs.RawLocalFileSystem.setPermission(RawLocalFileSystem.java:656)
	at org.apache.hadoop.fs.FilterFileSystem.setPermission(FilterFileSystem.java:490)
	at org.apache.hadoop.fs.ChecksumFileSystem.create(ChecksumFileSystem.java:462)
	at org.apache.hadoop.fs.ChecksumFileSystem.create(ChecksumFileSystem.java:428)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:908)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:889)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:786)
	at org.apache.hadoop.fs.FileSystem.create(FileSystem.java:775)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.writeTestFileUsingDataBuffer(TestIFile.java:677)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithDataBuffer(TestIFile.java:527)
	at org.apache.tez.runtime.library.common.sort.impl.TestIFile.testWithUniqueKeys(TestIFile.java:245)


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

Error Message:
/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/d5f90a1e-33fa-461d-9535-6d1f4999eca5_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/d5f90a1e-33fa-461d-9535-6d1f4999eca5_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:753)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:170)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:754)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:720)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:714)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:701)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.basicTest(TestPipelinedSorter.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testKVExceedsBuffer(TestPipelinedSorter.java:196)


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/90d74b64-9a1a-4b93-87d2-8934e4512bfe/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/90d74b64-9a1a-4b93-87d2-8934e4512bfe/file.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:747)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:524)
	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:720)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:714)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:701)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.basicTest(TestPipelinedSorter.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithLargeKeyValueWithMinBlockSize(TestPipelinedSorter.java:697)


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

Error Message:
/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/26bc1acf-3775-4f7a-9fc0-daf0c1b94c73_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/26bc1acf-3775-4f7a-9fc0-daf0c1b94c73_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:753)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:170)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:754)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:720)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:714)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:701)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testExceedsKVWithMultiplePartitions(TestPipelinedSorter.java:216)


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

Error Message:
/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/f14d5b55-98c5-4b72-aeca-a91073e3a73a_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/f14d5b55-98c5-4b72-aeca-a91073e3a73a_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:753)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:170)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:754)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:720)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:714)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData(TestPipelinedSorter.java:701)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.basicTest(TestPipelinedSorter.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithCustomComparator(TestPipelinedSorter.java:328)


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

Error Message:
/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/2a65bb09-edc6-456d-9167-d3225754e8fd_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/2a65bb09-edc6-456d-9167-d3225754e8fd_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:753)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:170)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:754)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.closeSorter(TestPipelinedSorter.java:720)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.test_with_lazyMemAllocation(TestPipelinedSorter.java:645)


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

Error Message:
/tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/d1029392-200a-4875-a3ec-94c5272980f9_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter/output/d1029392-200a-4875-a3ec-94c5272980f9_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.init(TezMerger.java:405)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:753)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:170)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.flush(PipelinedSorter.java:754)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.test_TEZ_2602_50mb(TestPipelinedSorter.java:259)


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

Error Message:
No space available in any of the local directories.

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: No space available in any of the local directories.
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:366)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.spillSingleRecord(PipelinedSorter.java:466)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.collect(PipelinedSorter.java:413)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.collect(PipelinedSorter.java:419)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.collect(PipelinedSorter.java:419)
	at org.apache.tez.runtime.library.common.sort.impl.PipelinedSorter.write(PipelinedSorter.java:366)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.writeData2(TestPipelinedSorter.java:388)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.basicTest2(TestPipelinedSorter.java:375)
	at org.apache.tez.runtime.library.common.sort.impl.TestPipelinedSorter.testWithVariableKVLength1(TestPipelinedSorter.java:298)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.testMerge

Error Message:
File file:/tmp/org.apache.tez.runtime.library.common.sort.impl.TestTezMerger/src/data_9160081343925123.out does not exist

Stack Trace:
java.io.FileNotFoundException: File file:/tmp/org.apache.tez.runtime.library.common.sort.impl.TestTezMerger/src/data_9160081343925123.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:747)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:524)
	at org.apache.hadoop.fs.FilterFileSystem.getFileStatus(FilterFileSystem.java:409)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$DiskSegment.<init>(TezMerger.java:370)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.<init>(TezMerger.java:514)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger.merge(TezMerger.java:83)
	at org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.merge(TestTezMerger.java:605)
	at org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.merge(TestTezMerger.java:599)
	at org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.testMerge(TestTezMerger.java:124)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.testMergeSegments

Error Message:
Could not find any valid local directory for file:/tmp/org.apache.tez.runtime.library.common.sort.impl.TestTezMerger/tmp_9160082213963045/intermediate.1

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for file:/tmp/org.apache.tez.runtime.library.common.sort.impl.TestTezMerger/tmp_9160082213963045/intermediate.1
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:837)
	at org.apache.tez.runtime.library.common.sort.impl.TezMerger$MergeQueue.merge(TezMerger.java:694)
	at org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.mergeSegments(TestTezMerger.java:704)
	at org.apache.tez.runtime.library.common.sort.impl.TestTezMerger.testMergeSegments(TestTezMerger.java:682)


FAILED:  org.apache.tez.runtime.library.common.sort.impl.dflt.TestDefaultSorter.testWithMultipleSpillsWithFinalMergeDisabled

Error Message:
Spill failed

Stack Trace:
java.io.IOException: Spill failed
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.sort.impl.dflt.DefaultSorter.spill(DefaultSorter.java:878)
	at org.apache.tez.runtime.library.common.sort.impl.dflt.DefaultSorter.sortAndSpill(DefaultSorter.java:847)
	at org.apache.tez.runtime.library.common.sort.impl.dflt.DefaultSorter$SpillThread.run(DefaultSorter.java:766)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[false, DISABLED, {2}]]

Error Message:
Could not find any valid local directory for output/3c885b0d-8657-4f74-90e1-b702e7643b1f_1/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/3c885b0d-8657-4f74-90e1-b702e7643b1f_1/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:721)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.finalSpill(UnorderedPartitionedKVWriter.java:677)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)


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

Error Message:
Could not find any valid local directory for output/e07bf1fd-44fa-497e-af07-1a73b9ff2c88_3/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/e07bf1fd-44fa-497e-af07-1a73b9ff2c88_3/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:721)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.finalSpill(UnorderedPartitionedKVWriter.java:677)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


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

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_e99ad9a8-4ef9-46ca-973d-707fe6a60c36/output/e99ad9a8-4ef9-46ca-973d-707fe6a60c36_3/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_e99ad9a8-4ef9-46ca-973d-707fe6a60c36/output/e99ad9a8-4ef9-46ca-973d-707fe6a60c36_3/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[false, DISABLED, {2}]]

Error Message:
Could not find any valid local directory for output/8b5fced3-478c-4a7f-9c47-c0b9dfddb423_1/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/8b5fced3-478c-4a7f-9c47-c0b9dfddb423_1/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:289)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:297)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[false, DISABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_dd414840-a325-4ffa-b731-00319972e343/output/dd414840-a325-4ffa-b731-00319972e343_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_dd414840-a325-4ffa-b731-00319972e343/output/dd414840-a325-4ffa-b731-00319972e343_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[false, DISABLED, {2}]]

Error Message:
Could not find any valid local directory for output/417fe092-626f-45fd-8c14-6c8f428fe0d1_1/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/417fe092-626f-45fd-8c14-6c8f428fe0d1_1/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:289)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:297)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs_WithPipelinedShuffle[test[false, DISABLED, {2}]]

Error Message:
Could not find any valid local directory for output/221c5121-fa49-4a50-b31c-96534796a23e_27/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/221c5121-fa49-4a50-b31c-96534796a23e_27/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:721)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.writeLargeRecord(UnorderedPartitionedKVWriter.java:819)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:322)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:326)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:515)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys[test[false, DISABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_9d6503c5-374f-4a0c-9e6e-c5b9491a36fb/output/9d6503c5-374f-4a0c-9e6e-c5b9491a36fb_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_9d6503c5-374f-4a0c-9e6e-c5b9491a36fb/output/9d6503c5-374f-4a0c-9e6e-c5b9491a36fb_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys(TestUnorderedPartitionedKVWriter.java:234)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoSpill[test[false, DISABLED, {2}]]

Error Message:
Cannot seek after EOF

Stack Trace:
java.io.EOFException: Cannot seek after EOF
	at org.apache.hadoop.fs.ChecksumFileSystem$FSDataBoundedInputStream.seek(ChecksumFileSystem.java:323)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:871)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoSpill(TestUnorderedPartitionedKVWriter.java:198)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill[test[false, DISABLED, {2}]]

Error Message:
Could not find any valid local directory for output/ca6ca92d-f0d2-4540-9871-a8a461435dd2/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/ca6ca92d-f0d2-4540-9871-a8a461435dd2/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getOutputFileForWrite(TezTaskOutputFiles.java:91)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:711)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:738)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill(TestUnorderedPartitionedKVWriter.java:203)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[false, ENABLED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[false, ENABLED, {2}]]

Error Message:
Could not find any valid local directory for output/31ce8ea7-c21a-4f83-819f-443b406113cb_3/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/31ce8ea7-c21a-4f83-819f-443b406113cb_3/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.writeLargeRecord(UnorderedPartitionedKVWriter.java:819)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:322)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:342)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions[test[false, ENABLED, {2}]]

Error Message:
Could not find any valid local directory for output/633d57f5-79a6-433a-af52-2ce7e15948e7_1/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/633d57f5-79a6-433a-af52-2ce7e15948e7_1/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:326)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:749)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:218)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle[test[false, ENABLED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:500)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[false, ENABLED, {2}]]

Error Message:
Could not find any valid local directory for output/5886263e-3bc7-410c-99d5-42c5b38c4d33/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/5886263e-3bc7-410c-99d5-42c5b38c4d33/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getOutputFileForWrite(TezTaskOutputFiles.java:91)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:711)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:738)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[false, ENABLED, {2}]]

Error Message:
Could not find any valid local directory for output/307e47c9-9cdd-400d-9946-c2174263ae5f_3/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/307e47c9-9cdd-400d-9946-c2174263ae5f_3/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:326)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:749)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[false, ENABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_ead6a752-3930-49b4-8079-ef819f5595cb/output/ead6a752-3930-49b4-8079-ef819f5595cb_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_ead6a752-3930-49b4-8079-ef819f5595cb/output/ead6a752-3930-49b4-8079-ef819f5595cb_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill[test[false, ENABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_014c0893-72df-4460-9432-7396dc07a669/output/014c0893-72df-4460-9432-7396dc07a669_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_014c0893-72df-4460-9432-7396dc07a669/output/014c0893-72df-4460-9432-7396dc07a669_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill(TestUnorderedPartitionedKVWriter.java:203)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[false, NONE, {2}]]

Error Message:
Could not find any valid local directory for output/6eccfef1-6c40-4a4a-9054-c472d8fc54e8_1/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/6eccfef1-6c40-4a4a-9054-c472d8fc54e8_1/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:721)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.finalSpill(UnorderedPartitionedKVWriter.java:677)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[false, NONE, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[false, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_b546bfba-8735-48ea-b51b-af4c57899aa2/output/b546bfba-8735-48ea-b51b-af4c57899aa2_2/file.out (No such file or directory)

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_b546bfba-8735-48ea-b51b-af4c57899aa2/output/b546bfba-8735-48ea-b51b-af4c57899aa2_2/file.out (No such file or directory)
	at java.io.FileInputStream.open(Native Method)
	at java.io.FileInputStream.<init>(FileInputStream.java:146)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileInputStream.<init>(RawLocalFileSystem.java:104)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:200)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions[test[false, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_f2e610d6-8b0b-4a70-9196-592d04c83b2e/output/f2e610d6-8b0b-4a70-9196-592d04c83b2e_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_f2e610d6-8b0b-4a70-9196-592d04c83b2e/output/f2e610d6-8b0b-4a70-9196-592d04c83b2e_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:218)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle[test[false, NONE, {2}]]

Error Message:
Could not find any valid local directory for output/894fddd6-9d33-4165-a1b7-f29916d80773_4/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/894fddd6-9d33-4165-a1b7-f29916d80773_4/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:721)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.finalSpill(UnorderedPartitionedKVWriter.java:677)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:572)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:500)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues[test[false, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_09057104-816f-4f65-b1c2-5190fa3436d0/output/09057104-816f-4f65-b1c2-5190fa3436d0_5/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_09057104-816f-4f65-b1c2-5190fa3436d0/output/09057104-816f-4f65-b1c2-5190fa3436d0_5/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues(TestUnorderedPartitionedKVWriter.java:239)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[false, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_e8e084a8-e221-4693-98f2-08d838011efb/output/e8e084a8-e221-4693-98f2-08d838011efb_0/file.out (No such file or directory)

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_e8e084a8-e221-4693-98f2-08d838011efb/output/e8e084a8-e221-4693-98f2-08d838011efb_0/file.out (No such file or directory)
	at java.io.FileInputStream.open(Native Method)
	at java.io.FileInputStream.<init>(FileInputStream.java:146)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileInputStream.<init>(RawLocalFileSystem.java:104)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:200)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[false, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_41a2eeae-f455-4162-9469-6a660e01c42f/output/41a2eeae-f455-4162-9469-6a660e01c42f_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_41a2eeae-f455-4162-9469-6a660e01c42f/output/41a2eeae-f455-4162-9469-6a660e01c42f_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[false, NONE, {2}]]

Error Message:
Could not find any valid local directory for output/2180ed3f-494c-40d1-9a79-75ec35854977_2/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/2180ed3f-494c-40d1-9a79-75ec35854977_2/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:307)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:310)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill[test[false, NONE, {2}]]

Error Message:
Could not find any valid local directory for output/08b53351-0f96-4343-addd-4296f60f8554/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/08b53351-0f96-4343-addd-4296f60f8554/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getOutputFileForWrite(TezTaskOutputFiles.java:91)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:711)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:738)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill(TestUnorderedPartitionedKVWriter.java:203)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[false, MEMORY_OPTIMIZED, {2}]]

Error Message:
Could not find any valid local directory for output/8345309a-794a-4277-a13c-5dfa4450b604_0/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/8345309a-794a-4277-a13c-5dfa4450b604_0/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[false, MEMORY_OPTIMIZED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[false, MEMORY_OPTIMIZED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_8bcc84e6-2c13-4986-8e7c-388269f4951c/output/8bcc84e6-2c13-4986-8e7c-388269f4951c_4/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_8bcc84e6-2c13-4986-8e7c-388269f4951c/output/8bcc84e6-2c13-4986-8e7c-388269f4951c_4/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues[test[false, MEMORY_OPTIMIZED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_f55fd273-f407-41ee-b35d-77b8a73ff7e9/output/f55fd273-f407-41ee-b35d-77b8a73ff7e9_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_f55fd273-f407-41ee-b35d-77b8a73ff7e9/output/f55fd273-f407-41ee-b35d-77b8a73ff7e9_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues(TestUnorderedPartitionedKVWriter.java:239)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[false, MEMORY_OPTIMIZED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_7cc2d433-54df-4816-a8c1-c8084b34d8af/output/7cc2d433-54df-4816-a8c1-c8084b34d8af/file.out.index (No such file or directory)

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_7cc2d433-54df-4816-a8c1-c8084b34d8af/output/7cc2d433-54df-4816-a8c1-c8084b34d8af/file.out.index (No such file or directory)
	at java.io.FileInputStream.open(Native Method)
	at java.io.FileInputStream.<init>(FileInputStream.java:146)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileInputStream.<init>(RawLocalFileSystem.java:104)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:200)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.<init>(TezSpillRecord.java:64)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.<init>(TezSpillRecord.java:56)
	at org.apache.tez.runtime.library.common.sort.impl.TezSpillRecord.<init>(TezSpillRecord.java:51)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:860)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[false, MEMORY_OPTIMIZED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_51483fe1-c5d8-476f-b405-348759f8986e/output/51483fe1-c5d8-476f-b405-348759f8986e_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_51483fe1-c5d8-476f-b405-348759f8986e/output/51483fe1-c5d8-476f-b405-348759f8986e_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[false, PRECISE, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[false, PRECISE, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[false, PRECISE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_8bfee416-bdc1-4906-875c-a888fa849248/output/8bfee416-bdc1-4906-875c-a888fa849248_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_8bfee416-bdc1-4906-875c-a888fa849248/output/8bfee416-bdc1-4906-875c-a888fa849248_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions[test[false, PRECISE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_f65b7880-c033-497a-a8ca-26cbf035839b/output/f65b7880-c033-497a-a8ca-26cbf035839b_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_f65b7880-c033-497a-a8ca-26cbf035839b/output/f65b7880-c033-497a-a8ca-26cbf035839b_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:218)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle[test[false, PRECISE, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:500)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues[test[false, PRECISE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_728c3c09-bb52-4b64-9bb8-40bba82f7693/output/728c3c09-bb52-4b64-9bb8-40bba82f7693_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_728c3c09-bb52-4b64-9bb8-40bba82f7693/output/728c3c09-bb52-4b64-9bb8-40bba82f7693_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargevalues(TestUnorderedPartitionedKVWriter.java:239)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[false, PRECISE, {2}]]

Error Message:
File /tmp/TestUnorderedPartitionedKVWriter/outDir_eea7775f-0ee8-4be2-9729-07e017cb38ac/output/eea7775f-0ee8-4be2-9729-07e017cb38ac/file.out does not exist

Stack Trace:
java.io.FileNotFoundException: File /tmp/TestUnorderedPartitionedKVWriter/outDir_eea7775f-0ee8-4be2-9729-07e017cb38ac/output/eea7775f-0ee8-4be2-9729-07e017cb38ac/file.out does not exist
	at org.apache.hadoop.fs.RawLocalFileSystem.deprecatedGetFileStatus(RawLocalFileSystem.java:534)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileLinkStatusInternal(RawLocalFileSystem.java:747)
	at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:524)
	at org.apache.hadoop.fs.FilterFileSystem.getFileStatus(FilterFileSystem.java:409)
	at org.apache.hadoop.fs.ChecksumFileSystem$ChecksumFSInputChecker.<init>(ChecksumFileSystem.java:140)
	at org.apache.hadoop.fs.ChecksumFileSystem.open(ChecksumFileSystem.java:341)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:413)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[false, PRECISE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_d4bd0980-736f-4fac-bd6f-ba85b68085a0/output/d4bd0980-736f-4fac-bd6f-ba85b68085a0_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_d4bd0980-736f-4fac-bd6f-ba85b68085a0/output/d4bd0980-736f-4fac-bd6f-ba85b68085a0_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


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

Error Message:
Could not find any valid local directory for output/4aa9ab0b-a780-41b1-9cfc-8bba9d649101_0/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/4aa9ab0b-a780-41b1-9cfc-8bba9d649101_0/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTestWithPipelinedTransfer(TestUnorderedPartitionedKVWriter.java:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[true, DISABLED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[true, DISABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_12de74cf-9938-4e15-853e-c0d8288c8ce9/output/12de74cf-9938-4e15-853e-c0d8288c8ce9_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_12de74cf-9938-4e15-853e-c0d8288c8ce9/output/12de74cf-9938-4e15-853e-c0d8288c8ce9_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


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

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_f8a7a1c8-96be-44b7-ab1c-d69effcebda0/output/f8a7a1c8-96be-44b7-ab1c-d69effcebda0_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_f8a7a1c8-96be-44b7-ab1c-d69effcebda0/output/f8a7a1c8-96be-44b7-ab1c-d69effcebda0_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:218)


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

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:500)


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

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_9b70f3ed-820e-4455-a244-e13aaaaf5896/output/9b70f3ed-820e-4455-a244-e13aaaaf5896_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_9b70f3ed-820e-4455-a244-e13aaaaf5896/output/9b70f3ed-820e-4455-a244-e13aaaaf5896_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[true, DISABLED, {2}]]

Error Message:
Could not find any valid local directory for output/6f686449-9556-4102-9293-9b233cc4f9b8/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/6f686449-9556-4102-9293-9b233cc4f9b8/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getOutputFileForWrite(TezTaskOutputFiles.java:91)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:711)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:738)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[true, DISABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_e4490283-eb41-4d2b-8d90-b9801173e52d/output/e4490283-eb41-4d2b-8d90-b9801173e52d_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_e4490283-eb41-4d2b-8d90-b9801173e52d/output/e4490283-eb41-4d2b-8d90-b9801173e52d_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoSpill[test[true, DISABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_cc6aa6a8-d2aa-455b-be24-d91a468ff072/output/cc6aa6a8-d2aa-455b-be24-d91a468ff072/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_cc6aa6a8-d2aa-455b-be24-d91a468ff072/output/cc6aa6a8-d2aa-455b-be24-d91a468ff072/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.ChecksumFileSystem$ChecksumFSInputChecker.<init>(ChecksumFileSystem.java:141)
	at org.apache.hadoop.fs.ChecksumFileSystem.open(ChecksumFileSystem.java:341)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:870)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoSpill(TestUnorderedPartitionedKVWriter.java:198)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill[test[true, DISABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_62edde2c-7bf0-4c02-a7ac-59f9205649f9/output/62edde2c-7bf0-4c02-a7ac-59f9205649f9_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_62edde2c-7bf0-4c02-a7ac-59f9205649f9/output/62edde2c-7bf0-4c02-a7ac-59f9205649f9_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill(TestUnorderedPartitionedKVWriter.java:203)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[true, ENABLED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[true, ENABLED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[true, ENABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_b61bf628-c115-40db-a787-39dd21823626/output/b61bf628-c115-40db-a787-39dd21823626_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_b61bf628-c115-40db-a787-39dd21823626/output/b61bf628-c115-40db-a787-39dd21823626_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions[test[true, ENABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_1c98f236-e59e-4348-a706-64241a960f11/output/1c98f236-e59e-4348-a706-64241a960f11_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_1c98f236-e59e-4348-a706-64241a960f11/output/1c98f236-e59e-4348-a706-64241a960f11_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:218)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle[test[true, ENABLED, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:500)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[true, ENABLED, {2}]]

Error Message:
Could not find any valid local directory for output/4f326c79-aa96-4eaa-b26e-ea98eaa73b78/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/4f326c79-aa96-4eaa-b26e-ea98eaa73b78/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getOutputFileForWrite(TezTaskOutputFiles.java:91)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:711)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:738)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[true, ENABLED, {2}]]

Error Message:
Could not find any valid local directory for output/b1318f7b-8d96-448d-87ae-4292ecb5fe27_2/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/b1318f7b-8d96-448d-87ae-4292ecb5fe27_2/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:326)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:749)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[true, ENABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_070485f7-d22c-481b-b383-f515f1d3efdd/output/070485f7-d22c-481b-b383-f515f1d3efdd_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_070485f7-d22c-481b-b383-f515f1d3efdd/output/070485f7-d22c-481b-b383-f515f1d3efdd_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoSpill[test[true, ENABLED, {2}]]

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.baseTest(TestUnorderedPartitionedKVWriter.java:853)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testNoSpill(TestUnorderedPartitionedKVWriter.java:198)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill[test[true, ENABLED, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_9808532a-f562-43bf-99af-26da6ab5263b/output/9808532a-f562-43bf-99af-26da6ab5263b_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_9808532a-f562-43bf-99af-26da6ab5263b/output/9808532a-f562-43bf-99af-26da6ab5263b_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill(TestUnorderedPartitionedKVWriter.java:203)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle[test[true, NONE, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:510)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs[test[true, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_7b7835ff-6e24-4fed-87f7-abaf5a11a4e7/output/7b7835ff-6e24-4fed-87f7-abaf5a11a4e7_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_7b7835ff-6e24-4fed-87f7-abaf5a11a4e7/output/7b7835ff-6e24-4fed-87f7-abaf5a11a4e7_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKvPairs(TestUnorderedPartitionedKVWriter.java:244)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions[test[true, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_883df662-3ac8-4d50-b054-0faafee77ffe/output/883df662-3ac8-4d50-b054-0faafee77ffe_1/file.out (No such file or directory)

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_883df662-3ac8-4d50-b054-0faafee77ffe/output/883df662-3ac8-4d50-b054-0faafee77ffe_1/file.out (No such file or directory)
	at java.io.FileInputStream.open(Native Method)
	at java.io.FileInputStream.<init>(FileInputStream.java:146)
	at org.apache.hadoop.fs.RawLocalFileSystem$LocalFSFileInputStream.<init>(RawLocalFileSystem.java:104)
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:200)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSkippedPartitions(TestUnorderedPartitionedKVWriter.java:218)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle[test[true, NONE, {2}]]

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:696)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:500)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText[test[true, NONE, {2}]]

Error Message:
Could not find any valid local directory for output/95eb7244-855c-40f9-b019-9600198a4cd6_1/file.out

Stack Trace:
org.apache.hadoop.util.DiskChecker$DiskErrorException: Could not find any valid local directory for output/95eb7244-855c-40f9-b019-9600198a4cd6_1/file.out
	at org.apache.hadoop.fs.LocalDirAllocator$AllocatorPerContext.getLocalPathForWrite(LocalDirAllocator.java:402)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:150)
	at org.apache.hadoop.fs.LocalDirAllocator.getLocalPathForWrite(LocalDirAllocator.java:131)
	at org.apache.tez.runtime.library.common.task.local.output.TezTaskOutputFiles.getSpillFileForWrite(TezTaskOutputFiles.java:207)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.getSpillPathDetails(UnorderedPartitionedKVWriter.java:718)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.setupNextBuffer(UnorderedPartitionedKVWriter.java:364)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:289)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.write(UnorderedPartitionedKVWriter.java:277)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:297)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testRandomText(TestUnorderedPartitionedKVWriter.java:229)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills[test[true, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_3d1524a3-6565-4927-b344-9e3e7ea84276/output/3d1524a3-6565-4927-b344-9e3e7ea84276_3/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_3d1524a3-6565-4927-b344-9e3e7ea84276/output/3d1524a3-6565-4927-b344-9e3e7ea84276_3/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.baseTest(TestUnorderedPartitionedKVWriter.java:752)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testMultipleSpills(TestUnorderedPartitionedKVWriter.java:208)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords[test[true, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_cdcf9c36-b560-4dbb-9090-ebae5437d5b1/output/cdcf9c36-b560-4dbb-9090-ebae5437d5b1_0/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_cdcf9c36-b560-4dbb-9090-ebae5437d5b1/output/cdcf9c36-b560-4dbb-9090-ebae5437d5b1_0/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testTextMixedRecords(TestUnorderedPartitionedKVWriter.java:249)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys[test[true, NONE, {2}]]

Error Message:
/tmp/TestUnorderedPartitionedKVWriter/outDir_11e3e733-ed90-4d8d-875a-8b5d659a3a61/output/11e3e733-ed90-4d8d-875a-8b5d659a3a61_1/file.out

Stack Trace:
java.io.FileNotFoundException: /tmp/TestUnorderedPartitionedKVWriter/outDir_11e3e733-ed90-4d8d-875a-8b5d659a3a61/output/11e3e733-ed90-4d8d-875a-8b5d659a3a61_1/file.out
	at org.apache.hadoop.fs.RawLocalFileSystem.open(RawLocalFileSystem.java:198)
	at org.apache.hadoop.fs.FileSystem.open(FileSystem.java:766)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.mergeAll(UnorderedPartitionedKVWriter.java:777)
	at org.apache.tez.runtime.library.common.writers.UnorderedPartitionedKVWriter.close(UnorderedPartitionedKVWriter.java:561)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.textTest(TestUnorderedPartitionedKVWriter.java:350)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testLargeKeys(TestUnorderedPartitionedKVWriter.java:234)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill[test[true, NONE, {2}]]

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.baseTest(TestUnorderedPartitionedKVWriter.java:853)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill(TestUnorderedPartitionedKVWriter.java:203)


FAILED:  org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle[test[true, MEMORY_OPTIMIZED, {2}]]

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:697)
	at org.apache.tez.runtime.library.common.writers.TestUnorderedPartitionedKVWriter.testSingleSpill_WithPipelinedShuffle(TestUnorderedPartitionedKVWriter.java:495)



Success: TEZ-3511 PreCommit Build #2116

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

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 4830 lines...]
[INFO] Tez ................................................ SUCCESS [  0.024 s]
[INFO] ------------------------------------------------------------------------
[INFO] BUILD SUCCESS
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 57:26 min
[INFO] Finished at: 2016-11-22T09:16:26+00:00
[INFO] Final Memory: 81M/1383M
[INFO] ------------------------------------------------------------------------




{color:green}+1 overall{color}.  Here are the results of testing the latest attachment
  http://issues.apache.org/jira/secure/attachment/12839955/TEZ-3511.5.patch
  against master revision 501a351.

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

    {color:green}+1 tests included{color}.  The patch appears to include 3 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/2116//testReport/
Console output: https://builds.apache.org/job/PreCommit-TEZ-Build/2116//console

This message is automatically generated.


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


Comment added.
602f9874765c34efa774e2b30f3a7758d6cf2a2e logged out


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


Archiving artifacts
[description-setter] Description set: TEZ-3511
Recording test results
Email was triggered for: Success
Sending email for trigger: Success



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

Failed: TEZ-3347 PreCommit Build #2115

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

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 25 lines...]
[PreCommit-TEZ-Build] $ /bin/bash /tmp/hudson2931549339684956572.sh
Running in Jenkins mode


======================================================================
======================================================================
    Testing patch for TEZ-3347.
======================================================================
======================================================================


HEAD is now at 501a351 TEZ-3508. TestTaskScheduler cleanup. (jlowe)
Switched to a new branch 'master'
Branch master set up to track remote branch master from origin.
Current branch master is up to date.
TEZ-3347 patch is being downloaded at Mon Nov 21 17:58:55 UTC 2016 from
http://issues.apache.org/jira/secure/attachment/12839842/TEZ-3347.002.patch
The patch does not appear to apply with p0 to p2
PATCH APPLICATION FAILED




{color:red}-1 overall{color}.  Here are the results of testing the latest attachment
  http://issues.apache.org/jira/secure/attachment/12839842/TEZ-3347.002.patch
  against master revision 501a351.

    {color:red}-1 patch{color}.  The patch command could not apply the patch.

Console output: https://builds.apache.org/job/PreCommit-TEZ-Build/2115//console

This message is automatically generated.


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


Comment added.
e45a7559fb62f0f4767c5fc5b9273dd0ca76c065 logged out


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


Build step 'Execute shell' marked build as failure
Archiving artifacts
[description-setter] Could not determine description.
Recording test results
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any



###################################################################################
############################## FAILED TESTS (if any) ##############################
No tests ran.

Failed: TEZ-2608 PreCommit Build #2114

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

###################################################################################
########################## LAST 60 LINES OF THE CONSOLE ###########################
[...truncated 4826 lines...]
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 56:54 min
[INFO] Finished at: 2016-11-18T22:55:55+00:00
[INFO] Final Memory: 85M/1488M
[INFO] ------------------------------------------------------------------------




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

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

    {color:red}-1 tests included{color}.  The patch doesn't appear to include any new or modified tests.
                        Please justify why no new tests are needed for this patch.
                        Also please list what manual steps were performed to verify this patch.

    {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/2114//testReport/
Console output: https://builds.apache.org/job/PreCommit-TEZ-Build/2114//console

This message is automatically generated.


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


Comment added.
37499414654f1709e5222d1ce84e6ef27861eaee logged out


======================================================================
======================================================================
    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) ##############################
All tests passed