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

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

Repository: incubator-ignite
Updated Branches:
  refs/heads/ignite-964 576c43501 -> ad11a4a12


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


[09/39] incubator-ignite git commit: # ignite-gg-1064 allow start if can not initialize multicast

Posted by iv...@apache.org.
# ignite-gg-1064 allow start if can not initialize multicast


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

Branch: refs/heads/ignite-964
Commit: b5bc06ee813471643c460aaa74ef4395ad79bd53
Parents: bade9f1
Author: sboikov <sb...@gridgain.com>
Authored: Tue Jun 30 12:40:53 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Tue Jun 30 12:40:53 2015 +0300

----------------------------------------------------------------------
 .../TcpDiscoveryMulticastIpFinder.java          | 74 ++++++++++++++++----
 1 file changed, 60 insertions(+), 14 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b5bc06ee/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
index 8e5a1fd..014d937 100644
--- a/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
+++ b/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/ipfinder/multicast/TcpDiscoveryMulticastIpFinder.java
@@ -26,7 +26,6 @@ import org.apache.ignite.marshaller.*;
 import org.apache.ignite.marshaller.jdk.*;
 import org.apache.ignite.resources.*;
 import org.apache.ignite.spi.*;
-import org.apache.ignite.spi.discovery.*;
 import org.apache.ignite.spi.discovery.tcp.*;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.*;
 import org.jetbrains.annotations.*;
@@ -278,7 +277,7 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
 
         addrSnds = new ArrayList<>(locAddrs.size());
 
-        Collection<InetAddress> reqItfs = new ArrayList<>(locAddrs.size()); // Interfaces used to send requests.
+        Set<InetAddress> reqItfs = new HashSet<>(locAddrs.size()); // Interfaces used to send requests.
 
         for (String locAddr : locAddrs) {
             InetAddress addr;
@@ -309,6 +308,8 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
             }
         }
 
+        boolean mcastErr = false;
+
         if (!clientMode) {
             if (addrSnds.isEmpty()) {
                 try {
@@ -317,13 +318,31 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
                     addrSnds.add(new AddressSender(mcastAddr, null, addrs));
                 }
                 catch (IOException e) {
-                    throw new IgniteSpiException("Failed to create multicast socket [mcastAddr=" + mcastAddr +
-                        ", mcastGrp=" + mcastGrp + ", mcastPort=" + mcastPort + ']', e);
+                    if (log.isDebugEnabled())
+                        log.debug("Failed to create multicast socket [mcastAddr=" + mcastAddr +
+                            ", mcastGrp=" + mcastGrp + ", mcastPort=" + mcastPort + ", err=" + e + ']');
+                }
+
+                if (addrSnds.isEmpty()) {
+                    try {
+                        addrSnds.add(new AddressSender(mcastAddr, mcastAddr, addrs));
+
+                        reqItfs.add(mcastAddr);
+                    }
+                    catch (IOException e) {
+                        log.debug("Failed to create multicast socket [mcastAddr=" + mcastAddr +
+                            ", mcastGrp=" + mcastGrp + ", mcastPort=" + mcastPort + ", locAddr=" + mcastAddr +
+                            ", err=" + e + ']');
+                    }
                 }
             }
 
-            for (AddressSender addrSnd : addrSnds)
-                addrSnd.start();
+            if (!addrSnds.isEmpty()) {
+                for (AddressSender addrSnd : addrSnds)
+                    addrSnd.start();
+            }
+            else
+                mcastErr = true;
         }
         else
             assert addrSnds.isEmpty() : addrSnds;
@@ -358,10 +377,30 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
                 }
             }
         }
-        else
-            ret = requestAddresses(mcastAddr, F.first(reqItfs));
+        else {
+            T2<Collection<InetSocketAddress>, Boolean> res = requestAddresses(mcastAddr, F.first(reqItfs));
+
+            ret = res.get1();
+
+            mcastErr |= res.get2();
+        }
+
+        if (ret.isEmpty()) {
+            if (mcastErr) {
+                if (getRegisteredAddresses().isEmpty()) {
+                    InetSocketAddress addr = new InetSocketAddress("localhost", TcpDiscoverySpi.DFLT_PORT);
+
+                    U.quietAndWarn(log, "TcpDiscoveryMulticastIpFinder failed to initialize multicast, " +
+                        "will use default address: " + addr);
 
-        if (!ret.isEmpty())
+                    registerAddresses(Collections.singleton(addr));
+                }
+                else
+                    U.quietAndWarn(log, "TcpDiscoveryMulticastIpFinder failed to initialize multicast, " +
+                        "will use pre-configured addresses.");
+            }
+        }
+        else
             registerAddresses(ret);
     }
 
@@ -379,11 +418,16 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
      *
      * @param mcastAddr Multicast address where to send request.
      * @param sockItf Optional interface multicast socket should be bound to.
-     * @return Collection of received addresses.
+     * @return Tuple where first value is collection of received addresses, second is boolean which is
+     *      {@code true} if got error on send.
      */
-    private Collection<InetSocketAddress> requestAddresses(InetAddress mcastAddr, @Nullable InetAddress sockItf) {
+    private T2<Collection<InetSocketAddress>, Boolean> requestAddresses(InetAddress mcastAddr,
+        @Nullable InetAddress sockItf)
+    {
         Collection<InetSocketAddress> rmtAddrs = new HashSet<>();
 
+        boolean sndErr = false;
+
         try {
             DatagramPacket reqPckt = new DatagramPacket(MSG_ADDR_REQ_DATA, MSG_ADDR_REQ_DATA.length,
                 mcastAddr, mcastPort);
@@ -414,6 +458,8 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
                         sock.send(reqPckt);
                     }
                     catch (IOException e) {
+                        sndErr = true;
+
                         if (!handleNetworkError(e))
                             break;
 
@@ -486,14 +532,14 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
             if (rmtAddrs.isEmpty() && sndError)
                 U.quietAndWarn(log, "Failed to send multicast message (is multicast enabled on this node?).");
 
-            return rmtAddrs;
+            return new T2<>(rmtAddrs, sndErr);
         }
         catch (IgniteInterruptedCheckedException ignored) {
             U.warn(log, "Got interrupted while sending address request.");
 
             Thread.currentThread().interrupt();
 
-            return rmtAddrs;
+            return new T2<>(rmtAddrs, sndErr);
         }
     }
 
@@ -610,7 +656,7 @@ public class TcpDiscoveryMulticastIpFinder extends TcpDiscoveryVmIpFinder {
 
         /** {@inheritDoc} */
         @Override protected void body() throws InterruptedException {
-            addrs = requestAddresses(mcastAddr, sockAddr);
+            addrs = requestAddresses(mcastAddr, sockAddr).get1();
         }
 
         /**


[15/39] incubator-ignite git commit: #ignite-964: sql query works with arguments.

Posted by iv...@apache.org.
#ignite-964: sql query works with arguments.


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

Branch: refs/heads/ignite-964
Commit: 54be1060053577dce1f689cb2aeec4210866b707
Parents: 3f86e4b
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 16:00:11 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 16:00:11 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/main/js/server.js            |  2 +-
 .../ignite/internal/NodeJsSqlQuerySelfTest.java | 60 +++++++++++++++-----
 modules/nodejs/src/test/js/test-query.js        | 22 +++----
 .../http/jetty/GridJettyRestHandler.java        |  2 -
 4 files changed, 57 insertions(+), 29 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/54be1060/modules/nodejs/src/main/js/server.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/server.js b/modules/nodejs/src/main/js/server.js
index e49ed83..021fffe 100644
--- a/modules/nodejs/src/main/js/server.js
+++ b/modules/nodejs/src/main/js/server.js
@@ -151,7 +151,7 @@ Server.prototype.checkConnection = function(callback) {
  */
 Server.prototype._signature = function() {
     if (!this._secretKey) {
-        return "";
+        return {};
     }
 
     var loadTimeInMS = Date.now();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/54be1060/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
index 8d33668..a6891fb 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
@@ -18,12 +18,11 @@
 package org.apache.ignite.internal;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.affinity.*;
+import org.apache.ignite.cache.query.*;
 import org.apache.ignite.cache.query.annotations.*;
 import org.apache.ignite.configuration.*;
 
 import java.io.*;
-import java.util.*;
 
 /**
  * Node js sql query test.
@@ -75,29 +74,40 @@ public class NodeJsSqlQuerySelfTest extends NodeJsAbstractTest {
      * Init cache.
      */
     private void initCache() {
-        CacheConfiguration<UUID, Person> personCacheCfg = new CacheConfiguration<>("person");
-        personCacheCfg.setIndexedTypes(UUID.class, Person.class);
+        CacheConfiguration<Integer, Person> personCacheCfg = new CacheConfiguration<>("person");
+        personCacheCfg.setIndexedTypes(Integer.class, Person.class);
 
-        IgniteCache<UUID, Person> personCache = grid(0).getOrCreateCache(personCacheCfg);
+        IgniteCache<Integer, Person> personCache = grid(0).getOrCreateCache(personCacheCfg);
+
+        personCache.clear();
 
         Person p1 = new Person("John", "Doe", 2000);
         Person p2 = new Person("Jane", "Doe", 1000);
         Person p3 = new Person("John", "Smith", 1000);
         Person p4 = new Person("Jane", "Smith", 2000);
 
-        personCache.put(p4.getId(), p1);
-        personCache.put(p4.getId(), p2);
-        personCache.put(p4.getId(), p3);
+        personCache.put(p1.getId(), p1);
+        personCache.put(p2.getId(), p2);
+        personCache.put(p3.getId(), p3);
         personCache.put(p4.getId(), p4);
+
+        SqlQuery qry = new SqlQuery(Person.class, "salary > ? and salary <= ?");
+
+        qry.setArgs(1000, 2000);
+
+        assertEquals(2, personCache.query(qry).getAll().size());
     }
 
     /**
      * Person class.
      */
     public static class Person implements Serializable {
+        /** Person id. */
+        private static int PERSON_ID = 0;
+
         /** Person ID (indexed). */
         @QuerySqlField(index = true)
-        private UUID id;
+        private Integer id;
 
         /** First name (not-indexed). */
         @QuerySqlField
@@ -116,44 +126,68 @@ public class NodeJsSqlQuerySelfTest extends NodeJsAbstractTest {
          * @param lastName Last name.
          * @param salary Salary.
          */
-        Person( String firstName, String lastName, double salary) {
-            id = UUID.randomUUID();
+        Person(String firstName, String lastName, double salary) {
+            id = PERSON_ID++;
 
             this.firstName = firstName;
             this.lastName = lastName;
             this.salary = salary;
         }
 
+        /**
+         * @param firstName First name.
+         */
         public void setFirstName(String firstName) {
             this.firstName = firstName;
         }
 
+        /**
+         * @return First name.
+         */
         public String getFirstName() {
             return firstName;
         }
 
+        /**
+         * @param lastName Last name.
+         */
         public void setLastName(String lastName) {
             this.lastName = lastName;
         }
 
+        /**
+         * @return Last name.
+         */
         public String getLastName() {
             return lastName;
         }
 
-        public void setId(UUID id) {
+        /**
+         * @param id Id.
+         */
+        public void setId(Integer id) {
             this.id = id;
         }
 
+        /**
+         * @param salary Salary.
+         */
         public void setSalary(double salary) {
             this.salary = salary;
         }
 
+        /**
+         * @return Salary.
+         */
         public double getSalary() {
 
             return salary;
         }
 
-        public UUID getId() {
+        /**
+         * @return Id.
+         */
+        public Integer getId() {
             return id;
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/54be1060/modules/nodejs/src/test/js/test-query.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-query.js b/modules/nodejs/src/test/js/test-query.js
index c407816..a86c057 100644
--- a/modules/nodejs/src/test/js/test-query.js
+++ b/modules/nodejs/src/test/js/test-query.js
@@ -40,7 +40,7 @@ testSqlQuery = function() {
         qry.on("end", function(err) {
             assert(err === null, "Error on query [err=" + err + "].");
 
-            assert(fullRes.length, 1, "Result length is not correct" +
+            assert(fullRes.length === 1, "Result length is not correct" +
                 "[expected=1, val = " + fullRes.length + "]");
 
             assert(fullRes[0]["key"] === "key0", "Result value for key is not correct "+
@@ -80,7 +80,7 @@ testSqlFieldsQuery = function() {
         qry.on("end", function(err) {
             assert(err === null, "Error on query [err=" + err + "].");
 
-            assert(fullRes.length, 4, "Result length is not correct" +
+            assert(fullRes.length === 4, "Result length is not correct" +
                 "[expected=1, val = " + fullRes.length + "]");
 
             fullRes.sort();
@@ -98,7 +98,7 @@ testSqlFieldsQuery = function() {
 }
 
 testSqlQueryWithParams = function() {
-    function sqlFieldsQuery(error, ignite) {
+    function sqlQueryWithParams(error, ignite) {
         assert(error == null, "error on sql query [err=" + error + "]");
 
         var qry = new SqlQuery("salary > ? and salary <= ?");
@@ -110,23 +110,18 @@ testSqlQueryWithParams = function() {
         var fullRes = [];
 
         qry.on("page", function(res) {
-            console.log("!!!!!Page:" + res);
-            console.log("!!!!!Page2:" + res);
-
             fullRes = fullRes.concat(res);
         });
 
         qry.on("end", function(err) {
-            console.log("RES:" + fullRes);
-
             assert(err === null, "Error on query [err=" + err + "].");
 
-            //TODO:
-            assert(fullRes.length, 2, "Result length is not correct" +
+            assert(fullRes.length === 2, "Result length is not correct" +
                 "[expected=1, val = " + fullRes.length + "]");
 
-            assert(fullRes[0].indexOf("Jane Doe") > -1,
-                "Result does not contain Jane Doe [res=" + fullRes[0] + "]");
+            assert(((fullRes[0]["value"]["firstName"].indexOf("Jane") > -1) ||
+                (fullRes[0]["value"]["firstName"].indexOf("John") > -1)),
+                "Result does not contain Jane and John [res=" + fullRes[0]["value"]["firstName"] + "]");
 
             TestUtils.testDone();
         });
@@ -134,4 +129,5 @@ testSqlQueryWithParams = function() {
         ignite.cache("person").query(qry);
     }
 
-    TestUtils.startIgniteN
\ No newline at end of file
+    TestUtils.startIgniteNode(sqlQueryWithParams.bind(null));
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/54be1060/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index e37f422..6327c88 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -522,10 +522,8 @@ public class GridJettyRestHandler extends AbstractHandler {
                     builder.append(reader.next() + "\n");
 
                 JSONObject o = JSONObject.fromObject(builder.toString());
-                System.out.println("ARGUMENTS " + o.get("arg"));
 
                 List<Object> args = (List<Object>)o.get("arg");
-
                 restReq0.arguments(args.toArray());
 
                 restReq0.typeName((String)params.get("type"));


[31/39] incubator-ignite git commit: #ignite-964: IgniteJsEmitResult code style.

Posted by iv...@apache.org.
#ignite-964: IgniteJsEmitResult code style.


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

Branch: refs/heads/ignite-964
Commit: cec45347bc6475c6b59f9128732b5c696ec20c47
Parents: 7e0a63b
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:26:52 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:26:52 2015 +0300

----------------------------------------------------------------------
 .../processors/rest/handlers/scripting/IgniteJsEmitResult.java   | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cec45347/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteJsEmitResult.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteJsEmitResult.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteJsEmitResult.java
index ecd6cba..b5ae106 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteJsEmitResult.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteJsEmitResult.java
@@ -37,9 +37,9 @@ public class IgniteJsEmitResult {
         List<T3<Object, Object, Object>> res = emitResPerCall.get();
 
         if (res == null)
-            res = new ArrayList();
+            res = new ArrayList<>();
 
-        res.add(new T3(f, args, node));
+        res.add(new T3<>(f, args, node));
 
         emitResPerCall.set(res);
     }


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

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

Branch: refs/heads/ignite-964
Commit: e91bc484e224ce8a039ef5bba71aa7f093dce262
Parents: 28525ac 0ef74a1
Author: sboikov <sb...@gridgain.com>
Authored: Tue Jun 30 17:31:22 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Tue Jun 30 17:31:22 2015 +0300

----------------------------------------------------------------------
 .../processors/clock/GridClockServer.java       | 21 ++++--
 .../TcpDiscoveryMulticastIpFinder.java          | 74 ++++++++++++++++----
 2 files changed, 76 insertions(+), 19 deletions(-)
----------------------------------------------------------------------



[07/39] incubator-ignite git commit: Merge branch 'ignite-964' into ignite-964-1

Posted by iv...@apache.org.
Merge branch 'ignite-964' into ignite-964-1


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

Branch: refs/heads/ignite-964
Commit: d218dfb1d3e3f75a5b96cfb1c4aace9489f76731
Parents: 8744687 f260e9b
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 11:05:00 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 11:05:00 2015 +0300

----------------------------------------------------------------------
 .../cache/GridCacheDeploymentManager.java       | 10 ++--
 .../shmem/IpcSharedMemoryServerEndpoint.java    | 10 +++-
 .../core/src/test/config/spark/spark-config.xml | 46 ++++++++++++++++++
 .../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 +++++++
 8 files changed, 127 insertions(+), 12 deletions(-)
----------------------------------------------------------------------



[37/39] incubator-ignite git commit: #ignite-964: nodejs code style.

Posted by iv...@apache.org.
#ignite-964: nodejs code style.


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

Branch: refs/heads/ignite-964
Commit: 3807762a9c7cb449e82357955b705927474c42ac
Parents: 49f4f91
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 13:01:11 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 13:01:11 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/main/js/cache.js             |  4 +-
 modules/nodejs/src/main/js/server.js            | 57 +++++++++++++-------
 .../ignite/internal/NodeJsSqlQuerySelfTest.java |  2 +-
 modules/nodejs/src/test/js/test-compute.js      |  3 --
 4 files changed, 42 insertions(+), 24 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3807762a/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index 3eaadb4..eef4039 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -180,8 +180,8 @@ Cache.prototype._sqlFieldsQuery = function(qry, onQueryExecute) {
 
 Cache.prototype._sqlQuery = function(qry, onQueryExecute) {
     if (qry.returnType() == null) {
-        qry.error("No type for sql query.");
-        qry.end();
+        qry.end("No type for sql query.");
+
         return;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3807762a/modules/nodejs/src/main/js/server.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/server.js b/modules/nodejs/src/main/js/server.js
index 021fffe..ee1a134 100644
--- a/modules/nodejs/src/main/js/server.js
+++ b/modules/nodejs/src/main/js/server.js
@@ -57,12 +57,10 @@ Server.prototype.host = function() {
  * Run http request
  *
  * @this {Server}
- * @param {string} cmdName command name.
- * @param params Parameters for command.
+ * @param {Command} cmd Command
  * @param {onGet} Called on finish
  */
 Server.prototype.runCommand = function(cmd, callback) {
-
     var requestQry = "cmd=" + cmd.name() + cmd.paramsString();
 
     var http = require('http');
@@ -89,6 +87,7 @@ Server.prototype.runCommand = function(cmd, callback) {
 
         response.on('end', function () {
             console.log("fullResponseString:" + fullResponseString);
+
             if (response.statusCode !== 200) {
                 if (response.statusCode === 401) {
                     callback.call(null, "Authentication failed. Status code 401.");
@@ -181,52 +180,74 @@ Server._escape = function(f) {
     return qs.escape(f.toString());
 }
 
+/**
+ * @constructor
+ * @this{Command}
+ * @param{string} name Command name.
+ */
 function Command(name) {
     this._name = name;
     this._params = [];
 }
 
+/**
+ * @this {Command}
+ * @param {string} key Key
+ * @param {string} val Value
+ * @returns this
+ */
 Command.prototype.addParam = function(key, value) {
     this._params.push({key: key, value: value});
     return this;
 }
 
-Command.prototype.addParams = function(prefix, params) {
-    for (var i = 1; i <= params.length; ++i) {
-        this.addParam(prefix + i, params[i - 1]);
-    }
-    return this;
-}
-
+/**
+ * @this {Command}
+ * @param{JSONObject} postData Post data.
+ * @returns this
+ */
 Command.prototype.setPostData = function(postData) {
     this._postData = postData;
     return this;
 }
 
+/**
+ * @this {Command}
+ * @returns Post data.
+ */
 Command.prototype.postData = function() {
     return this._postData;
 }
 
-Command.prototype._method = function() {
-    return this._isPost()? "POST" : "GET";
-}
-
-Command.prototype._isPost = function() {
-    return !!this._postData;
-}
-
+/**
+ * @this {Command}
+ * @returns Command name.
+ */
 Command.prototype.name = function() {
     return this._name;
 }
 
+/**
+ * @this {Command}
+ * @returns Http request string.
+ */
 Command.prototype.paramsString = function() {
     var paramsString = "";
 
     for (var p of this._params) {
         paramsString += "&" + Server._escape(p.key) + "=" + Server._escape(p.value);
     }
+
     return paramsString;
 }
 
+Command.prototype._method = function() {
+    return this._isPost()? "POST" : "GET";
+}
+
+Command.prototype._isPost = function() {
+    return !!this._postData;
+}
+
 exports.Server = Server;
 exports.Command = Command;
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3807762a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
index a6891fb..9024b93 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
@@ -91,7 +91,7 @@ public class NodeJsSqlQuerySelfTest extends NodeJsAbstractTest {
         personCache.put(p3.getId(), p3);
         personCache.put(p4.getId(), p4);
 
-        SqlQuery qry = new SqlQuery(Person.class, "salary > ? and salary <= ?");
+        SqlQuery<Integer, Person> qry = new SqlQuery<>(Person.class, "salary > ? and salary <= ?");
 
         qry.setArgs(1000, 2000);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3807762a/modules/nodejs/src/test/js/test-compute.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-compute.js b/modules/nodejs/src/test/js/test-compute.js
index 6ab738c..943ab02 100644
--- a/modules/nodejs/src/test/js/test-compute.js
+++ b/modules/nodejs/src/test/js/test-compute.js
@@ -164,9 +164,6 @@ function testComputeWithErrors(map) {
         var callback = function(err, res) {
             assert(err != null, "Do not get error on compute task.");
 
-            console.log("ERROR on Compute: "  + err);
-            console.log("End of ERROR.");
-
             assert(err.indexOf("Function evaluation failed") > -1, "Incorrect error "+
                 "[expected=function evaluation failed, value=" + err + "]");
 


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

Posted by iv...@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-964
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


[36/39] incubator-ignite git commit: #ignite-964: GridJettyRestHandler code style.

Posted by iv...@apache.org.
#ignite-964: GridJettyRestHandler code style.


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

Branch: refs/heads/ignite-964
Commit: 49f4f91036c39118df71863371b6b3ef83fa42eb
Parents: 990e5ec
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:49:27 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:49:27 2015 +0300

----------------------------------------------------------------------
 .../http/jetty/GridJettyRestHandler.java         | 19 ++-----------------
 1 file changed, 2 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/49f4f910/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index 11059f3..b5877b6 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -542,27 +542,12 @@ public class GridJettyRestHandler extends AbstractHandler {
 
                 restReq0.sqlQuery((String)params.get("qry"));
 
-                StringBuilder builder = new StringBuilder();
+                JSONObject o = parseRequest(req);
 
-                Scanner reader = null;
+                List args = (List)o.get("arg");
 
-                try {
-                    reader = new Scanner(req.getReader());
-                }
-                catch (IOException e) {
-                    throw new IgniteCheckedException(e);
-                }
-
-                while (reader.hasNext())
-                    builder.append(reader.next() + "\n");
-
-                JSONObject o = JSONObject.fromObject(builder.toString());
-
-                List<Object> args = (List<Object>)o.get("arg");
                 restReq0.arguments(args.toArray());
-
                 restReq0.typeName((String)params.get("type"));
-
                 restReq0.pageSize(Integer.parseInt((String) params.get("psz")));
                 restReq0.cacheName((String)params.get("cacheName"));
 


[29/39] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-sprint-7' into ignite-964-1

Posted by iv...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-sprint-7' into ignite-964-1


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

Branch: refs/heads/ignite-964
Commit: f9a738f3e3aa4370a7302512bdd149a2984e6ae5
Parents: b963d03 c7e7487
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:08:12 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:08:12 2015 +0300

----------------------------------------------------------------------
 .../configuration/CacheConfiguration.java       | 105 ++++++++++---------
 .../configuration/NearCacheConfiguration.java   |  10 +-
 .../managers/communication/GridIoManager.java   |  49 +++++----
 .../discovery/GridDiscoveryManager.java         |  26 +----
 .../processors/clock/GridClockServer.java       |  21 +++-
 .../util/nio/GridNioMessageTracker.java         |  23 +++-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   2 +-
 .../TcpDiscoveryMulticastIpFinder.java          |  74 ++++++++++---
 .../IgniteTopologyPrintFormatSelfTest.java      |  60 ++++++++++-
 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 ++++++
 15 files changed, 497 insertions(+), 123 deletions(-)
----------------------------------------------------------------------



[06/39] incubator-ignite git commit: #ignite-964: introduce command object in server.js

Posted by iv...@apache.org.
#ignite-964: introduce command object in server.js


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

Branch: refs/heads/ignite-964
Commit: 8744687687f5994c1a881432a7c0600a6b7368c4
Parents: 2c1ecf2
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 02:02:44 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 02:02:44 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/main/js/cache.js   | 100 ++++++++---------------------
 modules/nodejs/src/main/js/compute.js |  14 ++--
 modules/nodejs/src/main/js/ignite.js  |   7 +-
 modules/nodejs/src/main/js/server.js  |  85 ++++++++++++++++--------
 4 files changed, 98 insertions(+), 108 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/87446876/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index 9f72589..1ece92d 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -16,6 +16,7 @@
  */
 
 var Server = require("./server").Server;
+var Command = require("./server").Command;
 var SqlFieldsQuery = require("./sql-fields-query").SqlFieldsQuery
 var SqlQuery = require("./sql-query").SqlQuery
 
@@ -30,7 +31,6 @@ var SqlQuery = require("./sql-query").SqlQuery
 function Cache(server, cacheName) {
     this._server = server;
     this._cacheName = cacheName;
-    this._cacheNameParam = Server.pair("cacheName", this._cacheName);
 }
 
 /**
@@ -41,7 +41,7 @@ function Cache(server, cacheName) {
  * @param {onGet} callback Called on finish
  */
 Cache.prototype.get = function(key, callback) {
-    this._server.runCommand("get", [this._cacheNameParam, Server.pair("key", key)], callback);
+    this._server.runCommand(this._createCommand("get").addParam("key", key), callback);
 };
 
 /**
@@ -53,7 +53,7 @@ Cache.prototype.get = function(key, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.put = function(key, value, callback) {
-    this._server.runCommand("put", [this._cacheNameParam, Server.pair("key", key), Server.pair("val", value)],
+    this._server.runCommand(this._createCommand("put").addParam("key", key).addParam("val", value),
         callback);
 }
 
@@ -65,7 +65,7 @@ Cache.prototype.put = function(key, value, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.remove = function(key, callback) {
-    this._server.runCommand("rmv", [this._cacheNameParam, Server.pair("key", key)], callback);
+    this._server.runCommand(this._createCommand("rmv").addParam("key", key), callback);
 }
 
 /**
@@ -76,11 +76,7 @@ Cache.prototype.remove = function(key, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.removeAll = function(keys, callback) {
-    var params = [this._cacheNameParam];
-
-    params = params.concat(Cache.concatParams("k", keys));
-
-    this._server.runCommand("rmvall", params, callback);
+    this._server.runCommand(this._createCommand("rmvall").addParams("k", keys), callback);
 }
 
 /**
@@ -99,12 +95,7 @@ Cache.prototype.putAll = function(map, callback) {
         values.push(map[key]);
     }
 
-    var params = Cache.concatParams("k", keys);
-    params = params.concat(Cache.concatParams("v", values));
-
-    params.push(this._cacheNameParam);
-
-    this._server.runCommand("putall", params, callback);
+    this._server.runCommand(this._createCommand("putall").addParams("k", keys).addParams("v", values), callback);
 }
 
 /**
@@ -115,9 +106,7 @@ Cache.prototype.putAll = function(map, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.postPutAll = function(map, callback) {
-    var params = [this._cacheNameParam];
-
-    this._server.runCommand("putall2", params, callback, JSON.stringify(map));
+    this._server.runCommand(this._createCommand("putall2").setPostData(JSON.stringify(map)), callback);
 }
 
 /**
@@ -136,11 +125,7 @@ Cache.prototype.postPutAll = function(map, callback) {
  * @param {Cache~onGetAll} callback Called on finish
  */
 Cache.prototype.getAll = function(keys, callback) {
-    var params = Cache.concatParams("k", keys);
-
-    params.push(this._cacheNameParam);
-
-    this._server.runCommand("getall", params, callback);
+    this._server.runCommand(this._createCommand("getall").addParams("k", keys), callback);
 }
 
 /**
@@ -167,11 +152,9 @@ Cache.prototype.query = function(qry) {
             qry.end();
         }
         else {
-            this._server.runCommand("qryfetch", [
-                Server.pair("cacheName", this._cacheName),
-                Server.pair("qryId", res.queryId),
-                Server.pair("psz", qry.pageSize())],
-                onQueryExecute.bind(this, qry));
+            var command = this._createCommand("qryfetch");
+            command.addParam("qryId", res.queryId).addParam("psz", qry.pageSize());
+            this._server.runCommand(command, onQueryExecute.bind(this, qry));
         }
     }
 
@@ -184,63 +167,36 @@ Cache.prototype.query = function(qry) {
 }
 
 Cache.prototype._sqlFieldsQuery = function(qry, onQueryExecute) {
-    var params = [Server.pair("cacheName", this._cacheName),
-        Server.pair("qry", qry.query()),
-        Server.pair("psz", qry.pageSize())];
-
-    params = params.concat(this._sqlArguments(qry.arguments()));
-
-    this._server.runCommand("qryfieldsexecute", params,
-        onQueryExecute.bind(this, qry));
-}
-
-Cache.prototype._sqlArguments = function(args) {
-    var res = [];
-    console.log("ARGS=" + args);
-
-    for (var i = 1; i <= args.length; i++) {
-        res.push(Server.pair("arg" + i, args[i - 1]));
-    }
+    var command = this._createQueryCommand("qryfieldsexecute", qry);
+    command.addParams("arg", qry.arguments());
 
-    return res;
+    this._server.runCommand(command, onQueryExecute.bind(this, qry));
 }
 
 Cache.prototype._sqlQuery = function(qry, onQueryExecute) {
-    var params = [Server.pair("cacheName", this._cacheName),
-        Server.pair("qry", qry.query()),
-        Server.pair("psz", qry.pageSize())]
 
-    params = params.concat(this._sqlArguments(qry.arguments()));
-
-    if (qry.returnType() != null) {
-        params.push(Server.pair("type", qry.returnType()));
-    }
-    else {
+    if (qry.returnType() == null) {
         qry.error("No type for sql query.");
         qry.end();
-
         return;
     }
 
-    this._server.runCommand("qryexecute", params,
-        onQueryExecute.bind(this, qry));
-}
+    var command = this._createQueryCommand("qryexecute", qry);
+    command.addParams("arg", qry.arguments());
+    command.addParam("type", qry.returnType());
 
-/**
- * Concatenate all parameters
- *
- * @param {string} pref Prefix
- * @param {string[]} keys Keys
- * @returns List of parameters.
- */
-Cache.concatParams = function(pref, keys) {
-    var temp = []
+    this._server.runCommand(command, onQueryExecute.bind(this, qry));
+}
 
-    for (var i = 1; i <= keys.length; ++i) {
-        temp.push(Server.pair(pref + i, keys[i-1]));
-    }
+Cache.prototype._createCommand = function(name) {
+    var command = new Command(name);
+    return command.addParam("cacheName", this._cacheName);
+}
 
-    return temp;
+Cache.prototype._createQueryCommand = function(name, qry) {
+    var command = this._createCommand(name);
+    command.addParam("qry", qry.query());
+    return command.addParam("psz", qry.pageSize());
 }
 
 exports.Cache = Cache
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/87446876/modules/nodejs/src/main/js/compute.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/compute.js b/modules/nodejs/src/main/js/compute.js
index 5789528..830ba85 100644
--- a/modules/nodejs/src/main/js/compute.js
+++ b/modules/nodejs/src/main/js/compute.js
@@ -16,6 +16,7 @@
  */
 
 var Server = require("./server").Server;
+var Command = require("./server").Command;
 
 /**
  * @constructor
@@ -33,8 +34,7 @@ function Compute(server) {
  * @param {onGet} callback Callback
  */
 Compute.prototype.runScript = function(runnable, args, callback) {
-    this._server.runCommand("runscript", [Server.pair("func", runnable),
-        Server.pair("arg", args)], callback);
+    this._server.runCommand(new Command("runscript").addParam("func", runnable).addParam("arg", args), callback);
 }
 
 /**
@@ -45,13 +45,13 @@ Compute.prototype.runScript = function(runnable, args, callback) {
  * @param {onGet} callback Callback
  */
 Compute.prototype.execute = function(map, reduce, arg, callback) {
-    var params = [];
+    var command = new Command("excmapreduce");
 
-    params.push(Server.pair("map", map));
-    params.push(Server.pair("reduce", reduce));
-    params.push(Server.pair("arg", arg));
+    command.addParam("map", map);
+    command.addParam("reduce", reduce);
+    command.addParam("arg", arg);
 
-    this._server.runCommand("excmapreduce", params, callback);
+    this._server.runCommand(command, callback);
 }
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/87446876/modules/nodejs/src/main/js/ignite.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/ignite.js b/modules/nodejs/src/main/js/ignite.js
index d7203e4..dde259e 100644
--- a/modules/nodejs/src/main/js/ignite.js
+++ b/modules/nodejs/src/main/js/ignite.js
@@ -19,6 +19,7 @@ var Cache = require("./cache").Cache;
 var Compute = require("./compute").Compute;
 var ClusterNode = require("./cluster-node").ClusterNode;
 var Server = require("./server").Server;
+var Command = require("./server").Command;
 
 /**
  * Create an instance of Ignite
@@ -67,7 +68,7 @@ Ignite.prototype.compute = function() {
  * @param {onGet} callback Result in callback contains string with Ignite version.
  */
 Ignite.prototype.version = function(callback) {
-    this._server.runCommand("version", [], callback);
+    this._server.runCommand(new Command("version"), callback);
 }
 
 /**
@@ -77,7 +78,7 @@ Ignite.prototype.version = function(callback) {
  * @param {onGet} callback Result in callback contains string with Ignite name.
  */
 Ignite.prototype.name = function(callback) {
-    this._server.runCommand("name", [], callback);
+    this._server.runCommand(new Command("name"), callback);
 }
 
 /**
@@ -107,7 +108,7 @@ Ignite.prototype.cluster = function(callback) {
         callback.call(null, null, nodes);
     }
 
-    this._server.runCommand("top", [Server.pair("attr", "true"), Server.pair("mtr", "false")],
+    this._server.runCommand(new Command("top").addParam("attr", "true").addParam("mtr", "false"),
         onTop.bind(null, callback));
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/87446876/modules/nodejs/src/main/js/server.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/server.js b/modules/nodejs/src/main/js/server.js
index b3586e3..2714ae5 100644
--- a/modules/nodejs/src/main/js/server.js
+++ b/modules/nodejs/src/main/js/server.js
@@ -61,27 +61,23 @@ Server.prototype.host = function() {
  * @param params Parameters for command.
  * @param {onGet} Called on finish
  */
-Server.prototype.runCommand = function(cmdName, params, callback, postData) {
-    var paramsString = "";
-
-    for (var p of params) {
-        paramsString += "&" + p.key + "=" + p.value;
-    }
+Server.prototype.runCommand = function(cmd, callback) {
 
-    var requestQry = "cmd=" + cmdName + paramsString;
+    var requestQry = "cmd=" + cmd.name() + cmd.paramsString();
 
     var http = require('http');
 
     var options = {
         host: this._host,
         port: this._port,
-        method : postData ? "POST" : "GET",
+        method : cmd._method(),
         path: "/ignite?" + requestQry,
         headers: this._signature()
     };
 
-    if (postData)
-        options.headers['Content-Length'] = postData.length;
+    if (cmd._isPost()) {
+        options.headers['Content-Length'] = cmd.postData().length;
+    }
 
     function streamCallback(response) {
         var fullResponseString = '';
@@ -129,9 +125,9 @@ Server.prototype.runCommand = function(cmdName, params, callback, postData) {
 
     request.on('error', callback);
 
-    if (postData)
-        request.write(postData);
-
+    if (cmd._isPost()) {
+        request.write(cmd.postData());
+    }
     request.end();
 }
 
@@ -142,18 +138,7 @@ Server.prototype.runCommand = function(cmdName, params, callback, postData) {
  * @param {onGet} callback Called on finish
  */
 Server.prototype.checkConnection = function(callback) {
-    this.runCommand("version", [], callback);
-}
-
-/**
- * Returns pair for runCommand
- *
- * @param {string} key Key
- * @param {string} value Value
- * @returns Pair of strings
- */
-Server.pair = function(key, value) {
-    return {key: Server._escape(key), value: Server._escape(value)}
+    this.runCommand(new Command("version"), callback);
 }
 
 /**
@@ -194,4 +179,52 @@ Server._escape = function(f) {
     return qs.escape(f.toString());
 }
 
-exports.Server = Server;
\ No newline at end of file
+function Command(name) {
+    this._name = name;
+    this._params = [];
+}
+
+Command.prototype.addParam = function(key, value) {
+    this._params.push({key: key, value: value});
+    return this;
+}
+
+Command.prototype.addParams = function(prefix, params) {
+    for (var i = 1; i <= params.length; ++i) {
+        this.addParam(prefix + i, params[i - 1]);
+    }
+    return this;
+}
+
+Command.prototype.setPostData = function(postData) {
+    this._postData = postData;
+    return this;
+}
+
+Command.prototype.postData = function() {
+    return this._postData;
+}
+
+Command.prototype._method = function() {
+    return this._isPost()? "POST" : "GET";
+}
+
+Command.prototype._isPost = function() {
+    return !!this._postData;
+}
+
+Command.prototype.name = function() {
+    return this._name;
+}
+
+Command.prototype.paramsString = function() {
+    var paramsString = "";
+
+    for (var p of this._params) {
+        paramsString += "&" + Server._escape(p.key) + "=" + Server._escape(p.value);
+    }
+    return paramsString;
+}
+
+exports.Server = Server;
+exports.Command = Command;
\ No newline at end of file


[08/39] incubator-ignite git commit: IGNITE-1063 Added generic for chaining setters.

Posted by iv...@apache.org.
IGNITE-1063 Added generic for chaining setters.


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

Branch: refs/heads/ignite-964
Commit: ef7a35ce9afb830c2e02b624eb3f3298f66e6129
Parents: bade9f1
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Tue Jun 30 12:31:13 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Tue Jun 30 12:31:13 2015 +0300

----------------------------------------------------------------------
 .../configuration/CacheConfiguration.java       | 105 ++++++++++---------
 .../configuration/NearCacheConfiguration.java   |  10 +-
 2 files changed, 61 insertions(+), 54 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ef7a35ce/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
index 7af4974..e2308f2 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
@@ -419,7 +419,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param name Cache name. May be <tt>null</tt>, but may not be empty string.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setName(String name) {
+    public CacheConfiguration<K, V> setName(String name) {
         A.ensure(name == null || !name.isEmpty(), "Name cannot be null or empty.");
 
         this.name = name;
@@ -444,7 +444,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictPlc Cache expiration policy.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictionPolicy(@Nullable EvictionPolicy evictPlc) {
+    public CacheConfiguration<K, V> setEvictionPolicy(@Nullable EvictionPolicy evictPlc) {
         this.evictPlc = evictPlc;
 
         return this;
@@ -461,7 +461,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param nearCfg Near cache configuration.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setNearConfiguration(NearCacheConfiguration<K, V> nearCfg) {
+    public CacheConfiguration<K, V> setNearConfiguration(NearCacheConfiguration<K, V> nearCfg) {
         this.nearCfg = nearCfg;
 
         return this;
@@ -483,7 +483,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param writeSync Write synchronization mode.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setWriteSynchronizationMode(CacheWriteSynchronizationMode writeSync) {
+    public CacheConfiguration<K, V> setWriteSynchronizationMode(CacheWriteSynchronizationMode writeSync) {
         this.writeSync = writeSync;
 
         return this;
@@ -504,7 +504,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param nodeFilter Predicate specifying on which nodes the cache should be started.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter) {
+    public CacheConfiguration<K, V> setNodeFilter(IgnitePredicate<ClusterNode> nodeFilter) {
         this.nodeFilter = nodeFilter;
 
         return this;
@@ -536,7 +536,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictSync {@code true} if synchronized, {@code false} if not.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictSynchronized(boolean evictSync) {
+    public CacheConfiguration<K, V> setEvictSynchronized(boolean evictSync) {
         this.evictSync = evictSync;
 
         return this;
@@ -559,7 +559,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictKeyBufSize Eviction key buffer size.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictSynchronizedKeyBufferSize(int evictKeyBufSize) {
+    public CacheConfiguration<K, V> setEvictSynchronizedKeyBufferSize(int evictKeyBufSize) {
         this.evictKeyBufSize = evictKeyBufSize;
 
         return this;
@@ -593,7 +593,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictSyncConcurrencyLvl Concurrency level for synchronized evictions.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictSynchronizedConcurrencyLevel(int evictSyncConcurrencyLvl) {
+    public CacheConfiguration<K, V> setEvictSynchronizedConcurrencyLevel(int evictSyncConcurrencyLvl) {
         this.evictSyncConcurrencyLvl = evictSyncConcurrencyLvl;
 
         return this;
@@ -619,7 +619,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictSyncTimeout Timeout for synchronized evictions.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictSynchronizedTimeout(long evictSyncTimeout) {
+    public CacheConfiguration<K, V> setEvictSynchronizedTimeout(long evictSyncTimeout) {
         this.evictSyncTimeout = evictSyncTimeout;
 
         return this;
@@ -651,7 +651,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictMaxOverflowRatio Maximum eviction overflow ratio.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictMaxOverflowRatio(float evictMaxOverflowRatio) {
+    public CacheConfiguration<K, V> setEvictMaxOverflowRatio(float evictMaxOverflowRatio) {
         this.evictMaxOverflowRatio = evictMaxOverflowRatio;
 
         return this;
@@ -680,7 +680,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param evictFilter Eviction filter.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEvictionFilter(EvictionFilter<K, V> evictFilter) {
+    public CacheConfiguration<K, V> setEvictionFilter(EvictionFilter<K, V> evictFilter) {
         this.evictFilter = evictFilter;
 
         return this;
@@ -709,7 +709,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #isEagerTtl()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setEagerTtl(boolean eagerTtl) {
+    public CacheConfiguration<K, V> setEagerTtl(boolean eagerTtl) {
         this.eagerTtl = eagerTtl;
 
         return this;
@@ -731,7 +731,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param startSize Cache start size.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setStartSize(int startSize) {
+    public CacheConfiguration<K, V> setStartSize(int startSize) {
         this.startSize = startSize;
 
         return this;
@@ -775,7 +775,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param loadPrevVal Load previous value flag.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setLoadPreviousValue(boolean loadPrevVal) {
+    public CacheConfiguration<K, V> setLoadPreviousValue(boolean loadPrevVal) {
         this.loadPrevVal = loadPrevVal;
 
         return this;
@@ -798,7 +798,8 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @return {@code this} for chaining.
      */
     @SuppressWarnings("unchecked")
-    public CacheConfiguration setCacheStoreFactory(Factory<? extends CacheStore<? super K, ? super V>> storeFactory) {
+    public CacheConfiguration<K, V> setCacheStoreFactory(
+        Factory<? extends CacheStore<? super K, ? super V>> storeFactory) {
         this.storeFactory = storeFactory;
 
         return this;
@@ -819,7 +820,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param aff Cache key affinity.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setAffinity(AffinityFunction aff) {
+    public CacheConfiguration<K, V> setAffinity(AffinityFunction aff) {
         this.aff = aff;
 
         return this;
@@ -842,7 +843,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param cacheMode Caching mode.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setCacheMode(CacheMode cacheMode) {
+    public CacheConfiguration<K, V> setCacheMode(CacheMode cacheMode) {
         this.cacheMode = cacheMode;
 
         return this;
@@ -865,7 +866,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param atomicityMode Cache atomicity mode.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setAtomicityMode(CacheAtomicityMode atomicityMode) {
+    public CacheConfiguration<K, V> setAtomicityMode(CacheAtomicityMode atomicityMode) {
         this.atomicityMode = atomicityMode;
 
         return this;
@@ -888,7 +889,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param atomicWriteOrderMode Cache write ordering mode.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setAtomicWriteOrderMode(CacheAtomicWriteOrderMode atomicWriteOrderMode) {
+    public CacheConfiguration<K, V> setAtomicWriteOrderMode(CacheAtomicWriteOrderMode atomicWriteOrderMode) {
         this.atomicWriteOrderMode = atomicWriteOrderMode;
 
         return this;
@@ -913,7 +914,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param backups Number of backup nodes for one partition.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setBackups(int backups) {
+    public CacheConfiguration<K, V> setBackups(int backups) {
         this.backups = backups;
 
         return this;
@@ -935,7 +936,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param dfltLockTimeout Default lock timeout.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setDefaultLockTimeout(long dfltLockTimeout) {
+    public CacheConfiguration<K, V> setDefaultLockTimeout(long dfltLockTimeout) {
         this.dfltLockTimeout = dfltLockTimeout;
 
         return this;
@@ -956,7 +957,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param invalidate Flag to set this cache into invalidation-based mode. Default value is {@code false}.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setInvalidate(boolean invalidate) {
+    public CacheConfiguration<K, V> setInvalidate(boolean invalidate) {
         this.invalidate = invalidate;
 
         return this;
@@ -978,7 +979,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      *      receive JTA transaction manager.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setTransactionManagerLookupClassName(String tmLookupClsName) {
+    public CacheConfiguration<K, V> setTransactionManagerLookupClassName(String tmLookupClsName) {
         this.tmLookupClsName = tmLookupClsName;
 
         return this;
@@ -990,7 +991,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param rebalanceMode Rebalance mode.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceMode(CacheRebalanceMode rebalanceMode) {
+    public CacheConfiguration<K, V> setRebalanceMode(CacheRebalanceMode rebalanceMode) {
         this.rebalanceMode = rebalanceMode;
 
         return this;
@@ -1033,7 +1034,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getRebalanceOrder()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceOrder(int rebalanceOrder) {
+    public CacheConfiguration<K, V> setRebalanceOrder(int rebalanceOrder) {
         this.rebalanceOrder = rebalanceOrder;
 
         return this;
@@ -1057,7 +1058,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param rebalanceBatchSize Rebalance batch size.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceBatchSize(int rebalanceBatchSize) {
+    public CacheConfiguration<K, V> setRebalanceBatchSize(int rebalanceBatchSize) {
         this.rebalanceBatchSize = rebalanceBatchSize;
 
         return this;
@@ -1079,7 +1080,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param swapEnabled {@code True} if swap storage is enabled.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setSwapEnabled(boolean swapEnabled) {
+    public CacheConfiguration<K, V> setSwapEnabled(boolean swapEnabled) {
         this.swapEnabled = swapEnabled;
 
         return this;
@@ -1108,7 +1109,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getMaxConcurrentAsyncOperations()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setMaxConcurrentAsyncOperations(int maxConcurrentAsyncOps) {
+    public CacheConfiguration<K, V> setMaxConcurrentAsyncOperations(int maxConcurrentAsyncOps) {
         this.maxConcurrentAsyncOps = maxConcurrentAsyncOps;
 
         return this;
@@ -1131,7 +1132,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param writeBehindEnabled {@code true} if write-behind is enabled.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setWriteBehindEnabled(boolean writeBehindEnabled) {
+    public CacheConfiguration<K, V> setWriteBehindEnabled(boolean writeBehindEnabled) {
         this.writeBehindEnabled = writeBehindEnabled;
 
         return this;
@@ -1159,7 +1160,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getWriteBehindFlushSize()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setWriteBehindFlushSize(int writeBehindFlushSize) {
+    public CacheConfiguration<K, V> setWriteBehindFlushSize(int writeBehindFlushSize) {
         this.writeBehindFlushSize = writeBehindFlushSize;
 
         return this;
@@ -1188,7 +1189,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getWriteBehindFlushFrequency()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setWriteBehindFlushFrequency(long writeBehindFlushFreq) {
+    public CacheConfiguration<K, V> setWriteBehindFlushFrequency(long writeBehindFlushFreq) {
         this.writeBehindFlushFreq = writeBehindFlushFreq;
 
         return this;
@@ -1215,7 +1216,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getWriteBehindFlushThreadCount()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setWriteBehindFlushThreadCount(int writeBehindFlushThreadCnt) {
+    public CacheConfiguration<K, V> setWriteBehindFlushThreadCount(int writeBehindFlushThreadCnt) {
         this.writeBehindFlushThreadCnt = writeBehindFlushThreadCnt;
 
         return this;
@@ -1242,7 +1243,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #getWriteBehindBatchSize()
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setWriteBehindBatchSize(int writeBehindBatchSize) {
+    public CacheConfiguration<K, V> setWriteBehindBatchSize(int writeBehindBatchSize) {
         this.writeBehindBatchSize = writeBehindBatchSize;
 
         return this;
@@ -1267,7 +1268,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param rebalancePoolSize Size of rebalancing thread pool.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceThreadPoolSize(int rebalancePoolSize) {
+    public CacheConfiguration<K, V> setRebalanceThreadPoolSize(int rebalancePoolSize) {
         this.rebalancePoolSize = rebalancePoolSize;
 
         return this;
@@ -1290,7 +1291,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param rebalanceTimeout Rebalance timeout (ms).
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceTimeout(long rebalanceTimeout) {
+    public CacheConfiguration<K, V> setRebalanceTimeout(long rebalanceTimeout) {
         this.rebalanceTimeout = rebalanceTimeout;
 
         return this;
@@ -1328,7 +1329,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param rebalanceDelay Rebalance delay to set.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceDelay(long rebalanceDelay) {
+    public CacheConfiguration<K, V> setRebalanceDelay(long rebalanceDelay) {
         this.rebalanceDelay = rebalanceDelay;
 
         return this;
@@ -1364,7 +1365,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * {@code 0} to disable throttling.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setRebalanceThrottle(long rebalanceThrottle) {
+    public CacheConfiguration<K, V> setRebalanceThrottle(long rebalanceThrottle) {
         this.rebalanceThrottle = rebalanceThrottle;
 
         return this;
@@ -1391,7 +1392,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param affMapper Affinity mapper.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setAffinityMapper(AffinityKeyMapper affMapper) {
+    public CacheConfiguration<K, V> setAffinityMapper(AffinityKeyMapper affMapper) {
         this.affMapper = affMapper;
 
         return this;
@@ -1438,7 +1439,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param offHeapMaxMem Maximum memory in bytes available to off-heap memory space.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setOffHeapMaxMemory(long offHeapMaxMem) {
+    public CacheConfiguration<K, V> setOffHeapMaxMemory(long offHeapMaxMem) {
         this.offHeapMaxMem = offHeapMaxMem;
 
         return this;
@@ -1462,7 +1463,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param memMode Memory mode.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setMemoryMode(CacheMemoryMode memMode) {
+    public CacheConfiguration<K, V> setMemoryMode(CacheMemoryMode memMode) {
         this.memMode = memMode;
 
         return this;
@@ -1484,7 +1485,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param interceptor Cache interceptor.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setInterceptor(CacheInterceptor<K, V> interceptor) {
+    public CacheConfiguration<K, V> setInterceptor(CacheInterceptor<K, V> interceptor) {
         this.interceptor = interceptor;
 
         return this;
@@ -1505,7 +1506,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param typeMeta Collection of type metadata.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setTypeMetadata(Collection<CacheTypeMetadata> typeMeta) {
+    public CacheConfiguration<K, V> setTypeMetadata(Collection<CacheTypeMetadata> typeMeta) {
         this.typeMeta = typeMeta;
 
         return this;
@@ -1530,7 +1531,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param readFromBackup {@code true} to allow reads from backups.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setReadFromBackup(boolean readFromBackup) {
+    public CacheConfiguration<K, V> setReadFromBackup(boolean readFromBackup) {
         this.readFromBackup = readFromBackup;
 
         return this;
@@ -1554,7 +1555,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #isCopyOnRead
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setCopyOnRead(boolean cpOnRead) {
+    public CacheConfiguration<K, V> setCopyOnRead(boolean cpOnRead) {
         this.cpOnRead = cpOnRead;
 
         return this;
@@ -1567,7 +1568,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param cls One or more classes with SQL functions.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setSqlFunctionClasses(Class<?>... cls) {
+    public CacheConfiguration<K, V> setSqlFunctionClasses(Class<?>... cls) {
         this.sqlFuncCls = cls;
 
         return this;
@@ -1598,7 +1599,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param longQryWarnTimeout Timeout in milliseconds.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setLongQueryWarningTimeout(long longQryWarnTimeout) {
+    public CacheConfiguration<K, V> setLongQueryWarningTimeout(long longQryWarnTimeout) {
         this.longQryWarnTimeout = longQryWarnTimeout;
 
         return this;
@@ -1623,7 +1624,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param sqlEscapeAll Flag value.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setSqlEscapeAll(boolean sqlEscapeAll) {
+    public CacheConfiguration<K, V> setSqlEscapeAll(boolean sqlEscapeAll) {
         this.sqlEscapeAll = sqlEscapeAll;
 
         return this;
@@ -1660,7 +1661,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param indexedTypes Key and value type pairs.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setIndexedTypes(Class<?>... indexedTypes) {
+    public CacheConfiguration<K, V> setIndexedTypes(Class<?>... indexedTypes) {
         A.ensure(indexedTypes == null || (indexedTypes.length & 1) == 0,
             "Number of indexed types is expected to be even. Refer to method javadoc for details.");
 
@@ -1699,7 +1700,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @see #setOffHeapMaxMemory(long)
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setSqlOnheapRowCacheSize(int size) {
+    public CacheConfiguration<K, V> setSqlOnheapRowCacheSize(int size) {
         this.sqlOnheapRowCacheSize = size;
 
         return this;
@@ -1720,7 +1721,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param pluginCfgs Cache plugin configurations.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setPluginConfigurations(CachePluginConfiguration... pluginCfgs) {
+    public CacheConfiguration<K, V> setPluginConfigurations(CachePluginConfiguration... pluginCfgs) {
         this.pluginCfgs = pluginCfgs;
 
         return this;
@@ -1739,7 +1740,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @param topValidator validator.
      * @return {@code this} for chaining.
      */
-    public CacheConfiguration setTopologyValidator(TopologyValidator topValidator) {
+    public CacheConfiguration<K, V> setTopologyValidator(TopologyValidator topValidator) {
         this.topValidator = topValidator;
 
         return this;
@@ -1766,7 +1767,7 @@ public class CacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * @return {@code this} for chaining.
      * @see CacheStoreSessionListener
      */
-    public CacheConfiguration setCacheStoreSessionListenerFactories(
+    public CacheConfiguration<K, V> setCacheStoreSessionListenerFactories(
         Factory<? extends CacheStoreSessionListener>... storeSesLsnrs) {
         this.storeSesLsnrs = storeSesLsnrs;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ef7a35ce/modules/core/src/main/java/org/apache/ignite/configuration/NearCacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/NearCacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/NearCacheConfiguration.java
index 0593601..580010a 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/NearCacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/NearCacheConfiguration.java
@@ -64,9 +64,12 @@ public class NearCacheConfiguration<K, V> extends MutableConfiguration<K, V> {
 
     /**
      * @param nearEvictPlc Near eviction policy.
+     * @return {@code this} for chaining.
      */
-    public void setNearEvictionPolicy(EvictionPolicy<K, V> nearEvictPlc) {
+    public NearCacheConfiguration<K, V> setNearEvictionPolicy(EvictionPolicy<K, V> nearEvictPlc) {
         this.nearEvictPlc = nearEvictPlc;
+
+        return this;
     }
 
     /**
@@ -83,9 +86,12 @@ public class NearCacheConfiguration<K, V> extends MutableConfiguration<K, V> {
      * Start size for near cache. This property is only used for {@link CacheMode#PARTITIONED} caching mode.
      *
      * @param nearStartSize Start size for near cache.
+     * @return {@code this} for chaining.
      */
-    public void setNearStartSize(int nearStartSize) {
+    public NearCacheConfiguration<K, V> setNearStartSize(int nearStartSize) {
         this.nearStartSize = nearStartSize;
+
+        return this;
     }
 
     /** {@inheritDoc} */


[39/39] incubator-ignite git commit: #ignite-964: nodejs code style.

Posted by iv...@apache.org.
#ignite-964: nodejs code style.


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

Branch: refs/heads/ignite-964
Commit: ad11a4a12b7a7159fbc7b36128ed65c817628e99
Parents: 45f16ea
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 13:12:20 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 13:12:20 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/main/js/cache.js | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ad11a4a1/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index eef4039..c65f026 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -138,7 +138,7 @@ Cache.prototype.getAll = function(keys, callback) {
 /**
  * Execute sql query
  *
- * @param {SqlQuery} qry Query
+ * @param {SqlQuery|SqlFieldsQuery} qry Query
  */
 Cache.prototype.query = function(qry) {
     function onQueryExecute(qry, error, res) {


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

Posted by iv...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-sprint-7' into ignite-964-1


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

Branch: refs/heads/ignite-964
Commit: eb4f07b2c81af0ad92a942bebb1c8fd14078d03a
Parents: 54be106 8006a84
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 16:22:44 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 16:22:44 2015 +0300

----------------------------------------------------------------------
 .../discovery/GridDiscoveryManager.java         |  46 +++-
 .../IgniteTopologyPrintFormatSelfTest.java      | 233 +++++++++++++++++++
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 3 files changed, 274 insertions(+), 6 deletions(-)
----------------------------------------------------------------------



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

Posted by iv...@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-964
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(-)
----------------------------------------------------------------------



[19/39] incubator-ignite git commit: Merge branch 'ignite-sprint-7' into ignite-1063

Posted by iv...@apache.org.
Merge branch 'ignite-sprint-7' into ignite-1063


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

Branch: refs/heads/ignite-964
Commit: 28525acbe2e19f5605137dbb7e9b3824eab25987
Parents: ef7a35c 6ebcb6d
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Tue Jun 30 16:56:15 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Tue Jun 30 16:56:15 2015 +0300

----------------------------------------------------------------------
 .../discovery/GridDiscoveryManager.java         |  26 +-
 .../IgniteTopologyPrintFormatSelfTest.java      | 289 +++++++++++++++++++
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 3 files changed, 310 insertions(+), 6 deletions(-)
----------------------------------------------------------------------



[18/39] incubator-ignite git commit: IGNITE-1062 Added tests.

Posted by iv...@apache.org.
IGNITE-1062 Added tests.


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

Branch: refs/heads/ignite-964
Commit: 6ebcb6de192e1916e58226990eb9d9ec759da6ef
Parents: 8006a84
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Tue Jun 30 16:51:15 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Tue Jun 30 16:51:15 2015 +0300

----------------------------------------------------------------------
 .../discovery/GridDiscoveryManager.java         | 26 +--------
 .../IgniteTopologyPrintFormatSelfTest.java      | 60 +++++++++++++++++++-
 2 files changed, 61 insertions(+), 25 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/6ebcb6de/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
index 1d555e4..a8ce8ff 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
@@ -101,7 +101,7 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
     /** Predicate filtering client nodes. */
     private static final IgnitePredicate<ClusterNode> clientFilter = new P1<ClusterNode>() {
         @Override public boolean apply(ClusterNode n) {
-            return n.isClient();
+            return CU.clientNode(n);
         }
     };
 
@@ -940,9 +940,9 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
 
         Collection<ClusterNode> rmtNodes = discoCache.remoteNodes();
 
-        Collection<ClusterNode> serverNodes = discoCache.serverNodes();
+        Collection<ClusterNode> serverNodes = F.view(discoCache.allNodes(), F.not(clientFilter));
 
-        Collection<ClusterNode> clientNodes = discoCache.clientNodes();
+        Collection<ClusterNode> clientNodes = F.view(discoCache.allNodes(), clientFilter);
 
         ClusterNode locNode = discoCache.localNode();
 
@@ -2122,12 +2122,6 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
         /** Remote nodes. */
         private final List<ClusterNode> rmtNodes;
 
-        /** Client nodes. */
-        private final List<ClusterNode> clientNodes;
-
-        /** Server nodes. */
-        private final List<ClusterNode> serverNodes;
-
         /** All nodes. */
         private final List<ClusterNode> allNodes;
 
@@ -2216,10 +2210,6 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
 
             all.addAll(rmtNodes);
 
-            clientNodes = Collections.unmodifiableList(new ArrayList<>(F.view(all, clientFilter)));
-
-            serverNodes = Collections.unmodifiableList(new ArrayList<>(F.view(all, F.not(clientFilter))));
-
             Collections.sort(all, GridNodeOrderComparator.INSTANCE);
 
             allNodes = Collections.unmodifiableList(all);
@@ -2370,16 +2360,6 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
             return rmtNodes;
         }
 
-        /** @return Server nodes. */
-        Collection<ClusterNode> serverNodes() {
-            return serverNodes;
-        }
-
-        /** @return Client nodes. */
-        Collection<ClusterNode> clientNodes() {
-            return clientNodes;
-        }
-
         /** @return All nodes. */
         Collection<ClusterNode> allNodes() {
             return allNodes;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/6ebcb6de/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
index efbc431..2a71f28 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
@@ -56,11 +56,16 @@ public class IgniteTopologyPrintFormatSelfTest extends GridCommonAbstractTest {
         TcpDiscoverySpi disc = new TcpDiscoverySpi();
         disc.setIpFinder(IP_FINDER);
 
-        cfg.setDiscoverySpi(disc);
-
         if (gridName.endsWith("client"))
             cfg.setClientMode(true);
 
+        if (gridName.endsWith("client_force_server")) {
+            cfg.setClientMode(true);
+            disc.setForceServerMode(true);
+        }
+
+        cfg.setDiscoverySpi(disc);
+
         return cfg;
     }
 
@@ -176,6 +181,57 @@ public class IgniteTopologyPrintFormatSelfTest extends GridCommonAbstractTest {
     }
 
     /**
+     * @throws Exception If failed.
+     */
+    public void testForceServerAndClientLogs() throws Exception {
+        MockLogger log = new MockLogger();
+
+        log.setLevel(Level.INFO);
+
+        doForceServerAndClientTest(log);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testForceServerAndClientDebugLogs() throws Exception {
+        MockLogger log = new MockLogger();
+
+        log.setLevel(Level.DEBUG);
+
+        doForceServerAndClientTest(log);
+    }
+
+    /**
+     * @param log Log.
+     * @throws Exception If failed.
+     */
+    private void doForceServerAndClientTest(MockLogger log) throws Exception {
+        try {
+            Ignite server = startGrid("server");
+
+            setLogger(log, server);
+
+            Ignite server1 = startGrid("server1");
+            Ignite client1 = startGrid("first client");
+            Ignite client2 = startGrid("second client");
+            Ignite forceServClnt3 = startGrid("third client_force_server");
+
+            waitForDiscovery(server, server1, client1, client2, forceServClnt3);
+        }
+        finally {
+            stopAllGrids();
+        }
+
+        assertTrue(F.forAny(log.logs(), new IgnitePredicate<String>() {
+            @Override public boolean apply(String s) {
+                return s.contains("Topology snapshot [ver=5, server nodes=2, client nodes=3,")
+                    || (s.contains(">>> Number of server nodes: 2") && s.contains(">>> Number of client nodes: 3"));
+            }
+        }));
+    }
+
+    /**
      * Set log.
      *
      * @param log Log.


[34/39] incubator-ignite git commit: #ignite-964: JSONCacheObject code style.

Posted by iv...@apache.org.
#ignite-964: JSONCacheObject code style.


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

Branch: refs/heads/ignite-964
Commit: bb412c4233c29a14fb96a58fb3cda2e0ea528388
Parents: d85dab7
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:36:54 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:36:54 2015 +0300

----------------------------------------------------------------------
 .../protocols/http/jetty/JSONCacheObject.java   | 78 +++++++++++---------
 1 file changed, 45 insertions(+), 33 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bb412c42/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
index 67f2430..7ea30b3 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
@@ -26,28 +26,62 @@ import java.util.*;
  */
 public class JSONCacheObject {
     /** Fields map. */
-    private Map<Object, Object> fields = new HashMap<>();
+    private final Map<Object, Object> fields = new HashMap<>();
 
-    public JSONCacheObject() {
+    /**
+     * Empty constructor.
+     */
+    private JSONCacheObject() {
+    }
 
+    /**
+     * @param o JSON object.
+     */
+    public JSONCacheObject(JSONObject o) {
+        for (Object key : o.keySet())
+            addField(toSimpleObject(key), toSimpleObject(o.get(key)));
     }
 
-    public void setFields(Map<Object, Object> fields) {
-        this.fields = fields;
+    /**
+     * @param key Field name.
+     * @param val Field value.
+     */
+    public void addField(Object key, Object val) {
+        fields.put(key, val);
     }
 
-    public Map<Object, Object> getFields() {
-        return fields;
+    /**
+     * @param key Field name.
+     * @return Field value.
+     */
+    public Object getField(Object key) {
+        return fields.get(key);
     }
 
-    public JSONCacheObject(JSONObject o) {
-        for (Object key : o.keySet())
-            addField(toSimpleObject(key), toSimpleObject(o.get(key)));
+    /**
+     * @return Fields key set.
+     */
+    public Set<Object> keys() {
+        return fields.keySet();
+    }
+
+    /**
+     * @return Fields map.
+     */
+    public Map<Object, Object> getFields() {
+        return fields;
     }
 
+    /**
+     * Convert JSON object to JSONCacheObject
+     *
+     * @param o Object to convert.
+     * @return Converted object.
+     */
     private Object toSimpleObject(Object o) {
         if (o instanceof JSONObject) {
             JSONObject o1 = (JSONObject)o;
+
             JSONCacheObject res = new JSONCacheObject();
 
             for (Object key : o1.keySet())
@@ -57,7 +91,9 @@ public class JSONCacheObject {
         }
         else if (o instanceof JSONArray) {
             JSONArray o1 = (JSONArray) o;
+
             List<Object> val = new ArrayList<>();
+
             for (Object v : o1)
                 val.add(toSimpleObject(v));
 
@@ -67,32 +103,8 @@ public class JSONCacheObject {
         return o;
     }
 
-    /**
-     * @param key Field name.
-     * @param val Field value.
-     */
-    public void addField(Object key, Object val) {
-        fields.put(key, val);
-    }
-
-    /**
-     * @param key Field name.
-     * @return Field value.
-     */
-    public Object getField(Object key) {
-        return fields.get(key);
-    }
-
-    /**
-     * @return Fields key set.
-     */
-    public Set<Object> keys() {
-        return fields.keySet();
-    }
-
     /** {@inheritDoc} */
     @Override public int hashCode() {
-        //TODO:
         return fields.hashCode();
     }
 


[23/39] incubator-ignite git commit: #ignite-964: wip

Posted by iv...@apache.org.
#ignite-964: wip


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

Branch: refs/heads/ignite-964
Commit: 80bd452c985d685169f7ca8bc4bd264e0f4d33ca
Parents: ea50ebb
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 18:53:10 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 18:53:10 2015 +0300

----------------------------------------------------------------------
 .../processors/scripting/JSONCacheObject.java   |  78 -------------
 .../http/jetty/GridJettyRestHandler.java        |  53 ++++++---
 .../protocols/http/jetty/JSONCacheObject.java   | 111 +++++++++++++++++++
 3 files changed, 149 insertions(+), 93 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/80bd452c/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java
deleted file mode 100644
index 46067d7..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java
+++ /dev/null
@@ -1,78 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.internal.processors.scripting;
-
-import java.util.*;
-
-/**
- * Json cache object.
- */
-public class JSONCacheObject {
-    /** Fields map. */
-    private Map<String, Object> fields = new HashMap<>();
-
-    /**
-     * @param key Field name.
-     * @param val Field value.
-     */
-    public void addField(String key, Object val) {
-        fields.put(key, val);
-    }
-
-    /**
-     * @param key Field name.
-     * @return Field value.
-     */
-    public Object getField(String key) {
-        return fields.get(key);
-    }
-
-    /**
-     * @return Fields key set.
-     */
-    public Set<String> keys() {
-        return fields.keySet();
-    }
-
-    /** {@inheritDoc} */
-    @Override public int hashCode() {
-        //TODO:
-        return fields.hashCode();
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean equals(Object obj) {
-        if (obj == null || !(obj instanceof JSONCacheObject))
-            return false;
-
-        JSONCacheObject obj0 = (JSONCacheObject) obj;
-
-        if (fields.size() != obj0.fields.size())
-            return false;
-
-        for (String key : obj0.keys()) {
-            if (!fields.containsKey(key))
-                return false;
-
-            if (!obj0.getField(key).equals(getField(key)))
-                return false;
-        }
-
-        return true;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/80bd452c/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index 6327c88..f7b1db8 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -358,28 +358,28 @@ public class GridJettyRestHandler extends AbstractHandler {
 
                 if (req.getHeader("JSONObject") != null) {
                     if (cmd == CACHE_PUT_ALL) {
-                        StringBuilder builder = new StringBuilder();
+                        JSONObject o =parseRequest(req);
 
-                        Scanner reader = null;
+                        int i = 1;
 
-                        try {
-                            reader = new Scanner(req.getReader());
-                        }
-                        catch (IOException e) {
-                            throw new IgniteCheckedException(e);
-                        }
+                        Map<Object, Object> map = U.newHashMap(o.keySet().size());
 
-                        while (reader.hasNext())
-                            builder.append(reader.next() + "\n");
+                        while (o.get("k" + i) != null) {
+                            Object key = o.get("k" + i);
 
-                        JSONObject o = JSONObject.fromObject(builder.toString());
+                            Object val = o.get("val" + i);
 
-                        restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
+                            if (key instanceof JSONObject)
+                                key = new JSONCacheObject((JSONObject)key);
 
-                        Map<Object, Object> map = U.newHashMap(o.keySet().size());
+                            if (val instanceof JSONObject)
+                                val = new JSONCacheObject((JSONObject)val);
 
-                        for (Object k : o.keySet())
-                            map.put(k, o.get(k));
+                            map.put(key, val);
+                            i++;
+                        }
+
+                        restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
 
                         restReq0.values(map);
                     }
@@ -732,4 +732,27 @@ public class GridJettyRestHandler extends AbstractHandler {
 
         return null;
     }
+
+    /**
+     * @param req Request.
+     * @return JSON object.
+     * @throws IgniteCheckedException If failed.
+     */
+    private JSONObject parseRequest(HttpServletRequest req) throws IgniteCheckedException{
+        StringBuilder builder = new StringBuilder();
+
+        Scanner reader = null;
+
+        try {
+            reader = new Scanner(req.getReader());
+        }
+        catch (IOException e) {
+            throw new IgniteCheckedException(e);
+        }
+
+        while (reader.hasNext())
+            builder.append(reader.next() + "\n");
+
+        return JSONObject.fromObject(builder.toString());
+    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/80bd452c/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
new file mode 100644
index 0000000..9bcd419
--- /dev/null
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
@@ -0,0 +1,111 @@
+/*
+ * 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.rest.protocols.http.jetty;
+
+import net.sf.json.*;
+
+import java.util.*;
+
+/**
+ * Json cache object.
+ */
+public class JSONCacheObject {
+    /** Fields map. */
+    private Map<Object, Object> fields = new HashMap<>();
+
+    public JSONCacheObject() {
+
+    }
+
+    public JSONCacheObject(JSONObject o) {
+        for (Object key : o.keySet())
+            addField(toSimpleObject(key), toSimpleObject(o.get(key)));
+    }
+
+    private Object toSimpleObject(Object o) {
+        if (o instanceof JSONObject) {
+            JSONObject o1 = (JSONObject)o;
+            JSONCacheObject res = new JSONCacheObject();
+
+            for (Object key : o1.keySet())
+                res.addField(toSimpleObject(key), toSimpleObject(o1.get(key)));
+
+            return res;
+        }
+        else if (o instanceof JSONArray) {
+            JSONArray o1 = (JSONArray) o;
+            List<Object> val = new ArrayList<>();
+            for (Object v : o1)
+                val.add(toSimpleObject(v));
+
+            return val;
+        }
+
+        return o;
+    }
+
+    /**
+     * @param key Field name.
+     * @param val Field value.
+     */
+    public void addField(Object key, Object val) {
+        fields.put(key, val);
+    }
+
+    /**
+     * @param key Field name.
+     * @return Field value.
+     */
+    public Object getField(Object key) {
+        return fields.get(key);
+    }
+
+    /**
+     * @return Fields key set.
+     */
+    public Set<Object> keys() {
+        return fields.keySet();
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        //TODO:
+        return fields.hashCode();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object obj) {
+        if (obj == null || !(obj instanceof JSONCacheObject))
+            return false;
+
+        JSONCacheObject obj0 = (JSONCacheObject) obj;
+
+        if (fields.size() != obj0.fields.size())
+            return false;
+
+        for (Object key : obj0.keys()) {
+            if (!fields.containsKey(key))
+                return false;
+
+            if (!obj0.getField(key).equals(getField(key)))
+                return false;
+        }
+
+        return true;
+    }
+}


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

Posted by iv...@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-964
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=""
 


[38/39] incubator-ignite git commit: #ignite-964: nodejs code style.

Posted by iv...@apache.org.
#ignite-964: nodejs code style.


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

Branch: refs/heads/ignite-964
Commit: 45f16eaaab3de5b574725e187e29b33649ef0977
Parents: 3807762
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 13:07:47 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 13:07:47 2015 +0300

----------------------------------------------------------------------
 .../processors/rest/handlers/query/QueryCommandHandler.java        | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/45f16eaa/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
index 9432bb7..ec9575c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
@@ -205,7 +205,7 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
         res.setQueryId(qryId);
 
         if (!cur.hasNext())
-            curs.remove(req.queryId());
+            curs.remove(qryId);
 
         return res;
     }


[20/39] incubator-ignite git commit: #ignite-964: add test put all objects.

Posted by iv...@apache.org.
#ignite-964: add test put all objects.


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

Branch: refs/heads/ignite-964
Commit: bea777f9d99b2e8a1e5cab8ab2c1215a70d15aff
Parents: eb4f07b
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 17:24:01 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 17:24:01 2015 +0300

----------------------------------------------------------------------
 .../processors/scripting/JSONCacheObject.java   | 78 ++++++++++++++++++++
 modules/nodejs/src/main/js/cache.js             |  4 +-
 .../ignite/internal/NodeJsCacheApiSelfTest.java |  7 ++
 modules/nodejs/src/test/js/test-cache-api.js    | 16 ++--
 modules/nodejs/src/test/js/test-utils.js        | 15 ++++
 5 files changed, 113 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bea777f9/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java
new file mode 100644
index 0000000..46067d7
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/scripting/JSONCacheObject.java
@@ -0,0 +1,78 @@
+/*
+ * 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.scripting;
+
+import java.util.*;
+
+/**
+ * Json cache object.
+ */
+public class JSONCacheObject {
+    /** Fields map. */
+    private Map<String, Object> fields = new HashMap<>();
+
+    /**
+     * @param key Field name.
+     * @param val Field value.
+     */
+    public void addField(String key, Object val) {
+        fields.put(key, val);
+    }
+
+    /**
+     * @param key Field name.
+     * @return Field value.
+     */
+    public Object getField(String key) {
+        return fields.get(key);
+    }
+
+    /**
+     * @return Fields key set.
+     */
+    public Set<String> keys() {
+        return fields.keySet();
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        //TODO:
+        return fields.hashCode();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object obj) {
+        if (obj == null || !(obj instanceof JSONCacheObject))
+            return false;
+
+        JSONCacheObject obj0 = (JSONCacheObject) obj;
+
+        if (fields.size() != obj0.fields.size())
+            return false;
+
+        for (String key : obj0.keys()) {
+            if (!fields.containsKey(key))
+                return false;
+
+            if (!obj0.getField(key).equals(getField(key)))
+                return false;
+        }
+
+        return true;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bea777f9/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index 8ff6ee3..e0ed505 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -153,7 +153,6 @@ Cache.prototype._sqlFieldsQuery = function(qry, onQueryExecute) {
 }
 
 Cache.prototype._sqlQuery = function(qry, onQueryExecute) {
-
     if (qry.returnType() == null) {
         qry.error("No type for sql query.");
         qry.end();
@@ -171,12 +170,15 @@ Cache.prototype._sqlQuery = function(qry, onQueryExecute) {
 
 Cache.prototype._createCommand = function(name) {
     var command = new Command(name);
+
     return command.addParam("cacheName", this._cacheName);
 }
 
 Cache.prototype._createQueryCommand = function(name, qry) {
     var command = this._createCommand(name);
+
     command.addParam("qry", qry.query());
+
     return command.addParam("psz", qry.pageSize());
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bea777f9/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
index f17ca60..1a9293c 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
@@ -84,4 +84,11 @@ public class NodeJsCacheApiSelfTest extends NodeJsAbstractTest {
     public void testPutAllGetAll() throws Exception {
         runJsScript("testPutAllGetAll");
     }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testPutAllObjectGetAll() throws Exception {
+        runJsScript("testPutAllObjectGetAll");
+    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bea777f9/modules/nodejs/src/test/js/test-cache-api.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-cache-api.js b/modules/nodejs/src/test/js/test-cache-api.js
index fc29f22..515f543 100644
--- a/modules/nodejs/src/test/js/test-cache-api.js
+++ b/modules/nodejs/src/test/js/test-cache-api.js
@@ -35,6 +35,15 @@ testPutAllGetAll = function() {
     startTest("mycache", {trace: [putAll, getAll], entry: {"key1": "val1", "key2" : "val2"}});
 }
 
+testPutAllObjectGetAll = function() {
+    var key1 = {"name" : "Ann"};
+    var key2 = {"name" : "Paul"};
+    var val1 = {"age" : 12, "books" : ["1", "Book"]};
+    var val2 = {"age" : 13, "books" : ["1", "Book"]};
+
+    startTest("mycache", {trace: [putAll, getAll], entry: {key1 : val1, key2 : val2}});
+}
+
 testRemoveAll = function() {
     startTest("mycache", {trace: [putAll, getAll, removeAll, getNone], entry: {"key1": "val1", "key2" : "val2"}});
 }
@@ -93,10 +102,6 @@ function putAll(cache, entries, next) {
     cache.putAll(entries, next);
 }
 
-function postPutAll(cache, entries, next) {
-    cache.postPutAll(entries, next);
-}
-
 function getAll(cache, entries, next) {
     cache.getAll(Object.keys(entries), onGetAll);
     var expected = entries;
@@ -111,8 +116,7 @@ function getAll(cache, entries, next) {
 
             assert(!!values[key], "Cannot find key. [key=" + key + "].");
 
-            assert(values[key] === expected[key], "Incorrect value. [key=" + key +
-                ", expected=" + expected[key] + ", val= " + values[key] + "].");
+            TestUtils.compareObject(expected[key], values[key]);
         }
         next();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bea777f9/modules/nodejs/src/test/js/test-utils.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-utils.js b/modules/nodejs/src/test/js/test-utils.js
index 0b0aebb..1ec5ab7 100644
--- a/modules/nodejs/src/test/js/test-utils.js
+++ b/modules/nodejs/src/test/js/test-utils.js
@@ -15,6 +15,8 @@
  * limitations under the License.
  */
 
+var assert = require("assert");
+
 /**
  * Create instance of TestUtils
  *
@@ -49,6 +51,19 @@ TestUtils.sep = function() {
     return require('path').sep;
 }
 
+TestUtils.compareObject = function(o1, o2) {
+    if (typeof o1 !== 'object') {
+        assert(o1 === o2, "Incorrect value. [expected=" + o1 + ", val= " + o2 + "].");
+    }
+    else {
+        assert(Object.keys(o1).length === Object.keys(o2).length, "Incorrect key set")
+
+        for (var keyObj of Object.keys(o2)) {
+            TestUtils.compareObject(o1[keyObj], o2[keyObj]);
+        }
+    }
+}
+
 /**
  * @param {string} dir Directory with all ignite libs
  * @returns {string} Classpath for ignite node start


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

Posted by iv...@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-964
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));
     }
 }


[22/39] incubator-ignite git commit: #ignite-964: change test for object put all.

Posted by iv...@apache.org.
#ignite-964: change test for object put all.


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

Branch: refs/heads/ignite-964
Commit: ea50ebbaa16544b1a791b2bef16bdb8e0dd75e0a
Parents: bea777f
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 17:47:53 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 17:47:53 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/test/js/test-cache-api.js | 8 +++++++-
 1 file changed, 7 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ea50ebba/modules/nodejs/src/test/js/test-cache-api.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-cache-api.js b/modules/nodejs/src/test/js/test-cache-api.js
index 515f543..6e660b1 100644
--- a/modules/nodejs/src/test/js/test-cache-api.js
+++ b/modules/nodejs/src/test/js/test-cache-api.js
@@ -36,12 +36,18 @@ testPutAllGetAll = function() {
 }
 
 testPutAllObjectGetAll = function() {
+    var params = {}
     var key1 = {"name" : "Ann"};
     var key2 = {"name" : "Paul"};
     var val1 = {"age" : 12, "books" : ["1", "Book"]};
     var val2 = {"age" : 13, "books" : ["1", "Book"]};
 
-    startTest("mycache", {trace: [putAll, getAll], entry: {key1 : val1, key2 : val2}});
+    params["k1"] = key1;
+    params["k2"] = key2;
+    params["val1"] = val1;
+    params["val2"] = val2;
+
+    startTest("mycache", {trace: [putAll, getAll], entry: params});
 }
 
 testRemoveAll = function() {


[32/39] incubator-ignite git commit: #ignite-964: IgniteScriptingCommandHandler code style.

Posted by iv...@apache.org.
#ignite-964: IgniteScriptingCommandHandler code style.


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

Branch: refs/heads/ignite-964
Commit: 3bc20e8def3926f05950077cc40f61b1b2b641ac
Parents: cec4534
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:28:16 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:28:16 2015 +0300

----------------------------------------------------------------------
 .../rest/handlers/scripting/IgniteScriptingCommandHandler.java | 6 ------
 1 file changed, 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3bc20e8d/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteScriptingCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteScriptingCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteScriptingCommandHandler.java
index d7525a0..2d65016 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteScriptingCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/scripting/IgniteScriptingCommandHandler.java
@@ -260,9 +260,6 @@ public class IgniteScriptingCommandHandler extends GridRestCommandHandlerAdapter
      * Run script callable.
      */
     private static class RunScriptCallable implements Callable<GridRestResponse> {
-        /** */
-        private static final long serialVersionUID = 0L;
-
         /** Kernal context. */
         private GridKernalContext ctx;
 
@@ -294,9 +291,6 @@ public class IgniteScriptingCommandHandler extends GridRestCommandHandlerAdapter
      * Map reduce callable.
      */
     private static class MapReduceCallable implements Callable<GridRestResponse> {
-        /** */
-        private static final long serialVersionUID = 0L;
-
         /** Kernal context. */
         private GridKernalContext ctx;
 


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

Posted by iv...@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-964
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


[33/39] incubator-ignite git commit: #ignite-964: GridVersionCommandHandler code style.

Posted by iv...@apache.org.
#ignite-964: GridVersionCommandHandler code style.


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

Branch: refs/heads/ignite-964
Commit: d85dab7e830f9a7157755d6823080ab6a6dccc70
Parents: 3bc20e8
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:29:20 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:29:20 2015 +0300

----------------------------------------------------------------------
 .../processors/rest/GridRestProcessor.java      |  2 +-
 .../version/GridVersionCommandHandler.java      | 67 --------------------
 .../version/GridVersionNameCommandHandler.java  | 67 ++++++++++++++++++++
 3 files changed, 68 insertions(+), 68 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d85dab7e/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
index 86bfafe..5a073a0 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestProcessor.java
@@ -290,7 +290,7 @@ public class GridRestProcessor extends GridProcessorAdapter {
             addHandler(new GridCacheCommandHandler(ctx));
             addHandler(new GridTaskCommandHandler(ctx));
             addHandler(new GridTopologyCommandHandler(ctx));
-            addHandler(new GridVersionCommandHandler(ctx));
+            addHandler(new GridVersionNameCommandHandler(ctx));
             addHandler(new DataStructuresCommandHandler(ctx));
             addHandler(new IgniteScriptingCommandHandler(ctx));
             addHandler(new QueryCommandHandler(ctx));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d85dab7e/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionCommandHandler.java
deleted file mode 100644
index 9597ab3..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionCommandHandler.java
+++ /dev/null
@@ -1,67 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.internal.processors.rest.handlers.version;
-
-import org.apache.ignite.internal.*;
-import org.apache.ignite.internal.processors.rest.*;
-import org.apache.ignite.internal.processors.rest.handlers.*;
-import org.apache.ignite.internal.processors.rest.request.*;
-import org.apache.ignite.internal.util.future.*;
-import org.apache.ignite.internal.util.typedef.internal.*;
-
-import java.util.*;
-
-import static org.apache.ignite.internal.IgniteVersionUtils.*;
-import static org.apache.ignite.internal.processors.rest.GridRestCommand.*;
-
-/**
- * Handler for {@link GridRestCommand#VERSION} command.
- */
-public class GridVersionCommandHandler extends GridRestCommandHandlerAdapter {
-    /** Supported commands. */
-    private static final Collection<GridRestCommand> SUPPORTED_COMMANDS = U.sealList(VERSION, NAME);
-
-    /**
-     * @param ctx Context.
-     */
-    public GridVersionCommandHandler(GridKernalContext ctx) {
-        super(ctx);
-    }
-
-    /** {@inheritDoc} */
-    @Override public Collection<GridRestCommand> supportedCommands() {
-        return SUPPORTED_COMMANDS;
-    }
-
-    /** {@inheritDoc} */
-    @Override public IgniteInternalFuture<GridRestResponse> handleAsync(GridRestRequest req) {
-        assert req != null;
-
-        assert SUPPORTED_COMMANDS.contains(req.command());
-
-        switch (req.command()){
-            case VERSION:
-                return new GridFinishedFuture<>(new GridRestResponse(VER_STR));
-
-            case NAME:
-                return new GridFinishedFuture<>(new GridRestResponse(ctx.gridName()));
-        }
-
-        return new GridFinishedFuture<>();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d85dab7e/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionNameCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionNameCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionNameCommandHandler.java
new file mode 100644
index 0000000..c22b838
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/version/GridVersionNameCommandHandler.java
@@ -0,0 +1,67 @@
+/*
+ * 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.rest.handlers.version;
+
+import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.processors.rest.*;
+import org.apache.ignite.internal.processors.rest.handlers.*;
+import org.apache.ignite.internal.processors.rest.request.*;
+import org.apache.ignite.internal.util.future.*;
+import org.apache.ignite.internal.util.typedef.internal.*;
+
+import java.util.*;
+
+import static org.apache.ignite.internal.IgniteVersionUtils.*;
+import static org.apache.ignite.internal.processors.rest.GridRestCommand.*;
+
+/**
+ * Handler for {@link GridRestCommand#VERSION} and {@link GridRestCommand#NAME} command.
+ */
+public class GridVersionNameCommandHandler extends GridRestCommandHandlerAdapter {
+    /** Supported commands. */
+    private static final Collection<GridRestCommand> SUPPORTED_COMMANDS = U.sealList(VERSION, NAME);
+
+    /**
+     * @param ctx Context.
+     */
+    public GridVersionNameCommandHandler(GridKernalContext ctx) {
+        super(ctx);
+    }
+
+    /** {@inheritDoc} */
+    @Override public Collection<GridRestCommand> supportedCommands() {
+        return SUPPORTED_COMMANDS;
+    }
+
+    /** {@inheritDoc} */
+    @Override public IgniteInternalFuture<GridRestResponse> handleAsync(GridRestRequest req) {
+        assert req != null;
+
+        assert SUPPORTED_COMMANDS.contains(req.command());
+
+        switch (req.command()){
+            case VERSION:
+                return new GridFinishedFuture<>(new GridRestResponse(VER_STR));
+
+            case NAME:
+                return new GridFinishedFuture<>(new GridRestResponse(ctx.gridName()));
+        }
+
+        return new GridFinishedFuture<>();
+    }
+}


[24/39] incubator-ignite git commit: #ignite-964: nodejs cache works with json objects and strings.

Posted by iv...@apache.org.
#ignite-964: nodejs cache works with json objects and strings.


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

Branch: refs/heads/ignite-964
Commit: b963d033922fa712ddb11fd3542468af802ea91f
Parents: 80bd452
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 01:14:44 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 01:14:44 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/main/js/apache-ignite.js     |   1 +
 modules/nodejs/src/main/js/cache.js             |  71 +++++++++++--
 .../ignite/internal/NodeJsCacheApiSelfTest.java |   7 ++
 modules/nodejs/src/test/js/test-cache-api.js    | 100 ++++++++++++++-----
 modules/nodejs/src/test/js/test-utils.js        |  11 +-
 .../http/jetty/GridJettyRestHandler.java        |  91 ++++++++++++++---
 .../protocols/http/jetty/JSONCacheObject.java   |   8 ++
 7 files changed, 240 insertions(+), 49 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/nodejs/src/main/js/apache-ignite.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/apache-ignite.js b/modules/nodejs/src/main/js/apache-ignite.js
index af86916..82aa5ca 100644
--- a/modules/nodejs/src/main/js/apache-ignite.js
+++ b/modules/nodejs/src/main/js/apache-ignite.js
@@ -17,6 +17,7 @@
 
 module.exports = {
     Cache : require('./cache.js').Cache,
+    Entry : require('./cache.js').Entry,
     Ignition : require('./ignition.js').Ignition,
     Server : require('./server.js').Server,
     Ignite : require('./ignite.js').Ignite,

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index e0ed505..3eaadb4 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -41,7 +41,9 @@ function Cache(server, cacheName) {
  * @param {onGet} callback Called on finish
  */
 Cache.prototype.get = function(key, callback) {
-    this._server.runCommand(this._createCommand("get").addParam("key", key), callback);
+    this._server.runCommand(this._createCommand("get").
+        setPostData(JSON.stringify({"key": key})),
+        callback);
 };
 
 /**
@@ -53,7 +55,8 @@ Cache.prototype.get = function(key, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.put = function(key, value, callback) {
-    this._server.runCommand(this._createCommand("put").addParam("key", key).addParam("val", value),
+    this._server.runCommand(this._createCommand("put").
+        setPostData(JSON.stringify({"key": key, "val" : value})),
         callback);
 }
 
@@ -65,7 +68,9 @@ Cache.prototype.put = function(key, value, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.remove = function(key, callback) {
-    this._server.runCommand(this._createCommand("rmv").addParam("key", key), callback);
+    this._server.runCommand(this._createCommand("rmv").
+        setPostData(JSON.stringify({"key": key})),
+        callback);
 }
 
 /**
@@ -76,18 +81,21 @@ Cache.prototype.remove = function(key, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.removeAll = function(keys, callback) {
-    this._server.runCommand(this._createCommand("rmvall").addParams("k", keys), callback);
+    this._server.runCommand(this._createCommand("rmvall").
+        setPostData(JSON.stringify({"keys" : keys})),
+        callback);
 }
 
 /**
  * Put keys to cache
  *
  * @this {Cache}
- * @param {Object.<string, string>} map collection of entries to put in the cache
+ * @param {Entry[]} List of entries to put in the cache
  * @param {noValue} callback Called on finish
  */
-Cache.prototype.putAll = function(map, callback) {
-    this._server.runCommand(this._createCommand("putall").setPostData(JSON.stringify(map)), callback);
+Cache.prototype.putAll = function(entries, callback) {
+    this._server.runCommand(this._createCommand("putall").setPostData(
+        JSON.stringify({"entries" : entries})), callback);
 }
 
 /**
@@ -106,7 +114,25 @@ Cache.prototype.putAll = function(map, callback) {
  * @param {Cache~onGetAll} callback Called on finish
  */
 Cache.prototype.getAll = function(keys, callback) {
-    this._server.runCommand(this._createCommand("getall").addParams("k", keys), callback);
+    function onGetAll(callback, err, res) {
+        if (err) {
+            callback.call(null, err, null);
+
+            return;
+        }
+
+        var result = [];
+
+        for (var key of res) {
+            result.push(new Entry(key["key"], key["value"]));
+        }
+
+        callback.call(null, null, result);
+    }
+
+    this._server.runCommand(this._createCommand("getall").setPostData(
+        JSON.stringify({"keys" : keys})),
+        onGetAll.bind(null, callback));
 }
 
 /**
@@ -182,4 +208,31 @@ Cache.prototype._createQueryCommand = function(name, qry) {
     return command.addParam("psz", qry.pageSize());
 }
 
-exports.Cache = Cache
\ No newline at end of file
+/**
+ * @this{Entry}
+ * @param key Key
+ * @param val Value
+ */
+function Entry(key, val) {
+    this._key = key;
+    this._val = val;
+}
+
+/**
+ * @this{Entry}
+ * @returns Key
+  */
+Entry.prototype.key = function() {
+    return this._key;
+}
+
+/**
+ * @this{Entry}
+ * @returns Value
+ */
+Entry.prototype.val = function() {
+    return this._val;
+}
+
+exports.Cache = Cache
+exports.Entry = Entry
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
index 1a9293c..d8f3859 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
@@ -91,4 +91,11 @@ public class NodeJsCacheApiSelfTest extends NodeJsAbstractTest {
     public void testPutAllObjectGetAll() throws Exception {
         runJsScript("testPutAllObjectGetAll");
     }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testRemoveAllObjectGetAll() throws Exception {
+        runJsScript("testRemoveAllObjectGetAll");
+    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/nodejs/src/test/js/test-cache-api.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-cache-api.js b/modules/nodejs/src/test/js/test-cache-api.js
index 6e660b1..fa3f6cc 100644
--- a/modules/nodejs/src/test/js/test-cache-api.js
+++ b/modules/nodejs/src/test/js/test-cache-api.js
@@ -17,45 +17,71 @@
 
 var TestUtils = require("./test-utils").TestUtils;
 
+var Ignite = require(TestUtils.scriptPath());
+var Entry = Ignite.Entry;
+
 var assert = require("assert");
 
 testPutGet = function() {
-    startTest("mycache", {trace: [put, getExist], entry: "6"});
+    startTest("mycache", {trace: [put, getExist], entry: ["key" , "6"]});
 }
 
 testRemove = function() {
-    startTest("mycache", {trace: [put, getExist, remove, getNonExist], entry: "6"});
+    startTest("mycache", {trace: [put, getExist, remove, getNonExist], entry: ["key" , "6"]});
 }
 
 testRemoveNoKey = function() {
-    startTest("mycache", {trace: [remove, getNonExist], entry: "6"});
+    startTest("mycache", {trace: [remove, getNonExist], entry: ["key" , "6"]});
 }
 
 testPutAllGetAll = function() {
-    startTest("mycache", {trace: [putAll, getAll], entry: {"key1": "val1", "key2" : "val2"}});
+    entries = [];
+
+    entries.push(new Entry("key1", "val1"));
+    entries.push(new Entry("key2", "val2"));
+
+    startTest("mycache", {trace: [putAll, getAll], entry: entries});
 }
 
 testPutAllObjectGetAll = function() {
-    var params = {}
+    entries = [];
+
+    var key1 = {"name" : "Ann"};
+    var key2 = {"name" : "Paul"};
+    var val1 = {"age" : 12, "books" : ["1", "Book"]};
+    var val2 = {"age" : 13, "books" : ["1", "Book"]};
+
+    entries.push(new Entry(key1, val1));
+    entries.push(new Entry(key2, val2));
+
+    startTest("mycache", {trace: [putAll, getAll], entry: entries});
+}
+
+testRemoveAllObjectGetAll = function() {
+    entries = [];
+
     var key1 = {"name" : "Ann"};
     var key2 = {"name" : "Paul"};
     var val1 = {"age" : 12, "books" : ["1", "Book"]};
     var val2 = {"age" : 13, "books" : ["1", "Book"]};
 
-    params["k1"] = key1;
-    params["k2"] = key2;
-    params["val1"] = val1;
-    params["val2"] = val2;
+    entries.push(new Entry(key1, val1));
+    entries.push(new Entry(key2, val2));
 
-    startTest("mycache", {trace: [putAll, getAll], entry: params});
+    startTest("mycache", {trace: [putAll, getAll, removeAll, getNone], entry: entries});
 }
 
 testRemoveAll = function() {
-    startTest("mycache", {trace: [putAll, getAll, removeAll, getNone], entry: {"key1": "val1", "key2" : "val2"}});
+    entries = [];
+
+    entries.push(new Entry("key1", "val1"));
+    entries.push(new Entry("key2", "val2"));
+
+    startTest("mycache", {trace: [putAll, getAll, removeAll, getNone], entry: entries});
 }
 
 testIncorrectCacheName = function() {
-    startTest("mycache1", {trace: [incorrectPut], entry: "6"});
+    startTest("mycache1", {trace: [incorrectPut], entry: ["key", "6"]});
 }
 
 function startTest(cacheName, testDescription) {
@@ -77,25 +103,27 @@ function onStart(cacheName, testDescription, error, ignite) {
 }
 
 function put(cache, entry, next) {
-    cache.put("key", entry, next);
+    cache.put(entry[0], entry[1], next);
 }
 
 function getExist(cache, entry, next) {
-    cache.get("key", onGet);
+    var key = Object.keys(entry)[0];
+
+    cache.get(entry[0], onGet);
 
     function onGet(error, value) {
         assert(!error);
-        assert(value === entry);
+        assert(value === entry[1]);
         next();
     }
 }
 
 function remove(cache, entry, next) {
-    cache.remove("key", next);
+    cache.remove(entry[0], next);
 }
 
 function getNonExist(cache, entry, next) {
-    cache.get("key", onGet);
+    cache.get(entry[0], onGet);
 
     function onGet(error, value) {
         assert(!error);
@@ -109,21 +137,47 @@ function putAll(cache, entries, next) {
 }
 
 function getAll(cache, entries, next) {
-    cache.getAll(Object.keys(entries), onGetAll);
+    var keys = []
+
+    for (var entry of entries) {
+        keys.push(entry.key());
+    }
+
+    cache.getAll(keys, onGetAll.bind(null, keys));
+
     var expected = entries;
 
-    function onGetAll(error, values) {
+    function onGetAll(keys, error, values) {
         assert(!error, error);
 
-        var keys = Object.keys(expected);
+        assert(values.length === keys.length, "Values length is incorrect "
+            + "[expected=" + keys.length + ", real=" + values.length + "]");
 
         for (var i = 0; i < keys.length; ++i) {
             var key = keys[i];
 
-            assert(!!values[key], "Cannot find key. [key=" + key + "].");
+            var foundVal = null;
+
+            for (var j = 0; j < values.length; ++j) {
+                if (TestUtils.compareObject(key, values[j].key())) {
+                    foundVal = values[j];
+                }
+            }
+
+            var foundExp = null;
 
-            TestUtils.compareObject(expected[key], values[key]);
+            for (var j = 0; j < expected.length; ++j) {
+                if (TestUtils.compareObject(key, expected[j].key())) {
+                    foundExp = expected[j];
+                }
+            }
+
+            assert(foundVal !== null, "Cannot find key. [key=" + key + "].");
+            assert(foundExp !== null, "Cannot find key. [key=" + key + "].");
+
+            assert(TestUtils.compareObject(foundExp, foundVal), "Incorrect value");
         }
+
         next();
     }
 }
@@ -144,7 +198,7 @@ function getNone(cache, entries, next) {
 }
 
 function incorrectPut(cache, entry, next) {
-    cache.put("key", entry, callback);
+    cache.put(entry[0], entry[1], callback);
 
     function callback(error) {
         assert(!!error, "Do not get error for not exist cache");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/nodejs/src/test/js/test-utils.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-utils.js b/modules/nodejs/src/test/js/test-utils.js
index 1ec5ab7..8beb3dc 100644
--- a/modules/nodejs/src/test/js/test-utils.js
+++ b/modules/nodejs/src/test/js/test-utils.js
@@ -53,15 +53,20 @@ TestUtils.sep = function() {
 
 TestUtils.compareObject = function(o1, o2) {
     if (typeof o1 !== 'object') {
-        assert(o1 === o2, "Incorrect value. [expected=" + o1 + ", val= " + o2 + "].");
+        return o1 === o2;
     }
     else {
-        assert(Object.keys(o1).length === Object.keys(o2).length, "Incorrect key set")
+        if (Object.keys(o1).length !== Object.keys(o2).length)
+            return false;
 
         for (var keyObj of Object.keys(o2)) {
-            TestUtils.compareObject(o1[keyObj], o2[keyObj]);
+            if (!TestUtils.compareObject(o1[keyObj], o2[keyObj])) {
+                return false;
+            }
         }
     }
+
+    return true;
 }
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index f7b1db8..55fe156 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -291,6 +291,8 @@ public class GridJettyRestHandler extends AbstractHandler {
         JSON json;
 
         try {
+            createResponse(cmd, cmdRes);
+
             json = JSONSerializer.toJSON(cmdRes, cfg);
         }
         catch (JSONException e) {
@@ -313,6 +315,54 @@ public class GridJettyRestHandler extends AbstractHandler {
         }
     }
 
+    private void createResponse(GridRestCommand cmd, GridRestResponse cmdRes) {
+        if (cmd == CACHE_GET_ALL) {
+            if (cmdRes.getResponse() == null) {
+                return;
+            }
+
+            Map o = (Map)cmdRes.getResponse();
+
+            List<RestEntry> res = new ArrayList<>();
+
+            for (Object k : o.keySet())
+                res.add(new RestEntry(k, o.get(k)));
+
+            cmdRes.setResponse(res);
+        }
+    }
+
+    public static class RestEntry {
+        private Object key;
+        private Object value;
+        public RestEntry(Object key, Object value) {
+            if (key instanceof JSONCacheObject)
+                this.key = ((JSONCacheObject)key).getFields();
+            else
+                this.key = key;
+
+            if (value instanceof JSONCacheObject)
+                this.value = ((JSONCacheObject)value).getFields();
+            else
+                this.value = value;
+        }
+        public Object getKey() {
+            return key;
+        }
+
+        public void setKey(Object key) {
+            this.key = key;
+        }
+
+        public Object getValue() {
+            return value;
+        }
+
+        public void setValue(Object value) {
+            this.value = value;
+        }
+    }
+
     /**
      * Creates REST request.
      *
@@ -357,35 +407,48 @@ public class GridJettyRestHandler extends AbstractHandler {
                 String cacheName = (String)params.get("cacheName");
 
                 if (req.getHeader("JSONObject") != null) {
+                    JSONObject o = parseRequest(req);
+
+                    Map<Object, Object> map = U.newHashMap(o.keySet().size());
+
                     if (cmd == CACHE_PUT_ALL) {
-                        JSONObject o =parseRequest(req);
+                        List entries = (List)o.get("entries");
 
-                        int i = 1;
+                        for (Object entry : entries) {
+                            JSONCacheObject cacheEntry = new JSONCacheObject((JSONObject)entry);
 
-                        Map<Object, Object> map = U.newHashMap(o.keySet().size());
+                            Object key = cacheEntry.getField("_key");
+                            Object val = cacheEntry.getField("_val");
 
-                        while (o.get("k" + i) != null) {
-                            Object key = o.get("k" + i);
+                            map.put(key, val);
+                        }
 
-                            Object val = o.get("val" + i);
+                        restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
 
-                            if (key instanceof JSONObject)
-                                key = new JSONCacheObject((JSONObject)key);
+                        restReq0.values(map);
+                    }
+                    else if (cmd == CACHE_GET_ALL || cmd == CACHE_REMOVE_ALL) {
+                        JSONCacheObject cacheObj = new JSONCacheObject(o);
 
-                            if (val instanceof JSONObject)
-                                val = new JSONCacheObject((JSONObject)val);
+                        List keys = (List)cacheObj.getField("keys");
 
-                            map.put(key, val);
-                            i++;
-                        }
+                        for (Object key : keys)
+                            map.put(key, null);
 
                         restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
 
                         restReq0.values(map);
                     }
+                    else if (cmd == CACHE_GET || cmd == CACHE_PUT || cmd == CACHE_REMOVE) {
+                        JSONCacheObject cacheObj = new JSONCacheObject(o);
+
+                        restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
+
+                        restReq0.key(cacheObj.getField("key"));
+                        restReq0.value(cacheObj.getField("val"));
+                    }
                 }
                 else {
-
                     restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
                     restReq0.key(params.get("key"));
                     restReq0.value(params.get("val"));

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b963d033/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
index 9bcd419..67f2430 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/JSONCacheObject.java
@@ -32,6 +32,14 @@ public class JSONCacheObject {
 
     }
 
+    public void setFields(Map<Object, Object> fields) {
+        this.fields = fields;
+    }
+
+    public Map<Object, Object> getFields() {
+        return fields;
+    }
+
     public JSONCacheObject(JSONObject o) {
         for (Object key : o.keySet())
             addField(toSimpleObject(key), toSimpleObject(o.get(key)));


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

Posted by iv...@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-964
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(-)
----------------------------------------------------------------------



[35/39] incubator-ignite git commit: #ignite-964: GridJettyRestHandler code style.

Posted by iv...@apache.org.
#ignite-964: GridJettyRestHandler code style.


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

Branch: refs/heads/ignite-964
Commit: 990e5ecee7e78ce0c6f0e3f6a0c5b839f8eb5ff2
Parents: bb412c4
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:46:35 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:46:35 2015 +0300

----------------------------------------------------------------------
 .../http/jetty/GridJettyRestHandler.java        | 95 +++++++++++++-------
 1 file changed, 61 insertions(+), 34 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/990e5ece/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index 55fe156..11059f3 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -315,11 +315,14 @@ public class GridJettyRestHandler extends AbstractHandler {
         }
     }
 
+    /**
+     * @param cmd Rest command.
+     * @param cmdRes Rest response.
+     */
     private void createResponse(GridRestCommand cmd, GridRestResponse cmdRes) {
         if (cmd == CACHE_GET_ALL) {
-            if (cmdRes.getResponse() == null) {
+            if (cmdRes.getResponse() == null)
                 return;
-            }
 
             Map o = (Map)cmdRes.getResponse();
 
@@ -332,37 +335,6 @@ public class GridJettyRestHandler extends AbstractHandler {
         }
     }
 
-    public static class RestEntry {
-        private Object key;
-        private Object value;
-        public RestEntry(Object key, Object value) {
-            if (key instanceof JSONCacheObject)
-                this.key = ((JSONCacheObject)key).getFields();
-            else
-                this.key = key;
-
-            if (value instanceof JSONCacheObject)
-                this.value = ((JSONCacheObject)value).getFields();
-            else
-                this.value = value;
-        }
-        public Object getKey() {
-            return key;
-        }
-
-        public void setKey(Object key) {
-            this.key = key;
-        }
-
-        public Object getValue() {
-            return value;
-        }
-
-        public void setValue(Object value) {
-            this.value = value;
-        }
-    }
-
     /**
      * Creates REST request.
      *
@@ -804,7 +776,7 @@ public class GridJettyRestHandler extends AbstractHandler {
     private JSONObject parseRequest(HttpServletRequest req) throws IgniteCheckedException{
         StringBuilder builder = new StringBuilder();
 
-        Scanner reader = null;
+        Scanner reader;
 
         try {
             reader = new Scanner(req.getReader());
@@ -818,4 +790,59 @@ public class GridJettyRestHandler extends AbstractHandler {
 
         return JSONObject.fromObject(builder.toString());
     }
+
+    /**
+     * Rest entry.
+     */
+    public static class RestEntry {
+        /** Key. */
+        private Object key;
+
+        /** Value. */
+        private Object value;
+
+        /**
+         * @param key Key.
+         * @param val Value.
+         */
+        public RestEntry(Object key, Object val) {
+            if (key instanceof JSONCacheObject)
+                this.key = ((JSONCacheObject)key).getFields();
+            else
+                this.key = key;
+
+            if (val instanceof JSONCacheObject)
+                this.value = ((JSONCacheObject)val).getFields();
+            else
+                this.value = val;
+        }
+
+        /**
+         * @return Key.
+         */
+        public Object getKey() {
+            return key;
+        }
+
+        /**
+         * @param key Key.
+         */
+        public void setKey(Object key) {
+            this.key = key;
+        }
+
+        /**
+         * @return Value.
+         */
+        public Object getValue() {
+            return value;
+        }
+
+        /**
+         * @param val Value.
+         */
+        public void setValue(Object val) {
+            this.value = val;
+        }
+    }
 }


[13/39] incubator-ignite git commit: # ignite-gg-1064 use loopback address in clock server if failed to get local host

Posted by iv...@apache.org.
# ignite-gg-1064 use loopback address in clock server if failed to get local host


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

Branch: refs/heads/ignite-964
Commit: 0ef74a1449d503ae65a200e48da735b545e923da
Parents: b5bc06e
Author: sboikov <sb...@gridgain.com>
Authored: Tue Jun 30 15:07:18 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Tue Jun 30 15:07:18 2015 +0300

----------------------------------------------------------------------
 .../processors/clock/GridClockServer.java       | 21 +++++++++++++++-----
 1 file changed, 16 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0ef74a14/modules/core/src/main/java/org/apache/ignite/internal/processors/clock/GridClockServer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/clock/GridClockServer.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/clock/GridClockServer.java
index e47d1fa..a835da8 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/clock/GridClockServer.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/clock/GridClockServer.java
@@ -62,9 +62,20 @@ public class GridClockServer {
             int startPort = ctx.config().getTimeServerPortBase();
             int endPort = startPort + ctx.config().getTimeServerPortRange() - 1;
 
-            InetAddress locHost = !F.isEmpty(ctx.config().getLocalHost()) ?
-                InetAddress.getByName(ctx.config().getLocalHost()) :
-                U.getLocalHost();
+            InetAddress locHost;
+
+            if (F.isEmpty(ctx.config().getLocalHost())) {
+                try {
+                    locHost = U.getLocalHost();
+                }
+                catch (IOException e) {
+                    locHost = InetAddress.getLoopbackAddress();
+
+                    U.warn(log, "Failed to get local host address, will use loopback address: " + locHost);
+                }
+            }
+            else
+                locHost = InetAddress.getByName(ctx.config().getLocalHost());
 
             for (int p = startPort; p <= endPort; p++) {
                 try {
@@ -83,8 +94,8 @@ public class GridClockServer {
             }
 
             if (sock == null)
-                throw new IgniteCheckedException("Failed to bind time server socket within specified port range [locHost=" +
-                    locHost + ", startPort=" + startPort + ", endPort=" + endPort + ']');
+                throw new IgniteCheckedException("Failed to bind time server socket within specified port range " +
+                    "[locHost=" + locHost + ", startPort=" + startPort + ", endPort=" + endPort + ']');
         }
         catch (IOException e) {
             throw new IgniteCheckedException("Failed to start time server (failed to get local host address)", e);


[30/39] incubator-ignite git commit: #ignite-964: QueryCommandHandler code style.

Posted by iv...@apache.org.
#ignite-964: QueryCommandHandler code style.


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

Branch: refs/heads/ignite-964
Commit: 7e0a63b6408d079b146e7d5b9dc21efd766e803f
Parents: f9a738f
Author: ivasilinets <iv...@gridgain.com>
Authored: Wed Jul 1 12:25:35 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Wed Jul 1 12:25:35 2015 +0300

----------------------------------------------------------------------
 .../handlers/query/QueryCommandHandler.java     | 99 +++++++++-----------
 1 file changed, 43 insertions(+), 56 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e0a63b6/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
index a254115..9432bb7 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
@@ -25,7 +25,6 @@ import org.apache.ignite.internal.processors.rest.request.*;
 import org.apache.ignite.internal.util.future.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
 
-import javax.cache.*;
 import java.util.*;
 import java.util.concurrent.*;
 import java.util.concurrent.atomic.*;
@@ -45,8 +44,7 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
     private static final AtomicLong qryIdGen = new AtomicLong();
 
     /** Current queries. */
-    private final ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs =
-        new ConcurrentHashMap<>();
+    private final ConcurrentHashMap<Long, Iterator> curs = new ConcurrentHashMap<>();
 
     /**
      * @param ctx Context.
@@ -79,7 +77,7 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
                 assert req instanceof RestSqlQueryRequest : "Invalid type of query request.";
 
                 return ctx.closure().callLocalSafe(
-                    new FetchQueryCallable(ctx, (RestSqlQueryRequest)req, curs), false);
+                    new FetchQueryCallable((RestSqlQueryRequest)req, curs), false);
             }
         }
 
@@ -90,9 +88,6 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
      * Execute query callable.
      */
     private static class ExecuteQueryCallable implements Callable<GridRestResponse> {
-        /** */
-        private static final long serialVersionUID = 0L;
-
         /** Kernal context. */
         private GridKernalContext ctx;
 
@@ -100,14 +95,15 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
         private RestSqlQueryRequest req;
 
         /** Queries cursors. */
-        private ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs;
+        private ConcurrentHashMap<Long, Iterator> curs;
 
         /**
          * @param ctx Kernal context.
          * @param req Execute query request.
+         * @param curs Queries cursors.
          */
         public ExecuteQueryCallable(GridKernalContext ctx, RestSqlQueryRequest req,
-            ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs) {
+            ConcurrentHashMap<Long, Iterator> curs) {
             this.ctx = ctx;
             this.req = req;
             this.curs = curs;
@@ -129,31 +125,15 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
                     ((SqlFieldsQuery)qry).setArgs(req.arguments());
                 }
 
-                Iterator<Cache.Entry<Object, Object>> cur =
-                    ctx.grid().cache(req.cacheName()).query(qry).iterator();
+                Iterator cur = ctx.grid().cache(req.cacheName()).query(qry).iterator();
 
                 long qryId = qryIdGen.getAndIncrement();
 
                 curs.put(qryId, cur);
 
-                List res = new ArrayList<>();
-
-                CacheQueryResult response = new CacheQueryResult();
-
-                for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i) {
-                    res.add(cur.next());
-                }
-
-                response.setItems(res);
-
-                response.setLast(!cur.hasNext());
-
-                response.setQueryId(qryId);
-
-                if (!cur.hasNext())
-                    curs.remove(qryId);
+                CacheQueryResult res = createQueryResult(curs, cur, req, qryId);
 
-                return new GridRestResponse(response);
+                return new GridRestResponse(res);
             }
             catch (Exception e) {
                 return new GridRestResponse(GridRestResponse.STATUS_FAILED, e.getMessage());
@@ -165,25 +145,18 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
      * Fetch query callable.
      */
     private static class FetchQueryCallable implements Callable<GridRestResponse> {
-        /** */
-        private static final long serialVersionUID = 0L;
-
-        /** Kernal context. */
-        private GridKernalContext ctx;
-
         /** Execute query request. */
         private RestSqlQueryRequest req;
 
         /** Queries cursors. */
-        private ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs;
+        private ConcurrentHashMap<Long, Iterator> curs;
 
         /**
-         * @param ctx Kernal context.
          * @param req Execute query request.
+         * @param curs Queries cursors.
          */
-        public FetchQueryCallable(GridKernalContext ctx, RestSqlQueryRequest req,
-            ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs) {
-            this.ctx = ctx;
+        public FetchQueryCallable(RestSqlQueryRequest req,
+            ConcurrentHashMap<Long, Iterator> curs) {
             this.req = req;
             this.curs = curs;
         }
@@ -191,29 +164,15 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
         /** {@inheritDoc} */
         @Override public GridRestResponse call() throws Exception {
             try {
-                Iterator<Cache.Entry<Object, Object>> cur = curs.get(req.queryId());
+                Iterator cur = curs.get(req.queryId());
 
                 if (cur == null)
                     return new GridRestResponse(GridRestResponse.STATUS_FAILED,
                         "Cannot find query [qryId=" + req.queryId() + "]");
 
-                List res = new ArrayList<>();
+                CacheQueryResult res = createQueryResult(curs, cur, req, req.queryId());
 
-                CacheQueryResult response = new CacheQueryResult();
-
-                for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i) {
-                    res.add(cur.next());
-                }
-                response.setItems(res);
-
-                response.setLast(!cur.hasNext());
-
-                response.setQueryId(req.queryId());
-
-                if (!cur.hasNext())
-                    curs.remove(req.queryId());
-
-                return new GridRestResponse(response);
+                return new GridRestResponse(res);
             }
             catch (Exception e) {
                 curs.remove(req.queryId());
@@ -222,4 +181,32 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
             }
         }
     }
+
+    /**
+     * @param curs Queries cursors.
+     * @param cur Current cursor.
+     * @param req Sql request.
+     * @param qryId Query id.
+     * @return Query result with items.
+     */
+    private static CacheQueryResult createQueryResult(ConcurrentHashMap<Long, Iterator> curs, Iterator cur,
+        RestSqlQueryRequest req, Long qryId) {
+        CacheQueryResult res = new CacheQueryResult();
+
+        List<Object> items = new ArrayList<>();
+
+        for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i)
+            items.add(cur.next());
+
+        res.setItems(items);
+
+        res.setLast(!cur.hasNext());
+
+        res.setQueryId(qryId);
+
+        if (!cur.hasNext())
+            curs.remove(req.queryId());
+
+        return res;
+    }
 }


[16/39] incubator-ignite git commit: IGNITE-1062 Split in topology snapshot server and client nodes.

Posted by iv...@apache.org.
IGNITE-1062 Split in topology snapshot server and client nodes.


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

Branch: refs/heads/ignite-964
Commit: 8006a84344118f39e9190643420512fbee06bc73
Parents: bade9f1
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Tue Jun 30 16:06:28 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Tue Jun 30 16:06:28 2015 +0300

----------------------------------------------------------------------
 .../discovery/GridDiscoveryManager.java         |  46 +++-
 .../IgniteTopologyPrintFormatSelfTest.java      | 233 +++++++++++++++++++
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 3 files changed, 274 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8006a843/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
index 5e7600f..1d555e4 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/discovery/GridDiscoveryManager.java
@@ -98,6 +98,13 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
         }
     };
 
+    /** Predicate filtering client nodes. */
+    private static final IgnitePredicate<ClusterNode> clientFilter = new P1<ClusterNode>() {
+        @Override public boolean apply(ClusterNode n) {
+            return n.isClient();
+        }
+    };
+
     /** Disco history entries comparator. */
     private static final Comparator<Map.Entry<AffinityTopologyVersion, DiscoCache>> histCmp =
         new Comparator<Map.Entry<AffinityTopologyVersion, DiscoCache>>() {
@@ -933,6 +940,10 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
 
         Collection<ClusterNode> rmtNodes = discoCache.remoteNodes();
 
+        Collection<ClusterNode> serverNodes = discoCache.serverNodes();
+
+        Collection<ClusterNode> clientNodes = discoCache.clientNodes();
+
         ClusterNode locNode = discoCache.localNode();
 
         Collection<ClusterNode> allNodes = discoCache.allNodes();
@@ -949,7 +960,7 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
         double heap = U.heapSize(allNodes, 2);
 
         if (log.isQuiet())
-            U.quiet(false, topologySnapshotMessage(rmtNodes.size(), totalCpus, heap));
+            U.quiet(false, topologySnapshotMessage(serverNodes.size(), clientNodes.size(), totalCpus, heap));
 
         if (log.isDebugEnabled()) {
             String dbg = "";
@@ -959,7 +970,8 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
                 ">>> " + PREFIX + "." + U.nl() +
                 ">>> +----------------+" + U.nl() +
                 ">>> Grid name: " + (ctx.gridName() == null ? "default" : ctx.gridName()) + U.nl() +
-                ">>> Number of nodes: " + (rmtNodes.size() + 1) + U.nl() +
+                ">>> Number of server nodes: " + serverNodes.size() + U.nl() +
+                ">>> Number of client nodes: " + clientNodes.size() + U.nl() +
                 (discoOrdered ? ">>> Topology version: " + topVer + U.nl() : "") +
                 ">>> Topology hash: 0x" + Long.toHexString(hash).toUpperCase() + U.nl();
 
@@ -992,19 +1004,21 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
             log.debug(dbg);
         }
         else if (log.isInfoEnabled())
-            log.info(topologySnapshotMessage(rmtNodes.size(), totalCpus, heap));
+            log.info(topologySnapshotMessage(serverNodes.size(), clientNodes.size(), totalCpus, heap));
     }
 
     /**
-     * @param rmtNodesNum Remote nodes number.
+     * @param serverNodesNum Server nodes number.
+     * @param clientNodesNum Client nodes number.
      * @param totalCpus Total cpu number.
      * @param heap Heap size.
      * @return Topology snapshot message.
      */
-    private String topologySnapshotMessage(int rmtNodesNum, int totalCpus, double heap) {
+    private String topologySnapshotMessage(int serverNodesNum, int clientNodesNum, int totalCpus, double heap) {
         return PREFIX + " [" +
             (discoOrdered ? "ver=" + topSnap.get().topVer.topologyVersion() + ", " : "") +
-            "nodes=" + (rmtNodesNum + 1) +
+            "server nodes=" + serverNodesNum +
+            ", client nodes=" + clientNodesNum +
             ", CPUs=" + totalCpus +
             ", heap=" + heap + "GB" +
             ']';
@@ -2108,6 +2122,12 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
         /** Remote nodes. */
         private final List<ClusterNode> rmtNodes;
 
+        /** Client nodes. */
+        private final List<ClusterNode> clientNodes;
+
+        /** Server nodes. */
+        private final List<ClusterNode> serverNodes;
+
         /** All nodes. */
         private final List<ClusterNode> allNodes;
 
@@ -2196,6 +2216,10 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
 
             all.addAll(rmtNodes);
 
+            clientNodes = Collections.unmodifiableList(new ArrayList<>(F.view(all, clientFilter)));
+
+            serverNodes = Collections.unmodifiableList(new ArrayList<>(F.view(all, F.not(clientFilter))));
+
             Collections.sort(all, GridNodeOrderComparator.INSTANCE);
 
             allNodes = Collections.unmodifiableList(all);
@@ -2346,6 +2370,16 @@ public class GridDiscoveryManager extends GridManagerAdapter<DiscoverySpi> {
             return rmtNodes;
         }
 
+        /** @return Server nodes. */
+        Collection<ClusterNode> serverNodes() {
+            return serverNodes;
+        }
+
+        /** @return Client nodes. */
+        Collection<ClusterNode> clientNodes() {
+            return clientNodes;
+        }
+
         /** @return All nodes. */
         Collection<ClusterNode> allNodes() {
             return allNodes;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8006a843/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
new file mode 100644
index 0000000..efbc431
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/managers/discovery/IgniteTopologyPrintFormatSelfTest.java
@@ -0,0 +1,233 @@
+/*
+ * 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.managers.discovery;
+
+import org.apache.ignite.*;
+import org.apache.ignite.configuration.*;
+import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.managers.*;
+import org.apache.ignite.internal.util.typedef.*;
+import org.apache.ignite.lang.*;
+import org.apache.ignite.spi.discovery.tcp.*;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.*;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.*;
+import org.apache.ignite.testframework.*;
+import org.apache.ignite.testframework.junits.common.*;
+import org.apache.ignite.testframework.junits.logger.*;
+import org.apache.log4j.*;
+
+import java.util.*;
+
+/**
+ *
+ */
+public class IgniteTopologyPrintFormatSelfTest extends GridCommonAbstractTest {
+    /** */
+    public static final String TOPOLOGY_SNAPSHOT = "Topology snapshot";
+
+    /** */
+    public static final String SERV_NODE = ">>> Number of server nodes";
+
+    /** */
+    public static final String CLIENT_NODE = ">>> Number of client nodes";
+
+    /** */
+    private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
+
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        TcpDiscoverySpi disc = new TcpDiscoverySpi();
+        disc.setIpFinder(IP_FINDER);
+
+        cfg.setDiscoverySpi(disc);
+
+        if (gridName.endsWith("client"))
+            cfg.setClientMode(true);
+
+        return cfg;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void beforeTest() throws Exception {
+        stopAllGrids();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void afterTest() throws Exception {
+        stopAllGrids();
+
+        if (log instanceof MockLogger)
+            ((MockLogger)log).clear();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testServerLogs() throws Exception {
+        MockLogger log = new MockLogger();
+
+        log.setLevel(Level.INFO);
+
+        doServerLogTest(log);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testServerDebugLogs() throws Exception {
+        MockLogger log = new MockLogger();
+
+        log.setLevel(Level.DEBUG);
+
+        doServerLogTest(log);
+    }
+
+    /**
+     * @param log Logger.
+     * @throws Exception If failed.
+     */
+    private void doServerLogTest(MockLogger log) throws Exception {
+        try {
+            Ignite server = startGrid("server");
+
+            setLogger(log, server);
+
+            Ignite server1 = startGrid("server1");
+
+            waitForDiscovery(server, server1);
+        }
+        finally {
+            stopAllGrids();
+        }
+
+        assertTrue(F.forAny(log.logs(), new IgnitePredicate<String>() {
+            @Override public boolean apply(String s) {
+                return s.contains("Topology snapshot [ver=2, server nodes=2, client nodes=0,")
+                    || (s.contains(">>> Number of server nodes: 2") && s.contains(">>> Number of client nodes: 0"));
+            }
+        }));
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testServerAndClientLogs() throws Exception {
+        MockLogger log = new MockLogger();
+
+        log.setLevel(Level.INFO);
+
+        doServerAndClientTest(log);
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testServerAndClientDebugLogs() throws Exception {
+        MockLogger log = new MockLogger();
+
+        log.setLevel(Level.DEBUG);
+
+        doServerAndClientTest(log);
+    }
+
+    /**
+     * @param log Log.
+     * @throws Exception If failed.
+     */
+    private void doServerAndClientTest(MockLogger log) throws Exception {
+        try {
+            Ignite server = startGrid("server");
+
+            setLogger(log, server);
+
+            Ignite server1 = startGrid("server1");
+            Ignite client1 = startGrid("first client");
+            Ignite client2 = startGrid("second client");
+
+            waitForDiscovery(server, server1, client1, client2);
+        }
+        finally {
+            stopAllGrids();
+        }
+
+        assertTrue(F.forAny(log.logs(), new IgnitePredicate<String>() {
+            @Override public boolean apply(String s) {
+                return s.contains("Topology snapshot [ver=4, server nodes=2, client nodes=2,")
+                    || (s.contains(">>> Number of server nodes: 2") && s.contains(">>> Number of client nodes: 2"));
+            }
+        }));
+    }
+
+    /**
+     * Set log.
+     *
+     * @param log Log.
+     * @param server Ignite.
+     */
+    private void setLogger(MockLogger log, Ignite server) {
+        IgniteKernal server0 = (IgniteKernal)server;
+
+        GridDiscoveryManager discovery = server0.context().discovery();
+
+        GridTestUtils.setFieldValue(discovery, GridManagerAdapter.class, "log", log);
+    }
+
+    /**
+     *
+     */
+    private static class MockLogger extends GridTestLog4jLogger {
+        /** */
+        private List<String> logs = new ArrayList<>();
+
+        /**  {@inheritDoc} */
+        @Override public void debug(String msg) {
+            if ((msg != null && !msg.isEmpty()) && (
+                msg.contains(TOPOLOGY_SNAPSHOT)
+                    || msg.contains(SERV_NODE)
+                    || msg.contains(CLIENT_NODE)))
+                logs.add(msg);
+
+            super.debug(msg);
+        }
+
+        /** {@inheritDoc} */
+        @Override public void info(String msg) {
+            if ((msg != null && !msg.isEmpty()) && (
+                msg.contains(TOPOLOGY_SNAPSHOT)
+                || msg.contains(SERV_NODE)
+                || msg.contains(CLIENT_NODE)))
+                logs.add(msg);
+
+            super.info(msg);
+        }
+
+        /**
+         * @return Logs.
+         */
+        public List<String> logs() {
+            return logs;
+        }
+
+        /** */
+        public void clear() {
+            logs.clear();
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8006a843/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 e8c89ec..575f1fa 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
@@ -83,6 +83,7 @@ public class IgniteKernalSelfTestSuite extends TestSuite {
         suite.addTestSuite(GridKernalConcurrentAccessStopSelfTest.class);
         suite.addTestSuite(GridUpdateNotifierSelfTest.class);
         suite.addTestSuite(GridLocalEventListenerSelfTest.class);
+        suite.addTestSuite(IgniteTopologyPrintFormatSelfTest.class);
 
         // Managed Services.
         suite.addTestSuite(GridServiceProcessorSingleNodeSelfTest.class);


[05/39] incubator-ignite git commit: #ignite-964: post put all.

Posted by iv...@apache.org.
#ignite-964: post put all.


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

Branch: refs/heads/ignite-964
Commit: 2c1ecf283773c992a8fdaec62de583abd56a340d
Parents: 02b5387
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 00:36:13 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 00:36:13 2015 +0300

----------------------------------------------------------------------
 .../processors/rest/GridRestCommand.java        |  3 ++
 .../handlers/cache/GridCacheCommandHandler.java |  2 ++
 modules/nodejs/src/main/js/cache.js             | 13 ++++++++
 modules/nodejs/src/main/js/server.js            |  9 +++++-
 .../ignite/internal/NodeJsCacheApiSelfTest.java |  7 ++++
 modules/nodejs/src/test/js/test-cache-api.js    |  8 +++++
 .../http/jetty/GridJettyRestHandler.java        | 34 ++++++++++++++++++++
 7 files changed, 75 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
index 0afefb6..375a079 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
@@ -45,6 +45,9 @@ public enum GridRestCommand {
     /** Store several values in cache. */
     CACHE_PUT_ALL("putall"),
 
+    /** Store several values in cache. */
+    CACHE_PUT_ALL2("putall2"),
+
     /** Remove value from cache. */
     CACHE_REMOVE("rmv"),
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
index 1f24023..ef0391e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
@@ -58,6 +58,7 @@ public class GridCacheCommandHandler extends GridRestCommandHandlerAdapter {
         CACHE_PUT,
         CACHE_ADD,
         CACHE_PUT_ALL,
+        CACHE_PUT_ALL2,
         CACHE_REMOVE,
         CACHE_REMOVE_ALL,
         CACHE_REPLACE,
@@ -190,6 +191,7 @@ public class GridCacheCommandHandler extends GridRestCommandHandlerAdapter {
                     break;
                 }
 
+                case CACHE_PUT_ALL2:
                 case CACHE_PUT_ALL: {
                     Map<Object, Object> map = req0.values();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index fc988da..9f72589 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -108,6 +108,19 @@ Cache.prototype.putAll = function(map, callback) {
 }
 
 /**
+ * Put keys to cache
+ *
+ * @this {Cache}
+ * @param {Object.<string, string>} map collection of entries to put in the cache
+ * @param {noValue} callback Called on finish
+ */
+Cache.prototype.postPutAll = function(map, callback) {
+    var params = [this._cacheNameParam];
+
+    this._server.runCommand("putall2", params, callback, JSON.stringify(map));
+}
+
+/**
  * Callback for cache get
  *
  * @callback Cache~onGetAll

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/nodejs/src/main/js/server.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/server.js b/modules/nodejs/src/main/js/server.js
index 81462a4..b3586e3 100644
--- a/modules/nodejs/src/main/js/server.js
+++ b/modules/nodejs/src/main/js/server.js
@@ -61,7 +61,7 @@ Server.prototype.host = function() {
  * @param params Parameters for command.
  * @param {onGet} Called on finish
  */
-Server.prototype.runCommand = function(cmdName, params, callback) {
+Server.prototype.runCommand = function(cmdName, params, callback, postData) {
     var paramsString = "";
 
     for (var p of params) {
@@ -75,10 +75,14 @@ Server.prototype.runCommand = function(cmdName, params, callback) {
     var options = {
         host: this._host,
         port: this._port,
+        method : postData ? "POST" : "GET",
         path: "/ignite?" + requestQry,
         headers: this._signature()
     };
 
+    if (postData)
+        options.headers['Content-Length'] = postData.length;
+
     function streamCallback(response) {
         var fullResponseString = '';
 
@@ -125,6 +129,9 @@ Server.prototype.runCommand = function(cmdName, params, callback) {
 
     request.on('error', callback);
 
+    if (postData)
+        request.write(postData);
+
     request.end();
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
index f17ca60..a6c6140 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
@@ -84,4 +84,11 @@ public class NodeJsCacheApiSelfTest extends NodeJsAbstractTest {
     public void testPutAllGetAll() throws Exception {
         runJsScript("testPutAllGetAll");
     }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testPostPutAllGetAll() throws Exception {
+        runJsScript("testPostPutAllGetAll");
+    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/nodejs/src/test/js/test-cache-api.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-cache-api.js b/modules/nodejs/src/test/js/test-cache-api.js
index 335f888..90ccbb6 100644
--- a/modules/nodejs/src/test/js/test-cache-api.js
+++ b/modules/nodejs/src/test/js/test-cache-api.js
@@ -35,6 +35,10 @@ testPutAllGetAll = function() {
     startTest("mycache", {trace: [putAll, getAll], entry: {"key1": "val1", "key2" : "val2"}});
 }
 
+testPostPutAllGetAll = function() {
+    startTest("mycache", {trace: [postPutAll, getAll], entry: {"key1": "val1", "key2" : "val2"}});
+}
+
 testRemoveAll = function() {
     startTest("mycache", {trace: [putAll, getAll, removeAll, getNone], entry: {"key1": "val1", "key2" : "val2"}});
 }
@@ -93,6 +97,10 @@ function putAll(cache, entries, next) {
     cache.putAll(entries, next);
 }
 
+function postPutAll(cache, entries, next) {
+    cache.postPutAll(entries, next);
+}
+
 function getAll(cache, entries, next) {
     cache.getAll(Object.keys(entries), onGetAll);
     var expected = entries;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ecf28/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index 8d88adf..7e650d3 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -341,6 +341,40 @@ public class GridJettyRestHandler extends AbstractHandler {
                 break;
             }
 
+            case CACHE_PUT_ALL2: {
+                StringBuilder builder = new StringBuilder();
+
+                Scanner reader = null;
+
+                try {
+                    reader = new Scanner(req.getReader());
+                } catch (IOException e) {
+                    throw new IgniteCheckedException(e);
+                }
+
+                while (reader.hasNext())
+                    builder.append(reader.next() + "\n");
+
+                JSONObject o = JSONObject.fromObject(builder.toString());
+
+                GridRestCacheRequest restReq0 = new GridRestCacheRequest();
+
+                String cacheName = (String) params.get("cacheName");
+
+                restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
+
+                Map<Object, Object> map = U.newHashMap(o.keySet().size());
+
+                for (Object k : o.keySet())
+                    map.put(k, o.get(k));
+
+                restReq0.values(map);
+
+                restReq = restReq0;
+
+                break;
+            }
+
             case CACHE_GET:
             case CACHE_GET_ALL:
             case CACHE_PUT:


[14/39] incubator-ignite git commit: #ignite-964: wip

Posted by iv...@apache.org.
#ignite-964: wip


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

Branch: refs/heads/ignite-964
Commit: 3f86e4b46dc445623b71bb90e37c9672ce41022f
Parents: 0643798
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 15:30:56 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 15:30:56 2015 +0300

----------------------------------------------------------------------
 .../handlers/query/QueryCommandHandler.java     | 23 ++---
 modules/nodejs/src/main/js/cache.js             |  9 +-
 modules/nodejs/src/main/js/server.js            | 12 +--
 .../ignite/internal/NodeJsSqlQuerySelfTest.java | 96 ++++++++------------
 modules/nodejs/src/test/js/test-query.js        | 24 +++--
 .../http/jetty/GridJettyRestHandler.java        | 23 ++++-
 6 files changed, 97 insertions(+), 90 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3f86e4b4/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
index a9f7b0f..a254115 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/query/QueryCommandHandler.java
@@ -45,7 +45,7 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
     private static final AtomicLong qryIdGen = new AtomicLong();
 
     /** Current queries. */
-    private final ConcurrentHashMap<Long, Iterator<Cache.Entry<String, String>>> curs =
+    private final ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs =
         new ConcurrentHashMap<>();
 
     /**
@@ -100,14 +100,14 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
         private RestSqlQueryRequest req;
 
         /** Queries cursors. */
-        private ConcurrentHashMap<Long, Iterator<Cache.Entry<String, String>>> curs;
+        private ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs;
 
         /**
          * @param ctx Kernal context.
          * @param req Execute query request.
          */
         public ExecuteQueryCallable(GridKernalContext ctx, RestSqlQueryRequest req,
-            ConcurrentHashMap<Long, Iterator<Cache.Entry<String, String>>> curs) {
+            ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs) {
             this.ctx = ctx;
             this.req = req;
             this.curs = curs;
@@ -129,7 +129,7 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
                     ((SqlFieldsQuery)qry).setArgs(req.arguments());
                 }
 
-                Iterator<Cache.Entry<String, String>> cur =
+                Iterator<Cache.Entry<Object, Object>> cur =
                     ctx.grid().cache(req.cacheName()).query(qry).iterator();
 
                 long qryId = qryIdGen.getAndIncrement();
@@ -140,8 +140,9 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
 
                 CacheQueryResult response = new CacheQueryResult();
 
-                for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i)
+                for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i) {
                     res.add(cur.next());
+                }
 
                 response.setItems(res);
 
@@ -174,14 +175,14 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
         private RestSqlQueryRequest req;
 
         /** Queries cursors. */
-        private ConcurrentHashMap<Long, Iterator<Cache.Entry<String, String>>> curs;
+        private ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs;
 
         /**
          * @param ctx Kernal context.
          * @param req Execute query request.
          */
         public FetchQueryCallable(GridKernalContext ctx, RestSqlQueryRequest req,
-            ConcurrentHashMap<Long, Iterator<Cache.Entry<String, String>>> curs) {
+            ConcurrentHashMap<Long, Iterator<Cache.Entry<Object, Object>>> curs) {
             this.ctx = ctx;
             this.req = req;
             this.curs = curs;
@@ -190,19 +191,19 @@ public class QueryCommandHandler extends GridRestCommandHandlerAdapter {
         /** {@inheritDoc} */
         @Override public GridRestResponse call() throws Exception {
             try {
-                Iterator<Cache.Entry<String, String>> cur = curs.get(req.queryId());
+                Iterator<Cache.Entry<Object, Object>> cur = curs.get(req.queryId());
 
                 if (cur == null)
                     return new GridRestResponse(GridRestResponse.STATUS_FAILED,
                         "Cannot find query [qryId=" + req.queryId() + "]");
 
-                List<Cache.Entry<String, String>> res = new ArrayList<>();
+                List res = new ArrayList<>();
 
                 CacheQueryResult response = new CacheQueryResult();
 
-                for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i)
+                for (int i = 0; i < req.pageSize() && cur.hasNext(); ++i) {
                     res.add(cur.next());
-
+                }
                 response.setItems(res);
 
                 response.setLast(!cur.hasNext());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3f86e4b4/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index 0e08c82..8ff6ee3 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -129,7 +129,9 @@ Cache.prototype.query = function(qry) {
         }
         else {
             var command = this._createCommand("qryfetch");
+
             command.addParam("qryId", res.queryId).addParam("psz", qry.pageSize());
+
             this._server.runCommand(command, onQueryExecute.bind(this, qry));
         }
     }
@@ -144,7 +146,8 @@ Cache.prototype.query = function(qry) {
 
 Cache.prototype._sqlFieldsQuery = function(qry, onQueryExecute) {
     var command = this._createQueryCommand("qryfieldsexecute", qry);
-    command.addParams("arg", qry.arguments());
+
+    command.setPostData(JSON.stringify({"arg" : qry.arguments()}));
 
     this._server.runCommand(command, onQueryExecute.bind(this, qry));
 }
@@ -158,9 +161,11 @@ Cache.prototype._sqlQuery = function(qry, onQueryExecute) {
     }
 
     var command = this._createQueryCommand("qryexecute", qry);
-    command.addParams("arg", qry.arguments());
+
     command.addParam("type", qry.returnType());
 
+    command.setPostData(JSON.stringify({"arg" : qry.arguments()}));
+
     this._server.runCommand(command, onQueryExecute.bind(this, qry));
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3f86e4b4/modules/nodejs/src/main/js/server.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/server.js b/modules/nodejs/src/main/js/server.js
index 3cb98c1..e49ed83 100644
--- a/modules/nodejs/src/main/js/server.js
+++ b/modules/nodejs/src/main/js/server.js
@@ -67,22 +67,17 @@ Server.prototype.runCommand = function(cmd, callback) {
 
     var http = require('http');
 
-    var commHeaders = this._signature();
-
-    if (cmd._isPost()) {
-        commHeaders["JSONObject"] = "true";
-    }
-
     var options = {
         host: this._host,
         port: this._port,
         method : cmd._method(),
         path: "/ignite?" + requestQry,
-        headers: commHeaders
+        headers: this._signature()
     };
 
     if (cmd._isPost()) {
         options.headers['Content-Length'] = cmd.postData().length;
+        options.headers['JSONObject'] = "true";
     }
 
     function streamCallback(response) {
@@ -134,6 +129,7 @@ Server.prototype.runCommand = function(cmd, callback) {
     if (cmd._isPost()) {
         request.write(cmd.postData());
     }
+
     request.end();
 }
 
@@ -155,7 +151,7 @@ Server.prototype.checkConnection = function(callback) {
  */
 Server.prototype._signature = function() {
     if (!this._secretKey) {
-        return {};
+        return "";
     }
 
     var loadTimeInMS = Date.now();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3f86e4b4/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
index 97d9852..8d33668 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsSqlQuerySelfTest.java
@@ -75,45 +75,30 @@ public class NodeJsSqlQuerySelfTest extends NodeJsAbstractTest {
      * Init cache.
      */
     private void initCache() {
-        CacheConfiguration<UUID, Organization> orgCacheCfg = new CacheConfiguration<>("organization");
-        orgCacheCfg.setIndexedTypes(UUID.class, Organization.class);
+        CacheConfiguration<UUID, Person> personCacheCfg = new CacheConfiguration<>("person");
+        personCacheCfg.setIndexedTypes(UUID.class, Person.class);
 
-        CacheConfiguration<AffinityKey<UUID>, Person> personCacheCfg = new CacheConfiguration<>("person");
-        personCacheCfg.setIndexedTypes(AffinityKey.class, Person.class);
+        IgniteCache<UUID, Person> personCache = grid(0).getOrCreateCache(personCacheCfg);
 
-        IgniteCache<UUID, Organization> orgCache = grid(0).getOrCreateCache(orgCacheCfg);
+        Person p1 = new Person("John", "Doe", 2000);
+        Person p2 = new Person("Jane", "Doe", 1000);
+        Person p3 = new Person("John", "Smith", 1000);
+        Person p4 = new Person("Jane", "Smith", 2000);
 
-        Organization org1 = new Organization("ApacheIgnite");
-        Organization org2 = new Organization("Other");
-
-        orgCache.put(org1.id, org1);
-        orgCache.put(org2.id, org2);
-
-        IgniteCache<AffinityKey<UUID>, Person> personCache = grid(0).getOrCreateCache(personCacheCfg);
-
-        Person p1 = new Person(org1, "John", "Doe", 2000);
-        Person p2 = new Person(org1, "Jane", "Doe", 1000);
-        Person p3 = new Person(org2, "John", "Smith", 1000);
-        Person p4 = new Person(org2, "Jane", "Smith", 2000);
-
-        personCache.put(p1.key(), p1);
-        personCache.put(p2.key(), p2);
-        personCache.put(p3.key(), p3);
-        personCache.put(p4.key(), p4);
+        personCache.put(p4.getId(), p1);
+        personCache.put(p4.getId(), p2);
+        personCache.put(p4.getId(), p3);
+        personCache.put(p4.getId(), p4);
     }
 
     /**
      * Person class.
      */
-    private static class Person implements Serializable {
+    public static class Person implements Serializable {
         /** Person ID (indexed). */
         @QuerySqlField(index = true)
         private UUID id;
 
-        /** Organization ID (indexed). */
-        @QuerySqlField(index = true)
-        private UUID orgId;
-
         /** First name (not-indexed). */
         @QuerySqlField
         private String firstName;
@@ -126,55 +111,50 @@ public class NodeJsSqlQuerySelfTest extends NodeJsAbstractTest {
         @QuerySqlField(index = true)
         private double salary;
 
-        /** Custom cache key to guarantee that person is always collocated with its organization. */
-        private transient AffinityKey<UUID> key;
-
         /**
-         * @param org Organization.
          * @param firstName First name.
          * @param lastName Last name.
          * @param salary Salary.
          */
-        Person(Organization org, String firstName, String lastName, double salary) {
+        Person( String firstName, String lastName, double salary) {
             id = UUID.randomUUID();
 
-            orgId = org.id;
-
             this.firstName = firstName;
             this.lastName = lastName;
             this.salary = salary;
         }
 
-        /**
-         * @return Custom affinity key to guarantee that person is always collocated with organization.
-         */
-        public AffinityKey<UUID> key() {
-            if (key == null)
-                key = new AffinityKey<>(id, orgId);
+        public void setFirstName(String firstName) {
+            this.firstName = firstName;
+        }
 
-            return key;
+        public String getFirstName() {
+            return firstName;
         }
-    }
 
-    /**
-     * Organization class.
-     */
-    private static class Organization implements Serializable {
-        /** Organization ID (indexed). */
-        @QuerySqlField(index = true)
-        private UUID id;
+        public void setLastName(String lastName) {
+            this.lastName = lastName;
+        }
 
-        /** Organization name (indexed). */
-        @QuerySqlField(index = true)
-        private String name;
+        public String getLastName() {
+            return lastName;
+        }
 
-        /**
-         * @param name Organization name.
-         */
-        Organization(String name) {
-            id = UUID.randomUUID();
+        public void setId(UUID id) {
+            this.id = id;
+        }
+
+        public void setSalary(double salary) {
+            this.salary = salary;
+        }
+
+        public double getSalary() {
+
+            return salary;
+        }
 
-            this.name = name;
+        public UUID getId() {
+            return id;
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3f86e4b4/modules/nodejs/src/test/js/test-query.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-query.js b/modules/nodejs/src/test/js/test-query.js
index 77bbad1..c407816 100644
--- a/modules/nodejs/src/test/js/test-query.js
+++ b/modules/nodejs/src/test/js/test-query.js
@@ -110,24 +110,28 @@ testSqlQueryWithParams = function() {
         var fullRes = [];
 
         qry.on("page", function(res) {
+            console.log("!!!!!Page:" + res);
+            console.log("!!!!!Page2:" + res);
+
             fullRes = fullRes.concat(res);
         });
 
         qry.on("end", function(err) {
-                assert(err === null, "Error on query [err=" + err + "].");
+            console.log("RES:" + fullRes);
 
-                //TODO:
-                assert(fullRes.length, 1, "Result length is not correct" +
-                    "[expected=1, val = " + fullRes.length + "]");
+            assert(err === null, "Error on query [err=" + err + "].");
 
-                assert(fullRes[0].indexOf("Jane Doe") > -1,
-                    "Result does not contain Jane Doe [res=" + fullRes[0] + "]");
+            //TODO:
+            assert(fullRes.length, 2, "Result length is not correct" +
+                "[expected=1, val = " + fullRes.length + "]");
+
+            assert(fullRes[0].indexOf("Jane Doe") > -1,
+                "Result does not contain Jane Doe [res=" + fullRes[0] + "]");
 
-                TestUtils.testDone();
-            });
+            TestUtils.testDone();
+        });
 
         ignite.cache("person").query(qry);
     }
 
-    TestUtils.startIgniteNode(sqlFieldsQuery.bind(null));
-}
+    TestUtils.startIgniteN
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3f86e4b4/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index 0af9bf7..e37f422 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -506,9 +506,30 @@ public class GridJettyRestHandler extends AbstractHandler {
                 RestSqlQueryRequest restReq0 = new RestSqlQueryRequest();
 
                 restReq0.sqlQuery((String)params.get("qry"));
-                List<Object> args = values("arg", params);
+
+                StringBuilder builder = new StringBuilder();
+
+                Scanner reader = null;
+
+                try {
+                    reader = new Scanner(req.getReader());
+                }
+                catch (IOException e) {
+                    throw new IgniteCheckedException(e);
+                }
+
+                while (reader.hasNext())
+                    builder.append(reader.next() + "\n");
+
+                JSONObject o = JSONObject.fromObject(builder.toString());
+                System.out.println("ARGUMENTS " + o.get("arg"));
+
+                List<Object> args = (List<Object>)o.get("arg");
+
                 restReq0.arguments(args.toArray());
+
                 restReq0.typeName((String)params.get("type"));
+
                 restReq0.pageSize(Integer.parseInt((String) params.get("psz")));
                 restReq0.cacheName((String)params.get("cacheName"));
 


[25/39] incubator-ignite git commit: # ignite-sprint-7 minor

Posted by iv...@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-964
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'");
             }
         }
 


[11/39] incubator-ignite git commit: #ignite-964: remove postPutAll

Posted by iv...@apache.org.
#ignite-964: remove postPutAll


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

Branch: refs/heads/ignite-964
Commit: 2bf2b69e4f18eacd79072c762a9d4a14bfca11ae
Parents: 913a5d4
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 14:40:38 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 14:40:38 2015 +0300

----------------------------------------------------------------------
 .../processors/rest/GridRestCommand.java        |   3 -
 .../handlers/cache/GridCacheCommandHandler.java |   2 -
 modules/nodejs/src/main/js/cache.js             |   2 +-
 modules/nodejs/src/main/js/server.js            |  10 +-
 .../http/jetty/GridJettyRestHandler.java        | 108 +++++++++----------
 5 files changed, 61 insertions(+), 64 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2bf2b69e/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
index 375a079..0afefb6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/GridRestCommand.java
@@ -45,9 +45,6 @@ public enum GridRestCommand {
     /** Store several values in cache. */
     CACHE_PUT_ALL("putall"),
 
-    /** Store several values in cache. */
-    CACHE_PUT_ALL2("putall2"),
-
     /** Remove value from cache. */
     CACHE_REMOVE("rmv"),
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2bf2b69e/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
index ef0391e..1f24023 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandler.java
@@ -58,7 +58,6 @@ public class GridCacheCommandHandler extends GridRestCommandHandlerAdapter {
         CACHE_PUT,
         CACHE_ADD,
         CACHE_PUT_ALL,
-        CACHE_PUT_ALL2,
         CACHE_REMOVE,
         CACHE_REMOVE_ALL,
         CACHE_REPLACE,
@@ -191,7 +190,6 @@ public class GridCacheCommandHandler extends GridRestCommandHandlerAdapter {
                     break;
                 }
 
-                case CACHE_PUT_ALL2:
                 case CACHE_PUT_ALL: {
                     Map<Object, Object> map = req0.values();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2bf2b69e/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index 4333389..b19367c 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -106,7 +106,7 @@ Cache.prototype.putAll = function(map, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.postPutAll = function(map, callback) {
-    this._server.runCommand(this._createCommand("putall2").setPostData(JSON.stringify(map)), callback);
+    this._server.runCommand(this._createCommand("putall").setPostData(JSON.stringify(map)), callback);
 }
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2bf2b69e/modules/nodejs/src/main/js/server.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/server.js b/modules/nodejs/src/main/js/server.js
index 2714ae5..3cb98c1 100644
--- a/modules/nodejs/src/main/js/server.js
+++ b/modules/nodejs/src/main/js/server.js
@@ -67,12 +67,18 @@ Server.prototype.runCommand = function(cmd, callback) {
 
     var http = require('http');
 
+    var commHeaders = this._signature();
+
+    if (cmd._isPost()) {
+        commHeaders["JSONObject"] = "true";
+    }
+
     var options = {
         host: this._host,
         port: this._port,
         method : cmd._method(),
         path: "/ignite?" + requestQry,
-        headers: this._signature()
+        headers: commHeaders
     };
 
     if (cmd._isPost()) {
@@ -149,7 +155,7 @@ Server.prototype.checkConnection = function(callback) {
  */
 Server.prototype._signature = function() {
     if (!this._secretKey) {
-        return "";
+        return {};
     }
 
     var loadTimeInMS = Date.now();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2bf2b69e/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
----------------------------------------------------------------------
diff --git a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
index 7e650d3..0af9bf7 100644
--- a/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
+++ b/modules/rest-http/src/main/java/org/apache/ignite/internal/processors/rest/protocols/http/jetty/GridJettyRestHandler.java
@@ -323,8 +323,7 @@ public class GridJettyRestHandler extends AbstractHandler {
      * @throws IgniteCheckedException If creation failed.
      */
     @Nullable private GridRestRequest createRequest(GridRestCommand cmd,
-        Map<String, Object> params,
-        ServletRequest req) throws IgniteCheckedException {
+        Map<String, Object> params, HttpServletRequest req) throws IgniteCheckedException {
         GridRestRequest restReq;
 
         switch (cmd) {
@@ -341,40 +340,6 @@ public class GridJettyRestHandler extends AbstractHandler {
                 break;
             }
 
-            case CACHE_PUT_ALL2: {
-                StringBuilder builder = new StringBuilder();
-
-                Scanner reader = null;
-
-                try {
-                    reader = new Scanner(req.getReader());
-                } catch (IOException e) {
-                    throw new IgniteCheckedException(e);
-                }
-
-                while (reader.hasNext())
-                    builder.append(reader.next() + "\n");
-
-                JSONObject o = JSONObject.fromObject(builder.toString());
-
-                GridRestCacheRequest restReq0 = new GridRestCacheRequest();
-
-                String cacheName = (String) params.get("cacheName");
-
-                restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
-
-                Map<Object, Object> map = U.newHashMap(o.keySet().size());
-
-                for (Object k : o.keySet())
-                    map.put(k, o.get(k));
-
-                restReq0.values(map);
-
-                restReq = restReq0;
-
-                break;
-            }
-
             case CACHE_GET:
             case CACHE_GET_ALL:
             case CACHE_PUT:
@@ -391,35 +356,66 @@ public class GridJettyRestHandler extends AbstractHandler {
 
                 String cacheName = (String)params.get("cacheName");
 
-                restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
-                restReq0.key(params.get("key"));
-                restReq0.value(params.get("val"));
-                restReq0.value2(params.get("val2"));
+                if (req.getHeader("JSONObject") != null) {
+                    if (cmd == CACHE_PUT_ALL) {
+                        StringBuilder builder = new StringBuilder();
+
+                        Scanner reader = null;
+
+                        try {
+                            reader = new Scanner(req.getReader());
+                        }
+                        catch (IOException e) {
+                            throw new IgniteCheckedException(e);
+                        }
+
+                        while (reader.hasNext())
+                            builder.append(reader.next() + "\n");
+
+                        JSONObject o = JSONObject.fromObject(builder.toString());
+
+                        restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
+
+                        Map<Object, Object> map = U.newHashMap(o.keySet().size());
+
+                        for (Object k : o.keySet())
+                            map.put(k, o.get(k));
+
+                        restReq0.values(map);
+                    }
+                }
+                else {
+
+                    restReq0.cacheName(F.isEmpty(cacheName) ? null : cacheName);
+                    restReq0.key(params.get("key"));
+                    restReq0.value(params.get("val"));
+                    restReq0.value2(params.get("val2"));
 
-                Object val1 = params.get("val1");
+                    Object val1 = params.get("val1");
 
-                if (val1 != null)
-                    restReq0.value(val1);
+                    if (val1 != null)
+                        restReq0.value(val1);
 
-                restReq0.cacheFlags(intValue("cacheFlags", params, 0));
-                restReq0.ttl(longValue("exp", params, null));
+                    restReq0.cacheFlags(intValue("cacheFlags", params, 0));
+                    restReq0.ttl(longValue("exp", params, null));
 
-                if (cmd == CACHE_GET_ALL || cmd == CACHE_PUT_ALL || cmd == CACHE_REMOVE_ALL) {
-                    List<Object> keys = values("k", params);
-                    List<Object> vals = values("v", params);
+                    if (cmd == CACHE_GET_ALL || cmd == CACHE_PUT_ALL || cmd == CACHE_REMOVE_ALL) {
+                        List<Object> keys = values("k", params);
+                        List<Object> vals = values("v", params);
 
-                    if (keys.size() < vals.size())
-                        throw new IgniteCheckedException("Number of keys must be greater or equals to number of values.");
+                        if (keys.size() < vals.size())
+                            throw new IgniteCheckedException("Number of keys must be greater or equals to number of values.");
 
-                    Map<Object, Object> map = U.newHashMap(keys.size());
+                        Map<Object, Object> map = U.newHashMap(keys.size());
 
-                    Iterator<Object> keyIt = keys.iterator();
-                    Iterator<Object> valIt = vals.iterator();
+                        Iterator<Object> keyIt = keys.iterator();
+                        Iterator<Object> valIt = vals.iterator();
 
-                    while (keyIt.hasNext())
-                        map.put(keyIt.next(), valIt.hasNext() ? valIt.next() : null);
+                        while (keyIt.hasNext())
+                            map.put(keyIt.next(), valIt.hasNext() ? valIt.next() : null);
 
-                    restReq0.values(map);
+                        restReq0.values(map);
+                    }
                 }
 
                 restReq = restReq0;


[12/39] incubator-ignite git commit: #ignite-964: remove postPutAll

Posted by iv...@apache.org.
#ignite-964: remove postPutAll


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

Branch: refs/heads/ignite-964
Commit: 0643798e85545812677320fbde629dcfd75b5700
Parents: 2bf2b69
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 14:42:37 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 14:42:37 2015 +0300

----------------------------------------------------------------------
 modules/nodejs/src/main/js/cache.js              | 19 -------------------
 .../ignite/internal/NodeJsCacheApiSelfTest.java  |  7 -------
 modules/nodejs/src/test/js/test-cache-api.js     |  4 ----
 3 files changed, 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0643798e/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/main/js/cache.js b/modules/nodejs/src/main/js/cache.js
index b19367c..0e08c82 100644
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@ -87,25 +87,6 @@ Cache.prototype.removeAll = function(keys, callback) {
  * @param {noValue} callback Called on finish
  */
 Cache.prototype.putAll = function(map, callback) {
-    var keys = Object.keys(map);
-
-    var values = [];
-
-    for (var key of keys) {
-        values.push(map[key]);
-    }
-
-    this._server.runCommand(this._createCommand("putall").addParams("k", keys).addParams("v", values), callback);
-}
-
-/**
- * Put keys to cache
- *
- * @this {Cache}
- * @param {Object.<string, string>} map collection of entries to put in the cache
- * @param {noValue} callback Called on finish
- */
-Cache.prototype.postPutAll = function(map, callback) {
     this._server.runCommand(this._createCommand("putall").setPostData(JSON.stringify(map)), callback);
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0643798e/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
index a6c6140..f17ca60 100644
--- a/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
+++ b/modules/nodejs/src/test/java/org/apache/ignite/internal/NodeJsCacheApiSelfTest.java
@@ -84,11 +84,4 @@ public class NodeJsCacheApiSelfTest extends NodeJsAbstractTest {
     public void testPutAllGetAll() throws Exception {
         runJsScript("testPutAllGetAll");
     }
-
-    /**
-     * @throws Exception If failed.
-     */
-    public void testPostPutAllGetAll() throws Exception {
-        runJsScript("testPostPutAllGetAll");
-    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0643798e/modules/nodejs/src/test/js/test-cache-api.js
----------------------------------------------------------------------
diff --git a/modules/nodejs/src/test/js/test-cache-api.js b/modules/nodejs/src/test/js/test-cache-api.js
index 90ccbb6..fc29f22 100644
--- a/modules/nodejs/src/test/js/test-cache-api.js
+++ b/modules/nodejs/src/test/js/test-cache-api.js
@@ -35,10 +35,6 @@ testPutAllGetAll = function() {
     startTest("mycache", {trace: [putAll, getAll], entry: {"key1": "val1", "key2" : "val2"}});
 }
 
-testPostPutAllGetAll = function() {
-    startTest("mycache", {trace: [postPutAll, getAll], entry: {"key1": "val1", "key2" : "val2"}});
-}
-
 testRemoveAll = function() {
     startTest("mycache", {trace: [putAll, getAll, removeAll, getNone], entry: {"key1": "val1", "key2" : "val2"}});
 }


[10/39] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-964' into ignite-964-1

Posted by iv...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-964' into ignite-964-1


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

Branch: refs/heads/ignite-964
Commit: 913a5d46693644557eb4697bb35862466014d70e
Parents: d218dfb 576c435
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jun 30 14:26:07 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jun 30 14:26:07 2015 +0300

----------------------------------------------------------------------
 .../handlers/query/QueryCommandHandler.java     |  8 +--
 .../rest/request/RestSqlQueryRequest.java       | 10 ++--
 modules/nodejs/src/main/js/cache.js             |  9 +---
 modules/nodejs/src/main/js/sql-fields-query.js  | 23 ++------
 modules/nodejs/src/test/js/test-query.js        | 55 +++++++++-----------
 5 files changed, 43 insertions(+), 62 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/913a5d46/modules/nodejs/src/main/js/cache.js
----------------------------------------------------------------------
diff --cc modules/nodejs/src/main/js/cache.js
index 1ece92d,8f074e3..4333389
--- a/modules/nodejs/src/main/js/cache.js
+++ b/modules/nodejs/src/main/js/cache.js
@@@ -149,12 -146,14 +144,12 @@@ Cache.prototype.query = function(qry) 
          qry.page(res["items"]);
  
          if (res["last"]) {
-             qry.end();
+             qry.end(null);
          }
          else {
 -            this._server.runCommand("qryfetch", [
 -                Server.pair("cacheName", this._cacheName),
 -                Server.pair("qryId", res.queryId),
 -                Server.pair("psz", qry.pageSize())],
 -                onQueryExecute.bind(this, qry));
 +            var command = this._createCommand("qryfetch");
 +            command.addParam("qryId", res.queryId).addParam("psz", qry.pageSize());
 +            this._server.runCommand(command, onQueryExecute.bind(this, qry));
          }
      }