You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by rl...@apache.org on 2017/06/22 14:38:06 UTC

[01/11] ambari git commit: AMBARI-21135: Kafka service fails to start during EU from HDF 202 to 30 while resolving /etc/kafka/conf (jluniya)

Repository: ambari
Updated Branches:
  refs/heads/branch-feature-AMBARI-20859 8f03fd044 -> b5333870a


AMBARI-21135: Kafka service fails to start during EU from HDF 202 to 30 while resolving /etc/kafka/conf (jluniya)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/23760e71
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/23760e71
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/23760e71

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 23760e71a573da20d83e026d4a2e46177cada15b
Parents: e7fc3a6
Author: Jayush Luniya <jl...@hortonworks.com>
Authored: Wed Jun 21 12:17:13 2017 -0700
Committer: Jayush Luniya <jl...@hortonworks.com>
Committed: Wed Jun 21 12:17:13 2017 -0700

----------------------------------------------------------------------
 .../main/resources/custom_actions/scripts/install_packages.py  | 6 ++++++
 1 file changed, 6 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/23760e71/ambari-server/src/main/resources/custom_actions/scripts/install_packages.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/custom_actions/scripts/install_packages.py b/ambari-server/src/main/resources/custom_actions/scripts/install_packages.py
index a4a7a8c..eb3fb5d 100644
--- a/ambari-server/src/main/resources/custom_actions/scripts/install_packages.py
+++ b/ambari-server/src/main/resources/custom_actions/scripts/install_packages.py
@@ -36,6 +36,7 @@ from resource_management.libraries.functions.stack_select import get_stack_versi
 from resource_management.libraries.functions.version import format_stack_version
 from resource_management.libraries.functions.repo_version_history \
     import read_actual_version_from_history_file, write_actual_version_to_history_file, REPO_VERSION_HISTORY_FILE
+from resource_management.core.resources.system import Link
 from resource_management.libraries.functions import StackFeature
 from resource_management.libraries.functions import packages_analyzer
 from resource_management.libraries.functions.repository_util import create_repo_files, CommandRepository
@@ -198,6 +199,11 @@ class InstallPackages(Script):
       Logger.info("Configuration symlinks are not needed for {0}".format(stack_version))
       return
 
+    # After upgrading hdf-select package from HDF-2.X to HDF-3.Y, we need to create this symlink
+    if self.stack_name.upper() == "HDF" \
+            and not os.path.exists("/usr/bin/conf-select") and os.path.exists("/usr/bin/hdfconf-select"):
+      Link("/usr/bin/conf-select", to = "/usr/bin/hdfconf-select")
+
     for package_name, directories in conf_select.get_package_dirs().iteritems():
       conf_selector_name = stack_tools.get_stack_tool_name(stack_tools.CONF_SELECTOR_NAME)
       Logger.info("The current cluster stack of {0} does not require backing up configurations; "


[03/11] ambari git commit: AMBARI-21252.Namenode variable should be auto populated for FS action node(Venkata Sairam)

Posted by rl...@apache.org.
AMBARI-21252.Namenode variable should be auto populated for FS action node(Venkata Sairam)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/1f70d062
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/1f70d062
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/1f70d062

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 1f70d06277cb68a87ef861e48f7f2d0b0bbf7e03
Parents: 6cda103
Author: Venkata Sairam <ve...@gmail.com>
Authored: Thu Jun 22 09:21:36 2017 +0530
Committer: Venkata Sairam <ve...@gmail.com>
Committed: Thu Jun 22 09:21:36 2017 +0530

----------------------------------------------------------------------
 .../views/wfmanager/src/main/resources/ui/app/utils/constants.js    | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/1f70d062/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js b/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
index bf858d8..3989fc2 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
@@ -45,6 +45,7 @@ export default Ember.Object.create({
     {name : "map-reduce",supportsSchema : false, currentVersion:''},
     {name : "sub-workflow",supportsSchema : false, currentVersion:''},
     {name : "distcp",supportsSchema : true, currentVersion:''},
+    {name : "fs",supportsSchema : true, currentVersion:''},
     {name : "ssh",supportsSchema : false, currentVersion:''},
     {name : "email",supportsSchema : true, currentVersion:''}
   ]),


[07/11] ambari git commit: AMBARI-21293. Allow skipping Swagger generation

Posted by rl...@apache.org.
AMBARI-21293. Allow skipping Swagger generation


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/e0d5f409
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/e0d5f409
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/e0d5f409

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: e0d5f40942575b14a3e70aec1f8c09290f86ee21
Parents: b53cf91
Author: Attila Doroszlai <ad...@hortonworks.com>
Authored: Wed Jun 21 11:15:59 2017 +0200
Committer: Attila Doroszlai <ad...@hortonworks.com>
Committed: Thu Jun 22 08:24:14 2017 +0200

----------------------------------------------------------------------
 ambari-server/pom.xml | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/e0d5f409/ambari-server/pom.xml
----------------------------------------------------------------------
diff --git a/ambari-server/pom.xml b/ambari-server/pom.xml
index 1ada974..4b75d9b 100644
--- a/ambari-server/pom.xml
+++ b/ambari-server/pom.xml
@@ -438,6 +438,7 @@
               <swaggerDirectory>${swagger.generated.resources.dir}</swaggerDirectory>
             </apiSource>
           </apiSources>
+          <skipSwaggerGeneration>${swagger.skip}</skipSwaggerGeneration>
         </configuration>
         <executions>
           <execution>


[05/11] ambari git commit: AMBARI-21255.Remove YARN client mode option from WFM(Venkata Sairam)

Posted by rl...@apache.org.
AMBARI-21255.Remove YARN client mode option from WFM(Venkata Sairam)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/7335bf7e
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/7335bf7e
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/7335bf7e

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 7335bf7e2e08da032524009ce3ad2a6b1c2430aa
Parents: 9c69322
Author: Venkata Sairam <ve...@gmail.com>
Authored: Thu Jun 22 09:29:01 2017 +0530
Committer: Venkata Sairam <ve...@gmail.com>
Committed: Thu Jun 22 09:29:01 2017 +0530

----------------------------------------------------------------------
 .../ui/app/components/flow-designer.js          | 27 ++++++++++++++++++++
 .../ui/app/domain/actionjob_hanlder.js          |  3 +++
 .../app/templates/components/flow-designer.hbs  |  9 ++++++-
 .../app/templates/components/spark-action.hbs   |  7 ++++-
 .../main/resources/ui/app/utils/constants.js    |  2 +-
 5 files changed, 45 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/7335bf7e/contrib/views/wfmanager/src/main/resources/ui/app/components/flow-designer.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/components/flow-designer.js b/contrib/views/wfmanager/src/main/resources/ui/app/components/flow-designer.js
index 1cfe755..2c77b5b 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/components/flow-designer.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/components/flow-designer.js
@@ -364,6 +364,8 @@ export default Ember.Component.extend(FindNodeMixin, Validations, {
     });
   },
   importWorkflowFromString(data){
+    this.showSparkMasterFieldError(data);
+
     var wfObject=this.get("workflowImporter").importWorkflow(data);
     this.set("errors", wfObject.errors);
     if (wfObject.workflow === null) {
@@ -385,6 +387,7 @@ export default Ember.Component.extend(FindNodeMixin, Validations, {
     }
   },
   importWorkflowFromJSON(data){
+    this.showSparkMasterFieldError(data);
     var workflowImporter=WorkflowJsonImporter.create({});
     var workflow=workflowImporter.importWorkflow(data);
     this.resetDesigner();
@@ -393,6 +396,27 @@ export default Ember.Component.extend(FindNodeMixin, Validations, {
     this.rerender();
     this.doValidation();
   },
+  migrateActionObjectToCollection(data) {
+    if(Ember.isArray(data)) {
+      return data;
+    } else {
+      let ArrayData = [];
+      ArrayData.push(data);
+      return ArrayData;
+    }
+  },
+  showSparkMasterFieldError(data) {
+    let x2js = new X2JS();
+    let actionSettingsObj = x2js.xml_str2json(data);
+    let sparkActionList, sparkActionArray = [];
+    if(actionSettingsObj["workflow-app"] && actionSettingsObj["workflow-app"].action) {
+      sparkActionList = actionSettingsObj["workflow-app"].action;
+      sparkActionArray = this.migrateActionObjectToCollection(sparkActionList);
+      if(sparkActionArray.findBy('spark') && this.migrateActionObjectToCollection(sparkActionArray.findBy('spark')).find(function(item){return item.spark.master === "yarn-client"})) {
+        this.set('isSparkUnSupportedPropsAvailable', true);
+      }
+    }
+  },
   getWorkflowFromHdfs(filePath){
     var url = Ember.ENV.API_URL + "/readWorkflow?workflowPath="+filePath+'&jobType=WORKFLOW';
     var deferred = Ember.RSVP.defer();
@@ -1234,6 +1258,9 @@ export default Ember.Component.extend(FindNodeMixin, Validations, {
         self.set("data", data);
         self.set("isAssetImporting", false);
       });
+    },
+    closeInfo(flag) {
+      this.set(flag, false);
     }
   }
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/7335bf7e/contrib/views/wfmanager/src/main/resources/ui/app/domain/actionjob_hanlder.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/domain/actionjob_hanlder.js b/contrib/views/wfmanager/src/main/resources/ui/app/domain/actionjob_hanlder.js
index c9dc751..9bc19ba 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/domain/actionjob_hanlder.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/domain/actionjob_hanlder.js
@@ -243,6 +243,9 @@ var SparkActionJobHandler=ActionJobHandler.extend({
     ];
   },
   handleImport(actionNode,json){
+    if(json.master === "yarn-client") {
+           json.master = "yarn-cluster";
+         }
     this._super(actionNode,json);
   }
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/7335bf7e/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/flow-designer.hbs
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/flow-designer.hbs b/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/flow-designer.hbs
index 8c07d6d..a02db63 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/flow-designer.hbs
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/flow-designer.hbs
@@ -138,7 +138,14 @@
   {{/if}}
   <div  id="content" class="panel panel-default designer-main-panel col-xs-20">
     <div class="designer-panel designer-canvas">
-      {{designer-errors errors=errors validationErrors=validationErrors errorMsg=errorMsg data=data}}
+        {{designer-errors errors=errors validationErrors=validationErrors errorMsg=errorMsg data=data}}
+        {{#if isSparkUnSupportedPropsAvailable}}
+            <div class="alert alert-warning">
+                <a href="#" class="close" {{action "closeInfo" "isSparkUnSupportedPropsAvailable"}}> × </a>
+                Spark does not support YARN Client mode.Hence, YARN Client mode value will changed in xml while importing.
+            </div>
+        {{/if}}
+
       {{#if undoAvailable}}
         <div id="alert"class="alert alert-warning workflow-error" role="alert">
           {{#if (eq undoType 'nodeDeleted')}}

http://git-wip-us.apache.org/repos/asf/ambari/blob/7335bf7e/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/spark-action.hbs
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/spark-action.hbs b/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/spark-action.hbs
index de62e77..c8f14d3 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/spark-action.hbs
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/spark-action.hbs
@@ -63,8 +63,13 @@
           <input type=text placeholder="Custom" disabled={{disableCustomMaster}} value={{customMaster}} onchange={{action (mut actionModel.master) value="target.value"}}>
         </div>
       </div>
-      {{field-error model=this field='actionModel.master' showErrorMessage=showErrorMessage}}
     </div>
+      <div class="form-group">
+          <label for="inputEmail" class="control-label col-xs-2"></label>
+          <div class="col-xs-10">
+              {{field-error model=this field='actionModel.master' showErrorMessage=showErrorMessage}}
+          </div>
+      </div>
     <div class="form-group">
       <label for="inputEmail" class="control-label col-xs-2">Spark Options</label>
       <div class="col-xs-7">

http://git-wip-us.apache.org/repos/asf/ambari/blob/7335bf7e/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js b/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
index 3989fc2..ffdbdc0 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/utils/constants.js
@@ -50,7 +50,7 @@ export default Ember.Object.create({
     {name : "email",supportsSchema : true, currentVersion:''}
   ]),
   sparkMasterList :Ember.A([{value:'yarn-cluster',displayName:'Yarn Cluster'},
-                            {value:'yarn-client',displayName:'Yarn Client'},
+                            /*{value:'yarn-client',displayName:'Yarn Client'},*/
                             {value:'local',displayName:'Local'}]),
   timezoneList : Ember.A([
     {displayName:'UTC',gmtOffset:0, value:'UTC'},


[08/11] ambari git commit: AMBARI-21295. Enable Swagger checkstyle rule for endpoints documented so far

Posted by rl...@apache.org.
http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/RemoteClustersService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RemoteClustersService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RemoteClustersService.java
index 2921cc4..93cfc47 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RemoteClustersService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RemoteClustersService.java
@@ -32,10 +32,10 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
-
 /**
  * Service responsible for Remote Cluster resource requests.
  */
@@ -48,13 +48,12 @@ public class RemoteClustersService extends BaseService {
    * @param ui
    * @return collections of all remote clusters
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getRemoteClusters(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createRemoteClusterResource(null));
   }
 
-
   /**
    * Create a new RemoteAmbariCluster
    * @param body
@@ -63,7 +62,7 @@ public class RemoteClustersService extends BaseService {
    * @param clusterName
    * @return
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{clusterName}")
   @Produces("text/plain")
   public Response createRemoteCluster(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -71,7 +70,6 @@ public class RemoteClustersService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.POST, createRemoteClusterResource(clusterName));
   }
 
-
   /**
    * Update a Remote Cluster
    * @param body
@@ -80,7 +78,7 @@ public class RemoteClustersService extends BaseService {
    * @param clusterName
    * @return
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{clusterName}")
   @Produces("text/plain")
   public Response updateRemoteCluster(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -96,7 +94,7 @@ public class RemoteClustersService extends BaseService {
    * @param clusterName
    * @return
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{clusterName}")
   @Produces("text/plain")
   public Response deleteRemoteCluster(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -104,7 +102,6 @@ public class RemoteClustersService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.DELETE, createRemoteClusterResource(clusterName));
   }
 
-
   /**
    * Get information about a Remote Cluster
    * @param headers
@@ -112,7 +109,7 @@ public class RemoteClustersService extends BaseService {
    * @param clusterName
    * @return
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{clusterName}")
   @Produces("text/plain")
   public Response getRemoteCluster(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -120,9 +117,6 @@ public class RemoteClustersService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.GET, createRemoteClusterResource(clusterName));
   }
 
-
-
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryService.java
index 4dc07f3..467cee0 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -61,7 +62,7 @@ public class RepositoryService extends BaseService {
    * @param headers http headers
    * @param ui      uri info
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createRepository(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST, createResource(null));
@@ -76,7 +77,7 @@ public class RepositoryService extends BaseService {
    * @param repoId  repository id
    * @param ui      uri info
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{repoId}")
   @Produces("text/plain")
   public Response createRepository(String body, @Context HttpHeaders headers, @Context UriInfo ui, @PathParam("repoId") String repoId) {
@@ -90,7 +91,7 @@ public class RepositoryService extends BaseService {
    * @param headers http headers
    * @param ui      uri info
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getRepositories(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(null));
@@ -105,7 +106,7 @@ public class RepositoryService extends BaseService {
    * @param repoId  repository id
    * @return information regarding the specified repository
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{repoId}")
   @Produces("text/plain")
   public Response getRepository(@Context HttpHeaders headers, @Context UriInfo ui, @PathParam("repoId") String repoId) {
@@ -121,7 +122,7 @@ public class RepositoryService extends BaseService {
    * @param repoId  repository id
    * @return information regarding the specified repository
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{repoId}")
   @Produces("text/plain")
   public Response updateRepository(String body, @Context HttpHeaders headers, @Context UriInfo ui, @PathParam("repoId") String repoId) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryVersionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryVersionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryVersionService.java
index c6d8935..c282b7b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryVersionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RepositoryVersionService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -61,7 +62,7 @@ public class RepositoryVersionService extends BaseService {
    * @param headers http headers
    * @param ui      uri info
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getRepositoryVersions(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(null));
@@ -76,7 +77,7 @@ public class RepositoryVersionService extends BaseService {
    * @param repositoryVersionId   the repository version id
    * @return information regarding the specified repository
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{repositoryVersionId}")
   @Produces("text/plain")
   public Response getRepositoryVersion(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -92,7 +93,7 @@ public class RepositoryVersionService extends BaseService {
    * @param ui           uri info
    * @return information regarding the created repository
    */
-   @POST
+   @POST @ApiIgnore // until documented
    @Produces("text/plain")
    public Response createRepositoryVersion(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST, createResource(null));
@@ -106,7 +107,7 @@ public class RepositoryVersionService extends BaseService {
    * @param repositoryVersionId   the repository version id
    * @return information regarding the deleted repository
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{repositoryVersionId}")
   @Produces("text/plain")
   public Response deleteRepositoryVersion(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -122,7 +123,7 @@ public class RepositoryVersionService extends BaseService {
    * @param repositoryVersionId   the repository version id
    * @return information regarding the updated repository
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{repositoryVersionId}")
   @Produces("text/plain")
   public Response updateRepositoryVersion(String body, @Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/RequestScheduleService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RequestScheduleService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RequestScheduleService.java
index 5c48175..a734167 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RequestScheduleService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RequestScheduleService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -60,7 +61,7 @@ public class RequestScheduleService extends BaseService {
    * @param ui
    * @return
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getRequestSchedules(String body,
                                       @Context HttpHeaders headers,
@@ -75,7 +76,7 @@ public class RequestScheduleService extends BaseService {
    *
    * @return
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{requestScheduleId}")
   @Produces("text/plain")
   public Response getRequestSchedule(String body,
@@ -95,7 +96,7 @@ public class RequestScheduleService extends BaseService {
    * @param ui
    * @return
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createRequestSchedule(String body,
                                         @Context HttpHeaders headers,
@@ -113,7 +114,7 @@ public class RequestScheduleService extends BaseService {
    * @param requestScheduleId
    * @return
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{requestScheduleId}")
   @Produces("text/plain")
   public Response deleteRequestSchedule(@Context HttpHeaders headers,
@@ -123,8 +124,6 @@ public class RequestScheduleService extends BaseService {
       createRequestSchedule(m_clusterName, requestScheduleId));
   }
 
-
-
   /**
    * Create a request schedule resource instance
    * @param clusterName

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/RoleAuthorizationService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RoleAuthorizationService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RoleAuthorizationService.java
index f7365a1..4fe3613 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RoleAuthorizationService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RoleAuthorizationService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -68,7 +69,7 @@ public class RoleAuthorizationService extends BaseService {
    * @param ui      uri info
    * @return authorizations collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getAuthorizations(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createAuthorizationResource(null));
@@ -84,7 +85,7 @@ public class RoleAuthorizationService extends BaseService {
    * @param authorizationId authorization ID
    * @return authorization instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{authorization_id}")
   @Produces("text/plain")
   public Response getAuthorization(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ServiceConfigVersionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ServiceConfigVersionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ServiceConfigVersionService.java
index 43eabdc..c6e3201 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ServiceConfigVersionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ServiceConfigVersionService.java
@@ -28,6 +28,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -41,13 +42,12 @@ public class ServiceConfigVersionService extends BaseService {
     this.m_clusterName = m_clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getServiceConfigVersions(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET, createServiceConfigResource(m_clusterName));
   }
 
-
   ResourceInstance createServiceConfigResource(String clusterName) {
     Map<Resource.Type,String> mapIds = new HashMap<>();
     mapIds.put(Resource.Type.Cluster, clusterName);

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/StageService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/StageService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/StageService.java
index 7516379..349b270 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/StageService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/StageService.java
@@ -18,7 +18,6 @@
 
 package org.apache.ambari.server.api.services;
 
-
 import java.util.HashMap;
 import java.util.Map;
 
@@ -33,10 +32,10 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
-
 /**
  * Service responsible for stage resource requests.
  */
@@ -51,7 +50,6 @@ public class StageService extends BaseService {
    */
   private String m_requestId;
 
-
   // ----- Constructors ------------------------------------------------------
 
   /**
@@ -65,7 +63,6 @@ public class StageService extends BaseService {
     m_requestId = requestId;
   }
 
-
   // ----- StageService ------------------------------------------------------
 
   /**
@@ -79,7 +76,7 @@ public class StageService extends BaseService {
    *
    * @return stage resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{stageId}")
   @Produces("text/plain")
   public Response getStage(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -98,7 +95,7 @@ public class StageService extends BaseService {
    *
    * @return stage collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getStages(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET,
@@ -122,7 +119,7 @@ public class StageService extends BaseService {
    * @param ui          uri info
    * @return information regarding the created services
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{stageId}")
   @Produces("text/plain")
   public Response updateStages(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -139,7 +136,7 @@ public class StageService extends BaseService {
    * @param ui          uri info
    * @return information regarding the created services
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createStages(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/TargetClusterService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/TargetClusterService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/TargetClusterService.java
index 88a27f2..cb6eb39 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/TargetClusterService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/TargetClusterService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -50,7 +51,7 @@ public class TargetClusterService extends BaseService {
    * @param targetName    target id
    * @return target instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{targetName}")
   @Produces("text/plain")
   public Response getTargetCluster(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -67,7 +68,7 @@ public class TargetClusterService extends BaseService {
    * @param ui      uri info
    * @return target collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getTargetClusters(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET, createTargetClusterResource(null));
@@ -82,7 +83,7 @@ public class TargetClusterService extends BaseService {
    * @param targetName target id
    * @return information regarding the created target
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{targetName}")
   @Produces("text/plain")
   public Response createTargetCluster(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -100,7 +101,7 @@ public class TargetClusterService extends BaseService {
    * @param targetName target id
    * @return information regarding the updated target
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{targetName}")
   @Produces("text/plain")
   public Response updateTargetCluster(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -118,7 +119,7 @@ public class TargetClusterService extends BaseService {
    * @param targetName target id
    * @return information regarding the deleted target
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{targetName}")
   @Produces("text/plain")
   public Response deleteTargetCluster(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskAttemptService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskAttemptService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskAttemptService.java
index 55ff1ce..a1dcf2f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskAttemptService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskAttemptService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -71,7 +72,7 @@ public class TaskAttemptService extends BaseService {
    * 
    * @return task attempt instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{taskAttemptId}")
   @Produces("text/plain")
   public Response getTaskAttempt(String body, @Context HttpHeaders headers,
@@ -95,7 +96,7 @@ public class TaskAttemptService extends BaseService {
    * 
    * @return task attempt collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getTaskAttempts(String body, @Context HttpHeaders headers,
       @Context UriInfo ui) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskService.java
index 8441f7e..cc5491b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/TaskService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -74,7 +75,7 @@ public class TaskService extends BaseService {
    *
    * @return a task resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{taskId}")
   @Produces("text/plain")
   public Response getTask(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -93,7 +94,7 @@ public class TaskService extends BaseService {
    *
    * @return task collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeGroupService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeGroupService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeGroupService.java
index 004cd92..bc9aad1 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeGroupService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeGroupService.java
@@ -29,6 +29,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -45,7 +46,7 @@ public class UpgradeGroupService extends BaseService {
     m_upgradeId = upgradeId;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getGroups(String body,
       @Context HttpHeaders headers,
@@ -54,7 +55,7 @@ public class UpgradeGroupService extends BaseService {
         createResourceInstance(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{upgradeGroupId}")
   @Produces("text/plain")
   public Response getGroup(String body,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeItemService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeItemService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeItemService.java
index 4e83de9..9fc68df 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeItemService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeItemService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -48,7 +49,7 @@ public class UpgradeItemService extends BaseService {
     m_upgradeGroupId = upgradeGroupId;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getUpgrades(
       @Context HttpHeaders headers,
@@ -57,7 +58,7 @@ public class UpgradeItemService extends BaseService {
         createResourceInstance(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{upgradeItemId}")
   @Produces("text/plain")
   public Response getUpgradeItem(String body,
@@ -80,7 +81,7 @@ public class UpgradeItemService extends BaseService {
    *
    * @return information regarding the created services
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{upgradeItemId}")
   @Produces("text/plain")
   public Response updateUpgradeItem(String body,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeService.java
index dd21a7d..0e0df10 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -50,7 +51,7 @@ public class UpgradeService extends BaseService {
     m_clusterName = clusterName;
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createUpgrade(String body,
       @Context HttpHeaders headers,
@@ -59,7 +60,7 @@ public class UpgradeService extends BaseService {
         createResourceInstance(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getUpgrades( @Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -67,7 +68,7 @@ public class UpgradeService extends BaseService {
         createResourceInstance(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{upgradeId}")
   @Produces("text/plain")
   public Response getUpgradeItem(@Context HttpHeaders headers,
@@ -76,7 +77,7 @@ public class UpgradeService extends BaseService {
         createResourceInstance(id));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{upgradeId}")
   @Produces("text/plain")
   public Response updateUpgradeItem(String body, @Context HttpHeaders headers,
@@ -93,8 +94,6 @@ public class UpgradeService extends BaseService {
     return new UpgradeGroupService(m_clusterName, upgradeId);
   }
 
-
-
   /**
    * @param upgradeId the upgrade id
    * @return the resource instance

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeSummaryService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeSummaryService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeSummaryService.java
index 9ed9e32..ccd626f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeSummaryService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/UpgradeSummaryService.java
@@ -29,10 +29,10 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
-
 /**
  * Endpoint for a detailed summary of the cluster upgrades.
  */
@@ -49,7 +49,7 @@ public class UpgradeSummaryService extends BaseService {
     m_clusterName = clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getUpgradeSummaries(@Context HttpHeaders headers,
                                       @Context UriInfo ui) {
@@ -57,7 +57,7 @@ public class UpgradeSummaryService extends BaseService {
         createResourceInstance(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{requestId}")
   @Produces("text/plain")
   public Response getUpgradeSummary(@Context HttpHeaders headers,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ValidationService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ValidationService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ValidationService.java
index 64cca7f..6b6f643 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ValidationService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ValidationService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -50,7 +51,7 @@ public class ValidationService extends BaseService {
    * @param stackVersion stack version
    * @return validation items if any
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces(MediaType.TEXT_PLAIN)
   public Response getValidation(String body, @Context HttpHeaders headers, @Context UriInfo ui,
       @PathParam("stackName") String stackName, @PathParam("stackVersion") String stackVersion) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/VersionDefinitionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/VersionDefinitionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/VersionDefinitionService.java
index ce32003..9d0f32b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/VersionDefinitionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/VersionDefinitionService.java
@@ -34,6 +34,7 @@ import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.internal.VersionDefinitionResourceProvider;
 import org.apache.ambari.server.controller.spi.Resource;
@@ -44,7 +45,7 @@ import com.google.gson.JsonObject;
 @Path("/version_definitions/")
 public class VersionDefinitionService extends BaseService {
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces(MediaType.TEXT_PLAIN)
   public Response getServices(@Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -52,7 +53,7 @@ public class VersionDefinitionService extends BaseService {
       createResource(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{versionId}")
   @Produces(MediaType.TEXT_PLAIN)
   public Response getService(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -75,9 +76,7 @@ public class VersionDefinitionService extends BaseService {
     return new OperatingSystemService(mapIds);
   }
 
-
-
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces(MediaType.TEXT_PLAIN)
   public Response createVersion(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST,
@@ -91,7 +90,7 @@ public class VersionDefinitionService extends BaseService {
    * @param headers  the headers
    * @param ui       the URI info
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Consumes({MediaType.TEXT_XML})
   @Produces(MediaType.TEXT_PLAIN)
   public Response createVersionByXml(String body, @Context HttpHeaders headers,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ViewUrlsService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ViewUrlsService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ViewUrlsService.java
index 6bdf66d..fadcc72 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ViewUrlsService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ViewUrlsService.java
@@ -32,13 +32,13 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 import org.apache.ambari.server.security.authorization.AuthorizationException;
 
 import com.google.common.base.Optional;
 
-
 /**
  * Service responsible for view resource requests.
  */
@@ -52,13 +52,12 @@ public class ViewUrlsService extends BaseService {
 
    * @return collections of all view urls and any instances registered against them
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getViewUrls(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createViewUrlResource(Optional.<String>absent()));
   }
 
-
   /**
    * Create a new View URL
    * @param body
@@ -68,7 +67,7 @@ public class ViewUrlsService extends BaseService {
    * @return
    * @throws AuthorizationException
      */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{urlName}")
   @Produces("text/plain")
   public Response createUrl(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -76,7 +75,6 @@ public class ViewUrlsService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.POST, createViewUrlResource(Optional.of(urlName)));
   }
 
-
   /**
    * Update a view URL
    * @param body
@@ -86,7 +84,7 @@ public class ViewUrlsService extends BaseService {
    * @return
    * @throws AuthorizationException
      */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{urlName}")
   @Produces("text/plain")
   public Response updateUrl(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -103,7 +101,7 @@ public class ViewUrlsService extends BaseService {
    * @return
    * @throws AuthorizationException
      */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{urlName}")
   @Produces("text/plain")
   public Response deleteUrl(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -111,7 +109,6 @@ public class ViewUrlsService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.DELETE, createViewUrlResource(Optional.of(urlName)));
   }
 
-
   /**
    * Get information about a single view URL
    * @param headers
@@ -120,7 +117,7 @@ public class ViewUrlsService extends BaseService {
    * @return
    * @throws AuthorizationException
      */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{urlName}")
   @Produces("text/plain")
   public Response getUrl(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -128,9 +125,6 @@ public class ViewUrlsService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.GET, createViewUrlResource(Optional.of(urlName)));
   }
 
-
-
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetLayoutService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetLayoutService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetLayoutService.java
index b22ff4f..61167d6 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetLayoutService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetLayoutService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -46,7 +47,7 @@ public class WidgetLayoutService extends BaseService {
     this.clusterName = clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{widgetLayoutId}")
   @Produces("text/plain")
   public Response getService(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -65,7 +66,7 @@ public class WidgetLayoutService extends BaseService {
    *
    * @return instance collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getServices(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     System.out.println("###########");
@@ -73,7 +74,7 @@ public class WidgetLayoutService extends BaseService {
             createResource(null));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{widgetLayoutId}")
   @Produces("text/plain")
   public Response createService(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -82,7 +83,7 @@ public class WidgetLayoutService extends BaseService {
             createResource(widgetLayoutId));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createServices(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -90,7 +91,7 @@ public class WidgetLayoutService extends BaseService {
             createResource(null));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{widgetLayoutId}")
   @Produces("text/plain")
   public Response updateService(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -99,14 +100,14 @@ public class WidgetLayoutService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.PUT, createResource(widgetLayoutId));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateServices(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
     return handleRequest(headers, body, ui, Request.Type.PUT, createResource(null));
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{widgetLayoutId}")
   @Produces("text/plain")
   public Response deleteService(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetService.java
index 32a9857..d4586e4 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/WidgetService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -46,7 +47,7 @@ public class WidgetService extends BaseService {
     this.clusterName = clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{widgetId}")
   @Produces("text/plain")
   public Response getService(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -65,7 +66,7 @@ public class WidgetService extends BaseService {
    *
    * @return instance collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getServices(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -73,7 +74,7 @@ public class WidgetService extends BaseService {
             createResource(null));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{widgetId}")
   @Produces("text/plain")
   public Response createService(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -82,7 +83,7 @@ public class WidgetService extends BaseService {
             createResource(widgetId));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createServices(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -90,7 +91,7 @@ public class WidgetService extends BaseService {
             createResource(null));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{widgetId}")
   @Produces("text/plain")
   public Response updateService(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -99,14 +100,14 @@ public class WidgetService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.PUT, createResource(widgetId));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateServices(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
     return handleRequest(headers, body, ui, Request.Type.PUT, createResource(null));
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{widgetId}")
   @Produces("text/plain")
   public Response deleteService(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/WorkflowService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/WorkflowService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/WorkflowService.java
index b7e257a..6151e89 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/WorkflowService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/WorkflowService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -60,7 +61,7 @@ public class WorkflowService extends BaseService {
    *          workflow id
    * @return workflow instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{workflowId}")
   @Produces("text/plain")
   public Response getWorkflow(String body, @Context HttpHeaders headers,
@@ -78,7 +79,7 @@ public class WorkflowService extends BaseService {
    *          uri info
    * @return workflow collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getWorkflows(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/GroupService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/GroupService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/GroupService.java
index ede59b4..40bcf82 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/GroupService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/GroupService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -131,7 +132,7 @@ public class GroupService extends BaseService {
    *
    * @deprecated Use requests to /groups instead.
    */
-   @POST
+   @POST @ApiIgnore // deprecated
    @Deprecated
    @Path("{groupName}")
    @Produces("text/plain")
@@ -162,7 +163,6 @@ public class GroupService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createGroupResource(groupName));
   }
 
-
   /**
    * Create a group resource instance.
    *

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/MemberService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/MemberService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/MemberService.java
index 765d0d3..09e4050 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/MemberService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/groups/MemberService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -61,7 +62,7 @@ public class MemberService extends BaseService {
    * @param groupName    group name
    * @return information regarding the created member
    */
-   @POST
+   @POST @ApiIgnore // until documented
    @Produces("text/plain")
    public Response createMember(String body, @Context HttpHeaders headers, @Context UriInfo ui, @PathParam("groupName") String groupName) {
     return handleRequest(headers, body, ui, Request.Type.POST, createMemberResource(groupName, null));
@@ -77,7 +78,7 @@ public class MemberService extends BaseService {
    * @param userName     the user name
    * @return information regarding the created member
    */
-   @POST
+   @POST @ApiIgnore // until documented
    @Path("{userName}")
    @Produces("text/plain")
    public Response createMember(String body, @Context HttpHeaders headers, @Context UriInfo ui, @PathParam("groupName") String groupName,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/users/UserService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/users/UserService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/users/UserService.java
index ac6a055..a69ed4e 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/users/UserService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/users/UserService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -105,7 +106,7 @@ public class UserService extends BaseService {
    * @param ui          uri info
    * @return information regarding the created user
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createUser(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST, createUserResource(null));

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewExternalSubResourceService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewExternalSubResourceService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewExternalSubResourceService.java
index 9ce93bc..c2f61f9 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewExternalSubResourceService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewExternalSubResourceService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -68,7 +69,6 @@ public class ViewExternalSubResourceService  extends BaseService {
    */
   private final Map<String, Object> resourceServiceMap = new HashMap<>();
 
-
   // ----- Constructors ------------------------------------------------------
 
   public ViewExternalSubResourceService(Resource.Type type, ViewInstanceEntity viewInstanceDefinition) {
@@ -89,7 +89,7 @@ public class ViewExternalSubResourceService  extends BaseService {
    *
    * @return instance collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getResources(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET,
@@ -117,7 +117,6 @@ public class ViewExternalSubResourceService  extends BaseService {
     return service;
   }
 
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewInstanceService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewInstanceService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewInstanceService.java
index 08e0e9f..e4ebedb 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewInstanceService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewInstanceService.java
@@ -34,6 +34,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -91,7 +92,6 @@ public class ViewInstanceService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.GET, createResource(viewName, version, null));
   }
 
-
   /**
    * Handles URL: /views/{viewName}/versions/{version}/instances/{instanceID}
    * Get a specific instance.
@@ -120,7 +120,6 @@ public class ViewInstanceService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.GET, createResource(viewName, version, instanceName));
   }
 
-
   /**
    * Handles: POST /views/{viewName}/versions/{version}/instances/{instanceId}
    * Create a specific instance.
@@ -163,7 +162,7 @@ public class ViewInstanceService extends BaseService {
    *
    * @return information regarding the created instances
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createServices(String body, @Context HttpHeaders headers, @Context UriInfo ui,
                                  @PathParam("viewName") String viewName, @PathParam("version") String version) throws AuthorizationException {
@@ -212,7 +211,7 @@ public class ViewInstanceService extends BaseService {
    *
    * @return information regarding the updated instance
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateServices(String body, @Context HttpHeaders headers, @Context UriInfo ui,
                                  @PathParam("viewName") String viewName, @PathParam("version") String version) throws AuthorizationException {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPermissionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPermissionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPermissionService.java
index bdb6742..4f30f9f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPermissionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPermissionService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -47,7 +48,6 @@ import io.swagger.annotations.ApiParam;
 import io.swagger.annotations.ApiResponse;
 import io.swagger.annotations.ApiResponses;
 
-
 /**
  * Service responsible for custom view permission resource requests.
  */
@@ -128,7 +128,7 @@ public class ViewPermissionService extends BaseService {
    *
    * @return information regarding the created permission
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response createPermission(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -151,7 +151,7 @@ public class ViewPermissionService extends BaseService {
    * @param permissionId  permission id
    * @return information regarding the updated permission
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response updatePermission(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -175,7 +175,7 @@ public class ViewPermissionService extends BaseService {
    *
    * @return information regarding the deleted permission
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response deletePermission(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -187,7 +187,6 @@ public class ViewPermissionService extends BaseService {
         viewName, version, permissionId));
   }
 
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPrivilegeService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPrivilegeService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPrivilegeService.java
index a2e8952..9b1430f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPrivilegeService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewPrivilegeService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -158,7 +159,7 @@ public class ViewPrivilegeService extends BaseService {
    *
    * @return information regarding the updated privilege
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   // Remove comments when the below API call is fixed
   /*@Path("{privilegeId}")
   @Produces("text/plain")
@@ -192,7 +193,7 @@ public class ViewPrivilegeService extends BaseService {
    *
    * @return information regarding the updated privileges
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updatePrivileges(String body, @Context HttpHeaders headers, @Context UriInfo ui,
                                    @ApiParam(value = "view name") @PathParam("viewName") String viewName,
@@ -214,7 +215,7 @@ public class ViewPrivilegeService extends BaseService {
    *
    * @return information regarding the deleted privileges
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Produces("text/plain")
   public Response deletePrivileges(String body, @Context HttpHeaders headers, @Context UriInfo ui,
                                    @ApiParam(value = "view name") @PathParam("viewName") String viewName,
@@ -254,7 +255,6 @@ public class ViewPrivilegeService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createPrivilegeResource(viewName, version, instanceName, privilegeId));
   }
 
-
   protected ResourceInstance createPrivilegeResource(String viewName, String viewVersion, String instanceName, String privilegeId) {
     Map<Resource.Type,String> mapIds = new HashMap<>();
     mapIds.put(Resource.Type.View, viewName);

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewService.java
index a3da212..0806a01 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -46,7 +47,6 @@ import io.swagger.annotations.ApiParam;
 import io.swagger.annotations.ApiResponse;
 import io.swagger.annotations.ApiResponses;
 
-
 /**
  * Service responsible for view resource requests.
  */
@@ -106,7 +106,6 @@ public class ViewService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.GET, createViewResource(viewName));
   }
 
-
   /**
    * Handles: POST /views/{viewID}
    * Create a specific view.
@@ -117,7 +116,7 @@ public class ViewService extends BaseService {
    *
    * @return information regarding the created view
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{viewName}")
   @Produces("text/plain")
   public Response createView(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -136,7 +135,7 @@ public class ViewService extends BaseService {
    *
    * @return information regarding the updated view
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{viewName}")
   @Produces("text/plain")
   public Response updateView(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -155,7 +154,7 @@ public class ViewService extends BaseService {
    *
    * @return information regarding the deleted view
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{viewName}")
   @Produces("text/plain")
   public Response deleteView(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -164,7 +163,6 @@ public class ViewService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createViewResource(viewName));
   }
 
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewVersionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewVersionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewVersionService.java
index 90d5031..580b4bd 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewVersionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/views/ViewVersionService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.api.services.BaseService;
 import org.apache.ambari.server.api.services.Request;
@@ -47,7 +48,6 @@ import io.swagger.annotations.ApiParam;
 import io.swagger.annotations.ApiResponse;
 import io.swagger.annotations.ApiResponses;
 
-
 /**
  * Service responsible for view version resource requests.
  */
@@ -84,7 +84,6 @@ public class ViewVersionService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.GET, createResource(viewName, null));
   }
 
-
   /**
    * Handles: GET /views/{viewName}/versions/{version}
    * Get a specific view version.
@@ -124,7 +123,7 @@ public class ViewVersionService extends BaseService {
    *
    * @return information regarding the created view
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{version}")
   @Produces("text/plain")
   public Response createVersions(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -145,7 +144,7 @@ public class ViewVersionService extends BaseService {
    *
    * @return information regarding the updated view
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{version}")
   @Produces("text/plain")
   public Response updateVersions(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -166,7 +165,7 @@ public class ViewVersionService extends BaseService {
    *
    * @return information regarding the deleted view version
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{version}")
   @Produces("text/plain")
   public Response deleteVersions(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -175,7 +174,6 @@ public class ViewVersionService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createResource(viewName, version));
   }
 
-
   /**
    * Get the permissions sub-resource
    *
@@ -189,7 +187,6 @@ public class ViewVersionService extends BaseService {
     return new ViewPermissionService(viewName, version);
   }
 
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/proxy/ProxyService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/proxy/ProxyService.java b/ambari-server/src/main/java/org/apache/ambari/server/proxy/ProxyService.java
index 3237b36..f1994ce 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/proxy/ProxyService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/proxy/ProxyService.java
@@ -41,6 +41,7 @@ import javax.ws.rs.core.MultivaluedMap;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.controller.internal.URLStreamProvider;
 import org.apache.ambari.server.view.ImpersonatorSettingImpl;
 import org.slf4j.Logger;
@@ -66,24 +67,24 @@ public class ProxyService {
 
   private final static Logger LOG = LoggerFactory.getLogger(ProxyService.class);
 
-  @GET
+  @GET @ApiIgnore // until documented
   public Response processGetRequestForwarding(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(REQUEST_TYPE_GET, ui, null, headers);
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Consumes({MediaType.WILDCARD, MediaType.TEXT_PLAIN, MediaType.TEXT_XML, MediaType.APPLICATION_FORM_URLENCODED, MediaType.APPLICATION_JSON})
   public Response processPostRequestForwarding(InputStream body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(REQUEST_TYPE_POST, ui, body, headers);
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Consumes({MediaType.WILDCARD, MediaType.TEXT_PLAIN, MediaType.TEXT_XML, MediaType.APPLICATION_FORM_URLENCODED, MediaType.APPLICATION_JSON})
   public Response processPutRequestForwarding(InputStream body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(REQUEST_TYPE_PUT, ui, body, headers);
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   public Response processDeleteRequestForwarding(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(REQUEST_TYPE_DELETE, ui, null, headers);
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/resources/api/rest/GetResource.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/resources/api/rest/GetResource.java b/ambari-server/src/main/java/org/apache/ambari/server/resources/api/rest/GetResource.java
index f81c13a..0e00c2f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/resources/api/rest/GetResource.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/resources/api/rest/GetResource.java
@@ -17,7 +17,6 @@
  */
 package org.apache.ambari.server.resources.api.rest;
 
-
 import java.io.File;
 
 import javax.servlet.http.HttpServletRequest;
@@ -31,6 +30,7 @@ import javax.ws.rs.core.Context;
 import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.resources.ResourceManager;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -51,8 +51,7 @@ public class GetResource {
 	  resourceManager = instance;
   }
 
-
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{resourcePath:.*}")
   @Consumes(MediaType.TEXT_PLAIN)
   @Produces(MediaType.APPLICATION_OCTET_STREAM)

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateDownload.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateDownload.java b/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateDownload.java
index eddc6bb..881e614 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateDownload.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateDownload.java
@@ -17,12 +17,12 @@
  */
 package org.apache.ambari.server.security.unsecured.rest;
 
-
 import javax.ws.rs.GET;
 import javax.ws.rs.Path;
 import javax.ws.rs.Produces;
 import javax.ws.rs.core.MediaType;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.security.CertificateManager;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -39,11 +39,10 @@ public class CertificateDownload {
     certMan = instance;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces({MediaType.TEXT_PLAIN})
   public String downloadSrvrCrt() {
     return certMan.getServerCert();
   }
 
-
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateSign.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateSign.java b/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateSign.java
index 5e2d45a..bfc3f3a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateSign.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/CertificateSign.java
@@ -17,7 +17,6 @@
  */
 package org.apache.ambari.server.security.unsecured.rest;
 
-
 import javax.servlet.http.HttpServletRequest;
 import javax.ws.rs.Consumes;
 import javax.ws.rs.POST;
@@ -27,6 +26,7 @@ import javax.ws.rs.Produces;
 import javax.ws.rs.core.Context;
 import javax.ws.rs.core.MediaType;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.security.CertificateManager;
 import org.apache.ambari.server.security.SignCertResponse;
 import org.apache.ambari.server.security.SignMessage;
@@ -55,7 +55,7 @@ public class CertificateSign {
    * @throws Exception
    */
   @Path("{hostName}")
-  @POST
+  @POST @ApiIgnore // until documented
   @Consumes(MediaType.APPLICATION_JSON)
   @Produces({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
   public SignCertResponse signAgentCrt(@PathParam("hostName") String hostname,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/ConnectionInfo.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/ConnectionInfo.java b/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/ConnectionInfo.java
index ac2e536..2ab4639 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/ConnectionInfo.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/security/unsecured/rest/ConnectionInfo.java
@@ -25,27 +25,26 @@ import javax.ws.rs.Path;
 import javax.ws.rs.Produces;
 import javax.ws.rs.core.MediaType;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.configuration.Configuration;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 import com.google.inject.Inject;
 
-
 @Path("/connection_info")
 public class ConnectionInfo {
     private static final Logger LOG = LoggerFactory.getLogger(ConnectionInfo.class);
     private static HashMap<String,String> response= new HashMap<>();
     private static Configuration conf;
 
-
     @Inject
     public static void init(Configuration instance){
         conf = instance;
         response.put(Configuration.SRVR_TWO_WAY_SSL.getKey(),String.valueOf(conf.isTwoWaySsl()));
     }
 
-    @GET
+    @GET @ApiIgnore // until documented
     @Produces({MediaType.APPLICATION_JSON})
     public Map<String,String> connectionType() {
         return response;


[02/11] ambari git commit: AMBARI-21292.Convert Slider View to use yarn package manager(Venkata Sairam)

Posted by rl...@apache.org.
AMBARI-21292.Convert Slider View to use yarn package manager(Venkata Sairam)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/6cda103e
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/6cda103e
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/6cda103e

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 6cda103e26885233f27b82ab3af8ef099428c53f
Parents: 23760e7
Author: Venkata Sairam <ve...@gmail.com>
Authored: Thu Jun 22 09:16:58 2017 +0530
Committer: Venkata Sairam <ve...@gmail.com>
Committed: Thu Jun 22 09:16:58 2017 +0530

----------------------------------------------------------------------
 .../slider/src/main/resources/ui/package.json    | 19 ++++++++++---------
 1 file changed, 10 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/6cda103e/contrib/views/slider/src/main/resources/ui/package.json
----------------------------------------------------------------------
diff --git a/contrib/views/slider/src/main/resources/ui/package.json b/contrib/views/slider/src/main/resources/ui/package.json
index f9f8793..7658ae7 100755
--- a/contrib/views/slider/src/main/resources/ui/package.json
+++ b/contrib/views/slider/src/main/resources/ui/package.json
@@ -20,18 +20,19 @@
     "update:skeleton": "node setup.js update:skeleton"
   },
   "dependencies": {
-    "javascript-brunch": "~1.7.0",
-    "less-brunch":">= 1.0 < 1.5",
-    "css-brunch": "~1.7.0",
-    "stylus-brunch": "~1.7.0",
-    "uglify-js-brunch": "~1.7.0",
-    "clean-css-brunch": "~1.7.0",
-    "ember-handlebars-brunch": "git://github.com/fuseelements/ember-handlebars-brunch#fix/ember-1.3.0"
+    "clean-css-brunch": ">= 1.0 < 1.8",
+    "coffee-script-brunch": ">= 1.0 < 1.8",
+    "css-brunch": ">= 1.0 < 1.8",
+    "ember-handlebars-brunch": "git://github.com/fuseelements/ember-handlebars-brunch#fix/ember-1.3.0",
+    "handlebars": "^4.0.10",
+    "javascript-brunch": ">= 1.0 < 1.8",
+    "stylus-brunch": ">= 1.0 < 1.8",
+    "uglify-js-brunch": ">= 1.0 < 1.8"
   },
   "devDependencies": {
-    "phantomjs": "^1.9.2",
     "karma": "*",
+    "karma-phantomjs-launcher": "~0.1.2",
     "karma-qunit": "*",
-    "karma-phantomjs-launcher": "~0.1.2"
+    "phantomjs": "^1.9.2"
   }
 }


[11/11] ambari git commit: Merge branch 'trunk' into branch-feature-AMBARI-20859

Posted by rl...@apache.org.
Merge branch 'trunk' into branch-feature-AMBARI-20859


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/b5333870
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/b5333870
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/b5333870

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: b5333870a70948cf821f8a3e617b5efd3984de5e
Parents: 8f03fd0 5fc8ccc
Author: Robert Levas <rl...@hortonworks.com>
Authored: Thu Jun 22 10:37:55 2017 -0400
Committer: Robert Levas <rl...@hortonworks.com>
Committed: Thu Jun 22 10:37:55 2017 -0400

----------------------------------------------------------------------
 ambari-server/checkstyle.xml                    |   2 +-
 ambari-server/pom.xml                           |   1 +
 .../ambari/server/agent/rest/AgentResource.java |   7 +-
 .../server/api/rest/BootStrapResource.java      |  10 +-
 .../ambari/server/api/rest/HealthCheck.java     |   8 +-
 .../api/rest/KdcServerReachabilityCheck.java    |  10 +-
 .../api/services/AlertDefinitionService.java    |  13 +-
 .../server/api/services/AlertGroupService.java  |  11 +-
 .../api/services/AlertHistoryService.java       |   5 +-
 .../server/api/services/AlertNoticeService.java |   5 +-
 .../server/api/services/AlertService.java       |   7 +-
 .../server/api/services/AlertTargetService.java |  11 +-
 .../ClusterKerberosDescriptorService.java       |   6 +-
 .../services/ClusterStackVersionService.java    |  12 +-
 .../CompatibleRepositoryVersionService.java     |   5 +-
 .../server/api/services/ComponentService.java   |  15 +-
 .../server/api/services/ConfigGroupService.java |  12 +-
 .../api/services/ConfigurationService.java      |   5 +-
 .../server/api/services/CredentialService.java  |  11 +-
 .../api/services/ExtensionLinksService.java     |  13 +-
 .../server/api/services/ExtensionsService.java  |  11 +-
 .../ambari/server/api/services/FeedService.java |  11 +-
 .../api/services/HostComponentService.java      |  20 +-
 .../services/HostKerberosIdentityService.java   |   5 +-
 .../api/services/HostStackVersionService.java   |   7 +-
 .../server/api/services/InstanceService.java    |  11 +-
 .../ambari/server/api/services/JobService.java  |   5 +-
 .../api/services/KerberosDescriptorService.java |   9 +-
 .../ambari/server/api/services/KeyService.java  |   3 +-
 .../api/services/LdapSyncEventService.java      |  12 +-
 .../server/api/services/LoggingService.java     |   6 +-
 .../server/api/services/LogoutService.java      |   3 +-
 .../api/services/OperatingSystemService.java    |   5 +-
 .../server/api/services/PermissionService.java  |  12 +-
 .../api/services/PersistKeyValueService.java    |   9 +-
 .../api/services/PreUpgradeCheckService.java    |   3 +-
 .../server/api/services/PrivilegeService.java   |  17 +-
 .../api/services/RecommendationService.java     |   3 +-
 .../api/services/RemoteClustersService.java     |  18 +-
 .../server/api/services/RepositoryService.java  |  11 +-
 .../api/services/RepositoryVersionService.java  |  11 +-
 .../api/services/RequestScheduleService.java    |  11 +-
 .../api/services/RoleAuthorizationService.java  |   5 +-
 .../services/ServiceConfigVersionService.java   |   4 +-
 .../server/api/services/StageService.java       |  13 +-
 .../api/services/TargetClusterService.java      |  11 +-
 .../server/api/services/TaskAttemptService.java |   5 +-
 .../ambari/server/api/services/TaskService.java |   5 +-
 .../api/services/UpgradeGroupService.java       |   5 +-
 .../server/api/services/UpgradeItemService.java |   7 +-
 .../server/api/services/UpgradeService.java     |  11 +-
 .../api/services/UpgradeSummaryService.java     |   6 +-
 .../server/api/services/ValidationService.java  |   3 +-
 .../api/services/VersionDefinitionService.java  |  11 +-
 .../server/api/services/ViewUrlsService.java    |  18 +-
 .../api/services/WidgetLayoutService.java       |  15 +-
 .../server/api/services/WidgetService.java      |  15 +-
 .../server/api/services/WorkflowService.java    |   5 +-
 .../api/services/groups/GroupService.java       |   4 +-
 .../api/services/groups/MemberService.java      |   5 +-
 .../server/api/services/users/UserService.java  |   3 +-
 .../views/ViewExternalSubResourceService.java   |   5 +-
 .../api/services/views/ViewInstanceService.java |   7 +-
 .../services/views/ViewPermissionService.java   |   9 +-
 .../services/views/ViewPrivilegeService.java    |   8 +-
 .../server/api/services/views/ViewService.java  |  10 +-
 .../api/services/views/ViewVersionService.java  |  11 +-
 .../ambari/server/proxy/ProxyService.java       |   9 +-
 .../server/resources/api/rest/GetResource.java  |   5 +-
 .../unsecured/rest/CertificateDownload.java     |   5 +-
 .../unsecured/rest/CertificateSign.java         |   4 +-
 .../security/unsecured/rest/ConnectionInfo.java |   5 +-
 .../custom_actions/scripts/install_packages.py  |   6 +
 .../app/mixins/common/widgets/widget_mixin.js   |   3 +-
 .../test/mixins/common/widget_mixin_test.js     |   2 +
 .../slider/src/main/resources/ui/package.json   |  19 +-
 .../ui/app/components/flow-designer.js          |  27 ++
 .../resources/ui/app/components/hdfs-browser.js |   8 +-
 .../ui/app/domain/actionjob_hanlder.js          |   3 +
 .../ui/app/domain/workflow-xml-generator.js     |   3 +
 .../ui/app/services/workspace-manager.js        |   5 +
 .../src/main/resources/ui/app/styles/app.less   |   3 +-
 .../app/templates/components/flow-designer.hbs  |   9 +-
 .../app/templates/components/hdfs-browser.hbs   |  16 +-
 .../app/templates/components/spark-action.hbs   |   7 +-
 .../main/resources/ui/app/utils/constants.js    |   3 +-
 .../main/resources/ui/app/utils/hdfsviewer.js   |   3 +
 .../wfmanager/src/main/resources/ui/bower.json  |   1 -
 .../addon/components/directory-viewer.js        | 325 +++++++++++++------
 .../hdfs-directory-viewer/addon/styles/app.css  | 189 +++++++++++
 .../templates/components/directory-viewer.hbs   | 146 +++++++++
 .../addon/utils/viewer-config.js                |   3 +
 .../hdfs-directory-viewer/bower.json            |   1 -
 .../hdfs-directory-viewer/index.js              |   3 -
 .../hdfs-directory-viewer/package.json          |   5 +-
 .../src/main/resources/ui/package.json          |   3 +-
 96 files changed, 953 insertions(+), 441 deletions(-)
----------------------------------------------------------------------



[10/11] ambari git commit: AMBARI-21299 Service widgets don't remove old data of metrics. (atkach)

Posted by rl...@apache.org.
AMBARI-21299 Service widgets don't remove old data of metrics. (atkach)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/5fc8ccc9
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/5fc8ccc9
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/5fc8ccc9

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 5fc8ccc9655e702c20f0a4ff569610afe5d08f45
Parents: 965e4bd
Author: Andrii Tkach <at...@apache.org>
Authored: Wed Jun 21 20:59:33 2017 +0300
Committer: Andrii Tkach <at...@apache.org>
Committed: Thu Jun 22 14:24:23 2017 +0300

----------------------------------------------------------------------
 ambari-web/app/mixins/common/widgets/widget_mixin.js | 3 ++-
 ambari-web/test/mixins/common/widget_mixin_test.js   | 2 ++
 2 files changed, 4 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/5fc8ccc9/ambari-web/app/mixins/common/widgets/widget_mixin.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/mixins/common/widgets/widget_mixin.js b/ambari-web/app/mixins/common/widgets/widget_mixin.js
index 23df0c4..e20fe7e 100644
--- a/ambari-web/app/mixins/common/widgets/widget_mixin.js
+++ b/ambari-web/app/mixins/common/widgets/widget_mixin.js
@@ -84,7 +84,6 @@ App.WidgetMixin = Ember.Mixin.create({
   contentColor: Em.computed.ifThenElse('value', 'green', 'grey'),
 
   beforeRender: function () {
-    this.get('metrics').clear();
     this.loadMetrics();
   },
 
@@ -98,6 +97,8 @@ App.WidgetMixin = Ember.Mixin.create({
       requestCounter = 0,
       self = this;
 
+    this.set('metrics', []);
+
     for (var i in requestData) {
       request = requestData[i];
       requestCounter++;

http://git-wip-us.apache.org/repos/asf/ambari/blob/5fc8ccc9/ambari-web/test/mixins/common/widget_mixin_test.js
----------------------------------------------------------------------
diff --git a/ambari-web/test/mixins/common/widget_mixin_test.js b/ambari-web/test/mixins/common/widget_mixin_test.js
index fe972f9..48c7c3b 100644
--- a/ambari-web/test/mixins/common/widget_mixin_test.js
+++ b/ambari-web/test/mixins/common/widget_mixin_test.js
@@ -281,6 +281,7 @@ describe('App.WidgetMixin', function () {
     cases.forEach(function (item) {
       describe(item.title, function () {
         beforeEach(function() {
+          sinon.stub(mixinObject, 'loadMetrics');
           mixinObject.setProperties({
             isExportButtonHidden: false,
             childViews: item.childViews,
@@ -306,6 +307,7 @@ describe('App.WidgetMixin', function () {
         });
 
         afterEach(function() {
+          mixinObject.loadMetrics.restore();
           graph._showMessage.restore();
         });
 


[04/11] ambari git commit: AMBARI-21266.Workflow submission fails when action node names contain white space(Venkata Sairam)

Posted by rl...@apache.org.
AMBARI-21266.Workflow submission fails when action node names contain white space(Venkata Sairam)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/9c693228
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/9c693228
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/9c693228

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 9c6932286fd3860627a6c41ab997293b0caef5a1
Parents: 1f70d06
Author: Venkata Sairam <ve...@gmail.com>
Authored: Thu Jun 22 09:25:17 2017 +0530
Committer: Venkata Sairam <ve...@gmail.com>
Committed: Thu Jun 22 09:25:17 2017 +0530

----------------------------------------------------------------------
 .../src/main/resources/ui/app/domain/workflow-xml-generator.js    | 3 +++
 1 file changed, 3 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/9c693228/contrib/views/wfmanager/src/main/resources/ui/app/domain/workflow-xml-generator.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/domain/workflow-xml-generator.js b/contrib/views/wfmanager/src/main/resources/ui/app/domain/workflow-xml-generator.js
index a6e1eeb..4d63cbd 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/domain/workflow-xml-generator.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/domain/workflow-xml-generator.js
@@ -115,6 +115,9 @@ var WorkflowGenerator= Ember.Object.extend({
       if (jobHandler){
 
         jobHandler.setContext(this.workflowContext);
+        if(/\s/g.test(node.name)) {
+          this.workflowContext.addError({node : node, message : "Action name cannot contain white space."});
+        }
         if (!self.ignoreErrors && !node.get("domain")){
             this.workflowContext.addError({node : node, message : "Action Properties are empty"});
         }else{


[09/11] ambari git commit: AMBARI-21295. Enable Swagger checkstyle rule for endpoints documented so far

Posted by rl...@apache.org.
AMBARI-21295. Enable Swagger checkstyle rule for endpoints documented so far


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/965e4bd0
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/965e4bd0
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/965e4bd0

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: 965e4bd0f834f009988f771a85e81dca55f0d235
Parents: e0d5f40
Author: Attila Doroszlai <ad...@hortonworks.com>
Authored: Wed Jun 21 14:52:50 2017 +0200
Committer: Attila Doroszlai <ad...@hortonworks.com>
Committed: Thu Jun 22 08:29:25 2017 +0200

----------------------------------------------------------------------
 ambari-server/checkstyle.xml                    |  2 +-
 .../ambari/server/agent/rest/AgentResource.java |  7 ++++---
 .../server/api/rest/BootStrapResource.java      | 10 +++++-----
 .../ambari/server/api/rest/HealthCheck.java     |  8 +++++---
 .../api/rest/KdcServerReachabilityCheck.java    | 10 ++++------
 .../api/services/AlertDefinitionService.java    | 13 ++++++-------
 .../server/api/services/AlertGroupService.java  | 11 ++++++-----
 .../api/services/AlertHistoryService.java       |  5 +++--
 .../server/api/services/AlertNoticeService.java |  5 +++--
 .../server/api/services/AlertService.java       |  7 +++----
 .../server/api/services/AlertTargetService.java | 11 ++++++-----
 .../ClusterKerberosDescriptorService.java       |  6 +++---
 .../services/ClusterStackVersionService.java    | 12 +++++-------
 .../CompatibleRepositoryVersionService.java     |  5 +++--
 .../server/api/services/ComponentService.java   | 15 ++++++++-------
 .../server/api/services/ConfigGroupService.java | 12 ++++++------
 .../api/services/ConfigurationService.java      |  5 +++--
 .../server/api/services/CredentialService.java  | 11 ++++++-----
 .../api/services/ExtensionLinksService.java     | 13 +++++++------
 .../server/api/services/ExtensionsService.java  | 11 ++++++-----
 .../ambari/server/api/services/FeedService.java | 11 ++++++-----
 .../api/services/HostComponentService.java      | 20 ++++++++++----------
 .../services/HostKerberosIdentityService.java   |  5 +++--
 .../api/services/HostStackVersionService.java   |  7 ++++---
 .../server/api/services/InstanceService.java    | 11 ++++++-----
 .../ambari/server/api/services/JobService.java  |  5 +++--
 .../api/services/KerberosDescriptorService.java |  9 +++++----
 .../ambari/server/api/services/KeyService.java  |  3 ++-
 .../api/services/LdapSyncEventService.java      | 12 ++++++------
 .../server/api/services/LoggingService.java     |  6 ++----
 .../server/api/services/LogoutService.java      |  3 ++-
 .../api/services/OperatingSystemService.java    |  5 +++--
 .../server/api/services/PermissionService.java  | 12 ++++++------
 .../api/services/PersistKeyValueService.java    |  9 +++++----
 .../api/services/PreUpgradeCheckService.java    |  3 ++-
 .../server/api/services/PrivilegeService.java   | 17 ++++++++---------
 .../api/services/RecommendationService.java     |  3 ++-
 .../api/services/RemoteClustersService.java     | 18 ++++++------------
 .../server/api/services/RepositoryService.java  | 11 ++++++-----
 .../api/services/RepositoryVersionService.java  | 11 ++++++-----
 .../api/services/RequestScheduleService.java    | 11 +++++------
 .../api/services/RoleAuthorizationService.java  |  5 +++--
 .../services/ServiceConfigVersionService.java   |  4 ++--
 .../server/api/services/StageService.java       | 13 +++++--------
 .../api/services/TargetClusterService.java      | 11 ++++++-----
 .../server/api/services/TaskAttemptService.java |  5 +++--
 .../ambari/server/api/services/TaskService.java |  5 +++--
 .../api/services/UpgradeGroupService.java       |  5 +++--
 .../server/api/services/UpgradeItemService.java |  7 ++++---
 .../server/api/services/UpgradeService.java     | 11 +++++------
 .../api/services/UpgradeSummaryService.java     |  6 +++---
 .../server/api/services/ValidationService.java  |  3 ++-
 .../api/services/VersionDefinitionService.java  | 11 +++++------
 .../server/api/services/ViewUrlsService.java    | 18 ++++++------------
 .../api/services/WidgetLayoutService.java       | 15 ++++++++-------
 .../server/api/services/WidgetService.java      | 15 ++++++++-------
 .../server/api/services/WorkflowService.java    |  5 +++--
 .../api/services/groups/GroupService.java       |  4 ++--
 .../api/services/groups/MemberService.java      |  5 +++--
 .../server/api/services/users/UserService.java  |  3 ++-
 .../views/ViewExternalSubResourceService.java   |  5 ++---
 .../api/services/views/ViewInstanceService.java |  7 +++----
 .../services/views/ViewPermissionService.java   |  9 ++++-----
 .../services/views/ViewPrivilegeService.java    |  8 ++++----
 .../server/api/services/views/ViewService.java  | 10 ++++------
 .../api/services/views/ViewVersionService.java  | 11 ++++-------
 .../ambari/server/proxy/ProxyService.java       |  9 +++++----
 .../server/resources/api/rest/GetResource.java  |  5 ++---
 .../unsecured/rest/CertificateDownload.java     |  5 ++---
 .../unsecured/rest/CertificateSign.java         |  4 ++--
 .../security/unsecured/rest/ConnectionInfo.java |  5 ++---
 71 files changed, 301 insertions(+), 299 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/checkstyle.xml
----------------------------------------------------------------------
diff --git a/ambari-server/checkstyle.xml b/ambari-server/checkstyle.xml
index 97fdc2a..fb314bc 100644
--- a/ambari-server/checkstyle.xml
+++ b/ambari-server/checkstyle.xml
@@ -17,7 +17,7 @@
   -->
   <module name="TreeWalker">
     <module name="AvoidTransactionalOnPrivateMethodsCheck"/>
-    <!-- <module name="UndocumentedRestApiOperationCheck"/> Swagger - uncomment when API documentation is done -->
+    <module name="UndocumentedRestApiOperationCheck"/> <!-- Swagger -->
 
     <module name="FallThrough"/>
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/agent/rest/AgentResource.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/agent/rest/AgentResource.java b/ambari-server/src/main/java/org/apache/ambari/server/agent/rest/AgentResource.java
index a332459..4f63df9 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/agent/rest/AgentResource.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/agent/rest/AgentResource.java
@@ -29,6 +29,7 @@ import javax.ws.rs.WebApplicationException;
 import javax.ws.rs.core.Context;
 import javax.ws.rs.core.MediaType;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.AmbariException;
 import org.apache.ambari.server.agent.ComponentsResponse;
 import org.apache.ambari.server.agent.HeartBeat;
@@ -81,7 +82,7 @@ public class AgentResource {
    * @throws Exception
    */
   @Path("register/{hostName}")
-  @POST
+  @POST @ApiIgnore // until documented
   @Consumes(MediaType.APPLICATION_JSON)
   @Produces({MediaType.APPLICATION_JSON})
   public RegistrationResponse register(Register message,
@@ -116,7 +117,7 @@ public class AgentResource {
    * @throws Exception
    */
   @Path("heartbeat/{hostName}")
-  @POST
+  @POST @ApiIgnore // until documented
   @Consumes(MediaType.APPLICATION_JSON)
   @Produces({MediaType.APPLICATION_JSON})
   public HeartBeatResponse heartbeat(HeartBeat message)
@@ -150,7 +151,7 @@ public class AgentResource {
    * @throws Exception
    */
   @Path("components/{clusterName}")
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces({MediaType.APPLICATION_JSON})
   public ComponentsResponse components(
       @PathParam("clusterName") String clusterName) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/rest/BootStrapResource.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/rest/BootStrapResource.java b/ambari-server/src/main/java/org/apache/ambari/server/api/rest/BootStrapResource.java
index 1bf22b1..d9852d8 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/rest/BootStrapResource.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/rest/BootStrapResource.java
@@ -35,6 +35,7 @@ import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.bootstrap.BSHostStatus;
 import org.apache.ambari.server.bootstrap.BSResponse;
 import org.apache.ambari.server.bootstrap.BootStrapImpl;
@@ -64,7 +65,7 @@ public class BootStrapResource {
    * @response.representation.408.doc Request Timed out
    * @throws Exception
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Consumes(MediaType.APPLICATION_JSON)
   @Produces({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
   public BSResponse bootStrap(SshHostInfo sshInfo, @Context UriInfo uriInfo) {
@@ -85,7 +86,7 @@ public class BootStrapResource {
    * @response.representation.408.doc Request Timed out
    * @throws Exception
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("/{requestId}")
   @Produces({MediaType.APPLICATION_JSON, MediaType.APPLICATION_XML})
   public BootStrapStatus getBootStrapStatus(@PathParam("requestId")
@@ -96,13 +97,12 @@ public class BootStrapResource {
     return status;
   }
 
-
   /**
    * Gets a list of bootstrapped hosts.
    *
    * @param uriInfo the host info, with no SSL key information
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("/hosts")
   @Produces(MediaType.APPLICATION_JSON)
   public List<BSHostStatus> getBootStrapHosts(@Context UriInfo uriInfo) {
@@ -118,7 +118,7 @@ public class BootStrapResource {
    *
    * @param info  the host info, with no SSL key information required
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("/hosts")
   @Produces(MediaType.APPLICATION_JSON)
   public List<BSHostStatus> getBootStrapHosts(SshHostInfo info, @Context UriInfo uriInfo) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/rest/HealthCheck.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/rest/HealthCheck.java b/ambari-server/src/main/java/org/apache/ambari/server/api/rest/HealthCheck.java
index 4c7c5e8..b884b03 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/rest/HealthCheck.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/rest/HealthCheck.java
@@ -23,6 +23,8 @@ import javax.ws.rs.Path;
 import javax.ws.rs.Produces;
 import javax.ws.rs.core.MediaType;
 
+import org.apache.ambari.annotations.ApiIgnore;
+
 /**
  * A simple POJO to do a health check on the server to see if its running
  * or not
@@ -33,21 +35,21 @@ public class HealthCheck {
   private static final String status = "RUNNING";
   // This method is called if TEXT_PLAIN is request
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces(MediaType.TEXT_PLAIN)
   public String plainTextCheck() {
     return status;
   }
 
   // This method is called if XML is request
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces(MediaType.TEXT_XML)
   public String xmlCheck() {
     return "<?xml version=\"1.0\"?>" + "<status> " + status + "</status>";
   }
 
   // This method is called if HTML is request
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces(MediaType.TEXT_HTML)
   public String  htmlCheck() {
     return "<html> " + "<title>" + "Status" + "</title>"

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/rest/KdcServerReachabilityCheck.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/rest/KdcServerReachabilityCheck.java b/ambari-server/src/main/java/org/apache/ambari/server/api/rest/KdcServerReachabilityCheck.java
index b4f1fe1..5143a0c 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/rest/KdcServerReachabilityCheck.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/rest/KdcServerReachabilityCheck.java
@@ -27,6 +27,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.KdcServerConnectionVerification;
 import org.apache.ambari.server.StaticallyInject;
 
@@ -44,7 +45,6 @@ public class KdcServerReachabilityCheck {
   @Inject
   private static KdcServerConnectionVerification kdcConnectionChecker;
 
-
   /**
    * Handles: GET /kdc_check/{hosts}
    * Checks the reachability of the given KDC server(s). If a list of hosts is sent, checks will be
@@ -56,7 +56,7 @@ public class KdcServerReachabilityCheck {
    *                     Each entry may contain port separate by a colon (:)
    * @return status whether KDC server is reachable or not
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{hosts}")
   @Produces(MediaType.TEXT_PLAIN)
   public String plainTextCheck(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -81,9 +81,8 @@ public class KdcServerReachabilityCheck {
     return status;
   }
 
-
   // This method is called if XML is request
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{hostname}")
   @Produces(MediaType.TEXT_XML)
   public String xmlCheck(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -99,7 +98,7 @@ public class KdcServerReachabilityCheck {
   }
 
   // This method is called if HTML is request
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{hostname}")
   @Produces(MediaType.TEXT_HTML)
   public String  htmlCheck(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -116,5 +115,4 @@ public class KdcServerReachabilityCheck {
     .toString();
   }
 
-
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertDefinitionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertDefinitionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertDefinitionService.java
index bf9741a..7e78c7b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertDefinitionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertDefinitionService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -46,7 +47,7 @@ public class AlertDefinitionService extends BaseService {
     this.clusterName = clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getDefinitions(@Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -54,7 +55,7 @@ public class AlertDefinitionService extends BaseService {
       createResourceInstance(clusterName, null));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createDefinition(String body,
       @Context HttpHeaders headers,
@@ -63,7 +64,7 @@ public class AlertDefinitionService extends BaseService {
       createResourceInstance(clusterName, null));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{alertDefinitionId}")
   @Produces("text/plain")
   public Response updateDefinition(String body,
@@ -74,7 +75,7 @@ public class AlertDefinitionService extends BaseService {
       createResourceInstance(clusterName, id));
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{alertDefinitionId}")
   @Produces("text/plain")
   public Response deleteDefinition(String body,
@@ -85,8 +86,7 @@ public class AlertDefinitionService extends BaseService {
       createResourceInstance(clusterName, id));
   }
 
-
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{alertDefinitionId}")
   @Produces("text/plain")
   public Response getDefinitions(@Context HttpHeaders headers,
@@ -96,7 +96,6 @@ public class AlertDefinitionService extends BaseService {
       createResourceInstance(clusterName, id));
   }
 
-
   /**
    * Create a request schedule resource instance
    */

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertGroupService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertGroupService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertGroupService.java
index be1c65c..de04cf7 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertGroupService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertGroupService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -55,7 +56,7 @@ public class AlertGroupService extends BaseService {
     m_clusterName = clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getGroups(@Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -63,7 +64,7 @@ public class AlertGroupService extends BaseService {
         createAlertGroupResource(m_clusterName, null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{groupId}")
   public Response getGroup(@Context HttpHeaders headers,
@@ -72,7 +73,7 @@ public class AlertGroupService extends BaseService {
         createAlertGroupResource(m_clusterName, groupId));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createGroup(String body, @Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -80,7 +81,7 @@ public class AlertGroupService extends BaseService {
         createAlertGroupResource(m_clusterName, null));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{groupId}")
   public Response updateGroup(String body, @Context HttpHeaders headers,
@@ -89,7 +90,7 @@ public class AlertGroupService extends BaseService {
         createAlertGroupResource(m_clusterName, groupId));
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{groupId}")
   public Response deleteGroup(String body, @Context HttpHeaders headers,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertHistoryService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertHistoryService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertHistoryService.java
index 17733a2..0c6afc9 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertHistoryService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertHistoryService.java
@@ -29,6 +29,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -58,7 +59,7 @@ public class AlertHistoryService extends BaseService {
     this.hostName = hostName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getHistories(@Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -66,7 +67,7 @@ public class AlertHistoryService extends BaseService {
         createResourceInstance(clusterName, null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{alertHistoryId}")
   @Produces("text/plain")
   public Response getHistory(

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertNoticeService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertNoticeService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertNoticeService.java
index 2bbc51f..afa0098 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertNoticeService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertNoticeService.java
@@ -29,6 +29,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -49,7 +50,7 @@ public class AlertNoticeService extends BaseService {
     this.clusterName = clusterName;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getNotices(
       @Context HttpHeaders headers,
@@ -58,7 +59,7 @@ public class AlertNoticeService extends BaseService {
         createResourceInstance(clusterName, null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{alertNoticeId}")
   @Produces("text/plain")
   public Response getNotice(

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertService.java
index 9922359..5abe059 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertService.java
@@ -29,6 +29,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -50,7 +51,7 @@ public class AlertService extends BaseService {
   /**
    * Gets all the definitions for the target
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getAlerts(
       @Context HttpHeaders headers,
@@ -59,11 +60,10 @@ public class AlertService extends BaseService {
       createResourceInstance(null));
   }
 
-
   /**
    * Gets a specific alert's instance
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{alertId}")
   @Produces("text/plain")
   public Response getAlert(
@@ -74,7 +74,6 @@ public class AlertService extends BaseService {
       createResourceInstance(id));
   }
 
-
   /**
    * Create an alert resource instance
    * @param alertId the alert id, if requesting a specific one

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertTargetService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertTargetService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertTargetService.java
index f00dfbb..69ef5ee 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertTargetService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AlertTargetService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 import org.apache.ambari.server.state.alert.AlertTarget;
@@ -43,7 +44,7 @@ import org.apache.ambari.server.state.alert.AlertTarget;
 @Path("/alert_targets/")
 public class AlertTargetService extends BaseService {
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getTargets(@Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -51,7 +52,7 @@ public class AlertTargetService extends BaseService {
         createAlertTargetResource(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{targetId}")
   public Response getTargets(@Context HttpHeaders headers,
@@ -60,7 +61,7 @@ public class AlertTargetService extends BaseService {
         createAlertTargetResource(targetId));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createTarget(String body, @Context HttpHeaders headers,
       @Context UriInfo ui) {
@@ -68,7 +69,7 @@ public class AlertTargetService extends BaseService {
         createAlertTargetResource(null));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{targetId}")
   public Response updateGroup(String body, @Context HttpHeaders headers,
@@ -77,7 +78,7 @@ public class AlertTargetService extends BaseService {
         createAlertTargetResource(targetId));
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{targetId}")
   public Response deleteTarget(String body, @Context HttpHeaders headers,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterKerberosDescriptorService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterKerberosDescriptorService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterKerberosDescriptorService.java
index 0aeb52b..3895f87 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterKerberosDescriptorService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterKerberosDescriptorService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -66,7 +67,7 @@ public class ClusterKerberosDescriptorService extends BaseService {
    * @param ui      uri info
    * @return Kerberos descriptor resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getKerberosDescriptors(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(null));
@@ -81,7 +82,7 @@ public class ClusterKerberosDescriptorService extends BaseService {
    * @param type    Kerberos descriptor type (COMPOSITE, STACK, USER)
    * @return Kerberos descriptor instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{type}")
   @Produces("text/plain")
   public Response getKerberosDescriptor(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -89,7 +90,6 @@ public class ClusterKerberosDescriptorService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(type));
   }
 
-
   /**
    * Create a composite Kerberos Descriptor resource instance.
    *

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterStackVersionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterStackVersionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterStackVersionService.java
index eafc076..9d85d80 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterStackVersionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ClusterStackVersionService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -61,7 +62,7 @@ public class ClusterStackVersionService extends BaseService {
    *
    * @return information regarding all cluster stack versions
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getClusterStackVersions(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(null));
@@ -77,7 +78,7 @@ public class ClusterStackVersionService extends BaseService {
    *
    * @return information regarding the specific cluster stack version
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{stackVersionId}")
   @Produces("text/plain")
   public Response getClusterStackVersion(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -85,7 +86,6 @@ public class ClusterStackVersionService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(stackVersionId));
   }
 
-
   /**
    * Gets the cluster stack versions service.
    *
@@ -105,7 +105,6 @@ public class ClusterStackVersionService extends BaseService {
     return new RepositoryVersionService(mapIds);
   }
 
-
   /**
    * Handles: POST /{clustername}/stack_versions requests
    * Distribute repositories/install packages.
@@ -115,13 +114,12 @@ public class ClusterStackVersionService extends BaseService {
    * @param ui          uri info
    * @return information regarding the created services
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createRequests(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST, createResource(null));
   }
 
-
   /**
    * Handles: POST /{clustername}/stack_versions requests
    * triggering Finalize during manual Stack Upgrade
@@ -131,7 +129,7 @@ public class ClusterStackVersionService extends BaseService {
    * @param ui          uri info
    * @return information regarding the created services
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateRequests(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.PUT, createResource(null));

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/CompatibleRepositoryVersionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/CompatibleRepositoryVersionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/CompatibleRepositoryVersionService.java
index 5927f8b..813013b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/CompatibleRepositoryVersionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/CompatibleRepositoryVersionService.java
@@ -29,6 +29,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -58,7 +59,7 @@ public class CompatibleRepositoryVersionService extends BaseService {
    * @param headers http headers
    * @param ui      uri info
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getRepositoryVersions(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(null));
@@ -73,7 +74,7 @@ public class CompatibleRepositoryVersionService extends BaseService {
    * @param repositoryVersionId   the repository version id
    * @return information regarding the specified repository
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{repositoryVersionId}")
   @Produces("text/plain")
   public Response getRepositoryVersion(@Context HttpHeaders headers,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ComponentService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ComponentService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ComponentService.java
index 800e011..b489a15 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ComponentService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ComponentService.java
@@ -38,6 +38,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.configuration.Configuration;
 import org.apache.ambari.server.controller.spi.Resource;
@@ -78,7 +79,7 @@ public class ComponentService extends BaseService {
    * @param componentName component id
    * @return a component resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{componentName}")
   @Produces("text/plain")
   public Response getComponent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -99,7 +100,7 @@ public class ComponentService extends BaseService {
    * @param ui      uri info
    * @return component collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui,
                                  @QueryParam("format") String format) {
@@ -122,7 +123,7 @@ public class ComponentService extends BaseService {
    *
    * @return status code only, 201 if successful
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -141,7 +142,7 @@ public class ComponentService extends BaseService {
    *
    * @return information regarding the created component
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{componentName}")
   @Produces("text/plain")
   public Response createComponent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -162,7 +163,7 @@ public class ComponentService extends BaseService {
    *
    * @return information regarding the updated component
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{componentName}")
   @Produces("text/plain")
   public Response updateComponent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -182,7 +183,7 @@ public class ComponentService extends BaseService {
    *
    * @return information regarding the updated component
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -199,7 +200,7 @@ public class ComponentService extends BaseService {
    * @param componentName cluster id
    * @return information regarding the deleted cluster
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{componentName}")
   @Produces("text/plain")
   public Response deleteComponent(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigGroupService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigGroupService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigGroupService.java
index 5c52718..c758b7a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigGroupService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigGroupService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -60,7 +61,7 @@ public class ConfigGroupService extends BaseService {
    * @param ui
    * @return
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getConfigGroups(String body, @Context HttpHeaders headers,
                                   @Context UriInfo ui) {
@@ -74,7 +75,7 @@ public class ConfigGroupService extends BaseService {
    *
    * @return
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{groupId}")
   @Produces("text/plain")
   public Response getConfigGroup(String body, @Context HttpHeaders headers,
@@ -92,7 +93,7 @@ public class ConfigGroupService extends BaseService {
    * @param ui
    * @return
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createConfigGroup(String body, @Context HttpHeaders headers,
                                     @Context UriInfo ui) {
@@ -110,7 +111,7 @@ public class ConfigGroupService extends BaseService {
    * @param groupId
    * @return
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{groupId}")
   @Produces("text/plain")
   public Response updateConfigGroup(String body, @Context HttpHeaders
@@ -128,7 +129,7 @@ public class ConfigGroupService extends BaseService {
    * @param groupId
    * @return
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{groupId}")
   @Produces("text/plain")
   public Response deleteConfigGroup(@Context HttpHeaders headers,
@@ -138,7 +139,6 @@ public class ConfigGroupService extends BaseService {
       createConfigGroupResource(m_clusterName, groupId));
   }
 
-
   /**
    * Create a request resource instance.
    *

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigurationService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigurationService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigurationService.java
index c256eca..0eb8bd6 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigurationService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ConfigurationService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -64,7 +65,7 @@ public class ConfigurationService extends BaseService {
    * @param ui      uri info
    * @return service collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getConfigurations(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET, createConfigurationResource(m_clusterName));
@@ -92,7 +93,7 @@ public class ConfigurationService extends BaseService {
    * @param ui      uri info
    * @return status code only, 201 if successful
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createConfigurations(String body,@Context HttpHeaders headers, @Context UriInfo ui) {
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/CredentialService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/CredentialService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/CredentialService.java
index 449c292..40f1252 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/CredentialService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/CredentialService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -55,7 +56,7 @@ public class CredentialService extends BaseService {
    * @param ui      uri info
    * @return credential collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getCredentials(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createCredentialResource(null));
@@ -70,7 +71,7 @@ public class CredentialService extends BaseService {
    * @param alias   alias (or credential ID)
    * @return credential instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{alias}")
   @Produces("text/plain")
   public Response getCredential(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -87,7 +88,7 @@ public class CredentialService extends BaseService {
    * @param alias   alias (or credential ID)
    * @return information regarding the created credential
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{alias}")
   @Produces("text/plain")
   public Response createCredential(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -104,7 +105,7 @@ public class CredentialService extends BaseService {
    * @param alias   alias (or credential ID)
    * @return information regarding the created credential
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{alias}")
   @Produces("text/plain")
   public Response updateCredential(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -121,7 +122,7 @@ public class CredentialService extends BaseService {
    * @param alias   alias (or credential ID)
    * @return information regarding the deleted credential
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{alias}")
   @Produces("text/plain")
   public Response deleteCredential(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionLinksService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionLinksService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionLinksService.java
index 1acccd8..145b552 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionLinksService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionLinksService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -46,14 +47,14 @@ import org.apache.ambari.server.controller.spi.Resource;
 @Path("/links/")
 public class ExtensionLinksService extends BaseService {
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getExtensionLinks(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
     return handleRequest(headers, body, ui, Request.Type.GET, createExtensionLinkResource(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{linkId}")
   @Produces("text/plain")
   public Response getExtensionLink(String body, @Context HttpHeaders headers,
@@ -62,13 +63,13 @@ public class ExtensionLinksService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.GET, createExtensionLinkResource(linkId));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createExtensionLink(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST, createExtensionLinkResource(null));
   }
 
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{linkId}")
   @Produces("text/plain")
   public Response deleteExtensionLink(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -77,13 +78,13 @@ public class ExtensionLinksService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createExtensionLinkResource(linkId));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateExtensionLink(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.PUT, createExtensionLinkResource(null));
   }
 
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{linkId}")
   @Produces("text/plain")
   public Response updateExtensionLink(String body, @Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionsService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionsService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionsService.java
index 2fedd54..f0c2aea 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionsService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ExtensionsService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -44,7 +45,7 @@ import org.apache.ambari.server.controller.spi.Resource;
 @Path("/extensions/")
 public class ExtensionsService extends BaseService {
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getExtensions(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -52,7 +53,7 @@ public class ExtensionsService extends BaseService {
         createExtensionResource(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{extensionName}")
   @Produces("text/plain")
   public Response getExtension(String body, @Context HttpHeaders headers,
@@ -63,7 +64,7 @@ public class ExtensionsService extends BaseService {
         createExtensionResource(extensionName));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{extensionName}/versions")
   @Produces("text/plain")
   public Response getExtensionVersions(String body,
@@ -74,7 +75,7 @@ public class ExtensionsService extends BaseService {
         createExtensionVersionResource(extensionName, null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{extensionName}/versions/{extensionVersion}")
   @Produces("text/plain")
   public Response getExtensionVersion(String body,
@@ -86,7 +87,7 @@ public class ExtensionsService extends BaseService {
         createExtensionVersionResource(extensionName, extensionVersion));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{extensionName}/versions/{extensionVersion}/links")
   @Produces("text/plain")
   public Response getExtensionVersionLinks(String body,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/FeedService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/FeedService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/FeedService.java
index 73b9960..341bdef 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/FeedService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/FeedService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -50,7 +51,7 @@ public class FeedService extends BaseService {
    * @param feedName    feed id
    * @return feed instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{feedName}")
   @Produces("text/plain")
   public Response getFeed(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -67,7 +68,7 @@ public class FeedService extends BaseService {
    * @param ui      uri info
    * @return feed collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getFeeds(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET, createFeedResource(null));
@@ -82,7 +83,7 @@ public class FeedService extends BaseService {
    * @param feedName feed id
    * @return information regarding the created feed
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{feedName}")
   @Produces("text/plain")
   public Response createFeed(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -100,7 +101,7 @@ public class FeedService extends BaseService {
    * @param feedName feed id
    * @return information regarding the updated feed
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{feedName}")
   @Produces("text/plain")
   public Response updateFeed(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -118,7 +119,7 @@ public class FeedService extends BaseService {
    * @param feedName feed id
    * @return information regarding the deleted feed
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{feedName}")
   @Produces("text/plain")
   public Response deleteFeed(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostComponentService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostComponentService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostComponentService.java
index 6288972..a5e9aec 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostComponentService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostComponentService.java
@@ -38,6 +38,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.configuration.Configuration;
 import org.apache.ambari.server.controller.spi.Resource;
@@ -78,7 +79,7 @@ public class HostComponentService extends BaseService {
    * @param hostComponentName host_component id
    * @return host_component resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{hostComponentName}")
   @Produces("text/plain")
   public Response getHostComponent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -107,7 +108,7 @@ public class HostComponentService extends BaseService {
    * @param ui      uri info
    * @return host_component collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getHostComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui, @QueryParam("format") String format) {
     if (format != null && format.equals("client_config_tar")) {
@@ -128,7 +129,7 @@ public class HostComponentService extends BaseService {
    *
    * @return status code only, 201 if successful
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createHostComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -147,7 +148,7 @@ public class HostComponentService extends BaseService {
    *
    * @return host_component resource representation
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{hostComponentName}")
   @Produces("text/plain")
   public Response createHostComponent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -168,7 +169,7 @@ public class HostComponentService extends BaseService {
    *
    * @return information regarding updated host_component
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{hostComponentName}")
   @Produces("text/plain")
   public Response updateHostComponent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -188,7 +189,7 @@ public class HostComponentService extends BaseService {
    *
    * @return information regarding updated host_component resources
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updateHostComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -206,7 +207,7 @@ public class HostComponentService extends BaseService {
    *
    * @return host_component resource representation
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{hostComponentName}")
   @Produces("text/plain")
   public Response deleteHostComponent(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -225,7 +226,7 @@ public class HostComponentService extends BaseService {
    *
    * @return host_component resource representation
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Produces("text/plain")
   public Response deleteHostComponents(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -233,7 +234,7 @@ public class HostComponentService extends BaseService {
         createHostComponentResource(m_clusterName, m_hostName, null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{hostComponentName}/processes")
   @Produces("text/plain")
   public Response getProcesses(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -273,7 +274,6 @@ public class HostComponentService extends BaseService {
     mapIds.put(Resource.Type.Host, m_hostName);
     mapIds.put(Resource.Type.Component, hostComponentName);
 
-
     Response response = handleRequest(headers, body, ui, Request.Type.GET,
             createResource(Resource.Type.ClientConfig, mapIds));
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostKerberosIdentityService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostKerberosIdentityService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostKerberosIdentityService.java
index a99d269..3907fc3 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostKerberosIdentityService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostKerberosIdentityService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -71,7 +72,7 @@ public class HostKerberosIdentityService extends BaseService {
    * @param format     output format
    * @return a component resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{kerberosIdentityID}")
   @Produces("text/plain")
   public Response getKerberosIdentity(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -96,7 +97,7 @@ public class HostKerberosIdentityService extends BaseService {
    * @param ui      uri info
    * @return component collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getKerberosIdentities(String body, @Context HttpHeaders headers, @Context UriInfo ui, @QueryParam("format") String format) {
     return getKerberosIdentity(body, headers, ui, null, format);

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostStackVersionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostStackVersionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostStackVersionService.java
index bce51c4..29566ed 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostStackVersionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/HostStackVersionService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -66,7 +67,7 @@ public class HostStackVersionService extends BaseService {
    *
    * @return information regarding all host stack versions
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getHostStackVersions(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(ui, clusterName, hostName, null));
@@ -82,7 +83,7 @@ public class HostStackVersionService extends BaseService {
    *
    * @return information regarding the specific host stack version
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{stackVersionId}")
   @Produces("text/plain")
   public Response getHostStackVersion(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -99,7 +100,7 @@ public class HostStackVersionService extends BaseService {
    * @param ui          uri info
    * @return information regarding the created services
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createRequests(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.POST, createResource(ui, clusterName, hostName, null));

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/InstanceService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/InstanceService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/InstanceService.java
index 760ee24..292e38d 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/InstanceService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/InstanceService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -72,7 +73,7 @@ public class InstanceService extends BaseService {
    *
    * @return instance resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{instanceID}")
   @Produces("text/plain")
   public Response getInstance(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -90,7 +91,7 @@ public class InstanceService extends BaseService {
    * @param ui      uri info
    * @return instance collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getInstances(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET,
@@ -108,7 +109,7 @@ public class InstanceService extends BaseService {
    *
    * @return instance resource representation
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{instanceID}")
   @Produces("text/plain")
   public Response createInstance(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -129,7 +130,7 @@ public class InstanceService extends BaseService {
    *
    * @return information regarding updated instance
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{instanceID}")
   @Produces("text/plain")
   public Response updateInstance(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -149,7 +150,7 @@ public class InstanceService extends BaseService {
    *
    * @return instance resource representation
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{instanceID}")
   @Produces("text/plain")
   public Response deleteInstance(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/JobService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/JobService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/JobService.java
index bb882f1..51022a7 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/JobService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/JobService.java
@@ -30,6 +30,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -64,7 +65,7 @@ public class JobService extends BaseService {
    *          job id
    * @return job instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{jobId}")
   @Produces("text/plain")
   public Response getJob(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -82,7 +83,7 @@ public class JobService extends BaseService {
    *          uri info
    * @return job collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getJobs(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/KerberosDescriptorService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/KerberosDescriptorService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/KerberosDescriptorService.java
index 5f20c4f..6500514 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/KerberosDescriptorService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/KerberosDescriptorService.java
@@ -13,6 +13,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -45,13 +46,13 @@ public class KerberosDescriptorService extends BaseService {
    * @param ui      uri info
    * @return a collection of kerberos descriptors
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getKerberosDescriptors(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.GET, createKerberosDescriptorResource(null));
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{kerberosDescriptorName}")
   @Produces("text/plain")
   public Response getKerberosDescriptor(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -59,7 +60,7 @@ public class KerberosDescriptorService extends BaseService {
     return handleRequest(headers, body, ui, Request.Type.GET, createKerberosDescriptorResource(kerberosDescriptorName));
   }
 
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{kerberosDescriptorName}")
   @Produces("text/plain")
   public Response createKerberosDescriptor(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -76,7 +77,7 @@ public class KerberosDescriptorService extends BaseService {
    * @param kerberosDescriptorName kerebros descriptor name
    * @return information regarding the deleted kerberos descriptor
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{kerberosDescriptorName}")
   @Produces("text/plain")
   public Response deleteKerberosDescriptor(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/KeyService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/KeyService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/KeyService.java
index 9ddcc79..9cfa2a9 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/KeyService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/KeyService.java
@@ -26,6 +26,7 @@ import javax.ws.rs.PathParam;
 import javax.ws.rs.Produces;
 import javax.xml.bind.JAXBException;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.utils.StageUtils;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -43,7 +44,7 @@ public class KeyService {
   }
 
   @Path("{number}")
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public String getKeys(@PathParam("number") int number) throws IOException, JAXBException {
     Collection<String> keys = persistKeyVal.generateKeys(number);

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/LdapSyncEventService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/LdapSyncEventService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/LdapSyncEventService.java
index cef4a60..723e8df 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/LdapSyncEventService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/LdapSyncEventService.java
@@ -32,6 +32,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -50,7 +51,7 @@ public class LdapSyncEventService extends BaseService {
    *
    * @return view instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{eventId}")
   @Produces("text/plain")
   public Response getEvent(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -68,7 +69,7 @@ public class LdapSyncEventService extends BaseService {
    *
    * @return view collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getEvents(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createEventResource(null));
@@ -83,7 +84,7 @@ public class LdapSyncEventService extends BaseService {
    *
    * @return information regarding the created view
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createEvent(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -100,7 +101,7 @@ public class LdapSyncEventService extends BaseService {
    *
    * @return information regarding the updated event
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{eventId}")
   @Produces("text/plain")
   public Response updateEvent(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -119,7 +120,7 @@ public class LdapSyncEventService extends BaseService {
    *
    * @return information regarding the deleted event
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{eventId}")
   @Produces("text/plain")
   public Response deleteEvent(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -128,7 +129,6 @@ public class LdapSyncEventService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createEventResource(eventId));
   }
 
-
   // ----- helper methods ----------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/LoggingService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/LoggingService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/LoggingService.java
index a95aed8..c86b9a0 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/LoggingService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/LoggingService.java
@@ -34,6 +34,7 @@ import javax.ws.rs.core.MultivaluedMap;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.AmbariException;
 import org.apache.ambari.server.api.services.serializers.ResultSerializer;
 import org.apache.ambari.server.controller.AmbariManagementController;
@@ -72,7 +73,6 @@ public class LoggingService extends BaseService {
   @Inject
   private LoggingRequestHelperFactory helperFactory;
 
-
   private final String clusterName;
 
   public LoggingService(String clusterName) {
@@ -84,7 +84,7 @@ public class LoggingService extends BaseService {
     this.controllerFactory = controllerFactory;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("searchEngine")
   @Produces("text/plain")
   public Response getSearchEngine(String body, @Context HttpHeaders headers, @Context UriInfo uri) throws AuthorizationException {
@@ -149,7 +149,6 @@ public class LoggingService extends BaseService {
     Map<String, String> enumeratedQueryParameters =
       new HashMap<>();
 
-
     for (String queryName : queryParameters.keySet()) {
       List<String> queryValue = queryParameters.get(queryName);
       for (String value : queryValue) {
@@ -188,7 +187,6 @@ public class LoggingService extends BaseService {
         Response.ResponseBuilder builder = Response.status(result.getStatus().getStatusCode()).entity(
           serializer.serialize(result));
 
-
         if (mediaType != null) {
           builder.type(mediaType);
         }

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/LogoutService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/LogoutService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/LogoutService.java
index f2f5e0e..28c21e8 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/LogoutService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/LogoutService.java
@@ -24,6 +24,7 @@ import javax.ws.rs.Produces;
 import javax.ws.rs.core.Context;
 import javax.ws.rs.core.Response;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.StaticallyInject;
 import org.apache.ambari.server.audit.AuditLogger;
 import org.apache.ambari.server.audit.event.LogoutAuditEvent;
@@ -43,7 +44,7 @@ public class LogoutService {
   @Inject
   private static AuditLogger auditLogger;
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response performLogout(@Context HttpServletRequest servletRequest) {
     auditLog(servletRequest);

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/OperatingSystemService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/OperatingSystemService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/OperatingSystemService.java
index d6d786e..4a6032e 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/OperatingSystemService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/OperatingSystemService.java
@@ -29,6 +29,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -58,7 +59,7 @@ public class OperatingSystemService extends BaseService {
    * @param headers http headers
    * @param ui      uri info
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getOperatingSystems(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource(null));
@@ -73,7 +74,7 @@ public class OperatingSystemService extends BaseService {
    * @param osType  os type
    * @return information regarding the specified operating system
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{osType}")
   @Produces("text/plain")
   public Response getOperatingSystem(@Context HttpHeaders headers, @Context UriInfo ui, @PathParam("osType") String osType) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/PermissionService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PermissionService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PermissionService.java
index 18a32a1..27bcafb 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PermissionService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PermissionService.java
@@ -32,10 +32,10 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
-
 /**
  * Service responsible for permission resource requests.
  */
@@ -52,7 +52,7 @@ public class PermissionService extends BaseService {
    *
    * @return permission instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response getPermission(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -70,7 +70,7 @@ public class PermissionService extends BaseService {
    *
    * @return permission collection resource representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getPermissions(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createPermissionResource(null));
@@ -86,7 +86,7 @@ public class PermissionService extends BaseService {
    *
    * @return information regarding the created permission
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response createPermission(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -105,7 +105,7 @@ public class PermissionService extends BaseService {
    *
    * @return information regarding the updated permission
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response updatePermission(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -124,7 +124,7 @@ public class PermissionService extends BaseService {
    *
    * @return information regarding the deleted permission
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{permissionId}")
   @Produces("text/plain")
   public Response deletePermission(@Context HttpHeaders headers, @Context UriInfo ui,

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/PersistKeyValueService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PersistKeyValueService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PersistKeyValueService.java
index 59b1d4e..e068bb7 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PersistKeyValueService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PersistKeyValueService.java
@@ -33,6 +33,7 @@ import javax.ws.rs.WebApplicationException;
 import javax.ws.rs.core.Response;
 import javax.xml.bind.JAXBException;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.state.fsm.InvalidStateTransitionException;
 import org.apache.ambari.server.utils.StageUtils;
 import org.slf4j.Logger;
@@ -51,7 +52,7 @@ public class PersistKeyValueService {
   }
 
   @SuppressWarnings("unchecked")
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response update(String keyValues)
       throws WebApplicationException, InvalidStateTransitionException,
@@ -67,7 +68,7 @@ public class PersistKeyValueService {
   }
 
   @SuppressWarnings("unchecked")
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public String store(String values) throws IOException, JAXBException {
     LOG.debug("Received message from UI {}", values);
@@ -81,7 +82,7 @@ public class PersistKeyValueService {
     return stringRet;
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   @Path("{keyName}")
   public String getKey( @PathParam("keyName") String keyName) {
@@ -89,7 +90,7 @@ public class PersistKeyValueService {
     return persistKeyVal.getValue(keyName);
   }
 
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public String getAllKeyValues() throws JAXBException, IOException {
     Map<String, String> ret = persistKeyVal.getAllKeyValues();

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/PreUpgradeCheckService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PreUpgradeCheckService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PreUpgradeCheckService.java
index c4127a8..c7e23ac 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PreUpgradeCheckService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PreUpgradeCheckService.java
@@ -26,6 +26,7 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -55,7 +56,7 @@ public class PreUpgradeCheckService extends BaseService {
    * @param ui uri info
    * @return information about upgrade checks
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getPreUpgradeChecks(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createResource());

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/PrivilegeService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PrivilegeService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PrivilegeService.java
index f16d24c..84075ab 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/PrivilegeService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/PrivilegeService.java
@@ -30,9 +30,9 @@ import javax.ws.rs.core.HttpHeaders;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 
-
 /**
  * Service responsible for privilege requests.
  */
@@ -48,7 +48,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return privilege instance representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Path("{privilegeId}")
   @Produces("text/plain")
   public Response getPrivilege(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -66,7 +66,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return privilege collection representation
    */
-  @GET
+  @GET @ApiIgnore // until documented
   @Produces("text/plain")
   public Response getPrivileges(@Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, null, ui, Request.Type.GET, createPrivilegeResource(null));
@@ -82,7 +82,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return information regarding the created privilege
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces("text/plain")
   public Response createPrivilege(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -99,7 +99,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return information regarding the updated privilege
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Path("{privilegeId}")
   @Produces("text/plain")
   public Response updatePrivilege(String body, @Context HttpHeaders headers, @Context UriInfo ui,
@@ -118,7 +118,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return information regarding the updated privileges
    */
-  @PUT
+  @PUT @ApiIgnore // until documented
   @Produces("text/plain")
   public Response updatePrivileges(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
     return handleRequest(headers, body, ui, Request.Type.PUT, createPrivilegeResource(null));
@@ -134,7 +134,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return information regarding the deleted privileges
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Produces("text/plain")
   public Response deletePrivileges(String body, @Context HttpHeaders headers, @Context UriInfo ui) {
 
@@ -151,7 +151,7 @@ public abstract class PrivilegeService extends BaseService {
    *
    * @return information regarding the deleted privilege
    */
-  @DELETE
+  @DELETE @ApiIgnore // until documented
   @Path("{privilegeId}")
   @Produces("text/plain")
   public Response deletePrivilege(@Context HttpHeaders headers, @Context UriInfo ui,
@@ -160,7 +160,6 @@ public abstract class PrivilegeService extends BaseService {
     return handleRequest(headers, null, ui, Request.Type.DELETE, createPrivilegeResource(privilegeId));
   }
 
-
   // ----- PrivilegeService --------------------------------------------------
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/965e4bd0/ambari-server/src/main/java/org/apache/ambari/server/api/services/RecommendationService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RecommendationService.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RecommendationService.java
index ce317b6..37f4a99 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/RecommendationService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/RecommendationService.java
@@ -31,6 +31,7 @@ import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
 import javax.ws.rs.core.UriInfo;
 
+import org.apache.ambari.annotations.ApiIgnore;
 import org.apache.ambari.server.api.resources.ResourceInstance;
 import org.apache.ambari.server.controller.spi.Resource;
 
@@ -51,7 +52,7 @@ public class RecommendationService extends BaseService {
    * @param stackVersion stack version
    * @return recommendations for host-layout
    */
-  @POST
+  @POST @ApiIgnore // until documented
   @Produces(MediaType.TEXT_PLAIN)
   public Response getRecommendation(String body, @Context HttpHeaders headers, @Context UriInfo ui,
       @PathParam("stackName") String stackName, @PathParam("stackVersion") String stackVersion) {


[06/11] ambari git commit: AMBARI-21264.Integrate new hdfs-file browser in WFD(Venkata Sairam)

Posted by rl...@apache.org.
AMBARI-21264.Integrate new hdfs-file browser in WFD(Venkata Sairam)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/b53cf918
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/b53cf918
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/b53cf918

Branch: refs/heads/branch-feature-AMBARI-20859
Commit: b53cf918fc27d55a11fae25af9c4eba6dcee26fb
Parents: 7335bf7
Author: Venkata Sairam <ve...@gmail.com>
Authored: Thu Jun 22 09:35:30 2017 +0530
Committer: Venkata Sairam <ve...@gmail.com>
Committed: Thu Jun 22 09:35:30 2017 +0530

----------------------------------------------------------------------
 .../resources/ui/app/components/hdfs-browser.js |   8 +-
 .../ui/app/services/workspace-manager.js        |   5 +
 .../src/main/resources/ui/app/styles/app.less   |   3 +-
 .../app/templates/components/hdfs-browser.hbs   |  16 +-
 .../main/resources/ui/app/utils/hdfsviewer.js   |   3 +
 .../wfmanager/src/main/resources/ui/bower.json  |   1 -
 .../addon/components/directory-viewer.js        | 325 +++++++++++++------
 .../hdfs-directory-viewer/addon/styles/app.css  | 189 +++++++++++
 .../templates/components/directory-viewer.hbs   | 146 +++++++++
 .../addon/utils/viewer-config.js                |   3 +
 .../hdfs-directory-viewer/bower.json            |   1 -
 .../hdfs-directory-viewer/index.js              |   3 -
 .../hdfs-directory-viewer/package.json          |   5 +-
 .../src/main/resources/ui/package.json          |   3 +-
 14 files changed, 582 insertions(+), 129 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/app/components/hdfs-browser.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/components/hdfs-browser.js b/contrib/views/wfmanager/src/main/resources/ui/app/components/hdfs-browser.js
index 0194f13..b1fb29a 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/components/hdfs-browser.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/components/hdfs-browser.js
@@ -20,6 +20,7 @@ import HdfsViewerConfig from '../utils/hdfsviewer';
 export default Ember.Component.extend({
   config: HdfsViewerConfig.create(),
   uploaderService : Ember.inject.service('hdfs-file-uploader'),
+  userInfo : Ember.inject.service('workspace-manager'),
   initialize:function(){
     var self=this;
     self.$("#filediv").modal("show");
@@ -27,8 +28,12 @@ export default Ember.Component.extend({
       self.sendAction('closeWorkflowSubmitConfigs');
       self.sendAction("closeFileBrowser");
     });
-
   }.on('didInsertElement'),
+  setUserData : function() {
+    this.set("homeDirectory", "/user/"+this.get("userInfo").getUserName());
+    this.set("selectedPath", "/user/"+this.get("userInfo").getUserName());
+    this.set("filePath", "/user/"+this.get("userInfo").getUserName());
+  }.on("init"),
   selectFileType: "all",//can be all/file/folder
   selectedPath:"",
   isDirectory:false,
@@ -81,6 +86,7 @@ export default Ember.Component.extend({
     },
     viewerSelectedPath(data) {
       this.set("selectedPath",data.path);
+      this.set("filePath",data.path);
       this.set("isDirectory",data.isDirectory);
       this.set("alertMessage",null);
     },

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/app/services/workspace-manager.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/services/workspace-manager.js b/contrib/views/wfmanager/src/main/resources/ui/app/services/workspace-manager.js
index 8636fd5..4ac5ae1 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/services/workspace-manager.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/services/workspace-manager.js
@@ -21,6 +21,7 @@ export default Ember.Service.extend({
   tabsInfo : {},
   workInProgress : {},
   userInfo : Ember.inject.service('user-info'),
+  userName : null,
   setLastActiveTab(tabId){
     this.get("userInfo").getUserData().then(function(data){
        localStorage.setItem(data+"-lastActiveTab", tabId);
@@ -38,6 +39,7 @@ export default Ember.Service.extend({
   restoreTabs(){
       var deferred = Ember.RSVP.defer();
       this.get("userInfo").getUserData().then(function(data){
+        this.set("userName", data);
         var tabs = localStorage.getItem(data+'-tabsInfo');
         deferred.resolve(JSON.parse(tabs));
       }.bind(this)).catch(function(e){
@@ -87,5 +89,8 @@ export default Ember.Service.extend({
     }.bind(this)).catch(function(e){
       console.error(e);
     });
+  },
+  getUserName(){
+   return this.get("userName");
   }
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/app/styles/app.less
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/styles/app.less b/contrib/views/wfmanager/src/main/resources/ui/app/styles/app.less
index 0603b57..597e2e8 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/styles/app.less
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/styles/app.less
@@ -1060,6 +1060,7 @@ input:invalid {
   width: 100%;
 }
 .hdfs-browse{
+  height: 500px;
   max-height: 500px;
   overflow: scroll;
 }
@@ -1369,7 +1370,7 @@ input:invalid {
 }
 
 #cyRenderer input:invalid {
-  border: 1px solid @defaultRed;
+  border: 2px solid @defaultRed;
 }
 
 .cy-panzoom-panner{

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/hdfs-browser.hbs
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/hdfs-browser.hbs b/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/hdfs-browser.hbs
index 5779e36..cbd2a1f 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/hdfs-browser.hbs
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/templates/components/hdfs-browser.hbs
@@ -53,26 +53,14 @@
         {{/unless}}
         <div class="panel-body">
           <div>
-            {{#if showUploadSuccess}}
-              <div id="success-alert"class="alert alert-success alert-dismissible fade in" role="alert">
-                <span>File uploaded</span>
-              </div>
-            {{/if}}
-            {{#if alertMessage}}
-              <div class="alert alert-{{alertType}} col-xs-24">
-                {{alertMessage}}
-                {{#if alertDetails}}
-                -{{alertDetails}}
-                {{/if}}
-              </div>
-
-            {{/if}}
           <div class="directory-viewer-wrap hdfs-browse">
             {{#directory-viewer
               config=config
               errorAction="viewerError"
               pathSelectAction="viewerSelectedPath"
               uploaderService=uploaderService
+              width=850
+              homeDirectory = homeDirectory
             }}{{/directory-viewer}}
           </div>
         </div>

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/app/utils/hdfsviewer.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/app/utils/hdfsviewer.js b/contrib/views/wfmanager/src/main/resources/ui/app/utils/hdfsviewer.js
index 080409b..5e30c60 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/app/utils/hdfsviewer.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/app/utils/hdfsviewer.js
@@ -25,5 +25,8 @@ export default ViewerConfig.extend({
 
   listDirectoryUrl(pathParams) {
     return   Ember.ENV.FILE_API_URL+`/fileops/listdir?${pathParams}`;
+  },
+  createDirectoryUrl() {
+    return Ember.ENV.FILE_API_URL+`/fileops/mkdir`;
   }
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/bower.json
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/bower.json b/contrib/views/wfmanager/src/main/resources/ui/bower.json
index 75ac7a7..06fc3e3 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/bower.json
+++ b/contrib/views/wfmanager/src/main/resources/ui/bower.json
@@ -19,7 +19,6 @@
     "eonasdan-bootstrap-datetimepicker": "~4.17.37",
     "code-prettify": "*",
     "abdmob/x2js": "~1.2.0",
-    "bootstrap-treeview": "~1.2.0",
     "datatables": "~1.10.11",
     "vkBeautify": "https://github.com/vkiryukhin/vkBeautify.git",
     "cytoscape": "~2.7.7",

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/components/directory-viewer.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/components/directory-viewer.js b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/components/directory-viewer.js
index 65746e8..2f2b547 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/components/directory-viewer.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/components/directory-viewer.js
@@ -21,30 +21,81 @@ import layout from '../templates/components/directory-viewer';
 
 export default Ember.Component.extend({
   layout,
+  counter: 0,
   config: Ember.Object.create({}),
   classNames: ['directory-viewer'],
   startPath: '/',
-  treeData: Ember.A(),
+  folderName:'',
+  isDirectory: true,
+  isFile: true,
+  fileBrowserHeight: '850',
+  fileBrowserWidth: '650',
+  maxBreadCrumbsCount: 3,
+  elipsisLength: 8,
+  isFolderCreationSuccess: null,
+  isFolderCreationFailure: null,
+  isFolderCreationprogress:false,
+  // homeDirectory: '/app-logs/cstm-hdfs/logs',
+  fileSystem: Ember.A(),
   currentPath: Ember.computed.oneWay('startPath'),
-  currentQueryParam: Ember.computed('currentPath', function() {
+  currentPathArray: [{'path':'/'}],
+  breadCrumbs: {},
+  isCreateFolder : false,
+  folderAccessError: {},
+  createFolderError: {},
+  filteredFileSytemInfo: Ember.computed('fileSystem', 'isDirectory', 'isFile', function() {
+    return this.get('fileSystem').filter( (record) => {
+      if(record.traverse) {
+         return true;
+      }
+      if(this.get('isDirectory') && this.get('isFile')) {
+         return record.isDirectory || !record.isDirectory;
+      }
+      if(this.get('isDirectory')) {
+         return record.isDirectory;
+      }
+      if(this.get('isFile')) {
+         return !record.isDirectory;
+      }
+      return;
+  });
+  }),
+  currentQueryParam: Ember.computed('currentPath', 'homeDirectory', function() {
+    if(this.get('counter') === 1 && this.get('homeDirectory')){
+      this.set('currentPath', this.get('homeDirectory'));
+    }
     return Ember.$.param({path: this.get('currentPath')});
   }),
-
+  createFolderQueryParam: Ember.computed('currentPath', 'homeDirectory', 'folderName', function() {
+    return {path: this.get('currentPath')+"/"+this.get('folderName')};
+  }),
+  isDataLoading: true,
   startFetch: Ember.on('didInitAttrs', function() {
-    this.get('uploaderService').on('uploadSuccess', function(){
-      this.fetchData();
-    }.bind(this));
+    if(this.get('width')) {
+      this.set('fileBrowserWidth', this.get('width'));
+    }
+    if(this.get('height')) {
+      this.set('fileBrowserHeight', this.get('height'));
+    }
     this.fetchData();
   }),
-
-
+  setFileBroswerHeightAndWidth: Ember.on('didInsertElement', function() {
+    Ember.$('.top-header, #file-view-unix').css('width', this.get('fileBrowserWidth'));
+  }),
   fetchData: function() {
+    this.incrementProperty('counter');
+    this.startFileSystemFetchProgress();
+    this.set('folderAccessError', {});
     this.listPath(this.get('currentQueryParam')).then(
       (response) => {
         let list = this.filterDirectoriesIfRequired(response.files);
-        this.modifyTreeViewData(list);
+        this.stopFileSystemFetchProgress();
+        this.modifyFileSystemData(list);
       }, (error) => {
+        this.set('folderAccessError', error.responseJSON);
         this.sendAction('errorAction', error);
+        this.set('errorMsg', 'Error while accessing.Please try again.');
+        this.stopFileSystemFetchProgress();
       }
     );
   },
@@ -60,7 +111,29 @@ export default Ember.Component.extend({
       headers: headers
     });
   },
-
+  createFolder() {
+    let deferred = Ember.RSVP.defer();
+    let config = this.get('config');
+    let listUrl = config.createDirectoryUrl();
+    let headers = config.getHeaders();
+    headers = this.setHeadersForMkdir(headers);
+    Ember.$.ajax(listUrl, {
+      headers: headers,
+      method:'PUT',
+      data:JSON.stringify(this.get('createFolderQueryParam'))
+    }).done(function(data){
+        deferred.resolve(data);
+    }).fail(function(data){
+        deferred.reject(data);
+    });
+    return deferred.promise;
+  },
+  setHeadersForMkdir(headers) {
+    headers['Accept'] = 'application/json';
+    headers.dataType = 'json';
+    headers['Content-Type'] = 'application/json; charset=UTF-8';
+    return headers;
+  },
   filterDirectoriesIfRequired: function(files) {
     let showOnlyDirectories = this.get('config.showOnlyDirectories');
     return files.filter((entry) => {
@@ -68,7 +141,7 @@ export default Ember.Component.extend({
     });
   },
 
-  modifyTreeViewData: function(response) {
+  modifyFileSystemData: function(response) {
     let paths = response.map((entry) => {
       let isDirectory = entry.isDirectory;
       let icon = isDirectory ? this.get('config.folderIcon') : this.get('config.fileIcon');
@@ -77,120 +150,160 @@ export default Ember.Component.extend({
         pathSegment: this.getNameForPath(entry.path),
         isDirectory: isDirectory,
         icon: icon,
-        text: this.getNameForPath(entry.path)
+        permission: entry.permission,
+        text: this.getNameForPath(entry.path),
+        selectedClass: ''
       };
       if(isDirectory) {
         data.nodes = Ember.A();
       }
       return data;
     });
-
-    var currentPath = this.get('currentPath');
-    var newTreeData = Ember.copy(this.get('treeData'), true);
-    if(currentPath === '/') {
-      newTreeData = paths;
-    } else {
-      this.insertPathToTreeData(newTreeData, paths, currentPath.substring(1));
+    this.setCurrentPathAsList();
+    paths = this.insertRootAsFirstPath(paths, this.get('currentPath'));
+    this.setBreadCrumbsAndListMenu();
+    this.set('fileSystem', paths);
+    this.set('errorMsg', null);
+    this.stopFileSystemFetchProgress();
+  },
+  insertRootAsFirstPath(paths, currentPath) {
+    if(currentPath !== '/') {
+       paths.unshift({traverse:true, path: this.get('currentPathArray')[this.get('currentPathArray').length-2 >=0 ?this.get('currentPathArray').length-2:this.get('currentPathArray').length-1].path});
     }
-
-    this.set('treeData', newTreeData);
-    this.send('refreshTreeView');
+    return paths;
   },
-
-  insertPathToTreeData(treeData, paths, pathSegment) {
-    let isFinalSegment = pathSegment.indexOf('/') === -1? true: false;
-    let firstPathSegment = isFinalSegment? pathSegment: pathSegment.substring(0, pathSegment.indexOf('/'));
-    if(treeData.length === 0) {
-      treeData.pushObjects(paths);
+  setBreadCrumbsAndListMenu() {
+    let currentPathArray = this.get('currentPathArray');
+    if(currentPathArray.length > this.get('maxBreadCrumbsCount')){
+       this.set("breadCrumbs", {'dropDownMenu': currentPathArray.splice(0, currentPathArray.length - this.get('maxBreadCrumbsCount')), 'breadCrumbsMenu': currentPathArray.splice(0, currentPathArray.length)});
     } else {
-      treeData.forEach((entry) => {
-        entry.state = {};
-        if (entry.pathSegment === firstPathSegment) {
-          let nodesLength = entry.nodes.length;
-          entry.state.expanded = true;
-          if(nodesLength === 0) {
-            paths.forEach((pathEntry) => {
-              entry.nodes.push(pathEntry);
-            });
-          } else if(nodesLength > 0 && nodesLength !== paths.length && isFinalSegment){
-            entry.nodes = paths;
-          } else {
-            this.insertPathToTreeData(entry.nodes, paths, pathSegment.substring(pathSegment.indexOf('/') + 1));
-          }
-        } else {
-          this.collapseAll(entry);
-        }
-      });
+       this.set("breadCrumbs", {'breadCrumbsMenu': currentPathArray});
     }
   },
-
-  collapseAll: function(node) {
-    if (Ember.isNone(node.state)) {
-      node.state = {};
-    }
-    node.state.expanded = false;
-    if(!Ember.isNone(node.nodes)) {
-      node.nodes.forEach((entry) => {
-        this.collapseAll(entry);
-      });
+  shortenName(name) {
+    return name.length > this.get('elipsisLength') ? name.substring(0, this.get('elipsisLength'))+'...':name;
+  },
+  setCurrentPathAsList() {
+    let currentPath = this.get('currentPath'), relPath = "", currentPathArr = currentPath.split('/');
+    if(currentPath === "/") {
+      currentPathArr = [""];
     }
+    this.set('currentPathArray', []);
+    currentPathArr.forEach(function(item, i) {
+        if(i !== 1) {
+         relPath = relPath + "/"+ item;
+        } else if(i === 1){
+         relPath = relPath + currentPathArr[i];
+        }
+        console.log(relPath+" is relPath");
+        if(i === currentPathArr.length-1){
+           if(0 === currentPathArr.length-1) {
+             this.get('currentPathArray').push({'path':relPath, 'fullFileName' : item, 'name':item?this.shortenName(item):'root', isCurrentFolder: true, isRoot:true});
+           } else{
+             this.get('currentPathArray').push({'path':relPath, 'fullFileName' : item, 'name':item?this.shortenName(item):'root', isCurrentFolder: true});
+           }
+        } else if(i === 0){
+           this.get('currentPathArray').push({'path':relPath, 'fullFileName' : item, 'name':item?this.shortenName(item):'root', isRoot:true});
+        } else {
+           this.get('currentPathArray').push({'path':relPath ,'fullFileName' : item,  'name':item?this.shortenName(item):'root'});
+        }
+    }.bind(this));
   },
-
   getNameForPath: function(path) {
     return path.substring(path.lastIndexOf("/") + 1);
   },
-
-  collapseAllExceptPath: function(pathSegment) {
-    let collapseAll = function(nodes, pathSegment) {
-      var firstPathSegment;
-      if (pathSegment.indexOf('/') !== -1) {
-        firstPathSegment = pathSegment.substring(0, pathSegment.indexOf('/'));
-      } else {
-        firstPathSegment = pathSegment;
-      }
-
-      nodes.forEach((entry) => {
-        if (Ember.isNone(entry.state)) {
-          entry.state = {};
-        }
-        if(firstPathSegment !== entry.pathSegment) {
-          entry.state.expanded = false;
-        } else {
-          entry.state.expanded = true;
-          collapseAll(entry.nodes, pathSegment.substring(pathSegment.indexOf('/') + 1));
-        }
-      });
-    };
-    var newTreeData = this.get('treeData');
-    collapseAll(newTreeData, pathSegment);
-    this.set('treeData', newTreeData);
-    this.send('refreshTreeView');
+  stopFolderCreationProgress() {
+    this.set('isFolderCreationprogress', false);
+  },
+  startFolderCreationProgress() {
+    this.set('isFolderCreationprogress', true);
+  },
+  stopFileSystemFetchProgress() {
+    this.set('isDataLoading', false);
+  },
+  startFileSystemFetchProgress() {
+    this.set('isDataLoading', true);
+  },
+  resetFolderCreationMenuValidation() {
+    this.set('isFolderCreationSuccess', false);
+    this.set('isFolderCreationFailure', false);
+  },
+  folderCreationSuccess() {
+    this.set('createFolderError', {});
+    this.set('isFolderCreationSuccess', true);
+    this.set('isFolderCreationFailure', false);
+  },
+  folderCreationFailure() {
+    this.set('isFolderCreationSuccess', false);
+    this.set('isFolderCreationFailure', true);
+  },
+  resetGoToPathMenuValidation() {
+    this.set('isGoToFolderSuccess', false);
+    this.set('isGoToFolderFailure', false);
+  },
+  hideGoToPathMenu() {
+    this.set('isGoToFolder', false);
+  },
+  hideCreateFolderMenu() {
+    this.set('isCreateFolder', false);
   },
-
   actions: {
-    refreshTreeView() {
-      Ember.run.later(() => {
-        this.$().treeview({
-          data: this.get('treeData'),
-          expandIcon: this.get('config.expandIcon'),
-          collapseIcon: this.get('config.collapseIcon'),
-          //emptyIcon: "fa",
-          showBorder: false,
-          onNodeSelected: (event, data) => {
-            this.set('currentPath', data.path);
-            this.sendAction('pathSelectAction', {path: data.path, isDirectory: data.isDirectory});
-          },
-          onNodeExpanded: (event, data) => {
-            this.set('currentPath', data.path);
-            if (!Ember.isNone(data.nodes) && data.nodes.length === 0) {
-              var node = this.$().treeview('getNode', data.nodeId);
-              node.icon = "fa fa-refresh fa-spin";
-              this.fetchData();
-            } else {
-              this.collapseAllExceptPath(data.path.substring(1));
-            }
+    toggleCreateFolderMenu() {
+      if(this.get('isGoToFolder')) {
+        this.hideGoToPathMenu();
+      }
+      this.toggleProperty('isCreateFolder');
+      this.resetFolderCreationMenuValidation();
+    },
+    toggleGoToFolderMenu() {
+      if(this.get('isCreateFolder')) {
+        this.hideCreateFolderMenu();
+      }
+      this.toggleProperty('isGoToFolder');
+      this.resetGoToPathMenuValidation();
+    },
+    createFolder() {
+      if(Ember.isBlank(this.get('currentPath'))) {
+        return true;
+      }
+      this.startFolderCreationProgress();
+      this.set('createFolderError', {});
+      this.createFolder().then(function() {
+         this.send('drillToPath', this.get('currentPath'));
+         this.folderCreationSuccess();
+         this.stopFolderCreationProgress();
+      }.bind(this)).catch(function(e) {
+         this.set('createFolderError', e.responseJSON);
+         this.folderCreationFailure();
+         this.stopFolderCreationProgress();
+         console.error(e);
+      }.bind(this));
+    },
+    goToFolder() {
+      if(Ember.isBlank(this.get('currentPath'))) {
+        return true;
+      }
+      this.send('drillToPath', this.get('currentPath'));
+    },
+    drillToPath(path, fileItem) {
+       if(fileItem) {
+        this.sendAction('pathSelectAction', fileItem);
+       }
+       if(path.indexOf('/') !== 0){
+         this.set('errorMsg', 'Invalid path.');
+         return;
+       }
+       this.set('currentPath', path);
+       this.fetchData();
+    },
+    selectRow(index, fileItem) {
+       this.sendAction('pathSelectAction', fileItem);
+       this.get('fileSystem').forEach(function(item, i) {
+          if(index === i && !item.traverse){
+            Ember.set(item, "selectedClass", "row-selected");
+          } else {
+            Ember.set(item, "selectedClass", "");
           }
-        });
       });
     }
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/styles/app.css
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/styles/app.css b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/styles/app.css
new file mode 100644
index 0000000..b46fa34
--- /dev/null
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/styles/app.css
@@ -0,0 +1,189 @@
+/**
+ * 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.
+ */
+.directory-viewer{
+  width: 500px;
+}
+.directory-viewer-wrap {
+  height: 500px;
+  border: 1px solid #e2e2e2;
+}
+
+.directory-viewer .container-wrap {
+	position:relative;
+	height:400px;
+}
+.directory-viewer .top-header {
+	position: relative;
+	padding-left: 0px;
+	padding-right: 0px;
+	padding-bottom: 5px;
+	width: 500px;
+	border-bottom:1px solid #e2e2e2;
+}
+.directory-viewer .row-selected {
+	background-color:#c7ddef!important
+}
+.directory-viewer .file-row {
+	padding-top: 10px;
+    padding-bottom: 10px;
+    border-bottom: 1px solid #e2e2e2;
+}
+.directory-viewer .dropdown-menu>li>a {
+    display: block;
+    padding: 3px 20px;
+    clear: both;
+    font-weight: 400;
+    line-height: 1.42857143;
+    color: #337ab7;
+    white-space: nowrap;
+}
+.directory-viewer .file-row:hover {
+    background-color: #f5f5f5;
+}
+.directory-viewer .mod-icon {
+	font-size:1.5em
+}
+.directory-viewer .elipsisClass{
+    overflow: hidden;
+    text-overflow: ellipsis;
+    -o-text-overflow: ellipsis;
+    white-space: nowrap;
+    width: 50%;
+}
+.directory-viewer .elipsis-link{
+    overflow: initial;
+    text-overflow: ellipsis;
+    -o-text-overflow: ellipsis;
+    white-space: nowrap;
+    width: 50px;
+}
+.directory-viewer .pointer {
+    cursor: pointer;
+}
+.directory-viewer .breadcrumbs-label {
+	display: inline-block;
+	padding: 8px;
+}
+.directory-viewer #file-view-unix {
+	width:500px;
+	position:relative;
+	overflow:auto;
+}
+.directory-viewer .padding-left-10px {
+	padding-left: 10px;
+}
+.directory-viewer .padding-right-10px {
+	padding-right: 10px;
+}
+.directory-viewer .home-icon {
+	top:3px;
+	font-size:1.5em;
+	position:relative;
+}
+.directory-viewer .breadcrumb {
+	background-color:white;
+	margin-bottom:0px;
+	padding: 0px;
+}
+.directory-viewer .container-fluid {
+	position:relative;
+	height:400px;
+}
+.directory-viewer .folder-name {
+	width:100% !important;
+}
+.directory-viewer .add-folder {
+    padding: 10px;
+    height: auto;
+    padding-top:0px;
+    padding-left:10px;
+    padding-bottom:4px;
+    margin-top:3px;
+    left:16px;
+}
+.directory-viewer .go-to-folder {
+    height: auto;
+    padding-right: 0px;
+    padding-left: 10px;
+    padding-bottom: 4px;
+    margin-top:3px;
+    left: 8px;
+}
+.directory-viewer .btn-action {
+	padding: 5px 10px;
+}
+.directory-viewer #folderPath, .directory-viewer #folderName {
+	height: 32px;
+	top: 2px;
+	position: relative;
+}
+.directory-viewer .margin-right-5 {
+	margin-right: 5px !important;
+}
+.directory-viewer a, .directory-viewer .file-system-count  {
+  color: #337ab7;
+}
+.directory-viewer .top-header button.btn{
+  color: #fff !important;
+}
+
+.directory-viewer .form-group{
+  padding-left:0px;
+  width:90%;
+}
+
+.directory-viewer button{
+  position:relative;
+  top:2px;
+  left:5px;
+}
+
+.directory-viewer .file-creation-status {
+  margin-top:10px;
+  margin-bottom:0px;
+}
+
+.directory-viewer .file-creation-success {
+  color:green;
+}
+
+.directory-viewer .file-creation-failure {
+  color:red;
+}
+
+.directory-viewer .inline {
+  display:inline-block;
+}
+
+.directory-viewer .file-viewer-settings {
+  position:relative;
+  top:5px;
+}
+
+.directory-viewer .no-padding {
+  padding:0px;
+}
+
+.directory-viewer .file-system-status {
+  margin-top:10px;
+  padding-left:20px;
+}
+
+.directory-viewer .file-system-count {
+  text-align:center;
+}

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/templates/components/directory-viewer.hbs
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/templates/components/directory-viewer.hbs b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/templates/components/directory-viewer.hbs
index 4083ad6..64a747f 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/templates/components/directory-viewer.hbs
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/templates/components/directory-viewer.hbs
@@ -15,3 +15,149 @@
 * See the License for the specific language governing permissions and
 * limitations under the License.
 }}
+<div class="pull-left col-sm-6 top-header">
+{{#if isGoToFolder}}
+        <div class="container-fluid go-to-folder">
+            <div class="form-inline">
+                <div class="form-group">
+                    {{input class="form-control col-sm-4 folder-name" id="folderPath" placeholder="Enter folder path" name="folderPath" value=currentPath}}
+                </div>
+                <button type="button" class="btn btn-sm btn-default btn-primary btn-action" {{action "goToFolder"}}><i aria-hidden="true" class="fa fa-arrow-circle-right"></i></button>
+                <button type="button" class="btn btn-sm btn-default btn-danger btn-action" {{action "toggleGoToFolderMenu"}}>
+                    <i class="fa fa-times" aria-hidden="true"></i>
+                </button>
+            </div>
+        </div>
+{{else if isCreateFolder}}
+        <div class="container-fluid add-folder">
+            <div class="form-inline">
+                <div class="form-group">
+                    {{input class="form-control col-sm-4 folder-name" id="folderName" placeholder="Enter folder name" name="folderName" value=currentPath}}
+                </div>
+                <button type="button" class="btn btn-sm btn-default btn-primary" {{action "createFolder"}}><i class="fa fa-plus-circle" aria-hidden="true"></i></button>
+                <button type="button" class="btn btn-sm btn-default btn-danger" {{action "toggleCreateFolderMenu"}}><i class="fa fa-times" aria-hidden="true"></i></button>
+                {{#if isFolderCreationSuccess}}
+                    <div class="file-creation-status">
+                        <strong class="file-creation-success">Folder have been created.</strong>
+                    </div>
+                {{/if}}
+                {{#if isFolderCreationFailure}}
+                    <div class="file-creation-status">
+                        <strong class="file-creation-failure">Folder creation failed.</strong>
+                        <div class="file-creation-failure">
+                            {{createFolderError.message}}
+                        </div>
+                    </div>
+                {{/if}}
+                {{#if isFolderCreationprogress}}
+                    <div class="loading-data" class="file-creation-status">
+                        <i class="fa fa-spinner fa-pulse fa-1x fa-fw"></i>Creating the folder...
+                    </div>
+                {{/if}}
+            </div>
+        </div>
+
+{{else}}
+
+    {{#if breadCrumbs.dropDownMenu}}
+        <li class="inline">
+        <div class="dropdown">
+            <a class="dropdown-toggle" d="dropdownMenu1" data-toggle="dropdown" aria-haspopup="true" aria-expanded="true">
+	        <span class="fa-stack">
+	          <i class="fa fa-folder-o fa-stack-1x mod-icon" aria-hidden="true"></i>
+	          <i class="fa fa-caret-down fa-stack-1x" aria-hidden="true"></i>
+	        </span>
+            </a>
+        <ul class="dropdown-menu" aria-labelledby="dropdownMenu1">
+        {{#each breadCrumbs.dropDownMenu as |crumb index|}}
+                <li><a {{action "drillToPath" crumb.path crumb}}> <div title={{crumb.fullFileName}} class="elipsis-link pointer inline">{{crumb.name}}</div></a></li>
+        {{/each}}
+            </ul>
+        </div>
+        </li>&nbsp;/
+    {{/if}}
+    <div class="bs-example breadcrumbs-label">
+        <ul class="breadcrumb">
+            <li>
+                {{#each breadCrumbs.breadCrumbsMenu as |pathItem|}}
+                    {{#if pathItem.isRoot}}
+                        <a {{action "drillToPath" pathItem.path pathItem}}><i class="fa fa-folder-o home-icon" aria-hidden="true"></i></a>&nbsp;>
+                    {{else if pathItem.isCurrentFolder}}
+                        <span  title={{pathItem.fullFileName}}>{{pathItem.name}}</span>&nbsp;
+                    {{else}}
+                        <a {{action "drillToPath" pathItem.path pathItem}}><div class="pointer inline" title={{pathItem.fullFileName}}>{{pathItem.name}}</div></a>&nbsp;>
+                    {{/if}}
+                {{/each}}
+            </li>
+        </ul>
+    </div>
+
+    <div class="pull-right file-viewer-settings">
+        <li class="breadcrumbs-label no-padding">
+            <div class="dropdown">
+                <a class="dropdown-toggle" d="dropdownMenu1" data-toggle="dropdown" aria-haspopup="true" aria-expanded="true">
+		  <span class="btn btn-sm btn-default">
+		    <i class="fa fa-cog" aria-hidden="true"></i>
+		    <i class="fa fa-caret-down" aria-hidden="true"></i>
+		  </span>
+                </a>
+                <ul class="dropdown-menu" aria-labelledby="dropdownMenu1">
+                    <li><a>{{input type="checkbox" class="margin-right-5" name="dir" checked=isDirectory}}Directories</a></li>
+                    <li><a>{{input type="checkbox" class="margin-right-5" name="file" checked=isFile}}Files</a></li>
+                </ul>
+            </div>
+        </li>
+        <span {{ action "drillToPath" currentPath}} class="btn btn-sm btn-default">
+		    <i class="fa fa-refresh" aria-hidden="true"></i>
+		</span>
+        <button type="button" class="btn btn-sm btn-primary" {{action "toggleCreateFolderMenu"}}>
+            <i class="fa fa-plus-circle" aria-hidden="true"></i>{{!--  New Folder --}}
+        </button>
+        <button type="button" class="btn btn-sm btn-primary" {{action "toggleGoToFolderMenu"}}>
+            <i aria-hidden="true" class="fa fa-arrow-circle-o-right"></i> {{!-- Go To --}}
+        </button>
+    </div>
+{{/if}}
+</div>
+<div id="file-view-unix">
+    {{#if isDataLoading}}
+        <div class="loading-data file-system-status">
+            <i class="fa fa-spinner fa-pulse fa-1x fa-fw"></i>Fetching data...
+        </div>
+    {{else if errorMsg}}
+        <div class="file-system-status">
+            <strong class="file-creation-failure">{{errorMsg}}</strong>
+            <div class="file-creation-failure">
+                {{folderAccessError.message}}
+            </div>
+        </div>
+    {{else}}
+        {{#if filteredFileSytemInfo}}
+            <div class="container-fluid">
+                {{#ember-collection items=filteredFileSytemInfo cell-layout=(fixed-grid-layout fileBrowserWidth 41) as |item index|}}
+                    <div class="row file-row {{item.selectedClass}}" {{action 'selectRow' index item}}>
+                        {{#if item.traverse}}
+                            <div class="col-sm-8">
+                                <a class="padding-left-10px pointer" {{action "drillToPath" item.path item}}>
+                                    <i class="fa fa-reply padding-right-10px" aria-hidden="true"></i>
+                                </a>
+                            </div>
+                        {{else if item.isDirectory }}
+                            <div class="col-sm-6 elipsisClass">
+                                <a title={{item.text}} class="padding-left-10px pointer" {{action "drillToPath" item.path item}}>
+                                <i class="fa fa-folder-o padding-right-10px" aria-hidden="true"></i>{{ item.text }}
+                                </a>
+                            </div>
+                        {{else}}
+                            <div class="col-sm-6 elipsisClass" title={{item.text}}>
+                                <i class="fa fa-file padding-left-10px padding-right-10px" aria-hidden="true"></i>{{ item.text }}
+                            </div>
+                        {{/if}}
+                    </div>
+                {{/ember-collection}}
+            </div>
+        {{else}}
+            No files or folders.
+        {{/if}}
+    {{/if}}
+</div>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/utils/viewer-config.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/utils/viewer-config.js b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/utils/viewer-config.js
index 64773c6..c97c7c0 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/utils/viewer-config.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/addon/utils/viewer-config.js
@@ -54,6 +54,9 @@ export default Ember.Object.extend({
    */
   listDirectoryUrl(pathParams) {
     return `/listdir?${pathParams}`;
+  },
+  createDirectoryUrl() {
+    return `/mkdir`;
   }
 
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/bower.json
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/bower.json b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/bower.json
index f016904..206b8bd 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/bower.json
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/bower.json
@@ -10,7 +10,6 @@
     "loader.js": "^3.5.0",
     "qunit": "~1.20.0",
     "bootstrap": "~3.3.6",
-    "bootstrap-treeview": "~1.2.0",
     "font-awesome": "~4.5.0"
   },
   "resolutions": {

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/index.js
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/index.js b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/index.js
index dc074d7..762c281 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/index.js
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/index.js
@@ -23,10 +23,7 @@ module.exports = {
   name: 'hdfs-directory-viewer',
   included: function(app) {
     this._super.included(app);
-
     app.import(app.bowerDirectory + '/bootstrap/dist/css/bootstrap.css');
     app.import(app.bowerDirectory + '/bootstrap/dist/js/bootstrap.js');
-    app.import(app.bowerDirectory + '/bootstrap-treeview/src/js/bootstrap-treeview.js');
-    app.import(app.bowerDirectory + '/bootstrap-treeview/dist/bootstrap-treeview.min.css');
   }
 };

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/package.json
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/package.json b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/package.json
index 66a7b20..90e4357 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/package.json
+++ b/contrib/views/wfmanager/src/main/resources/ui/externaladdons/hdfs-directory-viewer/package.json
@@ -36,7 +36,10 @@
     "ember-disable-proxy-controllers": "^1.0.1",
     "ember-export-application-global": "^1.0.4",
     "ember-resolver": "^2.0.3",
-    "ember-try": "~0.0.8"
+    "ember-try": "~0.0.8",
+    "ember-truth-helpers": "1.2.0",
+    "ember-collection": "git://github.com/emberjs/ember-collection.git#4dbe10b7498886e277fc21b28139924f908d1926"
+
   },
   "keywords": [
     "ember-addon"

http://git-wip-us.apache.org/repos/asf/ambari/blob/b53cf918/contrib/views/wfmanager/src/main/resources/ui/package.json
----------------------------------------------------------------------
diff --git a/contrib/views/wfmanager/src/main/resources/ui/package.json b/contrib/views/wfmanager/src/main/resources/ui/package.json
index b5973c1..25ed6c1 100644
--- a/contrib/views/wfmanager/src/main/resources/ui/package.json
+++ b/contrib/views/wfmanager/src/main/resources/ui/package.json
@@ -49,7 +49,8 @@
     "ember-uuid": "1.0.0",
     "ember-validations": "~ 2.0.0-alpha.4",
     "ivy-codemirror": "2.0.3",
-    "loader.js": "^4.0.0"
+    "loader.js": "^4.0.0",
+    "ember-collection": "git://github.com/emberjs/ember-collection.git#4dbe10b7498886e277fc21b28139924f908d1926"
   },
   "ember-addon": {
     "paths": [