You are viewing a plain text version of this content. The canonical link for it is here.
Posted to common-commits@hadoop.apache.org by wa...@apache.org on 2016/03/10 04:40:23 UTC

[24/49] hadoop git commit: HADOOP-11791. Update src/site/markdown/releases to include old versions of Hadoop (aw)

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.1/RELEASENOTES.0.23.1.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.1/RELEASENOTES.0.23.1.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.1/RELEASENOTES.0.23.1.md
new file mode 100644
index 0000000..08c9df0
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.1/RELEASENOTES.0.23.1.md
@@ -0,0 +1,677 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop  0.23.1 Release Notes
+
+These release notes cover new developer and user-facing incompatibilities, features, and major improvements.
+
+
+---
+
+* [HADOOP-8013](https://issues.apache.org/jira/browse/HADOOP-8013) | *Major* | **ViewFileSystem does not honor setVerifyChecksum**
+
+**WARNING: No release note provided for this incompatible change.**
+
+
+---
+
+* [HADOOP-8009](https://issues.apache.org/jira/browse/HADOOP-8009) | *Critical* | **Create hadoop-client and hadoop-minicluster artifacts for downstream projects**
+
+Generate integration artifacts "org.apache.hadoop:hadoop-client" and "org.apache.hadoop:hadoop-minicluster" containing all the jars needed to use Hadoop client APIs, and to run Hadoop MiniClusters, respectively.  Push these artifacts to the maven repository when mvn-deploy, along with existing artifacts.
+
+
+---
+
+* [HADOOP-7986](https://issues.apache.org/jira/browse/HADOOP-7986) | *Major* | **Add config for History Server protocol in hadoop-policy for service level authorization.**
+
+Adding config for MapReduce History Server protocol in hadoop-policy.xml for service level authorization.
+
+
+---
+
+* [HADOOP-7963](https://issues.apache.org/jira/browse/HADOOP-7963) | *Blocker* | **test failures: TestViewFileSystemWithAuthorityLocalFileSystem and TestViewFileSystemLocalFileSystem**
+
+Fix ViewFS to catch a null canonical service-name and pass tests TestViewFileSystem*
+
+
+---
+
+* [HADOOP-7851](https://issues.apache.org/jira/browse/HADOOP-7851) | *Major* | **Configuration.getClasses() never returns the default value.**
+
+Fixed Configuration.getClasses() API to return the default value if the key is not set.
+
+
+---
+
+* [HADOOP-7802](https://issues.apache.org/jira/browse/HADOOP-7802) | *Major* | **Hadoop scripts unconditionally source "$bin"/../libexec/hadoop-config.sh.**
+
+Here is a patch to enable this behavior
+
+
+---
+
+* [HADOOP-7470](https://issues.apache.org/jira/browse/HADOOP-7470) | *Minor* | **move up to Jackson 1.8.8**
+
+**WARNING: No release note provided for this incompatible change.**
+
+
+---
+
+* [HADOOP-7348](https://issues.apache.org/jira/browse/HADOOP-7348) | *Major* | **Modify the option of FsShell getmerge from [addnl] to [-nl] for consistency**
+
+The 'fs -getmerge' tool now uses a -nl flag to determine if adding a newline at end of each file is required, in favor of the 'addnl' boolean flag that was used earlier.
+
+
+---
+
+* [HDFS-2316](https://issues.apache.org/jira/browse/HDFS-2316) | *Major* | **[umbrella] WebHDFS: a complete FileSystem implementation for accessing HDFS over HTTP**
+
+Provide WebHDFS as a complete FileSystem implementation for accessing HDFS over HTTP.
+Previous hftp feature was a read-only FileSystem and does not provide "write" accesses.
+
+
+---
+
+* [HDFS-2246](https://issues.apache.org/jira/browse/HDFS-2246) | *Major* | **Shortcut a local client reads to a Datanodes files directly**
+
+1. New configurations
+a. dfs.block.local-path-access.user is the key in datanode configuration to specify the user allowed to do short circuit read.
+b. dfs.client.read.shortcircuit is the key to enable short circuit read at the client side configuration.
+c. dfs.client.read.shortcircuit.skip.checksum is the key to bypass checksum check at the client side.
+2. By default none of the above are enabled and short circuit read will not kick in.
+3. If security is on, the feature can be used only for user that has kerberos credentials at the client, therefore map reduce tasks cannot benefit from it in general.
+
+
+---
+
+* [HDFS-2130](https://issues.apache.org/jira/browse/HDFS-2130) | *Major* | **Switch default checksum to CRC32C**
+
+The default checksum algorithm used on HDFS is now CRC32C. Data from previous versions of Hadoop can still be read backwards-compatibly.
+
+
+---
+
+* [HDFS-2129](https://issues.apache.org/jira/browse/HDFS-2129) | *Major* | **Simplify BlockReader to not inherit from FSInputChecker**
+
+BlockReader has been reimplemented to use direct byte buffers. If you use a custom socket factory, it must generate sockets that have associated Channels.
+
+
+---
+
+* [HDFS-1314](https://issues.apache.org/jira/browse/HDFS-1314) | *Minor* | **dfs.blocksize accepts only absolute value**
+
+The default blocksize property 'dfs.blocksize' now accepts unit symbols to be used instead of byte length. Values such as "10k", "128m", "1g" are now OK to provide instead of just no. of bytes as was before.
+
+
+---
+
+* [MAPREDUCE-3854](https://issues.apache.org/jira/browse/MAPREDUCE-3854) | *Major* | **Reinstate environment variable tests in TestMiniMRChildTask**
+
+Fixed and reenabled tests related to MR child JVM's environmental variables in TestMiniMRChildTask.
+
+
+---
+
+* [MAPREDUCE-3846](https://issues.apache.org/jira/browse/MAPREDUCE-3846) | *Critical* | **Restarted+Recovered AM hangs in some corner cases**
+
+Addressed MR AM hanging issues during AM restart and then the recovery.
+
+
+---
+
+* [MAPREDUCE-3834](https://issues.apache.org/jira/browse/MAPREDUCE-3834) | *Critical* | **If multiple hosts for a split belong to the same rack, the rack is added multiple times in the AM request table**
+
+Changed MR AM to not add the same rack entry multiple times into the container request table when multiple hosts for a split happen to be on the same rack
+
+
+---
+
+* [MAPREDUCE-3815](https://issues.apache.org/jira/browse/MAPREDUCE-3815) | *Critical* | **Data Locality suffers if the AM asks for containers using IPs instead of hostnames**
+
+Fixed MR AM to always use hostnames and never IPs when requesting containers so that scheduler can give off data local containers correctly.
+
+
+---
+
+* [MAPREDUCE-3808](https://issues.apache.org/jira/browse/MAPREDUCE-3808) | *Blocker* | **NPE in FileOutputCommitter when running a 0 reduce job**
+
+Fixed an NPE in FileOutputCommitter for jobs with maps but no reduces.
+
+
+---
+
+* [MAPREDUCE-3804](https://issues.apache.org/jira/browse/MAPREDUCE-3804) | *Major* | **yarn webapp interface vulnerable to cross scripting attacks**
+
+fix cross scripting attacks vulnerability through webapp interface.
+
+
+---
+
+* [MAPREDUCE-3802](https://issues.apache.org/jira/browse/MAPREDUCE-3802) | *Critical* | **If an MR AM dies twice  it looks like the process freezes**
+
+Added test to validate that AM can crash multiple times and still can recover successfully after MAPREDUCE-3846.
+
+
+---
+
+* [MAPREDUCE-3784](https://issues.apache.org/jira/browse/MAPREDUCE-3784) | *Major* | **maxActiveApplications(\|PerUser) per queue is too low for small clusters**
+
+Fixed CapacityScheduler so that maxActiveApplication and maxActiveApplicationsPerUser per queue are not too low for small clusters.
+
+
+---
+
+* [MAPREDUCE-3774](https://issues.apache.org/jira/browse/MAPREDUCE-3774) | *Major* | **yarn-default.xml should be moved to hadoop-yarn-common.**
+
+MAPREDUCE-3774. Moved yarn-default.xml to hadoop-yarn-common from hadoop-server-common.
+
+
+---
+
+* [MAPREDUCE-3760](https://issues.apache.org/jira/browse/MAPREDUCE-3760) | *Major* | **Blacklisted NMs should not appear in Active nodes list**
+
+Changed active nodes list to not contain unhealthy nodes on the webUI and metrics.
+
+
+---
+
+* [MAPREDUCE-3754](https://issues.apache.org/jira/browse/MAPREDUCE-3754) | *Major* | **RM webapp should have pages filtered based on App-state**
+
+Modified RM UI to filter applications based on state of the applications.
+
+
+---
+
+* [MAPREDUCE-3752](https://issues.apache.org/jira/browse/MAPREDUCE-3752) | *Blocker* | **Headroom should be capped by queue max-cap**
+
+Modified application limits to include queue max-capacities besides the usual user limits.
+
+
+---
+
+* [MAPREDUCE-3732](https://issues.apache.org/jira/browse/MAPREDUCE-3732) | *Blocker* | **CS should only use 'activeUsers with pending requests' for computing user-limits**
+
+Modified CapacityScheduler to use only users with pending requests for computing user-limits.
+
+
+---
+
+* [MAPREDUCE-3720](https://issues.apache.org/jira/browse/MAPREDUCE-3720) | *Major* | **Command line listJobs should not visit each AM**
+
+Changed bin/mapred job -list to not print job-specific information not available at RM.
+
+Very minor incompatibility in cmd-line output, inevitable due to MRv2 architecture.
+
+
+---
+
+* [MAPREDUCE-3716](https://issues.apache.org/jira/browse/MAPREDUCE-3716) | *Blocker* | **java.io.File.createTempFile fails in map/reduce tasks**
+
+Fixing YARN+MR to allow MR jobs to be able to use java.io.File.createTempFile to create temporary files as part of their tasks.
+
+
+---
+
+* [MAPREDUCE-3714](https://issues.apache.org/jira/browse/MAPREDUCE-3714) | *Blocker* | **Reduce hangs in a corner case**
+
+Fixed EventFetcher and Fetcher threads to shut-down properly so that reducers don't hang in corner cases.
+
+
+---
+
+* [MAPREDUCE-3713](https://issues.apache.org/jira/browse/MAPREDUCE-3713) | *Blocker* | **Incorrect headroom reported to jobs**
+
+Fixed the way head-room is allocated to applications by CapacityScheduler so that it deducts current-usage per user and not per-application.
+
+
+---
+
+* [MAPREDUCE-3711](https://issues.apache.org/jira/browse/MAPREDUCE-3711) | *Blocker* | **AppMaster recovery for Medium to large jobs take long time**
+
+Fixed MR AM recovery so that only single selected task output is recovered and thus reduce the unnecessarily bloated recovery time.
+
+
+---
+
+* [MAPREDUCE-3710](https://issues.apache.org/jira/browse/MAPREDUCE-3710) | *Major* | **last split generated by FileInputFormat.getSplits may not have the best locality**
+
+Improved FileInputFormat to return better locality for the last split.
+
+
+---
+
+* [MAPREDUCE-3703](https://issues.apache.org/jira/browse/MAPREDUCE-3703) | *Critical* | **ResourceManager should provide node lists in JMX output**
+
+New JMX Bean in ResourceManager to provide list of live node managers:
+
+Hadoop:service=ResourceManager,name=RMNMInfo LiveNodeManagers
+
+
+---
+
+* [MAPREDUCE-3699](https://issues.apache.org/jira/browse/MAPREDUCE-3699) | *Major* | **Default RPC handlers are very low for YARN servers**
+
+Increased RPC handlers for all YARN servers to reasonable values for working at scale.
+
+
+---
+
+* [MAPREDUCE-3656](https://issues.apache.org/jira/browse/MAPREDUCE-3656) | *Blocker* | **Sort job on 350 scale is consistently failing with latest MRV2 code**
+
+Fixed a race condition in MR AM which is failing the sort benchmark consistently.
+
+
+---
+
+* [MAPREDUCE-3641](https://issues.apache.org/jira/browse/MAPREDUCE-3641) | *Blocker* | **CapacityScheduler should be more conservative assigning off-switch requests**
+
+Making CapacityScheduler more conservative so as to assign only one off-switch container in a single scheduling iteration.
+
+
+---
+
+* [MAPREDUCE-3639](https://issues.apache.org/jira/browse/MAPREDUCE-3639) | *Blocker* | **TokenCache likely broken for FileSystems which don't issue delegation tokens**
+
+Fixed TokenCache to work with absent FileSystem canonical service-names.
+
+
+---
+
+* [MAPREDUCE-3630](https://issues.apache.org/jira/browse/MAPREDUCE-3630) | *Critical* | **NullPointerException running teragen**
+
+Committed to trunk and branch-0.23. Thanks Mahadev.
+
+
+---
+
+* [MAPREDUCE-3618](https://issues.apache.org/jira/browse/MAPREDUCE-3618) | *Major* | **TaskHeartbeatHandler holds a global lock for all task-updates**
+
+Fixed TaskHeartbeatHandler to not hold a global lock for all task-updates.
+
+
+---
+
+* [MAPREDUCE-3597](https://issues.apache.org/jira/browse/MAPREDUCE-3597) | *Major* | **Provide a way to access other info of history file from Rumentool**
+
+Rumen now provides {{Parsed*}} objects. These objects provide extra information that are not provided by {{Logged*}} objects.
+
+
+---
+
+* [MAPREDUCE-3586](https://issues.apache.org/jira/browse/MAPREDUCE-3586) | *Blocker* | **Lots of AMs hanging around in PIG testing**
+
+Modified CompositeService to avoid duplicate stop operations thereby solving race conditions in MR AM shutdown.
+
+
+---
+
+* [MAPREDUCE-3568](https://issues.apache.org/jira/browse/MAPREDUCE-3568) | *Critical* | **Optimize Job's progress calculations in MR AM**
+
+Optimized Job's progress calculations in MR AM.
+
+
+---
+
+* [MAPREDUCE-3564](https://issues.apache.org/jira/browse/MAPREDUCE-3564) | *Blocker* | **TestStagingCleanup and TestJobEndNotifier are failing on trunk.**
+
+Fixed failures in TestStagingCleanup and TestJobEndNotifier tests.
+
+
+---
+
+* [MAPREDUCE-3549](https://issues.apache.org/jira/browse/MAPREDUCE-3549) | *Blocker* | **write api documentation for web service apis for RM, NM, mapreduce app master, and job history server**
+
+new files added: A      hadoop-mapreduce-project/hadoop-yarn/hadoop-yarn-site/src/site/apt/WebServicesIntro.apt.vm
+A      hadoop-mapreduce-project/hadoop-yarn/hadoop-yarn-site/src/site/apt/NodeManagerRest.apt.vm
+A      hadoop-mapreduce-project/hadoop-yarn/hadoop-yarn-site/src/site/apt/ResourceManagerRest.apt.vm
+A      hadoop-mapreduce-project/hadoop-yarn/hadoop-yarn-site/src/site/apt/MapredAppMasterRest.apt.vm
+A      hadoop-mapreduce-project/hadoop-yarn/hadoop-yarn-site/src/site/apt/HistoryServerRest.apt.vm
+
+The hadoop-project/src/site/site.xml is split into separate patch.
+
+
+---
+
+* [MAPREDUCE-3532](https://issues.apache.org/jira/browse/MAPREDUCE-3532) | *Critical* | **When 0 is provided as port number in yarn.nodemanager.webapp.address, NMs webserver component picks up random port, NM keeps on Reporting 0 port to RM**
+
+Modified NM to report correct http address when an ephemeral web port is configured.
+
+
+---
+
+* [MAPREDUCE-3530](https://issues.apache.org/jira/browse/MAPREDUCE-3530) | *Blocker* | **Sometimes NODE\_UPDATE to the scheduler throws an NPE causing the scheduling to stop**
+
+Fixed an NPE occuring during scheduling in the ResourceManager.
+
+
+---
+
+* [MAPREDUCE-3528](https://issues.apache.org/jira/browse/MAPREDUCE-3528) | *Major* | **The task timeout check interval should be configurable independent of mapreduce.task.timeout**
+
+Fixed TaskHeartBeatHandler to use a new configuration for the thread loop interval separate from task-timeout configuration property.
+
+
+---
+
+* [MAPREDUCE-3519](https://issues.apache.org/jira/browse/MAPREDUCE-3519) | *Blocker* | **Deadlock in LocalDirsHandlerService and ShuffleHandler**
+
+Fixed a deadlock in NodeManager LocalDirectories's handling service.
+
+
+---
+
+* [MAPREDUCE-3512](https://issues.apache.org/jira/browse/MAPREDUCE-3512) | *Blocker* | **Batch jobHistory disk flushes**
+
+Batching JobHistory flushing to DFS so that we don't flush for every event slowing down AM.
+
+
+---
+
+* [MAPREDUCE-3511](https://issues.apache.org/jira/browse/MAPREDUCE-3511) | *Blocker* | **Counters occupy a good part of AM heap**
+
+Removed a multitude of cloned/duplicate counters in the AM thereby reducing the AM heap size and preventing full GCs.
+
+
+---
+
+* [MAPREDUCE-3490](https://issues.apache.org/jira/browse/MAPREDUCE-3490) | *Blocker* | **RMContainerAllocator counts failed maps towards Reduce ramp up**
+
+Fixed MapReduce AM to count failed maps also towards Reduce ramp up.
+
+
+---
+
+* [MAPREDUCE-3487](https://issues.apache.org/jira/browse/MAPREDUCE-3487) | *Critical* | **jobhistory web ui task counters no longer links to singletakecounter page**
+
+Fixed JobHistory web-UI to display links to single task's counters' page.
+
+
+---
+
+* [MAPREDUCE-3484](https://issues.apache.org/jira/browse/MAPREDUCE-3484) | *Major* | **JobEndNotifier is getting interrupted before completing all its retries.**
+
+Fixed JobEndNotifier to not get interrupted before completing all its retries.
+
+
+---
+
+* [MAPREDUCE-3481](https://issues.apache.org/jira/browse/MAPREDUCE-3481) | *Major* | **[Gridmix] Improve STRESS mode locking**
+
+Modified Gridmix STRESS mode locking structure. The submitted thread and the polling thread now run simultaneously without blocking each other.
+
+
+---
+
+* [MAPREDUCE-3462](https://issues.apache.org/jira/browse/MAPREDUCE-3462) | *Blocker* | **Job submission failing in JUnit tests**
+
+Fixed failing JUnit tests in Gridmix.
+
+
+---
+
+* [MAPREDUCE-3426](https://issues.apache.org/jira/browse/MAPREDUCE-3426) | *Blocker* | **uber-jobs tried to write outputs into wrong dir**
+
+Fixed MR AM in uber mode to write map intermediate outputs in the correct directory to work properly in secure mode.
+
+
+---
+
+* [MAPREDUCE-3417](https://issues.apache.org/jira/browse/MAPREDUCE-3417) | *Blocker* | **job access controls not working app master and job history UI's**
+
+Fixed job-access-controls to work with MR AM and JobHistoryServer web-apps.
+
+
+---
+
+* [MAPREDUCE-3412](https://issues.apache.org/jira/browse/MAPREDUCE-3412) | *Major* | **'ant docs' is broken**
+
+Fixes 'ant docs' by removing stale references to capacity-scheduler docs.
+
+
+---
+
+* [MAPREDUCE-3407](https://issues.apache.org/jira/browse/MAPREDUCE-3407) | *Minor* | **Wrong jar getting used in TestMR\*Jobs\* for MiniMRYarnCluster**
+
+Fixed pom files to refer to the correct MR app-jar needed by the integration tests.
+
+
+---
+
+* [MAPREDUCE-3404](https://issues.apache.org/jira/browse/MAPREDUCE-3404) | *Critical* | **Speculative Execution: speculative map tasks launched even if -Dmapreduce.map.speculative=false**
+
+Corrected MR AM to honor speculative configuration and enable speculating either maps or reduces.
+
+
+---
+
+* [MAPREDUCE-3399](https://issues.apache.org/jira/browse/MAPREDUCE-3399) | *Blocker* | **ContainerLocalizer should request new resources after completing the current one**
+
+Modified ContainerLocalizer to send a heartbeat to NM immediately after downloading a resource instead of always waiting for a second.
+
+
+---
+
+* [MAPREDUCE-3398](https://issues.apache.org/jira/browse/MAPREDUCE-3398) | *Blocker* | **Log Aggregation broken in Secure Mode**
+
+Fixed log aggregation to work correctly in secure mode. Contributed by Siddharth Seth.
+
+
+---
+
+* [MAPREDUCE-3392](https://issues.apache.org/jira/browse/MAPREDUCE-3392) | *Blocker* | **Cluster.getDelegationToken() throws NPE if client.getDelegationToken() returns null.**
+
+Fixed Cluster's getDelegationToken's API to return null when there isn't a supported token.
+
+
+---
+
+* [MAPREDUCE-3387](https://issues.apache.org/jira/browse/MAPREDUCE-3387) | *Critical* | **A tracking URL of N/A before the app master is launched breaks oozie**
+
+Fixed AM's tracking URL to always go through the proxy, even before the job started, so that it works properly with oozie throughout the job execution.
+
+
+---
+
+* [MAPREDUCE-3382](https://issues.apache.org/jira/browse/MAPREDUCE-3382) | *Critical* | **Network ACLs can prevent AMs to ping the Job-end notification URL**
+
+Enhanced MR AM to use a proxy to ping the job-end notification URL.
+
+
+---
+
+* [MAPREDUCE-3379](https://issues.apache.org/jira/browse/MAPREDUCE-3379) | *Major* | **LocalResourceTracker should not tracking deleted cache entries**
+
+Fixed LocalResourceTracker in NodeManager to remove deleted cache entries correctly.
+
+
+---
+
+* [MAPREDUCE-3375](https://issues.apache.org/jira/browse/MAPREDUCE-3375) | *Major* | **Memory Emulation system tests.**
+
+Added system tests to test the memory emulation feature in Gridmix.
+
+
+---
+
+* [MAPREDUCE-3368](https://issues.apache.org/jira/browse/MAPREDUCE-3368) | *Critical* | **compile-mapred-test fails**
+
+Fixed ant test compilation.
+
+
+---
+
+* [MAPREDUCE-3360](https://issues.apache.org/jira/browse/MAPREDUCE-3360) | *Critical* | **Provide information about lost nodes in the UI.**
+
+Added information about lost/rebooted/decommissioned nodes on the webapps.
+
+
+---
+
+* [MAPREDUCE-3355](https://issues.apache.org/jira/browse/MAPREDUCE-3355) | *Blocker* | **AM scheduling hangs frequently with sort job on 350 nodes**
+
+Fixed MR AM's ContainerLauncher to handle node-command timeouts correctly.
+
+
+---
+
+* [MAPREDUCE-3349](https://issues.apache.org/jira/browse/MAPREDUCE-3349) | *Blocker* | **No rack-name logged in JobHistory for unsuccessful tasks**
+
+Unsuccessful tasks now log hostname and rackname to job history.
+
+
+---
+
+* [MAPREDUCE-3345](https://issues.apache.org/jira/browse/MAPREDUCE-3345) | *Major* | **Race condition in ResourceManager causing TestContainerManagerSecurity to fail sometimes**
+
+Fixed a race condition in ResourceManager that was causing TestContainerManagerSecurity to fail sometimes.
+
+
+---
+
+* [MAPREDUCE-3342](https://issues.apache.org/jira/browse/MAPREDUCE-3342) | *Critical* | **JobHistoryServer doesn't show job queue**
+
+Fixed JobHistoryServer to also show the job's queue name.
+
+
+---
+
+* [MAPREDUCE-3339](https://issues.apache.org/jira/browse/MAPREDUCE-3339) | *Blocker* | **Job is getting hanged indefinitely,if the child processes are killed on the NM.  KILL\_CONTAINER eventtype is continuosly sent to the containers that are not existing**
+
+Fixed MR AM to stop considering node blacklisting after the number of nodes blacklisted crosses a threshold.
+
+
+---
+
+* [MAPREDUCE-3333](https://issues.apache.org/jira/browse/MAPREDUCE-3333) | *Blocker* | **MR AM for sort-job going out of memory**
+
+Fixed bugs in ContainerLauncher of MR AppMaster due to which per-container connections to NodeManager were lingering long enough to hit the ulimits on number of processes.
+
+
+---
+
+* [MAPREDUCE-3325](https://issues.apache.org/jira/browse/MAPREDUCE-3325) | *Major* | **Improvements to CapacityScheduler doc**
+
+document changes only.
+
+
+---
+
+* [MAPREDUCE-3312](https://issues.apache.org/jira/browse/MAPREDUCE-3312) | *Major* | **Make MR AM not send a stopContainer w/o corresponding start container**
+
+Modified MR AM to not send a stop-container request for a container that isn't launched at all.
+
+
+---
+
+* [MAPREDUCE-3299](https://issues.apache.org/jira/browse/MAPREDUCE-3299) | *Minor* | **Add AMInfo table to the AM job page**
+
+Added AMInfo table to the MR AM job pages to list all the job-attempts when AM restarts and recovers.
+
+
+---
+
+* [MAPREDUCE-3297](https://issues.apache.org/jira/browse/MAPREDUCE-3297) | *Major* | **Move Log Related components from yarn-server-nodemanager to yarn-common**
+
+Moved log related components into yarn-common so that HistoryServer and clients can use them without depending on the yarn-server-nodemanager module.
+
+
+---
+
+* [MAPREDUCE-3280](https://issues.apache.org/jira/browse/MAPREDUCE-3280) | *Major* | **MR AM should not read the username from configuration**
+
+Removed the unnecessary job user-name configuration in mapred-site.xml.
+
+
+---
+
+* [MAPREDUCE-3221](https://issues.apache.org/jira/browse/MAPREDUCE-3221) | *Minor* | **ant test TestSubmitJob failing on trunk**
+
+Fixed a bug in TestSubmitJob.
+
+
+---
+
+* [MAPREDUCE-3219](https://issues.apache.org/jira/browse/MAPREDUCE-3219) | *Minor* | **ant test TestDelegationToken failing on trunk**
+
+Reenabled and fixed bugs in the failing test TestDelegationToken.
+
+
+---
+
+* [MAPREDUCE-3217](https://issues.apache.org/jira/browse/MAPREDUCE-3217) | *Minor* | **ant test TestAuditLogger fails on trunk**
+
+Reenabled and fixed bugs in the failing ant test TestAuditLogger.
+
+
+---
+
+* [MAPREDUCE-3215](https://issues.apache.org/jira/browse/MAPREDUCE-3215) | *Minor* | **org.apache.hadoop.mapreduce.TestNoJobSetupCleanup failing on trunk**
+
+Reneabled and fixed bugs in the failing test TestNoJobSetupCleanup.
+
+
+---
+
+* [MAPREDUCE-3102](https://issues.apache.org/jira/browse/MAPREDUCE-3102) | *Major* | **NodeManager should fail fast with wrong configuration or permissions for LinuxContainerExecutor**
+
+Changed NodeManager to fail fast when LinuxContainerExecutor has wrong configuration or permissions.
+
+
+---
+
+* [MAPREDUCE-2950](https://issues.apache.org/jira/browse/MAPREDUCE-2950) | *Major* | **[Gridmix] TestUserResolve fails in trunk**
+
+Fixes bug in TestUserResolve.
+
+
+---
+
+* [MAPREDUCE-2863](https://issues.apache.org/jira/browse/MAPREDUCE-2863) | *Blocker* | **Support web-services for RM & NM**
+
+Support for web-services in YARN and MR components.
+
+
+---
+
+* [MAPREDUCE-2784](https://issues.apache.org/jira/browse/MAPREDUCE-2784) | *Major* | **[Gridmix] TestGridmixSummary fails with NPE when run in DEBUG mode.**
+
+Fixed bugs in ExecutionSummarizer and ResourceUsageMatcher.
+
+
+---
+
+* [MAPREDUCE-2765](https://issues.apache.org/jira/browse/MAPREDUCE-2765) | *Major* | **DistCp Rewrite**
+
+DistCpV2 added to hadoop-tools.
+
+
+---
+
+* [MAPREDUCE-2733](https://issues.apache.org/jira/browse/MAPREDUCE-2733) | *Major* | **Gridmix v3 cpu emulation system tests.**
+
+Adds system tests for the CPU emulation feature in Gridmix3.
+
+
+---
+
+* [MAPREDUCE-778](https://issues.apache.org/jira/browse/MAPREDUCE-778) | *Major* | **[Rumen] Need a standalone JobHistory log anonymizer**
+
+Added an anonymizer tool to Rumen. Anonymizer takes a Rumen trace file and/or topology as input. It supports persistence and plugins to override the default behavior.
+
+
+

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/CHANGES.0.23.10.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/CHANGES.0.23.10.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/CHANGES.0.23.10.md
new file mode 100644
index 0000000..82bef03
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/CHANGES.0.23.10.md
@@ -0,0 +1,132 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop Changelog
+
+## Release 0.23.10 - 2013-12-09
+
+### INCOMPATIBLE CHANGES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [YARN-707](https://issues.apache.org/jira/browse/YARN-707) | Add user info in the YARN ClientToken |  Blocker | . | Bikas Saha | Jason Lowe |
+
+
+### NEW FEATURES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+
+
+### IMPROVEMENTS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-9686](https://issues.apache.org/jira/browse/HADOOP-9686) | Easy access to final parameters in Configuration |  Major | conf | Jason Lowe | Jason Lowe |
+| [HADOOP-8704](https://issues.apache.org/jira/browse/HADOOP-8704) | add request logging to jetty/httpserver |  Major | . | Thomas Graves | Jonathan Eagles |
+| [HDFS-5010](https://issues.apache.org/jira/browse/HDFS-5010) | Reduce the frequency of getCurrentUser() calls from namenode |  Major | namenode, performance | Kihwal Lee | Kihwal Lee |
+| [MAPREDUCE-5640](https://issues.apache.org/jira/browse/MAPREDUCE-5640) | Rename TestLineRecordReader in jobclient module |  Trivial | test | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-1981](https://issues.apache.org/jira/browse/MAPREDUCE-1981) | Improve getSplits performance by using listLocatedStatus |  Major | job submission | Hairong Kuang | Hairong Kuang |
+| [YARN-985](https://issues.apache.org/jira/browse/YARN-985) | Nodemanager should log where a resource was localized |  Major | nodemanager | Ravi Prakash | Ravi Prakash |
+
+
+### BUG FIXES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-10091](https://issues.apache.org/jira/browse/HADOOP-10091) | Job with a har archive as input fails on 0.23 |  Blocker | fs | Jason Lowe | Jason Lowe |
+| [HADOOP-9757](https://issues.apache.org/jira/browse/HADOOP-9757) | Har metadata cache can grow without limit |  Major | fs | Jason Lowe | Cristina L. Abad |
+| [HADOOP-9476](https://issues.apache.org/jira/browse/HADOOP-9476) | Some test cases in TestUserGroupInformation fail if ran after testSetLoginUser. |  Major | security, test | Kihwal Lee | Robert Parker |
+| [HDFS-5558](https://issues.apache.org/jira/browse/HDFS-5558) | LeaseManager monitor thread can crash if the last block is complete but another block is not. |  Major | . | Kihwal Lee | Kihwal Lee |
+| [HDFS-5557](https://issues.apache.org/jira/browse/HDFS-5557) | Write pipeline recovery for the last packet in the block may cause rejection of valid replicas |  Critical | . | Kihwal Lee | Kihwal Lee |
+| [HDFS-5526](https://issues.apache.org/jira/browse/HDFS-5526) | Datanode cannot roll back to previous layout version |  Blocker | datanode | Tsz Wo Nicholas Sze | Kihwal Lee |
+| [HDFS-5438](https://issues.apache.org/jira/browse/HDFS-5438) | Flaws in block report processing can cause data loss |  Critical | namenode | Kihwal Lee | Kihwal Lee |
+| [HDFS-5346](https://issues.apache.org/jira/browse/HDFS-5346) | Avoid unnecessary call to getNumLiveDataNodes() for each block during IBR processing |  Major | namenode, performance | Kihwal Lee | Ravi Prakash |
+| [HDFS-5047](https://issues.apache.org/jira/browse/HDFS-5047) | Supress logging of full stack trace of quota and lease exceptions |  Major | namenode | Kihwal Lee | Robert Parker |
+| [HDFS-5028](https://issues.apache.org/jira/browse/HDFS-5028) | LeaseRenewer throw java.util.ConcurrentModificationException when timeout |  Major | . | zhaoyunjiong | zhaoyunjiong |
+| [HDFS-4998](https://issues.apache.org/jira/browse/HDFS-4998) | TestUnderReplicatedBlocks fails intermittently |  Major | test | Kihwal Lee | Kihwal Lee |
+| [HDFS-4995](https://issues.apache.org/jira/browse/HDFS-4995) | Make getContentSummary() less expensive |  Major | namenode | Kihwal Lee | Kihwal Lee |
+| [HDFS-4994](https://issues.apache.org/jira/browse/HDFS-4994) | Audit log getContentSummary() calls |  Minor | namenode | Kihwal Lee | Robert Parker |
+| [HDFS-4993](https://issues.apache.org/jira/browse/HDFS-4993) | fsck can fail if a file is renamed or deleted |  Major | . | Kihwal Lee | Robert Parker |
+| [HDFS-4984](https://issues.apache.org/jira/browse/HDFS-4984) | Incorrect Quota counting in INodeFile |  Major | namenode | Kihwal Lee | Jing Zhao |
+| [HDFS-4972](https://issues.apache.org/jira/browse/HDFS-4972) | [branch-0.23] permission check and operation are done in a separate lock for getBlockLocations() |  Major | namenode | Kihwal Lee | Kihwal Lee |
+| [HDFS-4943](https://issues.apache.org/jira/browse/HDFS-4943) | WebHdfsFileSystem does not work when original file path has encoded chars |  Minor | webhdfs | Jerry He | Jerry He |
+| [HDFS-4482](https://issues.apache.org/jira/browse/HDFS-4482) | ReplicationMonitor thread can exit with NPE due to the race between delete and replication of same file. |  Blocker | namenode | Uma Maheswara Rao G | Uma Maheswara Rao G |
+| [HDFS-4329](https://issues.apache.org/jira/browse/HDFS-4329) | DFSShell issues with directories with spaces in name |  Major | hdfs-client | Andy Isaacson | Cristina L. Abad |
+| [HDFS-3970](https://issues.apache.org/jira/browse/HDFS-3970) | BlockPoolSliceStorage#doRollback(..) should use BlockPoolSliceStorage instead of DataStorage to read prev version file. |  Major | datanode | Vinayakumar B | Vinayakumar B |
+| [HDFS-3020](https://issues.apache.org/jira/browse/HDFS-3020) | Auto-logSync based on edit log buffer size broken |  Critical | namenode | Todd Lipcon | Todd Lipcon |
+| [MAPREDUCE-5587](https://issues.apache.org/jira/browse/MAPREDUCE-5587) | TestTextOutputFormat fails on JDK7 |  Major | . | Jonathan Eagles | Jonathan Eagles |
+| [MAPREDUCE-5586](https://issues.apache.org/jira/browse/MAPREDUCE-5586) | TestCopyMapper#testCopyFailOnBlockSizeDifference fails when run from hadoop-tools/hadoop-distcp directory |  Major | . | Jonathan Eagles | Jonathan Eagles |
+| [MAPREDUCE-5585](https://issues.apache.org/jira/browse/MAPREDUCE-5585) | TestCopyCommitter#testNoCommitAction Fails on JDK7 |  Major | . | Jonathan Eagles | Jonathan Eagles |
+| [MAPREDUCE-5569](https://issues.apache.org/jira/browse/MAPREDUCE-5569) | FloatSplitter is not generating correct splits |  Major | . | Nathan Roberts | Nathan Roberts |
+| [MAPREDUCE-5561](https://issues.apache.org/jira/browse/MAPREDUCE-5561) | org.apache.hadoop.mapreduce.v2.app.job.impl.TestJobImpl testcase failing on trunk |  Critical | . | Cindy Li | Karthik Kambatla |
+| [MAPREDUCE-5543](https://issues.apache.org/jira/browse/MAPREDUCE-5543) | In-memory map outputs can be leaked after shuffle completes in 0.23 |  Blocker | mrv2 | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-5513](https://issues.apache.org/jira/browse/MAPREDUCE-5513) | ConcurrentModificationException in JobControl |  Major | . | Jason Lowe | Robert Parker |
+| [MAPREDUCE-5504](https://issues.apache.org/jira/browse/MAPREDUCE-5504) | mapred queue -info inconsistent with types |  Major | client | Thomas Graves | Kousuke Saruta |
+| [MAPREDUCE-5475](https://issues.apache.org/jira/browse/MAPREDUCE-5475) | MRClientService does not verify ACLs properly |  Blocker | mr-am, mrv2 | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-5468](https://issues.apache.org/jira/browse/MAPREDUCE-5468) | AM recovery does not work for map only jobs |  Blocker | . | Yesha Vora | Vinod Kumar Vavilapalli |
+| [MAPREDUCE-5440](https://issues.apache.org/jira/browse/MAPREDUCE-5440) | TestCopyCommitter Fails on JDK7 |  Major | mrv2 | Robert Parker | Robert Parker |
+| [MAPREDUCE-5425](https://issues.apache.org/jira/browse/MAPREDUCE-5425) | Junit in TestJobHistoryServer failing in jdk 7 |  Major | jobhistoryserver | Ashwin Shankar | Robert Parker |
+| [MAPREDUCE-5419](https://issues.apache.org/jira/browse/MAPREDUCE-5419) | TestSlive is getting FileNotFound Exception |  Major | mrv2 | Robert Parker | Robert Parker |
+| [MAPREDUCE-5414](https://issues.apache.org/jira/browse/MAPREDUCE-5414) | TestTaskAttempt fails jdk7 with NullPointerException |  Major | test | Nemon Lou | Nemon Lou |
+| [MAPREDUCE-5380](https://issues.apache.org/jira/browse/MAPREDUCE-5380) | Invalid mapred command should return non-zero exit code |  Major | . | Stephen Chu | Stephen Chu |
+| [MAPREDUCE-5373](https://issues.apache.org/jira/browse/MAPREDUCE-5373) | TestFetchFailure.testFetchFailureMultipleReduces could fail intermittently |  Major | . | Chuan Liu | Jonathan Eagles |
+| [MAPREDUCE-5317](https://issues.apache.org/jira/browse/MAPREDUCE-5317) | Stale files left behind for failed jobs |  Major | mrv2 | Ravi Prakash | Ravi Prakash |
+| [MAPREDUCE-5251](https://issues.apache.org/jira/browse/MAPREDUCE-5251) | Reducer should not implicate map attempt if it has insufficient space to fetch map output |  Major | mrv2 | Jason Lowe | Ashwin Shankar |
+| [MAPREDUCE-5001](https://issues.apache.org/jira/browse/MAPREDUCE-5001) | LocalJobRunner has race condition resulting in job failures |  Major | . | Brock Noland | Sandy Ryza |
+| [MAPREDUCE-4716](https://issues.apache.org/jira/browse/MAPREDUCE-4716) | TestHsWebServicesJobsQuery.testJobsQueryStateInvalid fails with jdk7 |  Major | jobhistoryserver | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-4579](https://issues.apache.org/jira/browse/MAPREDUCE-4579) | TestTaskAttempt fails jdk7 |  Major | . | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-4571](https://issues.apache.org/jira/browse/MAPREDUCE-4571) | TestHsWebServicesJobs fails on jdk7 |  Major | webapps | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-3193](https://issues.apache.org/jira/browse/MAPREDUCE-3193) | FileInputFormat doesn't read files recursively in the input path dir |  Major | mrv1, mrv2 | Ramgopal N | Devaraj K |
+| [YARN-1419](https://issues.apache.org/jira/browse/YARN-1419) | TestFifoScheduler.testAppAttemptMetrics fails intermittently under jdk7 |  Minor | scheduler | Jonathan Eagles | Jonathan Eagles |
+| [YARN-1386](https://issues.apache.org/jira/browse/YARN-1386) | NodeManager mistakenly loses resources and relocalizes them |  Critical | nodemanager | Jason Lowe | Jason Lowe |
+| [YARN-1243](https://issues.apache.org/jira/browse/YARN-1243) | ResourceManager: Error in handling event type NODE\_UPDATE to the scheduler - NPE at SchedulerApp.java:411 |  Major | capacityscheduler | Sanjay Upadhyay | Jason Lowe |
+| [YARN-1176](https://issues.apache.org/jira/browse/YARN-1176) | RM web services ClusterMetricsInfo total nodes doesn't include unhealthy nodes |  Critical | resourcemanager | Thomas Graves | Jonathan Eagles |
+| [YARN-1101](https://issues.apache.org/jira/browse/YARN-1101) | Active nodes can be decremented below 0 |  Major | resourcemanager | Robert Parker | Robert Parker |
+| [YARN-1036](https://issues.apache.org/jira/browse/YARN-1036) | Distributed Cache gives inconsistent result if cache files get deleted from task tracker |  Major | nodemanager | Ravi Prakash | Ravi Prakash |
+| [YARN-1031](https://issues.apache.org/jira/browse/YARN-1031) | JQuery UI components reference external css in branch-23 |  Major | . | Jonathan Eagles | Jonathan Eagles |
+| [YARN-949](https://issues.apache.org/jira/browse/YARN-949) | Failed log aggregation can leave a file open. |  Major | nodemanager | Kihwal Lee | Kihwal Lee |
+| [YARN-337](https://issues.apache.org/jira/browse/YARN-337) | RM handles killed application tracking URL poorly |  Major | resourcemanager | Jason Lowe | Jason Lowe |
+| [YARN-155](https://issues.apache.org/jira/browse/YARN-155) | TestAppManager intermittently fails with jdk7 |  Major | . | Thomas Graves | Thomas Graves |
+
+
+### TESTS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [MAPREDUCE-5610](https://issues.apache.org/jira/browse/MAPREDUCE-5610) | TestSleepJob fails in jdk7 |  Major | . | Jonathan Eagles | Jonathan Eagles |
+| [YARN-1119](https://issues.apache.org/jira/browse/YARN-1119) | Add ClusterMetrics checks to tho TestRMNodeTransitions tests |  Major | resourcemanager | Robert Parker | Mit Desai |
+
+
+### SUB-TASKS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-9956](https://issues.apache.org/jira/browse/HADOOP-9956) | RPC listener inefficiently assigns connections to readers |  Major | ipc | Daryn Sharp | Daryn Sharp |
+| [HADOOP-9955](https://issues.apache.org/jira/browse/HADOOP-9955) | RPC idle connection closing is extremely inefficient |  Major | ipc | Daryn Sharp | Daryn Sharp |
+| [HADOOP-9748](https://issues.apache.org/jira/browse/HADOOP-9748) | Reduce blocking on UGI.ensureInitialized |  Critical | security | Daryn Sharp | Daryn Sharp |
+| [HDFS-5239](https://issues.apache.org/jira/browse/HDFS-5239) | Allow FSNamesystem lock fairness to be configurable |  Major | namenode | Daryn Sharp | Daryn Sharp |
+| [YARN-573](https://issues.apache.org/jira/browse/YARN-573) | Shared data structures in Public Localizer and Private Localizer are not Thread safe. |  Critical | . | Omkar Vinit Joshi | Omkar Vinit Joshi |
+
+
+### OTHER:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+
+

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/RELEASENOTES.0.23.10.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/RELEASENOTES.0.23.10.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/RELEASENOTES.0.23.10.md
new file mode 100644
index 0000000..f1388d0
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.10/RELEASENOTES.0.23.10.md
@@ -0,0 +1,31 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop  0.23.10 Release Notes
+
+These release notes cover new developer and user-facing incompatibilities, features, and major improvements.
+
+
+---
+
+* [YARN-707](https://issues.apache.org/jira/browse/YARN-707) | *Blocker* | **Add user info in the YARN ClientToken**
+
+**WARNING: No release note provided for this incompatible change.**
+
+
+

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/CHANGES.0.23.11.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/CHANGES.0.23.11.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/CHANGES.0.23.11.md
new file mode 100644
index 0000000..3259d86
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/CHANGES.0.23.11.md
@@ -0,0 +1,105 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop Changelog
+
+## Release 0.23.11 - 2014-06-25
+
+### INCOMPATIBLE CHANGES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+
+
+### NEW FEATURES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+
+
+### IMPROVEMENTS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-10454](https://issues.apache.org/jira/browse/HADOOP-10454) | Provide FileContext version of har file system |  Major | . | Kihwal Lee | Kihwal Lee |
+| [HADOOP-10164](https://issues.apache.org/jira/browse/HADOOP-10164) | Allow UGI to login with a known Subject |  Major | . | Robert Joseph Evans | Robert Joseph Evans |
+| [HADOOP-7688](https://issues.apache.org/jira/browse/HADOOP-7688) | When a servlet filter throws an exception in init(..), the Jetty server failed silently. |  Major | . | Tsz Wo Nicholas Sze | Uma Maheswara Rao G |
+| [HDFS-6191](https://issues.apache.org/jira/browse/HDFS-6191) | Disable quota checks when replaying edit log. |  Major | namenode | Kihwal Lee | Kihwal Lee |
+| [HDFS-5637](https://issues.apache.org/jira/browse/HDFS-5637) | try to refeatchToken while local read InvalidToken occurred |  Major | hdfs-client, security | Liang Xie | Liang Xie |
+| [HDFS-4461](https://issues.apache.org/jira/browse/HDFS-4461) | DirectoryScanner: volume path prefix takes up memory for every block that is scanned |  Minor | . | Colin Patrick McCabe | Colin Patrick McCabe |
+
+
+### BUG FIXES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-10588](https://issues.apache.org/jira/browse/HADOOP-10588) | Workaround for jetty6 acceptor startup issue |  Major | . | Kihwal Lee | Kihwal Lee |
+| [HADOOP-10332](https://issues.apache.org/jira/browse/HADOOP-10332) | HttpServer's jetty audit log always logs 200 OK |  Major | . | Daryn Sharp | Jonathan Eagles |
+| [HADOOP-10146](https://issues.apache.org/jira/browse/HADOOP-10146) | Workaround JDK7 Process fd close bug |  Critical | util | Daryn Sharp | Daryn Sharp |
+| [HADOOP-10129](https://issues.apache.org/jira/browse/HADOOP-10129) | Distcp may succeed when it fails |  Critical | tools/distcp | Daryn Sharp | Daryn Sharp |
+| [HADOOP-10112](https://issues.apache.org/jira/browse/HADOOP-10112) | har file listing  doesn't work with wild card |  Major | tools | Brandon Li | Brandon Li |
+| [HADOOP-10110](https://issues.apache.org/jira/browse/HADOOP-10110) | hadoop-auth has a build break due to missing dependency |  Blocker | build | Chuan Liu | Chuan Liu |
+| [HADOOP-10081](https://issues.apache.org/jira/browse/HADOOP-10081) | Client.setupIOStreams can leak socket resources on exception or error |  Critical | ipc | Jason Lowe | Tsuyoshi Ozawa |
+| [HADOOP-9230](https://issues.apache.org/jira/browse/HADOOP-9230) | TestUniformSizeInputFormat fails intermittently |  Major | test | Karthik Kambatla | Karthik Kambatla |
+| [HADOOP-8826](https://issues.apache.org/jira/browse/HADOOP-8826) | Docs still refer to 0.20.205 as stable line |  Minor | . | Robert Joseph Evans | Mit Desai |
+| [HDFS-6449](https://issues.apache.org/jira/browse/HDFS-6449) | Incorrect counting in ContentSummaryComputationContext in 0.23. |  Critical | . | Kihwal Lee | Kihwal Lee |
+| [HDFS-6166](https://issues.apache.org/jira/browse/HDFS-6166) | revisit balancer so\_timeout |  Blocker | balancer & mover | Nathan Roberts | Nathan Roberts |
+| [HDFS-5881](https://issues.apache.org/jira/browse/HDFS-5881) | Fix skip() of the short-circuit local reader (legacy). |  Critical | . | Kihwal Lee | Kihwal Lee |
+| [HDFS-5806](https://issues.apache.org/jira/browse/HDFS-5806) | balancer should set SoTimeout to avoid indefinite hangs |  Major | balancer & mover | Nathan Roberts | Nathan Roberts |
+| [HDFS-5728](https://issues.apache.org/jira/browse/HDFS-5728) | [Diskfull] Block recovery will fail if the metafile does not have crc for all chunks of the block |  Critical | datanode | Vinayakumar B | Vinayakumar B |
+| [HDFS-4576](https://issues.apache.org/jira/browse/HDFS-4576) | Webhdfs authentication issues |  Major | webhdfs | Daryn Sharp | Daryn Sharp |
+| [MAPREDUCE-5789](https://issues.apache.org/jira/browse/MAPREDUCE-5789) | Average Reduce time is incorrect on Job Overview page |  Major | jobhistoryserver, webapps | Rushabh S Shah | Rushabh S Shah |
+| [MAPREDUCE-5778](https://issues.apache.org/jira/browse/MAPREDUCE-5778) | JobSummary does not escape newlines in the job name |  Major | jobhistoryserver | Jason Lowe | Akira AJISAKA |
+| [MAPREDUCE-5757](https://issues.apache.org/jira/browse/MAPREDUCE-5757) | ConcurrentModificationException in JobControl.toList |  Major | client | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-5746](https://issues.apache.org/jira/browse/MAPREDUCE-5746) | Job diagnostics can implicate wrong task for a failed job |  Major | jobhistoryserver | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-5744](https://issues.apache.org/jira/browse/MAPREDUCE-5744) | Job hangs because RMContainerAllocator$AssignedRequests.preemptReduce() violates the comparator contract |  Blocker | . | Sangjin Lee | Gera Shegalov |
+| [MAPREDUCE-5689](https://issues.apache.org/jira/browse/MAPREDUCE-5689) | MRAppMaster does not preempt reducers when scheduled maps cannot be fulfilled |  Critical | . | Lohit Vijayarenu | Lohit Vijayarenu |
+| [MAPREDUCE-5623](https://issues.apache.org/jira/browse/MAPREDUCE-5623) | TestJobCleanup fails because of RejectedExecutionException and NPE. |  Major | . | Tsuyoshi Ozawa | Jason Lowe |
+| [MAPREDUCE-5454](https://issues.apache.org/jira/browse/MAPREDUCE-5454) | TestDFSIO fails intermittently on JDK7 |  Major | test | Karthik Kambatla | Karthik Kambatla |
+| [MAPREDUCE-3191](https://issues.apache.org/jira/browse/MAPREDUCE-3191) | docs for map output compression incorrectly reference SequenceFile |  Trivial | . | Todd Lipcon | Chen He |
+| [YARN-3829](https://issues.apache.org/jira/browse/YARN-3829) | The History Tracking UI is broken for Tez application on ResourceManager WebUI |  Critical | applications | Irina Easterling |  |
+| [YARN-1932](https://issues.apache.org/jira/browse/YARN-1932) | Javascript injection on the job status page |  Blocker | . | Mit Desai | Mit Desai |
+| [YARN-1670](https://issues.apache.org/jira/browse/YARN-1670) | aggregated log writer can write more log data then it says is the log length |  Critical | . | Thomas Graves | Mit Desai |
+| [YARN-1592](https://issues.apache.org/jira/browse/YARN-1592) | CapacityScheduler tries to reserve more than a node's total memory on branch-0.23 |  Major | capacityscheduler | Thomas Graves | Thomas Graves |
+| [YARN-1180](https://issues.apache.org/jira/browse/YARN-1180) | Update capacity scheduler docs to include types on the configs |  Trivial | capacityscheduler | Thomas Graves | Chen He |
+| [YARN-1145](https://issues.apache.org/jira/browse/YARN-1145) | Potential file handle leak in aggregated logs web ui |  Major | . | Rohith Sharma K S | Rohith Sharma K S |
+| [YARN-1053](https://issues.apache.org/jira/browse/YARN-1053) | Diagnostic message from ContainerExitEvent is ignored in ContainerImpl |  Blocker | . | Omkar Vinit Joshi | Omkar Vinit Joshi |
+| [YARN-853](https://issues.apache.org/jira/browse/YARN-853) | maximum-am-resource-percent doesn't work after refreshQueues command |  Major | capacityscheduler | Devaraj K | Devaraj K |
+| [YARN-500](https://issues.apache.org/jira/browse/YARN-500) | ResourceManager webapp is using next port if configured port is already in use |  Major | resourcemanager | Nishan Shetty | Kenji Kikushima |
+
+
+### TESTS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+
+
+### SUB-TASKS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-10148](https://issues.apache.org/jira/browse/HADOOP-10148) | backport hadoop-10107 to branch-0.23 |  Minor | ipc | Chen He | Chen He |
+| [YARN-1575](https://issues.apache.org/jira/browse/YARN-1575) | Public localizer crashes with "Localized unkown resource" |  Critical | nodemanager | Jason Lowe | Jason Lowe |
+
+
+### OTHER:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+
+

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/RELEASENOTES.0.23.11.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/RELEASENOTES.0.23.11.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/RELEASENOTES.0.23.11.md
new file mode 100644
index 0000000..7fb4718
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.11/RELEASENOTES.0.23.11.md
@@ -0,0 +1,24 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop  0.23.11 Release Notes
+
+These release notes cover new developer and user-facing incompatibilities, features, and major improvements.
+
+
+

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/CHANGES.0.23.2.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/CHANGES.0.23.2.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/CHANGES.0.23.2.md
new file mode 100644
index 0000000..cd1c26a
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/CHANGES.0.23.2.md
@@ -0,0 +1,177 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop Changelog
+
+## Release 0.23.2 - Unreleased
+
+### INCOMPATIBLE CHANGES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-8164](https://issues.apache.org/jira/browse/HADOOP-8164) | Handle paths using back slash as path separator for windows only |  Major | fs | Suresh Srinivas | Daryn Sharp |
+| [HADOOP-8131](https://issues.apache.org/jira/browse/HADOOP-8131) | FsShell put doesn't correctly handle a non-existent dir |  Critical | . | Daryn Sharp | Daryn Sharp |
+| [HDFS-2887](https://issues.apache.org/jira/browse/HDFS-2887) | Define a FSVolume interface |  Major | datanode | Tsz Wo Nicholas Sze | Tsz Wo Nicholas Sze |
+
+
+### NEW FEATURES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HDFS-2943](https://issues.apache.org/jira/browse/HDFS-2943) | Expose last checkpoint time and transaction stats as JMX metrics |  Major | namenode | Aaron T. Myers | Aaron T. Myers |
+
+
+### IMPROVEMENTS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-8071](https://issues.apache.org/jira/browse/HADOOP-8071) | Avoid an extra packet in client code when nagling is disabled |  Minor | ipc | Todd Lipcon | Todd Lipcon |
+| [HADOOP-8048](https://issues.apache.org/jira/browse/HADOOP-8048) | Allow merging of Credentials |  Major | util | Daryn Sharp | Daryn Sharp |
+| [HDFS-3066](https://issues.apache.org/jira/browse/HDFS-3066) | cap space usage of default log4j rolling policy (hdfs specific changes) |  Major | scripts | Patrick Hunt | Patrick Hunt |
+| [HDFS-3024](https://issues.apache.org/jira/browse/HDFS-3024) | Improve performance of stringification in addStoredBlock |  Minor | namenode | Todd Lipcon | Todd Lipcon |
+| [HDFS-2985](https://issues.apache.org/jira/browse/HDFS-2985) | Improve logging when replicas are marked as corrupt |  Minor | namenode | Todd Lipcon | Todd Lipcon |
+| [HDFS-2981](https://issues.apache.org/jira/browse/HDFS-2981) | The default value of dfs.client.block.write.replace-datanode-on-failure.enable should be true |  Major | . | Tsz Wo Nicholas Sze | Tsz Wo Nicholas Sze |
+| [HDFS-2907](https://issues.apache.org/jira/browse/HDFS-2907) | Make FSDataset in Datanode Pluggable |  Minor | . | Sanjay Radia | Tsz Wo Nicholas Sze |
+| [HDFS-2655](https://issues.apache.org/jira/browse/HDFS-2655) | BlockReaderLocal#skip performs unnecessary IO |  Major | datanode | Eli Collins | Brandon Li |
+| [HDFS-2506](https://issues.apache.org/jira/browse/HDFS-2506) | Umbrella jira for tracking separation of wire protocol datatypes from the implementation types |  Major | datanode, namenode | Suresh Srinivas | Suresh Srinivas |
+| [HDFS-1217](https://issues.apache.org/jira/browse/HDFS-1217) | Some methods in the NameNdoe should not be public |  Major | namenode | Tsz Wo Nicholas Sze | Laxman |
+| [MAPREDUCE-3989](https://issues.apache.org/jira/browse/MAPREDUCE-3989) | cap space usage of default log4j rolling policy (mr specific changes) |  Major | . | Patrick Hunt | Patrick Hunt |
+| [MAPREDUCE-3922](https://issues.apache.org/jira/browse/MAPREDUCE-3922) | Fix the potential problem compiling 32 bit binaries on a x86\_64 host. |  Minor | build, mrv2 | Eugene Koontz | Hitesh Shah |
+| [MAPREDUCE-3901](https://issues.apache.org/jira/browse/MAPREDUCE-3901) | lazy load JobHistory Task and TaskAttempt details |  Major | jobhistoryserver, mrv2 | Siddharth Seth | Siddharth Seth |
+| [MAPREDUCE-3864](https://issues.apache.org/jira/browse/MAPREDUCE-3864) | Fix cluster setup docs for correct SNN HTTPS parameters |  Minor | documentation, security | Todd Lipcon | Todd Lipcon |
+| [MAPREDUCE-3849](https://issues.apache.org/jira/browse/MAPREDUCE-3849) | Change TokenCache's reading of the binary token file |  Major | security | Daryn Sharp | Daryn Sharp |
+| [MAPREDUCE-3730](https://issues.apache.org/jira/browse/MAPREDUCE-3730) | Allow restarted NM to rejoin cluster before RM expires it |  Minor | mrv2, resourcemanager | Jason Lowe | Jason Lowe |
+
+
+### BUG FIXES:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-8176](https://issues.apache.org/jira/browse/HADOOP-8176) | Disambiguate the destination of FsShell copies |  Major | fs | Daryn Sharp | Daryn Sharp |
+| [HADOOP-8146](https://issues.apache.org/jira/browse/HADOOP-8146) | FsShell commands cannot be interrupted |  Major | fs | Daryn Sharp | Daryn Sharp |
+| [HADOOP-8140](https://issues.apache.org/jira/browse/HADOOP-8140) | dfs -getmerge  should process its argments better |  Major | . | arkady borkovsky | Daryn Sharp |
+| [HADOOP-8137](https://issues.apache.org/jira/browse/HADOOP-8137) | Site side links for commands manual (MAPREDUCE-3497) |  Major | documentation | Vinod Kumar Vavilapalli | Thomas Graves |
+| [HADOOP-8123](https://issues.apache.org/jira/browse/HADOOP-8123) | hadoop-project invalid pom warnings prevent transitive dependency resolution |  Critical | build | Jonathan Eagles | Jonathan Eagles |
+| [HADOOP-8083](https://issues.apache.org/jira/browse/HADOOP-8083) | javadoc generation for some modules is not done under target/ |  Major | build | Alejandro Abdelnur | Alejandro Abdelnur |
+| [HADOOP-8082](https://issues.apache.org/jira/browse/HADOOP-8082) | add hadoop-client and hadoop-minicluster to the dependency-management section |  Major | build | Alejandro Abdelnur | Alejandro Abdelnur |
+| [HADOOP-8074](https://issues.apache.org/jira/browse/HADOOP-8074) | Small bug in hadoop error message for unknown commands |  Trivial | scripts | Eli Collins | Colin Patrick McCabe |
+| [HADOOP-8066](https://issues.apache.org/jira/browse/HADOOP-8066) | The full docs build intermittently fails |  Major | build | Aaron T. Myers | Andrew Bayer |
+| [HADOOP-8064](https://issues.apache.org/jira/browse/HADOOP-8064) | Remove unnecessary dependency on w3c.org in document processing |  Major | build | Kihwal Lee | Kihwal Lee |
+| [HADOOP-8057](https://issues.apache.org/jira/browse/HADOOP-8057) | hadoop-setup-conf.sh not working because of some extra spaces. |  Major | scripts | Vinayakumar B | Vinayakumar B |
+| [HADOOP-8051](https://issues.apache.org/jira/browse/HADOOP-8051) | HttpFS documentation it is not wired to the generated site |  Major | documentation | Alejandro Abdelnur | Alejandro Abdelnur |
+| [HADOOP-8050](https://issues.apache.org/jira/browse/HADOOP-8050) | Deadlock in metrics |  Major | metrics | Kihwal Lee | Kihwal Lee |
+| [HADOOP-8046](https://issues.apache.org/jira/browse/HADOOP-8046) | Revert StaticMapping semantics to the existing ones, add DNS mapping diagnostics in progress |  Minor | . | Steve Loughran | Steve Loughran |
+| [HADOOP-8042](https://issues.apache.org/jira/browse/HADOOP-8042) | When copying a file out of HDFS, modifying it, and uploading it back into HDFS, the put fails due to a CRC mismatch |  Critical | fs | Kevin J. Price | Daryn Sharp |
+| [HADOOP-8036](https://issues.apache.org/jira/browse/HADOOP-8036) | TestViewFsTrash assumes the user's home directory is 2 levels deep |  Major | fs, test | Eli Collins | Colin Patrick McCabe |
+| [HADOOP-8035](https://issues.apache.org/jira/browse/HADOOP-8035) | Hadoop Maven site is inefficient and runs phases redundantly |  Minor | build | Andrew Bayer | Andrew Bayer |
+| [HADOOP-7874](https://issues.apache.org/jira/browse/HADOOP-7874) | native libs should be under lib/native/ dir |  Major | build | Alejandro Abdelnur | Alejandro Abdelnur |
+| [HADOOP-7660](https://issues.apache.org/jira/browse/HADOOP-7660) | Maven generated .classpath doesnot includes "target/generated-test-source/java" as source directory. |  Minor | build | Laxman | Laxman |
+| [HADOOP-6502](https://issues.apache.org/jira/browse/HADOOP-6502) | DistributedFileSystem#listStatus is very slow when listing a directory with a size of 1300 |  Critical | util | Hairong Kuang | Sharad Agarwal |
+| [HDFS-3853](https://issues.apache.org/jira/browse/HDFS-3853) | Port MiniDFSCluster enableManagedDfsDirsRedundancy option to branch-2 |  Minor | namenode | Colin Patrick McCabe | Colin Patrick McCabe |
+| [HDFS-3160](https://issues.apache.org/jira/browse/HDFS-3160) | httpfs should exec catalina instead of forking it |  Major | scripts | Roman Shaposhnik | Roman Shaposhnik |
+| [HDFS-3101](https://issues.apache.org/jira/browse/HDFS-3101) | cannot read empty file using webhdfs |  Major | webhdfs | Zhanwei Wang | Tsz Wo Nicholas Sze |
+| [HDFS-3032](https://issues.apache.org/jira/browse/HDFS-3032) | Lease renewer tries forever even if renewal is not possible |  Major | hdfs-client | Kihwal Lee | Kihwal Lee |
+| [HDFS-3012](https://issues.apache.org/jira/browse/HDFS-3012) | Exception while renewing delegation token |  Critical | . | Ramya Sunil | Robert Joseph Evans |
+| [HDFS-3008](https://issues.apache.org/jira/browse/HDFS-3008) | Negative caching of local addrs doesn't work |  Major | hdfs-client | Eli Collins | Eli Collins |
+| [HDFS-3006](https://issues.apache.org/jira/browse/HDFS-3006) | Webhdfs "SETOWNER" call returns incorrect content-type |  Major | webhdfs | bc Wong | Tsz Wo Nicholas Sze |
+| [HDFS-2969](https://issues.apache.org/jira/browse/HDFS-2969) | ExtendedBlock.equals is incorrectly implemented |  Critical | datanode | Todd Lipcon | Todd Lipcon |
+| [HDFS-2950](https://issues.apache.org/jira/browse/HDFS-2950) | Secondary NN HTTPS address should be listed as a NAMESERVICE\_SPECIFIC\_KEY |  Minor | namenode | Todd Lipcon | Todd Lipcon |
+| [HDFS-2944](https://issues.apache.org/jira/browse/HDFS-2944) | Typo in hdfs-default.xml causes dfs.client.block.write.replace-datanode-on-failure.enable to be mistakenly disabled |  Major | hdfs-client | Aaron T. Myers | Aaron T. Myers |
+| [HDFS-2938](https://issues.apache.org/jira/browse/HDFS-2938) | Recursive delete of a large directory makes namenode unresponsive |  Major | namenode | Suresh Srinivas | Hari Mankude |
+| [HDFS-2815](https://issues.apache.org/jira/browse/HDFS-2815) | Namenode is not coming out of safemode when we perform ( NN crash + restart ) .  Also FSCK report shows blocks missed. |  Critical | namenode | Uma Maheswara Rao G | Uma Maheswara Rao G |
+| [HDFS-2764](https://issues.apache.org/jira/browse/HDFS-2764) | TestBackupNode is racy |  Major | namenode, test | Aaron T. Myers | Aaron T. Myers |
+| [HDFS-2725](https://issues.apache.org/jira/browse/HDFS-2725) | hdfs script usage information is missing the information about "dfs" command |  Major | hdfs-client | Prashant Sharma |  |
+| [HDFS-2525](https://issues.apache.org/jira/browse/HDFS-2525) | Race between BlockPoolSliceScanner and append |  Critical | datanode | Todd Lipcon | Brandon Li |
+| [HDFS-776](https://issues.apache.org/jira/browse/HDFS-776) | Fix exception handling in Balancer |  Critical | balancer & mover | Owen O'Malley | Uma Maheswara Rao G |
+| [MAPREDUCE-4061](https://issues.apache.org/jira/browse/MAPREDUCE-4061) | RM only has 1 AM launcher thread |  Blocker | mrv2 | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-4043](https://issues.apache.org/jira/browse/MAPREDUCE-4043) | Secret keys set in Credentials are not seen by tasks |  Blocker | mrv2, security | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-4034](https://issues.apache.org/jira/browse/MAPREDUCE-4034) | Unable to view task logs on history server with mapreduce.job.acl-view-job=\* |  Blocker | mrv2 | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-4025](https://issues.apache.org/jira/browse/MAPREDUCE-4025) | AM can crash if task attempt reports bogus progress value |  Blocker | mr-am, mrv2 | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-4006](https://issues.apache.org/jira/browse/MAPREDUCE-4006) | history server container log web UI sometimes combines stderr/stdout/syslog contents together |  Major | jobhistoryserver, mrv2 | Jason Lowe | Siddharth Seth |
+| [MAPREDUCE-4005](https://issues.apache.org/jira/browse/MAPREDUCE-4005) | AM container logs URL is broken for completed apps when log aggregation is enabled |  Major | mrv2 | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3982](https://issues.apache.org/jira/browse/MAPREDUCE-3982) | TestEmptyJob fails with FileNotFound |  Critical | mrv2 | Robert Joseph Evans | Robert Joseph Evans |
+| [MAPREDUCE-3977](https://issues.apache.org/jira/browse/MAPREDUCE-3977) | LogAggregationService leaks log aggregator objects |  Critical | mrv2, nodemanager | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3976](https://issues.apache.org/jira/browse/MAPREDUCE-3976) | TestRMContainerAllocator failing |  Major | mrv2 | Bikas Saha | Jason Lowe |
+| [MAPREDUCE-3975](https://issues.apache.org/jira/browse/MAPREDUCE-3975) | Default value not set for Configuration parameter mapreduce.job.local.dir |  Blocker | mrv2 | Eric Payne | Eric Payne |
+| [MAPREDUCE-3964](https://issues.apache.org/jira/browse/MAPREDUCE-3964) | ResourceManager does not have JVM metrics |  Critical | mrv2, resourcemanager | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3961](https://issues.apache.org/jira/browse/MAPREDUCE-3961) | Map/ReduceSlotMillis computation incorrect |  Major | mrv2 | Siddharth Seth | Siddharth Seth |
+| [MAPREDUCE-3960](https://issues.apache.org/jira/browse/MAPREDUCE-3960) | web proxy doesn't forward request to AM with configured hostname/IP |  Critical | mrv2 | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-3954](https://issues.apache.org/jira/browse/MAPREDUCE-3954) | Clean up passing HEAPSIZE to yarn and mapred commands. |  Blocker | mrv2 | Robert Joseph Evans | Robert Joseph Evans |
+| [MAPREDUCE-3931](https://issues.apache.org/jira/browse/MAPREDUCE-3931) | MR tasks failing due to changing timestamps on Resources to download |  Major | mrv2 | Vinod Kumar Vavilapalli | Siddharth Seth |
+| [MAPREDUCE-3930](https://issues.apache.org/jira/browse/MAPREDUCE-3930) | The AM page for a Reducer that has not been launched causes an NPE |  Critical | mrv2 | Robert Joseph Evans | Robert Joseph Evans |
+| [MAPREDUCE-3929](https://issues.apache.org/jira/browse/MAPREDUCE-3929) | output of mapred -showacl is not clear |  Major | mrv2 | John George | John George |
+| [MAPREDUCE-3920](https://issues.apache.org/jira/browse/MAPREDUCE-3920) | Revise yarn default port number selection |  Major | nodemanager, resourcemanager | Dave Thompson | Dave Thompson |
+| [MAPREDUCE-3918](https://issues.apache.org/jira/browse/MAPREDUCE-3918) | proc\_historyserver no longer in command line arguments for HistoryServer |  Major | mrv2 | Jonathan Eagles | Jonathan Eagles |
+| [MAPREDUCE-3913](https://issues.apache.org/jira/browse/MAPREDUCE-3913) | RM application webpage is unresponsive after 2000 jobs |  Critical | mrv2, webapps | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3910](https://issues.apache.org/jira/browse/MAPREDUCE-3910) | user not allowed to submit jobs even though queue -showacls shows it allows |  Blocker | mrv2 | John George | John George |
+| [MAPREDUCE-3904](https://issues.apache.org/jira/browse/MAPREDUCE-3904) | [NPE] Job history produced with mapreduce.cluster.acls.enabled false can not be viewed with mapreduce.cluster.acls.enabled true |  Major | mrv2 | Jonathan Eagles | Jonathan Eagles |
+| [MAPREDUCE-3903](https://issues.apache.org/jira/browse/MAPREDUCE-3903) | no admin override to view jobs on mr app master and job history server |  Critical | mrv2 | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-3897](https://issues.apache.org/jira/browse/MAPREDUCE-3897) | capacity scheduler - maxActiveApplicationsPerUser calculation can be wrong |  Critical | mrv2 | Thomas Graves | Eric Payne |
+| [MAPREDUCE-3896](https://issues.apache.org/jira/browse/MAPREDUCE-3896) | pig job through oozie hangs |  Blocker | jobhistoryserver, mrv2 | John George | Vinod Kumar Vavilapalli |
+| [MAPREDUCE-3884](https://issues.apache.org/jira/browse/MAPREDUCE-3884) | PWD should be first in the classpath of MR tasks |  Critical | mrv2 | Alejandro Abdelnur | Alejandro Abdelnur |
+| [MAPREDUCE-3878](https://issues.apache.org/jira/browse/MAPREDUCE-3878) | Null user on filtered jobhistory job page |  Critical | mrv2 | Jonathan Eagles | Jonathan Eagles |
+| [MAPREDUCE-3866](https://issues.apache.org/jira/browse/MAPREDUCE-3866) | bin/yarn prints the command line unnecessarily |  Minor | mrv2 | Vinod Kumar Vavilapalli | Vinod Kumar Vavilapalli |
+| [MAPREDUCE-3862](https://issues.apache.org/jira/browse/MAPREDUCE-3862) | Nodemanager can appear to hang on shutdown due to lingering DeletionService threads |  Major | mrv2, nodemanager | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3852](https://issues.apache.org/jira/browse/MAPREDUCE-3852) | test TestLinuxResourceCalculatorPlugin failing |  Blocker | mrv2 | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-3816](https://issues.apache.org/jira/browse/MAPREDUCE-3816) | capacity scheduler web ui bar graphs for used capacity wrong |  Critical | mrv2 | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-3792](https://issues.apache.org/jira/browse/MAPREDUCE-3792) | job -list displays only the jobs submitted by a particular user |  Critical | mrv2 | Ramya Sunil | Jason Lowe |
+| [MAPREDUCE-3790](https://issues.apache.org/jira/browse/MAPREDUCE-3790) | Broken pipe on streaming job can lead to truncated output for a successful job |  Major | contrib/streaming, mrv2 | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3738](https://issues.apache.org/jira/browse/MAPREDUCE-3738) | NM can hang during shutdown if AppLogAggregatorImpl thread dies unexpectedly |  Critical | mrv2, nodemanager | Jason Lowe | Jason Lowe |
+| [MAPREDUCE-3706](https://issues.apache.org/jira/browse/MAPREDUCE-3706) | HTTP Circular redirect error on the job attempts page |  Critical | mrv2 | Thomas Graves | Robert Joseph Evans |
+| [MAPREDUCE-3687](https://issues.apache.org/jira/browse/MAPREDUCE-3687) | If AM dies before it returns new tracking URL, proxy redirects to http://N/A/ and doesn't return error code |  Major | mrv2 | David Capwell | Ravi Prakash |
+| [MAPREDUCE-3686](https://issues.apache.org/jira/browse/MAPREDUCE-3686) | history server web ui - job counter values for map/reduce not shown properly |  Critical | mrv2 | Thomas Graves | Bhallamudi Venkata Siva Kamesh |
+| [MAPREDUCE-3680](https://issues.apache.org/jira/browse/MAPREDUCE-3680) | FifoScheduler web service rest API can print out invalid JSON |  Major | mrv2 | Thomas Graves |  |
+| [MAPREDUCE-3634](https://issues.apache.org/jira/browse/MAPREDUCE-3634) | All daemons should crash instead of hanging around when their EventHandlers get exceptions |  Major | mrv2 | Vinod Kumar Vavilapalli | Vinod Kumar Vavilapalli |
+| [MAPREDUCE-3614](https://issues.apache.org/jira/browse/MAPREDUCE-3614) |  finalState UNDEFINED if AM is killed by hand |  Major | mrv2 | Ravi Prakash | Ravi Prakash |
+| [MAPREDUCE-3583](https://issues.apache.org/jira/browse/MAPREDUCE-3583) | ProcfsBasedProcessTree#constructProcessInfo() may throw NumberFormatException |  Critical | . | Ted Yu | Ted Yu |
+| [MAPREDUCE-3497](https://issues.apache.org/jira/browse/MAPREDUCE-3497) | missing documentation for yarn cli and subcommands - similar to commands\_manual.html |  Major | documentation, mrv2 | Thomas Graves | Thomas Graves |
+| [MAPREDUCE-3034](https://issues.apache.org/jira/browse/MAPREDUCE-3034) | NM should act on a REBOOT command from RM |  Critical | mrv2, nodemanager | Vinod Kumar Vavilapalli | Devaraj K |
+| [MAPREDUCE-3009](https://issues.apache.org/jira/browse/MAPREDUCE-3009) | RM UI -\> Applications -\> Application(Job History) -\> Map Tasks -\> Task ID -\> Node link is not working |  Major | jobhistoryserver, mrv2 | chackaravarthy | chackaravarthy |
+| [MAPREDUCE-2855](https://issues.apache.org/jira/browse/MAPREDUCE-2855) | ResourceBundle lookup during counter name resolution takes a lot of time |  Major | . | Todd Lipcon | Siddharth Seth |
+| [MAPREDUCE-2793](https://issues.apache.org/jira/browse/MAPREDUCE-2793) | [MR-279] Maintain consistency in naming appIDs, jobIDs and attemptIDs |  Critical | mrv2 | Ramya Sunil | Bikas Saha |
+
+
+### TESTS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HDFS-3104](https://issues.apache.org/jira/browse/HDFS-3104) | Add tests for mkdir -p |  Major | test | Daryn Sharp | Daryn Sharp |
+| [HDFS-3098](https://issues.apache.org/jira/browse/HDFS-3098) | Update FsShell tests for quoted metachars |  Major | test | Daryn Sharp | Daryn Sharp |
+| [HDFS-3060](https://issues.apache.org/jira/browse/HDFS-3060) | Bump TestDistributedUpgrade#testDistributedUpgrade timeout |  Minor | test | Eli Collins | Eli Collins |
+| [HDFS-2038](https://issues.apache.org/jira/browse/HDFS-2038) | Update test to handle relative paths with globs |  Critical | test | Daryn Sharp | Kihwal Lee |
+| [MAPREDUCE-3877](https://issues.apache.org/jira/browse/MAPREDUCE-3877) | Add a test to formalise the current state transitions of the yarn lifecycle |  Minor | mrv2 | Steve Loughran | Steve Loughran |
+| [MAPREDUCE-3798](https://issues.apache.org/jira/browse/MAPREDUCE-3798) | TestJobCleanup testCustomCleanup is failing |  Major | test | Ravi Prakash | Ravi Prakash |
+
+
+### SUB-TASKS:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-8175](https://issues.apache.org/jira/browse/HADOOP-8175) | Add mkdir -p flag |  Major | fs | Daryn Sharp | Daryn Sharp |
+| [HADOOP-8173](https://issues.apache.org/jira/browse/HADOOP-8173) | FsShell needs to handle quoted metachars |  Major | fs | Daryn Sharp | Daryn Sharp |
+| [MAPREDUCE-3944](https://issues.apache.org/jira/browse/MAPREDUCE-3944) | JobHistory web services are slower then the UI and can easly overload the JH |  Blocker | mrv2 | Robert Joseph Evans | Robert Joseph Evans |
+
+
+### OTHER:
+
+| JIRA | Summary | Priority | Component | Reporter | Contributor |
+|:---- |:---- | :--- |:---- |:---- |:---- |
+| [HADOOP-8032](https://issues.apache.org/jira/browse/HADOOP-8032) | mvn site:stage-deploy should be able to use the scp protocol to stage documents |  Major | build, documentation | Ravi Prakash | Ravi Prakash |
+| [HDFS-2931](https://issues.apache.org/jira/browse/HDFS-2931) | Switch the DataNode's BlockVolumeChoosingPolicy to be a private-audience interface |  Minor | datanode | Harsh J | Harsh J |
+
+

http://git-wip-us.apache.org/repos/asf/hadoop/blob/140a33df/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/RELEASENOTES.0.23.2.md
----------------------------------------------------------------------
diff --git a/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/RELEASENOTES.0.23.2.md b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/RELEASENOTES.0.23.2.md
new file mode 100644
index 0000000..6591565
--- /dev/null
+++ b/hadoop-common-project/hadoop-common/src/site/markdown/release/0.23.2/RELEASENOTES.0.23.2.md
@@ -0,0 +1,199 @@
+
+<!---
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+-->
+# Apache Hadoop  0.23.2 Release Notes
+
+These release notes cover new developer and user-facing incompatibilities, features, and major improvements.
+
+
+---
+
+* [HADOOP-8175](https://issues.apache.org/jira/browse/HADOOP-8175) | *Major* | **Add mkdir -p flag**
+
+FsShell mkdir now accepts a -p flag.  Like unix, mkdir -p will not fail if the directory already exists.  Unlike unix, intermediate directories are always created, regardless of the flag, to avoid incompatibilities at this time.
+
+
+---
+
+* [HADOOP-8164](https://issues.apache.org/jira/browse/HADOOP-8164) | *Major* | **Handle paths using back slash as path separator for windows only**
+
+This jira only allows providing paths using back slash as separator on Windows. The back slash on *nix system will be used as escape character. The support for paths using back slash as path separator will be removed in HADOOP-8139 in release 23.3.
+
+
+---
+
+* [HADOOP-8131](https://issues.apache.org/jira/browse/HADOOP-8131) | *Critical* | **FsShell put doesn't correctly handle a non-existent dir**
+
+**WARNING: No release note provided for this incompatible change.**
+
+
+---
+
+* [HDFS-2950](https://issues.apache.org/jira/browse/HDFS-2950) | *Minor* | **Secondary NN HTTPS address should be listed as a NAMESERVICE\_SPECIFIC\_KEY**
+
+The configuration dfs.secondary.https.port has been renamed to dfs.namenode.secondary.https-port for consistency. The old configuration is still supported via a deprecation path.
+
+
+---
+
+* [HDFS-2907](https://issues.apache.org/jira/browse/HDFS-2907) | *Minor* | **Make FSDataset in Datanode Pluggable**
+
+Add a private conf property dfs.datanode.fsdataset.factory to make FSDataset in Datanode pluggable.
+
+
+---
+
+* [HDFS-2887](https://issues.apache.org/jira/browse/HDFS-2887) | *Major* | **Define a FSVolume interface**
+
+FSVolume, is a part of FSDatasetInterface implementation, should not be referred outside FSDataset.  A new FSVolumeInterface is defined.  The BlockVolumeChoosingPolicy.chooseVolume(..) method signature is also updated.
+
+
+---
+
+* [MAPREDUCE-3982](https://issues.apache.org/jira/browse/MAPREDUCE-3982) | *Critical* | **TestEmptyJob fails with FileNotFound**
+
+Fixed FileOutputCommitter to not err out for an 'empty-job' whose tasks don't write any outputs.
+
+
+---
+
+* [MAPREDUCE-3975](https://issues.apache.org/jira/browse/MAPREDUCE-3975) | *Blocker* | **Default value not set for Configuration parameter mapreduce.job.local.dir**
+
+Exporting mapreduce.job.local.dir for mapreduce tasks to use as job-level shared scratch space.
+
+
+---
+
+* [MAPREDUCE-3954](https://issues.apache.org/jira/browse/MAPREDUCE-3954) | *Blocker* | **Clean up passing HEAPSIZE to yarn and mapred commands.**
+
+Added new envs to separate heap size for different daemons started via bin scripts.
+
+
+---
+
+* [MAPREDUCE-3931](https://issues.apache.org/jira/browse/MAPREDUCE-3931) | *Major* | **MR tasks failing due to changing timestamps on Resources to download**
+
+Changed PB implementation of LocalResource to take locks so that race conditions don't fail tasks by inadvertantly changing the timestamps.
+
+
+---
+
+* [MAPREDUCE-3922](https://issues.apache.org/jira/browse/MAPREDUCE-3922) | *Minor* | **Fix the potential problem compiling 32 bit binaries on a x86\_64 host.**
+
+Fixed build to not compile 32bit container-executor binary by default on all platforms.
+
+
+---
+
+* [MAPREDUCE-3920](https://issues.apache.org/jira/browse/MAPREDUCE-3920) | *Major* | **Revise yarn default port number selection**
+
+port number changes for resourcemanager and nodemanager
+
+
+---
+
+* [MAPREDUCE-3910](https://issues.apache.org/jira/browse/MAPREDUCE-3910) | *Blocker* | **user not allowed to submit jobs even though queue -showacls shows it allows**
+
+Fixed a bug in CapacityScheduler LeafQueue which was causing app-submission to fail.
+
+
+---
+
+* [MAPREDUCE-3901](https://issues.apache.org/jira/browse/MAPREDUCE-3901) | *Major* | **lazy load JobHistory Task and TaskAttempt details**
+
+Modified JobHistory records in YARN to lazily load job and task reports so as to improve UI response times.
+
+
+---
+
+* [MAPREDUCE-3866](https://issues.apache.org/jira/browse/MAPREDUCE-3866) | *Minor* | **bin/yarn prints the command line unnecessarily**
+
+Fixed the bin/yarn script to not print the command line unnecessarily.
+
+
+---
+
+* [MAPREDUCE-3798](https://issues.apache.org/jira/browse/MAPREDUCE-3798) | *Major* | **TestJobCleanup testCustomCleanup is failing**
+
+Fixed failing TestJobCleanup.testCusomCleanup() and moved it to the maven build.
+
+
+---
+
+* [MAPREDUCE-3792](https://issues.apache.org/jira/browse/MAPREDUCE-3792) | *Critical* | **job -list displays only the jobs submitted by a particular user**
+
+Fix "bin/mapred job -list" to display all jobs instead of only the jobs owned by the user.
+
+
+---
+
+* [MAPREDUCE-3738](https://issues.apache.org/jira/browse/MAPREDUCE-3738) | *Critical* | **NM can hang during shutdown if AppLogAggregatorImpl thread dies unexpectedly**
+
+Committed to trunk and branch-0.23. Thanks Jason.
+
+
+---
+
+* [MAPREDUCE-3730](https://issues.apache.org/jira/browse/MAPREDUCE-3730) | *Minor* | **Allow restarted NM to rejoin cluster before RM expires it**
+
+Modified RM to allow restarted NMs to be able to join the cluster without waiting for expiry.
+
+
+---
+
+* [MAPREDUCE-3686](https://issues.apache.org/jira/browse/MAPREDUCE-3686) | *Critical* | **history server web ui - job counter values for map/reduce not shown properly**
+
+Fixed two bugs in Counters because of which web app displays zero counter values for framework counters.
+
+
+---
+
+* [MAPREDUCE-3634](https://issues.apache.org/jira/browse/MAPREDUCE-3634) | *Major* | **All daemons should crash instead of hanging around when their EventHandlers get exceptions**
+
+Fixed all daemons to crash instead of hanging around when their EventHandlers get exceptions.
+
+
+---
+
+* [MAPREDUCE-3614](https://issues.apache.org/jira/browse/MAPREDUCE-3614) | *Major* | ** finalState UNDEFINED if AM is killed by hand**
+
+Fixed MR AM to close history file quickly and send a correct final state to the RM when it is killed.
+
+
+---
+
+* [MAPREDUCE-3009](https://issues.apache.org/jira/browse/MAPREDUCE-3009) | *Major* | **RM UI -\> Applications -\> Application(Job History) -\> Map Tasks -\> Task ID -\> Node link is not working**
+
+Fixed node link on JobHistory webapp.
+
+
+---
+
+* [MAPREDUCE-2855](https://issues.apache.org/jira/browse/MAPREDUCE-2855) | *Major* | **ResourceBundle lookup during counter name resolution takes a lot of time**
+
+Passing a cached class-loader to ResourceBundle creator to minimize counter names lookup time.
+
+
+---
+
+* [MAPREDUCE-2793](https://issues.apache.org/jira/browse/MAPREDUCE-2793) | *Critical* | **[MR-279] Maintain consistency in naming appIDs, jobIDs and attemptIDs**
+
+Corrected AppIDs, JobIDs, TaskAttemptIDs to be of correct format on the web pages.
+
+
+