You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@metron.apache.org by ni...@apache.org on 2017/11/23 16:48:38 UTC

metron git commit: METRON-1316 Fastcapa Fails to Compile in Test Environment (nickwallen) closes apache/metron#841

Repository: metron
Updated Branches:
  refs/heads/master 59fe1b453 -> a1408d787


METRON-1316 Fastcapa Fails to Compile in Test Environment (nickwallen) closes apache/metron#841


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

Branch: refs/heads/master
Commit: a1408d787f740f6abc78842898bc1ab819def7d7
Parents: 59fe1b4
Author: nickwallen <ni...@nickallen.org>
Authored: Thu Nov 23 11:46:49 2017 -0500
Committer: nickallen <ni...@apache.org>
Committed: Thu Nov 23 11:46:49 2017 -0500

----------------------------------------------------------------------
 .../roles/fastcapa/defaults/main.yml            |  4 +-
 .../roles/fastcapa/tasks/dependencies.yml       |  1 +
 .../roles/packet-capture/defaults/main.yml      | 32 -------
 .../roles/packet-capture/meta/main.yml          | 19 ----
 .../roles/packet-capture/tasks/debug.yml        | 26 ------
 .../roles/packet-capture/tasks/dependencies.yml | 38 --------
 .../roles/packet-capture/tasks/dpdk.yml         | 59 -------------
 .../roles/packet-capture/tasks/kernel.yml       | 51 -----------
 .../roles/packet-capture/tasks/main.yml         | 22 -----
 .../roles/packet-capture/tasks/pcapture.yml     | 49 -----------
 .../roles/packet-capture/templates/pcapture     | 93 --------------------
 .../packet-capture/templates/pcapture.conf      | 67 --------------
 .../vagrant/fastcapa-test-platform/README.md    | 50 ++++++++++-
 .../vagrant/fastcapa-test-platform/Vagrantfile  | 71 ---------------
 .../vagrant/fastcapa-test-platform/ansible.cfg  | 22 -----
 .../centos-7.1/Vagrantfile                      | 72 +++++++++++++++
 .../centos-7.1/ansible.cfg                      | 22 +++++
 .../centos-7.1/vars/main.yml                    | 52 +++++++++++
 .../centos-7.4/Vagrantfile                      | 72 +++++++++++++++
 .../centos-7.4/ansible.cfg                      | 22 +++++
 .../centos-7.4/vars/main.yml                    | 52 +++++++++++
 .../vagrant/fastcapa-test-platform/playbook.yml |  6 --
 .../fastcapa-test-platform/vars/main.yml        | 52 -----------
 metron-sensors/fastcapa/src/worker.c            |  4 +-
 24 files changed, 346 insertions(+), 612 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/roles/fastcapa/defaults/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/fastcapa/defaults/main.yml b/metron-deployment/roles/fastcapa/defaults/main.yml
index a7edc08..d586046 100644
--- a/metron-deployment/roles/fastcapa/defaults/main.yml
+++ b/metron-deployment/roles/fastcapa/defaults/main.yml
@@ -17,8 +17,8 @@
 ---
 # dpdk
 dpdk_home: "/usr/local/dpdk"
-dpdk_version: "16.11.1"
-dpdk_sdk: "/root/dpdk-stable-{{ dpdk_version }}"
+dpdk_version: "17.08"
+dpdk_sdk: "/root/dpdk-{{ dpdk_version }}"
 dpdk_src_url: "http://fast.dpdk.org/rel/dpdk-{{ dpdk_version }}.tar.xz"
 dpdk_target: "x86_64-native-linuxapp-gcc"
 num_huge_pages: 512

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/roles/fastcapa/tasks/dependencies.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/fastcapa/tasks/dependencies.yml b/metron-deployment/roles/fastcapa/tasks/dependencies.yml
index 4d6edc4..5955702 100644
--- a/metron-deployment/roles/fastcapa/tasks/dependencies.yml
+++ b/metron-deployment/roles/fastcapa/tasks/dependencies.yml
@@ -24,6 +24,7 @@
       - glib2
       - glib2-devel
       - git
+      - numactl-devel
 
   #
   # install prerequisite packages and the latest kernel headers.  need to

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/roles/packet-capture/defaults/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/defaults/main.yml b/metron-deployment/roles/packet-capture/defaults/main.yml
deleted file mode 100644
index 3e6358c..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/meta/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/meta/main.yml b/metron-deployment/roles/packet-capture/meta/main.yml
deleted file mode 100644
index d253e88..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/tasks/debug.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/tasks/debug.yml b/metron-deployment/roles/packet-capture/tasks/debug.yml
deleted file mode 100644
index 06f1526..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/tasks/dependencies.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/tasks/dependencies.yml b/metron-deployment/roles/packet-capture/tasks/dependencies.yml
deleted file mode 100644
index 4d6edc4..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/tasks/dpdk.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/tasks/dpdk.yml b/metron-deployment/roles/packet-capture/tasks/dpdk.yml
deleted file mode 100644
index 3780be7..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/tasks/kernel.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/tasks/kernel.yml b/metron-deployment/roles/packet-capture/tasks/kernel.yml
deleted file mode 100644
index cd4abe6..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/tasks/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/tasks/main.yml b/metron-deployment/roles/packet-capture/tasks/main.yml
deleted file mode 100644
index f096178..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/tasks/pcapture.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/tasks/pcapture.yml b/metron-deployment/roles/packet-capture/tasks/pcapture.yml
deleted file mode 100644
index d00d379..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/templates/pcapture
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/templates/pcapture b/metron-deployment/roles/packet-capture/templates/pcapture
deleted file mode 100644
index 8c2221a..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/roles/packet-capture/templates/pcapture.conf
----------------------------------------------------------------------
diff --git a/metron-deployment/roles/packet-capture/templates/pcapture.conf b/metron-deployment/roles/packet-capture/templates/pcapture.conf
deleted file mode 100644
index e404476..0000000
--- a/metron-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/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/README.md
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/README.md b/metron-deployment/vagrant/fastcapa-test-platform/README.md
index 9bb0a39..95c3cdf 100644
--- a/metron-deployment/vagrant/fastcapa-test-platform/README.md
+++ b/metron-deployment/vagrant/fastcapa-test-platform/README.md
@@ -12,8 +12,15 @@ Two virtualized nodes are launched with Vagrant that can communicate with one an
 Getting Started
 ---------------
 
-Simply run `vagrant up` to launch the environment.  Automated tests are executed after provisioning completes to ensure that Fastcapa and the rest of the environment is functioning properly.
+The Fastcapa test environment can be executed on different operating systems.  There is a sub-directory for each operating system that Fastcapa can be tested on.  
 
+To run, simply execute `vagrant up` within the appropriate directory.  For example, to run the tests on CentOS 7.1 then execute the following commands.
+```
+cd centos-7.1
+vagrant up
+```
+
+Automated tests are executed after provisioning completes to ensure that Fastcapa and the rest of the environment is functioning properly.  If you see something like the following, then the tests have passed.
 ```
 $ vagrant up
 ==> source: Running provisioner: ansible...
@@ -30,6 +37,20 @@ ok: [source] => {
 }
 ```
 
+If the deployment process fails mid-course, running `vagrant provision` will continue the process from where it left off.  This can sometimes occur when the VM reboots as part of the deployment process.  The error might look like the following.
+```
+TASK [fastcapa : Restart for modified kernel params] ***************************
+fatal: [sink]: UNREACHABLE! => {"changed": false, "msg": "Failed to connect to the host via ssh: Shared connection to 127.0.0.1 closed.\r\n", "unreachable": true}
+	to retry, use: --limit @/Users/nallen/Development/metron/metron-deployment/vagrant/fastcapa-test-platform/playbook.retry
+
+PLAY RECAP *********************************************************************
+sink                       : ok=11   changed=9    unreachable=1    failed=0
+source                     : ok=29   changed=25   unreachable=0    failed=0
+
+Ansible failed to complete successfully. Any error output should be
+visible above. Please fix these errors and try again.
+```
+
 Going Deeper
 ------------
 
@@ -71,3 +92,30 @@ Ensure that the raw network packet data is being received by Kafka.
 ```
 
 Enter 'CTRL-C' to kill the `kafka-console-consumer` process once you are able to see that packets are being sent.  These packets will appear to be gibberish in the console.  This is the raw binary network packet data after all.
+
+FAQ
+---
+
+### Error Message: Timed out while waiting for the machine to boot
+
+```
+Timed out while waiting for the machine to boot. This means that
+Vagrant was unable to communicate with the guest machine within
+the configured ("config.vm.boot_timeout" value) time period.
+If you look above, you should be able to see the error(s) that
+Vagrant had when attempting to connect to the machine. These errors
+are usually good hints as to what may be wrong.
+If you're using a custom box, make sure that networking is properly
+working and you're able to connect to the machine. It is a common
+problem that networking isn't setup properly in these boxes.
+Verify that authentication configurations are also setup properly,
+as well.
+If the box appears to be booting properly, you may want to increase
+the timeout ("config.vm.boot_timeout") value.
+➜  centos-7.4 git:(master) ✗ vagrant status
+Current machine states:
+source                    running (virtualbox)
+sink                      not created (virtualbox)
+```
+
+If you are unable to launch any of the Fastcapa test environments, which results in a message like the one above, then you may need to upgrade your version of Virtualbox.  Success has been reported with versions of VirtualBox 5.1.22+.

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/Vagrantfile
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/Vagrantfile b/metron-deployment/vagrant/fastcapa-test-platform/Vagrantfile
deleted file mode 100644
index 7f58417..0000000
--- a/metron-deployment/vagrant/fastcapa-test-platform/Vagrantfile
+++ /dev/null
@@ -1,71 +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.
-#
-
-Vagrant.configure("2") do |config|
-
-  # enable hostmanager
-  config.hostmanager.enabled = true
-  config.hostmanager.manage_host = true
-
-  #
-  # source
-  #
-  config.vm.define "source" do |node|
-
-    # host settings
-    node.vm.hostname = "source"
-    node.vm.box = "bento/centos-6.7"
-    node.ssh.insert_key = "true"
-    node.vm.network :private_network, ip: "192.168.33.10", netmask: "255.255.255.0"
-
-    # provider
-    node.vm.provider "virtualbox" do |vb|
-      vb.memory = 1024
-      vb.cpus = 1
-    end
-  end
-
-  #
-  # sink
-  #
-  config.vm.define "sink" do |node|
-
-    # host settings
-    node.vm.hostname = "sink"
-    node.vm.box = "bento/centos-7.1"
-    node.ssh.insert_key = "true"
-    node.vm.network :private_network, ip: "192.168.33.11", netmask: "255.255.255.0"
-
-    # provider
-    node.vm.provider "virtualbox" do |vb|
-      vb.memory = 4096
-      vb.cpus = 3
-
-      # network adapter settings; [Am79C970A|Am79C973|82540EM|82543GC|82545EM|virtio]
-      vb.customize ["modifyvm", :id, "--nicpromisc2", "allow-all"]
-      vb.customize ["modifyvm", :id, "--nictype2","82545EM"]
-    end
-
-    # provision host
-    node.vm.provision :ansible do |ansible|
-      ansible.limit = "all"
-      ansible.playbook = "playbook.yml"
-    end
-  end
-
-
-end

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/ansible.cfg
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/ansible.cfg b/metron-deployment/vagrant/fastcapa-test-platform/ansible.cfg
deleted file mode 100644
index 9c650c2..0000000
--- a/metron-deployment/vagrant/fastcapa-test-platform/ansible.cfg
+++ /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.
-#
-
-[defaults]
-host_key_checking = false
-library = ../../extra_modules
-roles_path = ../../roles
-pipelining = True

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/Vagrantfile
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/Vagrantfile b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/Vagrantfile
new file mode 100644
index 0000000..179ca34
--- /dev/null
+++ b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/Vagrantfile
@@ -0,0 +1,72 @@
+#
+#  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.
+#
+
+Vagrant.configure("2") do |config|
+
+  # enable hostmanager
+  config.hostmanager.enabled = true
+  config.hostmanager.manage_host = true
+
+  #
+  # source
+  #
+  config.vm.define "source" do |node|
+
+    # host settings
+    node.vm.hostname = "source"
+    node.vm.box = "bento/centos-7.1"
+    node.ssh.insert_key = "true"
+    node.vm.network :private_network, ip: "192.168.33.10", netmask: "255.255.255.0"
+
+    # provider
+    node.vm.provider "virtualbox" do |vb|
+      vb.memory = 1024
+      vb.cpus = 1
+    end
+  end
+
+  #
+  # sink
+  #
+  config.vm.define "sink" do |node|
+
+    # host settings
+    node.vm.hostname = "sink"
+    node.vm.box = "bento/centos-7.1"
+    node.ssh.insert_key = "true"
+    node.vm.network :private_network, ip: "192.168.33.11", netmask: "255.255.255.0"
+
+    # provider
+    node.vm.provider "virtualbox" do |vb|
+      vb.memory = 4096
+      vb.cpus = 3
+
+      # network adapter settings; [Am79C970A|Am79C973|82540EM|82543GC|82545EM|virtio]
+      vb.customize ["modifyvm", :id, "--nicpromisc2", "allow-all"]
+      vb.customize ["modifyvm", :id, "--nictype2","82545EM"]
+    end
+
+    # provision host
+    node.vm.provision :ansible do |ansible|
+      ansible.limit = "all"
+      ansible.playbook = "../playbook.yml"
+      ansible.extra_vars = "vars/main.yml"
+    end
+  end
+
+
+end

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/ansible.cfg
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/ansible.cfg b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/ansible.cfg
new file mode 100644
index 0000000..0a83e32
--- /dev/null
+++ b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/ansible.cfg
@@ -0,0 +1,22 @@
+#
+#  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.
+#
+
+[defaults]
+host_key_checking = false
+library = ../../../extra_modules
+roles_path = ../../../roles
+pipelining = True

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/vars/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/vars/main.yml b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/vars/main.yml
new file mode 100644
index 0000000..563fc2a
--- /dev/null
+++ b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.1/vars/main.yml
@@ -0,0 +1,52 @@
+#
+#  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.
+#
+---
+
+# 0.9.4+ required for fastcapa
+librdkafka_version: 0.9.4
+librdkafka_url: https://github.com/edenhill/librdkafka/archive/v0.9.4.tar.gz
+
+dpdk_device: ["00:08.0"]
+dpdk_target: "x86_64-native-linuxapp-gcc"
+num_huge_pages: 512
+kafka_broker_url: source:9092
+zookeeper_url: source:2181
+pcap_replay_interface: enp0s3
+kafka_broker_home: /usr/hdp/current/kafka-broker/
+
+# fastcapa settings
+fastcapa_portmask: 0x01
+fastcapa_kafka_config: /etc/fastcapa.conf
+fastcapa_topic: pcap
+fastcapa_burst_size: 32
+fastcapa_nb_rx_desc: 1024
+fastcapa_nb_rx_queue: 1
+fastcapa_tx_ring_size: 2048
+
+# dummy variables for pycapa's dependence on ambari_gather_facts
+cluster_name: dummy
+namenode_host: dummy
+core_site_tag: dummy
+hdfs_url: dummy
+kafka_broker_hosts: dummy
+kafka_broker_tag: dummy
+kafka_broker_port: dummy
+zookeeper_hosts: dummy
+zookeeper_tag: dummy
+zookeeper_port: dummy
+metron_hosts: dummy
+kibana_hosts: dummy

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/Vagrantfile
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/Vagrantfile b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/Vagrantfile
new file mode 100644
index 0000000..c62a0f1
--- /dev/null
+++ b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/Vagrantfile
@@ -0,0 +1,72 @@
+#
+#  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.
+#
+
+Vagrant.configure("2") do |config|
+
+  # enable hostmanager
+  config.hostmanager.enabled = true
+  config.hostmanager.manage_host = true
+
+  #
+  # source
+  #
+  config.vm.define "source" do |node|
+
+    # host settings
+    node.vm.hostname = "source"
+    node.vm.box = "bento/centos-7.4"
+    node.ssh.insert_key = "true"
+    node.vm.network :private_network, ip: "192.168.33.10", netmask: "255.255.255.0"
+
+    # provider
+    node.vm.provider "virtualbox" do |vb|
+      vb.memory = 1024
+      vb.cpus = 1
+    end
+  end
+
+  #
+  # sink
+  #
+  config.vm.define "sink" do |node|
+
+    # host settings
+    node.vm.hostname = "sink"
+    node.vm.box = "bento/centos-7.4"
+    node.ssh.insert_key = "true"
+    node.vm.network :private_network, ip: "192.168.33.11", netmask: "255.255.255.0"
+
+    # provider
+    node.vm.provider "virtualbox" do |vb|
+      vb.memory = 4096
+      vb.cpus = 3
+
+      # network adapter settings; [Am79C970A|Am79C973|82540EM|82543GC|82545EM|virtio]
+      vb.customize ["modifyvm", :id, "--nicpromisc2", "allow-all"]
+      vb.customize ["modifyvm", :id, "--nictype2","82545EM"]
+    end
+
+    # provision host
+    node.vm.provision :ansible do |ansible|
+      ansible.limit = "all"
+      ansible.playbook = "../playbook.yml"
+      ansible.extra_vars = "vars/main.yml"
+    end
+  end
+
+
+end

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/ansible.cfg
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/ansible.cfg b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/ansible.cfg
new file mode 100644
index 0000000..0a83e32
--- /dev/null
+++ b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/ansible.cfg
@@ -0,0 +1,22 @@
+#
+#  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.
+#
+
+[defaults]
+host_key_checking = false
+library = ../../../extra_modules
+roles_path = ../../../roles
+pipelining = True

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/vars/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/vars/main.yml b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/vars/main.yml
new file mode 100644
index 0000000..563fc2a
--- /dev/null
+++ b/metron-deployment/vagrant/fastcapa-test-platform/centos-7.4/vars/main.yml
@@ -0,0 +1,52 @@
+#
+#  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.
+#
+---
+
+# 0.9.4+ required for fastcapa
+librdkafka_version: 0.9.4
+librdkafka_url: https://github.com/edenhill/librdkafka/archive/v0.9.4.tar.gz
+
+dpdk_device: ["00:08.0"]
+dpdk_target: "x86_64-native-linuxapp-gcc"
+num_huge_pages: 512
+kafka_broker_url: source:9092
+zookeeper_url: source:2181
+pcap_replay_interface: enp0s3
+kafka_broker_home: /usr/hdp/current/kafka-broker/
+
+# fastcapa settings
+fastcapa_portmask: 0x01
+fastcapa_kafka_config: /etc/fastcapa.conf
+fastcapa_topic: pcap
+fastcapa_burst_size: 32
+fastcapa_nb_rx_desc: 1024
+fastcapa_nb_rx_queue: 1
+fastcapa_tx_ring_size: 2048
+
+# dummy variables for pycapa's dependence on ambari_gather_facts
+cluster_name: dummy
+namenode_host: dummy
+core_site_tag: dummy
+hdfs_url: dummy
+kafka_broker_hosts: dummy
+kafka_broker_tag: dummy
+kafka_broker_port: dummy
+zookeeper_hosts: dummy
+zookeeper_tag: dummy
+zookeeper_port: dummy
+metron_hosts: dummy
+kibana_hosts: dummy

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/playbook.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/playbook.yml b/metron-deployment/vagrant/fastcapa-test-platform/playbook.yml
index 5f89d80..e038691 100644
--- a/metron-deployment/vagrant/fastcapa-test-platform/playbook.yml
+++ b/metron-deployment/vagrant/fastcapa-test-platform/playbook.yml
@@ -20,8 +20,6 @@
 #
 - hosts: source
   become: yes
-  vars_files:
-    - vars/main.yml
   roles:
     - role: kafka-broker
     - role: pcap_replay
@@ -35,8 +33,6 @@
 #
 - hosts: sink
   become: yes
-  vars_files:
-    - vars/main.yml
   roles:
     - role: librdkafka
     - role: fastcapa
@@ -48,8 +44,6 @@
 #
 - hosts: source
   become: yes
-  vars_files:
-    - vars/main.yml
   tasks:
     - include: tasks/validate-packets-sent.yml
     - include: tasks/validate-messages-received.yml

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-deployment/vagrant/fastcapa-test-platform/vars/main.yml
----------------------------------------------------------------------
diff --git a/metron-deployment/vagrant/fastcapa-test-platform/vars/main.yml b/metron-deployment/vagrant/fastcapa-test-platform/vars/main.yml
deleted file mode 100644
index 74bab29..0000000
--- a/metron-deployment/vagrant/fastcapa-test-platform/vars/main.yml
+++ /dev/null
@@ -1,52 +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.
-#
----
-
-# 0.9.4+ required for fastcapa
-librdkafka_version: 0.9.4
-librdkafka_url: https://github.com/edenhill/librdkafka/archive/v0.9.4.tar.gz 
-  
-dpdk_device: ["00:08.0"]
-dpdk_target: "x86_64-native-linuxapp-gcc"
-num_huge_pages: 512
-kafka_broker_url: source:9092
-zookeeper_url: source:2181
-pcap_replay_interface: eth1
-kafka_broker_home: /usr/hdp/current/kafka-broker/
-
-# fastcapa settings
-fastcapa_portmask: 0x01
-fastcapa_kafka_config: /etc/fastcapa.conf
-fastcapa_topic: pcap
-fastcapa_burst_size: 32
-fastcapa_nb_rx_desc: 1024
-fastcapa_nb_rx_queue: 1
-fastcapa_tx_ring_size: 2048
-
-# dummy variables for pycapa's dependence on ambari_gather_facts
-cluster_name: dummy
-namenode_host: dummy
-core_site_tag: dummy
-hdfs_url: dummy
-kafka_broker_hosts: dummy
-kafka_broker_tag: dummy
-kafka_broker_port: dummy
-zookeeper_hosts: dummy
-zookeeper_tag: dummy
-zookeeper_port: dummy
-metron_hosts: dummy
-kibana_hosts: dummy

http://git-wip-us.apache.org/repos/asf/metron/blob/a1408d78/metron-sensors/fastcapa/src/worker.c
----------------------------------------------------------------------
diff --git a/metron-sensors/fastcapa/src/worker.c b/metron-sensors/fastcapa/src/worker.c
index aa6a7c3..6017eea 100644
--- a/metron-sensors/fastcapa/src/worker.c
+++ b/metron-sensors/fastcapa/src/worker.c
@@ -138,7 +138,7 @@ static int receive_worker(rx_worker_params* params)
 
         // add each packet to the ring buffer
         if(likely(nb_in) > 0) {
-          const uint16_t nb_out = rte_ring_enqueue_burst(ring, (void *) pkts, nb_in);
+          const uint16_t nb_out = rte_ring_enqueue_burst(ring, (void *) pkts, nb_in, NULL);
           params->stats.out += nb_out;
           params->stats.drops += (nb_in - nb_out);
         }
@@ -174,7 +174,7 @@ static int transmit_worker(tx_worker_params *params)
 
         // dequeue packets from the ring
         struct rte_mbuf* pkts[params->tx_ring_size];
-        nb_in = rte_ring_dequeue_burst(ring, (void*) pkts, tx_burst_size);
+        nb_in = rte_ring_dequeue_burst(ring, (void*) pkts, tx_burst_size, NULL);
 
         if(likely(nb_in > 0)) {
             params->stats.in += nb_in;