You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@metron.apache.org by rm...@apache.org on 2016/04/26 16:46:35 UTC

[47/51] [partial] incubator-metron git commit: METRON-113 Project Reorganization (merrimanr) closes apache/incubator-metron#88

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/mysql_server/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/mysql_server/tasks/main.yml b/deployment/roles/mysql_server/tasks/main.yml
deleted file mode 100644
index a484ed0..0000000
--- a/deployment/roles/mysql_server/tasks/main.yml
+++ /dev/null
@@ -1,93 +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.
-#
----
-- name: Create temporary directories
-  file:
-    path: "/tmp/geoip"
-    state: directory
-    mode: 0755
-
-- name: Install Mysql Community Release Repo Def
-  get_url:
-    dest: /tmp/{{ mysql_rpm_version }}.rpm
-    url: "{{ mysql_yum_repo_url }}"
-
-- name: Install Mysql Community Release Repo
-  yum:
-    pkg: /tmp/{{ mysql_rpm_version }}.rpm
-    state: installed
-  register: result
-  until: result.rc == 0
-  retries: 5
-  delay: 10
-
-- name: Install MySQL
-  yum:
-    name: "{{ item }}"
-    state: latest
-  with_items:
-    - "mysql-community-server"
-    - "MySQL-python"
-  register: result
-  until: result.rc == 0
-  retries: 5
-  delay: 10
-
-- name: Start MySQL
-  service:
-    name: mysqld
-    state: started
-    enabled: yes
-
-- name: Retrieve temporary root password
-  shell: "grep 'temporary password' /var/log/mysqld.log | sed 's/.*root@localhost: //'"
-  args:
-    creates: ~/.my.cnf
-  register: temp_root_password
-
-- name: Update mysql root password
-  command: "mysqladmin --user=root --password='{{ temp_root_password.stdout }}' password '{{ mysql_root_password }}'"
-  ignore_errors: yes
-  args:
-    creates: ~/.my.cnf
-
-- name: Create .my.cnf
-  template:
-    src: "../roles/mysql_server/templates/.my.cnf"
-    dest: ~/.my.cnf
-
-
-- name: Download GeoIP databases
-  unarchive:
-    src:  http://geolite.maxmind.com/download/geoip/database/GeoLiteCity_CSV/GeoLiteCity-latest.tar.xz
-    dest: /tmp/geoip
-    copy: no
-    creates: /tmp/geopip/*/GeoLiteCity-Blocks.csv
-
-- name: Copy to MySQL import directory
-  shell: "cp /tmp/geoip/*/*.csv /var/lib/mysql-files/"
-
-- name: Copy DDL
-  copy:
-    src: geoip_ddl.sql
-    dest: /tmp/geoip_ddl.sql
-
-- name: Import GeoIP DDL
-  mysql_db:
-    name: all
-    state: import
-    target: /tmp/geoip_ddl.sql

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/mysql_server/templates/.my.cnf
----------------------------------------------------------------------
diff --git a/deployment/roles/mysql_server/templates/.my.cnf b/deployment/roles/mysql_server/templates/.my.cnf
deleted file mode 100644
index d5c0825..0000000
--- a/deployment/roles/mysql_server/templates/.my.cnf
+++ /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.
-#
-[client]
-user=root
-password={{ mysql_root_password }}
-host=localhost
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/ntp/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/ntp/tasks/main.yml b/deployment/roles/ntp/tasks/main.yml
deleted file mode 100644
index 7b1b9a8..0000000
--- a/deployment/roles/ntp/tasks/main.yml
+++ /dev/null
@@ -1,31 +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.
-#
----
-- name: Install ntp
-  yum:
-    name: ntp
-    state: present
-  register: result
-  until: result.rc == 0
-  retries: 5
-  delay: 10
-
-- name: Ensure ntp is running and enabled
-  service:
-    name: ntpd
-    state: started
-    enabled: yes

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/defaults/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/defaults/main.yml b/deployment/roles/packet-capture/defaults/main.yml
deleted file mode 100644
index 3e6358c..0000000
--- a/deployment/roles/packet-capture/defaults/main.yml
+++ /dev/null
@@ -1,32 +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.
-#
----
-# dpdk
-dpdk_home: "/usr/local/dpdk"
-dpdk_version: "2.2.0"
-dpdk_sdk: "/root/dpdk-{{ dpdk_version }}"
-dpdk_target: "x86_64-native-linuxapp-gcc"
-num_huge_pages: 512
-extra_cflags: -g
-
-# pcapture
-pcapture_work_dir: /root/packet-capture
-pcapture_prefix: /usr/local/bin
-pcapture_ld_library_path: /usr/local/lib
-pcapture_portmask: 0x01
-pcapture_kafka_config: /etc/pcapture.conf
-pcapture_bin: pcapture

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/meta/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/meta/main.yml b/deployment/roles/packet-capture/meta/main.yml
deleted file mode 100644
index d253e88..0000000
--- a/deployment/roles/packet-capture/meta/main.yml
+++ /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.
-#
----
-dependencies:
-  - librdkafka

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/tasks/debug.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/tasks/debug.yml b/deployment/roles/packet-capture/tasks/debug.yml
deleted file mode 100644
index 06f1526..0000000
--- a/deployment/roles/packet-capture/tasks/debug.yml
+++ /dev/null
@@ -1,26 +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.
-#
----
-  - name: Install debug utilities
-    yum: name=yum-utils
-    tags:
-      - debug
-
-  - name: Install debug symbols
-    shell: debuginfo-install -y glibc glib2 zlib
-    tags:
-      - debug

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/tasks/dependencies.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/tasks/dependencies.yml b/deployment/roles/packet-capture/tasks/dependencies.yml
deleted file mode 100644
index 4d6edc4..0000000
--- a/deployment/roles/packet-capture/tasks/dependencies.yml
+++ /dev/null
@@ -1,38 +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.
-#
----
-  - name: Install dependencies
-    yum: name={{ item }}
-    with_items:
-      - "@Development tools"
-      - pciutils
-      - net-tools
-      - glib2
-      - glib2-devel
-      - git
-
-  #
-  # install prerequisite packages and the latest kernel headers.  need to
-  # ensure that the kernel headers match the current running kernel version.
-  # if this is not the case, the DPDK build process will fail
-  #
-  - name: Install latest kernel headers and source
-    yum: name={{ item }} state=latest
-    with_items:
-      - kernel
-      - kernel-devel
-      - kernel-headers

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/tasks/dpdk.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/tasks/dpdk.yml b/deployment/roles/packet-capture/tasks/dpdk.yml
deleted file mode 100644
index 3780be7..0000000
--- a/deployment/roles/packet-capture/tasks/dpdk.yml
+++ /dev/null
@@ -1,59 +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.
-#
----
-  - name: "Download DPDK version {{ dpdk_version }}"
-    unarchive:
-      src: "http://dpdk.org/browse/dpdk/snapshot/dpdk-{{ dpdk_version }}.tar.gz"
-      dest: "/root"
-      creates: "{{ dpdk_sdk }}"
-      copy: no
-
-  - name: "Configure DPDK for the target environment: {{ dpdk_target }}"
-    shell: "make config T={{ dpdk_target }} DESTDIR={{ dpdk_home }}"
-    args:
-      chdir: "{{ dpdk_sdk }}"
-      creates: "{{ dpdk_home }}"
-
-  - name: "Turn on debug flags"
-    lineinfile:
-      dest: "{{ dpdk_sdk }}/config/common_linuxapp"
-      regexp: 'DEBUG=n'
-      line: 'DEBUG=y'
-    tags:
-      - debug
-
-  - name: "Build DPDK for the target environment: {{ dpdk_target }}"
-    shell: "make install T={{ dpdk_target }} DESTDIR={{ dpdk_home }} EXTRA_CFLAGS={{ extra_cflags }}"
-    args:
-      chdir: "{{ dpdk_sdk }}"
-      creates: "{{ dpdk_home }}"
-
-  - name: Load kernel modules to enable userspace IO
-    shell: "{{ item }}"
-    with_items:
-      - modprobe uio_pci_generic
-      - modprobe vfio-pci
-
-  - name: Bind the device to the loaded kernel module(s)
-    shell: "{{ dpdk_home }}/sbin/dpdk_nic_bind --force --bind=uio_pci_generic {{ item }}"
-    with_items: "{{ dpdk_device }}"
-
-  - name: Set useful environment variables
-    lineinfile: "dest=/root/.bash_profile line={{ item }}"
-    with_items:
-      - "export RTE_SDK={{ dpdk_sdk }}"
-      - "export RTE_TARGET={{ dpdk_target }}"

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/tasks/kernel.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/tasks/kernel.yml b/deployment/roles/packet-capture/tasks/kernel.yml
deleted file mode 100644
index cd4abe6..0000000
--- a/deployment/roles/packet-capture/tasks/kernel.yml
+++ /dev/null
@@ -1,51 +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.
-#
-#
-# DPDK requires specific kernel boot parameters.  set the params and reboot
-# the host, if the actual params differ from what is expected.
-#
----
-  - set_fact:
-      expected_kernel_params: "default_hugepagesz=1G hugepagesz=1G hugepages={{ num_huge_pages }} iommu=pt intel_iommu=on"
-
-  - name: Check kernel boot parameters
-    shell: "cat /proc/cmdline"
-    register: actual_kernel_params
-
-  - name: Alter kernel boot parameters
-    lineinfile:
-      dest: /etc/default/grub
-      regexp:  '^(GRUB_CMDLINE_LINUX=\"[^\"]+)\"$'
-      line: '\1 {{ expected_kernel_params }}"'
-      backrefs: yes
-    when: not expected_kernel_params in actual_kernel_params.stdout
-
-  - name: Update grub with kernel boot parameters
-    shell: /sbin/grub2-mkconfig -o /boot/grub2/grub.cfg
-    when: not expected_kernel_params in actual_kernel_params.stdout
-
-  - name: Restart for modified kernel params
-    command: shutdown -r now "modified kernel params"
-    async: 0
-    poll: 0
-    ignore_errors: true
-    when: not expected_kernel_params in actual_kernel_params.stdout
-    
-  - name: Wait for reboot of '{{ inventory_hostname }}'
-    local_action: wait_for host={{ inventory_hostname }} state=started port=22 timeout=300 delay=10
-    become: false
-    when: not expected_kernel_params in actual_kernel_params.stdout

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/tasks/main.yml b/deployment/roles/packet-capture/tasks/main.yml
deleted file mode 100644
index f096178..0000000
--- a/deployment/roles/packet-capture/tasks/main.yml
+++ /dev/null
@@ -1,22 +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.
-#
----
-  - include: dependencies.yml
-  - include: kernel.yml
-  - include: dpdk.yml
-  - include: pcapture.yml
-  - include: debug.yml

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/tasks/pcapture.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/tasks/pcapture.yml b/deployment/roles/packet-capture/tasks/pcapture.yml
deleted file mode 100644
index d00d379..0000000
--- a/deployment/roles/packet-capture/tasks/pcapture.yml
+++ /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.
-#
----
-- name: Distribute pcapture
-  copy: src=../../../metron-sensors/packet-capture dest={{ pcapture_work_dir | dirname }} mode=0755
-
-- name: Build pcapture
-  shell: "{{ item }}"
-  args:
-    chdir: "{{ pcapture_work_dir }}"
-  with_items:
-    - make
-  environment:
-    RTE_SDK: "{{ dpdk_sdk }}"
-    RTE_TARGET: "{{ dpdk_target }}"
-    LD_LIBRARY_PATH: "{{ pcapture_ld_library_path }}"
-
-- name: Install pcapture
-  shell: "cp {{ pcapture_work_dir }}/src/build/app/{{ pcapture_bin }} {{ pcapture_prefix }}"
-  args:
-    chdir: "{{ pcapture_work_dir }}"
-    creates: "{{ pcapture_prefix }}/{{ pcapture_bin }}"
-
-- name: Deploy configuration
-  template: src=pcapture.conf dest={{ pcapture_kafka_config }} mode=0755
-
-- name: Deploy service
-  template: src=pcapture dest=/etc/init.d/ mode=0755
-
-- name: Register the service with systemd
-  shell: systemctl enable pcapture
-  when: ansible_distribution == "CentOS" and ansible_distribution_major_version == "7"
-
-- name: Run pcapture
-  service: name=pcapture state=restarted

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/templates/pcapture
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/templates/pcapture b/deployment/roles/packet-capture/templates/pcapture
deleted file mode 100644
index 8c2221a..0000000
--- a/deployment/roles/packet-capture/templates/pcapture
+++ /dev/null
@@ -1,93 +0,0 @@
-#!/usr/bin/env 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.
-#
-# pcapture daemon
-# chkconfig: 345 20 80
-# description: Packet capture probe
-# processname: pcapture
-#
-
-export RTE_SDK="{{ dpdk_sdk }}"
-export RTE_TARGET="{{ dpdk_target }}"
-export LD_LIBRARY_PATH="{{ pcapture_ld_library_path }}"
-
-DAEMON_PATH="{{ dpdk_sdk }}"
-DAEMON="{{ pcapture_prefix }}/{{ pcapture_bin }}"
-DAEMONOPTS+=" -- "
-DAEMONOPTS+="-p {{ pcapture_portmask }} "
-DAEMONOPTS+="-t {{ pcapture_topic }} "
-DAEMONOPTS+="-c {{ pcapture_kafka_config }} "
-
-NAME="pcapture"
-DESC="Metron network packet capture probe"
-PIDFILE=/var/run/$NAME.pid
-SCRIPTNAME=/etc/init.d/$NAME
-DAEMONLOG=/var/log/$NAME.log
-NOW=`date`
-
-case "$1" in
-  start)
-    printf "%-50s" "Starting $NAME..."
-    echo "$NOW:  Starting $NAME..." >> $DAEMONLOG
-    cd $DAEMON_PATH
-    PID=`$DAEMON $DAEMONOPTS >> $DAEMONLOG 2>&1 & echo $!`
-    if [ -z $PID ]; then
-        printf "%s\n" "Fail"
-    else
-        echo $PID > $PIDFILE
-        printf "%s\n" "Ok"
-    fi
-  ;;
-
-  status)
-    printf "%-50s" "Checking $NAME..."
-    if [ -f $PIDFILE ]; then
-      PID=`cat $PIDFILE`
-      if [ -z "`ps axf | grep ${PID} | grep -v grep`" ]; then
-        printf "%s\n" "Process dead but pidfile exists"
-      else
-        echo "Running"
-      fi
-    else
-      printf "%s\n" "Service not running"
-    fi
-  ;;
-
-  stop)
-    printf "%-50s" "Stopping $NAME"
-    PID=`cat $PIDFILE`
-    cd $DAEMON_PATH
-    if [ -f $PIDFILE ]; then
-        echo "$NOW:  Stopping $NAME with pid=$PID" >> $DAEMONLOG
-        kill -HUP $PID
-        printf "%s\n" "Ok"
-        rm -f $PIDFILE
-    else
-        printf "%s\n" "pidfile not found"
-    fi
-  ;;
-
-  restart)
-    $0 stop
-    $0 start
-  ;;
-
-  *)
-    echo "Usage: $0 {status|start|stop|restart}"
-    exit 1
-esac

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/packet-capture/templates/pcapture.conf
----------------------------------------------------------------------
diff --git a/deployment/roles/packet-capture/templates/pcapture.conf b/deployment/roles/packet-capture/templates/pcapture.conf
deleted file mode 100644
index e404476..0000000
--- a/deployment/roles/packet-capture/templates/pcapture.conf
+++ /dev/null
@@ -1,67 +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.
-#
-
-#
-# kafka global settings
-#
-[kafka-global]
-
-# initial list of kafka brokers
-metadata.broker.list = {{ kafka_broker_url }}
-
-# identifies the client to kafka
-client.id = metron-packet-capture
-
-# max number of messages allowed on the producer queue
-queue.buffering.max.messages = 1000
-
-# maximum time, in milliseconds, for buffering data on the producer queue
-queue.buffering.max.ms = 3000
-
-# compression codec = none, gzip or snappy
-compression.codec = snappy
-
-# maximum number of messages batched in one MessageSet (increase for better compression)
-batch.num.messages = 10
-
-# max times to retry sending a failed message set
-message.send.max.retries = 5
-
-# backoff time before retrying a message send
-retry.backoff.ms = 250
-
-# how often statistics are emitted; 0 = never
-statistics.interval.ms = 0
-
-# only provide delivery reports for failed messages
-delivery.report.only.error = false
-
-#
-# kafka topic settings
-#
-[kafka-topic]
-
-# broker acks { 1 = leader ack, 0 = no acks, -1 = in sync replica ack }
-request.required.acks = 1
-
-# local message timeout. This value is only enforced locally and limits the time a
-# produced message waits for successful delivery. A time of 0 is infinite.
-message.timeout.ms = 10000
-
-# report offset of produced message back to application. The application must be
-# use the dr_msg_cb to retrieve the offset from rd_kafka_message_t.offset
-produce.offset.report = false

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/README.md
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/README.md b/deployment/roles/pcap_replay/README.md
deleted file mode 100644
index 8bc92c9..0000000
--- a/deployment/roles/pcap_replay/README.md
+++ /dev/null
@@ -1,44 +0,0 @@
-Pcap Replay
-===========
-
-This project enables packet capture data to be replayed through a network interface to simulate live network traffic.  This can be used to support functional, performance, and load testing of Apache Metron.
-
-Getting Started
----------------
-
-To replay packet capture data, simply start the `pcap-replay` SysV service.  To do this run the following command.
-
-```
-service pcap-replay start
-```
-
-All additional options accepted by `tcpreplay` can be passed to the service script to modify how the network data is replayed.  For example, this makes it simple to control the amount and rate of data replayed during functional, performance and load testing.
-
-Example: Replay data at a rate of 10 mbps.
-
-```
-service pcap-replay start --mbps 10
-```
-
-Example: Replay data at a rate of 10 packets per second.
-
-```
-service pcap-replay start --pps 10
-```
-
-All nodes on the same subnet with their network interface set to promiscuous mode will then be able to capture the network traffic being replayed.  To validate, simply run something like the following.
-
-```
-tcpdump -i eth1
-```
-
-Data
-----
-
-An example packet capture file has been installed at `/opt/pcap-replay/example.pcap`.  By default, the network traffic contained within this file is continually replayed.   
-
-To replay your own packet capture data, simply add any number of files containing `libpcap` formatted packet capture data to `/opt/pcap-replay`.  The files must end with the `.pcap` extension.  To pick up newly installed files, simply restart the service.
-
-```
-service pcap-replay restart
-```

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/defaults/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/defaults/main.yml b/deployment/roles/pcap_replay/defaults/main.yml
deleted file mode 100644
index b1fae1e..0000000
--- a/deployment/roles/pcap_replay/defaults/main.yml
+++ /dev/null
@@ -1,21 +0,0 @@
-#
-#  Licensed to the Apache Software Foundation (ASF) under one or more
-#  contributor license agreements.  See the NOTICE file distributed with
-#  this work for additional information regarding copyright ownership.
-#  The ASF licenses this file to You under the Apache License, Version 2.0
-#  (the "License"); you may not use this file except in compliance with
-#  the License.  You may obtain a copy of the License at
-#
-#      http://www.apache.org/licenses/LICENSE-2.0
-#
-#  Unless required by applicable law or agreed to in writing, software
-#  distributed under the License is distributed on an "AS IS" BASIS,
-#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-#
----
-pcap_replay_interface: eth0
-pcap_path: /opt/pcap-replay
-tcpreplay_version: 4.1.1
-tcpreplay_prefix: /opt

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/meta/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/meta/main.yml b/deployment/roles/pcap_replay/meta/main.yml
deleted file mode 100644
index 0c47853..0000000
--- a/deployment/roles/pcap_replay/meta/main.yml
+++ /dev/null
@@ -1,21 +0,0 @@
-#
-#  Licensed to the Apache Software Foundation (ASF) under one or more
-#  contributor license agreements.  See the NOTICE file distributed with
-#  this work for additional information regarding copyright ownership.
-#  The ASF licenses this file to You under the Apache License, Version 2.0
-#  (the "License"); you may not use this file except in compliance with
-#  the License.  You may obtain a copy of the License at
-#
-#      http://www.apache.org/licenses/LICENSE-2.0
-#
-#  Unless required by applicable law or agreed to in writing, software
-#  distributed under the License is distributed on an "AS IS" BASIS,
-#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-#
----
-dependencies:
-  - libselinux-python
-  - build-tools
-

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/tasks/main.yml b/deployment/roles/pcap_replay/tasks/main.yml
deleted file mode 100644
index 06919ed..0000000
--- a/deployment/roles/pcap_replay/tasks/main.yml
+++ /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.
-#
----
-- include: tcpreplay.yml
-- include: service.yml

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/tasks/service.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/tasks/service.yml b/deployment/roles/pcap_replay/tasks/service.yml
deleted file mode 100644
index 9e13e7f..0000000
--- a/deployment/roles/pcap_replay/tasks/service.yml
+++ /dev/null
@@ -1,22 +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.
-#
----
-- name: Create pcap directory
-  file: path={{ pcap_path }} state=directory mode=0755
-
-- name: Install init.d service script
-  template: src=pcap-replay dest=/etc/init.d/pcap-replay mode=0755

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/tasks/tcpreplay.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/tasks/tcpreplay.yml b/deployment/roles/pcap_replay/tasks/tcpreplay.yml
deleted file mode 100644
index e24dcf1..0000000
--- a/deployment/roles/pcap_replay/tasks/tcpreplay.yml
+++ /dev/null
@@ -1,38 +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.
-#
----
-- name: Download tcpreplay
-  get_url:
-    url: "https://github.com/appneta/tcpreplay/releases/download/v{{ tcpreplay_version }}/tcpreplay-{{ tcpreplay_version }}.tar.gz"
-    dest: "/tmp/tcpreplay-{{ tcpreplay_version }}.tar.gz"
-
-- name: Extract tcpreplay tarball
-  unarchive:
-    src: "/tmp/tcpreplay-{{ tcpreplay_version }}.tar.gz"
-    dest: /opt
-    copy: no
-    creates: "/opt/tcpreplay-{{ tcpreplay_version }}"
-
-- name: Compile and install tcpreplay
-  shell: "{{ item }}"
-  args:
-    chdir: "/opt/tcpreplay-{{ tcpreplay_version }}"
-    creates: "{{ tcpreplay_prefix }}/bin/tcpreplay"
-  with_items:
-    - "./configure --prefix={{ tcpreplay_prefix }}"
-    - make
-    - make install

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pcap_replay/templates/pcap-replay
----------------------------------------------------------------------
diff --git a/deployment/roles/pcap_replay/templates/pcap-replay b/deployment/roles/pcap_replay/templates/pcap-replay
deleted file mode 100644
index b9ae0c3..0000000
--- a/deployment/roles/pcap_replay/templates/pcap-replay
+++ /dev/null
@@ -1,92 +0,0 @@
-#!/usr/bin/env 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.
-#
-# pcap replay daemon
-# chkconfig: 345 20 80
-# description: Replays packet capture data stored in libpcap format
-# processname: pcap-replay
-#
-
-DAEMON_PATH="{{ pcap_path }}"
-PCAPIN=`ls $DAEMON_PATH/*.pcap 2> /dev/null`
-IFACE="{{ pcap_replay_interface }}"
-EXTRA_ARGS="${@:2}"
-DAEMON="{{ tcpreplay_prefix }}/bin/tcpreplay"
-DAEMONOPTS="--intf1=$IFACE --loop=0 $EXTRA_ARGS $PCAPIN"
-
-NAME=pcap-replay
-DESC="Replay packet capture data"
-PIDFILE=/var/run/$NAME.pid
-SCRIPTNAME=/etc/init.d/$NAME
-
-case "$1" in
-  start)
-    printf "%-50s" "Starting $NAME..."
-
-    # ensure that a pcap file exists to replay
-    if [ -z "$PCAPIN" ]; then
-      printf "%s: %s\n" "Fail: No pcap files found at " $DAEMON_PATH
-    else
-      # kick-off the daemon
-      cd $DAEMON_PATH
-      PID=`$DAEMON $DAEMONOPTS > /dev/null 2>&1 & echo $!`
-      if [ -z $PID ]; then
-          printf "%s\n" "Fail"
-      else
-          echo $PID > $PIDFILE
-          printf "%s\n" "Ok"
-      fi
-    fi
-  ;;
-
-  status)
-    printf "%-50s" "Checking $NAME..."
-    if [ -f $PIDFILE ]; then
-      PID=`cat $PIDFILE`
-      if [ -z "`ps axf | grep ${PID} | grep -v grep`" ]; then
-        printf "%s\n" "Process dead but pidfile exists"
-      else
-        echo "Running"
-      fi
-    else
-      printf "%s\n" "Service not running"
-    fi
-  ;;
-
-  stop)
-    printf "%-50s" "Stopping $NAME"
-    PID=`cat $PIDFILE`
-    cd $DAEMON_PATH
-    if [ -f $PIDFILE ]; then
-        kill -HUP $PID
-        printf "%s\n" "Ok"
-        rm -f $PIDFILE
-    else
-        printf "%s\n" "pidfile not found"
-    fi
-  ;;
-
-  restart)
-    $0 stop
-    $0 start
-  ;;
-
-  *)
-    echo "Usage: $0 {status|start|stop|restart}"
-    exit 1
-esac

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pycapa/meta/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pycapa/meta/main.yml b/deployment/roles/pycapa/meta/main.yml
deleted file mode 100644
index 3aaa18d..0000000
--- a/deployment/roles/pycapa/meta/main.yml
+++ /dev/null
@@ -1,22 +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.
-#
----
-dependencies:
-  - ambari_gather_facts
-  - epel
-  - python-pip
-  - kafka-client

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pycapa/tasks/dependencies.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pycapa/tasks/dependencies.yml b/deployment/roles/pycapa/tasks/dependencies.yml
deleted file mode 100644
index 19efdcd..0000000
--- a/deployment/roles/pycapa/tasks/dependencies.yml
+++ /dev/null
@@ -1,34 +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.
-#
----
-- name: Install epel-release repository
-  yum: name=epel-release
-
-- name: Install python and tcpdump
-  yum:
-    name: "{{item}}"
-  with_items:
-    - python
-    - tcpdump
-    - git
-  register: result
-  until: result.rc == 0
-  retries: 5
-  delay: 10
-
-- name: Install pip
-  easy_install: name=pip

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pycapa/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pycapa/tasks/main.yml b/deployment/roles/pycapa/tasks/main.yml
deleted file mode 100644
index 76bdc1c..0000000
--- a/deployment/roles/pycapa/tasks/main.yml
+++ /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.
-#
----
-- include: dependencies.yml
-- include: pycapa.yml

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pycapa/tasks/pycapa.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pycapa/tasks/pycapa.yml b/deployment/roles/pycapa/tasks/pycapa.yml
deleted file mode 100644
index 4d1a64e..0000000
--- a/deployment/roles/pycapa/tasks/pycapa.yml
+++ /dev/null
@@ -1,37 +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.
-#
----
-- name: Clone pycapa repo
-  git: repo={{ pycapa_repo }} dest={{ pycapa_home }}
-
-- name: Build pycapa
-  shell: "{{ item }}"
-  args:
-    chdir: "{{ pycapa_home }}"
-  with_items:
-    - pip install -r requirements.txt
-    - pip install argparse
-    - python setup.py install
-
-- name: Turn on promiscuous mode for {{ pycapa_sniff_interface }}
-  shell: "ip link set {{ pycapa_sniff_interface }} promisc on"
-
-- name: Install service script
-  template: src=pycapa dest=/etc/init.d/pycapa mode=0755
-
-- name: Start pycapa
-  service: name=pycapa state=restarted

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pycapa/templates/pycapa
----------------------------------------------------------------------
diff --git a/deployment/roles/pycapa/templates/pycapa b/deployment/roles/pycapa/templates/pycapa
deleted file mode 100644
index fffa13f..0000000
--- a/deployment/roles/pycapa/templates/pycapa
+++ /dev/null
@@ -1,84 +0,0 @@
-#!/usr/bin/env 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.
-#
-# metron pycapa service
-# chkconfig: 345 20 80
-# description: Metron Pycapa Packet Capture Daemon
-# processname: pycapa
-#
-NAME=pycapa
-DESC="Metron Pycapa Packet Capture"
-PIDFILE=/var/run/$NAME.pid
-SCRIPTNAME=/etc/init.d/$NAME
-LOGFILE="{{ pycapa_log }}"
-EXTRA_ARGS="${@:2}"
-DAEMON_PATH="{{ pycapa_home }}"
-DAEMON="/usr/bin/python"
-DAEMONOPTS="{{ pycapa_main }} -z {{ zookeeper_url }} -t {{ pycapa_topic }} -i {{ pycapa_sniff_interface }}"
-
-case "$1" in
-  start)
-    printf "%-50s" "Starting $NAME..."
-
-    # kick-off the daemon
-    cd $DAEMON_PATH
-    PID=`$DAEMON $DAEMONOPTS >> $LOGFILE 2>&1 & echo $!`
-    if [ -z $PID ]; then
-        printf "%s\n" "Fail"
-    else
-        echo $PID > $PIDFILE
-        printf "%s\n" "Ok"
-    fi
-  ;;
-
-  status)
-    printf "%-50s" "Checking $NAME..."
-    if [ -f $PIDFILE ]; then
-      PID=`cat $PIDFILE`
-      if [ -z "`ps axf | grep ${PID} | grep -v grep`" ]; then
-        printf "%s\n" "Process dead but pidfile exists"
-      else
-        echo "Running"
-      fi
-    else
-      printf "%s\n" "Service not running"
-    fi
-  ;;
-
-  stop)
-    printf "%-50s" "Stopping $NAME"
-    PID=`cat $PIDFILE`
-    cd $DAEMON_PATH
-    if [ -f $PIDFILE ]; then
-        kill -HUP $PID
-        printf "%s\n" "Ok"
-        rm -f $PIDFILE
-    else
-        printf "%s\n" "pidfile not found"
-    fi
-  ;;
-
-  restart)
-    $0 stop
-    $0 start
-  ;;
-
-  *)
-    echo "Usage: $0 {status|start|stop|restart}"
-    exit 1
-esac

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/pycapa/vars/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/pycapa/vars/main.yml b/deployment/roles/pycapa/vars/main.yml
deleted file mode 100644
index 5618a8e..0000000
--- a/deployment/roles/pycapa/vars/main.yml
+++ /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.
-#
----
-pycapa_repo: https://github.com/OpenSOC/pycapa.git
-pycapa_home: /usr/local/pycapa
-pycapa_main: "{{ pycapa_home }}/pycapa/pycapa_cli.py"
-pycapa_log: /var/log/pycapa.log
-pycapa_topic: pcap
-pycapa_sniff_interface: "{{ sniff_interface }}"

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/python-pip/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/python-pip/tasks/main.yml b/deployment/roles/python-pip/tasks/main.yml
deleted file mode 100644
index 809aca4..0000000
--- a/deployment/roles/python-pip/tasks/main.yml
+++ /dev/null
@@ -1,25 +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.
-#
----
-- name: Install python-pip
-  yum:
-    name: python-pip
-    state: installed
-  register: result
-  until: result.rc == 0
-  retries: 5
-  delay: 10

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/sensor-test-mode/README.md
----------------------------------------------------------------------
diff --git a/deployment/roles/sensor-test-mode/README.md b/deployment/roles/sensor-test-mode/README.md
deleted file mode 100644
index 76a3220..0000000
--- a/deployment/roles/sensor-test-mode/README.md
+++ /dev/null
@@ -1,27 +0,0 @@
-Sensor Test Mode
-================
-
-A role that configures each of the sensors to produce the maximum amount of telemetry data.  This role is useful only for testing.  It can be useful to support functional, performance, and load testing of Apache Metron.
-
-The role does the following to maximize the amount of telemetry data produced by each Metron sensor.
-
-- Plays a packet capture file through a network interface to simulate live network traffic.
-- Configures [YAF](https://tools.netsa.cert.org/yaf/yaf.html) with `idle-timeout=0`.  This causes a flow record to be produced for every network packet received.
-- Configures [Snort](https://www.snort.org/) to produce an alert for every network packet received.
-
-Getting Started
----------------
-
-To enable the `sensor-test-mode` role apply the role to the `sensors` host group in your Ansible playbook.
-
-```
-- hosts: sensors
-  roles:
-    - role: sensor-test-mode
-```
-
-The role has also been added to the default `metron_install.yml` playbook so that it can be turned on/off with a property in both the local Virtualbox and the remote EC2 deployments.
-
-```
-sensor_test_mode: True
-```

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/sensor-test-mode/files/example.pcap
----------------------------------------------------------------------
diff --git a/deployment/roles/sensor-test-mode/files/example.pcap b/deployment/roles/sensor-test-mode/files/example.pcap
deleted file mode 100644
index 06594ec..0000000
Binary files a/deployment/roles/sensor-test-mode/files/example.pcap and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/sensor-test-mode/meta/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/sensor-test-mode/meta/main.yml b/deployment/roles/sensor-test-mode/meta/main.yml
deleted file mode 100644
index 0e9e5b3..0000000
--- a/deployment/roles/sensor-test-mode/meta/main.yml
+++ /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.
-#
----
-dependencies:
-  - pcap_replay

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/sensor-test-mode/tasks/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/sensor-test-mode/tasks/main.yml b/deployment/roles/sensor-test-mode/tasks/main.yml
deleted file mode 100644
index 26b4e2a..0000000
--- a/deployment/roles/sensor-test-mode/tasks/main.yml
+++ /dev/null
@@ -1,56 +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.
-#
----
-#
-# load example pcap data to replay
-#
-- name: Install example pcap file
-  copy: src=example.pcap dest={{ pcap_path }}/
-
-- name: Start the pcap-replay service
-  service: name=pcap-replay state=restarted
-
-#
-# configure yaf to generate a flow record for every packet
-#
-- name: Stop running instances of yaf
-  become: True
-  service: name=yaf state=stopped
-
-- name: Configure yaf to generate a flow record for every network packet
-  become: True
-  service: name=yaf state=started args="--idle-timeout 0"
-
-#
-# configure snort to alert on every packet
-#
-- name: Configure snort to use a set of test rules
-  become: True
-  lineinfile:
-    dest: /etc/snort/snort.conf
-    line: "include $RULE_PATH/test.rules"
-
-- name: Create a snort alert for testing that alerts on every packet
-  become: True
-  lineinfile:
-    dest: /etc/snort/rules/test.rules
-    line: "alert tcp any any -> any any (msg:'snort test alert'; sid:999158; )"
-    create: yes
-
-- name: Restart snort
-  become: True
-  service: name=snortd state=restarted

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/snort/defaults/main.yml
----------------------------------------------------------------------
diff --git a/deployment/roles/snort/defaults/main.yml b/deployment/roles/snort/defaults/main.yml
deleted file mode 100644
index 6c6c0ea..0000000
--- a/deployment/roles/snort/defaults/main.yml
+++ /dev/null
@@ -1,25 +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.
-#
----
-snort_version: 2.9.8.0-1
-daq_version: 2.0.6-1
-snort_topic: snort
-snort_alert_csv_path: /var/log/snort/alert.csv
-snort_src_url: "https://snort.org/downloads/archive/snort/snort-{{ snort_version }}.src.rpm"
-snort_community_rules_url: "https://www.snort.org/downloads/community/community-rules.tar.gz"
-dag_src_url: "https://snort.org/downloads/snort/daq-{{ daq_version }}.src.rpm"
-

http://git-wip-us.apache.org/repos/asf/incubator-metron/blob/0117987e/deployment/roles/snort/files/flume-snort.conf
----------------------------------------------------------------------
diff --git a/deployment/roles/snort/files/flume-snort.conf b/deployment/roles/snort/files/flume-snort.conf
deleted file mode 100644
index 7dea516..0000000
--- a/deployment/roles/snort/files/flume-snort.conf
+++ /dev/null
@@ -1,44 +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.
-#
-
-snort.sources = exec-source
-snort.channels = memory-channel
-snort.sinks = kafka-sink logger-sink
-
-# snort alerts are logged to a file
-snort.sources.exec-source.type = exec
-snort.sources.exec-source.command = tail -F /var/log/snort/alert
-snort.sources.exec-source.restart = true
-snort.sources.exec-source.logStdErr = true
-
-# snort alerts are sent to kafka
-snort.sinks.kafka-sink.type = org.apache.flume.sink.kafka.KafkaSink
-snort.sinks.kafka-sink.brokerList = localhost:9092
-snort.sinks.kafka-sink.topic = snort
-
-# also log events
-snort.sinks.logger-sink.type = logger
-
-# buffer events in memory
-snort.channels.memory-channel.type = memory
-snort.channels.memory-channel.capacity = 1000
-snort.channels.memory-channel.transactionCapacity = 100
-
-# bind the source and sink to the channel
-snort.sources.exec-source.channels = memory-channel
-snort.sinks.kafka-sink.channel = memory-channel
-snort.sinks.logger-sink.channel = memory-channel