You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@bigtop.apache.org by rv...@apache.org on 2013/02/10 07:04:01 UTC

[13/50] [abbrv] git commit: BIGTOP-753. Bump Flume to 1.3.0

BIGTOP-753. Bump Flume to 1.3.0


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

Branch: refs/heads/RCs
Commit: ed925d886bb877f63df8826a0c93329721ff92f3
Parents: 87fb82e
Author: Roman Shaposhnik <rv...@cloudera.com>
Authored: Wed Nov 28 10:18:35 2012 -0800
Committer: Roman Shaposhnik <rv...@cloudera.com>
Committed: Sun Dec 2 21:03:03 2012 -0800

----------------------------------------------------------------------
 bigtop-deploy/live-cd/apache-bigtop.ks             |    2 +-
 bigtop-deploy/puppet/manifests/cluster.pp          |    6 +-
 .../puppet/modules/hadoop-flume/manifests/init.pp  |   33 +--
 .../modules/hadoop-flume/templates/flume.conf      |   36 +++
 .../puppet/modules/hadoop-flume/tests/init.pp      |   34 +++-
 .../src/common/flume/do-component-build            |    4 +-
 .../src/common/flume/flume-agent.default           |   24 ++
 bigtop-packages/src/common/flume/flume-agent.init  |  170 +++++++++++++++
 .../src/common/flume/flume-node.default            |   24 --
 bigtop-packages/src/common/flume/flume-node.init   |  169 --------------
 bigtop-packages/src/common/flume/install_flume.sh  |    4 +-
 bigtop-packages/src/deb/flume/control              |    4 +-
 bigtop-packages/src/deb/flume/flume-agent.postinst |   26 +++
 bigtop-packages/src/deb/flume/flume-node.postinst  |   26 ---
 bigtop-packages/src/deb/flume/flume.preinst        |    4 +-
 bigtop-packages/src/deb/flume/rules                |    4 +-
 bigtop-packages/src/rpm/flume/SPECS/flume.spec     |   45 ++--
 .../bigtop/itest/packagesmoke/CDHServices.groovy   |    2 +-
 .../bigtop/itest/packagesmoke/DeployCDH.groovy     |    4 +-
 .../package/src/main/resources/apt/flume-agent.xml |   14 ++
 .../package/src/main/resources/apt/flume-node.xml  |   14 --
 .../package/src/main/resources/apt/flume.xml       |    3 +-
 .../src/main/resources/apt/package_data.xml        |    8 +-
 .../package/src/main/resources/package_data.xml    |    6 +-
 .../src/main/resources/urpmi/package_data.xml      |   10 +-
 .../package/src/main/resources/yum/flume-agent.xml |    5 +
 .../package/src/main/resources/yum/flume-node.xml  |    5 -
 .../package/src/main/resources/yum/flume.xml       |    3 +-
 .../src/main/resources/yum/package_data.xml        |    8 +-
 .../src/main/resources/zypper/flume-agent.xml      |    5 +
 .../src/main/resources/zypper/flume-node.xml       |    5 -
 .../package/src/main/resources/zypper/flume.xml    |    3 +-
 .../src/main/resources/zypper/package_data.xml     |    8 +-
 bigtop.mk                                          |   10 +-
 34 files changed, 391 insertions(+), 337 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-deploy/live-cd/apache-bigtop.ks
----------------------------------------------------------------------
diff --git a/bigtop-deploy/live-cd/apache-bigtop.ks b/bigtop-deploy/live-cd/apache-bigtop.ks
index 65a8a2d..be16ebc 100644
--- a/bigtop-deploy/live-cd/apache-bigtop.ks
+++ b/bigtop-deploy/live-cd/apache-bigtop.ks
@@ -79,7 +79,7 @@ hive-server
 sqoop
 sqoop-metastore
 flume
-flume-node
+flume-agent
 mahout
 pig
 oozie

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-deploy/puppet/manifests/cluster.pp
----------------------------------------------------------------------
diff --git a/bigtop-deploy/puppet/manifests/cluster.pp b/bigtop-deploy/puppet/manifests/cluster.pp
index b4cb9f1..57d73b3 100644
--- a/bigtop-deploy/puppet/manifests/cluster.pp
+++ b/bigtop-deploy/puppet/manifests/cluster.pp
@@ -96,6 +96,10 @@ class hadoop_cluster_node {
 
     include kerberos::client
   }
+
+  # Flume agent is the only component that goes on EVERY node in the cluster
+  hadoop-flume::agent { "flume agent":
+  }
 }
 
 
@@ -295,6 +299,4 @@ class hadoop_gateway_node inherits hadoop_cluster_node {
   }
   hadoop-zookeeper::client { "zookeeper client":
   }
-  hadoop-flume::client { "flume client":
-  }
 }

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-deploy/puppet/modules/hadoop-flume/manifests/init.pp
----------------------------------------------------------------------
diff --git a/bigtop-deploy/puppet/modules/hadoop-flume/manifests/init.pp b/bigtop-deploy/puppet/modules/hadoop-flume/manifests/init.pp
index 0812b94..8e3bf64 100644
--- a/bigtop-deploy/puppet/modules/hadoop-flume/manifests/init.pp
+++ b/bigtop-deploy/puppet/modules/hadoop-flume/manifests/init.pp
@@ -14,36 +14,21 @@
 # limitations under the License.
 
 class hadoop-flume {
-  define client {
-    package { "flume":
+  define agent($sources = [], $sinks = [], $channels = []) {
+    package { "flume-agent":
       ensure => latest,
     } 
-  }
 
-  # It really is flume node, but node is a reserved keyword for puppet
-  define agent {
-    package { "flume-node":
-      ensure => latest,
-    } 
-
-    service { "flume-node":
-      ensure => running,
-      require => Package["flume-node"],
-      # FIXME: this need to be fixed in upstream flume
-      hasstatus => false,
-      hasrestart => true,
+    file {
+      "/etc/flume/conf/flume.conf":
+        content => template('hadoop-flume/flume.conf'),
+        require => Package["flume-agent"],
     }
-  }
-
-  define master {
-    package { "flume-master":
-      ensure => latest,
-    } 
 
-    service { "flume-master":
+    service { "flume-agent":
       ensure => running,
-      require => Package["flume-node"],
-      # FIXME: this need to be fixed in upstream flume
+      require => [Package["flume-agent"], File["/etc/flume/conf/flume.conf"]],
+      subscribe => [Package["flume-agent"], File["/etc/flume/conf/flume.conf"]],
       hasstatus => true,
       hasrestart => true,
     }

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-deploy/puppet/modules/hadoop-flume/templates/flume.conf
----------------------------------------------------------------------
diff --git a/bigtop-deploy/puppet/modules/hadoop-flume/templates/flume.conf b/bigtop-deploy/puppet/modules/hadoop-flume/templates/flume.conf
new file mode 100644
index 0000000..7007ead
--- /dev/null
+++ b/bigtop-deploy/puppet/modules/hadoop-flume/templates/flume.conf
@@ -0,0 +1,36 @@
+# 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.
+
+agent.channels = <%= (channels.collect { |k,v| k }).join(' ') %>
+agent.sources = <%= (sources.collect { |k,v| k }).join(' ') %>
+agent.sinks = <%= (sinks.collect { |k,v| k }).join(' ') %>
+
+<% channels.each do |channel,props| -%>
+<% props.each do |k,v| -%>
+agent.channels.<%= channel %>.<%= k %> = <%= v %>
+<% end -%>
+<% end -%>
+
+<% sources.each do |source,props| -%>
+<% props.each do |k,v| -%>
+agent.sources.<%= source %>.<%= k %> = <%= v %>
+<% end -%>
+<% end -%>
+
+<% sinks.each do |sink,props| -%>
+<% props.each do |k,v| -%>
+agent.sinks.<%= sink %>.<%= k %> = <%= v %>
+<% end -%>
+<% end -%>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-deploy/puppet/modules/hadoop-flume/tests/init.pp
----------------------------------------------------------------------
diff --git a/bigtop-deploy/puppet/modules/hadoop-flume/tests/init.pp b/bigtop-deploy/puppet/modules/hadoop-flume/tests/init.pp
index 00c9763..9694be6 100644
--- a/bigtop-deploy/puppet/modules/hadoop-flume/tests/init.pp
+++ b/bigtop-deploy/puppet/modules/hadoop-flume/tests/init.pp
@@ -13,8 +13,32 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-hadoop-flume::client { "test-flume": } 
-hadoop-flume::agent  { "test-flume-node": } 
-hadoop-flume::master { "test-flume-master": }
-
-
+hadoop-flume::agent  { "test-flume-agent": 
+  channels => {  mem    => { type => "memory", 
+                             capacity => "1000", 
+                             transactionCapactiy => "100" 
+                           }, 
+                 file   => { type => "file",
+                             checkpointDir => "/var/lib/flume/checkpoint",
+                             dataDirs => "/var/lib/flume/data",
+                           }
+              },
+  sources  => {  netcat => { type => "netcat", 
+                             bind => "0.0.0.0", 
+                             port => "1949", 
+                             channels => "mem" 
+                           }, 
+              },
+  sinks    => {  hdfs   => { type => "hdfs",
+                             "hdfs.path" => "/flume/test-flume-agent",
+                             "hdfs.writeFormat" => "Text",
+                             "hdfs.fileType" => "DataStream",
+                             "hdfs.filePrefix" => "events-",
+                             "hdfs.round" => "true",
+                             "hdfs.roundValue" => "10",
+                             "hdfs.roundUnit" => "minute",
+                             "hdfs.serializer" => "org.apache.flume.serialization.BodyTextEventSerializer",
+                             channel => "mem",
+                           }
+              },
+}

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/common/flume/do-component-build
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/common/flume/do-component-build b/bigtop-packages/src/common/flume/do-component-build
index 30799d1..77969d8 100755
--- a/bigtop-packages/src/common/flume/do-component-build
+++ b/bigtop-packages/src/common/flume/do-component-build
@@ -18,7 +18,9 @@ set -ex
 
 . `dirname $0`/bigtop.bom
 
-mvn -DskipTests -Dhadoop.profile=23 \
+export MAVEN_OPTS="-Xmx1536m -Xms256m -XX:MaxPermSize=256m"
+
+mvn -DskipTests -Dhadoop.profile=2  \
   -Dhadoop.version=$HADOOP_VERSION  \
   -Dhbase.version=$HBASE_VERSION    \
   clean install "$@"

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/common/flume/flume-agent.default
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/common/flume/flume-agent.default b/bigtop-packages/src/common/flume/flume-agent.default
new file mode 100644
index 0000000..509a646
--- /dev/null
+++ b/bigtop-packages/src/common/flume/flume-agent.default
@@ -0,0 +1,24 @@
+# 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.
+
+# Set name of flume agent (default: agent)
+# FLUME_AGENT_NAME=agent
+
+# Set name of flume configuration file (default: /etc/flume/conf/flume.conf)
+# FLUME_CONF_FILE=/etc/flume/conf/flume.conf
+
+# Set amount of time (in seconds) to wait for agent to shutdown gracefully
+# If timeout is reached, then agent is force-killed.
+# FLUME_SHUTDOWN_TIMEOUT=60

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/common/flume/flume-agent.init
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/common/flume/flume-agent.init b/bigtop-packages/src/common/flume/flume-agent.init
new file mode 100644
index 0000000..edb1e3f
--- /dev/null
+++ b/bigtop-packages/src/common/flume/flume-agent.init
@@ -0,0 +1,170 @@
+#!/bin/bash
+#
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+#
+# Starts a Flume NG agent
+#
+# chkconfig: 345 90 10
+# description: Flume NG agent
+#
+### BEGIN INIT INFO
+# Provides:          flume-agent
+# Required-Start:    $remote_fs
+# Should-Start:
+# Required-Stop:     $remote_fs
+# Should-Stop:
+# Default-Start:     3 4 5
+# Default-Stop:      0 1 2 6
+# Short-Description: Flume NG agent
+### END INIT INFO
+
+. /lib/lsb/init-functions
+
+if [ -f /etc/default/flume-agent ] ; then
+  . /etc/default/flume-agent
+fi
+
+# Autodetect JAVA_HOME if not defined
+if [ -e /usr/libexec/bigtop-detect-javahome ]; then
+  . /usr/libexec/bigtop-detect-javahome
+elif [ -e /usr/lib/bigtop-utils/bigtop-detect-javahome ]; then
+  . /usr/lib/bigtop-utils/bigtop-detect-javahome
+fi
+
+STATUS_RUNNING=0
+STATUS_DEAD=1
+STATUS_DEAD_AND_LOCK=2
+STATUS_NOT_RUNNING=3
+
+ERROR_PROGRAM_NOT_INSTALLED=5
+
+FLUME_LOG_DIR=/var/log/flume
+FLUME_CONF_DIR=/etc/flume/conf
+FLUME_RUN_DIR=/var/run/flume
+FLUME_HOME=/usr/lib/flume
+FLUME_USER=flume
+
+FLUME_LOCK_DIR="/var/lock/subsys/"
+LOCKFILE="${FLUME_LOCK_DIR}/flume-agent"
+desc="Flume NG agent daemon"
+
+FLUME_CONF_FILE=${FLUME_CONF_FILE:-${FLUME_CONF_DIR}/flume.conf}
+EXEC_PATH=/usr/bin/flume-ng
+FLUME_PID_FILE=${FLUME_RUN_DIR}/flume-agent.pid
+
+# These directories may be tmpfs and may or may not exist
+# depending on the OS (ex: /var/lock/subsys does not exist on debian/ubuntu)
+for dir in "$FLUME_RUN_DIR" "$FLUME_LOCK_DIR"; do
+  [ -d "${dir}" ] || install -d -m 0755 -o $FLUME_USER -g $FLUME_USER ${dir}
+done
+
+
+DEFAULT_FLUME_AGENT_NAME="agent"
+FLUME_AGENT_NAME=${FLUME_AGENT_NAME:-${DEFAULT_FLUME_AGENT_NAME}}
+FLUME_SHUTDOWN_TIMEOUT=${FLUME_SHUTDOWN_TIMEOUT:-60}
+
+start() {
+  [ -x $exec ] || exit $ERROR_PROGRAM_NOT_INSTALLED
+
+  checkstatus
+  status=$?
+  if [ "$status" -eq "$STATUS_RUNNING" ]; then
+    exit 0
+  fi
+
+  log_success_msg "Starting $desc (flume-agent): "
+  /bin/su -s /bin/bash -c "/bin/bash -c 'echo \$\$ >${FLUME_PID_FILE} && exec ${EXEC_PATH} agent --conf $FLUME_CONF_DIR --conf-file $FLUME_CONF_FILE --name $FLUME_AGENT_NAME >>${FLUME_LOG_DIR}/flume-agent.out 2>&1' &" $FLUME_USER
+  RETVAL=$?
+  [ $RETVAL -eq 0 ] && touch $LOCKFILE
+  return $RETVAL
+}
+
+stop() {
+  if [ ! -e $FLUME_PID_FILE ]; then
+    log_failure_msg "Flume agent is not running"
+    exit 0
+  fi
+
+  log_success_msg "Stopping $desc (flume-agent): "
+
+  FLUME_PID=`cat $FLUME_PID_FILE`
+  if [ -n $FLUME_PID ]; then
+    kill -TERM ${FLUME_PID} &>/dev/null
+    for i in `seq 1 ${FLUME_SHUTDOWN_TIMEOUT}` ; do
+      kill -0 ${FLUME_PID} &>/dev/null || break
+      sleep 1
+    done
+    kill -KILL ${FLUME_PID} &>/dev/null
+  fi
+  rm -f $LOCKFILE $FLUME_PID_FILE
+  return 0
+}
+
+restart() {
+  stop
+  start
+}
+
+checkstatus(){
+  pidofproc -p $FLUME_PID_FILE java > /dev/null
+  status=$?
+
+  case "$status" in
+    $STATUS_RUNNING)
+      log_success_msg "Flume NG agent is running"
+      ;;
+    $STATUS_DEAD)
+      log_failure_msg "Flume NG agent is dead and pid file exists"
+      ;;
+    $STATUS_DEAD_AND_LOCK)
+      log_failure_msg "Flume NG agent is dead and lock file exists"
+      ;;
+    $STATUS_NOT_RUNNING)
+      log_failure_msg "Flume NG agent is not running"
+      ;;
+    *)
+      log_failure_msg "Flume NG agent status is unknown"
+      ;;
+  esac
+  return $status
+}
+
+condrestart(){
+  [ -e ${LOCKFILE} ] && restart || :
+}
+
+case "$1" in
+  start)
+    start
+    ;;
+  stop)
+    stop
+    ;;
+  status)
+    checkstatus
+    ;;
+  restart)
+    restart
+    ;;
+  condrestart|try-restart)
+    condrestart
+    ;;
+  *)
+    echo $"Usage: $0 {start|stop|status|restart|try-restart|condrestart}"
+    exit 1
+esac
+
+exit $RETVAL

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/common/flume/flume-node.default
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/common/flume/flume-node.default b/bigtop-packages/src/common/flume/flume-node.default
deleted file mode 100644
index 509a646..0000000
--- a/bigtop-packages/src/common/flume/flume-node.default
+++ /dev/null
@@ -1,24 +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.
-
-# Set name of flume agent (default: agent)
-# FLUME_AGENT_NAME=agent
-
-# Set name of flume configuration file (default: /etc/flume/conf/flume.conf)
-# FLUME_CONF_FILE=/etc/flume/conf/flume.conf
-
-# Set amount of time (in seconds) to wait for agent to shutdown gracefully
-# If timeout is reached, then agent is force-killed.
-# FLUME_SHUTDOWN_TIMEOUT=60

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/common/flume/flume-node.init
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/common/flume/flume-node.init b/bigtop-packages/src/common/flume/flume-node.init
deleted file mode 100644
index 3dc9858..0000000
--- a/bigtop-packages/src/common/flume/flume-node.init
+++ /dev/null
@@ -1,169 +0,0 @@
-#!/bin/bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-#
-# Starts a Flume NG node
-#
-# chkconfig: 345 90 10
-# description: Flume NG node
-#
-### BEGIN INIT INFO
-# Provides:          flume-node
-# Required-Start:    $remote_fs
-# Should-Start:
-# Required-Stop:     $remote_fs
-# Should-Stop:
-# Default-Start:     3 4 5
-# Default-Stop:      0 1 2 6
-# Short-Description: Flume NG node
-### END INIT INFO
-
-. /lib/lsb/init-functions
-
-if [ -f /etc/default/flume-node ] ; then
-  . /etc/default/flume-node
-fi
-
-# Autodetect JAVA_HOME if not defined
-if [ -e /usr/libexec/bigtop-detect-javahome ]; then
-  . /usr/libexec/bigtop-detect-javahome
-elif [ -e /usr/lib/bigtop-utils/bigtop-detect-javahome ]; then
-  . /usr/lib/bigtop-utils/bigtop-detect-javahome
-fi
-
-STATUS_RUNNING=0
-STATUS_DEAD=1
-STATUS_DEAD_AND_LOCK=2
-STATUS_NOT_RUNNING=3
-
-ERROR_PROGRAM_NOT_INSTALLED=5
-
-FLUME_LOG_DIR=/var/log/flume
-FLUME_CONF_DIR=/etc/flume/conf
-FLUME_RUN_DIR=/var/run/flume
-FLUME_HOME=/usr/lib/flume
-FLUME_USER=flume
-
-FLUME_LOCK_DIR="/var/lock/subsys"
-LOCKFILE="${FLUME_LOCK_DIR}/flume-node"
-desc="Flume NG node daemon"
-
-FLUME_CONF_FILE=${FLUME_CONF_FILE:-${FLUME_CONF_DIR}/flume.conf}
-EXEC_PATH=/usr/bin/flume-ng
-FLUME_PID_FILE=${FLUME_RUN_DIR}/flume-node.pid
-
-# These directories may be tmpfs and may or may not exist
-# depending on the OS (ex: /var/lock/subsys does not exist on debian/ubuntu)
-for dir in "$FLUME_RUN_DIR" "$FLUME_LOCK_DIR"; do
-  [ -d "${dir}" ] || install -d -m 0755 -o $FLUME_USER -g $FLUME_USER ${dir}
-done
-
-DEFAULT_FLUME_NODE_NAME="agent"
-FLUME_NODE_NAME=${FLUME_NODE_NAME:-${DEFAULT_FLUME_NODE_NAME}}
-FLUME_SHUTDOWN_TIMEOUT=${FLUME_SHUTDOWN_TIMEOUT:-60}
-
-start() {
-  [ -x $exec ] || exit $ERROR_PROGRAM_NOT_INSTALLED
-
-  checkstatus
-  status=$?
-  if [ "$status" -eq "$STATUS_RUNNING" ]; then
-    exit 0
-  fi
-
-  log_success_msg "Starting $desc (flume-node): "
-  /bin/su -s /bin/bash -c "/bin/bash -c 'echo \$\$ > ${FLUME_PID_FILE} && exec ${EXEC_PATH} node --conf $FLUME_CONF_DIR --conf-file $FLUME_CONF_FILE --name $FLUME_NODE_NAME >>${FLUME_LOG_DIR}/flume-node.log 2>&1' &" $FLUME_USER
-  RETVAL=$?
-  [ $RETVAL -eq 0 ] && touch $LOCKFILE
-  return $RETVAL
-}
-
-stop() {
-  if [ ! -e $FLUME_PID_FILE ]; then
-    log_failure_msg "Flume node is not running"
-    exit 0
-  fi
-
-  log_success_msg "Stopping $desc (flume-node): "
-
-  FLUME_PID=`cat $FLUME_PID_FILE`
-  if [ -n $FLUME_PID ]; then
-    kill -TERM ${FLUME_PID} &>/dev/null
-    for i in `seq 1 ${FLUME_SHUTDOWN_TIMEOUT}` ; do
-      kill -0 ${FLUME_PID} &>/dev/null || break
-      sleep 1
-    done
-    kill -KILL ${FLUME_PID} &>/dev/null
-  fi
-  rm -f $LOCKFILE $FLUME_PID_FILE
-  return 0
-}
-
-restart() {
-  stop
-  start
-}
-
-checkstatus(){
-  pidofproc -p $FLUME_PID_FILE java > /dev/null
-  status=$?
-
-  case "$status" in
-    $STATUS_RUNNING)
-      log_success_msg "Flume NG node is running"
-      ;;
-    $STATUS_DEAD)
-      log_failure_msg "Flume NG node is dead and pid file exists"
-      ;;
-    $STATUS_DEAD_AND_LOCK)
-      log_failure_msg "Flume NG node is dead and lock file exists"
-      ;;
-    $STATUS_NOT_RUNNING)
-      log_failure_msg "Flume NG node is not running"
-      ;;
-    *)
-      log_failure_msg "Flume NG node status is unknown"
-      ;;
-  esac
-  return $status
-}
-
-condrestart(){
-  [ -e ${LOCKFILE} ] && restart || :
-}
-
-case "$1" in
-  start)
-    start
-    ;;
-  stop)
-    stop
-    ;;
-  status)
-    checkstatus
-    ;;
-  restart)
-    restart
-    ;;
-  condrestart|try-restart)
-    condrestart
-    ;;
-  *)
-    echo $"Usage: $0 {start|stop|status|restart|try-restart|condrestart}"
-    exit 1
-esac
-
-exit $RETVAL

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/common/flume/install_flume.sh
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/common/flume/install_flume.sh b/bigtop-packages/src/common/flume/install_flume.sh
index 8cbfab7..62f3db7 100755
--- a/bigtop-packages/src/common/flume/install_flume.sh
+++ b/bigtop-packages/src/common/flume/install_flume.sh
@@ -97,7 +97,7 @@ ETC_DIR=${ETC_DIR:-/etc/flume}
 install -d -m 0755 ${PREFIX}/${LIB_DIR}
 
 (cd ${PREFIX}/${LIB_DIR} &&
-  tar --strip-components=1 -xvzf ${BUILD_DIR}/flume-ng-dist/target/*flume-*-dist.tar.gz)
+  tar --strip-components=1 -xvzf ${BUILD_DIR}/flume-ng-dist/target/*flume-*-bin.tar.gz)
 
 # Take out useless things or we've installed elsewhere
 for x in flume-ng-* \
@@ -141,7 +141,7 @@ chmod 755 $wrapper
 install -d -m 0755 $PREFIX/$ETC_DIR/conf.empty
 (cd ${BUILD_DIR}/conf && tar cf - .) | (cd $PREFIX/$ETC_DIR/conf.empty && tar xf -)
 # XXX FIXME: We should handle this upstream more gracefully
-sed -i -e "s|flume\.log\.dir=.*|flume.log.dir=/var/log/flume-ng|" $PREFIX/$ETC_DIR/conf.empty/log4j.properties
+sed -i -e "s|flume\.log\.dir=.*|flume.log.dir=/var/log/flume|" $PREFIX/$ETC_DIR/conf.empty/log4j.properties
 touch $PREFIX/$ETC_DIR/conf.empty/flume.conf
 
 unlink $PREFIX/$LIB_DIR/conf || /bin/true

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/deb/flume/control
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/deb/flume/control b/bigtop-packages/src/deb/flume/control
index 541a35f..b053890 100644
--- a/bigtop-packages/src/deb/flume/control
+++ b/bigtop-packages/src/deb/flume/control
@@ -35,10 +35,10 @@ Description: Flume is a reliable, scalable, and manageable distributed log colle
  allows for intelligent dynamic management. It uses a simple extensible 
  data model that allows for online analytic applications.
 
-Package: flume-node
+Package: flume-agent
 Architecture: all
 Depends: flume (= ${source:Version})
-Description: The flume node daemon is a core element of flume's data path and is responsible for generating, processing, and delivering data.
+Description: The flume agent daemon is a core element of flume's data path and is responsible for generating, processing, and delivering data.
  Flume is a reliable, scalable, and manageable distributed data collection 
  application for collecting data such as logs and delivering it to data 
  stores such as Hadoop's HDFS.  It can efficiently collect, aggregate,

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/deb/flume/flume-agent.postinst
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/deb/flume/flume-agent.postinst b/bigtop-packages/src/deb/flume/flume-agent.postinst
new file mode 100644
index 0000000..091464a
--- /dev/null
+++ b/bigtop-packages/src/deb/flume/flume-agent.postinst
@@ -0,0 +1,26 @@
+#!/bin/sh
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#     http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+set -e
+if [ -x "/etc/init.d/flume-agent" ]; then
+  update-rc.d flume-agent defaults >/dev/null
+  if [ -x "`which invoke-rc.d 2>/dev/null`" ]; then
+    invoke-rc.d flume-agent start || :
+  else
+    /etc/init.d/flume-agent start || :
+  fi
+fi
+

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/deb/flume/flume-node.postinst
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/deb/flume/flume-node.postinst b/bigtop-packages/src/deb/flume/flume-node.postinst
deleted file mode 100644
index 04e0516..0000000
--- a/bigtop-packages/src/deb/flume/flume-node.postinst
+++ /dev/null
@@ -1,26 +0,0 @@
-#!/bin/sh
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-set -e
-if [ -x "/etc/init.d/flume-node" ]; then
-  update-rc.d flume-node defaults >/dev/null
-  if [ -x "`which invoke-rc.d 2>/dev/null`" ]; then
-    invoke-rc.d flume-node start || :
-  else
-    /etc/init.d/flume-node start || :
-  fi
-fi
-

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/deb/flume/flume.preinst
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/deb/flume/flume.preinst b/bigtop-packages/src/deb/flume/flume.preinst
index 20287a9..e78081c 100644
--- a/bigtop-packages/src/deb/flume/flume.preinst
+++ b/bigtop-packages/src/deb/flume/flume.preinst
@@ -37,12 +37,14 @@ case "$1" in
                 adduser \
                   --system \
                   --group \
-                  --home /var/run/flume \
+                  --home /var/lib/flume \
                   --gecos "Flume User" \
                   --shell /bin/false \
                   flume >/dev/null
         fi
         install -d -m 0755 -o flume -g flume /var/log/flume
+        install -d -m 0755 -o flume -g flume /var/run/flume
+        install -d -m 0755 -o flume -g flume /var/lib/flume
     ;;
 
     abort-upgrade)

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/deb/flume/rules
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/deb/flume/rules b/bigtop-packages/src/deb/flume/rules
index afe68b0..026d0f0 100755
--- a/bigtop-packages/src/deb/flume/rules
+++ b/bigtop-packages/src/deb/flume/rules
@@ -42,8 +42,8 @@ override_dh_auto_install:
 	sh -x debian/install_flume.sh \
 	  --build-dir=$${PWD} \
 	  --prefix=debian/flume
-	install -d -m 0755 debian/flume-node/etc/default
-	cp debian/flume-node.default debian/flume-node/etc/default/flume-node
+	install -d -m 0755 debian/flume-agent/etc/default
+	cp debian/flume-agent.default debian/flume-agent/etc/default/flume-agent
 	# Remove hadoop dependency and instead symlink in the hadoop jar
 	# rm debian/flume/usr/lib/flume/lib/hadoop-*
 	# ln -s /usr/lib/hadoop/hadoop-common.jar debian/flume/usr/lib/flume/lib/hadoop-common.jar

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-packages/src/rpm/flume/SPECS/flume.spec
----------------------------------------------------------------------
diff --git a/bigtop-packages/src/rpm/flume/SPECS/flume.spec b/bigtop-packages/src/rpm/flume/SPECS/flume.spec
index d81dc54..784d7a6 100644
--- a/bigtop-packages/src/rpm/flume/SPECS/flume.spec
+++ b/bigtop-packages/src/rpm/flume/SPECS/flume.spec
@@ -18,6 +18,9 @@
 %define lib_flume /usr/lib/flume
 %define log_flume /var/log/flume
 %define run_flume /var/run/flume
+%define vlb_flume /var/lib/flume
+
+%define flume_folder apache-%{name}-%{flume_base_version}-src
 
 %if  %{?suse_version:1}0
 
@@ -59,11 +62,11 @@ Group: Development/Libraries
 Buildroot: %{_topdir}/INSTALL/%{name}-%{version}
 BuildArch: noarch
 License: APL2
-Source0: apache-%{name}-%{flume_base_version}.tar.gz
+Source0: %{flume_folder}.tar.gz
 Source1: do-component-build
 Source2: install_%{name}.sh
-Source3: %{name}-node.init
-Source4: flume-node.default
+Source3: %{name}-agent.init
+Source4: flume-agent.default
 Requires: /usr/sbin/useradd
 Requires: coreutils
 Requires: hadoop-hdfs
@@ -78,8 +81,8 @@ Requires: sh-utils
 %description 
 Flume is a reliable, scalable, and manageable distributed data collection application for collecting data such as logs and delivering it to data stores such as Hadoop's HDFS.  It can efficiently collect, aggregate, and move large amounts of log data.  It has a simple, but flexible, architecture based on streaming data flows.  It is robust and fault tolerant with tunable reliability mechanisms and many failover and recovery mechanisms.  The system is centrally managed and allows for intelligent dynamic management. It uses a simple extensible data model that allows for online analytic applications.
 
-%package node
-Summary: The flume node daemon is a core element of flume's data path and is responsible for generating, processing, and delivering data.
+%package agent
+Summary: The flume agent daemon is a core element of flume's data path and is responsible for generating, processing, and delivering data.
 Group: Development/Libraries
 BuildArch: noarch
 Requires: %{name} = %{version}-%{release}
@@ -105,11 +108,11 @@ Requires: initscripts
 Requires: redhat-lsb
 %endif
 
-%description node
+%description agent
 Flume is a reliable, scalable, and manageable distributed data collection application for collecting data such as logs and delivering it to data stores such as Hadoop's HDFS.  It can efficiently collect, aggregate, and move large amounts of log data.  It has a simple, but flexible, architecture based on streaming data flows.  It is robust and fault tolerant with tunable reliability mechanisms and many failover and recovery mechanisms.  The system is centrally managed and allows for intelligent dynamic management. It uses a simple extensible data model that allows for online analytic applications.
 
 %prep
-%setup -n apache-%{name}-%{flume_base_version}
+%setup -n %{flume_folder}
 
 %build
 env FLUME_VERSION=%{version} sh %{SOURCE1}
@@ -124,7 +127,7 @@ sh %{SOURCE2} \
 
 
 # Install init script
-init_file=$RPM_BUILD_ROOT/%{initd_dir}/%{name}-node
+init_file=$RPM_BUILD_ROOT/%{initd_dir}/%{name}-agent
 %__cp %{SOURCE3} $init_file
 chmod 755 $init_file
 
@@ -132,7 +135,7 @@ chmod 755 $init_file
 %__install -d -m 0755 $RPM_BUILD_ROOT/usr/bin
 
 %__install -d -m 0755 $RPM_BUILD_ROOT/etc/default
-%__cp %{SOURCE4} $RPM_BUILD_ROOT/etc/default/%{name}-node
+%__cp %{SOURCE4} $RPM_BUILD_ROOT/etc/default/%{name}-agent
 
 # Get rid of hadoop jar, and instead link to installed hadoop
 rm $RPM_BUILD_ROOT/usr/lib/flume/lib/hadoop-* || true
@@ -141,8 +144,10 @@ ln -s /usr/lib/hadoop/hadoop-auth.jar $RPM_BUILD_ROOT/usr/lib/flume/lib/hadoop-a
 
 %pre
 getent group flume >/dev/null || groupadd -r flume
-getent passwd flume >/dev/null || useradd -c "Flume" -s /sbin/nologin -g flume -r -d %{run_flume} flume 2> /dev/null || :
+getent passwd flume >/dev/null || useradd -c "Flume" -s /sbin/nologin -g flume -r -d %{vlb_flume} flume 2> /dev/null || :
 %__install -d -o flume -g flume -m 0755 %{log_flume}
+%__install -d -o flume -g flume -m 0755 %{run_flume}
+%__install -d -o flume -g flume -m 0755 %{vlb_flume}
 
 # Manage configuration symlink
 %post
@@ -153,17 +158,17 @@ if [ "$1" = 0 ]; then
         %{alternatives_cmd} --remove %{name}-conf %{etc_flume}.empty || :
 fi
 
-%post node
-chkconfig --add %{name}-node
+%post agent
+chkconfig --add %{name}-agent
 
-%preun node
+%preun agent
 if [ $1 = 0 ] ; then
-        service %{name}-node stop > /dev/null 2>&1
-        chkconfig --del %{name}-node
+        service %{name}-agent stop > /dev/null 2>&1
+        chkconfig --del %{name}-agent
 fi
-%postun node
+%postun agent
 if [ $1 -ge 1 ]; then
-        service %{name}-node condrestart >/dev/null 2>&1
+        service %{name}-agent condrestart >/dev/null 2>&1
 fi
 
 
@@ -183,6 +188,6 @@ fi
 %{lib_flume}/lib/*.jar
 %{lib_flume}/conf
 
-%files node
-%attr(0755,root,root)/%{initd_dir}/%{name}-node
-%attr(0644,root,root) %config(noreplace) /etc/default/%{name}-node
+%files agent
+%attr(0755,root,root)/%{initd_dir}/%{name}-agent
+%attr(0644,root,root) %config(noreplace) /etc/default/%{name}-agent

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/CDHServices.groovy
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/CDHServices.groovy b/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/CDHServices.groovy
index 76e327c..c037b2e 100644
--- a/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/CDHServices.groovy
+++ b/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/CDHServices.groovy
@@ -55,7 +55,7 @@ class CDHServices {
                                         verifier : new StateVerifierOozie(),
                                       ],
                      flume          : [ services : [ "hadoop-namenode", "hadoop-datanode",
-                                                     "flume-master", "flume-node" ],
+                                                     "flume-master", "flume-agent" ],
                                         killIDs  : [ "hdfs", "flume" ],
                                         verifier : new StateVerifierFlume(),
                                       ],

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/DeployCDH.groovy
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/DeployCDH.groovy b/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/DeployCDH.groovy
index 23abf70..203a4f6 100644
--- a/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/DeployCDH.groovy
+++ b/bigtop-tests/test-artifacts/package/src/main/groovy/org/apache/bigtop/itest/packagesmoke/DeployCDH.groovy
@@ -33,7 +33,7 @@ class DeployCDH {
      "hadoop-0.20-pipes", "hadoop-0.20-secondarynamenode", "hadoop-0.20-source",
      "hadoop-0.20-tasktracker", "hadoop-hive", "hadoop-pig" ];
     List<String> cdh3b2 = [
-     "flume", "flume-master", "flume-node", "hadoop-0.20", "hadoop-0.20-conf-pseudo", "hadoop-0.20-conf-pseudo-hue",
+     "flume", "flume-master", "flume-agent", "hadoop-0.20", "hadoop-0.20-conf-pseudo", "hadoop-0.20-conf-pseudo-hue",
      "hadoop-0.20-datanode", "hadoop-0.20-fuse", "hadoop-0.20-jobtracker", "hadoop-0.20-namenode", "hadoop-0.20-native",
      "hadoop-0.20-pipes", "hadoop-0.20-secondarynamenode", "hadoop-0.20-source",
      "hadoop-0.20-tasktracker", "hadoop-hbase",
@@ -42,7 +42,7 @@ class DeployCDH {
      "hue-filebrowser", "hue-help", "hue-jobbrowser", "hue-jobsub", "hue-plugins", "hue-proxy",
      "hue-useradmin", "oozie", "sqoop" ];
     List<String> cdh3b3 = [
-     "flume", "flume-master", "flume-node", "hadoop-0.20", "hadoop-0.20-conf-pseudo",
+     "flume", "flume-master", "flume-agent", "hadoop-0.20", "hadoop-0.20-conf-pseudo",
      "hadoop-0.20-datanode", "hadoop-0.20-fuse", "hadoop-0.20-jobtracker", "hadoop-0.20-namenode", "hadoop-0.20-native",
      "hadoop-0.20-pipes", "hadoop-0.20-sbin", "hadoop-0.20-secondarynamenode", "hadoop-0.20-source",
      "hadoop-0.20-tasktracker", "hadoop-hbase", "hadoop-hbase-doc",

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-agent.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-agent.xml b/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-agent.xml
new file mode 100644
index 0000000..1c8d760
--- /dev/null
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-agent.xml
@@ -0,0 +1,14 @@
+<flume-agent>
+  <content>
+    <file name='/.' owners='1' perm='drwxr-xr-x' user='root' group='root' />
+    <file name='/usr' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
+    <file name='/usr/share' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
+    <file name='/usr/share/doc' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
+    <file name='/usr/share/doc/flume-agent' owners='1' perm='drwxr-xr-x' user='root' group='root' />
+    <file name='/usr/share/doc/flume-agent/changelog.Debian.gz' owners='1' perm='-rw-r--r--' user='root' group='root' />
+    <file name='/usr/share/doc/flume-agent/copyright' owners='1' perm='-rw-r--r--' user='root' group='root' />
+    <file name='/etc' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
+    <file name='/etc/init.d' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
+    <config name='/etc/init.d/flume-agent' owners='1' perm='-rwxr-xr-x' user='root' group='root' />
+  </content>
+</flume-agent>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-node.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-node.xml b/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-node.xml
deleted file mode 100644
index c5e9607..0000000
--- a/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume-node.xml
+++ /dev/null
@@ -1,14 +0,0 @@
-<flume-node>
-  <content>
-    <file name='/.' owners='1' perm='drwxr-xr-x' user='root' group='root' />
-    <file name='/usr' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
-    <file name='/usr/share' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
-    <file name='/usr/share/doc' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
-    <file name='/usr/share/doc/flume-node' owners='1' perm='drwxr-xr-x' user='root' group='root' />
-    <file name='/usr/share/doc/flume-node/changelog.Debian.gz' owners='1' perm='-rw-r--r--' user='root' group='root' />
-    <file name='/usr/share/doc/flume-node/copyright' owners='1' perm='-rw-r--r--' user='root' group='root' />
-    <file name='/etc' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
-    <file name='/etc/init.d' owners='-1' perm='drwxr-xr-x' user='root' group='root' />
-    <config name='/etc/init.d/flume-node' owners='1' perm='-rwxr-xr-x' user='root' group='root' />
-  </content>
-</flume-node>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume.xml b/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume.xml
index 5ed75e3..ca027f2 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/apt/flume.xml
@@ -23,7 +23,6 @@
     <file name='/usr/lib/flume/lib/flume-file-channel-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-irc-sink-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-jdbc-channel-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
-    <file name='/usr/lib/flume/lib/flume-ng-node-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/jasper-compiler-5.5.23.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/commons-dbcp-1.4.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/jaxb-api-2.2.2.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
@@ -105,4 +104,4 @@
     <file name='/usr/lib/flume/lib/hadoop-common.jar' owners='1' perm='lrwxrwxrwx' user='root' group='root' target='../../hadoop/hadoop-common.jar' />
     <file name='/usr/lib/flume/conf' owners='1' perm='lrwxrwxrwx' user='root' group='root' target='/etc/flume/conf' />
   </content>
-</flume>
\ No newline at end of file
+</flume>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/apt/package_data.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/apt/package_data.xml b/bigtop-tests/test-artifacts/package/src/main/resources/apt/package_data.xml
index 4ad1c4d..4701640 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/apt/package_data.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/apt/package_data.xml
@@ -28,7 +28,7 @@
       <adduser/>
     </deps>
   </flume>
-  <flume-node>
+  <flume-agent>
     <deps>
       <tag name="/bin/bash"/>
       <tag name="/bin/sh"/>
@@ -41,16 +41,16 @@
       <textutils/>
     </deps>
     <services>
-      <flume-node>
+      <flume-agent>
         <runlevel>2</runlevel>
         <runlevel>3</runlevel>
         <runlevel>4</runlevel>
         <runlevel>5</runlevel>
         <oninstall>start</oninstall>
         <configured>true</configured>
-      </flume-node>
+      </flume-agent>
     </services>
-  </flume-node>
+  </flume-agent>
   <solr>
     <users>
     </users>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/package_data.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/package_data.xml b/bigtop-tests/test-artifacts/package/src/main/resources/package_data.xml
index 156b6b7..17b0baa 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/package_data.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/package_data.xml
@@ -140,16 +140,16 @@ Java Servlet and JavaServer Pages technologies.</description>
       </flume-conf>
     </alternatives>
   </flume>
-  <flume-node>
+  <flume-agent>
     <metadata>
-      <summary>The flume node daemon is a core element of flume's data path and is responsible for generating, processing, and delivering data.</summary>
+      <summary>The flume agent daemon is a core element of flume's data path and is responsible for generating, processing, and delivering data.</summary>
       <description>Flume is a reliable, scalable, and manageable distributed data collection application for collecting data such as logs and delivering it to data stores such as Hadoop's HDFS. It can efficiently collect, aggregate, and move large amounts of log data. It has a simple, but flexible, architecture based on streaming data flows. It is robust and fault tolerant with tunable reliability mechanisms and many failover and recovery mechanisms. The system is centrally managed and allows for intelligent dynamic management. It uses a simple extensible data model that allows for online analytic applications.</description>
       <url>http://incubator.apache.org/projects/flume.html</url>
     </metadata>
     <deps>
       <flume>/self</flume>
     </deps>
-  </flume-node>
+  </flume-agent>
   <solr>
     <metadata>
       <summary>Apache Solr is the popular, blazing fast open source enterprise search platform</summary>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/urpmi/package_data.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/urpmi/package_data.xml b/bigtop-tests/test-artifacts/package/src/main/resources/urpmi/package_data.xml
index 1705877..456d9d3 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/urpmi/package_data.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/urpmi/package_data.xml
@@ -942,7 +942,7 @@
     <file name="/usr/share/doc/flume/man" owners="1" perm="drwxr-xr-x" user="flume" group="flume"/>
     <doc  name="/usr/share/doc/flume/man/flume.1" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
     <doc  name="/usr/share/doc/flume/man/flume-master.1" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
-    <doc  name="/usr/share/doc/flume/man/flume-node.1" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
+    <doc  name="/usr/share/doc/flume/man/flume-agent.1" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
     <doc  name="/usr/share/doc/flume/man/flume-shell.1" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
     <file name="/usr/share/doc/flume/UserGuide" owners="1" perm="drwxr-xr-x" user="flume" group="flume"/>
     <doc  name="/usr/share/doc/flume/UserGuide/architecture.png" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
@@ -1044,7 +1044,7 @@
     <doc  name="/usr/share/doc/flume/Windows/index.txt" owners="1" perm="-rw-r--r--" user="flume" group="flume"/>
     <doc  name="/usr/share/man/man1/flume.1.gz" owners="1" perm="-rw-r--r--" user="root" group="root"/>
     <doc  name="/usr/share/man/man1/flume-master.1.gz" owners="1" perm="-rw-r--r--" user="root" group="root"/>
-    <doc  name="/usr/share/man/man1/flume-node.1.gz" owners="1" perm="-rw-r--r--" user="root" group="root"/>
+    <doc  name="/usr/share/man/man1/flume-agent.1.gz" owners="1" perm="-rw-r--r--" user="root" group="root"/>
     <doc  name="/usr/share/man/man1/flume-shell.1.gz" owners="1" perm="-rw-r--r--" user="root" group="root"/>
   </content>
 </flume>
@@ -1068,7 +1068,7 @@
     <file name="/usr/lib/flume/bin/flume-daemon.sh" owners="2" perm="-rwxr-xr-x" user="root" group="root"/>
   </content>
 </flume-master>
-<flume-node>
+<flume-agent>
   <deps>
     <tag name="/bin/bash"/>
     <tag name="/bin/sh"/>
@@ -1082,12 +1082,12 @@
     <textutils/>
   </deps>
   <content>
-    <file name="/etc/rc.d/init.d/flume-node" owners="1" perm="-rwxr-xr-x" user="root" group="root"/>
+    <file name="/etc/rc.d/init.d/flume-agent" owners="1" perm="-rwxr-xr-x" user="root" group="root"/>
     <file name="/usr/lib/flume" owners="3" perm="drwxr-xr-x" user="root" group="root"/>
     <file name="/usr/lib/flume/bin" owners="3" perm="drwxr-xr-x" user="root" group="root"/>
     <file name="/usr/lib/flume/bin/flume-daemon.sh" owners="3" perm="-rwxr-xr-x" user="root" group="root"/>
   </content>
-</flume-node>
+</flume-agent>
 <sqoop>
   <deps>
     <tag name="/bin/bash"/>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-agent.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-agent.xml b/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-agent.xml
new file mode 100644
index 0000000..4260450
--- /dev/null
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-agent.xml
@@ -0,0 +1,5 @@
+<flume-agent>
+  <content>
+    <file name='/etc/rc.d/init.d/flume-agent' owners='1' perm='-rwxr-xr-x' user='root' group='root' />
+  </content>
+</flume-agent>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-node.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-node.xml b/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-node.xml
deleted file mode 100644
index 4829d21..0000000
--- a/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume-node.xml
+++ /dev/null
@@ -1,5 +0,0 @@
-<flume-node>
-  <content>
-    <file name='/etc/rc.d/init.d/flume-node' owners='1' perm='-rwxr-xr-x' user='root' group='root' />
-  </content>
-</flume-node>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume.xml b/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume.xml
index 582f09e..2b1e8ce 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/yum/flume.xml
@@ -43,7 +43,6 @@
     <file name='/usr/lib/flume/lib/flume-jdbc-channel-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-ng-core-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-ng-log4jappender-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
-    <file name='/usr/lib/flume/lib/flume-ng-node-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-ng-sdk-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-thrift-source-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/guava-10.0.1.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
@@ -95,4 +94,4 @@
     <doc  name='/usr/share/doc/flume-BIGTOP-PACKAGE-VERSION/README' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <doc  name='/usr/share/doc/flume-BIGTOP-PACKAGE-VERSION/RELEASE-NOTES' owners='1' perm='-rw-r--r--' user='root' group='root' />
   </content>
-</flume>
\ No newline at end of file
+</flume>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/yum/package_data.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/yum/package_data.xml b/bigtop-tests/test-artifacts/package/src/main/resources/yum/package_data.xml
index 5283583..96906d6 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/yum/package_data.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/yum/package_data.xml
@@ -45,7 +45,7 @@
       <textutils/>
     </deps>
   </flume>
-  <flume-node>
+  <flume-agent>
     <deps>
       <tag name="/bin/bash"/>
       <tag name="/bin/sh"/>
@@ -59,15 +59,15 @@
       <textutils/>
     </deps>
     <services>
-      <flume-node>
+      <flume-agent>
         <runlevel>3</runlevel>
         <runlevel>4</runlevel>
         <runlevel>5</runlevel>
         <oninstall>stop</oninstall>
         <configured>true</configured>
-      </flume-node>
+      </flume-agent>
     </services>
-  </flume-node>
+  </flume-agent>
   <solr>
     <users>
     </users>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-agent.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-agent.xml b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-agent.xml
new file mode 100644
index 0000000..b7eafce
--- /dev/null
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-agent.xml
@@ -0,0 +1,5 @@
+<flume-agent>
+  <content>
+    <file name='/etc/rc.d/flume-agent' owners='1' perm='-rwxr-xr-x' user='root' group='root' />
+  </content>
+</flume-agent>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-node.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-node.xml b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-node.xml
deleted file mode 100644
index d88314e..0000000
--- a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume-node.xml
+++ /dev/null
@@ -1,5 +0,0 @@
-<flume-node>
-  <content>
-    <file name='/etc/rc.d/flume-node' owners='1' perm='-rwxr-xr-x' user='root' group='root' />
-  </content>
-</flume-node>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume.xml b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume.xml
index 8db4f98..b460e28 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/flume.xml
@@ -43,7 +43,6 @@
     <file name='/usr/lib/flume/lib/flume-jdbc-channel-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-ng-core-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-ng-log4jappender-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
-    <file name='/usr/lib/flume/lib/flume-ng-node-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-ng-sdk-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/flume-thrift-source-1.1.0-incubating.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <file name='/usr/lib/flume/lib/guava-10.0.1.jar' owners='1' perm='-rw-r--r--' user='root' group='root' />
@@ -95,4 +94,4 @@
     <doc  name='/usr/share/doc/packages/flume/README' owners='1' perm='-rw-r--r--' user='root' group='root' />
     <doc  name='/usr/share/doc/packages/flume/RELEASE-NOTES' owners='1' perm='-rw-r--r--' user='root' group='root' />
   </content>
-</flume>
\ No newline at end of file
+</flume>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop-tests/test-artifacts/package/src/main/resources/zypper/package_data.xml
----------------------------------------------------------------------
diff --git a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/package_data.xml b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/package_data.xml
index 85f7043..66c1939 100644
--- a/bigtop-tests/test-artifacts/package/src/main/resources/zypper/package_data.xml
+++ b/bigtop-tests/test-artifacts/package/src/main/resources/zypper/package_data.xml
@@ -45,7 +45,7 @@
       <tag name="/usr/bin/env"/>
     </deps>
   </flume>
-  <flume-node>
+  <flume-agent>
     <deps>
       <sh-utils/>
       <textutils/>
@@ -59,15 +59,15 @@
       <tag name="/usr/bin/env"/>
     </deps>
     <services>
-      <flume-node>
+      <flume-agent>
         <runlevel>3</runlevel>
         <runlevel>4</runlevel>
         <runlevel>5</runlevel>
         <oninstall>stop</oninstall>
         <configured>true</configured>
-      </flume-node>
+      </flume-agent>
     </services>
-  </flume-node>
+  </flume-agent>
   <solr>
     <users>
     </users>

http://git-wip-us.apache.org/repos/asf/bigtop/blob/ed925d88/bigtop.mk
----------------------------------------------------------------------
diff --git a/bigtop.mk b/bigtop.mk
index 48f814c..429d498 100644
--- a/bigtop.mk
+++ b/bigtop.mk
@@ -144,12 +144,12 @@ $(eval $(call PACKAGE,mahout,MAHOUT))
 FLUME_NAME=flume
 FLUME_RELNOTES_NAME=Flume
 FLUME_PKG_NAME=flume
-FLUME_BASE_VERSION=1.1.0-incubating
-FLUME_PKG_VERSION=1.1.0
+FLUME_BASE_VERSION=1.3.0
+FLUME_PKG_VERSION=1.3.0
 FLUME_RELEASE_VERSION=1
-FLUME_TARBALL_DST=apache-$(FLUME_NAME)-$(FLUME_BASE_VERSION).tar.gz
-FLUME_TARBALL_SRC=apache-$(FLUME_NAME)-$(FLUME_BASE_VERSION).tar.gz
-FLUME_DOWNLOAD_PATH=/incubator/flume/$(FLUME_PKG_NAME)-$(FLUME_BASE_VERSION)
+FLUME_TARBALL_DST=apache-$(FLUME_NAME)-$(FLUME_BASE_VERSION)-src.tar.gz
+FLUME_TARBALL_SRC=$(FLUME_TARBALL_DST)
+FLUME_DOWNLOAD_PATH=/flume/$(FLUME_BASE_VERSION)
 FLUME_SITE=$(APACHE_MIRROR)$(FLUME_DOWNLOAD_PATH)
 FLUME_ARCHIVE=$(APACHE_ARCHIVE)$(FLUME_DOWNLOAD_PATH)
 $(eval $(call PACKAGE,flume,FLUME))