You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2015/07/02 09:20:00 UTC

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

Repository: incubator-ignite
Updated Branches:
  refs/heads/ignite-752 6b37a9e96 -> dd076a089


#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-752
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


[12/21] incubator-ignite git commit: IGNITE-1068: Fixing ordered messages back pressure control.

Posted by sb...@apache.org.
IGNITE-1068: Fixing ordered messages back pressure control.


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

Branch: refs/heads/ignite-752
Commit: c7e7487458b72ba8b666fba7b9e24004d425719f
Parents: bccba30
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Wed Jul 1 11:50:08 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Wed Jul 1 11:50:08 2015 +0300

----------------------------------------------------------------------
 .../managers/communication/GridIoManager.java   | 49 +++++++++++---------
 .../util/nio/GridNioMessageTracker.java         | 23 +++++++--
 2 files changed, 48 insertions(+), 24 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c7e74874/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java
index 4382731..d8dcc2c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java
@@ -27,6 +27,7 @@ import org.apache.ignite.internal.managers.deployment.*;
 import org.apache.ignite.internal.managers.eventstorage.*;
 import org.apache.ignite.internal.processors.timeout.*;
 import org.apache.ignite.internal.util.*;
+import org.apache.ignite.internal.util.lang.*;
 import org.apache.ignite.internal.util.tostring.*;
 import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
@@ -718,7 +719,7 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
             map = msgSetMap.get(msg.topic());
 
             if (map == null) {
-                set = new GridCommunicationMessageSet(plc, msg.topic(), nodeId, timeout, skipOnTimeout, msg);
+                set = new GridCommunicationMessageSet(plc, msg.topic(), nodeId, timeout, skipOnTimeout, msg, msgC);
 
                 map = new ConcurrentHashMap0<>();
 
@@ -748,7 +749,7 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
                     if (set == null) {
                         GridCommunicationMessageSet old = map.putIfAbsent(nodeId,
                             set = new GridCommunicationMessageSet(plc, msg.topic(),
-                                nodeId, timeout, skipOnTimeout, msg));
+                                nodeId, timeout, skipOnTimeout, msg, msgC));
 
                         assert old == null;
 
@@ -766,7 +767,7 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
                 assert set != null;
                 assert !isNew;
 
-                set.add(msg);
+                set.add(msg, msgC);
 
                 break;
             }
@@ -795,14 +796,6 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
         if (isNew && set.endTime() != Long.MAX_VALUE)
             ctx.timeout().addTimeoutObject(set);
 
-        if (set.reserved()) {
-            // Set is reserved which means that it is currently processed by worker thread.
-            if (msgC != null)
-                msgC.run();
-
-            return;
-        }
-
         final GridMessageListener lsnr = lsnrMap.get(msg.topic());
 
         if (lsnr == null) {
@@ -821,7 +814,8 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
                     "listener is registered): " + msg);
             }
 
-            // Mark the message as processed.
+            // Mark the message as processed, otherwise reading from the connection
+            // may stop.
             if (msgC != null)
                 msgC.run();
 
@@ -848,8 +842,6 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
                 }
                 finally {
                     threadProcessingMessage(false);
-
-                    msgC.run();
                 }
             }
         };
@@ -1852,7 +1844,7 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
 
         /** */
         @GridToStringInclude
-        private final Queue<IgniteBiTuple<GridIoMessage, Long>> msgs = new ConcurrentLinkedDeque<>();
+        private final Queue<GridTuple3<GridIoMessage, Long, IgniteRunnable>> msgs = new ConcurrentLinkedDeque<>();
 
         /** */
         private final AtomicBoolean reserved = new AtomicBoolean();
@@ -1873,6 +1865,7 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
          * @param timeout Timeout.
          * @param skipOnTimeout Whether message can be skipped on timeout.
          * @param msg Message to add immediately.
+         * @param msgC Message closure (may be {@code null}).
          */
         GridCommunicationMessageSet(
             GridIoPolicy plc,
@@ -1880,7 +1873,8 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
             UUID nodeId,
             long timeout,
             boolean skipOnTimeout,
-            GridIoMessage msg
+            GridIoMessage msg,
+            @Nullable IgniteRunnable msgC
         ) {
             assert nodeId != null;
             assert topic != null;
@@ -1899,7 +1893,7 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
 
             lastTs = U.currentTimeMillis();
 
-            msgs.add(F.t(msg, lastTs));
+            msgs.add(F.t(msg, lastTs, msgC));
         }
 
         /** {@inheritDoc} */
@@ -2017,15 +2011,28 @@ public class GridIoManager extends GridManagerAdapter<CommunicationSpi<Serializa
         void unwind(GridMessageListener lsnr) {
             assert reserved.get();
 
-            for (IgniteBiTuple<GridIoMessage, Long> t = msgs.poll(); t != null; t = msgs.poll())
-                lsnr.onMessage(nodeId, t.get1().message());
+            for (GridTuple3<GridIoMessage, Long, IgniteRunnable> t = msgs.poll(); t != null; t = msgs.poll()) {
+                try {
+                    lsnr.onMessage(
+                        nodeId,
+                        t.get1().message());
+                }
+                finally {
+                    if (t.get3() != null)
+                        t.get3().run();
+                }
+            }
         }
 
         /**
          * @param msg Message to add.
+         * @param msgC Message closure (may be {@code null}).
          */
-        void add(GridIoMessage msg) {
-            msgs.add(F.t(msg, U.currentTimeMillis()));
+        void add(
+            GridIoMessage msg,
+            @Nullable IgniteRunnable msgC
+        ) {
+            msgs.add(F.t(msg, U.currentTimeMillis(), msgC));
         }
 
         /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c7e74874/modules/core/src/main/java/org/apache/ignite/internal/util/nio/GridNioMessageTracker.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/nio/GridNioMessageTracker.java b/modules/core/src/main/java/org/apache/ignite/internal/util/nio/GridNioMessageTracker.java
index 52b7fed..c9ed1a0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/nio/GridNioMessageTracker.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/nio/GridNioMessageTracker.java
@@ -56,9 +56,26 @@ public class GridNioMessageTracker implements IgniteRunnable {
 
     /** {@inheritDoc} */
     @Override public void run() {
-        int cnt = msgCnt.decrementAndGet();
+        // In case of ordered messages this may be called twice for 1 message.
+        // Example: message arrives, but listener has not been installed yet.
+        // Message set is created, but message does not get actually processed.
+        // If this is not called, connection may be paused which causes hang.
+        // It seems acceptable to have the following logic accounting the aforementioned.
+        int cnt = 0;
 
-        assert cnt >= 0 : "Invalid count: " + cnt;
+        for (;;) {
+            int cur = msgCnt.get();
+
+            if (cur == 0)
+                break;
+
+            cnt = cur - 1;
+
+            if (msgCnt.compareAndSet(cur, cnt))
+                break;
+        }
+
+        assert cnt >= 0 : "Invalid count [cnt=" + cnt + ", this=" + this + ']';
 
         if (cnt < msgQueueLimit && paused && lock.tryLock()) {
             try {
@@ -116,6 +133,6 @@ public class GridNioMessageTracker implements IgniteRunnable {
 
     /** {@inheritDoc} */
     @Override public String toString() {
-        return S.toString(GridNioMessageTracker.class, this, super.toString());
+        return S.toString(GridNioMessageTracker.class, this, "hash", System.identityHashCode(this));
     }
 }


[06/21] incubator-ignite git commit: ignite-1060

Posted by sb...@apache.org.
ignite-1060


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

Branch: refs/heads/ignite-752
Commit: d685e82a5f4858a79e40a39eeb45c42ba9713f70
Parents: 3a0ccb5
Author: avinogradov <av...@gridgain.com>
Authored: Tue Jun 30 16:40:22 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Tue Jun 30 16:40:22 2015 +0300

----------------------------------------------------------------------
 assembly/dependencies-fabric.xml                |   1 +
 modules/core/src/test/resources/helloworld.gar  | Bin 6092 -> 0 bytes
 modules/core/src/test/resources/helloworld1.gar | Bin 6092 -> 0 bytes
 modules/core/src/test/resources/readme.txt      |   6 --
 modules/extdata/uri/META-INF/ignite.xml         |  38 +++++++++
 .../extdata/uri/modules/uri-dependency/pom.xml  |  42 ++++++++++
 .../deployment/uri/tasks/GarHelloWorldBean.java |  61 ++++++++++++++
 .../src/main/resources/gar-example.properties   |  18 ++++
 modules/extdata/uri/pom.xml                     |  60 +++++++++++++-
 .../deployment/uri/tasks/GarHelloWorldTask.java |  82 +++++++++++++++++++
 .../deployment/uri/tasks/gar-spring-bean.xml    |  29 +++++++
 modules/urideploy/pom.xml                       |  14 ++++
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |  13 +--
 13 files changed, 344 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/assembly/dependencies-fabric.xml
----------------------------------------------------------------------
diff --git a/assembly/dependencies-fabric.xml b/assembly/dependencies-fabric.xml
index c6668f6..b4808e7 100644
--- a/assembly/dependencies-fabric.xml
+++ b/assembly/dependencies-fabric.xml
@@ -110,6 +110,7 @@
                 <exclude>org.apache.ignite:ignite-tools</exclude>
                 <exclude>org.apache.ignite:ignite-extdata-p2p</exclude>
                 <exclude>org.apache.ignite:ignite-extdata-uri</exclude>
+                <exclude>org.apache.ignite:ignite-extdata-uri-dep</exclude>
                 <exclude>org.apache.ignite:ignite-examples</exclude>
                 <exclude>org.apache.ignite:ignite-indexing</exclude>
                 <exclude>org.apache.ignite:ignite-visor-console</exclude>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/core/src/test/resources/helloworld.gar
----------------------------------------------------------------------
diff --git a/modules/core/src/test/resources/helloworld.gar b/modules/core/src/test/resources/helloworld.gar
deleted file mode 100644
index 3b4555a..0000000
Binary files a/modules/core/src/test/resources/helloworld.gar and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/core/src/test/resources/helloworld1.gar
----------------------------------------------------------------------
diff --git a/modules/core/src/test/resources/helloworld1.gar b/modules/core/src/test/resources/helloworld1.gar
deleted file mode 100644
index 3b4555a..0000000
Binary files a/modules/core/src/test/resources/helloworld1.gar and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/core/src/test/resources/readme.txt
----------------------------------------------------------------------
diff --git a/modules/core/src/test/resources/readme.txt b/modules/core/src/test/resources/readme.txt
deleted file mode 100644
index 195d655..0000000
--- a/modules/core/src/test/resources/readme.txt
+++ /dev/null
@@ -1,6 +0,0 @@
-This folder is created for test GridTaskUriDeploymentDeadlockSelfTest. It contains helloworld.gar and helloworld1.gar
-which are the same and were copied from Apache Ignite GAR example.
-
-We put two files here to have a collision and make deployment SPI to unregister class loaders.
-
-This is intended to test GG-2852 issue.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/META-INF/ignite.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/META-INF/ignite.xml b/modules/extdata/uri/META-INF/ignite.xml
new file mode 100644
index 0000000..5ac671a
--- /dev/null
+++ b/modules/extdata/uri/META-INF/ignite.xml
@@ -0,0 +1,38 @@
+<?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.
+-->
+
+<!--
+    Spring configuration file for test classes in gar-file.
+-->
+<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">
+    <description>Ignite Spring configuration file in gar-file.</description>
+
+    <!--
+        Optional test tasks specification. If not provided, then all
+        tasks found inside GAR will be deployed.
+    -->
+    <util:list id="tasks">
+        <value>org.apache.ignite.spi.deployment.uri.tasks.GarHelloWorldTask</value>
+    </util:list>
+</beans>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/modules/uri-dependency/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/pom.xml b/modules/extdata/uri/modules/uri-dependency/pom.xml
new file mode 100644
index 0000000..5f45bbe
--- /dev/null
+++ b/modules/extdata/uri/modules/uri-dependency/pom.xml
@@ -0,0 +1,42 @@
+<?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.
+  -->
+
+<project xmlns="http://maven.apache.org/POM/4.0.0"
+         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <parent>
+        <groupId>org.apache.ignite</groupId>
+        <artifactId>ignite-parent</artifactId>
+        <version>1</version>
+        <relativePath>../../../../../parent</relativePath>
+    </parent>
+
+    <artifactId>ignite-extdata-uri-dep</artifactId>
+    <packaging>jar</packaging>
+
+    <version>1.1.6-SNAPSHOT</version>
+    <modelVersion>4.0.0</modelVersion>
+
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-core</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+    </dependencies>
+</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java b/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
new file mode 100644
index 0000000..bf329be
--- /dev/null
+++ b/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
@@ -0,0 +1,61 @@
+package org.apache.ignite.spi.deployment.uri.tasks;
+/*
+ *  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.
+ */
+
+import org.apache.ignite.internal.util.typedef.internal.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Imported class which should be placed in JAR file in GAR/lib folder.
+ * Loads message resource file via class loader.
+ */
+public class GarHelloWorldBean {
+    /** */
+    public static final String RESOURCE = "gar-example.properties";
+
+    /**
+     * Gets keyed message.
+     *
+     * @param key Message key.
+     * @return Keyed message.
+     */
+    @Nullable
+    public String getMessage(String key) {
+        InputStream in = null;
+
+        try {
+            in = getClass().getClassLoader().getResourceAsStream(RESOURCE);
+
+            Properties props = new Properties();
+
+            props.load(in);
+
+            return props.getProperty(key);
+        }
+        catch (IOException e) {
+            e.printStackTrace();
+        }
+        finally {
+            U.close(in, null);
+        }
+
+        return null;
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/modules/uri-dependency/src/main/resources/gar-example.properties
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/src/main/resources/gar-example.properties b/modules/extdata/uri/modules/uri-dependency/src/main/resources/gar-example.properties
new file mode 100644
index 0000000..e892a3c
--- /dev/null
+++ b/modules/extdata/uri/modules/uri-dependency/src/main/resources/gar-example.properties
@@ -0,0 +1,18 @@
+#
+#  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.
+#
+
+HELLOWORLD.MSG=Hello World!
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/pom.xml b/modules/extdata/uri/pom.xml
index 3d43040..a88bced 100644
--- a/modules/extdata/uri/pom.xml
+++ b/modules/extdata/uri/pom.xml
@@ -20,8 +20,10 @@
 <!--
     POM file.
 -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <modelVersion>4.0.0</modelVersion>
+    <packaging>pom</packaging>
 
     <parent>
         <groupId>org.apache.ignite</groupId>
@@ -51,8 +53,18 @@
             <artifactId>spring-beans</artifactId>
             <version>${spring.version}</version>
         </dependency>
+
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-extdata-uri-dep</artifactId>
+            <version>${project.version}</version>
+        </dependency>
     </dependencies>
 
+    <modules>
+        <module>modules/uri-dependency</module>
+    </modules>
+
     <build>
         <resources>
             <resource>
@@ -86,6 +98,21 @@
 
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-compiler-plugin</artifactId>
+                <executions>
+                    <execution>
+                        <id>compile</id>
+                        <phase>compile</phase>
+                        <goals>
+                            <!-- need to compile sources. pom packaging will not compile automatically. -->
+                            <goal>compile</goal>
+                        </goals>
+                    </execution>
+                </executions>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-antrun-plugin</artifactId>
                 <version>1.7</version>
                 <dependencies>
@@ -110,11 +137,36 @@
                         <phase>compile</phase>
                         <configuration>
                             <target>
-                                <copy file="${settings.localRepository}/com/sun/mail/javax.mail/1.5.2/javax.mail-1.5.2.jar" todir="${basedir}/target/classes/lib" />
+                                <!-- copying resources to classes -->
+                                <copy todir="${basedir}/target/classes">
+                                    <fileset dir="${basedir}/src/main/java">
+                                        <include name="**/*.xml"/>
+                                        <include name="**/*.properties"/>
+                                    </fileset>
+                                </copy>
+
+                                <copy
+                                    file="${settings.localRepository}/com/sun/mail/javax.mail/1.5.2/javax.mail-1.5.2.jar"
+                                    todir="${basedir}/target/classes/lib"/>
+
+                                <zip destfile="${basedir}/target/classes/lib/depend.jar" encoding="UTF-8">
+                                    <zipfileset dir="modules/uri-dependency/target/classes"/>
+                                </zip>
+
+                                <taskdef name="gar"
+                                         classname="org.apache.ignite.util.antgar.IgniteDeploymentGarAntTask"/>
 
-                                <taskdef name="gar" classname="org.apache.ignite.util.antgar.IgniteDeploymentGarAntTask" />
+                                <gar destfile="${basedir}/target/deploy/uri.gar" basedir="${basedir}/target/classes"/>
 
-                                <gar destfile="${basedir}/target/deploy/uri.gar" basedir="${basedir}/target/classes" />
+                                <!--
+                                This is created for test GridTaskUriDeploymentDeadlockSelfTest.
+                                We put two files here to have a collision and make deployment SPI to unregister class loaders.
+                                This is intended to test GG-2852 issue.
+                                -->
+                                <gar destfile="${basedir}/target/resources/helloworld.gar"
+                                     descrdir="${basedir}/META-INF" basedir="${basedir}/target/classes"/>
+                                <gar destfile="${basedir}/target/resources/helloworld1.gar"
+                                     descrdir="${basedir}/META-INF" basedir="${basedir}/target/classes"/>
                             </target>
                         </configuration>
                     </execution>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
new file mode 100644
index 0000000..13b2641
--- /dev/null
+++ b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
@@ -0,0 +1,82 @@
+/*
+ *  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.
+ */
+
+package org.apache.ignite.spi.deployment.uri.tasks;
+
+import org.apache.ignite.*;
+import org.apache.ignite.compute.*;
+import org.jetbrains.annotations.*;
+import org.springframework.beans.factory.support.*;
+import org.springframework.beans.factory.xml.*;
+import org.springframework.core.io.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * This class defines grid task for this example. Grid task is responsible for splitting the task into jobs. This
+ * particular implementation splits given string into individual words and creates grid jobs for each word. Task class
+ * in that example should be placed in GAR file.
+ */
+@ComputeTaskName("GarHelloWorldTask")
+public class GarHelloWorldTask extends ComputeTaskSplitAdapter<String, String> {
+    /** {@inheritDoc} */
+    @Override public Collection<? extends ComputeJob> split(int gridSize, String arg) throws IgniteException {
+        // Create Spring context.
+        AbstractBeanFactory fac = new XmlBeanFactory(
+            new ClassPathResource("org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml", getClass().getClassLoader()));
+
+        fac.setBeanClassLoader(getClass().getClassLoader());
+
+        // Load imported bean from GAR/lib folder.
+        GarHelloWorldBean bean = (GarHelloWorldBean)fac.getBean("example.bean");
+
+        String msg = bean.getMessage(arg);
+
+        assert msg != null;
+
+        // Split the passed in phrase into multiple words separated by spaces.
+        List<String> words = Arrays.asList(msg.split(" "));
+
+        Collection<ComputeJob> jobs = new ArrayList<>(words.size());
+
+        // Use imperative OOP APIs.
+        for (String word : words) {
+            // Every job gets its own word as an argument.
+            jobs.add(new ComputeJobAdapter(word) {
+                /*
+                 * Simply prints the job's argument.
+                 */
+                @Nullable
+                @Override public Serializable execute() {
+                    System.out.println(">>>");
+                    System.out.println(">>> Printing '" + argument(0) + "' on this node from grid job.");
+                    System.out.println(">>>");
+
+                    // This job does not return any result.
+                    return null;
+                }
+            });
+        }
+
+        return jobs;
+    }
+
+    @Nullable @Override public String reduce(List<ComputeJobResult> results) throws IgniteException {
+        return String.valueOf(results.size());
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
new file mode 100644
index 0000000..c3cf3e4
--- /dev/null
+++ b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
@@ -0,0 +1,29 @@
+<?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"
+       xsi:schemaLocation="
+        http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
+    <description>Spring file for GAR example.</description>
+
+    <!--
+        Bean used from imported jar file from GAR/lib.
+    -->
+    <bean id="example.bean" class="org.apache.ignite.spi.deployment.uri.tasks.GarHelloWorldBean" scope="singleton"/>
+</beans>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/urideploy/pom.xml
----------------------------------------------------------------------
diff --git a/modules/urideploy/pom.xml b/modules/urideploy/pom.xml
index 0add261..d14cff7 100644
--- a/modules/urideploy/pom.xml
+++ b/modules/urideploy/pom.xml
@@ -143,5 +143,19 @@
             <artifactId>log4j</artifactId>
             <scope>test</scope>
         </dependency>
+
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-extdata-uri</artifactId>
+            <version>${project.version}</version>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-extdata-p2p</artifactId>
+            <version>${project.version}</version>
+            <scope>test</scope>
+        </dependency>
     </dependencies>
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d685e82a/modules/urideploy/src/test/java/org/apache/ignite/internal/GridTaskUriDeploymentDeadlockSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/urideploy/src/test/java/org/apache/ignite/internal/GridTaskUriDeploymentDeadlockSelfTest.java b/modules/urideploy/src/test/java/org/apache/ignite/internal/GridTaskUriDeploymentDeadlockSelfTest.java
index a060868..d41542f 100644
--- a/modules/urideploy/src/test/java/org/apache/ignite/internal/GridTaskUriDeploymentDeadlockSelfTest.java
+++ b/modules/urideploy/src/test/java/org/apache/ignite/internal/GridTaskUriDeploymentDeadlockSelfTest.java
@@ -44,7 +44,7 @@ public class GridTaskUriDeploymentDeadlockSelfTest extends GridCommonAbstractTes
         UriDeploymentSpi deploymentSpi = new UriDeploymentSpi();
 
         deploymentSpi.setUriList(
-            Arrays.asList(U.resolveIgniteUrl("modules/core/src/test/resources/").toURI().toString()));
+            Arrays.asList(U.resolveIgniteUrl("modules/extdata/uri/target/resources/").toURI().toString()));
 
         if (gridName.endsWith("2")) {
             // Delay deployment for 2nd grid only.
@@ -91,18 +91,11 @@ public class GridTaskUriDeploymentDeadlockSelfTest extends GridCommonAbstractTes
 
             info(">>> Starting task.");
 
-            executeAsync(compute(g.cluster().forPredicate(F.equalTo(F.first(g.cluster().forRemotes().nodes())))),
-                "GridGarHelloWorldTask", "HELLOWORLD.MSG").get(60000);
+            assert "2".equals(executeAsync(compute(g.cluster().forPredicate(F.equalTo(F.first(g.cluster().forRemotes().nodes())))),
+                "GarHelloWorldTask", "HELLOWORLD.MSG").get(60000));
 
             f.get();
         }
-        catch (Exception e) {
-            error("Test failed.", e);
-
-            // With former version of GridDeploymentLocalStore test hangs forever.
-            // So, we need to forcibly exit.
-            // System.exit(1);
-        }
         finally {
             stopAllGrids();
         }


[03/21] incubator-ignite git commit: IGNITE-1046 Added license.

Posted by sb...@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-752
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=""
 


[09/21] incubator-ignite git commit: # ignite-sprint-7 minor

Posted by sb...@apache.org.
# ignite-sprint-7 minor


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

Branch: refs/heads/ignite-752
Commit: e0c53b8171add7bfed0249c67a8e743443b7593f
Parents: e91bc48
Author: sboikov <sb...@gridgain.com>
Authored: Wed Jul 1 10:06:20 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Wed Jul 1 10:06:20 2015 +0300

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


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/e0c53b81/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
index fa3e564..720ce3a 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
@@ -2332,7 +2332,7 @@ class ServerImpl extends TcpDiscoveryImpl {
 
                 LT.warn(log, null, "Local node has detected failed nodes and started cluster-wide procedure. " +
                         "To speed up failure detection please see 'Failure Detection' section under javadoc" +
-                        "for 'TcpDiscoverySpi'");
+                        " for 'TcpDiscoverySpi'");
             }
         }
 


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

Posted by sb...@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-752
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(-)
----------------------------------------------------------------------



[13/21] incubator-ignite git commit: 1.2.1-SNAPSHOT

Posted by sb...@apache.org.
1.2.1-SNAPSHOT


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

Branch: refs/heads/ignite-752
Commit: 204823c3300ca5c79c2972a8cb3e8dab044ac8d3
Parents: c7e7487
Author: Ignite Teamcity <ig...@apache.org>
Authored: Wed Jul 1 13:04:20 2015 +0300
Committer: Ignite Teamcity <ig...@apache.org>
Committed: Wed Jul 1 13:04:20 2015 +0300

----------------------------------------------------------------------
 examples/pom.xml                                  |  2 +-
 modules/aop/pom.xml                               |  2 +-
 modules/aws/pom.xml                               |  2 +-
 modules/clients/pom.xml                           |  2 +-
 modules/cloud/pom.xml                             |  2 +-
 modules/codegen/pom.xml                           |  2 +-
 modules/core/pom.xml                              |  2 +-
 modules/core/src/main/resources/ignite.properties |  2 +-
 modules/extdata/p2p/pom.xml                       |  2 +-
 modules/extdata/uri/pom.xml                       |  2 +-
 modules/gce/pom.xml                               |  2 +-
 modules/geospatial/pom.xml                        |  2 +-
 modules/hadoop/pom.xml                            |  2 +-
 modules/hibernate/pom.xml                         |  2 +-
 modules/indexing/pom.xml                          |  2 +-
 modules/jcl/pom.xml                               |  2 +-
 modules/jta/pom.xml                               |  2 +-
 modules/log4j/pom.xml                             |  2 +-
 modules/mesos/pom.xml                             |  2 +-
 modules/rest-http/pom.xml                         |  2 +-
 modules/scalar-2.10/pom.xml                       |  2 +-
 modules/scalar/pom.xml                            |  2 +-
 modules/schedule/pom.xml                          |  2 +-
 modules/schema-import/pom.xml                     |  2 +-
 modules/slf4j/pom.xml                             |  2 +-
 modules/spark-2.10/pom.xml                        |  2 +-
 modules/spark/pom.xml                             |  2 +-
 modules/spring/pom.xml                            |  2 +-
 modules/ssh/pom.xml                               |  2 +-
 modules/tools/pom.xml                             |  2 +-
 modules/urideploy/pom.xml                         |  2 +-
 modules/visor-console-2.10/pom.xml                |  2 +-
 modules/visor-console/pom.xml                     |  2 +-
 modules/visor-plugins/pom.xml                     |  2 +-
 modules/web/pom.xml                               |  2 +-
 modules/yardstick/pom.xml                         |  2 +-
 pom.xml                                           | 14 +++++++-------
 37 files changed, 43 insertions(+), 43 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/examples/pom.xml
----------------------------------------------------------------------
diff --git a/examples/pom.xml b/examples/pom.xml
index bcff11e..2f292e9 100644
--- a/examples/pom.xml
+++ b/examples/pom.xml
@@ -28,7 +28,7 @@
     </parent>
 
     <artifactId>ignite-examples</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/aop/pom.xml
----------------------------------------------------------------------
diff --git a/modules/aop/pom.xml b/modules/aop/pom.xml
index 5eea18d..704358f 100644
--- a/modules/aop/pom.xml
+++ b/modules/aop/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-aop</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/aws/pom.xml
----------------------------------------------------------------------
diff --git a/modules/aws/pom.xml b/modules/aws/pom.xml
index 05ecbc1..38d300e 100644
--- a/modules/aws/pom.xml
+++ b/modules/aws/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-aws</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/clients/pom.xml
----------------------------------------------------------------------
diff --git a/modules/clients/pom.xml b/modules/clients/pom.xml
index 7c4d2c8..ca68ef8 100644
--- a/modules/clients/pom.xml
+++ b/modules/clients/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-clients</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/cloud/pom.xml
----------------------------------------------------------------------
diff --git a/modules/cloud/pom.xml b/modules/cloud/pom.xml
index bb32689..d752588 100644
--- a/modules/cloud/pom.xml
+++ b/modules/cloud/pom.xml
@@ -29,7 +29,7 @@
     </parent>
 
     <artifactId>ignite-cloud</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <properties>
         <jcloud.version>1.9.0</jcloud.version>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/codegen/pom.xml
----------------------------------------------------------------------
diff --git a/modules/codegen/pom.xml b/modules/codegen/pom.xml
index 1ea5fe5..9a09a69 100644
--- a/modules/codegen/pom.xml
+++ b/modules/codegen/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-codegen</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <properties>
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/core/pom.xml
----------------------------------------------------------------------
diff --git a/modules/core/pom.xml b/modules/core/pom.xml
index 79fbc2f..c7cb953 100644
--- a/modules/core/pom.xml
+++ b/modules/core/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-core</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/core/src/main/resources/ignite.properties
----------------------------------------------------------------------
diff --git a/modules/core/src/main/resources/ignite.properties b/modules/core/src/main/resources/ignite.properties
index b25b2ca..830ca22 100644
--- a/modules/core/src/main/resources/ignite.properties
+++ b/modules/core/src/main/resources/ignite.properties
@@ -15,7 +15,7 @@
 # limitations under the License.
 #
 
-ignite.version=1.1.6-SNAPSHOT
+ignite.version=1.2.1-SNAPSHOT
 ignite.build=0
 ignite.revision=DEV
 ignite.rel.date=01011970

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/extdata/p2p/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/p2p/pom.xml b/modules/extdata/p2p/pom.xml
index 26f2e50..0ee1d9b 100644
--- a/modules/extdata/p2p/pom.xml
+++ b/modules/extdata/p2p/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-extdata-p2p</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/extdata/uri/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/pom.xml b/modules/extdata/uri/pom.xml
index 1690ab9..f2b3936 100644
--- a/modules/extdata/uri/pom.xml
+++ b/modules/extdata/uri/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-extdata-uri</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/gce/pom.xml
----------------------------------------------------------------------
diff --git a/modules/gce/pom.xml b/modules/gce/pom.xml
index 127c7a4..f132d39 100644
--- a/modules/gce/pom.xml
+++ b/modules/gce/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-gce</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/geospatial/pom.xml
----------------------------------------------------------------------
diff --git a/modules/geospatial/pom.xml b/modules/geospatial/pom.xml
index e28c139..10035c6 100644
--- a/modules/geospatial/pom.xml
+++ b/modules/geospatial/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-geospatial</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/hadoop/pom.xml
----------------------------------------------------------------------
diff --git a/modules/hadoop/pom.xml b/modules/hadoop/pom.xml
index e300ba0..bb46b2a 100644
--- a/modules/hadoop/pom.xml
+++ b/modules/hadoop/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-hadoop</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/hibernate/pom.xml
----------------------------------------------------------------------
diff --git a/modules/hibernate/pom.xml b/modules/hibernate/pom.xml
index d001b02..3130f4b 100644
--- a/modules/hibernate/pom.xml
+++ b/modules/hibernate/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-hibernate</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/indexing/pom.xml
----------------------------------------------------------------------
diff --git a/modules/indexing/pom.xml b/modules/indexing/pom.xml
index b044092..8c02e02 100644
--- a/modules/indexing/pom.xml
+++ b/modules/indexing/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-indexing</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/jcl/pom.xml
----------------------------------------------------------------------
diff --git a/modules/jcl/pom.xml b/modules/jcl/pom.xml
index b764c96..9f65eb0 100644
--- a/modules/jcl/pom.xml
+++ b/modules/jcl/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-jcl</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/jta/pom.xml
----------------------------------------------------------------------
diff --git a/modules/jta/pom.xml b/modules/jta/pom.xml
index 531e6f2..2d4df0b 100644
--- a/modules/jta/pom.xml
+++ b/modules/jta/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-jta</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/log4j/pom.xml
----------------------------------------------------------------------
diff --git a/modules/log4j/pom.xml b/modules/log4j/pom.xml
index af62389..3343438 100644
--- a/modules/log4j/pom.xml
+++ b/modules/log4j/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-log4j</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/mesos/pom.xml
----------------------------------------------------------------------
diff --git a/modules/mesos/pom.xml b/modules/mesos/pom.xml
index 07bee9e..491667d 100644
--- a/modules/mesos/pom.xml
+++ b/modules/mesos/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-mesos</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <properties>
         <jetty.version>9.2.10.v20150310</jetty.version>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/rest-http/pom.xml
----------------------------------------------------------------------
diff --git a/modules/rest-http/pom.xml b/modules/rest-http/pom.xml
index 2d7fe6d..c4cb62d 100644
--- a/modules/rest-http/pom.xml
+++ b/modules/rest-http/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-rest-http</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/scalar-2.10/pom.xml
----------------------------------------------------------------------
diff --git a/modules/scalar-2.10/pom.xml b/modules/scalar-2.10/pom.xml
index c4b8d60..b7c9178 100644
--- a/modules/scalar-2.10/pom.xml
+++ b/modules/scalar-2.10/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-scalar_2.10</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/scalar/pom.xml
----------------------------------------------------------------------
diff --git a/modules/scalar/pom.xml b/modules/scalar/pom.xml
index a048939..7a2e243 100644
--- a/modules/scalar/pom.xml
+++ b/modules/scalar/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-scalar</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/schedule/pom.xml
----------------------------------------------------------------------
diff --git a/modules/schedule/pom.xml b/modules/schedule/pom.xml
index 735035f..49b75bd 100644
--- a/modules/schedule/pom.xml
+++ b/modules/schedule/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-schedule</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/schema-import/pom.xml
----------------------------------------------------------------------
diff --git a/modules/schema-import/pom.xml b/modules/schema-import/pom.xml
index 2898327..7f8fff4 100644
--- a/modules/schema-import/pom.xml
+++ b/modules/schema-import/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-schema-import</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/slf4j/pom.xml
----------------------------------------------------------------------
diff --git a/modules/slf4j/pom.xml b/modules/slf4j/pom.xml
index fb7c86e..01ad28f 100644
--- a/modules/slf4j/pom.xml
+++ b/modules/slf4j/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-slf4j</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/spark-2.10/pom.xml
----------------------------------------------------------------------
diff --git a/modules/spark-2.10/pom.xml b/modules/spark-2.10/pom.xml
index 1b8b04e..7463d52 100644
--- a/modules/spark-2.10/pom.xml
+++ b/modules/spark-2.10/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-spark_2.10</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/spark/pom.xml
----------------------------------------------------------------------
diff --git a/modules/spark/pom.xml b/modules/spark/pom.xml
index 8c00ec8..265bb16 100644
--- a/modules/spark/pom.xml
+++ b/modules/spark/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-spark</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/spring/pom.xml
----------------------------------------------------------------------
diff --git a/modules/spring/pom.xml b/modules/spring/pom.xml
index 35638fe..ab98384 100644
--- a/modules/spring/pom.xml
+++ b/modules/spring/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-spring</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/ssh/pom.xml
----------------------------------------------------------------------
diff --git a/modules/ssh/pom.xml b/modules/ssh/pom.xml
index 23ae1df..708be4f 100644
--- a/modules/ssh/pom.xml
+++ b/modules/ssh/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-ssh</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/tools/pom.xml
----------------------------------------------------------------------
diff --git a/modules/tools/pom.xml b/modules/tools/pom.xml
index 9e5685d..17ba197 100644
--- a/modules/tools/pom.xml
+++ b/modules/tools/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-tools</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <properties>
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/urideploy/pom.xml
----------------------------------------------------------------------
diff --git a/modules/urideploy/pom.xml b/modules/urideploy/pom.xml
index 0add261..76a862b 100644
--- a/modules/urideploy/pom.xml
+++ b/modules/urideploy/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-urideploy</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/visor-console-2.10/pom.xml
----------------------------------------------------------------------
diff --git a/modules/visor-console-2.10/pom.xml b/modules/visor-console-2.10/pom.xml
index 8806438..193e676 100644
--- a/modules/visor-console-2.10/pom.xml
+++ b/modules/visor-console-2.10/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-visor-console_2.10</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/visor-console/pom.xml
----------------------------------------------------------------------
diff --git a/modules/visor-console/pom.xml b/modules/visor-console/pom.xml
index 8c6e4c9..87fa4f9 100644
--- a/modules/visor-console/pom.xml
+++ b/modules/visor-console/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-visor-console</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/visor-plugins/pom.xml
----------------------------------------------------------------------
diff --git a/modules/visor-plugins/pom.xml b/modules/visor-plugins/pom.xml
index e4162c0..8a80009 100644
--- a/modules/visor-plugins/pom.xml
+++ b/modules/visor-plugins/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-visor-plugins</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <!-- Ignite dependencies -->

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/web/pom.xml
----------------------------------------------------------------------
diff --git a/modules/web/pom.xml b/modules/web/pom.xml
index e6a23bd..f109880 100644
--- a/modules/web/pom.xml
+++ b/modules/web/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-web</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <dependencies>
         <dependency>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/modules/yardstick/pom.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/pom.xml b/modules/yardstick/pom.xml
index 5307447..a9ee178 100644
--- a/modules/yardstick/pom.xml
+++ b/modules/yardstick/pom.xml
@@ -31,7 +31,7 @@
     </parent>
 
     <artifactId>ignite-yardstick</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
 
     <properties>
         <yardstick.version>0.7.0</yardstick.version>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/204823c3/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 4f2441c..a6d1609 100644
--- a/pom.xml
+++ b/pom.xml
@@ -32,7 +32,7 @@
 
     <groupId>org.apache.ignite</groupId>
     <artifactId>apache-ignite</artifactId>
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
     <packaging>pom</packaging>
 
     <properties>
@@ -604,12 +604,12 @@
                                         </copy>
 
                                         <!-- appending filename to md5 and sha1 files. to be improved. -->
-                                        <echo file="${basedir}/target/site/${project.artifactId}-fabric-${project.version}-bin.zip.md5" append="true" message=" ${project.artifactId}-fabric-${project.version}-bin.zip"/>
-                                        <echo file="${basedir}/target/site/${project.artifactId}-fabric-${project.version}-bin.zip.sha1" append="true" message=" ${project.artifactId}-fabric-${project.version}-bin.zip"/>
-                                        <echo file="${basedir}/target/site/${project.artifactId}-hadoop-${project.version}-bin.zip.md5" append="true" message=" ${project.artifactId}-hadoop-${project.version}-bin.zip"/>
-                                        <echo file="${basedir}/target/site/${project.artifactId}-hadoop-${project.version}-bin.zip.sha1" append="true" message=" ${project.artifactId}-hadoop-${project.version}-bin.zip"/>
-                                        <echo file="${basedir}/target/site/${project.artifactId}-${project.version}-src.zip.md5" append="true" message=" ${project.artifactId}-${project.version}-src.zip"/>
-                                        <echo file="${basedir}/target/site/${project.artifactId}-${project.version}-src.zip.sha1" append="true" message=" ${project.artifactId}-${project.version}-src.zip"/>
+                                        <echo file="${basedir}/target/site/${project.artifactId}-fabric-${project.version}-bin.zip.md5" append="true" message=" ${project.artifactId}-fabric-${project.version}-bin.zip" />
+                                        <echo file="${basedir}/target/site/${project.artifactId}-fabric-${project.version}-bin.zip.sha1" append="true" message=" ${project.artifactId}-fabric-${project.version}-bin.zip" />
+                                        <echo file="${basedir}/target/site/${project.artifactId}-hadoop-${project.version}-bin.zip.md5" append="true" message=" ${project.artifactId}-hadoop-${project.version}-bin.zip" />
+                                        <echo file="${basedir}/target/site/${project.artifactId}-hadoop-${project.version}-bin.zip.sha1" append="true" message=" ${project.artifactId}-hadoop-${project.version}-bin.zip" />
+                                        <echo file="${basedir}/target/site/${project.artifactId}-${project.version}-src.zip.md5" append="true" message=" ${project.artifactId}-${project.version}-src.zip" />
+                                        <echo file="${basedir}/target/site/${project.artifactId}-${project.version}-src.zip.sha1" append="true" message=" ${project.artifactId}-${project.version}-src.zip" />
 
                                         <copy file="${basedir}/KEYS" todir="${basedir}/target/site" failonerror="false" />
                                     </target>


[18/21] incubator-ignite git commit: ignite-sprint-7 - compilation

Posted by sb...@apache.org.
ignite-sprint-7 - compilation


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

Branch: refs/heads/ignite-752
Commit: af3cfdf16ad68ce2ec3e7b1cab1d0b3116d831eb
Parents: 44b187d
Author: S.Vladykin <sv...@gridgain.com>
Authored: Wed Jul 1 11:19:43 2015 -0700
Committer: S.Vladykin <sv...@gridgain.com>
Committed: Wed Jul 1 11:19:43 2015 -0700

----------------------------------------------------------------------
 modules/extdata/uri/modules/uri-dependency/pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/af3cfdf1/modules/extdata/uri/modules/uri-dependency/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/pom.xml b/modules/extdata/uri/modules/uri-dependency/pom.xml
index 5f45bbe..3f3a188 100644
--- a/modules/extdata/uri/modules/uri-dependency/pom.xml
+++ b/modules/extdata/uri/modules/uri-dependency/pom.xml
@@ -29,7 +29,7 @@
     <artifactId>ignite-extdata-uri-dep</artifactId>
     <packaging>jar</packaging>
 
-    <version>1.1.6-SNAPSHOT</version>
+    <version>1.2.1-SNAPSHOT</version>
     <modelVersion>4.0.0</modelVersion>
 
     <dependencies>


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

Posted by sb...@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-752
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(-)
----------------------------------------------------------------------



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

Posted by sb...@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-752
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


[19/21] incubator-ignite git commit: license fix

Posted by sb...@apache.org.
license fix


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

Branch: refs/heads/ignite-752
Commit: d3783a1b3a00f89b35eb90867ced83337ce96d05
Parents: af3cfdf
Author: Anton Vinogradov <av...@gridgain.com>
Authored: Wed Jul 1 21:34:40 2015 +0300
Committer: Anton Vinogradov <av...@gridgain.com>
Committed: Wed Jul 1 21:34:40 2015 +0300

----------------------------------------------------------------------
 .../extdata/uri/modules/uri-dependency/pom.xml  | 30 ++++++++++----------
 .../deployment/uri/tasks/gar-spring-bean.xml    | 30 ++++++++++----------
 2 files changed, 30 insertions(+), 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d3783a1b/modules/extdata/uri/modules/uri-dependency/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/pom.xml b/modules/extdata/uri/modules/uri-dependency/pom.xml
index 3f3a188..c92eb38 100644
--- a/modules/extdata/uri/modules/uri-dependency/pom.xml
+++ b/modules/extdata/uri/modules/uri-dependency/pom.xml
@@ -1,20 +1,20 @@
 <?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.
-  -->
+  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.
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0"
          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d3783a1b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
index c3cf3e4..391b282 100644
--- a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
+++ b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/gar-spring-bean.xml
@@ -1,20 +1,20 @@
 <?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.
-  -->
+  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"


[15/21] incubator-ignite git commit: ignite-sprint-7: merge from ignite-934

Posted by sb...@apache.org.
ignite-sprint-7: merge from ignite-934


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

Branch: refs/heads/ignite-752
Commit: cc0936fa76eba5556402632eef5f06325206bac0
Parents: e91bc48
Author: Denis Magda <dm...@gridgain.com>
Authored: Wed Jul 1 16:59:14 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Wed Jul 1 16:59:14 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/compute/ComputeTaskSplitAdapter.java    | 2 +-
 .../org/apache/ignite/p2p/GridP2PContinuousDeploymentSelfTest.java | 2 --
 2 files changed, 1 insertion(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cc0936fa/modules/core/src/main/java/org/apache/ignite/compute/ComputeTaskSplitAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/compute/ComputeTaskSplitAdapter.java b/modules/core/src/main/java/org/apache/ignite/compute/ComputeTaskSplitAdapter.java
index bc4b3c2..7b3b0d6 100644
--- a/modules/core/src/main/java/org/apache/ignite/compute/ComputeTaskSplitAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/compute/ComputeTaskSplitAdapter.java
@@ -73,7 +73,7 @@ public abstract class ComputeTaskSplitAdapter<T, R> extends ComputeTaskAdapter<T
 
     /** Load balancer. */
     @LoadBalancerResource
-    private transient ComputeLoadBalancer balancer;
+    private ComputeLoadBalancer balancer;
 
     /**
      * This is a simplified version of {@link ComputeTask#map(List, Object)} method.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cc0936fa/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentSelfTest.java b/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentSelfTest.java
index 6b3ad63..c71ccbb 100644
--- a/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/p2p/GridP2PContinuousDeploymentSelfTest.java
@@ -98,8 +98,6 @@ public class GridP2PContinuousDeploymentSelfTest extends GridCommonAbstractTest
      */
     @SuppressWarnings("unchecked")
     public void testDeployment() throws Exception {
-        fail("https://issues.apache.org/jira/browse/IGNITE-934");
-
         Ignite ignite = startGrid(GRID_NAME);
 
         Class cls = getExternalClassLoader().loadClass(TEST_TASK_1);


[16/21] incubator-ignite git commit: Merge branch 'ignite-sprint-7' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-sprint-7

Posted by sb...@apache.org.
Merge branch 'ignite-sprint-7' of https://git-wip-us.apache.org/repos/asf/incubator-ignite 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/da6ff647
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/da6ff647
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/da6ff647

Branch: refs/heads/ignite-752
Commit: da6ff647913a6e97a567e8108a2fefcd12709e94
Parents: cc0936f 5269bab
Author: Denis Magda <dm...@gridgain.com>
Authored: Wed Jul 1 16:59:39 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Wed Jul 1 16:59:39 2015 +0300

----------------------------------------------------------------------
 examples/pom.xml                                |  2 +-
 modules/aop/pom.xml                             |  2 +-
 modules/aws/pom.xml                             |  2 +-
 modules/clients/pom.xml                         |  2 +-
 modules/cloud/pom.xml                           |  2 +-
 modules/codegen/pom.xml                         |  2 +-
 modules/core/pom.xml                            |  2 +-
 .../managers/communication/GridIoManager.java   | 49 +++++++++-------
 .../processors/cache/IgniteCacheFutureImpl.java | 42 +++++++++++++
 .../processors/cache/IgniteCacheProxy.java      |  2 +-
 .../internal/util/future/IgniteFutureImpl.java  | 18 ++++--
 .../util/nio/GridNioMessageTracker.java         | 23 +++++++-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  2 +-
 .../core/src/main/resources/ignite.properties   |  2 +-
 modules/docker/Dockerfile                       | 55 +++++++++++++++++
 modules/docker/README.txt                       | 11 ++++
 modules/docker/build_users_libs.sh              | 39 ++++++++++++
 modules/docker/download_ignite.sh               | 49 ++++++++++++++++
 modules/docker/execute.sh                       | 62 ++++++++++++++++++++
 modules/docker/run.sh                           | 34 +++++++++++
 modules/extdata/p2p/pom.xml                     |  2 +-
 modules/extdata/uri/pom.xml                     |  2 +-
 modules/gce/pom.xml                             |  2 +-
 modules/geospatial/pom.xml                      |  2 +-
 modules/hadoop/pom.xml                          |  2 +-
 modules/hibernate/pom.xml                       |  2 +-
 modules/indexing/pom.xml                        |  2 +-
 modules/jcl/pom.xml                             |  2 +-
 modules/jta/pom.xml                             |  2 +-
 modules/log4j/pom.xml                           |  2 +-
 modules/mesos/pom.xml                           |  2 +-
 modules/rest-http/pom.xml                       |  2 +-
 modules/scalar-2.10/pom.xml                     |  2 +-
 modules/scalar/pom.xml                          |  2 +-
 modules/schedule/pom.xml                        |  2 +-
 modules/schema-import/pom.xml                   |  2 +-
 modules/slf4j/pom.xml                           |  2 +-
 modules/spark-2.10/pom.xml                      |  2 +-
 modules/spark/pom.xml                           |  2 +-
 modules/spring/pom.xml                          |  2 +-
 modules/ssh/pom.xml                             |  2 +-
 modules/tools/pom.xml                           |  2 +-
 modules/urideploy/pom.xml                       |  2 +-
 modules/visor-console-2.10/pom.xml              |  2 +-
 modules/visor-console/pom.xml                   |  2 +-
 modules/visor-plugins/pom.xml                   |  2 +-
 modules/web/pom.xml                             |  2 +-
 modules/yardstick/pom.xml                       |  2 +-
 pom.xml                                         | 14 ++---
 49 files changed, 399 insertions(+), 73 deletions(-)
----------------------------------------------------------------------



[04/21] incubator-ignite git commit: IGNITE-1046 Added license.

Posted by sb...@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-752
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


[21/21] incubator-ignite git commit: ignite-752: improvements

Posted by sb...@apache.org.
ignite-752: improvements


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

Branch: refs/heads/ignite-752
Commit: dd076a0899f464e331fab8aa27643be542259937
Parents: 12ba6bc
Author: Denis Magda <dm...@gridgain.com>
Authored: Thu Jul 2 10:19:48 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Thu Jul 2 10:19:48 2015 +0300

----------------------------------------------------------------------
 .../configuration/IgniteConfiguration.java      |   3 +
 .../communication/tcp/TcpCommunicationSpi.java  |  28 ++--
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   2 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   2 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  12 +-
 .../IgniteConfigurationValidationSelfTest.java  | 141 +++++++++++++++++++
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |   4 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 8 files changed, 177 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
index d1d55ee..3fec5a4 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
@@ -1196,6 +1196,9 @@ public class IgniteConfiguration {
      * In case of {@link TcpCommunicationSpi} this timeout is set as default for socket connection timeout and
      * used for maximum socket connection timeout calculation.
      *
+     * Refer to {@link TcpDiscoverySpi} and {@link TcpCommunicationSpi} if advanced network related settings are
+     * required.
+     *
      * @param spiCommTimeout SPI communication timeout.
      * @return {@code this} for chaining.
      */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
index c9976af..bf3fa46 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
@@ -179,6 +179,9 @@ public class TcpCommunicationSpi extends IgniteSpiAdapter
     /** Default message queue limit per connection (for incoming and outgoing . */
     public static final int DFLT_MSG_QUEUE_LIMIT = GridNioServer.DFLT_SEND_QUEUE_LIMIT;
 
+    /** Default max connection timeout can't be bigger than this value. */
+    public static final long DFLT_MAX_CONN_TIMEOUT_LIMIT = 20000;
+
     /**
      * Default count of selectors for TCP server equals to
      * {@code "Math.min(4, Runtime.getRuntime().availableProcessors())"}.
@@ -1243,6 +1246,15 @@ public class TcpCommunicationSpi extends IgniteSpiAdapter
     @Override public Map<String, Object> getNodeAttributes() throws IgniteSpiException {
         nodeIdMsg = new NodeIdMessage(getLocalNodeId());
 
+        if (connTimeout == null)
+            connTimeout = ignite.configuration().getSpiCommunicationTimeout() != null ?
+                ignite.configuration().getSpiCommunicationTimeout() :
+                IgniteConfiguration.DFLT_SPI_COMMUNICATION_TIMEOUT;
+
+        if (maxConnTimeout == null)
+            // connTimeout will be doubled at least four times before failing. Using geometric progression formula.
+            maxConnTimeout = defaultMaxConnectTimeout();
+
         assertParameter(locPort > 1023, "locPort > 1023");
         assertParameter(locPort <= 0xffff, "locPort < 0xffff");
         assertParameter(locPortRange >= 0, "locPortRange >= 0");
@@ -1313,15 +1325,6 @@ public class TcpCommunicationSpi extends IgniteSpiAdapter
     @Override public void spiStart(String gridName) throws IgniteSpiException {
         assert locHost != null;
 
-        if (connTimeout == null)
-            connTimeout = ignite.configuration().getSpiCommunicationTimeout() != null ?
-                ignite.configuration().getSpiCommunicationTimeout() :
-                IgniteConfiguration.DFLT_SPI_COMMUNICATION_TIMEOUT;
-
-        if (maxConnTimeout == null)
-            // connTimeout will be doubled at least four times before failing. Using geometric progression formula.
-            maxConnTimeout = defaultMaxConnectTimeout();
-
         // Start SPI start stopwatch.
         startStopwatch();
 
@@ -2366,7 +2369,12 @@ public class TcpCommunicationSpi extends IgniteSpiAdapter
      * @return Max connect timeout.
      */
     private long defaultMaxConnectTimeout() {
-        return getConnectTimeout() * (1 << 4);
+        long maxTimeout = getConnectTimeout() * (1 << 4);
+
+        if (maxTimeout > DFLT_MAX_CONN_TIMEOUT_LIMIT)
+            maxTimeout = DFLT_MAX_CONN_TIMEOUT_LIMIT;
+
+        return maxTimeout;
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ClientImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ClientImpl.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ClientImpl.java
index 04276d2..4d4e6f6 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ClientImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ClientImpl.java
@@ -982,7 +982,7 @@ class ClientImpl extends TcpDiscoveryImpl {
                     try {
                         oldTimeout = sock.getSoTimeout();
 
-                        sock.setSoTimeout((int)spi.netTimeout);
+                        sock.setSoTimeout(spi.netTimeout.intValue());
 
                         InputStream in = new BufferedInputStream(sock.getInputStream());
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
index 720ce3a..2f20cd1 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ServerImpl.java
@@ -4044,7 +4044,7 @@ class ServerImpl extends TcpDiscoveryImpl {
 
                     int timeout = sock.getSoTimeout();
 
-                    sock.setSoTimeout((int)spi.netTimeout);
+                    sock.setSoTimeout(spi.netTimeout.intValue());
 
                     for (IgniteInClosure<Socket> connLsnr : spi.incomeConnLsnrs)
                         connLsnr.apply(sock);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
index 764ec92..bfab4ce 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
@@ -193,6 +193,9 @@ public class TcpDiscoverySpi extends IgniteSpiAdapter implements DiscoverySpi, T
     /** Default statistics print frequency in milliseconds (value is <tt>0ms</tt>). */
     public static final long DFLT_STATS_PRINT_FREQ = 0;
 
+    /** Default max ack timeout can't be bigger than this value. */
+    public static final long DFLT_MAX_ACK_TIMEOUT_LIMIT = 20000;
+
     /** Local address. */
     protected String locAddr;
 
@@ -499,7 +502,7 @@ public class TcpDiscoverySpi extends IgniteSpiAdapter implements DiscoverySpi, T
      * is reached, then the process of message sending is considered as failed.
      * <p>
      * If not specified, default is calculated in a way that message acknowledgement timeout will be doubled and used
-     * at least four times before failing.
+     * at least four times before failing and must be no bigger than {@link #DFLT_MAX_ACK_TIMEOUT_LIMIT}.
      * <p>
      * Affected server nodes only.
      *
@@ -1779,7 +1782,12 @@ public class TcpDiscoverySpi extends IgniteSpiAdapter implements DiscoverySpi, T
      * @return Max acknowledgement timeout.
      */
     private long defaultMaxAckTimeout() {
-        return getAckTimeout() * (1 << 4);
+        long maxAck = getAckTimeout() * (1 << 4);
+
+        if (maxAck > DFLT_MAX_ACK_TIMEOUT_LIMIT)
+            maxAck = DFLT_MAX_ACK_TIMEOUT_LIMIT;
+
+        return maxAck;
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/test/java/org/apache/ignite/internal/IgniteConfigurationValidationSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/IgniteConfigurationValidationSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/IgniteConfigurationValidationSelfTest.java
new file mode 100644
index 0000000..dccdccc
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/IgniteConfigurationValidationSelfTest.java
@@ -0,0 +1,141 @@
+/*
+ * 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.
+ */
+
+package org.apache.ignite.internal;
+
+import org.apache.ignite.*;
+import org.apache.ignite.configuration.*;
+import org.apache.ignite.spi.communication.tcp.*;
+import org.apache.ignite.spi.discovery.tcp.*;
+import org.apache.ignite.testframework.junits.common.*;
+
+import java.lang.reflect.*;
+
+/**
+ * Ignite configuration validation test.
+ */
+public class IgniteConfigurationValidationSelfTest extends GridCommonAbstractTest {
+    /** */
+    private static final long SPI_COMM_TIMEOUT = 2000;
+
+    /**
+     * @throws Exception In case of error.
+     */
+    public void testDefaultSpiCommunicationTimeouts() throws Exception {
+        IgniteConfiguration cfg = new IgniteConfiguration();
+
+        cfg.setDiscoverySpi(new TcpDiscoverySpi());
+        cfg.setCommunicationSpi(new TcpCommunicationSpi());
+
+        assertNull(cfg.getSpiCommunicationTimeout());
+
+        cfg.setSpiCommunicationTimeout(SPI_COMM_TIMEOUT);
+
+        checkTimeouts(cfg, IgniteConfiguration.DFLT_SPI_COMMUNICATION_TIMEOUT);
+    }
+
+    /**
+     * @throws Exception In case of error.
+     */
+    public void testDefaultCommunicationTimeoutsAfterNodeStart() throws Exception {
+        IgniteConfiguration cfg = new IgniteConfiguration();
+
+        cfg.setGridLogger(getTestResources().getLogger());
+        cfg.setSpiCommunicationTimeout(SPI_COMM_TIMEOUT);
+
+        Ignite node = startGrid(getTestGridName(), cfg);
+
+        try {
+            checkTimeouts(node.configuration(), SPI_COMM_TIMEOUT);
+        }
+        finally {
+            stopGrid();
+        }
+    }
+
+    /**
+     * @throws Exception
+     */
+    public void testAdvancedTimeoutsAfterNodeStart() throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration();
+
+        cfg.setSpiCommunicationTimeout(SPI_COMM_TIMEOUT);
+
+        TcpDiscoverySpi discSpi = (TcpDiscoverySpi)cfg.getDiscoverySpi();
+
+        discSpi.setSocketTimeout(2500);
+        discSpi.setHeartbeatFrequency(1200);
+
+        TcpCommunicationSpi commSpi = (TcpCommunicationSpi)cfg.getCommunicationSpi();
+
+        commSpi.setConnectTimeout(6000);
+
+        Ignite node = startGrid(getTestGridName(), cfg);
+
+        try {
+            discSpi = (TcpDiscoverySpi)node.configuration().getDiscoverySpi();
+
+            assertEquals(2500, discSpi.getSocketTimeout());
+            assertEquals(SPI_COMM_TIMEOUT, discSpi.getNetworkTimeout());
+            assertEquals(SPI_COMM_TIMEOUT, discSpi.getAckTimeout());
+            assertEquals(1200, discSpi.getHeartbeatFrequency());
+
+            assert discSpi.getMaxAckTimeout() > discSpi.getAckTimeout() && discSpi.getMaxAckTimeout()
+                <= TcpDiscoverySpi.DFLT_MAX_ACK_TIMEOUT_LIMIT;
+
+            commSpi = (TcpCommunicationSpi)node.configuration().getCommunicationSpi();
+
+            assertEquals(6000, commSpi.getConnectTimeout());
+
+            assert commSpi.getMaxConnectTimeout() > commSpi.getConnectTimeout() && commSpi.getMaxConnectTimeout() <=
+                TcpCommunicationSpi.DFLT_MAX_CONN_TIMEOUT_LIMIT;
+        }
+        finally {
+            stopGrid();
+        }
+    }
+
+    /**
+     * Checks timeouts.
+     *
+     * @param cfg Ignite configuration.
+     * @param expectedTimeout Expected timeout value.
+     * @throws Exception In case of error.
+     */
+    private void checkTimeouts(IgniteConfiguration cfg, long expectedTimeout) throws Exception {
+        TcpDiscoverySpi discSpi = (TcpDiscoverySpi)cfg.getDiscoverySpi();
+
+        assertEquals(expectedTimeout, discSpi.getSocketTimeout());
+        assertEquals(expectedTimeout, discSpi.getNetworkTimeout());
+        assertEquals(expectedTimeout, discSpi.getAckTimeout());
+
+        Field field = TcpDiscoverySpi.class.getDeclaredField("HEARTBEAT_DIVIDER");
+        field.setAccessible(true);
+
+        assertEquals((long)(expectedTimeout / field.getDouble(null)), discSpi.getHeartbeatFrequency());
+
+        assert discSpi.getMaxAckTimeout() > discSpi.getAckTimeout() && discSpi.getMaxAckTimeout()
+            <= TcpDiscoverySpi.DFLT_MAX_ACK_TIMEOUT_LIMIT;
+
+        TcpCommunicationSpi commSpi = (TcpCommunicationSpi)cfg.getCommunicationSpi();
+
+        assertEquals(expectedTimeout, commSpi.getConnectTimeout());
+
+        assert commSpi.getMaxConnectTimeout() > commSpi.getConnectTimeout() && commSpi.getMaxConnectTimeout() <=
+            TcpCommunicationSpi.DFLT_MAX_CONN_TIMEOUT_LIMIT;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
index ec6a526..9986539 100644
--- a/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/spi/discovery/tcp/TcpClientDiscoverySpiSelfTest.java
@@ -100,7 +100,7 @@ public class TcpClientDiscoverySpiSelfTest extends GridCommonAbstractTest {
     private long joinTimeout = TcpDiscoverySpi.DFLT_JOIN_TIMEOUT;
 
     /** */
-    private long netTimeout = TcpDiscoverySpi.DFLT_NETWORK_TIMEOUT;
+    private long netTimeout = IgniteConfiguration.DFLT_SPI_COMMUNICATION_TIMEOUT;
 
     /** */
     private boolean longSockTimeouts;
@@ -193,7 +193,7 @@ public class TcpClientDiscoverySpiSelfTest extends GridCommonAbstractTest {
         nodeId = null;
         clientIpFinder = null;
         joinTimeout = TcpDiscoverySpi.DFLT_JOIN_TIMEOUT;
-        netTimeout = TcpDiscoverySpi.DFLT_NETWORK_TIMEOUT;
+        netTimeout = IgniteConfiguration.DFLT_SPI_COMMUNICATION_TIMEOUT;
         longSockTimeouts = false;
 
         assert G.allGrids().isEmpty();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/dd076a08/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
index 575f1fa..74181d8 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteKernalSelfTestSuite.java
@@ -84,6 +84,7 @@ public class IgniteKernalSelfTestSuite extends TestSuite {
         suite.addTestSuite(GridUpdateNotifierSelfTest.class);
         suite.addTestSuite(GridLocalEventListenerSelfTest.class);
         suite.addTestSuite(IgniteTopologyPrintFormatSelfTest.class);
+        suite.addTestSuite(IgniteConfigurationValidationSelfTest.class);
 
         // Managed Services.
         suite.addTestSuite(GridServiceProcessorSingleNodeSelfTest.class);


[07/21] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-sprint-7' into ignite-1060

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


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

Branch: refs/heads/ignite-752
Commit: 2502b6212b59832a03882adc554e655b51725230
Parents: d685e82 6ebcb6d
Author: avinogradov <av...@gridgain.com>
Authored: Tue Jun 30 16:54:23 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Tue Jun 30 16:54:23 2015 +0300

----------------------------------------------------------------------
 .../discovery/GridDiscoveryManager.java         |  32 +-
 .../cache/GridCacheDeploymentManager.java       |  10 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  10 +-
 .../core/src/test/config/spark/spark-config.xml |  46 +++
 .../IgniteTopologyPrintFormatSelfTest.java      | 289 +++++++++++++++++++
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 .../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 ++
 11 files changed, 443 insertions(+), 18 deletions(-)
----------------------------------------------------------------------



[14/21] incubator-ignite git commit: IGNITE-1059: Fixed (thanks to Atri for help).

Posted by sb...@apache.org.
IGNITE-1059: Fixed (thanks to Atri for help).


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

Branch: refs/heads/ignite-752
Commit: 5269baba23e062e19981cd4c09d6f2271925fffd
Parents: 204823c
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Wed Jul 1 16:35:38 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Wed Jul 1 16:35:38 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/IgniteCacheFutureImpl.java | 42 ++++++++++++++++++++
 .../processors/cache/IgniteCacheProxy.java      |  2 +-
 .../internal/util/future/IgniteFutureImpl.java  | 18 +++++++--
 3 files changed, 57 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5269baba/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheFutureImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheFutureImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheFutureImpl.java
new file mode 100644
index 0000000..06c28e6
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheFutureImpl.java
@@ -0,0 +1,42 @@
+/*
+ * 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.
+ */
+
+package org.apache.ignite.internal.processors.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.util.future.*;
+import org.apache.ignite.internal.util.typedef.internal.*;
+
+/**
+ * Implementation of public API future for cache.
+ */
+public class IgniteCacheFutureImpl<V> extends IgniteFutureImpl<V> {
+    /**
+     * Constructor.
+     *
+     * @param fut Internal future.
+     */
+    public IgniteCacheFutureImpl(IgniteInternalFuture<V> fut) {
+        super(fut);
+    }
+
+    /** {@inheritDoc} */
+    @Override protected RuntimeException convertException(IgniteCheckedException e) {
+        return CU.convertToCacheException(e);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5269baba/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
index 48fd259..3360727 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
@@ -1555,7 +1555,7 @@ public class IgniteCacheProxy<K, V> extends AsyncSupportAdapter<IgniteCache<K, V
      * @param fut Future for async operation.
      */
     private <R> void setFuture(IgniteInternalFuture<R> fut) {
-        curFut.set(new IgniteFutureImpl<>(fut));
+        curFut.set(new IgniteCacheFutureImpl<>(fut));
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5269baba/modules/core/src/main/java/org/apache/ignite/internal/util/future/IgniteFutureImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/future/IgniteFutureImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/util/future/IgniteFutureImpl.java
index 86ad438..764e0ea 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/future/IgniteFutureImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/future/IgniteFutureImpl.java
@@ -100,7 +100,7 @@ public class IgniteFutureImpl<V> implements IgniteFuture<V> {
             return fut.cancel();
         }
         catch (IgniteCheckedException e) {
-            throw U.convertException(e);
+            throw convertException(e);
         }
     }
 
@@ -110,7 +110,7 @@ public class IgniteFutureImpl<V> implements IgniteFuture<V> {
             return fut.get();
         }
         catch (IgniteCheckedException e) {
-            throw U.convertException(e);
+            throw convertException(e);
         }
     }
 
@@ -120,7 +120,7 @@ public class IgniteFutureImpl<V> implements IgniteFuture<V> {
             return fut.get(timeout);
         }
         catch (IgniteCheckedException e) {
-            throw U.convertException(e);
+            throw convertException(e);
         }
     }
 
@@ -130,10 +130,20 @@ public class IgniteFutureImpl<V> implements IgniteFuture<V> {
             return fut.get(timeout, unit);
         }
         catch (IgniteCheckedException e) {
-            throw U.convertException(e);
+            throw convertException(e);
         }
     }
 
+    /**
+     * Convert internal exception to public exception.
+     *
+     * @param e Internal exception.
+     * @return Public excpetion.
+     */
+    protected RuntimeException convertException(IgniteCheckedException e) {
+        return U.convertException(e);
+    }
+
     /** {@inheritDoc} */
     @Override public String toString() {
         return "IgniteFuture [orig=" + fut + ']';


[20/21] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-sprint-7' into ignite-752

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


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

Branch: refs/heads/ignite-752
Commit: 12ba6bce12df0822d8c1ce45bbc850ca819efbd0
Parents: 6b37a9e d3783a1
Author: Denis Magda <dm...@gridgain.com>
Authored: Thu Jul 2 08:37:26 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Thu Jul 2 08:37:26 2015 +0300

----------------------------------------------------------------------
 assembly/dependencies-fabric.xml                |   1 +
 examples/pom.xml                                |   2 +-
 modules/aop/pom.xml                             |   2 +-
 modules/aws/pom.xml                             |   2 +-
 modules/clients/pom.xml                         |   2 +-
 modules/cloud/pom.xml                           |   2 +-
 modules/codegen/pom.xml                         |   2 +-
 modules/core/pom.xml                            |   2 +-
 .../ignite/compute/ComputeTaskSplitAdapter.java |   2 +-
 .../managers/communication/GridIoManager.java   |  49 ++++++-----
 .../processors/cache/IgniteCacheFutureImpl.java |  42 ++++++++++
 .../processors/cache/IgniteCacheProxy.java      |   2 +-
 .../internal/util/future/IgniteFutureImpl.java  |  18 ++++-
 .../util/nio/GridNioMessageTracker.java         |  23 +++++-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   2 +-
 .../core/src/main/resources/ignite.properties   |   2 +-
 modules/core/src/test/config/tests.properties   |   6 +-
 .../GridP2PContinuousDeploymentSelfTest.java    |   2 -
 modules/core/src/test/resources/helloworld.gar  | Bin 6092 -> 0 bytes
 modules/core/src/test/resources/helloworld1.gar | Bin 6092 -> 0 bytes
 modules/core/src/test/resources/readme.txt      |   6 --
 modules/docker/Dockerfile                       |  55 +++++++++++++
 modules/docker/README.txt                       |  11 +++
 modules/docker/build_users_libs.sh              |  39 +++++++++
 modules/docker/download_ignite.sh               |  49 +++++++++++
 modules/docker/execute.sh                       |  62 ++++++++++++++
 modules/docker/run.sh                           |  34 ++++++++
 modules/extdata/p2p/pom.xml                     |   4 +-
 modules/extdata/uri/META-INF/ignite.xml         |  38 +++++++++
 .../extdata/uri/modules/uri-dependency/pom.xml  |  42 ++++++++++
 .../deployment/uri/tasks/GarHelloWorldBean.java |  60 ++++++++++++++
 .../src/main/resources/gar-example.properties   |  18 +++++
 modules/extdata/uri/pom.xml                     |  62 ++++++++++++--
 .../deployment/uri/tasks/GarHelloWorldTask.java |  81 +++++++++++++++++++
 .../deployment/uri/tasks/gar-spring-bean.xml    |  29 +++++++
 modules/gce/pom.xml                             |   2 +-
 modules/geospatial/pom.xml                      |   2 +-
 modules/hadoop/pom.xml                          |   2 +-
 modules/hibernate/pom.xml                       |   2 +-
 modules/indexing/pom.xml                        |   2 +-
 modules/jcl/pom.xml                             |   2 +-
 modules/jta/pom.xml                             |   2 +-
 modules/log4j/pom.xml                           |   2 +-
 modules/mesos/pom.xml                           |   2 +-
 modules/rest-http/pom.xml                       |   2 +-
 modules/scalar-2.10/pom.xml                     |   2 +-
 modules/scalar/pom.xml                          |   2 +-
 modules/schedule/pom.xml                        |   2 +-
 modules/schema-import/pom.xml                   |   2 +-
 modules/slf4j/pom.xml                           |   2 +-
 modules/spark-2.10/pom.xml                      |   2 +-
 modules/spark/pom.xml                           |   2 +-
 modules/spring/pom.xml                          |   2 +-
 modules/ssh/pom.xml                             |   2 +-
 modules/tools/pom.xml                           |   2 +-
 modules/urideploy/pom.xml                       |  16 +++-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |  13 +--
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |   2 +-
 modules/visor-console-2.10/pom.xml              |   2 +-
 modules/visor-console/pom.xml                   |   2 +-
 modules/visor-plugins/pom.xml                   |   2 +-
 modules/web/pom.xml                             |   2 +-
 modules/yardstick/pom.xml                       |   2 +-
 pom.xml                                         |  14 ++--
 64 files changed, 747 insertions(+), 101 deletions(-)
----------------------------------------------------------------------



[05/21] incubator-ignite git commit: ignite-1060

Posted by sb...@apache.org.
ignite-1060


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

Branch: refs/heads/ignite-752
Commit: 3a0ccb5dd1ba0969cb13d8c8bad1d99a43144f03
Parents: 5dff89c
Author: avinogradov <av...@gridgain.com>
Authored: Mon Jun 29 17:08:13 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Mon Jun 29 17:08:13 2015 +0300

----------------------------------------------------------------------
 modules/core/src/test/config/tests.properties                  | 6 +++---
 modules/extdata/p2p/pom.xml                                    | 2 +-
 modules/extdata/uri/pom.xml                                    | 2 +-
 .../java/org/apache/ignite/p2p/GridP2PDisabledSelfTest.java    | 2 +-
 4 files changed, 6 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3a0ccb5d/modules/core/src/test/config/tests.properties
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/tests.properties b/modules/core/src/test/config/tests.properties
index a9c6b77..ce6d4d8 100644
--- a/modules/core/src/test/config/tests.properties
+++ b/modules/core/src/test/config/tests.properties
@@ -65,9 +65,9 @@ ant.gar.tmpdir=${java.io.tmpdir}/gg
 ant.gar.srcdir=@{IGNITE_HOME}/modules/extdata/uri/target/classes/
 
 # GAR paths to use in URI deployment SPI tests
-ant.urideployment.gar.uri=file://freq=5000@localhost/EXTDATA/uri/deploy
-ant.urideployment.gar.file=modules/extdata/uri/deploy/uri.gar
-ant.urideployment.gar.path=modules/extdata/uri/deploy/
+ant.urideployment.gar.uri=file://freq=5000@localhost/EXTDATA/uri/target/deploy
+ant.urideployment.gar.file=modules/extdata/uri/target/deploy/uri.gar
+ant.urideployment.gar.path=modules/extdata/uri/target/deploy/
 
 # Classpath directory for GridP2PUserVersionChangeSelfTest
 ant.userversion.class.dir=@{IGNITE_HOME}/modules/tests/java/

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3a0ccb5d/modules/extdata/p2p/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/p2p/pom.xml b/modules/extdata/p2p/pom.xml
index 26f2e50..cffa10b 100644
--- a/modules/extdata/p2p/pom.xml
+++ b/modules/extdata/p2p/pom.xml
@@ -85,7 +85,7 @@
                             <target>
                                 <taskdef name="gar" classname="org.apache.ignite.util.antgar.IgniteDeploymentGarAntTask" />
 
-                                <gar destfile="${basedir}/deploy/p2p.gar" descrdir="${basedir}/META-INF" basedir="${basedir}/target/classes" />
+                                <gar destfile="${basedir}/target/deploy/p2p.gar" descrdir="${basedir}/META-INF" basedir="${basedir}/target/classes" />
                             </target>
                         </configuration>
                     </execution>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3a0ccb5d/modules/extdata/uri/pom.xml
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/pom.xml b/modules/extdata/uri/pom.xml
index 1690ab9..3d43040 100644
--- a/modules/extdata/uri/pom.xml
+++ b/modules/extdata/uri/pom.xml
@@ -114,7 +114,7 @@
 
                                 <taskdef name="gar" classname="org.apache.ignite.util.antgar.IgniteDeploymentGarAntTask" />
 
-                                <gar destfile="${basedir}/deploy/uri.gar" basedir="${basedir}/target/classes" />
+                                <gar destfile="${basedir}/target/deploy/uri.gar" basedir="${basedir}/target/classes" />
                             </target>
                         </configuration>
                     </execution>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3a0ccb5d/modules/urideploy/src/test/java/org/apache/ignite/p2p/GridP2PDisabledSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/urideploy/src/test/java/org/apache/ignite/p2p/GridP2PDisabledSelfTest.java b/modules/urideploy/src/test/java/org/apache/ignite/p2p/GridP2PDisabledSelfTest.java
index d2d6187..5b2c9b1 100644
--- a/modules/urideploy/src/test/java/org/apache/ignite/p2p/GridP2PDisabledSelfTest.java
+++ b/modules/urideploy/src/test/java/org/apache/ignite/p2p/GridP2PDisabledSelfTest.java
@@ -121,7 +121,7 @@ public class GridP2PDisabledSelfTest extends GridCommonAbstractTest {
     private void checkGar() throws Exception {
         initGar = true;
 
-        String garDir = "modules/extdata/p2p/deploy";
+        String garDir = "modules/extdata/p2p/target/deploy";
         String garFileName = "p2p.gar";
 
         File origGarPath = U.resolveIgnitePath(garDir + '/' + garFileName);


[08/21] incubator-ignite git commit: ignite-1060

Posted by sb...@apache.org.
ignite-1060


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

Branch: refs/heads/ignite-752
Commit: 25cef86ab016d8345086f1bd90d6c6b3f6fdc2d8
Parents: 2502b62
Author: avinogradov <av...@gridgain.com>
Authored: Tue Jun 30 17:33:43 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Tue Jun 30 17:33:43 2015 +0300

----------------------------------------------------------------------
 .../apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java | 3 +--
 .../apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java | 3 +--
 2 files changed, 2 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/25cef86a/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java b/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
index bf329be..e62d49f 100644
--- a/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
+++ b/modules/extdata/uri/modules/uri-dependency/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldBean.java
@@ -36,8 +36,7 @@ public class GarHelloWorldBean {
      * @param key Message key.
      * @return Keyed message.
      */
-    @Nullable
-    public String getMessage(String key) {
+    @Nullable public String getMessage(String key) {
         InputStream in = null;
 
         try {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/25cef86a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
----------------------------------------------------------------------
diff --git a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
index 13b2641..7e46781 100644
--- a/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
+++ b/modules/extdata/uri/src/main/java/org/apache/ignite/spi/deployment/uri/tasks/GarHelloWorldTask.java
@@ -61,8 +61,7 @@ public class GarHelloWorldTask extends ComputeTaskSplitAdapter<String, String> {
                 /*
                  * Simply prints the job's argument.
                  */
-                @Nullable
-                @Override public Serializable execute() {
+                @Nullable @Override public Serializable execute() {
                     System.out.println(">>>");
                     System.out.println(">>> Printing '" + argument(0) + "' on this node from grid job.");
                     System.out.println(">>>");


[17/21] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-1060' into ignite-sprint-7

Posted by sb...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-1060' 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/44b187d4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/44b187d4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/44b187d4

Branch: refs/heads/ignite-752
Commit: 44b187d44e3270b69f95e8ed690ec772557b05b4
Parents: da6ff64 25cef86
Author: Anton <av...@gridgain.com>
Authored: Wed Jul 1 19:19:34 2015 +0300
Committer: Anton <av...@gridgain.com>
Committed: Wed Jul 1 19:19:34 2015 +0300

----------------------------------------------------------------------
 assembly/dependencies-fabric.xml                |   1 +
 modules/core/src/test/config/tests.properties   |   6 +-
 modules/core/src/test/resources/helloworld.gar  | Bin 6092 -> 0 bytes
 modules/core/src/test/resources/helloworld1.gar | Bin 6092 -> 0 bytes
 modules/core/src/test/resources/readme.txt      |   6 --
 modules/extdata/p2p/pom.xml                     |   2 +-
 modules/extdata/uri/META-INF/ignite.xml         |  38 +++++++++
 .../extdata/uri/modules/uri-dependency/pom.xml  |  42 ++++++++++
 .../deployment/uri/tasks/GarHelloWorldBean.java |  60 ++++++++++++++
 .../src/main/resources/gar-example.properties   |  18 +++++
 modules/extdata/uri/pom.xml                     |  60 +++++++++++++-
 .../deployment/uri/tasks/GarHelloWorldTask.java |  81 +++++++++++++++++++
 .../deployment/uri/tasks/gar-spring-bean.xml    |  29 +++++++
 modules/urideploy/pom.xml                       |  14 ++++
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |  13 +--
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |   2 +-
 16 files changed, 347 insertions(+), 25 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/44b187d4/modules/extdata/p2p/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/44b187d4/modules/extdata/uri/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/44b187d4/modules/urideploy/pom.xml
----------------------------------------------------------------------