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

git commit: FALCON-681 delete duplicate feed retention test from falcon regression contributed by SamarthG

Repository: incubator-falcon
Updated Branches:
  refs/heads/master 9aad374ab -> cb11ff259


FALCON-681 delete duplicate feed retention test from falcon regression contributed by SamarthG


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

Branch: refs/heads/master
Commit: cb11ff2599894f7c97a8c8ffdef612aff45b4343
Parents: 9aad374
Author: Samarth Gupta <sa...@inmobi.com>
Authored: Fri Sep 5 12:18:50 2014 +0530
Committer: Samarth Gupta <sa...@inmobi.com>
Committed: Fri Sep 5 12:18:50 2014 +0530

----------------------------------------------------------------------
 falcon-regression/CHANGES.txt                   |   2 +-
 .../falcon/regression/core/util/BundleUtil.java |   4 -
 .../regression/prism/FeedRetentionTest.java     | 215 -------------------
 .../FETL-BillingRC.xml                          |  14 +-
 .../test/resources/impressionRC/cluster-0.1.xml |  43 ----
 .../impressionRC/feed-FETL-ImpressionRC.xml     |  45 ----
 .../impressionRC/feed-FETL-RequestRC.xml        |  46 ----
 .../resources/impressionRC/feed-FETL2-RRLog.xml |  33 ---
 .../process-FETL-ImpressionRC-Conversion.xml    |  45 ----
 9 files changed, 4 insertions(+), 443 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/CHANGES.txt
----------------------------------------------------------------------
diff --git a/falcon-regression/CHANGES.txt b/falcon-regression/CHANGES.txt
index 0b4714a..20d5882 100644
--- a/falcon-regression/CHANGES.txt
+++ b/falcon-regression/CHANGES.txt
@@ -40,5 +40,5 @@ Trunk (Unreleased)
    mismatched (Raghav Kumar Gautam via Arpit Gupta)
 
   OPTIMIZATIONS
-
+  FALCON-681 delete duplicate feed retention test from falcon regression (SamarthG)
   BUG FIXES

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/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 1f73523..a069dc5 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
@@ -72,10 +72,6 @@ public final class BundleUtil {
         return readBundleFromFolder("LocalDC_feedReplicaltion_BillingRC");
     }
 
-    public static Bundle readImpressionRCBundle() throws IOException {
-        return readBundleFromFolder("impressionRC");
-    }
-
     public static Bundle readUpdateBundle() throws IOException {
         return readBundleFromFolder("updateBundle");
     }

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/FeedRetentionTest.java
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/FeedRetentionTest.java b/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/FeedRetentionTest.java
deleted file mode 100644
index 666a62f..0000000
--- a/falcon-regression/merlin/src/test/java/org/apache/falcon/regression/prism/FeedRetentionTest.java
+++ /dev/null
@@ -1,215 +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.regression.prism;
-
-import org.apache.falcon.regression.core.bundle.Bundle;
-import org.apache.falcon.entity.v0.feed.ActionType;
-import org.apache.falcon.entity.v0.feed.ClusterType;
-import org.apache.falcon.regression.core.helpers.ColoHelper;
-import org.apache.falcon.regression.core.util.AssertUtil;
-import org.apache.falcon.regression.core.util.BundleUtil;
-import org.apache.falcon.regression.core.util.HadoopUtil;
-import org.apache.falcon.regression.core.util.InstanceUtil;
-import org.apache.falcon.regression.core.util.OSUtil;
-import org.apache.falcon.regression.core.util.TimeUtil;
-import org.apache.falcon.regression.core.util.Util;
-import org.apache.falcon.regression.core.util.Util.URLS;
-import org.apache.falcon.regression.core.util.XmlUtil;
-import org.apache.falcon.regression.testHelper.BaseTestClass;
-import org.apache.hadoop.fs.FileSystem;
-import org.apache.log4j.Logger;
-import org.testng.annotations.AfterClass;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeClass;
-import org.testng.annotations.BeforeMethod;
-import org.testng.annotations.Test;
-
-import java.io.IOException;
-import java.lang.reflect.Method;
-import java.util.List;
-
-import org.apache.hadoop.fs.Path;
-
-
-@Test(groups = "embedded")
-public class FeedRetentionTest extends BaseTestClass {
-
-    ColoHelper cluster1 = servers.get(0);
-    ColoHelper cluster2 = servers.get(1);
-    FileSystem cluster1FS = serverFS.get(0);
-    FileSystem cluster2FS = serverFS.get(1);
-    String impressionrcWorkflowDir = baseHDFSDir + "/FeedRetentionTest/impressionrc/";
-    String impressionrcWorkflowLibPath = impressionrcWorkflowDir + "lib";
-    private static final Logger logger = Logger.getLogger(FeedRetentionTest.class);
-
-    @BeforeClass(alwaysRun = true)
-    public void uploadWorkflow() throws Exception {
-        for (FileSystem fs : serverFS) {
-            fs.copyFromLocalFile(new Path(
-                OSUtil.getPath(OSUtil.RESOURCES, "workflows", "impression_rc_workflow.xml")),
-                new Path(impressionrcWorkflowDir + "workflow.xml"));
-            HadoopUtil.uploadDir(fs, impressionrcWorkflowLibPath, OSUtil.RESOURCES_OOZIE + "lib");
-        }
-    }
-
-    @BeforeMethod(alwaysRun = true)
-    public void setUp(Method method) throws Exception {
-        logger.info("test name: " + method.getName());
-        //getImpressionRC bundle
-        bundles[0] = BundleUtil.readImpressionRCBundle();
-        bundles[0].generateUniqueBundle();
-        bundles[0] = new Bundle(bundles[0], cluster1);
-        bundles[0].setProcessWorkflow(impressionrcWorkflowDir);
-
-        bundles[1] = BundleUtil.readImpressionRCBundle();
-        bundles[1].generateUniqueBundle();
-        bundles[1] = new Bundle(bundles[1], cluster2);
-        bundles[1].setProcessWorkflow(impressionrcWorkflowDir);
-    }
-
-    @AfterMethod(alwaysRun = true)
-    public void tearDown() {
-        removeBundles();
-    }
-
-    /**
-     * submit 2 clusters
-     * submit and schedule feed on above 2 clusters, both having different locations
-     * submit and schedule process having the above feed as output feed and running on 2
-     * clusters
-     */
-    @Test(enabled = true)
-    public void testRetentionClickRC_2Colo() throws Exception {
-        String inputPath = baseHDFSDir + "/testInput/";
-        String inputData = inputPath + "${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}";
-        String outputPathTemplate = baseHDFSDir +
-            "/testOutput/op%d/ivoryRetention0%d/%s/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}";
-        String cluster1Def = bundles[0].getClusters().get(0);
-        String cluster2Def = bundles[1].getClusters().get(0);
-        String cluster1Name = Util.readEntityName(cluster1Def);
-        String cluster2Name = Util.readEntityName(cluster2Def);
-
-        List<String> dataDates = TimeUtil.getMinuteDatesOnEitherSide(
-            TimeUtil.getTimeWrtSystemTime(-5), TimeUtil.getTimeWrtSystemTime(10), 1);
-        HadoopUtil.flattenAndPutDataInFolder(cluster1FS, OSUtil.RESOURCES + "thriftRRMar0602.gz",
-            inputPath, dataDates);
-        HadoopUtil.flattenAndPutDataInFolder(cluster2FS, OSUtil.RESOURCES + "thriftRRMar0602.gz",
-            inputPath, dataDates);
-
-        prism.getClusterHelper().submitEntity(URLS.SUBMIT_URL, cluster1Def);
-        prism.getClusterHelper().submitEntity(URLS.SUBMIT_URL, cluster2Def);
-
-        String feedOutput01 = bundles[0].getFeed("FETL-RequestRC");
-        feedOutput01 = InstanceUtil.setFeedCluster(feedOutput01,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-01-01T00:00Z"),
-            XmlUtil.createRtention("days(10000)", ActionType.DELETE), null,
-            ClusterType.SOURCE, null);
-
-        feedOutput01 = InstanceUtil.setFeedCluster(feedOutput01,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-10-01T12:10Z"),
-            XmlUtil.createRtention("minutes(5)", ActionType.DELETE),
-            cluster1Name, ClusterType.SOURCE, "${cluster.colo}",
-            String.format(outputPathTemplate, 1, 1, "data"),
-            String.format(outputPathTemplate, 1, 1, "stats"),
-            String.format(outputPathTemplate, 1, 1, "meta"),
-            String.format(outputPathTemplate, 1, 1, "tmp"));
-
-        feedOutput01 = InstanceUtil.setFeedCluster(feedOutput01,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-10-01T12:25Z"),
-            XmlUtil.createRtention("minutes(5)", ActionType.DELETE),
-            cluster2Name, ClusterType.SOURCE,"${cluster.colo}",
-            String.format(outputPathTemplate, 1, 2, "data"),
-            String.format(outputPathTemplate, 1, 2, "stats"),
-            String.format(outputPathTemplate, 1, 2, "meta"),
-            String.format(outputPathTemplate, 1, 2, "tmp"));
-
-        //submit the new output feed
-        AssertUtil.assertSucceeded(
-            prism.getFeedHelper().submitEntity(URLS.SUBMIT_URL, feedOutput01));
-
-        String feedOutput02 = bundles[0].getFeed("FETL-ImpressionRC");
-        feedOutput02 = InstanceUtil.setFeedCluster(feedOutput02,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-01-01T00:00Z"),
-            XmlUtil.createRtention("days(10000)", ActionType.DELETE), null,
-            ClusterType.SOURCE, null);
-
-        feedOutput02 = InstanceUtil.setFeedCluster(feedOutput02,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-10-01T12:10Z"),
-            XmlUtil.createRtention("minutes(5)", ActionType.DELETE),
-            cluster1Name, ClusterType.SOURCE, "${cluster.colo}",
-            String.format(outputPathTemplate, 2, 1, "data"),
-            String.format(outputPathTemplate, 2, 1, "stats"),
-            String.format(outputPathTemplate, 2, 1, "meta"),
-            String.format(outputPathTemplate, 2, 1, "tmp"));
-
-        feedOutput02 = InstanceUtil.setFeedCluster(feedOutput02,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-10-01T12:25Z"),
-            XmlUtil.createRtention("minutes(5)", ActionType.DELETE),
-            cluster2Name, ClusterType.SOURCE, "${cluster.colo}",
-            String.format(outputPathTemplate, 2, 2, "data"),
-            String.format(outputPathTemplate, 2, 2, "stats"),
-            String.format(outputPathTemplate, 2, 2, "meta"),
-            String.format(outputPathTemplate, 2, 2, "tmp"));
-
-        //submit the new output feed
-        AssertUtil.assertSucceeded(
-            prism.getFeedHelper().submitEntity(URLS.SUBMIT_URL, feedOutput02));
-
-        String feedInput = bundles[0].getFeed("FETL2-RRLog");
-        feedInput = InstanceUtil.setFeedCluster(feedInput,
-                XmlUtil.createValidity("2010-10-01T12:00Z", "2099-01-01T00:00Z"),
-                XmlUtil.createRtention("days(10000)", ActionType.DELETE), null,
-                ClusterType.SOURCE, null);
-
-        feedInput = InstanceUtil.setFeedCluster(feedInput,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-10-01T12:10Z"),
-            XmlUtil.createRtention("minutes(5)", ActionType.DELETE),
-            cluster1Name, ClusterType.SOURCE, "${cluster.colo}", inputData);
-
-        feedInput = InstanceUtil.setFeedCluster(feedInput,
-            XmlUtil.createValidity("2010-10-01T12:00Z", "2099-10-01T12:25Z"),
-            XmlUtil.createRtention("minutes(5)", ActionType.DELETE),
-            cluster2Name, ClusterType.SOURCE, "${cluster.colo}", inputData);
-
-        AssertUtil.assertSucceeded(
-            prism.getFeedHelper().submitAndSchedule(URLS.SUBMIT_AND_SCHEDULE_URL, feedInput));
-
-        String process = bundles[0].getProcessData();
-        process = InstanceUtil.setProcessCluster(process, null,
-            XmlUtil.createProcessValidity("2012-10-01T12:00Z", "2012-10-01T12:10Z"));
-
-        process = InstanceUtil.setProcessCluster(process, cluster1Name,
-            XmlUtil.createProcessValidity(TimeUtil.getTimeWrtSystemTime(-2),
-                TimeUtil.getTimeWrtSystemTime(5)));
-        process = InstanceUtil.setProcessCluster(process, cluster2Name,
-            XmlUtil.createProcessValidity(TimeUtil.getTimeWrtSystemTime(-2),
-                TimeUtil.getTimeWrtSystemTime(5)));
-
-        logger.info("process: " + Util.prettyPrintXml(process));
-        AssertUtil.assertSucceeded(
-            prism.getProcessHelper().submitAndSchedule(URLS.SUBMIT_AND_SCHEDULE_URL, process));
-        AssertUtil.assertSucceeded(prism.getFeedHelper().schedule(URLS.SCHEDULE_URL, feedOutput01));
-        AssertUtil.assertSucceeded(prism.getFeedHelper().schedule(URLS.SCHEDULE_URL, feedOutput02));
-    }
-
-    @AfterClass(alwaysRun = true)
-    public void tearDownClass() throws IOException {
-        cleanTestDirs();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/resources/LocalDC_feedReplicaltion_BillingRC/FETL-BillingRC.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/LocalDC_feedReplicaltion_BillingRC/FETL-BillingRC.xml b/falcon-regression/merlin/src/test/resources/LocalDC_feedReplicaltion_BillingRC/FETL-BillingRC.xml
index d7e0a91..eb31839 100755
--- a/falcon-regression/merlin/src/test/resources/LocalDC_feedReplicaltion_BillingRC/FETL-BillingRC.xml
+++ b/falcon-regression/merlin/src/test/resources/LocalDC_feedReplicaltion_BillingRC/FETL-BillingRC.xml
@@ -27,15 +27,7 @@
     <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>
-        <cluster name="ua2-ruby" type="target" partition="${cluster.colo}">
-            <validity start="2012-07-16T00:00Z" end="2099-07-16T00:00Z"/>
-            <retention limit="days(10000)" action="delete"/>
-        </cluster>
-         <cluster name="prod-gloabl" type="source">
+         <cluster name="clusterName" type="source">
             <validity start="2012-07-20T03:00Z" end="2099-07-16T00:00Z"/>
             <retention limit="days(10000)" action="delete"/>
         </cluster>
@@ -45,8 +37,8 @@
         <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"/>
+    <ACL owner="default" group="group" permission="0x755"/>
+    <schema location="/schemaLocaltion/" provider="protobuf"/>
 
     <properties>
     <property name="field1" value="value1" />

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/resources/impressionRC/cluster-0.1.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/impressionRC/cluster-0.1.xml b/falcon-regression/merlin/src/test/resources/impressionRC/cluster-0.1.xml
deleted file mode 100755
index 144c3b4..0000000
--- a/falcon-regression/merlin/src/test/resources/impressionRC/cluster-0.1.xml
+++ /dev/null
@@ -1,43 +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="gs" description="" name="ua2-staging" xmlns="uri:falcon:cluster:0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
-	<interfaces>
-		<interface type="readonly" endpoint="hftp://gs1001.grid.corp.inmobi.com:50070"
-			version="0.20.2" />
-		<interface type="write" endpoint="hdfs://gs1001.grid.corp.inmobi.com:54310"
-			version="0.20.2" />
-		<interface type="execute" endpoint="hdfs://gs1001.grid.corp.inmobi.com:54311" version="0.20.2" />
-		<interface type="workflow" endpoint="http://gs1001.grid.corp.inmobi.com:11000/oozie/"
-			version="3.1" />
-		<interface type="messaging" endpoint="tcp://gs1001.grid.corp.inmobi.com:61616?daemon=true"
-			version="5.1.6" />
-		
-	</interfaces>
-	<locations>
-		<location name="staging" path="/projects/ivory/staging" />
-		<location name="temp" path="/tmp" />
-		<location name="working" path="/projects/ivory/working" />
-	</locations>
-	<properties>
-		 <property name="colo.name" value="ua2"/>
-        <property name="hbase.zookeeper.quorum" value="10.14.117.33"/>
-        <property name="hbase.zookeeper.property.clientPort" value="2181"/>
-	</properties>
-</cluster>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-ImpressionRC.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-ImpressionRC.xml b/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-ImpressionRC.xml
deleted file mode 100644
index 8b459ff..0000000
--- a/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-ImpressionRC.xml
+++ /dev/null
@@ -1,45 +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="FETL-ImpressionRC" description="RC Impression file and hbase store values generated by iolib" xmlns="uri:falcon:feed:0.1">
-    <partitions>
-        <partition name="EventTime"/>
-        <partition name="PricingModel"/>
-    </partitions>
-    <groups>minutelyrcdata</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-    <frequency>minutes(1)</frequency>
-    <clusters>
-        <cluster name="ua2-staging" >
-		<validity start="2010-12-27T06:00Z" end="2032-11-19T23:00Z"/>
-		<retention limit="days(5)" action="delete" />
-	</cluster>
-    </clusters>
-    <locations>
-        <location type="data" path="/data/fetl/impression/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-        <location type="stats" path="/data/fetl/stats/impression/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-        <location type="tmp" path="/data/fetl/staging/impression/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-    </locations>
-    <ACL owner="fetl" group="users" permission="0x755"/>
-    <schema location="/data/iolib/impressions/schema/" provider="protobuf"/>
-    <properties>
-	<property name="queueName" value="default" />
-	<property name="jobPriority" value="NORMAL" />
-    </properties>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-RequestRC.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-RequestRC.xml b/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-RequestRC.xml
deleted file mode 100644
index e9b47c6..0000000
--- a/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL-RequestRC.xml
+++ /dev/null
@@ -1,46 +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="FETL-RequestRC" description="RC Request file generated by iolib" xmlns="uri:falcon:feed:0.1">
-    <partitions>	
-        <partition name="EventTime"/>
-        <partition name="Fill-Nofill"/>
-    </partitions>
-    <groups>minutelyrcdata</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-    <frequency>minutes(1)</frequency>
-    <clusters>
-        <cluster name="ua2-staging" >
-		<validity start="2010-12-27T06:30Z" end="2099-12-27T07:00Z"/>
-	<retention limit="days(5)" action="delete" />
-	</cluster>
-    </clusters>
-    <locations>
-        <location type="data" path="/data/fetl/request/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-	<location type="stats" path="/data/fetl/stats/request/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-        <location type="tmp" path="/data/fetl/staging/request/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-    </locations>
-    <ACL owner="fetl" group="users" permission="0x755"/>
-    <schema location="/data/iolib/impressions/schema/" provider="protobuf"/>
-    <properties>
-	<property name="queueName" value="default" />
-	<property name="jobPriority" value="NORMAL" />
-    </properties>
-</feed>
-

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL2-RRLog.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL2-RRLog.xml b/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL2-RRLog.xml
deleted file mode 100644
index 2f986d8..0000000
--- a/falcon-regression/merlin/src/test/resources/impressionRC/feed-FETL2-RRLog.xml
+++ /dev/null
@@ -1,33 +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="FETL2-RRLog" description="rr log generated by databus" xmlns="uri:falcon:feed:0.1">
-    <frequency>minutes(1)</frequency>
-    <clusters>
-		<cluster name="ua2-staging">
-			<validity start="2010-12-27T06:00Z" end="2032-10-01T12:00Z" />
-			<retention limit="days(5)" action="delete" />
-		</cluster>
-	</clusters>
-    <locations>
-        <location type="data" path="/databus/streams_local/rr/${YEAR}/${MONTH}/${DAY}/${HOUR}/${MINUTE}"/>
-    </locations>
-    <ACL owner="databus" group="users" permission="0x755"/>
-    <schema location="/databus/streams_local/rr/schema/" provider="protobuf"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/incubator-falcon/blob/cb11ff25/falcon-regression/merlin/src/test/resources/impressionRC/process-FETL-ImpressionRC-Conversion.xml
----------------------------------------------------------------------
diff --git a/falcon-regression/merlin/src/test/resources/impressionRC/process-FETL-ImpressionRC-Conversion.xml b/falcon-regression/merlin/src/test/resources/impressionRC/process-FETL-ImpressionRC-Conversion.xml
deleted file mode 100644
index aff2f78..0000000
--- a/falcon-regression/merlin/src/test/resources/impressionRC/process-FETL-ImpressionRC-Conversion.xml
+++ /dev/null
@@ -1,45 +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="FETL-ImpressionRC-Conversion" xmlns="uri:falcon:process:0.1">
-    <clusters>
-        <cluster name="ua2-staging">
-            <validity start="2013-02-07T12:00Z" end="2019-02-07T12:10Z"/>
-        </cluster>
-    </clusters>
-    <parallel>1</parallel>
-    <order>FIFO</order>
-    <frequency>minutes(1)</frequency>
-    <inputs>
-        <input name="Input" feed="FETL2-RRLog" start="now(0,0)" end="now(0,0)"/>
-        <input name="Gate" feed="FETL2-RRLog" start="now(0,1)" end="now(0,1)"/>
-    </inputs>
-    <outputs>
-        <output name="Output" feed="FETL-RequestRC" instance="now(0,0)"/>
-	<output name="ImpressionPath" feed="FETL-ImpressionRC" instance="now(0,0)"/>
-    </outputs>
-    <properties>
-        <property name="logType" value="request"/>
-        <property name="jobPriority" value="VERY_HIGH" />
-	<property name="queueName" value="default" />
-    </properties>
-    <workflow path="/projects/localdc/lda/impressionrc-conversion"/>
-    <retry policy="exp-backoff" delay="minutes(1)" attempts="3"/>
-</process>
-