You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by nt...@apache.org on 2015/07/01 10:13:34 UTC

[1/6] incubator-ignite git commit: #IGNITE-1046 Added dockerfile and scripts for running container with ignite.

Repository: incubator-ignite
Updated Branches:
  refs/heads/ignite-sprint-7 e0c53b817 -> bccba308a


#IGNITE-1046 Added dockerfile and scripts for running container with ignite.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/9de7d248
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/9de7d248
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/9de7d248

Branch: refs/heads/ignite-sprint-7
Commit: 9de7d248d9ed720179887547772a899beea48488
Parents: 1c66078
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Wed Jun 24 16:26:07 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Wed Jun 24 16:26:07 2015 +0300

----------------------------------------------------------------------
 modules/docker/Dockerfile          | 38 +++++++++++++++++++++++++++++
 modules/docker/README.txt          | 11 +++++++++
 modules/docker/build_users_libs.sh | 23 ++++++++++++++++++
 modules/docker/download_ignite.sh  | 33 ++++++++++++++++++++++++++
 modules/docker/execute.sh          | 42 +++++++++++++++++++++++++++++++++
 modules/docker/run.sh              | 11 +++++++++
 6 files changed, 158 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9de7d248/modules/docker/Dockerfile
----------------------------------------------------------------------
diff --git a/modules/docker/Dockerfile b/modules/docker/Dockerfile
new file mode 100644
index 0000000..2723333
--- /dev/null
+++ b/modules/docker/Dockerfile
@@ -0,0 +1,38 @@
+# Start from a Debian image.
+FROM debian:8
+
+# Install tools.
+RUN apt-get update && apt-get install -y --fix-missing \
+  wget \
+  dstat \
+  maven \
+  git
+
+# Intasll Oracle JDK.
+RUN mkdir /opt/jdk
+
+RUN wget --header "Cookie: oraclelicense=accept-securebackup-cookie" \
+  http://download.oracle.com/otn-pub/java/jdk/7u76-b13/jdk-7u76-linux-x64.tar.gz
+
+RUN tar -zxf jdk-7u76-linux-x64.tar.gz -C /opt/jdk
+
+RUN rm jdk-7u76-linux-x64.tar.gz
+
+RUN update-alternatives --install /usr/bin/java java /opt/jdk/jdk1.7.0_76/bin/java 100
+
+RUN update-alternatives --install /usr/bin/javac javac /opt/jdk/jdk1.7.0_76/bin/javac 100
+
+# Sets java variables.
+ENV JAVA_HOME /opt/jdk/jdk1.7.0_76/
+
+# Create working directory
+RUN mkdir /home/ignite_home
+
+WORKDIR /home/ignite_home
+
+# Copy sh files and set permission
+ADD *.sh ./
+
+RUN chmod +x *.sh
+
+CMD ./run.sh
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9de7d248/modules/docker/README.txt
----------------------------------------------------------------------
diff --git a/modules/docker/README.txt b/modules/docker/README.txt
new file mode 100644
index 0000000..0299d4c
--- /dev/null
+++ b/modules/docker/README.txt
@@ -0,0 +1,11 @@
+Apache Ignite Docker module
+------------------------
+
+Apache Ignite Docker module provides Dockerfile and bash scripts for building docker image.
+
+Build image
+-------------------------------------
+
+cd to ./modules/docker
+
+sudo docker build .
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9de7d248/modules/docker/build_users_libs.sh
----------------------------------------------------------------------
diff --git a/modules/docker/build_users_libs.sh b/modules/docker/build_users_libs.sh
new file mode 100644
index 0000000..24f4420
--- /dev/null
+++ b/modules/docker/build_users_libs.sh
@@ -0,0 +1,23 @@
+#!/bin/bash
+
+if [ -z $GIT_REPO ]; then
+  echo Users git repo is not provided.
+
+  exit 0
+fi
+
+git clone $GIT_REPO user-repo
+
+cd user-repo
+
+if [ ! -z $GIT_BRANCH ]; then
+  git checkout $GIT_BRANCH
+fi
+
+if [ ! -z "$BUILD_CMD" ]; then
+  echo "Starting to execute build command: $BUILD_CMD"
+
+  eval "$BUILD_CMD"
+else
+  mvn clean package
+fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9de7d248/modules/docker/download_ignite.sh
----------------------------------------------------------------------
diff --git a/modules/docker/download_ignite.sh b/modules/docker/download_ignite.sh
new file mode 100644
index 0000000..6a8617f
--- /dev/null
+++ b/modules/docker/download_ignite.sh
@@ -0,0 +1,33 @@
+#!/bin/bash
+
+function download {
+  wget -O ignite.zip $1
+
+  unzip ignite.zip -d ignite
+
+  rm ignite.zip
+
+  exit 0
+}
+
+if [ ! -z $IGNITE_URL ]; then
+  download $IGNITE_URL
+fi
+
+if [ ! -z $IGNITE_VERSION ]; then
+  if [[ $IGNITE_VERSION  =~ [0-9]*\.[0-9]*\.0 ]]; then
+    download http://apache-mirror.rbc.ru/pub/apache/incubator/ignite/${IGNITE_VERSION}/apache-ignite-fabric-${IGNITE_VERSION}-incubating-bin.zip
+  else
+    download http://www.gridgain.com/media/gridgain-community-fabric-${IGNITE_VERSION}.zip
+  fi
+fi
+
+if [ -z $IGNITE_SOURCE ] || [ $IGNITE_SOURCE = "COMMUNITY" ]; then
+  download http://tiny.cc/updater/download_community.php
+fi
+
+if [ $IGNITE_SOURCE = "APACHE" ]; then
+  download http://tiny.cc/updater/download_ignite.php
+fi
+
+echo "Unsupported IGNITE_SOURCE type: ${IGNITE_SOURCE}"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9de7d248/modules/docker/execute.sh
----------------------------------------------------------------------
diff --git a/modules/docker/execute.sh b/modules/docker/execute.sh
new file mode 100644
index 0000000..2aaaa2d
--- /dev/null
+++ b/modules/docker/execute.sh
@@ -0,0 +1,42 @@
+#!/bin/bash
+
+if [ ! -z "$GIT_REPO" ]; then
+  if [ -z "$LIB_PATTERN" ]; then
+    find user-repo/ -regextype posix-extended -regex "user-repo/target/.*(jar|zip)$" -exec cp {} ignite/*/libs \;
+  else
+    find user-repo/ -regextype posix-extended -regex "$LIB_PATTERN" -exec cp {} ignite/*/libs \;
+  fi
+fi
+
+if [ ! -z "$OPTION_LIBS" ]; then
+  IFS=, LIBS_LIST=("$OPTION_LIBS")
+
+  for lib in ${LIBS_LIST[@]}; do
+    cp -r ./ignite/*/libs/optional/"$lib"/* ./ignite/*/libs
+  done
+fi
+
+# Try to download
+if [ ! -z "$IGNITE_CONFIG" ]; then
+  wget -O ignite-config.xml "$IGNITE_CONFIG" 2>/dev/null
+
+  RETVAL=$?
+
+  [ $RETVAL -eq 0 ] && IGNITE_CONFIG=ignite-config.xml
+
+  [ $RETVAL -ne 0 ] && rm ignite-config.xml && echo "Failed download config: $IGNITE_CONFIG. Try to load config from classpath."
+fi
+
+if [ ! -z "$EXEC_CMD" ]; then
+  echo "Starting to execute command: $EXEC_CMD"
+
+  eval "$EXEC_CMD"
+
+  exit 0
+fi
+
+if [ -z "$IGNITE_CONFIG" ]; then
+  ignite/*/bin/ignite.sh
+else
+  ignite/*/bin/ignite.sh ignite-config.xml
+fi
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9de7d248/modules/docker/run.sh
----------------------------------------------------------------------
diff --git a/modules/docker/run.sh b/modules/docker/run.sh
new file mode 100644
index 0000000..42fb29d
--- /dev/null
+++ b/modules/docker/run.sh
@@ -0,0 +1,11 @@
+#!/bin/bash
+
+if [ -z $SKIP_DOWNLOAD ]; then
+  ./download_ignite.sh
+fi
+
+if [ -z $SKIP_BUILD_LIBS ]; then
+  ./build_users_libs.sh
+fi
+
+./execute.sh
\ No newline at end of file


[5/6] incubator-ignite git commit: Merge branch 'ignite-sprint-7' into ignite-1046

Posted by nt...@apache.org.
Merge branch 'ignite-sprint-7' into ignite-1046


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

Branch: refs/heads/ignite-sprint-7
Commit: aea804b41fd0a73a1eb4f8f68e28bf77d00de966
Parents: 4eef6d0 e91bc48
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Wed Jul 1 11:03:32 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Wed Jul 1 11:03:32 2015 +0300

----------------------------------------------------------------------
 .../ClientAbstractConnectivitySelfTest.java     |   4 +-
 .../org/apache/ignite/cluster/ClusterGroup.java |  18 +-
 .../org/apache/ignite/cluster/ClusterNode.java  |   2 +
 .../ignite/compute/ComputeTaskSplitAdapter.java |   2 +-
 .../configuration/CacheConfiguration.java       | 105 +--
 .../configuration/IgniteReflectionFactory.java  |  81 +-
 .../configuration/NearCacheConfiguration.java   |  10 +-
 .../ignite/internal/GridKernalContextImpl.java  |   5 +-
 .../internal/cluster/ClusterGroupAdapter.java   |  50 +-
 .../cluster/IgniteClusterAsyncImpl.java         |  12 +-
 .../discovery/GridDiscoveryManager.java         |  32 +-
 .../processors/cache/GridCacheContext.java      |   2 +-
 .../cache/GridCacheDeploymentManager.java       |  10 +-
 .../GridCachePartitionExchangeManager.java      |   6 +-
 .../processors/cache/GridCacheProcessor.java    |  62 +-
 .../distributed/dht/GridDhtLocalPartition.java  |   3 +-
 .../distributed/dht/GridDhtLockFuture.java      |   2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   9 +-
 .../GridDhtPartitionsExchangeFuture.java        |  46 +-
 .../processors/clock/GridClockServer.java       |  21 +-
 .../datastructures/DataStructuresProcessor.java |  64 +-
 .../processors/hadoop/HadoopJobInfo.java        |   4 +-
 .../hadoop/counter/HadoopCounterWriter.java     |   5 +-
 .../processors/plugin/CachePluginManager.java   |  10 +-
 .../processors/rest/GridRestProcessor.java      |   4 +-
 .../handlers/task/GridTaskCommandHandler.java   |  12 +-
 .../processors/task/GridTaskWorker.java         |   4 +-
 .../internal/util/GridConfigurationFinder.java  |  55 +-
 .../ignite/internal/util/IgniteUtils.java       |   6 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  10 +-
 .../apache/ignite/internal/visor/VisorJob.java  |   2 +
 .../internal/visor/log/VisorLogSearchTask.java  |   2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   4 +
 .../visor/query/VisorQueryCleanupTask.java      |  14 +
 .../util/VisorClusterGroupEmptyException.java   |  37 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    | 151 ++--
 .../ignite/spi/discovery/tcp/ServerImpl.java    | 103 ++-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   3 +-
 .../TcpDiscoveryMulticastIpFinder.java          |  74 +-
 .../core/src/test/config/spark/spark-config.xml |  46 ++
 .../internal/ClusterGroupAbstractTest.java      | 777 ++++++++++++++++++
 .../internal/ClusterGroupHostsSelfTest.java     | 141 ++++
 .../ignite/internal/ClusterGroupSelfTest.java   | 251 ++++++
 .../internal/GridDiscoveryEventSelfTest.java    |  12 +-
 .../internal/GridProjectionAbstractTest.java    | 784 -------------------
 .../ignite/internal/GridProjectionSelfTest.java | 251 ------
 .../apache/ignite/internal/GridSelfTest.java    |   2 +-
 .../IgniteTopologyPrintFormatSelfTest.java      | 289 +++++++
 .../CacheReadThroughAtomicRestartSelfTest.java  |  32 +
 ...heReadThroughLocalAtomicRestartSelfTest.java |  32 +
 .../CacheReadThroughLocalRestartSelfTest.java   |  32 +
 ...dThroughReplicatedAtomicRestartSelfTest.java |  32 +
 ...cheReadThroughReplicatedRestartSelfTest.java |  32 +
 .../cache/CacheReadThroughRestartSelfTest.java  | 133 ++++
 .../cache/GridCacheAbstractSelfTest.java        |   2 +-
 .../cache/GridCacheDaemonNodeStopSelfTest.java  | 119 ---
 .../IgniteDaemonNodeMarshallerCacheTest.java    | 192 +++++
 ...eDynamicCacheStartNoExchangeTimeoutTest.java | 466 +++++++++++
 .../cache/IgniteDynamicCacheStartSelfTest.java  |  37 +
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |   4 +-
 .../GridCacheSetAbstractSelfTest.java           |  22 +-
 .../IgniteDataStructureWithJobTest.java         | 111 +++
 .../distributed/IgniteCache150ClientsTest.java  | 189 +++++
 ...teCacheClientNodePartitionsExchangeTest.java |   1 +
 .../distributed/IgniteCacheManyClientsTest.java |   1 +
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   5 -
 ...achePartitionedMultiNodeFullApiSelfTest.java |  53 +-
 .../GridCacheReplicatedFailoverSelfTest.java    |   5 +
 .../IgniteCacheTxStoreSessionTest.java          |   4 +
 .../internal/util/IgniteUtilsSelfTest.java      |  22 +
 .../tcp/TcpClientDiscoverySpiSelfTest.java      | 265 ++++++-
 .../testframework/junits/GridAbstractTest.java  |   2 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |   7 +-
 .../IgniteCacheDataStructuresSelfTestSuite.java |   1 +
 .../testsuites/IgniteCacheTestSuite3.java       |   1 -
 .../testsuites/IgniteCacheTestSuite4.java       |   8 +
 .../testsuites/IgniteClientTestSuite.java       |  38 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 .../p2p/GridP2PContinuousDeploymentTask1.java   |   2 +-
 modules/hadoop/pom.xml                          |  78 --
 .../fs/IgniteHadoopFileSystemCounterWriter.java |   9 +-
 .../processors/hadoop/HadoopClassLoader.java    |  29 +
 .../processors/hadoop/HadoopDefaultJobInfo.java |  27 +-
 .../internal/processors/hadoop/HadoopUtils.java | 237 ------
 .../hadoop/SecondaryFileSystemProvider.java     |   3 +-
 .../hadoop/fs/HadoopFileSystemCacheUtils.java   | 241 ++++++
 .../hadoop/fs/HadoopFileSystemsUtils.java       |  11 +
 .../hadoop/fs/HadoopLazyConcurrentMap.java      |   5 +
 .../hadoop/jobtracker/HadoopJobTracker.java     |  25 +-
 .../child/HadoopChildProcessRunner.java         |   3 +-
 .../processors/hadoop/v2/HadoopV2Job.java       |  84 +-
 .../hadoop/v2/HadoopV2JobResourceManager.java   |  22 +-
 .../hadoop/v2/HadoopV2TaskContext.java          |  37 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |   5 +-
 .../processors/hadoop/HadoopMapReduceTest.java  |   2 +-
 .../processors/hadoop/HadoopTasksV1Test.java    |   7 +-
 .../processors/hadoop/HadoopTasksV2Test.java    |   7 +-
 .../processors/hadoop/HadoopV2JobSelfTest.java  |   6 +-
 .../collections/HadoopAbstractMapTest.java      |   3 +-
 .../testsuites/IgniteHadoopTestSuite.java       |   2 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |   3 +-
 .../ignite/schema/model/PojoDescriptor.java     |   2 +
 .../apache/ignite/schema/model/PojoField.java   |   1 +
 .../parser/dialect/OracleMetadataDialect.java   |   2 +-
 .../org/apache/ignite/spark/IgniteContext.scala |  50 +-
 .../org/apache/ignite/spark/IgniteRddSpec.scala |  18 +
 .../commands/cache/VisorCacheCommand.scala      |   7 +-
 pom.xml                                         |  12 +-
 scripts/git-patch-prop.sh                       |   2 +-
 109 files changed, 4514 insertions(+), 1876 deletions(-)
----------------------------------------------------------------------



[3/6] incubator-ignite git commit: IGNITE-1046 Added license.

Posted by nt...@apache.org.
IGNITE-1046 Added license.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/86c5d207
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/86c5d207
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/86c5d207

Branch: refs/heads/ignite-sprint-7
Commit: 86c5d207094947aa9e53ea6da6314c125188ec8d
Parents: f57aa92
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Fri Jun 26 13:09:59 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Fri Jun 26 13:09:59 2015 +0300

----------------------------------------------------------------------
 modules/docker/Dockerfile          | 17 +++++++++++++++++
 modules/docker/build_users_libs.sh | 16 ++++++++++++++++
 modules/docker/download_ignite.sh  | 16 ++++++++++++++++
 modules/docker/execute.sh          | 16 ++++++++++++++++
 modules/docker/run.sh              | 16 ++++++++++++++++
 5 files changed, 81 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/86c5d207/modules/docker/Dockerfile
----------------------------------------------------------------------
diff --git a/modules/docker/Dockerfile b/modules/docker/Dockerfile
index 2723333..11e2e3d 100644
--- a/modules/docker/Dockerfile
+++ b/modules/docker/Dockerfile
@@ -1,3 +1,20 @@
+#
+# 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.
+#
+
 # Start from a Debian image.
 FROM debian:8
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/86c5d207/modules/docker/build_users_libs.sh
----------------------------------------------------------------------
diff --git a/modules/docker/build_users_libs.sh b/modules/docker/build_users_libs.sh
index 24f4420..4d37187 100644
--- a/modules/docker/build_users_libs.sh
+++ b/modules/docker/build_users_libs.sh
@@ -1,4 +1,20 @@
 #!/bin/bash
+#
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#      http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+#
 
 if [ -z $GIT_REPO ]; then
   echo Users git repo is not provided.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/86c5d207/modules/docker/download_ignite.sh
----------------------------------------------------------------------
diff --git a/modules/docker/download_ignite.sh b/modules/docker/download_ignite.sh
index 6a8617f..9e2cb51 100644
--- a/modules/docker/download_ignite.sh
+++ b/modules/docker/download_ignite.sh
@@ -1,4 +1,20 @@
 #!/bin/bash
+#
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#      http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+#
 
 function download {
   wget -O ignite.zip $1

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/86c5d207/modules/docker/execute.sh
----------------------------------------------------------------------
diff --git a/modules/docker/execute.sh b/modules/docker/execute.sh
index e0ed90c..8afba59 100644
--- a/modules/docker/execute.sh
+++ b/modules/docker/execute.sh
@@ -1,4 +1,20 @@
 #!/bin/bash
+#
+# Licensed to the Apache Software Foundation (ASF) under one or more
+# contributor license agreements.  See the NOTICE file distributed with
+# this work for additional information regarding copyright ownership.
+# The ASF licenses this file to You under the Apache License, Version 2.0
+# (the "License"); you may not use this file except in compliance with
+# the License.  You may obtain a copy of the License at
+#
+#      http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+#
 
 if [ ! -z "$GIT_REPO" ]; then
   if [ -z "$LIB_PATTERN" ]; then

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/86c5d207/modules/docker/run.sh
----------------------------------------------------------------------
diff --git a/modules/docker/run.sh b/modules/docker/run.sh
index 2e3110d..e7feb8c 100644
--- a/modules/docker/run.sh
+++ b/modules/docker/run.sh
@@ -1,4 +1,20 @@
 #!/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.
+#
 
 IGNITE_VERSION=""
 


[6/6] incubator-ignite git commit: Merge remote-tracking branch 'origin/ignite-sprint-7' into ignite-sprint-7

Posted by nt...@apache.org.
Merge remote-tracking branch 'origin/ignite-sprint-7' into ignite-sprint-7


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

Branch: refs/heads/ignite-sprint-7
Commit: bccba308a884ef527cf7f84f7f6dd57d55b1e51a
Parents: aea804b e0c53b8
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Wed Jul 1 11:13:36 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Wed Jul 1 11:13:36 2015 +0300

----------------------------------------------------------------------
 .../main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java  | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------



[4/6] incubator-ignite git commit: IGNITE-1046 Added license.

Posted by nt...@apache.org.
IGNITE-1046 Added license.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/4eef6d04
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/4eef6d04
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/4eef6d04

Branch: refs/heads/ignite-sprint-7
Commit: 4eef6d04c09a730188dbde33b9063965947a1683
Parents: 86c5d20
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Fri Jun 26 18:00:37 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Fri Jun 26 18:00:37 2015 +0300

----------------------------------------------------------------------
 modules/docker/run.sh | 8 +++++---
 1 file changed, 5 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4eef6d04/modules/docker/run.sh
----------------------------------------------------------------------
diff --git a/modules/docker/run.sh b/modules/docker/run.sh
index e7feb8c..0f01c1c 100644
--- a/modules/docker/run.sh
+++ b/modules/docker/run.sh
@@ -16,13 +16,15 @@
 # limitations under the License.
 #
 
-IGNITE_VERSION=""
-
 if [ -z $SKIP_BUILD_LIBS ]; then
   ./build_users_libs.sh
 
-  IGNITE_VERSION=$(mvn -f user-repo/pom.xml dependency:list | grep ':ignite-core:jar:.*:' | \
+  PROJ_VER=$(mvn -f user-repo/pom.xml dependency:list | grep ':ignite-core:jar:.*:' | \
     sed -rn 's/.*([0-9]+\.[0-9]+\.[0-9]+).*/\1/p')
+
+  if [ ! -z $PROJ_VER ]; then
+    IGNITE_VERSION=$PROJ_VER
+  fi
 fi
 
 if [ -z $SKIP_DOWNLOAD ]; then


[2/6] incubator-ignite git commit: IGNITE-1046 Added default option libs.

Posted by nt...@apache.org.
IGNITE-1046 Added default option libs.


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

Branch: refs/heads/ignite-sprint-7
Commit: f57aa921e7ac7b583b0f31931890f1f9454f3b1a
Parents: 9de7d24
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Fri Jun 26 13:06:45 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Fri Jun 26 13:06:45 2015 +0300

----------------------------------------------------------------------
 modules/docker/execute.sh |  4 ++++
 modules/docker/run.sh     | 11 ++++++++---
 2 files changed, 12 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f57aa921/modules/docker/execute.sh
----------------------------------------------------------------------
diff --git a/modules/docker/execute.sh b/modules/docker/execute.sh
index 2aaaa2d..e0ed90c 100644
--- a/modules/docker/execute.sh
+++ b/modules/docker/execute.sh
@@ -8,6 +8,10 @@ if [ ! -z "$GIT_REPO" ]; then
   fi
 fi
 
+if [ -z "$OPTION_LIBS" ]; then
+  OPTION_LIBS="ignite-log4j"
+fi
+
 if [ ! -z "$OPTION_LIBS" ]; then
   IFS=, LIBS_LIST=("$OPTION_LIBS")
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f57aa921/modules/docker/run.sh
----------------------------------------------------------------------
diff --git a/modules/docker/run.sh b/modules/docker/run.sh
index 42fb29d..2e3110d 100644
--- a/modules/docker/run.sh
+++ b/modules/docker/run.sh
@@ -1,11 +1,16 @@
 #!/bin/bash
 
-if [ -z $SKIP_DOWNLOAD ]; then
-  ./download_ignite.sh
-fi
+IGNITE_VERSION=""
 
 if [ -z $SKIP_BUILD_LIBS ]; then
   ./build_users_libs.sh
+
+  IGNITE_VERSION=$(mvn -f user-repo/pom.xml dependency:list | grep ':ignite-core:jar:.*:' | \
+    sed -rn 's/.*([0-9]+\.[0-9]+\.[0-9]+).*/\1/p')
+fi
+
+if [ -z $SKIP_DOWNLOAD ]; then
+  IGNITE_VERSION=$IGNITE_VERSION ./download_ignite.sh
 fi
 
 ./execute.sh
\ No newline at end of file