You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@falcon.apache.org by pa...@apache.org on 2016/03/01 09:26:12 UTC

[26/51] [partial] falcon git commit: FALCON-1830 Removed code source directories and updated pom

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/java/org/apache/falcon/workflow/WorkflowExecutionContextTest.java
----------------------------------------------------------------------
diff --git a/common/src/test/java/org/apache/falcon/workflow/WorkflowExecutionContextTest.java b/common/src/test/java/org/apache/falcon/workflow/WorkflowExecutionContextTest.java
deleted file mode 100644
index c0bc252..0000000
--- a/common/src/test/java/org/apache/falcon/workflow/WorkflowExecutionContextTest.java
+++ /dev/null
@@ -1,341 +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.workflow;
-
-import org.apache.falcon.entity.v0.SchemaHelper;
-import org.apache.falcon.entity.v0.process.EngineType;
-import org.testng.Assert;
-import org.testng.annotations.BeforeMethod;
-import org.testng.annotations.Test;
-
-import java.util.Date;
-
-
-/**
- * A test for WorkflowExecutionContext.
- */
-public class WorkflowExecutionContextTest {
-
-    private static final String FALCON_USER = "falcon-user";
-    private static final String LOGS_DIR = "target/log";
-    private static final String NOMINAL_TIME = "2014-01-01-01-00";
-    private static final String OPERATION = "GENERATE";
-
-    private static final String CLUSTER_NAME = "primary-cluster";
-    private static final String ENTITY_NAME = "sample-process";
-    private static final String WORKFLOW_NAME = "imp-click-join-workflow";
-    private static final String WORKFLOW_VERSION = "1.0.9";
-
-    private static final String INPUT_FEED_NAMES = "impression-feed#clicks-feed";
-    private static final String INPUT_INSTANCE_PATHS =
-            "jail://global:00/falcon/impression-feed/2014/01/01,jail://global:00/falcon/impression-feed/2014/01/02"
-                    + "#jail://global:00/falcon/clicks-feed/2014-01-01";
-
-    private static final String OUTPUT_FEED_NAMES = "imp-click-join1,imp-click-join2";
-    private static final String OUTPUT_INSTANCE_PATHS =
-            "jail://global:00/falcon/imp-click-join1/20140101,jail://global:00/falcon/imp-click-join2/20140101";
-
-    private static final String BROKER = "org.apache.activemq.ActiveMQConnectionFactory";
-
-    private static final String ISO8601_TIME = SchemaHelper.formatDateUTCToISO8601(
-            NOMINAL_TIME, WorkflowExecutionContext.INSTANCE_FORMAT);
-
-    private WorkflowExecutionContext context;
-
-    @BeforeMethod
-    public void setUp() throws Exception {
-        context = WorkflowExecutionContext.create(getTestMessageArgs(),
-                WorkflowExecutionContext.Type.POST_PROCESSING);
-    }
-
-    @Test
-    public void testGetValue() throws Exception {
-        Assert.assertEquals(context.getValue(WorkflowExecutionArgs.ENTITY_NAME), ENTITY_NAME);
-    }
-
-    @Test
-    public void testGetValueWithDefault() throws Exception {
-        Assert.assertEquals(context.getValue(WorkflowExecutionArgs.TOPIC_NAME, "ABSENT"), "ABSENT");
-    }
-
-    @Test
-    public void testContainsKey() throws Exception {
-        Assert.assertTrue(context.containsKey(WorkflowExecutionArgs.ENTITY_NAME));
-        Assert.assertFalse(context.containsKey(WorkflowExecutionArgs.TOPIC_NAME));
-    }
-
-    @Test
-    public void testEntrySet() throws Exception {
-        Assert.assertNotNull(context.entrySet());
-    }
-
-    @Test
-    public void testHasWorkflowSucceeded() throws Exception {
-        Assert.assertTrue(context.hasWorkflowSucceeded());
-        Assert.assertEquals(context.getWorkflowStatus(), WorkflowExecutionContext.Status.SUCCEEDED);
-    }
-
-    @Test
-    public void testHasWorkflowFailed() throws Exception {
-        Assert.assertFalse(context.hasWorkflowFailed());
-    }
-
-    @Test
-    public void testGetContextFile() throws Exception {
-        Assert.assertEquals(context.getContextFile(),
-                WorkflowExecutionContext.getFilePath(context.getLogDir(), context.getEntityName(),
-                        context.getEntityType(), context.getOperation()));
-    }
-
-    @Test
-    public void testGetLogDir() throws Exception {
-        Assert.assertEquals(context.getLogDir(), LOGS_DIR);
-    }
-
-    @Test
-    public void testGetLogFile() throws Exception {
-        Assert.assertEquals(context.getLogFile(), LOGS_DIR + "/log.txt");
-    }
-
-    @Test
-    public void testGetNominalTime() throws Exception {
-        Assert.assertEquals(context.getNominalTime(), NOMINAL_TIME);
-    }
-
-    @Test
-    public void testGetNominalTimeAsISO8601() throws Exception {
-        Assert.assertEquals(context.getNominalTimeAsISO8601(), ISO8601_TIME);
-    }
-
-    @Test
-    public void testGetTimestamp() throws Exception {
-        Assert.assertEquals(context.getTimestamp(), NOMINAL_TIME);
-    }
-
-    @Test
-    public void testGetTimeStampAsISO8601() throws Exception {
-        Assert.assertEquals(context.getTimeStampAsISO8601(), ISO8601_TIME);
-    }
-
-    @Test
-    public void testGetClusterName() throws Exception {
-        Assert.assertEquals(context.getClusterName(), CLUSTER_NAME);
-    }
-
-    @Test
-    public void testGetEntityName() throws Exception {
-        Assert.assertEquals(context.getEntityName(), ENTITY_NAME);
-    }
-
-    @Test
-    public void testGetEntityType() throws Exception {
-        Assert.assertEquals(context.getEntityType(), "PROCESS");
-    }
-
-    @Test
-    public void testGetOperation() throws Exception {
-        Assert.assertEquals(context.getOperation().name(), OPERATION);
-    }
-
-    @Test
-    public void testGetOutputFeedNames() throws Exception {
-        Assert.assertEquals(context.getOutputFeedNames(), OUTPUT_FEED_NAMES);
-    }
-
-    @Test
-    public void testGetOutputFeedNamesList() throws Exception {
-        Assert.assertEquals(context.getOutputFeedNamesList(),
-                OUTPUT_FEED_NAMES.split(WorkflowExecutionContext.OUTPUT_FEED_SEPARATOR));
-    }
-
-    @Test
-    public void testGetOutputFeedInstancePaths() throws Exception {
-        Assert.assertEquals(context.getOutputFeedInstancePaths(), OUTPUT_INSTANCE_PATHS);
-    }
-
-    @Test
-    public void testGetOutputFeedInstancePathsList() throws Exception {
-        Assert.assertEquals(context.getOutputFeedInstancePathsList(),
-                OUTPUT_INSTANCE_PATHS.split(","));
-    }
-
-    @Test
-    public void testGetInputFeedNames() throws Exception {
-        Assert.assertEquals(context.getOutputFeedNames(), OUTPUT_FEED_NAMES);
-    }
-
-    @Test
-    public void testGetInputFeedNamesList() throws Exception {
-        Assert.assertEquals(context.getInputFeedNamesList(),
-                INPUT_FEED_NAMES.split(WorkflowExecutionContext.INPUT_FEED_SEPARATOR));
-    }
-
-    @Test
-    public void testGetInputFeedInstancePaths() throws Exception {
-        Assert.assertEquals(context.getInputFeedInstancePaths(), INPUT_INSTANCE_PATHS);
-    }
-
-    @Test
-    public void testGetInputFeedInstancePathsList() throws Exception {
-        Assert.assertEquals(context.getInputFeedInstancePathsList(),
-                INPUT_INSTANCE_PATHS.split("#"));
-    }
-
-    @Test
-    public void testGetWorkflowEngineUrl() throws Exception {
-        Assert.assertEquals(context.getWorkflowEngineUrl(), "http://localhost:11000/oozie");
-    }
-
-    @Test
-    public void testGetUserWorkflowEngine() throws Exception {
-        Assert.assertEquals(context.getUserWorkflowEngine(), EngineType.PIG.name());
-    }
-
-    @Test
-    public void testGetUserWorkflowVersion() throws Exception {
-        Assert.assertEquals(context.getUserWorkflowVersion(), WORKFLOW_VERSION);
-    }
-
-    @Test
-    public void testGetWorkflowId() throws Exception {
-        Assert.assertEquals(context.getWorkflowId(), "workflow-01-00");
-    }
-
-    @Test
-    public void testGetUserSubflowId() throws Exception {
-        Assert.assertEquals(context.getUserSubflowId(), "userflow@wf-id");
-    }
-
-    @Test
-    public void testGetWorkflowRunId() throws Exception {
-        Assert.assertEquals(context.getWorkflowRunId(), 1);
-    }
-
-    @Test
-    public void testGetWorkflowRunIdString() throws Exception {
-        Assert.assertEquals(context.getWorkflowRunIdString(), "1");
-    }
-
-    @Test
-    public void testGetWorkflowUser() throws Exception {
-        Assert.assertEquals(context.getWorkflowUser(), FALCON_USER);
-    }
-
-    @Test
-    public void testGetExecutionCompletionTime() throws Exception {
-        Assert.assertNotNull(context.getExecutionCompletionTime());
-    }
-
-    @Test
-    public void testWorkflowStartEnd() throws Exception {
-        Assert.assertEquals(context.getWorkflowEndTime() - context.getWorkflowStartTime(), 1000000);
-    }
-
-    @Test
-    public void testSetAndGetValue() throws Exception {
-        context.setValue(WorkflowExecutionArgs.RUN_ID, "10");
-        Assert.assertEquals(context.getValue(WorkflowExecutionArgs.RUN_ID), "10");
-        context.setValue(WorkflowExecutionArgs.RUN_ID, "1");
-    }
-
-    @Test
-    public void testSerializeDeserialize() throws Exception {
-        String contextFile = context.getContextFile();
-        context.serialize();
-        WorkflowExecutionContext newContext = WorkflowExecutionContext.deSerialize(contextFile);
-        Assert.assertNotNull(newContext);
-        Assert.assertEquals(newContext.entrySet().size(), context.entrySet().size());
-    }
-
-    @Test
-    public void testSerializeDeserializeWithFile() throws Exception {
-        String contextFile = "/tmp/blah.json";
-        context.serialize(contextFile);
-        WorkflowExecutionContext newContext = WorkflowExecutionContext.deSerialize(contextFile);
-        Assert.assertNotNull(newContext);
-        Assert.assertEquals(newContext.entrySet().size(), context.entrySet().size());
-    }
-
-    @Test
-    public void testGetFilePathForProcess() throws Exception {
-        final String filePath = WorkflowExecutionContext.getFilePath(LOGS_DIR,
-                ENTITY_NAME, "PROCESS", WorkflowExecutionContext.EntityOperations.GENERATE);
-        Assert.assertEquals(filePath,
-                LOGS_DIR + "/" + ENTITY_NAME + "-wf-post-exec-context.json");
-        Assert.assertEquals(context.getContextFile(), filePath);
-    }
-
-
-    @Test
-    public void testGetFilePathForFeedRetention() throws Exception {
-        final String filePath = WorkflowExecutionContext.getFilePath(LOGS_DIR,
-                ENTITY_NAME, "FEED", WorkflowExecutionContext.EntityOperations.DELETE);
-        Assert.assertEquals(filePath,
-                LOGS_DIR + "/context/" + ENTITY_NAME + "-wf-post-exec-context.json");
-    }
-
-    @Test
-    public void testGetFilePathForFeedReplication() throws Exception {
-        final String filePath = WorkflowExecutionContext.getFilePath(LOGS_DIR,
-                ENTITY_NAME, "FEED", WorkflowExecutionContext.EntityOperations.REPLICATE);
-        Assert.assertEquals(filePath,
-                LOGS_DIR + "/" + ENTITY_NAME + "-wf-post-exec-context.json");
-        Assert.assertEquals(context.getContextFile(), filePath);
-    }
-
-    private static String[] getTestMessageArgs() {
-        long now = new Date().getTime();
-        return new String[]{
-            "-" + WorkflowExecutionArgs.CLUSTER_NAME.getName(), CLUSTER_NAME,
-            "-" + WorkflowExecutionArgs.ENTITY_TYPE.getName(), "process",
-            "-" + WorkflowExecutionArgs.ENTITY_NAME.getName(), ENTITY_NAME,
-            "-" + WorkflowExecutionArgs.NOMINAL_TIME.getName(), NOMINAL_TIME,
-            "-" + WorkflowExecutionArgs.OPERATION.getName(), OPERATION,
-
-            "-" + WorkflowExecutionArgs.INPUT_FEED_NAMES.getName(), INPUT_FEED_NAMES,
-            "-" + WorkflowExecutionArgs.INPUT_FEED_PATHS.getName(), INPUT_INSTANCE_PATHS,
-
-            "-" + WorkflowExecutionArgs.OUTPUT_FEED_NAMES.getName(), OUTPUT_FEED_NAMES,
-            "-" + WorkflowExecutionArgs.OUTPUT_FEED_PATHS.getName(), OUTPUT_INSTANCE_PATHS,
-
-            "-" + WorkflowExecutionArgs.WORKFLOW_ID.getName(), "workflow-01-00",
-            "-" + WorkflowExecutionArgs.WORKFLOW_USER.getName(), FALCON_USER,
-            "-" + WorkflowExecutionArgs.RUN_ID.getName(), "1",
-            "-" + WorkflowExecutionArgs.STATUS.getName(), "SUCCEEDED",
-            "-" + WorkflowExecutionArgs.TIMESTAMP.getName(), NOMINAL_TIME,
-
-            "-" + WorkflowExecutionArgs.WF_ENGINE_URL.getName(), "http://localhost:11000/oozie",
-            "-" + WorkflowExecutionArgs.USER_SUBFLOW_ID.getName(), "userflow@wf-id",
-            "-" + WorkflowExecutionArgs.USER_WORKFLOW_NAME.getName(), WORKFLOW_NAME,
-            "-" + WorkflowExecutionArgs.USER_WORKFLOW_VERSION.getName(), WORKFLOW_VERSION,
-            "-" + WorkflowExecutionArgs.USER_WORKFLOW_ENGINE.getName(), EngineType.PIG.name(),
-
-            "-" + WorkflowExecutionArgs.BRKR_IMPL_CLASS.getName(), BROKER,
-            "-" + WorkflowExecutionArgs.BRKR_URL.getName(), "tcp://localhost:61616?daemon=true",
-            "-" + WorkflowExecutionArgs.USER_BRKR_IMPL_CLASS.getName(), BROKER,
-            "-" + WorkflowExecutionArgs.USER_BRKR_URL.getName(), "tcp://localhost:61616?daemon=true",
-            "-" + WorkflowExecutionArgs.BRKR_TTL.getName(), "1000",
-
-            "-" + WorkflowExecutionArgs.LOG_DIR.getName(), LOGS_DIR,
-            "-" + WorkflowExecutionArgs.LOG_FILE.getName(), LOGS_DIR + "/log.txt",
-            "-" + WorkflowExecutionArgs.WF_START_TIME.getName(), Long.toString(now),
-            "-" + WorkflowExecutionArgs.WF_END_TIME.getName(), Long.toString(now + 1000000),
-        };
-    }
-}

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/java/org/apache/falcon/workflow/WorkflowJobEndNotificationServiceTest.java
----------------------------------------------------------------------
diff --git a/common/src/test/java/org/apache/falcon/workflow/WorkflowJobEndNotificationServiceTest.java b/common/src/test/java/org/apache/falcon/workflow/WorkflowJobEndNotificationServiceTest.java
deleted file mode 100644
index 9dd8f93..0000000
--- a/common/src/test/java/org/apache/falcon/workflow/WorkflowJobEndNotificationServiceTest.java
+++ /dev/null
@@ -1,176 +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.workflow;
-
-import org.apache.falcon.FalconException;
-import org.apache.falcon.entity.v0.process.EngineType;
-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 java.util.Date;
-import java.util.Properties;
-
-/**
- * A test for WorkflowJobEndNotificationService.
- */
-public class WorkflowJobEndNotificationServiceTest implements WorkflowExecutionListener {
-
-    private static final String FALCON_USER = "falcon-user";
-    private static final String LOGS_DIR = "target/log";
-    private static final String NOMINAL_TIME = "2014-01-01-01-00";
-    private static final String OPERATION = "GENERATE";
-
-    private static final String CLUSTER_NAME = "primary-cluster";
-    private static final String ENTITY_NAME = "sample-process";
-    private static final String WORKFLOW_NAME = "imp-click-join-workflow";
-    private static final String WORKFLOW_VERSION = "1.0.9";
-
-    private static final String INPUT_FEED_NAMES = "impression-feed#clicks-feed";
-    private static final String INPUT_INSTANCE_PATHS =
-            "jail://global:00/falcon/impression-feed/2014/01/01,jail://global:00/falcon/impression-feed/2014/01/02"
-                    + "#jail://global:00/falcon/clicks-feed/2014-01-01";
-
-    private static final String OUTPUT_FEED_NAMES = "imp-click-join1,imp-click-join2";
-    private static final String OUTPUT_INSTANCE_PATHS =
-            "jail://global:00/falcon/imp-click-join1/20140101,jail://global:00/falcon/imp-click-join2/20140101";
-
-    private static final String BROKER = "org.apache.activemq.ActiveMQConnectionFactory";
-
-    private WorkflowJobEndNotificationService service;
-    private WorkflowExecutionContext savedContext;
-
-    @BeforeClass
-    public void setUp() throws Exception {
-        service = new WorkflowJobEndNotificationService();
-        savedContext = WorkflowExecutionContext.create(getTestMessageArgs(),
-                WorkflowExecutionContext.Type.POST_PROCESSING);
-        Assert.assertNotNull(savedContext);
-        service.init();
-        service.registerListener(this);
-    }
-
-    @AfterClass
-    public void tearDown() throws Exception {
-        service.destroy();
-    }
-
-    @Test
-    public void testGetName() throws Exception {
-        Assert.assertEquals(service.getName(), WorkflowJobEndNotificationService.SERVICE_NAME);
-    }
-
-    @Test(priority = -1)
-    public void testBasic() throws Exception {
-        try {
-            notifyFailure(savedContext);
-            notifySuccess(savedContext);
-        } finally {
-            StartupProperties.get().setProperty("workflow.execution.listeners", "");
-        }
-    }
-
-    @Test
-    public void testNotificationsFromEngine() throws FalconException {
-        WorkflowExecutionContext context = WorkflowExecutionContext.create(getTestMessageArgs(),
-                WorkflowExecutionContext.Type.WORKFLOW_JOB);
-
-        // Pretend the start was already notified
-        Properties wfProps = new Properties();
-        wfProps.put(WorkflowExecutionArgs.CLUSTER_NAME.name(), CLUSTER_NAME);
-        service.getContextMap().put("workflow-01-00", wfProps);
-
-        // Should retrieve from cache.
-        service.notifySuspend(context);
-    }
-
-    @Override
-    public void onSuccess(WorkflowExecutionContext context) throws FalconException {
-        Assert.assertNotNull(context);
-        Assert.assertEquals(context.entrySet().size(), 28);
-    }
-
-    @Override
-    public void onFailure(WorkflowExecutionContext context) throws FalconException {
-        Assert.assertNotNull(context);
-        Assert.assertEquals(context.entrySet().size(), 28);
-    }
-
-    @Override
-    public void onStart(WorkflowExecutionContext context) throws FalconException {
-    }
-
-    @Override
-    public void onSuspend(WorkflowExecutionContext context) throws FalconException {
-    }
-
-    @Override
-    public void onWait(WorkflowExecutionContext context) throws FalconException {
-
-    }
-
-    private void notifyFailure(WorkflowExecutionContext context) throws FalconException {
-        service.notifyFailure(context);
-    }
-
-    private void notifySuccess(WorkflowExecutionContext context) throws FalconException {
-        service.notifySuccess(context);
-    }
-
-    private static String[] getTestMessageArgs() {
-        return new String[]{
-            "-" + WorkflowExecutionArgs.CLUSTER_NAME.getName(), CLUSTER_NAME,
-            "-" + WorkflowExecutionArgs.ENTITY_TYPE.getName(), "process",
-            "-" + WorkflowExecutionArgs.ENTITY_NAME.getName(), ENTITY_NAME,
-            "-" + WorkflowExecutionArgs.NOMINAL_TIME.getName(), NOMINAL_TIME,
-            "-" + WorkflowExecutionArgs.OPERATION.getName(), OPERATION,
-
-            "-" + WorkflowExecutionArgs.INPUT_FEED_NAMES.getName(), INPUT_FEED_NAMES,
-            "-" + WorkflowExecutionArgs.INPUT_FEED_PATHS.getName(), INPUT_INSTANCE_PATHS,
-
-            "-" + WorkflowExecutionArgs.OUTPUT_FEED_NAMES.getName(), OUTPUT_FEED_NAMES,
-            "-" + WorkflowExecutionArgs.OUTPUT_FEED_PATHS.getName(), OUTPUT_INSTANCE_PATHS,
-
-            "-" + WorkflowExecutionArgs.WORKFLOW_ID.getName(), "workflow-01-00",
-            "-" + WorkflowExecutionArgs.WORKFLOW_USER.getName(), FALCON_USER,
-            "-" + WorkflowExecutionArgs.RUN_ID.getName(), "1",
-            "-" + WorkflowExecutionArgs.STATUS.getName(), "SUCCEEDED",
-            "-" + WorkflowExecutionArgs.TIMESTAMP.getName(), NOMINAL_TIME,
-
-            "-" + WorkflowExecutionArgs.WF_ENGINE_URL.getName(), "http://localhost:11000/oozie",
-            "-" + WorkflowExecutionArgs.USER_SUBFLOW_ID.getName(), "userflow@wf-id",
-            "-" + WorkflowExecutionArgs.USER_WORKFLOW_NAME.getName(), WORKFLOW_NAME,
-            "-" + WorkflowExecutionArgs.USER_WORKFLOW_VERSION.getName(), WORKFLOW_VERSION,
-            "-" + WorkflowExecutionArgs.USER_WORKFLOW_ENGINE.getName(), EngineType.PIG.name(),
-
-            "-" + WorkflowExecutionArgs.BRKR_IMPL_CLASS.getName(), BROKER,
-            "-" + WorkflowExecutionArgs.BRKR_URL.getName(), "tcp://localhost:61616?daemon=true",
-            "-" + WorkflowExecutionArgs.USER_BRKR_IMPL_CLASS.getName(), BROKER,
-            "-" + WorkflowExecutionArgs.USER_BRKR_URL.getName(), "tcp://localhost:61616?daemon=true",
-            "-" + WorkflowExecutionArgs.BRKR_TTL.getName(), "1000",
-
-            "-" + WorkflowExecutionArgs.LOG_DIR.getName(), LOGS_DIR,
-            "-" + WorkflowExecutionArgs.LOG_FILE.getName(), LOGS_DIR + "/log.txt",
-            "-" + WorkflowExecutionArgs.WF_START_TIME.getName(), Long.toString(new Date().getTime()),
-            "-" + WorkflowExecutionArgs.WF_END_TIME.getName(), Long.toString(new Date().getTime() + 1000000),
-        };
-    }
-}

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/classpath.properties
----------------------------------------------------------------------
diff --git a/common/src/test/resources/classpath.properties b/common/src/test/resources/classpath.properties
deleted file mode 100644
index aedc45d..0000000
--- a/common/src/test/resources/classpath.properties
+++ /dev/null
@@ -1,21 +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.
-#
-
-*.domain=unittest
-
-unittest.test=hello world

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/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
deleted file mode 100644
index 5e36f72..0000000
--- a/common/src/test/resources/config/cluster/cluster-0.1.xml
+++ /dev/null
@@ -1,44 +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_type=forecasting</tags>
-    <interfaces>
-        <interface type="readonly" endpoint="hftp://localhost:50010"
-                   version="0.20.2"/>
-        <interface type="write" endpoint="jail://testCluster:00"
-                   version="0.20.2"/>
-        <interface type="execute" endpoint="localhost:8021" version="0.20.2"/>
-        <interface type="workflow" endpoint="http://localhost:11000/oozie/"
-                   version="4.0"/>
-        <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"/>
-    </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/falcon/blob/8e49379d/common/src/test/resources/config/cluster/cluster-bad-registry.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/cluster/cluster-bad-registry.xml b/common/src/test/resources/config/cluster/cluster-bad-registry.xml
deleted file mode 100644
index 1d15e16..0000000
--- a/common/src/test/resources/config/cluster/cluster-bad-registry.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="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="4.0"/>
-        <interface type="registry" endpoint="Hcat" version="0.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/falcon/blob/8e49379d/common/src/test/resources/config/cluster/cluster-bad-write-endpoint.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/cluster/cluster-bad-write-endpoint.xml b/common/src/test/resources/config/cluster/cluster-bad-write-endpoint.xml
deleted file mode 100644
index fc709a2..0000000
--- a/common/src/test/resources/config/cluster/cluster-bad-write-endpoint.xml
+++ /dev/null
@@ -1,44 +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="jail://testcluster:00"
-                   version="0.20.2"/>
-        <interface type="write" endpoint="hdfs://bad-end-point:8020"
-                   version="0.20.2"/>
-        <interface type="execute" endpoint="localhost:8021" version="0.20.2"/>
-        <interface type="workflow" endpoint="http://localhost:11000/oozie/"
-                   version="4.0"/>
-        <interface type="registry" endpoint="http://localhost:48080/templeton/v1"
-                   version="0.11.0"/>
-        <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/falcon/blob/8e49379d/common/src/test/resources/config/cluster/cluster-no-messaging.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/cluster/cluster-no-messaging.xml b/common/src/test/resources/config/cluster/cluster-no-messaging.xml
deleted file mode 100644
index 93e94cb..0000000
--- a/common/src/test/resources/config/cluster/cluster-no-messaging.xml
+++ /dev/null
@@ -1,38 +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="jail://testCluster:00"
-                   version="0.20.2"/>
-        <interface type="execute" endpoint="localhost:8021" version="0.20.2"/>
-        <interface type="workflow" endpoint="http://localhost:11000/oozie/"
-                   version="4.0"/>
-        <interface type="registry" endpoint="http://localhost:48080/templeton/v1"
-                   version="0.11.0"/>
-    </interfaces>
-    <locations>
-        <location name="staging" path="/projects/falcon/staging"/>
-        <location name="temp" path="/tmp"/>
-        <location name="working" path="/projects/falcon/working"/>
-    </locations>
-</cluster>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/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 d3def81..0000000
--- a/common/src/test/resources/config/cluster/cluster-no-registry.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="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="4.0"/>
-        <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>
-    <ACL owner="falcon-ut-user" group="falcon"/>
-    <properties>
-        <property name="field1" value="value1"/>
-        <property name="field2" value="value2"/>
-    </properties>
-</cluster>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/datasource/datasource-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/datasource/datasource-0.1.xml b/common/src/test/resources/config/datasource/datasource-0.1.xml
deleted file mode 100644
index 5b09f10..0000000
--- a/common/src/test/resources/config/datasource/datasource-0.1.xml
+++ /dev/null
@@ -1,48 +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.
-  -->
-<datasource colo="west-coast" description="HSQL database on west coast" type="hsql" name="test-hsql-db" xmlns="uri:falcon:datasource:0.1">
-    <tags>owner=foobar@ambari.apache.org, consumer=phoe@ambari.apache.org</tags>
-    <interfaces>
-        <interface type="readonly" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-text">
-                <userName>SA</userName>
-                <passwordText></passwordText>
-            </credential>
-        </interface>
-
-        <interface type="write" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-text">
-                <userName>SA</userName>
-                <passwordText>sqoop</passwordText>
-            </credential>
-        </interface>
-
-        <credential type="password-text">
-            <userName>SA</userName>
-            <passwordText>sqoop</passwordText>
-        </credential>
-    </interfaces>
-
-    <driver>
-       <clazz>org.hsqldb.jdbcDriver</clazz>
-       <jar>/user/oozie/share/lib/lib_20150721010816/sqoop/hsqldb-1.8.0.7.jar</jar>
-    </driver>
-
-    <ACL owner="testuser" group="group" permission="0x755"/>
-</datasource>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/datasource/datasource-file-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/datasource/datasource-file-0.1.xml b/common/src/test/resources/config/datasource/datasource-file-0.1.xml
deleted file mode 100644
index 76bf3c3..0000000
--- a/common/src/test/resources/config/datasource/datasource-file-0.1.xml
+++ /dev/null
@@ -1,48 +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.
-  -->
-<datasource colo="west-coast" description="HSQL database on west coast" type="hsql" name="test-hsql-db" xmlns="uri:falcon:datasource:0.1">
-    <tags>owner=foobar@ambari.apache.org, consumer=phoe@ambari.apache.org</tags>
-    <interfaces>
-        <interface type="readonly" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-file">
-                <userName>SA</userName>
-                <passwordFile>/falcon/passwordfile</passwordFile>
-            </credential>
-        </interface>
-
-        <interface type="write" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-file">
-                <userName>SA</userName>
-                <passwordFile>/falcon/passwordfile</passwordFile>
-            </credential>
-        </interface>
-
-        <credential type="password-file">
-            <userName>SA</userName>
-            <passwordFile>/falcon/passwordfile</passwordFile>
-        </credential>
-    </interfaces>
-
-    <driver>
-       <clazz>org.hsqldb.jdbcDriver</clazz>
-       <jar>/user/oozie/share/lib/lib_20150721010816/sqoop/hsqldb-1.8.0.7.jar</jar>
-    </driver>
-
-    <ACL owner="testuser" group="group" permission="0x755"/>
-</datasource>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/datasource/datasource-file-0.2.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/datasource/datasource-file-0.2.xml b/common/src/test/resources/config/datasource/datasource-file-0.2.xml
deleted file mode 100644
index 3ee40ed..0000000
--- a/common/src/test/resources/config/datasource/datasource-file-0.2.xml
+++ /dev/null
@@ -1,48 +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.
-  -->
-<datasource colo="west-coast" description="HSQL database on west coast" type="hsql" name="test-hsql-db" xmlns="uri:falcon:datasource:0.1">
-    <tags>owner=foobar@ambari.apache.org, consumer=phoe@ambari.apache.org</tags>
-    <interfaces>
-        <interface type="readonly" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-file">
-                <userName>SA</userName>
-                <passwordFile>"jail://global:00/falcon/passwordfile"/></passwordFile>
-            </credential>
-        </interface>
-
-        <interface type="write" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-file">
-                <userName>SA</userName>
-                <passwordFile>"jail://global:00/falcon/passwordfile"/></passwordFile>
-            </credential>
-        </interface>
-
-        <credential type="password-file">
-            <userName>SA</userName>
-            <passwordFile>"jail://global:00/falcon/passwordfile"/></passwordFile>
-        </credential>
-    </interfaces>
-
-    <driver>
-       <clazz>org.hsqldb.jdbcDriver</clazz>
-       <jar>/user/oozie/share/lib/lib_20150721010816/sqoop/hsqldb-1.8.0.7.jar</jar>
-    </driver>
-
-    <ACL owner="testuser" group="group" permission="0x755"/>
-</datasource>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/datasource/datasource-invalid-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/datasource/datasource-invalid-0.1.xml b/common/src/test/resources/config/datasource/datasource-invalid-0.1.xml
deleted file mode 100644
index 04fe737..0000000
--- a/common/src/test/resources/config/datasource/datasource-invalid-0.1.xml
+++ /dev/null
@@ -1,46 +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.
-  -->
-<datasource colo="west-coast" description="A new database on west coast" type="xyz" name="test-hsql-db" xmlns="uri:falcon:datasource:0.1">
-    <tags>owner=foobar@ambari.apache.org, consumer=phoe@ambari.apache.org</tags>
-    <interfaces>
-        <interface type="readonly" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-text">
-                <userName>SA</userName>
-                <passwordText></passwordText>
-            </credential>
-        </interface>
-
-        <interface type="write" endpoint="jdbc:hsqldb:localhost/db1">
-            <credential type="password-text">
-                <userName>SA</userName>
-                <passwordText>sqoop</passwordText>
-            </credential>
-        </interface>
-
-        <credential type="password-text">
-            <userName>SA</userName>
-            <passwordText>sqoop</passwordText>
-        </credential>
-    </interfaces>
-
-    <driver>
-       <clazz>org.hsqldb.jdbcDriver</clazz>
-       <jar>/user/oozie/share/lib/lib_20150721010816/sqoop/hsqldb-1.8.0.7.jar</jar>
-    </driver>
-</datasource>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-0.1.xml b/common/src/test/resources/config/feed/feed-0.1.xml
deleted file mode 100644
index cbe50c6..0000000
--- a/common/src/test/resources/config/feed/feed-0.1.xml
+++ /dev/null
@@ -1,70 +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="clicks" xmlns="uri:falcon:feed:0.1"
-        >
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <locations>
-                <location type="data" path="/projects/falcon/clicks"/>
-                <location type="stats" path="/projects/falcon/clicksStats"/>
-                <location type="meta" path="/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-        <cluster name="backupCluster" type="target">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00: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="/projects/falcon/clicks"/>
-        <location type="stats" path="/projects/falcon/clicksStats"/>
-        <location type="meta" path="/projects/falcon/clicksMetaData"/>
-    </locations>
-
-    <notification type="email" to="falcon@localhost"/>
-    <ACL owner="testuser-ut-user" 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/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-0.2.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-0.2.xml b/common/src/test/resources/config/feed/feed-0.2.xml
deleted file mode 100644
index ac137fc..0000000
--- a/common/src/test/resources/config/feed/feed-0.2.xml
+++ /dev/null
@@ -1,63 +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="clicks" xmlns="uri:falcon:feed:0.1"
-        >
-    <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="testCluster" type="source" partition="*/${cluster.colo}">
-            <validity start="2021-11-01T00:00Z" end="2021-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <locations>
-                <location type="data" path="/testCluster/projects/falcon/clicks"/>
-                <location type="stats" path="/testCluster/projects/falcon/clicksStats"/>
-                <location type="meta" path="/testCluster/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-        <cluster name="backupCluster" type="target">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(6)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <locations>
-                <location type="data" path="/backupCluster/projects/falcon/clicks"/>
-                <location type="stats" path="/backupCluster/projects/falcon/clicksStats"/>
-                <location type="meta" path="/backupCluster/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <location type="stats" path="/projects/falcon/clicksStats"/>
-        <location type="meta" path="/projects/falcon/clicksMetaData"/>
-    </locations>
-
-    <ACL owner="testuser-ut-user" group="group" permission="0x755"/>
-    <schema location="/schema/clicks" provider="protobuf"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-0.3.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-0.3.xml b/common/src/test/resources/config/feed/feed-0.3.xml
deleted file mode 100644
index e6d3e01..0000000
--- a/common/src/test/resources/config/feed/feed-0.3.xml
+++ /dev/null
@@ -1,83 +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="clicks" xmlns="uri:falcon:feed:0.1"
-        >
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <locations>
-                <location type="data" path="/projects/falcon/clicks"/>
-                <location type="stats" path="/projects/falcon/clicksStats"/>
-                <location type="meta" path="/projects/falcon/clicksMetaData"/>
-            </locations>
-            <lifecycle>
-                <retention-stage>
-                    <frequency>hours(10)</frequency>
-                    <queue>reports</queue>
-                    <priority>NORMAL</priority>
-                    <properties>
-                        <property name="retention.policy.agebaseddelete.limit" value="hours(9)"></property>
-                    </properties>
-                </retention-stage>
-            </lifecycle>
-        </cluster>
-        <cluster name="backupCluster" type="target">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00: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="/projects/falcon/clicks"/>
-        <location type="stats" path="/projects/falcon/clicksStats"/>
-        <location type="meta" path="/projects/falcon/clicksMetaData"/>
-    </locations>
-
-    <ACL owner="testuser-ut-user" group="group" permission="0x755"/>
-    <schema location="/schema/clicks" provider="protobuf"/>
-    <lifecycle>
-        <retention-stage>
-            <frequency>hours(17)</frequency>
-            <queue>reports</queue>
-            <priority>NORMAL</priority>
-            <properties>
-                <property name="retention.policy.agebaseddelete.limit" value="hours(7)"></property>
-            </properties>
-        </retention-stage>
-    </lifecycle>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-0.4.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-0.4.xml b/common/src/test/resources/config/feed/feed-0.4.xml
deleted file mode 100644
index c88fb14..0000000
--- a/common/src/test/resources/config/feed/feed-0.4.xml
+++ /dev/null
@@ -1,74 +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="clicks" xmlns="uri:falcon:feed:0.1"
-        >
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <locations>
-                <location type="data" path="/projects/falcon/clicks"/>
-                <location type="stats" path="/projects/falcon/clicksStats"/>
-                <location type="meta" path="/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-        <cluster name="backupCluster" type="target">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00: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="/projects/falcon/clicks"/>
-        <location type="stats" path="/projects/falcon/clicksStats"/>
-        <location type="meta" path="/projects/falcon/clicksMetaData"/>
-    </locations>
-
-    <ACL owner="testuser-ut-user" group="group" permission="0x755"/>
-    <schema location="/schema/clicks" provider="protobuf"/>
-    <lifecycle>
-        <retention-stage>
-            <frequency>hours(17)</frequency>
-            <queue>reports</queue>
-            <priority>NORMAL</priority>
-            <properties>
-                <property name="retention.policy.agebaseddelete.limit" value="hours(7)"></property>
-            </properties>
-        </retention-stage>
-    </lifecycle>
-
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-export-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-export-0.1.xml b/common/src/test/resources/config/feed/feed-export-0.1.xml
deleted file mode 100644
index d92ee17..0000000
--- a/common/src/test/resources/config/feed/feed-export-0.1.xml
+++ /dev/null
@@ -1,66 +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="Customer data" name="CustomerFeed" xmlns="uri:falcon:feed:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <export>
-                <target name="test-hsql-db" tableName="customer">
-                    <load type="updateonly"/>
-                    <fields>
-                        <excludes>
-                            <field>id</field>
-                            <field>name</field>
-                        </excludes>
-                    </fields>
-                </target>
-                <arguments>
-                    <argument name="--num-mappers" value="2"/>
-                </arguments>
-            </export>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <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"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-export-exclude-fields-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-export-exclude-fields-0.1.xml b/common/src/test/resources/config/feed/feed-export-exclude-fields-0.1.xml
deleted file mode 100644
index 6753a00..0000000
--- a/common/src/test/resources/config/feed/feed-export-exclude-fields-0.1.xml
+++ /dev/null
@@ -1,66 +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="Customer data" name="CustomerFeed" xmlns="uri:falcon:feed:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <export>
-                <target name="test-hsql-db" tableName="customer">
-                    <load type="updateonly"/>
-                    <fields>
-                        <excludes>
-                            <field>id</field>
-                            <field>name</field>
-                        </excludes>
-                    </fields>
-                </target>
-                <arguments>
-                    <argument name="--update-key" value="id"/>
-                </arguments>
-            </export>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <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"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-import-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-import-0.1.xml b/common/src/test/resources/config/feed/feed-import-0.1.xml
deleted file mode 100644
index 69f7ede..0000000
--- a/common/src/test/resources/config/feed/feed-import-0.1.xml
+++ /dev/null
@@ -1,69 +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="Customer data" name="CustomerFeed" xmlns="uri:falcon:feed:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <import>
-                <source name="test-hsql-db" tableName="customer">
-                    <extract type="full">
-                        <mergepolicy>snapshot</mergepolicy>
-                    </extract>
-                    <fields>
-                        <includes>
-                            <field>id</field>
-                            <field>name</field>
-                        </includes>
-                    </fields>
-                </source>
-                <arguments>
-                    <argument name="--split-by" value="id"/>
-                    <argument name="--num-mappers" value="2"/>
-                </arguments>
-            </import>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <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"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-import-exclude-fields-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-import-exclude-fields-0.1.xml b/common/src/test/resources/config/feed/feed-import-exclude-fields-0.1.xml
deleted file mode 100644
index 5a6fcd9..0000000
--- a/common/src/test/resources/config/feed/feed-import-exclude-fields-0.1.xml
+++ /dev/null
@@ -1,74 +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="Customer data" name="CustomerFeed" xmlns="uri:falcon:feed:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <import>
-                <source name="test-hsql-db" tableName="customer">
-                    <extract type="full">
-                        <mergepolicy>snapshot</mergepolicy>
-                    </extract>
-                    <fields>
-                        <excludes>
-                            <field>id</field>
-                            <field>name</field>
-                        </excludes>
-                    </fields>
-                </source>
-                <arguments>
-                    <argument name="--split-by" value="id"/>
-                    <argument name="--num-mappers" value="2"/>
-                </arguments>
-            </import>
-            <locations>
-                <location type="data" path="/projects/falcon/clicks"/>
-                <location type="stats" path="/projects/falcon/clicksStats"/>
-                <location type="meta" path="/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <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"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-import-invalid-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-import-invalid-0.1.xml b/common/src/test/resources/config/feed/feed-import-invalid-0.1.xml
deleted file mode 100644
index 9428bce..0000000
--- a/common/src/test/resources/config/feed/feed-import-invalid-0.1.xml
+++ /dev/null
@@ -1,73 +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="Customer data" name="CustomerFeed" xmlns="uri:falcon:feed:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <import>
-                <source name="test-hsql-db" tableName="customer">
-                    <extract type="full">
-                        <mergepolicy>snapshot</mergepolicy>
-                    </extract>
-                    <fields>
-                        <includes>
-                            <field>id</field>
-                            <field>name</field>
-                        </includes>
-                    </fields>
-                </source>
-                <arguments>
-                    <argument name="--num-mappers" value="2"/>
-                </arguments>
-            </import>
-            <locations>
-                <location type="data" path="/projects/falcon/clicks"/>
-                <location type="stats" path="/projects/falcon/clicksStats"/>
-                <location type="meta" path="/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <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"/>
-</feed>

http://git-wip-us.apache.org/repos/asf/falcon/blob/8e49379d/common/src/test/resources/config/feed/feed-import-noargs-0.1.xml
----------------------------------------------------------------------
diff --git a/common/src/test/resources/config/feed/feed-import-noargs-0.1.xml b/common/src/test/resources/config/feed/feed-import-noargs-0.1.xml
deleted file mode 100644
index c96249c..0000000
--- a/common/src/test/resources/config/feed/feed-import-noargs-0.1.xml
+++ /dev/null
@@ -1,64 +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="Customer data" name="CustomerFeed" xmlns="uri:falcon:feed:0.1">
-    <tags>consumer=consumer@xyz.com, owner=producer@xyz.com, _department_type=forecasting</tags>
-    <partitions>
-        <partition name="fraud"/>
-        <partition name="good"/>
-    </partitions>
-
-    <groups>online,bi</groups>
-    <availabilityFlag>_SUCCESS</availabilityFlag>
-
-    <frequency>hours(1)</frequency>
-    <sla slaLow="hours(2)" slaHigh="hours(3)"/>
-    <timezone>UTC</timezone>
-
-    <late-arrival cut-off="hours(6)"/>
-
-    <clusters>
-        <cluster name="testCluster" type="source">
-            <validity start="2011-11-01T00:00Z" end="2011-12-31T00:00Z"/>
-            <retention limit="hours(48)" action="delete"/>
-            <!-- Limit can be in Time or Instances 100, Action ENUM DELETE,ARCHIVE -->
-            <sla slaLow="hours(3)" slaHigh="hours(4)"/>
-            <import>
-                <source name="test-hsql-db" tableName="customer">
-                    <extract type="full">
-                        <mergepolicy>snapshot</mergepolicy>
-                    </extract>
-                </source>
-            </import>
-            <locations>
-                <location type="data" path="/projects/falcon/clicks"/>
-                <location type="stats" path="/projects/falcon/clicksStats"/>
-                <location type="meta" path="/projects/falcon/clicksMetaData"/>
-            </locations>
-        </cluster>
-    </clusters>
-
-    <locations>
-        <location type="data" path="/projects/falcon/clicks"/>
-        <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"/>
-</feed>