Version 0.7.0

RELEASED

Start date not set

Released: 18/May/15

Release Notes

0.7 release. Performance/Scalability enhancements.Show more
PTKeySummaryAssigneeStatus
BlockerSub-taskTEZ-776Reduce AM mem usage caused by storing TezEventsBikas SahaClosed
BlockerBugTEZ-2009Change license/copyright headers to 2015 Hitesh ShahClosed
BlockerBugTEZ-2290Scale memory for Default Sorter down to a max of 2047 MB if configured higherRajesh BalamohanClosed
BlockerTaskTEZ-2292Add e2e test for error reporting when vertex manager invokes plugin APIsBikas SahaClosed
BlockerBugTEZ-2313Regression in handling obsolete events in ShuffleSchedulerRajesh BalamohanClosed
BlockerBugTEZ-2314Tez task attempt failures due to bad event serializationBikas SahaClosed
BlockerBugTEZ-2358Pipelined Shuffle: MergeManager assumptions about 1 merge per source-taskRajesh BalamohanClosed
BlockerBugTEZ-2379org.apache.hadoop.yarn.state.InvalidStateTransitonException: Invalid event: T_ATTEMPT_KILLED at KILLEDHitesh ShahClosed
BlockerBugTEZ-2410VertexGroupCommitFinishedEvent & VertexCommitStartedEvent is not logged correctlyJeff ZhangClosed
BlockerBugTEZ-2412Should kill vertex in DAGImpl#VertexRerunWhileCommittingJeff ZhangClosed
BlockerBugTEZ-2445Disable the object cleanup in local mode in LogicalIOProcessorRuntimeTaskJeff ZhangClosed
CriticalImprovementTEZ-714OutputCommitters should not run in the main AM dispatcher threadJeff ZhangClosed
CriticalSub-taskTEZ-1521VertexDataMovementEventsGeneratedEvent may be logged twice in recovery log Jeff ZhangClosed
CriticalBugTEZ-1560Invalid state machine handling for V_SOURCE_VERTEX_RECOVERED in recoveryJeff ZhangClosed
CriticalBugTEZ-1889Fix test-patch to provide correct findbugs report Hitesh ShahClosed
CriticalBugTEZ-1949Whitelist TEZ_RUNTIME_OPTIMIZE_SHARED_FETCH for broadcast edgesGopal VijayaraghavanClosed
CriticalBugTEZ-2075Incompatible issue caused by TEZ-1233 that TezConfiguration.TEZ_SITE_XML is made private Jeff ZhangClosed
CriticalBugTEZ-2095master branch fails to compile against hadoop-2.4Hitesh ShahClosed
CriticalBugTEZ-2170Incorrect its in README.mdJakob HomanClosed
CriticalBugTEZ-2237Valid events should be sent out when an Output is not startedSiddharth SethClosed
CriticalBugTEZ-2305MR compatibility sleep job fails with IOException: Undefined job output-pathJeff ZhangClosed
CriticalBugTEZ-2366Pig tez MiniTezCluster unit tests fail intermittently after TEZ-2333Prakash RamachandranClosed
CriticalImprovementTEZ-2392Have all readers throw an Exception on incorrect next() usageRajesh BalamohanClosed
CriticalBugTEZ-2394Issues when there is an error in VertexManager callbacksBikas SahaClosed
CriticalBugTEZ-2397Translation of LocalResources via Tez plan serialization can be lossySiddharth SethClosed
CriticalBugTEZ-2401Tez UI: All-dag page has duration keep counting for KILLED dag.Prakash RamachandranClosed
CriticalBugTEZ-2404Handle DataMovementEvent before its TaskAttemptCompletedEventJeff ZhangClosed
CriticalBugTEZ-2405PipelinedSorter can throw NPE with custom compartorRajesh BalamohanClosed
CriticalBugTEZ-2426Ensure the eventRouter thread completes before switching to a new task and thread safety fixes in IPOContexts.Siddharth SethClosed
MajorBugTEZ-167Create tests for MR Combiner Devaraj KavaliClosed
MajorImprovementTEZ-1233Allow configuration of framework parameters per vertexJeff ZhangClosed
MajorImprovementTEZ-1274Remove Key/Value type checks in IFileRajesh BalamohanClosed
MajorTaskTEZ-1313Setup pre-commit build to test submitted patchesHitesh ShahClosed
MajorSub-taskTEZ-1482Fix memory issues for Local Mode running concurrent tasksPrakash RamachandranClosed
MajorImprovementTEZ-1518Clean up ID caches on DAG completionUnassignedResolved
MajorBugTEZ-1593Refactor PipelinedSorter to remove all MMAP based ByteBuffer referencesRajesh BalamohanClosed
MajorBugTEZ-1661LocalTaskScheduler hangs when shutdownJeff ZhangClosed
MajorImprovementTEZ-1767Enable RLE in reducer side merge codepathRajesh BalamohanClosed
MajorBugTEZ-1803Support > 2gb sort buffer in pipelinedsorterRajesh BalamohanClosed
MajorImprovementTEZ-1837Restrict usage of Environment variables to main methodsSiddharth SethClosed
MajorBugTEZ-1844Shouldn't invoke system.exit in local mode when AM is failed to startJeff ZhangClosed
MajorImprovementTEZ-1855Avoid scanning for previously written files within Inputs / OutputsRajesh BalamohanClosed
MajorTaskTEZ-1856Remove LocalOnFileSortedOutput, LocalMergedInput, LocalTaskOutputFilesSiddharth SethClosed
MajorImprovementTEZ-1867Create new central dispatcher for Tez AMBikas SahaClosed
MajorSub-taskTEZ-1879Create local UGI instances for each task and the AM, when running in LocalModeSiddharth SethClosed
MajorBugTEZ-1881Setup initial test-patch script for TEZ-1313Hitesh ShahClosed
MajorTaskTEZ-1897Create a concurrent version of AsyncDispatcherBikas SahaClosed
MajorSub-taskTEZ-1898Fix findbugs warnings in tez-api moduleHitesh ShahClosed
MajorSub-taskTEZ-1899Fix findbugs warnings in tez-commonSiddharth SethClosed
MajorSub-taskTEZ-1901Fix findbugs warnings in tez-examples Hitesh ShahClosed
MajorSub-taskTEZ-1902Fix findbugs warnings in tez-mapreduceHitesh ShahClosed
MajorSub-taskTEZ-1903Fix findbugs warnings in tez-runtime-internalsSiddharth SethClosed
MajorSub-taskTEZ-1904Fix findbugs warnings in tez-runtime-librarySiddharth SethClosed
MajorSub-taskTEZ-1905Fix findbugs warnings in tez-testsHitesh ShahClosed
MajorSub-taskTEZ-1906Fix findbugs warnings in tez-yarn-timeline-history-with-aclsHitesh ShahClosed
MajorBugTEZ-1912Merge exceptions are thrown when enabling tez.runtime.shuffle.memory-to-memory.enable && tez.runtime.shuffle.memory-to-memory.segmentsRajesh BalamohanClosed
MajorBugTEZ-1913Reduce deserialize cost in ValuesIteratorRajesh BalamohanClosed
MajorTaskTEZ-1914VertexManager logic should not run on the central dispatcherBikas SahaClosed
MajorImprovementTEZ-1917Examples should extend TezExampleBaseVasanth kumar RJClosed
MajorTaskTEZ-1933Move TezChild and related classes into tez-runtime-internalsSiddharth SethClosed
MajorBugTEZ-1935Organization should be removed from http://tez.apache.org/team-list.htmlHitesh ShahClosed
MajorSub-taskTEZ-1941Memory provided by *Context.getAvailableMemory needs to be setup explicitlySiddharth SethClosed
MajorBugTEZ-1945Remove 2 GB memlimit restriction in MergeManagerRajesh BalamohanClosed
MajorSub-taskTEZ-1951Fix general findbugs warnings in tez-dagHitesh ShahClosed
MajorBugTEZ-1963Fix post memory merge to be > 2 GBRajesh BalamohanClosed
MajorImprovementTEZ-1967Add a monitoring API on DAGClient which returns after a time interval or on DAG state changeVasanth kumar RJClosed
MajorSub-taskTEZ-1969Stop the DAGAppMaster when a local mode client is stoppedPrakash RamachandranClosed
MajorSub-taskTEZ-1980Suppress tez-dag findbugs warnings until addressedHitesh ShahClosed
MajorBugTEZ-1982TezChild setupUgi should not be using environmentSiddharth SethClosed
MajorBugTEZ-1988Tez UI: does not work when using file:// in a browser Prakash RamachandranClosed
MajorBugTEZ-1993Implement a pluggable InputSizeEstimator for grouping fairlyGopal VijayaraghavanClosed
MajorBugTEZ-1995Build failure against hadoop 2.2 Rajesh BalamohanClosed
MajorBugTEZ-1996Update Website after 0.6.0Jonathan Turner EaglesClosed
MajorBugTEZ-1997Remove synchronization DefaultSorter::isRLENeeded() (Causes sorter to hang indefinitely in large jobs) Rajesh BalamohanClosed
MajorBugTEZ-1999IndexOutOfBoundsException during mergeRajesh BalamohanClosed
MajorBugTEZ-2000Source vertex exists error during DAG submissionJeff ZhangClosed
MajorImprovementTEZ-2001Support pipelined data transfer for ordered outputRajesh BalamohanClosed
MajorImprovementTEZ-2016Tez UI: Dag View Fit and FinishSreenath SomarajapuramClosed
MajorSub-taskTEZ-2023Refactor logIndividualFetchComplete() to be common for both shuffle-schedulersRajesh BalamohanClosed
MajorTaskTEZ-2045TaskAttemptListener should not pull Tasks from AMContainerSiddharth SethClosed
MajorBugTEZ-2057tez-dag/pom.xml contains versions for dependenciesJonathan Turner EaglesClosed
MajorBugTEZ-2080Localclient should be using tezconf in init instead of yarnconfSiddharth SethClosed
MajorBugTEZ-2082Race condition in TaskAttemptListenerImpTezDag.getTask()Bikas SahaClosed
MajorImprovementTEZ-2083Make PipelinedSorter as the default sorterRajesh BalamohanClosed
MajorBugTEZ-2084Tez UI: Stacktrace format info is lost in diagnosticsPrakash RamachandranClosed
MajorBugTEZ-2085PipelinedSorter should bail out (on BufferOverflowException) instead of retrying continuouslyRajesh BalamohanClosed
MajorTaskTEZ-2093Add events to MockDAGAppMaster and add e2e test for event routingBikas SahaClosed
MajorTaskTEZ-2130Send the sessionToken as part of the AM CLCSiddharth SethClosed
MajorBugTEZ-2133Secured Impersonation: Failed to delete tez scratch data dirChang LiClosed
MajorImprovementTEZ-2149Optimizations for the timed version of DAGClient.getStatusSiddharth SethClosed
MajorImprovementTEZ-2159Tez UI: download timeline data for offline use.Prakash RamachandranClosed
MajorImprovementTEZ-2169Add NDC context to various threads and poolsSergey ShelukhinClosed
MajorBugTEZ-2171Remove unused metrics codePrasanth JayachandranClosed
MajorTaskTEZ-2174Make task priority available to TaskAttemptListenerSiddharth SethClosed
MajorImprovementTEZ-2176Move all logging to slf4jVasanth kumar RJClosed
MajorBugTEZ-2178YARN-3122 breaks tez compilation with hadoop 2.7.0Rajesh BalamohanClosed
MajorBugTEZ-2186OOM with a simple scatter gather job with re-useRajesh BalamohanClosed
MajorTaskTEZ-2191Simulation improvements to MockDAGAppMasterBikas SahaClosed
MajorBugTEZ-2195TestTezJobs::testInvalidQueueSubmission/testInvalidQueueSubmissionToSession fail with hadoop branch-2 Hitesh ShahClosed
MajorImprovementTEZ-2196Consider reusing UnorderedPartitionedKVWriter with single output in UnorderedKVOutputRajesh BalamohanClosed
MajorBugTEZ-2202Fix LocalTaskExecutionThread ID to the standard thread numberingGopal VijayaraghavanClosed
MajorTaskTEZ-2203Intern strings in tez countersBikas SahaClosed
MajorBugTEZ-2204TestAMRecovery increasingly flaky on jenkins builds. Jeff ZhangClosed
MajorImprovementTEZ-2209Fix pipelined shuffle to fetch data from any one attemptRajesh BalamohanClosed
MajorTaskTEZ-2210Record DAG AM CPU usage statsBikas SahaClosed
MajorImprovementTEZ-2212Notify components on DAG completionSiddharth SethClosed
MajorImprovementTEZ-2213For the ordered case, enabling pipelined shuffle should automatically disable final mergeRajesh BalamohanClosed
MajorBugTEZ-2221VertexGroup name should be unqiueJeff ZhangClosed
MajorBugTEZ-2223TestMockDAGAppMaster fails due to TEZ-2210 on macHitesh ShahClosed
MajorBugTEZ-2224EventQueue empty doesn't mean events are consumed in RecoveryServiceJeff ZhangClosed
MajorTaskTEZ-2231Create project by-lawsHitesh ShahClosed
MajorBugTEZ-2232Allow setParallelism to be called multiple times before tasks get scheduledBikas SahaClosed
MajorBugTEZ-2233Allow EdgeProperty of an edge to be changed by VertexManagerBikas SahaClosed
MajorSub-taskTEZ-2234Add API for statistics information - allow vertex managers to get output size per source vertexBikas SahaClosed
MajorSub-taskTEZ-2236Tez UI: Support loading of all tasks in the dag tasks pageSreenath SomarajapuramClosed
MajorBugTEZ-2248VertexImpl/DAGImpl.checkForCompletion have too many termination cause checksJeff ZhangClosed
MajorBugTEZ-2251Race condition in VertexImpl & Edge causes DAG to hangRajesh BalamohanClosed
MajorBugTEZ-2252Tez UI: in graphical view some of the sinks are hidden as they overlapSreenath SomarajapuramClosed
MajorBugTEZ-2261Should add diagnostics in DAGAppMaster when recovery error happensJeff ZhangClosed
MajorTaskTEZ-2264Remove unused taskUmbilical reference in TezTaskRunner, register as running lateSiddharth SethClosed
MajorBugTEZ-2265All inputs/outputs in a task share the same counter objectBikas SahaClosed
MajorBugTEZ-2269DAGAppMaster becomes unresponsiveUnassignedClosed
MajorSub-taskTEZ-2273Tez UI: Support client side searching & sorting for dag tasks pageSreenath SomarajapuramClosed
MajorSub-taskTEZ-2274Tez UI: full data loading, client side search and sort for other pagesSreenath SomarajapuramClosed
MajorSub-taskTEZ-2275Tez UI: enable faster loading and caching of data in tablesSreenath SomarajapuramClosed
MajorImprovementTEZ-2288Remove unnecessary contention on locks by getDag, getTask, getVertex etcUnassignedResolved
MajorBugTEZ-2293When running in "mr" mode, always use MR config settingsHitesh ShahClosed
MajorBugTEZ-2298Ignore sending failure message, when TaskReporter$HeartbeatCallable is shutdownSiddharth SethClosed
MajorBugTEZ-2299Invalid dag creation in MRRSleepJob post TEZ-2293Hitesh ShahClosed
MajorSub-taskTEZ-2308Add set/get of record counts in task/vertex statisticsBikas SahaClosed
MajorBugTEZ-2310Deadlock caused by StateChangeNotifier sending notifications on thread holding locksBikas SahaClosed
MajorBugTEZ-2318Tez UI: source and sink page is broken as they are not populated.Sreenath SomarajapuramClosed
MajorBugTEZ-2323Fix TestOrderedWordcount to use MR memory configsHitesh ShahClosed
MajorBugTEZ-2325Route status update event directly to the attempt Prakash RamachandranClosed
MajorBugTEZ-2328Add tez.runtime.sorter.class & rename tez.runtime.sort.threads to tez.runtime.pipelined.sorter.sort.threadsHitesh ShahClosed
MajorTaskTEZ-2330Create reconfigureVertex() API for input based initialization Bikas SahaClosed
MajorTaskTEZ-2333Enable local fetch optimization by default.Prakash RamachandranClosed
MajorBugTEZ-2340TestRecoveryParser failsJeff ZhangClosed
MajorSub-taskTEZ-2344TEZ-UI: Equip basic-ember-table's cell level loading for all use cases in all DAGs tableSreenath SomarajapuramClosed
MajorSub-taskTEZ-2345TEZ-UI: Enable cell level loading in all DAGs tableSreenath SomarajapuramClosed
MajorTaskTEZ-2352Move getTaskStatistics into the RuntimeTask classSiddharth SethClosed
MajorBugTEZ-2357Tez UI: misc.js.orig is committed by accidentPrakash RamachandranClosed
MajorBugTEZ-2360per-io counters flag should generate both overall and per-edge counters Prakash RamachandranClosed
MajorBugTEZ-2362State Change Notifier Thread should be stopped when dag is completedBikas SahaClosed
MajorBugTEZ-2364'joindatagen' AM picks wrong staging dirSiddharth SethClosed
MajorImprovementTEZ-2368Make a dag identifier available in Context classesSiddharth SethClosed
MajorBugTEZ-2369Add a few unit tests for RootInputInitializerManagerSiddharth SethClosed
MajorBugTEZ-2374Fix build break against hadoop-2.2 due to TEZ-2325Hitesh ShahClosed
MajorBugTEZ-2377RandomWriter ends up using TextOutputFormat instead of SequenceFileOutputFormatRajesh BalamohanResolved
MajorBugTEZ-2383Cleanup input/output/processor contexts in LogicalIOProcessorRuntimeTaskRajesh BalamohanClosed
MajorBugTEZ-2386Tez UI: Inconsistent usage of icon colorsPrakash RamachandranClosed
MajorBugTEZ-2389Tez UI: Sort by attempt-no is incorrect in attempts pages.Sreenath SomarajapuramClosed
MajorBugTEZ-2395Tez UI: Minimum/Maximum Duration show a empty bracket next to 0 secs when you purposefully failed a job.Prakash RamachandranClosed
MajorBugTEZ-2396pig-tez-tfile-parser pom is hard coded to depend on 0.6.0-SNAPSHOT versionRajesh BalamohanClosed
MajorBugTEZ-2406Tez UI: Display per-io counter columns in task and attempt pages under vertexSreenath SomarajapuramClosed
MajorBugTEZ-2415PMC RDF needs to use asfext:pmc, not asfext:PMCHitesh ShahClosed
MajorBugTEZ-2416Tez UI: Make tooltips display faster.Sreenath SomarajapuramClosed
MajorBugTEZ-2417Tez UI: Counters are blank in the Attempts page if all attempts failedPrakash RamachandranClosed
MajorBugTEZ-2423Tez UI: Remove Attempt Index column from task->attempts pageSreenath SomarajapuramClosed
MajorBugTEZ-2432Syntax error in DOAP file release sectionHitesh ShahClosed
MajorImprovementTEZ-2435Add public key to KEYSJeff ZhangClosed
MajorBugTEZ-2437FilterLinesByWord NPEs when run in LocalmodeUnassignedClosed
MajorImprovementTEZ-2446Tez UI: Add tezVersion details when downloading timeline data for offline usePrakash RamachandranClosed
MajorSub-taskTEZ-2517CLONE - Tez UI: Support loading of all tasks in the dag tasks pageSreenath SomarajapuramResolved
MajorSub-taskTEZ-2518CLONE - Tez UI: Support client side searching & sorting for dag tasks pageSreenath SomarajapuramResolved
MajorSub-taskTEZ-2520CLONE - Tez UI: enable faster loading and caching of data in tablesSreenath SomarajapuramResolved
MajorBugTEZ-2752logUnsuccessful completion in Attempt should write original finish time to ATSBikas SahaClosed
MajorSub-taskTEZ-2961ShuffleVertexManager assumption of 1 vmEvent per task broken by pipeliningUnassignedOpen
MajorBugTEZ-3030java.lang.NoClassDefFoundError: org/apache/hadoop/mapred/MRVersionUnassignedClosed
MajorBugTEZ-3031java.lang.NoSuchMethodErrorUnassignedClosed
MinorSub-taskTEZ-485Get rid of TezTaskStatusSiddharth SethClosed
MinorImprovementTEZ-1826Add option to disable split grouping and local mode option for tez-examplesJeff ZhangClosed
MinorBugTEZ-1827MiniTezCluster takes 10 minutes to shut downHitesh ShahClosed
MinorTaskTEZ-2008Add methods to SecureShuffleUtils to verify a reply based on a provided KeySiddharth SethClosed
MinorBugTEZ-2033Update TestOrderedWordCount to add processor configs as history text and use MR configs correctlyHitesh ShahClosed
MinorBugTEZ-2059Remove TaskEventHandler in TestDAGImplJeff ZhangClosed
MinorBugTEZ-2072Add missing Private annotation to createDAG in the DAG API classSiddharth SethClosed
MinorTaskTEZ-2243documentation should explicitly specify protobuf 2.5.0Michael HowardClosed
MinorBugTEZ-2341TestMockDAGAppMaster.testBasicCounters fails on windowsJeff ZhangClosed
MinorBugTEZ-2342TestFaultTolerance.testRandomFailingTasks fails due to timeoutJeff ZhangClosed
MinorBugTEZ-2363Counters: off by 1 error for REDUCE_INPUT_GROUPS counterGopal VijayaraghavanClosed
MinorImprovementTEZ-2384Add warning message in the case of prewarn under non-session modeJeff ZhangClosed
MinorBugTEZ-2408TestTaskAttempt fails to compile against hadoop-2.4 and hadoop-2.2 Hitesh ShahClosed
MinorBugTEZ-2424Bump up max counter group name length limit to account for per_io countersHitesh ShahClosed
TrivialBugTEZ-2070Controller class of output should be committer rather than initializer in DAG's dot fileJeff ZhangClosed
1185 of 185