You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@falcon.apache.org by ro...@apache.org on 2014/12/09 14:13:43 UTC

incubator-falcon git commit: FALCON-939 Fixing few typos and removing unused stuff. Contributed by Paul Isaychuk

Repository: incubator-falcon
Updated Branches:
  refs/heads/master 2ebfdc155 -> 73c9b9f54


FALCON-939 Fixing few typos and removing unused stuff. Contributed by Paul Isaychuk


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

Branch: refs/heads/master
Commit: 73c9b9f54f1d4f79597997818a1829b4be5dd7fd
Parents: 2ebfdc1
Author: Ruslan Ostafiychuk <ro...@apache.org>
Authored: Tue Dec 9 15:11:27 2014 +0200
Committer: Ruslan Ostafiychuk <ro...@apache.org>
Committed: Tue Dec 9 15:11:27 2014 +0200

----------------------------------------------------------------------
 falcon-regression/CHANGES.txt                   |  2 +
 .../falcon/regression/core/util/BundleUtil.java |  4 +-
 .../falcon/regression/ExternalFSTest.java       |  2 +-
 .../falcon/regression/FeedLateRerunTest.java    |  2 +-
 .../falcon/regression/FeedReplicationTest.java  |  2 +-
 .../PrismFeedReplicationPartitionExpTest.java   |  2 +-
 .../prism/PrismProcessScheduleTest.java         |  2 +-
 .../prism/UpdateAtSpecificTimeTest.java         |  2 +-
 .../EmptyInputTagProcess/cluster-0.1.xml        | 41 ---------------
 .../EmptyInputTagProcess/feed-template1.xml     | 52 --------------------
 .../EmptyInputTagProcess/feed-template2.xml     | 52 --------------------
 .../EmptyInputTagProcess/process-agg.xml        | 50 -------------------
 .../EmptyOutputTagProcess/cluster-0.1.xml       | 41 ---------------
 .../EmptyOutputTagProcess/feed-template1.xml    | 52 --------------------
 .../EmptyOutputTagProcess/feed-template2.xml    | 52 --------------------
 .../EmptyOutputTagProcess/process-agg.xml       | 50 -------------------
 .../FeedReplicaltionBundles/InputFeed.xml       | 47 ------------------
 .../FeedReplicaltionBundles/cluster-0.1.xml     | 38 --------------
 .../FeedReplicationBundles/InputFeed.xml        | 47 ++++++++++++++++++
 .../FeedReplicationBundles/cluster-0.1.xml      | 38 ++++++++++++++
 20 files changed, 95 insertions(+), 483 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/CHANGES.txt
----------------------------------------------------------------------
diff --git a/falcon-regression/CHANGES.txt b/falcon-regression/CHANGES.txt
index 87eed47..8ae1c7a 100644
--- a/falcon-regression/CHANGES.txt
+++ b/falcon-regression/CHANGES.txt
@@ -36,6 +36,8 @@ Trunk (Unreleased)
    via Samarth Gupta)
 
   IMPROVEMENTS
+   FALCON-939 Fixing few typos and removing unused stuff (Paul Isaychuk via Ruslan Ostafiychuk)
+
    FALCON-930 Delete old project name (ivory) from code and xmls (Ruslan Ostafiychuk via Raghav
    Kumar Gautam)
 

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin-core/src/main/java/org/apache/falcon/regression/core/util/BundleUtil.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin-core/src/main/java/org/apache/falcon/regression/core/util/BundleUtil.java b/falcon-regression/merlin-core/src/main/java/org/apache/falcon/regression/core/util/BundleUtil.java
index f52d563..6e25a60 100644
--- a/falcon-regression/merlin-core/src/main/java/org/apache/falcon/regression/core/util/BundleUtil.java
+++ b/falcon-regression/merlin-core/src/main/java/org/apache/falcon/regression/core/util/BundleUtil.java
@@ -51,8 +51,8 @@ public final class BundleUtil {
     }
     private static final Logger LOGGER = Logger.getLogger(BundleUtil.class);
 
-    public static Bundle readFeedReplicaltionBundle() throws IOException {
-        return readBundleFromFolder("FeedReplicaltionBundles");
+    public static Bundle readFeedReplicationBundle() throws IOException {
+        return readBundleFromFolder("FeedReplicationBundles");
     }
 
     public static Bundle readLateDataBundle() throws IOException {

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/ExternalFSTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/ExternalFSTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/ExternalFSTest.java
index 0cd3284..9c2a42b 100644
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/ExternalFSTest.java
+++ b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/ExternalFSTest.java
@@ -95,7 +95,7 @@ public class ExternalFSTest extends BaseTestClass{
     @BeforeMethod(alwaysRun = true)
     public void setUp(Method method) throws JAXBException, IOException {
         LOGGER.info("test name: " + method.getName());
-        Bundle bundle = BundleUtil.readFeedReplicaltionBundle();
+        Bundle bundle = BundleUtil.readFeedReplicationBundle();
 
         bundles[0] = new Bundle(bundle, cluster);
         bundles[1] = new Bundle(bundle, cluster2);

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedLateRerunTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedLateRerunTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedLateRerunTest.java
index 11763c3..da38085 100644
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedLateRerunTest.java
+++ b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedLateRerunTest.java
@@ -66,7 +66,7 @@ public class FeedLateRerunTest extends BaseTestClass {
     @BeforeMethod(alwaysRun = true)
     public void setUp(Method method) throws JAXBException, IOException {
         LOGGER.info("test name: " + method.getName());
-        Bundle bundle = BundleUtil.readFeedReplicaltionBundle();
+        Bundle bundle = BundleUtil.readFeedReplicationBundle();
 
         bundles[0] = new Bundle(bundle, cluster1);
         bundles[1] = new Bundle(bundle, cluster2);

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedReplicationTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedReplicationTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedReplicationTest.java
index 6c61a4a..e99bebd 100644
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedReplicationTest.java
+++ b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/FeedReplicationTest.java
@@ -80,7 +80,7 @@ public class FeedReplicationTest extends BaseTestClass {
     @BeforeMethod(alwaysRun = true)
     public void setUp(Method method) throws JAXBException, IOException {
         LOGGER.info("test name: " + method.getName());
-        Bundle bundle = BundleUtil.readFeedReplicaltionBundle();
+        Bundle bundle = BundleUtil.readFeedReplicationBundle();
 
         bundles[0] = new Bundle(bundle, cluster1);
         bundles[1] = new Bundle(bundle, cluster2);

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismFeedReplicationPartitionExpTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismFeedReplicationPartitionExpTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismFeedReplicationPartitionExpTest.java
index d7df953..315a9d1 100755
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismFeedReplicationPartitionExpTest.java
+++ b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismFeedReplicationPartitionExpTest.java
@@ -176,7 +176,7 @@ public class PrismFeedReplicationPartitionExpTest extends BaseTestClass {
     @BeforeMethod(alwaysRun = true)
     public void testName(Method method) throws Exception {
         LOGGER.info("test name: " + method.getName());
-        Bundle bundle = BundleUtil.readFeedReplicaltionBundle();
+        Bundle bundle = BundleUtil.readFeedReplicationBundle();
 
         for (int i = 0; i < 3; i++) {
             bundles[i] = new Bundle(bundle, servers.get(i));

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismProcessScheduleTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismProcessScheduleTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismProcessScheduleTest.java
index fdbbfdb..e00b4db 100644
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismProcessScheduleTest.java
+++ b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/PrismProcessScheduleTest.java
@@ -47,7 +47,7 @@ import java.lang.reflect.Method;
 import java.util.ArrayList;
 
 /**
- * Schedule process via prsm tests.
+ * Schedule process via prism tests.
  */
 public class PrismProcessScheduleTest extends BaseTestClass {
 

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/UpdateAtSpecificTimeTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/UpdateAtSpecificTimeTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/UpdateAtSpecificTimeTest.java
index 1b0a6a3..a72d1cc 100644
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/UpdateAtSpecificTimeTest.java
+++ b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/UpdateAtSpecificTimeTest.java
@@ -82,7 +82,7 @@ public class UpdateAtSpecificTimeTest extends BaseTestClass {
     @BeforeMethod(alwaysRun = true)
     public void setup(Method method) throws IOException {
         LOGGER.info("test name: " + method.getName());
-        Bundle bundle = BundleUtil.readFeedReplicaltionBundle();
+        Bundle bundle = BundleUtil.readFeedReplicationBundle();
         bundles[0] = new Bundle(bundle, cluster1);
         bundles[1] = new Bundle(bundle, cluster2);
         bundles[2] = new Bundle(bundle, cluster3);

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/cluster-0.1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/cluster-0.1.xml b/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/cluster-0.1.xml
deleted file mode 100644
index 6478384..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/cluster-0.1.xml
+++ /dev/null
@@ -1,41 +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="ua1" description="" name="corp" xmlns="uri:falcon:cluster:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-	<interfaces>
-		<interface type="readonly" endpoint="http://host:50070"
-			version="0.20.2" />
-		<interface type="write" endpoint="hdfs://host:54310"
-			version="0.20.2" />
-		<interface type="execute" endpoint="hdfs://host:54311" version="0.20.2" />
-		<interface type="workflow" endpoint="http://host:11000/oozie/"
-			version="3.1" />
-		<interface type="messaging" endpoint="tcp://host: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/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template1.xml b/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template1.xml
deleted file mode 100644
index 52e8463..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template1.xml
+++ /dev/null
@@ -1,52 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  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.
-  -->
-<feed description="clicks log" name="raaw-logs16" xmlns="uri:falcon:feed:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-   <partitions>
-        <partition name="country" />
-        <partition name="colo" />
-    </partitions>
-<!--
-    <groups>online,bi</groups>-->
-
-    <frequency>minutes(20)</frequency>
-    <timezone>UTC</timezone>
-    <late-arrival cut-off="hours(6)" />
-
-    <clusters>
-        <cluster name="corp" type="source">
-            <validity start="2009-02-01T00:00Z" end="2099-05-01T00:00Z"
-     />
-            <retention limit="months(9000)" action="delete" /> <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/test/input-data/rawLogs/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}" />
-        <location type="stats" path="/projects/falcon/clicksStats" />
-        <location type="meta" path="/projects/falcon/clicksMetaData" />
-    </locations>
-    
-    <ACL owner="testuser" group="group" permission="0x755" />
-    <schema location="/schema/clicks" provider="protobuf" />
-
-    <properties>
-        <property name="field1" value="value1" />
-        <property name="field2" value="value2" />
-    </properties>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template2.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template2.xml b/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template2.xml
deleted file mode 100644
index 94dbe52..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/feed-template2.xml
+++ /dev/null
@@ -1,52 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  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.
-  -->
-<feed description="clicks log" name="agregated-logs16" xmlns="uri:falcon:feed:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-<!--   <partitions>
-        <partition name="fraud" />
-        <partition name="good" />
-    </partitions>
-
-    <groups>online,bi</groups>-->
-
-    <frequency>hours(1)</frequency>
-<timezone>UTC</timezone>
-    <late-arrival cut-off="hours(6)" />
-
-    <clusters>
-        <cluster name="corp" type="source">
-            <validity start="2009-02-01T01:00Z" end="2099-05-01T00:00Z"
-           />
-            <retention limit="hours(6)" action="delete" /> <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/examples/output-data/aggregator/aggregatedLogs/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}" />
-        <location type="stats" path="/projects/falcon/clicksStats" />
-        <location type="meta" path="/projects/falcon/clicksMetaData" />
-    </locations>
-    
-    <ACL owner="testuser" group="group" permission="0x755" />
-    <schema location="/schema/clicks" provider="protobuf" />
-
-    <properties>
-        <property name="field1" value="value1" />
-        <property name="field2" value="value2" />
-    </properties>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/process-agg.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/process-agg.xml b/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/process-agg.xml
deleted file mode 100644
index 3f23ffe..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyInputTagProcess/process-agg.xml
+++ /dev/null
@@ -1,50 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="yes"?>
-<!--
-  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.
-  -->
-
-<process name="agregator-coord16" xmlns="uri:falcon:process:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-
-       <clusters>
-        <cluster name="corp">
-           <validity end="2011-01-03T03:00Z" start="2010-01-02T01:00Z" />  
-        </cluster>
-      </clusters>
-	<parallel>1</parallel>
-	<order>FIFO</order>
-       <frequency>minutes(5)</frequency>
-	<timezone>UTC</timezone>
-	
-	<inputs>
-
-	</inputs>
-	<outputs>
-		<output instance="now(0,0)" feed="agregated-logs16"
-			name="outputData" />
-	</outputs>
-	<properties>
-		<property name="queueName" value="default"/>
-		
-       <property name="fileTime" value="${formatTime(dateOffset(instanceTime(), 1, 'DAY'), 'yyyy-MMM-dd')}"/>
-       <property name="user" value="${user()}"/>
-   
-	</properties>
-	<workflow path="/examples/apps/aggregator"/>
-	<retry policy="periodic" delay="minutes(3)" attempts="3" />
-
-</process>
-

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/cluster-0.1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/cluster-0.1.xml b/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/cluster-0.1.xml
deleted file mode 100644
index 6478384..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/cluster-0.1.xml
+++ /dev/null
@@ -1,41 +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="ua1" description="" name="corp" xmlns="uri:falcon:cluster:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-	<interfaces>
-		<interface type="readonly" endpoint="http://host:50070"
-			version="0.20.2" />
-		<interface type="write" endpoint="hdfs://host:54310"
-			version="0.20.2" />
-		<interface type="execute" endpoint="hdfs://host:54311" version="0.20.2" />
-		<interface type="workflow" endpoint="http://host:11000/oozie/"
-			version="3.1" />
-		<interface type="messaging" endpoint="tcp://host: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/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template1.xml b/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template1.xml
deleted file mode 100644
index 52e8463..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template1.xml
+++ /dev/null
@@ -1,52 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  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.
-  -->
-<feed description="clicks log" name="raaw-logs16" xmlns="uri:falcon:feed:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-   <partitions>
-        <partition name="country" />
-        <partition name="colo" />
-    </partitions>
-<!--
-    <groups>online,bi</groups>-->
-
-    <frequency>minutes(20)</frequency>
-    <timezone>UTC</timezone>
-    <late-arrival cut-off="hours(6)" />
-
-    <clusters>
-        <cluster name="corp" type="source">
-            <validity start="2009-02-01T00:00Z" end="2099-05-01T00:00Z"
-     />
-            <retention limit="months(9000)" action="delete" /> <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/test/input-data/rawLogs/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}" />
-        <location type="stats" path="/projects/falcon/clicksStats" />
-        <location type="meta" path="/projects/falcon/clicksMetaData" />
-    </locations>
-    
-    <ACL owner="testuser" group="group" permission="0x755" />
-    <schema location="/schema/clicks" provider="protobuf" />
-
-    <properties>
-        <property name="field1" value="value1" />
-        <property name="field2" value="value2" />
-    </properties>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template2.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template2.xml b/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template2.xml
deleted file mode 100644
index 94dbe52..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/feed-template2.xml
+++ /dev/null
@@ -1,52 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  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.
-  -->
-<feed description="clicks log" name="agregated-logs16" xmlns="uri:falcon:feed:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-<!--   <partitions>
-        <partition name="fraud" />
-        <partition name="good" />
-    </partitions>
-
-    <groups>online,bi</groups>-->
-
-    <frequency>hours(1)</frequency>
-<timezone>UTC</timezone>
-    <late-arrival cut-off="hours(6)" />
-
-    <clusters>
-        <cluster name="corp" type="source">
-            <validity start="2009-02-01T01:00Z" end="2099-05-01T00:00Z"
-           />
-            <retention limit="hours(6)" action="delete" /> <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/examples/output-data/aggregator/aggregatedLogs/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}" />
-        <location type="stats" path="/projects/falcon/clicksStats" />
-        <location type="meta" path="/projects/falcon/clicksMetaData" />
-    </locations>
-    
-    <ACL owner="testuser" group="group" permission="0x755" />
-    <schema location="/schema/clicks" provider="protobuf" />
-
-    <properties>
-        <property name="field1" value="value1" />
-        <property name="field2" value="value2" />
-    </properties>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/process-agg.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/process-agg.xml b/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/process-agg.xml
deleted file mode 100644
index 2175e24..0000000
--- a/falcon-regression/merlin/src/test/resources/EmptyOutputTagProcess/process-agg.xml
+++ /dev/null
@@ -1,50 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="yes"?>
-<!--
-  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.
-  -->
-
-<process name="agregator-coord16" xmlns="uri:falcon:process:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-
-       <clusters>
-        <cluster name="corp">
-           <validity end="2011-01-03T03:00Z" start="2010-01-02T01:00Z" />  
-        </cluster>
-      </clusters>
-	<parallel>1</parallel>
-	<order>FIFO</order>
-       <frequency>minutes(5)</frequency>
-	<timezone>UTC</timezone>
-	
-	<inputs>
-		<input end="now(0,0)" start="now(0,-20)"
-			feed="raaw-logs16" name="inputData"/>
-	</inputs>
-	<outputs>
-
-	</outputs>
-	<properties>
-		<property name="queueName" value="default"/>
-		
-       <property name="fileTime" value="${formatTime(dateOffset(instanceTime(), 1, 'DAY'), 'yyyy-MMM-dd')}"/>
-       <property name="user" value="${user()}"/>
-   
-	</properties>
-	<workflow path="/examples/apps/aggregator"/>
-	<retry policy="periodic" delay="minutes(3)" attempts="3" />
-
-</process>
-

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/InputFeed.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/InputFeed.xml b/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/InputFeed.xml
deleted file mode 100755
index 4ddda84..0000000
--- a/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/InputFeed.xml
+++ /dev/null
@@ -1,47 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="yes"?>
-<!--
-  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.
-  -->
-
-<feed name="InputFeed" description="Input File" xmlns="uri:falcon:feed:0.1">
-    <partitions>
-        <partition name="colo"/>
-        <partition name="eventTime"/>
-        <partition name="impressionHour"/>
-        <partition name="pricingModel"/>
-    </partitions>
-    <frequency>minutes(5)</frequency>
-    <late-arrival cut-off="days(100000)"/>
-    <clusters>
-        <cluster name="lhr1-emerald" type="target" partition="${cluster.colo}">
-            <validity start="2012-07-20T00:00Z" end="2099-07-16T00:00Z"/>
-            <retention limit="days(10000)" action="delete"/>
-        </cluster>
-    </clusters>
-    <locations>
-        <location type="data" path="/data/regression/fetlrc/billing/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-        <location type="stats" path="/data/regression/fetlrc/billing/stats"/>
-        <location type="meta" path="/data/regression/fetlrc/billing/metadata"/>
-    </locations>
-    <ACL owner="fetl" group="group" permission="0x755"/>
-    <schema location="/databus/streams_local/click_rr/schema/" provider="protobuf"/>
-
-    <properties>
-    <property name="field1" value="value1" />
-    <property name="field2" value="value2" />
-  </properties>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/cluster-0.1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/cluster-0.1.xml b/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/cluster-0.1.xml
deleted file mode 100755
index 0ae5489..0000000
--- a/falcon-regression/merlin/src/test/resources/FeedReplicaltionBundles/cluster-0.1.xml
+++ /dev/null
@@ -1,38 +0,0 @@
-<?xml version="1.0" encoding="UTF-8" standalone="yes"?>
-<!--
-  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 name="falcon2-stg4" description="" colo="stg" xmlns="uri:falcon:cluster:0.1">
-    <interfaces>
-        <interface type="readonly" endpoint="hftp://host:50070" version="0.20.2-cdh3u0"/>
-        <interface type="execute" endpoint="host:54311" version="0.20.2-cdh3u0"/>
-        <interface type="write" endpoint="hdfs://host:54310" version="0.20.2-cdh3u0"/>
-        <interface type="messaging" endpoint="tcp://host:61618?daemon=true" version="5.1.6"/>
-        <interface type="workflow" endpoint="http://host:11002/oozie/" version="3.1.4"/>
-    </interfaces>
-    <locations>
-        <location name="staging" path="/projects/falcon/stg/staging"/>
-        <location name="temp" path="/tmp"/>
-        <location name="working" path="/projects/falcon/stg/working"/>
-    </locations>
-    <properties>
-        <property name="colo.name" value="ua1"/>
-        <property name="hbase.zookeeper.quorum" value="192.168.138.115"/>
-        <property name="hbase.zookeeper.property.clientPort" value="2181"/>
-    </properties>
-</cluster>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/InputFeed.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/InputFeed.xml b/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/InputFeed.xml
new file mode 100755
index 0000000..4ddda84
--- /dev/null
+++ b/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/InputFeed.xml
@@ -0,0 +1,47 @@
+<?xml version="1.0" encoding="UTF-8" standalone="yes"?>
+<!--
+  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.
+  -->
+
+<feed name="InputFeed" description="Input File" xmlns="uri:falcon:feed:0.1">
+    <partitions>
+        <partition name="colo"/>
+        <partition name="eventTime"/>
+        <partition name="impressionHour"/>
+        <partition name="pricingModel"/>
+    </partitions>
+    <frequency>minutes(5)</frequency>
+    <late-arrival cut-off="days(100000)"/>
+    <clusters>
+        <cluster name="lhr1-emerald" type="target" partition="${cluster.colo}">
+            <validity start="2012-07-20T00:00Z" end="2099-07-16T00:00Z"/>
+            <retention limit="days(10000)" action="delete"/>
+        </cluster>
+    </clusters>
+    <locations>
+        <location type="data" path="/data/regression/fetlrc/billing/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
+        <location type="stats" path="/data/regression/fetlrc/billing/stats"/>
+        <location type="meta" path="/data/regression/fetlrc/billing/metadata"/>
+    </locations>
+    <ACL owner="fetl" group="group" permission="0x755"/>
+    <schema location="/databus/streams_local/click_rr/schema/" provider="protobuf"/>
+
+    <properties>
+    <property name="field1" value="value1" />
+    <property name="field2" value="value2" />
+  </properties>
+</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/73c9b9f5/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/cluster-0.1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/cluster-0.1.xml b/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/cluster-0.1.xml
new file mode 100755
index 0000000..0ae5489
--- /dev/null
+++ b/falcon-regression/merlin/src/test/resources/FeedReplicationBundles/cluster-0.1.xml
@@ -0,0 +1,38 @@
+<?xml version="1.0" encoding="UTF-8" standalone="yes"?>
+<!--
+  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 name="falcon2-stg4" description="" colo="stg" xmlns="uri:falcon:cluster:0.1">
+    <interfaces>
+        <interface type="readonly" endpoint="hftp://host:50070" version="0.20.2-cdh3u0"/>
+        <interface type="execute" endpoint="host:54311" version="0.20.2-cdh3u0"/>
+        <interface type="write" endpoint="hdfs://host:54310" version="0.20.2-cdh3u0"/>
+        <interface type="messaging" endpoint="tcp://host:61618?daemon=true" version="5.1.6"/>
+        <interface type="workflow" endpoint="http://host:11002/oozie/" version="3.1.4"/>
+    </interfaces>
+    <locations>
+        <location name="staging" path="/projects/falcon/stg/staging"/>
+        <location name="temp" path="/tmp"/>
+        <location name="working" path="/projects/falcon/stg/working"/>
+    </locations>
+    <properties>
+        <property name="colo.name" value="ua1"/>
+        <property name="hbase.zookeeper.quorum" value="192.168.138.115"/>
+        <property name="hbase.zookeeper.property.clientPort" value="2181"/>
+    </properties>
+</cluster>