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

[01/12] ignite git commit: IGNITE-1346: Field rename.

Repository: ignite
Updated Branches:
  refs/heads/ignite-1273 f9a2edeac -> ea591c9a8


IGNITE-1346: Field rename.


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

Branch: refs/heads/ignite-1273
Commit: 34ce97b685de9097303ee68d380b7a3d9b43348a
Parents: aec0631
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Tue Sep 1 16:40:35 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Tue Sep 1 16:40:35 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/util/GridStripedSpinBusyLock.java     | 10 +++++-----
 1 file changed, 5 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/34ce97b6/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java b/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
index 678d521..614a88f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
@@ -31,16 +31,16 @@ public class GridStripedSpinBusyLock {
     /** Default amount of stripes. */
     private static final int DFLT_STRIPE_CNT = Runtime.getRuntime().availableProcessors() * 4;
 
-    /** States; they are not subjects to false-sharing because actual values are located far from each other. */
-    private final AtomicInteger[] states;
-
     /** Thread index. */
-    private static ThreadLocal<Integer> threadIdx = new ThreadLocal<Integer>() {
+    private static ThreadLocal<Integer> THREAD_IDX = new ThreadLocal<Integer>() {
         @Override protected Integer initialValue() {
             return new Random().nextInt(Integer.MAX_VALUE);
         }
     };
 
+    /** States; they are not subjects to false-sharing because actual values are located far from each other. */
+    private final AtomicInteger[] states;
+
     /**
      * Default constructor.
      */
@@ -120,6 +120,6 @@ public class GridStripedSpinBusyLock {
      * @return State.
      */
     private AtomicInteger state() {
-        return states[threadIdx.get() % states.length];
+        return states[THREAD_IDX.get() % states.length];
     }
 }


[08/12] ignite git commit: ignite-1273: removed metadata registration to avoid hangs

Posted by sb...@apache.org.
ignite-1273: removed metadata registration to avoid hangs


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

Branch: refs/heads/ignite-1273
Commit: 7e805fb1aceba753bd707564ee1d006ce8308876
Parents: 5222559
Author: Denis Magda <dm...@gridgain.com>
Authored: Wed Sep 2 08:28:59 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Wed Sep 2 08:28:59 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/internal/portable/PortableContext.java | 3 ---
 1 file changed, 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/7e805fb1/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableContext.java b/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableContext.java
index 8cf3e65..db7e41e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/portable/PortableContext.java
@@ -549,9 +549,6 @@ public class PortableContext implements Externalizable {
         userTypes.put(typeId, desc);
         descByCls.put(cls, desc);
 
-        if (isMetaDataEnabled(typeId))
-            metaHnd.addMeta(typeId, new PortableMetaDataImpl(typeName, desc.fieldsMeta(), null));
-
         return desc;
     }
 


[10/12] ignite git commit: Minor fix in test.

Posted by sb...@apache.org.
Minor fix in test.


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

Branch: refs/heads/ignite-1273
Commit: fdcd47b42e801deca9624ae0d79ff74a6259d404
Parents: 4ab1b47
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Wed Sep 2 11:22:16 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Wed Sep 2 11:22:16 2015 +0300

----------------------------------------------------------------------
 .../igfs/IgfsProcessorValidationSelfTest.java   | 26 +++++---------------
 1 file changed, 6 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/fdcd47b4/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorValidationSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorValidationSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorValidationSelfTest.java
index 6efcf9d..11a80af 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorValidationSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/igfs/IgfsProcessorValidationSelfTest.java
@@ -17,11 +17,6 @@
 
 package org.apache.ignite.internal.processors.igfs;
 
-import java.lang.reflect.Array;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.Collections;
 import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.configuration.CacheConfiguration;
@@ -35,8 +30,13 @@ import org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder;
 
+import java.lang.reflect.Array;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Collection;
+import java.util.Collections;
+
 import static org.apache.ignite.cache.CacheAtomicityMode.TRANSACTIONAL;
-import static org.apache.ignite.cache.CacheMode.PARTITIONED;
 import static org.apache.ignite.igfs.IgfsMode.DUAL_ASYNC;
 import static org.apache.ignite.igfs.IgfsMode.DUAL_SYNC;
 import static org.apache.ignite.igfs.IgfsMode.PROXY;
@@ -253,20 +253,6 @@ public class IgfsProcessorValidationSelfTest extends IgfsCommonAbstractTest {
     /**
      * @throws Exception If failed.
      */
-    public void testLocalIfBackupsEnabled() throws Exception {
-        g1Cfg.setCacheConfiguration(concat(dataCaches(1024), metaCaches(), CacheConfiguration.class));
-
-        for (CacheConfiguration cc : g1Cfg.getCacheConfiguration()) {
-            cc.setCacheMode(PARTITIONED);
-            cc.setBackups(1);
-        }
-
-        checkGridStartFails(g1Cfg, "IGFS data cache cannot be used with backups", true);
-    }
-
-    /**
-     * @throws Exception If failed.
-     */
     public void testLocalIfNonPrimaryModeAndHadoopFileSystemUriIsNull() throws Exception {
         g1Cfg.setCacheConfiguration(concat(dataCaches(1024), metaCaches(), CacheConfiguration.class));
 


[04/12] ignite git commit: Added tests.

Posted by sb...@apache.org.
Added tests.


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

Branch: refs/heads/ignite-1273
Commit: 88a907c08a00e60a8585806bb81acbe8c25ce2b3
Parents: 9b06cf3
Author: sboikov <sb...@gridgain.com>
Authored: Tue Sep 1 17:37:42 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Tue Sep 1 17:37:42 2015 +0300

----------------------------------------------------------------------
 .../CachePutAllFailoverAbstractTest.java        | 234 +++++++++++++++++++
 .../distributed/CachePutAllFailoverTxTest.java  |  30 +++
 2 files changed, 264 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/88a907c0/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverAbstractTest.java
new file mode 100644
index 0000000..ea81680
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverAbstractTest.java
@@ -0,0 +1,234 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.cache.distributed;
+
+import org.apache.ignite.IgniteCache;
+import org.apache.ignite.cache.CacheMode;
+import org.apache.ignite.configuration.CacheConfiguration;
+import org.apache.ignite.configuration.NearCacheConfiguration;
+import org.apache.ignite.internal.IgniteInternalFuture;
+import org.apache.ignite.internal.processors.cache.GridCacheAbstractSelfTest;
+import org.apache.ignite.internal.util.typedef.internal.S;
+import org.apache.ignite.internal.util.typedef.internal.U;
+import org.apache.ignite.testframework.GridTestUtils;
+import org.jetbrains.annotations.NotNull;
+
+import java.io.Serializable;
+import java.util.TreeMap;
+import java.util.concurrent.Callable;
+import java.util.concurrent.ThreadLocalRandom;
+import java.util.concurrent.atomic.AtomicBoolean;
+
+import static org.apache.ignite.cache.CacheMode.PARTITIONED;
+
+/**
+ *
+ */
+public abstract class CachePutAllFailoverAbstractTest extends GridCacheAbstractSelfTest {
+    /** */
+    private static final int NODE_CNT = 2;
+
+    /** */
+    private static final long TEST_TIME = 2 * 60_000;
+
+    /** {@inheritDoc} */
+    @Override protected int gridCount() {
+        return NODE_CNT;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected long getTestTimeout() {
+        return TEST_TIME + 60_000;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected CacheMode cacheMode() {
+        return PARTITIONED;
+    }
+
+    /** {@inheritDoc} */
+    @SuppressWarnings("unchecked")
+    @Override protected CacheConfiguration cacheConfiguration(String gridName) throws Exception {
+        CacheConfiguration ccfg = super.cacheConfiguration(gridName);
+
+        ccfg.setCacheStoreFactory(null);
+        ccfg.setReadThrough(false);
+        ccfg.setWriteThrough(false);
+
+        return ccfg;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected NearCacheConfiguration nearConfiguration() {
+        return null;
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testPutAllFailover() throws Exception {
+        final AtomicBoolean finished = new AtomicBoolean();
+
+        final long endTime = System.currentTimeMillis() + TEST_TIME;
+
+        IgniteInternalFuture<Object> restartFut = GridTestUtils.runAsync(new Callable<Object>() {
+            @Override public Object call() throws Exception {
+                Thread.currentThread().setName("restart-thread");
+
+                while (!finished.get() && System.currentTimeMillis() < endTime) {
+                    startGrid(NODE_CNT);
+
+                    U.sleep(500);
+
+                    stopGrid(NODE_CNT);
+                }
+
+                return null;
+            }
+        });
+
+        try {
+            final IgniteCache<TestKey, TestValue> cache = ignite(0).cache(null);
+
+            GridTestUtils.runMultiThreaded(new Callable<Object>() {
+                @Override public Object call() throws Exception {
+                    int iter = 0;
+
+                    ThreadLocalRandom rnd = ThreadLocalRandom.current();
+
+                    long time;
+
+                    long lastInfo = 0;
+
+                    while ((time = System.currentTimeMillis()) < endTime) {
+                        if (time - lastInfo > 5000)
+                            log.info("Do putAll [iter=" + iter + ']');
+
+                        TreeMap<TestKey, TestValue> map = new TreeMap<>();
+
+                        for (int k = 0; k < 100; k++)
+                            map.put(new TestKey(rnd.nextInt(200)), new TestValue(iter));
+
+                        cache.putAll(map);
+
+                        iter++;
+                    }
+
+                    return null;
+                }
+            }, 2, "update-thread");
+
+            finished.set(true);
+
+            restartFut.get();
+        }
+        finally {
+            finished.set(true);
+        }
+    }
+
+    /**
+     *
+     */
+    private static class TestKey implements Serializable, Comparable<TestKey> {
+        /** */
+        private long key;
+
+        /**
+         * @param key Key.
+         */
+        public TestKey(long key) {
+            this.key = key;
+        }
+
+        /**
+         * @return Key.
+         */
+        public long key() {
+            return key;
+        }
+
+        /** {@inheritDoc} */
+        @Override public int compareTo(@NotNull TestKey other) {
+            return ((Long)key).compareTo(other.key);
+        }
+
+        /** {@inheritDoc} */
+        @Override public boolean equals(Object o) {
+            if (this == o)
+                return true;
+
+            if (o == null || getClass() != o.getClass())
+                return false;
+
+            TestKey other = (TestKey)o;
+
+            return key == other.key;
+        }
+
+        /** {@inheritDoc} */
+        @Override public int hashCode() {
+            return (int)(key ^ (key >>> 32));
+        }
+
+        /** {@inheritDoc} */
+        @Override public String toString() {
+            return S.toString(TestKey.class, this);
+        }
+    }
+
+    /**
+     *
+     */
+    private static class TestValue implements Serializable {
+        /** */
+        private long val;
+
+        /**
+         * @param val Value.
+         */
+        public TestValue(long val) {
+            this.val = val;
+        }
+
+        /**
+         * @return Value.
+         */
+        public long value() {
+            return val;
+        }
+
+        /** {@inheritDoc} */
+        @Override public boolean equals(Object o) {
+            if (this == o)
+                return true;
+
+            if (o == null || getClass() != o.getClass())
+                return false;
+
+            TestValue other = (TestValue)o;
+
+            return val == other.val;
+        }
+
+        /** {@inheritDoc} */
+        @Override public String toString() {
+            return S.toString(TestValue.class, this);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/ignite/blob/88a907c0/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverTxTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverTxTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverTxTest.java
new file mode 100644
index 0000000..8a6f933
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/CachePutAllFailoverTxTest.java
@@ -0,0 +1,30 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.cache.distributed;
+
+import org.apache.ignite.cache.CacheAtomicityMode;
+
+/**
+ *
+ */
+public class CachePutAllFailoverTxTest extends CachePutAllFailoverAbstractTest {
+    /** {@inheritDoc} */
+    @Override protected CacheAtomicityMode atomicityMode() {
+        return CacheAtomicityMode.TRANSACTIONAL;
+    }
+}


[12/12] ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-1273' into ignite-1273-main

Posted by sb...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-1273' into ignite-1273-main


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

Branch: refs/heads/ignite-1273
Commit: ea591c9a89967681c88f210e2add00c184300efe
Parents: f9a2ede 4e93f49
Author: Denis Magda <dm...@gridgain.com>
Authored: Wed Sep 2 12:39:16 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Wed Sep 2 12:39:16 2015 +0300

----------------------------------------------------------------------
 .../internal/portable/PortableContext.java      |   3 -
 .../processors/platform/PlatformContext.java    |   4 +-
 .../processors/platform/PlatformException.java  |  71 ++++++
 .../platform/PlatformExtendedException.java     |  57 +++++
 .../platform/PlatformNativeException.java       |  77 ++++++
 .../platform/PlatformNoCallbackException.java   |  50 ++++
 .../internal/util/GridStripedSpinBusyLock.java  |  20 +-
 .../CachePutAllFailoverAbstractTest.java        | 234 +++++++++++++++++++
 .../distributed/CachePutAllFailoverTxTest.java  |  30 +++
 .../igfs/IgfsProcessorValidationSelfTest.java   |  26 +--
 .../platform/PlatformContextImpl.java           |   4 +-
 .../processors/platform/PlatformException.java  |  71 ------
 .../platform/PlatformExtendedException.java     |  39 ----
 .../platform/PlatformNoCallbackException.java   |  50 ----
 .../platform/cache/PlatformCache.java           |   2 +-
 .../PlatformCachePartialUpdateException.java    |  15 +-
 .../platform/compute/PlatformAbstractTask.java  |   1 +
 .../compute/PlatformNativeException.java        |  77 ------
 .../platform/utils/PlatformUtils.java           |   2 +-
 parent/pom.xml                                  |   6 +-
 20 files changed, 547 insertions(+), 292 deletions(-)
----------------------------------------------------------------------



[02/12] ignite git commit: IGNITE-1346: Minor opto.

Posted by sb...@apache.org.
IGNITE-1346: Minor opto.


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

Branch: refs/heads/ignite-1273
Commit: 465348e161b997ff15fa7a30de300d8997133a8c
Parents: 34ce97b
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Tue Sep 1 16:48:40 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Tue Sep 1 16:48:40 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/util/GridStripedSpinBusyLock.java     | 10 ++++++----
 1 file changed, 6 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/465348e1/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java b/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
index 614a88f..a11b0b1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/GridStripedSpinBusyLock.java
@@ -88,18 +88,20 @@ public class GridStripedSpinBusyLock {
      * Block.
      */
     public void block() {
-        boolean interrupt = false;
-
+        // 1. CAS-loop to set a writer bit.
         for (AtomicInteger state : states) {
-            // 1. CAS-loop to set a writer bit.
             while (true) {
                 int oldVal = state.get();
 
                 if (state.compareAndSet(oldVal, oldVal | WRITER_MASK))
                     break;
             }
+        }
 
-            // 2. Wait until all readers are out.
+        // 2. Wait until all readers are out.
+        boolean interrupt = false;
+
+        for (AtomicInteger state : states) {
             while (state.get() != WRITER_MASK) {
                 try {
                     Thread.sleep(10);


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

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


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

Branch: refs/heads/ignite-1273
Commit: 6731627eb505455c65be9fc2ef4f39a4ca20cec3
Parents: 88a907c 66504a0
Author: sboikov <sb...@gridgain.com>
Authored: Tue Sep 1 17:38:09 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Tue Sep 1 17:38:09 2015 +0300

----------------------------------------------------------------------
 .../processors/platform/PlatformContext.java    |   4 +-
 .../processors/platform/PlatformException.java  |  71 +++++++++++
 .../platform/PlatformExtendedException.java     |  57 +++++++++
 .../platform/PlatformNativeException.java       |  77 +++++++++++
 .../platform/PlatformNoCallbackException.java   |  50 ++++++++
 .../callback/PlatformCallbackGateway.java       |  10 +-
 .../internal/util/GridStripedSpinBusyLock.java  | 127 +++++++++++++++++++
 .../platform/PlatformContextImpl.java           |   4 +-
 .../processors/platform/PlatformException.java  |  71 -----------
 .../platform/PlatformExtendedException.java     |  39 ------
 .../platform/PlatformNoCallbackException.java   |  50 --------
 .../platform/cache/PlatformCache.java           |   2 +-
 .../PlatformCachePartialUpdateException.java    |  15 +--
 .../platform/compute/PlatformAbstractTask.java  |   1 +
 .../compute/PlatformNativeException.java        |  77 -----------
 .../platform/utils/PlatformUtils.java           |   2 +-
 16 files changed, 394 insertions(+), 263 deletions(-)
----------------------------------------------------------------------



[07/12] ignite git commit: Merge remote-tracking branch 'remotes/apache-git/master' into ignite-1273

Posted by sb...@apache.org.
Merge remote-tracking branch 'remotes/apache-git/master' into ignite-1273


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

Branch: refs/heads/ignite-1273
Commit: 52225590a1824e1b78382c38591aa6f46217a756
Parents: 8e8d59c 5a948dc
Author: Denis Magda <dm...@gridgain.com>
Authored: Wed Sep 2 08:28:25 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Wed Sep 2 08:28:25 2015 +0300

----------------------------------------------------------------------
 modules/core/pom.xml                            |    6 +-
 .../internal/GridEventConsumeHandler.java       |   15 +-
 .../managers/communication/GridIoManager.java   |   50 +-
 .../GridLifecycleAwareMessageFilter.java        |   38 -
 .../eventstorage/GridEventStorageManager.java   |   16 +-
 .../processors/cache/GridCacheAdapter.java      |    5 +-
 .../cache/GridLoadCacheCloseablePredicate.java  |   30 -
 .../distributed/dht/GridDhtCacheAdapter.java    |    6 +-
 .../CacheQueryCloseableScanBiPredicate.java     |   30 -
 .../cache/query/GridCacheQueryManager.java      |   52 +-
 .../CacheContinuousQueryFilterEx.java           |   31 -
 .../continuous/CacheContinuousQueryHandler.java |    5 +-
 .../platform/PlatformAwareEventFilter.java      |   39 -
 .../processors/platform/PlatformContext.java    |   37 +-
 .../platform/PlatformEventFilterListener.java   |   39 +
 .../processors/platform/PlatformException.java  |   71 +
 .../platform/PlatformExtendedException.java     |   57 +
 .../platform/PlatformLocalEventListener.java    |   28 -
 .../platform/PlatformNativeException.java       |   77 +
 .../platform/PlatformNoCallbackException.java   |   50 +
 .../cache/PlatformCacheEntryFilter.java         |   11 +-
 .../cache/PlatformCacheEntryProcessor.java      |   27 +
 .../cache/query/PlatformContinuousQuery.java    |    6 +-
 .../query/PlatformContinuousQueryFilter.java    |   30 +
 .../callback/PlatformCallbackGateway.java       |   10 +-
 .../cluster/PlatformClusterNodeFilter.java      |   28 +
 .../datastreamer/PlatformStreamReceiver.java    |   27 +
 .../platform/message/PlatformMessageFilter.java |   40 +
 .../internal/util/GridStripedSpinBusyLock.java  |  127 +
 .../CachePutAllFailoverAbstractTest.java        |  234 ++
 .../distributed/CachePutAllFailoverTxTest.java  |   30 +
 .../platform/src/main/cpp/common/Makefile.am    |   45 +
 .../platform/src/main/cpp/common/configure.ac   |   62 +
 .../src/main/cpp/common/ignite-common.pc.in     |    9 +
 .../src/main/cpp/common/include/Makefile.am     |   22 +
 .../common/include/ignite/common/concurrent.h   |  210 ++
 .../cpp/common/include/ignite/common/exports.h  |  145 ++
 .../cpp/common/include/ignite/common/java.h     |  652 ++++++
 .../cpp/common/os/linux/include/Makefile.am     |   21 +
 .../os/linux/include/ignite/common/common.h     |   81 +
 .../linux/include/ignite/common/concurrent_os.h |  394 ++++
 .../src/main/cpp/common/os/linux/src/common.cpp |   59 +
 .../cpp/common/os/linux/src/concurrent_os.cpp   |  175 ++
 .../os/win/include/ignite/common/common.h       |   56 +
 .../win/include/ignite/common/concurrent_os.h   |  406 ++++
 .../src/main/cpp/common/os/win/src/common.cpp   |   65 +
 .../cpp/common/os/win/src/concurrent_os.cpp     |  151 ++
 .../src/main/cpp/common/project/README.TXT      |    1 +
 .../src/main/cpp/common/project/vs/README.TXT   |    1 +
 .../main/cpp/common/project/vs/common.vcxproj   |  202 ++
 .../common/project/vs/common.vcxproj.filters    |   54 +
 .../src/main/cpp/common/project/vs/module.def   |   99 +
 .../src/main/cpp/common/project/vs/targetver.h  |   25 +
 .../src/main/cpp/common/src/concurrent.cpp      |   94 +
 .../src/main/cpp/common/src/exports.cpp         |  413 ++++
 .../platform/src/main/cpp/common/src/java.cpp   | 2204 ++++++++++++++++++
 .../platform/PlatformAbstractTarget.java        |   34 +-
 .../platform/PlatformContextImpl.java           |  621 +++++
 .../processors/platform/PlatformException.java  |   71 -
 .../platform/PlatformExtendedException.java     |   39 -
 .../platform/PlatformNoCallbackException.java   |   50 -
 .../platform/cache/PlatformCache.java           |   44 +-
 .../cache/PlatformCacheEntryFilterImpl.java     |    5 +-
 .../cache/PlatformCacheEntryProcessor.java      |  220 --
 .../cache/PlatformCacheEntryProcessorImpl.java  |  220 ++
 .../PlatformCachePartialUpdateException.java    |   24 +-
 .../PlatformContinuousQueryRemoteFilter.java    |   20 +-
 .../cluster/PlatformClusterNodeFilter.java      |   79 -
 .../cluster/PlatformClusterNodeFilterImpl.java  |   78 +
 .../platform/compute/PlatformAbstractTask.java  |    1 +
 .../compute/PlatformNativeException.java        |   77 -
 .../datastreamer/PlatformDataStreamer.java      |    2 +-
 .../datastreamer/PlatformStreamReceiver.java    |  120 -
 .../PlatformStreamReceiverImpl.java             |  119 +
 .../platform/events/PlatformEventFilter.java    |  164 --
 .../events/PlatformEventFilterListenerImpl.java |  163 ++
 .../platform/events/PlatformEvents.java         |   15 +-
 .../messaging/PlatformMessageFilter.java        |  110 -
 .../messaging/PlatformMessageFilterImpl.java    |  110 +
 .../messaging/PlatformMessageLocalFilter.java   |    9 +-
 .../platform/messaging/PlatformMessaging.java   |    7 +-
 .../transactions/PlatformTransactions.java      |    2 +-
 .../platform/utils/PlatformFutureUtils.java     |   82 +-
 .../platform/utils/PlatformUtils.java           |    2 +-
 parent/pom.xml                                  |   10 +
 85 files changed, 8067 insertions(+), 1329 deletions(-)
----------------------------------------------------------------------



[06/12] ignite git commit: Exclude test archives and project files from RAT

Posted by sb...@apache.org.
Exclude test archives and project files from RAT


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

Branch: refs/heads/ignite-1273
Commit: 5a948dcb6b6697746bf9780ad0e673bef336480a
Parents: 6731627
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Tue Sep 1 17:53:06 2015 -0700
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Tue Sep 1 17:53:06 2015 -0700

----------------------------------------------------------------------
 parent/pom.xml | 4 ++++
 1 file changed, 4 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/5a948dcb/parent/pom.xml
----------------------------------------------------------------------
diff --git a/parent/pom.xml b/parent/pom.xml
index 3556671..472d4ff 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -738,6 +738,10 @@
                                         <exclude>src/main/dotnet/Apache.Ignite.sln</exclude>
                                         <exclude>src/main/dotnet/Apache.Ignite.sln.DotSettings</exclude>
                                         <exclude>src/test/dotnet/Apache.Ignite.Core.Tests/Apache.Ignite.Core.Tests.csproj</exclude>
+                                        <exclude>src/test/portables/repo/org/apache/ignite/portable/test1/1.1/test1-1.1.jar</exclude>
+                                        <exclude>src/test/portables/repo/org/apache/ignite/portable/test2/1.1/test2-1.1.jar</exclude>
+                                        <exclude>src/main/cpp/common/project/vs/common.vcxproj</exclude>
+                                        <exclude>src/main/cpp/common/project/vs/common.vcxproj.filters</exclude>
                                         <exclude>**/Makefile.am</exclude>
                                         <exclude>**/configure.ac</exclude>
                                         <exclude>**/*.vcsproj</exclude>


[03/12] ignite git commit: IGNITE-1341: Refactored platform exceptions.

Posted by sb...@apache.org.
IGNITE-1341: Refactored platform exceptions.


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

Branch: refs/heads/ignite-1273
Commit: 66504a08c5db4e7cc03bfcb3336a00650d5f2375
Parents: 465348e
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Tue Sep 1 17:15:35 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Tue Sep 1 17:15:35 2015 +0300

----------------------------------------------------------------------
 .../processors/platform/PlatformContext.java    |  4 +-
 .../processors/platform/PlatformException.java  | 71 ++++++++++++++++++
 .../platform/PlatformExtendedException.java     | 57 +++++++++++++++
 .../platform/PlatformNativeException.java       | 77 ++++++++++++++++++++
 .../platform/PlatformNoCallbackException.java   | 50 +++++++++++++
 .../platform/PlatformContextImpl.java           |  4 +-
 .../processors/platform/PlatformException.java  | 71 ------------------
 .../platform/PlatformExtendedException.java     | 39 ----------
 .../platform/PlatformNoCallbackException.java   | 50 -------------
 .../platform/cache/PlatformCache.java           |  2 +-
 .../PlatformCachePartialUpdateException.java    | 15 +---
 .../platform/compute/PlatformAbstractTask.java  |  1 +
 .../compute/PlatformNativeException.java        | 77 --------------------
 .../platform/utils/PlatformUtils.java           |  2 +-
 14 files changed, 262 insertions(+), 258 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContext.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContext.java
index 218ae6b..a9b7d02 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContext.java
@@ -17,7 +17,6 @@
 
 package org.apache.ignite.internal.processors.platform;
 
-import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.cluster.ClusterMetrics;
 import org.apache.ignite.cluster.ClusterNode;
 import org.apache.ignite.events.Event;
@@ -216,8 +215,7 @@ public interface PlatformContext {
      * @param cause Native cause.
      * @return Exception.
      */
-    // TODO: Some common interface must be used here.
-    public IgniteCheckedException createNativeException(Object cause);
+    public PlatformNativeException createNativeException(Object cause);
 
     /**
      * Create job.

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java
new file mode 100644
index 0000000..4334d93
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java
@@ -0,0 +1,71 @@
+/*
+ * 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.platform;
+
+import org.apache.ignite.IgniteCheckedException;
+import org.apache.ignite.internal.util.typedef.internal.S;
+import org.jetbrains.annotations.Nullable;
+
+/**
+ * Interop checked exception.
+ */
+public class PlatformException extends IgniteCheckedException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Create empty exception.
+     */
+    public PlatformException() {
+        // No-op.
+    }
+
+    /**
+     * Creates new exception with given error message.
+     *
+     * @param msg Error message.
+     */
+    public PlatformException(String msg) {
+        super(msg);
+    }
+
+    /**
+     * Creates new grid exception with given throwable as a cause and
+     * source of error message.
+     *
+     * @param cause Non-null throwable cause.
+     */
+    public PlatformException(Throwable cause) {
+        this(cause.getMessage(), cause);
+    }
+
+    /**
+     * Creates new exception with given error message and optional nested exception.
+     *
+     * @param msg Error message.
+     * @param cause Optional nested exception (can be {@code null}).
+     */
+    public PlatformException(String msg, @Nullable Throwable cause) {
+        super(msg, cause);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(PlatformException.class, this);
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java
new file mode 100644
index 0000000..825db6c
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java
@@ -0,0 +1,57 @@
+/*
+ * 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.platform;
+
+import org.apache.ignite.internal.portable.PortableRawWriterEx;
+
+/**
+ * Denotes an exception which has some data to be written in a special manner.
+ */
+public abstract class PlatformExtendedException extends PlatformException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Platform context. */
+    protected final PlatformContext ctx;
+
+    /**
+     * Constructor.
+     *
+     * @param cause Root cause.
+     * @param ctx Platform context.
+     */
+    protected PlatformExtendedException(Throwable cause, PlatformContext ctx) {
+        super(cause);
+
+        this.ctx = ctx;
+    }
+
+    /**
+     * @return Platform context.
+     */
+    public PlatformContext context() {
+        return ctx;
+    }
+
+    /**
+     * Write data.
+     *
+     * @param writer Writer.
+     */
+    public abstract void writeData(PortableRawWriterEx writer);
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNativeException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNativeException.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNativeException.java
new file mode 100644
index 0000000..a99664a
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNativeException.java
@@ -0,0 +1,77 @@
+/*
+ * 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.platform;
+
+import org.apache.ignite.internal.util.typedef.internal.S;
+
+import java.io.Externalizable;
+import java.io.IOException;
+import java.io.ObjectInput;
+import java.io.ObjectOutput;
+
+/**
+ * Exception occurred on native side.
+ */
+public class PlatformNativeException extends PlatformException implements Externalizable {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /** Native cause. */
+    protected Object cause;
+
+    /**
+     * {@link java.io.Externalizable} support.
+     */
+    @SuppressWarnings("UnusedDeclaration")
+    public PlatformNativeException() {
+        // No-op.
+    }
+
+    /**
+     * Constructor.
+     *
+     * @param cause Native cause.
+     */
+    public PlatformNativeException(Object cause) {
+        super("Native platform exception occurred.");
+
+        this.cause = cause;
+    }
+
+    /**
+     * @return Native cause.
+     */
+    public Object cause() {
+        return cause;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeObject(cause);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        cause = in.readObject();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(PlatformNativeException.class, this, "cause", cause);
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java
new file mode 100644
index 0000000..f706bbd
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java
@@ -0,0 +1,50 @@
+/*
+ * 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.platform;
+
+import org.apache.ignite.internal.util.typedef.internal.S;
+
+/**
+ * Exception raised when interop callback is not set in native platform.
+ */
+@SuppressWarnings("UnusedDeclaration")
+public class PlatformNoCallbackException extends PlatformException {
+    /** */
+    private static final long serialVersionUID = 0L;
+
+    /**
+     * Constructor.
+     */
+    public PlatformNoCallbackException() {
+        // No-op.
+    }
+
+    /**
+     * Constructor.
+     *
+     * @param msg Message.
+     */
+    public PlatformNoCallbackException(String msg) {
+        super(msg);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(PlatformNoCallbackException.class, this);
+    }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
index 6d1d7a7..3895506 100644
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
+++ b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformContextImpl.java
@@ -17,7 +17,6 @@
 
 package org.apache.ignite.internal.processors.platform;
 
-import org.apache.ignite.IgniteCheckedException;
 import org.apache.ignite.IgniteException;
 import org.apache.ignite.cluster.ClusterMetrics;
 import org.apache.ignite.cluster.ClusterNode;
@@ -54,7 +53,6 @@ import org.apache.ignite.internal.processors.platform.compute.PlatformAbstractTa
 import org.apache.ignite.internal.processors.platform.compute.PlatformClosureJob;
 import org.apache.ignite.internal.processors.platform.compute.PlatformFullJob;
 import org.apache.ignite.internal.processors.platform.compute.PlatformJob;
-import org.apache.ignite.internal.processors.platform.compute.PlatformNativeException;
 import org.apache.ignite.internal.processors.platform.datastreamer.PlatformStreamReceiver;
 import org.apache.ignite.internal.processors.platform.datastreamer.PlatformStreamReceiverImpl;
 import org.apache.ignite.internal.processors.platform.events.PlatformEventFilterListenerImpl;
@@ -587,7 +585,7 @@ public class PlatformContextImpl implements PlatformContext {
     }
 
     /** {@inheritDoc} */
-    @Override public IgniteCheckedException createNativeException(Object cause) {
+    @Override public PlatformNativeException createNativeException(Object cause) {
         return new PlatformNativeException(cause);
     }
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java
deleted file mode 100644
index 4334d93..0000000
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformException.java
+++ /dev/null
@@ -1,71 +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.platform;
-
-import org.apache.ignite.IgniteCheckedException;
-import org.apache.ignite.internal.util.typedef.internal.S;
-import org.jetbrains.annotations.Nullable;
-
-/**
- * Interop checked exception.
- */
-public class PlatformException extends IgniteCheckedException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Create empty exception.
-     */
-    public PlatformException() {
-        // No-op.
-    }
-
-    /**
-     * Creates new exception with given error message.
-     *
-     * @param msg Error message.
-     */
-    public PlatformException(String msg) {
-        super(msg);
-    }
-
-    /**
-     * Creates new grid exception with given throwable as a cause and
-     * source of error message.
-     *
-     * @param cause Non-null throwable cause.
-     */
-    public PlatformException(Throwable cause) {
-        this(cause.getMessage(), cause);
-    }
-
-    /**
-     * Creates new exception with given error message and optional nested exception.
-     *
-     * @param msg Error message.
-     * @param cause Optional nested exception (can be {@code null}).
-     */
-    public PlatformException(String msg, @Nullable Throwable cause) {
-        super(msg, cause);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(PlatformException.class, this);
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java
deleted file mode 100644
index 8c33729..0000000
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformExtendedException.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.internal.processors.platform;
-
-import org.apache.ignite.internal.portable.PortableRawWriterEx;
-
-/**
- * Denotes an exception which has some data to be written in a special manner.
- */
-public interface PlatformExtendedException {
-    /**
-     * Gets platform context.
-     *
-     * @return Platform context.
-     */
-    public PlatformContext context();
-
-    /**
-     * Write data.
-     *
-     * @param writer Writer.
-     */
-    public void writeData(PortableRawWriterEx writer);
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java
deleted file mode 100644
index f706bbd..0000000
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/PlatformNoCallbackException.java
+++ /dev/null
@@ -1,50 +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.platform;
-
-import org.apache.ignite.internal.util.typedef.internal.S;
-
-/**
- * Exception raised when interop callback is not set in native platform.
- */
-@SuppressWarnings("UnusedDeclaration")
-public class PlatformNoCallbackException extends PlatformException {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /**
-     * Constructor.
-     */
-    public PlatformNoCallbackException() {
-        // No-op.
-    }
-
-    /**
-     * Constructor.
-     *
-     * @param msg Message.
-     */
-    public PlatformNoCallbackException(String msg) {
-        super(msg);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(PlatformNoCallbackException.class, this);
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCache.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCache.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCache.java
index e579be7..184aa33 100644
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCache.java
+++ b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCache.java
@@ -39,7 +39,7 @@ import org.apache.ignite.internal.processors.platform.PlatformContext;
 import org.apache.ignite.internal.processors.platform.cache.query.PlatformContinuousQuery;
 import org.apache.ignite.internal.processors.platform.cache.query.PlatformFieldsQueryCursor;
 import org.apache.ignite.internal.processors.platform.cache.query.PlatformQueryCursor;
-import org.apache.ignite.internal.processors.platform.compute.PlatformNativeException;
+import org.apache.ignite.internal.processors.platform.PlatformNativeException;
 import org.apache.ignite.internal.processors.platform.utils.PlatformFutureUtils;
 import org.apache.ignite.internal.processors.platform.utils.PlatformUtils;
 import org.apache.ignite.internal.util.GridConcurrentFactory;

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCachePartialUpdateException.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCachePartialUpdateException.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCachePartialUpdateException.java
index 58dfa4c..ef17a06 100644
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCachePartialUpdateException.java
+++ b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/cache/PlatformCachePartialUpdateException.java
@@ -20,7 +20,6 @@ package org.apache.ignite.internal.processors.platform.cache;
 import org.apache.ignite.internal.portable.PortableRawWriterEx;
 import org.apache.ignite.internal.processors.cache.CachePartialUpdateCheckedException;
 import org.apache.ignite.internal.processors.platform.PlatformContext;
-import org.apache.ignite.internal.processors.platform.PlatformException;
 import org.apache.ignite.internal.processors.platform.PlatformExtendedException;
 import org.apache.ignite.internal.processors.platform.utils.PlatformUtils;
 
@@ -29,13 +28,10 @@ import java.util.Collection;
 /**
  * Interop cache partial update exception.
  */
-public class PlatformCachePartialUpdateException extends PlatformException implements PlatformExtendedException {
+public class PlatformCachePartialUpdateException extends PlatformExtendedException {
     /** */
     private static final long serialVersionUID = 0L;
 
-    /** Platform context. */
-    private final PlatformContext ctx;
-
     /** Keep portable flag. */
     private final boolean keepPortable;
 
@@ -48,18 +44,11 @@ public class PlatformCachePartialUpdateException extends PlatformException imple
      */
     public PlatformCachePartialUpdateException(CachePartialUpdateCheckedException cause, PlatformContext ctx,
         boolean keepPortable) {
-        super(cause);
-
-        this.ctx = ctx;
+        super(cause, ctx);
         this.keepPortable = keepPortable;
     }
 
     /** {@inheritDoc} */
-    @Override public PlatformContext context() {
-        return ctx;
-    }
-
-    /** {@inheritDoc} */
     @Override public void writeData(PortableRawWriterEx writer) {
         Collection keys = ((CachePartialUpdateCheckedException)getCause()).failedKeys();
 

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformAbstractTask.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformAbstractTask.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformAbstractTask.java
index 0152713..b17dd97 100644
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformAbstractTask.java
+++ b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformAbstractTask.java
@@ -26,6 +26,7 @@ import org.apache.ignite.compute.ComputeJobResultPolicy;
 import org.apache.ignite.compute.ComputeTask;
 import org.apache.ignite.internal.portable.PortableRawWriterEx;
 import org.apache.ignite.internal.processors.platform.PlatformContext;
+import org.apache.ignite.internal.processors.platform.PlatformNativeException;
 import org.apache.ignite.internal.processors.platform.memory.PlatformMemory;
 import org.apache.ignite.internal.processors.platform.memory.PlatformOutputStream;
 import org.apache.ignite.internal.processors.platform.utils.PlatformUtils;

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformNativeException.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformNativeException.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformNativeException.java
deleted file mode 100644
index 106abb9..0000000
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/compute/PlatformNativeException.java
+++ /dev/null
@@ -1,77 +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.platform.compute;
-
-import java.io.Externalizable;
-import java.io.IOException;
-import java.io.ObjectInput;
-import java.io.ObjectOutput;
-import org.apache.ignite.internal.processors.platform.PlatformException;
-import org.apache.ignite.internal.util.typedef.internal.S;
-
-/**
- * Exception occurred on native side.
- */
-public class PlatformNativeException extends PlatformException implements Externalizable {
-    /** */
-    private static final long serialVersionUID = 0L;
-
-    /** Native cause. */
-    protected Object cause;
-
-    /**
-     * {@link Externalizable} support.
-     */
-    @SuppressWarnings("UnusedDeclaration")
-    public PlatformNativeException() {
-        // No-op.
-    }
-
-    /**
-     * Constructor.
-     *
-     * @param cause Native cause.
-     */
-    public PlatformNativeException(Object cause) {
-        super("Native platform exception occurred.");
-
-        this.cause = cause;
-    }
-
-    /**
-     * @return Native cause.
-     */
-    public Object cause() {
-        return cause;
-    }
-
-    /** {@inheritDoc} */
-    @Override public void writeExternal(ObjectOutput out) throws IOException {
-        out.writeObject(cause);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
-        cause = in.readObject();
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(PlatformNativeException.class, this, "cause", cause);
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ignite/blob/66504a08/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformUtils.java
----------------------------------------------------------------------
diff --git a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformUtils.java b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformUtils.java
index ab2a5eb..2e1da0b 100644
--- a/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformUtils.java
+++ b/modules/platform/src/main/java/org/apache/ignite/internal/processors/platform/utils/PlatformUtils.java
@@ -36,8 +36,8 @@ import org.apache.ignite.internal.portable.PortableRawReaderEx;
 import org.apache.ignite.internal.portable.PortableRawWriterEx;
 import org.apache.ignite.internal.processors.platform.PlatformContext;
 import org.apache.ignite.internal.processors.platform.PlatformExtendedException;
+import org.apache.ignite.internal.processors.platform.PlatformNativeException;
 import org.apache.ignite.internal.processors.platform.PlatformProcessor;
-import org.apache.ignite.internal.processors.platform.compute.PlatformNativeException;
 import org.apache.ignite.internal.processors.platform.memory.PlatformInputStream;
 import org.apache.ignite.internal.processors.platform.memory.PlatformMemory;
 import org.apache.ignite.internal.processors.platform.memory.PlatformMemoryUtils;


[09/12] ignite git commit: Fixing RAT.

Posted by sb...@apache.org.
Fixing RAT.


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

Branch: refs/heads/ignite-1273
Commit: 4ab1b47670bf41bc13ba72d1666297a3e8cabc46
Parents: 5a948dc
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Wed Sep 2 11:12:57 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Wed Sep 2 11:12:57 2015 +0300

----------------------------------------------------------------------
 parent/pom.xml | 6 ++----
 1 file changed, 2 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/4ab1b476/parent/pom.xml
----------------------------------------------------------------------
diff --git a/parent/pom.xml b/parent/pom.xml
index 472d4ff..2380b08 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -740,12 +740,10 @@
                                         <exclude>src/test/dotnet/Apache.Ignite.Core.Tests/Apache.Ignite.Core.Tests.csproj</exclude>
                                         <exclude>src/test/portables/repo/org/apache/ignite/portable/test1/1.1/test1-1.1.jar</exclude>
                                         <exclude>src/test/portables/repo/org/apache/ignite/portable/test2/1.1/test2-1.1.jar</exclude>
-                                        <exclude>src/main/cpp/common/project/vs/common.vcxproj</exclude>
-                                        <exclude>src/main/cpp/common/project/vs/common.vcxproj.filters</exclude>
                                         <exclude>**/Makefile.am</exclude>
                                         <exclude>**/configure.ac</exclude>
-                                        <exclude>**/*.vcsproj</exclude>
-                                        <exclude>**/*.vcsproj.filters</exclude>
+                                        <exclude>**/*.vcxproj</exclude>
+                                        <exclude>**/*.vcxproj.filters</exclude>
                                         <exclude>**/module.def</exclude>
                                         <exclude>**/ignite-common.pc.in</exclude>
                                     </excludes>


[11/12] ignite git commit: Merge remote-tracking branch 'remotes/apache-git/master' into ignite-1273

Posted by sb...@apache.org.
Merge remote-tracking branch 'remotes/apache-git/master' into ignite-1273


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

Branch: refs/heads/ignite-1273
Commit: 4e93f49dc615e6792ef83692139476e1d5c3b36b
Parents: 7e805fb fdcd47b
Author: Denis Magda <dm...@gridgain.com>
Authored: Wed Sep 2 12:31:58 2015 +0300
Committer: Denis Magda <dm...@gridgain.com>
Committed: Wed Sep 2 12:31:58 2015 +0300

----------------------------------------------------------------------
 .../igfs/IgfsProcessorValidationSelfTest.java   | 26 +++++---------------
 parent/pom.xml                                  |  6 ++---
 2 files changed, 8 insertions(+), 24 deletions(-)
----------------------------------------------------------------------