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 2016/12/30 08:28:05 UTC

[13/14] eagle git commit: [MINOR] Migrate 0.5.0-incubating-SNAPSHOT to 0.5.0-SNAPSHOT

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/eagle-topology.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/eagle-topology.sh b/eagle-assembly/src/main/bin/eagle-topology.sh
deleted file mode 100755
index 06cd7e5..0000000
--- a/eagle-assembly/src/main/bin/eagle-topology.sh
+++ /dev/null
@@ -1,195 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-source $(dirname $0)/eagle-env.sh
-
-TOPOLOGY_NAME_SET=0
-
-function print_help() {
-	echo "Usage: $0 options {start | stop | status}"
-	echo "Options:                       Description:"
-	echo "  --jar      <fatJar path>       (Optional) Default is ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar"
-	echo "  --main     <main class>        for example: org.apache.eagle.security.auditlog.HdfsAuditLogProcessorMain"
-	echo "  --topology <topology name>     for example: sandbox-hdfsAuditLog-topology"
-	echo "  --config   <file path>         for example: $EAGLE_HOME/conf/sandbox-hdfsAuditLog-application.conf"
-	echo "  --storm-ui <storm ui url>      Execute through storm UI API, default: http://localhost:8744"
-
-	echo "Command Examples:"
-	echo "  $0 --main <mainClass> --topology <topologyName> --config <filePath> start"
-	echo "  $0 --topology <topologyName> stop"
-	echo "  $0 --topology <topologyName> status"
-}
-
-function env_check(){
-    which storm >/dev/null 2>&1
-    if [ $? != 0 ];then
-        echo "Error: storm is not installed"
-        exit 1
-    fi
-}
-
-#### parameters are in pair plus command
-#if [ `expr $# % 2` != 1 ]
-#then
-#    print_help
-#    exit 1
-#fi
-
-cmd=""
-while [  $# -gt 0  ]; do
-case $1 in
-    "start")
-        cmd=$1
-        shift
-        ;;
-    "stop")
-        cmd=$1
-        shift
-        ;;
-    "status")
-        cmd=$1
-        shift
-        ;;
-    --jar)
-        if [ $# -lt 3 ]; then
-            print_help
-            exit 1
-        fi
-        jarName=$2
-        shift 2
-        ;;
-    --main)
-        if [ $# -lt 3 ]; then
-            print_help
-            exit 1
-        fi
-        mainClass=$2
-        shift 2
-        ;;
-    --topology)
-        if [ $# -lt 3 ]; then
-            print_help
-            exit 1
-        fi
-        TOPOLOGY_NAME_SET=1
-        topologyName=$2
-        shift 2
-        ;;
-    --config)
-        if [ $# -lt 3 ]; then
-            print_help
-            exit 1
-        fi
-        configFile=$2
-        shift 2
-        ;;
-	--storm-ui)
-		# TODO: configure through arguments
-		storm_ui="http://localhost:8744"
-		shift 1
-		;;
-    *)
-        echo "Internal Error: option processing error: $1" 1>&2
-        exit 1
-        ;;
-    esac
-done
-
-
-if [ -z "$jarName" ]; then
-    jarName=$(ls ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar)
-fi
-
-if [ -z "$mainClass" ]; then
-    mainClass="org.apache.eagle.security.auditlog.HdfsAuditLogProcessorMain"
-fi
-
-if [ -z "$topologyName" ]; then
-    topologyName=sandbox-hdfsAuditLog-topology
-fi
-
-if [ -z "$configFile" ]; then
-    configFile="$EAGLE_HOME/conf/sandbox-hdfsAuditLog-application.conf"
-fi
-
-case $cmd in
-"start")
-    env_check
-    echo "Starting eagle topology ..."
-    echo "jarName="$jarName "mainClass="$mainClass "configFile="$configFile
-    if [ $TOPOLOGY_NAME_SET = 1 ]; then
-	    storm jar -c nimbus.host=$EAGLE_NIMBUS_HOST ${jarName} $mainClass -D config.file=$configFile -D envContextConfig.topologyName=$topologyName
-	else
-	    storm jar -c nimbus.host=$EAGLE_NIMBUS_HOST ${jarName} $mainClass -D config.file=$configFile
-	fi
-	if [ $? = 0 ]; then
-		echo "Starting is completed"
-		exit 0
-	else
-		echo "Failure"
-		exit 1
-	fi
-	;;
-"stop")
-    env_check
-    echo "Stopping eagle topology ..."
-    storm kill -c nimbus.host=$EAGLE_NIMBUS_HOST $topologyName
-    if [ $? = 0 ]; then
-    	echo "Stopping is completed"
-	    exit 0
-    else
-    	echo "Failure"
-	exit 1
-    fi
-	;;
-"status")
-	if [ -z "$storm_ui" ];then
-	    env_check
-	    echo "Checking topology $topologyName status ..."
-	    output=`storm list  -c nimbus.host=$EAGLE_NIMBUS_HOST | grep $topologyName`
-	    if [ $? != 0 ];then
-	        echo "Topology is not alive: $topologyName is not found"
-	        exit 1
-	    fi
-
-	    echo $output | grep ACTIVE > /dev/null 2>&1
-
-	    if [ $? = 0 ];then
-	        echo "Topology is alive: $output"
-	        exit 0
-	    else
-	        echo "Topology is not alive: $output"
-	        exit 1
-	    fi
-    else
-	    echo "Checking topology $topologyName status through storm UI API on $storm_ui"
-	    curl -XGET $storm_ui/api/v1/topology/summary | grep $topologyName | grep ACTIVE >/dev/null 2>&1
-	    if [ $? == 0 ];then
-	        echo "$topologyName is running"
-	        exit 0
-	    else
-	        echo "$topologyName is dead"
-	        exit 1
-	    fi
-    fi
-    ;;
-*)
-	print_help
-	exit 1
-esac
-
-exit 0
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/eagle-userprofile-scheduler.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/eagle-userprofile-scheduler.sh b/eagle-assembly/src/main/bin/eagle-userprofile-scheduler.sh
deleted file mode 100755
index fb74513..0000000
--- a/eagle-assembly/src/main/bin/eagle-userprofile-scheduler.sh
+++ /dev/null
@@ -1,226 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-function usage() {
-	echo "Usage: $0 [options] {start|stop|status}"
-	echo ""
-	echo "Commands"
-	echo "  start                       Start scheduler process"
-	echo "  stop                        Stop scheduler process"
-	echo "  status                      Check scheduler process status"
-	echo ""
-	echo "Options:"
-	echo "  --config <configFilePath>     Configuration file path"
-	echo "  --log    <logFilePath>        Log file path"
-	echo "  --daemon                      Run as daemon service"
-	echo "	--site		site information"
-}
-
-source $(dirname $0)/eagle-env.sh
-
-[ ! -e $EAGLE_HOME/logs ] && mkdir -p $EAGLE_HOME/logs
-[ ! -e $EAGLE_HOME/temp ] && mkdir -p $EAGLE_HOME/temp
-
-SCHEDULER_JAR=$(ls $EAGLE_HOME/lib/userprofile/eagle-security-userprofile-training-*-assembly.jar)
-SCHEDULER_CLASS="org.apache.eagle.security.userprofile.daemon.Scheduler"
-SCHEDULER_JVM_OPTS="-server"
-SCHDULER_LOG_DIR=$(dirname $0)/logs/
-
-SCHEDULER_CLASSPATH=$EAGLE_HOME/conf:$SCHEDULER_JAR
-# Add eagle shared library jars
-for file in $EAGLE_HOME/lib/share/*;do
-	SCHEDULER_CLASSPATH=$SCHEDULER_CLASSPATH:$file
-done
-
-# Walk around comman-math3 conflict with spark
-SCHEDULER_OPTS="-D eagle.userprofile.driver-classpath=$(dirname $0)/../lib/share/asm-3.1.jar:$(dirname $0)/../lib/share/commons-math3-3.5.jar"
-
-# Specify user profile spark job assembly jar
-SCHEDULER_OPTS="$SCHEDULER_OPTS -D eagle.userprofile.jar=$SCHEDULER_JAR"
-
-SCHEDULER_CMD="java $SCHEDULER_JVM_OPTS -cp $SCHEDULER_CLASSPATH:$SCHEDULER_JAR $SCHEDULER_CLASS $SCHEDULER_OPTS"
-
-### parameters are in pair
-if [ $# = 0 ] ; then
-	usage
-	exit 1
-fi
-
-while [  $# -gt 0  ]; do
-case $1 in
-  "--site")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-	 site=$2
-     shift 2
-     ;;
-  "--config")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-	 config=$2
-     shift 2
-     ;;
-  "--log")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-	 log=$2
-     shift 2
-     ;;
-  "--daemon")
-     daemon="true"
-     shift 1
-     ;;
-  "start")
-    command="start"
-     shift 1
-    ;;
-  "stop")
-    command="stop"
-	shift 1
-    ;;
-  "status")
-    command="status"
-	shift 1
-    ;;
-  *)
-     echo "Internal Error: option processing error: $1" 1>&2
-     usage
-     exit 1
-     ;;
-  esac
-done
-
-# Validate Arguments
-# ==================
-
-# --site
-if [ -z "$site" ];then
-	echo "Error: --site required"
-	usage
-	exit 1
-fi
-
-pid=$(dirname $0)/../temp/$site-userprofile-scheduler.pid
-
-# --config
-if [ -z "$config" ];then
-	config=$(dirname $0)/../conf/$site-userprofile-scheduler.conf
-fi
-
-# --log
-if [ -z "$log" ];then
-	log=$(dirname $0)/../logs/$site-userprofile-scheduler.out
-fi
-
-# Define Functions
-# ================
-function start(){
-	if [ -e $pid ];then
-		pidv=`cat $pid`
-		ps -p $pidv 1>/dev/null 2>&1
-		if [ "$?" != "0" ];then
-			echo "Process [$pidv] is found, but dead, continue to start ..."
-		else
-			echo "Process [$pidv] is still runing, please top it firstly, exiting ..."
-			exit 1
-		fi
-	fi
-
-	if [ ! -e $config ];then
-		echo "Error: --config $config not exist"
-		usage
-		exit 1
-	fi
-
-	cmd="$SCHEDULER_CMD -D eagle.site=$site -D config.file=$config"
-
-	if [ "$daemon" == "true" ];then
-		echo "Executing: $cmd as daemon"
-		echo $cmd >> $log
-		nohup $cmd 1>>$log 2>&1 &
-		pidv=$!
-		echo $pidv > $pid
-		echo "Logging to: $log, pid: $pidv"
-	else
-		echo "Executing: $cmd"
-		$cmd
-	fi
-}
-
-function stop(){
-	if [ -e $pid ];then
-		pidv=`cat $pid`
-		ps -p $pidv 1>/dev/null 2>&1
-		if [ "$?" != "0" ];then
-			rm $pid
-			echo "Process [$pidv] is not running, but PID file exisits: $pid, removed"
-			exit 1
-		else
-			echo "Killing process [$pidv]"
-			kill $pidv
-			if [ $? == 0 ];then
-				rm $pid
-				echo "Killed successfully"
-				exit 0
-			else
-				echo "Failed to kill process [$pid]"
-				exit 1
-			fi
-		fi
-	else
-		echo "Process is not running"
-		exit 1
-	fi
-}
-
-function status(){
-	if [ -e $pid ];then
-		pidv=`cat $pid`
-		ps -p $pidv 1>/dev/null 2>&1
-		if [ "$?" != "0" ];then
-			echo "Process [$pidv] is dead"
-			exit 1
-		else
-			echo "Process [$pidv] is running"
-			exit 0
-		fi
-	else
-		echo "$pid not found, assume process should have been stopped"
-		exit 1
-	fi
-}
-
-case $command in
-	"start")
-		start
-		;;
-	"stop")
-		stop
-		;;
-	"status")
-		status
-		;;
-	*)  usage
-		exit 1
-		;;
-esac
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/eagle-userprofile-training.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/eagle-userprofile-training.sh b/eagle-assembly/src/main/bin/eagle-userprofile-training.sh
deleted file mode 100755
index 209570c..0000000
--- a/eagle-assembly/src/main/bin/eagle-userprofile-training.sh
+++ /dev/null
@@ -1,163 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-function usage() {
-	echo "Usage: $0 --jar <jarName> --main <mainClass> --site <sitename> --input <inputschema> --output <outputschema>"
-	echo "--site <siteName>     Must be given"
-	echo "--jar <jarName>       Default is $EAGLE_HOME/lib/userprofile/eagle-security-userprofile-training-0.1.0-assembly.jar"
-    echo "--main <mainClass>    Default is org.apache.eagle.security.userprofile.UserProfileTrainingCLI"
-    echo "--input               Default is /tmp/userprofile/hdfs-audit.log"
-    echo "--output              Default is eagle://localhost:9099. When modelSink is hdfs, the value is hdfs:///tmp/userprofile/output"
-	echo "Example: $0 --jar <jarName> --main <mainClass> --site <sitename> --input <input> --output <output>"
-}
-
-function env_check(){
-    which spark-submit >/dev/null 2>&1
-    if [ $? != 0 ];then
-        echo "Error: spark is not installed"
-        exit 1
-    fi
-}
-
-source $(dirname $0)/eagle-env.sh
-
-#### parameters are in pair
-if [ $# = 0 ] || [ `expr $# % 2` != 0 ] ; then
-	usage
-	exit 1
-fi
-
-while [  $# -gt 0  ]; do
-case $1 in
-  "--site")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-     site=$2
-     shift 2
-     ;;
-  "--jar")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-     jar=$2
-     shift 2
-     ;;
-  "--main")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-     main=$2
-     shift 2
-     ;;
-  "--input")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-     input=$2
-     shift 2
-     ;;
-  "--output")
-     if [ $# -lt 2 ]; then
-        usage
-        exit 1
-     fi
-     output=$2
-     shift 2
-     ;;
-  *)
-     echo "Internal Error: option processing error: $1" 1>&2
-     exit 1
-     ;;
-  esac
-done
-
-if [ -z "$site" ];then
-	echo "Error: --site is required" 1>&2
-	exit 1
-fi
-
-if [ -z "$main" ] ; then
-  main="org.apache.eagle.security.userprofile.UserProfileTrainingCLI"
-fi
-
-if [ -z "$jar" ] ; then
-  jar="$EAGLE_HOME/lib/userprofile/eagle-security-userprofile-training-0.1.0-assembly.jar"
-fi
-
-if [ -z "input" ] ; then
-  input="hdfs:///tmp/userprofile/hdfs-audit.log"
-fi
-
-if [ -z "output" ] ; then
-  output="eagle://localhost:9099"
-fi
-
-outputScheme=`echo $output | sed -E 's/^(.*):\/\/.*/\1/'`
-
-case $outputScheme in
- "hdfs")
-   env_check
-   echo "Starting eagle user profile training ..."
-   hdfsOutput=`echo $output | sed -E 's/hdfs:\/\/(.*)/\1/'`
-   spark-submit --class $main \
-                 --master "local[10]" \
-                 --driver-class-path $EAGLE_HOME/lib/share/asm-3.1.jar:$EAGLE_HOME/lib/share/commons-math3-3.5.jar \
-                 $jar \
-                 --site $site \
-                 --input $input \
-                 --output $hdfsOutput
-    if [ $? = 0 ]; then
-		echo "Starting is completed"
-		exit 0
-	else
-		echo "Failure"
-		exit 1
-	fi
-	;;
-  "eagle")
-    env_check
-    echo "Starting eagle user profile training ..."
-    eagleServiceHost=`echo $output | sed -E 's/eagle:\/\/(.*):(.*)/\1/'`
-    eagleServicePort=`echo $output | sed -E 's/eagle:\/\/(.*):(.*)/\2/'`
-    spark-submit --class $main \
-                 --master "local[10]" \
-                 --driver-class-path $EAGLE_HOME/lib/share/asm-3.1.jar:$EAGLE_HOME/lib/share/commons-math3-3.5.jar \
-                 $jar \
-                 --site $site \
-                 --input $input \
-                 --service-host $eagleServiceHost \
-                 --service-port $eagleServicePort
-
-    if [ $? = 0 ]; then
-        echo "Starting is completed"
-        exit 0
-    else
-        echo "Failure"
-        exit 1
-    fi
-    ;;
-  *)
-	usage
-	exit 1
-esac
-
-exit 0
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/hadoop-metric-monitor.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/hadoop-metric-monitor.sh b/eagle-assembly/src/main/bin/hadoop-metric-monitor.sh
deleted file mode 100755
index 327bec1..0000000
--- a/eagle-assembly/src/main/bin/hadoop-metric-monitor.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-##!/bin/bash
-#
-## 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.
-#
-source $(dirname $0)/eagle-env.sh
-
-######################################################################
-##            Import stream metadata for HADOOP METRIC
-######################################################################
-${EAGLE_HOME}/bin/hadoop-metric-init.sh
-
-######################################################################
-##            Run topology for HADOOP METRIC
-######################################################################
-### if topology exists, we should shutdown it
-echo "check topology status ..."
-active=$(${EAGLE_HOME}/bin/eagle-topology.sh --topology sandbox-hadoopjmx-topology status | grep ACTIVE)
-echo "topology status $active"
-if [ "$active" ]; then
- echo "stop topology ..."
- ${EAGLE_HOME}/bin/eagle-topology.sh --topology sandbox-hadoopjmx-topology stop
-fi
-echo "start Eagle Hadoop Metric Monitoring topology"
-${EAGLE_HOME}/bin/eagle-topology.sh --main org.apache.eagle.hadoop.metric.HadoopJmxMetricMonitor --topology sandbox-hadoopjmx-topology --config ${EAGLE_HOME}/conf/sandbox-hadoopjmx-topology.conf start
-
-######################################################################
-##            Setup minutely crontab job for HADOOP METRIC
-######################################################################
-echo "set up crontab script"
-DIR="$( cd "$( dirname "${BASH_SOURCE[0]}" )" && pwd )"
-cp $DIR/../tools/hadoop_jmx_collector/config-sample.json $DIR/../tools/hadoop_jmx_collector/config.json
-command="python $DIR/../tools/hadoop_jmx_collector/hadoop_jmx_kafka.py"
-job="* * * * * $command >> $DIR/../logs/hadoop_metric.log"
-echo "$job"
-cat <(fgrep -i -v "$command" <(crontab -l)) <(echo "$job") | crontab -
-
-echo "$(crontab -l)"

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/hdfs-securitylog-metadata-create.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/hdfs-securitylog-metadata-create.sh b/eagle-assembly/src/main/bin/hdfs-securitylog-metadata-create.sh
deleted file mode 100755
index 0d50376..0000000
--- a/eagle-assembly/src/main/bin/hdfs-securitylog-metadata-create.sh
+++ /dev/null
@@ -1,40 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-source $(dirname $0)/eagle-env.sh
-
-echo "Importing metadata for HDFS security log... "
-
-#### AlertStreamService: alert streams generated from data source
-
-curl -u ${EAGLE_SERVICE_USER}:${EAGLE_SERVICE_PASSWD} -X POST -H 'Content-Type:application/json' "http://${EAGLE_SERVICE_HOST}:${EAGLE_SERVICE_PORT}/eagle-service/rest/entities?serviceName=AlertStreamService" -d '[{"prefix":"alertStream","tags":{"application":"hdfsSecurityLog","streamName":"hdfsSecurityLogEventStream"},"desc":"alert event stream from HDFS security audit log"}]'
-
-
-#### AlertExecutorService: what alert streams are consumed by alert executor
-
-curl -u ${EAGLE_SERVICE_USER}:${EAGLE_SERVICE_PASSWD} -X POST -H 'Content-Type:application/json' "http://${EAGLE_SERVICE_HOST}:${EAGLE_SERVICE_PORT}/eagle-service/rest/entities?serviceName=AlertExecutorService" -d '[{"prefix":"alertExecutor","tags":{"application":"hdfsSecurityLog","alertExecutorId":"hdfsSecurityLogAlertExecutor","streamName":"hdfsSecurityLogEventStream"},"desc":"alert executor for HDFS security log event stream"}]'
-
-
-#### AlertStreamSchemaService: schema for event from alert stream
-
-curl -u ${EAGLE_SERVICE_USER}:${EAGLE_SERVICE_PASSWD} -X POST -H 'Content-Type:application/json' "http://${EAGLE_SERVICE_HOST}:${EAGLE_SERVICE_PORT}/eagle-service/rest/entities?serviceName=AlertStreamSchemaService" -d '[{"prefix":"alertStreamSchema","tags":{"application":"hdfsSecurityLog","streamName":"hdfsSecurityLogEventStream","attrName":"timestamp"},"attrDescription":"milliseconds of the datetime","attrType":"long","category":"","attrValueResolver":""},{"prefix":"alertStreamSchema","tags":{"application":"hdfsSecurityLog","streamName":"hdfsSecurityLogEventStream","attrName":"user"},"attrDescription":"","attrType":"string","category":"","attrValueResolver":""},{"prefix":"alertStreamSchema","tags":{"application":"hdfsSecurityLog","streamName":"hdfsSecurityLogEventStream","attrName":"allowed"},"attrDescription":"true, false or none","attrType":"bool","category":"","attrValueResolver":""}]'
-
-curl -u ${EAGLE_SERVICE_USER}:${EAGLE_SERVICE_PASSWD} -X POST -H 'Content-Type:application/json' "http://${EAGLE_SERVICE_HOST}:${EAGLE_SERVICE_PORT}/eagle-service/rest/entities?serviceName=AlertDataSourceService" -d '[{"prefix":"alertDataSource","tags":{"site":"sandbox","application":"hdfsSecurityLog"},"enabled":"true","desc":"HDFS Security"}]'
-
-
-echo ""
-

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/kafka-producer.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/kafka-producer.sh b/eagle-assembly/src/main/bin/kafka-producer.sh
deleted file mode 100755
index 3366de0..0000000
--- a/eagle-assembly/src/main/bin/kafka-producer.sh
+++ /dev/null
@@ -1,21 +0,0 @@
-#!/bin/bash
-# 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.
-
-if [ "x$EAGLE_HEAP_OPTS" = "x" ]; then
-    export EAGLE_HEAP_OPTS="-Xmx512M"
-fi
-
-exec $(dirname $0)/eagle-run-class.sh org.apache.eagle.contrib.kafka.ProducerTool "$@"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/kafka-server-start.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/kafka-server-start.sh b/eagle-assembly/src/main/bin/kafka-server-start.sh
deleted file mode 100755
index ce37610..0000000
--- a/eagle-assembly/src/main/bin/kafka-server-start.sh
+++ /dev/null
@@ -1,51 +0,0 @@
-#!/bin/bash
-# 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.
-
-if [ $# -lt 1 ];
-then
-	echo "USAGE: $0 [-daemon] conf/kafka-server.properties [--override property=value]*"
-	exit 1
-fi
-
-base_dir=$(dirname $0)
-
-if [ "x$EAGLE_LOG4J_OPTS" = "x" ]; then
-    export KAFKA_LOG4J_OPTS="-Dlog4j.configuration=file:$base_dir/../conf/log4j.properties"
-fi
-
-if [ "x$EAGLE_HEAP_OPTS" = "x" ]; then
-    export EAGLE_HEAP_OPTS="-Xmx1G -Xms1G"
-fi
-
-EXTRA_ARGS="-name kafkaServer -loggc"
-
-COMMAND=$1
-case $COMMAND in
-  -daemon)
-    EXTRA_ARGS="-daemon "$EXTRA_ARGS
-    shift
-    ;;
-  *)
-    ;;
-esac
-
-$base_dir/kafka-server-status.sh 1>/dev/null 2>&1
-if [ "$?" == "" ];then
-	echo "Kafka is still running, please stop firstly before starting"
-	exit 0
-else
-	exec $base_dir/eagle-run-class.sh $EXTRA_ARGS kafka.Kafka "$@"
-fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/kafka-server-status.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/kafka-server-status.sh b/eagle-assembly/src/main/bin/kafka-server-status.sh
deleted file mode 100755
index c794425..0000000
--- a/eagle-assembly/src/main/bin/kafka-server-status.sh
+++ /dev/null
@@ -1,24 +0,0 @@
-#!/bin/sh
-# 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.
-PIDS=$(ps ax | grep -i 'kafka\.Kafka' | grep java | grep -v grep | awk '{print $1}')
-
-if [ -z "$PIDS" ]; then
-  echo "No kafka server is running"
-  exit 1
-else
-  echo "Kafka server is running at $PIDS"
-  exit 0
-fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/kafka-server-stop.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/kafka-server-stop.sh b/eagle-assembly/src/main/bin/kafka-server-stop.sh
deleted file mode 100755
index 9de6d76..0000000
--- a/eagle-assembly/src/main/bin/kafka-server-stop.sh
+++ /dev/null
@@ -1,23 +0,0 @@
-#!/bin/sh
-# 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.
-PIDS=$(ps ax | grep -i 'kafka\.Kafka' | grep java | grep -v grep | awk '{print $1}')
-
-if [ -z "$PIDS" ]; then
-  echo "No kafka server to stop"
-  exit 1
-else
-  kill -s TERM $PIDS
-fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/kafka-stream-monitor.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/kafka-stream-monitor.sh b/eagle-assembly/src/main/bin/kafka-stream-monitor.sh
deleted file mode 100755
index 50dce87..0000000
--- a/eagle-assembly/src/main/bin/kafka-stream-monitor.sh
+++ /dev/null
@@ -1,53 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-source $(dirname $0)/eagle-env.sh
-
-if [ -e ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar ];then
-	export jar_name=$(ls ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar)
-else
-	echo "ERROR: ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar not found"
-	exit 1
-fi
-
-export main_class=org.apache.eagle.datastream.storm.KafkaStreamMonitor
-
-export alert_stream=$1
-export alert_executor=$2
-export config_file=$3
-
-if [ "$#" -lt "2" ];then
-	echo "ERROR: parameter required"
-	echo "Usage: kafka-stream-monitor.sh [alert_stream alert_executor config_file] or [alert_stream config_file]"
-	echo ""
-	exit 1
-fi
-if [ "$#" == "2" ];then
-	config_file=$2
-	alert_executor="${alert_stream}Executor"
-fi
-
-cmd="java -cp $EAGLE_STORM_CLASSPATH:$jar_name $main_class -D eagle.stream.name=$alert_stream -D eagle.stream.executor=$alert_executor -D config.file=$config_file -D envContextConfig.jarFile=$jar_name"
-
-echo "=========="
-echo "Alert Stream: $alert_stream"
-echo "Alert Executor: $alert_executor"
-echo "Alert Config: $config_file"
-echo "=========="
-echo "Run Cmd: $cmd"
-echo $cmd
-$cmd
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/kafka-topics.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/kafka-topics.sh b/eagle-assembly/src/main/bin/kafka-topics.sh
deleted file mode 100755
index 3c0b23d..0000000
--- a/eagle-assembly/src/main/bin/kafka-topics.sh
+++ /dev/null
@@ -1,17 +0,0 @@
-#!/bin/bash
-# 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.
-
-exec $(dirname $0)/eagle-run-class.sh kafka.admin.TopicCommand "$@"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/pipeline-runner.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/pipeline-runner.sh b/eagle-assembly/src/main/bin/pipeline-runner.sh
deleted file mode 100755
index 65bf3f3..0000000
--- a/eagle-assembly/src/main/bin/pipeline-runner.sh
+++ /dev/null
@@ -1,52 +0,0 @@
-#!/bin/bash
-
-# 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.
-
-source $(dirname $0)/eagle-env.sh
-
-if [ -e ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar ];then
-	export jar_name=$(ls ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar)
-else
-	echo "ERROR: ${EAGLE_HOME}/lib/topology/eagle-topology-*-assembly.jar not found"
-	exit 1
-fi
-if [ -e ${EAGLE_HOME}/conf/pipeline.conf ];then
-	export common_conf=$(ls ${EAGLE_HOME}/conf/pipeline.conf)
-else
-	echo "WARN: ${EAGLE_HOME}/conf/pipeline.conf not found"
-fi
-
-main_class=org.apache.eagle.stream.pipeline.Pipeline
-
-if [ "$#" == "0" ];then
-	echo "ERROR: parameter required"
-	echo "Usage: $0 [pipeline-config]"
-
-	echo ""
-	exit 1
-fi
-
-which storm >/dev/null 2>&1
-if [ $? != 0 ];then
-    echo "ERROR: storm not found"
-    exit 1
-else
-	export EAGLE_CLASSPATH=$EAGLE_CLASSPATH:$jar_name:`storm classpath`
-fi
-
-cmd="java -cp $EAGLE_CLASSPATH $main_class --conf $common_conf --pipeline $1 -D envContextConfig.jarFile=$jar_name"
-echo $cmd
-$cmd
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/zookeeper-server-start.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/zookeeper-server-start.sh b/eagle-assembly/src/main/bin/zookeeper-server-start.sh
deleted file mode 100755
index d0fbd3d..0000000
--- a/eagle-assembly/src/main/bin/zookeeper-server-start.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/bin/bash
-# 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.
-
-if [ $# -lt 1 ];
-then
-	echo "USAGE: $0 [-daemon] conf/zookeeper-server.properties"
-	exit 1
-fi
-base_dir=$(dirname $0)
-
-if [ "x$EAGLE_LOG4J_OPTS" = "x" ]; then
-    export EAGLE_LOG4J_OPTS="-Dlog4j.configuration=file:$base_dir/../conf/log4j.properties"
-fi
-
-if [ "x$EAGLE_HEAP_OPTS" = "x" ]; then
-    export EAGLE_HEAP_OPTS="-Xmx512M -Xms512M"
-fi
-
-EXTRA_ARGS="-name zookeeper -loggc"
-
-COMMAND=$1
-case $COMMAND in
-  -daemon)
-     EXTRA_ARGS="-daemon "$EXTRA_ARGS
-     shift
-     ;;
- *)
-     ;;
-esac
-
-$base_dir/zookeeper-server-status.sh 1>/dev/null 2>&1
-if [ "$?" == "" ];then
-	echo "Zookeeper is still running, please stop firstly before starting"
-	exit 0
-else
-	exec $base_dir/eagle-run-class.sh $EXTRA_ARGS org.apache.zookeeper.server.quorum.QuorumPeerMain "$@"
-fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/zookeeper-server-status.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/zookeeper-server-status.sh b/eagle-assembly/src/main/bin/zookeeper-server-status.sh
deleted file mode 100755
index 223a310..0000000
--- a/eagle-assembly/src/main/bin/zookeeper-server-status.sh
+++ /dev/null
@@ -1,24 +0,0 @@
-#!/bin/sh
-# 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.
-PIDS=$(ps ax | grep java | grep -i QuorumPeerMain | grep -v grep | awk '{print $1}')
-
-if [ -z "$PIDS" ]; then
-  echo "No zookeeper server is running"
-  exit 1
-else
-  echo "Zookeeper server is running at $PIDS"
-  exit 0
-fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/bin/zookeeper-server-stop.sh
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/bin/zookeeper-server-stop.sh b/eagle-assembly/src/main/bin/zookeeper-server-stop.sh
deleted file mode 100755
index 4155182..0000000
--- a/eagle-assembly/src/main/bin/zookeeper-server-stop.sh
+++ /dev/null
@@ -1,24 +0,0 @@
-#!/bin/sh
-
-# 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.
-PIDS=$(ps ax | grep java | grep -i QuorumPeerMain | grep -v grep | awk '{print $1}')
-
-if [ -z "$PIDS" ]; then
-  echo "No zookeeper server to stop"
-  exit 1
-else
-  kill -s TERM $PIDS
-fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/eagle-scheduler.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/eagle-scheduler.conf b/eagle-assembly/src/main/conf/eagle-scheduler.conf
deleted file mode 100644
index 74ff18b..0000000
--- a/eagle-assembly/src/main/conf/eagle-scheduler.conf
+++ /dev/null
@@ -1,42 +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.
-
-
-### scheduler propertise
-appCommandLoaderEnabled = false
-appCommandLoaderIntervalSecs = 1
-appHealthCheckIntervalSecs = 5
-
-### execution platform properties
-envContextConfig.env = "storm"
-envContextConfig.url = "http://sandbox.hortonworks.com:8744"
-envContextConfig.nimbusHost = "sandbox.hortonworks.com"
-envContextConfig.nimbusThriftPort = 6627
-envContextConfig.jarFile = "/dir-to-jar/eagle-topology-0.3.0-incubating-assembly.jar"
-
-### default topology properties
-eagleProps.mailHost = "mailHost.com"
-eagleProps.mailSmtpPort = "25"
-eagleProps.mailDebug = "true"
-eagleProps.eagleService.host = "localhost"
-eagleProps.eagleService.port = 9099
-eagleProps.eagleService.username = "admin"
-eagleProps.eagleService.password = "secret"
-eagleProps.dataJoinPollIntervalSec = 30
-
-dynamicConfigSource.enabled = true
-dynamicConfigSource.initDelayMillis = 0
-dynamicConfigSource.delayMillis = 30000
-

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/eagle-service.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/eagle-service.conf b/eagle-assembly/src/main/conf/eagle-service.conf
deleted file mode 100644
index c28a676..0000000
--- a/eagle-assembly/src/main/conf/eagle-service.conf
+++ /dev/null
@@ -1,30 +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.
-
-
-eagle {
-  service {
-    storage-type = "hbase"
-    hbase-zookeeper-quorum = "sandbox.hortonworks.com"
-    hbase-zookeeper-property-clientPort = 2181
-    zookeeper-znode-parent = "/hbase-unsecure",
-    springActiveProfile = "sandbox"
-    audit-enabled = true
-  }
-}
-
-
-
-

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/kafka-server.properties
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/kafka-server.properties b/eagle-assembly/src/main/conf/kafka-server.properties
deleted file mode 100644
index 684c81f..0000000
--- a/eagle-assembly/src/main/conf/kafka-server.properties
+++ /dev/null
@@ -1,115 +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.
-# see kafka.server.KafkaConfig for additional details and defaults
-
-############################# Server Basics #############################
-
-# The id of the broker. This must be set to a unique integer for each broker.
-broker.id=0
-
-############################# Socket Server Settings #############################
-
-# The address the socket server listens on. It will get the value returned from
-# java.net.InetAddress.getCanonicalHostName() if not configured.
-#   FORMAT:
-#     listeners = security_protocol://host_name:port
-#   EXAMPLE:
-#     listeners = PLAINTEXT://your.host.name:9092
-#listeners=PLAINTEXT://:9092
-
-# Hostname and port the broker will advertise to producers and consumers. If not set,
-# it uses the value for "listeners" if configured.  Otherwise, it will use the value
-# returned from java.net.InetAddress.getCanonicalHostName().
-#advertised.listeners=PLAINTEXT://your.host.name:9092
-
-# The number of threads handling network requests
-num.network.threads=3
-
-# The number of threads doing disk I/O
-num.io.threads=8
-
-# The send buffer (SO_SNDBUF) used by the socket server
-socket.send.buffer.bytes=102400
-
-# The receive buffer (SO_RCVBUF) used by the socket server
-socket.receive.buffer.bytes=102400
-
-# The maximum size of a request that the socket server will accept (protection against OOM)
-socket.request.max.bytes=104857600
-
-
-############################# Log Basics #############################
-
-# A comma seperated list of directories under which to store log files
-log.dirs=/tmp/eagle-kafka-logs
-
-# The default number of log partitions per topic. More partitions allow greater
-# parallelism for consumption, but this will also result in more files across
-# the brokers.
-num.partitions=1
-
-# The number of threads per data directory to be used for log recovery at startup and flushing at shutdown.
-# This value is recommended to be increased for installations with data dirs located in RAID array.
-num.recovery.threads.per.data.dir=1
-
-############################# Log Flush Policy #############################
-
-# Messages are immediately written to the filesystem but by default we only fsync() to sync
-# the OS cache lazily. The following configurations control the flush of data to disk.
-# There are a few important trade-offs here:
-#    1. Durability: Unflushed data may be lost if you are not using replication.
-#    2. Latency: Very large flush intervals may lead to latency spikes when the flush does occur as there will be a lot of data to flush.
-#    3. Throughput: The flush is generally the most expensive operation, and a small flush interval may lead to exceessive seeks.
-# The settings below allow one to configure the flush policy to flush data after a period of time or
-# every N messages (or both). This can be done globally and overridden on a per-topic basis.
-
-# The number of messages to accept before forcing a flush of data to disk
-#log.flush.interval.messages=10000
-
-# The maximum amount of time a message can sit in a log before we force a flush
-#log.flush.interval.ms=1000
-
-############################# Log Retention Policy #############################
-
-# The following configurations control the disposal of log segments. The policy can
-# be set to delete segments after a period of time, or after a given size has accumulated.
-# A segment will be deleted whenever *either* of these criteria are met. Deletion always happens
-# from the end of the log.
-
-# The minimum age of a log file to be eligible for deletion
-log.retention.hours=168
-
-# A size-based retention policy for logs. Segments are pruned from the log as long as the remaining
-# segments don't drop below log.retention.bytes.
-#log.retention.bytes=1073741824
-
-# The maximum size of a log segment file. When this size is reached a new log segment will be created.
-log.segment.bytes=1073741824
-
-# The interval at which log segments are checked to see if they can be deleted according
-# to the retention policies
-log.retention.check.interval.ms=300000
-
-############################# Zookeeper #############################
-
-# Zookeeper connection string (see zookeeper docs for details).
-# This is a comma separated host:port pairs, each corresponding to a zk
-# server. e.g. "127.0.0.1:3000,127.0.0.1:3001,127.0.0.1:3002".
-# You can also append an optional chroot string to the urls to specify the
-# root directory for all kafka znodes.
-zookeeper.connect=localhost:2181
-
-# Timeout in ms for connecting to zookeeper
-zookeeper.connection.timeout.ms=6000
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/ldap.properties
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/ldap.properties b/eagle-assembly/src/main/conf/ldap.properties
deleted file mode 100644
index 4a2c3f1..0000000
--- a/eagle-assembly/src/main/conf/ldap.properties
+++ /dev/null
@@ -1,23 +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.
-ldap.server=
-ldap.username=
-ldap.password=
-ldap.user.searchBase=
-ldap.user.searchPattern=
-ldap.user.groupSearchBase=
-acl.adminRole=
-acl.defaultRole=
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/log4j.properties
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/log4j.properties b/eagle-assembly/src/main/conf/log4j.properties
deleted file mode 100644
index 76ea987..0000000
--- a/eagle-assembly/src/main/conf/log4j.properties
+++ /dev/null
@@ -1,30 +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=INFO, stdout
-eagle.log.dir=../logs
-eagle.log.file=eagle.log
-# 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
-# Daily Rolling File Appender
-log4j.appender.DRFA=org.apache.log4j.DailyRollingFileAppender
-log4j.appender.DRFA.File=${eagle.log.dir}/${eagle.log.file}
-log4j.appender.DRFA.DatePattern=.yyyy-MM-dd
-## 30-day backup
-# log4j.appender.DRFA.MaxBackupIndex=30
-log4j.appender.DRFA.layout=org.apache.log4j.PatternLayout
-# Pattern format: Date LogLevel LoggerName LogMessage
-log4j.appender.DRFA.layout.ConversionPattern=%d{ISO8601} %p [%t] %c{2}[%L]: %m%n
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/pipeline.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/pipeline.conf b/eagle-assembly/src/main/conf/pipeline.conf
deleted file mode 100644
index 9715ca3..0000000
--- a/eagle-assembly/src/main/conf/pipeline.conf
+++ /dev/null
@@ -1,40 +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.
-
-{
-  "envContextConfig": {
-    "env": "storm"
-    "mode": "cluster"
-    "nimbusHost": "sandbox.hortonworks.com",
-    "nimbusThriftPort": 6627
-  }
-  "eagleProps": {
-    "dataJoinPollIntervalSec": 30
-    "mailHost": "smtp.server.host"
-    "mailSmtpPort": "25"
-    "mailDebug": "true"
-    "eagleService": {
-      "host": "localhost"
-      "port": 9099
-      "username": "admin"
-      "password": "secret"
-    }
-  }
-  "dynamicConfigSource": {
-    "enabled": true
-    "initDelayMillis": 0
-    "delayMillis": 30000
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-hadoopjmx-pipeline.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-hadoopjmx-pipeline.conf b/eagle-assembly/src/main/conf/sandbox-hadoopjmx-pipeline.conf
deleted file mode 100644
index 0211612..0000000
--- a/eagle-assembly/src/main/conf/sandbox-hadoopjmx-pipeline.conf
+++ /dev/null
@@ -1,49 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#    http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing software
-# distributed under the License is distributed on an "AS IS" BASIS
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-{
-  config {
-    envContextConfig {
-      "topologyName": "sandbox-hadoopjmx-pipeline"
-    }
-    eagleProps {
-      "site": "sandbox"
-      "application": "HADOOP"
-    }
-  }
-
-  dataflow {
-    KafkaSource.hadoopNNJmxStream {
-      parallism = 1000
-      topic = "nn_jmx_metric_sandbox"
-      zkConnection = "sandbox.hortonworks.com:2181"
-      zkConnectionTimeoutMS = 15000
-      consumerGroupId = "Consumer"
-      fetchSize = 1048586
-      transactionZKServers = "sandbox.hortonworks.com"
-      transactionZKPort = 2181
-      transactionZKRoot = "/consumers"
-      transactionStateUpdateMS = 2000
-      deserializerClass = "org.apache.eagle.datastream.storm.JsonMessageDeserializer"
-    }
-
-    Alert.hadoopNNJmxStreamAlertExecutor {
-      upStreamNames = [hadoopNNJmxStream]
-      alertExecutorId = hadoopNNJmxStreamAlertExecutor
-    }
-
-    hadoopNNJmxStream -> hadoopNNJmxStreamAlertExecutor {}
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-hadoopjmx-topology.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-hadoopjmx-topology.conf b/eagle-assembly/src/main/conf/sandbox-hadoopjmx-topology.conf
deleted file mode 100644
index b69b4b9..0000000
--- a/eagle-assembly/src/main/conf/sandbox-hadoopjmx-topology.conf
+++ /dev/null
@@ -1,69 +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.
-
-{
-  "envContextConfig": {
-    "env": "storm",
-    "mode": "cluster",
-    "topologyName": "hadoopJmxMetricTopology",
-    "stormConfigFile": "hadoopjmx.yaml",
-    "parallelismConfig": {
-      "kafkaMsgConsumer": 1,
-      "hadoopJmxMetricAlertExecutor*": 1
-    }
-  },
-  "dataSourceConfig": {
-    "topic": "nn_jmx_metric_sandbox",
-    "zkConnection": "sandbox.hortonworks.com:2181",
-    "zkConnectionTimeoutMS": 15000,
-    "consumerGroupId": "EagleConsumer",
-    "fetchSize": 1048586,
-    "deserializerClass": "org.apache.eagle.datastream.storm.JsonMessageDeserializer",
-    "transactionZKServers": "sandbox.hortonworks.com",
-    "transactionZKPort": 2181,
-    "transactionZKRoot": "/consumers",
-    "transactionStateUpdateMS": 2000
-  },
-  "alertExecutorConfigs": {
-    "hadoopJmxMetricAlertExecutor": {
-      "parallelism": 1,
-      "partitioner": "org.apache.eagle.policy.DefaultPolicyPartitioner"
-      "needValidation": "true"
-    }
-  },
-  "eagleProps": {
-    "site": "sandbox",
-    "application": "hadoopJmxMetricDataSource",
-    "dataJoinPollIntervalSec": 30,
-    "mailHost": "mailHost.com",
-    "mailSmtpPort": "25",
-    "mailDebug": "true",
-    "balancePartitionEnabled": true,
-    #"partitionRefreshIntervalInMin" : 60,
-    #"kafkaStatisticRangeInMin" : 60,
-    "eagleService": {
-      "host": "localhost",
-      "port": 9099,
-      "username": "admin",
-      "password": "secret"
-    }
-    "readHdfsUserCommandPatternFrom": "file"
-  },
-  "dynamicConfigSource": {
-    "enabled": true,
-    "initDelayMillis": 0,
-    "delayMillis": 30000
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-hbaseSecurityLog-application.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-hbaseSecurityLog-application.conf b/eagle-assembly/src/main/conf/sandbox-hbaseSecurityLog-application.conf
deleted file mode 100644
index 83d6bfd..0000000
--- a/eagle-assembly/src/main/conf/sandbox-hbaseSecurityLog-application.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.
-
-{
-  "envContextConfig": {
-    "env": "storm",
-    "mode": "cluster",
-    "topologyName": "sandbox-hbaseSecurityLog-topology",
-    "stormConfigFile": "security-auditlog-storm.yaml",
-    "parallelismConfig": {
-      "kafkaMsgConsumer": 1,
-      "hbaseSecurityLogAlertExecutor*": 1
-    }
-  },
-  "dataSourceConfig": {
-    "topic": "sandbox_hbase_security_log",
-    "zkConnection": "127.0.0.1:2181",
-    "zkConnectionTimeoutMS": 15000,
-    "brokerZkPath": "/brokers",
-    "fetchSize": 1048586,
-    "deserializerClass": "org.apache.eagle.security.hbase.HbaseAuditLogKafkaDeserializer",
-    "transactionZKServers": "127.0.0.1",
-    "transactionZKPort": 2181,
-    "transactionZKRoot": "/consumers",
-    "consumerGroupId": "eagle.hbasesecurity.consumer",
-    "transactionStateUpdateMS": 2000
-  },
-  "alertExecutorConfigs": {
-    "hbaseSecurityLogAlertExecutor": {
-      "parallelism": 1,
-      "partitioner": "org.apache.eagle.policy.DefaultPolicyPartitioner"
-      "needValidation": "true"
-    }
-  },
-  "eagleProps": {
-    "site": "sandbox",
-    "application": "hbaseSecurityLog",
-    "dataJoinPollIntervalSec": 30,
-    "mailHost": "mailHost.com",
-    "mailSmtpPort": "25",
-    "mailDebug": "true",
-    "eagleService": {
-      "host": "localhost",
-      "port": 9099
-      "username": "admin",
-      "password": "secret"
-    }
-  },
-  "dynamicConfigSource": {
-    "enabled": true,
-    "initDelayMillis": 0,
-    "delayMillis": 30000
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-hdfsAuditLog-application.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-hdfsAuditLog-application.conf b/eagle-assembly/src/main/conf/sandbox-hdfsAuditLog-application.conf
deleted file mode 100644
index be67309..0000000
--- a/eagle-assembly/src/main/conf/sandbox-hdfsAuditLog-application.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.
-
-{
-  "envContextConfig": {
-    "env": "storm",
-    "mode": "cluster",
-    "topologyName": "sandbox-hdfsAuditLog-topology",
-    "stormConfigFile": "security-auditlog-storm.yaml",
-    "parallelismConfig": {
-      "kafkaMsgConsumer": 1,
-      "hdfsAuditLogAlertExecutor*": 1
-    }
-  },
-  "dataSourceConfig": {
-    "topic": "sandbox_hdfs_audit_log",
-    "zkConnection": "127.0.0.1:2181",
-    "brokerZkPath": "/brokers",
-    "zkConnectionTimeoutMS": 15000,
-    "fetchSize": 1048586,
-    "deserializerClass": "org.apache.eagle.security.auditlog.HdfsAuditLogKafkaDeserializer",
-    "transactionZKServers": "127.0.0.1",
-    "transactionZKPort": 2181,
-    "transactionZKRoot": "/consumers",
-    "consumerGroupId": "eagle.hdfsaudit.consumer",
-    "transactionStateUpdateMS": 2000
-  },
-  "alertExecutorConfigs": {
-    "hdfsAuditLogAlertExecutor": {
-      "parallelism": 1,
-      "partitioner": "org.apache.eagle.policy.DefaultPolicyPartitioner",
-      "needValidation": "true"
-    }
-  },
-  "eagleProps": {
-    "site": "sandbox",
-    "application": "hdfsAuditLog",
-    "dataJoinPollIntervalSec": 30,
-    "mailHost": "mailHost.com",
-    "mailSmtpPort": "25",
-    "mailDebug": "true",
-    "eagleService": {
-      "host": "localhost",
-      "port": 9099
-      "username": "admin",
-      "password": "secret"
-    }
-  },
-  "dynamicConfigSource": {
-    "enabled": true,
-    "initDelayMillis": 0,
-    "delayMillis": 30000
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-hdfsSecurityLog-application.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-hdfsSecurityLog-application.conf b/eagle-assembly/src/main/conf/sandbox-hdfsSecurityLog-application.conf
deleted file mode 100644
index e68dd70..0000000
--- a/eagle-assembly/src/main/conf/sandbox-hdfsSecurityLog-application.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.
-
-{
-  "envContextConfig": {
-    "env": "storm",
-    "mode": "cluster",
-    "topologyName": "sandbox-hdfsSecurityLog-topology",
-    "stormConfigFile": "security-auditlog-storm.yaml",
-    "parallelismConfig": {
-      "kafkaMsgConsumer": 1,
-      "hdfsSecurityLogAlertExecutor*": 1
-    }
-  },
-  "dataSourceConfig": {
-    "topic": "sandbox_hdfs_security_log",
-    "zkConnection": "127.0.0.1:2181",
-    "brokerZkPath": "/brokers",
-    "zkConnectionTimeoutMS": 15000,
-    "fetchSize": 1048586,
-    "deserializerClass": "org.apache.eagle.security.securitylog.HDFSSecurityLogKafkaDeserializer",
-    "transactionZKServers": "127.0.0.1",
-    "transactionZKPort": 2181,
-    "transactionZKRoot": "/consumers",
-    "consumerGroupId": "eagle.hdfssecurity.consumer",
-    "transactionStateUpdateMS": 2000
-  },
-  "alertExecutorConfigs": {
-    "hdfsSecurityLogAlertExecutor": {
-      "parallelism": 1,
-      "partitioner": "eagle.alert.policy.DefaultPolicyPartitioner",
-      "needValidation": "true"
-    }
-  },
-  "eagleProps": {
-    "site": "sandbox",
-    "application": "hdfsSecurityLog",
-    "dataJoinPollIntervalSec": 30,
-    "mailHost": "mailHost.com",
-    "mailSmtpPort": "25",
-    "mailDebug": "true",
-    "eagleService": {
-      "host": "localhost",
-      "port": 9099
-      "username": "admin",
-      "password": "secret"
-    }
-  },
-  "dynamicConfigSource": {
-    "enabled": true,
-    "initDelayMillis": 0,
-    "delayMillis": 30000
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-hiveQueryLog-application.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-hiveQueryLog-application.conf b/eagle-assembly/src/main/conf/sandbox-hiveQueryLog-application.conf
deleted file mode 100644
index 8911e83..0000000
--- a/eagle-assembly/src/main/conf/sandbox-hiveQueryLog-application.conf
+++ /dev/null
@@ -1,63 +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.
-
-{
-  "envContextConfig": {
-    "env": "storm",
-    "mode": "cluster",
-    "topologyName": "sandbox-hiveQueryRunning-topology",
-    "stormConfigFile": "hive.storm.yaml",
-    "parallelismConfig": {
-      "msgConsumer": 2
-    }
-  },
-  "dataSourceConfig": {
-    "flavor": "stormrunning",
-    "zkQuorum": "localhost:2181",
-    "zkRoot": "/jobrunning",
-    "zkSessionTimeoutMs": 15000,
-    "zkRetryTimes": 3,
-    "zkRetryInterval": 2000,
-    "RMEndPoints": "http://localhost:8088/",
-    "HSEndPoint": "http://localhost:19888/",
-    "partitionerCls": "org.apache.eagle.job.DefaultJobPartitionerImpl"
-  },
-  "eagleProps": {
-    "site": "sandbox",
-    "application": "hiveQueryLog",
-    "mailHost": "atom.xyz.com",
-    "mailSmtpPort": "25",
-    "mailDebug": "true",
-    "eagleService": {
-      "host": "localhost",
-      "port": 9099,
-      "username": "admin",
-      "password": "secret"
-    }
-  },
-  "alertExecutorConfigs": {
-    "hiveAccessAlertByRunningJob": {
-      "parallelism": 1,
-      "partitioner": "org.apache.eagle.policy.DefaultPolicyPartitioner",
-      "needValidation": "true"
-    }
-  },
-  "dynamicConfigSource": {
-    "enabled": true,
-    "initDelayMillis": 0,
-    "delayMillis": 30000,
-    "ignoreDeleteFromSource": true
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-userprofile-scheduler.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-userprofile-scheduler.conf b/eagle-assembly/src/main/conf/sandbox-userprofile-scheduler.conf
deleted file mode 100644
index 4593a7e..0000000
--- a/eagle-assembly/src/main/conf/sandbox-userprofile-scheduler.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.
-
-# eagle configuration
-eagle {
-  # eagle site id
-  site = "sandbox"
-
-  # eagle service configuration
-  service {
-    # eagle service host, default: "localhost"
-    host = "localhost"
-    # eagle service port, default: 8080
-    port = 9099
-    username = "admin"
-    password = "secret"
-  }
-
-  # eagle userprofile configuration
-  userprofile {
-    # training audit log input path
-    training-audit-path = "file:///usr/hdp/2.3.0.0-2130/eagle/lib/userprofile/data/*.txt"
-
-    # detection audit log input path
-    detection-audit-path = "file:///usr/hdp/2.3.0.0-2130/eagle/lib/userprofile/data/validate"
-
-    # detection output kafka brokers
-    # default: localhost:9200
-    detection-kafka-brokers = "sandbox.hortonworks.com:6667"
-
-    # detection output kafka topic
-    detection-kafka-topic = "sandbox_hdfs_audit_log"
-  }
-}
-
-akka {
-  # Loggers to register at boot time (akka.event.Logging$DefaultLogger logs
-  # to STDOUT)
-  loggers = ["akka.event.slf4j.Slf4jLogger"]
-
-  # Log level used by the configured loggers (see "loggers") as soon
-  # as they have been started; before that, see "stdout-loglevel"
-  # Options: OFF, ERROR, WARNING, INFO, DEBUG
-  loglevel = "INFO"
-
-  # Log level for the very basic logger activated during ActorSystem startup.
-  # This logger prints the log messages to stdout (System.out).
-  # Options: OFF, ERROR, WARNING, INFO, DEBUG
-  stdout-loglevel = "INFO"
-
-  # Filter of log events that is used by the LoggingAdapter before
-  # publishing log events to the eventStream.
-  logging-filter = "akka.event.slf4j.Slf4jLoggingFilter"
-}

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/sandbox-userprofile-topology.conf
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/sandbox-userprofile-topology.conf b/eagle-assembly/src/main/conf/sandbox-userprofile-topology.conf
deleted file mode 100644
index a5f5983..0000000
--- a/eagle-assembly/src/main/conf/sandbox-userprofile-topology.conf
+++ /dev/null
@@ -1,64 +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.
-
-{
-  "deployInstanceIdentifier": {
-    "programId": "mlProgramId"
-  },
-  "envContextConfig": {
-    "env": "storm",
-    "topologyName": "sandbox-userprofile-topology",
-    "mode": "cluster",
-    "parallelismConfig": {
-      "kafkaMsgConsumer": 1,
-      "userProfileAnomalyDetectionExecutor*": 1
-    },
-    "stormConfigFile": "userprofile.storm.yaml"
-  },
-  "dataSourceConfig": {
-    "topic": "sandbox_hdfs_audit_log",
-    "zkConnection": "localhost:2181",
-    "zkConnectionTimeoutMS": 15000,
-    "consumerGroupId": "eagle.userprofile.consumer",
-    "fetchSize": 1048586,
-    "deserializerClass": "org.apache.eagle.security.auditlog.HdfsAuditLogKafkaDeserializer",
-    "transactionZKServers": "localhost",
-    "transactionZKPort": 2181,
-    "transactionZKRoot": "/brokers/topics",
-    "transactionStateUpdateMS": 2000
-  },
-  "eagleProps": {
-    "site": "sandbox",
-    "application": "userProfile",
-    "eagleService": {
-      "host": "localhost",
-      "port": "9099",
-      "username": "admin",
-      "password": "secret"
-    }
-  },
-  "alertExecutorConfigs": {
-    "userProfileAnomalyDetectionExecutor": {
-      "parallelism": 1,
-      "partitioner": "org.apache.eagle.policy.DefaultPolicyPartitioner",
-      "needValidation": true
-    }
-  },
-  "dynamicConfigSource": {
-    "enabled": true,
-    "initDelayMillis": 0,
-    "delayMillis": 5000
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/tools-log4j.properties
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/tools-log4j.properties b/eagle-assembly/src/main/conf/tools-log4j.properties
deleted file mode 100644
index 9c6875d..0000000
--- a/eagle-assembly/src/main/conf/tools-log4j.properties
+++ /dev/null
@@ -1,19 +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=INFO, 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
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/eagle/blob/8b3729f9/eagle-assembly/src/main/conf/zookeeper-server.properties
----------------------------------------------------------------------
diff --git a/eagle-assembly/src/main/conf/zookeeper-server.properties b/eagle-assembly/src/main/conf/zookeeper-server.properties
deleted file mode 100644
index c27b558..0000000
--- a/eagle-assembly/src/main/conf/zookeeper-server.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.
-# the directory where the snapshot is stored.
-dataDir=/tmp/eagle-zookeeper-data
-# the port at which the clients will connect
-clientPort=2181
-# disable the per-ip limit on the number of connections since this is a non-production config
-maxClientCnxns=0
\ No newline at end of file