You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@eagle.apache.org by ha...@apache.org on 2017/04/03 11:54:19 UTC

[11/84] [partial] eagle git commit: Clean repo for eagle site

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/policy.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/policy.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/policy.json
deleted file mode 100644
index 72eabad..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/policy.json
+++ /dev/null
@@ -1,36 +0,0 @@
-{
-  "name": "network_symptomatic_join",
-  "description": "Set parentKey of child alerts as docId of device down alert",
-  "inputStreams": [
-    "networkCorrelateIntermediumStream",
-    "deviceDownAlertStream"
-  ],
-  "outputStreams": [
-    "symptomaticAlertOutputStream"
-  ],
-  "definition": {
-    "type": "siddhi",
-    "value": "from networkCorrelateIntermediumStream#window.time(10 min) as left join deviceDownAlertStream[state=='open']#window.time(10 min) as right on left.linkedSwitch == right.entity select left.name, left.pod, left.docId, left.cause, left.firstOccurrenceTime, left.bubble, left.timestamp, left.severity, left.componentType, left.linkedSwitch, left.alertSource, left.entityType, left.ip, left.alertKey, left.message, 'symptomaticAlertOutputStream' as streamName, left.component, left.linkedPort, left.namespace, left.entity, left.dc, left.status, left.endTime, left.lastModifiedTime, right.docId as parentKey insert into symptomaticAlertOutputStream;",
-    "properties": {},
-    "inputStreams": [],
-    "outputStreams": []
-  },
-  "policyStatus": "ENABLED",
-  "partitionSpec": [
-    {
-      "streamId": "networkCorrelateIntermediumStream",
-      "type": "GROUPBY",
-      "columns": [
-        "linkedSwitch"
-      ]
-    },
-    {
-      "streamId": "deviceDownAlertStream",
-      "type": "GROUPBY",
-      "columns": [
-        "entity"
-      ]
-    }
-  ],
-  "parallelismHint": 0
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/streams.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/streams.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/streams.json
deleted file mode 100644
index ed7c78f..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/interpreter/streams.json
+++ /dev/null
@@ -1,524 +0,0 @@
-[
-  {
-    "streamId": "deviceDownAlertStream",
-    "description": "Stream definition for symptomatic parent alerts",
-    "validate": false,
-    "timeseries": false,
-    "dataSource": "network_aggregate_alert_output_datasource",
-    "columns": [
-      {
-        "name": "docId",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the docId for correlated alerts"
-      },
-      {
-        "name": "parentKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the parent key for correlated alert"
-      },
-      {
-        "name": "state",
-        "type": "STRING",
-        "defaultValue": "closed",
-        "required": true,
-        "description": "the alert state"
-      },
-      {
-        "name": "name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "namespace",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "lastModifiedTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "severity",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "severity for symptomatic alert"
-      },
-      {
-        "name": "severityCode",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "severity code for symptomatic alert"
-      },
-      {
-        "name": "streamName",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "entity",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "pod",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "bubble",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "dc",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "cause",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "message",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "count",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": false
-      },
-      {
-        "name": "firstOccurrenceTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": false
-      },
-      {
-        "name": "alertKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      }
-    ]
-  },
-  {
-    "streamId": "networkCorrelateIntermediumStream",
-    "description": "The template aggregated *OUTPUT* data stream schema for network correlation intermedium step",
-    "validate": false,
-    "timeseries": false,
-    "dataSource": "network_aggregate_alert_output_datasource",
-    "columns": [
-      {
-        "name": "docId",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the docId for aggregated alerts"
-      },
-      {
-        "name": "firstOccurrenceTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": "firstOccurTime for aggregated alert"
-      },
-      {
-        "name": "endTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": "the end time of aggregated alert, 0 as default"
-      },
-      {
-        "name": "alertKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the alert key for aggregated alert"
-      },
-      {
-        "name": "parentKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the parent key for aggregated alert"
-      },
-      {
-        "name": "state",
-        "type": "STRING",
-        "defaultValue": "closed",
-        "required": true,
-        "description": "the alert state"
-      },
-      {
-        "name": "name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "namespace",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "lastModifiedTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "severity",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "severity for aggregated alert"
-      },
-      {
-        "name": "alertSource",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "streamName",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "entity",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "entityType",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "ip",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "pod",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "bubble",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "dc",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "component",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "componentType",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "status",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "cause",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "message",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "linkedPort",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "linkedSwitch",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "severityCode",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false,
-        "description": ""
-      },
-      {
-        "name": "count",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": false,
-        "description": ""
-      }
-    ]
-  },
-  {
-    "streamId": "symptomaticAlertOutputStream",
-    "description": "Stream definition for symptomatic child alerts",
-    "validate": false,
-    "timeseries": false,
-    "dataSource": "network_aggregate_alert_output_datasource",
-    "columns": [
-      {
-        "name": "docId",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the docId for symptomatic alerts"
-      },
-      {
-        "name": "firstOccurrenceTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": "firstOccurTime for symptomatic alert"
-      },
-      {
-        "name": "endTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": "the end time of symptomatic alert, 0 as default"
-      },
-      {
-        "name": "alertKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the alert key for symptomatic alert"
-      },
-      {
-        "name": "parentKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "the parent key for symptomatic alert"
-      },
-      {
-        "name": "state",
-        "type": "STRING",
-        "defaultValue": "closed",
-        "required": true,
-        "description": "the alert state"
-      },
-      {
-        "name": "name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "namespace",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "lastModifiedTime",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "severity",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "severity for symptomatic alert"
-      },
-      {
-        "name": "severityCode",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": "severity code for symptomatic alert"
-      },
-      {
-        "name": "streamName",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "entity",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "entityType",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "ip",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "pod",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "bubble",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "dc",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "component",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "componentType",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "status",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "alertSource",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": false
-      },
-      {
-        "name": "cause",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "message",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "linkedPort",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "linkedSwitch",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": ""
-      },
-      {
-        "name": "count",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": ""
-      }
-    ]
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/log4j.properties b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/log4j.properties
deleted file mode 100644
index be79336..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/log4j.properties
+++ /dev/null
@@ -1,20 +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.
-log4j.rootLogger=DEBUG, stdout
-# standard output
-log4j.appender.stdout=org.apache.log4j.ConsoleAppender
-log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
-log4j.appender.stdout.layout.ConversionPattern=%d{ISO8601} %p [%t] %c{2}[%L]: %m%n
-log4j.logger.org.apache.eagle.alert.engine.evaluator.nodata=DEBUG
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/datasources.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/datasources.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/datasources.json
deleted file mode 100644
index 4162ed6..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/datasources.json
+++ /dev/null
@@ -1,36 +0,0 @@
-[
-  {
-    "name": "network_syslog_datasource",
-    "type": "KAFKA",
-    "properties": {
-    },
-    "topic": "syslog_events",
-    "schemeCls": "org.apache.eagle.alert.engine.scheme.JsonScheme",
-    "codec": {
-      "streamNameSelectorProp": {
-        "userProvidedStreamName": "syslog_stream",
-        "streamNameFormat": "%s"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.JsonStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": ""
-    }
-  },
-  {
-    "name": "network_syslog_alert_datasource",
-    "type": "KAFKA",
-    "properties": {
-    },
-    "topic": "syslog_alerts",
-    "schemeCls": "org.apache.eagle.alert.engine.scheme.JsonScheme",
-    "codec": {
-      "streamNameSelectorProp": {
-        "userProvidedStreamName": "syslog_stream_subalert",
-        "streamNameFormat": "%s"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.JsonStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": ""
-    }
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/policies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/policies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/policies.json
deleted file mode 100644
index 05743f5..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/policies.json
+++ /dev/null
@@ -1,50 +0,0 @@
-[
-  {
-    "name": "syslog_severity_critical_check",
-    "description": "syslog.severity > 3 then error",
-    "inputStreams": [
-      "syslog_stream"
-    ],
-    "outputStreams": [
-      "syslog_severity_critical_output"
-    ],
-    "definition": {
-      "type": "siddhi",
-      "value": "from syslog_stream[(severity_name == \"EMERG\" or severity_name == \"ALERT\" or severity_name ==\"CRIT\") and (regex:find(\"The system is overheating\", msg) or regex:find(\"Power Supply is not responding\",msg) or regex:find(\"Memory inconsistency detected\", msg))] select 'alert' as name, 'CRITICAL' as alertSeverity, namespace, facility_name, facility_code, severity_code,severity_name ,dims_hostname, dims_appname, msgid,  msg, epochMillis, str:concat('ab', 'c') as alertKey insert into syslog_severity_critical_output;"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "syslog_stream",
-        "type": "GROUPBY",
-        "columns": [
-          "dims_hostname"
-        ]
-      }
-    ],
-    "parallelismHint": 10
-  },
-  {
-    "name": "syslog_parent_alert",
-    "description": "aggregate alerts into parent alerts",
-    "inputStreams": [
-      "syslog_severity_critical_output"
-    ],
-    "outputStreams": [
-      "syslog_parent_alert_aggregate_out"
-    ],
-    "definition": {
-      "type": "siddhi",
-      "value": "from syslog_severity_critical_output#window.externalTimeBatch(timestamp, 3min) select 'AggregateAlert' as name, 'CRITICAL' as alertSeverity, namespace, facility_name, facility_code, severity_code,severity_name ,dims_hostname, dims_appname, msgid,  msg, epochMillis, str:subStr(alertKey, 0, 20) as alertKey insert into syslog_parent_alert_aggregate_out;"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "syslog_severity_critical_output",
-        "type": "GROUPBY",
-        "columns": [
-          "dims_hostname"
-        ]
-      }
-    ],
-    "parallelismHint": 10
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/publishments.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/publishments.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/publishments.json
deleted file mode 100644
index cb6198e..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/publishments.json
+++ /dev/null
@@ -1,16 +0,0 @@
-[
-  {
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-    "name": "network-syslog-publish",
-    "policyIds": [
-      "syslog_severity_critical_check",
-      "syslog_aggregation_alert"
-    ],
-    "dedupIntervalMin": "PT0M",
-    "properties": {
-      "kafka_broker": "localhost:9092",
-      "topic": "syslog_alerts"
-    },
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.JsonEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/streamdefinitions.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/streamdefinitions.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/streamdefinitions.json
deleted file mode 100644
index 68eb748..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/loopback/streamdefinitions.json
+++ /dev/null
@@ -1,195 +0,0 @@
-[
-  {
-    "streamId": "syslog_stream",
-    "dataSource": "network_syslog_datasource",
-    "description": "the data stream for syslog events",
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "dims_hostname",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "facility_code",
-        "type": "INT",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "facility_name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "severity_code",
-        "type": "INT",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "severity_name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "msg",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "msgid",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "procid",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "dims_appname",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "namespace",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "epochMillis",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": null
-      }
-    ]
-  },
-  {
-    "streamId": "syslog_severity_critical_check",
-    "dataSource": "network_syslog_alert_datasource",
-    "description": "the data stream for syslog events",
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "dims_hostname",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "facility_code",
-        "type": "INT",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "facility_name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "severity_code",
-        "type": "INT",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "severity_name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "msg",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "msgid",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "procid",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "dims_appname",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "name",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "namespace",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "epochMillis",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true,
-        "description": null
-      },
-      {
-        "name": "alertKey",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true,
-        "description": null
-      }
-    ]
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/application-nodata.conf
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/application-nodata.conf b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/application-nodata.conf
deleted file mode 100644
index 11df895..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/application-nodata.conf
+++ /dev/null
@@ -1,60 +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.
-{
-  "topology": {
-    "name": "alertUnitTopology_1",
-    "numOfTotalWorkers": 20,
-    "numOfSpoutTasks": 1,
-    "numOfRouterBolts": 4,
-    "numOfAlertBolts": 10,
-    "numOfPublishTasks": 1,
-    "localMode": "true"
-  },
-  "spout": {
-    "kafkaBrokerZkQuorum": "sandbox.hortonworks.com:2181",
-    "kafkaBrokerZkBasePath": "/brokers",
-    "stormKafkaUseSameZkQuorumWithKafkaBroker": true,
-    "stormKafkaTransactionZkQuorum": "",
-    "stormKafkaTransactionZkPath": "/consumers",
-    "stormKafkaEagleConsumer": "eagle_consumer",
-    "stormKafkaStateUpdateIntervalMs": 2000,
-    "stormKafkaFetchSizeBytes": 1048586,
-  },
-  "zkConfig": {
-    "zkQuorum": "sandbox.hortonworks.com:2181",
-    "zkRoot": "/alert",
-    "zkSessionTimeoutMs": 10000,
-    "connectionTimeoutMs": 10000,
-    "zkRetryTimes": 3,
-    "zkRetryInterval": 3000
-  },
-  "dynamicConfigSource": {
-    "initDelayMillis": 3000,
-    "delayMillis": 10000
-  },
-  "metadataService": {
-    "context": "/rest",
-    "host": "localhost",
-    "port": 8080
-  },
-  "coordinatorService": {
-    "host": "localhost",
-    "port": "8080",
-    "context": "/rest"
-  },
-  "kafkaProducer": {
-    "bootstrapServers": "sandbox.hortonworks.com:6667"
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/datasources.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/datasources.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/datasources.json
deleted file mode 100644
index 814f4c0..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/datasources.json
+++ /dev/null
@@ -1,17 +0,0 @@
-[
-  {
-    "name": "noDataAlertDataSource",
-    "type": "KAFKA",
-    "properties": {},
-    "topic": "noDataAlertTopic",
-    "schemeCls": "org.apache.eagle.alert.engine.scheme.JsonScheme",
-    "codec": {
-      "streamNameSelectorProp": {
-        "userProvidedStreamName": "noDataAlertStream"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.JsonStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": ""
-    }
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies-provided-wisb.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies-provided-wisb.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies-provided-wisb.json
deleted file mode 100644
index 64d6885..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies-provided-wisb.json
+++ /dev/null
@@ -1,23 +0,0 @@
-[
-  {
-    "name": "noDataAlertPolicy",
-    "description": "noDataAlertPolicy",
-    "inputStreams": [
-      "noDataAlertStream"
-    ],
-    "outputStreams": [
-      "noDataAlertStream_out"
-    ],
-    "definition": {
-      "type": "nodataalert",
-      "value": "PT1M,plain,1,host,host1,host2,host3"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "noDataAlertStream",
-        "type": "GROUPBY"
-      }
-    ],
-    "parallelismHint": 2
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies.json
deleted file mode 100644
index 18d08b9..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/policies.json
+++ /dev/null
@@ -1,26 +0,0 @@
-[
-  {
-    "name": "noDataAlertPolicy",
-    "description": "noDataAlertPolicy",
-    "inputStreams": [
-      "noDataAlertStream"
-    ],
-    "outputStreams": [
-      "noDataAlertStream_out"
-    ],
-    "definition": {
-      "type": "nodataalert",
-      "value": "PT1M,dynamic,1,host"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "noDataAlertStream",
-        "type": "GROUPBY",
-        "columns": [
-          "host"
-        ]
-      }
-    ],
-    "parallelismHint": 2
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/publishments.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/publishments.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/publishments.json
deleted file mode 100644
index d8d4476..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/publishments.json
+++ /dev/null
@@ -1,20 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "noDataAlertPolicy"
-    ],
-    "properties": {
-      "subject": "Eagle Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "services@corp.com",
-      "smtp.server": "smtp.mailhost.com",
-      "connection": "plaintext",
-      "smtp.port": "25"
-    },
-    "dedupIntervalMin": "PT5M",
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/streamdefinitions.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/streamdefinitions.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/streamdefinitions.json
deleted file mode 100644
index 4fb40d2..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/streamdefinitions.json
+++ /dev/null
@@ -1,29 +0,0 @@
-[
-  {
-    "streamId": "noDataAlertStream",
-    "dataSource": "noDataAlertDataSource",
-    "description": "the data stream for testing no data alert",
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "host",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true
-      },
-      {
-        "name": "value",
-        "type": "DOUBLE",
-        "defaultValue": "0.0",
-        "required": true
-      }
-    ]
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/topologies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/topologies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/topologies.json
deleted file mode 100644
index c13eeb2..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/nodata/topologies.json
+++ /dev/null
@@ -1,31 +0,0 @@
-[
-  {
-    "name": "alertUnitTopology_1",
-    "numOfSpout": 1,
-    "numOfAlertBolt": 10,
-    "numOfGroupBolt": 4,
-    "spoutId": "alertEngineSpout",
-    "groupNodeIds": [
-      "streamRouterBolt0",
-      "streamRouterBolt1",
-      "streamRouterBolt2",
-      "streamRouterBolt3"
-    ],
-    "alertBoltIds": [
-      "alertBolt0",
-      "alertBolt1",
-      "alertBolt2",
-      "alertBolt3",
-      "alertBolt4",
-      "alertBolt5",
-      "alertBolt6",
-      "alertBolt7",
-      "alertBolt8",
-      "alertBolt9"
-    ],
-    "pubBoltId": "alertPublishBolt",
-    "spoutParallelism": 1,
-    "groupParallelism": 1,
-    "alertParallelism": 1
-  }
-]

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments1.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments1.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments1.json
deleted file mode 100644
index 0b2d727..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments1.json
+++ /dev/null
@@ -1,25 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "perfmon_cpu_host_check",
-      "perfmon_cpu_pool_check"
-    ],
-    "properties": {
-      "subject": "Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "services@corp.com",
-      "mail.smtp.host": "smtp.mailhost.com",
-      "mail.smtp.auth": "true",
-      "mail.username": "username",
-      "mail.password": "password",
-      "mail.debug": "false",
-      "mail.connection": "tls",
-      "mail.smtp.port": "587"
-    },
-    "dedupIntervalMin": "PT1M",
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments2.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments2.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments2.json
deleted file mode 100644
index 96cc015..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/publishments2.json
+++ /dev/null
@@ -1,25 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "policy1",
-      "policy2"
-    ],
-    "properties": {
-      "subject": "Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "receiver@corp.com",
-      "mail.smtp.host": "smtp.mailhost.com",
-      "mail.smtp.auth": "true",
-      "mail.username": "username",
-      "mail.password": "password",
-      "mail.debug": "false",
-      "mail.connection": "tls",
-      "mail.smtp.port": "587"
-    },
-    "dedupIntervalMin": "PT0M",
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-empty-dedup-field.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-empty-dedup-field.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-empty-dedup-field.json
deleted file mode 100644
index 56c4686..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-empty-dedup-field.json
+++ /dev/null
@@ -1,23 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "perfmon_cpu_host_check",
-      "perfmon_cpu_pool_check"
-    ],
-    "properties": {
-      "subject": "Eagle Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "receiver@corp.com",
-      "smtp.server": "mailhost.com",
-      "connection": "plaintext",
-      "smtp.port": "25"
-    },
-    "dedupIntervalMin": "PT1M",
-    "dedupStateField": "state",
-  	"dedupStateCloseValue": "CLOSE",
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-extended-deduplicator.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-extended-deduplicator.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-extended-deduplicator.json
deleted file mode 100644
index 5e14e78..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-extended-deduplicator.json
+++ /dev/null
@@ -1,31 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "perfmon_cpu_host_check",
-      "perfmon_cpu_pool_check"
-    ],
-    "properties": {
-      "subject": "Eagle Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "receiver@corp.com",
-      "smtp.server": "mailhost.com",
-      "connection": "plaintext",
-      "smtp.port": "25"
-    },
-    "dedupIntervalMin": "PT1M",
-    "dedupFields": [
-      "appname"
-    ],
-    "dedupStateField": "state",
-    "overrideDeduplicator": {
-  		"className": "org.apache.eagle.alert.engine.publisher.dedup.TestDeduplicator",
-  		"properties": {
-  			"docIdField": "docId"
-  		}
-  	},
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-slack.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-slack.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-slack.json
deleted file mode 100644
index dee7106..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments-slack.json
+++ /dev/null
@@ -1,19 +0,0 @@
-[
-  {
-    "name": "test-slack-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertSlackPublisher",
-    "policyIds": [
-      "switch_check"
-    ],
-    "properties": {
-      "token": "your token",
-      "channels": "your channel1, your channel2",
-      "severitys": "CRITICAL"
-    },
-    "dedupIntervalMin": "PT1M",
-    "dedupFields": [
-      "appname"
-    ],
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments.json
deleted file mode 100644
index 1f4ddcc..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/router/publishments.json
+++ /dev/null
@@ -1,25 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "perfmon_cpu_host_check",
-      "perfmon_cpu_pool_check"
-    ],
-    "properties": {
-      "subject": "Eagle Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "receiver@corp.com",
-      "smtp.server": "mailhost.com",
-      "connection": "plaintext",
-      "smtp.port": "25"
-    },
-    "dedupIntervalMin": "PT1M",
-    "dedupFields": [
-      "appname"
-    ],
-    "dedupStateField": "state",
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/sample_perfmon_data.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/sample_perfmon_data.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/sample_perfmon_data.json
deleted file mode 100644
index 8d1e5fa..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/sample_perfmon_data.json
+++ /dev/null
@@ -1,10 +0,0 @@
-[
-  {
-    "host": "",
-    "timestamp": "",
-    "metric": "",
-    "pool": "",
-    "value": 1.0,
-    "colo": "phx"
-  },
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/application-integration.conf
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/application-integration.conf b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/application-integration.conf
deleted file mode 100644
index 288d9f9..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/application-integration.conf
+++ /dev/null
@@ -1,66 +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.
-{
-  "topology": {
-    "name": "alertUnitTopology_1",
-    "numOfTotalWorkers": 20,
-    "numOfSpoutTasks": 1,
-    "numOfRouterBolts": 4,
-    "numOfAlertBolts": 20,
-    "numOfPublishTasks": 1,
-    "localMode": "true"
-  },
-  "spout": {
-    "kafkaBrokerZkQuorum": "127.0.0.1:2181",
-    "kafkaBrokerZkBasePath": "/brokers",
-    "stormKafkaUseSameZkQuorumWithKafkaBroker": true,
-    "stormKafkaTransactionZkQuorum": "",
-    "stormKafkaTransactionZkPath": "/consumers",
-    "stormKafkaEagleConsumer": "eagle_consumer",
-    "stormKafkaStateUpdateIntervalMs": 2000,
-    "stormKafkaFetchSizeBytes": 1048586,
-  },
-  "zkConfig": {
-    "zkQuorum": "127.0.0.1:2181",
-    "zkRoot": "/alert",
-    "zkSessionTimeoutMs": 10000,
-    "connectionTimeoutMs": 10000,
-    "zkRetryTimes": 3,
-    "zkRetryInterval": 3000
-  },
-  "dynamicConfigSource": {
-    "initDelayMillis": 3000,
-    "delayMillis": 10000
-  },
-  "metadataService": {
-    "context": "/rest",
-    "host": "localhost",
-    "port": 8080
-  },
-  "coordinatorService": {
-    "host": "localhost",
-    "port": "8080",
-    "context": "/rest"
-  },
-  "kafkaProducer": {
-    "bootstrapServers": "127.0.0.1:9092"
-  },
-  "email": {
-    "sender": "eagle@eagle.com",
-    "recipients": "test@eagle.com",
-    "mail.smtp.host": "test.eagle.com",
-    "mail.smtp.port": "25"
-  }
-}

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/datasources.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/datasources.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/datasources.json
deleted file mode 100644
index 19c70b4..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/datasources.json
+++ /dev/null
@@ -1,19 +0,0 @@
-[
-  {
-    "name": "perfmon_datasource",
-    "type": "KAFKA",
-    "properties": {
-    },
-    "topic": "perfmon_metrics",
-    "schemeCls": "org.apache.eagle.alert.engine.scheme.JsonScheme",
-    "codec": {
-      "streamNameSelectorProp": {
-        "fieldNamesToInferStreamName": "metric",
-        "streamNameFormat": "%s"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.JsonStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": ""
-    }
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/policies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/policies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/policies.json
deleted file mode 100644
index 043d6a8..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/policies.json
+++ /dev/null
@@ -1,81 +0,0 @@
-[
-  {
-    "name": "perfmon_cpu_host_check",
-    "description": "policy to check host perfmon_cpu",
-    "inputStreams": [
-      "perfmon_cpu_stream"
-    ],
-    "outputStreams": [
-      "perfmon_cpu_check_output"
-    ],
-    "definition": {
-      "type": "siddhi",
-      "value": "from perfmon_cpu_stream[value > 90.0] select * group by host insert into perfmon_cpu_check_output;"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "perfmon_cpu_stream",
-        "type": "GROUPBY",
-        "columns": [
-          "host"
-        ],
-        "sortSpec": {
-          "windowPeriod": "PT1M"
-        }
-      }
-    ]
-  },
-  {
-    "name": "perfmon_cpu_pool_check",
-    "description": "policy to check pool perfmon_cpu",
-    "inputStreams": [
-      "perfmon_cpu_stream"
-    ],
-    "outputStreams": [
-      "perfmon_cpu_check_output"
-    ],
-    "definition": {
-      "type": "siddhi",
-      "value": "from perfmon_cpu_stream[value > 75.0] select * group by pool insert into perfmon_cpu_check_output;"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "perfmon_cpu_stream",
-        "type": "GROUPBY",
-        "columns": [
-          "pool"
-        ],
-        "sortSpec": {
-          "windowPeriod": "PT1M"
-        }
-      }
-    ]
-  },
-  {
-    "name": "perfmon_cpu_pool_check_2",
-    "description": "policy to check pool perfmon_cpu",
-    "inputStreams": [
-      "perfmon_cpu_stream"
-    ],
-    "outputStreams": [
-      "perfmon_cpu_check_output_2"
-    ],
-    "definition": {
-      "type": "siddhi",
-      "value": "from perfmon_cpu_stream[value > 90.0] select * group by pool insert into perfmon_cpu_check_output_2;"
-    },
-    "partitionSpec": [
-      {
-        "streamId": "perfmon_cpu_stream",
-        "type": "GROUPBY",
-        "columns": [
-          "pool"
-        ],
-        "sortSpec": {
-          "windowPeriod": "PT1M"
-        }
-      }
-    ],
-    "policyStatus": "DISABLED"
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/publishments.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/publishments.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/publishments.json
deleted file mode 100644
index 21edd0a..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/publishments.json
+++ /dev/null
@@ -1,34 +0,0 @@
-[
-  {
-    "name": "test-stream-output",
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-    "policyIds": [
-      "perfmon_cpu_host_check",
-      "perfmon_cpu_pool_check"
-    ],
-    "properties": {
-      "subject": "Eagle Test Alert",
-      "template": "",
-      "sender": "sender@corp.com",
-      "recipients": "services@corp.com",
-      "smtp.server": "smtp.mailhost.com",
-      "connection": "plaintext",
-      "smtp.port": "25"
-    },
-    "dedupIntervalMin": "PT1M",
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  },
-  {
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-    "name": "kafka-testAlertStream",
-    "policyIds": [
-      "perfmon_cpu_host_check"
-    ],
-    "dedupIntervalMin": "PT1M",
-    "properties": {
-      "kafka_broker": "localhost:9092",
-      "topic": "test_kafka"
-    },
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/streamdefinitions.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/streamdefinitions.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/streamdefinitions.json
deleted file mode 100644
index abfbcf3..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/streamdefinitions.json
+++ /dev/null
@@ -1,47 +0,0 @@
-[
-  {
-    "streamId": "perfmon_cpu_stream",
-    "dataSource": "perfmon_datasource",
-    "description": "the data stream for perfmon cpu metrics",
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "host",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true
-      },
-      {
-        "name": "metric",
-        "type": "STRING",
-        "defaultValue": "perfmon_cpu",
-        "required": true
-      },
-      {
-        "name": "pool",
-        "type": "STRING",
-        "defaultValue": "raptor_general",
-        "required": true
-      },
-      {
-        "name": "value",
-        "type": "DOUBLE",
-        "defaultValue": 0.0,
-        "required": true
-      },
-      {
-        "name": "colo",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      }
-    ]
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/topologies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/topologies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/topologies.json
deleted file mode 100644
index 7417934..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/simple/topologies.json
+++ /dev/null
@@ -1,41 +0,0 @@
-[
-  {
-    "name": "alertUnitTopology_1",
-    "numOfSpout": 1,
-    "numOfAlertBolt": 20,
-    "numOfGroupBolt": 4,
-    "spoutId": "alertEngineSpout",
-    "groupNodeIds": [
-      "streamRouterBolt0",
-      "streamRouterBolt1",
-      "streamRouterBolt2",
-      "streamRouterBolt3"
-    ],
-    "alertBoltIds": [
-      "alertBolt0",
-      "alertBolt1",
-      "alertBolt2",
-      "alertBolt3",
-      "alertBolt4",
-      "alertBolt5",
-      "alertBolt6",
-      "alertBolt7",
-      "alertBolt8",
-      "alertBolt9",
-      "alertBolt10",
-      "alertBolt11",
-      "alertBolt12",
-      "alertBolt13",
-      "alertBolt14",
-      "alertBolt15",
-      "alertBolt16",
-      "alertBolt17",
-      "alertBolt18",
-      "alertBolt19"
-    ],
-    "pubBoltId": "alertPublishBolt",
-    "spoutParallelism": 1,
-    "groupParallelism": 1,
-    "alertParallelism": 1
-  }
-]

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/application-statecheck.conf
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/application-statecheck.conf b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/application-statecheck.conf
deleted file mode 100644
index db14d3c..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/application-statecheck.conf
+++ /dev/null
@@ -1,60 +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.
-{
-  "topology": {
-    "name": "alertUnitTopology_1",
-    "numOfTotalWorkers": 20,
-    "numOfSpoutTasks": 1,
-    "numOfRouterBolts": 4,
-    "numOfAlertBolts": 10,
-    "numOfPublishTasks": 1,
-    "localMode": "true"
-  },
-  "spout": {
-    "kafkaBrokerZkQuorum": "localhost:2181",
-    "kafkaBrokerZkBasePath": "/brokers",
-    "stormKafkaUseSameZkQuorumWithKafkaBroker": true,
-    "stormKafkaTransactionZkQuorum": "",
-    "stormKafkaTransactionZkPath": "/consumers",
-    "stormKafkaEagleConsumer": "eagle_consumer",
-    "stormKafkaStateUpdateIntervalMs": 2000,
-    "stormKafkaFetchSizeBytes": 1048586,
-  },
-  "zkConfig": {
-    "zkQuorum": "localhost:2181",
-    "zkRoot": "/alert",
-    "zkSessionTimeoutMs": 10000,
-    "connectionTimeoutMs": 10000,
-    "zkRetryTimes": 3,
-    "zkRetryInterval": 3000
-  },
-  "dynamicConfigSource": {
-    "initDelayMillis": 3000,
-    "delayMillis": 10000
-  },
-  "metadataService": {
-    "context": "/rest",
-    "host": "localhost",
-    "port": 8080
-  },
-  "coordinatorService": {
-    "host": "localhost",
-    "port": "8080",
-    "context": "/rest"
-  },
-  "kafkaProducer": {
-    "bootstrapServers": "localhost:9092"
-  }
-}

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/datasources.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/datasources.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/datasources.json
deleted file mode 100644
index 19c70b4..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/datasources.json
+++ /dev/null
@@ -1,19 +0,0 @@
-[
-  {
-    "name": "perfmon_datasource",
-    "type": "KAFKA",
-    "properties": {
-    },
-    "topic": "perfmon_metrics",
-    "schemeCls": "org.apache.eagle.alert.engine.scheme.JsonScheme",
-    "codec": {
-      "streamNameSelectorProp": {
-        "fieldNamesToInferStreamName": "metric",
-        "streamNameFormat": "%s"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.JsonStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": ""
-    }
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/policies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/policies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/policies.json
deleted file mode 100644
index 7680b9e..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/policies.json
+++ /dev/null
@@ -1,38 +0,0 @@
-[
-  {
-    "name": "state_check_latency",
-    "definition": {
-      "type": "siddhi",
-      "value": "from perfmon_latency_stream#window.time(5 min) select host, timestamp, metric, pool, value, colo, convert(avg(value)/1000, 'int') as latencyState group by host insert into perfmon_latency_check_output;",
-      "inputStreams": [
-        "perfmon_latency_stream"
-      ],
-      "outputStreams": [
-        "perfmon_latency_check_output"
-      ]
-    },
-    "stateDefinition": {
-      "type": "siddhi",
-      "value": "from every a = perfmon_latency_check_output -> b = perfmon_latency_check_output[host == a.host and timestamp > a.timestamp] within 5 min select a.latencyState as fromState, b.latencyState as toState, b.timestamp as happenTime insert into perfmon_latency_check_output2",
-      "value1": "from every a = perfmon_latency_check_output[latencyState >= 1] -> b = perfmon_latency_check_output[host == a.host and latencyState != a.latencyState and timestamp > a.timestamp] within 5 min select a.latencyState as fromState, b.latencyState as toState, b.timestamp as happenTime insert into perfmon_latency_check_output2",
-      "inputStreams": [
-        "perfmon_latency_check_output"
-      ],
-      "outputStreams": [
-        "perfmon_latency_check_output2"
-      ]
-    },
-    "partitionSpec": [
-      {
-        "streamId": "perfmon_latency_stream",
-        "type": "GROUPBY",
-        "columns": [
-          "host"
-        ],
-        "sortSpec": {
-          "windowPeriod": "PT0M"
-        }
-      }
-    ]
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/publishments.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/publishments.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/publishments.json
deleted file mode 100644
index 3e1910f..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/publishments.json
+++ /dev/null
@@ -1,28 +0,0 @@
-[
-  {
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-    "name": "kafka-testAlertStream",
-    "policyIds": [
-      "state_check_latency"
-    ],
-    "dedupIntervalMin": "PT1M",
-    "properties": {
-      "kafka_broker": "localhost:9092",
-      "topic": "latency_state_kafka1"
-    },
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  },
-  {
-    "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-    "name": "kafka-testAlertStream_state",
-    "policyIds": [
-      "state_check_latency"
-    ],
-    "dedupIntervalMin": "PT1M",
-    "properties": {
-      "kafka_broker": "localhost:9092",
-      "topic": "latency_state_kafka2"
-    },
-    "serializer": "org.apache.eagle.alert.engine.publisher.impl.StringEventSerializer"
-  }
-]

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/streamdefinitions.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/streamdefinitions.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/streamdefinitions.json
deleted file mode 100644
index 8f9f80e..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/streamdefinitions.json
+++ /dev/null
@@ -1,98 +0,0 @@
-[
-  {
-    "streamId": "perfmon_latency_stream",
-    "dataSource": "perfmon_datasource",
-    "description": "the data stream for perfmon latency metrics",
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "host",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true
-      },
-      {
-        "name": "metric",
-        "type": "STRING",
-        "defaultValue": "perfmon_latency",
-        "required": true
-      },
-      {
-        "name": "pool",
-        "type": "STRING",
-        "defaultValue": "raptor_general",
-        "required": true
-      },
-      {
-        "name": "value",
-        "type": "DOUBLE",
-        "defaultValue": 0.0,
-        "required": true
-      },
-      {
-        "name": "colo",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      }
-    ]
-  },
-  {
-    "streamId": "perfmon_latency_check_output",
-    "dataSource": "",
-    "description": "the data stream for perfmon latency state output",
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "host",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      },
-      {
-        "name": "timestamp",
-        "type": "LONG",
-        "defaultValue": 0,
-        "required": true
-      },
-      {
-        "name": "metric",
-        "type": "STRING",
-        "defaultValue": "perfmon_latency",
-        "required": true
-      },
-      {
-        "name": "pool",
-        "type": "STRING",
-        "defaultValue": "raptor_general",
-        "required": true
-      },
-      {
-        "name": "value",
-        "type": "DOUBLE",
-        "defaultValue": 0.0,
-        "required": true
-      },
-      {
-        "name": "colo",
-        "type": "STRING",
-        "defaultValue": "",
-        "required": true
-      },
-      {
-        "name": "latencyState",
-        "type": "INT",
-        "defaultValue": 0,
-        "required": true
-      }
-    ]
-  }
-]
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/topologies.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/topologies.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/topologies.json
deleted file mode 100644
index c13eeb2..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/statecheck/topologies.json
+++ /dev/null
@@ -1,31 +0,0 @@
-[
-  {
-    "name": "alertUnitTopology_1",
-    "numOfSpout": 1,
-    "numOfAlertBolt": 10,
-    "numOfGroupBolt": 4,
-    "spoutId": "alertEngineSpout",
-    "groupNodeIds": [
-      "streamRouterBolt0",
-      "streamRouterBolt1",
-      "streamRouterBolt2",
-      "streamRouterBolt3"
-    ],
-    "alertBoltIds": [
-      "alertBolt0",
-      "alertBolt1",
-      "alertBolt2",
-      "alertBolt3",
-      "alertBolt4",
-      "alertBolt5",
-      "alertBolt6",
-      "alertBolt7",
-      "alertBolt8",
-      "alertBolt9"
-    ],
-    "pubBoltId": "alertPublishBolt",
-    "spoutParallelism": 1,
-    "groupParallelism": 1,
-    "alertParallelism": 1
-  }
-]

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testAlertBoltSpec.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testAlertBoltSpec.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testAlertBoltSpec.json
deleted file mode 100644
index fd255cd..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testAlertBoltSpec.json
+++ /dev/null
@@ -1,92 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltPoliciesMap": {
-    "alertBolt0": [
-      {
-        "name": "policy1",
-        "description": null,
-        "inputStreams": [
-          "testTopic3Stream"
-        ],
-        "outputStreams": [
-          "testAlertStream"
-        ],
-        "definition": {
-          "type": "siddhi",
-          "value": "from testTopic3Stream[value=='xyz'] select value insert into testAlertStream;"
-        },
-        "partitionSpec": [
-          {
-            "streamId": "testTopic3Stream",
-            "type": "GROUPBY",
-            "columns": [
-              "value"
-            ],
-            "sortSpec": {
-              "windowPeriod": "PT10S",
-              "windowMargin": 1000
-            }
-          }
-        ],
-        "parallelismHint": 0
-      },
-      {
-        "name": "policy2",
-        "description": null,
-        "inputStreams": [
-          "testTopic4Stream"
-        ],
-        "outputStreams": [
-          "testAlertStream"
-        ],
-        "definition": {
-          "type": "siddhi",
-          "value": "from testTopic4Stream[value=='xyz'] select value insert into testAlertStream;"
-        },
-        "partitionSpec": [
-          {
-            "streamId": "testTopic4Stream",
-            "type": "GROUPBY",
-            "columns": [
-              "value"
-            ],
-            "sortSpec": {
-              "windowPeriod": "PT10S",
-              "windowMargin": 1000
-            }
-          }
-        ],
-        "parallelismHint": 0
-      },
-      {
-        "name": "policy3",
-        "description": null,
-        "inputStreams": [
-          "testTopic5Stream"
-        ],
-        "outputStreams": [
-          "testAlertStream"
-        ],
-        "definition": {
-          "type": "siddhi",
-          "value": "from testTopic5Stream[value=='xyz'] select value insert into testAlertStream;"
-        },
-        "partitionSpec": [
-          {
-            "streamId": "testTopic5Stream",
-            "type": "GROUPBY",
-            "columns": [
-              "value"
-            ],
-            "sortSpec": {
-              "windowPeriod": "PT10S",
-              "windowMargin": 1000
-            }
-          }
-        ],
-        "parallelismHint": 0
-      }
-    ]
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd0.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd0.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd0.json
deleted file mode 100644
index 3d0d5a2..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd0.json
+++ /dev/null
@@ -1,26 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltId": "alertPublishBolt",
-  "publishments": [
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-      "name": "email-testAlertStream",
-      "policyIds": [
-        "policy1",
-        "policy2",
-        "policy3"
-      ],
-      "dedupIntervalMin": "PT1M",
-      "properties": {
-        "subject": "UMP Test Alert",
-        "template": "",
-        "sender": "sender@corp.com",
-        "recipients": "receiver@corp.com",
-        "smtp.server": "mailhost.com",
-        "connection": "plaintext",
-        "smtp.port": "25"
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd1.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd1.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd1.json
deleted file mode 100644
index 0187e8b..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForAdd1.json
+++ /dev/null
@@ -1,38 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltId": "alertPublishBolt",
-  "publishments": [
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-      "name": "email-testAlertStream",
-      "policyIds": [
-        "policy1",
-        "policy2",
-        "policy3"
-      ],
-      "dedupIntervalMin": "PT1M",
-      "properties": {
-        "subject": "UMP Test Alert",
-        "template": "",
-        "sender": "sender@corp.com",
-        "recipients": "receiver@corp.com",
-        "smtp.server": "mailhost.com",
-        "connection": "plaintext",
-        "smtp.port": "25"
-      }
-    },
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-      "name": "kafka-testAlertStream",
-      "policyIds": [
-        "testPolicy"
-      ],
-      "dedupIntervalMin": "PT1M",
-      "properties": {
-        "kafka_broker": "sandbox.hortonworks.com:6667",
-        "topic": "test_kafka"
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForMdyValue.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForMdyValue.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForMdyValue.json
deleted file mode 100644
index 6fa99d6..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishForMdyValue.json
+++ /dev/null
@@ -1,27 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltId": "alertPublishBolt",
-  "publishments": [
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-      "name": "email-testAlertStream",
-      "policyIds": [
-        "policy1",
-        "policy2",
-        "policy3",
-        "policy_MdyValue"
-      ],
-      "dedupIntervalMin": "PT1M",
-      "properties": {
-        "subject": "UMP Test Alert",
-        "template": "",
-        "sender": "sender@corp.com",
-        "recipients": "receiver@corp.com",
-        "smtp.server": "mailhost.com",
-        "connection": "plaintext",
-        "smtp.port": "25"
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec.json
deleted file mode 100644
index a8f4105..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec.json
+++ /dev/null
@@ -1,44 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltId": "alertPublishBolt",
-  "publishments": [
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-      "name": "email-testAlertStream",
-      "policyIds": [
-        "policy1",
-        "policy2",
-        "policy3"
-      ],
-      "streamIds": [
-        "stream1"
-      ],
-      "dedupIntervalMin": "PT1M",
-      "properties": {
-        "subject": "Test Alert",
-        "template": "",
-        "sender": "sender@corp.com",
-        "recipients": "receiver@corp.com",
-        "mail.smtp.host": "smtp.mailhost.com",
-        "mail.smtp.auth": "true",
-        "mail.username": "username",
-        "mail.password": "password",
-        "mail.debug": "false",
-        "mail.connection": "tls",
-        "mail.smtp.port": "587"
-      },
-      "serializer": "org.apache.eagle.alert.engine.publisher.impl.JsonEventSerializer"
-    }
-    /*    {
-          "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-          "name":"kafka-testAlertStream",
-          "policyIds": ["testPolicy"],
-          "dedupIntervalMin": "PT1M",
-          "properties":{
-            "kafka_broker":"sandbox.hortonworks.com:6667",
-            "topic":"test_kafka"
-          }
-        }*/
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec2.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec2.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec2.json
deleted file mode 100644
index e31e1f4..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec2.json
+++ /dev/null
@@ -1,42 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltId": "alertPublishBolt",
-  "publishments": [
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-      "name": "email-testAlertStream",
-      "policyIds": [
-        "policy1"
-      ],
-      "streamIds": [
-        "stream1"
-      ],
-      "dedupIntervalMin": "PT2M",
-      "properties": {
-        "subject": "Test Alert",
-        "template": "",
-        "sender": "sender@corp.com",
-        "recipients": "receiver@corp.com",
-        "mail.smtp.host": "smtp.mailhost.com",
-        "mail.smtp.auth": "true",
-        "mail.username": "username",
-        "mail.password": "password",
-        "mail.debug": "false",
-        "mail.connection": "tls",
-        "mail.smtp.port": "587"
-      },
-      "serializer": "org.apache.eagle.alert.engine.publisher.impl.JsonEventSerializer"
-    }
-    //    {
-    //      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-    //      "name":"kafka-testAlertStream",
-    //      "policyIds": ["testPolicy"],
-    //      "dedupIntervalMin": "PT1M",
-    //      "properties":{
-    //        "kafka_broker":"sandbox.hortonworks.com:6667",
-    //        "topic":"test_kafka"
-    //      }
-    //    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec3.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec3.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec3.json
deleted file mode 100644
index 0de8218..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testPublishSpec3.json
+++ /dev/null
@@ -1,39 +0,0 @@
-{
-  "version": "version1",
-  "topologyName": "testTopology",
-  "boltId": "alertPublishBolt",
-  "publishments": [
-    {
-      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertEmailPublisher",
-      "name": "email-testAlertStream",
-      "policyIds": [
-        "policy1"
-      ],
-      "dedupIntervalMin": "PT2M",
-      "properties": {
-        "subject": "Test Alert",
-        "template": "",
-        "sender": "sender@corp.com",
-        "recipients": "receiver@corp.com",
-        "mail.smtp.host": "smtp.mailhost.com",
-        "mail.smtp.auth": "true",
-        "mail.username": "username",
-        "mail.password": "password",
-        "mail.debug": "false",
-        "mail.connection": "tls",
-        "mail.smtp.port": "587"
-      },
-      "serializer": "org.apache.eagle.alert.engine.publisher.impl.JsonEventSerializer"
-    }
-    //    {
-    //      "type": "org.apache.eagle.alert.engine.publisher.impl.AlertKafkaPublisher",
-    //      "name":"kafka-testAlertStream",
-    //      "policyIds": ["testPolicy"],
-    //      "dedupIntervalMin": "PT1M",
-    //      "properties":{
-    //        "kafka_broker":"sandbox.hortonworks.com:6667",
-    //        "topic":"test_kafka"
-    //      }
-    //    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testSpoutSpec.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testSpoutSpec.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testSpoutSpec.json
deleted file mode 100644
index c97ec43..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testSpoutSpec.json
+++ /dev/null
@@ -1,139 +0,0 @@
-{
-  "version": null,
-  "topologyId": "testTopology",
-  "kafka2TupleMetadataMap": {
-    "testTopic5": {
-      "type": null,
-      "name": "testTopic5",
-      "properties": null,
-      "topic": "testTopic5",
-      "schemeCls": "org.apache.eagle.alert.engine.scheme.JsonScheme",
-      "codec": null
-    },
-    "testTopic3": {
-      "type": null,
-      "name": "testTopic3",
-      "properties": null,
-      "topic": "testTopic3",
-      "schemeCls": "org.apache.eagle.alert.engine.scheme.PlainStringScheme",
-      "codec": null
-    },
-    "testTopic4": {
-      "type": null,
-      "name": "testTopic4",
-      "properties": null,
-      "topic": "testTopic4",
-      "schemeCls": "org.apache.eagle.alert.engine.scheme.PlainStringScheme",
-      "codec": null
-    }
-  },
-  "tuple2StreamMetadataMap": {
-    "testTopic5": {
-      "activeStreamNames": [
-        "testTopic5Stream"
-      ],
-      "streamNameSelectorProp": {
-        "userProvidedStreamName": "testTopic5Stream"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.JsonStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": null
-    },
-    "testTopic3": {
-      "activeStreamNames": [
-        "testTopic3Stream"
-      ],
-      "streamNameSelectorProp": {
-        "userProvidedStreamName": "testTopic3Stream"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.PlainStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": null
-    },
-    "testTopic4": {
-      "activeStreamNames": [
-        "testTopic4Stream"
-      ],
-      "streamNameSelectorProp": {
-        "userProvidedStreamName": "testTopic4Stream"
-      },
-      "streamNameSelectorCls": "org.apache.eagle.alert.engine.scheme.PlainStringStreamNameSelector",
-      "timestampColumn": "timestamp",
-      "timestampFormat": null
-    }
-  },
-  "streamRepartitionMetadataMap": {
-    "testTopic5": [
-      {
-        "topicName": "testTopic5",
-        "streamId": "defaultStringStream",
-        "groupingStrategies": [
-          {
-            "partition": {
-              "streamId": "testTopic5Stream",
-              "type": "GROUPBY",
-              "columns": [
-                "value"
-              ],
-              "sortSpec": {
-                "windowPeriod": "PT10S",
-                "windowMargin": 1000
-              }
-            },
-            "numTotalParticipatingRouterBolts": 1,
-            "startSequence": 0,
-            "totalTargetBoltIds": []
-          }
-        ]
-      }
-    ],
-    "testTopic3": [
-      {
-        "topicName": "testTopic3",
-        "streamId": "defaultStringStream",
-        "groupingStrategies": [
-          {
-            "partition": {
-              "streamId": "testTopic3Stream",
-              "type": "GROUPBY",
-              "columns": [
-                "value"
-              ],
-              "sortSpec": {
-                "windowPeriod": "PT10S",
-                "windowMargin": 1000
-              }
-            },
-            "numTotalParticipatingRouterBolts": 1,
-            "startSequence": 0,
-            "totalTargetBoltIds": []
-          }
-        ]
-      }
-    ],
-    "testTopic4": [
-      {
-        "topicName": "testTopic4",
-        "streamId": "defaultStringStream",
-        "groupingStrategies": [
-          {
-            "partition": {
-              "streamId": "testTopic4Stream",
-              "type": "GROUPBY",
-              "columns": [
-                "value"
-              ],
-              "sortSpec": {
-                "windowPeriod": "PT10S",
-                "windowMargin": 1000
-              }
-            },
-            "numTotalParticipatingRouterBolts": 1,
-            "startSequence": 0,
-            "totalTargetBoltIds": []
-          }
-        ]
-      }
-    ]
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/6fd95d5c/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testStreamDefinitionsSpec.json
----------------------------------------------------------------------
diff --git a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testStreamDefinitionsSpec.json b/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testStreamDefinitionsSpec.json
deleted file mode 100644
index 6b3ccff..0000000
--- a/eagle-core/eagle-alert-parent/eagle-alert/alert-engine/src/test/resources/testStreamDefinitionsSpec.json
+++ /dev/null
@@ -1,47 +0,0 @@
-{
-  "testTopic5Stream": {
-    "streamId": "testTopic5Stream",
-    "dataSource": null,
-    "description": null,
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "value",
-        "type": "STRING",
-        "defaultValue": null,
-        "required": false
-      }
-    ]
-  },
-  "testTopic4Stream": {
-    "streamId": "testTopic4Stream",
-    "dataSource": null,
-    "description": null,
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "value",
-        "type": "STRING",
-        "defaultValue": null,
-        "required": false
-      }
-    ]
-  },
-  "testTopic3Stream": {
-    "streamId": "testTopic3Stream",
-    "dataSource": null,
-    "description": null,
-    "validate": false,
-    "timeseries": false,
-    "columns": [
-      {
-        "name": "value",
-        "type": "STRING",
-        "defaultValue": null,
-        "required": false
-      }
-    ]
-  }
-}
\ No newline at end of file