You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by yz...@apache.org on 2015/10/29 16:10:52 UTC

[01/12] ignite git commit: Muted test

Repository: ignite
Updated Branches:
  refs/heads/ignite-1.4-slow-server-debug aa3de3864 -> 3adc1576c


Muted test


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 93861f341f8bd138dd89fa80d30f22050f6a25cf
Parents: c39b6d4
Author: ashutak <as...@gridgain.com>
Authored: Wed Oct 28 17:07:48 2015 +0300
Committer: ashutak <as...@gridgain.com>
Committed: Wed Oct 28 17:07:48 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/IgniteCacheCreateRestartSelfTest.java     | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/93861f34/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheCreateRestartSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheCreateRestartSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheCreateRestartSelfTest.java
index e8babf7..e8e66c4 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheCreateRestartSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheCreateRestartSelfTest.java
@@ -71,8 +71,8 @@ public class IgniteCacheCreateRestartSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testStopOriginatingNode() throws Exception {
-        fail("https://issues.apache.org/jira/browse/IGNITE-1797");
-        
+        fail("https://issues.apache.org/jira/browse/IGNITE-1690");
+
         startGrids(NODES);
 
         ThreadLocalRandom rnd = ThreadLocalRandom.current();
@@ -108,4 +108,4 @@ public class IgniteCacheCreateRestartSelfTest extends GridCommonAbstractTest {
             ignite0.destroyCache(CACHE_NAME);
         }
     }
-}
\ No newline at end of file
+}


[08/12] ignite git commit: ignite-1745 GridCacheIoManager should send correct response in case of cache query error

Posted by yz...@apache.org.
ignite-1745 GridCacheIoManager should send correct response in case of cache query error


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 7bedc8aceefb94d1bd87620887a8a44025518abe
Parents: 3ec52f3
Author: agura <ag...@gridgain.com>
Authored: Tue Oct 27 18:22:42 2015 +0300
Committer: agura <ag...@gridgain.com>
Committed: Thu Oct 29 15:36:15 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheIoManager.java    | 28 +++++++++++++++--
 ...niteCacheP2pUnmarshallingQueryErrorTest.java | 32 +++++++++++++++++++-
 2 files changed, 57 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/7bedc8ac/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
index ec34f41..082f330 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheIoManager.java
@@ -53,6 +53,8 @@ import org.apache.ignite.internal.processors.cache.distributed.near.GridNearLock
 import org.apache.ignite.internal.processors.cache.distributed.near.GridNearLockResponse;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxPrepareRequest;
 import org.apache.ignite.internal.processors.cache.distributed.near.GridNearTxPrepareResponse;
+import org.apache.ignite.internal.processors.cache.query.GridCacheQueryRequest;
+import org.apache.ignite.internal.processors.cache.query.GridCacheQueryResponse;
 import org.apache.ignite.internal.util.F0;
 import org.apache.ignite.internal.util.GridLeanSet;
 import org.apache.ignite.internal.util.GridSpinReadWriteLock;
@@ -73,6 +75,9 @@ import static org.apache.ignite.internal.GridTopic.TOPIC_CACHE;
  * Cache communication manager.
  */
 public class GridCacheIoManager extends GridCacheSharedManagerAdapter {
+    /** Communication topic prefix for distributed queries. */
+    private static final String QUERY_TOPIC_PREFIX = "QUERY";
+
     /** Message ID generator. */
     private static final AtomicLong idGen = new AtomicLong();
 
@@ -304,8 +309,8 @@ public class GridCacheIoManager extends GridCacheSharedManagerAdapter {
     /**
      * Processes failed messages.
      *
-     * @param nodeId niode id.
-     * @param msg message.
+     * @param nodeId Node ID.
+     * @param msg Message.
      * @throws IgniteCheckedException If failed.
      */
     private void processFailedMessage(UUID nodeId, GridCacheMessage msg) throws IgniteCheckedException {
@@ -493,6 +498,25 @@ public class GridCacheIoManager extends GridCacheSharedManagerAdapter {
 
             break;
 
+            case 58: {
+                GridCacheQueryRequest req = (GridCacheQueryRequest)msg;
+
+                GridCacheQueryResponse res = new GridCacheQueryResponse(
+                    req.cacheId(),
+                    req.id(),
+                    req.classError(),
+                    cctx.deploymentEnabled());
+
+                cctx.io().sendOrderedMessage(
+                    ctx.node(nodeId),
+                    TOPIC_CACHE.topic(QUERY_TOPIC_PREFIX, nodeId, req.id()),
+                    res,
+                    ctx.ioPolicy(),
+                    Long.MAX_VALUE);
+            }
+
+            break;
+
             default:
                 throw new IgniteCheckedException("Failed to send response to node. Unsupported direct type [message="
                     + msg + "]");

http://git-wip-us.apache.org/repos/asf/ignite/blob/7bedc8ac/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheP2pUnmarshallingQueryErrorTest.java
----------------------------------------------------------------------
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheP2pUnmarshallingQueryErrorTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheP2pUnmarshallingQueryErrorTest.java
index 6a4ba3a..07fa2bc 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheP2pUnmarshallingQueryErrorTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/IgniteCacheP2pUnmarshallingQueryErrorTest.java
@@ -17,9 +17,13 @@
 
 package org.apache.ignite.internal.processors.cache;
 
+import java.io.IOException;
+import java.io.ObjectInputStream;
 import javax.cache.CacheException;
+import org.apache.ignite.cache.query.ScanQuery;
 import org.apache.ignite.cache.query.SqlQuery;
 import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.lang.IgniteBiPredicate;
 
 /**
  * Checks behavior on exception while unmarshalling key.
@@ -47,10 +51,36 @@ public class IgniteCacheP2pUnmarshallingQueryErrorTest extends IgniteCacheP2pUnm
         try {
             jcache(0).query(new SqlQuery<TestKey, String>(String.class, "field like '" + key + "'")).getAll();
 
-            assert false : "p2p marshalling failed, but error response was not sent";
+            fail("p2p marshalling failed, but error response was not sent");
         }
         catch (CacheException e) {
             // No-op
         }
     }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testResponseMessageOnRequestUnmarshallingFailed() throws Exception {
+        readCnt.set(Integer.MAX_VALUE);
+
+        jcache(0).put(new TestKey(String.valueOf(++key)), "");
+
+        try {
+            jcache().query(new ScanQuery<>(new IgniteBiPredicate<TestKey, String>() {
+                @Override public boolean apply(TestKey key, String val) {
+                    return false;
+                }
+
+                private void readObject(ObjectInputStream is) throws IOException {
+                    throw new IOException();
+                }
+            })).getAll();
+
+            fail("Request unmarshalling failed, but error response was not sent.");
+        }
+        catch (Exception e) {
+            // No-op.
+        }
+    }
 }
\ No newline at end of file


[07/12] ignite git commit: Muted test.

Posted by yz...@apache.org.
Muted test.


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 91059ba8422e0caf5df2125e19fa2dd165f1b91a
Parents: 9304dce
Author: ashutak <as...@gridgain.com>
Authored: Thu Oct 29 15:14:55 2015 +0300
Committer: ashutak <as...@gridgain.com>
Committed: Thu Oct 29 15:14:55 2015 +0300

----------------------------------------------------------------------
 .../GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest.java   | 7 ++++++-
 1 file changed, 6 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/91059ba8/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest.java
index f8151f4..c468cc2 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest.java
@@ -65,4 +65,9 @@ public class GridCacheAtomicMultiNodeP2PDisabledFullApiSelfTest
 
         return ccfg;
     }
-}
\ No newline at end of file
+
+    /** {@inheritDoc} */
+    @Override public void testWithSkipStore() throws Exception {
+        fail("https://issues.apache.org/jira/browse/IGNITE-1809");
+    }
+}


[02/12] ignite git commit: Muted test

Posted by yz...@apache.org.
Muted test


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 9fb79622bd24bf99532f7064c73a8ebd82a497df
Parents: 93861f3
Author: ashutak <as...@gridgain.com>
Authored: Wed Oct 28 17:35:06 2015 +0300
Committer: ashutak <as...@gridgain.com>
Committed: Wed Oct 28 17:35:06 2015 +0300

----------------------------------------------------------------------
 .../datastructures/IgniteCountDownLatchAbstractSelfTest.java     | 4 +++-
 1 file changed, 3 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/9fb79622/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteCountDownLatchAbstractSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteCountDownLatchAbstractSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteCountDownLatchAbstractSelfTest.java
index 58cbfa1..2f6f6f4 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteCountDownLatchAbstractSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteCountDownLatchAbstractSelfTest.java
@@ -283,6 +283,8 @@ public abstract class IgniteCountDownLatchAbstractSelfTest extends IgniteAtomics
      * @throws Exception If failed.
      */
     public void testLatchMultinode1() throws Exception {
+        fail("https://issues.apache.org/jira/browse/IGNITE-1802");
+
         if (gridCount() == 1)
             return;
 
@@ -389,4 +391,4 @@ public abstract class IgniteCountDownLatchAbstractSelfTest extends IgniteAtomics
     @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
         // No-op.
     }
-}
\ No newline at end of file
+}


[10/12] ignite git commit: ignite-1717: NPE during running ScalarCreditRiskExample with portableMarshaller

Posted by yz...@apache.org.
ignite-1717: NPE during running ScalarCreditRiskExample with portableMarshaller


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 15da54b9e392791818c5419068e0761d7a78f613
Parents: 48de059
Author: Andrey Gura <ag...@gridgain.com>
Authored: Thu Oct 29 16:15:07 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Thu Oct 29 16:15:07 2015 +0300

----------------------------------------------------------------------
 .../internal/portable/PortableWriterExImpl.java | 66 +++++++++++---------
 1 file changed, 35 insertions(+), 31 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/15da54b9/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableWriterExImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableWriterExImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableWriterExImpl.java
index 1d5ca60..a43ebc3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableWriterExImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableWriterExImpl.java
@@ -77,7 +77,7 @@ import static org.apache.ignite.internal.portable.GridPortableMarshaller.UNREGIS
 import static org.apache.ignite.internal.portable.GridPortableMarshaller.UUID;
 import static org.apache.ignite.internal.portable.GridPortableMarshaller.UUID_ARR;
 
- /**
+/**
  * Portable writer implementation.
  */
 public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx, ObjectOutput {
@@ -187,6 +187,16 @@ public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx
      * @throws PortableException In case of error.
      */
     void marshal(Object obj, boolean detached) throws PortableException {
+        marshal(obj, detached, true);
+    }
+
+    /**
+     * @param obj Object.
+     * @param detached Detached or not.
+     * @param enableReplace Object replacing enabled flag.
+     * @throws PortableException In case of error.
+     */
+    void marshal(Object obj, boolean detached, boolean enableReplace) throws PortableException {
         assert obj != null;
 
         cls = obj.getClass();
@@ -218,11 +228,11 @@ public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx
             return;
         }
 
-        if (desc.getWriteReplaceMethod() != null) {
-            Object replace;
+        if (enableReplace && desc.getWriteReplaceMethod() != null) {
+            Object replacedObj;
 
             try {
-                replace = desc.getWriteReplaceMethod().invoke(obj);
+                replacedObj = desc.getWriteReplaceMethod().invoke(obj);
             }
             catch (IllegalAccessException e) {
                 throw new RuntimeException(e);
@@ -234,21 +244,14 @@ public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx
                 throw new PortableException("Failed to execute writeReplace() method on " + obj, e);
             }
 
-            if (replace == null) {
+            if (replacedObj == null) {
                 doWriteByte(NULL);
                 return;
             }
 
-            if (cls != replace.getClass()) {
-                cls = replace.getClass();
-
-                desc = ctx.descriptorForClass(cls);
-
-                if (desc == null)
-                    throw new PortableException("Object is not portable: [class=" + cls + ']');
-            }
+            marshal(replacedObj, detached, false);
 
-            obj = replace;
+            return;
         }
 
         typeId = desc.typeId();
@@ -301,7 +304,7 @@ public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx
         wCtx.out.position(pos);
     }
 
-     /**
+    /**
      * @param bytes Number of bytes to reserve.
      * @return Offset.
      */
@@ -1740,7 +1743,7 @@ public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx
         return reserve(LEN_INT);
     }
 
-     /** {@inheritDoc} */
+    /** {@inheritDoc} */
     @Override public void writeInt(int pos, int val) throws PortableException {
         wCtx.out.writeInt(pos, val);
     }
@@ -1764,27 +1767,28 @@ public class PortableWriterExImpl implements PortableWriter, PortableRawWriterEx
         doWriteInt(id);
     }
 
-     /**
-      * Attempts to write the object as a handle.
-      *
-      * @param obj Object to write.
-      * @return {@code true} if the object has been written as a handle.
-      */
-     boolean tryWriteAsHandle(Object obj) {
-         int handle = handle(obj);
+    /**
+     * Attempts to write the object as a handle.
+     *
+     * @param obj Object to write.
+     * @return {@code true} if the object has been written as a handle.
+     */
+    boolean tryWriteAsHandle(Object obj) {
+        int handle = handle(obj);
 
-         if (handle >= 0) {
-             doWriteByte(GridPortableMarshaller.HANDLE);
-             doWriteInt(handle);
+        if (handle >= 0) {
+            doWriteByte(GridPortableMarshaller.HANDLE);
+            doWriteInt(handle);
 
-             return true;
-         }
+            return true;
+        }
 
-         return false;
-     }
+        return false;
+    }
 
     /**
      * Create new writer with same context.
+     *
      * @param typeId type
      * @return New writer.
      */


[06/12] ignite git commit: Muted test.

Posted by yz...@apache.org.
Muted test.


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 9304dce257104c4a599a58b1ecb58acab80db6c1
Parents: d24bf49
Author: ashutak <as...@gridgain.com>
Authored: Thu Oct 29 14:31:44 2015 +0300
Committer: ashutak <as...@gridgain.com>
Committed: Thu Oct 29 14:31:44 2015 +0300

----------------------------------------------------------------------
 .../GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest.java   | 7 ++++++-
 1 file changed, 6 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/9304dce2/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest.java
index 7a8cc49..e9251b6 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest.java
@@ -27,4 +27,9 @@ public class GridCacheAtomicNearEnabledMultiNodeFullApiSelfTest extends GridCach
     @Override protected NearCacheConfiguration nearConfiguration() {
         return new NearCacheConfiguration();
     }
-}
\ No newline at end of file
+
+    /** {@inheritDoc} */
+    @Override public void testIgniteCacheIterator() throws Exception {
+        fail("https://issues.apache.org/jira/browse/IGNITE-1756");
+    }
+}


[12/12] ignite git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-1.4-slow-server-debug

Posted by yz...@apache.org.
Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-1.4-slow-server-debug


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 3adc1576cb5f3e205b6c7551fba2f6e9857e2212
Parents: 88e8e8a 15da54b
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Thu Oct 29 18:10:17 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Thu Oct 29 18:10:17 2015 +0300

----------------------------------------------------------------------
 .../internal/portable/PortableWriterExImpl.java | 66 +++++++++++---------
 .../processors/cache/GridCacheIoManager.java    | 28 ++++++++-
 .../cache/CrossCacheTxRandomOperationsTest.java |  2 +
 .../cache/IgniteCacheCreateRestartSelfTest.java |  6 +-
 .../IgniteCountDownLatchAbstractSelfTest.java   |  4 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |  5 +-
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |  7 ++-
 ...omicNearEnabledMultiNodeFullApiSelfTest.java |  7 ++-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java | 32 +++++++++-
 9 files changed, 116 insertions(+), 41 deletions(-)
----------------------------------------------------------------------



[11/12] ignite git commit: imports

Posted by yz...@apache.org.
imports


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 88e8e8aff6bd1f48243e17a3c5c915a64973f80e
Parents: aa3de38
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Thu Oct 29 18:09:21 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Thu Oct 29 18:09:21 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java | 1 -
 1 file changed, 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/88e8e8af/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
index 4cd9e84..7f9edb2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
@@ -53,7 +53,6 @@ import org.apache.ignite.internal.processors.cache.GridCacheConcurrentMap;
 import org.apache.ignite.internal.processors.cache.GridCacheContext;
 import org.apache.ignite.internal.processors.cache.GridCacheEntryEx;
 import org.apache.ignite.internal.processors.cache.GridCacheEntryRemovedException;
-import org.apache.ignite.internal.processors.cache.GridCacheFilterFailedException;
 import org.apache.ignite.internal.processors.cache.GridCacheMapEntry;
 import org.apache.ignite.internal.processors.cache.GridCacheMapEntryFactory;
 import org.apache.ignite.internal.processors.cache.GridCacheOperation;


[03/12] ignite git commit: Muted test

Posted by yz...@apache.org.
Muted test


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: c122dcbda44a72b3899155d0c050eab6f43e473c
Parents: 9fb7962
Author: ashutak <as...@gridgain.com>
Authored: Wed Oct 28 18:24:39 2015 +0300
Committer: ashutak <as...@gridgain.com>
Committed: Wed Oct 28 18:24:39 2015 +0300

----------------------------------------------------------------------
 .../GridCachePartitionedQueueCreateMultiNodeSelfTest.java       | 5 ++++-
 1 file changed, 4 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/c122dcbd/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
index 2146fc1..5a722db 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/partitioned/GridCachePartitionedQueueCreateMultiNodeSelfTest.java
@@ -36,6 +36,7 @@ import org.apache.ignite.testframework.GridTestUtils;
 import org.apache.ignite.transactions.Transaction;
 
 import static java.util.concurrent.TimeUnit.MILLISECONDS;
+
 import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
 import static org.apache.ignite.cache.CacheMemoryMode.ONHEAP_TIERED;
 import static org.apache.ignite.cache.CacheMode.PARTITIONED;
@@ -168,6 +169,8 @@ public class GridCachePartitionedQueueCreateMultiNodeSelfTest extends IgniteColl
      * @throws Exception If failed.
      */
     public void testTx() throws Exception {
+        fail("https://issues.apache.org/jira/browse/IGNITE-1804");
+
         if (cacheConfiguration().getAtomicityMode() != TRANSACTIONAL)
             return;
 
@@ -230,4 +233,4 @@ public class GridCachePartitionedQueueCreateMultiNodeSelfTest extends IgniteColl
 
         fut.get();
     }
-}
\ No newline at end of file
+}


[09/12] ignite git commit: Merge branch 'ignite-1745'

Posted by yz...@apache.org.
Merge branch 'ignite-1745'


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 48de05989c858e8776a0947761486eed950bd8ce
Parents: 91059ba 7bedc8a
Author: agura <ag...@gridgain.com>
Authored: Thu Oct 29 15:36:59 2015 +0300
Committer: agura <ag...@gridgain.com>
Committed: Thu Oct 29 15:36:59 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheIoManager.java    | 28 +++++++++++++++--
 ...niteCacheP2pUnmarshallingQueryErrorTest.java | 32 +++++++++++++++++++-
 2 files changed, 57 insertions(+), 3 deletions(-)
----------------------------------------------------------------------



[05/12] ignite git commit: Merge remote-tracking branch 'apache/master'

Posted by yz...@apache.org.
Merge remote-tracking branch 'apache/master'


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: d24bf49cd87e37b9d16de074ad8c3ceb9024a1dd
Parents: c122dcb 303def3
Author: ashutak <as...@gridgain.com>
Authored: Thu Oct 29 14:24:07 2015 +0300
Committer: ashutak <as...@gridgain.com>
Committed: Thu Oct 29 14:24:07 2015 +0300

----------------------------------------------------------------------
 .../cache/affinity/fair/FairAffinityDynamicCacheSelfTest.java      | 2 ++
 .../processors/cache/CacheSerializableTransactionsTest.java        | 2 ++
 .../processors/cache/CrossCacheTxRandomOperationsTest.java         | 2 ++
 3 files changed, 6 insertions(+)
----------------------------------------------------------------------



[04/12] ignite git commit: Disabled hanging test (IGNITE-647).

Posted by yz...@apache.org.
Disabled hanging test (IGNITE-647).


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

Branch: refs/heads/ignite-1.4-slow-server-debug
Commit: 303def3595bce137d80c5859bf4615eece69433a
Parents: 215b0cd
Author: sboikov <sb...@gridgain.com>
Authored: Thu Oct 29 09:24:07 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Thu Oct 29 09:24:07 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/CrossCacheTxRandomOperationsTest.java         | 2 ++
 1 file changed, 2 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/303def35/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CrossCacheTxRandomOperationsTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CrossCacheTxRandomOperationsTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CrossCacheTxRandomOperationsTest.java
index 2577d93..d88f12f 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CrossCacheTxRandomOperationsTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/CrossCacheTxRandomOperationsTest.java
@@ -126,6 +126,8 @@ public class CrossCacheTxRandomOperationsTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testCrossCacheTxOperationsFairAffinity() throws Exception {
+        fail("https://issues.apache.org/jira/browse/IGNITE-647");
+
         txOperations(PARTITIONED, FULL_SYNC, true, true);
     }