You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@bigtop.apache.org by se...@apache.org on 2021/03/17 14:15:21 UTC

[bigtop] branch master updated: BIGTOP-3520. Drop ignite-hadoop. (#756)

This is an automated email from the ASF dual-hosted git repository.

sekikn pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/bigtop.git


The following commit(s) were added to refs/heads/master by this push:
     new ecbe340  BIGTOP-3520. Drop ignite-hadoop. (#756)
ecbe340 is described below

commit ecbe340a31f55b2d864eee32215fe5f5d477eac1
Author: Masatake Iwasaki <iw...@apache.org>
AuthorDate: Wed Mar 17 23:15:14 2021 +0900

    BIGTOP-3520. Drop ignite-hadoop. (#756)
---
 bigtop-ci/jenkins/jobsCreator.groovy               |   2 +-
 bigtop-deploy/puppet/README.md                     |   4 -
 bigtop-deploy/puppet/hieradata/site.yaml           |   1 -
 bigtop-deploy/puppet/manifests/cluster.pp          |   4 -
 .../puppet/modules/ignite_hadoop/manifests/init.pp |  83 --------
 .../modules/ignite_hadoop/templates/core-site.xml  |  65 ------
 .../ignite_hadoop/templates/default-config.xml     | 191 -----------------
 .../modules/ignite_hadoop/templates/hive-site.xml  |  33 ---
 .../modules/ignite_hadoop/templates/ignite-hadoop  |  21 --
 .../ignite_hadoop/templates/mapred-site.xml        |  63 ------
 .../puppet/modules/ignite_hadoop/tests/init.pp     |  16 --
 .../modules/zeppelin/templates/interpreter.json    |  25 ---
 .../src/common/ignite-hadoop/do-component-build    |  44 ----
 .../src/common/ignite-hadoop/ignite-hadoop.1       |  59 ------
 .../src/common/ignite-hadoop/ignite-hadoop.default |  24 ---
 .../src/common/ignite-hadoop/ignite-hadoop.svc     |  63 ------
 .../src/common/ignite-hadoop/install_ignite.sh     | 149 --------------
 .../common/ignite-hadoop/patch0-shmem-config.diff  |  14 --
 bigtop-packages/src/deb/ignite-hadoop/compat       |   1 -
 bigtop-packages/src/deb/ignite-hadoop/control      |  39 ----
 bigtop-packages/src/deb/ignite-hadoop/copyright    |  15 --
 bigtop-packages/src/deb/ignite-hadoop/format       |   1 -
 .../src/deb/ignite-hadoop/ignite-hadoop-doc.dirs   |   1 -
 .../src/deb/ignite-hadoop/ignite-hadoop.dirs       |   3 -
 .../src/deb/ignite-hadoop/ignite-hadoop.install    |   3 -
 .../src/deb/ignite-hadoop/ignite-hadoop.manpages   |   1 -
 .../src/deb/ignite-hadoop/ignite-hadoop.postinst   |  47 -----
 .../src/deb/ignite-hadoop/ignite-hadoop.preinst    |  62 ------
 .../src/deb/ignite-hadoop/ignite-hadoop.prerm      |  55 -----
 bigtop-packages/src/deb/ignite-hadoop/rules        |  46 -----
 .../src/deb/ignite-hadoop/source/format            |   1 -
 bigtop-packages/src/deb/logstash/copyright         |   2 +-
 bigtop-packages/src/deb/logstash/logstash.preinst  |   2 +-
 bigtop-packages/src/deb/logstash/logstash.prerm    |   2 +-
 bigtop-packages/src/deb/zeppelin/control           |   2 +-
 .../src/rpm/ignite-hadoop/SPECS/ignite-hadoop.spec | 225 ---------------------
 .../ignite-hadoop/TestIgniteHadoop.groovy          |  72 -------
 .../smoke-tests/ignite-hadoop/build.gradle         |  34 ----
 .../smoke-tests/ignite-hadoop/conf/core-site.xml   |  90 ---------
 .../ignite-hadoop/conf/log4j.properties            |  24 ---
 .../smoke-tests/ignite-hadoop/conf/mapred-site.xml |  66 ------
 bigtop-tests/smoke-tests/ignite-hadoop/test.data   |  11 -
 .../package/src/main/resources/package_data.xml    |  43 +---
 bigtop.bom                                         |  14 +-
 build.gradle                                       |   1 -
 docker/sandbox/README.md                           |  16 +-
 46 files changed, 11 insertions(+), 1729 deletions(-)

diff --git a/bigtop-ci/jenkins/jobsCreator.groovy b/bigtop-ci/jenkins/jobsCreator.groovy
index 824d8c4..b36dcc2 100644
--- a/bigtop-ci/jenkins/jobsCreator.groovy
+++ b/bigtop-ci/jenkins/jobsCreator.groovy
@@ -18,7 +18,7 @@
 // FIXME: it would be nice to extract the following from bigtop.mk on the fly
 def bigtopComponents = ["bigtop-groovy", "bigtop-jsvc", "bigtop-tomcat", "bigtop-utils",
                         "zookeeper", "hadoop", "hbase", "hive", "pig",
-                        "ignite-hadoop", "oozie", "phoenix",
+                        "oozie", "phoenix",
                         "solr", "spark", "sqoop", "alluxio", "whirr"]
 // FIXME: it would be nice to extract the following from some static configuration file
 def targetOS = ["fedora-20",  "opensuse-12.3",  "ubuntu-14.04"]
diff --git a/bigtop-deploy/puppet/README.md b/bigtop-deploy/puppet/README.md
index 5c15bfb..d30ddca 100644
--- a/bigtop-deploy/puppet/README.md
+++ b/bigtop-deploy/puppet/README.md
@@ -131,7 +131,6 @@ hadoop::hadoop_storage_dirs:
   - "/data/1"
   - "/data/2"
 hadoop_cluster_node::cluster_components:
-  - ignite_hadoop
   - hive
   - spark
   - yarn
@@ -143,9 +142,6 @@ And finally execute
 ```
 puppet apply -d --parser future --modulepath="bigtop-deploy/puppet/modules:/etc/puppet/modules" bigtop-deploy/puppet/manifests
 ```
-When ignite-hadoop accelerator is deployed the client configs are placed under
-`/etc/hadoop/ignite.client.conf`. All one needs to do to run Mapreduce jobs on ignite-hadoop grid
-is to set `HADOOP_CONF_DIR=/etc/hadoop/ignite.client.conf` in the client session.
 
 ## Passwords
 
diff --git a/bigtop-deploy/puppet/hieradata/site.yaml b/bigtop-deploy/puppet/hieradata/site.yaml
index 742a8e1..4081b2e 100644
--- a/bigtop-deploy/puppet/hieradata/site.yaml
+++ b/bigtop-deploy/puppet/hieradata/site.yaml
@@ -16,7 +16,6 @@ hadoop::hadoop_storage_dirs:
 #  - ambari
 #  - flink
 #  - gpdb
-#  - ignite_hadoop
 #  - hbase
 #  - hcat
 #  - hive
diff --git a/bigtop-deploy/puppet/manifests/cluster.pp b/bigtop-deploy/puppet/manifests/cluster.pp
index 4142549..a65fb9e 100644
--- a/bigtop-deploy/puppet/manifests/cluster.pp
+++ b/bigtop-deploy/puppet/manifests/cluster.pp
@@ -62,9 +62,6 @@ $roles_map = {
     worker => ["hbase-server"],
     client => ["hbase-client"],
   },
-  ignite_hadoop => {
-    worker => ["ignite-server"],
-  },
   solrcloud => {
     worker => ["solr-server"],
   },
@@ -201,7 +198,6 @@ class node_with_roles ($roles = hiera("bigtop::roles")) inherits hadoop_cluster_
     "flink",
     "hadoop",
     "hadoop_hbase",
-    "ignite_hadoop",
     "hadoop_hive",
     "hadoop_oozie",
     "hadoop_zookeeper",
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/manifests/init.pp b/bigtop-deploy/puppet/modules/ignite_hadoop/manifests/init.pp
deleted file mode 100644
index ffe7db3..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/manifests/init.pp
+++ /dev/null
@@ -1,83 +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.
-
-class ignite_hadoop {
-  class deploy ($roles) {
-    if ("ignite-server" in $roles) {
-      ignite_hadoop::server { "ignite-hadoop-node": }
-    }
-  }
-
-  define server() {
-    $hadoop_head_node = hiera("bigtop::hadoop_head_node")
-    $hadoop_namenode_port = hiera("hadoop::common_hdfs::hadoop_namenode_port", "8020")
-
-    package { "ignite-hadoop":
-      ensure => latest,
-    }
-
-    package { "ignite-hadoop-service":
-      ensure => latest,
-    }
-
-    file { "/etc/default/ignite-hadoop":
-      content => template("ignite_hadoop/ignite-hadoop"),
-      require => Package["ignite-hadoop"],
-    }
-
-    file { "/etc/hadoop/ignite.client.conf":
-      ensure  => directory,
-      owner   => 'root',
-      group   => 'root',
-      mode    => '0755',
-      require => Package["ignite-hadoop-service"],
-    }
-    file { "/etc/ignite-hadoop/conf/default-config.xml":
-        content => template('ignite_hadoop/default-config.xml'),
-        require => [Package["ignite-hadoop"]],
-    }
-    file { "/etc/hadoop/ignite.client.conf/core-site.xml":
-        content => template('ignite_hadoop/core-site.xml'),
-        require => [File["/etc/hadoop/ignite.client.conf"]],
-    }
-    file {
-      "/etc/hadoop/ignite.client.conf/mapred-site.xml":
-        content => template('ignite_hadoop/mapred-site.xml'),
-        require => [File["/etc/hadoop/ignite.client.conf"]],
-    }
-    file {
-      "/etc/hadoop/ignite.client.conf/hive-site.xml":
-        content => template('ignite_hadoop/hive-site.xml'),
-        require => [File["/etc/hadoop/ignite.client.conf"]],
-    }
-## let's make sure that ignite-hadoop libs are linked properly
-    file {'/usr/lib/hadoop/lib/ignite-core.jar':
-      ensure  => link,
-      target  => '/usr/lib/ignite-hadoop/libs/ignite-core.jar',
-      require => [Package["ignite-hadoop-service"]],
-    }
-    file {'/usr/lib/hadoop/lib/ignite-hadoop.jar':
-      ensure  => link,
-      target  => '/usr/lib/ignite-hadoop/libs/ignite-hadoop/ignite-hadoop.jar',
-      require => [Package["ignite-hadoop-service"]],
-    }
-
-    service { "ignite-hadoop-service":
-      ensure  => running,
-      require => [ Package["ignite-hadoop", "ignite-hadoop-service"], File["/etc/default/ignite-hadoop"] ],
-      subscribe => [ Package["ignite-hadoop"], File["/etc/default/ignite-hadoop", "/etc/ignite-hadoop/conf/default-config.xml"] ]
-    }
-  }
-}
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/core-site.xml b/bigtop-deploy/puppet/modules/ignite_hadoop/templates/core-site.xml
deleted file mode 100644
index a6edb36..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/core-site.xml
+++ /dev/null
@@ -1,65 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  Licensed under the Apache License, Version 2.0 (the "License");
-  you may not use this file except in compliance with the License.
-  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License. See accompanying LICENSE file.
--->
-
-<!--
-    This template file contains settings needed to run Apache Hadoop jobs
-    with Ignite's distributed in-memory file system GGFS.
-
-    You can replace '$HADOOP_HOME/etc/hadoop/core-site.xml' file with this one
-    to work with Ignite IGFS nodes running on localhost (these local nodes can be
-    a part of distributed cluster though). To work with file system on remote
-    hosts you need to change the host of file system URI to any host running
-    Ignite's IGFS node.
-
-    Note that Ignite jars must be in Apache Hadoop client classpath to work
-    with this configuration.
-
-    Run script '$IGNITE_HOME/bin/setup-hadoop.{sh|bat}' for Apache Hadoop client setup.
--->
-
-<configuration>
-    <!--
-        Set default file system to IGFS instance named "igfs" configured in Ignite.
-    -->
-    <property>
-        <name>fs.defaultFS</name>
-        <value>igfs://igfs@localhost</value>
-    </property>
-
-    <!--
-        Set Hadoop 1.* file system implementation class for GGFS.
-    -->
-    <property>
-        <name>fs.igfs.impl</name>
-        <value>org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem</value>
-    </property>
-
-    <!--
-        Set Hadoop 2.* file system implementation class for GGFS.
-    -->
-    <property>
-        <name>fs.AbstractFileSystem.igfs.impl</name>
-        <value>org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem</value>
-    </property>
-
-    <!--
-        Disallow data node replacement since it does not make sense for Ignite's IGFS nodes.
-    -->
-    <property>
-        <name>dfs.client.block.write.replace-datanode-on-failure.policy</name>
-        <value>NEVER</value>
-    </property>
-</configuration>
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/default-config.xml b/bigtop-deploy/puppet/modules/ignite_hadoop/templates/default-config.xml
deleted file mode 100644
index c31cdcb..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/default-config.xml
+++ /dev/null
@@ -1,191 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  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.
--->
-<beans xmlns="http://www.springframework.org/schema/beans"
-       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:util="http://www.springframework.org/schema/util"
-       xsi:schemaLocation="http://www.springframework.org/schema/beans
-       http://www.springframework.org/schema/beans/spring-beans.xsd
-       http://www.springframework.org/schema/util
-       http://www.springframework.org/schema/util/spring-util.xsd">
-
-  <!--
-      Optional description.
-  -->
-  <description>
-    Spring file for Ignite node configuration with IGFS and Apache Hadoop map-reduce support enabled.
-    Ignite node will start with this configuration by default.
-  </description>
-
-  <!--
-      Initialize property configurer so we can reference environment variables.
-  -->
-  <bean id="propertyConfigurer" class="org.springframework.beans.factory.config.PropertyPlaceholderConfigurer">
-    <property name="systemPropertiesModeName" value="SYSTEM_PROPERTIES_MODE_FALLBACK"/>
-    <property name="searchSystemEnvironment" value="true"/>
-  </bean>
-
-  <!--
-      Abstract IGFS file system configuration to be used as a template.
-  -->
-  <bean id="igfsCfgBase" class="org.apache.ignite.configuration.FileSystemConfiguration" abstract="true">
-    <!-- Must correlate with cache affinity mapper. -->
-    <property name="blockSize" value="#{128 * 1024}"/>
-    <property name="perNodeBatchSize" value="512"/>
-    <property name="perNodeParallelBatchCount" value="16"/>
-
-    <property name="prefetchBlocks" value="32"/>
-  </bean>
-
-  <!--
-      Abstract cache configuration for IGFS file data to be used as a template.
-  -->
-  <bean id="dataCacheCfgBase" class="org.apache.ignite.configuration.CacheConfiguration" abstract="true">
-    <property name="cacheMode" value="PARTITIONED"/>
-    <property name="atomicityMode" value="TRANSACTIONAL"/>
-    <property name="writeSynchronizationMode" value="FULL_SYNC"/>
-    <property name="backups" value="0"/>
-    <property name="affinityMapper">
-      <bean class="org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper">
-        <!-- How many sequential blocks will be stored on the same node. -->
-        <constructor-arg value="512"/>
-      </bean>
-    </property>
-  </bean>
-
-  <!--
-      Abstract cache configuration for IGFS metadata to be used as a template.
-  -->
-  <bean id="metaCacheCfgBase" class="org.apache.ignite.configuration.CacheConfiguration" abstract="true">
-    <property name="cacheMode" value="REPLICATED"/>
-    <property name="atomicityMode" value="TRANSACTIONAL"/>
-    <property name="writeSynchronizationMode" value="FULL_SYNC"/>
-  </bean>
-
-  <!--
-      Configuration of Ignite node.
-  -->
-  <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration">
-    <!--
-        Apache Hadoop Accelerator configuration.
-    -->
-    <property name="hadoopConfiguration">
-      <bean class="org.apache.ignite.configuration.HadoopConfiguration">
-        <!-- Information about finished jobs will be kept for 30 seconds. -->
-        <property name="finishedJobInfoTtl" value="30000"/>
-      </bean>
-    </property>
-
-    <!--
-        This port will be used by Apache Hadoop client to connect to Ignite node as if it was a job tracker.
-    -->
-    <property name="connectorConfiguration">
-      <bean class="org.apache.ignite.configuration.ConnectorConfiguration">
-        <property name="port" value="11211"/>
-      </bean>
-    </property>
-
-    <!--
-        Configure one IGFS file system instance named "igfs" on this node.
-    -->
-    <property name="fileSystemConfiguration">
-      <list>
-        <bean class="org.apache.ignite.configuration.FileSystemConfiguration" parent="igfsCfgBase">
-          <property name="name" value="igfs"/>
-
-          <!-- Remove the Ignite-2.7.6 deprecated property .
-          <property name="metaCacheName" value="igfs-meta"/>
-          <property name="dataCacheName" value="igfs-data"/>
-          -->
-
-          <!-- Configure TCP endpoint for communication with the file system instance. -->
-          <property name="ipcEndpointConfiguration">
-            <bean class="org.apache.ignite.igfs.IgfsIpcEndpointConfiguration">
-              <property name="type" value="TCP" />
-              <property name="host" value="0.0.0.0" />
-              <property name="port" value="10500" />
-            </bean>
-	  </property>
-          <property name="secondaryFileSystem">
-            <bean class="org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem">
-              <property name="fileSystemFactory">
-                <bean class="org.apache.ignite.hadoop.fs.CachingHadoopFileSystemFactory">
-                  <!-- ATTN: The trailing slash in the url is very important work around for a bug
-                  in the Ignite's URL parsing logic. It might get fixed in Ignite 2.1, though
-                  See https://is.gd/8c2LQY for more info -->
-                    <property name="uri" value='hdfs://<%= @hadoop_head_node %>:<%= @hadoop_namenode_port %>/'/>
-                  <property name="configPaths">
-                    <list>
-                      <value>/etc/hadoop/conf/core-site.xml</value>
-                    </list>
-                  </property>
-                </bean>
-              </property>
-              <property name="defaultUserName" value="ignite"/>
-            </bean>
-          </property>
-        </bean>
-      </list>
-    </property>
-
-    <!--
-        Caches needed by IGFS.
-    -->
-    <property name="cacheConfiguration">
-      <list>
-        <!-- File system metadata cache. -->
-        <bean class="org.apache.ignite.configuration.CacheConfiguration" parent="metaCacheCfgBase">
-          <property name="name" value="igfs-meta"/>
-        </bean>
-
-        <!-- File system files data cache. -->
-        <bean class="org.apache.ignite.configuration.CacheConfiguration" parent="dataCacheCfgBase">
-          <property name="name" value="igfs-data"/>
-        </bean>
-      </list>
-    </property>
-
-    <!--
-        Disable events.
-    -->
-    <property name="includeEventTypes">
-      <list>
-        <util:constant static-field="org.apache.ignite.events.EventType.EVT_TASK_FAILED"/>
-        <util:constant static-field="org.apache.ignite.events.EventType.EVT_TASK_FINISHED"/>
-        <util:constant static-field="org.apache.ignite.events.EventType.EVT_JOB_MAPPED"/>
-      </list>
-    </property>
-
-    <!--
-        TCP discovery SPI can be configured with list of addresses if multicast is not available.
-    -->
-    <!--
-    <property name="discoverySpi">
-        <bean class="org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi">
-            <property name="ipFinder">
-                <bean class="org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder">
-                    <property name="addresses">
-                        <list>
-                            <value>127.0.0.1:47500..47509</value>
-                        </list>
-                    </property>
-                </bean>
-            </property>
-        </bean>
-    </property>
-    -->
-  </bean>
-</beans>
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/hive-site.xml b/bigtop-deploy/puppet/modules/ignite_hadoop/templates/hive-site.xml
deleted file mode 100644
index 753c501..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/hive-site.xml
+++ /dev/null
@@ -1,33 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-
-<!--
-  ~ 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.
-  -->
-
-<!--
-    This file contains settings needed to run Apache Hive queries
-    with Ignite In-Memory Accelerator.
--->
-<configuration>
-    <!--
-        Ignite requires query plan to be passed not using local resource.
-    -->
-    <property>
-        <name>hive.rpc.query.plan</name>
-        <value>true</value>
-    </property>
-</configuration>
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/ignite-hadoop b/bigtop-deploy/puppet/modules/ignite_hadoop/templates/ignite-hadoop
deleted file mode 100644
index e4530ca..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/ignite-hadoop
+++ /dev/null
@@ -1,21 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-export HADOOP_PREFIX=/usr
-export IGNITE_HOME=/usr/lib/ignite-hadoop
-export IGNITE_LOG_DIR=/var/log/ignite-hadoop
-export IGNITE_PID_DIR=/var/run/ignite-hadoop
-export IGNITE_WORK_DIR="/var/run/ignite-hadoop/work"
-export HADOOP_HOME=${HADOOP_HOME:-/usr/lib/hadoop}
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/mapred-site.xml b/bigtop-deploy/puppet/modules/ignite_hadoop/templates/mapred-site.xml
deleted file mode 100644
index f2a0ae6..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/templates/mapred-site.xml
+++ /dev/null
@@ -1,63 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-  Licensed under the Apache License, Version 2.0 (the "License");
-  you may not use this file except in compliance with the License.
-  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License. See accompanying LICENSE file.
--->
-
-<!--
-    This template file contains settings needed to run Apache Hadoop jobs
-    with Ignite In-Memory Accelerator.
-
-    You can replace '$HADOOP_HOME/etc/hadoop/mapred-site.xml' file with this one
-    to run jobs on localhost (local node can be a part of distributed cluster though).
-    To run jobs on remote host you have to change jobtracker address to the REST address
-    of any running Ignite node.
-
-    Note that Ignite jars must be in Apache Hadoop client classpath to work
-    with this configuration.
-
-    Run script '$IGNITE_HOME/bin/setup-hadoop.{sh|bat}' for Apache Hadoop client setup.
--->
-
-<configuration>
-    <!--
-        Framework name must be set to 'ignite'.
-    -->
-    <property>
-        <name>mapreduce.framework.name</name>
-        <value>ignite</value>
-    </property>
-
-    <!--
-        Job tracker address must be set to the REST address of any running
-        Ignite node.
-    -->
-    <property>
-        <name>mapreduce.jobtracker.address</name>
-        <value>localhost:11211</value>
-    </property>
-
-    <!-- Parameters for job tuning. -->
-    <!--
-    <property>
-        <name>mapreduce.job.reduces</name>
-        <value>1</value>
-    </property>
-
-    <property>
-        <name>mapreduce.job.maps</name>
-        <value>4</value>
-    </property>
-    -->
-
-</configuration>
diff --git a/bigtop-deploy/puppet/modules/ignite_hadoop/tests/init.pp b/bigtop-deploy/puppet/modules/ignite_hadoop/tests/init.pp
deleted file mode 100644
index 75ae1df..0000000
--- a/bigtop-deploy/puppet/modules/ignite_hadoop/tests/init.pp
+++ /dev/null
@@ -1,16 +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.
-
-ignite_hadoop::server { "test-ignite-hadoop-server": }
diff --git a/bigtop-deploy/puppet/modules/zeppelin/templates/interpreter.json b/bigtop-deploy/puppet/modules/zeppelin/templates/interpreter.json
index c5a7deb..63452d3 100644
--- a/bigtop-deploy/puppet/modules/zeppelin/templates/interpreter.json
+++ b/bigtop-deploy/puppet/modules/zeppelin/templates/interpreter.json
@@ -49,31 +49,6 @@
         "remote": true
       }
     },
-    "2B44YVSN1": {
-      "id": "2B44YVSN1",
-      "name": "ignite",
-      "group": "ignite",
-      "properties": {
-        "ignite.peerClassLoadingEnabled": "true",
-        "ignite.config.url": "",
-        "ignite.jdbc.url": "jdbc:ignite://localhost:11211/default",
-        "ignite.clientMode": "true",
-        "ignite.addresses": "127.0.0.1:47500..47509"
-      },
-      "interpreterGroup": [
-        {
-          "class": "org.apache.zeppelin.ignite.IgniteInterpreter",
-          "name": "ignite"
-        },
-        {
-          "class": "org.apache.zeppelin.ignite.IgniteSqlInterpreter",
-          "name": "ignitesql"
-        }
-      ],
-      "option": {
-        "remote": true
-      }
-    },
     "2AKK3QQXU": {
       "id": "2AKK3QQXU",
       "name": "sh",
diff --git a/bigtop-packages/src/common/ignite-hadoop/do-component-build b/bigtop-packages/src/common/ignite-hadoop/do-component-build
deleted file mode 100644
index 7127d5c..0000000
--- a/bigtop-packages/src/common/ignite-hadoop/do-component-build
+++ /dev/null
@@ -1,44 +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.
-
-set -ex
-
-. `dirname $0`/bigtop.bom
-
-export MAVEN_OPTS="-Xmx512M"
-
-sed -i '/asm-all/{n;s/4.2/5.0.2/}' modules/hadoop/pom.xml
-
-# Fix JVM_OPTS variable unbound issue when starting ignite-hadoop-service
-sed -i "s/JVM_OPTS/\{JVM_OPTS\:\-\}/g" bin/include/service.sh
-sed -i "s/^.*{JVM_OPTS:-}=.*$/JVM_OPTS=\"\$\{JVM_OPTS\:\-\} \-Xms1g \-Xmx1g \-server \-XX\:\+AggressiveOpts \-XX\:MaxPermSize\=512m\"/" bin/include/service.sh
-
-cd ipc/shmem
-# patch and build it
-sed -i 's/\&ipcData->closed\,/(char *)\&ipcData->closed\,/' igniteshmem/org_apache_ignite_internal_util_ipc_shmem_IpcSharedMemoryUtils.cpp
-./configure && make
-# create layout
-mkdir -p META-INF/native/linux64
-cp ./igniteshmem/.libs/libigniteshmem.so META-INF/native/linux64/libigniteshmem.so
-# pack and install
-jar cf ignite-shmem-1.0.0.jar META-INF
-mvn install:install-file -Dfile=ignite-shmem-1.0.0.jar -DgroupId=org.gridgain -DartifactId=ignite-shmem -Dversion=1.0.0 -Dpackaging=jar -DcreateChecksum=true
-# clean up
-rm -rf META-INF
-cd -
-
-mvn clean install -Pall-java,all-scala -DskipTests -Dhadoop.version=$HADOOP_VERSION
-mvn initialize -Prelease -Dignite.edition=apache-ignite-hadoop
diff --git a/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.1 b/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.1
deleted file mode 100644
index 96c62c0..0000000
--- a/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.1
+++ /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.
-.\"
-.\" Process this file with
-.\" groff -man -Tascii ignite.1
-.\"
-.TH ignite 1 "Mar 2015 " Linux "User Manuals"
-
-.SH NAME
-Ignite \- Ignite is a filesystem and MR accelerator for Hadoop.
-
-.SH SYNOPSIS
-
-.B ignite
-\fICOMMAND\fR
-
-.SH DESCRIPTION
-
-Ignite is a filesystem and MR accelerator for Hadoop. Use it when you
-you need predictable file system caching, fast MR processing...
-
-Ignite is an open-source, distributed blah-blah
-
-For more information about Ignite, see http://ignite.apache.org/
-
-\fICOMMAND\fR may be one of the following:
-  something        do something
-  else             do something else
-
-Most commands print help when invoked w/o parameters or with --help.
-
-.SH ENVIRONMENT
-
-.IP JAVA_HOME
-The java implementation to use.  Overrides JAVA_HOME.
-
-.IP IGNITE_HOME
-Extra Java CLASSPATH entries.
-
-.IP IGNITE_CONF_DIR
-Alternate conf dir. Default is ${IGNITE_HOME}/conf.
-
-.IP HADOOP_HOME
-Optionally, the Hadoop home to run with.
-
-.SH COPYRIGHT
-2014 - 2015, The Apache Software Foundation
diff --git a/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.default b/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.default
deleted file mode 100644
index a094720..0000000
--- a/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.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.
-
-export IGNITE_HOME="/usr/lib/ignite-hadoop"
-export IGNITE_CONF_DIR="/etc/ignite-hadoop/conf"
-
-export IGNITE_PID_DIR="/var/run/ignite-hadoop"
-export IGNITE_LOG_DIR="/var/log/ignite-hadoop"
-export IGNITE_WORK_DIR="/var/run/ignite-hadoop/work"
-export IGNITE_IDENT_STRING=ignite
-
-export HADOOP_HOME=${HADOOP_HOME:-/usr/lib/hadoop}
diff --git a/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.svc b/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.svc
deleted file mode 100644
index aa3ca4c..0000000
--- a/bigtop-packages/src/common/ignite-hadoop/ignite-hadoop.svc
+++ /dev/null
@@ -1,63 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-DAEMON="ignite-hadoop"
-DESC="ignite-hadoop daemon"
-EXEC_PATH="\${IGNITE_HOME}/bin/include/service.sh"
-SVC_USER="ignite"
-PIDFILE="\${IGNITE_PID_DIR}/${DAEMON}.pid"
-
-generate_start() {
-
-cat <<'__EOT__'
-start() {
-    [ -x $EXEC_PATH ] || exit $ERROR_PROGRAM_NOT_INSTALLED
-    log_success_msg "Starting $DESC (${DAEMON}): "
-
-    checkstatusofproc
-    status=$?
-    if [ "$status" -eq "$STATUS_RUNNING" ]; then
-        log_success_msg "${DESC} is running"
-        exit 0
-    fi
-
-    runuser -s /bin/bash ${SVC_USER} -c "${EXEC_PATH} start ${DAEMON}"
-
-    checkstatusofproc
-    RETVAL=$?
-    [ $RETVAL -eq $STATUS_RUNNING ] && touch $LOCKFILE
-    return $RETVAL
-}
-__EOT__
-
-}
-
-generate_stop() {
-
-cat <<'__EOT__'
-stop() {
-    log_success_msg "Stopping $DESC (${DAEMON}): "
-
-    runuser -s /bin/bash ${SVC_USER} -c "${EXEC_PATH} stop ${DAEMON}"
-
-    sleep 3
-    RETVAL=$?
-
-    [ $RETVAL -eq $RETVAL_SUCCESS ] && rm -f $LOCKFILE $PIDFILE
-    return $RETVAL
-}
-__EOT__
-
-}
diff --git a/bigtop-packages/src/common/ignite-hadoop/install_ignite.sh b/bigtop-packages/src/common/ignite-hadoop/install_ignite.sh
deleted file mode 100644
index 933a30e..0000000
--- a/bigtop-packages/src/common/ignite-hadoop/install_ignite.sh
+++ /dev/null
@@ -1,149 +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.
-
-set -ex
-
-usage() {
-  echo "
-usage: $0 <options>
-  Required not-so-options:
-     --build-dir=DIR             path to ignite dist.dir
-     --prefix=PREFIX             path to install into
-
-  Optional options:
-     --doc-dir=DIR               path to install docs into [/usr/share/doc/ignite]
-     --lib-dir=DIR               path to install ignite home [/usr/lib/ignite]
-     --installed-lib-dir=DIR     path where lib-dir will end up on target system
-     --bin-dir=DIR               path to install bins [/usr/bin]
-     --examples-dir=DIR          path to install examples [doc-dir/examples]
-     ... [ see source for more similar options ]
-  "
-  exit 1
-}
-
-OPTS=$(getopt \
-  -n $0 \
-  -o '' \
-  -l 'prefix:' \
-  -l 'doc-dir:' \
-  -l 'lib-dir:' \
-  -l 'installed-lib-dir:' \
-  -l 'bin-dir:' \
-  -l 'examples-dir:' \
-  -l 'conf-dir:' \
-  -l 'build-dir:' -- "$@")
-
-if [ $? != 0 ] ; then
-    usage
-fi
-
-eval set -- "$OPTS"
-while true ; do
-    case "$1" in
-        --prefix)
-        PREFIX=$2 ; shift 2
-        ;;
-        --build-dir)
-        BUILD_DIR=$2 ; shift 2
-        ;;
-        --doc-dir)
-        DOC_DIR=$2 ; shift 2
-        ;;
-        --lib-dir)
-        LIB_DIR=$2 ; shift 2
-        ;;
-        --installed-lib-dir)
-        INSTALLED_LIB_DIR=$2 ; shift 2
-        ;;
-        --bin-dir)
-        BIN_DIR=$2 ; shift 2
-        ;;
-        --examples-dir)
-        EXAMPLES_DIR=$2 ; shift 2
-        ;;
-        --conf-dir)
-        CONF_DIR=$2 ; shift 2
-        ;;
-        --)
-        shift ; break
-        ;;
-        *)
-        echo "Unknown option: $1"
-        usage
-        exit 1
-        ;;
-    esac
-done
-
-for var in PREFIX BUILD_DIR ; do
-  if [ -z "$(eval "echo \$$var")" ]; then
-    echo Missing param: $var
-    usage
-  fi
-done
-
-MAN_DIR=${MAN_DIR:-/usr/share/man/man1}
-DOC_DIR=${DOC_DIR:-/usr/share/doc/ignite-hadoop}
-LIB_DIR=${LIB_DIR:-/usr/lib/ignite-hadoop}
-BIN_DIR=${BIN_DIR:-/usr/lib/ignite-hadoop/bin}
-ETC_DIR=${ETC_DIR:-/etc/ignite-hadoop}
-CONF_DIR=${CONF_DIR:-${ETC_DIR}/conf.dist}
-
-install -d -m 0755 $PREFIX/$LIB_DIR
-install -d -m 0755 $PREFIX/$LIB_DIR/libs
-install -d -m 0755 $PREFIX/$DOC_DIR
-install -d -m 0755 $PREFIX/$BIN_DIR
-install -d -m 0755 $PREFIX/$BIN_DIR/include
-install -d -m 0755 $PREFIX/$ETC_DIR
-install -d -m 0755 $PREFIX/$CONF_DIR
-install -d -m 0755 $PREFIX/$MAN_DIR
-install -d -m 0755 $PREFIX/var/run/ignite-hadoop/work/
-
-# Pattern matches both ignite-hadoop-*.zip and incubator-ignite-*.zip:
-unzip -x $BUILD_DIR/*ignite-*.zip
-
-UNZIP_DIR=*ignite-*/
-cp -ar $UNZIP_DIR/libs $PREFIX/$LIB_DIR
-cp -a $UNZIP_DIR/config/* $PREFIX/$CONF_DIR
-cp -ra $UNZIP_DIR/bin/* $PREFIX/$BIN_DIR
-
-ln -s $ETC_DIR/conf $PREFIX/$LIB_DIR/config
-# Create unversioned softlinks to the main libraries
-for dir in $PREFIX/$LIB_DIR/libs $PREFIX/$LIB_DIR/libs/ignite-hadoop ; do
-  (cd $dir &&
-  for j in ignite-*.jar; do
-     if [[ $j =~ ignite-(.*)-${IGNITE_HADOOP_VERSION}(.*).jar ]]; then
-       name=${BASH_REMATCH[1]}
-       ln -s $j ignite-$name.jar
-     fi
-  done)
-done
-
-wrapper=$PREFIX/usr/bin/ignite-hadoop
-mkdir -p `dirname $wrapper`
-cat > $wrapper <<EOF
-#!/bin/bash
-
-BIGTOP_DEFAULTS_DIR=\${BIGTOP_DEFAULTS_DIR-/etc/default}
-[ -n "\${BIGTOP_DEFAULTS_DIR}" -a -r \${BIGTOP_DEFAULTS_DIR}/hadoop ] && . \${BIGTOP_DEFAULTS_DIR}/hadoop
-[ -n "\${BIGTOP_DEFAULTS_DIR}" -a -r \${BIGTOP_DEFAULTS_DIR}/ignite-hadoop ] && . \${BIGTOP_DEFAULTS_DIR}/ignite-hadoop
-
-exec /usr/lib/ignite-hadoop/bin/include/service.sh \$1 ignite-hadoop
-EOF
-chmod 755 $wrapper
-
-install -d -m 0755 $PREFIX/usr/bin
diff --git a/bigtop-packages/src/common/ignite-hadoop/patch0-shmem-config.diff b/bigtop-packages/src/common/ignite-hadoop/patch0-shmem-config.diff
deleted file mode 100644
index 3fd4931..0000000
--- a/bigtop-packages/src/common/ignite-hadoop/patch0-shmem-config.diff
+++ /dev/null
@@ -1,14 +0,0 @@
-diff --git a/ipc/shmem/config.guess b/ipc/shmem/config.guess
-index 499bfa7..b274825 100755
---- a/ipc/shmem/config.guess
-+++ b/ipc/shmem/config.guess
-@@ -979,6 +979,9 @@ EOF
-     ppc:Linux:*:*)
- 	echo powerpc-unknown-linux-gnu
- 	exit ;;
-+    ppc64le:Linux:*:*)
-+	echo powerpc64le-unknown-linux-gnu
-+	exit ;;
-     s390:Linux:*:* | s390x:Linux:*:*)
- 	echo ${UNAME_MACHINE}-ibm-linux
- 	exit ;;
diff --git a/bigtop-packages/src/deb/ignite-hadoop/compat b/bigtop-packages/src/deb/ignite-hadoop/compat
deleted file mode 100644
index ec63514..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/compat
+++ /dev/null
@@ -1 +0,0 @@
-9
diff --git a/bigtop-packages/src/deb/ignite-hadoop/control b/bigtop-packages/src/deb/ignite-hadoop/control
deleted file mode 100644
index 4390663..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/control
+++ /dev/null
@@ -1,39 +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.
-Source: ignite-hadoop
-Section: misc
-Priority: extra
-Maintainer: Bigtop <de...@bigtop.apache.org>
-Build-Depends: debhelper (>= 7.0.50~)
-Standards-Version: 3.9.4
-Homepage: http://ignite.apache.org/
-
-Package: ignite-hadoop
-Architecture: any
-Depends: adduser, hadoop-hdfs, hadoop-mapreduce, bigtop-utils (>= 0.8)
-Description: Ignite is an open-source, distributed, in-memory computation platform
- .
-  * HDFS caching and MR performance booster
-
-Package: ignite-hadoop-service
-Architecture: all
-Depends: ignite-hadoop
-Description: Linux services for Apache Ignite
-
-Package: ignite-hadoop-doc
-Architecture: all
-Section: doc
-Description: Ignite Documentation
- Documentation for Ignite Hadoop Accelerator
diff --git a/bigtop-packages/src/deb/ignite-hadoop/copyright b/bigtop-packages/src/deb/ignite-hadoop/copyright
deleted file mode 100644
index 89a5120..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/copyright
+++ /dev/null
@@ -1,15 +0,0 @@
-Format: http://dep.debian.net/deps/dep5
-Source: https://git-wip-us.apache.org/repos/asf/incubator-ignite
-Upstream-Name: none
-
-Files: *
-Copyright: 2014 - 2015, The Apache Software Foundation
-License: Apache-2.0
-
-Files debian/*
-Copyright: 2011, The Apache Software Foundation
-License: Apache-2.0
-
-License: Apache-2.0
- On Debian systems, the complete text of the Apache 2.0 license
- can be found in "/usr/share/common-licenses/Apache-2.0".
diff --git a/bigtop-packages/src/deb/ignite-hadoop/format b/bigtop-packages/src/deb/ignite-hadoop/format
deleted file mode 100644
index 163aaf8..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/format
+++ /dev/null
@@ -1 +0,0 @@
-3.0 (quilt)
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop-doc.dirs b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop-doc.dirs
deleted file mode 100644
index 0e81ae2..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop-doc.dirs
+++ /dev/null
@@ -1 +0,0 @@
-/usr/share/docs/ignite-hadoop-docs
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.dirs b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.dirs
deleted file mode 100644
index aa0ebd3..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.dirs
+++ /dev/null
@@ -1,3 +0,0 @@
-/usr/bin
-/var/log/ignite-hadoop
-/etc/default
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.install b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.install
deleted file mode 100644
index 47c4ca8..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.install
+++ /dev/null
@@ -1,3 +0,0 @@
-/usr/lib/ignite-hadoop
-/usr/bin/ignite-hadoop
-/etc/ignite-hadoop
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.manpages b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.manpages
deleted file mode 100644
index 03d204f..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.manpages
+++ /dev/null
@@ -1 +0,0 @@
-debian/ignite-hadoop.1
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.postinst b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.postinst
deleted file mode 100644
index 5703d9e..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.postinst
+++ /dev/null
@@ -1,47 +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.
-
-# postinst script for ignite-hadoop
-
-gg_hadoop_pkg_name=ignite-hadoop
-
-set -e
-
-case "$1" in
-    configure)
-        # Install config alternatives
-        update-alternatives --install /etc/${gg_hadoop_pkg_name}/conf ${gg_hadoop_pkg_name}-conf \
-        /etc/${gg_hadoop_pkg_name}/conf.dist 30
-
-        mkdir -p /var/log/${gg_hadoop_pkg_name} /var/run/${gg_hadoop_pkg_name} /var/run/${gg_hadoop_pkg_name}/work || :
-        chown ignite:ignite /var/log/${gg_hadoop_pkg_name} /var/run/${gg_hadoop_pkg_name}
-        chmod g+w /var/log/${gg_hadoop_pkg_name} /var/run/${gg_hadoop_pkg_name}
-        chown ignite:ignite /var/run/${gg_hadoop_pkg_name} /var/run/${gg_hadoop_pkg_name}/work
-        chmod 0755 /var/run/${gg_hadoop_pkg_name}
-        chmod 1777 /var/run/${gg_hadoop_pkg_name}/work
-    ;;
-
-    abort-upgrade|abort-remove|abort-deconfigure)
-    ;;
-
-    *)
-        echo "postinst called with unknown argument \`$1'" >&2
-        exit 1
-    ;;
-esac
-
-#DEBHELPER#
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.preinst b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.preinst
deleted file mode 100644
index 2623c28..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.preinst
+++ /dev/null
@@ -1,62 +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.
-
-# preinst script for ignite-hadoop
-#
-# see: dh_installdeb(1)
-
-set -e
-
-# summary of how this script can be called:
-#        * <new-preinst> `install'
-#        * <new-preinst> `install' <old-version>
-#        * <new-preinst> `upgrade' <old-version>
-#        * <old-preinst> `abort-upgrade' <new-version>
-# for details, see http://www.debian.org/doc/debian-policy/ or
-# the debian-policy package
-
-
-case "$1" in
-    install|upgrade)
-        getent group ignite >/dev/null || groupadd -r ignite
-        if ! getent passwd ignite >/dev/null; then
-                # Adding system user: ignite.
-                adduser \
-                  --system \
-                  --ingroup ignite \
-                  --home /var/run/ignite-hadoop \
-                  --gecos "Ignite User" \
-                  --shell /bin/bash \
-                  ignite >/dev/null
-        fi
-    ;;
-
-    abort-upgrade)
-    ;;
-
-    *)
-        echo "preinst called with unknown argument \`$1'" >&2
-        exit 1
-    ;;
-esac
-
-# dh_installdeb will replace this with shell code automatically
-# generated by other debhelper scripts.
-
-#DEBHELPER#
-
-exit 0
diff --git a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.prerm b/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.prerm
deleted file mode 100644
index feacfd1..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/ignite-hadoop.prerm
+++ /dev/null
@@ -1,55 +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.
-
-# prerm script for ignite-hadoop
-#
-# see: dh_installdeb(1)
-
-set -e
-
-# summary of how this script can be called:
-#        * <prerm> `remove'
-#        * <old-prerm> `upgrade' <new-version>
-#        * <new-prerm> `failed-upgrade' <old-version>
-#        * <conflictor's-prerm> `remove' `in-favour' <package> <new-version>
-#        * <deconfigured's-prerm> `deconfigure' `in-favour'
-#          <package-being-installed> <version> `removing'
-#          <conflicting-package> <version>
-# for details, see http://www.debian.org/doc/debian-policy/ or
-# the debian-policy package
-
-
-case "$1" in
-    remove|upgrade|deconfigure)
-      update-alternatives --remove ignite-hadoop-conf /etc/ignite-hadoop/conf.dist || :
-    ;;
-
-    failed-upgrade)
-    ;;
-
-    *)
-        echo "prerm called with unknown argument \`$1'" >&2
-        exit 1
-    ;;
-esac
-
-# dh_installdeb will replace this with shell code automatically
-# generated by other debhelper scripts.
-
-#DEBHELPER#
-
-exit 0
diff --git a/bigtop-packages/src/deb/ignite-hadoop/rules b/bigtop-packages/src/deb/ignite-hadoop/rules
deleted file mode 100644
index e6e9224..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/rules
+++ /dev/null
@@ -1,46 +0,0 @@
-#!/usr/bin/make -f
-#
-# 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.
-#
-# -*- makefile -*-
-SHELL=/bin/bash
-
-# Uncomment this to turn on verbose mode.
-export DH_VERBOSE=1
-
-# This has to be exported to make some magic below work.
-export DH_OPTIONS
-
-ignite-hadoop_pkg_name=ignite-hadoop
-
-%:
-	dh $@
-
-override_dh_auto_build:
-	bash debian/do-component-build -Dmaven.repo.local=${HOME}/.m2/repository
-
-
-override_dh_auto_install:
-	cp debian/ignite-hadoop.default debian/${ignite-hadoop_pkg_name}/etc/default/${ignite-hadoop_pkg_name}
-	env HADOOP_VERSION=${IGNITE_HADOOP_BASE_VERSION} \
-	bash -x debian/install_ignite.sh \
-		--build-dir=target/bin \
-		--conf-dir=/etc/${ignite-hadoop_pkg_name}/conf.dist \
-		--doc-dir=usr/share/doc/${ignite-hadoop_pkg_name}-doc \
-		--prefix=debian/tmp
-	ln -s /var/log/${ignite-hadoop_pkg_name} debian/tmp/usr/lib/${ignite-hadoop_pkg_name}/logs
-	ln -s /var/run/${ignite-hadoop_pkg_name} debian/tmp/usr/lib/${ignite-hadoop_pkg_name}/pids
-	bash debian/init.d.tmpl debian/ignite-hadoop.svc deb debian/${ignite-hadoop_pkg_name}-service.init
diff --git a/bigtop-packages/src/deb/ignite-hadoop/source/format b/bigtop-packages/src/deb/ignite-hadoop/source/format
deleted file mode 100644
index 163aaf8..0000000
--- a/bigtop-packages/src/deb/ignite-hadoop/source/format
+++ /dev/null
@@ -1 +0,0 @@
-3.0 (quilt)
diff --git a/bigtop-packages/src/deb/logstash/copyright b/bigtop-packages/src/deb/logstash/copyright
index 89a5120..3c13abb 100644
--- a/bigtop-packages/src/deb/logstash/copyright
+++ b/bigtop-packages/src/deb/logstash/copyright
@@ -1,5 +1,5 @@
 Format: http://dep.debian.net/deps/dep5
-Source: https://git-wip-us.apache.org/repos/asf/incubator-ignite
+Source: https://github.com/elastic/logstash
 Upstream-Name: none
 
 Files: *
diff --git a/bigtop-packages/src/deb/logstash/logstash.preinst b/bigtop-packages/src/deb/logstash/logstash.preinst
index 292adbd..19c8952 100644
--- a/bigtop-packages/src/deb/logstash/logstash.preinst
+++ b/bigtop-packages/src/deb/logstash/logstash.preinst
@@ -15,7 +15,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-# preinst script for ignite-hadoop
+# preinst script for logstash
 #
 # see: dh_installdeb(1)
 
diff --git a/bigtop-packages/src/deb/logstash/logstash.prerm b/bigtop-packages/src/deb/logstash/logstash.prerm
index 307c462..2344f27 100644
--- a/bigtop-packages/src/deb/logstash/logstash.prerm
+++ b/bigtop-packages/src/deb/logstash/logstash.prerm
@@ -15,7 +15,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-# prerm script for ignite-hadoop
+# prerm script for logstash
 #
 # see: dh_installdeb(1)
 
diff --git a/bigtop-packages/src/deb/zeppelin/control b/bigtop-packages/src/deb/zeppelin/control
index 70d44ce..4eff5ce 100644
--- a/bigtop-packages/src/deb/zeppelin/control
+++ b/bigtop-packages/src/deb/zeppelin/control
@@ -26,6 +26,6 @@ Architecture: all
 Depends: adduser, bigtop-utils (>= 0.8), hadoop-client, spark-core (>= 1.5), spark-python (>= 1.5)
 Description: Web-based notebook for data analysts
  Zeppelin is a web-based notebook that enables interactive data analytics with
- multiple data analytics projects including Apache Ignite, Apache Flink, Apache Spark,
+ multiple data analytics projects including Apache Flink, Apache Spark,
  Apache Kylin, Apache Hive, and others.
  You can make beautiful data-driven, interactive and collaborative documents with SQL, Scala and more.
diff --git a/bigtop-packages/src/rpm/ignite-hadoop/SPECS/ignite-hadoop.spec b/bigtop-packages/src/rpm/ignite-hadoop/SPECS/ignite-hadoop.spec
deleted file mode 100644
index 7084948..0000000
--- a/bigtop-packages/src/rpm/ignite-hadoop/SPECS/ignite-hadoop.spec
+++ /dev/null
@@ -1,225 +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.
-%define etc_ignite_conf %{_sysconfdir}/%{name}/conf
-%define etc_ignite_conf_dist %{etc_ignite_conf}.dist
-%define ignite_home /usr/lib/%{name}
-%define bin_ignite %{ignite_home}/bin
-%define lib_ignite %{ignite_home}/lib
-%define conf_ignite %{ignite_home}/config
-%define logs_ignite %{ignite_home}/logs
-%define pids_ignite %{ignite_home}/pids
-%define man_dir %{_mandir}
-%define ignite_username ignite
-%define service_name %{name}-service
-%define vcs_tag %{ignite_hadoop_version}
-
-%if  %{?suse_version:1}0
-
-# Only tested on openSUSE 11.4. le'ts update it for previous release when confirmed
-%if 0%{suse_version} > 1130
-%define suse_check \# Define an empty suse_check for compatibility with older sles
-%endif
-
-# SLES is more strict anc check all symlinks point to valid path
-# But we do point to a hadoop jar which is not there at build time
-# (but would be at install time).
-# Since our package build system does not handle dependencies,
-# these symlink checks are deactivated
-%define __os_install_post \
-    %{suse_check} ; \
-    /usr/lib/rpm/brp-compress ; \
-    %{nil}
-
-%define doc_ignite %{_docdir}/%{name}
-%global initd_dir %{_sysconfdir}/rc.d
-%define alternatives_cmd update-alternatives
-
-%else
-
-# CentOS 5 does not have any dist macro
-# So I will suppose anything that is not Mageia or a SUSE will be a RHEL/CentOS/Fedora
-%if %{!?mgaversion:1}0
-
-# FIXME: brp-repack-jars uses unzip to expand jar files
-# Unfortunately guice-2.0.jar pulled by ivy contains some files and directories without any read permission
-# and make whole process to fail.
-# So for now brp-repack-jars is being deactivated until this is fixed.
-# See BIGTOP-294
-#%define __os_install_post \
-#    %{_rpmconfigdir}/brp-compress ; \
-#    %{_rpmconfigdir}/brp-strip-static-archive %{__strip} ; \
-#   %{_rpmconfigdir}/brp-strip-comment-note %{__strip} %{__objdump} ; \
-#   /usr/lib/rpm/brp-python-bytecompile ; \
-#   %{nil}
-%endif
-
-%define doc_ignite %{_docdir}/%{name}-%{ignite_hadoop_version}
-%global initd_dir %{_sysconfdir}/rc.d/init.d
-%define alternatives_cmd alternatives
-
-%endif
-
-# Disable debuginfo package
-%define debug_package %{nil}
-
-Name: ignite-hadoop
-Version: %{ignite_hadoop_version}
-Release: %{ignite_hadoop_release}
-Summary: Ignite Hadoop accelerator. The system provides for in-memory caching of HDFS data and MR performance improvements
-URL: http://ignite.apache.org/
-Group: Development/Libraries
-Buildroot: %{_topdir}/INSTALL/%{name}-%{version}
-License: APL2
-Source0: ignite-hadoop-%{ignite_hadoop_base_version}.tar.gz
-Source1: do-component-build
-Source2: install_ignite.sh
-Source3: ignite-hadoop.svc
-Source4: init.d.tmpl
-Source5: ignite-hadoop.default
-#BIGTOP_PATCH_FILES
-## This package _explicitly_ turns off the auto-discovery of required dependencies
-## to work around OSGI corner case, added to RPM lately. See BIGTOP-2421 for more info.
-Requires: coreutils, /usr/sbin/useradd, /sbin/chkconfig, /sbin/service
-Requires: hadoop-hdfs, hadoop-mapreduce, bigtop-utils >= 0.7
-AutoReq: no
-
-%if  0%{?mgaversion}
-Requires: bsh-utils
-%else
-Requires: coreutils
-%endif
-
-%description
-Ignite is an open-source, distributed, in-memory computation platform
-
-    * HDFS caching and MR performance booster
-
-%package service
-Summary: Hadoop Accelerator platform
-Group: System/Daemons
-Requires: %{name} = %{version}-%{release}
-Requires(pre): %{name} = %{version}-%{release}
-
-%if  %{?suse_version:1}0
-# Required for init scripts
-Requires: insserv
-%endif
-
-%if  0%{?mgaversion}
-# Required for init scripts
-Requires: initscripts
-%endif
-
-# CentOS 5 does not have any dist macro
-# So I will suppose anything that is not Mageia or a SUSE will be a RHEL/CentOS/Fedora
-%if %{!?suse_version:1}0 && %{!?mgaversion:1}0
-# Required for init scripts
-Requires: redhat-lsb
-%endif
-
-%description service
-Ignite Hadoop accelerator package
-
-%package doc
-Summary: Ignite Documentation
-Group: Documentation
-BuildArch: noarch
-
-%description doc
-Documentation for Ignite platform
-
-%prep
-%setup -n ignite-hadoop-%{vcs_tag}
-
-#BIGTOP_PATCH_COMMANDS
-
-%build
-bash %{SOURCE1}
-
-%install
-%__rm -rf $RPM_BUILD_ROOT
-env IGNITE_HADOOP_VERSION=%{version} bash %{SOURCE2} \
-  --build-dir=target/bin \
-  --doc-dir=%{doc_ignite} \
-  --conf-dir=%{etc_ignite_conf_dist} \
-	--prefix=$RPM_BUILD_ROOT
-
-%__install -d -m 0755 $RPM_BUILD_ROOT/%{initd_dir}/
-
-%__install -d -m 0755 $RPM_BUILD_ROOT/etc/default/
-%__install -m 0644 %{SOURCE5} $RPM_BUILD_ROOT/etc/default/%{name}
-
-%__install -d  -m 0755  %{buildroot}/%{_localstatedir}/log/%{name}
-
-ln -s %{_localstatedir}/log/%{name} %{buildroot}/%{logs_ignite}
-
-%__install -d  -m 0755  %{buildroot}/%{_localstatedir}/run/%{name}
-ln -s %{_localstatedir}/run/%{name} %{buildroot}/%{pids_ignite}
-
-init_file=$RPM_BUILD_ROOT/%{initd_dir}/%{service_name}
-bash %{SOURCE4} ${RPM_SOURCE_DIR}/ignite-hadoop.svc rpm $init_file
-chmod 755 $init_file
-
-%__install -d -m 0755 $RPM_BUILD_ROOT/usr/bin
-
-# Pull hadoop from their packages
-rm -f $RPM_BUILD_ROOT/%{lib_ignite}/libs/{hadoop}*.jar
-
-%pre
-getent group ignite 2>/dev/null >/dev/null || /usr/sbin/groupadd -r ignite
-getent passwd ignite 2>&1 > /dev/null || /usr/sbin/useradd -c "ignite" -s /sbin/nologin -g ignite -r -d /var/run/ignite ignite 2> /dev/null || :
-
-%post
-%{alternatives_cmd} --install %{etc_ignite_conf} %{name}-conf %{etc_ignite_conf_dist} 30
-
-%preun
-if [ "$1" = 0 ]; then
-        %{alternatives_cmd} --remove %{name}-conf %{etc_ignite_conf_dist} || :
-fi
-
-#######################
-#### FILES SECTION ####
-#######################
-%files
-%defattr(-,ignite,ignite)
-%dir %{_localstatedir}/log/%{name}
-%dir %{_localstatedir}/run/%{name}
-
-%defattr(-,root,root)
-%config(noreplace) %{_sysconfdir}/default/%{name}
-%{ignite_home}
-/usr/bin/%{name}
-%config(noreplace) %{etc_ignite_conf_dist}
-
-%files doc
-%defattr(-,root,root)
-%doc %{doc_ignite}/
-
-%define service_macro() \
-%files %1 \
-%attr(0755,root,root)/%{initd_dir}/%{service_name} \
-%post %1 \
-chkconfig --add %{service_name} \
-\
-%preun %1 \
-if [ $1 = 0 ] ; then \
-        service %{service_name} stop > /dev/null 2>&1 \
-        chkconfig --del %{service_name} \
-fi \
-%postun %1 \
-if [ $1 -ge 1 ]; then \
-        service %{service_name} condrestart >/dev/null 2>&1 \
-fi
-%service_macro service
diff --git a/bigtop-tests/smoke-tests/ignite-hadoop/TestIgniteHadoop.groovy b/bigtop-tests/smoke-tests/ignite-hadoop/TestIgniteHadoop.groovy
deleted file mode 100644
index beb31ea..0000000
--- a/bigtop-tests/smoke-tests/ignite-hadoop/TestIgniteHadoop.groovy
+++ /dev/null
@@ -1,72 +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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.
- */
-
-package org.apache.bigtop.itest.hadoop.ignite
-
-import org.apache.bigtop.itest.shell.Shell
-import org.apache.commons.logging.Log
-import org.apache.commons.logging.LogFactory
-import org.junit.Before
-import org.junit.Test
-
-import static org.junit.Assert.assertEquals
-
-class TestIgniteHadoop {
-  static private Log LOG = LogFactory.getLog(Object.class)
-
-  static Shell sh = new Shell("/bin/bash -s")
-
-  static String hadoopClassPath = "/usr/lib/ignite-hadoop/libs/*:/usr/lib/ignite-hadoop/libs/ignite-hadoop/*"
-
-  static String cmdPrefix = "export HADOOP_CLASSPATH=$hadoopClassPath:\$HADOOP_CLASSPATH; " +
-    "export HADOOP_CONF_DIR=\$(pwd)/conf;HADOOP_USER_NAME=hdfs"
-
-
-  private static void execCommand(String cmd) {
-    LOG.info(cmd)
-
-    sh.exec("$cmdPrefix $cmd")
-  }
-
-  @Before
-  void cleanFileSystem() {
-    execCommand("hadoop fs -rm -r /gh-input")
-    execCommand("hadoop fs -rm -r /gh-output")
-  }
-
-  @Test
-  void test() {
-    execCommand("hadoop fs -mkdir /gh-input")
-    execCommand("hadoop fs -put test.data /gh-input/")
-
-    execCommand("hadoop jar \$HADOOP_MAPRED_HOME/hadoop-mapreduce-examples.jar wordcount /gh-input /gh-output")
-
-    execCommand("hadoop fs -cat /gh-output/part-r-00000")
-
-    String expected =
-        "black\t5\n" +
-        "blue\t11\n" +
-        "green\t11\n" +
-        "white\t5\n" +
-        "yellow\t11";
-
-    String actual = sh.out.join('\n')
-
-    assertEquals("Incorrect output", expected, actual)
-  }
-}
diff --git a/bigtop-tests/smoke-tests/ignite-hadoop/build.gradle b/bigtop-tests/smoke-tests/ignite-hadoop/build.gradle
deleted file mode 100644
index 46e6364..0000000
--- a/bigtop-tests/smoke-tests/ignite-hadoop/build.gradle
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.
- */
-def tests_to_include() {
-  return [
-      "TestIgniteHadoop.groovy"
-  ];
-}
-
-sourceSets {
-  test {
-    groovy {
-        srcDirs = ["${BIGTOP_HOME}/bigtop-tests/smoke-tests/ignite-hadoop/"]
-    }
-  }
-}
-
-test.doFirst {
-  checkEnv(["HADOOP_MAPRED_HOME"])
-}
diff --git a/bigtop-tests/smoke-tests/ignite-hadoop/conf/core-site.xml b/bigtop-tests/smoke-tests/ignite-hadoop/conf/core-site.xml
deleted file mode 100644
index 8b8e634..0000000
--- a/bigtop-tests/smoke-tests/ignite-hadoop/conf/core-site.xml
+++ /dev/null
@@ -1,90 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-
-<!--
-  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.
--->
-
-<!--
-    This template file contains settings needed to run Apache Hadoop jobs
-    with Apache Ignite's distributed in-memory file system IGFS.
-
-    You can replace '$HADOOP_HOME/etc/hadoop/core-site.xml' file with this one
-    to work with IGFS nodes running on localhost (these local nodes can be
-    a part of distributed cluster though). To work with file system on remote
-    hosts you need to change the host of file system URI to any host running
-    IGFS node.
-
-    Note that Ignite jars must be in Apache Hadoop client classpath to work
-    with this configuration.
-
-    Run script '$IGNITE_HOME/bin/setup-hadoop.{sh|bat}' for Apache Hadoop client setup.
--->
-
-<configuration>
-    <!--
-        Set default file system to IGFS instance named "igfs" configured in Ignite.
-    -->
-    <property>
-        <name>fs.default.name</name>
-        <value>igfs://igfs@localhost</value>
-    </property>
-
-    <!--
-        Set Hadoop 1.* file system implementation class for IGFS.
-    -->
-    <property>
-        <name>fs.igfs.impl</name>
-        <value>org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem</value>
-    </property>
-
-    <!--
-        Set Hadoop 2.* file system implementation class for IGFS.
-    -->
-    <property>
-        <name>fs.AbstractFileSystem.igfs.impl</name>
-        <value>org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem</value>
-    </property>
-
-    <!--
-        Disallow data node replacement since it does not make sense for IGFS nodes.
-    -->
-    <property>
-        <name>dfs.client.block.write.replace-datanode-on-failure.policy</name>
-        <value>NEVER</value>
-    </property>
-
-    <!--
-        Allow to write the job statistics into IGFS.
-    -->
-    <!--
-    <property>
-        <name>ignite.counters.writer</name>
-        <value>org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter</value>
-    </property>
-    -->
-
-    <!--
-        By default data is placed into the file /user/<user_name>/<job_id>/performance
-        You can override this path with using macro ${USER} that is to injection of submitter user name.
-    -->
-    <!--
-    <property>
-        <name>ignite.counters.fswriter.directory</name>
-        <value>/user/${USER}</value>
-    </property>
-    -->
-</configuration>
diff --git a/bigtop-tests/smoke-tests/ignite-hadoop/conf/log4j.properties b/bigtop-tests/smoke-tests/ignite-hadoop/conf/log4j.properties
deleted file mode 100644
index 0723326..0000000
--- a/bigtop-tests/smoke-tests/ignite-hadoop/conf/log4j.properties
+++ /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 root logger level to INFO and its only appender to A1.
-log4j.rootLogger=INFO, A1
-
-# A1 is set to be a ConsoleAppender.
-log4j.appender.A1=org.apache.log4j.ConsoleAppender
-
-# A1 uses PatternLayout.
-log4j.appender.A1.layout=org.apache.log4j.PatternLayout
-log4j.appender.A1.layout.ConversionPattern=%-4r [BIGTOP-TEST-LOG %t] %-5p %c %x --- %m%n
diff --git a/bigtop-tests/smoke-tests/ignite-hadoop/conf/mapred-site.xml b/bigtop-tests/smoke-tests/ignite-hadoop/conf/mapred-site.xml
deleted file mode 100644
index a2ed437..0000000
--- a/bigtop-tests/smoke-tests/ignite-hadoop/conf/mapred-site.xml
+++ /dev/null
@@ -1,66 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-
-<!--
-  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.
--->
-
-<!--
-    This template file contains settings needed to run Apache Hadoop jobs
-    with Apache Ignite In-Memory Accelerator.
-
-    You can replace '$HADOOP_HOME/etc/hadoop/mapred-site.xml' file with this one
-    to run jobs on localhost (local node can be a part of distributed cluster though).
-    To run jobs on remote host you have to change jobtracker address to the REST address
-    of any running Ignite node.
-
-    Note that Ignite jars must be in Apache Hadoop client classpath to work
-    with this configuration.
-
-    Run script '$IGNITE_HOME/bin/setup-hadoop.{sh|bat}' for Apache Hadoop client setup.
--->
-
-<configuration>
-    <!--
-        Framework name must be set to 'ignite'.
-    -->
-    <property>
-        <name>mapreduce.framework.name</name>
-        <value>ignite</value>
-    </property>
-
-    <!--
-        Job tracker address must be set to the REST address of any running Ignite node.
-    -->
-    <property>
-        <name>mapreduce.jobtracker.address</name>
-        <value>localhost:11211</value>
-    </property>
-
-    <!-- Parameters for job tuning. -->
-    <!--
-    <property>
-        <name>mapreduce.job.reduces</name>
-        <value>1</value>
-    </property>
-
-    <property>
-        <name>mapreduce.job.maps</name>
-        <value>4</value>
-    </property>
-    -->
-
-</configuration>
diff --git a/bigtop-tests/smoke-tests/ignite-hadoop/test.data b/bigtop-tests/smoke-tests/ignite-hadoop/test.data
deleted file mode 100644
index 6599669..0000000
--- a/bigtop-tests/smoke-tests/ignite-hadoop/test.data
+++ /dev/null
@@ -1,11 +0,0 @@
-green blue yellow
-yellow green blue black white
-yellow green blue
-white yellow green blue black
-blue yellow green
-black white yellow green blue
-green blue yellow
-blue black white yellow green
-yellow green blue
-green blue black white yellow
-blue yellow green
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 a79c826..813dea3 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
@@ -443,48 +443,7 @@ server.</description>
       <hive-webhcat>/self</hive-webhcat>
     </deps>
   </hive-webhcat-server>
-  <ignite-hadoop>
-    <metadata>
-      <summary>Apache Ignite Hadoop accelerator. The system provides for in-memory caching of HDFS data and MR performance improvements</summary>
-      <description>Apache Ignite is an open-source, distributed, in-memory computation platform
-
-        * HDFS caching and MR performance booster
-
-      </description>
-      <url>https://ignite.incubator.apache.org/</url>
-    </metadata>
-    <deps>
-      <hadoop-hdfs/>
-      <hadoop-mapreduce/>
-      <bigtop-utils/>
-    </deps>
-    <alternatives>
-      <ignite-hadoop-conf>
-        <status>auto</status>
-        <link>/etc/ignite-hadoop/conf</link>
-        <value>/etc/ignite-hadoop/conf.dist</value>
-        <alt>/etc/ignite-hadoop/conf.dist</alt>
-      </ignite-hadoop-conf>
-    </alternatives>
-  </ignite-hadoop>
-    <ignite-hadoop-service>
-      <metadata>
-        <summary>Apache Ignite Hadoop Accelerator platform</summary>
-        <description>Ignite is an open-source, distributed, in-memory computation platform</description>
-        <url>https://ignite.incubator.apache.org/</url>
-      </metadata>
-      <deps>
-        <ignite-hadoop/>
-      </deps>
-    </ignite-hadoop-service>
-    <ignite-hadoop-doc>
-      <metadata>
-        <summary>Ignite Documentation</summary>
-        <description>Documentation for Apache Ignite platform</description>
-        <url>https://ignite.incubator.apache.org/</url>
-      </metadata>
-    </ignite-hadoop-doc>
-    <hbase>
+  <hbase>
     <metadata>
       <summary>HBase is the Hadoop database. Use it when you need random, realtime read/write access to your Big Data. This project's goal is the hosting of very large tables -- billions of rows X millions of columns -- atop clusters of commodity hardware.</summary>
       <description>HBase is an open-source, distributed, column-oriented store modeled after Google' Bigtable: A Distributed Storage System for Structured Data by Chang et al. Just as Bigtable leverages the distributed data storage provided by the Google File System, HBase provides Bigtable-like capabilities on top of Hadoop. HBase includes:
diff --git a/bigtop.bom b/bigtop.bom
index 2fe914f..3d4720f 100644
--- a/bigtop.bom
+++ b/bigtop.bom
@@ -115,13 +115,12 @@ bigtop {
     'bigtop-jsvc':['hadoop'],
     'bigtop-tomcat':['oozie'],
     zookeeper:['hadoop', 'hbase', 'kafka'],
-    hadoop:['ignite-hadoop', 'hbase', 'hive', 'tez', 'sqoop',
+    hadoop:['hbase', 'hive', 'tez', 'sqoop',
       'oozie', 'solr', 'spark',
       'phoenix', 'alluxio', 'ycsb', 'zeppelin'
     ],
     hbase:['phoenix', 'ycsb', 'hive'],
     hive:['oozie', 'zeppelin'],
-    'ignite-hadoop':['zeppelin'],
     spark:['livy', 'oozie', 'zeppelin'],
   ]
 
@@ -154,17 +153,6 @@ bigtop {
                 site = "${apache.APACHE_MIRROR}/${download_path}"
                 archive = "${apache.APACHE_ARCHIVE}/${download_path}" }
     }
-    'ignite-hadoop' {
-      name    = 'ignite-hadoop'
-      relNotes = 'Apache Ignite in-memory data fabric'
-      version { base = '2.7.6'; pkg = base; release = 1 }
-      tarball { destination = "${name}-${version.base}.tar.gz"
-                source      = "apache-ignite-${version.base}-src.zip" }
-      url     { download_path = "/ignite/${version.base}/"
-                site = "${apache.APACHE_MIRROR}/${download_path}"
-                archive = "${apache.APACHE_ARCHIVE}/${download_path}" }
-    }
-
     'hbase' {
       name    = 'hbase'
       relNotes = 'Apache HBase'
diff --git a/build.gradle b/build.gradle
index 79eaad4..4ecb0ea 100644
--- a/build.gradle
+++ b/build.gradle
@@ -78,7 +78,6 @@ rat {
        "bigtop-tests/smoke-tests/hive/passwd.ql",
        "bigtop-tests/smoke-tests/phoenix/*.csv",
        "bigtop-tests/smoke-tests/phoenix/*.sql",
-       "bigtop-tests/smoke-tests/ignite-hadoop/*.data",
        "bigtop-tests/smoke-tests/odpi-runtime/src/test/resources/*.json",
        "bigtop-tests/smoke-tests/odpi-runtime/src/test/resources/*.list",
        "bigtop-tests/smoke-tests/logstash/resources/**",
diff --git a/docker/sandbox/README.md b/docker/sandbox/README.md
index d7a6105..0782b76 100644
--- a/docker/sandbox/README.md
+++ b/docker/sandbox/README.md
@@ -77,7 +77,7 @@ docker run -d -p 50070:50070 -p 60010:60010 bigtop/sandbox:ubuntu-16.04_hdfs_hba
 
 ```
 export REPO=http://ci.bigtop.apache.org:8080/job/Bigtop-trunk-repos/BUILD_ENVIRONMENTS=centos-6%2Clabel=docker-slave-06//ws/output
-./build.sh -a bigtop -o centos-6 -c "hdfs, yarn, spark, ignite"
+./build.sh -a bigtop -o centos-6 -c "hdfs, yarn, spark"
 ```
 
 ### Customize your Big Data Stack
@@ -85,22 +85,14 @@ export REPO=http://ci.bigtop.apache.org:8080/job/Bigtop-trunk-repos/BUILD_ENVIRO
 * Edit *site.yaml.template.centos-6_hadoop* to create your own prefered stack
 
 ```
-cp site.yaml.template.centos-6_hadoop site.yaml.template.centos-6_hadoop_ignite
-vim site.yaml.template.centos-6_hadoop_ignite
-```
-
-* Add ignite in *hadoop_cluster_node::cluster_components* array and leave the other unchanged
-
-```
-...
-hadoop_cluster_node::cluster_components: [hdfs, yarn, ignite]
-...
+cp site.yaml.template.centos-6_hadoop site.yaml.template.centos-6_hadoop_hive
+vim site.yaml.template.centos-6_hadoop_hive
 ```
 
 * Build
 
 ```
-./build.sh -a bigtop -o centos-6 -f site.yaml.template.centos-6_hadoop_ignite -t my_ignite_stack
+./build.sh -a bigtop -o centos-6 -f site.yaml.template.centos-6_hadoop_hive -t my_hive_stack
 ```
 
 ## Known issues