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/03/02 17:35:53 UTC

[01/50] incubator-ignite git commit: #ignite-239: fix logger.

Repository: incubator-ignite
Updated Branches:
  refs/heads/ignite-337 472ef0515 -> b05e462d3


#ignite-239: fix logger.


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

Branch: refs/heads/ignite-337
Commit: 39428532fbd3fc402323b7e4580328fcc11cf653
Parents: 535aaf4
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 12:23:51 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 12:23:51 2015 +0300

----------------------------------------------------------------------
 .../src/main/java/org/apache/ignite/internal/IgnitionEx.java   | 6 ++++--
 .../cache/datastructures/GridCacheQueueCleanupSelfTest.java    | 1 -
 2 files changed, 4 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/39428532/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index f70836c..32a3d71 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1307,11 +1307,13 @@ public class IgnitionEx {
                 System.setProperty(IGNITE_CONFIG_URL, startCtx.configUrl().toString());
 
             // Initialize factory's log.
-            IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), cfg.getNodeId());
+            UUID nodeId = cfg.getNodeId() != null ? cfg.getNodeId() : UUID.randomUUID();
+
+            IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), nodeId);
 
             assert cfgLog != null;
 
-            cfgLog = new GridLoggerProxy(cfgLog, null, name, U.id8(cfg.getNodeId()));
+            cfgLog = new GridLoggerProxy(cfgLog, null, name, U.id8(nodeId));
 
             log = cfgLog.getLogger(G.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/39428532/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheQueueCleanupSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheQueueCleanupSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheQueueCleanupSelfTest.java
index e61d15b..1192426 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheQueueCleanupSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheQueueCleanupSelfTest.java
@@ -20,7 +20,6 @@ package org.apache.ignite.internal.processors.cache.datastructures;
 import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
 import org.apache.ignite.cluster.*;
-import org.apache.ignite.configuration.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.datastructures.*;


[32/50] incubator-ignite git commit: # ignite-382 Changed version.

Posted by sb...@apache.org.
# ignite-382 Changed version.


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

Branch: refs/heads/ignite-337
Commit: f252ee4177c3f1cf4b8eb47014e930da696600c2
Parents: 13e2d1f
Author: anovikov <an...@gridgain.com>
Authored: Mon Mar 2 16:36:11 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Mon Mar 2 16:36:11 2015 +0700

----------------------------------------------------------------------
 examples/pom-standalone.xml                       | 2 +-
 modules/core/src/main/resources/ignite.properties | 2 +-
 pom.xml                                           | 4 ++--
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f252ee41/examples/pom-standalone.xml
----------------------------------------------------------------------
diff --git a/examples/pom-standalone.xml b/examples/pom-standalone.xml
index 47df6bd..5de7433 100644
--- a/examples/pom-standalone.xml
+++ b/examples/pom-standalone.xml
@@ -28,7 +28,7 @@
 
     <properties>
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
-        <ignite.version>1.0.1-RC1-SNAPSHOT</ignite.version>
+        <ignite.version>1.0.0-RC2-SNAPSHOT</ignite.version>
     </properties>
 
     <groupId>org.apache.ignite</groupId>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f252ee41/modules/core/src/main/resources/ignite.properties
----------------------------------------------------------------------
diff --git a/modules/core/src/main/resources/ignite.properties b/modules/core/src/main/resources/ignite.properties
index caa7553..4295dce 100644
--- a/modules/core/src/main/resources/ignite.properties
+++ b/modules/core/src/main/resources/ignite.properties
@@ -15,7 +15,7 @@
 # limitations under the License.
 #
 
-ignite.version=1.0.1-rc1
+ignite.version=1.0.0-rc2
 ignite.build=0
 ignite.revision=DEV
 ignite.rel.date=01011970

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f252ee41/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 98f649d..b0ebc44 100644
--- a/pom.xml
+++ b/pom.xml
@@ -33,7 +33,7 @@
     </parent>
 
     <properties>
-        <ignite.version>1.0.1-RC1-SNAPSHOT</ignite.version>
+        <ignite.version>1.0.0-RC2-SNAPSHOT</ignite.version>
         <ignite.edition>fabric</ignite.edition>
         <hadoop.version>2.4.1</hadoop.version>
         <spring.version>4.1.0.RELEASE</spring.version>
@@ -574,7 +574,7 @@
                 </plugins>
             </build>
         </profile>
-        
+
         <profile>
             <id>test</id>
             <build>


[09/50] incubator-ignite git commit: IGNITE-136 Added test eviction for local store.

Posted by sb...@apache.org.
IGNITE-136 Added test eviction for local store.


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

Branch: refs/heads/ignite-337
Commit: 2e115bf663aef70f6141119adcbd11e2c7bbbaaa
Parents: 3a466e8
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Fri Feb 27 17:57:04 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Fri Feb 27 17:57:04 2015 +0300

----------------------------------------------------------------------
 .../GridCacheAbstractLocalStoreSelfTest.java    | 30 ++++++++++++++++++++
 1 file changed, 30 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2e115bf6/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
index 781c6a6..c43b8f8 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractLocalStoreSelfTest.java
@@ -25,6 +25,7 @@ import org.apache.ignite.configuration.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.internal.processors.cache.store.*;
 import org.apache.ignite.internal.util.lang.*;
+import org.apache.ignite.internal.util.typedef.internal.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.spi.discovery.tcp.*;
 import org.apache.ignite.spi.discovery.tcp.ipfinder.*;
@@ -35,6 +36,7 @@ import org.jetbrains.annotations.*;
 
 import javax.cache.*;
 import javax.cache.configuration.*;
+import javax.cache.expiry.*;
 import javax.cache.integration.*;
 import java.util.*;
 import java.util.concurrent.*;
@@ -170,6 +172,34 @@ public abstract class GridCacheAbstractLocalStoreSelfTest extends GridCommonAbst
     /**
      * @throws Exception If failed.
      */
+    public void testEvict() throws Exception {
+        Ignite ignite1 = startGrid(1);
+
+        IgniteCache<Object, Object> cache = ignite1.jcache(null).withExpiryPolicy(new CreatedExpiryPolicy(
+            new Duration(TimeUnit.MILLISECONDS, 100L)));
+
+        // Putting entry.
+        for (int i = 0; i < KEYS; i++)
+            cache.put(i, i);
+
+        // Wait when entry 
+        U.sleep(200);
+
+        // Check that entry is evicted from cache, but local store does contain it.
+        for (int i = 0; i < KEYS; i++) {
+            cache.localEvict(Arrays.asList(i));
+
+            assertNull(cache.localPeek(i));
+
+            assertEquals(i, (int)LOCAL_STORE_1.load(i).get1());
+
+            assertEquals(i, cache.get(i));
+        }
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
     public void testPrimaryNode() throws Exception {
         Ignite ignite1 = startGrid(1);
 


[10/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-2' into ignite-239

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


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

Branch: refs/heads/ignite-337
Commit: d1b9436a467148539d69a6dc70a084dd37ffa58f
Parents: 4f7dbf7 e1c0945
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 17:59:43 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 17:59:43 2015 +0300

----------------------------------------------------------------------
 config/ignite-log4j.xml                         |    2 +-
 .../datagrid/CacheContinuousQueryExample.java   |    2 +-
 ipc/shmem/Makefile.am                           |   15 +
 ipc/shmem/igniteshmem/Makefile.am               |   15 +
 ipc/shmem/include/Makefile.am                   |   15 +
 modules/clients/src/test/keystore/generate.sh   |   15 +-
 .../ignite/cache/query/ContinuousQuery.java     |   18 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |    2 +-
 .../internal/events/DiscoveryCustomEvent.java   |    3 +
 .../processors/cache/IgniteCacheProxy.java      |    6 +-
 .../optimized-classnames.previous.properties    |   15 +
 .../optimized/optimized-classnames.properties   | 1565 +-----------------
 .../TcpDiscoveryCustomEventMessage.java         |    3 +
 ...ridCacheContinuousQueryAbstractSelfTest.java |    8 +-
 modules/extdata/p2p/pom.xml                     |    6 -
 modules/hibernate/pom.xml                       |    6 -
 modules/indexing/pom.xml                        |    6 -
 modules/jta/pom.xml                             |    6 -
 modules/scalar/pom.xml                          |    6 -
 modules/spring/pom.xml                          |    6 -
 modules/visor-console/pom.xml                   |    7 -
 modules/web/pom.xml                             |    6 -
 modules/winservice/IgniteService.sln            |    2 +-
 .../IgniteService/IgniteService.csproj          |    2 +-
 .../config/benchmark-atomic-win.properties      |   15 +
 .../config/benchmark-atomic.properties          |   15 +
 .../config/benchmark-compute-win.properties     |   15 +
 .../config/benchmark-compute.properties         |   15 +
 .../config/benchmark-multicast.properties       |   15 +
 .../config/benchmark-query-win.properties       |   15 +
 .../yardstick/config/benchmark-query.properties |   15 +
 .../config/benchmark-tx-win.properties          |   15 +
 .../yardstick/config/benchmark-tx.properties    |   15 +
 .../yardstick/config/benchmark-win.properties   |   15 +
 modules/yardstick/config/benchmark.properties   |   15 +
 pom.xml                                         |  150 +-
 36 files changed, 358 insertions(+), 1694 deletions(-)
----------------------------------------------------------------------



[18/50] incubator-ignite git commit: # sprint-2 - javadoc fixes.

Posted by sb...@apache.org.
# sprint-2 - javadoc fixes.


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

Branch: refs/heads/ignite-337
Commit: a14ef18335ad5f6c78c35b711f4bd8d5a40f6910
Parents: 375376b
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Sat Feb 28 00:19:58 2015 -0500
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Sat Feb 28 00:19:58 2015 -0500

----------------------------------------------------------------------
 .../org/apache/ignite/cache/store/CacheStoreAdapter.java     | 2 +-
 .../org/apache/ignite/cache/store/CacheStoreSession.java     | 8 +++++++-
 2 files changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a14ef183/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreAdapter.java b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreAdapter.java
index 794281b..58a3f76 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreAdapter.java
@@ -39,7 +39,7 @@ import java.util.*;
 public abstract class CacheStoreAdapter<K, V> implements CacheStore<K, V> {
     /**
      * Default empty implementation. This method needs to be overridden only if
-     * {@link org.apache.ignite.cache.GridCache#loadCache(IgniteBiPredicate, long, Object...)} method
+     * {@link org.apache.ignite.IgniteCache#loadCache(IgniteBiPredicate, Object...)} method
      * is explicitly called.
      *
      * @param clo {@inheritDoc}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a14ef183/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
index 0bfc6fc..a2be4c5 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
@@ -23,7 +23,13 @@ import org.apache.ignite.transactions.*;
 import java.util.*;
 
 /**
- * Session for the cache store operations.
+ * Session for the cache store operations. The main purpose of cache store session
+ * is to hold context between multiple store invocations whenever in transaction. For example,
+ * if using JDBC, you can store the ongoing database connection in the session {@link #properties()} map.
+ * You can then commit this connection in the {@link CacheStore#txEnd(boolean)} method.
+ * <p>
+ * {@code CacheStoreSession} can be injected into an implementation of {@link CacheStore} with
+ * {@link CacheStoreSessionResource @CacheStoreSessionResource} annotation.
  *
  * @see CacheStoreSessionResource
  */


[08/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-2' into ignite-311

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


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

Branch: refs/heads/ignite-337
Commit: 2ef2271b3f214db6143cd4166377c46f465449f8
Parents: 6e2ef56 e1c0945
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 17:56:34 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 17:56:34 2015 +0300

----------------------------------------------------------------------
 config/hadoop/default-config.xml                |   12 +
 config/ignite-log4j.xml                         |    2 +-
 .../datagrid/CacheContinuousQueryExample.java   |    2 +-
 ipc/shmem/Makefile.am                           |   15 +
 ipc/shmem/igniteshmem/Makefile.am               |   15 +
 ipc/shmem/include/Makefile.am                   |   15 +
 modules/clients/src/test/keystore/generate.sh   |   15 +-
 .../src/main/java/org/apache/ignite/Ignite.java |    4 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |    2 +-
 .../ignite/cache/query/ContinuousQuery.java     |   18 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |    2 +-
 .../configuration/QueryConfiguration.java       |   37 +-
 .../ignite/events/DiscoveryCustomEvent.java     |   56 -
 .../org/apache/ignite/events/EventType.java     |   14 +-
 .../java/org/apache/ignite/igfs/IgfsMode.java   |    6 +-
 .../java/org/apache/ignite/igfs/package.html    |    2 +-
 .../internal/events/DiscoveryCustomEvent.java   |   71 +
 .../discovery/GridDiscoveryManager.java         |    7 +-
 .../processors/cache/IgniteCacheProxy.java      |    6 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |   10 +-
 .../visor/node/VisorBasicConfiguration.java     |   17 -
 .../node/VisorNodeEventsCollectorTask.java      |   10 +-
 .../internal/visor/node/VisorNodeGcTask.java    |   10 +-
 .../internal/visor/node/VisorNodePingTask.java  |   10 +-
 .../optimized-classnames.previous.properties    |   15 +
 .../optimized/optimized-classnames.properties   | 1565 +-----------------
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    9 +-
 .../TcpDiscoveryCustomEventMessage.java         |    3 +
 .../internal/GridDiscoveryEventSelfTest.java    |    9 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    8 +-
 ...dStartupWithUndefinedIgniteHomeSelfTest.java |  103 ++
 .../config/GridTestProperties.java              |   10 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |    1 +
 modules/extdata/p2p/pom.xml                     |    6 -
 .../client/hadoop/GridHadoopClientProtocol.java |    6 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |  412 +++++
 .../igfs/hadoop/v1/IgfsHadoopFileSystem.java    |    3 +-
 .../igfs/hadoop/v2/IgfsHadoopFileSystem.java    |    3 +-
 .../java/org/apache/ignite/igfs/package.html    |    2 +-
 .../igfs/hadoop/IgfsHadoopFSProperties.java     |   10 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |  413 -----
 .../internal/igfs/hadoop/IgfsHadoopReader.java  |    2 +-
 .../internal/igfs/hadoop/IgfsHadoopUtils.java   |    4 +-
 .../hadoop/GridHadoopClassLoader.java           |   12 +-
 .../processors/hadoop/GridHadoopSetup.java      |    8 +-
 .../processors/hadoop/GridHadoopUtils.java      |    4 +-
 .../collections/GridHadoopHashMultimapBase.java |    2 +-
 .../GridHadoopExternalCommunication.java        |   14 +-
 .../hadoop/v1/GridHadoopV1MapTask.java          |    6 +-
 .../v2/GridHadoopV2JobResourceManager.java      |    2 +-
 .../GridHadoopClientProtocolSelfTest.java       |    6 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |    2 +-
 .../IgfsHadoop20FileSystemAbstractSelfTest.java |    2 +-
 .../igfs/IgfsHadoopDualAbstractSelfTest.java    |    2 +-
 .../IgfsHadoopFileSystemAbstractSelfTest.java   |    1 +
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |    2 +-
 .../hadoop/GridHadoopGroupingTest.java          |    4 +-
 .../igfs/IgfsPerformanceBenchmark.java          |    9 +-
 .../testsuites/IgniteHadoopTestSuite.java       |    7 +-
 modules/hibernate/pom.xml                       |    6 -
 modules/indexing/pom.xml                        |    6 -
 modules/jta/pom.xml                             |    6 -
 modules/scalar/pom.xml                          |    6 -
 modules/spring/pom.xml                          |    6 -
 modules/visor-console/pom.xml                   |    7 -
 .../commands/alert/VisorAlertCommand.scala      |    8 +-
 .../commands/cache/VisorCacheCommand.scala      |   82 +-
 .../config/VisorConfigurationCommand.scala      |  140 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   64 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |    2 +-
 modules/web/pom.xml                             |    6 -
 modules/winservice/IgniteService.sln            |    2 +-
 .../IgniteService/IgniteService.csproj          |    2 +-
 .../config/benchmark-atomic-win.properties      |   15 +
 .../config/benchmark-atomic.properties          |   15 +
 .../config/benchmark-compute-win.properties     |   15 +
 .../config/benchmark-compute.properties         |   15 +
 .../config/benchmark-multicast.properties       |   15 +
 .../config/benchmark-query-win.properties       |   15 +
 .../yardstick/config/benchmark-query.properties |   15 +
 .../config/benchmark-tx-win.properties          |   15 +
 .../yardstick/config/benchmark-tx.properties    |   15 +
 .../yardstick/config/benchmark-win.properties   |   15 +
 modules/yardstick/config/benchmark.properties   |   15 +
 pom.xml                                         |  150 +-
 86 files changed, 1280 insertions(+), 2405 deletions(-)
----------------------------------------------------------------------



[50/50] incubator-ignite git commit: Merge branch 'sprint-2' into ignite-337

Posted by sb...@apache.org.
Merge branch 'sprint-2' into ignite-337


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

Branch: refs/heads/ignite-337
Commit: b05e462d3922303e9b26439cc7bad63513390f3f
Parents: 7ecb170 b2675bc
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Mar 2 18:16:03 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Mar 2 18:16:03 2015 +0300

----------------------------------------------------------------------
 examples/pom-standalone.xml                     |   2 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   8 +-
 .../configuration/IgniteConfiguration.java      |   5 +-
 .../ignite/internal/GridKernalContext.java      |  10 +-
 .../ignite/internal/GridKernalContextImpl.java  |  14 +-
 .../apache/ignite/internal/IgniteKernal.java    |  23 +-
 .../org/apache/ignite/internal/IgnitionEx.java  | 592 +++++++++----------
 .../affinity/GridAffinityAssignmentCache.java   |  13 +-
 .../processors/cache/CacheMetricsImpl.java      |   4 +
 .../processors/cache/GridCacheContext.java      |  19 +
 .../processors/cache/GridCacheMapEntry.java     |   9 +
 .../processors/cache/GridCacheProcessor.java    |  15 +
 .../processors/cache/GridCacheStoreManager.java |  12 +-
 .../GridDistributedCacheAdapter.java            |   2 +
 .../distributed/dht/GridDhtCacheEntry.java      |   3 +
 .../distributed/dht/GridDhtLocalPartition.java  |   5 +
 .../dht/atomic/GridDhtAtomicCache.java          |   2 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   2 +-
 .../cache/transactions/IgniteTxManager.java     |   7 +-
 .../processors/cluster/ClusterProcessor.java    |  46 ++
 .../dataload/IgniteDataLoaderImpl.java          |  29 +-
 .../core/src/main/resources/ignite.properties   |   2 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    | 440 ++++++++++++++
 .../cache/GridCacheAbstractMetricsSelfTest.java |  42 ++
 ...acheAbstractUsersAffinityMapperSelfTest.java | 207 +++++++
 ...dCacheAtomicUsersAffinityMapperSelfTest.java |  45 ++
 .../GridCachePartitionedLocalStoreSelfTest.java |  51 ++
 ...chePartitionedOffHeapLocalStoreSelfTest.java |  56 ++
 .../GridCacheReplicatedLocalStoreSelfTest.java  |  51 ++
 ...heReplicatedUsersAffinityMapperSelfTest.java |  45 ++
 ...ridCacheTxPartitionedLocalStoreSelfTest.java |  51 ++
 .../GridCacheTxUsersAffinityMapperSelfTest.java |  45 ++
 .../GridCacheQueueCleanupSelfTest.java          |   1 -
 .../ignite/testsuites/IgniteCacheTestSuite.java |   4 +
 modules/scalar/pom.xml                          |   6 +
 pom.xml                                         |   4 +-
 36 files changed, 1500 insertions(+), 372 deletions(-)
----------------------------------------------------------------------



[17/50] incubator-ignite git commit: # sprint-2 - Fixed warning in example.

Posted by sb...@apache.org.
# sprint-2 - Fixed warning in example.


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

Branch: refs/heads/ignite-337
Commit: 375376b68ccb9e8d83746f6eeac49a6388396012
Parents: a792c99
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Fri Feb 27 23:50:04 2015 -0500
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Fri Feb 27 23:50:04 2015 -0500

----------------------------------------------------------------------
 .../examples/datagrid/store/CacheNodeWithStoreStartup.java     | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/375376b6/examples/src/main/java/org/apache/ignite/examples/datagrid/store/CacheNodeWithStoreStartup.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/CacheNodeWithStoreStartup.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/CacheNodeWithStoreStartup.java
index 0c87f84..5245f98 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/CacheNodeWithStoreStartup.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/CacheNodeWithStoreStartup.java
@@ -64,19 +64,19 @@ public class CacheNodeWithStoreStartup {
 
         discoSpi.setIpFinder(ipFinder);
 
-        CacheConfiguration cacheCfg = new CacheConfiguration();
+        CacheConfiguration<Long, Person> cacheCfg = new CacheConfiguration<>();
 
         // Set atomicity as transaction, since we are showing transactions in example.
         cacheCfg.setAtomicityMode(TRANSACTIONAL);
 
-        CacheStore store;
+        CacheStore<Long, Person> store;
 
         // Uncomment other cache stores to try them.
         store = new CacheDummyPersonStore();
         // store = new CacheJdbcPersonStore();
         // store = new CacheHibernatePersonStore();
 
-        cacheCfg.setCacheStoreFactory(new FactoryBuilder.SingletonFactory(store));
+        cacheCfg.setCacheStoreFactory(new FactoryBuilder.SingletonFactory<>(store));
         cacheCfg.setReadThrough(true);
         cacheCfg.setWriteThrough(true);
 


[11/50] incubator-ignite git commit: #ignite-239: review.

Posted by sb...@apache.org.
#ignite-239: review.


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

Branch: refs/heads/ignite-337
Commit: 4ff4fd1d7ad0d7691bb911a5453d69d1a5ac627f
Parents: d1b9436
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 18:14:15 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 18:14:15 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/internal/IgnitionEx.java  | 77 ++++++++++----------
 1 file changed, 38 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4ff4fd1d/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index ca3abe9..6b8b197 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1295,51 +1295,19 @@ public class IgnitionEx {
         private void start0(GridStartContext startCtx) throws IgniteCheckedException {
             assert grid == null : "Grid is already started: " + name;
 
-            IgniteConfiguration cfg = startCtx.config() != null ? startCtx.config() : new IgniteConfiguration();
-
-            String ggHome = cfg.getIgniteHome();
-
-            // Set Ignite home.
-            if (ggHome == null)
-                ggHome = U.getIgniteHome();
-            else
-                // If user provided IGNITE_HOME - set it as a system property.
-                U.setIgniteHome(ggHome);
+            // Set configuration URL, if any, into system property.
+            if (startCtx.configUrl() != null)
+                System.setProperty(IGNITE_CONFIG_URL, startCtx.configUrl().toString());
 
-            U.setWorkDirectory(cfg.getWorkDirectory(), ggHome);
+            IgniteConfiguration cfg = startCtx.config() != null ? startCtx.config() : new IgniteConfiguration();
 
             // Ensure invariant.
             // It's a bit dirty - but this is a result of late refactoring
             // and I don't want to reshuffle a lot of code.
             assert F.eq(name, cfg.getGridName());
 
-            // Set configuration URL, if any, into system property.
-            if (startCtx.configUrl() != null)
-                System.setProperty(IGNITE_CONFIG_URL, startCtx.configUrl().toString());
-
-            // Initialize factory's log.
-            UUID nodeId = cfg.getNodeId() != null ? cfg.getNodeId() : UUID.randomUUID();
-
-            IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), nodeId);
-
-            assert cfgLog != null;
-
-            cfgLog = new GridLoggerProxy(cfgLog, null, name, U.id8(nodeId));
-
-            log = cfgLog.getLogger(G.class);
-
-            // Check Ignite home folder (after log is available).
-            if (ggHome != null) {
-                File ggHomeFile = new File(ggHome);
-
-                if (!ggHomeFile.exists() || !ggHomeFile.isDirectory())
-                    throw new IgniteCheckedException("Invalid Ignite installation home folder: " + ggHome);
-            }
-
             IgniteConfiguration myCfg = initializeConfiguration(cfg);
 
-            myCfg.setGridLogger(cfgLog);
-
             // Validate segmentation configuration.
             GridSegmentationPolicy segPlc = cfg.getSegmentationPolicy();
 
@@ -1521,9 +1489,41 @@ public class IgnitionEx {
          */
         private IgniteConfiguration initializeConfiguration(IgniteConfiguration cfg)
             throws IgniteCheckedException {
+            // Initialize factory's log.
+            UUID nodeId = cfg.getNodeId() != null ? cfg.getNodeId() : UUID.randomUUID();
+
+            IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), nodeId);
+
+            assert cfgLog != null;
+
+            cfgLog = new GridLoggerProxy(cfgLog, null, name, U.id8(nodeId));
+
+            log = cfgLog.getLogger(G.class);
+
+            String ggHome = cfg.getIgniteHome();
+
+            // Set Ignite home.
+            if (ggHome == null)
+                ggHome = U.getIgniteHome();
+            else
+                // If user provided IGNITE_HOME - set it as a system property.
+                U.setIgniteHome(ggHome);
+
+            U.setWorkDirectory(cfg.getWorkDirectory(), ggHome);
+
+            // Check Ignite home folder (after log is available).
+            if (ggHome != null) {
+                File ggHomeFile = new File(ggHome);
+
+                if (!ggHomeFile.exists() || !ggHomeFile.isDirectory())
+                    throw new IgniteCheckedException("Invalid Ignite installation home folder: " + ggHome);
+            }
+
             IgniteConfiguration myCfg = new IgniteConfiguration(cfg);
 
-            myCfg.setIgniteHome(U.getIgniteHome());
+            myCfg.setIgniteHome(ggHome);
+
+            myCfg.setGridLogger(cfgLog);
 
             // Local host.
             String locHost = IgniteSystemProperties.getString(IGNITE_LOCAL_HOST);
@@ -1606,8 +1606,7 @@ public class IgnitionEx {
             if (myCfg.getMBeanServer() == null)
                 myCfg.setMBeanServer(ManagementFactory.getPlatformMBeanServer());
 
-            if (myCfg.getNodeId() == null)
-               myCfg.setNodeId(UUID.randomUUID());
+            myCfg.setNodeId(nodeId);
 
             if (myCfg.getPeerClassLoadingLocalClassPathExclude() == null)
                 myCfg.setPeerClassLoadingLocalClassPathExclude(EMPTY_STR_ARR);


[02/50] incubator-ignite git commit: # Merge sprint-2 into ignite-339

Posted by sb...@apache.org.
# Merge sprint-2 into ignite-339


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

Branch: refs/heads/ignite-337
Commit: 555e3f9455dc82a011943a561c0aa6405cca82bc
Parents: 53141e5 4e7463d
Author: anovikov <an...@gridgain.com>
Authored: Fri Feb 27 17:21:33 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Fri Feb 27 17:21:33 2015 +0700

----------------------------------------------------------------------
 .../visor/node/VisorBasicConfiguration.java     |  17 ---
 .../commands/alert/VisorAlertCommand.scala      |   8 +-
 .../commands/cache/VisorCacheCommand.scala      |  95 +++++++------
 .../config/VisorConfigurationCommand.scala      | 140 ++++++++++---------
 .../commands/disco/VisorDiscoveryCommand.scala  |   2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |  64 ++++++---
 .../commands/tasks/VisorTasksCommandSpec.scala  |   2 +-
 7 files changed, 178 insertions(+), 150 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/555e3f94/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
----------------------------------------------------------------------
diff --cc modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
index 97adeac,5dd19b1..577067a
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
@@@ -776,6 -775,8 +775,7 @@@ object VisorCacheCommand 
          val evictCfg = cfg.evictConfiguration()
          val defaultCfg = cfg.defaultConfiguration()
          val storeCfg = cfg.storeConfiguration()
 -        val writeBehind = cfg.writeBehind()
+         val queryCfg = cfg.queryConfiguration()
  
          val cacheT = VisorTextTable()
  
@@@ -789,19 -792,21 +791,19 @@@
          cacheT += ("Time To Live", defaultCfg.timeToLive())
          cacheT += ("Time To Live Eager Flag", cfg.eagerTtl)
  
-         cacheT += ("Write Synchronization Mode", cfg.writeSynchronizationMode)
-         cacheT += ("Swap Enabled", cfg.swapEnabled())
-         cacheT += ("Invalidate", cfg.invalidate())
+         cacheT += ("Write Synchronization Mode", safe(cfg.writeSynchronizationMode))
+         cacheT += ("Swap Enabled", bool2Str(cfg.swapEnabled()))
+         cacheT += ("Invalidate", bool2Str(cfg.invalidate()))
 -        cacheT += ("Read Through", bool2Str(cfg.readThrough()))
 -        cacheT += ("Write Through", bool2Str(cfg.writeThrough()))
          cacheT += ("Start Size", cfg.startSize())
  
-         cacheT += ("Transaction Manager Lookup", cfg.transactionManagerLookupClassName())
+         cacheT += ("Transaction Manager Lookup", safe(cfg.transactionManagerLookupClassName()))
  
-         cacheT += ("Affinity Function", affinityCfg.function())
+         cacheT += ("Affinity Function", safe(affinityCfg.function()))
          cacheT += ("Affinity Backups", affinityCfg.partitionedBackups())
-         cacheT += ("Affinity Partitions", affinityCfg.partitions())
-         cacheT += ("Affinity Default Replicas", affinityCfg.defaultReplicas())
-         cacheT += ("Affinity Exclude Neighbors", affinityCfg.excludeNeighbors())
-         cacheT += ("Affinity Mapper", affinityCfg.mapper())
+         cacheT += ("Affinity Partitions", safe(affinityCfg.partitions()))
+         cacheT += ("Affinity Default Replicas", safe(affinityCfg.defaultReplicas()))
+         cacheT += ("Affinity Exclude Neighbors", safe(affinityCfg.excludeNeighbors()))
+         cacheT += ("Affinity Mapper", safe(affinityCfg.mapper()))
  
          cacheT += ("Preload Mode", preloadCfg.mode())
          cacheT += ("Preload Batch Size", preloadCfg.batchSize())
@@@ -830,30 -835,41 +832,45 @@@
  
          cacheT += ("Default Lock Timeout", defaultCfg.txLockTimeout())
          cacheT += ("Default Query Timeout", defaultCfg.queryTimeout())
-         cacheT += ("Query Indexing Enabled", cfg.queryIndexEnabled())
+         cacheT += ("Query Indexing Enabled", bool2Str(cfg.queryIndexEnabled()))
          cacheT += ("Query Iterators Number", cfg.maxQueryIteratorCount())
-         cacheT += ("Indexing SPI Name", cfg.indexingSpiName())
-         cacheT += ("Cache Interceptor", cfg.interceptor())
+         cacheT += ("Metadata type count", cfg.typeMeta().size())
+         cacheT += ("Indexing SPI Name", safe(cfg.indexingSpiName()))
+         cacheT += ("Cache Interceptor", safe(cfg.interceptor()))
+ 
+         cacheT += ("Store Enabled", bool2Str(storeCfg.enabled()))
+         cacheT += ("Store", safe(storeCfg.store()))
 -        cacheT += ("Store Values In Bytes", storeCfg.valueBytes())
 -        cacheT += ("Configured JDBC Store", bool2Str(cfg.jdbcStore()))
++        cacheT += ("Configured JDBC Store", bool2Str(storeCfg.jdbcStore()))
+ 
 -        cacheT += ("Off-Heap Size", cfg.offsetHeapMaxMemory())
++        cacheT += ("Read Through", bool2Str(storeCfg.readThrough()))
++        cacheT += ("Write Through", bool2Str(storeCfg.writeThrough()))
+ 
 -        cacheT += ("Write-Behind Enabled", bool2Str(writeBehind.enabled()))
 -        cacheT += ("Write-Behind Flush Size", writeBehind.flushSize())
 -        cacheT += ("Write-Behind Frequency", writeBehind.flushFrequency())
 -        cacheT += ("Write-Behind Flush Threads Count", writeBehind.flushThreadCount())
 -        cacheT += ("Write-Behind Batch Size", writeBehind.batchSize())
++        cacheT += ("Write-Behind Enabled", bool2Str(storeCfg.enabled()))
++        cacheT += ("Write-Behind Flush Size", storeCfg.flushSize())
++        cacheT += ("Write-Behind Frequency", storeCfg.flushFrequency())
++        cacheT += ("Write-Behind Flush Threads Count", storeCfg.flushThreadCount())
++        cacheT += ("Write-Behind Batch Size", storeCfg.batchSize())
  
          cacheT += ("Concurrent Asynchronous Operations Number", cfg.maxConcurrentAsyncOperations())
          cacheT += ("Memory Mode", cfg.memoryMode())
  
 +        cacheT += ("Store Values In Bytes", cfg.valueBytes())
 +
 +        cacheT += ("Off-Heap Size", cfg.offsetHeapMaxMemory())
 +
-         cacheT += ("Store Enabled", storeCfg.enabled())
-         cacheT += ("Store", storeCfg.store())
-         cacheT += ("Store Factory", storeCfg.storeFactory())
- 
-         cacheT += ("Store Read-Through", storeCfg.readThrough())
-         cacheT += ("Store Write-Through", storeCfg.writeThrough())
+         cacheT += ("Loader Factory Class Name", safe(cfg.loaderFactory()))
+         cacheT += ("Writer Factory Class Name", safe(cfg.writerFactory()))
+         cacheT += ("Expiry Policy Factory Class Name", safe(cfg.expiryPolicyFactory()))
  
-         cacheT += ("Write-Behind Enabled", storeCfg.writeBehindEnabled())
-         cacheT += ("Write-Behind Flush Size", storeCfg.flushSize())
-         cacheT += ("Write-Behind Frequency", storeCfg.flushFrequency())
-         cacheT += ("Write-Behind Flush Threads Count", storeCfg.flushThreadCount())
-         cacheT += ("Write-Behind Batch Size", storeCfg.batchSize())
+         if (queryCfg != null) {
+             cacheT +=("Query Type Resolver", safe(queryCfg.typeResolver()))
+             cacheT +=("Query Indexing Primitive Key", bool2Str(queryCfg.indexPrimitiveKey()))
+             cacheT +=("Query Indexing Primitive Value", bool2Str(queryCfg.indexPrimitiveValue()))
+             cacheT +=("Query Fixed Typing", bool2Str(queryCfg.indexFixedTyping()))
+             cacheT +=("Query Escaped Names", bool2Str(queryCfg.escapeAll()))
+         }
+         else
+             cacheT += ("Query Configuration", NA)
  
          println(title)
  


[04/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-2' into ignite-239

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


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

Branch: refs/heads/ignite-337
Commit: 5830deb20bf02705cb82203db074dfc2bb01473d
Parents: 3942853 4e7463d
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 16:04:40 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 16:04:40 2015 +0300

----------------------------------------------------------------------
 .../main/java/org/apache/ignite/IgniteFs.java   |   2 +-
 .../ignite/events/DiscoveryCustomEvent.java     |  56 --------
 .../org/apache/ignite/events/EventType.java     |  14 +-
 .../java/org/apache/ignite/igfs/package.html    |   2 +-
 .../internal/events/DiscoveryCustomEvent.java   |  68 +++++++++
 .../discovery/GridDiscoveryManager.java         |   7 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |  10 +-
 .../visor/node/VisorBasicConfiguration.java     |  17 ---
 .../node/VisorNodeEventsCollectorTask.java      |  10 +-
 .../internal/visor/node/VisorNodeGcTask.java    |  10 +-
 .../internal/visor/node/VisorNodePingTask.java  |  10 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   9 +-
 .../internal/GridDiscoveryEventSelfTest.java    |   9 +-
 ...dStartupWithUndefinedIgniteHomeSelfTest.java | 103 ++++++++++++++
 .../testsuites/IgniteKernalSelfTestSuite.java   |   1 +
 .../java/org/apache/ignite/igfs/package.html    |   2 +-
 .../testsuites/IgniteHadoopTestSuite.java       |   7 +-
 .../commands/alert/VisorAlertCommand.scala      |   8 +-
 .../commands/cache/VisorCacheCommand.scala      |  82 +++++++----
 .../config/VisorConfigurationCommand.scala      | 140 ++++++++++---------
 .../commands/disco/VisorDiscoveryCommand.scala  |   2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |  64 ++++++---
 .../commands/tasks/VisorTasksCommandSpec.scala  |   2 +-
 23 files changed, 392 insertions(+), 243 deletions(-)
----------------------------------------------------------------------



[22/50] incubator-ignite git commit: # sprint-2 - fixing comments.

Posted by sb...@apache.org.
# sprint-2 - fixing comments.


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

Branch: refs/heads/ignite-337
Commit: 3a77acf759cd30bbb7bdcb51ab8e1bcecb273639
Parents: 16105ec
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Sat Feb 28 09:49:15 2015 -0800
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Sat Feb 28 09:49:15 2015 -0800

----------------------------------------------------------------------
 .../ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3a77acf7/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
index 0473280..55ba1a7 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
@@ -131,7 +131,8 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
 
             int updated;
 
-            // Try update first.
+            // Try update first. If it does not work, then try insert.
+            // Some databases would allow these to be done in one 'upsert' operation.
             try (PreparedStatement st = conn.prepareStatement(
                 "update PERSONS set firstName=?, lastName=? where id=?")) {
                 st.setString(1, val.getFirstName());


[13/50] incubator-ignite git commit: review ignite-311

Posted by sb...@apache.org.
review ignite-311


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

Branch: refs/heads/ignite-337
Commit: 9fb1eeb55e8eadf9190d0d675f65e5020543ad39
Parents: 2ef2271
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Fri Feb 27 19:09:27 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Fri Feb 27 19:09:27 2015 +0300

----------------------------------------------------------------------
 .../apache/ignite/internal/GridProperties.java  | 79 --------------------
 .../ignite/internal/GridUpdateNotifier.java     |  2 +-
 .../apache/ignite/internal/IgniteKernal.java    |  2 +-
 .../ignite/internal/IgniteProperties.java       | 79 ++++++++++++++++++++
 .../ignite/internal/IgniteVersionUtils.java     |  8 +-
 .../plugin/IgnitePluginProcessor.java           | 37 +++------
 .../internal/GridUpdateNotifierSelfTest.java    |  2 +-
 7 files changed, 98 insertions(+), 111 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/main/java/org/apache/ignite/internal/GridProperties.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridProperties.java b/modules/core/src/main/java/org/apache/ignite/internal/GridProperties.java
deleted file mode 100644
index 89110af..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridProperties.java
+++ /dev/null
@@ -1,79 +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;
-
-import java.io.*;
-import java.util.*;
-
-/**
- * Ignite properties holder.
- */
-public class GridProperties {
-    /** Properties file path. */
-    private static final String FILE_PATH = "ignite.properties";
-
-    /** Properties. */
-    private static final Properties PROPS;
-
-    /**
-     *
-     */
-    static {
-        PROPS = new Properties();
-
-        readProperties(FILE_PATH, PROPS, true);
-    }
-
-    /**
-     * @param path Path.
-     * @param props Properties.
-     * @param throwExc Flag indicating whether to throw an exception or not.
-     */
-    public static void readProperties(String path, Properties props, boolean throwExc) {
-        try (InputStream is = IgniteVersionUtils.class.getClassLoader().getResourceAsStream(path)) {
-            if (is == null) {
-                if (throwExc)
-                    throw new RuntimeException("Failed to find properties file: " + path);
-                else
-                    return;
-            }
-
-            props.load(is);
-        }
-        catch (IOException e) {
-            throw new RuntimeException("Failed to read properties file: " + path, e);
-        }
-    }
-
-    /**
-     * Gets property value.
-     *
-     * @param key Property key.
-     * @return Property value (possibly empty string, but never {@code null}).
-     */
-    public static String get(String key) {
-        return PROPS.getProperty(key, "");
-    }
-
-    /**
-     *
-     */
-    private GridProperties() {
-        // No-op.
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/main/java/org/apache/ignite/internal/GridUpdateNotifier.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridUpdateNotifier.java b/modules/core/src/main/java/org/apache/ignite/internal/GridUpdateNotifier.java
index d1436a9..830481f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridUpdateNotifier.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridUpdateNotifier.java
@@ -42,7 +42,7 @@ import static java.net.URLEncoder.*;
  */
 class GridUpdateNotifier {
     /** Access URL to be used to access latest version data. */
-    private static final String UPD_STATUS_PARAMS = GridProperties.get("ignite.update.status.params");
+    private static final String UPD_STATUS_PARAMS = IgniteProperties.get("ignite.update.status.params");
 
     /** Throttling for logging out. */
     private static final long THROTTLE_PERIOD = 24 * 60 * 60 * 1000; // 1 day.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index c21ceb3..9c92edd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
@@ -100,7 +100,7 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
     private static final long serialVersionUID = 0L;
 
     /** Compatible versions. */
-    private static final String COMPATIBLE_VERS = GridProperties.get("ignite.compatible.vers");
+    private static final String COMPATIBLE_VERS = IgniteProperties.get("ignite.compatible.vers");
 
     /** Ignite site that is shown in log messages. */
     static final String SITE = "www.gridgain.com";

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/main/java/org/apache/ignite/internal/IgniteProperties.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteProperties.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteProperties.java
new file mode 100644
index 0000000..74c0ce4
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteProperties.java
@@ -0,0 +1,79 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Ignite properties holder.
+ */
+public class IgniteProperties {
+    /** Properties file path. */
+    private static final String FILE_PATH = "ignite.properties";
+
+    /** Properties. */
+    private static final Properties PROPS;
+
+    /**
+     *
+     */
+    static {
+        PROPS = new Properties();
+
+        readProperties(FILE_PATH, PROPS, true);
+    }
+
+    /**
+     * @param path Path.
+     * @param props Properties.
+     * @param throwExc Flag indicating whether to throw an exception or not.
+     */
+    public static void readProperties(String path, Properties props, boolean throwExc) {
+        try (InputStream is = IgniteVersionUtils.class.getClassLoader().getResourceAsStream(path)) {
+            if (is == null) {
+                if (throwExc)
+                    throw new RuntimeException("Failed to find properties file: " + path);
+                else
+                    return;
+            }
+
+            props.load(is);
+        }
+        catch (IOException e) {
+            throw new RuntimeException("Failed to read properties file: " + path, e);
+        }
+    }
+
+    /**
+     * Gets property value.
+     *
+     * @param key Property key.
+     * @return Property value (possibly empty string, but never {@code null}).
+     */
+    public static String get(String key) {
+        return PROPS.getProperty(key, "");
+    }
+
+    /**
+     *
+     */
+    private IgniteProperties() {
+        // No-op.
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/main/java/org/apache/ignite/internal/IgniteVersionUtils.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteVersionUtils.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteVersionUtils.java
index 51668b6..3c47f23 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteVersionUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteVersionUtils.java
@@ -54,13 +54,13 @@ public class IgniteVersionUtils {
      * Static initializer.
      */
     static {
-        VER_STR = GridProperties.get("ignite.version");
+        VER_STR = IgniteProperties.get("ignite.version");
 
-        BUILD_TSTAMP = Long.valueOf(GridProperties.get("ignite.build"));
+        BUILD_TSTAMP = Long.valueOf(IgniteProperties.get("ignite.build"));
         BUILD_TSTAMP_STR = new SimpleDateFormat("yyyyMMdd").format(new Date(BUILD_TSTAMP * 1000));
 
-        REV_HASH_STR = GridProperties.get("ignite.revision");
-        RELEASE_DATE_STR = GridProperties.get("ignite.rel.date");
+        REV_HASH_STR = IgniteProperties.get("ignite.revision");
+        RELEASE_DATE_STR = IgniteProperties.get("ignite.rel.date");
 
         String rev = REV_HASH_STR.length() > 8 ? REV_HASH_STR.substring(0, 8) : REV_HASH_STR;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
index aca8fb8..05f227b 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
@@ -42,9 +42,6 @@ public class IgnitePluginProcessor extends GridProcessorAdapter {
     /** */
     private volatile Map<Class<?>, Object[]> extensions;
 
-    /** Plugin information. */
-    public static final String PLUGIN_INFO = "Configured plugins: ";
-
     /**
      *
      * @param ctx Kernal context.
@@ -206,32 +203,22 @@ public class IgnitePluginProcessor extends GridProcessorAdapter {
     }
 
     /**
-     * Plugin information.
-     */
-    private String pluginInfo() {
-        Collection<PluginProvider> plugins = ctx.plugins().allProviders();
-
-        if (plugins.size() == 0)
-            return U.nl() + ">>>    " + PLUGIN_INFO + "none";
-
-        String info = U.nl() + ">>>    " + PLUGIN_INFO + U.nl();
-
-        for (PluginProvider plugin : plugins)
-            info += ">>>    " + plugin.name() + " " + plugin.version() + U.nl() +
-                ">>>    " + plugin.copyright();
-
-        return info;
-    }
-
-    /**
      * Print plugin information.
      */
     private void ackPluginsInfo() {
-        if (log.isQuiet())
-            U.quiet(false, pluginInfo().split(U.nl() + ">>> "));
+        U.quietAndInfo(log, "Configured plugins:");
 
-        if (log.isInfoEnabled())
-            log.info(pluginInfo());
+        if (plugins.isEmpty()) {
+            U.quietAndInfo(log, "  ^-- None");
+            U.quietAndInfo(log, "");
+        }
+        else {
+            for (PluginProvider plugin : plugins.values()) {
+                U.quietAndInfo(log, "  ^-- " + plugin.name() + " " + plugin.version());
+                U.quietAndInfo(log, "  ^-- " + plugin.copyright());
+                U.quietAndInfo(log, "");
+            }
+        }
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9fb1eeb5/modules/core/src/test/java/org/apache/ignite/internal/GridUpdateNotifierSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/GridUpdateNotifierSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/GridUpdateNotifierSelfTest.java
index 8cc0b28..07bcf48 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/GridUpdateNotifierSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/GridUpdateNotifierSelfTest.java
@@ -36,7 +36,7 @@ public class GridUpdateNotifierSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testNotifier() throws Exception {
-        GridUpdateNotifier ntf = new GridUpdateNotifier(null, GridProperties.get("ignite.version"),
+        GridUpdateNotifier ntf = new GridUpdateNotifier(null, IgniteProperties.get("ignite.version"),
             IgniteKernal.SITE, TEST_GATEWAY, false);
 
         ntf.checkForNewVersion(new SelfExecutor(), log);


[35/50] incubator-ignite git commit: Improve IgniteCacheExpiryPolicyAbstractTest.

Posted by sb...@apache.org.
Improve IgniteCacheExpiryPolicyAbstractTest.


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

Branch: refs/heads/ignite-337
Commit: 0086e9cd2ab652d58adc4edf016932388de9686a
Parents: c847e88
Author: sevdokimov <se...@gridgain.com>
Authored: Mon Mar 2 14:23:19 2015 +0300
Committer: sevdokimov <se...@gridgain.com>
Committed: Mon Mar 2 14:25:02 2015 +0300

----------------------------------------------------------------------
 .../IgniteCacheExpiryPolicyAbstractTest.java    | 38 ++------------------
 1 file changed, 3 insertions(+), 35 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0086e9cd/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/expiry/IgniteCacheExpiryPolicyAbstractTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/expiry/IgniteCacheExpiryPolicyAbstractTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/expiry/IgniteCacheExpiryPolicyAbstractTest.java
index 3110cbc..e04659c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/expiry/IgniteCacheExpiryPolicyAbstractTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/expiry/IgniteCacheExpiryPolicyAbstractTest.java
@@ -103,23 +103,7 @@ public abstract class IgniteCacheExpiryPolicyAbstractTest extends IgniteCacheAbs
      * @throws Exception If failed.
      */
     public void testZeroOnUpdate() throws Exception {
-        factory = new Factory<ExpiryPolicy>() {
-            @Override public ExpiryPolicy create() {
-                return new ExpiryPolicy() {
-                    @Override public Duration getExpiryForCreation() {
-                        return null;
-                    }
-
-                    @Override public Duration getExpiryForAccess() {
-                        return null;
-                    }
-
-                    @Override public Duration getExpiryForUpdate() {
-                        return Duration.ZERO;
-                    }
-                };
-            }
-        };
+        factory = new FactoryBuilder.SingletonFactory<>(new TestPolicy(null, 0L, null));
 
         startGrids();
 
@@ -150,23 +134,7 @@ public abstract class IgniteCacheExpiryPolicyAbstractTest extends IgniteCacheAbs
      * @throws Exception If failed.
      */
     public void testZeroOnAccess() throws Exception {
-        factory = new Factory<ExpiryPolicy>() {
-            @Override public ExpiryPolicy create() {
-                return new ExpiryPolicy() {
-                    @Override public Duration getExpiryForCreation() {
-                        return null;
-                    }
-
-                    @Override public Duration getExpiryForAccess() {
-                        return Duration.ZERO;
-                    }
-
-                    @Override public Duration getExpiryForUpdate() {
-                        return null;
-                    }
-                };
-            }
-        };
+        factory = new FactoryBuilder.SingletonFactory<>(new TestPolicy(null, null, 0L));
 
         startGrids();
 
@@ -1087,7 +1055,7 @@ public abstract class IgniteCacheExpiryPolicyAbstractTest extends IgniteCacheAbs
     /**
      *
      */
-    private class TestPolicy implements ExpiryPolicy {
+    private static class TestPolicy implements ExpiryPolicy {
         /** */
         private Long create;
 


[23/50] incubator-ignite git commit: # sprint-2 - javadoc fixes.

Posted by sb...@apache.org.
# sprint-2 - javadoc fixes.


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

Branch: refs/heads/ignite-337
Commit: 036bd71537630b082b747f518172da6ebfe11105
Parents: 3a77acf
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Sat Feb 28 19:05:42 2015 -0800
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Sat Feb 28 19:05:42 2015 -0800

----------------------------------------------------------------------
 .../src/main/java/org/apache/ignite/cache/store/CacheStore.java  | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/036bd715/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStore.java b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStore.java
index 848df39..eefcfb3 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStore.java
@@ -119,7 +119,7 @@ public interface CacheStore<K, V> extends CacheLoader<K, V>, CacheWriter<K, V> {
     /**
      * Loads all values from underlying persistent storage. Note that keys are not
      * passed, so it is up to implementation to figure out what to load. This method
-     * is called whenever {@link org.apache.ignite.cache.GridCache#loadCache(org.apache.ignite.lang.IgniteBiPredicate, long, Object...)}
+     * is called whenever {@link org.apache.ignite.IgniteCache#loadCache(IgniteBiPredicate, Object...)}
      * method is invoked which is usually to preload the cache from persistent storage.
      * <p>
      * This method is optional, and cache implementation does not depend on this
@@ -132,7 +132,7 @@ public interface CacheStore<K, V> extends CacheLoader<K, V>, CacheWriter<K, V> {
      *
      * @param clo Closure for loaded values.
      * @param args Arguments passes into
-     *      {@link org.apache.ignite.cache.GridCache#loadCache(org.apache.ignite.lang.IgniteBiPredicate, long, Object...)} method.
+     *      {@link org.apache.ignite.IgniteCache#loadCache(IgniteBiPredicate, Object...)} method.
      * @throws CacheLoaderException If loading failed.
      */
     public void loadCache(IgniteBiInClosure<K, V> clo, @Nullable Object... args) throws CacheLoaderException;


[44/50] incubator-ignite git commit: Merge branch 'ignite-270' into sprint-2

Posted by sb...@apache.org.
Merge branch 'ignite-270' into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 2511ebe18c564e43e642bc879ffe44b02497c90a
Parents: b0e6ab1 18548b2
Author: anovikov <an...@gridgain.com>
Authored: Mon Mar 2 21:43:59 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Mon Mar 2 21:43:59 2015 +0700

----------------------------------------------------------------------
 modules/scalar/pom.xml | 6 ++++++
 1 file changed, 6 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2511ebe1/modules/scalar/pom.xml
----------------------------------------------------------------------


[27/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-11' into sprint-2

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


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

Branch: refs/heads/ignite-337
Commit: c9f46c1b39577c82d1084f13ffedb965a8e2c83c
Parents: 036bd71 6130f7e
Author: sevdokimov <se...@jetbrains.com>
Authored: Sun Mar 1 22:59:09 2015 +0300
Committer: sevdokimov <se...@jetbrains.com>
Committed: Sun Mar 1 22:59:09 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/util/IgniteUtils.java       |  90 ++++++++++--
 .../spi/discovery/tcp/TcpDiscoverySpi.java      | 137 +++++++++++--------
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   | 116 ++++++++++++++++
 3 files changed, 275 insertions(+), 68 deletions(-)
----------------------------------------------------------------------



[38/50] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-2' into sprint-2

Posted by sb...@apache.org.
Merge remote-tracking branch 'origin/sprint-2' into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 3be22ab1f4d9e9096b5600cf8728b19800760ccc
Parents: ea6a1c0 0086e9c
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Mar 2 16:00:38 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Mar 2 16:00:38 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/visor/cache/VisorCache.java | 190 ++------
 .../cache/VisorCacheAffinityConfiguration.java  |  53 +-
 .../visor/cache/VisorCacheConfiguration.java    | 484 ++++---------------
 .../cache/VisorCacheDefaultConfiguration.java   |  27 +-
 .../cache/VisorCacheEvictionConfiguration.java  |  81 +---
 .../cache/VisorCacheNearConfiguration.java      |  42 +-
 .../cache/VisorCachePreloadConfiguration.java   |  54 +--
 .../cache/VisorCacheStoreConfiguration.java     | 148 +++++-
 .../VisorCacheWriteBehindConfiguration.java     | 137 ------
 .../visor/node/VisorAtomicConfiguration.java    |  27 +-
 .../visor/node/VisorBasicConfiguration.java     | 180 +------
 .../node/VisorCacheQueryConfiguration.java      |  45 +-
 .../node/VisorExecutorServiceConfiguration.java |  54 +--
 .../visor/node/VisorGridConfiguration.java      | 177 +------
 .../visor/node/VisorIgfsConfiguration.java      | 244 ++--------
 .../visor/node/VisorLifecycleConfiguration.java |   9 +-
 .../visor/node/VisorMetricsConfiguration.java   |  29 +-
 .../node/VisorPeerToPeerConfiguration.java      |  28 +-
 .../visor/node/VisorQueryConfiguration.java     |  65 +--
 .../visor/node/VisorRestConfiguration.java      |  80 +--
 .../node/VisorSegmentationConfiguration.java    |  45 +-
 .../visor/node/VisorSpisConfiguration.java      |  92 +---
 .../node/VisorTransactionConfiguration.java     |  62 +--
 .../internal/visor/util/VisorTaskUtils.java     |   4 +-
 .../core/src/test/config/store/jdbc/Ignite.xml  |  63 ++-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |  38 +-
 .../ignite/schema/generator/XmlGenerator.java   |   8 +-
 .../apache/ignite/schema/model/PojoField.java   |  11 +-
 .../apache/ignite/schema/load/model/Ignite.xml  | 133 +++--
 .../commands/cache/VisorCacheCommand.scala      |  25 +-
 .../yardstick/config/ignite-store-config.xml    |  15 +-
 31 files changed, 606 insertions(+), 2044 deletions(-)
----------------------------------------------------------------------



[33/50] incubator-ignite git commit: # IGNITE-339 Review.

Posted by sb...@apache.org.
# IGNITE-339 Review.


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

Branch: refs/heads/ignite-337
Commit: c847e88513d47925a03e84faf8739b6e7b012755
Parents: 60e0ecb
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Mar 2 16:44:13 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Mar 2 16:44:13 2015 +0700

----------------------------------------------------------------------
 .../internal/visor/cache/VisorCacheConfiguration.java | 10 ----------
 .../visor/commands/cache/VisorCacheCommand.scala      | 14 +++++---------
 2 files changed, 5 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c847e885/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
index 2ad0e49..a6ec05c 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
@@ -48,9 +48,6 @@ public class VisorCacheConfiguration implements Serializable {
     /** Cache atomicity mode */
     private CacheAtomicityMode atomicityMode;
 
-    /** Cache atomic sequence reserve size */
-    private int atomicSeqReserveSize;
-
     /** Cache atomicity write ordering mode. */
     private CacheAtomicWriteOrderMode atomicWriteOrderMode;
 
@@ -226,13 +223,6 @@ public class VisorCacheConfiguration implements Serializable {
     }
 
     /**
-     * @return Cache atomic sequence reserve size
-     */
-    public int atomicSequenceReserveSize() {
-        return atomicSeqReserveSize;
-    }
-
-    /**
      * @return Cache atomicity write ordering mode.
      */
     public CacheAtomicWriteOrderMode atomicWriteOrderMode() {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c847e885/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
index 7232221..e2ca05b 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
@@ -783,7 +783,6 @@ object VisorCacheCommand {
 
         cacheT += ("Mode", cfg.mode)
         cacheT += ("Atomicity Mode", safe(cfg.atomicityMode))
-        cacheT += ("Atomic Sequence Reserve Size", cfg.atomicSequenceReserveSize)
         cacheT += ("Atomic Write Ordering Mode", safe(cfg.atomicWriteOrderMode))
         cacheT += ("Statistic Enabled", bool2Str(cfg.statisticsEnabled()))
         cacheT += ("Management Enabled", bool2Str(cfg.managementEnabled()))
@@ -839,11 +838,10 @@ object VisorCacheCommand {
         cacheT += ("Cache Interceptor", safe(cfg.interceptor()))
 
         cacheT += ("Store Enabled", bool2Str(storeCfg.enabled()))
-        cacheT += ("Store", safe(storeCfg.store()))
-        cacheT += ("Configured JDBC Store", bool2Str(storeCfg.jdbcStore()))
-
-        cacheT += ("Read Through", bool2Str(storeCfg.readThrough()))
-        cacheT += ("Write Through", bool2Str(storeCfg.writeThrough()))
+        cacheT += ("Store Сlass", safe(storeCfg.store()))
+        cacheT += ("Store Factory Сlass", storeCfg.storeFactory())
+        cacheT += ("Store Read Through", bool2Str(storeCfg.readThrough()))
+        cacheT += ("Store Write Through", bool2Str(storeCfg.writeThrough()))
 
         cacheT += ("Write-Behind Enabled", bool2Str(storeCfg.enabled()))
         cacheT += ("Write-Behind Flush Size", storeCfg.flushSize())
@@ -853,9 +851,7 @@ object VisorCacheCommand {
 
         cacheT += ("Concurrent Asynchronous Operations Number", cfg.maxConcurrentAsyncOperations())
         cacheT += ("Memory Mode", cfg.memoryMode())
-
-        cacheT += ("Store Values Bytes", cfg.valueBytes())
-
+        cacheT += ("Keep Values Bytes", cfg.valueBytes())
         cacheT += ("Off-Heap Size", cfg.offsetHeapMaxMemory())
 
         cacheT += ("Loader Factory Class Name", safe(cfg.loaderFactory()))


[29/50] incubator-ignite git commit: Merge branches 'ignite-377' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2

Posted by sb...@apache.org.
Merge branches 'ignite-377' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 13e2d1f678cea51f18b7c5ae2ec48157eccbf4c3
Parents: c9f46c1 061ea8a
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Mar 2 15:55:59 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Mar 2 15:55:59 2015 +0700

----------------------------------------------------------------------
 .../core/src/test/config/store/jdbc/Ignite.xml  |  63 ++++++---
 .../ignite/schema/generator/XmlGenerator.java   |   8 +-
 .../apache/ignite/schema/model/PojoField.java   |  11 +-
 .../apache/ignite/schema/load/model/Ignite.xml  | 133 ++++++++++++++-----
 .../yardstick/config/ignite-store-config.xml    |  15 ++-
 5 files changed, 168 insertions(+), 62 deletions(-)
----------------------------------------------------------------------



[34/50] incubator-ignite git commit: Merge branch 'sprint-2' into ignite-337

Posted by sb...@apache.org.
Merge branch 'sprint-2' into ignite-337


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

Branch: refs/heads/ignite-337
Commit: aa7ce405cb1603a099e23a7feca008e5eda2134c
Parents: 472ef05 c847e88
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Mar 2 13:23:08 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Mar 2 13:23:08 2015 +0300

----------------------------------------------------------------------
 .../store/CacheNodeWithStoreStartup.java        |   6 +-
 .../store/jdbc/CacheJdbcPersonStore.java        | 115 ++---
 .../apache/ignite/cache/store/CacheStore.java   |   4 +-
 .../ignite/cache/store/CacheStoreAdapter.java   |   2 +-
 .../ignite/cache/store/CacheStoreSession.java   |  17 +-
 .../apache/ignite/internal/GridProperties.java  |  78 ---
 .../ignite/internal/GridUpdateNotifier.java     |   2 +-
 .../apache/ignite/internal/IgniteKernal.java    |  18 +-
 .../ignite/internal/IgniteProperties.java       |  79 +++
 .../ignite/internal/IgniteVersionUtils.java     |   8 +-
 .../processors/cache/GridCacheStoreManager.java |   6 +-
 .../plugin/IgnitePluginProcessor.java           |  24 +
 .../ignite/internal/util/IgniteUtils.java       |  90 +++-
 .../ignite/internal/visor/cache/VisorCache.java | 190 ++------
 .../cache/VisorCacheAffinityConfiguration.java  |  53 +-
 .../visor/cache/VisorCacheConfiguration.java    | 484 ++++---------------
 .../cache/VisorCacheDefaultConfiguration.java   |  27 +-
 .../cache/VisorCacheEvictionConfiguration.java  |  81 +---
 .../cache/VisorCacheNearConfiguration.java      |  42 +-
 .../cache/VisorCachePreloadConfiguration.java   |  54 +--
 .../cache/VisorCacheStoreConfiguration.java     | 148 +++++-
 .../VisorCacheWriteBehindConfiguration.java     | 137 ------
 .../visor/node/VisorAtomicConfiguration.java    |  27 +-
 .../visor/node/VisorBasicConfiguration.java     | 180 +------
 .../node/VisorCacheQueryConfiguration.java      |  45 +-
 .../node/VisorExecutorServiceConfiguration.java |  54 +--
 .../visor/node/VisorGridConfiguration.java      | 177 +------
 .../visor/node/VisorIgfsConfiguration.java      | 244 ++--------
 .../visor/node/VisorLifecycleConfiguration.java |   9 +-
 .../visor/node/VisorMetricsConfiguration.java   |  29 +-
 .../node/VisorPeerToPeerConfiguration.java      |  28 +-
 .../visor/node/VisorQueryConfiguration.java     |  65 +--
 .../visor/node/VisorRestConfiguration.java      |  80 +--
 .../node/VisorSegmentationConfiguration.java    |  45 +-
 .../visor/node/VisorSpisConfiguration.java      |  92 +---
 .../node/VisorTransactionConfiguration.java     |  62 +--
 .../internal/visor/util/VisorTaskUtils.java     |   4 +-
 .../apache/ignite/plugin/PluginProvider.java    |   5 +
 .../spi/discovery/tcp/TcpDiscoverySpi.java      | 137 +++---
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   | 116 +++++
 .../core/src/test/config/store/jdbc/Ignite.xml  |  63 ++-
 .../internal/GridUpdateNotifierSelfTest.java    |   2 +-
 .../junits/cache/TestCacheSession.java          |   5 +
 .../cache/TestThreadLocalCacheSession.java      |   5 +
 .../ignite/schema/generator/XmlGenerator.java   |   8 +-
 .../apache/ignite/schema/model/PojoField.java   |  11 +-
 .../apache/ignite/schema/load/model/Ignite.xml  | 133 +++--
 .../commands/cache/VisorCacheCommand.scala      |  25 +-
 .../yardstick/config/ignite-store-config.xml    |  15 +-
 49 files changed, 1079 insertions(+), 2252 deletions(-)
----------------------------------------------------------------------



[48/50] incubator-ignite git commit: Merge branch 'ignite-382' into sprint-2

Posted by sb...@apache.org.
Merge branch 'ignite-382' into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 3b309f250e872fff4ea290fb2b8acb7388fadfb2
Parents: 028e446 f252ee4
Author: anovikov <an...@gridgain.com>
Authored: Mon Mar 2 21:48:07 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Mon Mar 2 21:48:07 2015 +0700

----------------------------------------------------------------------
 examples/pom-standalone.xml                       | 2 +-
 modules/core/src/main/resources/ignite.properties | 2 +-
 pom.xml                                           | 4 ++--
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------



[28/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-2' into ignite-239

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


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

Branch: refs/heads/ignite-337
Commit: 0b1eccf96a260b3208c153ead6b4e314798726ad
Parents: 0dfe349 c9f46c1
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Mar 2 11:40:06 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Mar 2 11:40:06 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/util/IgniteUtils.java       |  90 ++++++++++--
 .../spi/discovery/tcp/TcpDiscoverySpi.java      | 137 +++++++++++--------
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   | 116 ++++++++++++++++
 3 files changed, 275 insertions(+), 68 deletions(-)
----------------------------------------------------------------------



[30/50] incubator-ignite git commit: Merge branches 'ignite-339' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-339

Posted by sb...@apache.org.
Merge branches 'ignite-339' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-339


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

Branch: refs/heads/ignite-337
Commit: 60e0ecb2e269e6af2b0c04df2aed6f494657b03c
Parents: 5d3a2be 13e2d1f
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Mar 2 15:59:00 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Mar 2 15:59:00 2015 +0700

----------------------------------------------------------------------
 .../store/CacheNodeWithStoreStartup.java        |   6 +-
 .../store/jdbc/CacheJdbcPersonStore.java        | 115 ++++++----------
 .../apache/ignite/cache/store/CacheStore.java   |   4 +-
 .../ignite/cache/store/CacheStoreAdapter.java   |   2 +-
 .../ignite/cache/store/CacheStoreSession.java   |  17 ++-
 .../processors/cache/GridCacheStoreManager.java |   6 +-
 .../ignite/internal/util/IgniteUtils.java       |  90 ++++++++++--
 .../spi/discovery/tcp/TcpDiscoverySpi.java      | 137 +++++++++++--------
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   | 116 ++++++++++++++++
 .../core/src/test/config/store/jdbc/Ignite.xml  |  63 +++++++--
 .../junits/cache/TestCacheSession.java          |   5 +
 .../cache/TestThreadLocalCacheSession.java      |   5 +
 .../ignite/schema/generator/XmlGenerator.java   |   8 +-
 .../apache/ignite/schema/model/PojoField.java   |  11 +-
 .../apache/ignite/schema/load/model/Ignite.xml  | 133 +++++++++++++-----
 .../yardstick/config/ignite-store-config.xml    |  15 +-
 16 files changed, 521 insertions(+), 212 deletions(-)
----------------------------------------------------------------------



[26/50] incubator-ignite git commit: #ignite-239: small refactoring.

Posted by sb...@apache.org.
#ignite-239: small refactoring.


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

Branch: refs/heads/ignite-337
Commit: 0dfe349c28e2fc24b3b2e092f4f36c1d63f84ff3
Parents: 55669d4
Author: ivasilinets <va...@gmail.com>
Authored: Sun Mar 1 21:21:11 2015 +0300
Committer: ivasilinets <va...@gmail.com>
Committed: Sun Mar 1 21:21:11 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/internal/IgnitionEx.java  | 28 ++++++++++----------
 1 file changed, 14 insertions(+), 14 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0dfe349c/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index 9770205..c2c23f7 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1393,7 +1393,7 @@ public class IgnitionEx {
                 Class helperCls = Class.forName("org.apache.ignite.util.GridConfigurationHelper");
 
                 helperCls.getMethod("overrideConfiguration", IgniteConfiguration.class, Properties.class,
-                        String.class, IgniteLogger.class).invoke(helperCls, myCfg, System.getProperties(), name, log);
+                    String.class, IgniteLogger.class).invoke(helperCls, myCfg, System.getProperties(), name, log);
             }
             catch (Exception ignored) {
                 // No-op.
@@ -1522,14 +1522,14 @@ public class IgnitionEx {
             // for correct segment after segmentation happens.
             if (!F.isEmpty(cfg.getSegmentationResolvers()) && segPlc == RESTART_JVM && !cfg.isWaitForSegmentOnStart()) {
                 U.warn(log, "Found potential configuration problem (forgot to enable waiting for segment" +
-                        "on start?) [segPlc=" + segPlc + ", wait=false]");
+                    "on start?) [segPlc=" + segPlc + ", wait=false]");
             }
 
             myCfg.setTransactionConfiguration(myCfg.getTransactionConfiguration() != null ?
-                    new TransactionConfiguration(myCfg.getTransactionConfiguration()) : null);
+                new TransactionConfiguration(myCfg.getTransactionConfiguration()) : null);
 
             myCfg.setConnectorConfiguration(myCfg.getConnectorConfiguration() != null ?
-                    new ConnectorConfiguration(myCfg.getConnectorConfiguration()) : null);
+                new ConnectorConfiguration(myCfg.getConnectorConfiguration()) : null);
 
             // Local host.
             String locHost = IgniteSystemProperties.getString(IGNITE_LOCAL_HOST);
@@ -1546,7 +1546,7 @@ public class IgnitionEx {
             if (!F.isEmpty(depModeName)) {
                 if (!F.isEmpty(myCfg.getCacheConfiguration())) {
                     U.quietAndInfo(log, "Skipping deployment mode override for caches (custom closure " +
-                            "execution may not work for console Visor)");
+                        "execution may not work for console Visor)");
                 }
                 else {
                     try {
@@ -1557,8 +1557,8 @@ public class IgnitionEx {
                     }
                     catch (IllegalArgumentException e) {
                         throw new IgniteCheckedException("Failed to override deployment mode using system property " +
-                                "(are there any misspellings?)" +
-                                "[name=" + IGNITE_DEP_MODE_OVERRIDE + ", value=" + depModeName + ']', e);
+                            "(are there any misspellings?)" +
+                            "[name=" + IGNITE_DEP_MODE_OVERRIDE + ", value=" + depModeName + ']', e);
                     }
                 }
             }
@@ -1576,18 +1576,18 @@ public class IgnitionEx {
             if (marsh == null) {
                 if (!U.isHotSpot()) {
                     U.warn(log, "OptimizedMarshaller is not supported on this JVM " +
-                            "(only Java HotSpot VMs are supported). Switching to standard JDK marshalling - " +
-                            "object serialization performance will be significantly slower.",
+                        "(only Java HotSpot VMs are supported). Switching to standard JDK marshalling - " +
+                        "object serialization performance will be significantly slower.",
                         "To enable fast marshalling upgrade to recent 1.6 or 1.7 HotSpot VM release.");
 
                     marsh = new JdkMarshaller();
                 }
                 else if (!OptimizedMarshaller.available()) {
                     U.warn(log, "OptimizedMarshaller is not supported on this JVM " +
-                            "(only recent 1.6 and 1.7 versions HotSpot VMs are supported). " +
-                            "To enable fast marshalling upgrade to recent 1.6 or 1.7 HotSpot VM release. " +
-                            "Switching to standard JDK marshalling - " +
-                            "object serialization performance will be significantly slower.",
+                        "(only recent 1.6 and 1.7 versions HotSpot VMs are supported). " +
+                        "To enable fast marshalling upgrade to recent 1.6 or 1.7 HotSpot VM release. " +
+                        "Switching to standard JDK marshalling - " +
+                        "object serialization performance will be significantly slower.",
                         "To enable fast marshalling upgrade to recent 1.6 or 1.7 HotSpot VM release.");
 
                     marsh = new JdkMarshaller();
@@ -1597,7 +1597,7 @@ public class IgnitionEx {
             }
             else if (marsh instanceof OptimizedMarshaller && !U.isHotSpot()) {
                 U.warn(log, "Using OptimizedMarshaller on untested JVM (only Java HotSpot VMs were tested) - " +
-                        "object serialization behavior could yield unexpected results.",
+                    "object serialization behavior could yield unexpected results.",
                     "Using GridOptimizedMarshaller on untested JVM.");
             }
 


[20/50] incubator-ignite git commit: IGNITE-377 Rework schema load XML generator to generate instead of int number.

Posted by sb...@apache.org.
 IGNITE-377 Rework schema load XML generator to generate <util:constant static-field="java.sql.Types.XXX"/> instead of int number.


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

Branch: refs/heads/ignite-337
Commit: 061ea8aed7f43a47b5097f3c626701c688014e63
Parents: 6097e7b
Author: AKuznetsov <ak...@gridgain.com>
Authored: Sun Mar 1 00:17:19 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Sun Mar 1 00:17:19 2015 +0700

----------------------------------------------------------------------
 .../core/src/test/config/store/jdbc/Ignite.xml  |  63 ++++++---
 .../ignite/schema/generator/XmlGenerator.java   |   8 +-
 .../apache/ignite/schema/model/PojoField.java   |  11 +-
 .../apache/ignite/schema/load/model/Ignite.xml  | 133 ++++++++++++++-----
 .../yardstick/config/ignite-store-config.xml    |  15 ++-
 5 files changed, 168 insertions(+), 62 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/061ea8ae/modules/core/src/test/config/store/jdbc/Ignite.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/store/jdbc/Ignite.xml b/modules/core/src/test/config/store/jdbc/Ignite.xml
index 1b6f702..d56b4e6 100644
--- a/modules/core/src/test/config/store/jdbc/Ignite.xml
+++ b/modules/core/src/test/config/store/jdbc/Ignite.xml
@@ -21,9 +21,12 @@
     XML generated by Apache Ignite Schema Load utility: 02/03/2015
 -->
 <beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:util="http://www.springframework.org/schema/util"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xsi:schemaLocation="http://www.springframework.org/schema/beans
-                           http://www.springframework.org/schema/beans/spring-beans.xsd">
+                           http://www.springframework.org/schema/beans/spring-beans.xsd
+                           http://www.springframework.org/schema/util
+                           http://www.springframework.org/schema/util/spring-util.xsd">
     <bean class="org.apache.ignite.cache.CacheTypeMetadata">
         <property name="databaseSchema" value="PUBLIC"/>
         <property name="databaseTable" value="ORGANIZATION"/>
@@ -33,7 +36,9 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
@@ -43,24 +48,31 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="NAME"/>
-                    <property name="databaseType" value="12"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARCHAR"/>
+                    </property>
                     <property name="javaName" value="name"/>
                     <property name="javaType" value="java.lang.String"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="CITY"/>
-                    <property name="databaseType" value="12"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARCHAR"/>
+                    </property>
                     <property name="javaName" value="city"/>
                     <property name="javaType" value="java.lang.String"/>
                 </bean>
             </list>
         </property>
+
     </bean>
     <bean class="org.apache.ignite.cache.CacheTypeMetadata">
         <property name="databaseSchema" value="PUBLIC"/>
@@ -71,7 +83,9 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
@@ -81,24 +95,31 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ORG_ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="orgId"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="NAME"/>
-                    <property name="databaseType" value="12"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARCHAR"/>
+                    </property>
                     <property name="javaName" value="name"/>
                     <property name="javaType" value="java.lang.String"/>
                 </bean>
             </list>
         </property>
+
     </bean>
     <bean class="org.apache.ignite.cache.CacheTypeMetadata">
         <property name="databaseSchema" value="PUBLIC"/>
@@ -109,19 +130,25 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="int"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ORG_ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="orgId"/>
                     <property name="javaType" value="int"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="CITY_ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="cityId"/>
                     <property name="javaType" value="int"/>
                 </bean>
@@ -131,19 +158,25 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ORG_ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="orgId"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="NAME"/>
-                    <property name="databaseType" value="12"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARCHAR"/>
+                    </property>
                     <property name="javaName" value="name"/>
                     <property name="javaType" value="java.lang.String"/>
                 </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/061ea8ae/modules/schema-load/src/main/java/org/apache/ignite/schema/generator/XmlGenerator.java
----------------------------------------------------------------------
diff --git a/modules/schema-load/src/main/java/org/apache/ignite/schema/generator/XmlGenerator.java b/modules/schema-load/src/main/java/org/apache/ignite/schema/generator/XmlGenerator.java
index d4d7054..c62a720 100644
--- a/modules/schema-load/src/main/java/org/apache/ignite/schema/generator/XmlGenerator.java
+++ b/modules/schema-load/src/main/java/org/apache/ignite/schema/generator/XmlGenerator.java
@@ -159,7 +159,8 @@ public class XmlGenerator {
                 Element item = addBean(doc, list, CacheTypeFieldMetadata.class);
 
                 addProperty(doc, item, "databaseName", field.dbName());
-                addProperty(doc, item, "databaseType", String.valueOf(field.dbType()));
+                Element dbType = addProperty(doc, item, "databaseType", null);
+                addElement(doc, dbType, "util:constant", "static-field", "java.sql.Types." + field.dbTypeName());
                 addProperty(doc, item, "javaName", field.javaName());
                 addProperty(doc, item, "javaType", field.javaTypeName());
             }
@@ -308,9 +309,12 @@ public class XmlGenerator {
             Element beans = addElement(doc, doc, "beans");
             beans.setAttribute("xmlns", "http://www.springframework.org/schema/beans");
             beans.setAttribute("xmlns:xsi", "http://www.w3.org/2001/XMLSchema-instance");
+            beans.setAttribute("xmlns:util", "http://www.springframework.org/schema/util");
             beans.setAttribute("xsi:schemaLocation",
                 "http://www.springframework.org/schema/beans " +
-                "http://www.springframework.org/schema/beans/spring-beans.xsd");
+                "http://www.springframework.org/schema/beans/spring-beans.xsd " +
+                "http://www.springframework.org/schema/util " +
+                "http://www.springframework.org/schema/util/spring-util.xsd");
 
             for (PojoDescriptor pojo : pojos)
                 addTypeMetadata(doc, beans, pkg, pojo, includeKeys);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/061ea8ae/modules/schema-load/src/main/java/org/apache/ignite/schema/model/PojoField.java
----------------------------------------------------------------------
diff --git a/modules/schema-load/src/main/java/org/apache/ignite/schema/model/PojoField.java b/modules/schema-load/src/main/java/org/apache/ignite/schema/model/PojoField.java
index f9a5837..10939d9 100644
--- a/modules/schema-load/src/main/java/org/apache/ignite/schema/model/PojoField.java
+++ b/modules/schema-load/src/main/java/org/apache/ignite/schema/model/PojoField.java
@@ -45,9 +45,6 @@ public class PojoField {
     /** Field name in database. */
     private final StringProperty dbNameProp;
 
-    /** JDBC field type in database. */
-    private final int dbType;
-
     /** Field type in database. */
     private final StringProperty dbTypeNameProp;
 
@@ -139,8 +136,6 @@ public class PojoField {
     public PojoField(String dbName, int dbType, String javaName, String javaTypeName, boolean key, boolean nullable) {
         dbNameProp = new SimpleStringProperty(dbName);
 
-        this.dbType = dbType;
-
         dbTypeNameProp = new SimpleStringProperty(jdbcTypeName(dbType));
 
         javaNamePrev = javaName;
@@ -340,10 +335,10 @@ public class PojoField {
     }
 
     /**
-     * @return POJO field JDBC type in database.
+     * @return POJO field JDBC type name in database.
      */
-    public int dbType() {
-        return dbType;
+    public String dbTypeName() {
+        return dbTypeNameProp.get();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/061ea8ae/modules/schema-load/src/test/java/org/apache/ignite/schema/load/model/Ignite.xml
----------------------------------------------------------------------
diff --git a/modules/schema-load/src/test/java/org/apache/ignite/schema/load/model/Ignite.xml b/modules/schema-load/src/test/java/org/apache/ignite/schema/load/model/Ignite.xml
index 8690dbd..f0b5696 100644
--- a/modules/schema-load/src/test/java/org/apache/ignite/schema/load/model/Ignite.xml
+++ b/modules/schema-load/src/test/java/org/apache/ignite/schema/load/model/Ignite.xml
@@ -21,9 +21,12 @@
     XML generated by Apache Ignite Schema Load utility: 02/05/2015
 -->
 <beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:util="http://www.springframework.org/schema/util"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xsi:schemaLocation="http://www.springframework.org/schema/beans
-                           http://www.springframework.org/schema/beans/spring-beans.xsd">
+                           http://www.springframework.org/schema/beans/spring-beans.xsd
+                           http://www.springframework.org/schema/util
+                           http://www.springframework.org/schema/util/spring-util.xsd">
     <bean class="org.apache.ignite.cache.CacheTypeMetadata">
         <property name="databaseSchema" value="PUBLIC"/>
         <property name="databaseTable" value="OBJECTS"/>
@@ -33,7 +36,9 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="PK"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="pk"/>
                     <property name="javaType" value="int"/>
                 </bean>
@@ -43,91 +48,121 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="PK"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="pk"/>
                     <property name="javaType" value="int"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="BOOLCOL"/>
-                    <property name="databaseType" value="16"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.BOOLEAN"/>
+                    </property>
                     <property name="javaName" value="boolcol"/>
                     <property name="javaType" value="java.lang.Boolean"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="BYTECOL"/>
-                    <property name="databaseType" value="-6"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.TINYINT"/>
+                    </property>
                     <property name="javaName" value="bytecol"/>
                     <property name="javaType" value="java.lang.Byte"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="SHORTCOL"/>
-                    <property name="databaseType" value="5"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.SMALLINT"/>
+                    </property>
                     <property name="javaName" value="shortcol"/>
                     <property name="javaType" value="java.lang.Short"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="INTCOL"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="intcol"/>
                     <property name="javaType" value="java.lang.Integer"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="LONGCOL"/>
-                    <property name="databaseType" value="-5"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.BIGINT"/>
+                    </property>
                     <property name="javaName" value="longcol"/>
                     <property name="javaType" value="java.lang.Long"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="FLOATCOL"/>
-                    <property name="databaseType" value="7"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.REAL"/>
+                    </property>
                     <property name="javaName" value="floatcol"/>
                     <property name="javaType" value="java.lang.Float"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="DOUBLECOL"/>
-                    <property name="databaseType" value="8"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DOUBLE"/>
+                    </property>
                     <property name="javaName" value="doublecol"/>
                     <property name="javaType" value="java.lang.Double"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="DOUBLECOL2"/>
-                    <property name="databaseType" value="8"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DOUBLE"/>
+                    </property>
                     <property name="javaName" value="doublecol2"/>
                     <property name="javaType" value="java.lang.Double"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="BIGDECIMALCOL"/>
-                    <property name="databaseType" value="3"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DECIMAL"/>
+                    </property>
                     <property name="javaName" value="bigdecimalcol"/>
                     <property name="javaType" value="java.math.BigDecimal"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="STRCOL"/>
-                    <property name="databaseType" value="12"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARCHAR"/>
+                    </property>
                     <property name="javaName" value="strcol"/>
                     <property name="javaType" value="java.lang.String"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="DATECOL"/>
-                    <property name="databaseType" value="91"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DATE"/>
+                    </property>
                     <property name="javaName" value="datecol"/>
                     <property name="javaType" value="java.sql.Date"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="TIMECOL"/>
-                    <property name="databaseType" value="92"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.TIME"/>
+                    </property>
                     <property name="javaName" value="timecol"/>
                     <property name="javaType" value="java.sql.Time"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="TSCOL"/>
-                    <property name="databaseType" value="93"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.TIMESTAMP"/>
+                    </property>
                     <property name="javaName" value="tscol"/>
                     <property name="javaType" value="java.sql.Timestamp"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ARRCOL"/>
-                    <property name="databaseType" value="-3"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARBINARY"/>
+                    </property>
                     <property name="javaName" value="arrcol"/>
                     <property name="javaType" value="java.lang.Object"/>
                 </bean>
@@ -181,7 +216,9 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="PK"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="pk"/>
                     <property name="javaType" value="int"/>
                 </bean>
@@ -191,91 +228,121 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="PK"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="pk"/>
                     <property name="javaType" value="int"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="BOOLCOL"/>
-                    <property name="databaseType" value="16"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.BOOLEAN"/>
+                    </property>
                     <property name="javaName" value="boolcol"/>
                     <property name="javaType" value="boolean"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="BYTECOL"/>
-                    <property name="databaseType" value="-6"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.TINYINT"/>
+                    </property>
                     <property name="javaName" value="bytecol"/>
                     <property name="javaType" value="byte"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="SHORTCOL"/>
-                    <property name="databaseType" value="5"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.SMALLINT"/>
+                    </property>
                     <property name="javaName" value="shortcol"/>
                     <property name="javaType" value="short"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="INTCOL"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="intcol"/>
                     <property name="javaType" value="int"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="LONGCOL"/>
-                    <property name="databaseType" value="-5"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.BIGINT"/>
+                    </property>
                     <property name="javaName" value="longcol"/>
                     <property name="javaType" value="long"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="FLOATCOL"/>
-                    <property name="databaseType" value="7"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.REAL"/>
+                    </property>
                     <property name="javaName" value="floatcol"/>
                     <property name="javaType" value="float"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="DOUBLECOL"/>
-                    <property name="databaseType" value="8"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DOUBLE"/>
+                    </property>
                     <property name="javaName" value="doublecol"/>
                     <property name="javaType" value="double"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="DOUBLECOL2"/>
-                    <property name="databaseType" value="8"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DOUBLE"/>
+                    </property>
                     <property name="javaName" value="doublecol2"/>
                     <property name="javaType" value="double"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="BIGDECIMALCOL"/>
-                    <property name="databaseType" value="3"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DECIMAL"/>
+                    </property>
                     <property name="javaName" value="bigdecimalcol"/>
                     <property name="javaType" value="java.math.BigDecimal"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="STRCOL"/>
-                    <property name="databaseType" value="12"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARCHAR"/>
+                    </property>
                     <property name="javaName" value="strcol"/>
                     <property name="javaType" value="java.lang.String"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="DATECOL"/>
-                    <property name="databaseType" value="91"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.DATE"/>
+                    </property>
                     <property name="javaName" value="datecol"/>
                     <property name="javaType" value="java.sql.Date"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="TIMECOL"/>
-                    <property name="databaseType" value="92"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.TIME"/>
+                    </property>
                     <property name="javaName" value="timecol"/>
                     <property name="javaType" value="java.sql.Time"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="TSCOL"/>
-                    <property name="databaseType" value="93"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.TIMESTAMP"/>
+                    </property>
                     <property name="javaName" value="tscol"/>
                     <property name="javaType" value="java.sql.Timestamp"/>
                 </bean>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ARRCOL"/>
-                    <property name="databaseType" value="-3"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.VARBINARY"/>
+                    </property>
                     <property name="javaName" value="arrcol"/>
                     <property name="javaType" value="java.lang.Object"/>
                 </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/061ea8ae/modules/yardstick/config/ignite-store-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-store-config.xml b/modules/yardstick/config/ignite-store-config.xml
index 161cfa5..066b246 100644
--- a/modules/yardstick/config/ignite-store-config.xml
+++ b/modules/yardstick/config/ignite-store-config.xml
@@ -21,9 +21,12 @@
     Ignite Spring configuration file to startup grid.
 -->
 <beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:util="http://www.springframework.org/schema/util"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-       xsi:schemaLocation="
-        http://www.springframework.org/schema/beans  http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
+       xsi:schemaLocation="http://www.springframework.org/schema/beans
+                           http://www.springframework.org/schema/beans/spring-beans.xsd
+                           http://www.springframework.org/schema/util
+                           http://www.springframework.org/schema/util/spring-util.xsd">
     <!--
         Store data source.
     -->
@@ -45,7 +48,9 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="ID"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="int"/>
                 </bean>
@@ -55,7 +60,9 @@
             <list>
                 <bean class="org.apache.ignite.cache.CacheTypeFieldMetadata">
                     <property name="databaseName" value="VALUE"/>
-                    <property name="databaseType" value="4"/>
+                    <property name="databaseType">
+                        <util:constant static-field="java.sql.Types.INTEGER"/>
+                    </property>
                     <property name="javaName" value="id"/>
                     <property name="javaType" value="int"/>
                 </bean>


[45/50] incubator-ignite git commit: # MInor JavADoc change.

Posted by sb...@apache.org.
# MInor JavADoc change.


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

Branch: refs/heads/ignite-337
Commit: 235758cd98f4aca320a6f9c07c5d90ddb956d796
Parents: b0e6ab1
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Mon Mar 2 17:44:16 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Mon Mar 2 17:44:16 2015 +0300

----------------------------------------------------------------------
 .../core/src/main/java/org/apache/ignite/IgniteCluster.java  | 8 ++++----
 1 file changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/235758cd/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java b/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java
index 8669559..c24ba5e 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java
@@ -28,10 +28,10 @@ import java.util.*;
 import java.util.concurrent.*;
 
 /**
- * {@code GridCluster} also provides a handle on {@link #nodeLocalMap()} which provides map-like functionality
- * linked to current grid node. Node-local map is useful for saving shared state between job executions
- * on the grid. Additionally you can also ping, start, and restart remote nodes, map keys to caching nodes,
- * and get other useful information about topology.
+ * Represents whole cluster (all available nodes) and also provides a handle on {@link #nodeLocalMap()} which
+ * provides map-like functionality linked to current grid node. Node-local map is useful for saving shared state
+ * between job executions on the grid. Additionally you can also ping, start, and restart remote nodes, map keys to
+ * caching nodes, and get other useful information about topology.
  */
 public interface IgniteCluster extends ClusterGroup, IgniteAsyncSupport {
     /**


[36/50] incubator-ignite git commit: Merge branch 'sprint-2' into ignite-337

Posted by sb...@apache.org.
Merge branch 'sprint-2' into ignite-337


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

Branch: refs/heads/ignite-337
Commit: 7ecb1701ff2162210b415c40631b83fbb557acfa
Parents: aa7ce40 0086e9c
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Mar 2 14:30:26 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Mar 2 14:30:26 2015 +0300

----------------------------------------------------------------------
 .../IgniteCacheExpiryPolicyAbstractTest.java    | 38 ++------------------
 1 file changed, 3 insertions(+), 35 deletions(-)
----------------------------------------------------------------------



[37/50] incubator-ignite git commit: sprint-2 fix for ignite-301

Posted by sb...@apache.org.
sprint-2 fix for ignite-301


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

Branch: refs/heads/ignite-337
Commit: ea6a1c03c66c1f78a9d9f00f73f9483c32569858
Parents: c9f46c1
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Mar 2 16:00:21 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Mar 2 16:00:21 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/GridKernalContext.java      | 10 ++++-
 .../ignite/internal/GridKernalContextImpl.java  | 14 +++++-
 .../apache/ignite/internal/IgniteKernal.java    | 23 +++++-----
 .../processors/cluster/ClusterProcessor.java    | 46 ++++++++++++++++++++
 4 files changed, 78 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ea6a1c03/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
index 100ad28..cb9ffa1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
@@ -33,11 +33,12 @@ import org.apache.ignite.internal.processors.affinity.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.clock.*;
 import org.apache.ignite.internal.processors.closure.*;
+import org.apache.ignite.internal.processors.cluster.*;
 import org.apache.ignite.internal.processors.continuous.*;
 import org.apache.ignite.internal.processors.dataload.*;
 import org.apache.ignite.internal.processors.datastructures.*;
-import org.apache.ignite.internal.processors.igfs.*;
 import org.apache.ignite.internal.processors.hadoop.*;
+import org.apache.ignite.internal.processors.igfs.*;
 import org.apache.ignite.internal.processors.job.*;
 import org.apache.ignite.internal.processors.jobmetrics.*;
 import org.apache.ignite.internal.processors.offheap.*;
@@ -508,4 +509,11 @@ public interface GridKernalContext extends Iterable<GridComponent> {
      * @return Exception registry.
      */
     public IgniteExceptionRegistry exceptionRegistry();
+
+    /**
+     * Gets Cluster processor.
+     *
+     * @return Cluster processor.
+     */
+    public ClusterProcessor cluster();
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ea6a1c03/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
index 395ad52..756c16a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
@@ -36,11 +36,12 @@ import org.apache.ignite.internal.processors.cache.dr.os.*;
 import org.apache.ignite.internal.processors.cache.serialization.*;
 import org.apache.ignite.internal.processors.clock.*;
 import org.apache.ignite.internal.processors.closure.*;
+import org.apache.ignite.internal.processors.cluster.*;
 import org.apache.ignite.internal.processors.continuous.*;
 import org.apache.ignite.internal.processors.dataload.*;
 import org.apache.ignite.internal.processors.datastructures.*;
-import org.apache.ignite.internal.processors.igfs.*;
 import org.apache.ignite.internal.processors.hadoop.*;
+import org.apache.ignite.internal.processors.igfs.*;
 import org.apache.ignite.internal.processors.job.*;
 import org.apache.ignite.internal.processors.jobmetrics.*;
 import org.apache.ignite.internal.processors.offheap.*;
@@ -245,6 +246,10 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
 
     /** */
     @GridToStringExclude
+    private ClusterProcessor cluster;
+
+    /** */
+    @GridToStringExclude
     private DataStructuresProcessor dataStructuresProc;
 
     /** */
@@ -461,6 +466,8 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
             qryProc = (GridQueryProcessor)comp;
         else if (comp instanceof DataStructuresProcessor)
             dataStructuresProc = (DataStructuresProcessor)comp;
+        else if (comp instanceof ClusterProcessor)
+            cluster = (ClusterProcessor)comp;
         else
             assert (comp instanceof GridPluginComponent) : "Unknown manager class: " + comp.getClass();
 
@@ -854,6 +861,11 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
     }
 
     /** {@inheritDoc} */
+    @Override public ClusterProcessor cluster() {
+        return cluster;
+    }
+
+    /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(GridKernalContextImpl.class, this);
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ea6a1c03/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index 9c92edd..f46d071 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
@@ -39,6 +39,7 @@ import org.apache.ignite.internal.processors.affinity.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.clock.*;
 import org.apache.ignite.internal.processors.closure.*;
+import org.apache.ignite.internal.processors.cluster.*;
 import org.apache.ignite.internal.processors.continuous.*;
 import org.apache.ignite.internal.processors.dataload.*;
 import org.apache.ignite.internal.processors.datastructures.*;
@@ -182,10 +183,6 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
     @GridToStringExclude
     private boolean errOnStop;
 
-    /** Cluster. */
-    @GridToStringExclude
-    private IgniteClusterImpl cluster;
-
     /** Scheduler. */
     @GridToStringExclude
     private IgniteScheduler scheduler;
@@ -229,37 +226,37 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
 
     /** {@inheritDoc} */
     @Override public IgniteClusterEx cluster() {
-        return cluster;
+        return ctx.cluster().get();
     }
 
     /** {@inheritDoc} */
     @Override public ClusterNode localNode() {
-        return cluster.localNode();
+        return ctx.cluster().get().localNode();
     }
 
     /** {@inheritDoc} */
     @Override public IgniteCompute compute() {
-        return cluster.compute();
+        return ctx.cluster().get().compute();
     }
 
     /** {@inheritDoc} */
     @Override public IgniteMessaging message() {
-        return cluster.message();
+        return ctx.cluster().get().message();
     }
 
     /** {@inheritDoc} */
     @Override public IgniteEvents events() {
-        return cluster.events();
+        return ctx.cluster().get().events();
     }
 
     /** {@inheritDoc} */
     @Override public IgniteServices services() {
-        return cluster.services();
+        return ctx.cluster().get().services();
     }
 
     /** {@inheritDoc} */
     @Override public ExecutorService executorService() {
-        return cluster.executorService();
+        return ctx.cluster().get().executorService();
     }
 
     /** {@inheritDoc} */
@@ -678,7 +675,7 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
                 igfsExecSvc,
                 restExecSvc);
 
-            cluster = new IgniteClusterImpl(ctx);
+            startProcessor(ctx, new ClusterProcessor(ctx), attrs);
 
             U.onGridStart();
 
@@ -1793,7 +1790,7 @@ public class IgniteKernal implements IgniteEx, IgniteMXBean, Externalizable {
                 // No more kernal calls from this point on.
                 gw.setState(STOPPING);
 
-                cluster.clearNodeMap();
+                ctx.cluster().get().clearNodeMap();
 
                 if (log.isDebugEnabled())
                     log.debug("Grid " + (gridName == null ? "" : '\'' + gridName + "' ") + "is stopping.");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ea6a1c03/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterProcessor.java
new file mode 100644
index 0000000..0ee00f1
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cluster/ClusterProcessor.java
@@ -0,0 +1,46 @@
+/*
+ * 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.cluster;
+
+import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.cluster.*;
+import org.apache.ignite.internal.processors.*;
+
+/**
+ *
+ */
+public class ClusterProcessor extends GridProcessorAdapter {
+    /** */
+    private IgniteClusterImpl cluster;
+
+    /**
+     * @param ctx Kernal context.
+     */
+    public ClusterProcessor(GridKernalContext ctx) {
+        super(ctx);
+
+        cluster = new IgniteClusterImpl(ctx);
+    }
+
+    /**
+     * @return Cluster.
+     */
+    public IgniteClusterImpl get() {
+        return cluster;
+    }
+}


[47/50] incubator-ignite git commit: Merge branch 'ignite-136' into sprint-2

Posted by sb...@apache.org.
Merge branch 'ignite-136' into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 9a931983f51f96ad9b96551aee654874e746aa94
Parents: 028e446 2e115bf
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Mon Mar 2 17:47:24 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Mon Mar 2 17:47:24 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheMapEntry.java     |   9 +
 .../distributed/dht/GridDhtCacheEntry.java      |   3 +
 .../distributed/dht/GridDhtLocalPartition.java  |   5 +
 .../GridCacheAbstractLocalStoreSelfTest.java    | 440 +++++++++++++++++++
 .../GridCachePartitionedLocalStoreSelfTest.java |  51 +++
 ...chePartitionedOffHeapLocalStoreSelfTest.java |  56 +++
 .../GridCacheReplicatedLocalStoreSelfTest.java  |  51 +++
 ...ridCacheTxPartitionedLocalStoreSelfTest.java |  51 +++
 .../ignite/testsuites/IgniteCacheTestSuite.java |   4 +
 9 files changed, 670 insertions(+)
----------------------------------------------------------------------



[24/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-2' into ignite-239

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


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

Branch: refs/heads/ignite-337
Commit: ba010da403a0425f6d0ccfe006e41e1997bbbf9f
Parents: 8476463 036bd71
Author: ivasilinets <va...@gmail.com>
Authored: Sun Mar 1 15:26:27 2015 +0300
Committer: ivasilinets <va...@gmail.com>
Committed: Sun Mar 1 15:26:27 2015 +0300

----------------------------------------------------------------------
 .../store/CacheNodeWithStoreStartup.java        |   6 +-
 .../store/jdbc/CacheJdbcPersonStore.java        | 115 +++++++------------
 .../apache/ignite/cache/store/CacheStore.java   |   4 +-
 .../ignite/cache/store/CacheStoreAdapter.java   |   2 +-
 .../ignite/cache/store/CacheStoreSession.java   |  17 ++-
 .../apache/ignite/internal/GridProperties.java  |  78 -------------
 .../ignite/internal/GridUpdateNotifier.java     |   2 +-
 .../apache/ignite/internal/IgniteKernal.java    |  18 +--
 .../ignite/internal/IgniteProperties.java       |  79 +++++++++++++
 .../ignite/internal/IgniteVersionUtils.java     |   8 +-
 .../processors/cache/GridCacheStoreManager.java |   6 +-
 .../plugin/IgnitePluginProcessor.java           |  24 ++++
 .../apache/ignite/plugin/PluginProvider.java    |   5 +
 .../internal/GridUpdateNotifierSelfTest.java    |   2 +-
 .../junits/cache/TestCacheSession.java          |   5 +
 .../cache/TestThreadLocalCacheSession.java      |   5 +
 .../HibernateReadWriteAccessStrategy.java       |  81 ++++++++++---
 17 files changed, 264 insertions(+), 193 deletions(-)
----------------------------------------------------------------------



[46/50] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-2' into sprint-2

Posted by sb...@apache.org.
Merge remote-tracking branch 'origin/sprint-2' into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 028e44637fe9ff3fe3347d685f7d52422ff1cb0d
Parents: 2511ebe 235758c
Author: anovikov <an...@gridgain.com>
Authored: Mon Mar 2 21:44:49 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Mon Mar 2 21:44:49 2015 +0700

----------------------------------------------------------------------
 .../core/src/main/java/org/apache/ignite/IgniteCluster.java  | 8 ++++----
 1 file changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------



[06/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-2' into ignite-239

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


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

Branch: refs/heads/ignite-337
Commit: 1689a203b0dca44b2435e676d5c2c9c9c3fda095
Parents: 4f0feee dd66167
Author: sboikov <sb...@gridgain.com>
Authored: Fri Feb 27 17:16:36 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Feb 27 17:16:36 2015 +0300

----------------------------------------------------------------------
 config/hadoop/default-config.xml                |  12 +
 .../src/main/java/org/apache/ignite/Ignite.java |   4 +-
 .../configuration/QueryConfiguration.java       |  37 +-
 .../java/org/apache/ignite/igfs/IgfsMode.java   |   6 +-
 .../config/GridTestProperties.java              |  10 +-
 .../client/hadoop/GridHadoopClientProtocol.java |   6 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     | 412 ++++++++++++++++++
 .../igfs/hadoop/v1/IgfsHadoopFileSystem.java    |   3 +-
 .../igfs/hadoop/v2/IgfsHadoopFileSystem.java    |   3 +-
 .../igfs/hadoop/IgfsHadoopFSProperties.java     |  10 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     | 413 -------------------
 .../internal/igfs/hadoop/IgfsHadoopReader.java  |   2 +-
 .../internal/igfs/hadoop/IgfsHadoopUtils.java   |   4 +-
 .../hadoop/GridHadoopClassLoader.java           |  12 +-
 .../processors/hadoop/GridHadoopSetup.java      |   8 +-
 .../processors/hadoop/GridHadoopUtils.java      |   4 +-
 .../collections/GridHadoopHashMultimapBase.java |   2 +-
 .../GridHadoopExternalCommunication.java        |  14 +-
 .../hadoop/v1/GridHadoopV1MapTask.java          |   6 +-
 .../v2/GridHadoopV2JobResourceManager.java      |   2 +-
 .../GridHadoopClientProtocolSelfTest.java       |   6 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |   2 +-
 .../IgfsHadoop20FileSystemAbstractSelfTest.java |   2 +-
 .../igfs/IgfsHadoopDualAbstractSelfTest.java    |   2 +-
 .../IgfsHadoopFileSystemAbstractSelfTest.java   |   1 +
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   2 +-
 .../hadoop/GridHadoopGroupingTest.java          |   4 +-
 .../igfs/IgfsPerformanceBenchmark.java          |   9 +-
 28 files changed, 530 insertions(+), 468 deletions(-)
----------------------------------------------------------------------



[03/50] incubator-ignite git commit: # ignite-339 Refactored Visor Configurations

Posted by sb...@apache.org.
# ignite-339 Refactored Visor Configurations


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

Branch: refs/heads/ignite-337
Commit: 57bdd8a5412bec7fafd2481bc42752d50de36463
Parents: 555e3f9
Author: anovikov <an...@gridgain.com>
Authored: Fri Feb 27 18:20:57 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Fri Feb 27 18:20:57 2015 +0700

----------------------------------------------------------------------
 .../visor/cache/VisorCacheConfiguration.java    |  10 -
 .../visor/node/VisorAtomicConfiguration.java    |  27 +-
 .../visor/node/VisorBasicConfiguration.java     | 180 ++------------
 .../node/VisorCacheQueryConfiguration.java      |  45 +---
 .../node/VisorExecutorServiceConfiguration.java |  54 +---
 .../visor/node/VisorGridConfiguration.java      | 177 ++------------
 .../visor/node/VisorIgfsConfiguration.java      | 244 ++-----------------
 .../visor/node/VisorLifecycleConfiguration.java |   9 +-
 .../visor/node/VisorMetricsConfiguration.java   |  29 +--
 .../node/VisorPeerToPeerConfiguration.java      |  28 +--
 .../visor/node/VisorQueryConfiguration.java     |  65 +----
 .../visor/node/VisorRestConfiguration.java      |  80 +-----
 .../node/VisorSegmentationConfiguration.java    |  45 +---
 .../visor/node/VisorSpisConfiguration.java      |  92 +------
 .../node/VisorTransactionConfiguration.java     |  64 +----
 15 files changed, 139 insertions(+), 1010 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
index cf149f7..8eee437 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
@@ -60,9 +60,6 @@ public class VisorCacheConfiguration implements Serializable {
     /** Write synchronization mode. */
     private CacheWriteSynchronizationMode writeSynchronizationMode;
 
-    /** Sequence reserve size. */
-    private int seqReserveSize;
-
     /** Swap enabled flag. */
     private boolean swapEnabled;
 
@@ -257,13 +254,6 @@ public class VisorCacheConfiguration implements Serializable {
     }
 
     /**
-     * @return Sequence reserve size.
-     */
-    public int sequenceReserveSize() {
-        return seqReserveSize;
-    }
-
-    /**
      * @return Swap enabled flag.
      */
     public boolean swapEnabled() {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorAtomicConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorAtomicConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorAtomicConfiguration.java
index 79ce903..c39e3d9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorAtomicConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorAtomicConfiguration.java
@@ -48,9 +48,9 @@ public class VisorAtomicConfiguration implements Serializable {
     public static VisorAtomicConfiguration from(AtomicConfiguration src) {
         VisorAtomicConfiguration cfg = new VisorAtomicConfiguration();
 
-        cfg.atomicSequenceReserveSize(src.getAtomicSequenceReserveSize());
-        cfg.cacheMode(src.getCacheMode());
-        cfg.backups(src.getBackups());
+        cfg.seqReserveSize = src.getAtomicSequenceReserveSize();
+        cfg.cacheMode = src.getCacheMode();
+        cfg.backups = src.getBackups();
 
         return cfg;
     }
@@ -63,13 +63,6 @@ public class VisorAtomicConfiguration implements Serializable {
     }
 
     /**
-     * @param seqReserveSize Atomic sequence reservation size.
-     */
-    public void atomicSequenceReserveSize(int seqReserveSize) {
-        this.seqReserveSize = seqReserveSize;
-    }
-
-    /**
      * @return Cache mode.
      */
     public CacheMode cacheMode() {
@@ -77,26 +70,12 @@ public class VisorAtomicConfiguration implements Serializable {
     }
 
     /**
-     * @param cacheMode Cache mode.
-     */
-    public void cacheMode(CacheMode cacheMode) {
-        this.cacheMode = cacheMode;
-    }
-
-    /**
      * @return Number of backup nodes.
      */
     public int backups() {
         return backups;
     }
 
-    /**
-     * @param backups Number of backup nodes.
-     */
-    public void backups(int backups) {
-        this.backups = backups;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorAtomicConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorBasicConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorBasicConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorBasicConfiguration.java
index 8a79299..a3b6052 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorBasicConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorBasicConfiguration.java
@@ -104,26 +104,26 @@ public class VisorBasicConfiguration implements Serializable {
     public static VisorBasicConfiguration from(IgniteEx ignite, IgniteConfiguration c) {
         VisorBasicConfiguration cfg = new VisorBasicConfiguration();
 
-        cfg.gridName(c.getGridName());
-        cfg.ggHome(getProperty(IGNITE_HOME, c.getIgniteHome()));
-        cfg.localHost(getProperty(IGNITE_LOCAL_HOST, c.getLocalHost()));
-        cfg.nodeId(ignite.localNode().id());
-        cfg.marshaller(compactClass(c.getMarshaller()));
-        cfg.deploymentMode(compactObject(c.getDeploymentMode()));
-        cfg.daemon(boolValue(IGNITE_DAEMON, c.isDaemon()));
-        cfg.jmxRemote(ignite.isJmxRemoteEnabled());
-        cfg.restart(ignite.isRestartEnabled());
-        cfg.networkTimeout(c.getNetworkTimeout());
-        cfg.logger(compactClass(c.getGridLogger()));
-        cfg.discoStartupDelay(c.getDiscoveryStartupDelay());
-        cfg.mBeanServer(compactClass(c.getMBeanServer()));
-        cfg.noAscii(boolValue(IGNITE_NO_ASCII, false));
-        cfg.noDiscoOrder(boolValue(IGNITE_NO_DISCO_ORDER, false));
-        cfg.noShutdownHook(boolValue(IGNITE_NO_SHUTDOWN_HOOK, false));
-        cfg.programName(getProperty(IGNITE_PROG_NAME));
-        cfg.quiet(boolValue(IGNITE_QUIET, true));
-        cfg.successFile(getProperty(IGNITE_SUCCESS_FILE));
-        cfg.updateNotifier(boolValue(IGNITE_UPDATE_NOTIFIER, true));
+        cfg.gridName = c.getGridName();
+        cfg.ggHome = getProperty(IGNITE_HOME, c.getIgniteHome());
+        cfg.locHost = getProperty(IGNITE_LOCAL_HOST, c.getLocalHost());
+        cfg.nodeId = ignite.localNode().id();
+        cfg.marsh = compactClass(c.getMarshaller());
+        cfg.deployMode = compactObject(c.getDeploymentMode());
+        cfg.daemon = boolValue(IGNITE_DAEMON, c.isDaemon());
+        cfg.jmxRemote = ignite.isJmxRemoteEnabled();
+        cfg.restart = ignite.isRestartEnabled();
+        cfg.netTimeout = c.getNetworkTimeout();
+        cfg.log = compactClass(c.getGridLogger());
+        cfg.discoStartupDelay = c.getDiscoveryStartupDelay();
+        cfg.mBeanSrv = compactClass(c.getMBeanServer());
+        cfg.noAscii = boolValue(IGNITE_NO_ASCII, false);
+        cfg.noDiscoOrder = boolValue(IGNITE_NO_DISCO_ORDER, false);
+        cfg.noShutdownHook = boolValue(IGNITE_NO_SHUTDOWN_HOOK, false);
+        cfg.progName = getProperty(IGNITE_PROG_NAME);
+        cfg.quiet = boolValue(IGNITE_QUIET, true);
+        cfg.successFile = getProperty(IGNITE_SUCCESS_FILE);
+        cfg.updateNtf = boolValue(IGNITE_UPDATE_NOTIFIER, true);
 
         return cfg;
     }
@@ -136,13 +136,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param gridName New grid name.
-     */
-    public void gridName(@Nullable String gridName) {
-        this.gridName = gridName;
-    }
-
-    /**
      * @return IGNITE_HOME determined at startup.
      */
     @Nullable public String ggHome() {
@@ -150,13 +143,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param ggHome New IGNITE_HOME determined at startup.
-     */
-    public void ggHome(@Nullable String ggHome) {
-        this.ggHome = ggHome;
-    }
-
-    /**
      * @return Local host value used.
      */
     @Nullable public String localHost() {
@@ -164,13 +150,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param locHost New local host value used.
-     */
-    public void localHost(@Nullable String locHost) {
-        this.locHost = locHost;
-    }
-
-    /**
      * @return Node id.
      */
     public UUID nodeId() {
@@ -178,13 +157,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param nodeId New node id.
-     */
-    public void nodeId(UUID nodeId) {
-        this.nodeId = nodeId;
-    }
-
-    /**
      * @return Marshaller used.
      */
     public String marshaller() {
@@ -192,13 +164,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param marsh New marshaller used.
-     */
-    public void marshaller(String marsh) {
-        this.marsh = marsh;
-    }
-
-    /**
      * @return Deployment Mode.
      */
     public Object deploymentMode() {
@@ -206,13 +171,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param deployMode New Deployment Mode.
-     */
-    public void deploymentMode(Object deployMode) {
-        this.deployMode = deployMode;
-    }
-
-    /**
      * @return Whether this node daemon or not.
      */
     public boolean daemon() {
@@ -220,13 +178,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param daemon New whether this node daemon or not.
-     */
-    public void daemon(boolean daemon) {
-        this.daemon = daemon;
-    }
-
-    /**
      * @return Whether remote JMX is enabled.
      */
     public boolean jmxRemote() {
@@ -234,13 +185,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param jmxRemote New whether remote JMX is enabled.
-     */
-    public void jmxRemote(boolean jmxRemote) {
-        this.jmxRemote = jmxRemote;
-    }
-
-    /**
      * @return Is node restart enabled.
      */
     public boolean restart() {
@@ -248,13 +192,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param restart New is node restart enabled.
-     */
-    public void restart(boolean restart) {
-        this.restart = restart;
-    }
-
-    /**
      * @return Network timeout.
      */
     public long networkTimeout() {
@@ -262,13 +199,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param netTimeout New network timeout.
-     */
-    public void networkTimeout(long netTimeout) {
-        this.netTimeout = netTimeout;
-    }
-
-    /**
      * @return Logger used on node.
      */
     public String logger() {
@@ -276,13 +206,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param log New logger used on node.
-     */
-    public void logger(String log) {
-        this.log = log;
-    }
-
-    /**
      * @return Discovery startup delay.
      */
     public long discoStartupDelay() {
@@ -290,13 +213,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param discoStartupDelay New discovery startup delay.
-     */
-    public void discoStartupDelay(long discoStartupDelay) {
-        this.discoStartupDelay = discoStartupDelay;
-    }
-
-    /**
      * @return MBean server name
      */
     @Nullable public String mBeanServer() {
@@ -304,13 +220,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param mBeanSrv New mBean server name
-     */
-    public void mBeanServer(@Nullable String mBeanSrv) {
-        this.mBeanSrv = mBeanSrv;
-    }
-
-    /**
      * @return Whether ASCII logo is disabled.
      */
     public boolean noAscii() {
@@ -318,13 +227,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param noAscii New whether ASCII logo is disabled.
-     */
-    public void noAscii(boolean noAscii) {
-        this.noAscii = noAscii;
-    }
-
-    /**
      * @return Whether no discovery order is allowed.
      */
     public boolean noDiscoOrder() {
@@ -332,13 +234,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param noDiscoOrder New whether no discovery order is allowed.
-     */
-    public void noDiscoOrder(boolean noDiscoOrder) {
-        this.noDiscoOrder = noDiscoOrder;
-    }
-
-    /**
      * @return Whether shutdown hook is disabled.
      */
     public boolean noShutdownHook() {
@@ -346,13 +241,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param noShutdownHook New whether shutdown hook is disabled.
-     */
-    public void noShutdownHook(boolean noShutdownHook) {
-        this.noShutdownHook = noShutdownHook;
-    }
-
-    /**
      * @return Name of command line program.
      */
     public String programName() {
@@ -360,13 +248,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param progName New name of command line program.
-     */
-    public void programName(String progName) {
-        this.progName = progName;
-    }
-
-    /**
      * @return Whether node is in quiet mode.
      */
     public boolean quiet() {
@@ -374,13 +255,6 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param quiet New whether node is in quiet mode.
-     */
-    public void quiet(boolean quiet) {
-        this.quiet = quiet;
-    }
-
-    /**
      * @return Success file name.
      */
     public String successFile() {
@@ -388,26 +262,12 @@ public class VisorBasicConfiguration implements Serializable {
     }
 
     /**
-     * @param successFile New success file name.
-     */
-    public void successFile(String successFile) {
-        this.successFile = successFile;
-    }
-
-    /**
      * @return Whether update checker is enabled.
      */
     public boolean updateNotifier() {
         return updateNtf;
     }
 
-    /**
-     * @param updateNtf New whether update checker is enabled.
-     */
-    public void updateNotifier(boolean updateNtf) {
-        this.updateNtf = updateNtf;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorBasicConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheQueryConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheQueryConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheQueryConfiguration.java
index 882fa34..8d284c2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheQueryConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorCacheQueryConfiguration.java
@@ -58,12 +58,12 @@ public class VisorCacheQueryConfiguration implements Serializable {
             QueryTypeResolver rslvr = qccfg.getTypeResolver();
 
             if (rslvr != null)
-                cfg.typeResolver(U.compact(rslvr.getClass().getName()));
+                cfg.typeRslvr = U.compact(rslvr.getClass().getName());
 
-            cfg.indexPrimitiveKey(qccfg.isIndexPrimitiveKey());
-            cfg.indexPrimitiveValue(qccfg.isIndexPrimitiveValue());
-            cfg.indexFixedTyping(qccfg.isIndexFixedTyping());
-            cfg.escapeAll(qccfg.isEscapeAll());
+            cfg.idxPrimitiveKey = qccfg.isIndexPrimitiveKey();
+            cfg.idxPrimitiveVal = qccfg.isIndexPrimitiveValue();
+            cfg.idxFixedTyping = qccfg.isIndexFixedTyping();
+            cfg.escapeAll = qccfg.isEscapeAll();
         }
 
         return cfg;
@@ -77,13 +77,6 @@ public class VisorCacheQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param typeRslvr Query type resolver class name.
-     */
-    public void typeResolver(String typeRslvr) {
-        this.typeRslvr = typeRslvr;
-    }
-
-    /**
      * @return {@code true} if primitive keys should be indexed.
      */
     public boolean indexPrimitiveKey() {
@@ -91,13 +84,6 @@ public class VisorCacheQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param idxPrimitiveKey {@code true} if primitive keys should be indexed.
-     */
-    public void indexPrimitiveKey(boolean idxPrimitiveKey) {
-        this.idxPrimitiveKey = idxPrimitiveKey;
-    }
-
-    /**
      * @return {@code true} if primitive values should be indexed.
      */
     public boolean indexPrimitiveValue() {
@@ -105,13 +91,6 @@ public class VisorCacheQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param idxPrimitiveVal {@code true} if primitive values should be indexed.
-     */
-    public void indexPrimitiveValue(boolean idxPrimitiveVal) {
-        this.idxPrimitiveVal = idxPrimitiveVal;
-    }
-
-    /**
      * @return {@code true} if SQL engine should try to convert values to their respective SQL types.
      */
     public boolean indexFixedTyping() {
@@ -119,23 +98,9 @@ public class VisorCacheQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param idxFixedTyping {@code true} if SQL engine should try to convert values to their respective SQL types.
-     */
-    public void indexFixedTyping(boolean idxFixedTyping) {
-        this.idxFixedTyping = idxFixedTyping;
-    }
-
-    /**
      * @return {@code true} if SQL engine generate SQL statements with escaped names.
      */
     public boolean escapeAll() {
         return escapeAll;
     }
-
-    /**
-     * @param escapeAll {@code true} if SQL engine should generate SQL statements with escaped names.
-     */
-    public void escapeAll(boolean escapeAll) {
-        this.escapeAll = escapeAll;
-    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
index 05f407e..8bc891e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
@@ -54,16 +54,16 @@ public class VisorExecutorServiceConfiguration implements Serializable {
     public static VisorExecutorServiceConfiguration from(IgniteConfiguration c) {
         VisorExecutorServiceConfiguration cfg = new VisorExecutorServiceConfiguration();
 
-        cfg.publicThreadPoolSize(c.getPublicThreadPoolSize());
-        cfg.systemThreadPoolSize(c.getSystemThreadPoolSize());
-        cfg.managementThreadPoolSize(c.getManagementThreadPoolSize());
-        cfg.peerClassLoadingThreadPoolSize(c.getPeerClassLoadingThreadPoolSize());
-        cfg.igfsThreadPoolSize(c.getIgfsThreadPoolSize());
+        cfg.pubPoolSize = c.getPublicThreadPoolSize();
+        cfg.sysPoolSz = c.getSystemThreadPoolSize();
+        cfg.mgmtPoolSize = c.getManagementThreadPoolSize();
+        cfg.p2pPoolSz = c.getPeerClassLoadingThreadPoolSize();
+        cfg.igfsPoolSize = c.getIgfsThreadPoolSize();
 
         ConnectorConfiguration cc = c.getConnectorConfiguration();
 
         if (cc != null)
-            cfg.restThreadPoolSize(cc.getThreadPoolSize());
+            cfg.restPoolSz = cc.getThreadPoolSize();
 
         return cfg;
     }
@@ -76,13 +76,6 @@ public class VisorExecutorServiceConfiguration implements Serializable {
     }
 
     /**
-     * @param pubPoolSize Public pool size.
-     */
-    public void publicThreadPoolSize(int pubPoolSize) {
-        this.pubPoolSize = pubPoolSize;
-    }
-
-    /**
      * @return System pool size.
      */
     public int systemThreadPoolSize() {
@@ -90,13 +83,6 @@ public class VisorExecutorServiceConfiguration implements Serializable {
     }
 
     /**
-     * @param sysPoolSz System pool size.
-     */
-    public void systemThreadPoolSize(int sysPoolSz) {
-        this.sysPoolSz = sysPoolSz;
-    }
-
-    /**
      * @return Management pool size.
      */
     public int managementThreadPoolSize() {
@@ -104,13 +90,6 @@ public class VisorExecutorServiceConfiguration implements Serializable {
     }
 
     /**
-     * @param mgmtPoolSize New Management pool size.
-     */
-    public void managementThreadPoolSize(int mgmtPoolSize) {
-        this.mgmtPoolSize = mgmtPoolSize;
-    }
-
-    /**
      * @return IGFS pool size.
      */
     public int igfsThreadPoolSize() {
@@ -118,13 +97,6 @@ public class VisorExecutorServiceConfiguration implements Serializable {
     }
 
     /**
-     * @param igfsPoolSize New iGFS pool size.
-     */
-    public void igfsThreadPoolSize(int igfsPoolSize) {
-        this.igfsPoolSize = igfsPoolSize;
-    }
-
-    /**
      * @return Peer-to-peer pool size.
      */
     public int peerClassLoadingThreadPoolSize() {
@@ -132,26 +104,12 @@ public class VisorExecutorServiceConfiguration implements Serializable {
     }
 
     /**
-     * @param p2pPoolSz New peer-to-peer pool size.
-     */
-    public void peerClassLoadingThreadPoolSize(int p2pPoolSz) {
-        this.p2pPoolSz = p2pPoolSz;
-    }
-
-    /**
      * @return REST requests pool size.
      */
     public int restThreadPoolSize() {
         return restPoolSz;
     }
 
-    /**
-     * @param restPoolSz REST requests pool size.
-     */
-    public void restThreadPoolSize(int restPoolSz) {
-        this.restPoolSz = restPoolSz;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorExecutorServiceConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorGridConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorGridConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorGridConfiguration.java
index 446db32..96c69d9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorGridConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorGridConfiguration.java
@@ -102,25 +102,25 @@ public class VisorGridConfiguration implements Serializable {
 
         IgniteConfiguration c = ignite.configuration();
 
-        basic(VisorBasicConfiguration.from(ignite, c));
-        metrics(VisorMetricsConfiguration.from(c));
-        spis(VisorSpisConfiguration.from(c));
-        p2p(VisorPeerToPeerConfiguration.from(c));
-        lifecycle(VisorLifecycleConfiguration.from(c));
-        executeService(VisorExecutorServiceConfiguration.from(c));
-        segmentation(VisorSegmentationConfiguration.from(c));
-        includeProperties(compactArray(c.getIncludeProperties()));
-        includeEventTypes(c.getIncludeEventTypes());
-        rest(VisorRestConfiguration.from(c));
-        userAttributes(c.getUserAttributes());
-        caches(VisorCacheConfiguration.list(ignite, c.getCacheConfiguration()));
-        igfss(VisorIgfsConfiguration.list(c.getIgfsConfiguration()));
-        streamers(VisorStreamerConfiguration.list(c.getStreamerConfiguration()));
-        env(new HashMap<>(getenv()));
-        systemProperties(getProperties());
-        atomic(VisorAtomicConfiguration.from(c.getAtomicConfiguration()));
-        transaction(VisorTransactionConfiguration.from(c.getTransactionConfiguration()));
-        queryConfiguration(VisorQueryConfiguration.from(c.getQueryConfiguration()));
+        basic = VisorBasicConfiguration.from(ignite, c);
+        metrics = VisorMetricsConfiguration.from(c);
+        spis = VisorSpisConfiguration.from(c);
+        p2p = VisorPeerToPeerConfiguration.from(c);
+        lifecycle = VisorLifecycleConfiguration.from(c);
+        execSvc = VisorExecutorServiceConfiguration.from(c);
+        seg = VisorSegmentationConfiguration.from(c);
+        inclProps = compactArray(c.getIncludeProperties());
+        inclEvtTypes = c.getIncludeEventTypes();
+        rest = VisorRestConfiguration.from(c);
+        userAttrs = c.getUserAttributes();
+        caches = VisorCacheConfiguration.list(ignite, c.getCacheConfiguration());
+        igfss = VisorIgfsConfiguration.list(c.getIgfsConfiguration());
+        streamers = VisorStreamerConfiguration.list(c.getStreamerConfiguration());
+        env = new HashMap<>(getenv());
+        sysProps = getProperties();
+        atomic = VisorAtomicConfiguration.from(c.getAtomicConfiguration());
+        txCfg = VisorTransactionConfiguration.from(c.getTransactionConfiguration());
+        qryCfg = VisorQueryConfiguration.from(c.getQueryConfiguration());
 
         return this;
     }
@@ -133,13 +133,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param basic New basic.
-     */
-    public void basic(VisorBasicConfiguration basic) {
-        this.basic = basic;
-    }
-
-    /**
      * @return Metrics.
      */
     public VisorMetricsConfiguration metrics() {
@@ -147,13 +140,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param metrics New metrics.
-     */
-    public void metrics(VisorMetricsConfiguration metrics) {
-        this.metrics = metrics;
-    }
-
-    /**
      * @return SPIs.
      */
     public VisorSpisConfiguration spis() {
@@ -161,13 +147,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param spis New SPIs.
-     */
-    public void spis(VisorSpisConfiguration spis) {
-        this.spis = spis;
-    }
-
-    /**
      * @return P2P.
      */
     public VisorPeerToPeerConfiguration p2p() {
@@ -175,13 +154,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param p2P New p2p.
-     */
-    public void p2p(VisorPeerToPeerConfiguration p2P) {
-        p2p = p2P;
-    }
-
-    /**
      * @return Lifecycle.
      */
     public VisorLifecycleConfiguration lifecycle() {
@@ -189,13 +161,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param lifecycle New lifecycle.
-     */
-    public void lifecycle(VisorLifecycleConfiguration lifecycle) {
-        this.lifecycle = lifecycle;
-    }
-
-    /**
      * @return Executors service configuration.
      */
     public VisorExecutorServiceConfiguration executeService() {
@@ -203,13 +168,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param execSvc New executors service configuration.
-     */
-    public void executeService(VisorExecutorServiceConfiguration execSvc) {
-        this.execSvc = execSvc;
-    }
-
-    /**
      * @return Segmentation.
      */
     public VisorSegmentationConfiguration segmentation() {
@@ -217,13 +175,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param seg New segmentation.
-     */
-    public void segmentation(VisorSegmentationConfiguration seg) {
-        this.seg = seg;
-    }
-
-    /**
      * @return Include properties.
      */
     public String includeProperties() {
@@ -231,13 +182,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param inclProps New include properties.
-     */
-    public void includeProperties(String inclProps) {
-        this.inclProps = inclProps;
-    }
-
-    /**
      * @return Include events types.
      */
     public int[] includeEventTypes() {
@@ -245,13 +189,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param inclEvtTypes New include events types.
-     */
-    public void includeEventTypes(int[] inclEvtTypes) {
-        this.inclEvtTypes = inclEvtTypes;
-    }
-
-    /**
      * @return Rest.
      */
     public VisorRestConfiguration rest() {
@@ -259,13 +196,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param rest New rest.
-     */
-    public void rest(VisorRestConfiguration rest) {
-        this.rest = rest;
-    }
-
-    /**
      * @return User attributes.
      */
     public Map<String, ?> userAttributes() {
@@ -273,13 +203,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param userAttrs New user attributes.
-     */
-    public void userAttributes(Map<String, ?> userAttrs) {
-        this.userAttrs = userAttrs;
-    }
-
-    /**
      * @return Caches.
      */
     public Iterable<VisorCacheConfiguration> caches() {
@@ -287,13 +210,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param caches New caches.
-     */
-    public void caches(Iterable<VisorCacheConfiguration> caches) {
-        this.caches = caches;
-    }
-
-    /**
      * @return Igfss.
      */
     public Iterable<VisorIgfsConfiguration> igfss() {
@@ -301,13 +217,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param igfss New igfss.
-     */
-    public void igfss(Iterable<VisorIgfsConfiguration> igfss) {
-        this.igfss = igfss;
-    }
-
-    /**
      * @return Streamers.
      */
     public Iterable<VisorStreamerConfiguration> streamers() {
@@ -315,13 +224,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param streamers New streamers.
-     */
-    public void streamers(Iterable<VisorStreamerConfiguration> streamers) {
-        this.streamers = streamers;
-    }
-
-    /**
      * @return Environment.
      */
     public Map<String, String> env() {
@@ -329,13 +231,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param env New environment.
-     */
-    public void env(Map<String, String> env) {
-        this.env = env;
-    }
-
-    /**
      * @return System properties.
      */
     public Properties systemProperties() {
@@ -343,13 +238,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param sysProps New system properties.
-     */
-    public void systemProperties(Properties sysProps) {
-        this.sysProps = sysProps;
-    }
-
-    /**
      * @return Configuration of atomic data structures.
      */
     public VisorAtomicConfiguration atomic() {
@@ -357,13 +245,6 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param atomic New configuration of atomic data structures.
-     */
-    public void atomic(VisorAtomicConfiguration atomic) {
-        this.atomic = atomic;
-    }
-
-    /**
      * @return Transactions configuration.
      */
     public VisorTransactionConfiguration transaction() {
@@ -371,28 +252,14 @@ public class VisorGridConfiguration implements Serializable {
     }
 
     /**
-     * @param txCfg New transactions configuration.
-     */
-    public void transaction(VisorTransactionConfiguration txCfg) {
-        this.txCfg = txCfg;
-    }
-
-    /** {@inheritDoc} */
-    @Override public String toString() {
-        return S.toString(VisorGridConfiguration.class, this);
-    }
-
-    /**
      * @return Query configuration.
      */
     public VisorQueryConfiguration queryConfiguration() {
         return qryCfg;
     }
 
-    /**
-     * @param qryCfg New query configuration.
-     */
-    public void queryConfiguration(VisorQueryConfiguration qryCfg) {
-        this.qryCfg = qryCfg;
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(VisorGridConfiguration.class, this);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorIgfsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorIgfsConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorIgfsConfiguration.java
index 287de27..056ac7f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorIgfsConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorIgfsConfiguration.java
@@ -128,44 +128,44 @@ public class VisorIgfsConfiguration implements Serializable {
     public static VisorIgfsConfiguration from(IgfsConfiguration igfs) {
         VisorIgfsConfiguration cfg = new VisorIgfsConfiguration();
 
-        cfg.name(igfs.getName());
-        cfg.metaCacheName(igfs.getMetaCacheName());
-        cfg.dataCacheName(igfs.getDataCacheName());
-        cfg.blockSize(igfs.getBlockSize());
-        cfg.prefetchBlocks(igfs.getPrefetchBlocks());
-        cfg.streamBufferSize(igfs.getStreamBufferSize());
-        cfg.perNodeBatchSize(igfs.getPerNodeBatchSize());
-        cfg.perNodeParallelBatchCount(igfs.getPerNodeParallelBatchCount());
+        cfg.name = igfs.getName();
+        cfg.metaCacheName = igfs.getMetaCacheName();
+        cfg.dataCacheName = igfs.getDataCacheName();
+        cfg.blockSize = igfs.getBlockSize();
+        cfg.prefetchBlocks = igfs.getPrefetchBlocks();
+        cfg.streamBufSize = igfs.getStreamBufferSize();
+        cfg.perNodeBatchSize = igfs.getPerNodeBatchSize();
+        cfg.perNodeParallelBatchCnt = igfs.getPerNodeParallelBatchCount();
 
         Igfs secFs = igfs.getSecondaryFileSystem();
 
         if (secFs != null) {
             Map<String, String> props = secFs.properties();
 
-            cfg.secondaryHadoopFileSystemUri(props.get(SECONDARY_FS_URI));
-            cfg.secondaryHadoopFileSystemConfigPath(props.get(SECONDARY_FS_CONFIG_PATH));
+            cfg.secondaryHadoopFileSysUri = props.get(SECONDARY_FS_URI);
+            cfg.secondaryHadoopFileSysCfgPath = props.get(SECONDARY_FS_CONFIG_PATH);
         }
 
-        cfg.defaultMode(igfs.getDefaultMode());
-        cfg.pathModes(igfs.getPathModes());
-        cfg.dualModePutExecutorService(compactClass(igfs.getDualModePutExecutorService()));
-        cfg.dualModePutExecutorServiceShutdown(igfs.getDualModePutExecutorServiceShutdown());
-        cfg.dualModeMaxPendingPutsSize(igfs.getDualModeMaxPendingPutsSize());
-        cfg.maxTaskRangeLength(igfs.getMaximumTaskRangeLength());
-        cfg.fragmentizerConcurrentFiles(igfs.getFragmentizerConcurrentFiles());
-        cfg.fragmentizerLocalWritesRatio(igfs.getFragmentizerLocalWritesRatio());
-        cfg.fragmentizerEnabled(igfs.isFragmentizerEnabled());
-        cfg.fragmentizerThrottlingBlockLength(igfs.getFragmentizerThrottlingBlockLength());
-        cfg.fragmentizerThrottlingDelay(igfs.getFragmentizerThrottlingDelay());
+        cfg.dfltMode = igfs.getDefaultMode();
+        cfg.pathModes = igfs.getPathModes();
+        cfg.dualModePutExecutorSrvc = compactClass(igfs.getDualModePutExecutorService());
+        cfg.dualModePutExecutorSrvcShutdown = igfs.getDualModePutExecutorServiceShutdown();
+        cfg.dualModeMaxPendingPutsSize = igfs.getDualModeMaxPendingPutsSize();
+        cfg.maxTaskRangeLen = igfs.getMaximumTaskRangeLength();
+        cfg.fragmentizerConcurrentFiles = igfs.getFragmentizerConcurrentFiles();
+        cfg.fragmentizerLocWritesRatio = igfs.getFragmentizerLocalWritesRatio();
+        cfg.fragmentizerEnabled = igfs.isFragmentizerEnabled();
+        cfg.fragmentizerThrottlingBlockLen = igfs.getFragmentizerThrottlingBlockLength();
+        cfg.fragmentizerThrottlingDelay = igfs.getFragmentizerThrottlingDelay();
 
         Map<String, String> endpointCfg = igfs.getIpcEndpointConfiguration();
-        cfg.ipcEndpointConfiguration(endpointCfg != null ? endpointCfg.toString() : null);
+        cfg.ipcEndpointCfg = endpointCfg != null ? endpointCfg.toString() : null;
 
-        cfg.ipcEndpointEnabled(igfs.isIpcEndpointEnabled());
-        cfg.maxSpace(igfs.getMaxSpaceSize());
-        cfg.managementPort(igfs.getManagementPort());
-        cfg.sequenceReadsBeforePrefetch(igfs.getSequentialReadsBeforePrefetch());
-        cfg.trashPurgeTimeout(igfs.getTrashPurgeTimeout());
+        cfg.ipcEndpointEnabled = igfs.isIpcEndpointEnabled();
+        cfg.maxSpace = igfs.getMaxSpaceSize();
+        cfg.mgmtPort = igfs.getManagementPort();
+        cfg.seqReadsBeforePrefetch = igfs.getSequentialReadsBeforePrefetch();
+        cfg.trashPurgeTimeout = igfs.getTrashPurgeTimeout();
 
         return cfg;
     }
@@ -196,13 +196,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param name New IGFS instance name.
-     */
-    public void name(@Nullable String name) {
-        this.name = name;
-    }
-
-    /**
      * @return Cache name to store IGFS meta information.
      */
     @Nullable public String metaCacheName() {
@@ -210,13 +203,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param metaCacheName New cache name to store IGFS meta information.
-     */
-    public void metaCacheName(@Nullable String metaCacheName) {
-        this.metaCacheName = metaCacheName;
-    }
-
-    /**
      * @return Cache name to store IGFS data.
      */
     @Nullable public String dataCacheName() {
@@ -224,13 +210,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param dataCacheName New cache name to store IGFS data.
-     */
-    public void dataCacheName(@Nullable String dataCacheName) {
-        this.dataCacheName = dataCacheName;
-    }
-
-    /**
      * @return File's data block size.
      */
     public int blockSize() {
@@ -238,13 +217,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param blockSize New file's data block size.
-     */
-    public void blockSize(int blockSize) {
-        this.blockSize = blockSize;
-    }
-
-    /**
      * @return Number of pre-fetched blocks if specific file's chunk is requested.
      */
     public int prefetchBlocks() {
@@ -252,13 +224,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param prefetchBlocks New number of pre-fetched blocks if specific file's chunk is requested.
-     */
-    public void prefetchBlocks(int prefetchBlocks) {
-        this.prefetchBlocks = prefetchBlocks;
-    }
-
-    /**
      * @return Read/write buffer size for IGFS stream operations in bytes.
      */
     public int streamBufferSize() {
@@ -266,13 +231,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param streamBufSize New read/write buffer size for IGFS stream operations in bytes.
-     */
-    public void streamBufferSize(int streamBufSize) {
-        this.streamBufSize = streamBufSize;
-    }
-
-    /**
      * @return Number of file blocks buffered on local node before sending batch to remote node.
      */
     public int perNodeBatchSize() {
@@ -280,13 +238,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param perNodeBatchSize New number of file blocks buffered on local node before sending batch to remote node.
-     */
-    public void perNodeBatchSize(int perNodeBatchSize) {
-        this.perNodeBatchSize = perNodeBatchSize;
-    }
-
-    /**
      * @return Number of batches that can be concurrently sent to remote node.
      */
     public int perNodeParallelBatchCount() {
@@ -294,13 +245,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param perNodeParallelBatchCnt New number of batches that can be concurrently sent to remote node.
-     */
-    public void perNodeParallelBatchCount(int perNodeParallelBatchCnt) {
-        this.perNodeParallelBatchCnt = perNodeParallelBatchCnt;
-    }
-
-    /**
      * @return URI of the secondary Hadoop file system.
      */
     @Nullable public String secondaryHadoopFileSystemUri() {
@@ -308,13 +252,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param secondaryHadoopFileSysUri New URI of the secondary Hadoop file system.
-     */
-    public void secondaryHadoopFileSystemUri(@Nullable String secondaryHadoopFileSysUri) {
-        this.secondaryHadoopFileSysUri = secondaryHadoopFileSysUri;
-    }
-
-    /**
      * @return Path for the secondary hadoop file system config.
      */
     @Nullable public String secondaryHadoopFileSystemConfigPath() {
@@ -322,13 +259,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param secondaryHadoopFileSysCfgPath New path for the secondary hadoop file system config.
-     */
-    public void secondaryHadoopFileSystemConfigPath(@Nullable String secondaryHadoopFileSysCfgPath) {
-        this.secondaryHadoopFileSysCfgPath = secondaryHadoopFileSysCfgPath;
-    }
-
-    /**
      * @return IGFS instance mode.
      */
     public IgfsMode defaultMode() {
@@ -336,13 +266,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param dfltMode New IGFS instance mode.
-     */
-    public void defaultMode(IgfsMode dfltMode) {
-        this.dfltMode = dfltMode;
-    }
-
-    /**
      * @return Map of paths to IGFS modes.
      */
     @Nullable public Map<String, IgfsMode> pathModes() {
@@ -350,13 +273,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param pathModes New map of paths to IGFS modes.
-     */
-    public void pathModes(@Nullable Map<String, IgfsMode> pathModes) {
-        this.pathModes = pathModes;
-    }
-
-    /**
      * @return Dual mode PUT operations executor service.
      */
     public String dualModePutExecutorService() {
@@ -364,13 +280,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param dualModePutExecutorSrvc New dual mode PUT operations executor service.
-     */
-    public void dualModePutExecutorService(String dualModePutExecutorSrvc) {
-        this.dualModePutExecutorSrvc = dualModePutExecutorSrvc;
-    }
-
-    /**
      * @return Dual mode PUT operations executor service shutdown flag.
      */
     public boolean dualModePutExecutorServiceShutdown() {
@@ -378,13 +287,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param dualModePutExecutorSrvcShutdown New dual mode PUT operations executor service shutdown flag.
-     */
-    public void dualModePutExecutorServiceShutdown(boolean dualModePutExecutorSrvcShutdown) {
-        this.dualModePutExecutorSrvcShutdown = dualModePutExecutorSrvcShutdown;
-    }
-
-    /**
      * @return Maximum amount of data in pending puts.
      */
     public long dualModeMaxPendingPutsSize() {
@@ -392,13 +294,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param dualModeMaxPendingPutsSize New maximum amount of data in pending puts.
-     */
-    public void dualModeMaxPendingPutsSize(long dualModeMaxPendingPutsSize) {
-        this.dualModeMaxPendingPutsSize = dualModeMaxPendingPutsSize;
-    }
-
-    /**
      * @return Maximum range length.
      */
     public long maxTaskRangeLength() {
@@ -406,13 +301,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param maxTaskRangeLen New maximum range length.
-     */
-    public void maxTaskRangeLength(long maxTaskRangeLen) {
-        this.maxTaskRangeLen = maxTaskRangeLen;
-    }
-
-    /**
      * @return Fragmentizer concurrent files.
      */
     public int fragmentizerConcurrentFiles() {
@@ -420,13 +308,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param fragmentizerConcurrentFiles New fragmentizer concurrent files.
-     */
-    public void fragmentizerConcurrentFiles(int fragmentizerConcurrentFiles) {
-        this.fragmentizerConcurrentFiles = fragmentizerConcurrentFiles;
-    }
-
-    /**
      * @return Fragmentizer local writes ratio.
      */
     public float fragmentizerLocalWritesRatio() {
@@ -434,13 +315,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param fragmentizerLocWritesRatio New fragmentizer local writes ratio.
-     */
-    public void fragmentizerLocalWritesRatio(float fragmentizerLocWritesRatio) {
-        this.fragmentizerLocWritesRatio = fragmentizerLocWritesRatio;
-    }
-
-    /**
      * @return Fragmentizer enabled flag.
      */
     public boolean fragmentizerEnabled() {
@@ -448,13 +322,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param fragmentizerEnabled New fragmentizer enabled flag.
-     */
-    public void fragmentizerEnabled(boolean fragmentizerEnabled) {
-        this.fragmentizerEnabled = fragmentizerEnabled;
-    }
-
-    /**
      * @return Fragmentizer throttling block length.
      */
     public long fragmentizerThrottlingBlockLength() {
@@ -462,13 +329,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param fragmentizerThrottlingBlockLen New fragmentizer throttling block length.
-     */
-    public void fragmentizerThrottlingBlockLength(long fragmentizerThrottlingBlockLen) {
-        this.fragmentizerThrottlingBlockLen = fragmentizerThrottlingBlockLen;
-    }
-
-    /**
      * @return Fragmentizer throttling delay.
      */
     public long fragmentizerThrottlingDelay() {
@@ -476,13 +336,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param fragmentizerThrottlingDelay New fragmentizer throttling delay.
-     */
-    public void fragmentizerThrottlingDelay(long fragmentizerThrottlingDelay) {
-        this.fragmentizerThrottlingDelay = fragmentizerThrottlingDelay;
-    }
-
-    /**
      * @return IPC endpoint config (in JSON format) to publish IGFS over.
      */
     @Nullable public String ipcEndpointConfiguration() {
@@ -490,13 +343,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param ipcEndpointCfg New IPC endpoint config (in JSON format) to publish IGFS over.
-     */
-    public void ipcEndpointConfiguration(@Nullable String ipcEndpointCfg) {
-        this.ipcEndpointCfg = ipcEndpointCfg;
-    }
-
-    /**
      * @return IPC endpoint enabled flag.
      */
     public boolean ipcEndpointEnabled() {
@@ -504,13 +350,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param ipcEndpointEnabled New iPC endpoint enabled flag.
-     */
-    public void ipcEndpointEnabled(boolean ipcEndpointEnabled) {
-        this.ipcEndpointEnabled = ipcEndpointEnabled;
-    }
-
-    /**
      * @return Maximum space.
      */
     public long maxSpace() {
@@ -518,13 +357,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param maxSpace New maximum space.
-     */
-    public void maxSpace(long maxSpace) {
-        this.maxSpace = maxSpace;
-    }
-
-    /**
      * @return Management port.
      */
     public int managementPort() {
@@ -532,13 +364,6 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param mgmtPort New management port.
-     */
-    public void managementPort(int mgmtPort) {
-        this.mgmtPort = mgmtPort;
-    }
-
-    /**
      * @return Amount of sequential block reads before prefetch is triggered.
      */
     public int sequenceReadsBeforePrefetch() {
@@ -546,29 +371,14 @@ public class VisorIgfsConfiguration implements Serializable {
     }
 
     /**
-     * @param seqReadsBeforePrefetch New amount of sequential block reads before prefetch is triggered.
-     */
-    public void sequenceReadsBeforePrefetch(int seqReadsBeforePrefetch) {
-        this.seqReadsBeforePrefetch = seqReadsBeforePrefetch;
-    }
-
-    /**
      * @return Trash purge await timeout.
      */
     public long trashPurgeTimeout() {
         return trashPurgeTimeout;
     }
 
-    /**
-     * @param trashPurgeTimeout New trash purge await timeout.
-     */
-    public void trashPurgeTimeout(long trashPurgeTimeout) {
-        this.trashPurgeTimeout = trashPurgeTimeout;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorIgfsConfiguration.class, this);
     }
-
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorLifecycleConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorLifecycleConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorLifecycleConfiguration.java
index 723fbee..3e0f9cc 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorLifecycleConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorLifecycleConfiguration.java
@@ -42,7 +42,7 @@ public class VisorLifecycleConfiguration implements Serializable {
     public static VisorLifecycleConfiguration from(IgniteConfiguration c) {
         VisorLifecycleConfiguration cfg = new VisorLifecycleConfiguration();
 
-        cfg.beans(compactArray(c.getLifecycleBeans()));
+        cfg.beans = compactArray(c.getLifecycleBeans());
 
         return cfg;
     }
@@ -54,13 +54,6 @@ public class VisorLifecycleConfiguration implements Serializable {
         return beans;
     }
 
-    /**
-     * @param beans New lifecycle beans.
-     */
-    public void beans(@Nullable String beans) {
-        this.beans = beans;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorLifecycleConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorMetricsConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorMetricsConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorMetricsConfiguration.java
index 51dc092..e76adac 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorMetricsConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorMetricsConfiguration.java
@@ -18,6 +18,7 @@
 package org.apache.ignite.internal.visor.node;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.internal.util.typedef.internal.*;
 
 import java.io.*;
 
@@ -44,9 +45,9 @@ public class VisorMetricsConfiguration implements Serializable {
     public static VisorMetricsConfiguration from(IgniteConfiguration c) {
         VisorMetricsConfiguration cfg = new VisorMetricsConfiguration();
 
-        cfg.expireTime(c.getMetricsExpireTime());
-        cfg.historySize(c.getMetricsHistorySize());
-        cfg.loggerFrequency(c.getMetricsLogFrequency());
+        cfg.expTime = c.getMetricsExpireTime();
+        cfg.histSize = c.getMetricsHistorySize();
+        cfg.logFreq = c.getMetricsLogFrequency();
 
         return cfg;
     }
@@ -59,13 +60,6 @@ public class VisorMetricsConfiguration implements Serializable {
     }
 
     /**
-     * @param expTime New metrics expire time.
-     */
-    public void expireTime(long expTime) {
-        this.expTime = expTime;
-    }
-
-    /**
      * @return Number of node metrics stored in memory.
      */
     public int historySize() {
@@ -73,23 +67,14 @@ public class VisorMetricsConfiguration implements Serializable {
     }
 
     /**
-     * @param histSize New number of node metrics stored in memory.
-     */
-    public void historySize(int histSize) {
-        this.histSize = histSize;
-    }
-
-    /**
      * @return Frequency of metrics log printout.
      */
     public long loggerFrequency() {
         return logFreq;
     }
 
-    /**
-     * @param logFreq New frequency of metrics log printout.
-     */
-    public void loggerFrequency(long logFreq) {
-        this.logFreq = logFreq;
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(VisorMetricsConfiguration.class, this);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorPeerToPeerConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorPeerToPeerConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorPeerToPeerConfiguration.java
index 7f0d050..5c4f8fc 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorPeerToPeerConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorPeerToPeerConfiguration.java
@@ -48,9 +48,9 @@ public class VisorPeerToPeerConfiguration implements Serializable {
     public static VisorPeerToPeerConfiguration from(IgniteConfiguration c) {
         VisorPeerToPeerConfiguration cfg = new VisorPeerToPeerConfiguration();
 
-        cfg.p2pEnabled(c.isPeerClassLoadingEnabled());
-        cfg.p2pMissedResponseCacheSize(c.getPeerClassLoadingMissedResourcesCacheSize());
-        cfg.p2pLocalClassPathExclude(compactArray(c.getPeerClassLoadingLocalClassPathExclude()));
+        cfg.p2pEnabled = c.isPeerClassLoadingEnabled();
+        cfg.p2pMissedResCacheSize = c.getPeerClassLoadingMissedResourcesCacheSize();
+        cfg.p2pLocClsPathExcl = compactArray(c.getPeerClassLoadingLocalClassPathExclude());
 
         return cfg;
     }
@@ -63,13 +63,6 @@ public class VisorPeerToPeerConfiguration implements Serializable {
     }
 
     /**
-     * @param p2pEnabled New whether peer-to-peer class loading is enabled.
-     */
-    public void p2pEnabled(boolean p2pEnabled) {
-        this.p2pEnabled = p2pEnabled;
-    }
-
-    /**
      * @return Missed resource cache size.
      */
     public int p2pMissedResponseCacheSize() {
@@ -77,27 +70,12 @@ public class VisorPeerToPeerConfiguration implements Serializable {
     }
 
     /**
-     * @param p2pMissedResCacheSize New missed resource cache size.
-     */
-    public void p2pMissedResponseCacheSize(int p2pMissedResCacheSize) {
-        this.p2pMissedResCacheSize = p2pMissedResCacheSize;
-    }
-
-    /**
      * @return List of packages from the system classpath that need to be loaded from task originating node.
      */
     @Nullable public String p2pLocalClassPathExclude() {
         return p2pLocClsPathExcl;
     }
 
-    /**
-     * @param p2pLocClsPathExcl New list of packages from the system classpath that need to be loaded from task
-     * originating node.
-     */
-    public void p2pLocalClassPathExclude(@Nullable String p2pLocClsPathExcl) {
-        this.p2pLocClsPathExcl = p2pLocClsPathExcl;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorPeerToPeerConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorQueryConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorQueryConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorQueryConfiguration.java
index a2599ab..de5e0b2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorQueryConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorQueryConfiguration.java
@@ -70,13 +70,13 @@ public class VisorQueryConfiguration implements Serializable {
             for (int i = 0; i < sz; i++)
                 strClss[i] = U.compact(clss[i].getName());
 
-            c.indexCustomFunctionClasses(strClss);
-            c.searchPath(qcfg.getSearchPath());
-            c.initialScriptPath(qcfg.getInitialScriptPath());
-            c.maxOffHeapMemory(qcfg.getMaxOffHeapMemory());
-            c.longQueryExecutionTimeout(qcfg.getLongQueryExecutionTimeout());
-            c.longQueryExplain(qcfg.isLongQueryExplain());
-            c.useOptimizedSerializer(qcfg.isUseOptimizedSerializer());
+            c.idxCustomFuncClss = strClss;
+            c.searchPath = qcfg.getSearchPath();
+            c.initScriptPath = qcfg.getInitialScriptPath();
+            c.maxOffHeapMemory = qcfg.getMaxOffHeapMemory();
+            c.longQryExecTimeout = qcfg.getLongQueryExecutionTimeout();
+            c.longQryExplain = qcfg.isLongQueryExplain();
+            c.useOptimizedSerializer = qcfg.isUseOptimizedSerializer();
         }
 
         return c;
@@ -90,13 +90,6 @@ public class VisorQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param idxCustomFuncClss Classes with methods annotated by {@link QuerySqlFunction}.
-     */
-    public void indexCustomFunctionClasses(String[] idxCustomFuncClss) {
-        this.idxCustomFuncClss = idxCustomFuncClss;
-    }
-
-    /**
      * @return Optional search path consisting of space names to search SQL schema objects.
      */
     public String[] searchPath() {
@@ -104,13 +97,6 @@ public class VisorQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param searchPath Optional search path consisting of space names to search SQL schema objects.
-     */
-    public void searchPath(String[] searchPath) {
-        this.searchPath = searchPath;
-    }
-
-    /**
      * @return Script path to be ran against H2 database after opening.
      */
     public String initialScriptPath() {
@@ -118,13 +104,6 @@ public class VisorQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param initScriptPath Script path to be ran against H2 database after opening.
-     */
-    public void initialScriptPath(String initScriptPath) {
-        this.initScriptPath = initScriptPath;
-    }
-
-    /**
      * @return Maximum amount of memory available to off-heap storage.
      */
     public long maxOffHeapMemory() {
@@ -132,13 +111,6 @@ public class VisorQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param maxOffHeapMemory Maximum amount of memory available to off-heap storage.
-     */
-    public void maxOffHeapMemory(long maxOffHeapMemory) {
-        this.maxOffHeapMemory = maxOffHeapMemory;
-    }
-
-    /**
      * @return Query execution time threshold.
      */
     public long longQueryExecutionTimeout() {
@@ -146,13 +118,6 @@ public class VisorQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param longQryExecTimeout Query execution time threshold.
-     */
-    public void longQueryExecutionTimeout(long longQryExecTimeout) {
-        this.longQryExecTimeout = longQryExecTimeout;
-    }
-
-    /**
      * @return If {@code true}, SPI will print SQL execution plan for long queries.
      */
     public boolean longQryExplain() {
@@ -160,24 +125,14 @@ public class VisorQueryConfiguration implements Serializable {
     }
 
     /**
-     * @param longQryExplain If {@code true}, SPI will print SQL execution plan for long queries.
-     */
-    public void longQueryExplain(boolean longQryExplain) {
-        this.longQryExplain = longQryExplain;
-    }
-
-    /**
      * @return The flag indicating that serializer for H2 database will be set to Ignite's marshaller.
      */
     public boolean useOptimizedSerializer() {
         return useOptimizedSerializer;
     }
 
-    /**
-     * @param useOptimizedSerializer The flag indicating that serializer for H2 database will be set to Ignite's
-     * marshaller.
-     */
-    public void useOptimizedSerializer(boolean useOptimizedSerializer) {
-        this.useOptimizedSerializer = useOptimizedSerializer;
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return S.toString(VisorQueryConfiguration.class, this);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorRestConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorRestConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorRestConfiguration.java
index 1bdb7b7..f279253 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorRestConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorRestConfiguration.java
@@ -72,16 +72,16 @@ public class VisorRestConfiguration implements Serializable {
 
         boolean restEnabled = clnCfg != null;
 
-        cfg.restEnabled(restEnabled);
+        cfg.restEnabled = restEnabled;
 
         if (restEnabled) {
-            cfg.tcpSslEnabled(clnCfg.isSslEnabled());
-            cfg.jettyPath(clnCfg.getJettyPath());
-            cfg.jettyHost(getProperty(IGNITE_JETTY_HOST));
-            cfg.jettyPort(intValue(IGNITE_JETTY_PORT, null));
-            cfg.tcpHost(clnCfg.getHost());
-            cfg.tcpPort(clnCfg.getPort());
-            cfg.tcpSslContextFactory(compactClass(clnCfg.getSslContextFactory()));
+            cfg.tcpSslEnabled = clnCfg.isSslEnabled();
+            cfg.jettyPath = clnCfg.getJettyPath();
+            cfg.jettyHost = getProperty(IGNITE_JETTY_HOST);
+            cfg.jettyPort = intValue(IGNITE_JETTY_PORT, null);
+            cfg.tcpHost = clnCfg.getHost();
+            cfg.tcpPort = clnCfg.getPort();
+            cfg.tcpSslCtxFactory = compactClass(clnCfg.getSslContextFactory());
         }
 
         return cfg;
@@ -93,14 +93,6 @@ public class VisorRestConfiguration implements Serializable {
     public boolean restEnabled() {
         return restEnabled;
     }
-
-    /**
-     * @param restEnabled New whether REST enabled or not.
-     */
-    public void restEnabled(boolean restEnabled) {
-        this.restEnabled = restEnabled;
-    }
-
     /**
      * @return Whether or not SSL is enabled for TCP binary protocol.
      */
@@ -109,13 +101,6 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param tcpSslEnabled New whether or not SSL is enabled for TCP binary protocol.
-     */
-    public void tcpSslEnabled(boolean tcpSslEnabled) {
-        this.tcpSslEnabled = tcpSslEnabled;
-    }
-
-    /**
      * @return Rest accessible folders (log command can get files from).
      */
     @Nullable public String[] accessibleFolders() {
@@ -123,13 +108,6 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param accessibleFolders New rest accessible folders (log command can get files from).
-     */
-    public void accessibleFolders(String[] accessibleFolders) {
-        this.accessibleFolders = accessibleFolders;
-    }
-
-    /**
      * @return Jetty config path.
      */
     @Nullable public String jettyPath() {
@@ -137,13 +115,6 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param jettyPath New jetty config path.
-     */
-    public void jettyPath(String jettyPath) {
-        this.jettyPath = jettyPath;
-    }
-
-    /**
      * @return Jetty host.
      */
     @Nullable public String jettyHost() {
@@ -151,13 +122,6 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param jettyHost New jetty host.
-     */
-    public void jettyHost(String jettyHost) {
-        this.jettyHost = jettyHost;
-    }
-
-    /**
      * @return Jetty port.
      */
     @Nullable public Integer jettyPort() {
@@ -165,13 +129,6 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param jettyPort New jetty port.
-     */
-    public void jettyPort(Integer jettyPort) {
-        this.jettyPort = jettyPort;
-    }
-
-    /**
      * @return REST TCP binary host.
      */
     @Nullable public String tcpHost() {
@@ -179,13 +136,6 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param tcpHost New rEST TCP binary host.
-     */
-    public void tcpHost(String tcpHost) {
-        this.tcpHost = tcpHost;
-    }
-
-    /**
      * @return REST TCP binary port.
      */
     @Nullable public Integer tcpPort() {
@@ -193,26 +143,12 @@ public class VisorRestConfiguration implements Serializable {
     }
 
     /**
-     * @param tcpPort New rEST TCP binary port.
-     */
-    public void tcpPort(Integer tcpPort) {
-        this.tcpPort = tcpPort;
-    }
-
-    /**
      * @return Context factory for SSL.
      */
     @Nullable public String tcpSslContextFactory() {
         return tcpSslCtxFactory;
     }
 
-    /**
-     * @param tcpSslCtxFactory New context factory for SSL.
-     */
-    public void tcpSslContextFactory(String tcpSslCtxFactory) {
-        this.tcpSslCtxFactory = tcpSslCtxFactory;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorRestConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSegmentationConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSegmentationConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSegmentationConfiguration.java
index 547e1c6..d712774 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSegmentationConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSegmentationConfiguration.java
@@ -55,11 +55,11 @@ public class VisorSegmentationConfiguration implements Serializable {
     public static VisorSegmentationConfiguration from(IgniteConfiguration c) {
         VisorSegmentationConfiguration cfg = new VisorSegmentationConfiguration();
 
-        cfg.policy(c.getSegmentationPolicy());
-        cfg.resolvers(compactArray(c.getSegmentationResolvers()));
-        cfg.checkFrequency(c.getSegmentCheckFrequency());
-        cfg.waitOnStart(c.isWaitForSegmentOnStart());
-        cfg.passRequired(c.isAllSegmentationResolversPassRequired());
+        cfg.plc = c.getSegmentationPolicy();
+        cfg.resolvers = compactArray(c.getSegmentationResolvers());
+        cfg.checkFreq = c.getSegmentCheckFrequency();
+        cfg.waitOnStart = c.isWaitForSegmentOnStart();
+        cfg.passRequired = c.isAllSegmentationResolversPassRequired();
 
         return cfg;
     }
@@ -72,13 +72,6 @@ public class VisorSegmentationConfiguration implements Serializable {
     }
 
     /**
-     * @param plc New segmentation policy.
-     */
-    public void policy(GridSegmentationPolicy plc) {
-        this.plc = plc;
-    }
-
-    /**
      * @return Segmentation resolvers.
      */
     @Nullable public String resolvers() {
@@ -86,13 +79,6 @@ public class VisorSegmentationConfiguration implements Serializable {
     }
 
     /**
-     * @param resolvers New segmentation resolvers.
-     */
-    public void resolvers(@Nullable String resolvers) {
-        this.resolvers = resolvers;
-    }
-
-    /**
      * @return Frequency of network segment check by discovery manager.
      */
     public long checkFrequency() {
@@ -100,13 +86,6 @@ public class VisorSegmentationConfiguration implements Serializable {
     }
 
     /**
-     * @param checkFreq New frequency of network segment check by discovery manager.
-     */
-    public void checkFrequency(long checkFreq) {
-        this.checkFreq = checkFreq;
-    }
-
-    /**
      * @return Whether or not node should wait for correct segment on start.
      */
     public boolean waitOnStart() {
@@ -114,26 +93,12 @@ public class VisorSegmentationConfiguration implements Serializable {
     }
 
     /**
-     * @param waitOnStart New whether or not node should wait for correct segment on start.
-     */
-    public void waitOnStart(boolean waitOnStart) {
-        this.waitOnStart = waitOnStart;
-    }
-
-    /**
      * @return Whether or not all resolvers should succeed for node to be in correct segment.
      */
     public boolean passRequired() {
         return passRequired;
     }
 
-    /**
-     * @param passRequired New whether or not all resolvers should succeed for node to be in correct segment.
-     */
-    public void passRequired(boolean passRequired) {
-        this.passRequired = passRequired;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorSegmentationConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSpisConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSpisConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSpisConfiguration.java
index 6833393..4afb90f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSpisConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorSpisConfiguration.java
@@ -18,6 +18,7 @@
 package org.apache.ignite.internal.visor.node;
 
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.spi.*;
@@ -141,16 +142,16 @@ public class VisorSpisConfiguration implements Serializable {
     public static VisorSpisConfiguration from(IgniteConfiguration c) {
         VisorSpisConfiguration cfg = new VisorSpisConfiguration();
 
-        cfg.discoverySpi(collectSpiInfo(c.getDiscoverySpi()));
-        cfg.communicationSpi(collectSpiInfo(c.getCommunicationSpi()));
-        cfg.eventStorageSpi(collectSpiInfo(c.getEventStorageSpi()));
-        cfg.collisionSpi(collectSpiInfo(c.getCollisionSpi()));
-        cfg.deploymentSpi(collectSpiInfo(c.getDeploymentSpi()));
-        cfg.checkpointSpis(collectSpiInfo(c.getCheckpointSpi()));
-        cfg.failoverSpis(collectSpiInfo(c.getFailoverSpi()));
-        cfg.loadBalancingSpis(collectSpiInfo(c.getLoadBalancingSpi()));
-        cfg.swapSpaceSpi(collectSpiInfo(c.getSwapSpaceSpi()));
-        cfg.indexingSpis(collectSpiInfo(c.getIndexingSpi()));
+        cfg.discoSpi = collectSpiInfo(c.getDiscoverySpi());
+        cfg.commSpi = collectSpiInfo(c.getCommunicationSpi());
+        cfg.evtSpi = collectSpiInfo(c.getEventStorageSpi());
+        cfg.colSpi = collectSpiInfo(c.getCollisionSpi());
+        cfg.deploySpi = collectSpiInfo(c.getDeploymentSpi());
+        cfg.cpSpis = collectSpiInfo(c.getCheckpointSpi());
+        cfg.failSpis = collectSpiInfo(c.getFailoverSpi());
+        cfg.loadBalancingSpis = collectSpiInfo(c.getLoadBalancingSpi());
+        cfg.swapSpaceSpis = collectSpiInfo(c.getSwapSpaceSpi());
+        cfg.indexingSpis = F.asArray(collectSpiInfo(c.getIndexingSpi()));
 
         return cfg;
     }
@@ -163,13 +164,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param discoSpi New discovery SPI.
-     */
-    public void discoverySpi(IgniteBiTuple<String, Map<String, Object>> discoSpi) {
-        this.discoSpi = discoSpi;
-    }
-
-    /**
      * @return Communication SPI.
      */
     public IgniteBiTuple<String, Map<String, Object>> communicationSpi() {
@@ -177,13 +171,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param commSpi New communication SPI.
-     */
-    public void communicationSpi(IgniteBiTuple<String, Map<String, Object>> commSpi) {
-        this.commSpi = commSpi;
-    }
-
-    /**
      * @return Event storage SPI.
      */
     public IgniteBiTuple<String, Map<String, Object>> eventStorageSpi() {
@@ -191,13 +178,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param evtSpi New event storage SPI.
-     */
-    public void eventStorageSpi(IgniteBiTuple<String, Map<String, Object>> evtSpi) {
-        this.evtSpi = evtSpi;
-    }
-
-    /**
      * @return Collision SPI.
      */
     public IgniteBiTuple<String, Map<String, Object>> collisionSpi() {
@@ -205,13 +185,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param colSpi New collision SPI.
-     */
-    public void collisionSpi(IgniteBiTuple<String, Map<String, Object>> colSpi) {
-        this.colSpi = colSpi;
-    }
-
-    /**
      * @return Deployment SPI.
      */
     public IgniteBiTuple<String, Map<String, Object>> deploymentSpi() {
@@ -219,13 +192,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param deploySpi New deployment SPI.
-     */
-    public void deploymentSpi(IgniteBiTuple<String, Map<String, Object>> deploySpi) {
-        this.deploySpi = deploySpi;
-    }
-
-    /**
      * @return Checkpoint SPIs.
      */
     public IgniteBiTuple<String, Map<String, Object>>[] checkpointSpis() {
@@ -233,13 +199,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param cpSpis New checkpoint SPIs.
-     */
-    public void checkpointSpis(IgniteBiTuple<String, Map<String, Object>>[] cpSpis) {
-        this.cpSpis = cpSpis;
-    }
-
-    /**
      * @return Failover SPIs.
      */
     public IgniteBiTuple<String, Map<String, Object>>[] failoverSpis() {
@@ -247,13 +206,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param failSpis New failover SPIs.
-     */
-    public void failoverSpis(IgniteBiTuple<String, Map<String, Object>>[] failSpis) {
-        this.failSpis = failSpis;
-    }
-
-    /**
      * @return Load balancing SPIs.
      */
     public IgniteBiTuple<String, Map<String, Object>>[] loadBalancingSpis() {
@@ -261,13 +213,6 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param loadBalancingSpis New load balancing SPIs.
-     */
-    public void loadBalancingSpis(IgniteBiTuple<String, Map<String, Object>>[] loadBalancingSpis) {
-        this.loadBalancingSpis = loadBalancingSpis;
-    }
-
-    /**
      * @return Swap space SPIs.
      */
     public IgniteBiTuple<String, Map<String, Object>> swapSpaceSpi() {
@@ -275,27 +220,12 @@ public class VisorSpisConfiguration implements Serializable {
     }
 
     /**
-     * @param swapSpaceSpis New swap space SPIs.
-     */
-    public void swapSpaceSpi(IgniteBiTuple<String, Map<String, Object>> swapSpaceSpis) {
-        this.swapSpaceSpis = swapSpaceSpis;
-    }
-
-    /**
      * @return Indexing SPIs.
      */
     public IgniteBiTuple<String, Map<String, Object>>[] indexingSpis() {
         return indexingSpis;
     }
 
-    /**
-     * @param indexingSpis New indexing SPIs.
-     */
-    @SafeVarargs
-    public final void indexingSpis(IgniteBiTuple<String, Map<String, Object>>... indexingSpis) {
-        this.indexingSpis = indexingSpis;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorSpisConfiguration.class, this);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57bdd8a5/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
index 597336b..667ff51 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
@@ -3,7 +3,7 @@
  * 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 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
@@ -31,10 +31,10 @@ public class VisorTransactionConfiguration implements Serializable {
     private static final long serialVersionUID = 0L;
 
     /** Default cache concurrency. */
-    private TransactionConcurrency dfltConcurrency;
+    private TransactionConcurrency dfltTxConcurrency;
 
     /** Default transaction isolation. */
-    private TransactionIsolation dfltIsolation;
+    private TransactionIsolation dfltTxIsolation;
 
     /** Default transaction timeout. */
     private long dfltTxTimeout;
@@ -57,12 +57,12 @@ public class VisorTransactionConfiguration implements Serializable {
     public static VisorTransactionConfiguration from(TransactionConfiguration src) {
         VisorTransactionConfiguration cfg = new VisorTransactionConfiguration();
 
-        cfg.defaultTxConcurrency(src.getDefaultTxConcurrency());
-        cfg.defaultTxIsolation(src.getDefaultTxIsolation());
-        cfg.defaultTxTimeout(src.getDefaultTxTimeout());
-        cfg.pessimisticTxLogLinger(src.getPessimisticTxLogLinger());
-        cfg.pessimisticTxLogSize(src.getPessimisticTxLogSize());
-        cfg.txSerializableEnabled(src.isTxSerializableEnabled());
+        cfg.dfltTxConcurrency = src.getDefaultTxConcurrency();
+        cfg.dfltTxIsolation = src.getDefaultTxIsolation();
+        cfg.dfltTxTimeout = src.getDefaultTxTimeout();
+        cfg.pessimisticTxLogLinger = src.getPessimisticTxLogLinger();
+        cfg.pessimisticTxLogSize = src.getPessimisticTxLogSize();
+        cfg.txSerEnabled = src.isTxSerializableEnabled();
 
         return cfg;
     }
@@ -71,28 +71,14 @@ public class VisorTransactionConfiguration implements Serializable {
      * @return Default cache transaction concurrency.
      */
     public TransactionConcurrency defaultTxConcurrency() {
-        return dfltConcurrency;
-    }
-
-    /**
-     * @param dfltConcurrency Default cache transaction concurrency.
-     */
-    public void defaultTxConcurrency(TransactionConcurrency dfltConcurrency) {
-        this.dfltConcurrency = dfltConcurrency;
+        return dfltTxConcurrency;
     }
 
     /**
      * @return Default cache transaction isolation.
      */
     public TransactionIsolation defaultTxIsolation() {
-        return dfltIsolation;
-    }
-
-    /**
-     * @param dfltIsolation Default cache transaction isolation.
-     */
-    public void defaultTxIsolation(TransactionIsolation dfltIsolation) {
-        this.dfltIsolation = dfltIsolation;
+        return dfltTxIsolation;
     }
 
     /**
@@ -103,13 +89,6 @@ public class VisorTransactionConfiguration implements Serializable {
     }
 
     /**
-     * @param dfltTxTimeout Default transaction timeout.
-     */
-    public void defaultTxTimeout(long dfltTxTimeout) {
-        this.dfltTxTimeout = dfltTxTimeout;
-    }
-
-    /**
      * @return Pessimistic log cleanup delay in milliseconds.
      */
     public int pessimisticTxLogLinger() {
@@ -117,13 +96,6 @@ public class VisorTransactionConfiguration implements Serializable {
     }
 
     /**
-     * @param pessimisticTxLogLinger Pessimistic log cleanup delay.
-     */
-    public void pessimisticTxLogLinger(int pessimisticTxLogLinger) {
-        this.pessimisticTxLogLinger = pessimisticTxLogLinger;
-    }
-
-    /**
      * @return Pessimistic transaction log size.
      */
     public int getPessimisticTxLogSize() {
@@ -131,26 +103,12 @@ public class VisorTransactionConfiguration implements Serializable {
     }
 
     /**
-     * @param pessimisticTxLogSize Pessimistic transactions log size.
-     */
-    public void pessimisticTxLogSize(int pessimisticTxLogSize) {
-        this.pessimisticTxLogSize = pessimisticTxLogSize;
-    }
-
-    /**
      * @return {@code True} if serializable transactions are enabled, {@code false} otherwise.
      */
     public boolean txSerializableEnabled() {
         return txSerEnabled;
     }
 
-    /**
-     * @param txSerEnabled Flag to enable/disable serializable cache transactions.
-     */
-    public void txSerializableEnabled(boolean txSerEnabled) {
-        this.txSerEnabled = txSerEnabled;
-    }
-
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(VisorTransactionConfiguration.class, this);


[19/50] incubator-ignite git commit: # sprint-2 - exception fix.

Posted by sb...@apache.org.
# sprint-2 - exception fix.


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

Branch: refs/heads/ignite-337
Commit: 6097e7bfc3af49296b50017d5661d313aaa3db80
Parents: a14ef18
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Sat Feb 28 00:29:42 2015 -0500
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Sat Feb 28 00:29:42 2015 -0500

----------------------------------------------------------------------
 .../examples/datagrid/store/jdbc/CacheJdbcPersonStore.java     | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/6097e7bf/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
index 6388fbf..d80861d 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
@@ -92,7 +92,7 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
     }
 
     /** {@inheritDoc} */
-    @Nullable @Override public Person load(Long key) {
+    @Override public Person load(Long key) {
         Transaction tx = transaction();
 
         System.out.println(">>> Store load [key=" + key + ", xid=" + (tx == null ? null : tx.xid()) + ']');
@@ -185,7 +185,7 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
             }
         }
         catch (SQLException e) {
-            throw new CacheLoaderException("Failed to remove object: " + key, e);
+            throw new CacheWriterException("Failed to remove object: " + key, e);
         }
         finally {
             end(tx, conn);
@@ -302,7 +302,7 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
     /**
      * @return Current transaction.
      */
-    @Nullable private Transaction transaction() {
+    private Transaction transaction() {
         return ses != null ? ses.transaction() : null;
     }
 }


[39/50] incubator-ignite git commit: sprint-2 fix for ignite-321

Posted by sb...@apache.org.
sprint-2 fix for ignite-321


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

Branch: refs/heads/ignite-337
Commit: 11efb91874a547c408dcac58f0651725ad518abe
Parents: 3be22ab
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Mar 2 16:36:02 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Mar 2 16:36:02 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheStoreManager.java | 12 ++++----
 .../GridDistributedCacheAdapter.java            |  2 ++
 .../dataload/IgniteDataLoaderImpl.java          | 29 +++++++++++++++-----
 3 files changed, 30 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/11efb918/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
index 9262a8f..c768f54 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
@@ -616,6 +616,9 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
                     handleClassCastException(e);
                 }
                 catch (Exception e) {
+                    if (!(e instanceof CacheWriterException))
+                        e = new CacheWriterException(e);
+
                     if (!entries.isEmpty()) {
                         List<Object> keys = new ArrayList<>(entries.size());
 
@@ -625,9 +628,6 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
                         throw new CacheStorePartialUpdateException(keys, e);
                     }
 
-                    if (!(e instanceof CacheWriterException))
-                        e = new CacheWriterException(e);
-
                     throw new IgniteCheckedException(e);
                 }
                 finally {
@@ -725,12 +725,12 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
                 handleClassCastException(e);
             }
             catch (Exception e) {
-                if (!keys0.isEmpty())
-                    throw new CacheStorePartialUpdateException(keys0, e);
-
                 if (!(e instanceof CacheWriterException))
                     e = new CacheWriterException(e);
 
+                if (!keys0.isEmpty())
+                    throw new CacheStorePartialUpdateException(keys0, e);
+
                 throw new IgniteCheckedException(e);
             }
             finally {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/11efb918/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedCacheAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedCacheAdapter.java
index dc82e83..00190d9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedCacheAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/GridDistributedCacheAdapter.java
@@ -277,6 +277,8 @@ public abstract class GridDistributedCacheAdapter<K, V> extends GridCacheAdapter
                     dht = (GridDhtCacheAdapter<K, V>)cacheAdapter;
 
                 try (IgniteDataLoader<K, V> dataLdr = ignite.dataLoader(cacheName)) {
+                    ((IgniteDataLoaderImpl)dataLdr).maxRemapCount(0);
+
                     dataLdr.updater(GridDataLoadCacheUpdaters.<K, V>batched());
 
                     for (GridDhtLocalPartition<K, V> locPart : dht.topology().currentLocalPartitions()) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/11efb918/modules/core/src/main/java/org/apache/ignite/internal/processors/dataload/IgniteDataLoaderImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/dataload/IgniteDataLoaderImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/dataload/IgniteDataLoaderImpl.java
index ced8d1d..ed3bbcb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/dataload/IgniteDataLoaderImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/dataload/IgniteDataLoaderImpl.java
@@ -66,7 +66,7 @@ public class IgniteDataLoaderImpl<K, V> implements IgniteDataLoader<K, V>, Delay
     private byte[] updaterBytes;
 
     /** Max remap count before issuing an error. */
-    private static final int MAX_REMAP_CNT = 32;
+    private static final int DFLT_MAX_REMAP_CNT = 32;
 
     /** Log reference. */
     private static final AtomicReference<IgniteLogger> logRef = new AtomicReference<>();
@@ -156,6 +156,9 @@ public class IgniteDataLoaderImpl<K, V> implements IgniteDataLoader<K, V>, Delay
     /** */
     private boolean skipStore;
 
+    /** */
+    private int maxRemapCnt = DFLT_MAX_REMAP_CNT;
+
     /**
      * @param ctx Grid kernal context.
      * @param cacheName Cache name.
@@ -434,12 +437,6 @@ public class IgniteDataLoaderImpl<K, V> implements IgniteDataLoader<K, V>, Delay
     ) {
         assert entries != null;
 
-        if (remaps >= MAX_REMAP_CNT) {
-            resFut.onDone(new IgniteCheckedException("Failed to finish operation (too many remaps): " + remaps));
-
-            return;
-        }
-
         Map<ClusterNode, Collection<Map.Entry<K, V>>> mappings = new HashMap<>();
 
         boolean initPda = ctx.deploy().enabled() && jobPda == null;
@@ -526,6 +523,10 @@ public class IgniteDataLoaderImpl<K, V> implements IgniteDataLoader<K, V>, Delay
                             resFut.onDone(new IgniteCheckedException("Data loader has been cancelled: " +
                                 IgniteDataLoaderImpl.this, e1));
                         }
+                        else if (remaps + 1 > maxRemapCnt) {
+                            resFut.onDone(new IgniteCheckedException("Failed to finish operation (too many remaps): "
+                                + remaps), e1);
+                        }
                         else
                             load0(entriesForNode, resFut, activeKeys, remaps + 1);
                     }
@@ -760,6 +761,20 @@ public class IgniteDataLoaderImpl<K, V> implements IgniteDataLoader<K, V>, Delay
         close(false);
     }
 
+    /**
+     * @return Max remap count.
+     */
+    public int maxRemapCount() {
+        return maxRemapCnt;
+    }
+
+    /**
+     * @param maxRemapCnt New max remap count.
+     */
+    public void maxRemapCount(int maxRemapCnt) {
+        this.maxRemapCnt = maxRemapCnt;
+    }
+
     /** {@inheritDoc} */
     @Override public String toString() {
         return S.toString(IgniteDataLoaderImpl.class, this);


[14/50] incubator-ignite git commit: Merge branch 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2

Posted by sb...@apache.org.
Merge branch 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2


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

Branch: refs/heads/ignite-337
Commit: a792c995ed211f56b741396ab9c2cf2f74646597
Parents: 9fb1eeb f053746
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 19:57:11 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 19:57:11 2015 +0300

----------------------------------------------------------------------
 .../HibernateReadWriteAccessStrategy.java       | 81 +++++++++++++++-----
 1 file changed, 63 insertions(+), 18 deletions(-)
----------------------------------------------------------------------



[42/50] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-2' into sprint-2

Posted by sb...@apache.org.
Merge remote-tracking branch 'origin/sprint-2' into sprint-2


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

Branch: refs/heads/ignite-337
Commit: 403d60feed477a4598509b619b2f63de307b9b5b
Parents: 8baca04 9671471
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Mar 2 17:16:40 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Mar 2 17:16:40 2015 +0300

----------------------------------------------------------------------
 .../configuration/IgniteConfiguration.java      |   5 +-
 .../org/apache/ignite/internal/IgnitionEx.java  | 592 +++++++++----------
 .../GridCacheQueueCleanupSelfTest.java          |   1 -
 3 files changed, 267 insertions(+), 331 deletions(-)
----------------------------------------------------------------------



[49/50] incubator-ignite git commit: Merge branch 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2

Posted by sb...@apache.org.
Merge branch 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-2


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

Branch: refs/heads/ignite-337
Commit: b2675bc3a6875c462e3d0aeb1478ee4d72039c44
Parents: 9a93198 3b309f2
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Mon Mar 2 17:50:47 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Mon Mar 2 17:50:47 2015 +0300

----------------------------------------------------------------------
 examples/pom-standalone.xml                       | 2 +-
 modules/core/src/main/resources/ignite.properties | 2 +-
 pom.xml                                           | 4 ++--
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------



[41/50] incubator-ignite git commit: ignite-342 review

Posted by sb...@apache.org.
ignite-342 review


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

Branch: refs/heads/ignite-337
Commit: 8baca046e02e703b5ce5c0a2f1a34ba279392a3e
Parents: 11efb91
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Mar 2 17:16:26 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Mar 2 17:16:26 2015 +0300

----------------------------------------------------------------------
 .../affinity/GridAffinityAssignmentCache.java   |  13 +-
 .../processors/cache/GridCacheContext.java      |  19 ++
 .../processors/cache/GridCacheProcessor.java    |  15 ++
 ...acheAbstractUsersAffinityMapperSelfTest.java | 207 +++++++++++++++++++
 ...dCacheAtomicUsersAffinityMapperSelfTest.java |  45 ++++
 ...heReplicatedUsersAffinityMapperSelfTest.java |  45 ++++
 .../GridCacheTxUsersAffinityMapperSelfTest.java |  45 ++++
 7 files changed, 388 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8baca046/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
index 9c12a17..69795b1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/affinity/GridAffinityAssignmentCache.java
@@ -305,7 +305,18 @@ public class GridAffinityAssignmentCache {
             }
         }
 
-        return aff.partition(affMapper.affinityKey(key));
+        return aff.partition(affinityKey(key));
+    }
+
+    /**
+     * If Key is {@link GridCacheInternal GridCacheInternal} entry when won't passed into user's mapper and
+     * will use {@link GridCacheDefaultAffinityKeyMapper default}.
+     *
+     * @param key Key.
+     * @return Affinity key.
+     */
+    private Object affinityKey(Object key) {
+        return (key instanceof GridCacheInternal ? ctx.defaultAffMapper() : affMapper).affinityKey(key);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8baca046/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheContext.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheContext.java
index 3ec013c..44f8e69 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheContext.java
@@ -19,6 +19,7 @@ package org.apache.ignite.internal.processors.cache;
 
 import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
+import org.apache.ignite.cache.affinity.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.internal.*;
@@ -164,6 +165,9 @@ public class GridCacheContext<K, V> implements Externalizable {
     /** Cached local rich node. */
     private ClusterNode locNode;
 
+    /** Default cache affinity mapper. */
+    private CacheAffinityKeyMapper affMapper;
+
     /**
      * Thread local projection. If it's set it means that method call was initiated
      * by child projection of initial cache.
@@ -1016,6 +1020,20 @@ public class GridCacheContext<K, V> implements Externalizable {
     }
 
     /**
+     * @return Default affinity key mapper.
+     */
+    public CacheAffinityKeyMapper defaultAffMapper() {
+        return affMapper;
+    }
+
+    /**
+     * Sets default affinity key mapper.
+     */
+    public void defaultAffMapper(CacheAffinityKeyMapper dfltAffMapper) {
+        this.affMapper = dfltAffMapper;
+    }
+
+    /**
      * @param p Single predicate.
      * @return Array containing single predicate.
      */
@@ -1770,6 +1788,7 @@ public class GridCacheContext<K, V> implements Externalizable {
         evictMgr = null;
         qryMgr = null;
         dataStructuresMgr = null;
+        affMapper = null;
 
         mgrs.clear();
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8baca046/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
index e99c706..f74f969 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
@@ -618,6 +618,17 @@ public class GridCacheProcessor extends GridProcessorAdapter {
 
             U.startLifecycleAware(lifecycleAwares(cfg, jta.tmLookup(), cfgStore));
 
+            // Init default key mapper.
+            CacheAffinityKeyMapper dfltAffMapper;
+
+            if (cfg.getAffinityMapper().getClass().equals(GridCacheDefaultAffinityKeyMapper.class))
+                dfltAffMapper = cfg.getAffinityMapper();
+            else {
+                dfltAffMapper = new GridCacheDefaultAffinityKeyMapper();
+
+                prepare(cfg, dfltAffMapper, false);
+            }
+
             cfgs[i] = cfg; // Replace original configuration value.
 
             GridCacheAffinityManager affMgr = new GridCacheAffinityManager();
@@ -655,6 +666,8 @@ public class GridCacheProcessor extends GridProcessorAdapter {
                 drMgr,
                 jta);
 
+            cacheCtx.defaultAffMapper(dfltAffMapper);
+
             GridCacheAdapter cache = null;
 
             switch (cfg.getCacheMode()) {
@@ -793,6 +806,8 @@ public class GridCacheProcessor extends GridProcessorAdapter {
                     drMgr,
                     jta);
 
+                cacheCtx.defaultAffMapper(dfltAffMapper);
+
                 GridDhtCacheAdapter dht = null;
 
                 switch (cfg.getAtomicityMode()) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8baca046/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractUsersAffinityMapperSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractUsersAffinityMapperSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractUsersAffinityMapperSelfTest.java
new file mode 100644
index 0000000..71f28ce
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractUsersAffinityMapperSelfTest.java
@@ -0,0 +1,207 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.*;
+import org.apache.ignite.cache.affinity.*;
+import org.apache.ignite.configuration.*;
+import org.apache.ignite.internal.util.*;
+import org.apache.ignite.lang.*;
+import org.apache.ignite.spi.discovery.tcp.*;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.*;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.*;
+import org.apache.ignite.testframework.junits.common.*;
+
+import java.io.*;
+
+/**
+ * Test affinity mapper.
+ */
+public abstract class GridCacheAbstractUsersAffinityMapperSelfTest extends GridCommonAbstractTest {
+    /** */
+    private static final int KEY_CNT = 1000;
+
+    /** */
+    private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
+
+    /** */
+    public static final CacheAffinityKeyMapper AFFINITY_MAPPER = new UsersAffinityKeyMapper();
+
+    /** */
+    public GridCacheAbstractUsersAffinityMapperSelfTest() {
+        super(false /* doesn't start grid */);
+    }
+
+    /** {@inheritDoc} */
+    @Override protected void afterTest() throws Exception {
+        super.afterTest();
+
+        stopAllGrids();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        CacheConfiguration cacheCfg = new CacheConfiguration();
+
+        cacheCfg.setName(null);
+        cacheCfg.setCacheMode(getCacheMode());
+        cacheCfg.setAtomicityMode(getAtomicMode());
+        cacheCfg.setDistributionMode(getDistributionMode());
+        cacheCfg.setWriteSynchronizationMode(CacheWriteSynchronizationMode.FULL_SYNC);
+        cacheCfg.setPreloadMode(CachePreloadMode.SYNC);
+        cacheCfg.setAffinityMapper(AFFINITY_MAPPER);
+
+        cfg.setCacheConfiguration(cacheCfg);
+
+        TcpDiscoverySpi spi = new TcpDiscoverySpi();
+
+        spi.setIpFinder(IP_FINDER);
+
+        cfg.setDiscoverySpi(spi);
+
+        return cfg;
+    }
+
+    /**
+     * @return Distribution mode.
+     */
+    protected abstract CacheDistributionMode getDistributionMode();
+
+    /**
+     * @return Cache atomicity mode.
+     */
+    protected abstract CacheAtomicityMode getAtomicMode();
+
+    /**
+     * @return Cache mode.
+     */
+    protected abstract CacheMode getCacheMode();
+
+    /**
+     * @throws Exception If failed.
+     */
+    public void testAffinityMapper() throws Exception {
+        IgniteCache<Object, Object> cache = startGrid(0).jcache(null);
+
+        for (int i = 0; i < KEY_CNT; i++) {
+            cache.put(String.valueOf(i), String.valueOf(i));
+
+            cache.put(new TestAffinityKey(i, String.valueOf(i)), i);
+        }
+
+        assertEquals(1, cache.get(new TestAffinityKey(1, "1")));
+
+        startGrid(1);
+
+        for (int i = 0; i < KEY_CNT; i++)
+            grid(i % 2).compute().affinityRun(null, new TestAffinityKey(1, "1"), new NoopClosure());
+    }
+
+    /**
+     * Test key for field annotation.
+     */
+    private static class TestAffinityKey implements Externalizable {
+        /** Key. */
+        private int key;
+
+        /** Affinity key. */
+        @CacheAffinityKeyMapped
+        private String affKey;
+
+        /**
+         * Constructor.
+         */
+        public TestAffinityKey() {
+        }
+
+        /**
+         * Constructor.
+         *
+         * @param key Key.
+         * @param affKey Affinity key.
+         */
+        TestAffinityKey(int key, String affKey) {
+            this.key = key;
+            this.affKey = affKey;
+        }
+
+        /**
+         * @return Key.
+         */
+        public int key() {
+            return key;
+        }
+
+        /**
+         * @return Affinity key.
+         */
+        public String affinityKey() {
+            return affKey;
+        }
+
+        /** {@inheritDoc} */
+        @Override public boolean equals(Object o) {
+            return o instanceof TestAffinityKey && key == ((TestAffinityKey)o).key();
+        }
+
+        /** {@inheritDoc} */
+        @Override public int hashCode() {
+            return key + affKey.hashCode();
+        }
+
+        /** {@inheritDoc} */
+        @Override public void writeExternal(ObjectOutput out) throws IOException {
+            out.writeInt(key);
+            out.writeUTF(affKey);
+        }
+
+        /** {@inheritDoc} */
+        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+            key = in.readInt();
+            affKey = in.readUTF();
+        }
+    }
+
+    /**
+     * Users affinity mapper.
+     */
+    private static class UsersAffinityKeyMapper extends GridCacheDefaultAffinityKeyMapper{
+        /** {@inheritDoc} */
+        @Override public Object affinityKey(Object key) {
+            GridArgumentCheck.notNull(key, "key");
+
+            assertFalse("GridCacheInternal entry mustn't be passed in user's key mapper.",
+                key instanceof GridCacheInternal);
+
+            return super.affinityKey(key);
+        }
+    }
+
+    /**
+     * Noop closure.
+     */
+    private static class NoopClosure implements IgniteRunnable {
+        /** {@inheritDoc} */
+        @Override public void run() {
+            // No-op.
+        }
+    }
+}

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

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

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


[40/50] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-239' into sprint-2

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


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

Branch: refs/heads/ignite-337
Commit: 96714719d98de537accd7c7c571cfdbbabfa948d
Parents: 11efb91 08df446
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Mar 2 17:05:34 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Mar 2 17:05:34 2015 +0300

----------------------------------------------------------------------
 .../configuration/IgniteConfiguration.java      |   5 +-
 .../org/apache/ignite/internal/IgnitionEx.java  | 592 +++++++++----------
 .../GridCacheQueueCleanupSelfTest.java          |   1 -
 3 files changed, 267 insertions(+), 331 deletions(-)
----------------------------------------------------------------------



[15/50] incubator-ignite git commit: Merge branches 'ignite-339' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-339

Posted by sb...@apache.org.
Merge branches 'ignite-339' and 'sprint-2' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-339


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

Branch: refs/heads/ignite-337
Commit: 2710ece0fb8c18fec65d7e4f745f048eca07790e
Parents: 57bdd8a a792c99
Author: AKuznetsov <ak...@gridgain.com>
Authored: Sat Feb 28 01:40:08 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Sat Feb 28 01:40:08 2015 +0700

----------------------------------------------------------------------
 config/hadoop/default-config.xml                |   12 +
 config/ignite-log4j.xml                         |    2 +-
 .../datagrid/CacheContinuousQueryExample.java   |    2 +-
 ipc/shmem/Makefile.am                           |   15 +
 ipc/shmem/igniteshmem/Makefile.am               |   15 +
 ipc/shmem/include/Makefile.am                   |   15 +
 modules/clients/src/test/keystore/generate.sh   |   15 +-
 .../src/main/java/org/apache/ignite/Ignite.java |    4 +-
 .../ignite/cache/query/ContinuousQuery.java     |   18 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |    2 +-
 .../configuration/QueryConfiguration.java       |   37 +-
 .../java/org/apache/ignite/igfs/IgfsMode.java   |    6 +-
 .../apache/ignite/internal/GridProperties.java  |   78 -
 .../ignite/internal/GridUpdateNotifier.java     |    2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   18 +-
 .../ignite/internal/IgniteProperties.java       |   79 +
 .../ignite/internal/IgniteVersionUtils.java     |    8 +-
 .../internal/events/DiscoveryCustomEvent.java   |    3 +
 .../processors/cache/IgniteCacheProxy.java      |    6 +-
 .../plugin/IgnitePluginProcessor.java           |   24 +
 .../optimized-classnames.previous.properties    |   15 +
 .../optimized/optimized-classnames.properties   | 1565 +-----------------
 .../apache/ignite/plugin/PluginProvider.java    |    5 +
 .../TcpDiscoveryCustomEventMessage.java         |    3 +
 .../internal/GridUpdateNotifierSelfTest.java    |    2 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    8 +-
 .../config/GridTestProperties.java              |   10 +-
 modules/extdata/p2p/pom.xml                     |    6 -
 .../client/hadoop/GridHadoopClientProtocol.java |    6 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |  412 +++++
 .../igfs/hadoop/v1/IgfsHadoopFileSystem.java    |    3 +-
 .../igfs/hadoop/v2/IgfsHadoopFileSystem.java    |    3 +-
 .../igfs/hadoop/IgfsHadoopFSProperties.java     |   10 +-
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |  413 -----
 .../internal/igfs/hadoop/IgfsHadoopReader.java  |    2 +-
 .../internal/igfs/hadoop/IgfsHadoopUtils.java   |    4 +-
 .../hadoop/GridHadoopClassLoader.java           |   12 +-
 .../processors/hadoop/GridHadoopSetup.java      |    8 +-
 .../processors/hadoop/GridHadoopUtils.java      |    4 +-
 .../collections/GridHadoopHashMultimapBase.java |    2 +-
 .../GridHadoopExternalCommunication.java        |   14 +-
 .../hadoop/v1/GridHadoopV1MapTask.java          |    6 +-
 .../v2/GridHadoopV2JobResourceManager.java      |    2 +-
 .../GridHadoopClientProtocolSelfTest.java       |    6 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |    2 +-
 .../IgfsHadoop20FileSystemAbstractSelfTest.java |    2 +-
 .../igfs/IgfsHadoopDualAbstractSelfTest.java    |    2 +-
 .../IgfsHadoopFileSystemAbstractSelfTest.java   |    1 +
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |    2 +-
 .../hadoop/GridHadoopGroupingTest.java          |    4 +-
 .../igfs/IgfsPerformanceBenchmark.java          |    9 +-
 modules/hibernate/pom.xml                       |    6 -
 .../HibernateReadWriteAccessStrategy.java       |   81 +-
 modules/indexing/pom.xml                        |    6 -
 modules/jta/pom.xml                             |    6 -
 modules/scalar/pom.xml                          |    6 -
 modules/spring/pom.xml                          |    6 -
 modules/visor-console/pom.xml                   |    7 -
 modules/web/pom.xml                             |    6 -
 modules/winservice/IgniteService.sln            |    2 +-
 .../IgniteService/IgniteService.csproj          |    2 +-
 .../config/benchmark-atomic-win.properties      |   15 +
 .../config/benchmark-atomic.properties          |   15 +
 .../config/benchmark-compute-win.properties     |   15 +
 .../config/benchmark-compute.properties         |   15 +
 .../config/benchmark-multicast.properties       |   15 +
 .../config/benchmark-query-win.properties       |   15 +
 .../yardstick/config/benchmark-query.properties |   15 +
 .../config/benchmark-tx-win.properties          |   15 +
 .../yardstick/config/benchmark-tx.properties    |   15 +
 .../yardstick/config/benchmark-win.properties   |   15 +
 modules/yardstick/config/benchmark.properties   |   15 +
 pom.xml                                         |  150 +-
 73 files changed, 1074 insertions(+), 2273 deletions(-)
----------------------------------------------------------------------



[07/50] incubator-ignite git commit: # ignite-239

Posted by sb...@apache.org.
# ignite-239


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

Branch: refs/heads/ignite-337
Commit: 4f7dbf76ea6638792abd23e7d0327eabd8bc377b
Parents: 1689a20
Author: sboikov <sb...@gridgain.com>
Authored: Fri Feb 27 17:27:18 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Feb 27 17:27:18 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/internal/IgnitionEx.java  | 71 +++++++++-----------
 1 file changed, 33 insertions(+), 38 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4f7dbf76/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index f39cd7e..ca3abe9 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1517,36 +1517,28 @@ public class IgnitionEx {
         /**
          * @param cfg Ignite configuration copy to.
          * @return New ignite configuration.
+         * @throws IgniteCheckedException If failed.
          */
         private IgniteConfiguration initializeConfiguration(IgniteConfiguration cfg)
             throws IgniteCheckedException {
             IgniteConfiguration myCfg = new IgniteConfiguration(cfg);
 
-            initializeDefaultConfigurationParameters(myCfg);
-
-            return myCfg;
-        }
-
-        /**
-         * Initialize default parameters.
-         */
-        public void initializeDefaultConfigurationParameters(IgniteConfiguration cfg) throws IgniteCheckedException {
-            cfg.setIgniteHome(U.getIgniteHome());
+            myCfg.setIgniteHome(U.getIgniteHome());
 
             // Local host.
             String locHost = IgniteSystemProperties.getString(IGNITE_LOCAL_HOST);
 
-            cfg.setLocalHost(F.isEmpty(locHost) ? cfg.getLocalHost() : locHost);
+            myCfg.setLocalHost(F.isEmpty(locHost) ? myCfg.getLocalHost() : locHost);
 
             // Override daemon flag if it was set on the factory.
             if (daemon)
-                cfg.setDaemon(true);
+                myCfg.setDaemon(true);
 
-            Marshaller marsh = cfg.getMarshaller();
+            Marshaller marsh = myCfg.getMarshaller();
 
             if (marsh == null) {
                 if (!U.isHotSpot()) {
-                    U.warn(log, "GridOptimizedMarshaller is not supported on this JVM " +
+                    U.warn(log, "OptimizedMarshaller is not supported on this JVM " +
                             "(only Java HotSpot VMs are supported). Switching to standard JDK marshalling - " +
                             "object serialization performance will be significantly slower.",
                         "To enable fast marshalling upgrade to recent 1.6 or 1.7 HotSpot VM release.");
@@ -1554,7 +1546,7 @@ public class IgnitionEx {
                     marsh = new JdkMarshaller();
                 }
                 else if (!OptimizedMarshaller.available()) {
-                    U.warn(log, "GridOptimizedMarshaller is not supported on this JVM " +
+                    U.warn(log, "OptimizedMarshaller is not supported on this JVM " +
                             "(only recent 1.6 and 1.7 versions HotSpot VMs are supported). " +
                             "To enable fast marshalling upgrade to recent 1.6 or 1.7 HotSpot VM release. " +
                             "Switching to standard JDK marshalling - " +
@@ -1567,7 +1559,7 @@ public class IgnitionEx {
                     marsh = new OptimizedMarshaller();
             }
             else if (marsh instanceof OptimizedMarshaller && !U.isHotSpot()) {
-                U.warn(log, "Using GridOptimizedMarshaller on untested JVM (only Java HotSpot VMs were tested) - " +
+                U.warn(log, "Using OptimizedMarshaller on untested JVM (only Java HotSpot VMs were tested) - " +
                         "object serialization behavior could yield unexpected results.",
                     "Using GridOptimizedMarshaller on untested JVM.");
             }
@@ -1576,7 +1568,7 @@ public class IgnitionEx {
             String depModeName = IgniteSystemProperties.getString(IGNITE_DEP_MODE_OVERRIDE);
 
             if (!F.isEmpty(depModeName)) {
-                if (!F.isEmpty(cfg.getCacheConfiguration())) {
+                if (!F.isEmpty(myCfg.getCacheConfiguration())) {
                     U.quietAndInfo(log, "Skipping deployment mode override for caches (custom closure " +
                         "execution may not work for console Visor)");
                 }
@@ -1584,8 +1576,8 @@ public class IgnitionEx {
                     try {
                         DeploymentMode depMode = DeploymentMode.valueOf(depModeName);
 
-                        if (cfg.getDeploymentMode() != depMode)
-                            cfg.setDeploymentMode(depMode);
+                        if (myCfg.getDeploymentMode() != depMode)
+                            myCfg.setDeploymentMode(depMode);
                     }
                     catch (IllegalArgumentException e) {
                         throw new IgniteCheckedException("Failed to override deployment mode using system property " +
@@ -1595,12 +1587,12 @@ public class IgnitionEx {
                 }
             }
 
-            cfg.setMarshaller(marsh);
+            myCfg.setMarshaller(marsh);
 
-            cfg.setConnectorConfiguration(cfg.getConnectorConfiguration() != null ?
-                new ConnectorConfiguration(cfg.getConnectorConfiguration()) : null);
+            myCfg.setConnectorConfiguration(myCfg.getConnectorConfiguration() != null ?
+                new ConnectorConfiguration(myCfg.getConnectorConfiguration()) : null);
 
-            IgfsConfiguration[] igfsCfgs = cfg.getIgfsConfiguration();
+            IgfsConfiguration[] igfsCfgs = myCfg.getIgfsConfiguration();
 
             if (igfsCfgs != null) {
                 IgfsConfiguration[] clone = igfsCfgs.clone();
@@ -1608,19 +1600,19 @@ public class IgnitionEx {
                 for (int i = 0; i < igfsCfgs.length; i++)
                     clone[i] = new IgfsConfiguration(igfsCfgs[i]);
 
-                cfg.setIgfsConfiguration(clone);
+                myCfg.setIgfsConfiguration(clone);
             }
 
-            if (cfg.getMBeanServer() == null)
-                cfg.setMBeanServer(ManagementFactory.getPlatformMBeanServer());
+            if (myCfg.getMBeanServer() == null)
+                myCfg.setMBeanServer(ManagementFactory.getPlatformMBeanServer());
 
-            if (cfg.getNodeId() == null)
-               cfg.setNodeId(UUID.randomUUID());
+            if (myCfg.getNodeId() == null)
+               myCfg.setNodeId(UUID.randomUUID());
 
-            if (cfg.getPeerClassLoadingLocalClassPathExclude() == null)
-                cfg.setPeerClassLoadingLocalClassPathExclude(EMPTY_STR_ARR);
+            if (myCfg.getPeerClassLoadingLocalClassPathExclude() == null)
+                myCfg.setPeerClassLoadingLocalClassPathExclude(EMPTY_STR_ARR);
 
-            StreamerConfiguration[] streamerCfgs = cfg.getStreamerConfiguration();
+            StreamerConfiguration[] streamerCfgs = myCfg.getStreamerConfiguration();
 
             if (streamerCfgs != null) {
                 StreamerConfiguration[] clone = streamerCfgs.clone();
@@ -1628,26 +1620,29 @@ public class IgnitionEx {
                 for (int i = 0; i < streamerCfgs.length; i++)
                     clone[i] = new StreamerConfiguration(streamerCfgs[i]);
 
-                cfg.setStreamerConfiguration(clone);
+                myCfg.setStreamerConfiguration(clone);
             }
 
-            cfg.setTransactionConfiguration(cfg.getTransactionConfiguration() != null ?
-                new TransactionConfiguration(cfg.getTransactionConfiguration()) : null);
+            myCfg.setTransactionConfiguration(myCfg.getTransactionConfiguration() != null ?
+                new TransactionConfiguration(myCfg.getTransactionConfiguration()) : null);
 
-            if (cfg.getUserAttributes() == null) {
+            if (myCfg.getUserAttributes() == null) {
                 Map<String, ?> emptyAttr = Collections.emptyMap();
-                cfg.setUserAttributes(emptyAttr);
+                myCfg.setUserAttributes(emptyAttr);
             }
 
-            initializeDefaultCacheConfiguration(cfg);
+            initializeDefaultCacheConfiguration(myCfg);
+
+            initializeDefaultSpi(myCfg);
 
-            initializeDefaultSpi(cfg);
+            return myCfg;
         }
 
         /**
          * Initialize default cache configuration.
          *
          * @param cfg Ignite configuration.
+         * @throws IgniteCheckedException If failed.
          */
         public void initializeDefaultCacheConfiguration(IgniteConfiguration cfg) throws IgniteCheckedException {
             CacheConfiguration[] cacheCfgs = cfg.getCacheConfiguration();


[25/50] incubator-ignite git commit: #ignite-239: small refactoring.

Posted by sb...@apache.org.
#ignite-239: small refactoring.


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

Branch: refs/heads/ignite-337
Commit: 55669d46b838a1312e1067c8608243b89462fc54
Parents: ba010da
Author: ivasilinets <va...@gmail.com>
Authored: Sun Mar 1 15:39:37 2015 +0300
Committer: ivasilinets <va...@gmail.com>
Committed: Sun Mar 1 15:39:37 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/internal/IgnitionEx.java  | 172 +++++++++----------
 1 file changed, 86 insertions(+), 86 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/55669d46/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index c7e7cb6..9770205 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1295,29 +1295,14 @@ public class IgnitionEx {
         private void start0(GridStartContext startCtx) throws IgniteCheckedException {
             assert grid == null : "Grid is already started: " + name;
 
-            // Set configuration URL, if any, into system property.
-            if (startCtx.configUrl() != null)
-                System.setProperty(IGNITE_CONFIG_URL, startCtx.configUrl().toString());
-
             IgniteConfiguration cfg = startCtx.config() != null ? startCtx.config() : new IgniteConfiguration();
 
-            // Ensure invariant.
-            // It's a bit dirty - but this is a result of late refactoring
-            // and I don't want to reshuffle a lot of code.
-            assert F.eq(name, cfg.getGridName());
-
-            // Validate segmentation configuration.
-            GridSegmentationPolicy segPlc = cfg.getSegmentationPolicy();
-
-            // 1. Warn on potential configuration problem: grid is not configured to wait
-            // for correct segment after segmentation happens.
-            if (!F.isEmpty(cfg.getSegmentationResolvers()) && segPlc == RESTART_JVM && !cfg.isWaitForSegmentOnStart()) {
-                U.warn(log, "Found potential configuration problem (forgot to enable waiting for segment" +
-                    "on start?) [segPlc=" + segPlc + ", wait=false]");
-            }
-
             IgniteConfiguration myCfg = initializeConfiguration(cfg);
 
+            // Set configuration URL, if any, into system property.
+            if (startCtx.configUrl() != null)
+                System.setProperty(IGNITE_CONFIG_URL, startCtx.configUrl().toString());
+
             // Ensure that SPIs support multiple grid instances, if required.
             if (!startCtx.single()) {
                 ensureMultiInstanceSupport(myCfg.getDeploymentSpi());
@@ -1331,17 +1316,6 @@ public class IgnitionEx {
                 ensureMultiInstanceSupport(myCfg.getSwapSpaceSpi());
             }
 
-            try {
-                // Use reflection to avoid loading undesired classes.
-                Class helperCls = Class.forName("org.apache.ignite.util.GridConfigurationHelper");
-
-                helperCls.getMethod("overrideConfiguration", IgniteConfiguration.class, Properties.class,
-                    String.class, IgniteLogger.class).invoke(helperCls, myCfg, System.getProperties(), name, log);
-            }
-            catch (Exception ignored) {
-                // No-op.
-            }
-
             execSvc = new IgniteThreadPoolExecutor(
                 "pub-" + cfg.getGridName(),
                 cfg.getPublicThreadPoolSize(),
@@ -1414,6 +1388,17 @@ public class IgnitionEx {
             // Register Ignite MBean for current grid instance.
             registerFactoryMbean(myCfg.getMBeanServer());
 
+            try {
+                // Use reflection to avoid loading undesired classes.
+                Class helperCls = Class.forName("org.apache.ignite.util.GridConfigurationHelper");
+
+                helperCls.getMethod("overrideConfiguration", IgniteConfiguration.class, Properties.class,
+                        String.class, IgniteLogger.class).invoke(helperCls, myCfg, System.getProperties(), name, log);
+            }
+            catch (Exception ignored) {
+                // No-op.
+            }
+
             boolean started = false;
 
             try {
@@ -1489,16 +1474,7 @@ public class IgnitionEx {
          */
         private IgniteConfiguration initializeConfiguration(IgniteConfiguration cfg)
             throws IgniteCheckedException {
-            // Initialize factory's log.
-            UUID nodeId = cfg.getNodeId() != null ? cfg.getNodeId() : UUID.randomUUID();
-
-            IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), nodeId);
-
-            assert cfgLog != null;
-
-            cfgLog = new GridLoggerProxy(cfgLog, null, name, U.id8(nodeId));
-
-            log = cfgLog.getLogger(G.class);
+            IgniteConfiguration myCfg = new IgniteConfiguration(cfg);
 
             String ggHome = cfg.getIgniteHome();
 
@@ -1511,6 +1487,24 @@ public class IgnitionEx {
 
             U.setWorkDirectory(cfg.getWorkDirectory(), ggHome);
 
+            // Ensure invariant.
+            // It's a bit dirty - but this is a result of late refactoring
+            // and I don't want to reshuffle a lot of code.
+            assert F.eq(name, cfg.getGridName());
+
+            UUID nodeId = cfg.getNodeId() != null ? cfg.getNodeId() : UUID.randomUUID();
+
+            IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), nodeId);
+
+            assert cfgLog != null;
+
+            cfgLog = new GridLoggerProxy(cfgLog, null, name, U.id8(nodeId));
+
+            // Initialize factory's log.
+            log = cfgLog.getLogger(G.class);
+
+            myCfg.setGridLogger(cfgLog);
+
             // Check Ignite home folder (after log is available).
             if (ggHome != null) {
                 File ggHomeFile = new File(ggHome);
@@ -1519,11 +1513,23 @@ public class IgnitionEx {
                     throw new IgniteCheckedException("Invalid Ignite installation home folder: " + ggHome);
             }
 
-            IgniteConfiguration myCfg = new IgniteConfiguration(cfg);
-
             myCfg.setIgniteHome(ggHome);
 
-            myCfg.setGridLogger(cfgLog);
+            // Validate segmentation configuration.
+            GridSegmentationPolicy segPlc = cfg.getSegmentationPolicy();
+
+            // 1. Warn on potential configuration problem: grid is not configured to wait
+            // for correct segment after segmentation happens.
+            if (!F.isEmpty(cfg.getSegmentationResolvers()) && segPlc == RESTART_JVM && !cfg.isWaitForSegmentOnStart()) {
+                U.warn(log, "Found potential configuration problem (forgot to enable waiting for segment" +
+                        "on start?) [segPlc=" + segPlc + ", wait=false]");
+            }
+
+            myCfg.setTransactionConfiguration(myCfg.getTransactionConfiguration() != null ?
+                    new TransactionConfiguration(myCfg.getTransactionConfiguration()) : null);
+
+            myCfg.setConnectorConfiguration(myCfg.getConnectorConfiguration() != null ?
+                    new ConnectorConfiguration(myCfg.getConnectorConfiguration()) : null);
 
             // Local host.
             String locHost = IgniteSystemProperties.getString(IGNITE_LOCAL_HOST);
@@ -1534,6 +1540,37 @@ public class IgnitionEx {
             if (daemon)
                 myCfg.setDaemon(true);
 
+            // Check for deployment mode override.
+            String depModeName = IgniteSystemProperties.getString(IGNITE_DEP_MODE_OVERRIDE);
+
+            if (!F.isEmpty(depModeName)) {
+                if (!F.isEmpty(myCfg.getCacheConfiguration())) {
+                    U.quietAndInfo(log, "Skipping deployment mode override for caches (custom closure " +
+                            "execution may not work for console Visor)");
+                }
+                else {
+                    try {
+                        DeploymentMode depMode = DeploymentMode.valueOf(depModeName);
+
+                        if (myCfg.getDeploymentMode() != depMode)
+                            myCfg.setDeploymentMode(depMode);
+                    }
+                    catch (IllegalArgumentException e) {
+                        throw new IgniteCheckedException("Failed to override deployment mode using system property " +
+                                "(are there any misspellings?)" +
+                                "[name=" + IGNITE_DEP_MODE_OVERRIDE + ", value=" + depModeName + ']', e);
+                    }
+                }
+            }
+
+            if (myCfg.getUserAttributes() == null) {
+                Map<String, ?> emptyAttr = Collections.emptyMap();
+                myCfg.setUserAttributes(emptyAttr);
+            }
+
+            if (myCfg.getMBeanServer() == null)
+                myCfg.setMBeanServer(ManagementFactory.getPlatformMBeanServer());
+
             Marshaller marsh = myCfg.getMarshaller();
 
             if (marsh == null) {
@@ -1564,33 +1601,12 @@ public class IgnitionEx {
                     "Using GridOptimizedMarshaller on untested JVM.");
             }
 
-            // Check for deployment mode override.
-            String depModeName = IgniteSystemProperties.getString(IGNITE_DEP_MODE_OVERRIDE);
-
-            if (!F.isEmpty(depModeName)) {
-                if (!F.isEmpty(myCfg.getCacheConfiguration())) {
-                    U.quietAndInfo(log, "Skipping deployment mode override for caches (custom closure " +
-                        "execution may not work for console Visor)");
-                }
-                else {
-                    try {
-                        DeploymentMode depMode = DeploymentMode.valueOf(depModeName);
-
-                        if (myCfg.getDeploymentMode() != depMode)
-                            myCfg.setDeploymentMode(depMode);
-                    }
-                    catch (IllegalArgumentException e) {
-                        throw new IgniteCheckedException("Failed to override deployment mode using system property " +
-                            "(are there any misspellings?)" +
-                            "[name=" + IGNITE_DEP_MODE_OVERRIDE + ", value=" + depModeName + ']', e);
-                    }
-                }
-            }
-
             myCfg.setMarshaller(marsh);
 
-            myCfg.setConnectorConfiguration(myCfg.getConnectorConfiguration() != null ?
-                new ConnectorConfiguration(myCfg.getConnectorConfiguration()) : null);
+            if (myCfg.getPeerClassLoadingLocalClassPathExclude() == null)
+                myCfg.setPeerClassLoadingLocalClassPathExclude(EMPTY_STR_ARR);
+
+            myCfg.setNodeId(nodeId);
 
             IgfsConfiguration[] igfsCfgs = myCfg.getIgfsConfiguration();
 
@@ -1603,14 +1619,6 @@ public class IgnitionEx {
                 myCfg.setIgfsConfiguration(clone);
             }
 
-            if (myCfg.getMBeanServer() == null)
-                myCfg.setMBeanServer(ManagementFactory.getPlatformMBeanServer());
-
-            myCfg.setNodeId(nodeId);
-
-            if (myCfg.getPeerClassLoadingLocalClassPathExclude() == null)
-                myCfg.setPeerClassLoadingLocalClassPathExclude(EMPTY_STR_ARR);
-
             StreamerConfiguration[] streamerCfgs = myCfg.getStreamerConfiguration();
 
             if (streamerCfgs != null) {
@@ -1622,18 +1630,10 @@ public class IgnitionEx {
                 myCfg.setStreamerConfiguration(clone);
             }
 
-            myCfg.setTransactionConfiguration(myCfg.getTransactionConfiguration() != null ?
-                new TransactionConfiguration(myCfg.getTransactionConfiguration()) : null);
-
-            if (myCfg.getUserAttributes() == null) {
-                Map<String, ?> emptyAttr = Collections.emptyMap();
-                myCfg.setUserAttributes(emptyAttr);
-            }
+            initializeDefaultSpi(myCfg);
 
             initializeDefaultCacheConfiguration(myCfg);
 
-            initializeDefaultSpi(myCfg);
-
             return myCfg;
         }
 
@@ -1722,7 +1722,7 @@ public class IgnitionEx {
         }
 
         /**
-         * Initialize default values for spi.
+         * Initialize default SPI implementations.
          *
          * @param cfg Ignite configuration.
          */


[12/50] incubator-ignite git commit: #ignite-239: review.

Posted by sb...@apache.org.
#ignite-239: review.


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

Branch: refs/heads/ignite-337
Commit: 8476463b9145eff58d28da7e57d83d96e50a066c
Parents: 4ff4fd1
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 18:17:07 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 18:17:07 2015 +0300

----------------------------------------------------------------------
 .../src/main/java/org/apache/ignite/internal/IgnitionEx.java     | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8476463b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index 6b8b197..c7e7cb6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1306,8 +1306,6 @@ public class IgnitionEx {
             // and I don't want to reshuffle a lot of code.
             assert F.eq(name, cfg.getGridName());
 
-            IgniteConfiguration myCfg = initializeConfiguration(cfg);
-
             // Validate segmentation configuration.
             GridSegmentationPolicy segPlc = cfg.getSegmentationPolicy();
 
@@ -1318,6 +1316,8 @@ public class IgnitionEx {
                     "on start?) [segPlc=" + segPlc + ", wait=false]");
             }
 
+            IgniteConfiguration myCfg = initializeConfiguration(cfg);
+
             // Ensure that SPIs support multiple grid instances, if required.
             if (!startCtx.single()) {
                 ensureMultiInstanceSupport(myCfg.getDeploymentSpi());


[21/50] incubator-ignite git commit: sprint-2 - Added isWithinTransaction() method to session.

Posted by sb...@apache.org.
sprint-2 - Added isWithinTransaction() method to session.


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

Branch: refs/heads/ignite-337
Commit: 16105ec9687732d0b01cfeaee9a5b1c227b0921f
Parents: 6097e7b
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Sat Feb 28 09:44:30 2015 -0800
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Sat Feb 28 09:44:30 2015 -0800

----------------------------------------------------------------------
 .../store/jdbc/CacheJdbcPersonStore.java        | 110 +++++++------------
 .../ignite/cache/store/CacheStoreSession.java   |   9 ++
 .../processors/cache/GridCacheStoreManager.java |   6 +-
 .../junits/cache/TestCacheSession.java          |   5 +
 .../cache/TestThreadLocalCacheSession.java      |   5 +
 5 files changed, 62 insertions(+), 73 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/16105ec9/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
index d80861d..0473280 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/store/jdbc/CacheJdbcPersonStore.java
@@ -22,7 +22,6 @@ import org.apache.ignite.cache.store.*;
 import org.apache.ignite.examples.datagrid.store.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
-import org.apache.ignite.transactions.*;
 import org.jetbrains.annotations.*;
 
 import javax.cache.*;
@@ -72,8 +71,6 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
 
     /** {@inheritDoc} */
     @Override public void txEnd(boolean commit) {
-        Transaction tx = transaction();
-
         Map<String, Connection> props = ses.properties();
 
         try (Connection conn = props.remove(ATTR_NAME)) {
@@ -84,23 +81,21 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
                     conn.rollback();
             }
 
-            System.out.println(">>> Transaction ended [xid=" + tx.xid() + ", commit=" + commit + ']');
+            System.out.println(">>> Transaction ended [commit=" + commit + ']');
         }
         catch (SQLException e) {
-            throw new CacheWriterException("Failed to end transaction [xid=" + tx.xid() + ", commit=" + commit + ']', e);
+            throw new CacheWriterException("Failed to end transaction: " + ses.transaction(), e);
         }
     }
 
     /** {@inheritDoc} */
     @Override public Person load(Long key) {
-        Transaction tx = transaction();
-
-        System.out.println(">>> Store load [key=" + key + ", xid=" + (tx == null ? null : tx.xid()) + ']');
+        System.out.println(">>> Loading key: " + key);
 
         Connection conn = null;
 
         try {
-            conn = connection(tx);
+            conn = connection();
 
             try (PreparedStatement st = conn.prepareStatement("select * from PERSONS where id=?")) {
                 st.setString(1, key.toString());
@@ -108,14 +103,14 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
                 ResultSet rs = st.executeQuery();
 
                 if (rs.next())
-                    return person(rs.getLong(1), rs.getString(2), rs.getString(3));
+                    return new Person(rs.getLong(1), rs.getString(2), rs.getString(3));
             }
         }
         catch (SQLException e) {
             throw new CacheLoaderException("Failed to load object: " + key, e);
         }
         finally {
-            end(tx, conn);
+            end(conn);
         }
 
         return null;
@@ -123,60 +118,57 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
 
     /** {@inheritDoc} */
     @Override public void write(Cache.Entry<? extends Long, ? extends Person> entry) {
-        Transaction tx = transaction();
-
         Long key = entry.getKey();
 
         Person val = entry.getValue();
 
-        System.out.println(">>> Store put [key=" + key + ", val=" + val + ", xid=" + (tx == null ? null : tx.xid()) + ']');
+        System.out.println(">>> Putting [key=" + key + ", val=" + val +  ']');
 
         Connection conn = null;
 
         try {
-            conn = connection(tx);
+            conn = connection();
 
-        int updated;
+            int updated;
 
-        try (PreparedStatement st = conn.prepareStatement(
-            "update PERSONS set firstName=?, lastName=? where id=?")) {
-            st.setString(1, val.getFirstName());
-            st.setString(2, val.getLastName());
-            st.setLong(3, val.getId());
+            // Try update first.
+            try (PreparedStatement st = conn.prepareStatement(
+                "update PERSONS set firstName=?, lastName=? where id=?")) {
+                st.setString(1, val.getFirstName());
+                st.setString(2, val.getLastName());
+                st.setLong(3, val.getId());
 
-            updated = st.executeUpdate();
-        }
+                updated = st.executeUpdate();
+            }
 
-        // If update failed, try to insert.
-        if (updated == 0) {
-            try (PreparedStatement st = conn.prepareStatement(
-                "insert into PERSONS (id, firstName, lastName) values(?, ?, ?)")) {
-                st.setLong(1, val.getId());
-                st.setString(2, val.getFirstName());
-                st.setString(3, val.getLastName());
+            // If update failed, try to insert.
+            if (updated == 0) {
+                try (PreparedStatement st = conn.prepareStatement(
+                    "insert into PERSONS (id, firstName, lastName) values(?, ?, ?)")) {
+                    st.setLong(1, val.getId());
+                    st.setString(2, val.getFirstName());
+                    st.setString(3, val.getLastName());
 
-                st.executeUpdate();
+                    st.executeUpdate();
+                }
             }
         }
-        }
         catch (SQLException e) {
             throw new CacheLoaderException("Failed to put object [key=" + key + ", val=" + val + ']', e);
         }
         finally {
-            end(tx, conn);
+            end(conn);
         }
     }
 
     /** {@inheritDoc} */
     @Override public void delete(Object key) {
-        Transaction tx = transaction();
-
-        System.out.println(">>> Store remove [key=" + key + ", xid=" + (tx == null ? null : tx.xid()) + ']');
+        System.out.println(">>> Removing key: " + key);
 
         Connection conn = null;
 
         try {
-            conn = connection(tx);
+            conn = connection();
 
             try (PreparedStatement st = conn.prepareStatement("delete from PERSONS where id=?")) {
                 st.setLong(1, (Long)key);
@@ -188,7 +180,7 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
             throw new CacheWriterException("Failed to remove object: " + key, e);
         }
         finally {
-            end(tx, conn);
+            end(conn);
         }
     }
 
@@ -199,17 +191,13 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
 
         final int entryCnt = (Integer)args[0];
 
-        Connection conn = null;
-
-        try {
-            conn = connection(null);
-
+        try (Connection conn = connection()) {
             try (PreparedStatement st = conn.prepareStatement("select * from PERSONS")) {
                 try (ResultSet rs = st.executeQuery()) {
                     int cnt = 0;
 
                     while (cnt < entryCnt && rs.next()) {
-                        Person person = person(rs.getLong(1), rs.getString(2), rs.getString(3));
+                        Person person = new Person(rs.getLong(1), rs.getString(2), rs.getString(3));
 
                         clo.apply(person.getId(), person);
 
@@ -223,18 +211,16 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
         catch (SQLException e) {
             throw new CacheLoaderException("Failed to load values from cache store.", e);
         }
-        finally {
-            end(null, conn);
-        }
     }
 
     /**
-     * @param tx Cache transaction.
      * @return Connection.
      * @throws SQLException In case of error.
      */
-    private Connection connection(@Nullable Transaction tx) throws SQLException  {
-        if (tx != null) {
+    private Connection connection() throws SQLException  {
+        // If there is an ongoing transaction,
+        // we must reuse the same connection.
+        if (ses.isWithinTransaction()) {
             Map<Object, Object> props = ses.properties();
 
             Connection conn = (Connection)props.get(ATTR_NAME);
@@ -257,11 +243,10 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
     /**
      * Closes allocated resources depending on transaction status.
      *
-     * @param tx Active transaction, if any.
      * @param conn Allocated connection.
      */
-    private void end(@Nullable Transaction tx, @Nullable Connection conn) {
-        if (tx == null && conn != null) {
+    private void end(@Nullable Connection conn) {
+        if (!ses.isWithinTransaction() && conn != null) {
             // Close connection right away if there is no transaction.
             try {
                 conn.close();
@@ -286,23 +271,4 @@ public class CacheJdbcPersonStore extends CacheStoreAdapter<Long, Person> {
 
         return conn;
     }
-
-    /**
-     * Builds person object out of provided values.
-     *
-     * @param id ID.
-     * @param firstName First name.
-     * @param lastName Last name.
-     * @return Person.
-     */
-    private Person person(Long id, String firstName, String lastName) {
-        return new Person(id, firstName, lastName);
-    }
-
-    /**
-     * @return Current transaction.
-     */
-    private Transaction transaction() {
-        return ses != null ? ses.transaction() : null;
-    }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/16105ec9/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
index a2be4c5..38fe95c 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/store/CacheStoreSession.java
@@ -43,6 +43,15 @@ public interface CacheStoreSession {
     public Transaction transaction();
 
     /**
+     * Returns {@code true} if performing store operation within a transaction,
+     * {@code false} otherwise. Analogous to calling {@code transaction() != null}.
+     *
+     * @return {@code True} if performing store operation within a transaction,
+     * {@code false} otherwise.
+     */
+    public boolean isWithinTransaction();
+
+    /**
      * Gets current session properties. You can add properties directly to the
      * returned map.
      *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/16105ec9/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
index fac6ea3..9262a8f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManager.java
@@ -36,7 +36,6 @@ import org.jetbrains.annotations.*;
 
 import javax.cache.*;
 import javax.cache.integration.*;
-import java.lang.reflect.*;
 import java.util.*;
 
 /**
@@ -913,6 +912,11 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
         }
 
         /** {@inheritDoc} */
+        @Override public boolean isWithinTransaction() {
+            return transaction() != null;
+        }
+
+        /** {@inheritDoc} */
         @SuppressWarnings("unchecked")
         @Override public <K1, V1> Map<K1, V1> properties() {
             SessionData ses0 = sesHolder.get();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/16105ec9/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestCacheSession.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestCacheSession.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestCacheSession.java
index cca20fe..0709880 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestCacheSession.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestCacheSession.java
@@ -50,6 +50,11 @@ public class TestCacheSession implements CacheStoreSession {
     }
 
     /** {@inheritDoc} */
+    @Override public boolean isWithinTransaction() {
+        return transaction() != null;
+    }
+
+    /** {@inheritDoc} */
     @SuppressWarnings("unchecked")
     @Override public <K, V> Map<K, V> properties() {
         if (props == null)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/16105ec9/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestThreadLocalCacheSession.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestThreadLocalCacheSession.java b/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestThreadLocalCacheSession.java
index 6687f1f..2bbcf1b 100644
--- a/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestThreadLocalCacheSession.java
+++ b/modules/core/src/test/java/org/apache/ignite/testframework/junits/cache/TestThreadLocalCacheSession.java
@@ -49,6 +49,11 @@ public class TestThreadLocalCacheSession implements CacheStoreSession {
     }
 
     /** {@inheritDoc} */
+    @Override public boolean isWithinTransaction() {
+        return transaction() != null;
+    }
+
+    /** {@inheritDoc} */
     @SuppressWarnings("unchecked")
     @Override public <K, V> Map<K, V> properties() {
         TestCacheSession ses = sesHolder.get();


[43/50] incubator-ignite git commit: ignite-352 review

Posted by sb...@apache.org.
ignite-352 review


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

Branch: refs/heads/ignite-337
Commit: b0e6ab17c284850190012e7c120a95c34316b982
Parents: 403d60f
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Mar 2 17:28:39 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Mar 2 17:28:39 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/CacheMetricsImpl.java      |  4 ++
 .../dht/atomic/GridDhtAtomicCache.java          |  2 +-
 .../dht/colocated/GridDhtColocatedCache.java    |  2 +-
 .../cache/transactions/IgniteTxManager.java     |  7 +++-
 .../cache/GridCacheAbstractMetricsSelfTest.java | 42 ++++++++++++++++++++
 5 files changed, 53 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0e6ab17/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
index 0de039b..446070e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheMetricsImpl.java
@@ -460,6 +460,8 @@ public class CacheMetricsImpl implements CacheMetrics {
 
     /**
      * Transaction commit callback.
+     *
+     * @param duration the time taken in nanoseconds.
      */
     public void onTxCommit(long duration) {
         txCommits.incrementAndGet();
@@ -472,6 +474,8 @@ public class CacheMetricsImpl implements CacheMetrics {
 
     /**
      * Transaction rollback callback.
+     *
+     * @param duration the time taken in nanoseconds.
      */
     public void onTxRollback(long duration) {
         txRollbacks.incrementAndGet();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0e6ab17/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 9f9af31..add51bd 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
@@ -990,7 +990,7 @@ public class GridDhtAtomicCache<K, V> extends GridDhtCacheAdapter<K, V> {
 
                 if (!success)
                     break;
-                else if (!skipVals)
+                else if (!skipVals && ctx.config().isStatisticsEnabled())
                     metrics0().onRead(true);
             }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0e6ab17/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
index a59b6aa..cdb1759 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/colocated/GridDhtColocatedCache.java
@@ -318,7 +318,7 @@ public class GridDhtColocatedCache<K, V> extends GridDhtTransactionalCacheAdapte
 
                 if (!success)
                     break;
-                else if (!skipVals)
+                else if (!skipVals && ctx.config().isStatisticsEnabled())
                     ctx.cache().metrics0().onRead(true);
             }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0e6ab17/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
index cf32dcc..af57ce4 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxManager.java
@@ -1243,7 +1243,8 @@ public class IgniteTxManager<K, V> extends GridCacheSharedManagerAdapter<K, V> {
                     GridCacheContext<K, V> cacheCtx = cctx.cacheContext(cacheId);
 
                     if (cacheCtx.cache().configuration().isStatisticsEnabled())
-                        cacheCtx.cache().metrics0().onTxCommit(System.nanoTime() - tx.startTime());
+                        // Convert start time from ms to ns.
+                        cacheCtx.cache().metrics0().onTxCommit((U.currentTimeMillis() - tx.startTime()) * 1000);
                 }
             }
 
@@ -1316,7 +1317,9 @@ public class IgniteTxManager<K, V> extends GridCacheSharedManagerAdapter<K, V> {
                 for (int cacheId : tx.activeCacheIds()) {
                     GridCacheContext<K, V> cacheCtx = cctx.cacheContext(cacheId);
 
-                    cacheCtx.cache().metrics0().onTxRollback(System.nanoTime() - tx.startTime());
+                    if (cacheCtx.cache().configuration().isStatisticsEnabled())
+                        // Convert start time from ms to ns.
+                        cacheCtx.cache().metrics0().onTxRollback((U.currentTimeMillis() - tx.startTime()) * 1000);
                 }
             }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0e6ab17/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractMetricsSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractMetricsSelfTest.java
index d1c5e12..a7fb34a 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractMetricsSelfTest.java
@@ -103,6 +103,48 @@ public abstract class GridCacheAbstractMetricsSelfTest extends GridCacheAbstract
     /**
      * @throws Exception If failed.
      */
+    public void testGetMetricsDisable() throws Exception {
+        // Disable statistics.
+        for (int i = 0; i < gridCount(); i++) {
+            Ignite g = grid(i);
+
+            g.jcache(null).getConfiguration(CacheConfiguration.class).setStatisticsEnabled(false);
+        }
+
+        IgniteCache<Object, Object> jcache = grid(0).jcache(null);
+
+        // Write to cache.
+        for (int i = 0; i < KEY_CNT; i++)
+            jcache.put(i, i);
+
+        // Get from cache.
+        for (int i = 0; i < KEY_CNT; i++)
+            jcache.get(i);
+
+        // Remove from cache.
+        for (int i = 0; i < KEY_CNT; i++)
+            jcache.remove(i);
+
+        // Assert that statistics is clear.
+        for (int i = 0; i < gridCount(); i++) {
+            CacheMetrics m = grid(i).jcache(null).metrics();
+
+            assertEquals(m.getCacheGets(), 0);
+            assertEquals(m.getCachePuts(), 0);
+            assertEquals(m.getCacheRemovals(), 0);
+            assertEquals(m.getCacheHits(), 0);
+            assertEquals(m.getCacheMisses(), 0);
+            assertEquals(m.getAverageGetTime(), 0f);
+            assertEquals(m.getAverageRemoveTime(), 0f);
+            assertEquals(m.getAveragePutTime(), 0f);
+            assertEquals(m.getAverageTxCommitTime(), 0f);
+            assertEquals(m.getAverageTxRollbackTime(), 0f);
+        }
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
     public void testGetMetricsSnapshot() throws Exception {
         IgniteCache<Object, Object> cache = grid(0).jcache(null);
 


[31/50] incubator-ignite git commit: #ignite-239: review.

Posted by sb...@apache.org.
#ignite-239: review.


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

Branch: refs/heads/ignite-337
Commit: 08df446b39f28b7a4b670650f0e39797c0cfa5c5
Parents: 0b1eccf
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Mar 2 12:15:13 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Mar 2 12:15:13 2015 +0300

----------------------------------------------------------------------
 .../main/java/org/apache/ignite/internal/IgnitionEx.java  | 10 ++++------
 1 file changed, 4 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/08df446b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index c2c23f7..cb2efbf 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -1494,6 +1494,8 @@ public class IgnitionEx {
 
             UUID nodeId = cfg.getNodeId() != null ? cfg.getNodeId() : UUID.randomUUID();
 
+            myCfg.setNodeId(nodeId);
+
             IgniteLogger cfgLog = initLogger(cfg.getGridLogger(), nodeId);
 
             assert cfgLog != null;
@@ -1563,10 +1565,8 @@ public class IgnitionEx {
                 }
             }
 
-            if (myCfg.getUserAttributes() == null) {
-                Map<String, ?> emptyAttr = Collections.emptyMap();
-                myCfg.setUserAttributes(emptyAttr);
-            }
+            if (myCfg.getUserAttributes() == null)
+                myCfg.setUserAttributes(Collections.<String, Object>emptyMap());
 
             if (myCfg.getMBeanServer() == null)
                 myCfg.setMBeanServer(ManagementFactory.getPlatformMBeanServer());
@@ -1606,8 +1606,6 @@ public class IgnitionEx {
             if (myCfg.getPeerClassLoadingLocalClassPathExclude() == null)
                 myCfg.setPeerClassLoadingLocalClassPathExclude(EMPTY_STR_ARR);
 
-            myCfg.setNodeId(nodeId);
-
             IgfsConfiguration[] igfsCfgs = myCfg.getIgfsConfiguration();
 
             if (igfsCfgs != null) {


[16/50] incubator-ignite git commit: # IGNITE-339 Review.

Posted by sb...@apache.org.
# IGNITE-339 Review.


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

Branch: refs/heads/ignite-337
Commit: 5d3a2be2b24b0d2c6e72648008219d269f92a142
Parents: 2710ece
Author: AKuznetsov <ak...@gridgain.com>
Authored: Sat Feb 28 01:53:32 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Sat Feb 28 01:53:32 2015 +0700

----------------------------------------------------------------------
 .../internal/visor/cache/VisorCacheConfiguration.java   | 12 ++----------
 .../visor/node/VisorTransactionConfiguration.java       |  2 +-
 .../ignite/visor/commands/cache/VisorCacheCommand.scala |  2 +-
 3 files changed, 4 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5d3a2be2/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
index 8eee437..2ad0e49 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/cache/VisorCacheConfiguration.java
@@ -93,7 +93,7 @@ public class VisorCacheConfiguration implements Serializable {
     /** Cache interceptor. */
     private String interceptor;
 
-    /** Should value bytes be stored. */
+    /** Flag indicating if cached values should be additionally stored in serialized form. */
     private boolean valBytes;
 
     /** Cache affinityCfg config. */
@@ -331,21 +331,13 @@ public class VisorCacheConfiguration implements Serializable {
     }
 
     /**
-     * @return Should value bytes be stored.
+     * @return {@code true} if cached values should be additionally stored in serialized form.
      */
     public boolean valueBytes() {
         return valBytes;
     }
 
     /**
-     * @param valBytes New should value bytes be stored.
-     */
-    public void valueBytes(boolean valBytes) {
-        this.valBytes = valBytes;
-    }
-
-
-    /**
      * @return Collection of type metadata.
      */
     public Collection<VisorCacheTypeMetadata> typeMeta() {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5d3a2be2/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
index 667ff51..773f9dd 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorTransactionConfiguration.java
@@ -3,7 +3,7 @@
  * 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 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

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/5d3a2be2/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
index 577067a..7232221 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/cache/VisorCacheCommand.scala
@@ -854,7 +854,7 @@ object VisorCacheCommand {
         cacheT += ("Concurrent Asynchronous Operations Number", cfg.maxConcurrentAsyncOperations())
         cacheT += ("Memory Mode", cfg.memoryMode())
 
-        cacheT += ("Store Values In Bytes", cfg.valueBytes())
+        cacheT += ("Store Values Bytes", cfg.valueBytes())
 
         cacheT += ("Off-Heap Size", cfg.offsetHeapMaxMemory())
 


[05/50] incubator-ignite git commit: #ignite-239: small fixes.

Posted by sb...@apache.org.
#ignite-239: small fixes.


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

Branch: refs/heads/ignite-337
Commit: 4f0feeecb8c4c48ee7e7ffe4679ff0ac28ef3a0b
Parents: 5830deb
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Feb 27 16:15:17 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Feb 27 16:15:17 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/internal/IgnitionEx.java  | 72 ++++++++++----------
 1 file changed, 37 insertions(+), 35 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4f0feeec/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
index 32a3d71..f39cd7e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
@@ -119,9 +119,6 @@ public class IgnitionEx {
     /** */
     private static volatile boolean daemon;
 
-    /** */
-    private static final String[] EMPTY_STR_ARR = new String[0];
-
     /**
      * Checks runtime version to be 1.7.x or 1.8.x.
      * This will load pretty much first so we must do these checks here.
@@ -1138,6 +1135,9 @@ public class IgnitionEx {
         private static final Map<MBeanServer, GridMBeanServerData> mbeans =
             new HashMap<>();
 
+        /** */
+        private static final String[] EMPTY_STR_ARR = new String[0];
+
         /** Grid name. */
         private final String name;
 
@@ -1297,6 +1297,17 @@ public class IgnitionEx {
 
             IgniteConfiguration cfg = startCtx.config() != null ? startCtx.config() : new IgniteConfiguration();
 
+            String ggHome = cfg.getIgniteHome();
+
+            // Set Ignite home.
+            if (ggHome == null)
+                ggHome = U.getIgniteHome();
+            else
+                // If user provided IGNITE_HOME - set it as a system property.
+                U.setIgniteHome(ggHome);
+
+            U.setWorkDirectory(cfg.getWorkDirectory(), ggHome);
+
             // Ensure invariant.
             // It's a bit dirty - but this is a result of late refactoring
             // and I don't want to reshuffle a lot of code.
@@ -1317,20 +1328,18 @@ public class IgnitionEx {
 
             log = cfgLog.getLogger(G.class);
 
-            IgniteConfiguration myCfg = initializeDefaultConfiguration(cfg);
-
-            myCfg.setGridLogger(cfgLog);
+            // Check Ignite home folder (after log is available).
+            if (ggHome != null) {
+                File ggHomeFile = new File(ggHome);
 
-            if (myCfg.getConnectorConfiguration() != null) {
-                restExecSvc = new IgniteThreadPoolExecutor(
-                    "rest-" + cfg.getGridName(),
-                    myCfg.getConnectorConfiguration().getThreadPoolSize(),
-                    myCfg.getConnectorConfiguration().getThreadPoolSize(),
-                    ConnectorConfiguration.DFLT_KEEP_ALIVE_TIME,
-                    new LinkedBlockingQueue<Runnable>(ConnectorConfiguration.DFLT_THREADPOOL_QUEUE_CAP)
-                );
+                if (!ggHomeFile.exists() || !ggHomeFile.isDirectory())
+                    throw new IgniteCheckedException("Invalid Ignite installation home folder: " + ggHome);
             }
 
+            IgniteConfiguration myCfg = initializeConfiguration(cfg);
+
+            myCfg.setGridLogger(cfgLog);
+
             // Validate segmentation configuration.
             GridSegmentationPolicy segPlc = cfg.getSegmentationPolicy();
 
@@ -1417,6 +1426,16 @@ public class IgnitionEx {
                 0,
                 new LinkedBlockingQueue<Runnable>());
 
+            if (myCfg.getConnectorConfiguration() != null) {
+                restExecSvc = new IgniteThreadPoolExecutor(
+                    "rest-" + myCfg.getGridName(),
+                    myCfg.getConnectorConfiguration().getThreadPoolSize(),
+                    myCfg.getConnectorConfiguration().getThreadPoolSize(),
+                    ConnectorConfiguration.DFLT_KEEP_ALIVE_TIME,
+                    new LinkedBlockingQueue<Runnable>(ConnectorConfiguration.DFLT_THREADPOOL_QUEUE_CAP)
+                );
+            }
+
             utilityCacheExecSvc = new IgniteThreadPoolExecutor(
                 "utility-" + cfg.getGridName(),
                 DFLT_SYSTEM_CORE_THREAD_CNT,
@@ -1499,10 +1518,12 @@ public class IgnitionEx {
          * @param cfg Ignite configuration copy to.
          * @return New ignite configuration.
          */
-        private IgniteConfiguration initializeDefaultConfiguration(IgniteConfiguration cfg)
+        private IgniteConfiguration initializeConfiguration(IgniteConfiguration cfg)
             throws IgniteCheckedException {
             IgniteConfiguration myCfg = new IgniteConfiguration(cfg);
+
             initializeDefaultConfigurationParameters(myCfg);
+
             return myCfg;
         }
 
@@ -1510,26 +1531,7 @@ public class IgnitionEx {
          * Initialize default parameters.
          */
         public void initializeDefaultConfigurationParameters(IgniteConfiguration cfg) throws IgniteCheckedException {
-            // Set Ignite home.
-            String ggHome = cfg.getIgniteHome();
-
-            if (ggHome == null)
-                ggHome = U.getIgniteHome();
-            else
-                // If user provided IGNITE_HOME - set it as a system property.
-                U.setIgniteHome(ggHome);
-
-            U.setWorkDirectory(cfg.getWorkDirectory(), ggHome);
-
-            // Check Ignite home folder (after log is available).
-            if (ggHome != null) {
-                File ggHomeFile = new File(ggHome);
-
-                if (!ggHomeFile.exists() || !ggHomeFile.isDirectory())
-                    throw new IgniteCheckedException("Invalid Ignite installation home folder: " + ggHome);
-            }
-
-            cfg.setIgniteHome(ggHome);
+            cfg.setIgniteHome(U.getIgniteHome());
 
             // Local host.
             String locHost = IgniteSystemProperties.getString(IGNITE_LOCAL_HOST);