You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@falcon.apache.org by ve...@apache.org on 2013/09/24 00:55:43 UTC

[1/6] git commit: Revert "Single merged commit for FALCON-86 & FALCON-88"

Updated Branches:
  refs/heads/FALCON-85 f278ec82f -> 0879caff4


Revert "Single merged commit for FALCON-86 & FALCON-88"

This reverts commit edf03d4a85b7f047135c7c2f711de8d88484b9d1.


Project: http://git-wip-us.apache.org/repos/asf/incubator-falcon/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-falcon/commit/7b128817
Tree: http://git-wip-us.apache.org/repos/asf/incubator-falcon/tree/7b128817
Diff: http://git-wip-us.apache.org/repos/asf/incubator-falcon/diff/7b128817

Branch: refs/heads/FALCON-85
Commit: 7b128817689c11969525f82931e0c69d270e7af9
Parents: c82b663
Author: srikanth.sundarrajan <sr...@inmobi.com>
Authored: Mon Sep 2 07:56:07 2013 +0530
Committer: srikanth.sundarrajan <sr...@inmobi.com>
Committed: Mon Sep 2 07:56:07 2013 +0530

----------------------------------------------------------------------
 CHANGES.txt | 6 ------
 1 file changed, 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/7b128817/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index b2dc1d3..fbf99d3 100755
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -5,12 +5,6 @@ Trunk (Unreleased)
   INCOMPATIBLE CHANGES
 
   NEW FEATURES
-    FALCON-86 Hive table integration with cluster entity. (Venaktesh 
-    Seetharam via Srikanth Sundarrajan)
-
-    FALCON-88 Add embedded hive and webhcat for integration tests. 
-    (Venkatesh Seetharam via Srikanth Sundarrajan)
-
     FALCON-62 Falcon compilation with hadoop 2.0 libs. (Shwetha GS
     via Srikanth Sundarrajan)
 


[2/6] git commit: Revert "FALCON-88 Add embedded hive and webhcat for integration tests. Contributed by Venkatesh Seetharam"

Posted by ve...@apache.org.
Revert "FALCON-88 Add embedded hive and webhcat for integration tests. Contributed by Venkatesh Seetharam"

This reverts commit 19bcf9994125bba86bf5ed79ef3d44c5bf0a2f8a.


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

Branch: refs/heads/FALCON-85
Commit: f1db98b378a36b749206682b3bc3900e0cad7716
Parents: 7b12881
Author: srikanth.sundarrajan <sr...@inmobi.com>
Authored: Mon Sep 2 07:56:10 2013 +0530
Committer: srikanth.sundarrajan <sr...@inmobi.com>
Committed: Mon Sep 2 07:56:10 2013 +0530

----------------------------------------------------------------------
 hadoop-webapp/pom.xml                           |  21 ---
 .../falcon/listener/HadoopStartupListener.java  | 140 ++++++-------------
 hadoop-webapp/src/main/resources/hive-site.xml  |  27 ----
 .../src/main/resources/webhcat-site.xml         |  29 ----
 pom.xml                                         |  30 +---
 webapp/pom.xml                                  |   1 -
 6 files changed, 44 insertions(+), 204 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/f1db98b3/hadoop-webapp/pom.xml
----------------------------------------------------------------------
diff --git a/hadoop-webapp/pom.xml b/hadoop-webapp/pom.xml
index c8c51d6..312a71b 100644
--- a/hadoop-webapp/pom.xml
+++ b/hadoop-webapp/pom.xml
@@ -91,27 +91,6 @@
             <groupId>org.apache.activemq</groupId>
             <artifactId>activemq-core</artifactId>
         </dependency>
-
-        <dependency>
-            <groupId>org.apache.hive</groupId>
-            <artifactId>hive-metastore</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>org.apache.hcatalog</groupId>
-            <artifactId>webhcat</artifactId>
-        </dependency>
-
-        <!-- Hive Metastore and WebHcat fails with out these dependencies -->
-        <dependency>
-            <groupId>org.slf4j</groupId>
-            <artifactId>slf4j-api</artifactId>
-        </dependency>
-
-        <dependency>
-            <groupId>org.slf4j</groupId>
-            <artifactId>slf4j-log4j12</artifactId>
-        </dependency>
     </dependencies>
 
     <build>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/f1db98b3/hadoop-webapp/src/main/java/org/apache/falcon/listener/HadoopStartupListener.java
----------------------------------------------------------------------
diff --git a/hadoop-webapp/src/main/java/org/apache/falcon/listener/HadoopStartupListener.java b/hadoop-webapp/src/main/java/org/apache/falcon/listener/HadoopStartupListener.java
index 570ba02..5114a4b 100644
--- a/hadoop-webapp/src/main/java/org/apache/falcon/listener/HadoopStartupListener.java
+++ b/hadoop-webapp/src/main/java/org/apache/falcon/listener/HadoopStartupListener.java
@@ -19,8 +19,6 @@
 package org.apache.falcon.listener;
 
 import java.io.File;
-import java.io.IOException;
-import java.lang.reflect.InvocationTargetException;
 
 import javax.servlet.ServletContextEvent;
 import javax.servlet.ServletContextListener;
@@ -30,9 +28,7 @@ import org.apache.commons.io.FileUtils;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.hdfs.server.datanode.DataNode;
 import org.apache.hadoop.hdfs.server.namenode.NameNode;
-import org.apache.hadoop.hive.metastore.HiveMetaStore;
 import org.apache.hadoop.mapred.JobConf;
-import org.apache.hcatalog.templeton.AppConfig;
 import org.apache.log4j.Logger;
 
 /**
@@ -52,18 +48,54 @@ public class HadoopStartupListener implements ServletContextListener {
             final String[] emptyArgs = {};
             String hadoopProfle = System.getProperty("hadoop.profile", "1");
             if (hadoopProfle.equals("1")) {
-                startHadoop1Services(conf, emptyArgs);
+                NameNode.createNameNode(emptyArgs, conf);
+                DataNode.createDataNode(emptyArgs, conf);
+                JobConf jobConf = new JobConf(conf);
+                /**
+                 * Reflection code:
+                 * JobTracker jt = JobTracker.startTracker(jobConf);
+                 * jt.offerService();
+                 * TaskTracker tt = new TaskTracker(jobConf);
+                 * tt.run();
+                 */
+                Object jt = Class.forName("org.apache.hadoop.mapred.JobTracker")
+                                .getMethod("startTracker", JobConf.class).invoke(null, jobConf);
+                startService(jt, "offerService");
+                Object tt = Class.forName("org.apache.hadoop.mapred.TaskTracker")
+                                .getConstructor(JobConf.class).newInstance(jobConf);
+                startService(tt, "run");
             } else if (hadoopProfle.equals("2")) {
-                startHadoop2Services(conf, emptyArgs);
+                /**
+                 * Reflection code:
+                 * DefaultMetricsSystem.setMiniClusterMode(true);
+                 * ResourceManager resourceManager = new ResourceManager(new MemStore());
+                 * YarnConfiguration yarnConf = new YarnConfiguration(conf);
+                 * resourceManager.init(yarnConf);
+                 * resourceManager.start();
+                 * NodeManager nodeManager = new NodeManager();
+                 * nodeManager.init(yarnConf);
+                 * nodeManager.start();
+                 */
+                Class.forName("org.apache.hadoop.metrics2.lib.DefaultMetricsSystem")
+                                .getMethod("setMiniClusterMode", boolean.class).invoke(null, true);
+                NameNode.createNameNode(emptyArgs, conf);
+                DataNode.createDataNode(emptyArgs, conf);
+
+                Object memStore = instance("org.apache.hadoop.yarn.server.resourcemanager.recovery.MemStore");
+                Object resourceManager = Class.forName("org.apache.hadoop.yarn.server.resourcemanager.ResourceManager")
+                        .getConstructor(Class.forName("org.apache.hadoop.yarn.server.resourcemanager.recovery.Store"))
+                        .newInstance(memStore);
+                Object yarnConf = Class.forName("org.apache.hadoop.yarn.conf.YarnConfiguration")
+                        .getConstructor(Configuration.class).newInstance(conf);
+                invoke(resourceManager, "init", Configuration.class, yarnConf);
+                startService(resourceManager, "start");
+                Object nodeManager = instance("org.apache.hadoop.yarn.server.nodemanager.NodeManager");
+                invoke(nodeManager, "init", Configuration.class, yarnConf);
+                startService(nodeManager, "start");
             } else {
                 throw new RuntimeException("Unhandled hadoop profile " + hadoopProfle);
             }
-
             startBroker();
-
-            startHiveMetaStore();
-            startHiveWebMetaStore();
-
         } catch (Exception e) {
             e.printStackTrace();
             LOG.error("Unable to start hadoop cluster", e);
@@ -71,59 +103,6 @@ public class HadoopStartupListener implements ServletContextListener {
         }
     }
 
-    private void startHadoop1Services(Configuration conf, String[] emptyArgs)
-        throws IOException, IllegalAccessException, InvocationTargetException,
-               NoSuchMethodException, ClassNotFoundException, InstantiationException {
-
-        NameNode.createNameNode(emptyArgs, conf);
-        DataNode.createDataNode(emptyArgs, conf);
-
-        JobConf jobConf = new JobConf(conf);
-        // JobTracker jt = JobTracker.startTracker(jobConf);
-        // jt.offerService();
-        // TaskTracker tt = new TaskTracker(jobConf);
-        // tt.run();
-
-        Object jt = Class.forName("org.apache.hadoop.mapred.JobTracker")
-                        .getMethod("startTracker", JobConf.class).invoke(null, jobConf);
-        startService(jt, "offerService");
-
-        Object tt = Class.forName("org.apache.hadoop.mapred.TaskTracker")
-                        .getConstructor(JobConf.class).newInstance(jobConf);
-        startService(tt, "run");
-    }
-
-    private void startHadoop2Services(Configuration conf, String[] emptyArgs) throws Exception {
-
-        // DefaultMetricsSystem.setMiniClusterMode(true);
-        // ResourceManager resourceManager = new ResourceManager(new MemStore());
-        // YarnConfiguration yarnConf = new YarnConfiguration(conf);
-        // resourceManager.init(yarnConf);
-        // resourceManager.start();
-        // NodeManager nodeManager = new NodeManager();
-        // nodeManager.init(yarnConf);
-        // nodeManager.start();
-
-        Class.forName("org.apache.hadoop.metrics2.lib.DefaultMetricsSystem")
-                        .getMethod("setMiniClusterMode", boolean.class).invoke(null, true);
-
-        NameNode.createNameNode(emptyArgs, conf);
-        DataNode.createDataNode(emptyArgs, conf);
-
-        Object memStore = instance("org.apache.hadoop.yarn.server.resourcemanager.recovery.MemStore");
-        Object resourceManager = Class.forName("org.apache.hadoop.yarn.server.resourcemanager.ResourceManager")
-                .getConstructor(Class.forName("org.apache.hadoop.yarn.server.resourcemanager.recovery.Store"))
-                .newInstance(memStore);
-        Object yarnConf = Class.forName("org.apache.hadoop.yarn.conf.YarnConfiguration")
-                .getConstructor(Configuration.class).newInstance(conf);
-        invoke(resourceManager, "init", Configuration.class, yarnConf);
-        startService(resourceManager, "start");
-
-        Object nodeManager = instance("org.apache.hadoop.yarn.server.nodemanager.NodeManager");
-        invoke(nodeManager, "init", Configuration.class, yarnConf);
-        startService(nodeManager, "start");
-    }
-
     private void startBroker() throws Exception {
         broker = new BrokerService();
         broker.setUseJmx(false);
@@ -133,39 +112,6 @@ public class HadoopStartupListener implements ServletContextListener {
         broker.start();
     }
 
-    public static final String META_STORE_PORT = "49083";
-    private void startHiveMetaStore() {
-        try {
-            new Thread(new Runnable() {
-                @Override
-                public void run() {
-                    try {
-                        String[] args = new String[]{
-                            "-v",
-                            "-p", META_STORE_PORT,
-                        };
-
-                        HiveMetaStore.main(args);
-                    } catch (Throwable t) {
-                        throw new RuntimeException(t);
-                    }
-                }
-            }).start();
-        } catch (Exception e) {
-            throw new RuntimeException("Unable to start hive metastore server.", e);
-        }
-    }
-
-    public static final String WEB_HCAT_PORT = "48080";
-    private void startHiveWebMetaStore() {
-        String[] args = new String[]{
-            "-D" + AppConfig.PORT + "=" + WEB_HCAT_PORT,
-            "-D" + AppConfig.HADOOP_CONF_DIR + "=./target/webapps/hadoop/conf",
-        };
-
-        org.apache.hcatalog.templeton.Main.main(args);
-    }
-
     private Object instance(String clsName) throws Exception {
         return Class.forName(clsName).newInstance();
     }

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/f1db98b3/hadoop-webapp/src/main/resources/hive-site.xml
----------------------------------------------------------------------
diff --git a/hadoop-webapp/src/main/resources/hive-site.xml b/hadoop-webapp/src/main/resources/hive-site.xml
deleted file mode 100644
index 89d739b..0000000
--- a/hadoop-webapp/src/main/resources/hive-site.xml
+++ /dev/null
@@ -1,27 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  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.
--->
-
-<configuration>
-    <!-- Forcing the creation of the db dir under target -->
-    <property>
-        <name>javax.jdo.option.ConnectionURL</name>
-        <value>jdbc:derby:;databaseName=./target/metastore_db;create=true</value>
-    </property>
-</configuration>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/f1db98b3/hadoop-webapp/src/main/resources/webhcat-site.xml
----------------------------------------------------------------------
diff --git a/hadoop-webapp/src/main/resources/webhcat-site.xml b/hadoop-webapp/src/main/resources/webhcat-site.xml
deleted file mode 100644
index 6d0772c..0000000
--- a/hadoop-webapp/src/main/resources/webhcat-site.xml
+++ /dev/null
@@ -1,29 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  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.
--->
-
-<configuration>
-
-    <property>
-        <name>templeton.hadoop.conf.dir</name>
-        <value>${env.HADOOP_CONF_DIR}</value>
-        <description>The path to the Hadoop configuration.</description>
-    </property>
-
-</configuration>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/f1db98b3/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 7498a69..d211e21 100644
--- a/pom.xml
+++ b/pom.xml
@@ -98,11 +98,10 @@
 
         <hadoop.profile>1</hadoop.profile>
         <hadoop.version>1.1.2</hadoop.version>
-        <slf4j.version>1.6.1</slf4j.version>
+        <slf4j.version>1.2</slf4j.version>
         <oozie.version>3.2.2</oozie.version>
         <activemq.version>5.4.3</activemq.version>
         <hadoop-distcp.version>0.3</hadoop-distcp.version>
-        <hive.version>0.11.0</hive.version>
         <jetty.version>6.1.26</jetty.version>
         <internal.maven.repo>file:///tmp/falcontemprepo</internal.maven.repo>
         <skipCheck>false</skipCheck>
@@ -704,30 +703,6 @@
             </dependency>
 
             <dependency>
-                <groupId>org.apache.hive</groupId>
-                <artifactId>hive-metastore</artifactId>
-                <version>${hive.version}</version>
-                <exclusions>
-                    <exclusion> <!--Oozie already imports this-->
-                        <groupId>org.apache.derby</groupId>
-                        <artifactId>derby</artifactId>
-                    </exclusion>
-                </exclusions>
-            </dependency>
-
-            <dependency>
-                <groupId>org.apache.hcatalog</groupId>
-                <artifactId>webhcat</artifactId>
-                <version>${hive.version}</version>
-                <exclusions>
-                    <exclusion>
-                        <groupId>xerces</groupId>
-                        <artifactId>xercesImpl</artifactId>
-                    </exclusion>
-                </exclusions>
-            </dependency>
-
-            <dependency>
                 <groupId>net.sourceforge.findbugs</groupId>
                 <artifactId>annotations</artifactId>
                 <version>1.3.2</version>
@@ -906,9 +881,6 @@
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-javadoc-plugin</artifactId>
-                <configuration>
-                    <skip>${skipCheck}</skip>
-                </configuration>
                 <executions>
                     <execution>
                         <id>attach-javadocs</id>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/f1db98b3/webapp/pom.xml
----------------------------------------------------------------------
diff --git a/webapp/pom.xml b/webapp/pom.xml
index fc7f9e6..ffeeb46 100644
--- a/webapp/pom.xml
+++ b/webapp/pom.xml
@@ -174,7 +174,6 @@
                             <dependencySourceIncludes>
                                 <dependencySourceInclude>org.apache.falcon:*</dependencySourceInclude>
                             </dependencySourceIncludes>
-                            <skip>${skipCheck}</skip>
                         </configuration>
                     </execution>
                 </executions>


[5/6] git commit: Merge commit 'f1db98b378a36b749206682b3bc3900e0cad7716' into 85

Posted by ve...@apache.org.
Merge commit 'f1db98b378a36b749206682b3bc3900e0cad7716' into 85

Conflicts:
	hadoop-webapp/pom.xml
	pom.xml


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

Branch: refs/heads/FALCON-85
Commit: a298d857d393676a2f768130ce9fee6582c5ff91
Parents: 72d1857 f1db98b
Author: Venkatesh Seetharam <ve...@apache.org>
Authored: Mon Sep 23 15:13:43 2013 -0700
Committer: Venkatesh Seetharam <ve...@apache.org>
Committed: Mon Sep 23 15:13:43 2013 -0700

----------------------------------------------------------------------
 hadoop-webapp/pom.xml | 20 --------------------
 pom.xml               |  3 ---
 2 files changed, 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/a298d857/hadoop-webapp/pom.xml
----------------------------------------------------------------------
diff --cc hadoop-webapp/pom.xml
index 96a6043,312a71b..21540d0
--- a/hadoop-webapp/pom.xml
+++ b/hadoop-webapp/pom.xml
@@@ -91,58 -91,6 +91,38 @@@
              <groupId>org.apache.activemq</groupId>
              <artifactId>activemq-core</artifactId>
          </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.hive</groupId>
 +            <artifactId>hive-metastore</artifactId>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.hcatalog</groupId>
 +            <artifactId>webhcat</artifactId>
 +        </dependency>
 +
 +        <!-- Hive Metastore and WebHcat fails with out these dependencies -->
 +        <dependency>
 +            <groupId>org.slf4j</groupId>
 +            <artifactId>slf4j-api</artifactId>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.slf4j</groupId>
 +            <artifactId>slf4j-log4j12</artifactId>
 +        </dependency>
-         <dependency>
-             <groupId>org.apache.hive</groupId>
-             <artifactId>hive-metastore</artifactId>
-         </dependency>
- 
-         <dependency>
-             <groupId>org.apache.hcatalog</groupId>
-             <artifactId>webhcat</artifactId>
-         </dependency>
 +
 +        <!-- Oozie dependencies -->
 +        <dependency>
 +            <groupId>org.apache.hive</groupId>
 +            <artifactId>hive-exec</artifactId>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.hcatalog</groupId>
 +            <artifactId>webhcat-java-client</artifactId>
 +        </dependency>
- 
-         <!-- Hive Metastore and WebHcat fails with out these dependencies -->
-         <dependency>
-             <groupId>org.slf4j</groupId>
-             <artifactId>slf4j-api</artifactId>
-         </dependency>
- 
-         <dependency>
-             <groupId>org.slf4j</groupId>
-             <artifactId>slf4j-log4j12</artifactId>
-         </dependency>
      </dependencies>
  
      <build>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/a298d857/pom.xml
----------------------------------------------------------------------


[6/6] git commit: Merge commit 'd422dba4816fb3003d72c8c1e3d835c19c99f50c' into 85

Posted by ve...@apache.org.
Merge commit 'd422dba4816fb3003d72c8c1e3d835c19c99f50c' into 85

Conflicts:
	common/src/main/java/org/apache/falcon/catalog/AbstractCatalogService.java
	common/src/main/java/org/apache/falcon/catalog/HiveCatalogService.java
	webapp/src/test/resources/cluster-template.xml


Project: http://git-wip-us.apache.org/repos/asf/incubator-falcon/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-falcon/commit/0879caff
Tree: http://git-wip-us.apache.org/repos/asf/incubator-falcon/tree/0879caff
Diff: http://git-wip-us.apache.org/repos/asf/incubator-falcon/diff/0879caff

Branch: refs/heads/FALCON-85
Commit: 0879caff43689f8daebcea6f1c4c9e3fd3eb4f02
Parents: a298d85 d422dba
Author: Venkatesh Seetharam <ve...@apache.org>
Authored: Mon Sep 23 15:22:51 2013 -0700
Committer: Venkatesh Seetharam <ve...@apache.org>
Committed: Mon Sep 23 15:22:51 2013 -0700

----------------------------------------------------------------------
 .../entity/parser/ClusterEntityParserTest.java     | 17 ++++++++++++++---
 1 file changed, 14 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/0879caff/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
----------------------------------------------------------------------
diff --cc common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
index dffa691,20d14e8..6bf1df8
--- a/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
+++ b/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
@@@ -18,6 -18,15 +18,13 @@@
  
  package org.apache.falcon.entity.parser;
  
 -import static org.testng.AssertJUnit.assertEquals;
 -
+ import java.io.IOException;
+ import java.io.InputStream;
+ import java.io.StringWriter;
+ 
+ import javax.xml.bind.JAXBException;
+ import javax.xml.bind.Marshaller;
+ 
  import org.apache.falcon.FalconException;
  import org.apache.falcon.cluster.util.EmbeddedCluster;
  import org.apache.falcon.entity.AbstractTestBase;
@@@ -32,10 -40,6 +39,7 @@@ import org.testng.annotations.AfterClas
  import org.testng.annotations.BeforeClass;
  import org.testng.annotations.Test;
  
- import javax.xml.bind.JAXBException;
- import java.io.IOException;
- import java.io.InputStream;
 +
  /**
   * Test for validating cluster entity parsing.
   */
@@@ -65,32 -69,18 +69,39 @@@ public class ClusterEntityParserTest ex
  
          Interface write = ClusterHelper.getInterface(cluster, Interfacetype.WRITE);
          //assertEquals(write.getEndpoint(), conf.get("fs.default.name"));
 -        assertEquals(write.getVersion(), "0.20.2");
 +        Assert.assertEquals(write.getVersion(), "0.20.2");
  
          Interface workflow = ClusterHelper.getInterface(cluster, Interfacetype.WORKFLOW);
 -        assertEquals(workflow.getEndpoint(), "http://localhost:11000/oozie/");
 -        assertEquals(workflow.getVersion(), "3.1");
 +        Assert.assertEquals(workflow.getEndpoint(), "http://localhost:11000/oozie/");
 +        Assert.assertEquals(workflow.getVersion(), "3.1");
  
 -        assertEquals(ClusterHelper.getLocation(cluster, "staging"), "/projects/falcon/staging");
++        Assert.assertEquals(ClusterHelper.getLocation(cluster, "staging"), "/projects/falcon/staging");
+ 
+         StringWriter stringWriter = new StringWriter();
+         Marshaller marshaller = EntityType.CLUSTER.getMarshaller();
+         marshaller.marshal(cluster, stringWriter);
+         System.out.println(stringWriter.toString());
++
 +        Interface catalog = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
 +        Assert.assertEquals(catalog.getEndpoint(), "http://localhost:48080/templeton/v1");
 +        Assert.assertEquals(catalog.getVersion(), "0.11.0");
 +
 +        Assert.assertEquals(ClusterHelper.getLocation(cluster, "staging"), "/projects/falcon/staging");
 +    }
 +
 +    @Test
 +    public void testParseClusterWithoutRegistry() throws IOException, FalconException, JAXBException {
 +
 +        InputStream stream = this.getClass().getResourceAsStream("/config/cluster/cluster-no-registry.xml");
 +
 +        Cluster cluster = parser.parse(stream);
 +
 +        Interface catalog = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
 +        Assert.assertNull(catalog);
 +
 +        StartupProperties.get().setProperty("catalog.service.impl", "");
 +        catalog = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
 +        Assert.assertNull(catalog);
      }
  
      /**


[3/6] git commit: Revert "FALCON-86 Hive table integration with cluster entity. Contributed by Venkatesh Seetharam"

Posted by ve...@apache.org.
Revert "FALCON-86 Hive table integration with cluster entity. Contributed by Venkatesh Seetharam"

This reverts commit 8b09e1b272113e9b769a20f09b6c0c4e2ec7c18a.


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

Branch: refs/heads/FALCON-85
Commit: d422dba4816fb3003d72c8c1e3d835c19c99f50c
Parents: f1db98b
Author: srikanth.sundarrajan <sr...@inmobi.com>
Authored: Mon Sep 2 07:56:11 2013 +0530
Committer: srikanth.sundarrajan <sr...@inmobi.com>
Committed: Mon Sep 2 07:56:11 2013 +0530

----------------------------------------------------------------------
 .../falcon/catalog/AbstractCatalogService.java  | 37 --------------
 .../falcon/catalog/CatalogServiceFactory.java   | 49 ------------------
 .../falcon/catalog/HiveCatalogService.java      | 46 -----------------
 .../entity/parser/ClusterEntityParser.java      | 31 +----------
 common/src/main/resources/startup.properties    |  2 -
 .../entity/parser/ClusterEntityParserTest.java  | 54 ++++++++------------
 .../resources/config/cluster/cluster-0.1.xml    |  3 +-
 .../config/cluster/cluster-no-registry.xml      | 42 ---------------
 src/conf/startup.properties                     |  2 -
 .../resource/ClusterEntityValidationIT.java     |  2 -
 webapp/src/test/resources/cluster-template.xml  |  6 +--
 11 files changed, 28 insertions(+), 246 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/main/java/org/apache/falcon/catalog/AbstractCatalogService.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/falcon/catalog/AbstractCatalogService.java b/common/src/main/java/org/apache/falcon/catalog/AbstractCatalogService.java
deleted file mode 100644
index 4086611..0000000
--- a/common/src/main/java/org/apache/falcon/catalog/AbstractCatalogService.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/**
- * 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.
- */
-
-package org.apache.falcon.catalog;
-
-import org.apache.falcon.FalconException;
-
-/**
- * Interface definition for a catalog registry service
- * such as Hive or HCatalog.
- */
-public abstract class AbstractCatalogService {
-
-    /**
-     * This method checks if the catalog service is alive.
-     *
-     * @param catalogBaseUrl url for the catalog service
-     * @return if the service was reachable
-     * @throws FalconException exception
-     */
-    public abstract boolean isAlive(String catalogBaseUrl) throws FalconException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/main/java/org/apache/falcon/catalog/CatalogServiceFactory.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/falcon/catalog/CatalogServiceFactory.java b/common/src/main/java/org/apache/falcon/catalog/CatalogServiceFactory.java
deleted file mode 100644
index c8a0fa0..0000000
--- a/common/src/main/java/org/apache/falcon/catalog/CatalogServiceFactory.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/**
- * 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.
- */
-
-package org.apache.falcon.catalog;
-
-import org.apache.falcon.FalconException;
-import org.apache.falcon.util.ReflectionUtils;
-import org.apache.falcon.util.StartupProperties;
-
-/**
- * Factory for providing appropriate catalog service
- * implementation to the falcon service.
- */
-@SuppressWarnings("unchecked")
-public final class CatalogServiceFactory {
-
-    public static final String CATALOG_SERVICE = "catalog.service.impl";
-
-    private CatalogServiceFactory() {
-    }
-
-    public static boolean isEnabled() {
-        return StartupProperties.get().containsKey(CATALOG_SERVICE);
-    }
-
-    public static AbstractCatalogService getCatalogService() throws FalconException {
-        if (!isEnabled()) {
-            throw new FalconException(
-                "Catalog integration is not enabled in falcon. Implementation is missing: " + CATALOG_SERVICE);
-        }
-
-        return ReflectionUtils.getInstance(CATALOG_SERVICE);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/main/java/org/apache/falcon/catalog/HiveCatalogService.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/falcon/catalog/HiveCatalogService.java b/common/src/main/java/org/apache/falcon/catalog/HiveCatalogService.java
deleted file mode 100644
index e6f7fe2..0000000
--- a/common/src/main/java/org/apache/falcon/catalog/HiveCatalogService.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/**
- * 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.
- */
-
-package org.apache.falcon.catalog;
-
-import com.sun.jersey.api.client.Client;
-import com.sun.jersey.api.client.ClientResponse;
-import com.sun.jersey.api.client.WebResource;
-import org.apache.falcon.FalconException;
-import org.apache.log4j.Logger;
-
-import javax.ws.rs.core.MediaType;
-
-/**
- * An implementation of CatalogService that uses Hive Meta Store (HCatalog)
- * as the backing Catalog registry.
- */
-public class HiveCatalogService extends AbstractCatalogService {
-
-    private static final Logger LOG = Logger.getLogger(HiveCatalogService.class);
-
-    @Override
-    public boolean isAlive(String catalogBaseUrl) throws FalconException {
-        LOG.info("Checking if the service is alive for: " + catalogBaseUrl);
-
-        Client client = Client.create();
-        WebResource service = client.resource(catalogBaseUrl);
-        ClientResponse response = service.path("status").accept(MediaType.APPLICATION_JSON).head();
-        return response.getStatus() == 200;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/main/java/org/apache/falcon/entity/parser/ClusterEntityParser.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/falcon/entity/parser/ClusterEntityParser.java b/common/src/main/java/org/apache/falcon/entity/parser/ClusterEntityParser.java
index 631ec60..b4e4a95 100644
--- a/common/src/main/java/org/apache/falcon/entity/parser/ClusterEntityParser.java
+++ b/common/src/main/java/org/apache/falcon/entity/parser/ClusterEntityParser.java
@@ -23,13 +23,11 @@ import java.io.IOException;
 import javax.jms.ConnectionFactory;
 
 import org.apache.falcon.FalconException;
-import org.apache.falcon.catalog.CatalogServiceFactory;
 import org.apache.falcon.entity.ClusterHelper;
 import org.apache.falcon.entity.store.StoreAccessException;
 import org.apache.falcon.entity.v0.EntityType;
 import org.apache.falcon.entity.v0.cluster.Cluster;
 import org.apache.falcon.entity.v0.cluster.Interfacetype;
-import org.apache.falcon.entity.v0.cluster.Interface;
 import org.apache.falcon.util.DeploymentUtil;
 import org.apache.falcon.util.StartupProperties;
 import org.apache.falcon.workflow.WorkflowEngineFactory;
@@ -58,9 +56,6 @@ public class ClusterEntityParser extends EntityParser<Cluster> {
         validateScheme(cluster, Interfacetype.WRITE);
         validateScheme(cluster, Interfacetype.WORKFLOW);
         validateScheme(cluster, Interfacetype.MESSAGING);
-        if (ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY) != null) {
-            validateScheme(cluster, Interfacetype.REGISTRY);
-        }
 
         // No interface validations in prism or other falcon servers.
         // Only the falcon server for which the cluster belongs to should validate interfaces
@@ -74,7 +69,8 @@ public class ClusterEntityParser extends EntityParser<Cluster> {
         validateExecuteInterface(cluster);
         validateWorkflowInterface(cluster);
         validateMessagingInterface(cluster);
-        validateRegistryInterface(cluster);
+
+        // Interfacetype.REGISTRY is not validated as its not used
     }
 
     private void validateScheme(Cluster cluster, Interfacetype interfacetype)
@@ -157,27 +153,4 @@ public class ClusterEntityParser extends EntityParser<Cluster> {
                     + " for: " + implementation, e);
         }
     }
-
-    private void validateRegistryInterface(Cluster cluster) throws ValidationException {
-        final Interface catalogInterface = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
-        if (catalogInterface == null) {
-            LOG.info("Catalog service is not enabled for cluster: " + cluster.getName());
-            return;
-        }
-
-        if (!CatalogServiceFactory.isEnabled()) {
-            throw new ValidationException("Catalog registry implementation is not defined: catalog.service.impl");
-        }
-
-        final String catalogUrl = catalogInterface.getEndpoint();
-        LOG.info("Validating catalog registry interface: " + catalogUrl);
-
-        try {
-            if (!CatalogServiceFactory.getCatalogService().isAlive(catalogUrl)) {
-                throw new ValidationException("Unable to reach Catalog server:" + catalogUrl);
-            }
-        } catch (FalconException e) {
-            throw new ValidationException("Invalid Catalog server or port: " + catalogUrl, e);
-        }
-    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/main/resources/startup.properties
----------------------------------------------------------------------
diff --git a/common/src/main/resources/startup.properties b/common/src/main/resources/startup.properties
index 80d46f7..1b4e470 100644
--- a/common/src/main/resources/startup.properties
+++ b/common/src/main/resources/startup.properties
@@ -27,8 +27,6 @@
 *.SchedulableEntityManager.impl=org.apache.falcon.resource.SchedulableEntityManager
 *.ConfigSyncService.impl=org.apache.falcon.resource.ConfigSyncService
 *.ProcessInstanceManager.impl=org.apache.falcon.resource.InstanceManager
-*.catalog.service.impl=org.apache.falcon.catalog.HiveCatalogService
-
 *.application.services=org.apache.falcon.entity.store.ConfigurationStore,\
                         org.apache.falcon.service.ProcessSubscriberService,\
                         org.apache.falcon.rerun.service.RetryService,\

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
----------------------------------------------------------------------
diff --git a/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java b/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
index dffa691..20d14e8 100644
--- a/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
+++ b/common/src/test/java/org/apache/falcon/entity/parser/ClusterEntityParserTest.java
@@ -18,6 +18,15 @@
 
 package org.apache.falcon.entity.parser;
 
+import static org.testng.AssertJUnit.assertEquals;
+
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.StringWriter;
+
+import javax.xml.bind.JAXBException;
+import javax.xml.bind.Marshaller;
+
 import org.apache.falcon.FalconException;
 import org.apache.falcon.cluster.util.EmbeddedCluster;
 import org.apache.falcon.entity.AbstractTestBase;
@@ -26,16 +35,11 @@ import org.apache.falcon.entity.v0.EntityType;
 import org.apache.falcon.entity.v0.cluster.Cluster;
 import org.apache.falcon.entity.v0.cluster.Interface;
 import org.apache.falcon.entity.v0.cluster.Interfacetype;
-import org.apache.falcon.util.StartupProperties;
 import org.testng.Assert;
 import org.testng.annotations.AfterClass;
 import org.testng.annotations.BeforeClass;
 import org.testng.annotations.Test;
 
-import javax.xml.bind.JAXBException;
-import java.io.IOException;
-import java.io.InputStream;
-
 /**
  * Test for validating cluster entity parsing.
  */
@@ -52,45 +56,31 @@ public class ClusterEntityParserTest extends AbstractTestBase {
         ClusterHelper.getInterface(cluster, Interfacetype.WRITE).setEndpoint(conf.get("fs.default.name"));
 
         Assert.assertNotNull(cluster);
-        Assert.assertEquals(cluster.getName(), "testCluster");
+        assertEquals(cluster.getName(), "testCluster");
 
         Interface execute = ClusterHelper.getInterface(cluster, Interfacetype.EXECUTE);
 
-        Assert.assertEquals(execute.getEndpoint(), "localhost:8021");
-        Assert.assertEquals(execute.getVersion(), "0.20.2");
+        assertEquals(execute.getEndpoint(), "localhost:8021");
+        assertEquals(execute.getVersion(), "0.20.2");
 
         Interface readonly = ClusterHelper.getInterface(cluster, Interfacetype.READONLY);
-        Assert.assertEquals(readonly.getEndpoint(), "hftp://localhost:50010");
-        Assert.assertEquals(readonly.getVersion(), "0.20.2");
+        assertEquals(readonly.getEndpoint(), "hftp://localhost:50010");
+        assertEquals(readonly.getVersion(), "0.20.2");
 
         Interface write = ClusterHelper.getInterface(cluster, Interfacetype.WRITE);
         //assertEquals(write.getEndpoint(), conf.get("fs.default.name"));
-        Assert.assertEquals(write.getVersion(), "0.20.2");
+        assertEquals(write.getVersion(), "0.20.2");
 
         Interface workflow = ClusterHelper.getInterface(cluster, Interfacetype.WORKFLOW);
-        Assert.assertEquals(workflow.getEndpoint(), "http://localhost:11000/oozie/");
-        Assert.assertEquals(workflow.getVersion(), "3.1");
-
-        Interface catalog = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
-        Assert.assertEquals(catalog.getEndpoint(), "http://localhost:48080/templeton/v1");
-        Assert.assertEquals(catalog.getVersion(), "0.11.0");
-
-        Assert.assertEquals(ClusterHelper.getLocation(cluster, "staging"), "/projects/falcon/staging");
-    }
-
-    @Test
-    public void testParseClusterWithoutRegistry() throws IOException, FalconException, JAXBException {
-
-        InputStream stream = this.getClass().getResourceAsStream("/config/cluster/cluster-no-registry.xml");
-
-        Cluster cluster = parser.parse(stream);
+        assertEquals(workflow.getEndpoint(), "http://localhost:11000/oozie/");
+        assertEquals(workflow.getVersion(), "3.1");
 
-        Interface catalog = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
-        Assert.assertNull(catalog);
+        assertEquals(ClusterHelper.getLocation(cluster, "staging"), "/projects/falcon/staging");
 
-        StartupProperties.get().setProperty("catalog.service.impl", "");
-        catalog = ClusterHelper.getInterface(cluster, Interfacetype.REGISTRY);
-        Assert.assertNull(catalog);
+        StringWriter stringWriter = new StringWriter();
+        Marshaller marshaller = EntityType.CLUSTER.getMarshaller();
+        marshaller.marshal(cluster, stringWriter);
+        System.out.println(stringWriter.toString());
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/test/resources/config/cluster/cluster-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/cluster/cluster-0.1.xml b/common/src/test/resources/config/cluster/cluster-0.1.xml
index 658711d..fd6e06e 100644
--- a/common/src/test/resources/config/cluster/cluster-0.1.xml
+++ b/common/src/test/resources/config/cluster/cluster-0.1.xml
@@ -29,8 +29,7 @@
                    version="3.1"/>
         <interface type="messaging" endpoint="tcp://localhost:61616?daemon=true"
                    version="5.1.6"/>
-        <interface type="registry" endpoint="http://localhost:48080/templeton/v1"
-                   version="0.11.0"/>
+        <interface type="registry" endpoint="Hcat" version="1"/>
     </interfaces>
     <locations>
         <location name="staging" path="/projects/falcon/staging"/>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/common/src/test/resources/config/cluster/cluster-no-registry.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/cluster/cluster-no-registry.xml b/common/src/test/resources/config/cluster/cluster-no-registry.xml
deleted file mode 100644
index 85dfe32..0000000
--- a/common/src/test/resources/config/cluster/cluster-no-registry.xml
+++ /dev/null
@@ -1,42 +0,0 @@
-<?xml version="1.0"?>
-<!--~
-  ~ 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.
-  -->
-
-<cluster colo="default" description="" name="testCluster" xmlns="uri:falcon:cluster:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, department=forecasting</tags>
-    <interfaces>
-        <interface type="readonly" endpoint="hftp://localhost:50010"
-                   version="0.20.2"/>
-        <interface type="write" endpoint="hdfs://localhost:8020"
-                   version="0.20.2"/>
-        <interface type="execute" endpoint="localhost:8021" version="0.20.2"/>
-        <interface type="workflow" endpoint="http://localhost:11000/oozie/"
-                   version="3.1"/>
-        <interface type="messaging" endpoint="tcp://localhost:61616?daemon=true"
-                   version="5.1.6"/>
-    </interfaces>
-    <locations>
-        <location name="staging" path="/projects/falcon/staging"/>
-        <location name="temp" path="/tmp"/>
-        <location name="working" path="/projects/falcon/working"/>
-    </locations>
-    <properties>
-        <property name="field1" value="value1"/>
-        <property name="field2" value="value2"/>
-    </properties>
-</cluster>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/src/conf/startup.properties
----------------------------------------------------------------------
diff --git a/src/conf/startup.properties b/src/conf/startup.properties
index dca38b4..6b8617e 100644
--- a/src/conf/startup.properties
+++ b/src/conf/startup.properties
@@ -31,8 +31,6 @@
 *.SchedulableEntityManager.impl=org.apache.falcon.resource.SchedulableEntityManager
 *.ConfigSyncService.impl=org.apache.falcon.resource.ConfigSyncService
 *.ProcessInstanceManager.impl=org.apache.falcon.resource.InstanceManager
-*.catalog.service.impl=org.apache.falcon.catalog.HiveCatalogService
-
 *.application.services=org.apache.falcon.entity.store.ConfigurationStore,\
                         org.apache.falcon.service.ProcessSubscriberService,\
                         org.apache.falcon.rerun.service.RetryService,\

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/webapp/src/test/java/org/apache/falcon/resource/ClusterEntityValidationIT.java
----------------------------------------------------------------------
diff --git a/webapp/src/test/java/org/apache/falcon/resource/ClusterEntityValidationIT.java b/webapp/src/test/java/org/apache/falcon/resource/ClusterEntityValidationIT.java
index b96c994..8f2b6e4 100644
--- a/webapp/src/test/java/org/apache/falcon/resource/ClusterEntityValidationIT.java
+++ b/webapp/src/test/java/org/apache/falcon/resource/ClusterEntityValidationIT.java
@@ -77,8 +77,6 @@ public class ClusterEntityValidationIT {
             {Interfacetype.WORKFLOW, "http://workflow-interface:9999/oozie/"},
             {Interfacetype.MESSAGING, "messaging-interface:9999"},
             {Interfacetype.MESSAGING, "tcp://messaging-interface:9999"},
-            {Interfacetype.REGISTRY, "catalog-interface:9999"},
-            {Interfacetype.REGISTRY, "http://catalog-interface:9999"},
         };
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/d422dba4/webapp/src/test/resources/cluster-template.xml
----------------------------------------------------------------------
diff --git a/webapp/src/test/resources/cluster-template.xml b/webapp/src/test/resources/cluster-template.xml
index fbc46c5..11aaedf 100644
--- a/webapp/src/test/resources/cluster-template.xml
+++ b/webapp/src/test/resources/cluster-template.xml
@@ -17,7 +17,8 @@
   limitations under the License.
   -->
 
-<cluster colo="##colo##" description="" name="##cluster##" xmlns="uri:falcon:cluster:0.1">
+<cluster colo="##colo##" description="" name="##cluster##" xmlns="uri:falcon:cluster:0.1"
+        >
     <interfaces>
         <interface type="readonly" endpoint="hftp://localhost:41110"
                    version="0.20.2"/>
@@ -28,8 +29,7 @@
                    version="3.1"/>
         <interface type="messaging" endpoint="tcp://localhost:61616?daemon=true"
                    version="5.1.6"/>
-        <interface type="registry" endpoint="http://localhost:48080/templeton/v1/"
-                   version="0.11.0"/>
+        <interface type="registry" endpoint="Hcat" version="1"/>
     </interfaces>
     <locations>
         <location name="staging" path="/projects/falcon/staging"/>


[4/6] git commit: Merge commit '7b128817689c11969525f82931e0c69d270e7af9' into 85

Posted by ve...@apache.org.
Merge commit '7b128817689c11969525f82931e0c69d270e7af9' into 85

Conflicts:
	CHANGES.txt


Project: http://git-wip-us.apache.org/repos/asf/incubator-falcon/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-falcon/commit/72d18571
Tree: http://git-wip-us.apache.org/repos/asf/incubator-falcon/tree/72d18571
Diff: http://git-wip-us.apache.org/repos/asf/incubator-falcon/diff/72d18571

Branch: refs/heads/FALCON-85
Commit: 72d18571cff2ab1399f617e9f047726727656ec4
Parents: f278ec8 7b12881
Author: Venkatesh Seetharam <ve...@apache.org>
Authored: Mon Sep 23 15:07:38 2013 -0700
Committer: Venkatesh Seetharam <ve...@apache.org>
Committed: Mon Sep 23 15:07:38 2013 -0700

----------------------------------------------------------------------

----------------------------------------------------------------------