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

[01/50] [abbrv] incubator-ignite git commit: IGNITE-146 (remove async instance caching inside Async support adapter and always create new instance)

Repository: incubator-ignite
Updated Branches:
  refs/heads/ignite-16 d0444b79c -> ff7ee6d30


IGNITE-146 (remove async instance caching inside Async support adapter and always create new instance)


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

Branch: refs/heads/ignite-16
Commit: 25fb8e5ca42d8137c37ce513868bd246a5cc146a
Parents: fc768b8
Author: sevdokimov <se...@gridgain.com>
Authored: Thu Jan 29 13:05:20 2015 +0300
Committer: sevdokimov <se...@gridgain.com>
Committed: Thu Jan 29 17:22:35 2015 +0300

----------------------------------------------------------------------
 .../ignite/lang/IgniteAsyncSupportAdapter.java  | 27 +++-----------------
 1 file changed, 4 insertions(+), 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/25fb8e5c/modules/core/src/main/java/org/apache/ignite/lang/IgniteAsyncSupportAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/lang/IgniteAsyncSupportAdapter.java b/modules/core/src/main/java/org/apache/ignite/lang/IgniteAsyncSupportAdapter.java
index e9ab2a1..3d8e14c 100644
--- a/modules/core/src/main/java/org/apache/ignite/lang/IgniteAsyncSupportAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/lang/IgniteAsyncSupportAdapter.java
@@ -24,15 +24,9 @@ import org.apache.ignite.internal.*;
  * Adapter for {@link IgniteAsyncSupport}.
  */
 public class IgniteAsyncSupportAdapter<T extends IgniteAsyncSupport> implements IgniteAsyncSupport {
-    /** */
-    private static final Object mux = new Object();
-
     /** Future for previous asynchronous operation. */
     protected ThreadLocal<IgniteInternalFuture<?>> curFut;
 
-    /** */
-    private volatile T asyncInstance;
-
     /**
      * Default constructor.
      */
@@ -44,29 +38,16 @@ public class IgniteAsyncSupportAdapter<T extends IgniteAsyncSupport> implements
      * @param async Async enabled flag.
      */
     public IgniteAsyncSupportAdapter(boolean async) {
-        if (async) {
+        if (async)
             curFut = new ThreadLocal<>();
-
-            asyncInstance = (T)this;
-        }
     }
 
     /** {@inheritDoc} */
     @Override public T withAsync() {
-        T res = asyncInstance;
-
-        if (res == null) {
-            res = createAsyncInstance();
-
-            synchronized (mux) {
-                if (asyncInstance != null)
-                    return asyncInstance;
-
-                asyncInstance = res;
-            }
-        }
+        if (isAsync())
+            return (T)this;
 
-        return res;
+        return createAsyncInstance();
     }
 
     /**


[09/50] [abbrv] incubator-ignite git commit: # ignite-sprint-1 fixed build.

Posted by vo...@apache.org.
# ignite-sprint-1 fixed build.


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

Branch: refs/heads/ignite-16
Commit: 4fe57d44373294700dcdeb42206bd525ce84475a
Parents: bdebb40
Author: AKuznetsov <ak...@gridgain.com>
Authored: Fri Jan 30 09:55:21 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Fri Jan 30 09:55:21 2015 +0700

----------------------------------------------------------------------
 assembly/release-hadoop.xml | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4fe57d44/assembly/release-hadoop.xml
----------------------------------------------------------------------
diff --git a/assembly/release-hadoop.xml b/assembly/release-hadoop.xml
index 7dbd5ea..576425c 100644
--- a/assembly/release-hadoop.xml
+++ b/assembly/release-hadoop.xml
@@ -39,15 +39,15 @@
             <outputDirectory>/docs</outputDirectory>
         </file>
         <file>
-            <source>docs/core-site.gridgain.xml</source>
+            <source>docs/core-site.ignite.xml</source>
             <outputDirectory>/docs</outputDirectory>
         </file>
         <file>
-            <source>docs/mapred-site.gridgain.xml</source>
+            <source>docs/mapred-site.ignite.xml</source>
             <outputDirectory>/docs</outputDirectory>
         </file>
         <file>
-            <source>docs/hive-site.gridgain.xml</source>
+            <source>docs/hive-site.ignite.xml</source>
             <outputDirectory>/docs</outputDirectory>
         </file>
     </files>


[29/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-86

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-86


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

Branch: refs/heads/ignite-16
Commit: 258ee1c0fe0deb89c598695f5b674ead98d9620a
Parents: 7e1ed4e 4da5e29
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 30 14:30:06 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 30 14:30:06 2015 +0300

----------------------------------------------------------------------
 NOTICE.txt                                      |   14 +-
 assembly/libs/readme.txt                        |  111 +-
 assembly/release-base-fabric.xml                |    2 +-
 assembly/release-hadoop.xml                     |    6 +-
 docs/core-site.gridgain.xml                     |   89 -
 docs/core-site.ignite.xml                       |   89 +
 docs/gridgain_readme.md                         |  149 -
 docs/gridgain_readme.pdf                        |  Bin 407698 -> 0 bytes
 docs/hadoop_readme.md                           |   80 +-
 docs/hadoop_readme.pdf                          |  Bin 411788 -> 82297 bytes
 docs/hive-site.gridgain.xml                     |   36 -
 docs/hive-site.ignite.xml                       |   36 +
 docs/ignite_readme.md                           |  100 +
 docs/ignite_readme.pdf                          |  Bin 0 -> 76810 bytes
 docs/mapred-site.gridgain.xml                   |   79 -
 docs/mapred-site.ignite.xml                     |   79 +
 examples/config/filesystem/readme.txt           |    4 +-
 .../hibernate/example-hibernate-L2-cache.xml    |   14 +-
 examples/config/hibernate/readme.txt            |    4 +-
 examples/config/servlet/readme.txt              |    2 +-
 .../ComputeFibonacciContinuationExample.java    |   13 +-
 .../compute/ComputeRunnableExample.java         |    7 +-
 .../datagrid/CacheDataLoaderExample.java        |   15 +-
 .../HibernateL2CacheExampleNodeStartup.java     |    6 +-
 .../examples/ScalarContinuationExample.scala    |   11 +-
 ipc/readme.txt                                  |    4 +-
 ipc/shmem/Makefile.am                           |    2 +-
 ipc/shmem/Makefile.in                           |    2 +-
 ipc/shmem/configure                             |    4 +-
 ipc/shmem/configure.ac                          |    2 +-
 ipc/shmem/ggshmem/Makefile.am                   |   23 -
 ipc/shmem/ggshmem/Makefile.in                   |  589 --
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |  882 --
 ipc/shmem/igniteshmem/Makefile.am               |   23 +
 ipc/shmem/igniteshmem/Makefile.in               |  589 ++
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  882 ++
 ipc/shmem/include/Makefile.am                   |    2 +-
 ipc/shmem/include/Makefile.in                   |    2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |  117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |  117 -
 ipc/shmem/readme.txt                            |   17 +-
 modules/aop/readme.txt                          |   12 +-
 .../apache/ignite/gridify/AbstractAopTest.java  |    2 +-
 .../apache/ignite/gridify/TestGridifyTask.java  |    2 +-
 .../singlesplit/SingleSplitsLoadTest.java       |    2 +-
 modules/aws/readme.txt                          |   12 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java |   12 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |    8 +-
 .../ignite/client/ClientStartNodeTask.java      |    2 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    5 +-
 .../integration/ClientAbstractSelfTest.java     |   28 +-
 .../rest/AbstractRestProcessorSelfTest.java     |    2 +
 .../rest/ClientMemcachedProtocolSelfTest.java   |    4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |   11 +-
 .../rest/RestMemcacheProtocolSelfTest.java      |    9 +-
 .../rest/RestProcessorStartSelfTest.java        |    3 +-
 .../rest/TaskCommandHandlerSelfTest.java        |    2 +-
 .../java/META-INF/native/linux64/libggshmem.so  |  Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |  Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |  Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |  Bin 0 -> 33116 bytes
 .../src/main/java/org/apache/ignite/Ignite.java |   10 +
 .../java/org/apache/ignite/IgniteCache.java     |   55 +-
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteCluster.java   |    2 +-
 .../java/org/apache/ignite/IgniteCompute.java   |    2 +-
 .../org/apache/ignite/IgniteDataLoader.java     |   14 +-
 .../java/org/apache/ignite/IgniteEvents.java    |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |    2 +-
 .../java/org/apache/ignite/IgniteManaged.java   |    2 +-
 .../java/org/apache/ignite/IgniteMessaging.java |    2 +-
 .../java/org/apache/ignite/IgniteScheduler.java |    6 +-
 .../apache/ignite/IgniteSystemProperties.java   |    6 +-
 .../main/java/org/apache/ignite/Ignition.java   |   38 +-
 .../org/apache/ignite/cache/CacheEntry.java     |   27 +-
 .../java/org/apache/ignite/cache/CacheLock.java |   57 -
 .../org/apache/ignite/cache/CacheMBean.java     |  295 -
 .../org/apache/ignite/cache/CacheManager.java   |  172 +-
 .../org/apache/ignite/cache/CacheMetrics.java   |  416 +-
 .../apache/ignite/cache/CacheProjection.java    |   43 +-
 .../apache/ignite/cache/CachingProvider.java    |    2 +-
 .../java/org/apache/ignite/cache/GridCache.java |   20 +-
 .../ignite/cache/GridCacheVersionedEntry.java   |   82 +
 .../ignite/cache/affinity/CacheAffinity.java    |    9 +-
 .../fifo/CacheFifoEvictionPolicyMBean.java      |   10 +-
 ...CacheGgfsPerBlockLruEvictionPolicyMBean.java |   18 +-
 .../lru/CacheLruEvictionPolicyMBean.java        |   10 +-
 .../random/CacheRandomEvictionPolicyMBean.java  |    6 +-
 .../apache/ignite/cache/query/CacheQueries.java |    7 +-
 .../ignite/cache/query/CacheQueryFuture.java    |    4 +-
 .../client/router/GridTcpRouterMBean.java       |   16 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |  697 +-
 .../org/apache/ignite/cluster/ClusterNode.java  |   40 +-
 .../ignite/cluster/ClusterNodeMetrics.java      |  695 --
 .../ignite/compute/ComputeTaskFuture.java       |    4 +-
 .../ignite/compute/ComputeTaskSession.java      |    3 +-
 .../ignite/fs/mapreduce/IgniteFsTask.java       |    2 +-
 .../org/apache/ignite/hadoop/GridHadoop.java    |    6 +-
 .../ignite/internal/ClusterGroupAdapter.java    |    4 +-
 .../internal/ClusterLocalNodeMetrics.java       |  311 -
 .../ClusterLocalNodeMetricsMXBeanImpl.java      |  309 +
 .../ignite/internal/ClusterMetricsImpl.java     |  813 --
 .../ignite/internal/ClusterMetricsSnapshot.java | 1397 +++
 .../internal/ClusterNodeLocalMapImpl.java       |    2 +-
 .../internal/ClusterNodeMetricsMBean.java       |   29 -
 .../java/org/apache/ignite/internal/GridEx.java |  143 -
 .../org/apache/ignite/internal/GridGainEx.java  | 2399 -----
 .../ignite/internal/GridJobSessionImpl.java     |    2 +-
 .../org/apache/ignite/internal/GridKernal.java  | 3308 -------
 .../ignite/internal/GridKernalContext.java      |    2 +-
 .../ignite/internal/GridKernalContextImpl.java  |    8 +-
 .../apache/ignite/internal/GridLoggerProxy.java |    2 +-
 .../ignite/internal/GridTaskSessionImpl.java    |    2 +-
 .../ignite/internal/GridUpdateNotifier.java     |    2 +-
 .../ignite/internal/IgniteClusterAsyncImpl.java |   14 +-
 .../ignite/internal/IgniteComputeImpl.java      |   70 +-
 .../ignite/internal/IgniteEventsImpl.java       |    9 +-
 .../org/apache/ignite/internal/IgniteEx.java    |  143 +
 .../ignite/internal/IgniteInternalFuture.java   |  190 +
 .../apache/ignite/internal/IgniteKernal.java    | 3322 +++++++
 .../ignite/internal/IgniteManagedImpl.java      |    2 +-
 .../ignite/internal/IgniteMessagingImpl.java    |   12 +-
 .../ignite/internal/IgniteSchedulerImpl.java    |    6 +-
 .../internal/IgniteThreadPoolMBeanAdapter.java  |  149 -
 .../internal/IgniteThreadPoolMXBeanAdapter.java |  129 +
 .../org/apache/ignite/internal/IgnitionEx.java  | 2396 +++++
 .../ignite/internal/IgnitionMBeanAdapter.java   |   59 -
 .../ignite/internal/IgnitionMXBeanAdapter.java  |   59 +
 .../internal/executor/GridExecutorService.java  |   46 +-
 .../managers/communication/GridIoManager.java   |    3 +-
 .../discovery/GridDiscoveryManager.java         |    6 +-
 .../eventstorage/GridEventStorageManager.java   |    4 +-
 .../internal/mxbean/IgniteStandardMXBean.java   |  277 +
 .../apache/ignite/internal/mxbean/package.html  |   24 +
 .../affinity/GridAffinityAssignment.java        |   10 +-
 .../affinity/GridAffinityAssignmentCache.java   |    5 +-
 .../affinity/GridAffinityProcessor.java         |  338 +-
 .../processors/affinity/GridAffinityUtils.java  |    2 +-
 .../processors/cache/CacheLockImpl.java         |  134 +-
 .../processors/cache/CacheMetricsImpl.java      |  586 ++
 .../cache/CacheMetricsMXBeanImpl.java           |  310 +
 .../processors/cache/CacheMetricsSnapshot.java  |  518 +
 .../processors/cache/GridCacheAdapter.java      |  719 +-
 .../cache/GridCacheAffinityManager.java         |    8 +-
 .../cache/GridCacheAtomicVersionComparator.java |    2 +
 .../cache/GridCacheBatchSwapEntry.java          |    1 +
 .../cache/GridCacheClearAllRunnable.java        |    1 +
 .../processors/cache/GridCacheContext.java      |   60 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../processors/cache/GridCacheEntryEx.java      |    9 +
 .../processors/cache/GridCacheEntryImpl.java    |   27 +-
 .../processors/cache/GridCacheEntryInfo.java    |    1 +
 .../cache/GridCacheEvictionEntry.java           |   27 +-
 .../cache/GridCacheEvictionManager.java         |    8 +-
 .../cache/GridCacheEvictionRequest.java         |    1 +
 .../cache/GridCacheExplicitLockSpan.java        |    5 +-
 .../cache/GridCacheFilterEvaluationEntry.java   |   27 +-
 .../processors/cache/GridCacheFuture.java       |    4 +-
 .../processors/cache/GridCacheIoManager.java    |   15 +-
 .../cache/GridCacheLockTimeoutException.java    |    2 +
 .../processors/cache/GridCacheMBeanAdapter.java |  217 -
 .../processors/cache/GridCacheMapEntry.java     |  172 +-
 .../cache/GridCacheMetricsAdapter.java          |  260 -
 .../cache/GridCacheMultiTxFuture.java           |    6 +-
 .../processors/cache/GridCacheMvcc.java         |    1 +
 .../cache/GridCacheMvccCandidate.java           |    5 +-
 .../processors/cache/GridCacheMvccManager.java  |   30 +-
 .../cache/GridCacheOffheapSwapEntry.java        |    1 +
 .../GridCachePartitionExchangeManager.java      |    9 +-
 .../processors/cache/GridCachePreloader.java    |    7 +-
 .../cache/GridCachePreloaderAdapter.java        |    9 +-
 .../processors/cache/GridCacheProcessor.java    |   47 +-
 .../processors/cache/GridCacheProjectionEx.java |   28 +-
 .../cache/GridCacheProjectionImpl.java          |   70 +-
 .../processors/cache/GridCacheProxyImpl.java    |   99 +-
 .../cache/GridCacheSharedContext.java           |   14 +-
 .../processors/cache/GridCacheStoreManager.java |   44 +-
 .../processors/cache/GridCacheSwapEntry.java    |    1 +
 .../cache/GridCacheSwapEntryImpl.java           |    1 +
 .../processors/cache/GridCacheSwapManager.java  |    1 +
 .../processors/cache/GridCacheTtlManager.java   |    4 +
 .../cache/GridCacheUpdateAtomicResult.java      |    7 +-
 .../processors/cache/GridCacheUtils.java        |    8 +-
 .../processors/cache/GridCacheVersion.java      |  256 -
 .../processors/cache/GridCacheVersionEx.java    |  104 -
 .../cache/GridCacheVersionManager.java          |  281 -
 .../processors/cache/GridCacheVersionable.java  |   28 -
 .../processors/cache/GridDrResolveResult.java   |   63 -
 .../cache/IgniteCacheExpiryPolicy.java          |    1 +
 .../processors/cache/IgniteCacheProxy.java      |   98 +-
 .../GridCacheAtomicSequenceImpl.java            |    3 +-
 .../GridCacheDataStructuresManager.java         |    4 +-
 .../distributed/GridCacheCommittedTxInfo.java   |    2 +-
 .../distributed/GridCacheMappedVersion.java     |    2 +-
 ...ridCacheOptimisticCheckPreparedTxFuture.java |    8 +-
 ...idCacheOptimisticCheckPreparedTxRequest.java |    2 +-
 ...dCacheOptimisticCheckPreparedTxResponse.java |    2 +-
 .../GridCachePerThreadTxCommitBuffer.java       |    1 +
 ...dCachePessimisticCheckCommittedTxFuture.java |    8 +-
 ...CachePessimisticCheckCommittedTxRequest.java |    2 +-
 ...achePessimisticCheckCommittedTxResponse.java |    1 +
 .../distributed/GridCacheTtlUpdateRequest.java  |    1 +
 .../distributed/GridCacheTxCommitBuffer.java    |    2 +-
 .../distributed/GridCacheTxFinishSync.java      |    8 +-
 .../distributed/GridDistributedBaseMessage.java |    1 +
 .../GridDistributedCacheAdapter.java            |    8 +-
 .../distributed/GridDistributedCacheEntry.java  |    1 +
 .../distributed/GridDistributedLockRequest.java |    1 +
 .../GridDistributedLockResponse.java            |    1 +
 .../GridDistributedTxFinishRequest.java         |    1 +
 .../GridDistributedTxFinishResponse.java        |    1 +
 .../distributed/GridDistributedTxMapping.java   |    1 +
 .../GridDistributedTxPrepareRequest.java        |    1 +
 .../GridDistributedTxPrepareResponse.java       |    1 +
 .../GridDistributedTxRemoteAdapter.java         |   55 +-
 .../cache/distributed/dht/GridDhtCache.java     |   12 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   13 +-
 .../distributed/dht/GridDhtCacheEntry.java      |    8 +-
 .../distributed/dht/GridDhtEmbeddedFuture.java  |    8 +-
 .../cache/distributed/dht/GridDhtFuture.java    |    4 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |   12 +-
 .../distributed/dht/GridDhtLocalPartition.java  |    6 +-
 .../distributed/dht/GridDhtLockFuture.java      |   12 +-
 .../distributed/dht/GridDhtLockRequest.java     |    1 +
 .../distributed/dht/GridDhtLockResponse.java    |    1 +
 .../distributed/dht/GridDhtTopologyFuture.java  |    4 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   30 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   12 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |    1 +
 .../dht/GridDhtTxFinishResponse.java            |    2 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   20 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   12 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   12 +-
 .../dht/GridDhtTxPrepareRequest.java            |    1 +
 .../dht/GridDhtTxPrepareResponse.java           |    1 +
 .../cache/distributed/dht/GridDhtTxRemote.java  |    1 +
 .../dht/GridPartitionedGetFuture.java           |   35 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  159 +-
 .../GridDhtAtomicDeferredUpdateResponse.java    |    1 +
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    1 +
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |    1 +
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |    1 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   35 +-
 .../dht/atomic/GridNearAtomicUpdateRequest.java |    1 +
 .../atomic/GridNearAtomicUpdateResponse.java    |    1 +
 .../dht/colocated/GridDhtColocatedCache.java    |   29 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   24 +-
 .../colocated/GridDhtDetachedCacheEntry.java    |    1 +
 .../dht/preloader/GridDhtForceKeysFuture.java   |    7 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   13 +-
 .../GridDhtPartitionsAbstractMessage.java       |    1 +
 .../GridDhtPartitionsExchangeFuture.java        |   21 +-
 .../preloader/GridDhtPartitionsFullMessage.java |    1 +
 .../GridDhtPartitionsSingleMessage.java         |    1 +
 .../dht/preloader/GridDhtPreloader.java         |   29 +-
 .../distributed/near/GridNearAtomicCache.java   |   46 +-
 .../distributed/near/GridNearCacheAdapter.java  |   23 +-
 .../near/GridNearCacheClearAllRunnable.java     |    1 +
 .../distributed/near/GridNearCacheEntry.java    |    4 +-
 .../distributed/near/GridNearGetFuture.java     |   45 +-
 .../distributed/near/GridNearGetRequest.java    |    1 +
 .../distributed/near/GridNearGetResponse.java   |    1 +
 .../distributed/near/GridNearLockFuture.java    |   30 +-
 .../distributed/near/GridNearLockRequest.java   |    1 +
 .../distributed/near/GridNearLockResponse.java  |    1 +
 .../near/GridNearTransactionalCache.java        |   10 +-
 .../near/GridNearTxFinishFuture.java            |   18 +-
 .../near/GridNearTxFinishRequest.java           |    2 +-
 .../near/GridNearTxFinishResponse.java          |    1 +
 .../cache/distributed/near/GridNearTxLocal.java |   59 +-
 .../near/GridNearTxPrepareFuture.java           |   18 +-
 .../near/GridNearTxPrepareResponse.java         |    1 +
 .../distributed/near/GridNearTxRemote.java      |    1 +
 .../cache/dr/GridCacheDrExpirationInfo.java     |    2 +-
 .../processors/cache/dr/GridCacheDrInfo.java    |    2 +-
 .../processors/cache/dr/GridCacheDrManager.java |   58 +-
 .../cache/dr/os/GridOsCacheDrManager.java       |   36 +-
 .../extras/GridCacheAttributesEntryExtras.java  |    1 +
 .../GridCacheAttributesMvccEntryExtras.java     |    1 +
 ...dCacheAttributesMvccObsoleteEntryExtras.java |    1 +
 ...cheAttributesMvccObsoleteTtlEntryExtras.java |    1 +
 .../GridCacheAttributesMvccTtlEntryExtras.java  |    1 +
 .../GridCacheAttributesObsoleteEntryExtras.java |    1 +
 ...idCacheAttributesObsoleteTtlEntryExtras.java |    1 +
 .../GridCacheAttributesTtlEntryExtras.java      |    1 +
 .../cache/extras/GridCacheEntryExtras.java      |    1 +
 .../extras/GridCacheEntryExtrasAdapter.java     |    1 +
 .../cache/extras/GridCacheMvccEntryExtras.java  |    1 +
 .../GridCacheMvccObsoleteEntryExtras.java       |    1 +
 .../GridCacheMvccObsoleteTtlEntryExtras.java    |    1 +
 .../extras/GridCacheMvccTtlEntryExtras.java     |    1 +
 .../extras/GridCacheObsoleteEntryExtras.java    |    1 +
 .../extras/GridCacheObsoleteTtlEntryExtras.java |    1 +
 .../cache/extras/GridCacheTtlEntryExtras.java   |    1 +
 .../processors/cache/local/GridLocalCache.java  |    8 +-
 .../cache/local/GridLocalCacheEntry.java        |    1 +
 .../cache/local/GridLocalLockFuture.java        |    1 +
 .../processors/cache/local/GridLocalTx.java     |   12 +-
 .../cache/local/GridLocalTxFuture.java          |    1 +
 .../local/atomic/GridLocalAtomicCache.java      |  162 +-
 .../GridCacheDistributedFieldsQueryFuture.java  |    4 +-
 .../query/GridCacheDistributedQueryManager.java |    9 +-
 .../query/GridCacheFieldsQueryErrorFuture.java  |    3 +-
 .../query/GridCacheLocalFieldsQueryFuture.java  |    4 +-
 .../cache/query/GridCacheLocalQueryFuture.java  |    3 +-
 .../cache/query/GridCacheQueriesEx.java         |    6 +-
 .../cache/query/GridCacheQueriesImpl.java       |   11 +-
 .../cache/query/GridCacheQueriesProxy.java      |   11 +-
 .../cache/query/GridCacheQueryManager.java      |   54 +-
 .../query/GridCacheQueryMetadataAware.java      |    4 +-
 .../GridCacheContinuousQueryEntry.java          |   27 +-
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |    2 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |    2 +-
 .../transactions/IgniteTransactionsImpl.java    |    3 +-
 .../cache/transactions/IgniteTxAdapter.java     |   59 +-
 .../cache/transactions/IgniteTxEntry.java       |    1 +
 .../cache/transactions/IgniteTxEx.java          |   10 +-
 .../cache/transactions/IgniteTxHandler.java     |   49 +-
 .../transactions/IgniteTxLocalAdapter.java      |  201 +-
 .../cache/transactions/IgniteTxLocalEx.java     |   18 +-
 .../cache/transactions/IgniteTxManager.java     |   21 +-
 .../cache/transactions/IgniteTxProxyImpl.java   |   11 +-
 .../cache/transactions/IgniteTxRemoteEx.java    |    2 +-
 .../version/GridCachePlainVersionedEntry.java   |  131 +
 .../version/GridCacheRawVersionedEntry.java     |  238 +
 .../cache/version/GridCacheVersion.java         |  256 +
 ...ridCacheVersionAbstractConflictResolver.java |   56 +
 .../GridCacheVersionConflictContext.java        |   73 +
 .../GridCacheVersionConflictContextImpl.java    |  188 +
 .../GridCacheVersionConflictResolver.java       |   59 +
 .../cache/version/GridCacheVersionEx.java       |  104 +
 .../cache/version/GridCacheVersionManager.java  |  282 +
 .../cache/version/GridCacheVersionable.java     |   28 +
 .../version/GridCacheVersionedEntryEx.java      |   31 +
 .../closure/GridClosureProcessor.java           |   56 +-
 .../continuous/GridContinuousProcessor.java     |    4 +-
 .../dataload/GridDataLoaderProcessor.java       |    5 +-
 .../dataload/IgniteDataLoaderImpl.java          |   87 +-
 .../dr/GridDrDataLoadCacheUpdater.java          |    8 +-
 .../processors/dr/GridRawVersionedEntry.java    |  210 -
 .../processors/dr/GridVersionedEntry.java       |   80 -
 .../email/IgniteEmailProcessorAdapter.java      |    5 +-
 .../email/IgniteNoopEmailProcessor.java         |    5 +-
 .../processors/fs/GridGgfsAsyncImpl.java        |   10 +-
 .../processors/fs/GridGgfsDataManager.java      |   30 +-
 .../internal/processors/fs/GridGgfsEx.java      |    3 +-
 .../internal/processors/fs/GridGgfsImpl.java    |   20 +-
 .../processors/fs/GridGgfsInputStreamImpl.java  |   19 +-
 .../processors/fs/GridGgfsIpcHandler.java       |    4 +-
 .../processors/fs/GridGgfsMetaManager.java      |    9 +-
 .../internal/processors/fs/GridGgfsServer.java  |   34 +-
 .../processors/fs/GridGgfsServerHandler.java    |    4 +-
 .../processors/fs/GridGgfsServerManager.java    |    8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |    2 +-
 .../processors/fs/IgniteFsOutputStreamImpl.java |    3 +-
 .../processors/fs/IgniteFsProcessor.java        |    4 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |    2 +-
 .../hadoop/IgniteHadoopNoopProcessor.java       |    5 +-
 .../hadoop/IgniteHadoopProcessorAdapter.java    |    5 +-
 .../processors/query/GridQueryIndexing.java     |    4 +-
 .../processors/query/GridQueryProcessor.java    |   12 +-
 .../resource/GridResourceProcessor.java         |    2 +-
 .../resource/GridSpringResourceContext.java     |    2 +-
 .../processors/rest/GridRestProcessor.java      |   18 +-
 .../rest/GridRestProtocolHandler.java           |    4 +-
 .../rest/handlers/GridRestCommandHandler.java   |    4 +-
 .../handlers/cache/GridCacheCommandHandler.java |   71 +-
 .../cache/GridCacheQueryCommandHandler.java     |   16 +-
 .../handlers/cache/GridCacheRestMetrics.java    |   77 +-
 .../handlers/log/GridLogCommandHandler.java     |    3 +-
 .../metadata/GridPortableMetadataHandler.java   |    3 +-
 .../handlers/task/GridTaskCommandHandler.java   |   14 +-
 .../top/GridTopologyCommandHandler.java         |    5 +-
 .../version/GridVersionCommandHandler.java      |    3 +-
 .../tcp/GridTcpMemcachedNioListener.java        |   17 +-
 .../protocols/tcp/GridTcpRestNioListener.java   |    5 +-
 .../service/GridServiceProcessor.java           |   22 +-
 .../processors/service/GridServiceProxy.java    |    2 +-
 .../processors/streamer/IgniteStreamerImpl.java |    4 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9100 -----------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../GridTcpCommunicationMessageAdapter.java     |    1 +
 .../GridTcpCommunicationMessageState.java       |    3 +-
 .../util/future/GridCompoundFuture.java         |   28 +-
 .../util/future/GridCompoundIdentityFuture.java |    2 +-
 .../util/future/GridEmbeddedFuture.java         |   38 +-
 .../util/future/GridFinishedFuture.java         |    8 +-
 .../util/future/GridFinishedFutureEx.java       |    9 +-
 .../internal/util/future/GridFutureAdapter.java |   30 +-
 .../util/future/GridFutureAdapterEx.java        |   31 +-
 .../util/future/GridFutureChainListener.java    |    8 +-
 .../internal/util/ipc/GridIpcEndpoint.java      |   49 -
 .../util/ipc/GridIpcEndpointBindException.java  |   47 -
 .../util/ipc/GridIpcEndpointFactory.java        |   84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |   29 -
 .../util/ipc/GridIpcServerEndpoint.java         |   73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |   66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |  250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |   49 +
 .../util/ipc/IpcEndpointBindException.java      |   47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |   84 +
 .../internal/util/ipc/IpcEndpointType.java      |   29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |   73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |   66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |  250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |   87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |  179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |   87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |  179 +
 .../GridIpcOutOfSystemResourcesException.java   |   59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |  336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |   67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |  171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |   99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |  242 -
 ...cSharedMemoryOperationTimedoutException.java |   59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |   80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |  707 --
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |  374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |  242 -
 .../shmem/IpcOutOfSystemResourcesException.java |   59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |  336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |   67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |  171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |   99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |  261 +
 ...cSharedMemoryOperationTimedoutException.java |   59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |   80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  707 ++
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |  374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |  242 +
 .../ignite/internal/util/lang/GridFunc.java     |   53 +-
 .../ignite/internal/util/nio/GridNioFuture.java |    2 +-
 .../util/nio/GridShmemCommunicationClient.java  |    4 +-
 .../apache/ignite/internal/util/typedef/X.java  |    6 +-
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../apache/ignite/internal/visor/VisorJob.java  |    2 +-
 .../internal/visor/VisorMultiNodeTask.java      |    2 +-
 .../ignite/internal/visor/cache/VisorCache.java |    2 +-
 .../internal/visor/cache/VisorCacheMetrics.java |   37 +-
 .../visor/cache/VisorCachePreloadTask.java      |    6 +-
 .../visor/cache/VisorCacheResetMetricsTask.java |    2 +-
 .../compute/VisorComputeMonitoringHolder.java   |   10 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../visor/node/VisorBasicConfiguration.java     |    2 +-
 .../visor/node/VisorGridConfiguration.java      |    2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    6 +-
 .../internal/visor/node/VisorNodeGcTask.java    |    2 +-
 .../internal/visor/query/VisorQueryTask.java    |    2 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../apache/ignite/lang/IgniteAsyncSupport.java  |    6 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   25 +-
 .../ignite/lang/IgniteAsyncSupported.java       |    2 +-
 .../org/apache/ignite/lang/IgniteFuture.java    |  189 -
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../ignite/mxbean/CacheMetricsMXBean.java       |  245 +
 .../mxbean/ClusterLocalNodeMetricsMXBean.java   |  240 +
 .../apache/ignite/mxbean/IgniteCacheMXBean.java |   72 -
 .../org/apache/ignite/mxbean/IgniteMBean.java   |  386 -
 .../ignite/mxbean/IgniteMBeanDescription.java   |   34 -
 .../IgniteMBeanParametersDescriptions.java      |   34 -
 .../mxbean/IgniteMBeanParametersNames.java      |   34 -
 .../org/apache/ignite/mxbean/IgniteMXBean.java  |  386 +
 .../ignite/mxbean/IgniteMXBeanDescription.java  |   34 +
 .../IgniteMXBeanParametersDescriptions.java     |   34 +
 .../mxbean/IgniteMXBeanParametersNames.java     |   34 +
 .../ignite/mxbean/IgniteStandardMBean.java      |  275 -
 .../ignite/mxbean/IgniteThreadPoolMBean.java    |  152 -
 .../ignite/mxbean/IgniteThreadPoolMXBean.java   |  152 +
 .../org/apache/ignite/mxbean/IgnitionMBean.java |  151 -
 .../apache/ignite/mxbean/IgnitionMXBean.java    |  151 +
 .../ignite/scheduler/SchedulerFuture.java       |    4 +-
 .../ignite/spi/IgniteSpiManagementMBean.java    |   14 +-
 .../noop/NoopAuthenticationSpiMBean.java        |    2 +-
 .../cache/CacheCheckpointSpiMBean.java          |    4 +-
 .../checkpoint/jdbc/JdbcCheckpointSpiMBean.java |   24 +-
 .../sharedfs/SharedFsCheckpointSpiMBean.java    |    6 +-
 .../fifoqueue/FifoQueueCollisionSpiMBean.java   |   18 +-
 .../JobStealingCollisionSpiMBean.java           |   36 +-
 .../PriorityQueueCollisionSpiMBean.java         |   34 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   24 +-
 .../tcp/TcpCommunicationSpiMBean.java           |   58 +-
 .../local/LocalDeploymentSpiMBean.java          |    2 +-
 .../spi/discovery/DiscoveryMetricsHelper.java   |  368 -
 .../spi/discovery/DiscoveryMetricsProvider.java |    2 +-
 .../discovery/DiscoveryNodeMetricsAdapter.java  | 1068 --
 .../discovery/tcp/TcpClientDiscoverySpi.java    |    6 +-
 .../tcp/TcpClientDiscoverySpiMBean.java         |   34 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   16 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java |   62 +-
 .../tcp/internal/TcpDiscoveryNode.java          |   16 +-
 .../messages/TcpDiscoveryHeartbeatMessage.java  |   36 +-
 .../memory/MemoryEventStorageSpiMBean.java      |   10 +-
 .../failover/always/AlwaysFailoverSpiMBean.java |    6 +-
 .../JobStealingFailoverSpiMBean.java            |    8 +-
 .../failover/never/NeverFailoverSpiMBean.java   |    2 +-
 .../adaptive/AdaptiveCpuLoadProbe.java          |    2 +-
 .../adaptive/AdaptiveJobCountLoadProbe.java     |    2 +-
 .../adaptive/AdaptiveLoadBalancingSpiMBean.java |    4 +-
 .../AdaptiveProcessingTimeLoadProbe.java        |    2 +-
 .../RoundRobinLoadBalancingSpiMBean.java        |    4 +-
 .../WeightedRandomLoadBalancingSpiMBean.java    |    6 +-
 .../noop/NoopSecureSessionSpiMBean.java         |    2 +-
 .../swapspace/file/FileSwapSpaceSpiMBean.java   |   12 +-
 .../apache/ignite/streamer/StreamerMBean.java   |   34 +-
 .../ignite/streamer/StreamerStageMBean.java     |   24 +-
 .../ignite/streamer/StreamerWindowMBean.java    |   10 +-
 .../index/StreamerIndexProviderMBean.java       |   12 +-
 .../StreamerCacheAffinityEventRouter.java       |    2 +-
 .../ignite/GridExceptionHelpLinksSelfTest.java  |  106 -
 .../ignite/GridExternalizableAbstractTest.java  |   41 -
 .../org/apache/ignite/GridTestTaskSession.java  |    4 +-
 .../ignite/IgniteCacheAffinitySelfTest.java     |  283 +
 .../IgniteExceptionHelpLinksSelfTest.java       |  105 +
 .../IgniteExternalizableAbstractTest.java       |   41 +
 ...CachePartitionFairAffinityNodesSelfTest.java |    6 +-
 .../store/GridCacheBalancingStoreSelfTest.java  |    3 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |    7 +-
 .../fs/GridGgfsEventsAbstractSelfTest.java      |    2 +-
 .../ignite/fs/GridGgfsFragmentizerSelfTest.java |    2 +-
 .../ignite/internal/ClusterMetricsSelfTest.java |  124 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |    6 +-
 .../internal/GridCancelOnGridStopSelfTest.java  |    2 +-
 .../GridCancelledJobsMetricsSelfTest.java       |    2 +-
 .../internal/GridContinuousTaskSelfTest.java    |    4 +-
 .../internal/GridDiscoveryEventSelfTest.java    |    3 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    6 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    4 +-
 .../internal/GridExecutorServiceTest.java       |  315 -
 .../GridExplicitImplicitDeploymentSelfTest.java |  476 -
 .../GridFailoverCustomTopologySelfTest.java     |    2 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |   90 +-
 .../ignite/internal/GridKernalTestUtils.java    |    3 +-
 .../internal/GridListenActorSelfTest.java       |    3 +-
 .../internal/GridMultipleJobsSelfTest.java      |    8 +-
 .../internal/GridNonHistoryMetricsSelfTest.java |    4 +-
 .../internal/GridProjectionAbstractTest.java    |   40 +-
 .../ignite/internal/GridReduceSelfTest.java     |    4 +-
 .../GridTaskCancelSingleNodeSelfTest.java       |    2 +-
 .../internal/GridTaskExecutionSelfTest.java     |    2 +-
 .../GridTaskFutureImplStopGridSelfTest.java     |    5 +-
 .../GridTaskInstanceExecutionSelfTest.java      |    2 +-
 .../internal/GridTaskJobRejectSelfTest.java     |    2 +-
 .../internal/GridTaskListenerSelfTest.java      |    4 +-
 .../GridTopicExternalizableSelfTest.java        |    3 +-
 .../GridTopologyBuildVersionSelfTest.java       |    2 +-
 .../internal/GridUpdateNotifierSelfTest.java    |    3 +-
 .../internal/IgniteExecutorServiceTest.java     |  315 +
 ...gniteExplicitImplicitDeploymentSelfTest.java |  476 +
 .../GridCheckpointManagerAbstractSelfTest.java  |    6 +-
 .../GridCommunicationSendMessageSelfTest.java   |    4 +-
 .../GridDeploymentMessageCountSelfTest.java     |    4 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    2 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |    6 +-
 .../events/GridEventStorageManagerSelfTest.java |    3 +-
 .../swapspace/GridSwapSpaceManagerSelfTest.java |    2 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |    6 +-
 .../GridCacheAbstractFailoverSelfTest.java      |    3 +-
 .../cache/GridCacheAbstractFlagsTest.java       |    4 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java |    5 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  473 +-
 .../GridCacheAbstractIteratorsSelfTest.java     |   10 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |  752 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   50 +
 .../GridCacheAbstractRemoveFailureTest.java     |    6 +-
 .../cache/GridCacheAbstractSelfTest.java        |    2 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |    4 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |    8 +-
 .../cache/GridCacheBasicApiAbstractTest.java    |  229 +-
 .../cache/GridCacheConcurrentMapTest.java       |    6 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    6 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |    7 +-
 .../GridCacheFinishPartitionsSelfTest.java      |   52 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |    6 +-
 ...idCacheGetAndTransformStoreAbstractTest.java |    4 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |   19 +-
 .../GridCacheGroupLockFailoverSelfTest.java     |    7 +-
 .../cache/GridCacheIncrementTransformTest.java  |    4 +-
 .../processors/cache/GridCacheLeakTest.java     |    2 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |   18 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |    3 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    6 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |    5 +-
 .../cache/GridCacheMvccFlagsTest.java           |    5 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    4 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |    5 +-
 .../processors/cache/GridCacheMvccSelfTest.java |    5 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |   15 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    2 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |    5 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   11 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |    2 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |    6 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |    2 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |    8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   17 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |    2 +-
 .../GridCacheReferenceCleanupSelfTest.java      |    6 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |    4 +-
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    4 +-
 .../processors/cache/GridCacheStopSelfTest.java |    6 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |    4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |    4 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |    2 +-
 .../processors/cache/GridCacheTestEntryEx.java  |    6 +
 ...cheTransactionalAbstractMetricsSelfTest.java |   20 +-
 .../cache/GridCacheTtlManagerLoadTest.java      |    5 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |    2 +-
 .../GridCacheVariableTopologySelfTest.java      |    4 +-
 .../cache/GridCacheVersionSelfTest.java         |    1 +
 ...idCacheWriteBehindStoreAbstractSelfTest.java |    4 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |    4 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |    6 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |    7 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |   14 +-
 .../processors/cache/IgniteTxAbstractTest.java  |    2 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |    3 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    2 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    6 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |    6 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |    2 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |   27 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    9 +-
 .../GridCacheCountDownLatchSelfTest.java        |   10 +-
 .../GridCacheQueueCleanupSelfTest.java          |    5 +-
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   11 +-
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |   17 +-
 .../GridCacheSetAbstractSelfTest.java           |   15 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |    6 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |    6 +-
 ...dCachePartitionedQueueEntryMoveSelfTest.java |    6 +-
 .../GridCacheAbstractJobExecutionTest.java      |    8 +-
 .../GridCacheAtomicTimeoutSelfTest.java         |   11 +-
 .../GridCacheBasicOpAbstractTest.java           |    7 +-
 .../distributed/GridCacheEventAbstractTest.java |    2 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |    2 +-
 .../distributed/GridCacheLockAbstractTest.java  |   68 +-
 .../GridCacheMultiNodeAbstractTest.java         |   15 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |  141 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    4 +-
 .../GridCacheNodeFailureAbstractTest.java       |    6 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  288 +
 ...iteTxConsistencyRestartAbstractSelfTest.java |    4 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |   10 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |   24 +-
 .../IgniteTxPreloadAbstractTest.java            |    4 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   11 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |    2 +-
 .../dht/GridCacheColocatedDebugTest.java        |   54 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |    2 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   10 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |   12 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |    2 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |    2 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |    6 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |    5 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |    5 +-
 .../dht/GridCacheGlobalLoadTest.java            |    2 +-
 ...ePartitionedNearDisabledMetricsSelfTest.java |   14 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |   60 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |    8 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    6 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |    4 +-
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 ...AtomicPartitionedTckMetricsSelfTestImpl.java |  183 +
 .../near/GridCacheNearMetricsSelfTest.java      |  163 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |   67 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |   42 +-
 .../near/GridCacheNearReadersSelfTest.java      |   17 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |    2 +-
 .../near/GridCachePartitionedBasicApiTest.java  |    4 +-
 .../GridCachePartitionedEntryLockSelfTest.java  |    7 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    6 +-
 .../GridCachePartitionedFullApiSelfTest.java    |    4 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |    2 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |    2 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |    7 +-
 .../GridCachePartitionedProjectionSelfTest.java |    4 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |    6 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    5 +-
 .../GridCacheReplicatedBasicApiTest.java        |    4 +-
 .../GridCacheReplicatedEvictionSelfTest.java    |    5 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |    5 +-
 ...heConcurrentEvictionConsistencySelfTest.java |    4 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |    4 +-
 .../GridCacheEvictionLockUnlockSelfTest.java    |    7 +-
 .../cache/eviction/GridCacheMockEntry.java      |   27 +-
 ...cheSynchronousEvictionsFailoverSelfTest.java |    4 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    2 +-
 .../IgniteCacheTxStoreSessionTest.java          |   11 +-
 ...dCacheAtomicLocalTckMetricsSelfTestImpl.java |  161 +
 .../local/GridCacheLocalBasicApiSelfTest.java   |    4 +-
 .../cache/local/GridCacheLocalLockSelfTest.java |   81 +-
 .../GridCacheLocalMultithreadedSelfTest.java    |   85 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    4 +-
 .../clock/GridTimeSyncProcessorSelfTest.java    |    6 +-
 .../closure/GridClosureProcessorSelfTest.java   |   43 +-
 .../continuous/GridEventConsumeSelfTest.java    |   18 +-
 .../continuous/GridMessageListenSelfTest.java   |    4 +-
 .../GridDataLoaderProcessorSelfTest.java        |   23 +-
 .../processors/fs/GridGgfsAbstractSelfTest.java |    6 +-
 .../fs/GridGgfsDataManagerSelfTest.java         |    9 +-
 .../processors/fs/GridGgfsModesSelfTest.java    |    4 +-
 .../fs/GridGgfsProcessorSelfTest.java           |    2 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    6 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    4 +-
 .../processors/fs/GridGgfsSizeSelfTest.java     |    8 +-
 .../processors/fs/GridGgfsTaskSelfTest.java     |    7 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |   13 +-
 .../GridServiceProcessorAbstractSelfTest.java   |   38 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |   14 +-
 .../GridServiceReassignmentSelfTest.java        |    2 +-
 .../streamer/GridStreamerFailoverSelfTest.java  |    4 +-
 .../streamer/GridStreamerSelfTest.java          |    2 +-
 .../timeout/GridTimeoutProcessorSelfTest.java   |    5 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  717 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 .../util/future/GridCompoundFutureSelfTest.java |    8 +-
 .../util/future/GridEmbeddedFutureSelfTest.java |    7 +-
 .../util/future/GridFinishedFutureSelfTest.java |    9 +-
 .../util/future/GridFutureAdapterSelfTest.java  |   23 +-
 .../future/GridFutureListenPerformanceTest.java |    5 +-
 ...idIpcServerEndpointDeserializerSelfTest.java |  160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |  160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |   76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |   71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |   76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |   71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |  500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |   36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |  259 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |   84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |  500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |   36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |   78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |  267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |   84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |   65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |   35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |  133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |  125 -
 .../IpcSharedMemoryBenchmarkParty.java          |   35 +
 .../IpcSharedMemoryBenchmarkReader.java         |  133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |  125 +
 .../internal/util/nio/GridNioSelfTest.java      |    8 +-
 .../offheap/GridOffHeapMapAbstractSelfTest.java |    7 +-
 ...idOffHeapPartitionedMapAbstractSelfTest.java |    3 +-
 ...apPartitionedMapPerformanceAbstractTest.java |   10 +-
 .../unsafe/GridUnsafeMemorySelfTest.java        |    6 +-
 .../ignite/jvmtest/ConcurrentMapTest.java       |    4 +-
 .../ignite/jvmtest/NetworkFailureTest.java      |   16 +-
 .../QueueSizeCounterMultiThreadedTest.java      |    4 +-
 .../jvmtest/ReadWriteLockMultiThreadedTest.java |   10 +-
 .../ignite/lang/GridBasicPerformanceTest.java   |    5 +-
 .../apache/ignite/lang/GridFuncSelfTest.java    |   13 +-
 .../lang/GridFutureListenPerformanceTest.java   |    5 +-
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../loadtest/GridSingleExecutionTest.java       |    2 +-
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |    6 +-
 .../cache/GridCacheAbstractLoadTest.java        |    6 +-
 .../cache/GridCachePutRemoveLoadTest.java       |    2 +-
 .../loadtests/cache/GridCacheSwapLoadTest.java  |   13 +-
 .../GridCacheWriteBehindStoreLoadTest.java      |    4 +-
 .../loadtests/colocation/GridTestMain.java      |   12 +-
 .../communication/GridIoManagerBenchmark.java   |   10 +-
 .../communication/GridIoManagerBenchmark0.java  |   22 +-
 .../GridContinuousOperationsLoadTest.java       |    4 +-
 .../multisplit/GridMultiSplitsLoadTest.java     |    2 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |    2 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |    2 +-
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |    2 +-
 .../loadtests/hashmap/GridCacheTestContext.java |    1 +
 .../loadtests/hashmap/GridHashMapLoadTest.java  |    1 +
 ...GridJobExecutionLoadTestClientSemaphore.java |    7 +-
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |    9 +-
 .../loadtests/job/GridJobLoadTestSubmitter.java |    2 +-
 .../mergesort/GridMergeSortLoadTask.java        |    8 +-
 ...apPartitionedMapPerformanceAbstractTest.java |   10 +-
 .../streamer/GridStreamerIndexLoadTest.java     |    8 +-
 .../marshaller/GridMarshallerAbstractTest.java  |   20 +-
 .../ignite/messaging/GridMessagingSelfTest.java |   10 +-
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java |    2 +-
 .../GridP2PContinuousDeploymentSelfTest.java    |    4 +-
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |   10 +-
 .../GridP2PMissedResourceCacheSizeSelfTest.java |    8 +-
 .../ignite/p2p/GridP2PTimeoutSelfTest.java      |    8 +-
 .../ignite/p2p/GridP2PUndeploySelfTest.java     |    2 +-
 ...idSessionFutureWaitJobAttributeSelfTest.java |    2 +-
 ...GridSessionSetJobAttributeOrderSelfTest.java |    2 +-
 ...sionSetJobAttributeWaitListenerSelfTest.java |    2 +-
 .../GridSessionSetTaskAttributeSelfTest.java    |    2 +-
 ...GridSessionTaskWaitJobAttributeSelfTest.java |    2 +-
 .../GridSessionWaitAttributeSelfTest.java       |    2 +-
 ...redFsCheckpointSpiMultiThreadedSelfTest.java |    8 +-
 .../collision/GridTestCollisionTaskSession.java |    3 +-
 ...bStealingCollisionSpiAttributesSelfTest.java |    4 +-
 ...alingCollisionSpiCustomTopologySelfTest.java |    4 +-
 .../GridJobStealingCollisionSpiSelfTest.java    |    4 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |   21 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |    3 +-
 .../tcp/GridTcpCommunicationSpiLanTest.java     |    3 +-
 ...cpCommunicationSpiMultithreadedSelfTest.java |    9 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |    7 +-
 ...ClusterMetricsSnapshotSerializeSelfTest.java |  170 +
 .../GridDiscoveryMetricsHelperSelfTest.java     |  149 -
 .../tcp/GridTcpDiscoveryMultiThreadedTest.java  |    7 +-
 .../discovery/tcp/GridTcpDiscoverySelfTest.java |   14 +-
 .../file/GridFileSwapSpaceSpiSelfTest.java      |    7 +-
 .../GridCacheStoreValueBytesTest.java           |    7 +-
 .../index/GridStreamerIndexSelfTest.java        |    8 +-
 .../window/GridStreamerWindowSelfTest.java      |    4 +-
 .../testframework/GridSpiTestContext.java       |    6 +-
 .../ignite/testframework/GridTestNode.java      |    8 +-
 .../ignite/testframework/GridTestUtils.java     |   12 +-
 .../testframework/junits/GridAbstractTest.java  |   22 +-
 .../testframework/junits/GridTestIgnite.java    |    6 +
 .../junits/GridTestKernalContext.java           |    2 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |    5 +-
 .../junits/common/GridCommonAbstractTest.java   |   34 +-
 .../junits/spi/GridSpiAbstractTest.java         |    2 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    2 +-
 .../IgniteCacheMetricsSelfTestSuite.java        |    4 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    2 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    6 +-
 .../ignite/testsuites/IgniteFsTestSuite.java    |    2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    4 +-
 ...dConcurrentLinkedDequeMultiThreadedTest.java |    6 +-
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |   10 +-
 .../apache/ignite/util/GridIndexFillTest.java   |    4 +-
 .../ignite/util/GridSnapshotLockSelfTest.java   |    6 +-
 .../util/GridSpinReadWriteLockSelfTest.java     |    4 +-
 .../util/GridTopologyHeapSizeSelfTest.java      |    4 +-
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   49 +-
 modules/core/src/test/resources/readme.txt      |    2 +-
 modules/email/readme.txt                        |   12 +-
 .../processors/email/IgniteEmailProcessor.java  |    5 +-
 modules/hadoop/readme.txt                       |   12 +-
 .../GridHadoopClientProtocolProvider.java       |    8 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   10 +-
 .../hadoop/GridHadoopClassLoader.java           |    4 +-
 .../processors/hadoop/GridHadoopImpl.java       |    6 +-
 .../hadoop/IgniteHadoopProcessor.java           |    5 +-
 .../hadoop/jobtracker/GridHadoopJobTracker.java |   19 +-
 .../GridHadoopDefaultMapReducePlanner.java      |    2 +-
 .../proto/GridHadoopProtocolJobStatusTask.java  |    7 +-
 .../hadoop/shuffle/GridHadoopShuffle.java       |    2 +-
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |    7 +-
 .../GridHadoopExternalTaskExecutor.java         |   16 +-
 .../child/GridHadoopChildProcessRunner.java     |   18 +-
 .../GridHadoopExternalCommunication.java        |   26 +-
 .../GridHadoopIpcToNioAdapter.java              |    6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |    4 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |    4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |    4 +-
 .../hadoop/GridHadoopPopularWordsTest.java      |    4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   16 +-
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |    5 +-
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |    4 +-
 .../hadoop/GridHadoopMapReduceTest.java         |    4 +-
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   12 +-
 .../GridHadoopExecutorServiceTest.java          |    4 +-
 ...GridHadoopExternalTaskExecutionSelfTest.java |    6 +-
 .../ggfs/GridGgfsPerformanceBenchmark.java      |    4 +-
 modules/hibernate/readme.txt                    |   14 +-
 .../hibernate/GridHibernateRegionFactory.java   |   10 +-
 modules/indexing/readme.txt                     |   12 +-
 .../processors/query/h2/IgniteH2Indexing.java   |    4 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |    2 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    6 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    8 +-
 .../cache/GridCacheQueryLoadSelfTest.java       |    2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |   24 +-
 ...idCacheReduceQueryMultithreadedSelfTest.java |    6 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |    5 +-
 .../near/GridCacheQueryNodeRestartSelfTest.java |    5 +-
 .../GridCacheReplicatedFieldsQuerySelfTest.java |    2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    6 +-
 .../query/h2/GridH2IndexRebuildTest.java        |    7 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |    6 +-
 .../query/h2/sql/GridQueryParsingTest.java      |    2 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    4 +-
 modules/jcl/readme.txt                          |   12 +-
 modules/jta/readme.txt                          |   12 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |    2 +-
 modules/log4j/readme.txt                        |   12 +-
 modules/rest-http/readme.txt                    |   12 +-
 modules/scalar/readme.txt                       |    8 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |   33 +-
 modules/schedule/readme.txt                     |   12 +-
 .../processors/schedule/ScheduleFutureImpl.java |   22 +-
 .../schedule/GridScheduleSelfTest.java          |   13 +-
 modules/slf4j/readme.txt                        |   12 +-
 modules/spring/readme.txt                       |   12 +-
 .../java/org/apache/ignite/IgniteSpring.java    |    8 +-
 .../org/apache/ignite/IgniteSpringBean.java     |    6 +
 .../cache/spring/SpringDynamicCacheManager.java |    2 +-
 modules/ssh/readme.txt                          |   12 +-
 .../GridProjectionStartStopRestartSelfTest.java |    2 +-
 modules/urideploy/readme.txt                    |   12 +-
 .../uri/GridUriDeploymentSpiMBean.java          |    8 +-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |    2 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    7 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |   15 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   30 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |   25 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |    2 +-
 modules/web/readme.txt                          |   16 +-
 .../GridServletContextListenerStartup.java      |    4 +-
 .../startup/servlet/GridServletStartup.java     |    4 +-
 .../internal/websession/WebSessionSelfTest.java |    4 +-
 pom.xml                                         |    4 +-
 937 files changed, 39037 insertions(+), 35301 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePreloaderAdapter.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheSwapManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/258ee1c0/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerImpl.java
----------------------------------------------------------------------


[27/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' into ignite-113

Posted by vo...@apache.org.
Merge branch 'sprint-1' into ignite-113


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

Branch: refs/heads/ignite-16
Commit: 9e748990ace4c836a8ea834af7ad999f1a53f060
Parents: b5631df c98118f
Author: Artem SHutak <as...@gridgain.com>
Authored: Fri Jan 30 13:37:16 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Fri Jan 30 13:37:16 2015 +0300

----------------------------------------------------------------------
 assembly/release-hadoop.xml                     |    6 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../processors/cache/GridCacheAdapter.java      |   16 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../cache/GridCacheMvccCandidate.java           |    4 +-
 .../processors/cache/GridCacheStoreManager.java |   25 +-
 .../processors/cache/IgniteCacheProxy.java      |   24 +-
 .../transactions/IgniteTxLocalAdapter.java      |   42 +-
 .../service/GridServiceProcessor.java           |    2 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9141 ------------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   27 +-
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../IgniteExceptionHelpLinksSelfTest.java       |    3 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   10 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   50 +
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  288 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 .../IgniteCacheTxStoreSessionTest.java          |   11 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    4 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  728 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |    2 +-
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../ignite/messaging/GridMessagingSelfTest.java |    2 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    1 +
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../hadoop/GridHadoopClassLoader.java           |    4 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    2 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   21 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |   25 +-
 54 files changed, 10396 insertions(+), 10026 deletions(-)
----------------------------------------------------------------------



[25/50] [abbrv] incubator-ignite git commit: # sprint-1: removed unused import.

Posted by vo...@apache.org.
# sprint-1: removed unused import.


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

Branch: refs/heads/ignite-16
Commit: 2ec1cb2be1ea27a10d524da984bddf306c4de862
Parents: 9550905
Author: AKuznetsov <ak...@gridgain.com>
Authored: Fri Jan 30 17:35:28 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Fri Jan 30 17:35:28 2015 +0700

----------------------------------------------------------------------
 .../src/main/scala/org/apache/ignite/visor/visor.scala              | 1 -
 1 file changed, 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2ec1cb2b/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
index 764a347..fef1aff 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
@@ -42,7 +42,6 @@ import org.apache.ignite.lang.{IgniteNotPeerDeployable, IgnitePredicate}
 import org.apache.ignite.lifecycle.IgniteListener
 import org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
 import org.apache.ignite.thread.IgniteThreadPoolExecutor
-import org.apache.ignite.visor.VisorTag
 import org.apache.ignite.visor.commands.{VisorConsoleCommand, VisorTextTable}
 import org.apache.ignite.{IgniteState, IgniteSystemProperties, Ignition, _}
 import org.jetbrains.annotations.Nullable


[05/50] [abbrv] incubator-ignite git commit: # sprint-1 Fixed typo after auto renaming.

Posted by vo...@apache.org.
# sprint-1 Fixed typo after auto renaming.


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

Branch: refs/heads/ignite-16
Commit: 14ad3ea5c988ab0a034fbfb389b9274f9631fd69
Parents: 7eebc7e
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 22:30:51 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 22:30:51 2015 +0700

----------------------------------------------------------------------
 .../org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/14ad3ea5/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
index 1899ca4..837b424 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
@@ -278,7 +278,7 @@ class VisorAlertCommand {
                             // Grid-wide metrics (not node specific).
                             case "cc" if v != null => gf = makeGridFilter(v, gf, grid.metrics().getTotalCpus)
                             case "nc" if v != null => gf = makeGridFilter(v, gf, grid.nodes().size)
-                            case "hc" if v != null => gf = makeGridFilter(v, gf, IgniteUtils.neighborhood(grid.nodes()).size)
+                            case "hc" if v != null => gf = makeGridFilter(v, gf, U.neighborhood(grid.nodes()).size)
                             case "cl" if v != null => gf = makeGridFilter(v, gf,
                                 () => (grid.metrics().getAverageCpuLoad * 100).toLong)
 


[06/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

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


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

Branch: refs/heads/ignite-16
Commit: 580c36e66625ad203dfa18e830649c64e3e531f0
Parents: 14ad3ea f30d79d
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 22:31:25 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 22:31:25 2015 +0700

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      | 16 ++-----
 .../processors/cache/IgniteCacheProxy.java      |  2 +-
 .../GridCacheAbstractProjectionSelfTest.java    | 50 ++++++++++++++++++++
 .../commands/alert/VisorAlertCommand.scala      |  2 +-
 4 files changed, 55 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/580c36e6/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
----------------------------------------------------------------------


[48/50] [abbrv] incubator-ignite git commit: #gg-9757: Removed "GridInteropAware".

Posted by vo...@apache.org.
#gg-9757: Removed "GridInteropAware".


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

Branch: refs/heads/ignite-16
Commit: 61a70d9fdbed60103d19a955b37eb6345d78daa5
Parents: 88514f7
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Mon Feb 2 13:18:25 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Mon Feb 2 13:18:25 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheStoreManager.java | 25 ++++++++--
 .../cache/GridCacheWriteBehindStore.java        | 19 +-------
 .../processors/interop/GridInteropAware.java    | 49 --------------------
 3 files changed, 21 insertions(+), 72 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/61a70d9f/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 d89a670..f83c476 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
@@ -27,7 +27,6 @@ import org.apache.ignite.internal.util.tostring.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.transactions.*;
-import org.apache.ignite.internal.processors.interop.*;
 import org.apache.ignite.internal.util.lang.*;
 import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
@@ -180,16 +179,27 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
         boolean convertPortable = !cctx.config().isKeepPortableInStore();
 
         if (cctx.config().isPortableEnabled()) {
-            if (store instanceof GridInteropAware)
-                ((GridInteropAware)store).configure(cctx.cache().name(), convertPortable);
-            else
-                this.convertPortable = convertPortable;
+            this.convertPortable = convertPortable;
         }
         else if (convertPortable)
             U.warn(log, "GridCacheConfiguration.isKeepPortableInStore() configuration property will " +
                 "be ignored because portable mode is not enabled for cache: " + cctx.namex());
     }
 
+    /**
+     * @return Convert-portable flag.
+     */
+    public boolean convertPortable() {
+        return convertPortable;
+    }
+
+    /**
+     * @param convertPortable Convert-portable flag.
+     */
+    public void convertPortable(boolean convertPortable) {
+        this.convertPortable = convertPortable;
+    }
+
     /** {@inheritDoc} */
     @Override protected void stop0(boolean cancel) {
         if (store instanceof LifecycleAware) {
@@ -246,6 +256,7 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
      * @return Loaded value, possibly <tt>null</tt>.
      * @throws IgniteCheckedException If data loading failed.
      */
+    @SuppressWarnings("unchecked")
     @Nullable private Object loadFromStore(@Nullable IgniteTx tx,
         K key,
         boolean convert)
@@ -300,6 +311,7 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
      * @param val Internal value.
      * @return User value.
      */
+    @SuppressWarnings("unchecked")
     private V convert(Object val) {
         if (val == null)
             return null;
@@ -406,6 +418,7 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
 
             try {
                 CI2<K, Object> c = new CI2<K, Object>() {
+                    @SuppressWarnings("ConstantConditions")
                     @Override public void apply(K k, Object val) {
                         if (convert) {
                             V v = convert(val);
@@ -518,6 +531,7 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
      * @return {@code true} If there is a persistent storage.
      * @throws IgniteCheckedException If storage failed.
      */
+    @SuppressWarnings("unchecked")
     public boolean putToStore(@Nullable IgniteTx tx, K key, V val, GridCacheVersion ver)
         throws IgniteCheckedException {
         if (store != null) {
@@ -628,6 +642,7 @@ public class GridCacheStoreManager<K, V> extends GridCacheManagerAdapter<K, V> {
      * @return {@code True} if there is a persistent storage.
      * @throws IgniteCheckedException If storage failed.
      */
+    @SuppressWarnings("unchecked")
     public boolean removeFromStore(@Nullable IgniteTx tx, K key) throws IgniteCheckedException {
         if (store != null) {
             // Never remove internal key from store as it is never persisted.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/61a70d9f/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
index a31d3b5..39d7439 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
@@ -56,7 +56,7 @@ import static javax.cache.Cache.Entry;
  * Since write operations to the cache store are deferred, transaction support is lost; no
  * transaction objects are passed to the underlying store.
  */
-public class GridCacheWriteBehindStore<K, V> extends CacheStore<K, V> implements LifecycleAware, GridInteropAware {
+public class GridCacheWriteBehindStore<K, V> extends CacheStore<K, V> implements LifecycleAware {
     /** Default write cache initial capacity. */
     public static final int DFLT_INITIAL_CAPACITY = 1024;
 
@@ -289,23 +289,6 @@ public class GridCacheWriteBehindStore<K, V> extends CacheStore<K, V> implements
         }
     }
 
-    /** {@inheritDoc} */
-    @Override public void configure(Object... params) {
-        // No-op.
-    }
-
-    /** {@inheritDoc} */
-    @Override public void initialize(GridKernalContext ctx) throws IgniteCheckedException {
-        if (store instanceof GridInteropAware)
-            ((GridInteropAware)store).initialize(ctx);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void destroy(GridKernalContext ctx) throws IgniteCheckedException {
-        if (store instanceof GridInteropAware)
-            ((GridInteropAware)store).destroy(ctx);
-    }
-
     /**
      * Gets count of write buffer overflow events since initialization. Each overflow event causes
      * the ongoing flush operation to be performed synchronously.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/61a70d9f/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropAware.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropAware.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropAware.java
deleted file mode 100644
index 81035d8..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropAware.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.internal.processors.interop;
-
-import org.apache.ignite.*;
-import org.apache.ignite.internal.*;
-
-/**
- * Interface for interop-aware components.
- */
-public interface GridInteropAware {
-    /**
-     * Sets configuration parameters.
-     *
-     * @param params Configuration parameters.
-     */
-    public void configure(Object... params);
-
-    /**
-     * Initializes interop-aware component.
-     *
-     * @param ctx Context.
-     * @throws IgniteCheckedException In case of error.
-     */
-    public void initialize(GridKernalContext ctx) throws IgniteCheckedException;
-
-    /**
-     * Destroys interop-aware component.
-     *
-     * @param ctx Context.
-     * @throws IgniteCheckedException In case of error.
-     */
-    public void destroy(GridKernalContext ctx) throws IgniteCheckedException;
-}


[16/50] [abbrv] incubator-ignite git commit: #Test: Fix hadoop

Posted by vo...@apache.org.
#Test: Fix hadoop


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

Branch: refs/heads/ignite-16
Commit: b6eb388670f0954cfca76a17e134486b4465b015
Parents: 9550905
Author: sboikov <sb...@gridgain.com>
Authored: Fri Jan 30 11:35:56 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Fri Jan 30 11:35:56 2015 +0300

----------------------------------------------------------------------
 .../ignite/internal/processors/hadoop/GridHadoopClassLoader.java | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b6eb3886/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/GridHadoopClassLoader.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/GridHadoopClassLoader.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/GridHadoopClassLoader.java
index 809d77f..1aa01b5 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/GridHadoopClassLoader.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/GridHadoopClassLoader.java
@@ -74,10 +74,10 @@ public class GridHadoopClassLoader extends URLClassLoader {
      * @return {@code true} if we need to check this class.
      */
     private static boolean isGgfsOrGgHadoop(String cls) {
-        String gg = "org.apache.";
+        String gg = "org.apache.ignite";
         int len = gg.length();
 
-        return cls.startsWith(gg) && (cls.indexOf("ggfs.", len) != -1 || cls.indexOf("hadoop.", len) != -1);
+        return cls.startsWith(gg) && (cls.indexOf("ggfs.", len) != -1 || cls.indexOf(".fs.", len) != -1 || cls.indexOf("hadoop.", len) != -1);
     }
 
     /**


[32/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-71

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-71


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

Branch: refs/heads/ignite-16
Commit: 8df3ac4ea6b75407b802448d04211a1995fac74e
Parents: 9b6f75e ff01e66
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 15:10:45 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 15:10:45 2015 +0300

----------------------------------------------------------------------
 .../util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java    | 2 +-
 .../org/apache/ignite/messaging/GridMessagingSelfTest.java     | 2 +-
 .../internal/processors/hadoop/GridHadoopClassLoader.java      | 4 ++--
 .../marshaller/optimized/OptimizedClassNamesGenerator.java     | 6 +++---
 .../src/main/scala/org/apache/ignite/visor/visor.scala         | 1 -
 5 files changed, 7 insertions(+), 8 deletions(-)
----------------------------------------------------------------------



[30/50] [abbrv] incubator-ignite git commit: Ignite-71 GridLog4jCorrectFileNameTest fix

Posted by vo...@apache.org.
Ignite-71 GridLog4jCorrectFileNameTest 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/9b6f75e2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/9b6f75e2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/9b6f75e2

Branch: refs/heads/ignite-16
Commit: 9b6f75e27be952f9e703824feb65183e0e6b2aa9
Parents: 2690391
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 14:38:47 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 14:38:47 2015 +0300

----------------------------------------------------------------------
 .../apache/ignite/logger/log4j/GridLog4jCorrectFileNameTest.java   | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9b6f75e2/modules/log4j/src/test/java/org/apache/ignite/logger/log4j/GridLog4jCorrectFileNameTest.java
----------------------------------------------------------------------
diff --git a/modules/log4j/src/test/java/org/apache/ignite/logger/log4j/GridLog4jCorrectFileNameTest.java b/modules/log4j/src/test/java/org/apache/ignite/logger/log4j/GridLog4jCorrectFileNameTest.java
index dc9cd37..0f76f25 100644
--- a/modules/log4j/src/test/java/org/apache/ignite/logger/log4j/GridLog4jCorrectFileNameTest.java
+++ b/modules/log4j/src/test/java/org/apache/ignite/logger/log4j/GridLog4jCorrectFileNameTest.java
@@ -81,7 +81,7 @@ public class GridLog4jCorrectFileNameTest extends TestCase {
     private void checkOneNode(int id) throws Exception {
         try (Ignite ignite = G.start(getConfiguration("grid" + id))) {
             String id8 = U.id8(ignite.cluster().localNode().id());
-            String logPath = "work/log/gridgain-" + id8 + ".log";
+            String logPath = "work/log/ignite-" + id8 + ".log";
             File logFile = U.resolveGridGainPath(logPath);
 
             assertNotNull("Failed to resolve path: " + logPath, logFile);


[34/50] [abbrv] incubator-ignite git commit: #Tests: Fix GridCachePutAllFailoverSelfTest.

Posted by vo...@apache.org.
#Tests: Fix GridCachePutAllFailoverSelfTest.


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

Branch: refs/heads/ignite-16
Commit: 57f55f6dfba2a6661f46ca5184131e6689c20dd1
Parents: ff01e66
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 30 15:39:25 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 30 15:39:25 2015 +0300

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


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/57f55f6d/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
index 80f62d3..86c2c05 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCachePutAllFailoverSelfTest.java
@@ -51,7 +51,7 @@ public class GridCachePutAllFailoverSelfTest extends GridCommonAbstractTest {
     private static TcpDiscoveryIpFinder ipFinder = new TcpDiscoveryVmIpFinder(true);
 
     /** Size of the test map. */
-    private static final int TEST_MAP_SIZE = 100000;
+    private static final int TEST_MAP_SIZE = 30000;
 
     /** Cache name. */
     private static final String CACHE_NAME = "partitioned";
@@ -327,7 +327,7 @@ public class GridCachePutAllFailoverSelfTest extends GridCommonAbstractTest {
 
             if (!failedWait && !absentKeys.isEmpty()) {
                 // Give some time to preloader.
-                U.sleep(15000);
+                U.sleep(20000);
 
                 absentKeys = findAbsentKeys(runningWorkers.get(0), testKeys);
             }


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

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-67' into sprint-1

Conflicts:
	config/ignite-log4j.xml
	config/java.util.logging.properties
	modules/core/src/test/config/log4j-test.xml
	modules/log4j/src/main/java/org/apache/ignite/logger/log4j/IgniteLog4jNodeIdFilePath.java


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

Branch: refs/heads/ignite-16
Commit: 115f59799edf7038475002553891700d77c0ce03
Parents: f64485b ac05bb9
Author: Anton Vinogradov <av...@gridgain.com>
Authored: Fri Jan 30 22:01:50 2015 +0300
Committer: Anton Vinogradov <av...@gridgain.com>
Committed: Fri Jan 30 22:01:50 2015 +0300

----------------------------------------------------------------------
 bin/ggrouter.sh                                 |  10 +-
 bin/ggstart.bat                                 |  42 ++--
 bin/ggstart.sh                                  |  36 ++--
 bin/ggvisorcmd.bat                              |  36 ++--
 bin/ggvisorcmd.sh                               |  22 +--
 bin/include/functions.sh                        |  42 ++--
 bin/include/hadoop-classpath.bat                |   2 +-
 bin/include/hadoop-classpath.sh                 |   4 +-
 bin/include/parseargs.bat                       |   2 +-
 bin/include/parseargs.sh                        |   6 +-
 bin/include/service.sh                          |  12 +-
 bin/include/setenv.bat                          |  28 +--
 bin/include/setenv.sh                           |  34 ++--
 bin/include/target-classpath.bat                |   8 +-
 bin/include/target-classpath.sh                 |  14 +-
 bin/setup-hadoop.sh                             |  10 +-
 config/hadoop/default-config.xml                |   2 +-
 config/ignite-log4j.xml                         |   4 +-
 config/java.util.logging.properties             |   2 +-
 config/router/default-router.xml                |   2 +-
 docs/mapred-site.ignite.xml                     |   2 +-
 examples/config/example-cache.xml               |   2 +-
 examples/config/example-streamer.xml            |   8 +-
 examples/config/filesystem/example-ggfs.xml     |   2 +-
 examples/config/servlet/WEB-INF/web.xml         |   2 +-
 examples/rest/http-rest-example.php             |   2 +-
 examples/rest/memcache-rest-example.php         |   2 +-
 .../hibernate/HibernateL2CacheExample.java      |   2 +-
 .../streaming/StreamingCheckInExample.java      |   6 +-
 .../StreamingPopularNumbersExample.java         |   6 +-
 .../streaming/StreamingPriceBarsExample.java    |   6 +-
 .../StreamingRunningAverageExample.java         |   6 +-
 .../scalar/examples/ScalarPrimeExample.scala    |   2 +-
 .../GridMonteCarloExamplesSelfTest.java         |   4 +-
 .../testsuites/IgniteExamplesSelfTestSuite.java |   2 +-
 .../ScalarExamplesSelfTestSuite.scala           |   2 +-
 .../GridifySetToXXXNonSpringAopSelfTest.java    |  20 +-
 .../GridifySetToXXXSpringAopSelfTest.java       |  20 +-
 .../ignite/gridify/NonSpringAopSelfTest.java    |  20 +-
 .../optimized/OptimizedMarshallerAopTest.java   |   4 +-
 .../testsuites/IgniteAopSelfTestSuite.java      |   2 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |  20 +-
 modules/clients/src/test/bin/start-nodes-ssh.sh |   2 +-
 modules/clients/src/test/bin/start-nodes.cmd    |  24 +--
 modules/clients/src/test/bin/start-nodes.sh     |  26 +--
 .../client/ClientDefaultCacheSelfTest.java      |   4 +-
 .../client/ClientTopologyCacheSelfTest.java     |   2 +-
 .../integration/ClientAbstractSelfTest.java     |   4 +-
 .../client/router/ClientFailedInitSelfTest.java |   4 +-
 .../client/router/RouterFactorySelfTest.java    |   4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |   4 +-
 .../rest/TaskCommandHandlerSelfTest.java        |   4 +-
 .../protocols/tcp/TcpRestParserSelfTest.java    |   6 +-
 .../src/test/resources/jetty/rest-jetty-ssl.xml |  10 +-
 .../src/test/resources/jetty/rest-jetty.xml     |   8 +-
 .../test/resources/jetty/router-jetty-ssl.xml   |   8 +-
 .../src/test/resources/jetty/router-jetty.xml   |   8 +-
 modules/clients/src/test/resources/log4j.xml    |   4 +-
 .../clients/src/test/resources/spring-cache.xml |   2 +-
 .../src/test/resources/spring-router-ssl.xml    |   4 +-
 .../src/test/resources/spring-router.xml        |   4 +-
 .../src/test/resources/spring-server-node.xml   |   2 +-
 .../test/resources/spring-server-ssl-node.xml   |   2 +-
 .../apache/ignite/IgniteBasicWarmupClosure.java |   6 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   2 +-
 .../java/org/apache/ignite/IgniteLogger.java    |   4 +-
 .../apache/ignite/IgniteSystemProperties.java   | 190 +++++++++----------
 .../main/java/org/apache/ignite/Ignition.java   |   6 +-
 .../apache/ignite/cache/CacheConfiguration.java |   3 +-
 .../CacheConsistentHashAffinityFunction.java    |   2 +-
 .../apache/ignite/client/GridClientCompute.java |   8 +-
 .../ignite/client/router/GridRouterFactory.java |   4 +-
 .../impl/GridRouterCommandLineStartup.java      |   2 +-
 .../router/impl/GridTcpRouterNioParser.java     |   4 +-
 .../apache/ignite/compute/gridify/Gridify.java  |   2 +-
 .../ignite/compute/gridify/GridifySetToSet.java |   2 +-
 .../compute/gridify/GridifySetToValue.java      |   2 +-
 .../ClientConnectionConfiguration.java          |  16 +-
 .../configuration/IgniteConfiguration.java      |  72 +++----
 .../configuration/IgniteDeploymentMode.java     |   4 +-
 .../apache/ignite/fs/IgniteFsConfiguration.java |   2 +-
 .../ignite/internal/GridKernalContextImpl.java  |   2 +-
 .../apache/ignite/internal/GridLoggerProxy.java |   4 +-
 .../internal/GridPerformanceSuggestions.java    |   4 +-
 .../ignite/internal/IgniteInternalFuture.java   |   8 +-
 .../apache/ignite/internal/IgniteKernal.java    |  20 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |  46 ++---
 .../processors/cache/GridCacheAdapter.java      |   2 +-
 .../GridCachePartitionExchangeManager.java      |   2 +-
 .../processors/cache/GridCacheProcessor.java    |   4 +-
 .../processors/cache/GridCacheUtils.java        |   2 +-
 .../distributed/dht/GridDhtLocalPartition.java  |   2 +-
 .../dht/GridPartitionedGetFuture.java           |   2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   4 +-
 .../distributed/near/GridNearAtomicCache.java   |   2 +-
 .../distributed/near/GridNearGetFuture.java     |   2 +-
 .../cache/transactions/IgniteTxManager.java     |  10 +-
 .../processors/fs/IgniteFsProcessor.java        |   8 +-
 .../processors/job/GridJobProcessor.java        |   2 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |   4 +-
 .../handlers/log/GridLogCommandHandler.java     |   2 +-
 .../handlers/task/GridTaskCommandHandler.java   |   2 +-
 .../protocols/tcp/GridClientPacketType.java     |   4 +-
 .../protocols/tcp/GridMemcachedMessage.java     |   4 +-
 .../rest/protocols/tcp/GridTcpRestParser.java   |  18 +-
 .../streamer/GridStreamProcessor.java           |   6 +-
 .../internal/util/GridConcurrentFactory.java    |   3 +-
 .../internal/util/GridConfigurationFinder.java  |   4 +-
 .../internal/util/GridReflectionCache.java      |   3 +-
 .../ignite/internal/util/IgniteUtils.java       |  50 ++---
 .../util/future/GridFinishedFuture.java         |   2 +-
 .../internal/util/future/GridFutureAdapter.java |   4 +-
 .../internal/util/io/GridUnsafeDataInput.java   |   2 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |   2 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   4 +-
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |   2 +-
 .../internal/util/nio/GridBufferedParser.java   |   2 +-
 .../nio/GridConnectionBytesVerifyFilter.java    |  18 +-
 .../util/nodestart/GridNodeStartUtils.java      |  10 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java   |   2 +-
 .../util/portscanner/GridJmxPortFinder.java     |   4 +-
 .../apache/ignite/internal/util/typedef/X.java  |   4 +-
 .../visor/node/VisorBasicConfiguration.java     |  26 +--
 .../visor/node/VisorEmailConfiguration.java     |  14 +-
 .../visor/node/VisorLifecycleConfiguration.java |   2 +-
 .../visor/node/VisorRestConfiguration.java      |   4 +-
 .../apache/ignite/jdbc/IgniteJdbcDriver.java    |   2 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |   4 +-
 .../ignite/logger/java/IgniteJavaLogger.java    |   4 +-
 .../java/IgniteJavaLoggerFileHandler.java       |   2 +-
 .../optimized/IgniteOptimizedMarshaller.java    |   2 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   4 +-
 .../ignite/spi/IgniteSpiManagementMBean.java    |   2 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |   6 +-
 .../communication/tcp/TcpCommunicationSpi.java  |  12 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   2 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |   2 +-
 .../TcpDiscoveryMulticastIpFinder.java          |  18 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |   2 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |   2 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |   4 +-
 .../ignite/startup/BasicWarmupClosure.java      |   6 +-
 .../startup/cmdline/CommandLineStartup.java     |  12 +-
 .../startup/cmdline/CommandLineTransformer.java |   2 +-
 .../spring-cache-client-benchmark-1.xml         |   2 +-
 .../spring-cache-client-benchmark-2.xml         |   2 +-
 .../spring-cache-client-benchmark-3.xml         |   2 +-
 modules/core/src/test/config/example-cache.xml  |   2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |   2 +-
 modules/core/src/test/config/log4j-test.xml     |   2 +-
 .../core/src/test/config/spring-cache-load.xml  |   2 +-
 .../core/src/test/config/spring-multicache.xml  |   2 +-
 .../average/spring-streamer-average-base.xml    |   2 +-
 .../average/spring-streamer-average-local.xml   |   2 +-
 .../average/spring-streamer-average-random.xml  |   2 +-
 .../config/streamer/spring-streamer-base.xml    |   2 +-
 modules/core/src/test/config/tests.properties   |  10 +-
 .../internal/GridFactoryVmShutdownTest.java     |   2 +-
 .../ignite/internal/GridHomePathSelfTest.java   |   2 +-
 .../GridNodeVisorAttributesSelfTest.java        |   4 +-
 .../ignite/internal/GridStartStopSelfTest.java  |   2 +-
 .../ignite/internal/GridVersionSelfTest.java    |   8 +-
 .../GridCacheAbstractRemoveFailureTest.java     |   6 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |   6 +-
 .../cache/GridCacheSlowTxWarnTest.java          |   2 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |   6 +-
 .../GridCacheNodeFailureAbstractTest.java       |   2 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |   6 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |   2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |   6 +-
 ...GridUnsafeDataOutputArraySizingSelfTest.java |   2 +-
 .../loadtest/GridSingleExecutionTest.java       |   4 +-
 .../cache/GridCacheAbstractLoadTest.java        |   2 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |   2 +-
 .../loadtests/cache/GridCacheLoadTest.java      |   2 +-
 .../capacity/spring-capacity-cache.xml          |   2 +-
 .../loadtests/colocation/spring-colocation.xml  |   2 +-
 .../GridContinuousOperationsLoadTest.java       |  18 +-
 .../streamer/GridStreamerIndexLoadTest.java     |   2 +-
 .../ignite/loadtests/util/GridLoadTestArgs.java |   8 +-
 .../startup/GridRandomCommandLineLoader.java    |   8 +-
 .../ignite/startup/GridVmNodesStarter.java      |   8 +-
 .../GridCommandLineTransformerSelfTest.java     |   6 +-
 .../ignite/testframework/GridTestUtils.java     |  10 +-
 .../config/GridTestProperties.java              |  16 +-
 .../testframework/junits/GridAbstractTest.java  |   2 +-
 .../logger/GridLog4jRollingFileAppender.java    |   2 +-
 .../junits/logger/GridTestLog4jLogger.java      |   6 +-
 .../core/src/test/webapp/META-INF/gg-config.xml |   2 +-
 .../fs/hadoop/v1/GridGgfsHadoopFileSystem.java  |   6 +-
 .../fs/hadoop/v2/GridGgfsHadoopFileSystem.java  |   6 +-
 .../apache/ignite/hadoop/GridHadoopSetup.java   |  16 +-
 .../GridHadoopExternalTaskExecutor.java         |   2 +-
 .../hadoop/GridHadoopPopularWordsTest.java      |   6 +-
 .../processors/query/h2/IgniteH2Indexing.java   |   2 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |   6 +-
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |   6 +-
 .../http/jetty/GridJettyRestProtocol.java       |  16 +-
 .../processors/schedule/ScheduleFutureImpl.java |   4 +-
 .../java/org/apache/ignite/IgniteSpring.java    |   2 +-
 .../ignite/cache/spring/SpringCacheManager.java |   2 +-
 .../spring/IgniteSpringProcessorImpl.java       |  10 +-
 .../ignite/internal/GridFactorySelfTest.java    |   2 +-
 .../util/nodestart/GridNodeCallableImpl.java    |  10 +-
 .../internal/GridNodeStartUtilsSelfTest.java    |   6 +-
 .../GridProjectionStartStopRestartSelfTest.java |   4 +-
 .../optimized/OptimizedClassNamesGenerator.java |  12 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |   8 +-
 .../file/GridFileDeploymentSelfTest.java        |   4 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |   2 +-
 .../ignite/visor/commands/deploy/Packet.scala   |   4 +-
 .../commands/deploy/VisorDeployCommand.scala    |  18 +-
 .../ignite/visor/commands/start/Packet.scala    |   2 +-
 .../commands/start/VisorStartCommand.scala      |   4 +-
 .../scala/org/apache/ignite/visor/visor.scala   |  14 +-
 .../testsuites/VisorConsoleSelfTestSuite.scala  |   2 +-
 .../cache/websession/GridWebSessionFilter.java  |  22 +--
 .../IgniteServletContextListenerStartup.java    |  18 +-
 .../startup/servlet/IgniteServletStartup.java   |   6 +-
 .../internal/websession/WebSessionSelfTest.java |   8 +-
 .../websession/WebSessionServerStart.java       |   2 +-
 pom.xml                                         |  10 +-
 223 files changed, 883 insertions(+), 896 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/config/ignite-log4j.xml
----------------------------------------------------------------------
diff --cc config/ignite-log4j.xml
index d8fefb7,0000000..3f171bf
mode 100644,000000..100644
--- a/config/ignite-log4j.xml
+++ b/config/ignite-log4j.xml
@@@ -1,152 -1,0 +1,152 @@@
 +<?xml version="1.0" encoding="UTF-8"?>
 +
 +<!--
 +  Licensed to the Apache Software Foundation (ASF) under one or more
 +  contributor license agreements.  See the NOTICE file distributed with
 +  this work for additional information regarding copyright ownership.
 +  The ASF licenses this file to You under the Apache License, Version 2.0
 +  (the "License"); you may not use this file except in compliance with
 +  the License.  You may obtain a copy of the License at
 +
 +       http://www.apache.org/licenses/LICENSE-2.0
 +
 +  Unless required by applicable law or agreed to in writing, software
 +  distributed under the License is distributed on an "AS IS" BASIS,
 +  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 +  See the License for the specific language governing permissions and
 +  limitations under the License.
 +  -->
 +
 +<!DOCTYPE log4j:configuration PUBLIC "-//APACHE//DTD LOG4J 1.2//EN"
 +    "http://logging.apache.org/log4j/1.2/apidocs/org/apache/log4j/xml/doc-files/log4j.dtd">
 +
 +<!--
 +    Default log4j configuration for GridGain.
 +-->
 +<log4j:configuration xmlns:log4j="http://jakarta.apache.org/log4j/" debug="false">
 +    <!--
 +        Logs System.out messages to console.
 +
 +        Note, this appender is disabled by default.
 +        To enable, uncomment the section below and also CONSOLE appender in the <root> element.
 +    -->
 +    <!--
 +    <appender name="CONSOLE" class="org.apache.log4j.ConsoleAppender">
 +        <param name="Target" value="System.out"/>
 +
 +        <param name="Threshold" value="DEBUG"/>
 +
 +        <layout class="org.apache.log4j.PatternLayout">
 +            <param name="ConversionPattern" value="[%d{ABSOLUTE}][%-5p][%t][%c{1}] %m%n"/>
 +        </layout>
 +
 +        <filter class="org.apache.log4j.varia.LevelRangeFilter">
 +            <param name="levelMin" value="DEBUG"/>
 +            <param name="levelMax" value="WARN"/>
 +        </filter>
 +    </appender>
 +    -->
 +
 +    <!--
 +        Logs all ERROR messages to console.
 +    -->
 +    <appender name="CONSOLE_ERR" class="org.apache.log4j.ConsoleAppender">
 +        <!-- Log to STDERR. -->
 +        <param name="Target" value="System.err"/>
 +
 +        <!-- Log from ERROR and higher (change to WARN if needed). -->
 +        <param name="Threshold" value="ERROR"/>
 +
 +        <!-- The default pattern: Date Priority [Category] Message\n -->
 +        <layout class="org.apache.log4j.PatternLayout">
 +            <param name="ConversionPattern" value="[%d{ABSOLUTE}][%-5p][%t][%c{1}] %m%n"/>
 +        </layout>
 +    </appender>
 +
 +    <!--
 +        Logs all output to specified file.
-         By default, the logging goes to GRIDGAIN_HOME/work/log folder
++        By default, the logging goes to IGNITE_HOME/work/log folder
 +    -->
 +    <appender name="FILE" class="org.gridgain.grid.logger.log4j.GridLog4jRollingFileAppender">
 +        <param name="Threshold" value="DEBUG"/>
-         <param name="File" value="${GRIDGAIN_HOME}/work/log/ignite.log"/>
++        <param name="File" value="${IGNITE_HOME}/work/log/ignite.log"/>
 +        <param name="Append" value="true"/>
 +        <param name="MaxFileSize" value="10MB"/>
 +        <param name="MaxBackupIndex" value="10"/>
 +        <layout class="org.apache.log4j.PatternLayout">
 +            <param name="ConversionPattern" value="[%d{ABSOLUTE}][%-5p][%t][%c{1}] %m%n"/>
 +        </layout>
 +    </appender>
 +
 +    <!--
 +    <category name="org.gridgain">
 +        <level value="DEBUG"/>
 +    </category>
 +    -->
 +
 +    <!--
 +        Uncomment this category to enable cache
 +        query execution tracing.
 +    -->
 +    <!--
 +    <category name="org.gridgain.cache.queries">
 +        <level value="DEBUG"/>
 +    </category>
 +    -->
 +
 +    <!--
 +        Uncomment to enable DGC tracing.
 +    -->
 +    <!--
 +    <category name="org.gridgain.grid.kernal.processors.cache.GridCacheDgcManager.trace">
 +        <level value="DEBUG"/>
 +    </category>
 +    -->
 +
 +    <!--
 +        Uncomment to disable courtesy notices, such as SPI configuration
 +        consistency warnings.
 +    -->
 +    <!--
 +    <category name="org.gridgain.grid.CourtesyConfigNotice">
 +        <level value="OFF"/>
 +    </category>
 +    -->
 +
 +    <category name="org.springframework">
 +        <level value="WARN"/>
 +    </category>
 +
 +    <category name="org.eclipse.jetty">
 +        <level value="WARN"/>
 +    </category>
 +
 +    <!--
 +        Avoid warnings about failed bind attempt when multiple nodes running on the same host.
 +    -->
 +    <category name="org.eclipse.jetty.util.log">
 +        <level value="ERROR"/>
 +    </category>
 +
 +    <category name="org.eclipse.jetty.util.component">
 +        <level value="ERROR"/>
 +    </category>
 +
 +    <category name="com.amazonaws">
 +        <level value="WARN"/>
 +    </category>
 +
 +    <!-- Default settings. -->
 +    <root>
 +        <!-- Print out all info by default. -->
 +        <level value="INFO"/>
 +
 +        <!-- Uncomment to enable logging to console. -->
 +        <!--
 +        <appender-ref ref="CONSOLE"/>
 +        -->
 +
 +        <appender-ref ref="CONSOLE_ERR"/>
 +        <appender-ref ref="FILE"/>
 +    </root>
 +</log4j:configuration>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/config/java.util.logging.properties
----------------------------------------------------------------------
diff --cc config/java.util.logging.properties
index 19dddb4,3e11d63..f30e028
--- a/config/java.util.logging.properties
+++ b/config/java.util.logging.properties
@@@ -64,11 -64,11 +64,11 @@@ java.util.logging.ConsoleHandler.format
  java.util.logging.ConsoleHandler.level=INFO
  
  #
 -# File handler logs all messages into files with pattern `gridgain-%{id8}.%g.log`
 +# File handler logs all messages into files with pattern `ignite-%{id8}.%g.log`
- # under `$GRIDGAIN_HOME/work/log/` directory. The placeholder `%{id8}` is a truncated node ID.
+ # under `$IGNITE_HOME/work/log/` directory. The placeholder `%{id8}` is a truncated node ID.
  #
 -org.gridgain.grid.logger.java.GridJavaLoggerFileHandler.formatter=org.apache.ignite.logger.java.IgniteJavaLoggerFormatter
 -org.gridgain.grid.logger.java.GridJavaLoggerFileHandler.pattern=gridgain-%{id8}.%g.log
 -org.gridgain.grid.logger.java.GridJavaLoggerFileHandler.level=INFO
 -org.gridgain.grid.logger.java.GridJavaLoggerFileHandler.limit=10485760
 -org.gridgain.grid.logger.java.GridJavaLoggerFileHandler.count=10
 +org.apache.ignite.logger.java.IgniteJavaLoggerFileHandler.formatter=org.apache.ignite.logger.java.IgniteJavaLoggerFormatter
 +org.apache.ignite.logger.java.IgniteJavaLoggerFileHandler.pattern=ignite-%{id8}.%g.log
 +org.apache.ignite.logger.java.IgniteJavaLoggerFileHandler.level=INFO
 +org.apache.ignite.logger.java.IgniteJavaLoggerFileHandler.limit=10485760
 +org.apache.ignite.logger.java.IgniteJavaLoggerFileHandler.count=10

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/examples/config/servlet/WEB-INF/web.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/clients/src/test/java/org/apache/ignite/client/integration/ClientAbstractSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/IgniteLogger.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/Ignition.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/compute/gridify/GridifySetToSet.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/compute/gridify/GridifySetToValue.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/internal/processors/rest/handlers/log/GridLogCommandHandler.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/logger/java/IgniteJavaLoggerFileHandler.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/main/java/org/apache/ignite/spi/discovery/tcp/TcpDiscoverySpi.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/test/config/log4j-test.xml
----------------------------------------------------------------------
diff --cc modules/core/src/test/config/log4j-test.xml
index 0f29c37,a1332f3..984e973
--- a/modules/core/src/test/config/log4j-test.xml
+++ b/modules/core/src/test/config/log4j-test.xml
@@@ -66,7 -66,7 +66,7 @@@
      -->
      <appender name="FILE" class="org.apache.log4j.RollingFileAppender">
          <param name="Threshold" value="DEBUG"/>
-         <param name="File" value="${GRIDGAIN_HOME}/work/log/ignite.log"/>
 -        <param name="File" value="${IGNITE_HOME}/work/log/gridgain.log"/>
++        <param name="File" value="${IGNITE_HOME}/work/log/ignite.log"/>
          <param name="Append" value="true"/>
          <param name="MaxFileSize" value="10MB"/>
          <param name="MaxBackupIndex" value="10"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
index d959f55,aa5808e..f8629d6
--- a/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
+++ b/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
@@@ -47,10 -47,10 +47,10 @@@ import static org.apache.ignite.IgniteS
   */
  public final class GridRandomCommandLineLoader {
      /** Name of the system property defining name of command line program. */
-     private static final String GRIDGAIN_PROG_NAME = "GRIDGAIN_PROG_NAME";
+     private static final String IGNITE_PROG_NAME = "IGNITE_PROG_NAME";
  
      /** Copyright text. Ant processed. */
 -    private static final String COPYRIGHT = "Copyright (C) 2014 GridGain Systems.";
 +    private static final String COPYRIGHT = "2015 Copyright(C) Apache Software Foundation.";
  
      /** Version. Ant processed. */
      private static final String VER = "x.x.x";

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/test/java/org/apache/ignite/testframework/junits/logger/GridLog4jRollingFileAppender.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/core/src/test/java/org/apache/ignite/testframework/junits/logger/GridTestLog4jLogger.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/log4j/src/main/java/org/apache/ignite/logger/log4j/IgniteLog4jLogger.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/log4j/src/main/java/org/apache/ignite/logger/log4j/IgniteLog4jNodeIdFilePath.java
----------------------------------------------------------------------
diff --cc modules/log4j/src/main/java/org/apache/ignite/logger/log4j/IgniteLog4jNodeIdFilePath.java
index 63945a0,a12bf5e..4423ace
--- a/modules/log4j/src/main/java/org/apache/ignite/logger/log4j/IgniteLog4jNodeIdFilePath.java
+++ b/modules/log4j/src/main/java/org/apache/ignite/logger/log4j/IgniteLog4jNodeIdFilePath.java
@@@ -46,10 -46,10 +46,10 @@@ class IgniteLog4jNodeIdFilePath impleme
  
      /** {@inheritDoc} */
      @Override public String apply(String oldPath) {
-         if (!F.isEmpty(U.GRIDGAIN_LOG_DIR))
-             return U.nodeIdLogFileName(nodeId, new File(U.GRIDGAIN_LOG_DIR, "ignite.log").getAbsolutePath());
+         if (!F.isEmpty(U.IGNITE_LOG_DIR))
 -            return U.nodeIdLogFileName(nodeId, new File(U.IGNITE_LOG_DIR, "gridgain.log").getAbsolutePath());
++            return U.nodeIdLogFileName(nodeId, new File(U.IGNITE_LOG_DIR, "ignite.log").getAbsolutePath());
  
-         if (oldPath != null) // fileName could be null if GRIDGAIN_HOME is not defined.
+         if (oldPath != null) // fileName could be null if IGNITE_HOME is not defined.
              return U.nodeIdLogFileName(nodeId, oldPath);
  
          String tmpDir = IgniteSystemProperties.getString("java.io.tmpdir");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCacheManager.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/ssh/src/main/java/org/apache/ignite/internal/util/nodestart/GridNodeCallableImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/tools/src/main/java/org/apache/ignite/tools/marshaller/optimized/OptimizedClassNamesGenerator.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/UriDeploymentSpi.java
----------------------------------------------------------------------
diff --cc modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/UriDeploymentSpi.java
index e25752b,0000000..7c72243
mode 100644,000000..100644
--- a/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/UriDeploymentSpi.java
+++ b/modules/urideploy/src/main/java/org/apache/ignite/spi/deployment/uri/UriDeploymentSpi.java
@@@ -1,1367 -1,0 +1,1367 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *      http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +
 +package org.apache.ignite.spi.deployment.uri;
 +
 +import org.apache.ignite.*;
 +import org.apache.ignite.compute.*;
 +import org.apache.ignite.lang.*;
 +import org.apache.ignite.resources.*;
 +import org.apache.ignite.spi.*;
 +import org.apache.ignite.spi.deployment.*;
 +import org.apache.ignite.spi.deployment.uri.scanners.*;
 +import org.apache.ignite.spi.deployment.uri.scanners.file.*;
 +import org.apache.ignite.spi.deployment.uri.scanners.ftp.*;
 +import org.apache.ignite.spi.deployment.uri.scanners.http.*;
 +import org.apache.ignite.internal.util.typedef.*;
 +import org.apache.ignite.internal.util.typedef.internal.*;
 +import org.jetbrains.annotations.*;
 +
 +import java.io.*;
 +import java.net.*;
 +import java.util.*;
 +import java.util.Map.*;
 +
 +/**
 + * Implementation of {@link org.apache.ignite.spi.deployment.DeploymentSpi} which can deploy tasks from
 + * different sources like file system folders, FTP, email and HTTP.
 + * There are different ways to deploy tasks in grid and every deploy method
 + * depends on selected source protocol. This SPI is configured to work
 + * with a list of URI's. Every URI contains all data about protocol/transport
 + * plus configuration parameters like credentials, scan frequency, and others.
 + * <p>
 + * When SPI establishes a connection with an URI, it downloads deployable units
 + * to the temporary directory in order to prevent it from any changes while
 + * scanning. Use method {@link #setTemporaryDirectoryPath(String) setTemporaryDirectoryPath(String)})
 + * to set custom temporary folder for downloaded deployment units. SPI will
 + * create folder under the path with name identical to local node ID.
 + * <p>
 + * SPI tracks all changes of every given URI. This means that if any file is
 + * changed or deleted, SPI will re-deploy or delete corresponding tasks.
 + * Note that the very first apply to {@link #findResource(String)} findClassLoader(String)}
 + * is blocked until SPI finishes scanning all URI's at least once.
 + * <p>
 + * There are several deployable unit types supported:
 + * <ul>
 + * <li>GAR file.</li>
 + * <li>Local disk folder with structure of unpacked GAR file.</li>
 + * <li>Local disk folder containing only compiled Java classes.</li>
 + * </ul>
 + * <h1 class="header">GAR file</h1>
 + * GAR file is a deployable unit. GAR file is based on <a href="http://www.gzip.org/zlib/">ZLIB</a>
 + * compression format like simple JAR file and its structure is similar to WAR archive.
 + * GAR file has {@code '.gar'} extension.
 + * <p>
 + * GAR file structure (file or directory ending with {@code '.gar'}):
 + *   <pre class="snippet">
 + *      META-INF/
 + *              |
 + *               - gridgain.xml
 + *               - ...
 + *      lib/
 + *         |
 + *          -some-lib.jar
 + *          - ...
 + *      xyz.class
 + *      ...</pre>
 + * <ul>
 + * <li>
 + * {@code META-INF/} entry may contain {@code gridgain.xml} file which is a
 + * task descriptor file. The purpose of task descriptor XML file is to specify
 + * all tasks to be deployed. This file is a regular
 + * <a href="http://www.springframework.org/documentation">Spring</a> XML
 + * definition file.  {@code META-INF/} entry may also contain any other file
 + * specified by JAR format.
 + * </li>
 + * <li>
 + * {@code lib/} entry contains all library dependencies.
 + * </li>
 + * <li>Compiled Java classes must be placed in the root of a GAR file.</li>
 + * </ul>
 + * GAR file may be deployed without descriptor file. If there is no descriptor file, SPI
 + * will scan all classes in archive and instantiate those that implement
 + * {@link org.apache.ignite.compute.ComputeTask} interface. In that case, all grid task classes must have a
 + * public no-argument constructor. Use {@link org.apache.ignite.compute.ComputeTaskAdapter} adapter for
 + * convenience when creating grid tasks.
 + * <p>
 + * By default, all downloaded GAR files that have digital signature in {@code META-INF}
 + * folder will be verified and deployed only if signature is valid.
 + * <p>
 + * <h1 class="header">URI</h1>
 + * This SPI uses a hierarchical URI definition. For more information about standard URI
 + * syntax refer to {@link URI java.net.URI} documentation.
 + * <blockquote class="snippet">
 + * [<i>scheme</i><tt><b>:</b></tt>][<tt><b>//</b></tt><i>authority</i>][<i>path</i>][<tt><b>?</b></tt><i>query</i>][<tt><b>#</b></tt><i>fragment</i>]
 + * </blockquote>
 + * <p>
 + * Every URI defines its own deployment repository which will be scanned for any changes.
 + * URI itself has all information about protocol, connectivity, scan intervals and other
 + * parameters.
 + * <p>
 + * URI's may contain special characters, like spaces. If {@code encodeUri}
 + * flag is set to {@code true} (see {@link #setEncodeUri(boolean)}), then
 + * URI 'path' field will be automatically encoded. By default this flag is
 + * set to {@code true}.
 + * <p>
 + * <h1 class="header">Configuration</h1>
 + * {@code UriDeploymentSpi} has the following optional configuration
 + * parameters (there are no mandatory parameters):
 + * <ul>
 + * <li>
 + * Temporary directory path where scanned GAR files and directories are
 + * copied to (see {@link #setTemporaryDirectoryPath(String) setTemporaryDirectoryPath(String)}).
 + * </li>
 + * <li>
 + * List of URIs to scan (see {@link #setUriList(List)}). If not
 + * specified, then URI specified by {@link #DFLT_DEPLOY_DIR DFLT_DEPLOY_DIR} is used.
 + * </li>
 + * <li>
 + * Flag to control encoding of the {@code 'path'} portion of URI
 + * (see {@link #setEncodeUri(boolean) setEncodeUri(boolean)}).
 + * </li>
 + * </ul>
 + * <h1 class="header">Protocols</h1>
 + * Following protocols are supported in SPI:
 + * <ul>
 + * <li><a href="#file">file://</a> - File protocol</li>
 + * <li><a href="#classes">classes://</a> - Custom File protocol.</li>
 + * <li><a href="#ftp">ftp://</a> - File transfer protocol</li>
 + * <li><a href="#http">http://</a> - HTTP protocol</li>
 + * <li><a href="#http">https://</a> - Secure HTTP protocol</li>
 + * </ul>
 + * In addition to SPI configuration parameters, all necessary configuration
 + * parameters for selected URI should be defined in URI. Different protocols
 + * have different configuration parameters described below. Parameters are
 + * separated by '{@code ;}' character.
 + * <p>
 + * <a name="file"></a>
 + * <h1 class="header">File</h1>
 + * For this protocol SPI will scan folder specified by URI on file system and
 + * download any GAR files or directories that end with .gar from source
 + * directory defined in URI. For file system URI must have scheme equal to {@code file}.
 + * <p>
 + * Following parameters are supported for FILE protocol:
 + * <table class="doctable">
 + *  <tr>
 + *      <th>Parameter</th>
 + *      <th>Description</th>
 + *      <th>Optional</th>
 + *      <th>Default</th>
 + *  </tr>
 + *  <tr>
 + *      <td>freq</td>
 + *      <td>File directory scan frequency in milliseconds.</td>
 + *      <td>Yes</td>
 + *      <td>{@code 5000} ms specified in {@link #DFLT_DISK_SCAN_FREQUENCY DFLT_DISK_SCAN_FREQUENCY}.</td>
 + *  </tr>
 + * </table>
 + * <h2 class="header">File URI Example</h2>
 + * The following example will scan {@code 'c:/Program files/gridgain/deployment'}
 + * folder on local box every {@code '5000'} milliseconds. Note that since path
 + * has spaces, {@link #setEncodeUri(boolean) setEncodeUri(boolean)} parameter must
 + * be set to {@code true} (which is default behavior).
 + * <blockquote class="snippet">
 + * {@code file://freq=5000@localhost/c:/Program files/gridgain/deployment}
 + * </blockquote>
 + * <a name="classes"></a>
 + * <h1 class="header">Classes</h1>
 + * For this protocol SPI will scan folder specified by URI on file system
 + * looking for compiled classes that implement {@link org.apache.ignite.compute.ComputeTask} interface.
 + * This protocol comes very handy during development, as it allows developer
 + * to specify IDE compilation output folder as URI and all task classes
 + * in that folder will be deployed automatically.
 + * <p>
 + * Following parameters are supported for CLASSES protocol:
 + * <table class="doctable">
 + *  <tr>
 + *      <th>Parameter</th>
 + *      <th>Description</th>
 + *      <th>Optional</th>
 + *      <th>Default</th>
 + *  </tr>
 + *  <tr>
 + *      <td>freq</td>
 + *      <td>File directory scan frequency in milliseconds.</td>
 + *      <td>Yes</td>
 + *      <td>{@code 5000} ms specified in {@link #DFLT_DISK_SCAN_FREQUENCY DFLT_DISK_SCAN_FREQUENCY}.</td>
 + *  </tr>
 + * </table>
 + * <h2 class="header">Classes URI Example</h2>
 + * The following example will scan {@code 'c:/Program files/gridgain/deployment'}
 + * folder on local box every {@code '5000'} milliseconds. Note that since path
 + * has spaces, {@link #setEncodeUri(boolean) setEncodeUri(boolean)} parameter must
 + * be set to {@code true} (which is default behavior).
 + * <blockquote class="snippet">
 + * {@code classes://freq=5000@localhost/c:/Program files/gridgain/deployment}
 + * </blockquote>
 + * <a name="ftp"></a>
 + * <h1 class="header">FTP</h1>
 + * For FTP protocol SPI will scan and download only GAR files from source
 + * directory defined in URI. SPI doesn't scan FTP folders recursively.
 + * The following parameters are supported for FTP protocol:
 + * <table class="doctable">
 + *  <tr>
 + *      <th>Parameter</th>
 + *      <th>Description</th>
 + *      <th>Optional</th>
 + *      <th>Default</th>
 + *  </tr>
 + *  <tr>
 + *      <td>freq</td>
 + *      <td>FTP location scan frequency in milliseconds.</td>
 + *      <td>Yes</td>
 + *      <td>{@code 300000} ms specified in {@link #DFLT_FTP_SCAN_FREQUENCY DFLT_FTP_SCAN_FREQUENCY}.</td>
 + *  </tr>
 + *  <tr>
 + *      <td>username:password</td>
 + *      <td>
 + *          FTP username and password specified in standard URI server-based
 + *          authority format.
 + *      </td>
 + *      <td>No</td>
 + *      <td>---</td>
 + *  </tr>
 + * </table>
 + * <h2 class="header">FTP URI Example</h2>
 + * Here is an example of an FTP URI that connects identified as
 + * {@code username:password} to {@code 'localhost'} on port {@code '21'},
 + * with initial path set to {@code 'gridgain/deployment'}
 + * <blockquote class="snippet">
 + * ftp://username:password;freq=10000@localhost:21/gridgain/deployment
 + * </blockquote>
 + * <p>
 + * <h2 class="header">HTTP URI Example</h2>
 + * The following example will scan {@code 'gridgain/deployment'} folder with
 + * on site {@code 'www.mysite.com'} using authentication
 + * {@code 'username:password'} every {@code '10000'} milliseconds.
 + * <blockquote class="snippet">
 + * {@code http://username:password;freq=10000@www.mysite.com:110/gridgain/deployment}
 + * </blockquote>
 + * <h2 class="header">Java Example</h2>
 + * UriDeploymentSpi needs to be explicitly configured to override default local deployment SPI.
 + * <pre name="code" class="java">
 + * UriDeploymentSpi deploySpi = new UriDeploymentSpi();
 + *
 + * GridConfiguration cfg = new GridConfiguration();
 + *
 + * List&lt;String&gt; uris = new ArrayList&lt;String&gt;(5);
 + *
 + * uris.add("http://www.site.com/tasks");
 + * uris.add("ftp://ftpuser:password;freq=10000@localhost:21/gg-test/deployment");
 + * uris.add("file://freq=20000@localhost/c:/Program files/gg-deployment");
 + * uris.add("classes:///c:/Java_Projects/myproject/out");
 + *
 + * // Set URIs.
 + * deploySpi.setUriList(uris);
 + *
 + * // Override temporary directory path.
 + * deploySpi.setTemporaryDirectoryPath("c:/tmp/grid");
 + *
 + * //  Override default deployment SPI.
 + * cfg.setDeploymentSpi(deploySpi);
 + *
 + * //  Start grid.
 + * G.start(cfg);
 + * </pre>
 + * <p>
 + * <h2 class="header">Spring Example</h2>
 + * UriDeploymentSpi can be configured from Spring XML configuration file:
 + * <pre name="code" class="xml">
 + * &lt;bean id="grid.custom.cfg" class="org.gridgain.grid.GridConfiguration" singleton="true"&gt;
 + *         ...
 + *         &lt;property name="deploymentSpi"&gt;
 + *             &lt;bean class="org.gridgain.grid.spi.deployment.uri.UriDeploymentSpi"&gt;
 + *                 &lt;property name="temporaryDirectoryPath" value="c:/tmp/grid"/&gt;
 + *                 &lt;property name="uriList"&gt;
 + *                     &lt;list&gt;
 + *                         &lt;value&gt;http://www.site.com/tasks&lt;/value&gt;
 + *                         &lt;value&gt;ftp://ftpuser:password;freq=10000@localhost:21/gg-test/deployment&lt;/value&gt;
 + *                         &lt;value&gt;file://freq=20000@localhost/c:/Program files/gg-deployment&lt;/value&gt;
 + *                         &lt;value&gt;classes:///c:/Java_Projects/myproject/out&lt;/value&gt;
 + *                     &lt;/list&gt;
 + *                 &lt;/property&gt;
 + *             &lt;/bean&gt;
 + *         &lt;/property&gt;
 + *         ...
 + * &lt;/bean&gt;
 + * </pre>
 + * <p>
 + * <img src="http://www.gridgain.com/images/spring-small.png">
 + * <br>
 + * For information about Spring framework visit <a href="http://www.springframework.org/">www.springframework.org</a>
 + * @see org.apache.ignite.spi.deployment.DeploymentSpi
 + */
 +@IgniteSpiMultipleInstancesSupport(true)
 +@IgniteSpiConsistencyChecked(optional = false)
 +@SuppressWarnings({"FieldAccessedSynchronizedAndUnsynchronized"})
 +public class UriDeploymentSpi extends IgniteSpiAdapter implements DeploymentSpi, UriDeploymentSpiMBean {
 +    /**
 +     * Default deployment directory where SPI will pick up GAR files. Note that this path is relative to
-      * {@code GRIDGAIN_HOME/work} folder if {@code GRIDGAIN_HOME} system or environment variable specified,
++     * {@code IGNITE_HOME/work} folder if {@code IGNITE_HOME} system or environment variable specified,
 +     * otherwise it is relative to {@code work} folder under system {@code java.io.tmpdir} folder.
 +     *
 +     * @see org.apache.ignite.configuration.IgniteConfiguration#getWorkDirectory()
 +     */
 +    public static final String DFLT_DEPLOY_DIR = "deployment/file";
 +
 +    /** Default scan frequency for {@code file://} and {@code classes://} protocols (value is {@code 5000}). */
 +    public static final int DFLT_DISK_SCAN_FREQUENCY = 5000;
 +
 +    /** Default scan frequency for {@code ftp://} protocol (value is {@code 300000}). */
 +    public static final int DFLT_FTP_SCAN_FREQUENCY = 300000;
 +
 +    /** Default scan frequency for {@code http://} protocol (value is {@code 300000}). */
 +    public static final int DFLT_HTTP_SCAN_FREQUENCY = 300000;
 +
 +    /** Default task description file path and name (value is {@code META-INF/gridgain.xml}). */
 +    public static final String XML_DESCRIPTOR_PATH = "META-INF/gridgain.xml";
 +
 +    /**
 +     * Default temporary directory name relative to file path
 +     * {@link #setTemporaryDirectoryPath(String)}} (value is {@code gg.uri.deployment.tmp}).
 +     */
 +    public static final String DEPLOY_TMP_ROOT_NAME = "gg.uri.deployment.tmp";
 +
 +    /** Temporary directory name. */
 +    private String tmpDirPath;
 +
 +    /** Sub-folder of 'tmpDirPath'. */
 +    private String deployTmpDirPath;
 +
 +    /** List of URIs to be scanned. */
 +    private List<String> uriList = new ArrayList<>();
 +
 +    /** List of encoded URIs. */
 +    private Collection<URI> uriEncodedList = new ArrayList<>();
 +
 +    /** Indicates whether md5 digest should be checked by this SPI before file deployment. */
 +    private boolean checkMd5;
 +
 +    /** */
 +    @SuppressWarnings({"CollectionDeclaredAsConcreteClass"})
 +    private final LinkedList<GridUriDeploymentUnitDescriptor> unitLoaders =
 +        new LinkedList<>();
 +
 +    /** */
 +    @SuppressWarnings({"TypeMayBeWeakened"})
 +    private final LastTimeUnitDescriptorComparator unitComp = new LastTimeUnitDescriptorComparator();
 +
 +    /** List of scanners. Every URI has it's own scanner. */
 +    private final Collection<GridUriDeploymentScanner> scanners = new ArrayList<>();
 +
 +    /** Whether URIs should be encoded or not. */
 +    private boolean encodeUri = true;
 +
 +    /** Whether first scan cycle is completed or not. */
 +    private int firstScanCntr;
 +
 +    /** Deployment listener which processes all notifications from scanners. */
 +    private volatile DeploymentListener lsnr;
 +
 +    /** */
 +    private final Object mux = new Object();
 +
 +    /** */
 +    @IgniteLoggerResource
 +    private IgniteLogger log;
 +
 +    /** NOTE: flag for test purposes only. */
 +    @SuppressWarnings("UnusedDeclaration")
 +    private boolean delayOnNewOrUpdatedFile;
 +
 +    /**
 +     * Sets absolute path to temporary directory which will be used by
 +     * deployment SPI to keep all deployed classes in.
 +     * <p>
 +     * If not provided, default value is {@code java.io.tmpdir} system property value.
 +     *
 +     * @param tmpDirPath Temporary directory path.
 +     */
 +    @IgniteSpiConfiguration(optional = true)
 +    public void setTemporaryDirectoryPath(String tmpDirPath) {
 +        this.tmpDirPath = tmpDirPath;
 +    }
 +
 +    /**
 +     * Sets list of URI which point to GAR file and which should be
 +     * scanned by SPI for the new tasks.
 +     * <p>
 +     * If not provided, default value is list with
-      * {@code file://${GRIDGAIN_HOME}/work/deployment/file} element.
-      * Note that system property {@code GRIDGAIN_HOME} must be set.
-      * For unknown {@code GRIDGAIN_HOME} list of URI must be provided explicitly.
++     * {@code file://${IGNITE_HOME}/work/deployment/file} element.
++     * Note that system property {@code IGNITE_HOME} must be set.
++     * For unknown {@code IGNITE_HOME} list of URI must be provided explicitly.
 +     *
 +     * @param uriList GAR file URIs.
 +     */
 +    @IgniteSpiConfiguration(optional = true)
 +    public void setUriList(List<String> uriList) {
 +        this.uriList = uriList;
 +    }
 +
 +    /**
 +     * If set to {@code true} then SPI should exclude files with same md5s from deployment.
 +     * Otherwise it should try to load new unit regardless to possible file duplication.
 +     *
 +     * @param checkMd5 new value for the property
 +     */
 +    @IgniteSpiConfiguration(optional = true)
 +    public void setCheckMd5(boolean checkMd5) {
 +        this.checkMd5 = checkMd5;
 +    }
 +
 +    /**
 +     * Gets {@code checkMd5} property.
 +     *
 +     * @return value of the {@code checkMd5} property.
 +     */
 +    @Override public boolean isCheckMd5() {
 +        return checkMd5;
 +    }
 +
 +    /**
 +     * Indicates that URI must be encoded before usage. Encoding means replacing
 +     * all occurrences of space with '%20', percent sign with '%25'
 +     * and semicolon with '%3B'.
 +     * <p>
 +     * If not provided, default value is {@code true}.
 +     *
 +     * @param encodeUri {@code true} if every URI should be encoded and
 +     *      {@code false} otherwise.
 +     */
 +    @IgniteSpiConfiguration(optional = true)
 +    public void setEncodeUri(boolean encodeUri) {
 +        this.encodeUri = encodeUri;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public String getTemporaryDirectoryPath() {
 +        return tmpDirPath;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public List<String> getUriList() {
 +        return Collections.unmodifiableList(uriList);
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public void setListener(@Nullable DeploymentListener lsnr) {
 +        this.lsnr = lsnr;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public void spiStop() throws IgniteSpiException {
 +        for (GridUriDeploymentScanner scanner : scanners)
 +            scanner.cancel();
 +
 +        for (GridUriDeploymentScanner scanner : scanners)
 +            scanner.join();
 +
 +        // Clear inner collections.
 +        uriEncodedList.clear();
 +        scanners.clear();
 +
 +        List<ClassLoader> tmpClsLdrs;
 +
 +        // Release all class loaders.
 +        synchronized (mux) {
 +            tmpClsLdrs = new ArrayList<>(unitLoaders.size());
 +
 +            for (GridUriDeploymentUnitDescriptor desc : unitLoaders)
 +                tmpClsLdrs.add(desc.getClassLoader());
 +        }
 +
 +        for (ClassLoader ldr : tmpClsLdrs)
 +            onUnitReleased(ldr);
 +
 +        // Delete temp directory.
 +        if (deployTmpDirPath != null)
 +            U.delete(new File(deployTmpDirPath));
 +
 +        unregisterMBean();
 +
 +        // Ack ok stop.
 +        if (log.isDebugEnabled())
 +            log.debug(stopInfo());
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public void spiStart(String gridName) throws IgniteSpiException {
 +        // Start SPI start stopwatch.
 +        startStopwatch();
 +
 +        assertParameter(uriList != null, "uriList != null");
 +
 +        initializeUriList();
 +
 +        if (uriEncodedList.isEmpty())
 +            addDefaultUri();
 +
 +        initializeTemporaryDirectoryPath();
 +
 +        registerMBean(gridName, this, UriDeploymentSpiMBean.class);
 +
 +        FilenameFilter filter = new FilenameFilter() {
 +            @Override public boolean accept(File dir, String name) {
 +                assert name != null;
 +
 +                return name.toLowerCase().endsWith(".gar");
 +            }
 +        };
 +
 +        firstScanCntr = 0;
 +
 +        GridUriDeploymentScannerListener lsnr = new GridUriDeploymentScannerListener() {
 +            @Override public void onNewOrUpdatedFile(File file, String uri, long tstamp) {
 +                if (log.isInfoEnabled())
 +                    log.info("Found new or updated GAR units [uri=" + U.hidePassword(uri) +
 +                        ", file=" + file.getAbsolutePath() + ", tstamp=" + tstamp + ']');
 +
 +                if (delayOnNewOrUpdatedFile) {
 +                    U.warn(log, "Delaying onNewOrUpdatedFile() by 10000 ms since 'delayOnNewOrUpdatedFile' " +
 +                        "is set to true (is this intentional?).");
 +
 +                    try {
 +                        U.sleep(10000);
 +                    }
 +                    catch (IgniteInterruptedException ignored) {
 +                        // No-op
 +                    }
 +
 +                    U.warn(log, "Delay finished.");
 +                }
 +
 +                try {
 +                    GridUriDeploymentFileProcessorResult fileRes = GridUriDeploymentFileProcessor.processFile(file, uri,
 +                        new File(deployTmpDirPath), log);
 +
 +                    if (fileRes != null)
 +                        newUnitReceived(uri, fileRes.getFile(), tstamp, fileRes.getClassLoader(),
 +                            fileRes.getTaskClasses(), fileRes.getMd5());
 +                }
 +                catch (IgniteSpiException e) {
 +                    U.error(log, "Error when processing file: " + file.getAbsolutePath(), e);
 +                }
 +            }
 +
 +            /** {@inheritDoc} */
 +            @Override public void onDeletedFiles(List<String> uris) {
 +                if (log.isInfoEnabled()) {
 +                    List<String> uriList = null;
 +
 +                    if (uris != null) {
 +                        uriList = new ArrayList<>();
 +
 +                        for (String uri : uris)
 +                            uriList.add(U.hidePassword(uri));
 +                    }
 +
 +                    log.info("Found deleted GAR units [uris=" + uriList + ']');
 +                }
 +
 +                processDeletedFiles(uris);
 +            }
 +
 +            /** {@inheritDoc} */
 +            @Override public void onFirstScanFinished() {
 +                synchronized (mux) {
 +                    firstScanCntr++;
 +
 +                    if (isFirstScanFinished(firstScanCntr))
 +                        mux.notifyAll();
 +                }
 +            }
 +        };
 +
 +        for (URI uri : uriEncodedList) {
 +            String proto = uri.getScheme();
 +
 +            File file = new File(deployTmpDirPath);
 +
 +            long freq = -1;
 +
 +            try {
 +                freq = getFrequencyFromUri(uri);
 +            }
 +            catch (NumberFormatException e) {
 +                U.error(log, "Error parsing parameter value for frequency.", e);
 +            }
 +
 +            assert proto != null;
 +
 +            GridUriDeploymentScanner scanner;
 +
 +            switch (proto) {
 +                case "file":
 +                    scanner = new GridUriDeploymentFileScanner(gridName, uri, file, freq > 0 ? freq :
 +                        DFLT_DISK_SCAN_FREQUENCY, filter, lsnr, log);
 +                    break;
 +
 +                case "http":
 +                case "https":
 +                    scanner = new GridUriDeploymentHttpScanner(gridName, uri, file, freq > 0 ? freq :
 +                        DFLT_HTTP_SCAN_FREQUENCY, filter, lsnr, log);
 +                    break;
 +
 +                case "ftp":
 +                    scanner = new GridUriDeploymentFtpScanner(gridName, uri, file, freq > 0 ? freq :
 +                        DFLT_FTP_SCAN_FREQUENCY, filter, lsnr, log);
 +                    break;
 +
 +                default:
 +                    throw new IgniteSpiException("Unsupported protocol: " + proto);
 +            }
 +
 +            scanners.add(scanner);
 +
 +            scanner.start();
 +        }
 +
 +        // Ack parameters.
 +        if (log.isDebugEnabled()) {
 +            log.debug(configInfo("tmpDirPath", tmpDirPath));
 +            log.debug(configInfo("uriList", uriList));
 +            log.debug(configInfo("encodeUri", encodeUri));
 +            log.debug(configInfo("scanners", scanners));
 +        }
 +
 +        // Ack ok start.
 +        if (log.isDebugEnabled())
 +            log.debug(startInfo());
 +    }
 +
 +    /**
 +     * Gets URI refresh frequency.
 +     * URI is parsed and {@code freq} parameter value returned.
 +     *
 +     * @param uri URI to be parsed.
 +     * @return {@code -1} if there if no {@code freq} parameter otherwise
 +     *      returns frequency.
 +     * @throws NumberFormatException Thrown if {@code freq} parameter value
 +     *      is not a number.
 +     */
 +    private long getFrequencyFromUri(URI uri) throws NumberFormatException {
 +        assert uri != null;
 +
 +        String userInfo = uri.getUserInfo();
 +
 +        if (userInfo != null) {
 +            String[] arr = userInfo.split(";");
 +
 +            if (arr != null && arr.length > 0)
 +                for (String el : arr)
 +                    if (el.startsWith("freq="))
 +                        return Long.parseLong(el.substring(5));
 +        }
 +
 +        return -1;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Nullable
 +    @Override public DeploymentResource findResource(String rsrcName) {
 +        assert rsrcName != null;
 +
 +        // Wait until all scanners finish their first scanning.
 +        try {
 +            synchronized (mux) {
 +                while (!isFirstScanFinished(firstScanCntr))
 +                    mux.wait(5000);
 +            }
 +        }
 +        catch (InterruptedException e) {
 +            U.error(log, "Failed to wait while all scanners finish their first scanning.", e);
 +
 +            Thread.currentThread().interrupt();
 +
 +            return null;
 +        }
 +
 +        synchronized (mux) {
 +            // Last updated class loader has highest priority in search.
 +            for (GridUriDeploymentUnitDescriptor unitDesc : unitLoaders) {
 +                // Try to find resource for current class loader.
 +                String clsName = rsrcName;
 +                Class<?> clsByAlias = unitDesc.getResourcesByAlias().get(rsrcName);
 +
 +                if (clsByAlias != null)
 +                    clsName = clsByAlias.getName();
 +
 +                try {
 +                    ClassLoader ldr = unitDesc.getClassLoader();
 +
 +                    Class<?> cls = ldr instanceof GridUriDeploymentClassLoader ?
 +                        ((GridUriDeploymentClassLoader)ldr).loadClassGarOnly(clsName) :
 +                        ldr.loadClass(clsName);
 +
 +                    assert cls != null;
 +
 +                    IgniteBiTuple<Class<?>, String> rsrc = unitDesc.findResource(rsrcName);
 +
 +                    if (rsrc != null) {
 +                        // Recalculate resource name in case if access is performed by
 +                        // class name and not the resource name.
 +                        String alias = rsrc.get2();
 +
 +                        return new DeploymentResourceAdapter(
 +                            alias != null ? alias : rsrcName,
 +                            cls,
 +                            unitDesc.getClassLoader());
 +                    }
 +                    // Ignore invalid tasks.
 +                    else if (!ComputeTask.class.isAssignableFrom(cls)) {
 +                        unitDesc.addResource(cls);
 +
 +                        return new DeploymentResourceAdapter(rsrcName, cls, unitDesc.getClassLoader());
 +                    }
 +                }
 +                catch (ClassNotFoundException ignored) {
 +                    // No-op.
 +                }
 +            }
 +
 +            return null;
 +        }
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public boolean register(ClassLoader ldr, Class<?> rsrc) throws IgniteSpiException {
 +        A.notNull(ldr, "ldr");
 +        A.notNull(rsrc, "rsrc");
 +
 +        long tstamp = U.currentTimeMillis();
 +
 +        Collection<ClassLoader> rmvClsLdrs = new ArrayList<>();
 +
 +        Map<String, String> newRsrcs;
 +
 +        synchronized (mux) {
 +            GridUriDeploymentUnitDescriptor desc = null;
 +
 +            // Find existing class loader.
 +            for (GridUriDeploymentUnitDescriptor unitDesc : unitLoaders)
 +                if (unitDesc.getClassLoader().equals(ldr)) {
 +                    desc = unitDesc;
 +
 +                    break;
 +                }
 +
 +            if (desc == null) {
 +                desc = new GridUriDeploymentUnitDescriptor(tstamp, ldr);
 +
 +                // New unit has largest timestamp.
 +                assert unitLoaders.size() <= 0 || unitComp.compare(desc, unitLoaders.getFirst()) <= 0;
 +
 +                unitLoaders.addFirst(desc);
 +            }
 +
 +            newRsrcs = addResources(ldr, desc, new Class<?>[]{rsrc});
 +
 +            if (!F.isEmpty(newRsrcs))
 +                removeResources(ldr, newRsrcs, rmvClsLdrs);
 +        }
 +
 +        for (ClassLoader cldLdr : rmvClsLdrs)
 +            onUnitReleased(cldLdr);
 +
 +        return !F.isEmpty(newRsrcs);
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public boolean unregister(String rsrcName) {
 +        assert rsrcName != null;
 +
 +        Collection<ClassLoader> rmvClsLdrs = new ArrayList<>();
 +
 +        boolean rmv;
 +
 +        synchronized (mux) {
 +            Map<String, String> rsrcs = U.newHashMap(1);
 +
 +            rsrcs.put(rsrcName, rsrcName);
 +
 +            rmv = removeResources(null, rsrcs, rmvClsLdrs);
 +        }
 +
 +        for (ClassLoader cldLdr : rmvClsLdrs)
 +            onUnitReleased(cldLdr);
 +
 +        return rmv;
 +    }
 +
 +    /**
 +     * Add new classes in class loader resource map.
 +     * Note that resource map may contain two entries for one added class:
 +     * task name -> class name and class name -> class name.
 +     *
 +     * @param ldr Registered class loader.
 +     * @param desc Deployment descriptor.
 +     * @param clss Registered classes array.
 +     * @return Map of new resources added for registered class loader.
 +     * @throws org.apache.ignite.spi.IgniteSpiException If resource already registered. Exception thrown
 +     * if registered resources conflicts with rule when all task classes must be
 +     * annotated with different task names.
 +     */
 +    @Nullable
 +    private Map<String, String> addResources(ClassLoader ldr, GridUriDeploymentUnitDescriptor desc, Class<?>[] clss)
 +        throws IgniteSpiException {
 +        assert ldr != null;
 +        assert desc != null;
 +        assert clss != null;
 +
 +        // Maps resources to classes.
 +        // Map may contain 2 entries for one class.
 +        Map<String, Class<?>> alias2Cls = new HashMap<>(clss.length * 2, 1.0f);
 +
 +        // Check alias collision between added classes.
 +        for (Class<?> cls : clss) {
 +            String alias = null;
 +
 +            if (ComputeTask.class.isAssignableFrom(cls)) {
 +                ComputeTaskName nameAnn = U.getAnnotation(cls, ComputeTaskName.class);
 +
 +                if (nameAnn != null)
 +                    alias = nameAnn.value();
 +            }
 +
 +            // If added classes maps to one alias.
 +            if (alias != null && alias2Cls.containsKey(alias) && !alias2Cls.get(alias).equals(cls))
 +                throw new IgniteSpiException("Failed to register resources with given task name " +
 +                    "(found another class with same task name) [taskName=" + alias +
 +                    ", cls1=" + cls.getName() + ", cls2=" + alias2Cls.get(alias).getName() + ", ldr=" + ldr + ']');
 +
 +            if (alias != null) {
 +                alias2Cls.put(alias, cls);
 +
 +                desc.addResource(alias, cls);
 +            }
 +            else
 +                desc.addResource(cls);
 +        }
 +
 +        Map<String, String> newRsrcs = null;
 +
 +        // Check collisions between added and exist classes.
 +        for (Entry<String, Class<?>> entry : alias2Cls.entrySet()) {
 +            String newAlias = entry.getKey();
 +            String newName = entry.getValue().getName();
 +            Class<?> cls = desc.getResourceByAlias(newAlias);
 +
 +            if (cls != null) {
 +                // Different classes for the same resource name.
 +                if (!cls.getName().equals(newName))
 +                    throw new IgniteSpiException("Failed to register resources with given task name " +
 +                        "(found another class with same task name in the same class loader) [taskName=" + newAlias +
 +                        ", existingCls=" + cls.getName() + ", newCls=" + newName + ", ldr=" + ldr + ']');
 +            }
 +            // Add resources that should be removed for another class loaders.
 +            else {
 +                if (newRsrcs == null)
 +                    newRsrcs = U.newHashMap(alias2Cls.size() + clss.length);
 +
 +                newRsrcs.put(newAlias, newName);
 +                newRsrcs.put(newName, newName);
 +            }
 +        }
 +
 +        return newRsrcs;
 +    }
 +
 +    /**
 +     * Remove resources for all class loaders except {@code ignoreClsLdr}.
 +     *
 +     * @param ignoreClsLdr Ignored class loader or {@code null} to remove for all class loaders.
 +     * @param rsrcs Resources that should be used in search for class loader to remove.
 +     * @param rmvClsLdrs Class loaders to remove.
 +     * @return {@code True} if resource was removed.
 +     */
 +    private boolean removeResources(@Nullable ClassLoader ignoreClsLdr, Map<String, String> rsrcs,
 +        Collection<ClassLoader> rmvClsLdrs) {
 +        assert Thread.holdsLock(mux);
 +        assert rsrcs != null;
 +
 +        boolean res = false;
 +
 +        for (Iterator<GridUriDeploymentUnitDescriptor> iter = unitLoaders.iterator(); iter.hasNext();) {
 +            GridUriDeploymentUnitDescriptor desc = iter.next();
 +            ClassLoader ldr = desc.getClassLoader();
 +
 +            if (ignoreClsLdr == null || !ldr.equals(ignoreClsLdr)) {
 +                boolean isRmv = false;
 +
 +                // Check class loader's registered resources.
 +                for (String rsrcName : rsrcs.keySet()) {
 +                    IgniteBiTuple<Class<?>, String> rsrc = desc.findResource(rsrcName);
 +
 +                    // Remove class loader if resource found.
 +                    if (rsrc != null) {
 +                        iter.remove();
 +
 +                        // Add class loaders in collection to notify listener outside synchronization block.
 +                        rmvClsLdrs.add(ldr);
 +
 +                        isRmv = true;
 +                        res = true;
 +
 +                        break;
 +                    }
 +                }
 +
 +                if (isRmv)
 +                    continue;
 +
 +                // Check is possible to load resources with classloader.
 +                for (Entry<String, String> entry : rsrcs.entrySet()) {
 +                    // Check classes with class loader only when classes points to classes to avoid redundant check.
 +                    // Resources map contains two entries for class with task name(alias).
 +                    if (entry.getKey().equals(entry.getValue()) && isResourceExist(ldr, entry.getKey())) {
 +                        iter.remove();
 +
 +                        // Add class loaders in collection to notify listener outside synchronization block.
 +                        rmvClsLdrs.add(ldr);
 +
 +                        res = true;
 +
 +                        break;
 +                    }
 +                }
 +            }
 +        }
 +
 +        return res;
 +    }
 +
 +    /**
 +     * Gets resource name for a given class name.
 +     *
 +     * @param clsName Class name.
 +     * @param rsrcs Map of resources.
 +     * @return Resource name.
 +     */
 +    private String getResourceName(String clsName, Map<String, String> rsrcs) {
 +        assert Thread.holdsLock(mux);
 +
 +        String rsrcName = clsName;
 +
 +        for (Entry<String, String> e : rsrcs.entrySet())
 +            if (e.getValue().equals(clsName) && !e.getKey().equals(clsName)) {
 +                rsrcName = e.getKey();
 +
 +                break;
 +            }
 +
 +        return rsrcName;
 +    }
 +
 +    /**
 +     * Check is class can be reached.
 +     *
 +     * @param ldr Class loader.
 +     * @param clsName Class name.
 +     * @return {@code true} if class can be loaded.
 +     */
 +    private boolean isResourceExist(ClassLoader ldr, String clsName) {
 +        String rsrc = clsName.replaceAll("\\.", "/") + ".class";
 +
 +        InputStream in = null;
 +
 +        try {
 +            in = ldr instanceof GridUriDeploymentClassLoader ?
 +                ((GridUriDeploymentClassLoader)ldr).getResourceAsStreamGarOnly(rsrc) :
 +                ldr.getResourceAsStream(rsrc);
 +
 +            return in != null;
 +        }
 +        finally {
 +            U.close(in, log);
 +        }
 +    }
 +
 +    /**
 +     * Tests whether first scan is finished or not.
 +     *
 +     * @param cntr Number of already scanned URIs.
 +     * @return {@code true} if all URIs have been scanned at least once and
 +     *      {@code false} otherwise.
 +     */
 +    private boolean isFirstScanFinished(int cntr) {
 +        assert uriEncodedList != null;
 +
 +        return cntr >= uriEncodedList.size();
 +    }
 +
 +    /**
 +     * Fills in list of URIs with all available URIs and encodes them if
 +     * encoding is enabled.
 +     *
 +     * @throws org.apache.ignite.spi.IgniteSpiException Thrown if at least one URI has incorrect syntax.
 +     */
 +    private void initializeUriList() throws IgniteSpiException {
 +        for (String uri : uriList) {
 +            assertParameter(uri != null, "uriList.get(X) != null");
 +
 +            assert uri != null;
 +
 +            String encUri = encodeUri(uri.replaceAll("\\\\", "/"));
 +
 +            URI uriObj;
 +
 +            try {
 +                uriObj = new URI(encUri);
 +            }
 +            catch (URISyntaxException e) {
 +                throw new IgniteSpiException("Failed to parse URI [uri=" + U.hidePassword(uri) +
 +                    ", encodedUri=" + U.hidePassword(encUri) + ']', e);
 +            }
 +
 +            if (uriObj.getScheme() == null || uriObj.getScheme().trim().isEmpty())
 +                throw new IgniteSpiException("Failed to get 'scheme' from URI [uri=" +
 +                    U.hidePassword(uri) +
 +                    ", encodedUri=" + U.hidePassword(encUri) + ']');
 +
 +            uriEncodedList.add(uriObj);
 +        }
 +    }
 +
 +    /**
 +     * Add configuration for file scanner {@link GridUriDeploymentFileScanner}.
 +     *
 +     * @throws org.apache.ignite.spi.IgniteSpiException Thrown if default URI syntax is incorrect.
 +     */
 +    private void addDefaultUri() throws IgniteSpiException {
 +        assert uriEncodedList != null;
 +
 +        URI uri;
 +
 +        try {
 +            uri = U.resolveWorkDirectory(DFLT_DEPLOY_DIR, false).toURI();
 +        }
 +        catch (IgniteCheckedException e) {
 +            throw new IgniteSpiException("Failed to initialize default file scanner", e);
 +        }
 +
 +        uriEncodedList.add(uri);
 +    }
 +
 +    /**
 +     * Encode URI path if encoding is enabled. Set of encoded characters
 +     * in path is (' ', ';', '%').
 +     *
 +     * @param path URI which should be encoded.
 +     * @return Either encoded URI if encoding is enabled or given one
 +     *      if encoding is disabled.
 +     */
 +    private String encodeUri(String path) {
 +        return encodeUri ? new GridUriDeploymentUriParser(path).parse() : path;
 +    }
 +
 +    /**
 +     * Initializes temporary directory path. Path consists of base path
 +     * (either {@link #tmpDirPath} value or {@code java.io.tmpdir}
 +     * system property value if first is {@code null}) and path relative
 +     * to base one - {@link #DEPLOY_TMP_ROOT_NAME}/{@code local node ID}.
 +     *
 +     * @throws org.apache.ignite.spi.IgniteSpiException Thrown if temporary directory could not be created.
 +     */
 +    private void initializeTemporaryDirectoryPath() throws IgniteSpiException {
 +        String tmpDirPath = this.tmpDirPath == null ? System.getProperty("java.io.tmpdir") : this.tmpDirPath;
 +
 +        if (tmpDirPath == null)
 +            throw new IgniteSpiException("Error initializing temporary deployment directory.");
 +
 +        File dir = new File(tmpDirPath + File.separator + DEPLOY_TMP_ROOT_NAME + File.separator +
 +            ignite.configuration().getNodeId());
 +
 +        if (!U.mkdirs(dir))
 +            throw new IgniteSpiException("Error initializing temporary deployment directory: " + dir);
 +
 +        if (!dir.isDirectory())
 +            throw new IgniteSpiException("Temporary deployment directory path is not a valid directory: " + dir);
 +
 +        if (!dir.canRead() || !dir.canWrite())
 +            throw new IgniteSpiException("Can not write to or read from temporary deployment directory: " + dir);
 +
 +        this.tmpDirPath = tmpDirPath;
 +
 +        deployTmpDirPath = dir.getPath();
 +    }
 +
 +    /**
 +     * Deploys all tasks that correspond to given descriptor.
 +     * First method checks tasks versions and stops processing tasks that
 +     * have both versioned and unversioned instances.
 +     * <p>
 +     * Than it deletes tasks with lower version and deploys newest tasks.
 +     *
 +     * @param newDesc Tasks deployment descriptor.
 +     * @param clss Registered classes.
 +     */
 +    private void newUnitReceived(GridUriDeploymentUnitDescriptor newDesc, Collection<Class<?>> clss) {
 +        assert newDesc != null;
 +        assert newDesc.getType() == GridUriDeploymentUnitDescriptor.Type.FILE;
 +
 +        if (clss != null && !clss.isEmpty()) {
 +            try {
 +                addResources(newDesc.getClassLoader(), newDesc, clss.toArray(new Class<?>[clss.size()]));
 +            }
 +            catch (IgniteSpiException e) {
 +                U.warn(log, "Failed to register GAR class loader [newDesc=" + newDesc +
 +                    ", msg=" + e.getMessage() + ']');
 +            }
 +        }
 +
 +        Collection<ClassLoader> rmvClsLdrs = new ArrayList<>();
 +
 +        synchronized (mux) {
 +            if (checkMd5 && unitDeployed(newDesc.getMd5())) {
 +                if (log.isInfoEnabled())
 +                    LT.info(log, "Skipping new deployment unit because of md5 match " +
 +                        "[uri='" + U.hidePassword(newDesc.getUri()) +
 +                        "', file=" + (newDesc.getFile() == null ? "N/A" : newDesc.getFile()) + ']');
 +
 +                return;
 +            }
 +
 +            boolean isAdded = false;
 +            boolean ignoreNewUnit = false;
 +
 +            for (ListIterator<GridUriDeploymentUnitDescriptor> iter = unitLoaders.listIterator();
 +                 iter.hasNext();) {
 +                GridUriDeploymentUnitDescriptor desc = iter.next();
 +
 +                assert !newDesc.getClassLoader().equals(desc.getClassLoader()) :
 +                    "Uri scanners always create new class loader for every GAR file: " + newDesc;
 +
 +                // Only for GAR files. Undeploy all for overwritten GAR files.
 +                if (desc.getType() == GridUriDeploymentUnitDescriptor.Type.FILE &&
 +                    newDesc.getUri().equals(desc.getUri()) && !newDesc.getFile().equals(desc.getFile())) {
 +                    // Remove descriptor.
 +                    iter.remove();
 +
 +                    // Add class loaders in collection to notify listener outside synchronization block.
 +                    rmvClsLdrs.add(desc.getClassLoader());
 +
 +                    // Last descriptor.
 +                    if (!iter.hasNext())
 +                        // New descriptor will be added after loop.
 +                        break;
 +
 +                    continue;
 +                }
 +
 +                if (!isAdded) {
 +                    // Unit with largest timestamp win.
 +                    // Insert it before current element.
 +                    if (unitComp.compare(newDesc, desc) <= 0) {
 +                        // Remove current class loader if found collisions.
 +                        if (checkUnitCollision(desc, newDesc)) {
 +                            iter.remove();
 +                            iter.add(newDesc);
 +
 +                            // Add class loaders in collection to notify listener outside synchronization block.
 +                            rmvClsLdrs.add(desc.getClassLoader());
 +                        }
 +                        // Or add new class loader before current class loader.
 +                        else {
 +                            iter.set(newDesc);
 +                            iter.add(desc);
 +                        }
 +
 +                        isAdded = true;
 +                    }
 +                    else if (checkUnitCollision(newDesc, desc)) {
 +                        // Don't add new unit if found collisions with latest class loader.
 +                        ignoreNewUnit = true;
 +                        break;
 +                    }
 +                }
 +                // New descriptor already added and we need to check other class loaders for collisions.
 +                else if (checkUnitCollision(newDesc, desc)) {
 +                    iter.remove();
 +
 +                    // Add class loaders in collection to notify listener outside synchronization block.
 +                    rmvClsLdrs.add(desc.getClassLoader());
 +                }
 +            }
 +
 +            if (!ignoreNewUnit) {
 +                if (!isAdded)
 +                    unitLoaders.add(newDesc);
 +
 +                if (log.isDebugEnabled())
 +                    LT.info(log, "Class loader (re)registered [clsLdr=" + newDesc.getClassLoader() +
 +                        ", tstamp=" + newDesc.getTimestamp() +
 +                        ", uri='" + U.hidePassword(newDesc.getUri()) +
 +                        "', file=" + (newDesc.getFile() == null ? "N/A" : newDesc.getFile()) + ']');
 +            }
 +        }
 +
 +        for (ClassLoader cldLdr : rmvClsLdrs)
 +            onUnitReleased(cldLdr);
 +    }
 +
 +    /**
 +     * Check task resource collisions in added descriptor {@code newDesc} with another
 +     * descriptor {@code existDesc}.
 +     *
 +     * @param newDesc New added descriptor.
 +     * @param existDesc Exist descriptor.
 +     * @return {@code True} if collisions found.
 +     */
 +    private boolean checkUnitCollision(GridUriDeploymentUnitDescriptor newDesc,
 +        GridUriDeploymentUnitDescriptor existDesc) {
 +        assert newDesc != null;
 +        assert existDesc != null;
 +
 +        Map<String, Class<?>> rsrcsByAlias = newDesc.getResourcesByAlias();
 +
 +        for (Entry<String, Class<?>> entry : existDesc.getResourcesByAlias().entrySet()) {
 +            String rsrcName = entry.getKey();
 +
 +            if (rsrcsByAlias.containsKey(rsrcName)) {
 +                U.warn(log, "Found collision with task name in different GAR files. " +
 +                    "Class loader will be removed [taskName=" + rsrcName + ", cls1=" + rsrcsByAlias.get(rsrcName) +
 +                    ", cls2=" + entry.getValue() + ", newDesc=" + newDesc + ", existDesc=" + existDesc + ']');
 +
 +                return true;
 +            }
 +        }
 +
 +        for (Class<?> rsrcCls : existDesc.getResources()) {
 +            if (!ComputeTask.class.isAssignableFrom(rsrcCls) &&
 +                isResourceExist(newDesc.getClassLoader(), rsrcCls.getName())) {
 +                U.warn(log, "Found collision with task class in different GAR files. " +
 +                    "Class loader will be removed [taskCls=" + rsrcCls +
 +                    ", removedDesc=" + newDesc + ", existDesc=" + existDesc + ']');
 +
 +                return true;
 +            }
 +        }
 +
 +        return false;
 +    }
 +
 +    /**
 +     * Deploys or redeploys given tasks.
 +     *
 +     * @param uri GAR file deployment URI.
 +     * @param file GAR file.
 +     * @param tstamp File modification date.
 +     * @param ldr Class loader.
 +     * @param clss List of tasks which were found in GAR file.
 +     * @param md5 md5 of the new unit.
 +     */
 +    private void newUnitReceived(String uri, File file, long tstamp, ClassLoader ldr,
 +        Collection<Class<? extends ComputeTask<?, ?>>> clss, @Nullable String md5) {
 +        assert uri != null;
 +        assert file != null;
 +        assert tstamp > 0;
 +
 +        // To avoid units with incorrect timestamp.
 +        tstamp = Math.min(tstamp, U.currentTimeMillis());
 +
 +        // Create descriptor.
 +        GridUriDeploymentUnitDescriptor desc = new GridUriDeploymentUnitDescriptor(uri, file, tstamp, ldr, md5);
 +
 +        newUnitReceived(desc, clss != null && !clss.isEmpty() ? new ArrayList<Class<?>>(clss) : null);
 +    }
 +
 +    /**
 +     * Removes all tasks that belong to GAR files which are on list
 +     * of removed files.
 +     *
 +     * @param uris List of removed files.
 +     */
 +    @SuppressWarnings({"TypeMayBeWeakened"})
 +    private void processDeletedFiles(List<String> uris) {
 +        assert uris != null;
 +
 +        if (uris.isEmpty())
 +            return;
 +
 +        synchronized (mux) {
 +            Set<String> uriSet = new HashSet<>(uris);
 +
 +            for (Iterator<GridUriDeploymentUnitDescriptor> iter = unitLoaders.iterator(); iter.hasNext();) {
 +                GridUriDeploymentUnitDescriptor desc = iter.next();
 +
 +                if (desc.getType() == GridUriDeploymentUnitDescriptor.Type.FILE && uriSet.contains(desc.getUri())) {
 +                    // Remove descriptor.
 +                    iter.remove();
 +
 +                    onUnitReleased(desc.getClassLoader());
 +                }
 +            }
 +        }
 +    }
 +
 +    /**
 +     * Notifies listener about released class loader.
 +     *
 +     * @param clsLdr Released class loader.
 +     */
 +    private void onUnitReleased(ClassLoader clsLdr) {
 +        // Make sure we don't remove system class loader.
 +        if (!clsLdr.equals(getClass().getClassLoader()))
 +            GridUriDeploymentFileProcessor.cleanupUnit(clsLdr, log);
 +
 +        DeploymentListener tmp = lsnr;
 +
 +        if (tmp != null)
 +            tmp.onUnregistered(clsLdr);
 +    }
 +
 +    /**
 +     * Checks if a nut with the same md5 ai already deployed with this SPI.
 +     *
 +     * @param md5 md5 of a new unit.
 +     * @return {@code true} if this unit deployed, {@code false} otherwise.
 +     */
 +    private boolean unitDeployed(String md5) {
 +        assert Thread.holdsLock(mux);
 +
 +        if (md5 != null) {
 +            for (GridUriDeploymentUnitDescriptor d: unitLoaders)
 +                if (md5.equals(d.getMd5()))
 +                    return true;
 +        }
 +
 +        return false;
 +    }
 +
 +    /**
 +     * Task deployment descriptor comparator.
 +     * The greater descriptor is those one that has less timestamp.
 +     */
 +    private static class LastTimeUnitDescriptorComparator implements Comparator<GridUriDeploymentUnitDescriptor>,
 +        Serializable {
 +        /** */
 +        private static final long serialVersionUID = 0L;
 +
 +        /** {@inheritDoc} */
 +        @Override public int compare(GridUriDeploymentUnitDescriptor o1, GridUriDeploymentUnitDescriptor o2) {
 +            if (o1.getTimestamp() < o2.getTimestamp())
 +                return 1;
 +
 +            return o1.getTimestamp() == o2.getTimestamp() ? 0 : -1;
 +        }
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public String toString() {
 +        return S.toString(UriDeploymentSpi.class, this);
 +    }
 +}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/urideploy/src/test/java/org/apache/ignite/spi/deployment/uri/scanners/file/GridFileDeploymentSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/web/src/main/java/org/apache/ignite/cache/websession/GridWebSessionFilter.java
----------------------------------------------------------------------


[38/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branches 'remotes/origin/ignite-69', 'remotes/origin/ignite-71' and 'remotes/origin/ignite-72-1' into sprint-1

Posted by vo...@apache.org.
Merge remote-tracking branches 'remotes/origin/ignite-69', 'remotes/origin/ignite-71' and 'remotes/origin/ignite-72-1' into sprint-1


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

Branch: refs/heads/ignite-16
Commit: f64485ba826858addfb68943db8fcf1b146af2e8
Parents: 5203363 43d54c2 8df3ac4 ae74087
Author: Anton Vinogradov <av...@gridgain.com>
Authored: Fri Jan 30 21:01:27 2015 +0300
Committer: Anton Vinogradov <av...@gridgain.com>
Committed: Fri Jan 30 21:01:27 2015 +0300

----------------------------------------------------------------------
 assembly/release-base.xml                       |     2 +-
 config/gridgain-log4j.xml                       |   152 -
 config/ignite-log4j.xml                         |   152 +
 config/java.util.logging.properties             |    14 +-
 .../apache/ignite/examples/ComputeExample.java  |    59 +
 .../ignite/examples/MessagingExample.java       |   166 +
 .../org/gridgain/examples/ComputeExample.java   |    59 -
 .../org/gridgain/examples/MessagingExample.java |   166 -
 .../integration/ClientAbstractSelfTest.java     |     2 +-
 .../rest/RestBinaryProtocolSelfTest.java        |     2 +-
 .../java/org/apache/ignite/IgniteLogger.java    |     2 +-
 .../impl/GridRouterCommandLineStartup.java      |     2 +-
 .../apache/ignite/internal/GridProductImpl.java |     2 +-
 .../apache/ignite/internal/IgniteKernal.java    |     8 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |     6 +-
 .../handlers/log/GridLogCommandHandler.java     |     2 +-
 .../java/IgniteJavaLoggerFileHandler.java       |     2 +-
 .../ignite/thread/IgniteThreadFactory.java      |     2 +-
 modules/core/src/test/config/log4j-test.xml     |     2 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |     2 +-
 .../startup/GridRandomCommandLineLoader.java    |     2 +-
 .../testframework/junits/GridAbstractTest.java  |     2 +-
 .../logger/GridLog4jRollingFileAppender.java    |     2 +-
 .../junits/logger/GridTestLog4jLogger.java      |     2 +-
 .../src/test/resources/log/gridgain.log.tst     | 13706 -----------------
 .../core/src/test/resources/log/ignite.log.tst  | 13706 +++++++++++++++++
 .../child/GridHadoopExternalProcessStarter.java |     2 +-
 .../apache/ignite/logger/jcl/GridJclLogger.java |     4 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |     2 +-
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |     4 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |     4 +-
 .../rest/protocols/http/jetty/rest.html         |     6 +-
 modules/scalar/pom.xml                          |     6 +-
 .../util/nodestart/GridNodeCallableImpl.java    |     2 +-
 pom.xml                                         |    10 +-
 35 files changed, 14132 insertions(+), 14132 deletions(-)
----------------------------------------------------------------------


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

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f64485ba/pom.xml
----------------------------------------------------------------------


[31/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-69

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-69


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

Branch: refs/heads/ignite-16
Commit: 43d54c27f61691e3e4d15276dd7cf4676929a975
Parents: 5a50356 ff01e66
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 15:09:09 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 15:09:09 2015 +0300

----------------------------------------------------------------------
 .../util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java    | 2 +-
 .../org/apache/ignite/messaging/GridMessagingSelfTest.java     | 2 +-
 .../internal/processors/hadoop/GridHadoopClassLoader.java      | 4 ++--
 .../marshaller/optimized/OptimizedClassNamesGenerator.java     | 6 +++---
 .../src/main/scala/org/apache/ignite/visor/visor.scala         | 1 -
 5 files changed, 7 insertions(+), 8 deletions(-)
----------------------------------------------------------------------



[07/50] [abbrv] incubator-ignite git commit: # sprint-1 Fixed typo after auto renaming.

Posted by vo...@apache.org.
# sprint-1 Fixed typo after auto renaming.


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

Branch: refs/heads/ignite-16
Commit: 9502c0d9f747bc77d6e10f999d86e7f6dc5cb402
Parents: 580c36e
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 22:35:26 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 22:35:26 2015 +0700

----------------------------------------------------------------------
 .../org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9502c0d9/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
index ca22fa1..837b424 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
@@ -17,7 +17,7 @@
 
 package org.apache.ignite.visor.commands.alert
 
-import org.apache.ignite.internal.util.IgniteUtils
+import org.apache.ignite.internal.util.{IgniteUtils => U}
 import org.apache.ignite.internal.util.lang.{GridFunc => F}
 
 import org.apache.ignite._


[41/50] [abbrv] incubator-ignite git commit: gg*{sh, bat} renamed to ignite*{sh, bat}

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
index 0103f7c..ba632f3 100644
--- a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
+++ b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-1.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
index 5a2aece..f22430e 100644
--- a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
+++ b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-2.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
index 041a003..25078bc 100644
--- a/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
+++ b/modules/core/src/test/config/benchmark/spring-cache-client-benchmark-3.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/example-cache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/example-cache.xml b/modules/core/src/test/config/example-cache.xml
index 0382d07..2217994 100644
--- a/modules/core/src/test/config/example-cache.xml
+++ b/modules/core/src/test/config/example-cache.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file to GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/ggfs-loopback.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-loopback.xml b/modules/core/src/test/config/ggfs-loopback.xml
index d736e31..94cab9a 100644
--- a/modules/core/src/test/config/ggfs-loopback.xml
+++ b/modules/core/src/test/config/ggfs-loopback.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-ggfs-loopback.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-ggfs-loopback.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-ggfs-loopback.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/ggfs-shmem.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/ggfs-shmem.xml b/modules/core/src/test/config/ggfs-shmem.xml
index 535b363..48a1ca1 100644
--- a/modules/core/src/test/config/ggfs-shmem.xml
+++ b/modules/core/src/test/config/ggfs-shmem.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-ggfs-shmem.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-ggfs-shmem.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-ggfs-shmem.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/spring-cache-load.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/spring-cache-load.xml b/modules/core/src/test/config/spring-cache-load.xml
index 687a4c0..05f6c53 100644
--- a/modules/core/src/test/config/spring-cache-load.xml
+++ b/modules/core/src/test/config/spring-cache-load.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/spring-multicache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/spring-multicache.xml b/modules/core/src/test/config/spring-multicache.xml
index f11b24f..c5261ff 100644
--- a/modules/core/src/test/config/spring-multicache.xml
+++ b/modules/core/src/test/config/spring-multicache.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/streamer/average/spring-streamer-average-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/streamer/average/spring-streamer-average-base.xml b/modules/core/src/test/config/streamer/average/spring-streamer-average-base.xml
index 6675989..5f90c9f 100644
--- a/modules/core/src/test/config/streamer/average/spring-streamer-average-base.xml
+++ b/modules/core/src/test/config/streamer/average/spring-streamer-average-base.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/streamer/average/spring-streamer-average-local.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/streamer/average/spring-streamer-average-local.xml b/modules/core/src/test/config/streamer/average/spring-streamer-average-local.xml
index aa9facd..8db31aa 100644
--- a/modules/core/src/test/config/streamer/average/spring-streamer-average-local.xml
+++ b/modules/core/src/test/config/streamer/average/spring-streamer-average-local.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/streamer/average/spring-streamer-average-random.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/streamer/average/spring-streamer-average-random.xml b/modules/core/src/test/config/streamer/average/spring-streamer-average-random.xml
index 53925db..463820a 100644
--- a/modules/core/src/test/config/streamer/average/spring-streamer-average-random.xml
+++ b/modules/core/src/test/config/streamer/average/spring-streamer-average-random.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/config/streamer/spring-streamer-base.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/config/streamer/spring-streamer-base.xml b/modules/core/src/test/config/streamer/spring-streamer-base.xml
index 326124f..3cfe8cb 100644
--- a/modules/core/src/test/config/streamer/spring-streamer-base.xml
+++ b/modules/core/src/test/config/streamer/spring-streamer-base.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheMultiNodeDataStructureTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheMultiNodeDataStructureTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheMultiNodeDataStructureTest.java
index b739318..a265a51 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheMultiNodeDataStructureTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/GridCacheMultiNodeDataStructureTest.java
@@ -25,8 +25,8 @@ import org.apache.ignite.internal.util.typedef.*;
 /**
  * Starts up an node with cache configuration.
  * You can also must start a stand-alone GridGain instance by passing the path
- * to configuration file to {@code 'ggstart.{sh|bat}'} script, like so:
- * {@code 'ggstart.sh examples/config/example-cache.xml'}.
+ * to configuration file to {@code 'ignite.{sh|bat}'} script, like so:
+ * {@code 'ignite.sh examples/config/example-cache.xml'}.
  */
 public class GridCacheMultiNodeDataStructureTest {
     /** Ensure singleton. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml b/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
index 00b787c..6374e35 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/capacity/spring-capacity-cache.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml b/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
index 2d8a89d..7592340 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/colocation/spring-colocation.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/java/org/apache/ignite/loadtests/mapper/GridNodeStartup.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/loadtests/mapper/GridNodeStartup.java b/modules/core/src/test/java/org/apache/ignite/loadtests/mapper/GridNodeStartup.java
index 22f906f..1fb7d71 100644
--- a/modules/core/src/test/java/org/apache/ignite/loadtests/mapper/GridNodeStartup.java
+++ b/modules/core/src/test/java/org/apache/ignite/loadtests/mapper/GridNodeStartup.java
@@ -25,8 +25,8 @@ import javax.swing.*;
 /**
  * Starts up an empty node with cache configuration.
  * You can also start a stand-alone GridGain instance by passing the path
- * to configuration file to {@code 'ggstart.{sh|bat}'} script, like so:
- * {@code 'ggstart.sh examples/config/example-cache.xml'}.
+ * to configuration file to {@code 'ignite.{sh|bat}'} script, like so:
+ * {@code 'ignite.sh examples/config/example-cache.xml'}.
  * <p>
  * The difference is that running this class from IDE adds all example classes to classpath
  * but running from command line doesn't.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java b/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
index f8629d6..b8c24f8 100644
--- a/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
+++ b/modules/core/src/test/java/org/apache/ignite/startup/GridRandomCommandLineLoader.java
@@ -125,7 +125,7 @@ public final class GridRandomCommandLineLoader {
         if (errMsg != null)
             echo("ERROR: " + errMsg);
 
-        String runner = System.getProperty(IGNITE_PROG_NAME, "randggstart.{sh|bat}");
+        String runner = System.getProperty(IGNITE_PROG_NAME, "randignite.{sh|bat}");
 
         int space = runner.indexOf(' ');
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/java/org/apache/ignite/startup/GridVmNodesStarter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/startup/GridVmNodesStarter.java b/modules/core/src/test/java/org/apache/ignite/startup/GridVmNodesStarter.java
index 16c8f80..e02ae4a 100644
--- a/modules/core/src/test/java/org/apache/ignite/startup/GridVmNodesStarter.java
+++ b/modules/core/src/test/java/org/apache/ignite/startup/GridVmNodesStarter.java
@@ -99,7 +99,7 @@ public final class GridVmNodesStarter {
         if (errMsg != null)
             echo("ERROR: " + errMsg);
 
-        String runner = System.getProperty(IGNITE_PROG_NAME, "randggstart.{sh|bat}");
+        String runner = System.getProperty(IGNITE_PROG_NAME, "randignite.{sh|bat}");
 
         int space = runner.indexOf(' ');
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/webapp/META-INF/gg-config.xml
----------------------------------------------------------------------
diff --git a/modules/core/src/test/webapp/META-INF/gg-config.xml b/modules/core/src/test/webapp/META-INF/gg-config.xml
index aa6bb69..0b8d1fa 100644
--- a/modules/core/src/test/webapp/META-INF/gg-config.xml
+++ b/modules/core/src/test/webapp/META-INF/gg-config.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/spring-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/spring-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/spring-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/email/readme.txt
----------------------------------------------------------------------
diff --git a/modules/email/readme.txt b/modules/email/readme.txt
index 9fd9108..2e434de 100644
--- a/modules/email/readme.txt
+++ b/modules/email/readme.txt
@@ -6,7 +6,7 @@ expiration or fatal system errors (this should be also configured via 'GridConfi
 configuration properties).
 
 To enable email module when starting a standalone node, move 'optional/ignite-email' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing email Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/hadoop/readme.txt
----------------------------------------------------------------------
diff --git a/modules/hadoop/readme.txt b/modules/hadoop/readme.txt
index 0212371..37b7a65 100644
--- a/modules/hadoop/readme.txt
+++ b/modules/hadoop/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite Hadoop module provides In-Memory MapReduce engine and driver to us
 which are 100% compatible with HDFS and YARN.
 
 To enable Hadoop module when starting a standalone node, move 'optional/ignite-hadoop' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Hadoop Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/hibernate/readme.txt
----------------------------------------------------------------------
diff --git a/modules/hibernate/readme.txt b/modules/hibernate/readme.txt
index 7b4b70a..5a33622 100644
--- a/modules/hibernate/readme.txt
+++ b/modules/hibernate/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite Hibernate module provides Hibernate second-level cache (L2 cache)
 on Apache Ignite In-Memory Data Grid.
 
 To enable Hibernate module when starting a standalone node, move 'optional/ignite-hibernate' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Hibernate Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/indexing/readme.txt
----------------------------------------------------------------------
diff --git a/modules/indexing/readme.txt b/modules/indexing/readme.txt
index 699b2ee..f0ea6ba 100644
--- a/modules/indexing/readme.txt
+++ b/modules/indexing/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite indexing module provides capabilities to index cache context and r
 individual field queries against these indexes.
 
 To enable indexing module when starting a standalone node, move 'optional/ignite-indexing' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing indexing Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/jcl/readme.txt
----------------------------------------------------------------------
diff --git a/modules/jcl/readme.txt b/modules/jcl/readme.txt
index 0f713dc..ac37421 100644
--- a/modules/jcl/readme.txt
+++ b/modules/jcl/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite JCL module provides GridLogger implementation that can delegate to
 on Jakarta Commons Logging (JCL).
 
 To enable JCL module when starting a standalone node, move 'optional/ignite-jcl' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing JCL Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/jta/readme.txt
----------------------------------------------------------------------
diff --git a/modules/jta/readme.txt b/modules/jta/readme.txt
index 5893824..c6c08b2 100644
--- a/modules/jta/readme.txt
+++ b/modules/jta/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite JTA Module
 Apache Ignite JTA module provides capabilities to integrate Apache Ignite cache transactions with JTA.
 
 To enable JTA module when starting a standalone node, move 'optional/ignite-jta' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing JTA Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/log4j/readme.txt
----------------------------------------------------------------------
diff --git a/modules/log4j/readme.txt b/modules/log4j/readme.txt
index 8d8ff4f..9ca3c55 100644
--- a/modules/log4j/readme.txt
+++ b/modules/log4j/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite Log4J Module
 Apache Ignite Log4J module provides GridLogger implementation based on Apache Log4J.
 
 To enable Log4J module when starting a standalone node, move 'optional/ignite-log4j' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Log4J Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/rest-http/readme.txt
----------------------------------------------------------------------
diff --git a/modules/rest-http/readme.txt b/modules/rest-http/readme.txt
index 139f287..0df2cf5 100644
--- a/modules/rest-http/readme.txt
+++ b/modules/rest-http/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite REST-HTTP module provides Jetty-based server which can be used to
 in grid using REST approach via HTTP protocol.
 
 To enable REST-HTTP module when starting a standalone node, move 'optional/ignite-rest-http' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing REST-HTTP Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/scalar/readme.txt
----------------------------------------------------------------------
diff --git a/modules/scalar/readme.txt b/modules/scalar/readme.txt
index 88bb921..38c5879 100644
--- a/modules/scalar/readme.txt
+++ b/modules/scalar/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite Scalar Module
 Apache Ignite Scalar module provides Scala-based DSL with extensions and shortcuts for Apache Ignite API.
 
 To enable Scalar module when starting a standalone node, move 'optional/ignite-scalar' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Scalar Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/schedule/readme.txt
----------------------------------------------------------------------
diff --git a/modules/schedule/readme.txt b/modules/schedule/readme.txt
index ba51203..4ca7ac8 100644
--- a/modules/schedule/readme.txt
+++ b/modules/schedule/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite Schedule Module
 Apache Ignite Schedule module provides functionality for scheduling jobs locally using UNIX cron-based syntax.
 
 To enable Schedule module when starting a standalone node, move 'optional/ignite-schedule' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Schedule Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/slf4j/readme.txt
----------------------------------------------------------------------
diff --git a/modules/slf4j/readme.txt b/modules/slf4j/readme.txt
index c6fadc3..2583ce3 100644
--- a/modules/slf4j/readme.txt
+++ b/modules/slf4j/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite SLF4J Module
 Apache Ignite SLF4J module provides GridLogger implementation based on SLF4J.
 
 To enable SLF4J module when starting a standalone node, move 'optional/ignite-slf4j' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing SLF4J Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/spring/readme.txt
----------------------------------------------------------------------
diff --git a/modules/spring/readme.txt b/modules/spring/readme.txt
index 93eade9..24718b7 100644
--- a/modules/spring/readme.txt
+++ b/modules/spring/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite Spring module provides resources injection capabilities and parser
 configuration XML files.
 
 To enable Spring module when starting a standalone node, move 'optional/ignite-spring' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Spring Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCacheManager.java
----------------------------------------------------------------------
diff --git a/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCacheManager.java b/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCacheManager.java
index e7f2a46..bd13e60 100644
--- a/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCacheManager.java
+++ b/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCacheManager.java
@@ -125,7 +125,7 @@ import java.util.*;
  * <h1>Starting Remote Nodes</h1>
  * Remember that the node started inside your application is an entry point
  * to the whole topology it connects to. You can start as many remote standalone
- * nodes as you need using {@code bin/ggstart.{sh|bat}} scripts provided in
+ * nodes as you need using {@code bin/ignite.{sh|bat}} scripts provided in
  * GridGain distribution, and all these nodes will participate
  * in caching data.
  */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/ssh/readme.txt
----------------------------------------------------------------------
diff --git a/modules/ssh/readme.txt b/modules/ssh/readme.txt
index e69c896..a0876e7 100644
--- a/modules/ssh/readme.txt
+++ b/modules/ssh/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite SSH Module
 Apache Ignite SSH module provides capabilities to start Apache Ignite nodes on remote machines via SSH.
 
 To enable SSH module when starting a standalone node, move 'optional/ignite-ssh' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing SSH Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/ssh/src/main/java/org/apache/ignite/internal/util/nodestart/GridNodeCallableImpl.java
----------------------------------------------------------------------
diff --git a/modules/ssh/src/main/java/org/apache/ignite/internal/util/nodestart/GridNodeCallableImpl.java b/modules/ssh/src/main/java/org/apache/ignite/internal/util/nodestart/GridNodeCallableImpl.java
index 77f3f96..0d80430 100644
--- a/modules/ssh/src/main/java/org/apache/ignite/internal/util/nodestart/GridNodeCallableImpl.java
+++ b/modules/ssh/src/main/java/org/apache/ignite/internal/util/nodestart/GridNodeCallableImpl.java
@@ -41,10 +41,10 @@ public class GridNodeCallableImpl implements GridNodeCallable {
     private static final String DFLT_IGNITE_HOME_LINUX = "$IGNITE_HOME";
 
     /** Default start script path for Windows. */
-    private static final String DFLT_SCRIPT_WIN = "bin\\ggstart.bat -v -np";
+    private static final String DFLT_SCRIPT_WIN = "bin\\ignite.bat -v -np";
 
     /** Default start script path for Linux. */
-    private static final String DFLT_SCRIPT_LINUX = "bin/ggstart.sh -v";
+    private static final String DFLT_SCRIPT_LINUX = "bin/ignite.sh -v";
 
     /**
      * Logs folder for Windows.
@@ -301,11 +301,11 @@ public class GridNodeCallableImpl implements GridNodeCallable {
     }
 
     /**
-     * Builds ggstart.sh attributes to set up SSH username and password and log directory for started node.
+     * Builds ignite.sh attributes to set up SSH username and password and log directory for started node.
      *
      * @param username SSH user name.
      * @param host Host.
-     * @return {@code ggstart.sh} script arguments.
+     * @return {@code ignite.sh} script arguments.
      */
     private String buildRemoteLogArguments(String username, String host) {
         assert username != null;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/urideploy/readme.txt
----------------------------------------------------------------------
diff --git a/modules/urideploy/readme.txt b/modules/urideploy/readme.txt
index a641ddf..a2cdb62 100644
--- a/modules/urideploy/readme.txt
+++ b/modules/urideploy/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite URI Deploy module provides capabilities to deploy tasks from diffe
 File System, HTTP, FTP, or even Email.
 
 To enable URI Deploy module when starting a standalone node, move 'optional/ignite-urideploy' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing URI Deploy Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
index b389df5..3aefa2a 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/Packet.scala
@@ -31,7 +31,7 @@ package org.apache.ignite
  * Visor console provides monitoring capabilities for GridGain.
  *
  * ==Usage==
- * GridGain ships with `IGNITE_HOME/bin/ggvisorcmd.{sh|bat}` script that starts Visor console.
+ * GridGain ships with `IGNITE_HOME/bin/ignitevisorcmd.{sh|bat}` script that starts Visor console.
  *
  * Just type:<ex>help</ex> in Visor console to get help and get started.
  */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
index 8d3edf7..457f201 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/Packet.scala
@@ -66,8 +66,8 @@ package org.apache.ignite.visor.commands
  *         If not provided, default GridGain configuration is used.
  *     -s=<path>
  *         Path to start script (relative to GridGain home).
- *         Default is "bin/ggstart.sh" for Unix or
- *         "bin\ggstart.bat" for Windows.
+ *         Default is "bin/ignite.sh" for Unix or
+ *         "bin\ignite.bat" for Windows.
  *     -m=<num>
  *         Defines maximum number of nodes that can be started in parallel on one host.
  *         This actually means number of parallel SSH connections to each SSH server.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/VisorStartCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/VisorStartCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/VisorStartCommand.scala
index b6592c3..d4affc1 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/VisorStartCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/VisorStartCommand.scala
@@ -92,8 +92,8 @@ private case class Result(
  *         If not provided, default GridGain configuration is used.
  *     -s=<path>
  *         Path to start script (relative to GridGain home).
- *         Default is "bin/ggstart.sh" for Unix or
- *         "bin\ggstart.bat" for Windows.
+ *         Default is "bin/ignite.sh" for Unix or
+ *         "bin\ignite.bat" for Windows.
  *     -m=<num>
  *         Defines maximum number of nodes that can be started in parallel on one host.
  *         This actually means number of parallel SSH connections to each SSH server.
@@ -384,8 +384,8 @@ object VisorStartCommand {
             ),
             "-s=<path>" -> List(
                 "Path to start script (relative to GridGain home).",
-                "Default is \"bin/ggstart.sh\" for Unix or",
-                "\"bin\\ggstart.bat\" for Windows."
+                "Default is \"bin/ignite.sh\" for Unix or",
+                "\"bin\\ignite.bat\" for Windows."
             ),
             "-m=<num>" -> List(
                 "Defines maximum number of nodes that can be started in parallel on one host.",

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
index e69d7ee..476714e 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
@@ -115,7 +115,7 @@ trait VisorTag
  * Visor console provides monitoring capabilities for GridGain.
  *
  * ==Usage==
- * GridGain ships with `IGNITE_HOME/bin/ggvisorcmd.{sh|bat}` script that starts Visor console.
+ * GridGain ships with `IGNITE_HOME/bin/ignitevisorcmd.{sh|bat}` script that starts Visor console.
  *
  * Just type:<ex>help</ex> in Visor console to get help and get started.
  */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/web/readme.txt
----------------------------------------------------------------------
diff --git a/modules/web/readme.txt b/modules/web/readme.txt
index 5acdf40..68f62b3 100644
--- a/modules/web/readme.txt
+++ b/modules/web/readme.txt
@@ -6,7 +6,7 @@ which allow to start Apache Ignite inside any web container. Additionally this m
 capabilities to cache web sessions in Apache Ignite cache.
 
 To enable Web module when starting a standalone node, move 'optional/ignite-web' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing Web Module In Maven Project


[47/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-86' into sprint-1

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/ignite-86' into sprint-1


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

Branch: refs/heads/ignite-16
Commit: 88514f70095e2b21415d24cec10ec79896d016d4
Parents: 7f50e80 258ee1c
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Feb 2 12:30:33 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Feb 2 12:30:33 2015 +0300

----------------------------------------------------------------------
 .../GridDeploymentPerLoaderStore.java           |  20 ++-
 .../GridDeploymentPerVersionStore.java          |   4 +-
 .../processors/cache/GridCacheAdapter.java      |   5 +-
 .../cache/GridCacheDeploymentManager.java       | 161 +++++++++++--------
 .../cache/GridCachePreloaderAdapter.java        |   2 +-
 .../processors/cache/GridCacheProcessor.java    |   5 +-
 .../processors/cache/GridCacheSwapManager.java  |   3 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   2 +-
 .../streamer/GridStreamProcessor.java           |   5 +-
 .../processors/streamer/IgniteStreamerEx.java   |   3 +-
 .../processors/streamer/IgniteStreamerImpl.java |   5 +-
 11 files changed, 113 insertions(+), 102 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/88514f70/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/88514f70/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/88514f70/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/GridStreamProcessor.java
----------------------------------------------------------------------


[13/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-72-1

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-72-1


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

Branch: refs/heads/ignite-16
Commit: e19655dfb3fd53f5423d3842bce7ca3395dc0f3b
Parents: 18e02cd 9550905
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 11:30:11 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 11:30:11 2015 +0300

----------------------------------------------------------------------
 assembly/release-base-fabric.xml                |    2 +-
 assembly/release-hadoop.xml                     |    6 +-
 ipc/shmem/Makefile.am                           |    2 +-
 ipc/shmem/Makefile.in                           |    2 +-
 ipc/shmem/configure                             |    4 +-
 ipc/shmem/configure.ac                          |    2 +-
 ipc/shmem/ggshmem/Makefile.am                   |   23 -
 ipc/shmem/ggshmem/Makefile.in                   |  589 --
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |  882 --
 ipc/shmem/igniteshmem/Makefile.am               |   23 +
 ipc/shmem/igniteshmem/Makefile.in               |  589 ++
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  882 ++
 ipc/shmem/include/Makefile.am                   |    2 +-
 ipc/shmem/include/Makefile.in                   |    2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |  117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |  117 -
 ipc/shmem/readme.txt                            |    9 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |    2 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |    2 +-
 .../rest/TaskCommandHandlerSelfTest.java        |    2 +-
 .../java/META-INF/native/linux64/libggshmem.so  |  Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |  Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |  Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |  Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../main/java/org/apache/ignite/Ignition.java   |   38 +-
 .../apache/ignite/cache/CachingProvider.java    |    2 +-
 .../ignite/fs/mapreduce/IgniteFsTask.java       |    2 +-
 .../ignite/internal/ClusterGroupAdapter.java    |    2 +-
 .../internal/ClusterNodeLocalMapImpl.java       |    2 +-
 .../java/org/apache/ignite/internal/GridEx.java |  143 -
 .../org/apache/ignite/internal/GridGainEx.java  | 2399 -----
 .../org/apache/ignite/internal/GridKernal.java  | 3322 -------
 .../ignite/internal/GridKernalContext.java      |    2 +-
 .../ignite/internal/GridKernalContextImpl.java  |    8 +-
 .../apache/ignite/internal/GridLoggerProxy.java |    2 +-
 .../ignite/internal/GridUpdateNotifier.java     |    2 +-
 .../ignite/internal/IgniteClusterAsyncImpl.java |    4 +-
 .../org/apache/ignite/internal/IgniteEx.java    |  143 +
 .../apache/ignite/internal/IgniteKernal.java    | 3322 +++++++
 .../org/apache/ignite/internal/IgnitionEx.java  | 2396 +++++
 .../processors/affinity/GridAffinityUtils.java  |    2 +-
 .../processors/cache/GridCacheAdapter.java      |   24 +-
 .../processors/cache/GridCacheContext.java      |    4 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../cache/GridCacheMvccCandidate.java           |    4 +-
 .../processors/cache/GridCacheStoreManager.java |   25 +-
 .../processors/cache/IgniteCacheProxy.java      |   24 +-
 .../GridCacheDataStructuresManager.java         |    4 +-
 .../cache/query/GridCacheQueryManager.java      |    2 +-
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |    2 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |    2 +-
 .../transactions/IgniteTxLocalAdapter.java      |   42 +-
 .../dr/GridDrDataLoadCacheUpdater.java          |    2 +-
 .../internal/processors/fs/GridGgfsImpl.java    |    2 +-
 .../internal/processors/fs/GridGgfsServer.java  |   26 +-
 .../processors/fs/GridGgfsServerManager.java    |    8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |    2 +-
 .../processors/fs/IgniteFsProcessor.java        |    4 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |    2 +-
 .../resource/GridResourceProcessor.java         |    2 +-
 .../resource/GridSpringResourceContext.java     |    2 +-
 .../handlers/cache/GridCacheCommandHandler.java |    6 +-
 .../handlers/task/GridTaskCommandHandler.java   |    2 +-
 .../service/GridServiceProcessor.java           |    2 +-
 .../processors/service/GridServiceProxy.java    |    2 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9100 -----------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../internal/util/ipc/GridIpcEndpoint.java      |   49 -
 .../util/ipc/GridIpcEndpointBindException.java  |   47 -
 .../util/ipc/GridIpcEndpointFactory.java        |   84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |   29 -
 .../util/ipc/GridIpcServerEndpoint.java         |   73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |   66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |  250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |   49 +
 .../util/ipc/IpcEndpointBindException.java      |   47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |   84 +
 .../internal/util/ipc/IpcEndpointType.java      |   29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |   73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |   66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |  250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |   87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |  179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |   87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |  179 +
 .../GridIpcOutOfSystemResourcesException.java   |   59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |  336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |   67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |  171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |   99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |  242 -
 ...cSharedMemoryOperationTimedoutException.java |   59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |   80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |  707 --
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |  374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |  242 -
 .../shmem/IpcOutOfSystemResourcesException.java |   59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |  336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |   67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |  171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |   99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |  261 +
 ...cSharedMemoryOperationTimedoutException.java |   59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |   80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  707 ++
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |  374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |  242 +
 .../util/nio/GridShmemCommunicationClient.java  |    4 +-
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../apache/ignite/internal/visor/VisorJob.java  |    2 +-
 .../internal/visor/VisorMultiNodeTask.java      |    2 +-
 .../ignite/internal/visor/cache/VisorCache.java |    2 +-
 .../compute/VisorComputeMonitoringHolder.java   |   10 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../visor/node/VisorBasicConfiguration.java     |    2 +-
 .../visor/node/VisorGridConfiguration.java      |    2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    6 +-
 .../internal/visor/query/VisorQueryTask.java    |    2 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   27 +-
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   24 +-
 .../StreamerCacheAffinityEventRouter.java       |    2 +-
 .../ignite/GridExceptionHelpLinksSelfTest.java  |  106 -
 .../ignite/GridExternalizableAbstractTest.java  |   41 -
 .../IgniteExceptionHelpLinksSelfTest.java       |  105 +
 .../IgniteExternalizableAbstractTest.java       |   41 +
 ...CachePartitionFairAffinityNodesSelfTest.java |    6 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |    2 +-
 .../fs/GridGgfsEventsAbstractSelfTest.java      |    2 +-
 .../ignite/fs/GridGgfsFragmentizerSelfTest.java |    2 +-
 .../internal/GridDiscoveryEventSelfTest.java    |    3 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    4 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../internal/GridExecutorServiceTest.java       |  315 -
 .../GridExplicitImplicitDeploymentSelfTest.java |  476 -
 .../ignite/internal/GridKernalTestUtils.java    |    3 +-
 .../internal/GridListenActorSelfTest.java       |    3 +-
 .../GridTopicExternalizableSelfTest.java        |    3 +-
 .../GridTopologyBuildVersionSelfTest.java       |    2 +-
 .../internal/GridUpdateNotifierSelfTest.java    |    3 +-
 .../internal/IgniteExecutorServiceTest.java     |  315 +
 ...gniteExplicitImplicitDeploymentSelfTest.java |  476 +
 .../GridCheckpointManagerAbstractSelfTest.java  |    2 +-
 .../GridCommunicationSendMessageSelfTest.java   |    4 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    2 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |    6 +-
 .../swapspace/GridSwapSpaceManagerSelfTest.java |    2 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |    6 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |    4 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   10 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   50 +
 .../cache/GridCacheAbstractSelfTest.java        |    2 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |    4 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    4 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |    4 +-
 .../GridCacheFinishPartitionsSelfTest.java      |    4 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |    4 +-
 .../processors/cache/GridCacheLeakTest.java     |    2 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    2 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |    2 +-
 .../cache/GridCacheMvccFlagsTest.java           |    4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    4 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |    4 +-
 .../processors/cache/GridCacheMvccSelfTest.java |    4 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |    2 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    2 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |    2 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |    6 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |    2 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |    6 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |    2 +-
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    4 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |    4 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |    2 +-
 .../cache/GridCacheTtlManagerLoadTest.java      |    2 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |    2 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |    2 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../processors/cache/IgniteTxAbstractTest.java  |    2 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |    3 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    2 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    6 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |    2 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    2 +-
 .../GridCacheCountDownLatchSelfTest.java        |    2 +-
 .../GridCacheQueueCleanupSelfTest.java          |    2 +-
 .../GridCacheSetAbstractSelfTest.java           |    8 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |    2 +-
 .../GridCacheAtomicTimeoutSelfTest.java         |    2 +-
 .../distributed/GridCacheEventAbstractTest.java |    2 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |    2 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |    2 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  288 +
 ...iteTxConsistencyRestartAbstractSelfTest.java |    4 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |   10 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |   20 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |    2 +-
 .../dht/GridCacheColocatedDebugTest.java        |    6 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |    2 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    4 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |    4 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |    2 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |    2 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |    2 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |   32 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |    8 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    2 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |    4 +-
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |    6 +-
 .../near/GridCacheNearReadersSelfTest.java      |    4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |    2 +-
 .../GridCachePartitionedFullApiSelfTest.java    |    4 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |    2 +-
 .../GridCachePartitionedProjectionSelfTest.java |    4 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    2 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    2 +-
 .../IgniteCacheTxStoreSessionTest.java          |   11 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    4 +-
 .../clock/GridTimeSyncProcessorSelfTest.java    |    6 +-
 .../continuous/GridEventConsumeSelfTest.java    |    2 +-
 .../processors/fs/GridGgfsAbstractSelfTest.java |    2 +-
 .../processors/fs/GridGgfsModesSelfTest.java    |    4 +-
 .../fs/GridGgfsProcessorSelfTest.java           |    2 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    6 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    4 +-
 .../processors/fs/GridGgfsSizeSelfTest.java     |    8 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |   10 +-
 .../GridServiceReassignmentSelfTest.java        |    2 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  717 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 .../util/future/GridFinishedFutureSelfTest.java |    2 +-
 ...idIpcServerEndpointDeserializerSelfTest.java |  160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |  160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |   76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |   71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |   76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |   71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |  500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |   36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |  267 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |   84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |  500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |   36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |   78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |  267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |   84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |   65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |   35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |  133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |  125 -
 .../IpcSharedMemoryBenchmarkParty.java          |   35 +
 .../IpcSharedMemoryBenchmarkReader.java         |  133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |  125 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../cache/GridCachePutRemoveLoadTest.java       |    2 +-
 .../communication/GridIoManagerBenchmark.java   |   10 +-
 .../communication/GridIoManagerBenchmark0.java  |   12 +-
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |    2 +-
 .../marshaller/GridMarshallerAbstractTest.java  |    6 +-
 .../tcp/GridTcpDiscoveryMultiThreadedTest.java  |    2 +-
 .../discovery/tcp/GridTcpDiscoverySelfTest.java |   14 +-
 .../ignite/testframework/GridTestUtils.java     |    4 +-
 .../testframework/junits/GridAbstractTest.java  |   14 +-
 .../junits/GridTestKernalContext.java           |    2 +-
 .../junits/common/GridCommonAbstractTest.java   |   22 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    2 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    1 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    4 +-
 .../ignite/testsuites/IgniteFsTestSuite.java    |    2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   10 +-
 .../GridHadoopDefaultMapReducePlanner.java      |    2 +-
 .../GridHadoopExternalCommunication.java        |   26 +-
 .../GridHadoopIpcToNioAdapter.java              |    6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |    4 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |    4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |    4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |    4 +-
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |    2 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    6 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    4 +-
 .../cache/GridCacheQueryLoadSelfTest.java       |    2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |    8 +-
 .../GridCacheReplicatedFieldsQuerySelfTest.java |    2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    4 +-
 .../query/h2/sql/GridQueryParsingTest.java      |    2 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    2 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |    2 +-
 .../java/org/apache/ignite/IgniteSpring.java    |    8 +-
 .../cache/spring/SpringDynamicCacheManager.java |    2 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    2 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   26 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |   25 +-
 .../GridServletContextListenerStartup.java      |    4 +-
 .../startup/servlet/GridServletStartup.java     |    4 +-
 326 files changed, 24257 insertions(+), 23673 deletions(-)
----------------------------------------------------------------------



[11/50] [abbrv] incubator-ignite git commit: IGNITE-109 - Merge branch 'ignite-109' into sprint-1

Posted by vo...@apache.org.
IGNITE-109 - Merge branch 'ignite-109' into sprint-1


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

Branch: refs/heads/ignite-16
Commit: 9550905e62dad06717ab666330c1d5b6523adc02
Parents: 61a9f98
Author: Alexey Goncharuk <ag...@gridgain.com>
Authored: Thu Jan 29 19:04:43 2015 -0800
Committer: Alexey Goncharuk <ag...@gridgain.com>
Committed: Thu Jan 29 19:04:43 2015 -0800

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


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9550905e/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCrossCacheTxStoreSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCrossCacheTxStoreSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCrossCacheTxStoreSelfTest.java
index 7df7619..f80549c 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCrossCacheTxStoreSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCrossCacheTxStoreSelfTest.java
@@ -108,7 +108,7 @@ public class IgniteCrossCacheTxStoreSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testWriteThrough() throws Exception {
-        GridEx grid = grid(0);
+        IgniteEx grid = grid(0);
 
         TestStore firstStore = (TestStore)grid(0).configuration().getCacheConfiguration()[1].getCacheStoreFactory().create();
 
@@ -153,7 +153,7 @@ public class IgniteCrossCacheTxStoreSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testIncompatibleCaches1() throws Exception {
-        GridEx grid = grid(0);
+        IgniteEx grid = grid(0);
 
         try (IgniteTx ignored = grid.transactions().txStart()) {
             GridCache<Object, Object> cacheA = grid.cache("cacheA");
@@ -174,7 +174,7 @@ public class IgniteCrossCacheTxStoreSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testIncompatibleCaches2() throws Exception {
-        GridEx grid = grid(0);
+        IgniteEx grid = grid(0);
 
         try (IgniteTx ignored = grid.transactions().txStart()) {
             GridCache<Object, Object> cacheA = grid.cache("cacheA");


[12/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-72-1

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/e19655df/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
index 0000000,7854bd9..e29d04d
mode 000000,100644..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
@@@ -1,0 -1,3322 +1,3322 @@@
+ /*
+  * Licensed to the Apache Software Foundation (ASF) under one or more
+  * contributor license agreements.  See the NOTICE file distributed with
+  * this work for additional information regarding copyright ownership.
+  * The ASF licenses this file to You under the Apache License, Version 2.0
+  * (the "License"); you may not use this file except in compliance with
+  * the License.  You may obtain a copy of the License at
+  *
+  *      http://www.apache.org/licenses/LICENSE-2.0
+  *
+  * Unless required by applicable law or agreed to in writing, software
+  * distributed under the License is distributed on an "AS IS" BASIS,
+  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  * See the License for the specific language governing permissions and
+  * limitations under the License.
+  */
+ 
+ package org.apache.ignite.internal;
+ 
+ import org.apache.ignite.*;
+ import org.apache.ignite.cache.*;
+ import org.apache.ignite.cache.affinity.*;
+ import org.apache.ignite.cluster.*;
+ import org.apache.ignite.configuration.*;
+ import org.apache.ignite.internal.processors.*;
+ import org.apache.ignite.internal.processors.cache.*;
+ import org.apache.ignite.internal.processors.portable.*;
+ import org.apache.ignite.internal.util.*;
+ import org.apache.ignite.lang.*;
+ import org.apache.ignite.lifecycle.*;
+ import org.apache.ignite.marshaller.*;
+ import org.apache.ignite.marshaller.optimized.*;
+ import org.apache.ignite.mxbean.*;
+ import org.apache.ignite.plugin.*;
+ import org.apache.ignite.internal.product.*;
+ import org.apache.ignite.spi.*;
+ import org.apache.ignite.spi.authentication.*;
+ import org.apache.ignite.spi.authentication.noop.*;
+ import org.apache.ignite.hadoop.*;
+ import org.apache.ignite.internal.managers.*;
+ import org.apache.ignite.internal.managers.checkpoint.*;
+ import org.apache.ignite.internal.managers.collision.*;
+ import org.apache.ignite.internal.managers.communication.*;
+ import org.apache.ignite.internal.managers.deployment.*;
+ import org.apache.ignite.internal.managers.discovery.*;
+ import org.apache.ignite.internal.managers.eventstorage.*;
+ import org.apache.ignite.internal.managers.failover.*;
+ import org.apache.ignite.internal.managers.indexing.*;
+ import org.apache.ignite.internal.managers.loadbalancer.*;
+ import org.apache.ignite.internal.managers.securesession.*;
+ import org.apache.ignite.internal.managers.security.*;
+ import org.apache.ignite.internal.managers.swapspace.*;
+ import org.apache.ignite.internal.processors.affinity.*;
+ import org.apache.ignite.internal.processors.clock.*;
+ import org.apache.ignite.internal.processors.closure.*;
+ import org.apache.ignite.internal.processors.continuous.*;
+ import org.apache.ignite.internal.processors.dataload.*;
+ import org.apache.ignite.internal.processors.email.*;
+ import org.apache.ignite.internal.processors.interop.*;
+ import org.apache.ignite.internal.processors.job.*;
+ import org.apache.ignite.internal.processors.jobmetrics.*;
+ import org.apache.ignite.internal.processors.license.*;
+ import org.apache.ignite.internal.processors.offheap.*;
+ import org.apache.ignite.internal.processors.plugin.*;
+ import org.apache.ignite.internal.processors.port.*;
+ import org.apache.ignite.internal.processors.query.*;
+ import org.apache.ignite.internal.processors.resource.*;
+ import org.apache.ignite.internal.processors.rest.*;
+ import org.apache.ignite.internal.processors.segmentation.*;
+ import org.apache.ignite.internal.processors.service.*;
+ import org.apache.ignite.internal.processors.session.*;
+ import org.apache.ignite.internal.processors.streamer.*;
+ import org.apache.ignite.internal.processors.task.*;
+ import org.apache.ignite.internal.processors.timeout.*;
+ import org.apache.ignite.plugin.security.*;
+ import org.apache.ignite.spi.securesession.noop.*;
+ import org.apache.ignite.internal.util.future.*;
+ import org.apache.ignite.internal.util.lang.*;
+ import org.apache.ignite.internal.util.nodestart.*;
+ import org.apache.ignite.internal.util.tostring.*;
+ import org.apache.ignite.internal.util.typedef.*;
+ import org.apache.ignite.internal.util.typedef.internal.*;
+ import org.jetbrains.annotations.*;
+ 
+ import javax.management.*;
+ import java.io.*;
+ import java.lang.management.*;
+ import java.lang.reflect.*;
+ import java.net.*;
+ import java.text.*;
+ import java.util.*;
+ import java.util.concurrent.*;
+ import java.util.concurrent.atomic.*;
+ 
+ import static org.apache.ignite.internal.GridKernalState.*;
+ import static org.apache.ignite.lifecycle.LifecycleEventType.*;
+ import static org.apache.ignite.IgniteSystemProperties.*;
+ import static org.apache.ignite.internal.IgniteComponentType.*;
+ import static org.apache.ignite.internal.GridNodeAttributes.*;
+ import static org.apache.ignite.internal.GridProductImpl.*;
+ import static org.apache.ignite.internal.processors.license.GridLicenseSubsystem.*;
+ import static org.apache.ignite.internal.util.nodestart.GridNodeStartUtils.*;
+ 
+ /**
+  * GridGain kernal.
+  * <p/>
+  * See <a href="http://en.wikipedia.org/wiki/Kernal">http://en.wikipedia.org/wiki/Kernal</a> for information on the
+  * misspelling.
+  */
+ public class IgniteKernal extends ClusterGroupAdapter implements IgniteEx, IgniteMXBean {
+     /** */
+     private static final long serialVersionUID = 0L;
+ 
+     /** Compatible versions. */
+     private static final String COMPATIBLE_VERS = GridProperties.get("gridgain.compatible.vers");
+ 
+     /** GridGain site that is shown in log messages. */
+     static final String SITE = "www.gridgain.com";
+ 
+     /** System line separator. */
+     private static final String NL = U.nl();
+ 
+     /** Periodic version check delay. */
+     private static final long PERIODIC_VER_CHECK_DELAY = 1000 * 60 * 60; // Every hour.
+ 
+     /** Periodic version check delay. */
+     private static final long PERIODIC_VER_CHECK_CONN_TIMEOUT = 10 * 1000; // 10 seconds.
+ 
+     /** Periodic version check delay. */
+     private static final long PERIODIC_LIC_CHECK_DELAY = 1000 * 60; // Every minute.
+ 
+     /** Periodic starvation check interval. */
+     private static final long PERIODIC_STARVATION_CHECK_FREQ = 1000 * 30;
+ 
+     /** Shutdown delay in msec. when license violation detected. */
+     private static final int SHUTDOWN_DELAY = 60 * 1000;
+ 
+     /** */
+     private IgniteConfiguration cfg;
+ 
+     /** */
+     @SuppressWarnings({"FieldAccessedSynchronizedAndUnsynchronized"})
+     @GridToStringExclude
+     private GridLoggerProxy log;
+ 
+     /** */
+     private String gridName;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName kernalMBean;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName locNodeMBean;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName pubExecSvcMBean;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName sysExecSvcMBean;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName mgmtExecSvcMBean;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName p2PExecSvcMBean;
+ 
+     /** */
+     @GridToStringExclude
+     private ObjectName restExecSvcMBean;
+ 
+     /** Kernal start timestamp. */
+     private long startTime = U.currentTimeMillis();
+ 
+     /** Spring context, potentially {@code null}. */
+     private GridSpringResourceContext rsrcCtx;
+ 
+     /** */
+     @GridToStringExclude
+     private Timer updateNtfTimer;
+ 
+     /** */
+     @GridToStringExclude
+     private Timer starveTimer;
+ 
+     /** */
+     @GridToStringExclude
+     private Timer licTimer;
+ 
+     /** */
+     @GridToStringExclude
+     private Timer metricsLogTimer;
+ 
+     /** Indicate error on grid stop. */
+     @GridToStringExclude
+     private boolean errOnStop;
+ 
+     /** Node local store. */
+     @GridToStringExclude
+     private ClusterNodeLocalMap nodeLoc;
+ 
+     /** Scheduler. */
+     @GridToStringExclude
+     private IgniteScheduler scheduler;
+ 
+     /** Grid security instance. */
+     @GridToStringExclude
+     private GridSecurity security;
+ 
+     /** Portables instance. */
+     @GridToStringExclude
+     private IgnitePortables portables;
+ 
+     /** Kernal gateway. */
+     @GridToStringExclude
+     private final AtomicReference<GridKernalGateway> gw = new AtomicReference<>();
+ 
+     /** Data Grid edition usage registered flag. */
+     @GridToStringExclude
+     private volatile boolean dbUsageRegistered;
+ 
+     /** */
+     @GridToStringExclude
+     private final Collection<String> compatibleVers;
+ 
+     /** Stop guard. */
+     @GridToStringExclude
+     private final AtomicBoolean stopGuard = new AtomicBoolean();
+ 
+     /**
+      * No-arg constructor is required by externalization.
+      */
+     public IgniteKernal() {
+         this(null);
+     }
+ 
+     /**
+      * @param rsrcCtx Optional Spring application context.
+      */
+     public IgniteKernal(@Nullable GridSpringResourceContext rsrcCtx) {
+         super(null, null, null, (IgnitePredicate<ClusterNode>)null);
+ 
+         this.rsrcCtx = rsrcCtx;
+ 
+         String[] compatibleVers = COMPATIBLE_VERS.split(",");
+ 
+         for (int i = 0; i < compatibleVers.length; i++)
+             compatibleVers[i] = compatibleVers[i].trim();
+ 
+         this.compatibleVers = Collections.unmodifiableList(Arrays.asList(compatibleVers));
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public IgniteCluster cluster() {
+         return this;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public final IgniteCompute compute(ClusterGroup prj) {
+         return ((ClusterGroupAdapter)prj).compute();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public final IgniteMessaging message(ClusterGroup prj) {
+         return ((ClusterGroupAdapter)prj).message();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public final IgniteEvents events(ClusterGroup prj) {
+         return ((ClusterGroupAdapter)prj).events();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public IgniteManaged managed(ClusterGroup prj) {
+         return ((ClusterGroupAdapter)prj).managed();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public ExecutorService executorService(ClusterGroup prj) {
+         return ((ClusterGroupAdapter)prj).executorService();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String name() {
+         return gridName;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getCopyright() {
+         return ctx.product().copyright();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getLicenseFilePath() {
+         assert cfg != null;
+ 
+         return cfg.getLicenseUrl();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public long getStartTimestamp() {
+         return startTime;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getStartTimestampFormatted() {
+         return DateFormat.getDateTimeInstance().format(new Date(startTime));
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public long getUpTime() {
+         return U.currentTimeMillis() - startTime;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getUpTimeFormatted() {
+         return X.timeSpan2HMSM(U.currentTimeMillis() - startTime);
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getFullVersion() {
+         return COMPOUND_VER + '-' + BUILD_TSTAMP_STR;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getCheckpointSpiFormatted() {
+         assert cfg != null;
+ 
+         return Arrays.toString(cfg.getCheckpointSpi());
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getSwapSpaceSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getSwapSpaceSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getCommunicationSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getCommunicationSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getDeploymentSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getDeploymentSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getDiscoverySpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getDiscoverySpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getEventStorageSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getEventStorageSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getCollisionSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getCollisionSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getFailoverSpiFormatted() {
+         assert cfg != null;
+ 
+         return Arrays.toString(cfg.getFailoverSpi());
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getLoadBalancingSpiFormatted() {
+         assert cfg != null;
+ 
+         return Arrays.toString(cfg.getLoadBalancingSpi());
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getAuthenticationSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getAuthenticationSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getSecureSessionSpiFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getSecureSessionSpi().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getOsInformation() {
+         return U.osString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getJdkInformation() {
+         return U.jdkString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getOsUser() {
+         return System.getProperty("user.name");
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getVmName() {
+         return ManagementFactory.getRuntimeMXBean().getName();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getInstanceName() {
+         return gridName;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getExecutorServiceFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getExecutorService().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getGridGainHome() {
+         assert cfg != null;
+ 
+         return cfg.getGridGainHome();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getGridLoggerFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getGridLogger().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String getMBeanServerFormatted() {
+         assert cfg != null;
+ 
+         return cfg.getMBeanServer().toString();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public UUID getLocalNodeId() {
+         assert cfg != null;
+ 
+         return cfg.getNodeId();
+     }
+ 
+     /** {@inheritDoc} */
+     @SuppressWarnings("unchecked")
+     @Override public Collection<String> getUserAttributesFormatted() {
+         assert cfg != null;
+ 
+         return F.transform(cfg.getUserAttributes().entrySet(), new C1<Map.Entry<String, ?>, String>() {
+             @Override public String apply(Map.Entry<String, ?> e) {
+                 return e.getKey() + ", " + e.getValue().toString();
+             }
+         });
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public boolean isPeerClassLoadingEnabled() {
+         assert cfg != null;
+ 
+         return cfg.isPeerClassLoadingEnabled();
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public Collection<String> getLifecycleBeansFormatted() {
+         LifecycleBean[] beans = cfg.getLifecycleBeans();
+ 
+         return F.isEmpty(beans) ? Collections.<String>emptyList() : F.transform(beans, F.<LifecycleBean>string());
+     }
+ 
+     /**
+      * @param attrs Current attributes.
+      * @param name  New attribute name.
+      * @param val New attribute value.
+      * @throws IgniteCheckedException If duplicated SPI name found.
+      */
+     private void add(Map<String, Object> attrs, String name, @Nullable Serializable val) throws IgniteCheckedException {
+         assert attrs != null;
+         assert name != null;
+ 
+         if (attrs.put(name, val) != null) {
+             if (name.endsWith(ATTR_SPI_CLASS))
+                 // User defined duplicated names for the different SPIs.
+                 throw new IgniteCheckedException("Failed to set SPI attribute. Duplicated SPI name found: " +
+                     name.substring(0, name.length() - ATTR_SPI_CLASS.length()));
+ 
+             // Otherwise it's a mistake of setting up duplicated attribute.
+             assert false : "Duplicate attribute: " + name;
+         }
+     }
+ 
+     /**
+      * Notifies life-cycle beans of grid event.
+      *
+      * @param evt Grid event.
+      * @throws IgniteCheckedException If user threw exception during start.
+      */
+     @SuppressWarnings({"CatchGenericClass"})
+     private void notifyLifecycleBeans(LifecycleEventType evt) throws IgniteCheckedException {
+         if (!cfg.isDaemon() && cfg.getLifecycleBeans() != null)
+             for (LifecycleBean bean : cfg.getLifecycleBeans())
+                 if (bean != null)
+                     bean.onLifecycleEvent(evt);
+     }
+ 
+     /**
+      * Notifies life-cycle beans of grid event.
+      *
+      * @param evt Grid event.
+      */
+     @SuppressWarnings({"CatchGenericClass"})
+     private void notifyLifecycleBeansEx(LifecycleEventType evt) {
+         try {
+             notifyLifecycleBeans(evt);
+         }
+         // Catch generic throwable to secure against user assertions.
+         catch (Throwable e) {
+             U.error(log, "Failed to notify lifecycle bean (safely ignored) [evt=" + evt +
+                 ", gridName=" + gridName + ']', e);
+         }
+     }
+ 
+     /**
+      * @param cfg Grid configuration to use.
+      * @param utilityCachePool Utility cache pool.
+      * @param errHnd Error handler to use for notification about startup problems.
+      * @throws IgniteCheckedException Thrown in case of any errors.
+      */
+     @SuppressWarnings({"CatchGenericClass", "unchecked"})
+     public void start(final IgniteConfiguration cfg, ExecutorService utilityCachePool, GridAbsClosure errHnd)
+         throws IgniteCheckedException {
+         gw.compareAndSet(null, new GridKernalGatewayImpl(cfg.getGridName()));
+ 
+         GridKernalGateway gw = this.gw.get();
+ 
+         gw.writeLock();
+ 
+         try {
+             switch (gw.getState()) {
+                 case STARTED: {
+                     U.warn(log, "Grid has already been started (ignored).");
+ 
+                     return;
+                 }
+ 
+                 case STARTING: {
+                     U.warn(log, "Grid is already in process of being started (ignored).");
+ 
+                     return;
+                 }
+ 
+                 case STOPPING: {
+                     throw new IgniteCheckedException("Grid is in process of being stopped");
+                 }
+ 
+                 case STOPPED: {
+                     break;
+                 }
+             }
+ 
+             gw.setState(STARTING);
+         }
+         finally {
+             gw.writeUnlock();
+         }
+ 
+         assert cfg != null;
+ 
+         // Make sure we got proper configuration.
+         validateCommon(cfg);
+ 
+         gridName = cfg.getGridName();
+ 
+         this.cfg = cfg;
+ 
+         log = (GridLoggerProxy)cfg.getGridLogger().getLogger(getClass().getName() +
+             (gridName != null ? '%' + gridName : ""));
+ 
+         RuntimeMXBean rtBean = ManagementFactory.getRuntimeMXBean();
+ 
+         // Ack various information.
+         ackAsciiLogo();
+         ackConfigUrl();
+         ackDaemon();
+         ackOsInfo();
+         ackLanguageRuntime();
+         ackRemoteManagement();
+         ackVmArguments(rtBean);
+         ackClassPaths(rtBean);
+         ackSystemProperties();
+         ackEnvironmentVariables();
+         ackSmtpConfiguration();
+         ackCacheConfiguration();
+         ackP2pConfiguration();
+ 
+         // Run background network diagnostics.
+         GridDiagnostic.runBackgroundCheck(gridName, cfg.getExecutorService(), log);
+ 
+         boolean notifyEnabled = IgniteSystemProperties.getBoolean(GG_UPDATE_NOTIFIER, true);
+ 
+         GridUpdateNotifier verChecker0 = null;
+ 
+         if (notifyEnabled) {
+             try {
+                 verChecker0 = new GridUpdateNotifier(gridName, VER, SITE, gw, false);
+ 
+                 verChecker0.checkForNewVersion(cfg.getExecutorService(), log);
+             }
+             catch (IgniteCheckedException e) {
+                 if (log.isDebugEnabled())
+                     log.debug("Failed to create GridUpdateNotifier: " + e);
+             }
+         }
+ 
+         final GridUpdateNotifier verChecker = verChecker0;
+ 
+         // Ack 3-rd party licenses location.
+         if (log.isInfoEnabled() && cfg.getGridGainHome() != null)
+             log.info("3-rd party licenses can be found at: " + cfg.getGridGainHome() + File.separatorChar + "libs" +
+                 File.separatorChar + "licenses");
+ 
+         // Check that user attributes are not conflicting
+         // with internally reserved names.
+         for (String name : cfg.getUserAttributes().keySet())
+             if (name.startsWith(ATTR_PREFIX))
+                 throw new IgniteCheckedException("User attribute has illegal name: '" + name + "'. Note that all names " +
+                     "starting with '" + ATTR_PREFIX + "' are reserved for internal use.");
+ 
+         // Ack local node user attributes.
+         logNodeUserAttributes();
+ 
+         // Ack configuration.
+         ackSpis();
+ 
+         Map<String, Object> attrs = createNodeAttributes(cfg, BUILD_TSTAMP_STR);
+ 
+         // Spin out SPIs & managers.
+         try {
+             GridKernalContextImpl ctx =
+                 new GridKernalContextImpl(log, this, cfg, gw, utilityCachePool, ENT);
+ 
+             nodeLoc = new ClusterNodeLocalMapImpl(ctx);
+ 
+             U.onGridStart();
+ 
+             // Set context into rich adapter.
+             setKernalContext(ctx);
+ 
+             // Start and configure resource processor first as it contains resources used
+             // by all other managers and processors.
+             GridResourceProcessor rsrcProc = new GridResourceProcessor(ctx);
+ 
+             rsrcProc.setSpringContext(rsrcCtx);
+ 
+             ctx.product(new GridProductImpl(ctx, verChecker));
+ 
+             scheduler = new IgniteSchedulerImpl(ctx);
+ 
+             startProcessor(ctx, rsrcProc, attrs);
+ 
+             // Inject resources into lifecycle beans.
+             if (!cfg.isDaemon() && cfg.getLifecycleBeans() != null)
+                 for (LifecycleBean bean : cfg.getLifecycleBeans())
+                     if (bean != null)
+                         rsrcProc.inject(bean);
+ 
+             // Lifecycle notification.
+             notifyLifecycleBeans(BEFORE_GRID_START);
+ 
+             // Starts lifecycle aware components.
+             U.startLifecycleAware(lifecycleAwares(cfg));
+ 
+             addHelper(ctx, GGFS_HELPER.create(F.isEmpty(cfg.getGgfsConfiguration())));
+ 
+             startProcessor(ctx, new IgnitePluginProcessor(ctx, cfg), attrs);
+ 
+             // Off-heap processor has no dependencies.
+             startProcessor(ctx, new GridOffHeapProcessor(ctx), attrs);
+ 
+             // Closure processor should be started before all others
+             // (except for resource processor), as many components can depend on it.
+             startProcessor(ctx, new GridClosureProcessor(ctx), attrs);
+ 
+             // Start some other processors (order & place is important).
+             startProcessor(ctx, (GridProcessor)EMAIL.create(ctx, cfg.getSmtpHost() == null), attrs);
+             startProcessor(ctx, new GridPortProcessor(ctx), attrs);
+             startProcessor(ctx, new GridJobMetricsProcessor(ctx), attrs);
+ 
+             // Timeout processor needs to be started before managers,
+             // as managers may depend on it.
+             startProcessor(ctx, new GridTimeoutProcessor(ctx), attrs);
+ 
+             // Start SPI managers.
+             // NOTE: that order matters as there are dependencies between managers.
+             startManager(ctx, createComponent(GridSecurityManager.class, ctx), attrs);
+             startManager(ctx, createComponent(GridSecureSessionManager.class, ctx), attrs);
+             startManager(ctx, new GridIoManager(ctx), attrs);
+             startManager(ctx, new GridCheckpointManager(ctx), attrs);
+ 
+             startManager(ctx, new GridEventStorageManager(ctx), attrs);
+             startManager(ctx, new GridDeploymentManager(ctx), attrs);
+             startManager(ctx, new GridLoadBalancerManager(ctx), attrs);
+             startManager(ctx, new GridFailoverManager(ctx), attrs);
+             startManager(ctx, new GridCollisionManager(ctx), attrs);
+             startManager(ctx, new GridSwapSpaceManager(ctx), attrs);
+             startManager(ctx, new GridIndexingManager(ctx), attrs);
+ 
+             ackSecurity(ctx);
+ 
+             // Start processors before discovery manager, so they will
+             // be able to start receiving messages once discovery completes.
+             startProcessor(ctx, new GridClockSyncProcessor(ctx), attrs);
+             startProcessor(ctx, createComponent(GridLicenseProcessor.class, ctx), attrs);
+             startProcessor(ctx, new GridAffinityProcessor(ctx), attrs);
+             startProcessor(ctx, createComponent(GridSegmentationProcessor.class, ctx), attrs);
+             startProcessor(ctx, new GridQueryProcessor(ctx), attrs);
+             startProcessor(ctx, new GridCacheProcessor(ctx), attrs);
+             startProcessor(ctx, new GridTaskSessionProcessor(ctx), attrs);
+             startProcessor(ctx, new GridJobProcessor(ctx), attrs);
+             startProcessor(ctx, new GridTaskProcessor(ctx), attrs);
+             startProcessor(ctx, (GridProcessor)SCHEDULE.createOptional(ctx), attrs);
+             startProcessor(ctx, createComponent(GridPortableProcessor.class, ctx), attrs);
+             startProcessor(ctx, createComponent(GridInteropProcessor.class, ctx), attrs);
+             startProcessor(ctx, new GridRestProcessor(ctx), attrs);
+             startProcessor(ctx, new GridDataLoaderProcessor(ctx), attrs);
+             startProcessor(ctx, new GridStreamProcessor(ctx), attrs);
+             startProcessor(ctx, (GridProcessor)GGFS.create(ctx, F.isEmpty(cfg.getGgfsConfiguration())), attrs);
+             startProcessor(ctx, new GridContinuousProcessor(ctx), attrs);
+             startProcessor(ctx, (GridProcessor)(cfg.isPeerClassLoadingEnabled() ?
+                 IgniteComponentType.HADOOP.create(ctx, true): // No-op when peer class loading is enabled.
+                 IgniteComponentType.HADOOP.createIfInClassPath(ctx, cfg.getHadoopConfiguration() != null)), attrs);
+             startProcessor(ctx, new GridServiceProcessor(ctx), attrs);
+ 
+             // Start plugins.
+             for (PluginProvider provider : ctx.plugins().allProviders()) {
+                 ctx.add(new GridPluginComponent(provider));
+ 
+                 provider.start(ctx.plugins().pluginContextForProvider(provider), attrs);
+             }
+ 
+             ctx.createMessageFactory();
+ 
+             if (ctx.isEnterprise()) {
+                 security = new GridSecurityImpl(ctx);
+                 portables = new GridPortablesImpl(ctx);
+             }
+ 
+             gw.writeLock();
+ 
+             try {
+                 gw.setState(STARTED);
+ 
+                 // Start discovery manager last to make sure that grid is fully initialized.
+                 startManager(ctx, new GridDiscoveryManager(ctx), attrs);
+             }
+             finally {
+                 gw.writeUnlock();
+             }
+ 
+             // Check whether physical RAM is not exceeded.
+             checkPhysicalRam();
+ 
+             // Suggest configuration optimizations.
+             suggestOptimizations(ctx, cfg);
+ 
+             if (!ctx.isEnterprise())
+                 warnNotSupportedFeaturesForOs(cfg);
+ 
+             // Notify discovery manager the first to make sure that topology is discovered.
+             ctx.discovery().onKernalStart();
+ 
+             // Notify IO manager the second so further components can send and receive messages.
+             ctx.io().onKernalStart();
+ 
+             // Callbacks.
+             for (GridComponent comp : ctx) {
+                 // Skip discovery manager.
+                 if (comp instanceof GridDiscoveryManager)
+                     continue;
+ 
+                 // Skip IO manager.
+                 if (comp instanceof GridIoManager)
+                     continue;
+ 
+                 comp.onKernalStart();
+             }
+ 
+             // Ack the license.
+             ctx.license().ackLicense();
+ 
+             // Register MBeans.
+             registerKernalMBean();
+             registerLocalNodeMBean();
+             registerExecutorMBeans();
+ 
+             // Lifecycle bean notifications.
+             notifyLifecycleBeans(AFTER_GRID_START);
+         }
+         catch (Throwable e) {
+             IgniteSpiVersionCheckException verCheckErr = X.cause(e, IgniteSpiVersionCheckException.class);
+ 
+             if (verCheckErr != null)
+                 U.error(log, verCheckErr.getMessage());
+             else if (X.hasCause(e, InterruptedException.class, IgniteInterruptedException.class))
+                 U.warn(log, "Grid startup routine has been interrupted (will rollback).");
+             else
+                 U.error(log, "Got exception while starting (will rollback startup routine).", e);
+ 
+             errHnd.apply();
+ 
+             stop(true);
+ 
+             if (e instanceof IgniteCheckedException)
+                 throw (IgniteCheckedException)e;
+             else
+                 throw new IgniteCheckedException(e);
+         }
+ 
+         // Mark start timestamp.
+         startTime = U.currentTimeMillis();
+ 
+         // Ack latest version information.
+         if (verChecker != null)
+             verChecker.reportStatus(log);
+ 
+         if (notifyEnabled) {
+             assert verChecker != null;
+ 
+             verChecker.reportOnlyNew(true);
+             verChecker.licenseProcessor(ctx.license());
+ 
 -            updateNtfTimer = new Timer("gridgain-update-notifier-timer");
++            updateNtfTimer = new Timer("ignite-update-notifier-timer");
+ 
+             // Setup periodic version check.
+             updateNtfTimer.scheduleAtFixedRate(new GridTimerTask() {
+                 @Override public void safeRun() throws InterruptedException {
+                     verChecker.topologySize(nodes().size());
+ 
+                     verChecker.checkForNewVersion(cfg.getExecutorService(), log);
+ 
+                     // Just wait for 10 secs.
+                     Thread.sleep(PERIODIC_VER_CHECK_CONN_TIMEOUT);
+ 
+                     // Report status if one is available.
+                     // No-op if status is NOT available.
+                     verChecker.reportStatus(log);
+                 }
+             }, PERIODIC_VER_CHECK_DELAY, PERIODIC_VER_CHECK_DELAY);
+         }
+ 
+         String intervalStr = IgniteSystemProperties.getString(GG_STARVATION_CHECK_INTERVAL);
+ 
+         // Start starvation checker if enabled.
+         boolean starveCheck = !isDaemon() && !"0".equals(intervalStr);
+ 
+         if (starveCheck) {
+             final long interval = F.isEmpty(intervalStr) ? PERIODIC_STARVATION_CHECK_FREQ : Long.parseLong(intervalStr);
+ 
 -            starveTimer = new Timer("gridgain-starvation-checker");
++            starveTimer = new Timer("ignite-starvation-checker");
+ 
+             starveTimer.scheduleAtFixedRate(new GridTimerTask() {
+                 /** Last completed task count. */
+                 private long lastCompletedCnt;
+ 
+                 @Override protected void safeRun() {
+                     ExecutorService e = cfg.getExecutorService();
+ 
+                     if (!(e instanceof ThreadPoolExecutor))
+                         return;
+ 
+                     ThreadPoolExecutor exec = (ThreadPoolExecutor)e;
+ 
+                     long completedCnt = exec.getCompletedTaskCount();
+ 
+                     // If all threads are active and no task has completed since last time and there is
+                     // at least one waiting request, then it is possible starvation.
+                     if (exec.getPoolSize() == exec.getActiveCount() && completedCnt == lastCompletedCnt &&
+                         !exec.getQueue().isEmpty())
+                         LT.warn(log, null, "Possible thread pool starvation detected (no task completed in last " +
+                             interval + "ms, is executorService pool size large enough?)");
+ 
+                     lastCompletedCnt = completedCnt;
+                 }
+             }, interval, interval);
+         }
+ 
+         if (!isDaemon()) {
 -            licTimer = new Timer("gridgain-license-checker");
++            licTimer = new Timer("ignite-license-checker");
+ 
+             // Setup periodic license check.
+             licTimer.scheduleAtFixedRate(new GridTimerTask() {
+                 @Override public void safeRun() throws InterruptedException {
+                     try {
+                         ctx.license().checkLicense();
+                     }
+                     // This exception only happens when license processor was unable
+                     // to resolve license violation on its own and this grid instance
+                     // now needs to be shutdown.
+                     //
+                     // Note that in most production configurations the license will
+                     // have certain grace period and license processor will attempt
+                     // to reload the license during the grace period.
+                     //
+                     // This exception thrown here means that grace period, if any,
+                     // has expired and license violation is still unresolved.
+                     catch (IgniteProductLicenseException ignored) {
+                         U.error(log, "License violation is unresolved. GridGain node will shutdown in " +
+                             (SHUTDOWN_DELAY / 1000) + " sec.");
+                         U.error(log, "  ^-- Contact your support for immediate assistance (!)");
+ 
+                         // Allow interruption to break from here since
+                         // node is stopping anyways.
+                         Thread.sleep(SHUTDOWN_DELAY);
+ 
+                         G.stop(gridName, true);
+                     }
+                     // Safety net.
+                     catch (Throwable e) {
+                         U.error(log, "Unable to check the license due to system error.", e);
+                         U.error(log, "Grid instance will be stopped...");
+ 
+                         // Stop the grid if we get unknown license-related error.
+                         // Should never happen. Practically an assertion...
+                         G.stop(gridName, true);
+                     }
+                 }
+             }, PERIODIC_LIC_CHECK_DELAY, PERIODIC_LIC_CHECK_DELAY);
+         }
+ 
+         long metricsLogFreq = cfg.getMetricsLogFrequency();
+ 
+         if (metricsLogFreq > 0) {
 -            metricsLogTimer = new Timer("gridgain-metrics-logger");
++            metricsLogTimer = new Timer("ignite-metrics-logger");
+ 
+             metricsLogTimer.scheduleAtFixedRate(new GridTimerTask() {
+                 /** */
+                 private final DecimalFormat dblFmt = new DecimalFormat("#.##");
+ 
+                 @Override protected void safeRun() {
+                     if (log.isInfoEnabled()) {
+                         ClusterMetrics m = localNode().metrics();
+ 
+                         double cpuLoadPct = m.getCurrentCpuLoad() * 100;
+                         double avgCpuLoadPct = m.getAverageCpuLoad() * 100;
+                         double gcPct = m.getCurrentGcCpuLoad() * 100;
+ 
+                         long heapUsed = m.getHeapMemoryUsed();
+                         long heapMax = m.getHeapMemoryMaximum();
+ 
+                         long heapUsedInMBytes = heapUsed / 1024 / 1024;
+                         long heapCommInMBytes = m.getHeapMemoryCommitted() / 1024 / 1024;
+ 
+                         double freeHeapPct = heapMax > 0 ? ((double)((heapMax - heapUsed) * 100)) / heapMax : -1;
+ 
+                         int hosts = 0;
+                         int nodes = 0;
+                         int cpus = 0;
+ 
+                         try {
+                             ClusterMetrics metrics = metrics();
+ 
+                             Collection<ClusterNode> nodes0 = nodes();
+ 
+                             hosts = U.neighborhood(nodes0).size();
+                             nodes = nodes0.size();
+                             cpus = metrics.getTotalCpus();
+                         }
+                         catch (IgniteCheckedException ignore) {
+                             // No-op.
+                         }
+ 
+                         int pubPoolActiveThreads = 0;
+                         int pubPoolIdleThreads = 0;
+                         int pubPoolQSize = 0;
+ 
+                         ExecutorService pubExec = cfg.getExecutorService();
+ 
+                         if (pubExec instanceof ThreadPoolExecutor) {
+                             ThreadPoolExecutor exec = (ThreadPoolExecutor)pubExec;
+ 
+                             int poolSize = exec.getPoolSize();
+ 
+                             pubPoolActiveThreads = Math.min(poolSize, exec.getActiveCount());
+                             pubPoolIdleThreads = poolSize - pubPoolActiveThreads;
+                             pubPoolQSize = exec.getQueue().size();
+                         }
+ 
+                         int sysPoolActiveThreads = 0;
+                         int sysPoolIdleThreads = 0;
+                         int sysPoolQSize = 0;
+ 
+                         ExecutorService sysExec = cfg.getSystemExecutorService();
+ 
+                         if (sysExec instanceof ThreadPoolExecutor) {
+                             ThreadPoolExecutor exec = (ThreadPoolExecutor)sysExec;
+ 
+                             int poolSize = exec.getPoolSize();
+ 
+                             sysPoolActiveThreads = Math.min(poolSize, exec.getActiveCount());
+                             sysPoolIdleThreads = poolSize - sysPoolActiveThreads;
+                             sysPoolQSize = exec.getQueue().size();
+                         }
+ 
+                         String msg = NL +
+                             "Metrics for local node (to disable set 'metricsLogFrequency' to 0)" + NL +
+                             "    ^-- H/N/C [hosts=" + hosts + ", nodes=" + nodes + ", CPUs=" + cpus + "]" + NL +
+                             "    ^-- CPU [cur=" + dblFmt.format(cpuLoadPct) + "%, avg=" +
+                                 dblFmt.format(avgCpuLoadPct) + "%, GC=" + dblFmt.format(gcPct) + "%]" + NL +
+                             "    ^-- Heap [used=" + dblFmt.format(heapUsedInMBytes) + "MB, free=" +
+                                 dblFmt.format(freeHeapPct) + "%, comm=" + dblFmt.format(heapCommInMBytes) + "MB]" + NL +
+                             "    ^-- Public thread pool [active=" + pubPoolActiveThreads + ", idle=" +
+                                 pubPoolIdleThreads + ", qSize=" + pubPoolQSize + "]" + NL +
+                             "    ^-- System thread pool [active=" + sysPoolActiveThreads + ", idle=" +
+                                 sysPoolIdleThreads + ", qSize=" + sysPoolQSize + "]" + NL +
+                             "    ^-- Outbound messages queue [size=" + m.getOutboundMessagesQueueSize() + "]";
+ 
+                         log.info(msg);
+                     }
+                 }
+             }, metricsLogFreq, metricsLogFreq);
+         }
+ 
+         ctx.performance().logSuggestions(log, gridName);
+ 
+         ackBenchmarks();
+         ackVisor();
+ 
+         ackStart(rtBean);
+ 
+         if (!isDaemon())
+             ctx.discovery().ackTopology();
+ 
+         // Send node start email notification, if enabled.
+         if (isSmtpEnabled() && isAdminEmailsSet() && cfg.isLifeCycleEmailNotification()) {
+             SB sb = new SB();
+ 
+             for (GridPortRecord rec : ctx.ports().records())
+                 sb.a(rec.protocol()).a(":").a(rec.port()).a(" ");
+ 
+             String nid = localNode().id().toString().toUpperCase();
+             String nid8 = U.id8(localNode().id()).toUpperCase();
+ 
+             IgniteProductLicense lic = ctx.license().license();
+ 
+             String body =
+                 "GridGain node started with the following parameters:" + NL +
+                 NL +
+                 "----" + NL +
+                 "GridGain ver. " + COMPOUND_VER + '#' + BUILD_TSTAMP_STR + "-sha1:" + REV_HASH + NL +
+                 "Grid name: " + gridName + NL +
+                 "Node ID: " + nid + NL +
+                 "Node order: " + localNode().order() + NL +
+                 "Node addresses: " + U.addressesAsString(localNode()) + NL +
+                 "Local ports: " + sb + NL +
+                 "OS name: " + U.osString() + NL +
+                 "OS user: " + System.getProperty("user.name") + NL +
+                 "CPU(s): " + localNode().metrics().getTotalCpus() + NL +
+                 "Heap: " + U.heapSize(localNode(), 2) + "GB" + NL +
+                 "JVM name: " + U.jvmName() + NL +
+                 "JVM vendor: " + U.jvmVendor() + NL +
+                 "JVM version: " + U.jvmVersion() + NL +
+                 "VM name: " + rtBean.getName() + NL;
+ 
+             if (lic != null) {
+                 body +=
+                     "License ID: " + lic.id().toString().toUpperCase() + NL +
+                     "Licensed to: " + lic.userOrganization() + NL;
+             }
+             else
+                 assert !ENT;
+ 
+             body +=
+                 "----" + NL +
+                 NL +
+                 "NOTE:" + NL +
+                 "This message is sent automatically to all configured admin emails." + NL +
+                 "To change this behavior use 'lifeCycleEmailNotify' grid configuration property." +
+                 NL + NL +
+                 "| " + SITE + NL +
+                 "| support@gridgain.com" + NL;
+ 
+             sendAdminEmailAsync("GridGain node started: " + nid8, body, false);
+         }
+     }
+ 
+     /**
+      * Validates common configuration parameters.
+      *
+      * @param cfg Configuration.
+      */
+     private void validateCommon(IgniteConfiguration cfg) {
+         A.notNull(cfg.getNodeId(), "cfg.getNodeId()");
+ 
+         A.notNull(cfg.getMBeanServer(), "cfg.getMBeanServer()");
+         A.notNull(cfg.getGridLogger(), "cfg.getGridLogger()");
+         A.notNull(cfg.getMarshaller(), "cfg.getMarshaller()");
+         A.notNull(cfg.getExecutorService(), "cfg.getExecutorService()");
+         A.notNull(cfg.getUserAttributes(), "cfg.getUserAttributes()");
+ 
+         // All SPIs should be non-null.
+         A.notNull(cfg.getSwapSpaceSpi(), "cfg.getSwapSpaceSpi()");
+         A.notNull(cfg.getCheckpointSpi(), "cfg.getCheckpointSpi()");
+         A.notNull(cfg.getCommunicationSpi(), "cfg.getCommunicationSpi()");
+         A.notNull(cfg.getDeploymentSpi(), "cfg.getDeploymentSpi()");
+         A.notNull(cfg.getDiscoverySpi(), "cfg.getDiscoverySpi()");
+         A.notNull(cfg.getEventStorageSpi(), "cfg.getEventStorageSpi()");
+         A.notNull(cfg.getAuthenticationSpi(), "cfg.getAuthenticationSpi()");
+         A.notNull(cfg.getSecureSessionSpi(), "cfg.getSecureSessionSpi()");
+         A.notNull(cfg.getCollisionSpi(), "cfg.getCollisionSpi()");
+         A.notNull(cfg.getFailoverSpi(), "cfg.getFailoverSpi()");
+         A.notNull(cfg.getLoadBalancingSpi(), "cfg.getLoadBalancingSpi()");
+         A.notNull(cfg.getIndexingSpi(), "cfg.getIndexingSpi()");
+ 
+         A.ensure(cfg.getNetworkTimeout() > 0, "cfg.getNetworkTimeout() > 0");
+         A.ensure(cfg.getNetworkSendRetryDelay() > 0, "cfg.getNetworkSendRetryDelay() > 0");
+         A.ensure(cfg.getNetworkSendRetryCount() > 0, "cfg.getNetworkSendRetryCount() > 0");
+ 
+         if (!F.isEmpty(cfg.getPluginConfigurations())) {
+             for (PluginConfiguration pluginCfg : cfg.getPluginConfigurations())
+                 A.notNull(pluginCfg.providerClass(), "PluginConfiguration.providerClass()");
+         }
+     }
+ 
+     /**
+      * Checks whether physical RAM is not exceeded.
+      */
+     @SuppressWarnings("ConstantConditions")
+     private void checkPhysicalRam() {
+         long ram = ctx.discovery().localNode().attribute(ATTR_PHY_RAM);
+ 
+         if (ram != -1) {
+             String macs = ctx.discovery().localNode().attribute(ATTR_MACS);
+ 
+             long totalHeap = 0;
+ 
+             for (ClusterNode node : ctx.discovery().allNodes()) {
+                 if (macs.equals(node.attribute(ATTR_MACS))) {
+                     long heap = node.metrics().getHeapMemoryMaximum();
+ 
+                     if (heap != -1)
+                         totalHeap += heap;
+                 }
+             }
+ 
+             if (totalHeap > ram) {
+                 U.quietAndWarn(log, "Attempting to start more nodes than physical RAM " +
+                     "available on current host (this can cause significant slowdown)");
+             }
+         }
+     }
+ 
+     /**
+      * @param ctx Context.
+      * @param cfg Configuration to check for possible performance issues.
+      */
+     private void suggestOptimizations(GridKernalContext ctx, IgniteConfiguration cfg) {
+         GridPerformanceSuggestions perf = ctx.performance();
+ 
+         if (ctx.collision().enabled())
+             perf.add("Disable collision resolution (remove 'collisionSpi' from configuration)");
+ 
+         if (ctx.checkpoint().enabled())
+             perf.add("Disable checkpoints (remove 'checkpointSpi' from configuration)");
+ 
+         if (cfg.isPeerClassLoadingEnabled())
+             perf.add("Disable peer class loading (set 'peerClassLoadingEnabled' to false)");
+ 
+         if (cfg.isMarshalLocalJobs())
+             perf.add("Disable local jobs marshalling (set 'marshalLocalJobs' to false)");
+ 
+         if (cfg.getIncludeEventTypes() != null && cfg.getIncludeEventTypes().length != 0)
+             perf.add("Disable grid events (remove 'includeEventTypes' from configuration)");
+ 
+         if (IgniteOptimizedMarshaller.available() && !(cfg.getMarshaller() instanceof IgniteOptimizedMarshaller))
+             perf.add("Enable optimized marshaller (set 'marshaller' to " +
+                 IgniteOptimizedMarshaller.class.getSimpleName() + ')');
+     }
+ 
+     /**
+      * Warns user about unsupported features which was configured in OS edition.
+      *
+      * @param cfg Grid configuration.
+      */
+     private void warnNotSupportedFeaturesForOs(IgniteConfiguration cfg) {
+         Collection<String> msgs = new ArrayList<>();
+ 
+         if (!F.isEmpty(cfg.getSegmentationResolvers()))
+             msgs.add("Network segmentation detection.");
+ 
+         if (cfg.getSecureSessionSpi() != null && !(cfg.getSecureSessionSpi() instanceof NoopSecureSessionSpi))
+             msgs.add("Secure session SPI.");
+ 
+         if (cfg.getAuthenticationSpi() != null && !(cfg.getAuthenticationSpi() instanceof NoopAuthenticationSpi))
+             msgs.add("Authentication SPI.");
+ 
+         if (!F.isEmpty(msgs)) {
+             U.quietAndInfo(log, "The following features are not supported in open source edition, " +
+                 "related configuration settings will be ignored " +
+                 "(consider downloading enterprise edition from http://www.gridgain.com):");
+ 
+             for (String s : msgs)
+                 U.quietAndInfo(log, "  ^-- " + s);
+ 
+             U.quietAndInfo(log, "");
+         }
+     }
+ 
+     /**
+      * Creates attributes map and fills it in.
+      *
+      * @param cfg Grid configuration.
+      * @param build Build string.
+      * @return Map of all node attributes.
+      * @throws IgniteCheckedException thrown if was unable to set up attribute.
+      */
+     @SuppressWarnings({"SuspiciousMethodCalls", "unchecked", "TypeMayBeWeakened"})
+     private Map<String, Object> createNodeAttributes(IgniteConfiguration cfg, String build) throws IgniteCheckedException {
+         Map<String, Object> attrs = new HashMap<>();
+ 
+         final String[] incProps = cfg.getIncludeProperties();
+ 
+         try {
+             // Stick all environment settings into node attributes.
+             attrs.putAll(F.view(System.getenv(), new P1<String>() {
+                 @Override public boolean apply(String name) {
+                     return incProps == null || U.containsStringArray(incProps, name, true) ||
+                         U.isVisorNodeStartProperty(name) || U.isVisorRequiredProperty(name);
+                 }
+             }));
+ 
+             if (log.isDebugEnabled())
+                 log.debug("Added environment properties to node attributes.");
+         }
+         catch (SecurityException e) {
+             throw new IgniteCheckedException("Failed to add environment properties to node attributes due to " +
+                 "security violation: " + e.getMessage());
+         }
+ 
+         try {
+             // Stick all system properties into node's attributes overwriting any
+             // identical names from environment properties.
+             for (Map.Entry<Object, Object> e : F.view(System.getProperties(), new P1<Object>() {
+                 @Override public boolean apply(Object o) {
+                     String name = (String)o;
+ 
+                     return incProps == null || U.containsStringArray(incProps, name, true) ||
+                         U.isVisorRequiredProperty(name);
+                 }
+             }).entrySet()) {
+                 Object val = attrs.get(e.getKey());
+ 
+                 if (val != null && !val.equals(e.getValue()))
+                     U.warn(log, "System property will override environment variable with the same name: "
+                         + e.getKey());
+ 
+                 attrs.put((String)e.getKey(), e.getValue());
+             }
+ 
+             if (log.isDebugEnabled())
+                 log.debug("Added system properties to node attributes.");
+         }
+         catch (SecurityException e) {
+             throw new IgniteCheckedException("Failed to add system properties to node attributes due to security " +
+                 "violation: " + e.getMessage());
+         }
+ 
+         // Add local network IPs and MACs.
+         String ips = F.concat(U.allLocalIps(), ", "); // Exclude loopbacks.
+         String macs = F.concat(U.allLocalMACs(), ", "); // Only enabled network interfaces.
+ 
+         // Ack network context.
+         if (log.isInfoEnabled()) {
+             log.info("Non-loopback local IPs: " + (F.isEmpty(ips) ? "N/A" : ips));
+             log.info("Enabled local MACs: " + (F.isEmpty(macs) ? "N/A" : macs));
+         }
+ 
+         // Warn about loopback.
+         if (ips.isEmpty() && macs.isEmpty())
+             U.warn(log, "GridGain is starting on loopback address... Only nodes on the same physical " +
+                 "computer can participate in topology.",
+                 "GridGain is starting on loopback address...");
+ 
+         // Stick in network context into attributes.
+         add(attrs, ATTR_IPS, (ips.isEmpty() ? "" : ips));
+         add(attrs, ATTR_MACS, (macs.isEmpty() ? "" : macs));
+ 
+         // Stick in some system level attributes
+         add(attrs, ATTR_JIT_NAME, U.getCompilerMx() == null ? "" : U.getCompilerMx().getName());
+         add(attrs, ATTR_BUILD_VER, COMPOUND_VER);
+         add(attrs, ATTR_BUILD_DATE, build);
+         add(attrs, ATTR_COMPATIBLE_VERS, (Serializable)compatibleVersions());
+         add(attrs, ATTR_MARSHALLER, cfg.getMarshaller().getClass().getName());
+         add(attrs, ATTR_USER_NAME, System.getProperty("user.name"));
+         add(attrs, ATTR_GRID_NAME, gridName);
+ 
+         add(attrs, ATTR_PEER_CLASSLOADING, cfg.isPeerClassLoadingEnabled());
+         add(attrs, ATTR_DEPLOYMENT_MODE, cfg.getDeploymentMode());
+         add(attrs, ATTR_LANG_RUNTIME, getLanguage());
+ 
+         add(attrs, ATTR_JVM_PID, U.jvmPid());
+ 
+         // Build a string from JVM arguments, because parameters with spaces are split.
+         SB jvmArgs = new SB(512);
+ 
+         for (String arg : U.jvmArgs()) {
+             if (arg.startsWith("-"))
+                 jvmArgs.a("@@@");
+             else
+                 jvmArgs.a(' ');
+ 
+             jvmArgs.a(arg);
+         }
+         // Add it to attributes.
+         add(attrs, ATTR_JVM_ARGS, jvmArgs.toString());
+ 
+         // Check daemon system property and override configuration if it's set.
+         if (isDaemon())
+             add(attrs, ATTR_DAEMON, "true");
+ 
+         // In case of the parsing error, JMX remote disabled or port not being set
+         // node attribute won't be set.
+         if (isJmxRemoteEnabled()) {
+             String portStr = System.getProperty("com.sun.management.jmxremote.port");
+ 
+             if (portStr != null)
+                 try {
+                     add(attrs, ATTR_JMX_PORT, Integer.parseInt(portStr));
+                 }
+                 catch (NumberFormatException ignore) {
+                     // No-op.
+                 }
+         }
+ 
+         // Whether restart is enabled and stick the attribute.
+         add(attrs, ATTR_RESTART_ENABLED, Boolean.toString(isRestartEnabled()));
+ 
+         // Save port range, port numbers will be stored by rest processor at runtime.
+         if (cfg.getClientConnectionConfiguration() != null)
+             add(attrs, ATTR_REST_PORT_RANGE, cfg.getClientConnectionConfiguration().getRestPortRange());
+ 
+         try {
+             AuthenticationSpi authSpi = cfg.getAuthenticationSpi();
+ 
+             boolean securityEnabled = authSpi != null && !U.hasAnnotation(authSpi.getClass(), IgniteSpiNoop.class);
+ 
+             GridSecurityCredentialsProvider provider = cfg.getSecurityCredentialsProvider();
+ 
+             if (provider != null) {
+                 GridSecurityCredentials cred = provider.credentials();
+ 
+                 if (cred != null)
+                     add(attrs, ATTR_SECURITY_CREDENTIALS, cred);
+                 else if (securityEnabled)
+                     throw new IgniteCheckedException("Failed to start node (authentication SPI is configured, " +
+                         "by security credentials provider returned null).");
+             }
+             else if (securityEnabled)
+                 throw new IgniteCheckedException("Failed to start node (authentication SPI is configured, " +
+                     "but security credentials provider is not set. Fix the configuration and restart the node).");
+         }
+         catch (IgniteCheckedException e) {
+             throw new IgniteCheckedException("Failed to create node security credentials", e);
+         }
+ 
+         // Stick in SPI versions and classes attributes.
+         addAttributes(attrs, cfg.getCollisionSpi());
+         addAttributes(attrs, cfg.getSwapSpaceSpi());
+         addAttributes(attrs, cfg.getDiscoverySpi());
+         addAttributes(attrs, cfg.getFailoverSpi());
+         addAttributes(attrs, cfg.getCommunicationSpi());
+         addAttributes(attrs, cfg.getEventStorageSpi());
+         addAttributes(attrs, cfg.getCheckpointSpi());
+         addAttributes(attrs, cfg.getLoadBalancingSpi());
+         addAttributes(attrs, cfg.getAuthenticationSpi());
+         addAttributes(attrs, cfg.getSecureSessionSpi());
+         addAttributes(attrs, cfg.getDeploymentSpi());
+ 
+         // Set user attributes for this node.
+         if (cfg.getUserAttributes() != null) {
+             for (Map.Entry<String, ?> e : cfg.getUserAttributes().entrySet()) {
+                 if (attrs.containsKey(e.getKey()))
+                     U.warn(log, "User or internal attribute has the same name as environment or system " +
+                         "property and will take precedence: " + e.getKey());
+ 
+                 attrs.put(e.getKey(), e.getValue());
+             }
+         }
+ 
+         return attrs;
+     }
+ 
+     /**
+      * Add SPI version and class attributes into node attributes.
+      *
+      * @param attrs Node attributes map to add SPI attributes to.
+      * @param spiList Collection of SPIs to get attributes from.
+      * @throws IgniteCheckedException Thrown if was unable to set up attribute.
+      */
+     private void addAttributes(Map<String, Object> attrs, IgniteSpi... spiList) throws IgniteCheckedException {
+         for (IgniteSpi spi : spiList) {
+             Class<? extends IgniteSpi> spiCls = spi.getClass();
+ 
+             add(attrs, U.spiAttribute(spi, ATTR_SPI_CLASS), spiCls.getName());
+         }
+     }
+ 
+     /** @throws IgniteCheckedException If registration failed. */
+     private void registerKernalMBean() throws IgniteCheckedException {
+         try {
+             kernalMBean = U.registerMBean(
+                 cfg.getMBeanServer(),
+                 cfg.getGridName(),
+                 "Kernal",
+                 getClass().getSimpleName(),
+                 this,
+                 IgniteMXBean.class);
+ 
+             if (log.isDebugEnabled())
+                 log.debug("Registered kernal MBean: " + kernalMBean);
+         }
+         catch (JMException e) {
+             kernalMBean = null;
+ 
+             throw new IgniteCheckedException("Failed to register kernal MBean.", e);
+         }
+     }
+ 
+     /** @throws IgniteCheckedException If registration failed. */
+     private void registerLocalNodeMBean() throws IgniteCheckedException {
+         ClusterLocalNodeMetricsMXBean mbean = new ClusterLocalNodeMetricsMXBeanImpl(ctx.discovery().localNode());
+ 
+         try {
+             locNodeMBean = U.registerMBean(
+                 cfg.getMBeanServer(),
+                 cfg.getGridName(),
+                 "Kernal",
+                 mbean.getClass().getSimpleName(),
+                 mbean,
+                 ClusterLocalNodeMetricsMXBean.class);
+ 
+             if (log.isDebugEnabled())
+                 log.debug("Registered local node MBean: " + locNodeMBean);
+         }
+         catch (JMException e) {
+             locNodeMBean = null;
+ 
+             throw new IgniteCheckedException("Failed to register local node MBean.", e);
+         }
+     }
+ 
+     /** @throws IgniteCheckedException If registration failed. */
+     private void registerExecutorMBeans() throws IgniteCheckedException {
+         pubExecSvcMBean = registerExecutorMBean(cfg.getExecutorService(), "GridExecutionExecutor");
+         sysExecSvcMBean = registerExecutorMBean(cfg.getSystemExecutorService(), "GridSystemExecutor");
+         mgmtExecSvcMBean = registerExecutorMBean(cfg.getManagementExecutorService(), "GridManagementExecutor");
+         p2PExecSvcMBean = registerExecutorMBean(cfg.getPeerClassLoadingExecutorService(), "GridClassLoadingExecutor");
+ 
+         ClientConnectionConfiguration clientCfg = cfg.getClientConnectionConfiguration();
+ 
+         if (clientCfg != null) {
+             restExecSvcMBean = clientCfg.getRestExecutorService() != null ?
+                 registerExecutorMBean(clientCfg.getRestExecutorService(), "GridRestExecutor") : null;
+         }
+     }
+ 
+     /**
+      * @param exec Executor service to register.
+      * @param name Property name for executor.
+      * @return Name for created MBean.
+      * @throws IgniteCheckedException If registration failed.
+      */
+     private ObjectName registerExecutorMBean(ExecutorService exec, String name) throws IgniteCheckedException {
+         assert exec != null;
+ 
+         try {
+             ObjectName res = U.registerMBean(
+                 cfg.getMBeanServer(),
+                 cfg.getGridName(),
+                 "Thread Pools",
+                 name,
+                 new IgniteThreadPoolMXBeanAdapter(exec),
+                 IgniteThreadPoolMXBean.class);
+ 
+             if (log.isDebugEnabled())
+                 log.debug("Registered executor service MBean: " + res);
+ 
+             return res;
+         }
+         catch (JMException e) {
+             throw new IgniteCheckedException("Failed to register executor service MBean [name=" + name + ", exec=" + exec + ']',
+                 e);
+         }
+     }
+ 
+     /**
+      * Unregisters given mbean.
+      *
+      * @param mbean MBean to unregister.
+      * @return {@code True} if successfully unregistered, {@code false} otherwise.
+      */
+     private boolean unregisterMBean(@Nullable ObjectName mbean) {
+         if (mbean != null)
+             try {
+                 cfg.getMBeanServer().unregisterMBean(mbean);
+ 
+                 if (log.isDebugEnabled())
+                     log.debug("Unregistered MBean: " + mbean);
+ 
+                 return true;
+             }
+             catch (JMException e) {
+                 U.error(log, "Failed to unregister MBean.", e);
+ 
+                 return false;
+             }
+ 
+         return true;
+     }
+ 
+     /**
+      * @param ctx Kernal context.
+      * @param mgr Manager to start.
+      * @param attrs SPI attributes to set.
+      * @throws IgniteCheckedException Throw in case of any errors.
+      */
+     private void startManager(GridKernalContextImpl ctx, GridManager mgr, Map<String, Object> attrs)
+         throws IgniteCheckedException {
+         mgr.addSpiAttributes(attrs);
+ 
+         // Set all node attributes into discovery manager,
+         // so they can be distributed to all nodes.
+         if (mgr instanceof GridDiscoveryManager)
+             ((GridDiscoveryManager)mgr).setNodeAttributes(attrs, ctx.product().version());
+ 
+         // Add manager to registry before it starts to avoid
+         // cases when manager is started but registry does not
+         // have it yet.
+         ctx.add(mgr);
+ 
+         try {
+             mgr.start();
+         }
+         catch (IgniteCheckedException e) {
+             throw new IgniteCheckedException("Failed to start manager: " + mgr, e);
+         }
+     }
+ 
+     /**
+      * @param ctx Kernal context.
+      * @param proc Processor to start.
+      * @param attrs Attributes.
+      * @throws IgniteCheckedException Thrown in case of any error.
+      */
+     private void startProcessor(GridKernalContextImpl ctx, GridProcessor proc, Map<String, Object> attrs)
+         throws IgniteCheckedException {
+         ctx.add(proc);
+ 
+         try {
+             proc.start();
+ 
+             proc.addAttributes(attrs);
+         }
+         catch (IgniteCheckedException e) {
+             throw new IgniteCheckedException("Failed to start processor: " + proc, e);
+         }
+     }
+ 
+     /**
+      * Add helper.
+      *
+      * @param ctx Context.
+      * @param helper Helper.
+      */
+     private void addHelper(GridKernalContextImpl ctx, Object helper) {
+         ctx.addHelper(helper);
+     }
+ 
+     /**
+      * Gets "on" or "off" string for given boolean value.
+      *
+      * @param b Boolean value to convert.
+      * @return Result string.
+      */
+     private String onOff(boolean b) {
+         return b ? "on" : "off";
+     }
+ 
+     /**
+      *
+      * @return Whether or not REST is enabled.
+      */
+     private boolean isRestEnabled() {
+         assert cfg != null;
+ 
+         return cfg.getClientConnectionConfiguration() != null;
+     }
+ 
+     /**
+      * Acks remote management.
+      */
+     private void ackRemoteManagement() {
+         assert log != null;
+ 
+         if (!log.isInfoEnabled())
+             return;
+ 
+         SB sb = new SB();
+ 
+         sb.a("Remote Management [");
+ 
+         boolean on = isJmxRemoteEnabled();
+ 
+         sb.a("restart: ").a(onOff(isRestartEnabled())).a(", ");
+         sb.a("REST: ").a(onOff(isRestEnabled())).a(", ");
+         sb.a("JMX (");
+         sb.a("remote: ").a(onOff(on));
+ 
+         if (on) {
+             sb.a(", ");
+ 
+             sb.a("port: ").a(System.getProperty("com.sun.management.jmxremote.port", "<n/a>")).a(", ");
+             sb.a("auth: ").a(onOff(Boolean.getBoolean("com.sun.management.jmxremote.authenticate"))).a(", ");
+ 
+             // By default SSL is enabled, that's why additional check for null is needed.
+             // See http://docs.oracle.com/javase/6/docs/technotes/guides/management/agent.html
+             sb.a("ssl: ").a(onOff(Boolean.getBoolean("com.sun.management.jmxremote.ssl") ||
+                 System.getProperty("com.sun.management.jmxremote.ssl") == null));
+         }
+ 
+         sb.a(")");
+ 
+         sb.a(']');
+ 
+         log.info(sb.toString());
+     }
+ 
+     /**
+      * Acks configuration URL.
+      */
+     private void ackConfigUrl() {
+         assert log != null;
+ 
+         if (log.isInfoEnabled())
+             log.info("Config URL: " + System.getProperty(GG_CONFIG_URL, "n/a"));
+     }
+ 
+     /**
+      * Acks Visor instructions.
+      */
+     private void ackVisor() {
+         assert log != null;
+ 
+         if (isDaemon())
+             return;
+ 
+         if (ctx.isEnterprise())
+             U.quietAndInfo(log, "To start GUI Management & Monitoring run ggvisorui.{sh|bat}");
+         else
+             U.quietAndInfo(log, "To start Console Management & Monitoring run ggvisorcmd.{sh|bat}");
+     }
+ 
+     /**
+      * Acks benchmarking instructions.
+      */
+     private void ackBenchmarks() {
+         if (!isDaemon())
+             U.quietAndInfo(log, "If running benchmarks, see http://bit.ly/GridGain-Benchmarking");
+     }
+ 
+     /**
+      * Acks ASCII-logo. Thanks to http://patorjk.com/software/taag
+      */
+     private void ackAsciiLogo() {
+         assert log != null;
+ 
+         String fileName = log.fileName();
+ 
+         if (System.getProperty(GG_NO_ASCII) == null) {
+             String ver = "ver. " + ACK_VER;
+ 
+             // Big thanks to: http://patorjk.com/software/taag
+             // Font name "Small Slant"
+             if (log.isQuiet()) {
+                 U.quiet(false,
+                     "   __________  ________________ ",
+                     "  /  _/ ___/ |/ /  _/_  __/ __/ ",
+                     " _/ // (_ /    // /  / / / _/   ",
+                     "/___/\\___/_/|_/___/ /_/ /___/  ",
+                     " ",
+                     ver,
+                     COPYRIGHT,
+                     "",
+                     "Quiet mode.");
+ 
+                 if (fileName != null)
+                     U.quiet(false, "  ^-- Logging to file '" +  fileName + '\'');
+ 
+                 U.quiet(false,
+                     "  ^-- To see **FULL** console log here add -DGRIDGAIN_QUIET=false or \"-v\" to ggstart.{sh|bat}",
+                     "");
+             }
+ 
+             if (log.isInfoEnabled()) {
+                 log.info(NL + NL +
+                     ">>>    __________  ________________  " + NL +
+                     ">>>   /  _/ ___/ |/ /  _/_  __/ __/  " + NL +
+                     ">>>  _/ // (_ /    // /  / / / _/    " + NL +
+                     ">>> /___/\\___/_/|_/___/ /_/ /___/   " + NL +
+                     ">>> " + NL +
+                     ">>> " + ver + NL +
+                     ">>> " + COPYRIGHT + NL
+                 );
+             }
+         }
+     }
+ 
+     /**
+      * Prints start info.
+      *
+      * @param rtBean Java runtime bean.
+      */
+     private void ackStart(RuntimeMXBean rtBean) {
+         if (log.isQuiet()) {
+             U.quiet(false, "");
+             U.quiet(false, "GridGain node started OK (id=" + U.id8(localNode().id()) +
+                 (F.isEmpty(gridName) ? "" : ", grid=" + gridName) + ')');
+         }
+ 
+         if (log.isInfoEnabled()) {
+             log.info("");
+ 
+             String ack = "GridGain ver. " + COMPOUND_VER + '#' + BUILD_TSTAMP_STR + "-sha1:" + REV_HASH;
+ 
+             String dash = U.dash(ack.length());
+ 
+             SB sb = new SB();
+ 
+             for (GridPortRecord rec : ctx.ports().records())
+                 sb.a(rec.protocol()).a(":").a(rec.port()).a(" ");
+ 
+             String str =
+                 NL + NL +
+                     ">>> " + dash + NL +
+                     ">>> " + ack + NL +
+                     ">>> " + dash + NL +
+                     ">>> OS name: " + U.osString() + NL +
+                     ">>> CPU(s): " + localNode().metrics().getTotalCpus() + NL +
+                     ">>> Heap: " + U.heapSize(localNode(), 2) + "GB" + NL +
+                     ">>> VM name: " + rtBean.getName() + NL +
+                     ">>> Grid name: " + gridName + NL +
+                     ">>> Local node [" +
+                     "ID=" + localNode().id().toString().toUpperCase() +
+                     ", order=" + localNode().order() +
+                     "]" + NL +
+                     ">>> Local node addresses: " + U.addressesAsString(localNode()) + NL +
+                     ">>> Local ports: " + sb + NL;
+ 
+             str += ">>> GridGain documentation: http://" + SITE + "/documentation" + NL;
+ 
+             log.info(str);
+         }
+     }
+ 
+     /**
+      * Logs out OS information.
+      */
+     private void ackOsInfo() {
+         assert log != null;
+ 
+         if (log.isInfoEnabled()) {
+             log.info("OS: " + U.osString());
+             log.info("OS user: " + System.getProperty("user.name"));
+         }
+     }
+ 
+     /**
+      * Logs out language runtime.
+      */
+     private void ackLanguageRuntime() {
+         assert log != null;
+ 
+         if (log.isInfoEnabled()) {
+             log.info("Language runtime: " + getLanguage());
+             log.info("VM information: " + U.jdkString());
+             log.info("VM total memory: " + U.heapSize(2) + "GB");
+         }
+     }
+ 
+     /**
+      * @return Language runtime.
+      */
+     @SuppressWarnings("ThrowableInstanceNeverThrown")
+     private String getLanguage() {
+         boolean scala = false;
+         boolean groovy = false;
+         boolean clojure = false;
+ 
+         for (StackTraceElement elem : Thread.currentThread().getStackTrace()) {
+             String s = elem.getClassName().toLowerCase();
+ 
+             if (s.contains("scala")) {
+                 scala = true;
+ 
+                 break;
+             }
+             else if (s.contains("groovy")) {
+                 groovy = true;
+ 
+                 break;
+             }
+             else if (s.contains("clojure")) {
+                 clojure = true;
+ 
+                 break;
+             }
+         }
+ 
+         if (scala) {
+             try (InputStream in = getClass().getResourceAsStream("/library.properties")) {
+                 Properties props = new Properties();
+ 
+                 if (in != null)
+                     props.load(in);
+ 
+                 return "Scala ver. " + props.getProperty("version.number", "<unknown>");
+             }
+             catch (Throwable ignore) {
+                 return "Scala ver. <unknown>";
+             }
+         }
+ 
+         // How to get Groovy and Clojure version at runtime?!?
+         return groovy ? "Groovy" : clojure ? "Clojure" : U.jdkName() + " ver. " + U.jdkVersion();
+     }
+ 
+     /**
+      * Stops grid instance.
+      *
+      * @param cancel Whether or not to cancel running jobs.
+      */
+     public void stop(boolean cancel) {
+         // Make sure that thread stopping grid is not interrupted.
+         boolean interrupted = Thread.interrupted();
+ 
+         try {
+             stop0(cancel);
+         }
+         finally {
+             if (interrupted)
+                 Thread.currentThread().interrupt();
+         }
+     }
+ 
+     /**
+      * @param cancel Whether or not to cancel running jobs.
+      */
+     private void stop0(boolean cancel) {
+         String nid = getLocalNodeId().toString().toUpperCase();
+         String nid8 = U.id8(getLocalNodeId()).toUpperCase();
+ 
+         gw.compareAndSet(null, new GridKernalGatewayImpl(gridName));
+ 
+         GridKernalGateway gw = this.gw.get();
+ 
+         if (stopGuard.compareAndSet(false, true)) {
+             // Only one thread is allowed to perform stop sequence.
+             boolean firstStop = false;
+ 
+             GridKernalState state = gw.getState();
+ 
+             if (state == STARTED)
+                 firstStop = true;
+             else if (state == STARTING)
+                 U.warn(log, "Attempt to stop starting grid. This operation " +
+                     "cannot be guaranteed to be successful.");
+ 
+             if (firstStop) {
+                 // Notify lifecycle beans.
+                 if (log.isDebugEnabled())
+                     log.debug("Notifying lifecycle beans.");
+ 
+                 notifyLifecycleBeansEx(LifecycleEventType.BEFORE_GRID_STOP);
+             }
+ 
+             IgniteEmailProcessorAdapter email = ctx.email();
+ 
+             List<GridComponent> comps = ctx.components();
+ 
+             // Callback component in reverse order while kernal is still functional
+             // if called in the same thread, at least.
+             for (ListIterator<GridComponent> it = comps.listIterator(comps.size()); it.hasPrevious();) {
+                 GridComponent comp = it.previous();
+ 
+                 try {
+                     comp.onKernalStop(cancel);
+                 }
+                 catch (Throwable e) {
+                     errOnStop = true;
+ 
+                     U.error(log, "Failed to pre-stop processor: " + comp, e);
+                 }
+             }
+ 
+             // Cancel update notification timer.
+             if (updateNtfTimer != null)
+                 updateNtfTimer.cancel();
+ 
+             if (starveTimer != null)
+                 starveTimer.cancel();
+ 
+             // Cancel license timer.
+             if (licTimer != null)
+                 licTimer.cancel();
+ 
+             // Cancel metrics log timer.
+             if (metricsLogTimer != null)
+                 metricsLogTimer.cancel();
+ 
+             gw.writeLock();
+ 
+             try {
+                 assert gw.getState() == STARTED || gw.getState() == STARTING;
+ 
+                 // No more kernal calls from this point on.
+                 gw.setState(STOPPING);
+ 
+                 // Clear node local store.
+                 nodeLoc.clear();
+ 
+                 if (log.isDebugEnabled())
+                     log.debug("Grid " + (gridName == null ? "" : '\'' + gridName + "' ") + "is stopping.");
+             }
+             finally {
+                 gw.writeUnlock();
+             }
+ 
+             // Unregister MBeans.
+             if (!(
+                 unregisterMBean(pubExecSvcMBean) &
+                     unregisterMBean(sysExecSvcMBean) &
+                     unregisterMBean(mgmtExecSvcMBean) &
+                     unregisterMBean(p2PExecSvcMBean) &
+                     unregisterMBean(kernalMBean) &
+                     unregisterMBean(locNodeMBean) &
+                     unregisterMBean(restExecSvcMBean)
+             ))
+                 errOnStop = false;
+ 
+             // Stop components in reverse order.
+             for (ListIterator<GridComponent> it = comps.listIterator(comps.size()); it.hasPrevious();) {
+                 GridComponent comp = it.previous();
+ 
+                 try {
+                     comp.stop(cancel);
+ 
+                     if (log.isDebugEnabled())
+                         log.debug("Component stopped: " + comp);
+                 }
+                 catch (Throwable e) {
+                     errOnStop = true;
+ 
+                     U.error(log, "Failed to stop component (ignoring): " + comp, e);
+                 }
+             }
+ 
+             // Stops lifecycle aware components.
+             U.stopLifecycleAware(log, lifecycleAwares(cfg));
+ 
+             // Lifecycle notification.
+             notifyLifecycleBeansEx(LifecycleEventType.AFTER_GRID_STOP);
+ 
+             // Clean internal class/classloader caches to avoid stopped contexts held in memory.
+             IgniteOptimizedMarshaller.clearCache();
+             IgniteMarshallerExclusions.clearCache();
+             GridEnumCache.clear();
+ 
+             gw.writeLock();
+ 
+             try {
+                 gw.setState(STOPPED);
+             }
+             finally {
+                 gw.writeUnlock();
+             }
+ 
+             // Ack stop.
+             if (log.isQuiet()) {
+                 if (!errOnStop)
+                     U.quiet(false, "GridGain node stopped OK [uptime=" +
+                         X.timeSpan2HMSM(U.currentTimeMillis() - startTime) + ']');
+                 else
+                     U.quiet(true, "GridGain node stopped wih ERRORS [uptime=" +
+                         X.timeSpan2HMSM(U.currentTimeMillis() - startTime) + ']');
+             }
+ 
+             if (log.isInfoEnabled())
+                 if (!errOnStop) {
+                     String ack = "GridGain ver. " + COMPOUND_VER + '#' + BUILD_TSTAMP_STR + "-sha1:" + REV_HASH +
+                         " stopped OK";
+ 
+                     String dash = U.dash(ack.length());
+ 
+                     log.info(NL + NL +
+                         ">>> " + dash + NL +
+                         ">>> " + ack + NL +
+                         ">>> " + dash + NL +
+                         ">>> Grid name: " + gridName + NL +
+                         ">>> Grid uptime: " + X.timeSpan2HMSM(U.currentTimeMillis() - startTime) +
+                         NL +
+                         NL);
+                 }
+                 else {
+                     String ack = "GridGain ver. " + COMPOUND_VER + '#' + BUILD_TSTAMP_STR + "-sha1:" + REV_HASH +
+                         " stopped with ERRORS";
+ 
+                     String dash = U.dash(ack.length());
+ 
+                     log.info(NL + NL +
+                         ">>> " + ack + NL +
+                         ">>> " + dash + NL +
+                         ">>> Grid name: " + gridName + NL +
+                         ">>> Grid uptime: " + X.timeSpan2HMSM(U.currentTimeMillis() - startTime) +
+                         NL +
+                         ">>> See log above for detailed error message." + NL +
+                         ">>> Note that some errors during stop can prevent grid from" + NL +
+                         ">>> maintaining correct topology since this node may have" + NL +
+                         ">>> not exited grid properly." + NL +
+                         NL);
+                 }
+ 
+             // Send node start email notification, if enabled.
+             if (isSmtpEnabled() && isAdminEmailsSet() && cfg.isLifeCycleEmailNotification()) {
+                 String errOk = errOnStop ? "with ERRORS" : "OK";
+ 
+                 String headline = "GridGain ver. " + COMPOUND_VER + '#' + BUILD_TSTAMP_STR +
+                     " stopped " + errOk + ":";
+                 String subj = "GridGain node stopped " + errOk + ": " + nid8;
+ 
+                 IgniteProductLicense lic = ctx.license() != null ? ctx.license().license() : null;
+ 
+                 String body =
+                     headline + NL + NL +
+                     "----" + NL +
+                     "GridGain ver. " + COMPOUND_VER + '#' + BUILD_TSTAMP_STR + "-sha1:" + REV_HASH + NL +
+                     "Grid name: " + gridName + NL +
+                     "Node ID: " + nid + NL +
+                     "Node uptime: " + X.timeSpan2HMSM(U.currentTimeMillis() - startTime) + NL;
+ 
+                 if (lic != null) {
+                     body +=
+                         "License ID: " + lic.id().toString().toUpperCase() + NL +
+                         "Licensed to: " + lic.userOrganization() + NL;
+                 }
+                 else
+                     assert !ENT;
+ 
+                 body +=
+                     "----" + NL +
+                     NL +
+                     "NOTE:" + NL +
+                     "This message is sent automatically to all configured admin emails." + NL +
+                     "To change this behavior use 'lifeCycleEmailNotify' grid configuration property.";
+ 
+                 if (errOnStop)
+                     body +=
+                         NL + NL +
+                             "NOTE:" + NL +
+                             "See node's log for detailed error message." + NL +
+                             "Some errors during stop can prevent grid from" + NL +
+                             "maintaining correct topology since this node may " + NL +
+                             "have not exited grid properly.";
+ 
+                 body +=
+                     NL + NL +
+                         "| " + SITE + NL +
+                         "| support@gridgain.com" + NL;
+ 
+                 if (email != null) {
+                     try {
+                         email.sendNow(subj,
+                             body,
+                             false,
+                             Arrays.asList(cfg.getAdminEmails()));
+                     }
+                     catch (IgniteCheckedException e) {
+                         U.error(log, "Failed to send lifecycle email notification.", e);
+                     }
+                 }
+             }
+ 
+             U.onGridStop();
+         }
+         else {
+             // Proper notification.
+             if (log.isDebugEnabled()) {
+                 if (gw.getState() == STOPPED)
+                     log.debug("Grid is already stopped. Nothing to do.");
+                 else
+                     log.debug("Grid is being stopped by another thread. Aborting this stop sequence " +
+                         "allowing other thread to finish.");
+             }
+         }
+     }
+ 
+     /**
+      * USED ONLY FOR TESTING.
+      *
+      * @param <K> Key type.
+      * @param <V> Value type.
+      * @return Internal cache instance.
+      */
+     /*@java.test.only*/
+     public <K, V> GridCacheAdapter<K, V> internalCache() {
+         return internalCache(null);
+     }
+ 
+     /**
+      * USED ONLY FOR TESTING.
+      *
+      * @param name Cache name.
+      * @param <K>  Key type.
+      * @param <V>  Value type.
+      * @return Internal cache instance.
+      */
+     /*@java.test.only*/
+     public <K, V> GridCacheAdapter<K, V> internalCache(@Nullable String name) {
+         return ctx.cache().internalCache(name);
+     }
+ 
+     /**
+      * It's intended for use by internal marshalling implementation only.
+      *
+      * @return Kernal context.
+      */
+     public GridKernalContext context() {
+         return ctx;
+     }
+ 
+     /**
+      * Prints all system properties in debug mode.
+      */
+     private void ackSystemProperties() {
+         assert log != null;
+ 
+         if (log.isDebugEnabled())
+             for (Object key : U.asIterable(System.getProperties().keys()))
+                 log.debug("System property [" + key + '=' + System.getProperty((String) key) + ']');
+     }
+ 
+     /**
+      * Prints all user attributes in info mode.
+      */
+     private void logNodeUserAttributes() {
+         assert log != null;
+ 
+         if (log.isInfoEnabled())
+             for (Map.Entry<?, ?> attr : cfg.getUserAttributes().entrySet())
+                 log.info("Local node user attribute [" + attr.getKey() + '=' + attr.getValue() + ']');
+     }
+ 
+     /**
+      * Prints all environment variables in debug mode.
+      */
+     private void ackEnvironmentVariables() {
+         assert log != null;
+ 
+         if (log.isDebugEnabled())
+             for (Map.Entry<?, ?> envVar : System.getenv().entrySet())
+                 log.debug("Environment variable [" + envVar.getKey() + '=' + envVar.getValue() + ']');
+     }
+ 
+     /**
+      * Acks daemon mode status.
+      */
+     private void ackDaemon() {
+         assert log != null;
+ 
+         if (log.isInfoEnabled())
+             log.info("Daemon mode: " + (isDaemon() ? "on" : "off"));
+     }
+ 
+     /**
+      *
+      * @return {@code True} is this node is daemon.
+      */
+     private boolean isDaemon() {
+         assert cfg != null;
+ 
+         return cfg.isDaemon() || "true".equalsIgnoreCase(System.getProperty(GG_DAEMON));
+     }
+ 
+     /**
+      * Whether or not remote JMX management is enabled for this node. Remote JMX management is
+      * enabled when the following system property is set:
+      * <ul>
+      *     <li>{@code com.sun.management.jmxremote}</li>
+      * </ul>
+      *
+      * @return {@code True} if remote JMX management is enabled - {@code false} otherwise.
+      */
+     @Override public boolean isJmxRemoteEnabled() {
+         return System.getProperty("com.sun.management.jmxremote") != null;
+     }
+ 
+     /**
+      * Whether or not node restart is enabled. Node restart us supported when this node was started
+      * with {@code bin/ggstart.{sh|bat}} script using {@code -r} argument. Node can be
+      * programmatically restarted using {@link org.apache.ignite.Ignition#restart(boolean)}} method.
+      *
+      * @return {@code True} if restart mode is enabled, {@code false} otherwise.
+      * @see org.apache.ignite.Ignition#restart(boolean)
+      */
+     @Override public boolean isRestartEnabled() {
+         return System.getProperty(GG_SUCCESS_FILE) != null;
+     }
+ 
+     /**
+      * Whether or not SMTP is configured. Note that SMTP is considered configured if
+      * SMTP host is provided in configuration (see {@link org.apache.ignite.configuration.IgniteConfiguration#getSmtpHost()}.
+      * <p>
+      * If SMTP is not configured all emails notifications will be disabled.
+      *
+      * @return {@code True} if SMTP is configured - {@code false} otherwise.
+      * @see org.apache.ignite.configuration.IgniteConfiguration#getSmtpFromEmail()
+      * @see org.apache.ignite.configuration.IgniteConfiguration#getSmtpHost()
+      * @see org.apache.ignite.configuration.IgniteConfiguration#getSmtpPassword()
+      * @see org.apache.ignite.configuration.IgniteConfiguration#getSmtpPort()
+      * @see org.apache.ignite.configuration.IgniteConfiguration#getSmtpUsername()
+      * @see org.apache.ignite.configuration.IgniteConfiguration#isSmtpSsl()
+      * @see org.apache.ignite.configuration.IgniteConfiguration#isSmtpStartTls()
+      * @see #sendAdminEmailAsync(String, String, boolean)
+      */
+     @Override public boolean isSmtpEnabled() {
+         assert cfg != null;
+ 
+         return cfg.getSmtpHost() != null;
+     }
+ 
+     /**
+      * Prints all configuration properties in info mode and SPIs in debug mode.
+      */
+     private void ackSpis() {
+         assert log != null;
+ 
+         if (log.isDebugEnabled()) {
+             log.debug("+-------------+");
+             log.debug("START SPI LIST:");
+             log.debug("+-------------+");
+             log.debug("Grid checkpoint SPI     : " + Arrays.toString(cfg.getCheckpointSpi()));
+             log.debug("Grid collision SPI      : " + cfg.getCollisionSpi());
+             log.debug("Grid communication SPI  : " + cfg.getCommunicationSpi());
+             log.debug("Grid deployment SPI     : " + cfg.getDeploymentSpi());
+             log.debug("Grid discovery SPI      : " + cfg.getDiscoverySpi());
+             log.debug("Grid event storage SPI  : " + cfg.getEventStorageSpi());
+             log.debug("Grid failover SPI       : " + Arrays.toString(cfg.getFailoverSpi()));
+             log.debug("Grid load balancing SPI : " + Arrays.toString(cfg.getLoadBalancingSpi()));
+             log.debug("Grid authentication SPI : " + cfg.getAuthenticationSpi());
+             log.debug("Grid secure session SPI : " + cfg.getSecureSessionSpi());
+             log.debug("Grid swap space SPI     : " + cfg.getSwapSpaceSpi());
+         }
+     }


<TRUNCATED>

[02/50] [abbrv] incubator-ignite git commit: Fix IgniteCacheIterator

Posted by vo...@apache.org.
Fix IgniteCacheIterator


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

Branch: refs/heads/ignite-16
Commit: 9900ae49ba2b839eb3c549bb95cdf397743a8303
Parents: 4535322
Author: ivasilinets <iv...@gridgain.com>
Authored: Thu Jan 29 18:14:08 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Thu Jan 29 18:14:08 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      | 16 ++-----
 .../processors/cache/IgniteCacheProxy.java      |  2 +-
 .../GridCacheAbstractProjectionSelfTest.java    | 50 ++++++++++++++++++++
 3 files changed, 54 insertions(+), 14 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9900ae49/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
index 92d2039..1c04d29 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
@@ -3887,10 +3887,10 @@ public abstract class GridCacheAdapter<K, V> implements GridCache<K, V>,
     }
 
     /**
-     * @param prj Projection.
+     * @param delegate Cache proxy.
      * @return Distributed ignite cache iterator.
      */
-    public Iterator<Cache.Entry<K, V>> igniteIterator(final GridCacheProjectionImpl<K, V> prj) {
+    public Iterator<Cache.Entry<K, V>> igniteIterator(final IgniteCacheProxy<K, V> delegate) {
         CacheQueryFuture<Map.Entry<K, V>> fut = queries().createScanQuery(null)
             .keepAll(false)
             .execute();
@@ -3901,17 +3901,7 @@ public abstract class GridCacheAdapter<K, V> implements GridCache<K, V>,
             }
 
             @Override protected void remove(Cache.Entry<K, V> item) {
-                GridCacheProjectionImpl<K, V> prev = ctx.gate().enter(prj);
-
-                try {
-                    GridCacheAdapter.this.removex(item.getKey());
-                }
-                catch (IgniteCheckedException e) {
-                    throw new CacheException(e);
-                }
-                finally {
-                    ctx.gate().leave(prev);
-                }
+                delegate.remove(item.getKey());
             }
         });
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9900ae49/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
index 743e5b9..0bb2543 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
@@ -943,7 +943,7 @@ public class IgniteCacheProxy<K, V> extends IgniteAsyncSupportAdapter<IgniteCach
         GridCacheProjectionImpl<K, V> prev = gate.enter(prj);
 
         try {
-            return ((GridCacheAdapter)delegate).igniteIterator(prj);
+            return ctx.cache().igniteIterator(this);
         }
         finally {
             gate.leave(prev);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9900ae49/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractProjectionSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractProjectionSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractProjectionSelfTest.java
index 6337339..acdeede 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractProjectionSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractProjectionSelfTest.java
@@ -617,6 +617,56 @@ public abstract class GridCacheAbstractProjectionSelfTest extends GridCacheAbstr
     /**
      * @throws Exception if failed.
      */
+    public void testSkipStoreIterator() throws Exception {
+        assertNull(cache().put("1", 100500));
+
+        IgniteCache<String, Integer> c = jcache().withSkipStore();
+
+        Iterator i = c.iterator();
+
+        assertTrue(i.hasNext());
+
+        i.next();
+
+        i.remove();
+
+        i = c.iterator();
+
+        assertFalse(i.hasNext());
+
+        assertNull(c.get("1"));
+
+        assertEquals(100500, map.get("1"));
+    }
+
+    /**
+     * @throws Exception if failed.
+     */
+    public void testNotSkipStoreIterator() throws Exception {
+        assertNull(cache().put("1", 100500));
+
+        IgniteCache<String, Integer> c = jcache();
+
+        Iterator i = c.iterator();
+
+        assertTrue(i.hasNext());
+
+        i.next();
+
+        i.remove();
+
+        i = c.iterator();
+
+        assertFalse(i.hasNext());
+
+        assertNull(c.get("1"));
+
+        assertNull(map.get("1"));
+    }
+
+    /**
+     * @throws Exception if failed.
+     */
     // TODO: enable when GG-7579 is fixed.
     public void _testSkipStoreFlagMultinode() throws Exception {
         final int nGrids = 3;


[39/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-67' into sprint-1

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletContextListenerStartup.java
----------------------------------------------------------------------
diff --cc modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletContextListenerStartup.java
index e28f3e2,0000000..79f3f3a
mode 100644,000000..100644
--- a/modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletContextListenerStartup.java
+++ b/modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletContextListenerStartup.java
@@@ -1,181 -1,0 +1,181 @@@
 +/*
 + * 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.startup.servlet;
 +
 +import org.apache.ignite.*;
 +import org.apache.ignite.configuration.*;
 +import org.apache.ignite.internal.*;
 +import org.apache.ignite.lang.*;
 +import org.apache.ignite.internal.processors.resource.*;
 +import org.apache.ignite.internal.util.typedef.*;
 +import org.apache.ignite.internal.util.typedef.internal.*;
 +
 +import javax.servlet.*;
 +import java.net.*;
 +import java.util.*;
 +
 +/**
 + * This class defines GridGain startup based on servlet context listener.
 + * This startup can be used to start GridGain inside any web container.
 + * <p>
 + * This startup must be defined in {@code web.xml} file.
 + * <pre name="code" class="xml">
 + * &lt;listener&gt;
 + *     &lt;listener-class&gt;org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup&lt;/listener-class&gt;
 + * &lt;/listener&gt;
 + *
 + * &lt;context-param&gt;
-  *     &lt;param-name&gt;GridGainConfigurationFilePath&lt;/param-name&gt;
++ *     &lt;param-name&gt;IgniteConfigurationFilePath&lt;/param-name&gt;
 + *     &lt;param-value&gt;config/default-config.xml&lt;/param-value&gt;
 + * &lt;/context-param&gt;
 + * </pre>
 + * <p>
 + * Servlet context listener based startup may be used in any web container like Tomcat, Jetty and etc.
 + * Depending on the way this startup is deployed the GridGain instance can be accessed
 + * by either all web applications or by only one. See web container class loading architecture:
 + * <ul>
 + * <li><a target=_blank href="http://tomcat.apache.org/tomcat-7.0-doc/class-loader-howto.html">http://tomcat.apache.org/tomcat-7.0-doc/class-loader-howto.html</a></li>
 + * <li><a target=_blank href="http://docs.codehaus.org/display/JETTY/Classloading">http://docs.codehaus.org/display/JETTY/Classloading</a></li>
 + * </ul>
 + * <p>
 + * <h2 class="header">Tomcat</h2>
 + * There are two ways to start GridGain on Tomcat.
 + * <ul>
 + * <li>GridGain started when web container starts and GridGain instance is accessible only to all web applications.
 + *     <ol>
 + *     <li>Add GridGain libraries in Tomcat common loader.
 + *         Add in file {@code $TOMCAT_HOME/conf/catalina.properties} for property {@code common.loader}
-  *         the following {@code $GRIDGAIN_HOME/*.jar,$GRIDGAIN_HOME/libs/*.jar}
-  *         (replace {@code $GRIDGAIN_HOME} with absolute path).
++ *         the following {@code $IGNITE_HOME/*.jar,$IGNITE_HOME/libs/*.jar}
++ *         (replace {@code $IGNITE_HOME} with absolute path).
 + *     </li>
 + *     <li>Configure this startup in {@code $TOMCAT_HOME/conf/web.xml}
 + *         <pre name="code" class="xml">
 + *         &lt;listener&gt;
 + *             &lt;listener-class&gt;org.apache.ignite.startup.servlet.IgniteServletContextListenerStartup&lt;/listener-class&gt;
 + *         &lt;/listener&gt;
 + *
 + *         &lt;context-param&gt;
-  *             &lt;param-name&gt;GridGainConfigurationFilePath&lt;/param-name&gt;
++ *             &lt;param-name&gt;IgniteConfigurationFilePath&lt;/param-name&gt;
 + *             &lt;param-value&gt;config/default-config.xml&lt;/param-value&gt;
 + *         &lt;/context-param&gt;
 + *         </pre>
 + *     </li>
 + *     </ol>
 + * </li>
 + * <li>
 + * GridGain started from WAR-file and GridGain instance is accessible only to that web application.
 + * Difference with approach described above is that {@code web.xml} file and all libraries should
 + * be added in WAR file without changes in Tomcat configuration files.
 + * </li>
 + * </ul>
 + */
 +public class IgniteServletContextListenerStartup implements ServletContextListener {
 +    /** Configuration file path parameter name. */
-     public static final String GRIDGAIN_CFG_FILE_PATH_PARAM = "GridGainConfigurationFilePath";
++    public static final String IGNITE_CFG_FILE_PATH_PARAM = "IgniteConfigurationFilePath";
 +
 +    /** Names of started grids. */
 +    private final Collection<String> gridNames = new ArrayList<>();
 +
 +    /** {@inheritDoc} */
 +    @Override public void contextInitialized(ServletContextEvent evt) {
 +        ServletContext ctx = evt.getServletContext();
 +
-         String cfgFile = ctx.getInitParameter(GRIDGAIN_CFG_FILE_PATH_PARAM);
++        String cfgFile = ctx.getInitParameter(IGNITE_CFG_FILE_PATH_PARAM);
 +
 +        Collection<IgniteConfiguration> cfgs;
 +        GridSpringResourceContext rsrcCtx = null;
 +
 +        if (cfgFile != null) {
 +            URL cfgUrl = null;
 +
 +            try {
 +                cfgUrl = evt.getServletContext().getResource("/META-INF/" + cfgFile);
 +            }
 +            catch (MalformedURLException ignored) {
-                 // Ignore, we still need to try with GRIDGAIN_HOME.
++                // Ignore, we still need to try with IGNITE_HOME.
 +            }
 +
 +            if (cfgUrl == null)
-                 // Try with GRIDGAIN_HOME and with context class loader.
++                // Try with IGNITE_HOME and with context class loader.
 +                cfgUrl = U.resolveGridGainUrl(cfgFile);
 +
 +            if (cfgUrl == null)
 +                throw new IgniteException("Failed to find Spring configuration file (path provided should be " +
-                     "either absolute, relative to GRIDGAIN_HOME, or relative to META-INF folder): " + cfgFile);
++                    "either absolute, relative to IGNITE_HOME, or relative to META-INF folder): " + cfgFile);
 +
 +            IgniteBiTuple<Collection<IgniteConfiguration>, ? extends GridSpringResourceContext> t;
 +
 +            try {
 +                t = IgnitionEx.loadConfigurations(cfgUrl);
 +            }
 +            catch (IgniteCheckedException e) {
 +                throw new IgniteException("Failed to load GridGain configuration.", e);
 +            }
 +
 +            cfgs = t.get1();
 +            rsrcCtx  = t.get2();
 +
 +            if (cfgs.isEmpty())
 +                throw new IgniteException("Can't find grid factory configuration in: " + cfgUrl);
 +        }
 +        else
 +            cfgs = Collections.<IgniteConfiguration>singleton(new IgniteConfiguration());
 +
 +        try {
 +            assert !cfgs.isEmpty();
 +
 +            for (IgniteConfiguration cfg : cfgs) {
 +                assert cfg != null;
 +
 +                Ignite ignite;
 +
 +                synchronized (IgniteServletContextListenerStartup.class) {
 +                    try {
 +                        ignite = G.ignite(cfg.getGridName());
 +                    }
 +                    catch (IgniteIllegalStateException ignored) {
 +                        ignite = IgnitionEx.start(new IgniteConfiguration(cfg), rsrcCtx);
 +                    }
 +                }
 +
 +                // Check if grid is not null - started properly.
 +                if (ignite != null)
 +                    gridNames.add(ignite.name());
 +            }
 +        }
 +        catch (IgniteCheckedException e) {
 +            // Stop started grids only.
 +            for (String name : gridNames)
 +                G.stop(name, true);
 +
 +            throw new IgniteException("Failed to start GridGain.", e);
 +        }
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public void contextDestroyed(ServletContextEvent evt) {
 +        // Stop started grids only.
 +        for (String name: gridNames)
 +            G.stop(name, true);
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public String toString() {
 +        return S.toString(IgniteServletContextListenerStartup.class, this);
 +    }
 +}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletStartup.java
----------------------------------------------------------------------
diff --cc modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletStartup.java
index 32c456c,0000000..20ea055
mode 100644,000000..100644
--- a/modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletStartup.java
+++ b/modules/web/src/main/java/org/apache/ignite/startup/servlet/IgniteServletStartup.java
@@@ -1,187 -1,0 +1,187 @@@
 +/*
 + * 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.startup.servlet;
 +
 +import org.apache.ignite.*;
 +import org.apache.ignite.configuration.*;
 +import org.apache.ignite.internal.*;
 +import org.apache.ignite.lang.*;
 +import org.apache.ignite.internal.processors.resource.*;
 +import org.apache.ignite.internal.util.typedef.*;
 +import org.apache.ignite.internal.util.typedef.internal.*;
 +
 +import javax.servlet.*;
 +import javax.servlet.http.*;
 +import java.net.*;
 +import java.util.*;
 +
 +/**
 + * This class defines servlet-based GridGain startup. This startup can be used to start GridGain
 + * inside any web container as servlet.
 + * <p>
 + * This startup must be defined in {@code web.xml} file.
 + * <pre name="code" class="xml">
 + * &lt;servlet&gt;
 + *     &lt;servlet-name&gt;GridGain&lt;/servlet-name&gt;
 + *     &lt;servlet-class&gt;org.apache.ignite.startup.servlet.IgniteServletStartup&lt;/servlet-class&gt;
 + *     &lt;init-param&gt;
 + *         &lt;param-name&gt;cfgFilePath&lt;/param-name&gt;
 + *         &lt;param-value&gt;config/default-config.xml&lt;/param-value&gt;
 + *     &lt;/init-param&gt;
 + *     &lt;load-on-startup&gt;1&lt;/load-on-startup&gt;
 + * &lt;/servlet&gt;
 + * </pre>
 + * <p>
 + * Servlet-based startup may be used in any web container like Tomcat, Jetty and etc.
 + * Depending on the way this startup is deployed the GridGain instance can be accessed
 + * by either all web applications or by only one. See web container class loading architecture:
 + * <ul>
 + * <li><a target=_blank href="http://tomcat.apache.org/tomcat-7.0-doc/class-loader-howto.html">http://tomcat.apache.org/tomcat-7.0-doc/class-loader-howto.html</a></li>
 + * <li><a target=_blank href="http://docs.codehaus.org/display/JETTY/Classloading">http://docs.codehaus.org/display/JETTY/Classloading</a></li>
 + * </ul>
 + * <p>
 + * <h2 class="header">Tomcat</h2>
 + * There are two ways to start GridGain on Tomcat.
 + * <ul>
 + * <li>GridGain started when web container starts and GridGain instance is accessible only to all web applications.
 + * <ol>
 + *     <li>Add GridGain libraries in Tomcat common loader.
 + *         Add in file {@code $TOMCAT_HOME/conf/catalina.properties} for property {@code shared.loader}
-  *         the following {@code $GRIDGAIN_HOME/gridgain.jar,$GRIDGAIN_HOME/libs/*.jar}
-  *         (replace {@code $GRIDGAIN_HOME} with absolute path).
++ *         the following {@code $IGNITE_HOME/gridgain.jar,$IGNITE_HOME/libs/*.jar}
++ *         (replace {@code $IGNITE_HOME} with absolute path).
 + *     </li>
 + *     <li>Configure startup in {@code $TOMCAT_HOME/conf/web.xml}
 + *         <pre name="code" class="xml">
 + *         &lt;servlet&gt;
 + *             &lt;servlet-name&gt;GridGain&lt;/servlet-name&gt;
 + *             &lt;servlet-class&gt;org.apache.ignite.startup.servlet.IgniteServletStartup&lt;/servlet-class&gt;
 + *             &lt;init-param&gt;
 + *                 &lt;param-name&gt;cfgFilePath&lt;/param-name&gt;
 + *                 &lt;param-value&gt;config/default-config.xml&lt;/param-value&gt;
 + *             &lt;/init-param&gt;
 + *             &lt;load-on-startup&gt;1&lt;/load-on-startup&gt;
 + *         &lt;/servlet&gt;
 + *         </pre>
 + *     </li>
 + *     </ol>
 + * </li>
 + * <li>
 + * GridGain started from WAR-file and GridGain instance is accessible only to that web application.
 + * Difference with approach described above is that {@code web.xml} file and all libraries should
 + * be added in WAR file without changes in Tomcat configuration files.
 + * </li>
 + * </ul>
 + * <p>
 + * <h2 class="header">Jetty</h2>
 + * Below is Java code example with Jetty API:
 + * <pre name="code" class="java">
 + * Server service = new Server();
 + *
 + * service.addListener("localhost:8090");
 + *
 + * ServletHttpContext ctx = (ServletHttpContext)service.getContext("/");
 + *
 + * ServletHolder servlet = ctx.addServlet("GridGain", "/GridGainStartup",
 + *      "org.apache.ignite.startup.servlet.IgniteServletStartup");
 + *
 + * servlet.setInitParameter("cfgFilePath", "config/default-config.xml");
 + *
 + * servlet.setInitOrder(1);
 + *
 + * servlet.start();
 + *
 + * service.start();
 + * </pre>
 + */
 +public class IgniteServletStartup extends HttpServlet {
 +    /** */
 +    private static final long serialVersionUID = 0L;
 +
 +    /** Grid loaded flag. */
 +    private static boolean loaded;
 +
 +    /** Configuration file path variable name. */
 +    private static final String cfgFilePathParam = "cfgFilePath";
 +
 +    /** */
 +    private Collection<String> gridNames = new ArrayList<>();
 +
 +    /** {@inheritDoc} */
 +    @SuppressWarnings({"unchecked"})
 +    @Override public void init() throws ServletException {
 +        // Avoid multiple servlet instances. GridGain should be loaded once.
 +        if (loaded)
 +            return;
 +
 +        String cfgFile = getServletConfig().getInitParameter(cfgFilePathParam);
 +
 +        if (cfgFile == null)
 +            throw new ServletException("Failed to read property: " + cfgFilePathParam);
 +
 +        URL cfgUrl = U.resolveGridGainUrl(cfgFile);
 +
 +        if (cfgUrl == null)
 +            throw new ServletException("Failed to find Spring configuration file (path provided should be " +
-                 "either absolute, relative to GRIDGAIN_HOME, or relative to META-INF folder): " + cfgFile);
++                "either absolute, relative to IGNITE_HOME, or relative to META-INF folder): " + cfgFile);
 +
 +        try {
 +            IgniteBiTuple<Collection<IgniteConfiguration>, ? extends GridSpringResourceContext> t =
 +                IgnitionEx.loadConfigurations(cfgUrl);
 +
 +            Collection<IgniteConfiguration> cfgs = t.get1();
 +
 +            if (cfgs == null)
 +                throw new ServletException("Failed to find a single grid factory configuration in: " + cfgUrl);
 +
 +            for (IgniteConfiguration cfg : cfgs) {
 +                assert cfg != null;
 +
 +                IgniteConfiguration adapter = new IgniteConfiguration(cfg);
 +
 +                Ignite ignite = IgnitionEx.start(adapter, t.get2());
 +
 +                // Test if grid is not null - started properly.
 +                if (ignite != null)
 +                    gridNames.add(ignite.name());
 +            }
 +        }
 +        catch (IgniteCheckedException e) {
 +            // Stop started grids only.
 +            for (String name: gridNames)
 +                G.stop(name, true);
 +
 +            throw new ServletException("Failed to start GridGain.", e);
 +        }
 +
 +        loaded = true;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public void destroy() {
 +        // Stop started grids only.
 +        for (String name: gridNames)
 +            G.stop(name, true);
 +
 +        loaded = false;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public String toString() {
 +        return S.toString(IgniteServletStartup.class, this);
 +    }
 +}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/115f5979/pom.xml
----------------------------------------------------------------------


[24/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

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


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

Branch: refs/heads/ignite-16
Commit: 71442e29f702a9c8ffc51d8f291a410292a517d5
Parents: 746ce78 4da5e29
Author: Artem SHutak <as...@gridgain.com>
Authored: Fri Jan 30 13:21:59 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Fri Jan 30 13:21:59 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/messaging/GridMessagingSelfTest.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------



[15/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-71

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-71


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

Branch: refs/heads/ignite-16
Commit: 2690391596363075afddd447c5025c39b28df1d6
Parents: 258a0e7 9550905
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 11:33:47 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 11:33:47 2015 +0300

----------------------------------------------------------------------
 assembly/release-hadoop.xml                     |    6 +-
 ipc/shmem/Makefile.am                           |    2 +-
 ipc/shmem/Makefile.in                           |    2 +-
 ipc/shmem/configure                             |    4 +-
 ipc/shmem/configure.ac                          |    2 +-
 ipc/shmem/ggshmem/Makefile.am                   |   23 -
 ipc/shmem/ggshmem/Makefile.in                   |  589 --
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |  882 --
 ipc/shmem/igniteshmem/Makefile.am               |   23 +
 ipc/shmem/igniteshmem/Makefile.in               |  589 ++
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  882 ++
 ipc/shmem/include/Makefile.am                   |    2 +-
 ipc/shmem/include/Makefile.in                   |    2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |  117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |  117 -
 ipc/shmem/readme.txt                            |    9 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../java/META-INF/native/linux64/libggshmem.so  |  Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |  Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |  Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |  Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../processors/cache/GridCacheAdapter.java      |   16 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../cache/GridCacheMvccCandidate.java           |    4 +-
 .../processors/cache/GridCacheStoreManager.java |   25 +-
 .../processors/cache/IgniteCacheProxy.java      |   24 +-
 .../transactions/IgniteTxLocalAdapter.java      |   42 +-
 .../internal/processors/fs/GridGgfsServer.java  |   26 +-
 .../processors/fs/GridGgfsServerManager.java    |    8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |    2 +-
 .../processors/fs/IgniteFsProcessor.java        |    4 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |    2 +-
 .../service/GridServiceProcessor.java           |    2 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9100 -----------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../internal/util/ipc/GridIpcEndpoint.java      |   49 -
 .../util/ipc/GridIpcEndpointBindException.java  |   47 -
 .../util/ipc/GridIpcEndpointFactory.java        |   84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |   29 -
 .../util/ipc/GridIpcServerEndpoint.java         |   73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |   66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |  250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |   49 +
 .../util/ipc/IpcEndpointBindException.java      |   47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |   84 +
 .../internal/util/ipc/IpcEndpointType.java      |   29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |   73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |   66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |  250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |   87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |  179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |   87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |  179 +
 .../GridIpcOutOfSystemResourcesException.java   |   59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |  336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |   67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |  171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |   99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |  242 -
 ...cSharedMemoryOperationTimedoutException.java |   59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |   80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |  707 --
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |  374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |  242 -
 .../shmem/IpcOutOfSystemResourcesException.java |   59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |  336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |   67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |  171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |   99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |  261 +
 ...cSharedMemoryOperationTimedoutException.java |   59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |   80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  707 ++
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |  374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |  242 +
 .../util/nio/GridShmemCommunicationClient.java  |    4 +-
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    4 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   27 +-
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   24 +-
 .../IgniteExceptionHelpLinksSelfTest.java       |    3 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   10 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   50 +
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  288 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 .../IgniteCacheTxStoreSessionTest.java          |   11 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    4 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    4 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    4 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  717 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 ...idIpcServerEndpointDeserializerSelfTest.java |  160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |  160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |   76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |   71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |   76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |   71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |  500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |   36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |  267 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |   84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |  500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |   36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |   78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |  267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |   84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |   65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |   35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |  133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |  125 -
 .../IpcSharedMemoryBenchmarkParty.java          |   35 +
 .../IpcSharedMemoryBenchmarkReader.java         |  133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |  125 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    1 +
 .../ignite/testsuites/IgniteFsTestSuite.java    |    2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   10 +-
 .../GridHadoopExternalCommunication.java        |   26 +-
 .../GridHadoopIpcToNioAdapter.java              |    6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |    2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |    4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |    4 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    2 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   20 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |   25 +-
 158 files changed, 17135 insertions(+), 16542 deletions(-)
----------------------------------------------------------------------



[17/50] [abbrv] incubator-ignite git commit: Ignite-67 log fix

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a360ab77/modules/core/src/test/resources/log/gridgain.log.tst
----------------------------------------------------------------------
diff --git a/modules/core/src/test/resources/log/gridgain.log.tst b/modules/core/src/test/resources/log/gridgain.log.tst
index 7a825be..ea74097 100644
--- a/modules/core/src/test/resources/log/gridgain.log.tst
+++ b/modules/core/src/test/resources/log/gridgain.log.tst
@@ -1,10 +1,10 @@
-[14:14:22,515][INFO ][main][GridListenActorSelfTest]
+[14:14:22,515][INFO ][main][GridListenActorSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -15,8 +15,8 @@
 [14:14:22,516][INFO ][main][GridListenActorSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:22,516][INFO ][main][GridListenActorSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:22,516][INFO ][main][GridListenActorSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:22,516][INFO ][main][GridListenActorSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:22,516][INFO ][main][GridListenActorSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:22,516][INFO ][main][GridListenActorSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:22,516][INFO ][main][GridListenActorSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:22,517][WARN ][main][GridListenActorSelfTest] SMTP is not configured - email notifications are off.
 [14:14:22,517][WARN ][main][GridListenActorSelfTest] Cache is not configured - data grid is off.
 [14:14:22,521][INFO ][main][GridListenActorSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -36,7 +36,7 @@
 [14:14:24,721][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:24,721][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:24,721][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:24,740][INFO ][main][GridListenActorSelfTest]
+[14:14:24,740][INFO ][main][GridListenActorSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -49,7 +49,7 @@
 >>> Grid name: kernal.GridListenActorSelfTest
 >>> Local node [ID=353D63B5-A2F0-41D1-A30E-37016F357233, order=1353320063496]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45010 UDP:50001 TCP:55010
+>>> Local ports: TCP:8080 TCP:11211 TCP:45010 UDP:50001 TCP:55010 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:24,740][INFO ][main][GridListenActorSelfTest] >>> Starting test: testListenByClosure <<<
@@ -61,13 +61,13 @@
 [14:14:30,938][INFO ][main][GridListenActorSelfTest] >>> Starting test: testReceiveAll <<<
 [14:14:32,948][INFO ][main][GridListenActorSelfTest] >>> Stopping test: testReceiveAll in 2010 ms <<<
 [14:14:32,956][INFO ][main][GridListenActorSelfTest] >>> Starting test: testRespondToRemote <<<
-[14:14:32,960][INFO ][test-runner][GridListenActorSelfTest1]
+[14:14:32,960][INFO ][test-runner][GridListenActorSelfTest1] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -78,8 +78,8 @@
 [14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:32,961][INFO ][test-runner][GridListenActorSelfTest1] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:32,961][WARN ][test-runner][GridListenActorSelfTest1] SMTP is not configured - email notifications are off.
 [14:14:32,961][WARN ][test-runner][GridListenActorSelfTest1] Cache is not configured - data grid is off.
 [14:14:32,964][INFO ][test-runner][GridListenActorSelfTest1] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -103,7 +103,7 @@
 [14:14:35,652][INFO ][test-runner][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:35,652][INFO ][test-runner][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:35,652][INFO ][test-runner][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:35,667][INFO ][test-runner][GridListenActorSelfTest1]
+[14:14:35,667][INFO ][test-runner][GridListenActorSelfTest1] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -116,7 +116,7 @@
 >>> Grid name: kernal.GridListenActorSelfTest1
 >>> Local node [ID=1F7E8040-8A17-4E14-A513-1709BEBE265B, order=1353320073559]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:45011 UDP:50001 TCP:55011
+>>> Local ports: TCP:45011 UDP:50001 TCP:55011 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:36,672][INFO ][test-runner][GridListenActorSelfTest] >>> Stopping grid [name=kernal.GridListenActorSelfTest1, id=1f7e8040-8a17-4e14-a513-1709bebe265b]
@@ -125,7 +125,7 @@
 [14:14:36,679][INFO ][disco-event-worker-#15%kernal.GridListenActorSelfTest%][GridDiscoveryManager] Node left topology: GridMulticastDiscoveryNode [id=1f7e8040-8a17-4e14-a513-1709bebe265b, state=LEFT, lastHeartbeat=1353320076673, addrs=[192.168.2.14], addr=/192.168.2.14, tcpPort=55011, startTime=1353320073559]
 [14:14:36,680][INFO ][disco-event-worker-#15%kernal.GridListenActorSelfTest%][GridDiscoveryManager] Topology snapshot [nodes=1, CPUs=4, hash=0x8C20EE0]
 [14:14:36,693][INFO ][test-runner][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320075676, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=e4269281b31-1f7e8040-8a17-4e14-a513-1709bebe265b, userVer=0, loc=true, sampleCls=class java.lang.String, sampleClsName=java.lang.String, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:36,701][INFO ][test-runner][GridListenActorSelfTest1]
+[14:14:36,701][INFO ][test-runner][GridListenActorSelfTest1] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -141,7 +141,7 @@
 [14:14:37,780][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:14:37,781][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:14:37,794][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320064744, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=a2269281b31-353d63b5-a2f0-41d1-a30e-37016f357233, userVer=0, loc=true, sampleCls=class org.gridgain.grid.kernal.GridListenActorSelfTest$1, sampleClsName=org.gridgain.grid.kernal.GridListenActorSelfTest$1, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:37,799][INFO ][main][GridListenActorSelfTest]
+[14:14:37,799][INFO ][main][GridListenActorSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -150,13 +150,13 @@
 >>> Grid uptime: 00:00:13:57
 
 
-[14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest]
+[14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -167,8 +167,8 @@
 [14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:37,814][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:37,814][WARN ][main][GridSessionCancelSiblingsFromFutureSelfTest] SMTP is not configured - email notifications are off.
 [14:14:37,815][WARN ][main][GridSessionCancelSiblingsFromFutureSelfTest] Cache is not configured - data grid is off.
 [14:14:37,815][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -188,7 +188,7 @@
 [14:14:39,448][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:39,448][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:39,448][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:39,468][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest]
+[14:14:39,468][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -201,7 +201,7 @@
 >>> Grid name: session.GridSessionCancelSiblingsFromFutureSelfTest
 >>> Local node [ID=741AF89C-78C4-453D-83D5-86B9A66DCA08, order=1353320078398]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45020 UDP:50002 TCP:55020
+>>> Local ports: TCP:8080 TCP:11211 TCP:45020 UDP:50002 TCP:55020 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:39,468][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] >>> Starting test: testCancelSiblings <<<
@@ -381,7 +381,7 @@
 [14:14:40,676][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:14:40,677][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:14:40,687][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320079467, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=95269281b31-741af89c-78c4-453d-83d5-86b9a66dca08, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionCancelSiblingsFromFutureSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionCancelSiblingsFromFutureSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:40,691][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest]
+[14:14:40,691][INFO ][main][GridSessionCancelSiblingsFromFutureSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -390,13 +390,13 @@
 >>> Grid uptime: 00:00:01:228
 
 
-[14:14:40,706][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest]
+[14:14:40,706][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -407,8 +407,8 @@
 [14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:40,707][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:40,707][WARN ][main][GridSessionCancelSiblingsFromJobSelfTest] SMTP is not configured - email notifications are off.
 [14:14:40,707][WARN ][main][GridSessionCancelSiblingsFromJobSelfTest] Cache is not configured - data grid is off.
 [14:14:40,708][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -428,7 +428,7 @@
 [14:14:42,296][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:42,296][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:42,296][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:42,301][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest]
+[14:14:42,301][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -441,7 +441,7 @@
 >>> Grid name: session.GridSessionCancelSiblingsFromJobSelfTest
 >>> Local node [ID=8993B4E0-A3E8-4C20-A054-CF7C39915903, order=1353320081250]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45030 UDP:50003 TCP:55030
+>>> Local ports: TCP:8080 TCP:11211 TCP:45030 UDP:50003 TCP:55030 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:42,301][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] >>> Starting test: testCancelSiblings <<<
@@ -581,7 +581,7 @@
 [14:14:43,460][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:14:43,461][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:14:43,469][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320082296, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=71469281b31-8993b4e0-a3e8-4c20-a054-cf7c39915903, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionCancelSiblingsFromJobSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionCancelSiblingsFromJobSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:43,473][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest]
+[14:14:43,473][INFO ][main][GridSessionCancelSiblingsFromJobSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -590,13 +590,13 @@
 >>> Grid uptime: 00:00:01:170
 
 
-[14:14:43,487][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest]
+[14:14:43,487][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -607,8 +607,8 @@
 [14:14:43,487][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:43,488][WARN ][main][GridSessionCancelSiblingsFromTaskSelfTest] SMTP is not configured - email notifications are off.
 [14:14:43,488][WARN ][main][GridSessionCancelSiblingsFromTaskSelfTest] Cache is not configured - data grid is off.
 [14:14:43,488][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -628,7 +628,7 @@
 [14:14:45,082][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:45,082][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:45,082][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:45,087][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest]
+[14:14:45,087][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -641,7 +641,7 @@
 >>> Grid name: session.GridSessionCancelSiblingsFromTaskSelfTest
 >>> Local node [ID=D7B39FFC-59FF-4354-B89A-F9F90A8D786C, order=1353320084041]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45040 UDP:50004 TCP:55040
+>>> Local ports: TCP:8080 TCP:11211 TCP:45040 UDP:50004 TCP:55040 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:45,087][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] >>> Starting test: testCancelSiblings <<<
@@ -781,7 +781,7 @@
 [14:14:46,233][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:14:46,233][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:14:46,240][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320085087, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=bc569281b31-d7b39ffc-59ff-4354-b89a-f9f90a8d786c, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionCancelSiblingsFromTaskSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionCancelSiblingsFromTaskSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:46,243][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest]
+[14:14:46,243][INFO ][main][GridSessionCancelSiblingsFromTaskSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -790,13 +790,13 @@
 >>> Grid uptime: 00:00:01:159
 
 
-[14:14:46,257][INFO ][main][GridSessionSetFutureAttributeSelfTest]
+[14:14:46,257][INFO ][main][GridSessionSetFutureAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -807,8 +807,8 @@
 [14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:46,258][INFO ][main][GridSessionSetFutureAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:46,259][WARN ][main][GridSessionSetFutureAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:14:46,259][WARN ][main][GridSessionSetFutureAttributeSelfTest] Cache is not configured - data grid is off.
 [14:14:46,260][INFO ][main][GridSessionSetFutureAttributeSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -828,7 +828,7 @@
 [14:14:47,838][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:47,838][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:47,838][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:47,847][INFO ][main][GridSessionSetFutureAttributeSelfTest]
+[14:14:47,847][INFO ][main][GridSessionSetFutureAttributeSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -841,7 +841,7 @@
 >>> Grid name: session.GridSessionSetFutureAttributeSelfTest
 >>> Local node [ID=19A0735F-3E28-48E1-AA00-737D4BBE7953, order=1353320086800]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45050 UDP:50005 TCP:55050
+>>> Local ports: TCP:8080 TCP:11211 TCP:45050 UDP:50005 TCP:55050 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:47,847][INFO ][main][GridSessionSetFutureAttributeSelfTest] >>> Starting test: testMultiThreaded <<<
@@ -931,7 +931,7 @@
 [14:14:49,005][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:14:49,006][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:14:49,013][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320087847, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=f7769281b31-19a0735f-3e28-48e1-aa00-737d4bbe7953, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetFutureAttributeSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetFutureAttributeSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:49,018][INFO ][main][GridSessionSetFutureAttributeSelfTest]
+[14:14:49,018][INFO ][main][GridSessionSetFutureAttributeSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -940,13 +940,13 @@
 >>> Grid uptime: 00:00:01:177
 
 
-[14:14:49,033][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest]
+[14:14:49,033][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -957,8 +957,8 @@
 [14:14:49,034][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:49,034][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:49,035][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:49,035][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:49,035][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:49,035][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:49,035][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:49,035][WARN ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] SMTP is not configured - email notifications are off.
 [14:14:49,035][WARN ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] Cache is not configured - data grid is off.
 [14:14:49,036][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -978,7 +978,7 @@
 [14:14:50,611][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:50,611][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:50,611][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:50,619][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest]
+[14:14:50,619][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -991,7 +991,7 @@
 >>> Grid name: session.GridSessionSetFutureAttributeWaitListenerSelfTest
 >>> Local node [ID=F07B5F6E-FB13-4C51-B228-BE1F37F7ECDB, order=1353320089568]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45060 UDP:50006 TCP:55060
+>>> Local ports: TCP:8080 TCP:11211 TCP:45060 UDP:50006 TCP:55060 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:50,620][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] >>> Starting test: testSetAttribute <<<
@@ -1008,7 +1008,7 @@
 [14:14:51,692][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:14:51,692][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:14:51,699][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320090615, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=51969281b31-f07b5f6e-fb13-4c51-b228-be1f37f7ecdb, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetFutureAttributeWaitListenerSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetFutureAttributeWaitListenerSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:14:51,702][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest]
+[14:14:51,702][INFO ][main][GridSessionSetFutureAttributeWaitListenerSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -1017,13 +1017,13 @@
 >>> Grid uptime: 00:00:01:79
 
 
-[14:14:51,713][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest]
+[14:14:51,713][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -1034,8 +1034,8 @@
 [14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:14:51,714][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:14:51,714][WARN ][main][GridSessionSetJobAttributeWaitListenerSelfTest] SMTP is not configured - email notifications are off.
 [14:14:51,714][WARN ][main][GridSessionSetJobAttributeWaitListenerSelfTest] Cache is not configured - data grid is off.
 [14:14:51,715][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -1055,7 +1055,7 @@
 [14:14:53,295][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:14:53,295][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:14:53,295][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:14:53,300][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest]
+[14:14:53,300][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -1068,7 +1068,7 @@
 >>> Grid name: session.GridSessionSetJobAttributeWaitListenerSelfTest
 >>> Local node [ID=A31FA636-CFFE-4737-8BE5-A303AA1C4507, order=1353320092248]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45070 UDP:50007 TCP:55070
+>>> Local ports: TCP:8080 TCP:11211 TCP:45070 UDP:50007 TCP:55070 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:14:53,300][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] >>> Starting test: testSetAttribute <<<
@@ -1244,7 +1244,7 @@
 [14:16:34,407][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:34,408][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:34,416][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320093295, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=34969281b31-a31fa636-cffe-4737-8be5-a303aa1c4507, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetJobAttributeWaitListenerSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetJobAttributeWaitListenerSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:34,419][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest]
+[14:16:34,419][INFO ][main][GridSessionSetJobAttributeWaitListenerSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -1253,13 +1253,13 @@
 >>> Grid uptime: 00:01:41:116
 
 
-[14:16:34,433][INFO ][main][GridSessionSetJobAttributeSelfTest]
+[14:16:34,433][INFO ][main][GridSessionSetJobAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -1270,8 +1270,8 @@
 [14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:34,434][INFO ][main][GridSessionSetJobAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:34,434][WARN ][main][GridSessionSetJobAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:16:34,434][WARN ][main][GridSessionSetJobAttributeSelfTest] Cache is not configured - data grid is off.
 [14:16:34,438][INFO ][main][GridSessionSetJobAttributeSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -1291,7 +1291,7 @@
 [14:16:36,021][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:36,021][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:36,021][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:36,025][INFO ][main][GridSessionSetJobAttributeSelfTest]
+[14:16:36,025][INFO ][main][GridSessionSetJobAttributeSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -1304,7 +1304,7 @@
 >>> Grid name: session.GridSessionSetJobAttributeSelfTest
 >>> Local node [ID=46924B92-D354-4A08-87EA-5C8D6271E515, order=1353320194964]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45080 UDP:50008 TCP:55080
+>>> Local ports: TCP:8080 TCP:11211 TCP:45080 UDP:50008 TCP:55080 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:16:36,025][INFO ][main][GridSessionSetJobAttributeSelfTest] >>> Starting test: testMultiThreaded <<<
@@ -1434,7 +1434,7 @@
 [14:16:37,133][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:37,134][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:37,140][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320196025, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=88a69281b31-46924b92-d354-4a08-87ea-5c8d6271e515, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetJobAttributeSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetJobAttributeSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:37,143][INFO ][main][GridSessionSetJobAttributeSelfTest]
+[14:16:37,143][INFO ][main][GridSessionSetJobAttributeSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -1444,13 +1444,13 @@
 
 
 [14:16:37,151][INFO ][main][GridSessionSetJobAttribute2SelfTest] >>> Starting test: testJobSetAttribute <<<
-[14:16:37,157][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1]
+[14:16:37,157][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -1461,8 +1461,8 @@
 [14:16:37,157][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:37,158][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:37,158][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:37,158][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:37,158][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:37,158][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:37,158][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:37,158][WARN ][test-runner][GridSessionSetJobAttribute2SelfTest1] SMTP is not configured - email notifications are off.
 [14:16:37,158][WARN ][test-runner][GridSessionSetJobAttribute2SelfTest1] Cache is not configured - data grid is off.
 [14:16:37,159][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -1482,7 +1482,7 @@
 [14:16:38,723][INFO ][test-runner][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:38,723][INFO ][test-runner][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:38,723][INFO ][test-runner][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:38,728][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1]
+[14:16:38,728][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -1495,16 +1495,16 @@
 >>> Grid name: session.GridSessionSetJobAttribute2SelfTest1
 >>> Local node [ID=EF330C54-275E-44C5-BB30-FFD93D498E2F, order=1353320197688]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45090 UDP:50009 TCP:55090
+>>> Local ports: TCP:8080 TCP:11211 TCP:45090 UDP:50009 TCP:55090 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
-[14:16:38,729][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2]
+[14:16:38,729][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -1515,8 +1515,8 @@
 [14:16:38,729][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:38,729][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:38,729][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:38,730][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:38,730][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:38,730][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:38,730][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:38,730][WARN ][test-runner][GridSessionSetJobAttribute2SelfTest2] SMTP is not configured - email notifications are off.
 [14:16:38,730][WARN ][test-runner][GridSessionSetJobAttribute2SelfTest2] Cache is not configured - data grid is off.
 [14:16:38,730][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -1540,7 +1540,7 @@
 [14:16:41,369][INFO ][test-runner][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:41,369][INFO ][test-runner][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:41,369][INFO ][test-runner][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:41,377][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2]
+[14:16:41,377][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -1553,7 +1553,7 @@
 >>> Grid name: session.GridSessionSetJobAttribute2SelfTest2
 >>> Local node [ID=50A69295-104F-4E04-90B2-F70E331E9A21, order=1353320199270]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:45091 UDP:50009 TCP:55091
+>>> Local ports: TCP:45091 UDP:50009 TCP:55091 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:16:41,496][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest] >>> Stopping grid [name=session.GridSessionSetJobAttribute2SelfTest1, id=ef330c54-275e-44c5-bb30-ffd93d498e2f]
@@ -1562,7 +1562,7 @@
 [14:16:42,555][INFO ][disco-event-worker-#685%session.GridSessionSetJobAttribute2SelfTest2%][GridDiscoveryManager] Node left topology: GridMulticastDiscoveryNode [id=ef330c54-275e-44c5-bb30-ffd93d498e2f, state=LEFT, lastHeartbeat=1353320202554, addrs=[192.168.2.14], addr=/192.168.2.14, tcpPort=55090, startTime=1353320197688]
 [14:16:42,556][INFO ][disco-event-worker-#685%session.GridSessionSetJobAttribute2SelfTest2%][GridDiscoveryManager] Topology snapshot [nodes=1, CPUs=4, hash=0x7C68505C]
 [14:16:42,559][INFO ][test-runner][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320201375, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=c2c69281b31-ef330c54-275e-44c5-bb30-ffd93d498e2f, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetJobAttribute2SelfTest$SessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetJobAttribute2SelfTest$SessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:42,561][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1]
+[14:16:42,561][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest1] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -1575,7 +1575,7 @@
 [14:16:42,562][INFO ][test-runner][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:42,562][INFO ][test-runner][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:42,568][INFO ][test-runner][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320201385, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=23c69281b31-50a69295-104f-4e04-90b2-f70e331e9a21, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetJobAttribute2SelfTest$SessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetJobAttribute2SelfTest$SessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:42,570][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2]
+[14:16:42,570][INFO ][test-runner][GridSessionSetJobAttribute2SelfTest2] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -1585,13 +1585,13 @@
 
 
 [14:16:42,571][INFO ][main][GridSessionSetJobAttribute2SelfTest] >>> Stopping test: testJobSetAttribute in 5420 ms <<<
-[14:16:42,580][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest]
+[14:16:42,580][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -1602,8 +1602,8 @@
 [14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:42,581][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:42,582][WARN ][main][GridSessionJobWaitTaskAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:16:42,582][WARN ][main][GridSessionJobWaitTaskAttributeSelfTest] Cache is not configured - data grid is off.
 [14:16:42,583][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -1623,7 +1623,7 @@
 [14:16:44,144][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:44,144][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:44,144][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:44,148][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest]
+[14:16:44,148][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -1636,7 +1636,7 @@
 >>> Grid name: session.GridSessionJobWaitTaskAttributeSelfTest
 >>> Local node [ID=B39CEE3B-7910-40D6-97BF-85D584DA07C8, order=1353320203107]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45100 UDP:50010 TCP:55100
+>>> Local ports: TCP:8080 TCP:11211 TCP:45100 UDP:50010 TCP:55100 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:16:44,148][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] >>> Starting test: testMultiThreaded <<<
@@ -1856,7 +1856,7 @@
 [14:16:45,285][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:45,285][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:45,291][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320204144, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=44c69281b31-b39cee3b-7910-40d6-97bf-85d584da07c8, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionJobWaitTaskAttributeSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionJobWaitTaskAttributeSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:45,294][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest]
+[14:16:45,294][INFO ][main][GridSessionJobWaitTaskAttributeSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -1865,13 +1865,13 @@
 >>> Grid uptime: 00:00:01:141
 
 
-[14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest]
+[14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -1882,8 +1882,8 @@
 [14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:45,307][INFO ][main][GridSessionSetTaskAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:45,307][WARN ][main][GridSessionSetTaskAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:16:45,307][WARN ][main][GridSessionSetTaskAttributeSelfTest] Cache is not configured - data grid is off.
 [14:16:45,308][INFO ][main][GridSessionSetTaskAttributeSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -1903,7 +1903,7 @@
 [14:16:46,878][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:46,879][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:46,879][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:46,883][INFO ][main][GridSessionSetTaskAttributeSelfTest]
+[14:16:46,883][INFO ][main][GridSessionSetTaskAttributeSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -1916,7 +1916,7 @@
 >>> Grid name: session.GridSessionSetTaskAttributeSelfTest
 >>> Local node [ID=B9710CC2-6190-44C8-9214-43AC2125C016, order=1353320205839]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45110 UDP:50011 TCP:55110
+>>> Local ports: TCP:8080 TCP:11211 TCP:45110 UDP:50011 TCP:55110 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:16:46,883][INFO ][main][GridSessionSetTaskAttributeSelfTest] >>> Starting test: testMultiThreaded <<<
@@ -2106,7 +2106,7 @@
 [14:16:47,991][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:47,991][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:47,997][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320206876, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=add69281b31-b9710cc2-6190-44c8-9214-43ac2125c016, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionSetTaskAttributeSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionSetTaskAttributeSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:47,999][INFO ][main][GridSessionSetTaskAttributeSelfTest]
+[14:16:47,999][INFO ][main][GridSessionSetTaskAttributeSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -2115,13 +2115,13 @@
 >>> Grid uptime: 00:00:01:118
 
 
-[14:16:48,012][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest]
+[14:16:48,012][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -2132,8 +2132,8 @@
 [14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:48,013][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:48,013][WARN ][main][GridSessionFutureWaitTaskAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:16:48,014][WARN ][main][GridSessionFutureWaitTaskAttributeSelfTest] Cache is not configured - data grid is off.
 [14:16:48,014][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -2153,7 +2153,7 @@
 [14:16:49,596][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:49,596][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:49,596][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:49,604][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest]
+[14:16:49,604][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -2166,7 +2166,7 @@
 >>> Grid name: session.GridSessionFutureWaitTaskAttributeSelfTest
 >>> Local node [ID=16566258-770B-4ECF-962F-A6A9D4076A69, order=1353320208548]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45120 UDP:50012 TCP:55120
+>>> Local ports: TCP:8080 TCP:11211 TCP:45120 UDP:50012 TCP:55120 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:16:49,604][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] >>> Starting test: testMultiThreaded <<<
@@ -2306,7 +2306,7 @@
 [14:16:50,720][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:50,721][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:50,726][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320209606, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=07f69281b31-16566258-770b-4ecf-962f-a6a9d4076a69, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionFutureWaitTaskAttributeSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionFutureWaitTaskAttributeSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:50,729][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest]
+[14:16:50,729][INFO ][main][GridSessionFutureWaitTaskAttributeSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -2315,13 +2315,13 @@
 >>> Grid uptime: 00:00:01:129
 
 
-[14:16:50,744][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest]
+[14:16:50,744][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -2332,8 +2332,8 @@
 [14:16:50,744][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:50,745][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:50,745][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:50,745][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:50,745][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:50,745][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:50,745][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:50,745][WARN ][main][GridSessionFutureWaitJobAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:16:50,745][WARN ][main][GridSessionFutureWaitJobAttributeSelfTest] Cache is not configured - data grid is off.
 [14:16:50,746][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] 3-rd party licenses can be found at: /usr/local/TeamCityAgent/work/d46fc9c3d71112c2/libs/licenses
@@ -2353,7 +2353,7 @@
 [14:16:52,314][INFO ][main][GridLicenseControllerImpl] Licensed to 'GridGain Systems, Internal Development Only' on Feb 3, 2011
 [14:16:52,314][INFO ][main][GridLicenseControllerImpl] License [ID=7D5CB773-225C-4165-8162-3BB67337894B, type=ENT]
 [14:16:52,314][INFO ][main][GridLicenseControllerImpl] License limits [expire-date: never]
-[14:16:52,322][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest]
+[14:16:52,322][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] 
 
 >>> +--------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY
@@ -2366,7 +2366,7 @@
 >>> Grid name: session.GridSessionFutureWaitJobAttributeSelfTest
 >>> Local node [ID=6CB9A71D-90AF-4C65-B212-2D3AE90802F4, order=1353320211278]
 >>> Local node addresses: [192.168.2.14]
->>> Local ports: TCP:8080 TCP:11211 TCP:45130 UDP:50013 TCP:55130
+>>> Local ports: TCP:8080 TCP:11211 TCP:45130 UDP:50013 TCP:55130 
 >>> GridGain documentation: http://www.gridgain.com/product.html
 
 [14:16:52,322][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] >>> Starting test: testMultiThreaded <<<
@@ -3026,7 +3026,7 @@
 [14:16:53,553][INFO ][main][GridJettyRestProtocol] Command protocol successfully stopped: Jetty REST
 [14:16:53,553][INFO ][main][GridTcpRestProtocol] Command protocol successfully stopped: TCP binary
 [14:16:53,558][INFO ][main][GridDeploymentLocalStore] Removed undeployed class: GridDeployment [ts=1353320212315, depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@3326b249, clsLdrId=e2179281b31-6cb9a71d-90af-4c65-b212-2d3ae90802f4, userVer=0, loc=true, sampleCls=class org.gridgain.grid.session.GridSessionFutureWaitJobAttributeSelfTest$GridTaskSessionTestTask, sampleClsName=org.gridgain.grid.session.GridSessionFutureWaitJobAttributeSelfTest$GridTaskSessionTestTask, undeployed=true, pendingUndeploy=false, usage=0]
-[14:16:53,561][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest]
+[14:16:53,561][INFO ][main][GridSessionFutureWaitJobAttributeSelfTest] 
 
 >>> +-------------------------------------+
 >>> GridGain ver. x.x.x-DDMMYYYY stopped OK
@@ -3035,13 +3035,13 @@
 >>> Grid uptime: 00:00:01:238
 
 
-[14:16:53,575][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest]
+[14:16:53,575][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] 
 
->>>   _____     _     _______      _
->>>  / ___/____(_)___/ / ___/___ _(_)___
->>> / (_ // __/ // _  / (_ // _ `/ // _ \
+>>>   _____     _     _______      _         
+>>>  / ___/____(_)___/ / ___/___ _(_)___     
+>>> / (_ // __/ // _  / (_ // _ `/ // _ \   
 >>> \___//_/ /_/ \_,_/\___/ \_,_/_//_//_/
->>>
+>>> 
 >>>  ---==++ IN-MEMORY BIG DATA ++==---
 >>>        ver. x.x.x-DDMMYYYY
 >>> Copyright (C) 2012 GridGain Systems
@@ -3052,8 +3052,8 @@
 [14:16:53,575][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] Language runtime: Java Platform API Specification ver. 1.6
 [14:16:53,575][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] JVM name: Java HotSpot(TM) 64-Bit Server VM
 [14:16:53,576][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] Remote Management [restart: off, REST: on, JMX (remote: off)]
-[14:16:53,576][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] IGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
-[14:16:53,576][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DIGNITE_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DIGNITE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DIGNITE_NO_DISCO_ORDER=true, -DIGNITE_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
+[14:16:53,576][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] GRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2
+[14:16:53,576][INFO ][main][GridSessionTaskWaitJobAttributeSelfTest] VM arguments: [-ea, -XX:MaxPermSize=128m, -Xms512m, -Xmx1024m, -Duser.name=bamboo, -DGRIDGAIN_UPDATE_NOTIFIER=false, -DGRIDGAIN_DISABLED=true, -DGRIDGAIN_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_STABLE_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -DGRIDGAIN_ROUTER_PREFER_REMOTE=true, -DGRIDGAIN_NO_DISCO_ORDER=true, -DGRIDGAIN_QUIET=false, -DGG_TEST_HOME=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.id=34324, -Dteamcity.buildType.id=bt5, -Dagent.ownPort=9090, -Dteamcity.build.checkoutDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dteamcity.build.workingDir=/usr/local/TeamCityAgent/work/d46fc9c3d71112c2, -Dagent.work.dir=/usr/local/TeamCityAgent/work, -Dagent.name=teamcity-4, -Dagent.home.dir=/usr/local/TeamCityAgent, -Dteamcity.runtime.props.file=/usr/local/TeamCityAgent/temp/agentTmp/ant2684847485530994862runtime]
 [14:16:53,576][WARN ][main][GridSessionTaskWaitJobAttributeSelfTest] SMTP is not configured - email notifications are off.
 [14:16:53,576][WARN ][main][GridSessionTaskWaitJobAttributeSelfTest] Cache is not configured - data grid is off.
 [14:16:53,577][INFO ][main][GridSessionTaskWaitJobA

<TRUNCATED>

[18/50] [abbrv] incubator-ignite git commit: Ignite-67 log fix

Posted by vo...@apache.org.
Ignite-67 log 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/a360ab77
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/a360ab77
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/a360ab77

Branch: refs/heads/ignite-16
Commit: a360ab7794b844dd49693de91a7a7f9b115486dd
Parents: ed8d4d8
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 12:22:44 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 12:22:44 2015 +0300

----------------------------------------------------------------------
 .../src/test/resources/log/gridgain.log.tst     | 2540 +++++++++---------
 1 file changed, 1270 insertions(+), 1270 deletions(-)
----------------------------------------------------------------------



[28/50] [abbrv] incubator-ignite git commit: # sprint-1: fixed opt class names generator.

Posted by vo...@apache.org.
# sprint-1: fixed opt class names generator.


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

Branch: refs/heads/ignite-16
Commit: ff01e66e78cdf836066ec9aaf7eedf2f450c3929
Parents: c98118f
Author: AKuznetsov <ak...@gridgain.com>
Authored: Fri Jan 30 17:42:17 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Fri Jan 30 17:42:17 2015 +0700

----------------------------------------------------------------------
 .../marshaller/optimized/OptimizedClassNamesGenerator.java     | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ff01e66e/modules/tools/src/main/java/org/apache/ignite/tools/marshaller/optimized/OptimizedClassNamesGenerator.java
----------------------------------------------------------------------
diff --git a/modules/tools/src/main/java/org/apache/ignite/tools/marshaller/optimized/OptimizedClassNamesGenerator.java b/modules/tools/src/main/java/org/apache/ignite/tools/marshaller/optimized/OptimizedClassNamesGenerator.java
index 39e9a57..f135754 100644
--- a/modules/tools/src/main/java/org/apache/ignite/tools/marshaller/optimized/OptimizedClassNamesGenerator.java
+++ b/modules/tools/src/main/java/org/apache/ignite/tools/marshaller/optimized/OptimizedClassNamesGenerator.java
@@ -210,7 +210,7 @@ public class OptimizedClassNamesGenerator {
     private void checkSerialVersionUid(Class cls) {
         // Check only GridGain classes.
         if (cls.isEnum() || cls.getSimpleName().isEmpty() || (!cls.getName().startsWith("org.gridgain.grid") &&
-            !cls.getName().startsWith("org.gridgain.client")))
+            !cls.getName().startsWith("org.gridgain.client") && !cls.getName().startsWith("org.apache.ignite")))
             return;
 
         try {
@@ -285,14 +285,14 @@ public class OptimizedClassNamesGenerator {
         File dir;
 
         if (args.length > 0 && args[0] != null && !args[0].isEmpty())
-            dir = new File(args[0], "/org/gridgain/grid/marshaller/optimized");
+            dir = new File(args[0], "/org/apache/ignite/marshaller/optimized");
         else {
             String home = home();
 
             if (home == null)
                 throw new Exception("Failed to find GridGain home.");
 
-            dir = new File(home, "/os/modules/core/src/main/java/org/gridgain/grid/marshaller/optimized");
+            dir = new File(home, "/os/modules/core/src/main/java/org/apache/ignite/marshaller/optimized");
         }
 
         if (!dir.exists())


[37/50] [abbrv] incubator-ignite git commit: Merge branch 'ignite-113' into sprint-1

Posted by vo...@apache.org.
Merge branch 'ignite-113' into sprint-1


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

Branch: refs/heads/ignite-16
Commit: 5203363e7b1cd297032da02611f81f24cbe60e6c
Parents: 57f55f6 9e74899
Author: Artem SHutak <as...@gridgain.com>
Authored: Fri Jan 30 18:15:14 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Fri Jan 30 18:15:14 2015 +0300

----------------------------------------------------------------------
 examples/config/servlet/WEB-INF/web.xml         |    2 +-
 .../main/java/org/apache/ignite/Ignition.java   |    6 +-
 .../apache/ignite/cache/query/CacheQuery.java   |    3 +-
 .../cache/query/CacheQuerySqlFunction.java      |    4 +-
 .../cache/query/annotations/QuerySqlField.java  |    2 +-
 .../query/annotations/QuerySqlFunction.java     |    2 +-
 .../apache/ignite/cache/store/CacheStore.java   |    2 +-
 .../ignite/compute/gridify/GridifySetToSet.java |    2 +-
 .../compute/gridify/GridifySetToValue.java      |    2 +-
 .../configuration/GridQueryConfiguration.java   |  201 ---
 .../configuration/IgniteConfiguration.java      |    8 +-
 .../configuration/IgniteQueryConfiguration.java |  201 +++
 .../ignite/spi/checkpoint/CheckpointSpi.java    |    2 +-
 .../ignite/spi/deployment/DeploymentSpi.java    |    2 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    2 +-
 .../apache/ignite/transactions/IgniteTx.java    |    2 +-
 modules/core/src/test/webapp/WEB-INF/web.xml    |    2 +-
 .../hibernate/CacheHibernateBlobStore.java      |  593 ++++++++
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   29 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |   86 ++
 .../hibernate/GridCacheHibernateBlobStore.java  |  593 --------
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |   29 -
 .../GridCacheHibernateBlobStoreEntry.java       |   86 --
 ...idHibernateL2CacheTransactionalSelfTest.java |    2 +-
 .../CacheHibernateBlobStoreSelfTest.java        |  108 ++
 .../GridCacheHibernateBlobStoreSelfTest.java    |  108 --
 .../cache/store/hibernate/hibernate.cfg.xml     |    2 +-
 .../testsuites/IgniteHibernateTestSuite.java    |    2 +-
 .../processors/query/h2/IgniteH2Indexing.java   |    6 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |    2 +-
 .../query/h2/sql/GridQueryParsingTest.java      |    2 +-
 .../apache/ignite/cache/jta/CacheTmLookup.java  |   50 +
 .../ignite/cache/jta/GridCacheTmLookup.java     |   50 -
 .../cache/jta/jndi/CacheJndiTmLookup.java       |   74 +
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |   74 -
 .../jta/reflect/CacheReflectionTmLookup.java    |  115 ++
 .../reflect/GridCacheReflectionTmLookup.java    |  115 --
 .../processors/cache/jta/CacheJtaManager.java   |    4 +-
 ...CacheJtaConfigurationValidationSelfTest.java |    2 +-
 .../processors/cache/GridCacheJtaSelfTest.java  |    2 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |    4 +-
 .../ignite/cache/spring/SpringCacheManager.java |    2 +-
 .../ignite/tools/javadoc/GridLinkTaglet.java    |  165 ---
 .../ignite/tools/javadoc/IgniteLinkTaglet.java  |  165 +++
 .../uri/GridUriDeploymentFileProcessor.java     |    2 +-
 .../deployment/uri/GridUriDeploymentSpi.java    | 1367 ------------------
 .../uri/GridUriDeploymentSpiMBean.java          |   53 -
 .../spi/deployment/uri/UriDeploymentSpi.java    | 1367 ++++++++++++++++++
 .../deployment/uri/UriDeploymentSpiMBean.java   |   53 +
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |    2 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |    2 +-
 .../uri/GridUriDeploymentAbstractSelfTest.java  |    2 +-
 .../GridUriDeploymentClassLoaderSelfTest.java   |    2 +-
 ...riDeploymentClassloaderRegisterSelfTest.java |    4 +-
 .../uri/GridUriDeploymentConfigSelfTest.java    |   10 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |    2 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |    2 +-
 ...loymentMultiScannersErrorThrottlingTest.java |    2 +-
 .../GridUriDeploymentMultiScannersSelfTest.java |    2 +-
 .../uri/GridUriDeploymentSimpleSelfTest.java    |   10 +-
 .../file/GridFileDeploymentSelfTest.java        |    2 +-
 .../GridFileDeploymentUndeploySelfTest.java     |    8 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |    2 +-
 .../http/GridHttpDeploymentSelfTest.java        |    2 +-
 .../IgniteUriDeploymentTestSuite.java           |    3 +-
 .../cache/websession/GridWebSessionFilter.java  |    4 +-
 .../GridServletContextListenerStartup.java      |  181 ---
 .../startup/servlet/GridServletStartup.java     |  187 ---
 .../IgniteServletContextListenerStartup.java    |  181 +++
 .../startup/servlet/IgniteServletStartup.java   |  187 +++
 pom.xml                                         |    6 +-
 72 files changed, 3279 insertions(+), 3283 deletions(-)
----------------------------------------------------------------------



[14/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-69

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-69


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

Branch: refs/heads/ignite-16
Commit: 5a50356e2f06f633ea3da1516694d606bc03cd48
Parents: a297fb3 9550905
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 11:33:01 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 11:33:01 2015 +0300

----------------------------------------------------------------------
 assembly/release-hadoop.xml                     |    6 +-
 ipc/shmem/Makefile.am                           |    2 +-
 ipc/shmem/Makefile.in                           |    2 +-
 ipc/shmem/configure                             |    4 +-
 ipc/shmem/configure.ac                          |    2 +-
 ipc/shmem/ggshmem/Makefile.am                   |   23 -
 ipc/shmem/ggshmem/Makefile.in                   |  589 --
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |  882 --
 ipc/shmem/igniteshmem/Makefile.am               |   23 +
 ipc/shmem/igniteshmem/Makefile.in               |  589 ++
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  882 ++
 ipc/shmem/include/Makefile.am                   |    2 +-
 ipc/shmem/include/Makefile.in                   |    2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |  117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |  117 -
 ipc/shmem/readme.txt                            |    9 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../java/META-INF/native/linux64/libggshmem.so  |  Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |  Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |  Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |  Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../processors/cache/GridCacheAdapter.java      |   16 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../cache/GridCacheMvccCandidate.java           |    4 +-
 .../processors/cache/GridCacheStoreManager.java |   25 +-
 .../processors/cache/IgniteCacheProxy.java      |   24 +-
 .../transactions/IgniteTxLocalAdapter.java      |   42 +-
 .../internal/processors/fs/GridGgfsServer.java  |   26 +-
 .../processors/fs/GridGgfsServerManager.java    |    8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |    2 +-
 .../processors/fs/IgniteFsProcessor.java        |    4 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |    2 +-
 .../service/GridServiceProcessor.java           |    2 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9100 -----------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../internal/util/ipc/GridIpcEndpoint.java      |   49 -
 .../util/ipc/GridIpcEndpointBindException.java  |   47 -
 .../util/ipc/GridIpcEndpointFactory.java        |   84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |   29 -
 .../util/ipc/GridIpcServerEndpoint.java         |   73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |   66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |  250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |   49 +
 .../util/ipc/IpcEndpointBindException.java      |   47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |   84 +
 .../internal/util/ipc/IpcEndpointType.java      |   29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |   73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |   66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |  250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |   87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |  179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |   87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |  179 +
 .../GridIpcOutOfSystemResourcesException.java   |   59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |  336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |   67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |  171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |   99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |  242 -
 ...cSharedMemoryOperationTimedoutException.java |   59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |   80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |  707 --
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |  374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |  242 -
 .../shmem/IpcOutOfSystemResourcesException.java |   59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |  336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |   67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |  171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |   99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |  261 +
 ...cSharedMemoryOperationTimedoutException.java |   59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |   80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  707 ++
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |  374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |  242 +
 .../util/nio/GridShmemCommunicationClient.java  |    4 +-
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    4 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   27 +-
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   24 +-
 .../IgniteExceptionHelpLinksSelfTest.java       |    3 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   10 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   50 +
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  288 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 .../IgniteCacheTxStoreSessionTest.java          |   11 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    4 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    4 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    4 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  717 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 ...idIpcServerEndpointDeserializerSelfTest.java |  160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |  160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |   76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |   71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |   76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |   71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |  500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |   36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |  267 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |   84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |  500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |   36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |   78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |  267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |   84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |   65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |   35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |  133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |  125 -
 .../IpcSharedMemoryBenchmarkParty.java          |   35 +
 .../IpcSharedMemoryBenchmarkReader.java         |  133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |  125 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    1 +
 .../ignite/testsuites/IgniteFsTestSuite.java    |    2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   10 +-
 .../GridHadoopExternalCommunication.java        |   26 +-
 .../GridHadoopIpcToNioAdapter.java              |    6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |    2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |    4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |    4 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    2 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   20 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |   25 +-
 158 files changed, 17135 insertions(+), 16542 deletions(-)
----------------------------------------------------------------------



[36/50] [abbrv] incubator-ignite git commit: #Tests: Fix GridCacheCommandHandlerSelfTest.

Posted by vo...@apache.org.
#Tests: Fix GridCacheCommandHandlerSelfTest.


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

Branch: refs/heads/ignite-16
Commit: 8b57933eda84a6e9cbaafdfe5af49f2175c30549
Parents: 0331e7b
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 30 17:08:20 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 30 17:08:20 2015 +0300

----------------------------------------------------------------------
 .../handlers/cache/GridCacheCommandHandlerSelfTest.java   | 10 +++++-----
 1 file changed, 5 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8b57933e/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
index 7a1765b..f577c21 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/rest/handlers/cache/GridCacheCommandHandlerSelfTest.java
@@ -75,7 +75,7 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testCacheGetFailsSyncNotify() throws Exception {
-        GridRestCommandHandler hnd = new TestableGridCacheCommandHandler(((IgniteKernal)grid()).context(), "getAsync",
+        GridRestCommandHandler hnd = new TestableCacheCommandHandler(((IgniteKernal)grid()).context(), "getAsync",
             true);
 
         GridRestCacheRequest req = new GridRestCacheRequest();
@@ -100,7 +100,7 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
      * @throws Exception If failed.
      */
     public void testCacheGetFailsAsyncNotify() throws Exception {
-        GridRestCommandHandler hnd = new TestableGridCacheCommandHandler(((IgniteKernal)grid()).context(), "getAsync",
+        GridRestCommandHandler hnd = new TestableCacheCommandHandler(((IgniteKernal)grid()).context(), "getAsync",
             false);
 
         GridRestCacheRequest req = new GridRestCacheRequest();
@@ -207,7 +207,7 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
     /**
      * Test command handler.
      */
-    private static class TestableGridCacheCommandHandler extends GridCacheCommandHandler {
+    private static class TestableCacheCommandHandler extends GridCacheCommandHandler {
         /** */
         private final String failMtd;
 
@@ -221,7 +221,7 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
          * @param failMtd Method to fail.
          * @param sync Sync notification flag.
          */
-        TestableGridCacheCommandHandler(final GridKernalContext ctx, final String failMtd, final boolean sync) {
+        TestableCacheCommandHandler(final GridKernalContext ctx, final String failMtd, final boolean sync) {
             super(ctx);
 
             this.failMtd = failMtd;
@@ -249,7 +249,7 @@ public class GridCacheCommandHandlerSelfTest extends GridCommonAbstractTest {
                             return fut;
                         }
                         // Rewriting flagOn result to keep intercepting invocations after it.
-                        else if ("flagOn".equals(mtd.getName()))
+                        else if ("flagsOn".equals(mtd.getName()))
                             return proxy;
                         else if ("forSubjectId".equals(mtd.getName()))
                             return proxy;


[19/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-67

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryServerEndpoint.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryServerEndpoint.java
index 0000000,d22f2c9..679fec1
mode 000000,100644..100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryServerEndpoint.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryServerEndpoint.java
@@@ -1,0 -1,707 +1,707 @@@
+ /*
+  * 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.util.ipc.shmem;
+ 
+ import org.apache.ignite.*;
+ import org.apache.ignite.internal.util.*;
+ import org.apache.ignite.resources.*;
+ import org.apache.ignite.thread.*;
+ import org.apache.ignite.internal.processors.resource.*;
+ import org.apache.ignite.internal.util.typedef.*;
+ import org.apache.ignite.internal.util.typedef.internal.*;
+ import org.apache.ignite.internal.util.ipc.*;
+ import org.apache.ignite.internal.util.lang.*;
+ import org.apache.ignite.internal.util.tostring.*;
+ import org.apache.ignite.internal.util.worker.*;
+ import org.jetbrains.annotations.*;
+ 
+ import java.io.*;
+ import java.net.*;
+ import java.nio.channels.*;
+ import java.util.*;
+ import java.util.concurrent.atomic.*;
+ 
+ /**
+  * Server shared memory IPC endpoint.
+  */
+ public class IpcSharedMemoryServerEndpoint implements IpcServerEndpoint {
+     /** Troubleshooting public wiki page. */
+     public static final String TROUBLESHOOTING_URL = "http://bit.ly/GridGain-Troubleshooting";
+ 
+     /** IPC error message. */
+     public static final String OUT_OF_RESOURCES_MSG = "Failed to allocate shared memory segment " +
+         "(for troubleshooting see " + TROUBLESHOOTING_URL + ')';
+ 
+     /** Default endpoint port number. */
+     public static final int DFLT_IPC_PORT = 10500;
+ 
+     /** Default shared memory space in bytes. */
+     public static final int DFLT_SPACE_SIZE = 256 * 1024;
+ 
+     /**
 -     * Default token directory. Note that this path is relative to {@code GRIDGAIN_HOME/work} folder
 -     * if {@code GRIDGAIN_HOME} system or environment variable specified, otherwise it is relative to
++     * Default token directory. Note that this path is relative to {@code IGNITE_HOME/work} folder
++     * if {@code IGNITE_HOME} system or environment variable specified, otherwise it is relative to
+      * {@code work} folder under system {@code java.io.tmpdir} folder.
+      *
+      * @see org.apache.ignite.configuration.IgniteConfiguration#getWorkDirectory()
+      */
+     public static final String DFLT_TOKEN_DIR_PATH = "ipc/shmem";
+ 
+     /**
+      * Shared memory token file name prefix.
+      *
+      * Token files are created and stored in the following manner: [tokDirPath]/[nodeId]-[current
+      * PID]/gg-shmem-space-[auto_idx]-[other_party_pid]-[size]
+      */
+     public static final String TOKEN_FILE_NAME = "gg-shmem-space-";
+ 
+     /** Default lock file name. */
+     private static final String LOCK_FILE_NAME = "lock.file";
+ 
+     /** GC frequency. */
+     private static final long GC_FREQ = 10000;
+ 
+     /** ID generator. */
+     private static final AtomicLong tokIdxGen = new AtomicLong();
+ 
+     /** Port to bind socket to. */
+     private int port = DFLT_IPC_PORT;
+ 
+     /** Prefix. */
+     private String tokDirPath = DFLT_TOKEN_DIR_PATH;
+ 
+     /** Space size. */
+     private int size = DFLT_SPACE_SIZE;
+ 
+     /** Server socket. */
+     @GridToStringExclude
+     private ServerSocket srvSock;
+ 
+     /** Token directory. */
+     private File tokDir;
+ 
+     /** Logger. */
+     @IgniteLoggerResource
+     private IgniteLogger log;
+ 
+     /** Local node ID. */
+     private UUID locNodeId;
+ 
+     /** Grid name. */
+     private String gridName;
+ 
+     /** Flag allowing not to print out of resources warning. */
+     private boolean omitOutOfResourcesWarn;
+ 
+     /** GC worker. */
+     private GridWorker gcWorker;
+ 
+     /** Pid of the current process. */
+     private int pid;
+ 
+     /** Closed flag. */
+     private volatile boolean closed;
+ 
+     /** Spaces opened on with this endpoint. */
+     private final Collection<IpcSharedMemoryClientEndpoint> endpoints =
+         new GridConcurrentHashSet<>();
+ 
+     /** Use this constructor when dependencies could be injected with {@link GridResourceProcessor#injectGeneric(Object)}. */
+     public IpcSharedMemoryServerEndpoint() {
+         // No-op.
+     }
+ 
+     /**
+      * Constructor to set dependencies explicitly.
+      *
+      * @param log Log.
+      * @param locNodeId Node id.
+      * @param gridName Grid name.
+      */
+     public IpcSharedMemoryServerEndpoint(IgniteLogger log, UUID locNodeId, String gridName) {
+         this.log = log;
+         this.locNodeId = locNodeId;
+         this.gridName = gridName;
+     }
+ 
+     /** @param omitOutOfResourcesWarn If {@code true}, out of resources warning will not be printed by server. */
+     public void omitOutOfResourcesWarning(boolean omitOutOfResourcesWarn) {
+         this.omitOutOfResourcesWarn = omitOutOfResourcesWarn;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public void start() throws IgniteCheckedException {
+         IpcSharedMemoryNativeLoader.load();
+ 
+         pid = IpcSharedMemoryUtils.pid();
+ 
+         if (pid == -1)
+             throw new IpcEndpointBindException("Failed to get PID of the current process.");
+ 
+         if (size <= 0)
+             throw new IpcEndpointBindException("Space size should be positive: " + size);
+ 
+         String tokDirPath = this.tokDirPath;
+ 
+         if (F.isEmpty(tokDirPath))
+             throw new IpcEndpointBindException("Token directory path is empty.");
+ 
+         tokDirPath = tokDirPath + '/' + locNodeId.toString() + '-' + IpcSharedMemoryUtils.pid();
+ 
+         tokDir = U.resolveWorkDirectory(tokDirPath, false);
+ 
+         if (port <= 0 || port >= 0xffff)
+             throw new IpcEndpointBindException("Port value is illegal: " + port);
+ 
+         try {
+             srvSock = new ServerSocket();
+ 
+             // Always bind to loopback.
+             srvSock.bind(new InetSocketAddress("127.0.0.1", port));
+         }
+         catch (IOException e) {
+             // Although empty socket constructor never throws exception, close it just in case.
+             U.closeQuiet(srvSock);
+ 
+             throw new IpcEndpointBindException("Failed to bind shared memory IPC endpoint (is port already " +
+                 "in use?): " + port, e);
+         }
+ 
+         gcWorker = new GcWorker(gridName, "ipc-shmem-gc", log);
+ 
+         new IgniteThread(gcWorker).start();
+ 
+         if (log.isInfoEnabled())
+             log.info("IPC shared memory server endpoint started [port=" + port +
+                 ", tokDir=" + tokDir.getAbsolutePath() + ']');
+     }
+ 
+     /** {@inheritDoc} */
+     @SuppressWarnings("ErrorNotRethrown")
+     @Override public IpcEndpoint accept() throws IgniteCheckedException {
+         while (!Thread.currentThread().isInterrupted()) {
+             Socket sock = null;
+ 
+             boolean accepted = false;
+ 
+             try {
+                 sock = srvSock.accept();
+ 
+                 accepted = true;
+ 
+                 InputStream inputStream = sock.getInputStream();
+                 ObjectInputStream in = new ObjectInputStream(inputStream);
+ 
+                 ObjectOutputStream out = new ObjectOutputStream(sock.getOutputStream());
+ 
+                 IpcSharedMemorySpace inSpace = null;
+ 
+                 IpcSharedMemorySpace outSpace = null;
+ 
+                 boolean err = true;
+ 
+                 try {
+                     IpcSharedMemoryInitRequest req = (IpcSharedMemoryInitRequest)in.readObject();
+ 
+                     if (log.isDebugEnabled())
+                         log.debug("Processing request: " + req);
+ 
+                     IgnitePair<String> p = inOutToken(req.pid(), size);
+ 
+                     String file1 = p.get1();
+                     String file2 = p.get2();
+ 
+                     assert file1 != null;
+                     assert file2 != null;
+ 
+                     // Create tokens.
+                     new File(file1).createNewFile();
+                     new File(file2).createNewFile();
+ 
+                     if (log.isDebugEnabled())
+                         log.debug("Created token files: " + p);
+ 
+                     inSpace = new IpcSharedMemorySpace(
+                         file1,
+                         req.pid(),
+                         pid,
+                         size,
+                         true,
+                         log);
+ 
+                     outSpace = new IpcSharedMemorySpace(
+                         file2,
+                         pid,
+                         req.pid(),
+                         size,
+                         false,
+                         log);
+ 
+                     IpcSharedMemoryClientEndpoint ret = new IpcSharedMemoryClientEndpoint(inSpace, outSpace,
+                         log);
+ 
+                     out.writeObject(new IpcSharedMemoryInitResponse(file2, outSpace.sharedMemoryId(),
+                         file1, inSpace.sharedMemoryId(), pid, size));
+ 
+                     err = !in.readBoolean();
+ 
+                     endpoints.add(ret);
+ 
+                     return ret;
+                 }
+                 catch (UnsatisfiedLinkError e) {
+                     throw IpcSharedMemoryUtils.linkError(e);
+                 }
+                 catch (IOException e) {
+                     if (log.isDebugEnabled())
+                         log.debug("Failed to process incoming connection " +
+                             "(was connection closed by another party):" + e.getMessage());
+                 }
+                 catch (ClassNotFoundException e) {
+                     U.error(log, "Failed to process incoming connection.", e);
+                 }
+                 catch (ClassCastException e) {
+                     String msg = "Failed to process incoming connection (most probably, shared memory " +
+                         "rest endpoint has been configured by mistake).";
+ 
+                     LT.warn(log, null, msg);
+ 
+                     sendErrorResponse(out, e);
+                 }
+                 catch (IpcOutOfSystemResourcesException e) {
+                     if (!omitOutOfResourcesWarn)
+                         LT.warn(log, null, OUT_OF_RESOURCES_MSG);
+ 
+                     sendErrorResponse(out, e);
+                 }
+                 catch (IgniteCheckedException e) {
+                     LT.error(log, e, "Failed to process incoming shared memory connection.");
+ 
+                     sendErrorResponse(out, e);
+                 }
+                 finally {
+                     // Exception has been thrown, need to free system resources.
+                     if (err) {
+                         if (inSpace != null)
+                             inSpace.forceClose();
+ 
+                         // Safety.
+                         if (outSpace != null)
+                             outSpace.forceClose();
+                     }
+                 }
+             }
+             catch (IOException e) {
+                 if (!Thread.currentThread().isInterrupted() && !accepted)
+                     throw new IgniteCheckedException("Failed to accept incoming connection.", e);
+ 
+                 if (!closed)
+                     LT.error(log, null, "Failed to process incoming shared memory connection: " + e.getMessage());
+             }
+             finally {
+                 U.closeQuiet(sock);
+             }
+         } // while
+ 
+         throw new IgniteInterruptedException("Socket accept was interrupted.");
+     }
+ 
+     /**
+      * Injects resources.
+      *
+      * @param ignite Ignite
+      */
+     @IgniteInstanceResource
+     private void injectResources(Ignite ignite){
+         if (ignite != null) {
+             // Inject resources.
+             gridName = ignite.name();
+             locNodeId = ignite.configuration().getNodeId();
+         }
+         else {
+             // Cleanup resources.
+             gridName = null;
+             locNodeId = null;
+         }
+     }
+ 
+     /**
+      * @param out Output stream.
+      * @param err Error cause.
+      */
+     private void sendErrorResponse(ObjectOutput out, Exception err) {
+         try {
+             out.writeObject(new IpcSharedMemoryInitResponse(err));
+         }
+         catch (IOException e) {
+             U.error(log, "Failed to send error response to client.", e);
+         }
+     }
+ 
+     /**
+      * @param pid PID of the other party.
+      * @param size Size of the space.
+      * @return Token pair.
+      */
+     private IgnitePair<String> inOutToken(int pid, int size) {
+         while (true) {
+             long idx = tokIdxGen.get();
+ 
+             if (tokIdxGen.compareAndSet(idx, idx + 2))
+                 return F.pair(new File(tokDir, TOKEN_FILE_NAME + idx + "-" + pid + "-" + size).getAbsolutePath(),
+                     new File(tokDir, TOKEN_FILE_NAME + (idx + 1) + "-" + pid + "-" + size).getAbsolutePath());
+         }
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public int getPort() {
+         return port;
+     }
+ 
+     /** {@inheritDoc} */
+     @Nullable @Override public String getHost() {
+         return null;
+     }
+ 
+     /**
+      * {@inheritDoc}
+      *
+      * @return {@code false} as shared memory endpoints can not be used for management.
+      */
+     @Override public boolean isManagement() {
+         return false;
+     }
+ 
+     /**
+      * Sets port endpoint will be bound to.
+      *
+      * @param port Port number.
+      */
+     public void setPort(int port) {
+         this.port = port;
+     }
+ 
+     /**
+      * Gets token directory path.
+      *
+      * @return Token directory path.
+      */
+     public String getTokenDirectoryPath() {
+         return tokDirPath;
+     }
+ 
+     /**
+      * Sets token directory path.
+      *
+      * @param tokDirPath Token directory path.
+      */
+     public void setTokenDirectoryPath(String tokDirPath) {
+         this.tokDirPath = tokDirPath;
+     }
+ 
+     /**
+      * Gets size of shared memory spaces that are created by the endpoint.
+      *
+      * @return Size of shared memory space.
+      */
+     public int getSize() {
+         return size;
+     }
+ 
+     /**
+      * Sets size of shared memory spaces that are created by the endpoint.
+      *
+      * @param size Size of shared memory space.
+      */
+     public void setSize(int size) {
+         this.size = size;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public void close() {
+         closed = true;
+ 
+         U.closeQuiet(srvSock);
+ 
+         if (gcWorker != null) {
+             U.cancel(gcWorker);
+ 
+             // This method may be called from already interrupted thread.
+             // Need to ensure cleaning on close.
+             boolean interrupted = Thread.interrupted();
+ 
+             try {
+                 U.join(gcWorker);
+             }
+             catch (IgniteInterruptedException e) {
+                 U.warn(log, "Interrupted when stopping GC worker.", e);
+             }
+             finally {
+                 if (interrupted)
+                     Thread.currentThread().interrupt();
+             }
+         }
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String toString() {
+         return S.toString(IpcSharedMemoryServerEndpoint.class, this);
+     }
+ 
+     /**
+      * Sets configuration properties from the map.
+      *
+      * @param endpointCfg Map of properties.
+      * @throws IgniteCheckedException If invalid property name or value.
+      */
+     public void setupConfiguration(Map<String, String> endpointCfg) throws IgniteCheckedException {
+         for (Map.Entry<String,String> e : endpointCfg.entrySet()) {
+             try {
+                 switch (e.getKey()) {
+                     case "type":
+                     case "host":
+                     case "management":
+                         //Ignore these properties
+                         break;
+ 
+                     case "port":
+                         setPort(Integer.parseInt(e.getValue()));
+                         break;
+ 
+                     case "size":
+                         setSize(Integer.parseInt(e.getValue()));
+                         break;
+ 
+                     case "tokenDirectoryPath":
+                         setTokenDirectoryPath(e.getValue());
+                         break;
+ 
+                     default:
+                         throw new IgniteCheckedException("Invalid property '" + e.getKey() + "' of " + getClass().getSimpleName());
+                 }
+             }
+             catch (Throwable t) {
+                 if (t instanceof IgniteCheckedException)
+                     throw t;
+ 
+                 throw new IgniteCheckedException("Invalid value '" + e.getValue() + "' of the property '" + e.getKey() + "' in " +
+                         getClass().getSimpleName(), t);
+             }
+         }
+     }
+ 
+     /**
+      *
+      */
+     private class GcWorker extends GridWorker {
+         /**
+          * @param gridName Grid name.
+          * @param name Name.
+          * @param log Log.
+          */
+         protected GcWorker(@Nullable String gridName, String name, IgniteLogger log) {
+             super(gridName, name, log);
+         }
+ 
+         /** {@inheritDoc} */
+         @Override protected void body() throws InterruptedException, IgniteInterruptedException {
+             if (log.isDebugEnabled())
+                 log.debug("GC worker started.");
+ 
+             File workTokDir = tokDir.getParentFile();
+ 
+             assert workTokDir != null;
+ 
+             while (!isCancelled()) {
+                 U.sleep(GC_FREQ);
+ 
+                 if (log.isDebugEnabled())
+                     log.debug("Starting GC iteration.");
+ 
+                 RandomAccessFile lockFile = null;
+ 
+                 FileLock lock = null;
+ 
+                 try {
+                     lockFile = new RandomAccessFile(new File(workTokDir, LOCK_FILE_NAME), "rw");
+ 
+                     lock = lockFile.getChannel().lock();
+ 
+                     if (lock != null)
+                         processTokenDirectory(workTokDir);
+                     else if (log.isDebugEnabled())
+                         log.debug("Token directory is being processed concurrently: " + workTokDir.getAbsolutePath());
+                 }
+                 catch (OverlappingFileLockException ignored) {
+                     if (log.isDebugEnabled())
+                         log.debug("Token directory is being processed concurrently: " + workTokDir.getAbsolutePath());
+                 }
+                 catch (IOException e) {
+                     U.error(log, "Failed to process directory: " + workTokDir.getAbsolutePath(), e);
+                 }
+                 finally {
+                     U.releaseQuiet(lock);
+                     U.closeQuiet(lockFile);
+                 }
+ 
+                 // Process spaces created by this endpoint.
+                 if (log.isDebugEnabled())
+                     log.debug("Processing local spaces.");
+ 
+                 for (IpcSharedMemoryClientEndpoint e : endpoints) {
+                     if (log.isDebugEnabled())
+                         log.debug("Processing endpoint: " + e);
+ 
+                     if (!e.checkOtherPartyAlive()) {
+                         endpoints.remove(e);
+ 
+                         if (log.isDebugEnabled())
+                             log.debug("Removed endpoint: " + e);
+                     }
+                 }
+             }
+         }
+ 
+         /** @param workTokDir Token directory (common for multiple nodes). */
+         private void processTokenDirectory(File workTokDir) {
+             for (File f : workTokDir.listFiles()) {
+                 if (!f.isDirectory()) {
+                     if (!f.getName().equals(LOCK_FILE_NAME)) {
+                         if (log.isDebugEnabled())
+                             log.debug("Unexpected file: " + f.getName());
+                     }
+ 
+                     continue;
+                 }
+ 
+                 if (f.equals(tokDir)) {
+                     if (log.isDebugEnabled())
+                         log.debug("Skipping own token directory: " + tokDir.getName());
+ 
+                     continue;
+                 }
+ 
+                 String name = f.getName();
+ 
+                 int pid;
+ 
+                 try {
+                     pid = Integer.parseInt(name.substring(name.lastIndexOf('-') + 1));
+                 }
+                 catch (NumberFormatException ignored) {
+                     if (log.isDebugEnabled())
+                         log.debug("Failed to parse file name: " + name);
+ 
+                     continue;
+                 }
+ 
+                 // Is process alive?
+                 if (IpcSharedMemoryUtils.alive(pid)) {
+                     if (log.isDebugEnabled())
+                         log.debug("Skipping alive node: " + pid);
+ 
+                     continue;
+                 }
+ 
+                 if (log.isDebugEnabled())
+                     log.debug("Possibly stale token folder: " + f);
+ 
+                 // Process each token under stale token folder.
+                 File[] shmemToks = f.listFiles();
+ 
+                 if (shmemToks == null)
+                     // Although this is strange, but is reproducible sometimes on linux.
+                     return;
+ 
+                 int rmvCnt = 0;
+ 
+                 try {
+                     for (File f0 : shmemToks) {
+                         if (log.isDebugEnabled())
+                             log.debug("Processing token file: " + f0.getName());
+ 
+                         if (f0.isDirectory()) {
+                             if (log.isDebugEnabled())
+                                 log.debug("Unexpected directory: " + f0.getName());
+                         }
+ 
+                         // Token file format: gg-shmem-space-[auto_idx]-[other_party_pid]-[size]
+                         String[] toks = f0.getName().split("-");
+ 
+                         if (toks.length != 6) {
+                             if (log.isDebugEnabled())
+                                 log.debug("Unrecognized token file: " + f0.getName());
+ 
+                             continue;
+                         }
+ 
+                         int pid0;
+                         int size;
+ 
+                         try {
+                             pid0 = Integer.parseInt(toks[4]);
+                             size = Integer.parseInt(toks[5]);
+                         }
+                         catch (NumberFormatException ignored) {
+                             if (log.isDebugEnabled())
+                                 log.debug("Failed to parse file name: " + name);
+ 
+                             continue;
+                         }
+ 
+                         if (IpcSharedMemoryUtils.alive(pid0)) {
+                             if (log.isDebugEnabled())
+                                 log.debug("Skipping alive process: " + pid0);
+ 
+                             continue;
+                         }
+ 
+                         if (log.isDebugEnabled())
+                             log.debug("Possibly stale token file: " + f0);
+ 
+                         IpcSharedMemoryUtils.freeSystemResources(f0.getAbsolutePath(), size);
+ 
+                         if (f0.delete()) {
+                             if (log.isDebugEnabled())
+                                 log.debug("Deleted file: " + f0.getName());
+ 
+                             rmvCnt++;
+                         }
+                         else if (!f0.exists()) {
+                             if (log.isDebugEnabled())
+                                 log.debug("File has been concurrently deleted: " + f0.getName());
+ 
+                             rmvCnt++;
+                         }
+                         else if (log.isDebugEnabled())
+                             log.debug("Failed to delete file: " + f0.getName());
+                     }
+                 }
+                 finally {
+                     // Assuming that no new files can appear, since
+                     if (rmvCnt == shmemToks.length) {
+                         U.delete(f);
+ 
+                         if (log.isDebugEnabled())
+                             log.debug("Deleted empty token directory: " + f.getName());
+                     }
+                 }
+             }
+         }
+     }
+ }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemorySpace.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemorySpace.java
index 0000000,ba4be48..249d995
mode 000000,100644..100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemorySpace.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemorySpace.java
@@@ -1,0 -1,374 +1,374 @@@
+ /*
+  * 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.util.ipc.shmem;
+ 
+ import org.apache.ignite.*;
+ import org.apache.ignite.internal.util.typedef.internal.*;
+ 
+ import java.io.*;
+ import java.nio.*;
+ import java.util.concurrent.atomic.*;
+ import java.util.concurrent.locks.*;
+ 
+ import static org.apache.ignite.IgniteSystemProperties.*;
+ 
+ /**
+  *
+  */
+ @SuppressWarnings({"PointlessBooleanExpression", "ConstantConditions"})
+ public class IpcSharedMemorySpace implements Closeable {
+     /** Debug flag (enable for testing). */
 -    private static final boolean DEBUG = Boolean.getBoolean(GG_IPC_SHMEM_SPACE_DEBUG);
++    private static final boolean DEBUG = Boolean.getBoolean(IGNITE_IPC_SHMEM_SPACE_DEBUG);
+ 
+     /** Shared memory segment size (operable). */
+     private final int opSize;
+ 
+     /** Shared memory native pointer. */
+     private final long shmemPtr;
+ 
+     /** Shared memory ID. */
+     private final int shmemId;
+ 
+     /** Semaphore set ID. */
+     private final int semId;
+ 
+     /** Local closed flag. */
+     private final AtomicBoolean closed = new AtomicBoolean();
+ 
+     /** {@code True} if space has been closed. */
+     private final boolean isReader;
+ 
+     /** Lock to protect readers and writers from concurrent close. */
+     private final ReadWriteLock lock = new ReentrantReadWriteLock();
+ 
+     /** */
+     private final int writerPid;
+ 
+     /** */
+     private final int readerPid;
+ 
+     /** */
+     private final String tokFileName;
+ 
+     /** */
+     private final IgniteLogger log;
+ 
+     /**
+      * This will allocate system resources for the space.
+      *
+      * @param tokFileName Token filename.
+      * @param writerPid Writer PID.
+      * @param readerPid Reader PID.
+      * @param size Size in bytes.
+      * @param reader {@code True} if reader.
+      * @param parent Parent logger.
+      * @throws IgniteCheckedException If failed.
+      */
+     public IpcSharedMemorySpace(String tokFileName, int writerPid, int readerPid, int size, boolean reader,
+                                 IgniteLogger parent) throws IgniteCheckedException {
+         assert size > 0 : "Size cannot be less than 1 byte";
+ 
+         log = parent.getLogger(IpcSharedMemorySpace.class);
+ 
+         opSize = size;
+ 
+         shmemPtr = IpcSharedMemoryUtils.allocateSystemResources(tokFileName, size, DEBUG && log.isDebugEnabled());
+ 
+         shmemId = IpcSharedMemoryUtils.sharedMemoryId(shmemPtr);
+         semId = IpcSharedMemoryUtils.semaphoreId(shmemPtr);
+ 
+         isReader = reader;
+ 
+         this.tokFileName = tokFileName;
+         this.readerPid = readerPid;
+         this.writerPid = writerPid;
+ 
+         if (DEBUG && log.isDebugEnabled())
+             log.debug("Shared memory space has been created: " + this);
+     }
+ 
+     /**
+      * This should be called in order to attach to already allocated system resources.
+      *
+      * @param tokFileName Token file name (for proper cleanup).
+      * @param writerPid Writer PID.
+      * @param readerPid Reader PID.
+      * @param size Size.
+      * @param reader Reader flag.
+      * @param shmemId Shared memory ID.
+      * @param parent Logger.
+      * @throws IgniteCheckedException If failed.
+      */
+     public IpcSharedMemorySpace(String tokFileName, int writerPid, int readerPid, int size, boolean reader,
+                                 int shmemId, IgniteLogger parent) throws IgniteCheckedException {
+         assert size > 0 : "Size cannot be less than 1 byte";
+ 
+         log = parent.getLogger(IpcSharedMemorySpace.class);
+ 
+         opSize = size;
+         isReader = reader;
+         this.shmemId = shmemId;
+         this.writerPid = writerPid;
+         this.readerPid = readerPid;
+         this.tokFileName = tokFileName;
+ 
+         shmemPtr = IpcSharedMemoryUtils.attach(shmemId, DEBUG && log.isDebugEnabled());
+ 
+         semId = IpcSharedMemoryUtils.semaphoreId(shmemPtr);
+     }
+ 
+     /**
+      * @param buf Buffer.
+      * @param off Offset.
+      * @param len Length.
+      * @param timeout Operation timeout in milliseconds ({@code 0} to wait forever).
+      * @throws IgniteCheckedException If space has been closed.
+      * @throws IpcSharedMemoryOperationTimedoutException If operation times out.
+      */
+     public void write(byte[] buf, int off, int len, long timeout) throws IgniteCheckedException,
+             IpcSharedMemoryOperationTimedoutException {
+         assert buf != null;
+         assert len > 0;
+         assert buf.length >= off + len;
+         assert timeout >= 0;
+ 
+         assert !isReader;
+ 
+         lock.readLock().lock();
+ 
+         try {
+             if (closed.get())
+                 throw new IgniteCheckedException("Shared memory segment has been closed: " + this);
+ 
+             IpcSharedMemoryUtils.writeSharedMemory(shmemPtr, buf, off, len, timeout);
+         }
+         finally {
+             lock.readLock().unlock();
+         }
+     }
+ 
+     /**
+      * @param buf Buffer.
+      * @param off Offset.
+      * @param len Length.
+      * @param timeout Operation timeout in milliseconds ({@code 0} to wait forever).
+      * @throws IgniteCheckedException If space has been closed.
+      * @throws IpcSharedMemoryOperationTimedoutException If operation times out.
+      */
+     public void write(ByteBuffer buf, int off, int len, long timeout) throws IgniteCheckedException,
+             IpcSharedMemoryOperationTimedoutException {
+         assert buf != null;
+         assert len > 0;
+         assert buf.limit() >= off + len;
+         assert timeout >= 0;
+         assert !isReader;
+ 
+         lock.readLock().lock();
+ 
+         try {
+             if (closed.get())
+                 throw new IgniteCheckedException("Shared memory segment has been closed: " + this);
+ 
+             IpcSharedMemoryUtils.writeSharedMemoryByteBuffer(shmemPtr, buf, off, len, timeout);
+         }
+         finally {
+             lock.readLock().unlock();
+         }
+     }
+ 
+     /**
+      * Blocks until at least 1 byte is read.
+      *
+      * @param buf Buffer.
+      * @param off Offset.
+      * @param len Length.
+      * @param timeout Operation timeout in milliseconds ({@code 0} to wait forever).
+      * @return Read bytes count.
+      * @throws IgniteCheckedException If space has been closed.
+      * @throws IpcSharedMemoryOperationTimedoutException If operation times out.
+      */
+     public int read(byte[] buf, int off, int len, long timeout) throws IgniteCheckedException,
+             IpcSharedMemoryOperationTimedoutException {
+         assert buf != null;
+         assert len > 0;
+         assert buf.length >= off + len;
+ 
+         assert isReader;
+ 
+         lock.readLock().lock();
+ 
+         try {
+             if (closed.get())
+                 throw new IgniteCheckedException("Shared memory segment has been closed: " + this);
+ 
+             return (int) IpcSharedMemoryUtils.readSharedMemory(shmemPtr, buf, off, len, timeout);
+         }
+         finally {
+             lock.readLock().unlock();
+         }
+     }
+ 
+     /**
+      * Blocks until at least 1 byte is read.
+      *
+      * @param buf Buffer.
+      * @param off Offset.
+      * @param len Length.
+      * @param timeout Operation timeout in milliseconds ({@code 0} to wait forever).
+      * @return Read bytes count.
+      * @throws IgniteCheckedException If space has been closed.
+      * @throws IpcSharedMemoryOperationTimedoutException If operation times out.
+      */
+     public int read(ByteBuffer buf, int off, int len, long timeout) throws IgniteCheckedException,
+             IpcSharedMemoryOperationTimedoutException {
+         assert buf != null;
+         assert len > 0;
+         assert buf.capacity() >= off + len;
+         assert isReader;
+ 
+         lock.readLock().lock();
+ 
+         try {
+             if (closed.get())
+                 throw new IgniteCheckedException("Shared memory segment has been closed: " + this);
+ 
+             return (int) IpcSharedMemoryUtils.readSharedMemoryByteBuffer(shmemPtr, buf, off, len, timeout);
+         }
+         finally {
+             lock.readLock().unlock();
+         }
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public void close() {
+         close0(false);
+     }
+ 
+     /**
+      * Forcibly closes the space and frees all system resources.
+      * <p>
+      * This method should be called with caution as it may result to the other-party
+      * process crash. It is intended to call when there was an IO error during handshake
+      * and other party has not yet attached to the space.
+      */
+     public void forceClose() {
+         close0(true);
+     }
+ 
+     /**
+      * @return Shared memory ID.
+      */
+     public int sharedMemoryId() {
+         return shmemId;
+     }
+ 
+     /**
+      * @return Semaphore set ID.
+      */
+     public int semaphoreId() {
+         return semId;
+     }
+ 
+     /**
+      * @param force {@code True} to close the space.
+      */
+     private void close0(boolean force) {
+         if (!closed.compareAndSet(false, true))
+             return;
+ 
+         IpcSharedMemoryUtils.ipcClose(shmemPtr);
+ 
+         // Wait all readers and writes to leave critical section.
+         lock.writeLock().lock();
+ 
+         try {
+             IpcSharedMemoryUtils.freeSystemResources(tokFileName, shmemPtr, force);
+         }
+         finally {
+             lock.writeLock().unlock();
+         }
+ 
+         if (DEBUG && log.isDebugEnabled())
+             log.debug("Shared memory space has been closed: " + this);
+     }
+ 
+     /**
+      * @return Bytes available for read.
+      * @throws IgniteCheckedException If failed.
+      */
+     public int unreadCount() throws IgniteCheckedException {
+         lock.readLock().lock();
+ 
+         try {
+             if (closed.get())
+                 throw new IgniteCheckedException("Shared memory segment has been closed: " + this);
+ 
+             return IpcSharedMemoryUtils.unreadCount(shmemPtr);
+         }
+         finally {
+             lock.readLock().unlock();
+         }
+     }
+ 
+     /**
+      * @return Shared memory pointer.
+      */
+     public long sharedMemPointer() {
+         return shmemPtr;
+     }
+ 
+     /**
+      * @return Reader PID.
+      */
+     public int readerPid() {
+         return readerPid;
+     }
+ 
+     /**
+      * @return Writer PID.
+      */
+     public int writerPid() {
+         return writerPid;
+     }
+ 
+     /**
+      * @return Vis-a-vis PID.
+      */
+     public int otherPartyPid() {
+         return isReader ? writerPid : readerPid;
+     }
+ 
+     /**
+      * @return Token file name used to create shared memory space.
+      */
+     public String tokenFileName() {
+         return tokFileName;
+     }
+ 
+     /**
+      * @return Space size.
+      */
+     public int size() {
+         return opSize;
+     }
+ 
+     /** {@inheritDoc} */
+     @Override public String toString() {
+         return S.toString(IpcSharedMemorySpace.class, this, "closed", closed.get());
+     }
+ }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/marshaller/optimized/IgniteOptimizedMarshaller.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/spi/communication/tcp/TcpCommunicationSpi.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithSpecifiedWorkDirectorySelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedGridGainHomeSelfTest.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedGridGainHomeSelfTest.java
index 095bd2d,a56f8b2..8fae702
--- a/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedGridGainHomeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/util/GridStartupWithUndefinedGridGainHomeSelfTest.java
@@@ -29,10 -29,10 +29,10 @@@ import org.apache.ignite.internal.util.
  import org.apache.ignite.testframework.junits.common.*;
  
  import static org.apache.ignite.IgniteSystemProperties.*;
- import static org.apache.ignite.internal.util.GridUtils.*;
+ import static org.apache.ignite.internal.util.IgniteUtils.*;
  
  /**
 - * Checks that node can be started without operations with undefined GRIDGAIN_HOME.
 + * Checks that node can be started without operations with undefined IGNITE_HOME.
   * <p>
   * Notes:
   * 1. The test intentionally extends JUnit {@link TestCase} class to make the test

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/deploy/VisorDeployCommand.scala
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/start/VisorStartCommand.scala
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/visor-console/src/main/scala/org/apache/ignite/visor/visor.scala
----------------------------------------------------------------------


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

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


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

Branch: refs/heads/ignite-16
Commit: 4009aaa35cba35752b80d39c03d3b5a87fdf4041
Parents: 9900ae4 7eebc7e
Author: ivasilinets <iv...@gridgain.com>
Authored: Thu Jan 29 18:14:21 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Thu Jan 29 18:14:21 2015 +0300

----------------------------------------------------------------------
 ipc/shmem/Makefile.am                           |    2 +-
 ipc/shmem/Makefile.in                           |    2 +-
 ipc/shmem/configure                             |    4 +-
 ipc/shmem/configure.ac                          |    2 +-
 ipc/shmem/ggshmem/Makefile.am                   |   23 -
 ipc/shmem/ggshmem/Makefile.in                   |  589 --
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |  882 --
 ipc/shmem/igniteshmem/Makefile.am               |   23 +
 ipc/shmem/igniteshmem/Makefile.in               |  589 ++
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  882 ++
 ipc/shmem/include/Makefile.am                   |    2 +-
 ipc/shmem/include/Makefile.in                   |    2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |  117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |  117 -
 ipc/shmem/readme.txt                            |    9 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |    2 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |    2 +-
 .../rest/TaskCommandHandlerSelfTest.java        |    2 +-
 .../java/META-INF/native/linux64/libggshmem.so  |  Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |  Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |  Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |  Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../main/java/org/apache/ignite/Ignition.java   |   38 +-
 .../apache/ignite/cache/CachingProvider.java    |    2 +-
 .../ignite/fs/mapreduce/IgniteFsTask.java       |    2 +-
 .../ignite/internal/ClusterGroupAdapter.java    |    2 +-
 .../internal/ClusterNodeLocalMapImpl.java       |    2 +-
 .../java/org/apache/ignite/internal/GridEx.java |  143 -
 .../org/apache/ignite/internal/GridGainEx.java  | 2399 -----
 .../org/apache/ignite/internal/GridKernal.java  | 3322 -------
 .../ignite/internal/GridKernalContext.java      |    2 +-
 .../ignite/internal/GridKernalContextImpl.java  |    8 +-
 .../apache/ignite/internal/GridLoggerProxy.java |    2 +-
 .../ignite/internal/GridUpdateNotifier.java     |    2 +-
 .../ignite/internal/IgniteClusterAsyncImpl.java |    4 +-
 .../org/apache/ignite/internal/IgniteEx.java    |  143 +
 .../apache/ignite/internal/IgniteKernal.java    | 3322 +++++++
 .../org/apache/ignite/internal/IgnitionEx.java  | 2396 +++++
 .../processors/affinity/GridAffinityUtils.java  |    2 +-
 .../processors/cache/GridCacheAdapter.java      |    8 +-
 .../processors/cache/GridCacheContext.java      |    4 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../cache/GridCacheMvccCandidate.java           |    4 +-
 .../processors/cache/IgniteCacheProxy.java      |   22 +-
 .../GridCacheDataStructuresManager.java         |    4 +-
 .../cache/query/GridCacheQueryManager.java      |    2 +-
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |    2 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |    2 +-
 .../dr/GridDrDataLoadCacheUpdater.java          |    2 +-
 .../internal/processors/fs/GridGgfsImpl.java    |    2 +-
 .../internal/processors/fs/GridGgfsServer.java  |   26 +-
 .../processors/fs/GridGgfsServerManager.java    |    8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |    2 +-
 .../processors/fs/IgniteFsProcessor.java        |    4 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |    2 +-
 .../resource/GridResourceProcessor.java         |    2 +-
 .../resource/GridSpringResourceContext.java     |    2 +-
 .../handlers/cache/GridCacheCommandHandler.java |    6 +-
 .../handlers/task/GridTaskCommandHandler.java   |    2 +-
 .../service/GridServiceProcessor.java           |    2 +-
 .../processors/service/GridServiceProxy.java    |    2 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9100 -----------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../internal/util/ipc/GridIpcEndpoint.java      |   49 -
 .../util/ipc/GridIpcEndpointBindException.java  |   47 -
 .../util/ipc/GridIpcEndpointFactory.java        |   84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |   29 -
 .../util/ipc/GridIpcServerEndpoint.java         |   73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |   66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |  250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |   49 +
 .../util/ipc/IpcEndpointBindException.java      |   47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |   84 +
 .../internal/util/ipc/IpcEndpointType.java      |   29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |   73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |   66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |  250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |   87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |  179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |   87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |  179 +
 .../GridIpcOutOfSystemResourcesException.java   |   59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |  336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |   67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |  171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |   99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |  242 -
 ...cSharedMemoryOperationTimedoutException.java |   59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |   80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |  707 --
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |  374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |  242 -
 .../shmem/IpcOutOfSystemResourcesException.java |   59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |  336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |   67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |  171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |   99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |  261 +
 ...cSharedMemoryOperationTimedoutException.java |   59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |   80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  707 ++
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |  374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |  242 +
 .../util/nio/GridShmemCommunicationClient.java  |    4 +-
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../apache/ignite/internal/visor/VisorJob.java  |    2 +-
 .../internal/visor/VisorMultiNodeTask.java      |    2 +-
 .../ignite/internal/visor/cache/VisorCache.java |    2 +-
 .../compute/VisorComputeMonitoringHolder.java   |   10 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../visor/node/VisorBasicConfiguration.java     |    2 +-
 .../visor/node/VisorGridConfiguration.java      |    2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    6 +-
 .../internal/visor/query/VisorQueryTask.java    |    2 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   27 +-
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   24 +-
 .../StreamerCacheAffinityEventRouter.java       |    2 +-
 .../ignite/GridExceptionHelpLinksSelfTest.java  |  106 -
 .../ignite/GridExternalizableAbstractTest.java  |   41 -
 .../IgniteExceptionHelpLinksSelfTest.java       |  105 +
 .../IgniteExternalizableAbstractTest.java       |   41 +
 ...CachePartitionFairAffinityNodesSelfTest.java |    6 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |    2 +-
 .../fs/GridGgfsEventsAbstractSelfTest.java      |    2 +-
 .../ignite/fs/GridGgfsFragmentizerSelfTest.java |    2 +-
 .../internal/GridDiscoveryEventSelfTest.java    |    3 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    4 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../internal/GridExecutorServiceTest.java       |  315 -
 .../GridExplicitImplicitDeploymentSelfTest.java |  476 -
 .../ignite/internal/GridKernalTestUtils.java    |    3 +-
 .../internal/GridListenActorSelfTest.java       |    3 +-
 .../GridTopicExternalizableSelfTest.java        |    3 +-
 .../GridTopologyBuildVersionSelfTest.java       |    2 +-
 .../internal/GridUpdateNotifierSelfTest.java    |    3 +-
 .../internal/IgniteExecutorServiceTest.java     |  315 +
 ...gniteExplicitImplicitDeploymentSelfTest.java |  476 +
 .../GridCheckpointManagerAbstractSelfTest.java  |    2 +-
 .../GridCommunicationSendMessageSelfTest.java   |    4 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    2 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |    6 +-
 .../swapspace/GridSwapSpaceManagerSelfTest.java |    2 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |    6 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |    4 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   10 +-
 .../cache/GridCacheAbstractSelfTest.java        |    2 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |    4 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    4 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |    4 +-
 .../GridCacheFinishPartitionsSelfTest.java      |    4 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |    4 +-
 .../processors/cache/GridCacheLeakTest.java     |    2 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    2 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |    2 +-
 .../cache/GridCacheMvccFlagsTest.java           |    4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    4 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |    4 +-
 .../processors/cache/GridCacheMvccSelfTest.java |    4 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |    2 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    2 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |    2 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |    6 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |    2 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |    6 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |    2 +-
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    4 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |    4 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |    2 +-
 .../cache/GridCacheTtlManagerLoadTest.java      |    2 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |    2 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |    2 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../processors/cache/IgniteTxAbstractTest.java  |    2 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |    3 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    2 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    6 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |    2 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    2 +-
 .../GridCacheCountDownLatchSelfTest.java        |    2 +-
 .../GridCacheQueueCleanupSelfTest.java          |    2 +-
 .../GridCacheSetAbstractSelfTest.java           |    8 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |    2 +-
 .../GridCacheAtomicTimeoutSelfTest.java         |    2 +-
 .../distributed/GridCacheEventAbstractTest.java |    2 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |    2 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |    2 +-
 ...iteTxConsistencyRestartAbstractSelfTest.java |    4 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |   10 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |   20 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |    2 +-
 .../dht/GridCacheColocatedDebugTest.java        |    6 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |    2 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    4 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |    4 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |    2 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |    2 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |    2 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |   32 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |    8 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    2 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |    4 +-
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |    6 +-
 .../near/GridCacheNearReadersSelfTest.java      |    4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |    2 +-
 .../GridCachePartitionedFullApiSelfTest.java    |    4 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |    2 +-
 .../GridCachePartitionedProjectionSelfTest.java |    4 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    2 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    2 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    4 +-
 .../clock/GridTimeSyncProcessorSelfTest.java    |    6 +-
 .../continuous/GridEventConsumeSelfTest.java    |    2 +-
 .../processors/fs/GridGgfsAbstractSelfTest.java |    2 +-
 .../processors/fs/GridGgfsModesSelfTest.java    |    4 +-
 .../fs/GridGgfsProcessorSelfTest.java           |    2 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    6 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    4 +-
 .../processors/fs/GridGgfsSizeSelfTest.java     |    8 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |   10 +-
 .../GridServiceReassignmentSelfTest.java        |    2 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  717 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 .../util/future/GridFinishedFutureSelfTest.java |    2 +-
 ...idIpcServerEndpointDeserializerSelfTest.java |  160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |  160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |   76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |   71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |   76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |   71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |  500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |   36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |  267 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |   84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |  500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |   36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |   78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |  267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |   84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |   65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |   35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |  133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |  125 -
 .../IpcSharedMemoryBenchmarkParty.java          |   35 +
 .../IpcSharedMemoryBenchmarkReader.java         |  133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |  125 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../cache/GridCachePutRemoveLoadTest.java       |    2 +-
 .../communication/GridIoManagerBenchmark.java   |   10 +-
 .../communication/GridIoManagerBenchmark0.java  |   12 +-
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |    2 +-
 .../marshaller/GridMarshallerAbstractTest.java  |    6 +-
 .../tcp/GridTcpDiscoveryMultiThreadedTest.java  |    2 +-
 .../discovery/tcp/GridTcpDiscoverySelfTest.java |   14 +-
 .../ignite/testframework/GridTestUtils.java     |    4 +-
 .../testframework/junits/GridAbstractTest.java  |   14 +-
 .../junits/GridTestKernalContext.java           |    2 +-
 .../junits/common/GridCommonAbstractTest.java   |   22 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    2 +-
 .../testsuites/IgniteComputeGridTestSuite.java  |    4 +-
 .../ignite/testsuites/IgniteFsTestSuite.java    |    2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   10 +-
 .../GridHadoopDefaultMapReducePlanner.java      |    2 +-
 .../GridHadoopExternalCommunication.java        |   26 +-
 .../GridHadoopIpcToNioAdapter.java              |    6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |    4 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |    4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |    4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |    4 +-
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |    2 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    6 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    4 +-
 .../cache/GridCacheQueryLoadSelfTest.java       |    2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |    8 +-
 .../GridCacheReplicatedFieldsQuerySelfTest.java |    2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    4 +-
 .../query/h2/sql/GridQueryParsingTest.java      |    2 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    2 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |    2 +-
 .../java/org/apache/ignite/IgniteSpring.java    |    8 +-
 .../cache/spring/SpringDynamicCacheManager.java |    2 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    4 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   26 +-
 .../GridServletContextListenerStartup.java      |    4 +-
 .../startup/servlet/GridServletStartup.java     |    4 +-
 316 files changed, 23824 insertions(+), 23627 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4009aaa3/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4009aaa3/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/IgniteCacheProxy.java
----------------------------------------------------------------------


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

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


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

Branch: refs/heads/ignite-16
Commit: 6f49e95540bcf0be76e82a635e1420d666c7a24d
Parents: b82eea3 7e8ea4f
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 2 15:13:37 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 2 15:13:37 2015 +0700

----------------------------------------------------------------------
 assembly/libs/readme.txt                        |   115 +-
 assembly/release-base-fabric.xml                |     6 +-
 assembly/release-base.xml                       |     6 +-
 assembly/release-hadoop.xml                     |     6 +-
 bin/ggrouter.bat                                |    33 -
 bin/ggrouter.sh                                 |    50 -
 bin/ggstart.bat                                 |   228 -
 bin/ggstart.sh                                  |   176 -
 bin/ggvisorcmd.bat                              |   144 -
 bin/ggvisorcmd.sh                               |   124 -
 bin/ignite.bat                                  |   228 +
 bin/ignite.sh                                   |   176 +
 bin/igniterouter.bat                            |    33 +
 bin/igniterouter.sh                             |    50 +
 bin/ignitevisorcmd.bat                          |   144 +
 bin/ignitevisorcmd.sh                           |   124 +
 bin/include/functions.sh                        |    42 +-
 bin/include/hadoop-classpath.bat                |     2 +-
 bin/include/hadoop-classpath.sh                 |     4 +-
 bin/include/parseargs.bat                       |     2 +-
 bin/include/parseargs.sh                        |     6 +-
 bin/include/service.sh                          |    12 +-
 bin/include/setenv.bat                          |    28 +-
 bin/include/setenv.sh                           |    34 +-
 bin/include/target-classpath.bat                |     8 +-
 bin/include/target-classpath.sh                 |    14 +-
 bin/setup-hadoop.bat                            |     2 +-
 bin/setup-hadoop.sh                             |    12 +-
 config/gridgain-log4j.xml                       |   152 -
 config/hadoop/default-config.xml                |     2 +-
 config/ignite-log4j.xml                         |   152 +
 config/java.util.logging.properties             |    16 +-
 config/router/default-router.xml                |     2 +-
 docs/core-site.gridgain.xml                     |    89 -
 docs/core-site.ignite.xml                       |    89 +
 docs/gridgain_readme.md                         |   149 -
 docs/gridgain_readme.pdf                        |   Bin 407698 -> 0 bytes
 docs/hadoop_readme.md                           |    84 +-
 docs/hadoop_readme.pdf                          |   Bin 411788 -> 82297 bytes
 docs/hive-site.gridgain.xml                     |    36 -
 docs/hive-site.ignite.xml                       |    36 +
 docs/ignite_readme.md                           |   100 +
 docs/ignite_readme.pdf                          |   Bin 0 -> 76810 bytes
 docs/mapred-site.gridgain.xml                   |    79 -
 docs/mapred-site.ignite.xml                     |    79 +
 examples/config/example-cache.xml               |     2 +-
 examples/config/example-streamer.xml            |     8 +-
 examples/config/filesystem/example-ggfs.xml     |     2 +-
 examples/config/filesystem/readme.txt           |     4 +-
 examples/config/hibernate/readme.txt            |     4 +-
 examples/config/servlet/WEB-INF/web.xml         |     4 +-
 examples/config/servlet/readme.txt              |     2 +-
 examples/rest/http-rest-example.php             |     2 +-
 examples/rest/memcache-rest-example.php         |     2 +-
 .../compute/ComputeBroadcastExample.java        |     2 +-
 .../compute/ComputeCallableExample.java         |     2 +-
 .../examples/compute/ComputeClosureExample.java |     2 +-
 .../compute/ComputeContinuousMapperExample.java |     2 +-
 .../compute/ComputeExecutorServiceExample.java  |     2 +-
 .../ComputeFibonacciContinuationExample.java    |    13 +-
 .../compute/ComputeProjectionExample.java       |     2 +-
 .../examples/compute/ComputeReducerExample.java |     2 +-
 .../compute/ComputeRunnableExample.java         |     7 +-
 .../compute/ComputeScheduleExample.java         |     2 +-
 .../examples/compute/ComputeTaskMapExample.java |     2 +-
 .../compute/ComputeTaskSplitExample.java        |     2 +-
 .../compute/montecarlo/CreditRiskExample.java   |     2 +-
 .../examples/datagrid/CacheAffinityExample.java |     2 +-
 .../examples/datagrid/CacheApiExample.java      |     2 +-
 .../datagrid/CacheContinuousQueryExample.java   |     2 +-
 .../datagrid/CacheDataLoaderExample.java        |     2 +-
 .../examples/datagrid/CacheEventsExample.java   |     2 +-
 .../datagrid/CachePopularNumbersExample.java    |     2 +-
 .../examples/datagrid/CachePutGetExample.java   |     2 +-
 .../examples/datagrid/CacheQueryExample.java    |     2 +-
 .../datagrid/CacheTransactionExample.java       |     2 +-
 .../datastructures/CacheAtomicLongExample.java  |     2 +-
 .../CacheAtomicReferenceExample.java            |     2 +-
 .../CacheAtomicSequenceExample.java             |     2 +-
 .../CacheAtomicStampedExample.java              |     2 +-
 .../CacheCountDownLatchExample.java             |     2 +-
 .../datastructures/CacheQueueExample.java       |     2 +-
 .../datastructures/CacheSetExample.java         |     2 +-
 .../hibernate/HibernateL2CacheExample.java      |     2 +-
 .../starschema/CacheStarSchemaExample.java      |     2 +-
 .../ignite/examples/events/EventsExample.java   |     2 +-
 .../ignite/examples/ggfs/GgfsExample.java       |     2 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |     2 +-
 .../ignite/examples/ggfs/GgfsNodeStartup.java   |     4 +-
 .../examples/messaging/MessagingExample.java    |     2 +-
 .../messaging/MessagingPingPongExample.java     |     2 +-
 .../MessagingPingPongListenActorExample.java    |     2 +-
 .../misc/deployment/DeploymentExample.java      |     2 +-
 .../misc/springbean/SpringBeanExample.java      |     2 +-
 .../examples/services/ServicesExample.java      |     2 +-
 .../streaming/StreamingCheckInExample.java      |     8 +-
 .../StreamingPopularNumbersExample.java         |     8 +-
 .../streaming/StreamingPriceBarsExample.java    |     8 +-
 .../StreamingRunningAverageExample.java         |     8 +-
 .../apache/ignite/examples/ComputeExample.java  |    59 +
 .../ignite/examples/MessagingExample.java       |   166 +
 .../org/gridgain/examples/ComputeExample.java   |    59 -
 .../org/gridgain/examples/MessagingExample.java |   166 -
 .../examples/ScalarCacheAffinityExample1.scala  |     2 +-
 .../examples/ScalarCacheAffinityExample2.scala  |     2 +-
 .../ScalarCacheAffinitySimpleExample.scala      |     2 +-
 .../scalar/examples/ScalarCacheExample.scala    |     2 +-
 .../ScalarCachePopularNumbersExample.scala      |     2 +-
 .../examples/ScalarCacheQueryExample.scala      |     2 +-
 .../scalar/examples/ScalarClosureExample.scala  |     2 +-
 .../examples/ScalarContinuationExample.scala    |    11 +-
 .../examples/ScalarCreditRiskExample.scala      |     2 +-
 .../examples/ScalarPiCalculationExample.scala   |     2 +-
 .../scalar/examples/ScalarPingPongExample.scala |     2 +-
 .../scalar/examples/ScalarPrimeExample.scala    |     2 +-
 .../scalar/examples/ScalarScheduleExample.scala |     2 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |     2 +-
 .../scalar/examples/ScalarTaskExample.scala     |     2 +-
 .../examples/ScalarWorldShortestMapReduce.scala |     2 +-
 .../GridMonteCarloExamplesSelfTest.java         |     4 +-
 .../testsuites/IgniteExamplesSelfTestSuite.java |     2 +-
 .../ScalarExamplesSelfTestSuite.scala           |     2 +-
 ipc/readme.txt                                  |     4 +-
 ipc/shmem/Makefile.am                           |     2 +-
 ipc/shmem/Makefile.in                           |     2 +-
 ipc/shmem/configure                             |     4 +-
 ipc/shmem/configure.ac                          |     2 +-
 ipc/shmem/ggshmem/Makefile.am                   |    23 -
 ipc/shmem/ggshmem/Makefile.in                   |   589 -
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |   882 --
 ipc/shmem/igniteshmem/Makefile.am               |    23 +
 ipc/shmem/igniteshmem/Makefile.in               |   589 +
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |   882 ++
 ipc/shmem/include/Makefile.am                   |     2 +-
 ipc/shmem/include/Makefile.in                   |     2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |   117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |   117 -
 ipc/shmem/readme.txt                            |    17 +-
 modules/aop/readme.txt                          |    14 +-
 .../GridifySetToXXXNonSpringAopSelfTest.java    |    20 +-
 .../GridifySetToXXXSpringAopSelfTest.java       |    20 +-
 .../ignite/gridify/NonSpringAopSelfTest.java    |    20 +-
 .../optimized/OptimizedMarshallerAopTest.java   |     4 +-
 .../testsuites/IgniteAopSelfTestSuite.java      |     2 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |    20 +-
 modules/aws/readme.txt                          |    14 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |     4 +-
 modules/clients/src/test/bin/start-nodes-ssh.sh |     2 +-
 modules/clients/src/test/bin/start-nodes.cmd    |    24 +-
 modules/clients/src/test/bin/start-nodes.sh     |    34 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |     8 +-
 .../client/ClientDefaultCacheSelfTest.java      |     4 +-
 .../client/ClientTopologyCacheSelfTest.java     |     2 +-
 .../ClientPropertiesConfigurationSelfTest.java  |     4 +-
 .../ClientAbstractMultiNodeSelfTest.java        |     4 +-
 .../integration/ClientAbstractSelfTest.java     |    14 +-
 .../client/router/ClientFailedInitSelfTest.java |     4 +-
 .../client/router/RouterFactorySelfTest.java    |     4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |     4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |     4 +-
 .../rest/RestProcessorStartSelfTest.java        |     3 +-
 .../rest/TaskCommandHandlerSelfTest.java        |     6 +-
 .../protocols/tcp/TcpRestParserSelfTest.java    |     6 +-
 .../src/test/resources/jetty/rest-jetty-ssl.xml |    10 +-
 .../src/test/resources/jetty/rest-jetty.xml     |     8 +-
 .../test/resources/jetty/router-jetty-ssl.xml   |     8 +-
 .../src/test/resources/jetty/router-jetty.xml   |     8 +-
 modules/clients/src/test/resources/log4j.xml    |     4 +-
 .../clients/src/test/resources/spring-cache.xml |     2 +-
 .../src/test/resources/spring-router-ssl.xml    |     4 +-
 .../src/test/resources/spring-router.xml        |     4 +-
 .../src/test/resources/spring-server-node.xml   |     2 +-
 .../test/resources/spring-server-ssl-node.xml   |     2 +-
 .../java/META-INF/native/linux64/libggshmem.so  |   Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |   Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |   Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |   Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteBasicWarmupClosure.java |     6 +-
 .../apache/ignite/IgniteCheckedException.java   |     2 +-
 .../java/org/apache/ignite/IgniteCluster.java   |     6 +-
 .../org/apache/ignite/IgniteDataLoader.java     |    14 +-
 .../java/org/apache/ignite/IgniteException.java |     2 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |     4 +-
 .../java/org/apache/ignite/IgniteLogger.java    |     6 +-
 .../java/org/apache/ignite/IgniteScheduler.java |     6 +-
 .../apache/ignite/IgniteSystemProperties.java   |   198 +-
 .../main/java/org/apache/ignite/Ignition.java   |    54 +-
 .../apache/ignite/cache/CacheConfiguration.java |     3 +-
 .../org/apache/ignite/cache/CacheEntry.java     |    27 +-
 .../apache/ignite/cache/CacheProjection.java    |    43 +-
 .../apache/ignite/cache/CachingProvider.java    |     2 +-
 .../java/org/apache/ignite/cache/GridCache.java |     5 +-
 .../CacheConsistentHashAffinityFunction.java    |     2 +-
 .../apache/ignite/cache/query/CacheQueries.java |     7 +-
 .../apache/ignite/cache/query/CacheQuery.java   |     3 +-
 .../ignite/cache/query/CacheQueryFuture.java    |     4 +-
 .../cache/query/CacheQuerySqlFunction.java      |     4 +-
 .../cache/query/annotations/QuerySqlField.java  |     2 +-
 .../query/annotations/QuerySqlFunction.java     |     2 +-
 .../apache/ignite/cache/store/CacheStore.java   |     2 +-
 .../apache/ignite/client/GridClientCompute.java |     8 +-
 .../ignite/client/router/GridRouterFactory.java |     4 +-
 .../impl/GridRouterCommandLineStartup.java      |     4 +-
 .../router/impl/GridTcpRouterNioParser.java     |     4 +-
 .../ignite/compute/ComputeTaskFuture.java       |     4 +-
 .../ignite/compute/ComputeTaskSession.java      |     3 +-
 .../apache/ignite/compute/gridify/Gridify.java  |     2 +-
 .../ignite/compute/gridify/GridifySetToSet.java |     4 +-
 .../compute/gridify/GridifySetToValue.java      |     4 +-
 .../ClientConnectionConfiguration.java          |    16 +-
 .../configuration/GridQueryConfiguration.java   |   201 -
 .../configuration/IgniteConfiguration.java      |    80 +-
 .../configuration/IgniteDeploymentMode.java     |     4 +-
 .../configuration/IgniteQueryConfiguration.java |   201 +
 .../apache/ignite/fs/IgniteFsConfiguration.java |     2 +-
 .../ignite/fs/mapreduce/IgniteFsTask.java       |     2 +-
 .../org/apache/ignite/hadoop/GridHadoop.java    |     6 +-
 .../ignite/internal/ClusterGroupAdapter.java    |     2 +-
 .../internal/ClusterNodeLocalMapImpl.java       |     2 +-
 .../java/org/apache/ignite/internal/GridEx.java |   143 -
 .../org/apache/ignite/internal/GridGainEx.java  |  2399 ---
 .../ignite/internal/GridJobSessionImpl.java     |     2 +-
 .../org/apache/ignite/internal/GridKernal.java  |  3322 ----
 .../ignite/internal/GridKernalContext.java      |     2 +-
 .../ignite/internal/GridKernalContextImpl.java  |    10 +-
 .../apache/ignite/internal/GridLoggerProxy.java |     6 +-
 .../internal/GridPerformanceSuggestions.java    |     4 +-
 .../apache/ignite/internal/GridProductImpl.java |     2 +-
 .../ignite/internal/GridTaskSessionImpl.java    |     2 +-
 .../ignite/internal/GridUpdateNotifier.java     |     2 +-
 .../ignite/internal/IgniteClusterAsyncImpl.java |     4 +-
 .../org/apache/ignite/internal/IgniteEx.java    |   143 +
 .../ignite/internal/IgniteInternalFuture.java   |   190 +
 .../apache/ignite/internal/IgniteKernal.java    |  3322 ++++
 .../ignite/internal/IgniteSchedulerImpl.java    |     6 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |  2396 +++
 .../internal/executor/GridExecutorService.java  |    44 +-
 .../discovery/GridDiscoveryManager.java         |     2 +-
 .../eventstorage/GridEventStorageManager.java   |     4 +-
 .../affinity/GridAffinityAssignmentCache.java   |     5 +-
 .../affinity/GridAffinityProcessor.java         |     8 +-
 .../processors/affinity/GridAffinityUtils.java  |     2 +-
 .../processors/cache/CacheLockImpl.java         |     4 +-
 .../processors/cache/GridCacheAdapter.java      |   366 +-
 .../cache/GridCacheAffinityManager.java         |     8 +-
 .../processors/cache/GridCacheContext.java      |    16 +-
 .../cache/GridCacheDeploymentManager.java       |     2 +-
 .../processors/cache/GridCacheEntryImpl.java    |    27 +-
 .../cache/GridCacheEvictionEntry.java           |    27 +-
 .../cache/GridCacheEvictionManager.java         |     4 +-
 .../cache/GridCacheExplicitLockSpan.java        |     4 +-
 .../cache/GridCacheFilterEvaluationEntry.java   |    27 +-
 .../processors/cache/GridCacheFuture.java       |     3 +-
 .../processors/cache/GridCacheIoManager.java    |    15 +-
 .../cache/GridCacheMultiTxFuture.java           |     6 +-
 .../cache/GridCacheMvccCandidate.java           |     4 +-
 .../processors/cache/GridCacheMvccManager.java  |    29 +-
 .../GridCachePartitionExchangeManager.java      |    11 +-
 .../processors/cache/GridCachePreloader.java    |     7 +-
 .../cache/GridCachePreloaderAdapter.java        |     9 +-
 .../processors/cache/GridCacheProcessor.java    |    13 +-
 .../processors/cache/GridCacheProjectionEx.java |    27 +-
 .../cache/GridCacheProjectionImpl.java          |    69 +-
 .../processors/cache/GridCacheProxyImpl.java    |    73 +-
 .../cache/GridCacheSharedContext.java           |    13 +-
 .../processors/cache/GridCacheStoreManager.java |    25 +-
 .../processors/cache/GridCacheUtils.java        |     9 +-
 .../processors/cache/IgniteCacheProxy.java      |    37 +-
 .../GridCacheAtomicSequenceImpl.java            |     3 +-
 .../GridCacheDataStructuresManager.java         |     4 +-
 ...ridCacheOptimisticCheckPreparedTxFuture.java |     7 +-
 ...dCachePessimisticCheckCommittedTxFuture.java |     7 +-
 .../distributed/GridCacheTxFinishSync.java      |     8 +-
 .../GridDistributedCacheAdapter.java            |     7 +-
 .../GridDistributedTxRemoteAdapter.java         |     7 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |    12 +-
 .../distributed/dht/GridDhtCacheEntry.java      |     7 +-
 .../distributed/dht/GridDhtEmbeddedFuture.java  |     8 +-
 .../cache/distributed/dht/GridDhtFuture.java    |     4 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |    11 +-
 .../distributed/dht/GridDhtLocalPartition.java  |     7 +-
 .../distributed/dht/GridDhtLockFuture.java      |    11 +-
 .../distributed/dht/GridDhtTopologyFuture.java  |     4 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |    29 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |    11 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |    19 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |    11 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |    11 +-
 .../dht/GridPartitionedGetFuture.java           |    34 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   122 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |    34 +-
 .../dht/colocated/GridDhtColocatedCache.java    |    24 +-
 .../colocated/GridDhtColocatedLockFuture.java   |    23 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |     7 +-
 .../preloader/GridDhtPartitionDemandPool.java   |    13 +-
 .../GridDhtPartitionsExchangeFuture.java        |    20 +-
 .../dht/preloader/GridDhtPreloader.java         |    29 +-
 .../distributed/near/GridNearAtomicCache.java   |    47 +-
 .../distributed/near/GridNearCacheAdapter.java  |    15 +-
 .../distributed/near/GridNearGetFuture.java     |    38 +-
 .../distributed/near/GridNearLockFuture.java    |    23 +-
 .../near/GridNearTransactionalCache.java        |     9 +-
 .../near/GridNearTxFinishFuture.java            |    17 +-
 .../cache/distributed/near/GridNearTxLocal.java |    58 +-
 .../near/GridNearTxPrepareFuture.java           |    17 +-
 .../processors/cache/local/GridLocalCache.java  |     7 +-
 .../processors/cache/local/GridLocalTx.java     |    12 +-
 .../local/atomic/GridLocalAtomicCache.java      |   139 +-
 .../GridCacheDistributedFieldsQueryFuture.java  |     4 +-
 .../query/GridCacheDistributedQueryManager.java |     9 +-
 .../query/GridCacheFieldsQueryErrorFuture.java  |     3 +-
 .../query/GridCacheLocalFieldsQueryFuture.java  |     4 +-
 .../cache/query/GridCacheLocalQueryFuture.java  |     3 +-
 .../cache/query/GridCacheQueriesEx.java         |     6 +-
 .../cache/query/GridCacheQueriesImpl.java       |    11 +-
 .../cache/query/GridCacheQueriesProxy.java      |    11 +-
 .../cache/query/GridCacheQueryManager.java      |    50 +-
 .../query/GridCacheQueryMetadataAware.java      |     4 +-
 .../GridCacheContinuousQueryEntry.java          |    27 +-
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |     2 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |     2 +-
 .../transactions/IgniteTransactionsImpl.java    |     3 +-
 .../cache/transactions/IgniteTxAdapter.java     |     7 +-
 .../cache/transactions/IgniteTxEx.java          |     9 +-
 .../cache/transactions/IgniteTxHandler.java     |    48 +-
 .../transactions/IgniteTxLocalAdapter.java      |   148 +-
 .../cache/transactions/IgniteTxLocalEx.java     |    17 +-
 .../cache/transactions/IgniteTxManager.java     |    25 +-
 .../cache/transactions/IgniteTxProxyImpl.java   |     9 +-
 .../closure/GridClosureProcessor.java           |    56 +-
 .../continuous/GridContinuousProcessor.java     |     4 +-
 .../dataload/GridDataLoaderProcessor.java       |     5 +-
 .../dataload/IgniteDataLoaderImpl.java          |    58 +-
 .../dr/GridDrDataLoadCacheUpdater.java          |     5 +-
 .../email/IgniteEmailProcessorAdapter.java      |     5 +-
 .../email/IgniteNoopEmailProcessor.java         |     5 +-
 .../processors/fs/GridGgfsAsyncImpl.java        |     3 +-
 .../processors/fs/GridGgfsDataManager.java      |    30 +-
 .../internal/processors/fs/GridGgfsEx.java      |     3 +-
 .../internal/processors/fs/GridGgfsImpl.java    |    18 +-
 .../processors/fs/GridGgfsInputStreamImpl.java  |    19 +-
 .../processors/fs/GridGgfsIpcHandler.java       |     4 +-
 .../processors/fs/GridGgfsMetaManager.java      |     9 +-
 .../internal/processors/fs/GridGgfsServer.java  |    34 +-
 .../processors/fs/GridGgfsServerHandler.java    |     4 +-
 .../processors/fs/GridGgfsServerManager.java    |     8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |     2 +-
 .../processors/fs/IgniteFsOutputStreamImpl.java |     3 +-
 .../processors/fs/IgniteFsProcessor.java        |    12 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |     2 +-
 .../hadoop/IgniteHadoopNoopProcessor.java       |     5 +-
 .../hadoop/IgniteHadoopProcessorAdapter.java    |     5 +-
 .../processors/job/GridJobProcessor.java        |     2 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |     4 +-
 .../processors/query/GridQueryIndexing.java     |     4 +-
 .../processors/query/GridQueryProcessor.java    |    12 +-
 .../resource/GridResourceProcessor.java         |     2 +-
 .../resource/GridSpringResourceContext.java     |     2 +-
 .../processors/rest/GridRestProcessor.java      |    18 +-
 .../rest/GridRestProtocolHandler.java           |     4 +-
 .../rest/handlers/GridRestCommandHandler.java   |     4 +-
 .../handlers/cache/GridCacheCommandHandler.java |    60 +-
 .../cache/GridCacheQueryCommandHandler.java     |    12 +-
 .../handlers/log/GridLogCommandHandler.java     |     7 +-
 .../metadata/GridPortableMetadataHandler.java   |     3 +-
 .../handlers/task/GridTaskCommandHandler.java   |    12 +-
 .../top/GridTopologyCommandHandler.java         |     3 +-
 .../version/GridVersionCommandHandler.java      |     3 +-
 .../protocols/tcp/GridClientPacketType.java     |     4 +-
 .../protocols/tcp/GridMemcachedMessage.java     |     4 +-
 .../tcp/GridTcpMemcachedNioListener.java        |    17 +-
 .../protocols/tcp/GridTcpRestNioListener.java   |     5 +-
 .../rest/protocols/tcp/GridTcpRestParser.java   |    18 +-
 .../service/GridServiceProcessor.java           |    22 +-
 .../processors/service/GridServiceProxy.java    |     2 +-
 .../streamer/GridStreamProcessor.java           |     6 +-
 .../processors/streamer/IgniteStreamerImpl.java |     4 +-
 .../internal/util/GridConcurrentFactory.java    |     3 +-
 .../internal/util/GridConfigurationFinder.java  |     4 +-
 .../internal/util/GridReflectionCache.java      |     3 +-
 .../apache/ignite/internal/util/GridUtils.java  |  9100 -----------
 .../ignite/internal/util/IgniteUtils.java       |  9141 +++++++++++
 .../util/future/GridCompoundFuture.java         |    28 +-
 .../util/future/GridCompoundIdentityFuture.java |     2 +-
 .../util/future/GridEmbeddedFuture.java         |    38 +-
 .../util/future/GridFinishedFuture.java         |    10 +-
 .../util/future/GridFinishedFutureEx.java       |     9 +-
 .../internal/util/future/GridFutureAdapter.java |    34 +-
 .../util/future/GridFutureAdapterEx.java        |    31 +-
 .../util/future/GridFutureChainListener.java    |     8 +-
 .../internal/util/io/GridUnsafeDataInput.java   |     2 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |     2 +-
 .../internal/util/ipc/GridIpcEndpoint.java      |    49 -
 .../util/ipc/GridIpcEndpointBindException.java  |    47 -
 .../util/ipc/GridIpcEndpointFactory.java        |    84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |    29 -
 .../util/ipc/GridIpcServerEndpoint.java         |    73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |    66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |   250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |    49 +
 .../util/ipc/IpcEndpointBindException.java      |    47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |    84 +
 .../internal/util/ipc/IpcEndpointType.java      |    29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |    73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |    66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |   250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |    87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |   179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |    87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |   179 +
 .../GridIpcOutOfSystemResourcesException.java   |    59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |   336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |    67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |   171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |    99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |   242 -
 ...cSharedMemoryOperationTimedoutException.java |    59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |    80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |   707 -
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |   374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |   242 -
 .../shmem/IpcOutOfSystemResourcesException.java |    59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |   336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |    67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |   171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |    99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |   261 +
 ...cSharedMemoryOperationTimedoutException.java |    59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |    80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   707 +
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |   374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |   242 +
 .../ignite/internal/util/lang/GridFunc.java     |    53 +-
 .../internal/util/nio/GridBufferedParser.java   |     2 +-
 .../nio/GridConnectionBytesVerifyFilter.java    |    18 +-
 .../ignite/internal/util/nio/GridNioFuture.java |     2 +-
 .../util/nio/GridShmemCommunicationClient.java  |     4 +-
 .../util/nodestart/GridNodeStartUtils.java      |    10 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java   |     2 +-
 .../util/portscanner/GridJmxPortFinder.java     |     4 +-
 .../apache/ignite/internal/util/typedef/X.java  |    10 +-
 .../internal/util/typedef/internal/U.java       |     4 +-
 .../apache/ignite/internal/visor/VisorJob.java  |     2 +-
 .../internal/visor/VisorMultiNodeTask.java      |     2 +-
 .../ignite/internal/visor/cache/VisorCache.java |     2 +-
 .../visor/cache/VisorCachePreloadTask.java      |     6 +-
 .../compute/VisorComputeMonitoringHolder.java   |    10 +-
 .../visor/misc/VisorResolveHostNameTask.java    |     2 +-
 .../visor/node/VisorBasicConfiguration.java     |    28 +-
 .../visor/node/VisorEmailConfiguration.java     |    14 +-
 .../visor/node/VisorGridConfiguration.java      |     2 +-
 .../visor/node/VisorLifecycleConfiguration.java |     2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |     6 +-
 .../visor/node/VisorRestConfiguration.java      |     4 +-
 .../internal/visor/query/VisorQueryTask.java    |     2 +-
 .../internal/visor/query/VisorQueryUtils.java   |     4 +-
 .../apache/ignite/jdbc/IgniteJdbcDriver.java    |     2 +-
 .../apache/ignite/lang/IgniteAsyncSupport.java  |     4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |    38 +-
 .../org/apache/ignite/lang/IgniteFuture.java    |   189 -
 .../apache/ignite/lifecycle/LifecycleBean.java  |     4 +-
 .../ignite/logger/java/IgniteJavaLogger.java    |     4 +-
 .../java/IgniteJavaLoggerFileHandler.java       |     4 +-
 .../optimized/IgniteOptimizedMarshaller.java    |     4 +-
 .../segmentation/GridSegmentationPolicy.java    |     2 +-
 .../ignite/scheduler/SchedulerFuture.java       |     4 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |     4 +-
 .../ignite/spi/IgniteSpiManagementMBean.java    |     2 +-
 .../ignite/spi/checkpoint/CheckpointSpi.java    |     2 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |     6 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    36 +-
 .../ignite/spi/deployment/DeploymentSpi.java    |     2 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |     8 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |     2 +-
 .../TcpDiscoveryMulticastIpFinder.java          |    18 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |     2 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |     2 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |     4 +-
 .../ignite/startup/BasicWarmupClosure.java      |     6 +-
 .../startup/cmdline/CommandLineStartup.java     |    18 +-
 .../startup/cmdline/CommandLineTransformer.java |     8 +-
 .../StreamerCacheAffinityEventRouter.java       |     2 +-
 .../ignite/thread/IgniteThreadFactory.java      |     2 +-
 .../apache/ignite/transactions/IgniteTx.java    |     2 +-
 .../core/src/test/bin/start-nodes-custom.bat    |     2 +-
 modules/core/src/test/bin/start-nodes-custom.sh |     2 +-
 .../spring-cache-client-benchmark-1.xml         |     2 +-
 .../spring-cache-client-benchmark-2.xml         |     2 +-
 .../spring-cache-client-benchmark-3.xml         |     2 +-
 modules/core/src/test/config/example-cache.xml  |     2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |     2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |     2 +-
 modules/core/src/test/config/log4j-test.xml     |     2 +-
 .../core/src/test/config/spring-cache-load.xml  |     2 +-
 .../core/src/test/config/spring-multicache.xml  |     2 +-
 .../average/spring-streamer-average-base.xml    |     2 +-
 .../average/spring-streamer-average-local.xml   |     2 +-
 .../average/spring-streamer-average-random.xml  |     2 +-
 .../config/streamer/spring-streamer-base.xml    |     2 +-
 modules/core/src/test/config/tests.properties   |    10 +-
 .../ignite/GridExceptionHelpLinksSelfTest.java  |   106 -
 .../ignite/GridExternalizableAbstractTest.java  |    41 -
 .../org/apache/ignite/GridTestTaskSession.java  |     4 +-
 .../IgniteExceptionHelpLinksSelfTest.java       |   105 +
 .../IgniteExternalizableAbstractTest.java       |    41 +
 ...CachePartitionFairAffinityNodesSelfTest.java |     6 +-
 .../store/GridCacheBalancingStoreSelfTest.java  |     3 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |     7 +-
 .../fs/GridGgfsEventsAbstractSelfTest.java      |     2 +-
 .../ignite/fs/GridGgfsFragmentizerSelfTest.java |     2 +-
 .../internal/GridDiscoveryEventSelfTest.java    |     3 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |     4 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |     2 +-
 .../internal/GridExecutorServiceTest.java       |   315 -
 .../GridExplicitImplicitDeploymentSelfTest.java |   476 -
 .../internal/GridFactoryVmShutdownTest.java     |     2 +-
 .../ignite/internal/GridHomePathSelfTest.java   |     2 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |    56 +-
 .../ignite/internal/GridKernalTestUtils.java    |     3 +-
 .../internal/GridListenActorSelfTest.java       |     3 +-
 .../internal/GridMultipleJobsSelfTest.java      |     6 +-
 .../GridNodeVisorAttributesSelfTest.java        |     4 +-
 .../internal/GridProjectionAbstractTest.java    |    20 +-
 .../ignite/internal/GridReduceSelfTest.java     |     2 +-
 .../ignite/internal/GridStartStopSelfTest.java  |     2 +-
 .../GridTaskFutureImplStopGridSelfTest.java     |     5 +-
 .../internal/GridTaskListenerSelfTest.java      |     4 +-
 .../GridTopicExternalizableSelfTest.java        |     3 +-
 .../GridTopologyBuildVersionSelfTest.java       |     2 +-
 .../internal/GridUpdateNotifierSelfTest.java    |     3 +-
 .../ignite/internal/GridVersionSelfTest.java    |     8 +-
 .../internal/IgniteExecutorServiceTest.java     |   315 +
 ...gniteExplicitImplicitDeploymentSelfTest.java |   476 +
 .../GridCheckpointManagerAbstractSelfTest.java  |     4 +-
 .../GridCommunicationSendMessageSelfTest.java   |     4 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |     2 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |     6 +-
 .../events/GridEventStorageManagerSelfTest.java |     3 +-
 .../swapspace/GridSwapSpaceManagerSelfTest.java |     2 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |     6 +-
 .../GridCacheAbstractFailoverSelfTest.java      |     3 +-
 .../cache/GridCacheAbstractFlagsTest.java       |     4 +-
 ...cheAbstractFullApiMultithreadedSelfTest.java |     5 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   381 +-
 .../GridCacheAbstractIteratorsSelfTest.java     |    10 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |    28 +-
 .../GridCacheAbstractProjectionSelfTest.java    |    50 +
 .../GridCacheAbstractRemoveFailureTest.java     |    12 +-
 .../cache/GridCacheAbstractSelfTest.java        |     2 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |     4 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |     8 +-
 .../cache/GridCacheConcurrentMapTest.java       |     6 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |     4 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |     4 +-
 .../GridCacheFinishPartitionsSelfTest.java      |    27 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |     6 +-
 ...idCacheGetAndTransformStoreAbstractTest.java |     4 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |     6 +-
 .../GridCacheGroupLockFailoverSelfTest.java     |     5 +-
 .../cache/GridCacheIncrementTransformTest.java  |     4 +-
 .../processors/cache/GridCacheLeakTest.java     |     2 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |    18 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |     9 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |     6 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |     5 +-
 .../cache/GridCacheMvccFlagsTest.java           |     4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |     4 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |     4 +-
 .../processors/cache/GridCacheMvccSelfTest.java |     4 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |     2 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |     2 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |     5 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |     2 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |     6 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |     2 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |     8 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    17 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |     2 +-
 .../GridCacheReferenceCleanupSelfTest.java      |     6 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |     4 +-
 .../GridCacheReturnValueTransferSelfTest.java   |     2 +-
 .../cache/GridCacheSlowTxWarnTest.java          |     6 +-
 .../processors/cache/GridCacheStopSelfTest.java |     6 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |     4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |     4 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |     2 +-
 .../cache/GridCacheTtlManagerLoadTest.java      |     5 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |     2 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |     6 +-
 .../GridCacheVariableTopologySelfTest.java      |     4 +-
 ...idCacheWriteBehindStoreAbstractSelfTest.java |     4 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |     4 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |     6 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |     7 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    10 +-
 .../processors/cache/IgniteTxAbstractTest.java  |     2 +-
 .../IgniteTxConcurrentGetAbstractTest.java      |     3 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |     2 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |     6 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |     6 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |     2 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |    27 +-
 ...actQueueFailoverDataConsistencySelfTest.java |     9 +-
 .../GridCacheCountDownLatchSelfTest.java        |     8 +-
 .../GridCacheMultiNodeDataStructureTest.java    |     4 +-
 .../GridCacheQueueCleanupSelfTest.java          |     5 +-
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |     7 +-
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |    17 +-
 .../GridCacheSetAbstractSelfTest.java           |    15 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |     6 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |     6 +-
 ...dCachePartitionedQueueEntryMoveSelfTest.java |     6 +-
 .../GridCacheAbstractJobExecutionTest.java      |     6 +-
 .../GridCacheAtomicTimeoutSelfTest.java         |    11 +-
 .../GridCacheBasicOpAbstractTest.java           |     7 +-
 .../distributed/GridCacheEventAbstractTest.java |     2 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |     2 +-
 .../distributed/GridCacheLockAbstractTest.java  |     6 +-
 .../GridCacheMultiNodeAbstractTest.java         |    15 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |     2 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |     4 +-
 .../GridCacheNodeFailureAbstractTest.java       |     8 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |   288 +
 ...iteTxConsistencyRestartAbstractSelfTest.java |     4 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |    10 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |    22 +-
 .../IgniteTxPreloadAbstractTest.java            |     4 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java     |    11 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |     2 +-
 .../dht/GridCacheColocatedDebugTest.java        |    11 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |     2 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    10 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |    12 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |     2 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |     2 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |     6 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |     5 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |     5 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |    60 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |     8 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |     5 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |     4 +-
 ...GridCacheValueConsistencyAtomicSelfTest.java |     2 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |     6 +-
 .../near/GridCacheNearReadersSelfTest.java      |     4 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |     2 +-
 .../GridCachePartitionedEntryLockSelfTest.java  |     5 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |     6 +-
 .../GridCachePartitionedFullApiSelfTest.java    |     4 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |     2 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |     5 +-
 .../GridCachePartitionedProjectionSelfTest.java |     4 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |     6 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    11 +-
 .../GridCacheReplicatedEvictionSelfTest.java    |     5 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |     5 +-
 ...heConcurrentEvictionConsistencySelfTest.java |     4 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |     4 +-
 .../cache/eviction/GridCacheMockEntry.java      |    27 +-
 ...cheSynchronousEvictionsFailoverSelfTest.java |     4 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |     2 +-
 .../IgniteCacheTxStoreSessionTest.java          |    11 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |     4 +-
 .../clock/GridTimeSyncProcessorSelfTest.java    |     6 +-
 .../closure/GridClosureProcessorSelfTest.java   |    27 +-
 .../continuous/GridEventConsumeSelfTest.java    |    10 +-
 .../GridDataLoaderProcessorSelfTest.java        |    23 +-
 .../processors/fs/GridGgfsAbstractSelfTest.java |     6 +-
 .../fs/GridGgfsDataManagerSelfTest.java         |     9 +-
 .../processors/fs/GridGgfsModesSelfTest.java    |     4 +-
 .../fs/GridGgfsProcessorSelfTest.java           |     2 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |     6 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |     4 +-
 .../processors/fs/GridGgfsSizeSelfTest.java     |     8 +-
 .../processors/fs/GridGgfsTaskSelfTest.java     |     5 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    13 +-
 .../GridServiceProcessorAbstractSelfTest.java   |    20 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |     8 +-
 .../GridServiceReassignmentSelfTest.java        |     2 +-
 .../streamer/GridStreamerFailoverSelfTest.java  |     4 +-
 .../timeout/GridTimeoutProcessorSelfTest.java   |     5 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |     4 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    10 +-
 .../internal/util/GridTestClockTimer.java       |     6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |   717 -
 .../internal/util/IgniteUtilsSelfTest.java      |   728 +
 .../util/future/GridCompoundFutureSelfTest.java |     8 +-
 .../util/future/GridEmbeddedFutureSelfTest.java |     7 +-
 .../util/future/GridFinishedFutureSelfTest.java |     9 +-
 .../util/future/GridFutureAdapterSelfTest.java  |    23 +-
 .../future/GridFutureListenPerformanceTest.java |     5 +-
 ...GridUnsafeDataOutputArraySizingSelfTest.java |     2 +-
 ...idIpcServerEndpointDeserializerSelfTest.java |   160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |   160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |    76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |    71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |    76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |    71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |   500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |    36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |    87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |   259 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |    84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |   500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |    36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |    78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |    87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |   267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |    84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |    65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |    35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |   133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |   125 -
 .../IpcSharedMemoryBenchmarkParty.java          |    35 +
 .../IpcSharedMemoryBenchmarkReader.java         |   133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |   125 +
 .../internal/util/nio/GridNioSelfTest.java      |     8 +-
 .../offheap/GridOffHeapMapAbstractSelfTest.java |     7 +-
 ...idOffHeapPartitionedMapAbstractSelfTest.java |     3 +-
 ...apPartitionedMapPerformanceAbstractTest.java |    10 +-
 .../unsafe/GridUnsafeMemorySelfTest.java        |     6 +-
 .../ignite/jvmtest/ConcurrentMapTest.java       |     4 +-
 .../ignite/jvmtest/NetworkFailureTest.java      |    16 +-
 .../QueueSizeCounterMultiThreadedTest.java      |     4 +-
 .../jvmtest/ReadWriteLockMultiThreadedTest.java |    10 +-
 .../ignite/lang/GridBasicPerformanceTest.java   |     5 +-
 .../apache/ignite/lang/GridFuncSelfTest.java    |    13 +-
 .../lang/GridFutureListenPerformanceTest.java   |     5 +-
 .../ignite/lang/GridSetWrapperSelfTest.java     |     2 +-
 .../loadtest/GridSingleExecutionTest.java       |     4 +-
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |     6 +-
 .../cache/GridCacheAbstractLoadTest.java        |     8 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |     2 +-
 .../loadtests/cache/GridCacheLoadTest.java      |     2 +-
 .../cache/GridCachePutRemoveLoadTest.java       |     2 +-
 .../loadtests/cache/GridCacheSwapLoadTest.java  |    13 +-
 .../GridCacheWriteBehindStoreLoadTest.java      |     4 +-
 .../capacity/spring-capacity-cache.xml          |     2 +-
 .../loadtests/colocation/GridTestMain.java      |    10 +-
 .../loadtests/colocation/spring-colocation.xml  |     2 +-
 .../communication/GridIoManagerBenchmark.java   |    10 +-
 .../communication/GridIoManagerBenchmark0.java  |    22 +-
 .../GridContinuousOperationsLoadTest.java       |    22 +-
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |     2 +-
 ...GridJobExecutionLoadTestClientSemaphore.java |     5 +-
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |     7 +-
 .../loadtests/mapper/GridNodeStartup.java       |     4 +-
 .../mergesort/GridMergeSortLoadTask.java        |     6 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |     2 +-
 ...apPartitionedMapPerformanceAbstractTest.java |    10 +-
 .../streamer/GridStreamerIndexLoadTest.java     |    10 +-
 .../ignite/loadtests/util/GridLoadTestArgs.java |     8 +-
 .../marshaller/GridMarshallerAbstractTest.java  |    20 +-
 .../ignite/messaging/GridMessagingSelfTest.java |     8 +-
 ...redFsCheckpointSpiMultiThreadedSelfTest.java |     8 +-
 .../collision/GridTestCollisionTaskSession.java |     3 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |     3 +-
 .../tcp/GridTcpCommunicationSpiLanTest.java     |     3 +-
 ...cpCommunicationSpiMultithreadedSelfTest.java |     9 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |     7 +-
 .../tcp/GridTcpDiscoveryMultiThreadedTest.java  |     7 +-
 .../discovery/tcp/GridTcpDiscoverySelfTest.java |    14 +-
 .../file/GridFileSwapSpaceSpiSelfTest.java      |     7 +-
 .../startup/GridRandomCommandLineLoader.java    |    10 +-
 .../ignite/startup/GridVmNodesStarter.java      |     8 +-
 .../GridCommandLineTransformerSelfTest.java     |     6 +-
 .../GridCacheStoreValueBytesTest.java           |     7 +-
 .../index/GridStreamerIndexSelfTest.java        |     8 +-
 .../window/GridStreamerWindowSelfTest.java      |     4 +-
 .../ignite/testframework/GridTestUtils.java     |    22 +-
 .../config/GridTestProperties.java              |    16 +-
 .../testframework/junits/GridAbstractTest.java  |    26 +-
 .../junits/GridTestKernalContext.java           |     2 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |     3 +-
 .../junits/common/GridCommonAbstractTest.java   |    26 +-
 .../logger/GridLog4jRollingFileAppender.java    |     4 +-
 .../junits/logger/GridTestLog4jLogger.java      |     8 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |     2 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |     1 +
 .../testsuites/IgniteComputeGridTestSuite.java  |     4 +-
 .../ignite/testsuites/IgniteFsTestSuite.java    |     2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |     7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |     2 +-
 ...dConcurrentLinkedDequeMultiThreadedTest.java |     6 +-
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |    10 +-
 .../apache/ignite/util/GridIndexFillTest.java   |     4 +-
 .../ignite/util/GridSnapshotLockSelfTest.java   |     6 +-
 .../util/GridSpinReadWriteLockSelfTest.java     |     4 +-
 .../src/test/resources/log/gridgain.log.tst     | 13706 -----------------
 .../core/src/test/resources/log/ignite.log.tst  | 13706 +++++++++++++++++
 modules/core/src/test/resources/readme.txt      |     2 +-
 .../core/src/test/webapp/META-INF/gg-config.xml |     2 +-
 modules/core/src/test/webapp/WEB-INF/web.xml    |     2 +-
 modules/email/readme.txt                        |    14 +-
 .../processors/email/IgniteEmailProcessor.java  |     5 +-
 modules/hadoop/readme.txt                       |    14 +-
 .../GridHadoopClientProtocolProvider.java       |     8 +-
 .../fs/hadoop/v1/GridGgfsHadoopFileSystem.java  |     6 +-
 .../fs/hadoop/v2/GridGgfsHadoopFileSystem.java  |     6 +-
 .../apache/ignite/hadoop/GridHadoopSetup.java   |    16 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |    10 +-
 .../hadoop/GridHadoopClassLoader.java           |     4 +-
 .../processors/hadoop/GridHadoopImpl.java       |     6 +-
 .../hadoop/IgniteHadoopProcessor.java           |     5 +-
 .../hadoop/jobtracker/GridHadoopJobTracker.java |    19 +-
 .../GridHadoopDefaultMapReducePlanner.java      |     2 +-
 .../proto/GridHadoopProtocolJobStatusTask.java  |     7 +-
 .../hadoop/shuffle/GridHadoopShuffle.java       |     2 +-
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |     7 +-
 .../GridHadoopExternalTaskExecutor.java         |    18 +-
 .../child/GridHadoopChildProcessRunner.java     |    18 +-
 .../child/GridHadoopExternalProcessStarter.java |     2 +-
 .../GridHadoopExternalCommunication.java        |    26 +-
 .../GridHadoopIpcToNioAdapter.java              |     6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |     2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |     2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |     4 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |     2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |     2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |     2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |     8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |     4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |     4 +-
 .../hadoop/GridHadoopPopularWordsTest.java      |     6 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |    12 +-
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |     5 +-
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |     4 +-
 .../hadoop/GridHadoopMapReduceTest.java         |     4 +-
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |    12 +-
 .../GridHadoopExecutorServiceTest.java          |     4 +-
 ...GridHadoopExternalTaskExecutionSelfTest.java |     6 +-
 .../ggfs/GridGgfsPerformanceBenchmark.java      |     4 +-
 modules/hibernate/readme.txt                    |    16 +-
 .../hibernate/CacheHibernateBlobStore.java      |   593 +
 .../CacheHibernateBlobStoreEntry.hbm.xml        |    29 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |    86 +
 .../hibernate/GridCacheHibernateBlobStore.java  |   593 -
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |    29 -
 .../GridCacheHibernateBlobStoreEntry.java       |    86 -
 ...idHibernateL2CacheTransactionalSelfTest.java |     2 +-
 .../CacheHibernateBlobStoreSelfTest.java        |   108 +
 .../GridCacheHibernateBlobStoreSelfTest.java    |   108 -
 .../cache/store/hibernate/hibernate.cfg.xml     |     2 +-
 .../testsuites/IgniteHibernateTestSuite.java    |     2 +-
 modules/indexing/readme.txt                     |    14 +-
 .../processors/query/h2/IgniteH2Indexing.java   |    12 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |     2 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |     8 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |     8 +-
 .../cache/GridCacheQueryLoadSelfTest.java       |     2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |    26 +-
 ...idCacheReduceQueryMultithreadedSelfTest.java |     6 +-
 .../near/GridCacheQueryNodeRestartSelfTest.java |     5 +-
 .../GridCacheReplicatedFieldsQuerySelfTest.java |     2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |     6 +-
 .../query/h2/GridH2IndexRebuildTest.java        |     7 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |     6 +-
 .../query/h2/sql/GridQueryParsingTest.java      |     4 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java   |     4 +-
 modules/jcl/readme.txt                          |    14 +-
 .../apache/ignite/logger/jcl/GridJclLogger.java |     4 +-
 modules/jta/readme.txt                          |    14 +-
 .../apache/ignite/cache/jta/CacheTmLookup.java  |    50 +
 .../ignite/cache/jta/GridCacheTmLookup.java     |    50 -
 .../cache/jta/jndi/CacheJndiTmLookup.java       |    74 +
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |    74 -
 .../jta/reflect/CacheReflectionTmLookup.java    |   115 +
 .../reflect/GridCacheReflectionTmLookup.java    |   115 -
 .../processors/cache/jta/CacheJtaManager.java   |     4 +-
 ...CacheJtaConfigurationValidationSelfTest.java |     2 +-
 .../processors/cache/GridCacheJtaSelfTest.java  |     2 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |     6 +-
 modules/log4j/readme.txt                        |    14 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |     8 +-
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |     8 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |     4 +-
 modules/rest-http/readme.txt                    |    14 +-
 .../http/jetty/GridJettyRestProtocol.java       |    16 +-
 .../rest/protocols/http/jetty/rest.html         |     6 +-
 modules/scalar/pom.xml                          |     6 +-
 modules/scalar/readme.txt                       |    10 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |    25 +-
 modules/schedule/readme.txt                     |    14 +-
 .../processors/schedule/ScheduleFutureImpl.java |    26 +-
 .../schedule/GridScheduleSelfTest.java          |    13 +-
 modules/slf4j/readme.txt                        |    14 +-
 modules/spring/readme.txt                       |    14 +-
 .../java/org/apache/ignite/IgniteSpring.java    |    10 +-
 .../ignite/cache/spring/SpringCacheManager.java |     6 +-
 .../cache/spring/SpringDynamicCacheManager.java |     2 +-
 .../spring/IgniteSpringProcessorImpl.java       |    10 +-
 .../ignite/internal/GridFactorySelfTest.java    |     2 +-
 modules/ssh/readme.txt                          |    14 +-
 .../util/nodestart/GridNodeCallableImpl.java    |    20 +-
 .../internal/GridNodeStartUtilsSelfTest.java    |     6 +-
 .../GridProjectionStartStopRestartSelfTest.java |     4 +-
 .../ignite/tools/javadoc/GridLinkTaglet.java    |   165 -
 .../ignite/tools/javadoc/IgniteLinkTaglet.java  |   165 +
 .../optimized/OptimizedClassNamesGenerator.java |    18 +-
 modules/urideploy/readme.txt                    |    14 +-
 .../uri/GridUriDeploymentFileProcessor.java     |     2 +-
 .../deployment/uri/GridUriDeploymentSpi.java    |  1367 --
 .../uri/GridUriDeploymentSpiMBean.java          |    53 -
 .../spi/deployment/uri/UriDeploymentSpi.java    |  1367 ++
 .../deployment/uri/UriDeploymentSpiMBean.java   |    53 +
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |     4 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |     2 +-
 .../uri/GridUriDeploymentAbstractSelfTest.java  |     2 +-
 .../GridUriDeploymentClassLoaderSelfTest.java   |     2 +-
 ...riDeploymentClassloaderRegisterSelfTest.java |     4 +-
 .../uri/GridUriDeploymentConfigSelfTest.java    |    10 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |     2 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |     2 +-
 ...loymentMultiScannersErrorThrottlingTest.java |     2 +-
 .../GridUriDeploymentMultiScannersSelfTest.java |     2 +-
 .../uri/GridUriDeploymentSimpleSelfTest.java    |    10 +-
 .../file/GridFileDeploymentSelfTest.java        |     6 +-
 .../GridFileDeploymentUndeploySelfTest.java     |     8 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |     2 +-
 .../http/GridHttpDeploymentSelfTest.java        |     2 +-
 .../IgniteUriDeploymentTestSuite.java           |     3 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |     2 +-
 .../ignite/visor/commands/VisorConsole.scala    |     6 +-
 .../commands/alert/VisorAlertCommand.scala      |     2 +-
 .../config/VisorConfigurationCommand.scala      |     6 +-
 .../ignite/visor/commands/deploy/Packet.scala   |     4 +-
 .../commands/deploy/VisorDeployCommand.scala    |    22 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |     4 +-
 .../commands/events/VisorEventsCommand.scala    |     4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |    13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |     4 +-
 .../ignite/visor/commands/start/Packet.scala    |     6 +-
 .../commands/start/VisorStartCommand.scala      |    16 +-
 .../commands/tasks/VisorTasksCommand.scala      |     4 +-
 .../commands/top/VisorTopologyCommand.scala     |     6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |     8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    41 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    25 +-
 .../testsuites/VisorConsoleSelfTestSuite.scala  |     2 +-
 modules/web/readme.txt                          |    18 +-
 .../cache/websession/GridWebSessionFilter.java  |    26 +-
 .../GridServletContextListenerStartup.java      |   181 -
 .../startup/servlet/GridServletStartup.java     |   187 -
 .../IgniteServletContextListenerStartup.java    |   181 +
 .../startup/servlet/IgniteServletStartup.java   |   187 +
 .../internal/websession/WebSessionSelfTest.java |    12 +-
 .../websession/WebSessionServerStart.java       |     2 +-
 pom.xml                                         |    26 +-
 948 files changed, 46464 insertions(+), 45536 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/6f49e955/pom.xml
----------------------------------------------------------------------


[08/50] [abbrv] incubator-ignite git commit: # ignite-sprint-1.

Posted by vo...@apache.org.
# ignite-sprint-1.


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

Branch: refs/heads/ignite-16
Commit: bdebb406d6f58e7c6c4b334f6ea1a8be2b4ad7c8
Parents: 9502c0d
Author: AKuznetsov <ak...@gridgain.com>
Authored: Fri Jan 30 09:38:18 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Fri Jan 30 09:38:18 2015 +0700

----------------------------------------------------------------------
 .../visor/commands/gc/VisorGcCommand.scala      | 13 ++++------
 .../visor/commands/gc/VisorGcCommandSpec.scala  | 25 +++++++++++---------
 2 files changed, 19 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bdebb406/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/VisorGcCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/VisorGcCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/VisorGcCommand.scala
index ef1a241..713247c 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/VisorGcCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/gc/VisorGcCommand.scala
@@ -17,17 +17,14 @@
 
 package org.apache.ignite.visor.commands.gc
 
-import org.apache.ignite.internal.visor.node.VisorNodeGcTask
-
 import org.apache.ignite._
 import org.apache.ignite.cluster.{ClusterGroupEmptyException, ClusterNode}
-
-import java.lang.{Boolean => JavaBoolean}
-import java.util.{UUID, HashSet => JavaHashSet}
-
+import org.apache.ignite.internal.visor.node.VisorNodeGcTask
 import org.apache.ignite.visor.VisorTag
 import org.apache.ignite.visor.commands.{VisorConsoleCommand, VisorTextTable}
-import visor.visor._
+import org.apache.ignite.visor.visor._
+
+import java.util.UUID
 
 import scala.collection.JavaConversions._
 import scala.language.{implicitConversions, reflectiveCalls}
@@ -240,5 +237,5 @@ object VisorGcCommand {
      *
      * @param vs Visor tagging trait.
      */
-    implicit def fromGc2Visor(vs: VisorTag) = cmd
+    implicit def fromGc2Visor(vs: VisorTag): VisorGcCommand = cmd
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bdebb406/modules/visor-console/src/test/scala/org/apache/ignite/visor/commands/gc/VisorGcCommandSpec.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/test/scala/org/apache/ignite/visor/commands/gc/VisorGcCommandSpec.scala b/modules/visor-console/src/test/scala/org/apache/ignite/visor/commands/gc/VisorGcCommandSpec.scala
index 5e6f1c3..1a59274 100644
--- a/modules/visor-console/src/test/scala/org/apache/ignite/visor/commands/gc/VisorGcCommandSpec.scala
+++ b/modules/visor-console/src/test/scala/org/apache/ignite/visor/commands/gc/VisorGcCommandSpec.scala
@@ -17,26 +17,29 @@
 
 package org.apache.ignite.visor.commands.gc
 
-import org.apache.ignite.visor.visor
-import org.scalatest._
-
+import org.apache.ignite.configuration.IgniteConfiguration
 import org.apache.ignite.visor.commands.gc.VisorGcCommand._
-import org.apache.ignite.visor.commands.top.VisorTopologyCommand._
+import org.apache.ignite.visor.{VisorRuntimeBaseSpec, visor}
 
 /**
  * Unit test for 'gc' command.
  */
-class VisorGcCommandSpec extends FlatSpec with Matchers with BeforeAndAfterAll {
+class VisorGcCommandSpec extends VisorRuntimeBaseSpec(1) {
     behavior of "A 'gc' visor command"
 
-    override def beforeAll() {
-        visor.open("-d")
+    /**
+     * Creates grid configuration for provided grid host.
+     *
+     * @param name Grid name.
+     * @return Grid configuration.
+     */
+    override def config(name: String): IgniteConfiguration = {
+        val cfg = new IgniteConfiguration
 
-        visor.top()
-    }
+        cfg.setGridName(name)
+        cfg.setLifeCycleEmailNotification(false)
 
-    override def afterAll() {
-        visor.close()
+        cfg
     }
 
     it should "run GC on all nodes" in {


[50/50] [abbrv] incubator-ignite git commit: #ignite-16: Finished.

Posted by vo...@apache.org.
#ignite-16: Finished.


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

Branch: refs/heads/ignite-16
Commit: ff7ee6d30460db42c4f1364b135ba21e20a26c60
Parents: 2636e2c
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Mon Feb 2 14:35:01 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Mon Feb 2 14:35:01 2015 +0300

----------------------------------------------------------------------
 .../internal/processors/cache/GridCacheWriteBehindStore.java   | 1 -
 .../hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java      | 6 ------
 2 files changed, 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ff7ee6d3/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
index 5159348..d303225 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
@@ -20,7 +20,6 @@ package org.apache.ignite.internal.processors.cache;
 import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
 import org.apache.ignite.cache.store.*;
-import org.apache.ignite.internal.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.thread.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ff7ee6d3/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java b/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
index 65b8ba2..514c44f 100644
--- a/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
+++ b/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopDefaultMapReducePlannerSelfTest.java
@@ -28,7 +28,6 @@ import org.apache.ignite.internal.processors.fs.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.hadoop.*;
 import org.apache.ignite.internal.processors.hadoop.planner.*;
-import org.apache.ignite.internal.processors.interop.*;
 import org.apache.ignite.internal.util.lang.*;
 import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.testframework.*;
@@ -1011,11 +1010,6 @@ public class GridHadoopDefaultMapReducePlannerSelfTest extends GridHadoopAbstrac
         }
 
         /** {@inheritDoc} */
-        @Override public GridInteropProcessor interop() {
-            return null;
-        }
-
-        /** {@inheritDoc} */
         @Override public ClusterNode localNode() {
             return null;
         }


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

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


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

Branch: refs/heads/ignite-16
Commit: 7f50e8056cebeb773cb569bb3bf8007ef6960585
Parents: 8b57933 06d9b7d
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Feb 2 12:01:10 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Feb 2 12:01:10 2015 +0300

----------------------------------------------------------------------
 assembly/libs/readme.txt                        |     4 +-
 assembly/release-base-fabric.xml                |     4 +-
 assembly/release-base.xml                       |     6 +-
 bin/ggrouter.bat                                |    33 -
 bin/ggrouter.sh                                 |    50 -
 bin/ggstart.bat                                 |   228 -
 bin/ggstart.sh                                  |   176 -
 bin/ggvisorcmd.bat                              |   144 -
 bin/ggvisorcmd.sh                               |   124 -
 bin/ignite.bat                                  |   228 +
 bin/ignite.sh                                   |   176 +
 bin/igniterouter.bat                            |    33 +
 bin/igniterouter.sh                             |    50 +
 bin/ignitevisorcmd.bat                          |   144 +
 bin/ignitevisorcmd.sh                           |   124 +
 bin/include/functions.sh                        |    42 +-
 bin/include/hadoop-classpath.bat                |     2 +-
 bin/include/hadoop-classpath.sh                 |     4 +-
 bin/include/parseargs.bat                       |     2 +-
 bin/include/parseargs.sh                        |     6 +-
 bin/include/service.sh                          |    12 +-
 bin/include/setenv.bat                          |    28 +-
 bin/include/setenv.sh                           |    34 +-
 bin/include/target-classpath.bat                |     8 +-
 bin/include/target-classpath.sh                 |    14 +-
 bin/setup-hadoop.bat                            |     2 +-
 bin/setup-hadoop.sh                             |    12 +-
 config/gridgain-log4j.xml                       |   152 -
 config/hadoop/default-config.xml                |     2 +-
 config/ignite-log4j.xml                         |   152 +
 config/java.util.logging.properties             |    16 +-
 config/router/default-router.xml                |     2 +-
 docs/hadoop_readme.md                           |     6 +-
 docs/ignite_readme.md                           |    12 +-
 docs/mapred-site.ignite.xml                     |     2 +-
 examples/config/example-cache.xml               |     2 +-
 examples/config/example-streamer.xml            |     8 +-
 examples/config/filesystem/example-ggfs.xml     |     2 +-
 examples/config/servlet/WEB-INF/web.xml         |     4 +-
 examples/rest/http-rest-example.php             |     2 +-
 examples/rest/memcache-rest-example.php         |     2 +-
 .../compute/ComputeBroadcastExample.java        |     2 +-
 .../compute/ComputeCallableExample.java         |     2 +-
 .../examples/compute/ComputeClosureExample.java |     2 +-
 .../compute/ComputeContinuousMapperExample.java |     2 +-
 .../compute/ComputeExecutorServiceExample.java  |     2 +-
 .../ComputeFibonacciContinuationExample.java    |     2 +-
 .../compute/ComputeProjectionExample.java       |     2 +-
 .../examples/compute/ComputeReducerExample.java |     2 +-
 .../compute/ComputeRunnableExample.java         |     2 +-
 .../compute/ComputeScheduleExample.java         |     2 +-
 .../examples/compute/ComputeTaskMapExample.java |     2 +-
 .../compute/ComputeTaskSplitExample.java        |     2 +-
 .../compute/montecarlo/CreditRiskExample.java   |     2 +-
 .../examples/datagrid/CacheAffinityExample.java |     2 +-
 .../examples/datagrid/CacheApiExample.java      |     2 +-
 .../datagrid/CacheContinuousQueryExample.java   |     2 +-
 .../datagrid/CacheDataLoaderExample.java        |     2 +-
 .../examples/datagrid/CacheEventsExample.java   |     2 +-
 .../datagrid/CachePopularNumbersExample.java    |     2 +-
 .../examples/datagrid/CachePutGetExample.java   |     2 +-
 .../examples/datagrid/CacheQueryExample.java    |     2 +-
 .../datagrid/CacheTransactionExample.java       |     2 +-
 .../datastructures/CacheAtomicLongExample.java  |     2 +-
 .../CacheAtomicReferenceExample.java            |     2 +-
 .../CacheAtomicSequenceExample.java             |     2 +-
 .../CacheAtomicStampedExample.java              |     2 +-
 .../CacheCountDownLatchExample.java             |     2 +-
 .../datastructures/CacheQueueExample.java       |     2 +-
 .../datastructures/CacheSetExample.java         |     2 +-
 .../hibernate/HibernateL2CacheExample.java      |     2 +-
 .../starschema/CacheStarSchemaExample.java      |     2 +-
 .../ignite/examples/events/EventsExample.java   |     2 +-
 .../ignite/examples/ggfs/GgfsExample.java       |     2 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |     2 +-
 .../ignite/examples/ggfs/GgfsNodeStartup.java   |     4 +-
 .../examples/messaging/MessagingExample.java    |     2 +-
 .../messaging/MessagingPingPongExample.java     |     2 +-
 .../MessagingPingPongListenActorExample.java    |     2 +-
 .../misc/deployment/DeploymentExample.java      |     2 +-
 .../misc/springbean/SpringBeanExample.java      |     2 +-
 .../examples/services/ServicesExample.java      |     2 +-
 .../streaming/StreamingCheckInExample.java      |     8 +-
 .../StreamingPopularNumbersExample.java         |     8 +-
 .../streaming/StreamingPriceBarsExample.java    |     8 +-
 .../StreamingRunningAverageExample.java         |     8 +-
 .../apache/ignite/examples/ComputeExample.java  |    59 +
 .../ignite/examples/MessagingExample.java       |   166 +
 .../org/gridgain/examples/ComputeExample.java   |    59 -
 .../org/gridgain/examples/MessagingExample.java |   166 -
 .../examples/ScalarCacheAffinityExample1.scala  |     2 +-
 .../examples/ScalarCacheAffinityExample2.scala  |     2 +-
 .../ScalarCacheAffinitySimpleExample.scala      |     2 +-
 .../scalar/examples/ScalarCacheExample.scala    |     2 +-
 .../ScalarCachePopularNumbersExample.scala      |     2 +-
 .../examples/ScalarCacheQueryExample.scala      |     2 +-
 .../scalar/examples/ScalarClosureExample.scala  |     2 +-
 .../examples/ScalarContinuationExample.scala    |     2 +-
 .../examples/ScalarCreditRiskExample.scala      |     2 +-
 .../examples/ScalarPiCalculationExample.scala   |     2 +-
 .../scalar/examples/ScalarPingPongExample.scala |     2 +-
 .../scalar/examples/ScalarPrimeExample.scala    |     2 +-
 .../scalar/examples/ScalarScheduleExample.scala |     2 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |     2 +-
 .../scalar/examples/ScalarTaskExample.scala     |     2 +-
 .../examples/ScalarWorldShortestMapReduce.scala |     2 +-
 .../GridMonteCarloExamplesSelfTest.java         |     4 +-
 .../testsuites/IgniteExamplesSelfTestSuite.java |     2 +-
 .../ScalarExamplesSelfTestSuite.scala           |     2 +-
 modules/aop/readme.txt                          |     2 +-
 .../GridifySetToXXXNonSpringAopSelfTest.java    |    20 +-
 .../GridifySetToXXXSpringAopSelfTest.java       |    20 +-
 .../ignite/gridify/NonSpringAopSelfTest.java    |    20 +-
 .../optimized/OptimizedMarshallerAopTest.java   |     4 +-
 .../testsuites/IgniteAopSelfTestSuite.java      |     2 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |    20 +-
 modules/aws/readme.txt                          |     2 +-
 modules/clients/src/test/bin/start-nodes-ssh.sh |     2 +-
 modules/clients/src/test/bin/start-nodes.cmd    |    24 +-
 modules/clients/src/test/bin/start-nodes.sh     |    34 +-
 .../client/ClientDefaultCacheSelfTest.java      |     4 +-
 .../client/ClientTopologyCacheSelfTest.java     |     2 +-
 .../integration/ClientAbstractSelfTest.java     |     6 +-
 .../client/router/ClientFailedInitSelfTest.java |     4 +-
 .../client/router/RouterFactorySelfTest.java    |     4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |     4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |     2 +-
 .../rest/TaskCommandHandlerSelfTest.java        |     4 +-
 .../protocols/tcp/TcpRestParserSelfTest.java    |     6 +-
 .../src/test/resources/jetty/rest-jetty-ssl.xml |    10 +-
 .../src/test/resources/jetty/rest-jetty.xml     |     8 +-
 .../test/resources/jetty/router-jetty-ssl.xml   |     8 +-
 .../src/test/resources/jetty/router-jetty.xml   |     8 +-
 modules/clients/src/test/resources/log4j.xml    |     4 +-
 .../clients/src/test/resources/spring-cache.xml |     2 +-
 .../src/test/resources/spring-router-ssl.xml    |     4 +-
 .../src/test/resources/spring-router.xml        |     4 +-
 .../src/test/resources/spring-server-node.xml   |     2 +-
 .../test/resources/spring-server-ssl-node.xml   |     2 +-
 .../apache/ignite/IgniteBasicWarmupClosure.java |     6 +-
 .../java/org/apache/ignite/IgniteCluster.java   |     6 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |     4 +-
 .../java/org/apache/ignite/IgniteLogger.java    |     6 +-
 .../apache/ignite/IgniteSystemProperties.java   |   192 +-
 .../main/java/org/apache/ignite/Ignition.java   |    16 +-
 .../apache/ignite/cache/CacheConfiguration.java |     3 +-
 .../CacheConsistentHashAffinityFunction.java    |     2 +-
 .../apache/ignite/cache/query/CacheQuery.java   |     3 +-
 .../cache/query/CacheQuerySqlFunction.java      |     4 +-
 .../cache/query/annotations/QuerySqlField.java  |     2 +-
 .../query/annotations/QuerySqlFunction.java     |     2 +-
 .../apache/ignite/cache/store/CacheStore.java   |     2 +-
 .../apache/ignite/client/GridClientCompute.java |     8 +-
 .../ignite/client/router/GridRouterFactory.java |     4 +-
 .../impl/GridRouterCommandLineStartup.java      |     4 +-
 .../router/impl/GridTcpRouterNioParser.java     |     4 +-
 .../apache/ignite/compute/gridify/Gridify.java  |     2 +-
 .../ignite/compute/gridify/GridifySetToSet.java |     4 +-
 .../compute/gridify/GridifySetToValue.java      |     4 +-
 .../ClientConnectionConfiguration.java          |    16 +-
 .../configuration/GridQueryConfiguration.java   |   201 -
 .../configuration/IgniteConfiguration.java      |    80 +-
 .../configuration/IgniteDeploymentMode.java     |     4 +-
 .../configuration/IgniteQueryConfiguration.java |   201 +
 .../apache/ignite/fs/IgniteFsConfiguration.java |     2 +-
 .../ignite/internal/GridKernalContextImpl.java  |     2 +-
 .../apache/ignite/internal/GridLoggerProxy.java |     4 +-
 .../internal/GridPerformanceSuggestions.java    |     4 +-
 .../apache/ignite/internal/GridProductImpl.java |     2 +-
 .../ignite/internal/IgniteInternalFuture.java   |     8 +-
 .../apache/ignite/internal/IgniteKernal.java    |    32 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |    54 +-
 .../processors/cache/GridCacheAdapter.java      |     2 +-
 .../GridCachePartitionExchangeManager.java      |     2 +-
 .../processors/cache/GridCacheProcessor.java    |     4 +-
 .../processors/cache/GridCacheUtils.java        |     2 +-
 .../distributed/dht/GridDhtLocalPartition.java  |     2 +-
 .../dht/GridPartitionedGetFuture.java           |     2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |     4 +-
 .../distributed/near/GridNearAtomicCache.java   |     2 +-
 .../distributed/near/GridNearGetFuture.java     |     2 +-
 .../cache/transactions/IgniteTxManager.java     |    10 +-
 .../processors/fs/IgniteFsProcessor.java        |     8 +-
 .../processors/job/GridJobProcessor.java        |     2 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |     4 +-
 .../handlers/log/GridLogCommandHandler.java     |     4 +-
 .../handlers/task/GridTaskCommandHandler.java   |     2 +-
 .../protocols/tcp/GridClientPacketType.java     |     4 +-
 .../protocols/tcp/GridMemcachedMessage.java     |     4 +-
 .../rest/protocols/tcp/GridTcpRestParser.java   |    18 +-
 .../streamer/GridStreamProcessor.java           |     6 +-
 .../internal/util/GridConcurrentFactory.java    |     3 +-
 .../internal/util/GridConfigurationFinder.java  |     4 +-
 .../internal/util/GridReflectionCache.java      |     3 +-
 .../ignite/internal/util/IgniteUtils.java       |    50 +-
 .../util/future/GridFinishedFuture.java         |     2 +-
 .../internal/util/future/GridFutureAdapter.java |     4 +-
 .../internal/util/io/GridUnsafeDataInput.java   |     2 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |     2 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |     4 +-
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |     2 +-
 .../internal/util/nio/GridBufferedParser.java   |     2 +-
 .../nio/GridConnectionBytesVerifyFilter.java    |    18 +-
 .../util/nodestart/GridNodeStartUtils.java      |    10 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java   |     2 +-
 .../util/portscanner/GridJmxPortFinder.java     |     4 +-
 .../apache/ignite/internal/util/typedef/X.java  |     4 +-
 .../visor/node/VisorBasicConfiguration.java     |    26 +-
 .../visor/node/VisorEmailConfiguration.java     |    14 +-
 .../visor/node/VisorLifecycleConfiguration.java |     2 +-
 .../visor/node/VisorRestConfiguration.java      |     4 +-
 .../apache/ignite/jdbc/IgniteJdbcDriver.java    |     2 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |     4 +-
 .../ignite/logger/java/IgniteJavaLogger.java    |     4 +-
 .../java/IgniteJavaLoggerFileHandler.java       |     4 +-
 .../optimized/IgniteOptimizedMarshaller.java    |     2 +-
 .../segmentation/GridSegmentationPolicy.java    |     2 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |     4 +-
 .../ignite/spi/IgniteSpiManagementMBean.java    |     2 +-
 .../ignite/spi/checkpoint/CheckpointSpi.java    |     2 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |     6 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    12 +-
 .../ignite/spi/deployment/DeploymentSpi.java    |     2 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |     4 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |     2 +-
 .../TcpDiscoveryMulticastIpFinder.java          |    18 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |     2 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |     2 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |     4 +-
 .../ignite/startup/BasicWarmupClosure.java      |     6 +-
 .../startup/cmdline/CommandLineStartup.java     |    18 +-
 .../startup/cmdline/CommandLineTransformer.java |     8 +-
 .../ignite/thread/IgniteThreadFactory.java      |     2 +-
 .../apache/ignite/transactions/IgniteTx.java    |     2 +-
 .../core/src/test/bin/start-nodes-custom.bat    |     2 +-
 modules/core/src/test/bin/start-nodes-custom.sh |     2 +-
 .../spring-cache-client-benchmark-1.xml         |     2 +-
 .../spring-cache-client-benchmark-2.xml         |     2 +-
 .../spring-cache-client-benchmark-3.xml         |     2 +-
 modules/core/src/test/config/example-cache.xml  |     2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |     2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |     2 +-
 modules/core/src/test/config/log4j-test.xml     |     2 +-
 .../core/src/test/config/spring-cache-load.xml  |     2 +-
 .../core/src/test/config/spring-multicache.xml  |     2 +-
 .../average/spring-streamer-average-base.xml    |     2 +-
 .../average/spring-streamer-average-local.xml   |     2 +-
 .../average/spring-streamer-average-random.xml  |     2 +-
 .../config/streamer/spring-streamer-base.xml    |     2 +-
 modules/core/src/test/config/tests.properties   |    10 +-
 .../internal/GridFactoryVmShutdownTest.java     |     2 +-
 .../ignite/internal/GridHomePathSelfTest.java   |     2 +-
 .../GridNodeVisorAttributesSelfTest.java        |     4 +-
 .../ignite/internal/GridStartStopSelfTest.java  |     2 +-
 .../ignite/internal/GridVersionSelfTest.java    |     8 +-
 .../GridCacheAbstractRemoveFailureTest.java     |     6 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |     6 +-
 .../cache/GridCacheSlowTxWarnTest.java          |     2 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |     6 +-
 .../GridCacheMultiNodeDataStructureTest.java    |     4 +-
 .../GridCacheNodeFailureAbstractTest.java       |     2 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |     6 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |     2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |     6 +-
 ...GridUnsafeDataOutputArraySizingSelfTest.java |     2 +-
 .../loadtest/GridSingleExecutionTest.java       |     4 +-
 .../cache/GridCacheAbstractLoadTest.java        |     2 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |     2 +-
 .../loadtests/cache/GridCacheLoadTest.java      |     2 +-
 .../capacity/spring-capacity-cache.xml          |     2 +-
 .../loadtests/colocation/spring-colocation.xml  |     2 +-
 .../GridContinuousOperationsLoadTest.java       |    18 +-
 .../loadtests/mapper/GridNodeStartup.java       |     4 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |     2 +-
 .../streamer/GridStreamerIndexLoadTest.java     |     2 +-
 .../ignite/loadtests/util/GridLoadTestArgs.java |     8 +-
 .../startup/GridRandomCommandLineLoader.java    |    10 +-
 .../ignite/startup/GridVmNodesStarter.java      |     8 +-
 .../GridCommandLineTransformerSelfTest.java     |     6 +-
 .../ignite/testframework/GridTestUtils.java     |    10 +-
 .../config/GridTestProperties.java              |    16 +-
 .../testframework/junits/GridAbstractTest.java  |     4 +-
 .../logger/GridLog4jRollingFileAppender.java    |     4 +-
 .../junits/logger/GridTestLog4jLogger.java      |     8 +-
 .../src/test/resources/log/gridgain.log.tst     | 13706 -----------------
 .../core/src/test/resources/log/ignite.log.tst  | 13706 +++++++++++++++++
 .../core/src/test/webapp/META-INF/gg-config.xml |     2 +-
 modules/core/src/test/webapp/WEB-INF/web.xml    |     2 +-
 modules/email/readme.txt                        |     2 +-
 modules/hadoop/readme.txt                       |     2 +-
 .../fs/hadoop/v1/GridGgfsHadoopFileSystem.java  |     6 +-
 .../fs/hadoop/v2/GridGgfsHadoopFileSystem.java  |     6 +-
 .../apache/ignite/hadoop/GridHadoopSetup.java   |    16 +-
 .../GridHadoopExternalTaskExecutor.java         |     2 +-
 .../child/GridHadoopExternalProcessStarter.java |     2 +-
 .../hadoop/GridHadoopPopularWordsTest.java      |     6 +-
 modules/hibernate/readme.txt                    |     2 +-
 .../hibernate/CacheHibernateBlobStore.java      |   593 +
 .../CacheHibernateBlobStoreEntry.hbm.xml        |    29 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |    86 +
 .../hibernate/GridCacheHibernateBlobStore.java  |   593 -
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |    29 -
 .../GridCacheHibernateBlobStoreEntry.java       |    86 -
 ...idHibernateL2CacheTransactionalSelfTest.java |     2 +-
 .../CacheHibernateBlobStoreSelfTest.java        |   108 +
 .../GridCacheHibernateBlobStoreSelfTest.java    |   108 -
 .../cache/store/hibernate/hibernate.cfg.xml     |     2 +-
 .../testsuites/IgniteHibernateTestSuite.java    |     2 +-
 modules/indexing/readme.txt                     |     2 +-
 .../processors/query/h2/IgniteH2Indexing.java   |     8 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |     2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |     2 +-
 .../query/h2/sql/GridQueryParsingTest.java      |     2 +-
 modules/jcl/readme.txt                          |     2 +-
 .../apache/ignite/logger/jcl/GridJclLogger.java |     4 +-
 modules/jta/readme.txt                          |     2 +-
 .../apache/ignite/cache/jta/CacheTmLookup.java  |    50 +
 .../ignite/cache/jta/GridCacheTmLookup.java     |    50 -
 .../cache/jta/jndi/CacheJndiTmLookup.java       |    74 +
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |    74 -
 .../jta/reflect/CacheReflectionTmLookup.java    |   115 +
 .../reflect/GridCacheReflectionTmLookup.java    |   115 -
 .../processors/cache/jta/CacheJtaManager.java   |     4 +-
 ...CacheJtaConfigurationValidationSelfTest.java |     2 +-
 .../processors/cache/GridCacheJtaSelfTest.java  |     2 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |     4 +-
 modules/log4j/readme.txt                        |     2 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |     8 +-
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |     8 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |     4 +-
 modules/rest-http/readme.txt                    |     2 +-
 .../http/jetty/GridJettyRestProtocol.java       |    16 +-
 .../rest/protocols/http/jetty/rest.html         |     6 +-
 modules/scalar/pom.xml                          |     6 +-
 modules/scalar/readme.txt                       |     2 +-
 modules/schedule/readme.txt                     |     2 +-
 .../processors/schedule/ScheduleFutureImpl.java |     4 +-
 modules/slf4j/readme.txt                        |     2 +-
 modules/spring/readme.txt                       |     2 +-
 .../java/org/apache/ignite/IgniteSpring.java    |     2 +-
 .../ignite/cache/spring/SpringCacheManager.java |     6 +-
 .../spring/IgniteSpringProcessorImpl.java       |    10 +-
 .../ignite/internal/GridFactorySelfTest.java    |     2 +-
 modules/ssh/readme.txt                          |     2 +-
 .../util/nodestart/GridNodeCallableImpl.java    |    20 +-
 .../internal/GridNodeStartUtilsSelfTest.java    |     6 +-
 .../GridProjectionStartStopRestartSelfTest.java |     4 +-
 .../ignite/tools/javadoc/GridLinkTaglet.java    |   165 -
 .../ignite/tools/javadoc/IgniteLinkTaglet.java  |   165 +
 .../optimized/OptimizedClassNamesGenerator.java |    12 +-
 modules/urideploy/readme.txt                    |     2 +-
 .../uri/GridUriDeploymentFileProcessor.java     |     2 +-
 .../deployment/uri/GridUriDeploymentSpi.java    |  1367 --
 .../uri/GridUriDeploymentSpiMBean.java          |    53 -
 .../spi/deployment/uri/UriDeploymentSpi.java    |  1367 ++
 .../deployment/uri/UriDeploymentSpiMBean.java   |    53 +
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |     2 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |     2 +-
 .../uri/GridUriDeploymentAbstractSelfTest.java  |     2 +-
 .../GridUriDeploymentClassLoaderSelfTest.java   |     2 +-
 ...riDeploymentClassloaderRegisterSelfTest.java |     4 +-
 .../uri/GridUriDeploymentConfigSelfTest.java    |    10 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |     2 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |     2 +-
 ...loymentMultiScannersErrorThrottlingTest.java |     2 +-
 .../GridUriDeploymentMultiScannersSelfTest.java |     2 +-
 .../uri/GridUriDeploymentSimpleSelfTest.java    |    10 +-
 .../file/GridFileDeploymentSelfTest.java        |     6 +-
 .../GridFileDeploymentUndeploySelfTest.java     |     8 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |     2 +-
 .../http/GridHttpDeploymentSelfTest.java        |     2 +-
 .../IgniteUriDeploymentTestSuite.java           |     3 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |     2 +-
 .../ignite/visor/commands/deploy/Packet.scala   |     4 +-
 .../commands/deploy/VisorDeployCommand.scala    |    18 +-
 .../ignite/visor/commands/start/Packet.scala    |     6 +-
 .../commands/start/VisorStartCommand.scala      |    12 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    14 +-
 .../testsuites/VisorConsoleSelfTestSuite.scala  |     2 +-
 modules/web/readme.txt                          |     2 +-
 .../cache/websession/GridWebSessionFilter.java  |    26 +-
 .../GridServletContextListenerStartup.java      |   181 -
 .../startup/servlet/GridServletStartup.java     |   187 -
 .../IgniteServletContextListenerStartup.java    |   181 +
 .../startup/servlet/IgniteServletStartup.java   |   187 +
 .../internal/websession/WebSessionSelfTest.java |     8 +-
 .../websession/WebSessionServerStart.java       |     2 +-
 modules/yardstick/README.md                     |    67 +
 .../config/benchmark-atomic-win.properties      |    42 +
 .../config/benchmark-atomic.properties          |    48 +
 .../config/benchmark-compute-win.properties     |    45 +
 .../config/benchmark-compute.properties         |    51 +
 .../config/benchmark-query-win.properties       |    43 +
 .../yardstick/config/benchmark-query.properties |    49 +
 .../config/benchmark-tx-win.properties          |    42 +
 .../yardstick/config/benchmark-tx.properties    |    48 +
 .../yardstick/config/benchmark-win.properties   |    50 +
 modules/yardstick/config/benchmark.properties   |    61 +
 modules/yardstick/config/ignite-base-config.xml |   118 +
 .../config/ignite-localhost-config.xml          |    55 +
 .../config/ignite-multicast-config.xml          |    38 +
 modules/yardstick/pom.xml                       |   185 +
 .../yardstick/IgniteAbstractBenchmark.java      |   130 +
 .../yardstick/IgniteBenchmarkArguments.java     |   213 +
 .../org/apache/ignite/yardstick/IgniteNode.java |   191 +
 .../cache/IgniteCacheAbstractBenchmark.java     |    44 +
 .../yardstick/cache/IgniteGetBenchmark.java     |    41 +
 .../yardstick/cache/IgnitePutBenchmark.java     |    42 +
 .../yardstick/cache/IgnitePutGetBenchmark.java  |    47 +
 .../cache/IgnitePutGetTxBenchmark.java          |    52 +
 .../yardstick/cache/IgnitePutTxBenchmark.java   |    43 +
 .../cache/IgniteSqlQueryBenchmark.java          |    94 +
 .../cache/IgniteSqlQueryJoinBenchmark.java      |   118 +
 .../cache/IgniteSqlQueryPutBenchmark.java       |    86 +
 .../yardstick/cache/model/Organization.java     |   110 +
 .../ignite/yardstick/cache/model/Person.java    |   191 +
 .../yardstick/cache/model/SampleValue.java      |    62 +
 .../compute/IgniteAffinityCallBenchmark.java    |    36 +
 .../yardstick/compute/IgniteApplyBenchmark.java |    72 +
 .../compute/IgniteBroadcastBenchmark.java       |    35 +
 .../compute/IgniteExecuteBenchmark.java         |    35 +
 .../yardstick/compute/IgniteRunBenchmark.java   |    71 +
 .../yardstick/compute/model/NoopCallable.java   |    41 +
 .../yardstick/compute/model/NoopTask.java       |    97 +
 pom.xml                                         |    35 +-
 425 files changed, 21889 insertions(+), 19106 deletions(-)
----------------------------------------------------------------------



[45/50] [abbrv] incubator-ignite git commit: # IGNITE-102: Merge with sprint-1.

Posted by vo...@apache.org.
# IGNITE-102: Merge with sprint-1.


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

Branch: refs/heads/ignite-16
Commit: 06d9b7d2396a83566a131e3959f894bf9e08e865
Parents: 6f49e95
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 2 15:32:24 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 2 15:32:24 2015 +0700

----------------------------------------------------------------------
 .../src/main/java/org/apache/ignite/yardstick/IgniteNode.java      | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/06d9b7d2/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteNode.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteNode.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteNode.java
index ad71ca2..b07d1f0 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteNode.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteNode.java
@@ -134,7 +134,7 @@ public class IgniteNode implements BenchmarkServer {
             url = new URL(springCfgPath);
         }
         catch (MalformedURLException e) {
-            url = GridUtils.resolveGridGainUrl(springCfgPath);
+            url = IgniteUtils.resolveGridGainUrl(springCfgPath);
 
             if (url == null)
                 throw new IgniteCheckedException("Spring XML configuration path is invalid: " + springCfgPath +


[04/50] [abbrv] incubator-ignite git commit: Tests: Fix compile

Posted by vo...@apache.org.
Tests: Fix compile


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

Branch: refs/heads/ignite-16
Commit: f30d79d1f4b71833fea763fdacfe5f15300e4aa2
Parents: 4009aaa
Author: ivasilinets <iv...@gridgain.com>
Authored: Thu Jan 29 18:29:51 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Thu Jan 29 18:29:51 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f30d79d1/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
----------------------------------------------------------------------
diff --git a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
index 1899ca4..8047b8a 100644
--- a/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
+++ b/modules/visor-console/src/main/scala/org/apache/ignite/visor/commands/alert/VisorAlertCommand.scala
@@ -17,7 +17,7 @@
 
 package org.apache.ignite.visor.commands.alert
 
-import org.apache.ignite.internal.util.{IgniteUtils => U}
+import org.apache.ignite.internal.util.IgniteUtils
 import org.apache.ignite.internal.util.lang.{GridFunc => F}
 
 import org.apache.ignite._


[23/50] [abbrv] incubator-ignite git commit: Fix IpcSharedMemoryNativeLoaderSelfTest # testLoadWithCorruptedLibFile (add classpath)

Posted by vo...@apache.org.
Fix IpcSharedMemoryNativeLoaderSelfTest # testLoadWithCorruptedLibFile (add classpath)


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

Branch: refs/heads/ignite-16
Commit: 746ce78ac39f63374dfe76129bd226b1fa3b2c75
Parents: b6eb388
Author: Artem SHutak <as...@gridgain.com>
Authored: Fri Jan 30 13:21:26 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Fri Jan 30 13:21:26 2015 +0300

----------------------------------------------------------------------
 .../util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java        | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/746ce78a/modules/core/src/test/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java
index e70c207..65fa543 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java
@@ -46,7 +46,7 @@ public class IpcSharedMemoryNativeLoaderSelfTest extends TestCase {
             null,
             null,
             Collections.<String>emptyList(),
-            null
+            System.getProperty("surefire.test.class.path")
         ).getProcess();
 
         readStreams(ps);


[35/50] [abbrv] incubator-ignite git commit: #Tests: Fix hadoop tests.

Posted by vo...@apache.org.
#Tests: Fix hadoop tests.


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

Branch: refs/heads/ignite-16
Commit: 0331e7bf307ba87b36d4303ae6dc3df49ce79a21
Parents: 57f55f6
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 30 16:11:47 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 30 16:11:47 2015 +0300

----------------------------------------------------------------------
 .../internal/processors/hadoop/GridHadoopCommandLineTest.java    | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0331e7bf/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopCommandLineTest.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopCommandLineTest.java b/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopCommandLineTest.java
index c243c30..a83dc08 100644
--- a/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopCommandLineTest.java
+++ b/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/GridHadoopCommandLineTest.java
@@ -157,9 +157,9 @@ public class GridHadoopCommandLineTest extends GridCommonAbstractTest {
 
         testWorkDir = Files.createTempDirectory("hadoop-cli-test").toFile();
 
-        U.copy(U.resolveGridGainPath("docs/core-site.gridgain.xml"), new File(testWorkDir, "core-site.xml"), false);
+        U.copy(U.resolveGridGainPath("docs/core-site.ignite.xml"), new File(testWorkDir, "core-site.xml"), false);
 
-        File srcFile = U.resolveGridGainPath("docs/mapred-site.gridgain.xml");
+        File srcFile = U.resolveGridGainPath("docs/mapred-site.ignite.xml");
         File dstFile = new File(testWorkDir, "mapred-site.xml");
 
         try (BufferedReader in = new BufferedReader(new FileReader(srcFile));


[10/50] [abbrv] incubator-ignite git commit: IGNITE-109 - Merge branch 'ignite-109' into sprint-1

Posted by vo...@apache.org.
IGNITE-109 - Merge branch 'ignite-109' into sprint-1


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

Branch: refs/heads/ignite-16
Commit: 61a9f986a918052aae159e21ca37693491d34382
Parents: 4fe57d4 e4cd632
Author: Alexey Goncharuk <ag...@gridgain.com>
Authored: Thu Jan 29 19:04:38 2015 -0800
Committer: Alexey Goncharuk <ag...@gridgain.com>
Committed: Thu Jan 29 19:04:38 2015 -0800

----------------------------------------------------------------------
 .../processors/cache/GridCacheStoreManager.java |  25 +-
 .../transactions/IgniteTxLocalAdapter.java      |  42 ++-
 .../IgniteCrossCacheTxStoreSelfTest.java        | 288 +++++++++++++++++++
 .../IgniteCacheTxStoreSessionTest.java          |  11 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   1 +
 5 files changed, 357 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/61a9f986/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
----------------------------------------------------------------------


[21/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-67

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-67


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

Branch: refs/heads/ignite-16
Commit: ac05bb9c8089895506126591a2b04766588a25e1
Parents: a360ab7 9550905
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 12:29:32 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 12:29:32 2015 +0300

----------------------------------------------------------------------
 assembly/release-hadoop.xml                     |    6 +-
 ipc/shmem/Makefile.am                           |    2 +-
 ipc/shmem/Makefile.in                           |    2 +-
 ipc/shmem/configure                             |    4 +-
 ipc/shmem/configure.ac                          |    2 +-
 ipc/shmem/ggshmem/Makefile.am                   |   23 -
 ipc/shmem/ggshmem/Makefile.in                   |  589 --
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |  882 --
 ipc/shmem/igniteshmem/Makefile.am               |   23 +
 ipc/shmem/igniteshmem/Makefile.in               |  589 ++
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |  882 ++
 ipc/shmem/include/Makefile.am                   |    2 +-
 ipc/shmem/include/Makefile.in                   |    2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |  117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |  117 -
 ipc/shmem/readme.txt                            |    9 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |    4 +-
 .../ClientPropertiesConfigurationSelfTest.java  |    4 +-
 .../java/META-INF/native/linux64/libggshmem.so  |  Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |  Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |  Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |  Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteCheckedException.java   |    2 +-
 .../java/org/apache/ignite/IgniteException.java |    2 +-
 .../processors/cache/GridCacheAdapter.java      |   16 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../cache/GridCacheMvccCandidate.java           |    4 +-
 .../processors/cache/GridCacheStoreManager.java |   25 +-
 .../processors/cache/IgniteCacheProxy.java      |   24 +-
 .../transactions/IgniteTxLocalAdapter.java      |   42 +-
 .../internal/processors/fs/GridGgfsServer.java  |   26 +-
 .../processors/fs/GridGgfsServerManager.java    |    8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |    2 +-
 .../processors/fs/IgniteFsProcessor.java        |    4 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |    2 +-
 .../service/GridServiceProcessor.java           |    2 +-
 .../apache/ignite/internal/util/GridUtils.java  | 9100 -----------------
 .../ignite/internal/util/IgniteUtils.java       | 9141 ++++++++++++++++++
 .../internal/util/ipc/GridIpcEndpoint.java      |   49 -
 .../util/ipc/GridIpcEndpointBindException.java  |   47 -
 .../util/ipc/GridIpcEndpointFactory.java        |   84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |   29 -
 .../util/ipc/GridIpcServerEndpoint.java         |   73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |   66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |  250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |   49 +
 .../util/ipc/IpcEndpointBindException.java      |   47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |   84 +
 .../internal/util/ipc/IpcEndpointType.java      |   29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |   73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |   66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |  250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |   87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |  179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |   87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |  179 +
 .../GridIpcOutOfSystemResourcesException.java   |   59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |  336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |   67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |  171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |   99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |  242 -
 ...cSharedMemoryOperationTimedoutException.java |   59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |   80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |  707 --
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |  374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |  242 -
 .../shmem/IpcOutOfSystemResourcesException.java |   59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |  336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |   67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |  171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |   99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |  261 +
 ...cSharedMemoryOperationTimedoutException.java |   59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |   80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |  707 ++
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |  374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |  242 +
 .../util/nio/GridShmemCommunicationClient.java  |    4 +-
 .../internal/util/typedef/internal/U.java       |    4 +-
 .../visor/misc/VisorResolveHostNameTask.java    |    2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |    4 +-
 .../internal/visor/query/VisorQueryUtils.java   |    4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |   27 +-
 .../optimized/IgniteOptimizedMarshaller.java    |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   24 +-
 .../IgniteExceptionHelpLinksSelfTest.java       |    3 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |   10 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   50 +
 .../GridCacheReturnValueTransferSelfTest.java   |    2 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  288 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |    2 +-
 .../IgniteCacheTxStoreSessionTest.java          |   11 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    4 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    4 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    4 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |    2 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    4 +-
 .../internal/util/GridTestClockTimer.java       |    6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |  717 --
 .../internal/util/IgniteUtilsSelfTest.java      |  728 ++
 ...idIpcServerEndpointDeserializerSelfTest.java |  160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |  160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |   76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |   71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |   76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |   71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |  500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |   36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |   87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |  267 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |   84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |  500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |   36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |   78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |   87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |  267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |   84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |   65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |   35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |  133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |  125 -
 .../IpcSharedMemoryBenchmarkParty.java          |   35 +
 .../IpcSharedMemoryBenchmarkReader.java         |  133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |  125 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |    2 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    1 +
 .../ignite/testsuites/IgniteFsTestSuite.java    |    2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   10 +-
 .../GridHadoopExternalCommunication.java        |   26 +-
 .../GridHadoopIpcToNioAdapter.java              |    6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |    2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |    4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |    4 +-
 .../ignite/visor/commands/VisorConsole.scala    |    6 +-
 .../commands/alert/VisorAlertCommand.scala      |    2 +-
 .../config/VisorConfigurationCommand.scala      |    6 +-
 .../commands/deploy/VisorDeployCommand.scala    |    4 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    4 +-
 .../commands/events/VisorEventsCommand.scala    |    4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../commands/start/VisorStartCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |    4 +-
 .../commands/top/VisorTopologyCommand.scala     |    6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   20 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |   25 +-
 158 files changed, 17135 insertions(+), 16542 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/internal/processors/fs/IgniteFsProcessor.java
----------------------------------------------------------------------


[43/50] [abbrv] incubator-ignite git commit: gg*{sh, bat} renamed to ignite*{sh, bat}

Posted by vo...@apache.org.
gg*{sh,bat} renamed to ignite*{sh,bat}


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

Branch: refs/heads/ignite-16
Commit: 7e8ea4f1d71e6c9a9e329a0f00471878a73d6b54
Parents: 115f597
Author: Anton Vinogradov <av...@gridgain.com>
Authored: Fri Jan 30 22:33:10 2015 +0300
Committer: Anton Vinogradov <av...@gridgain.com>
Committed: Fri Jan 30 22:33:11 2015 +0300

----------------------------------------------------------------------
 assembly/libs/readme.txt                        |   4 +-
 assembly/release-base-fabric.xml                |   4 +-
 assembly/release-base.xml                       |   4 +-
 bin/ggrouter.bat                                |  33 ---
 bin/ggrouter.sh                                 |  50 ----
 bin/ggstart.bat                                 | 228 -------------------
 bin/ggstart.sh                                  | 176 --------------
 bin/ggvisorcmd.bat                              | 144 ------------
 bin/ggvisorcmd.sh                               | 124 ----------
 bin/ignite.bat                                  | 228 +++++++++++++++++++
 bin/ignite.sh                                   | 176 ++++++++++++++
 bin/igniterouter.bat                            |  33 +++
 bin/igniterouter.sh                             |  50 ++++
 bin/ignitevisorcmd.bat                          | 144 ++++++++++++
 bin/ignitevisorcmd.sh                           | 124 ++++++++++
 bin/setup-hadoop.bat                            |   2 +-
 bin/setup-hadoop.sh                             |   2 +-
 config/hadoop/default-config.xml                |   2 +-
 config/router/default-router.xml                |   2 +-
 docs/hadoop_readme.md                           |   6 +-
 docs/ignite_readme.md                           |  12 +-
 examples/config/example-cache.xml               |   2 +-
 examples/config/example-streamer.xml            |   2 +-
 examples/config/filesystem/example-ggfs.xml     |   2 +-
 examples/rest/http-rest-example.php             |   2 +-
 examples/rest/memcache-rest-example.php         |   2 +-
 .../compute/ComputeBroadcastExample.java        |   2 +-
 .../compute/ComputeCallableExample.java         |   2 +-
 .../examples/compute/ComputeClosureExample.java |   2 +-
 .../compute/ComputeContinuousMapperExample.java |   2 +-
 .../compute/ComputeExecutorServiceExample.java  |   2 +-
 .../ComputeFibonacciContinuationExample.java    |   2 +-
 .../compute/ComputeProjectionExample.java       |   2 +-
 .../examples/compute/ComputeReducerExample.java |   2 +-
 .../compute/ComputeRunnableExample.java         |   2 +-
 .../compute/ComputeScheduleExample.java         |   2 +-
 .../examples/compute/ComputeTaskMapExample.java |   2 +-
 .../compute/ComputeTaskSplitExample.java        |   2 +-
 .../compute/montecarlo/CreditRiskExample.java   |   2 +-
 .../examples/datagrid/CacheAffinityExample.java |   2 +-
 .../examples/datagrid/CacheApiExample.java      |   2 +-
 .../datagrid/CacheContinuousQueryExample.java   |   2 +-
 .../datagrid/CacheDataLoaderExample.java        |   2 +-
 .../examples/datagrid/CacheEventsExample.java   |   2 +-
 .../datagrid/CachePopularNumbersExample.java    |   2 +-
 .../examples/datagrid/CachePutGetExample.java   |   2 +-
 .../examples/datagrid/CacheQueryExample.java    |   2 +-
 .../datagrid/CacheTransactionExample.java       |   2 +-
 .../datastructures/CacheAtomicLongExample.java  |   2 +-
 .../CacheAtomicReferenceExample.java            |   2 +-
 .../CacheAtomicSequenceExample.java             |   2 +-
 .../CacheAtomicStampedExample.java              |   2 +-
 .../CacheCountDownLatchExample.java             |   2 +-
 .../datastructures/CacheQueueExample.java       |   2 +-
 .../datastructures/CacheSetExample.java         |   2 +-
 .../starschema/CacheStarSchemaExample.java      |   2 +-
 .../ignite/examples/events/EventsExample.java   |   2 +-
 .../ignite/examples/ggfs/GgfsExample.java       |   2 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |   2 +-
 .../ignite/examples/ggfs/GgfsNodeStartup.java   |   4 +-
 .../examples/messaging/MessagingExample.java    |   2 +-
 .../messaging/MessagingPingPongExample.java     |   2 +-
 .../MessagingPingPongListenActorExample.java    |   2 +-
 .../misc/deployment/DeploymentExample.java      |   2 +-
 .../misc/springbean/SpringBeanExample.java      |   2 +-
 .../examples/services/ServicesExample.java      |   2 +-
 .../streaming/StreamingCheckInExample.java      |   2 +-
 .../StreamingPopularNumbersExample.java         |   2 +-
 .../streaming/StreamingPriceBarsExample.java    |   2 +-
 .../StreamingRunningAverageExample.java         |   2 +-
 .../apache/ignite/examples/ComputeExample.java  |   2 +-
 .../ignite/examples/MessagingExample.java       |   2 +-
 .../examples/ScalarCacheAffinityExample1.scala  |   2 +-
 .../examples/ScalarCacheAffinityExample2.scala  |   2 +-
 .../ScalarCacheAffinitySimpleExample.scala      |   2 +-
 .../scalar/examples/ScalarCacheExample.scala    |   2 +-
 .../ScalarCachePopularNumbersExample.scala      |   2 +-
 .../examples/ScalarCacheQueryExample.scala      |   2 +-
 .../scalar/examples/ScalarClosureExample.scala  |   2 +-
 .../examples/ScalarContinuationExample.scala    |   2 +-
 .../examples/ScalarCreditRiskExample.scala      |   2 +-
 .../examples/ScalarPiCalculationExample.scala   |   2 +-
 .../scalar/examples/ScalarPingPongExample.scala |   2 +-
 .../scalar/examples/ScalarPrimeExample.scala    |   2 +-
 .../scalar/examples/ScalarScheduleExample.scala |   2 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |   2 +-
 .../scalar/examples/ScalarTaskExample.scala     |   2 +-
 .../examples/ScalarWorldShortestMapReduce.scala |   2 +-
 modules/aop/readme.txt                          |   2 +-
 modules/aws/readme.txt                          |   2 +-
 modules/clients/src/test/bin/start-nodes.cmd    |  10 +-
 modules/clients/src/test/bin/start-nodes.sh     |   8 +-
 .../clients/src/test/resources/spring-cache.xml |   2 +-
 .../src/test/resources/spring-router-ssl.xml    |   2 +-
 .../src/test/resources/spring-router.xml        |   2 +-
 .../src/test/resources/spring-server-node.xml   |   2 +-
 .../test/resources/spring-server-ssl-node.xml   |   2 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   4 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |   4 +-
 .../java/org/apache/ignite/IgniteLogger.java    |   2 +-
 .../apache/ignite/IgniteSystemProperties.java   |   4 +-
 .../main/java/org/apache/ignite/Ignition.java   |   4 +-
 .../ignite/client/router/GridRouterFactory.java |   2 +-
 .../configuration/IgniteDeploymentMode.java     |   2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   6 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   2 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |   2 +-
 .../segmentation/GridSegmentationPolicy.java    |   2 +-
 .../startup/cmdline/CommandLineStartup.java     |  10 +-
 .../startup/cmdline/CommandLineTransformer.java |   6 +-
 .../core/src/test/bin/start-nodes-custom.bat    |   2 +-
 modules/core/src/test/bin/start-nodes-custom.sh |   2 +-
 .../spring-cache-client-benchmark-1.xml         |   2 +-
 .../spring-cache-client-benchmark-2.xml         |   2 +-
 .../spring-cache-client-benchmark-3.xml         |   2 +-
 modules/core/src/test/config/example-cache.xml  |   2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |   2 +-
 .../core/src/test/config/spring-cache-load.xml  |   2 +-
 .../core/src/test/config/spring-multicache.xml  |   2 +-
 .../average/spring-streamer-average-base.xml    |   2 +-
 .../average/spring-streamer-average-local.xml   |   2 +-
 .../average/spring-streamer-average-random.xml  |   2 +-
 .../config/streamer/spring-streamer-base.xml    |   2 +-
 .../GridCacheMultiNodeDataStructureTest.java    |   4 +-
 .../capacity/spring-capacity-cache.xml          |   2 +-
 .../loadtests/colocation/spring-colocation.xml  |   2 +-
 .../loadtests/mapper/GridNodeStartup.java       |   4 +-
 .../startup/GridRandomCommandLineLoader.java    |   2 +-
 .../ignite/startup/GridVmNodesStarter.java      |   2 +-
 .../core/src/test/webapp/META-INF/gg-config.xml |   2 +-
 modules/email/readme.txt                        |   2 +-
 modules/hadoop/readme.txt                       |   2 +-
 modules/hibernate/readme.txt                    |   2 +-
 modules/indexing/readme.txt                     |   2 +-
 modules/jcl/readme.txt                          |   2 +-
 modules/jta/readme.txt                          |   2 +-
 modules/log4j/readme.txt                        |   2 +-
 modules/rest-http/readme.txt                    |   2 +-
 modules/scalar/readme.txt                       |   2 +-
 modules/schedule/readme.txt                     |   2 +-
 modules/slf4j/readme.txt                        |   2 +-
 modules/spring/readme.txt                       |   2 +-
 .../ignite/cache/spring/SpringCacheManager.java |   2 +-
 modules/ssh/readme.txt                          |   2 +-
 .../util/nodestart/GridNodeCallableImpl.java    |   8 +-
 modules/urideploy/readme.txt                    |   2 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |   2 +-
 .../ignite/visor/commands/start/Packet.scala    |   4 +-
 .../commands/start/VisorStartCommand.scala      |   8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 modules/web/readme.txt                          |   2 +-
 152 files changed, 934 insertions(+), 934 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/assembly/libs/readme.txt
----------------------------------------------------------------------
diff --git a/assembly/libs/readme.txt b/assembly/libs/readme.txt
index 7595da9..78b3604 100644
--- a/assembly/libs/readme.txt
+++ b/assembly/libs/readme.txt
@@ -2,7 +2,7 @@ Apache Ignite Dependencies
 --------------------------
 
 Current folder contains JAR files for all Apache Ignite modules along with their dependencies.
-When node is started using 'ggstart.{sh|bat}' script, all JARs and classes located in
+When node is started using 'ignite.{sh|bat}' script, all JARs and classes located in
 'libs' folder and all its sub-folders except 'optional' are added to classpath of the node.
 
 By default, only Apache Ignite core JAR and a minimum set of modules is enabled, while other
@@ -10,7 +10,7 @@ modules are located in 'optional' folder and therefore disabled.
 
 To enable any of optional Ignite modules when starting a standalone node,
 move corresponding module folder from 'libs/optional' to 'libs' before running
-'ggstart.{sh|bat}' script. The content of the module folder will be added to
+'ignite.{sh|bat}' script. The content of the module folder will be added to
 classpath in this case.
 
 If you need to add your own classes to classpath of the node (e.g., task classes), put them

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/assembly/release-base-fabric.xml
----------------------------------------------------------------------
diff --git a/assembly/release-base-fabric.xml b/assembly/release-base-fabric.xml
index bd70839..f985b6a 100644
--- a/assembly/release-base-fabric.xml
+++ b/assembly/release-base-fabric.xml
@@ -39,7 +39,7 @@
             <directory>bin</directory>
             <outputDirectory>/bin</outputDirectory>
             <includes>
-                <include>ggrouter.bat</include>
+                <include>igniterouter.bat</include>
             </includes>
         </fileSet>
 
@@ -48,7 +48,7 @@
             <outputDirectory>/bin</outputDirectory>
             <fileMode>0755</fileMode>
             <includes>
-                <include>ggrouter.sh</include>
+                <include>igniterouter.sh</include>
             </includes>
         </fileSet>
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/assembly/release-base.xml
----------------------------------------------------------------------
diff --git a/assembly/release-base.xml b/assembly/release-base.xml
index 3995732..5cdeb2a 100644
--- a/assembly/release-base.xml
+++ b/assembly/release-base.xml
@@ -55,7 +55,7 @@
             </includes>
             <excludes>
                 <exclude>**/*hadoop*.bat</exclude>
-                <exclude>ggrouter.bat</exclude>
+                <exclude>igniterouter.bat</exclude>
                 <exclude>**/target-classpath.bat</exclude>
             </excludes>
         </fileSet>
@@ -69,7 +69,7 @@
             </includes>
             <excludes>
                 <exclude>**/*hadoop*.sh</exclude>
-                <exclude>ggrouter.sh</exclude>
+                <exclude>igniterouter.sh</exclude>
                 <exclude>**/target-classpath.sh</exclude>
                 <exclude>**/service.sh</exclude>
             </excludes>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggrouter.bat
----------------------------------------------------------------------
diff --git a/bin/ggrouter.bat b/bin/ggrouter.bat
deleted file mode 100644
index a364061..0000000
--- a/bin/ggrouter.bat
+++ /dev/null
@@ -1,33 +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.
-
-::
-:: Grid router command line loader.
-::
-
-@echo off
-
-if "%OS%" == "Windows_NT" setlocal
-
-::
-:: Set router service environment.
-::
-set "DEFAULT_CONFIG=config\router\default-router.xml"
-set MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
-
-::
-:: Start router service.
-::
-call "%~dp0\ggstart.bat" %*

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggrouter.sh
----------------------------------------------------------------------
diff --git a/bin/ggrouter.sh b/bin/ggrouter.sh
deleted file mode 100755
index 29ac1d1..0000000
--- a/bin/ggrouter.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/bin/bash
-#  Licensed to the Apache Software Foundation (ASF) under one or more
-#  contributor license agreements.  See the NOTICE file distributed with
-#  this work for additional information regarding copyright ownership.
-#  The ASF licenses this file to You under the Apache License, Version 2.0
-#  (the "License"); you may not use this file except in compliance with
-#  the License.  You may obtain a copy of the License at
-#
-#       http://www.apache.org/licenses/LICENSE-2.0
-#
-#  Unless required by applicable law or agreed to in writing, software
-#  distributed under the License is distributed on an "AS IS" BASIS,
-#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-
-#
-# Router command line loader.
-#
-
-#
-# Import common functions.
-#
-if [ "${IGNITE_HOME}" = "" ];
-    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
-    else IGNITE_HOME_TMP=${IGNITE_HOME};
-fi
-
-#
-# Set SCRIPTS_HOME - base path to scripts.
-#
-SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
-
-source "${SCRIPTS_HOME}"/include/functions.sh
-
-#
-# Discover IGNITE_HOME environment variable.
-#
-setGridGainHome
-
-#
-# Set router service environment.
-#
-export DEFAULT_CONFIG=config/router/default-router.xml
-export MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
-
-#
-# Start router service.
-#
-. "${SCRIPTS_HOME}"/ggstart.sh $@

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggstart.bat
----------------------------------------------------------------------
diff --git a/bin/ggstart.bat b/bin/ggstart.bat
deleted file mode 100644
index 2db610b..0000000
--- a/bin/ggstart.bat
+++ /dev/null
@@ -1,228 +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.
-
-::
-:: Grid command line loader.
-::
-
-@echo off
-
-if "%OS%" == "Windows_NT"  setlocal
-
-:: Check JAVA_HOME.
-if defined JAVA_HOME  goto checkJdk
-    echo %0, ERROR:
-    echo JAVA_HOME environment variable is not found.
-    echo Please point JAVA_HOME variable to location of JDK 1.7 or JDK 1.8.
-    echo You can also download latest JDK at http://java.com/download.
-goto error_finish
-
-:checkJdk
-:: Check that JDK is where it should be.
-if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
-    echo %0, ERROR:
-    echo JAVA is not found in JAVA_HOME=%JAVA_HOME%.
-    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
-    echo You can also download latest JDK at http://java.com/download.
-goto error_finish
-
-:checkJdkVersion
-"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
-if %ERRORLEVEL% equ 0 goto checkGridGainHome1
-    echo %0, ERROR:
-    echo The version of JAVA installed in %JAVA_HOME% is incorrect.
-    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
-    echo You can also download latest JDK at http://java.com/download.
-goto error_finish
-
-:: Check IGNITE_HOME.
-:checkGridGainHome1
-if defined IGNITE_HOME goto checkGridGainHome2
-    pushd "%~dp0"/..
-    set IGNITE_HOME=%CD%
-    popd
-
-:checkGridGainHome2
-:: Strip double quotes from IGNITE_HOME
-set IGNITE_HOME=%IGNITE_HOME:"=%
-
-:: remove all trailing slashes from IGNITE_HOME.
-if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
-if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
-goto checkGridGainHome3
-
-:removeTrailingSlash
-set IGNITE_HOME=%IGNITE_HOME:~0,-1%
-goto checkGridGainHome2
-
-:checkGridGainHome3
-if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
-    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
-    echo Please create IGNITE_HOME environment variable pointing to location of
-    echo GridGain installation folder.
-    goto error_finish
-
-:checkGridGainHome4
-
-::
-:: Set SCRIPTS_HOME - base path to scripts.
-::
-set SCRIPTS_HOME=%IGNITE_HOME%\bin
-
-:: Remove trailing spaces
-for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
-
-if /i "%SCRIPTS_HOME%\" == "%~dp0" goto setProgName
-    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
-
-:setProgName
-::
-:: Set program name.
-::
-set PROG_NAME=ggstart.bat
-if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
-
-:run
-
-::
-:: Set IGNITE_LIBS
-::
-call "%SCRIPTS_HOME%\include\setenv.bat"
-call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
-set CP=%IGNITE_LIBS%
-
-::
-:: Parse command line parameters.
-::
-if not defined DEFAULT_CONFIG set "DEFAULT_CONFIG=config\default-config.xml"
-call "%SCRIPTS_HOME%\include\parseargs.bat" %*
-if %ERRORLEVEL% neq 0 (
-    echo Arguments parsing failed
-    exit /b %ERRORLEVEL%
-)
-
-::
-:: Process 'restart'.
-::
-set RANDOM_NUMBER_COMMAND="%JAVA_HOME%\bin\java.exe" -cp %CP% org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
-for /f "usebackq tokens=*" %%i in (`"%RANDOM_NUMBER_COMMAND%"`) do set RANDOM_NUMBER=%%i
-
-set RESTART_SUCCESS_FILE="%IGNITE_HOME%\work\ignite_success_%RANDOM_NUMBER%"
-set RESTART_SUCCESS_OPT=-DIGNITE_SUCCESS_FILE=%RESTART_SUCCESS_FILE%
-
-::
-:: Find available port for JMX
-::
-:: You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
-::
-for /F "tokens=*" %%A in ('""%JAVA_HOME%\bin\java" -cp %CP% org.gridgain.grid.util.portscanner.GridJmxPortFinder"') do (
-    set JMX_PORT=%%A
-)
-
-::
-:: This variable defines necessary parameters for JMX
-:: monitoring and management.
-::
-:: This enables remote unsecure access to JConsole or VisualVM.
-::
-:: ADD YOUR ADDITIONAL PARAMETERS/OPTIONS HERE
-::
-if "%JMX_PORT%" == "" (
-    echo %0, WARN: Failed to resolve JMX host. JMX will be disabled.
-    set JMX_MON=
-) else (
-    set JMX_MON=-Dcom.sun.management.jmxremote -Dcom.sun.management.jmxremote.port=%JMX_PORT% ^
-    -Dcom.sun.management.jmxremote.authenticate=false -Dcom.sun.management.jmxremote.ssl=false
-)
-
-::
-:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-::
-:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-::
-if "%JVM_OPTS%" == "" set JVM_OPTS=-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m
-
-::
-:: Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
-::
-:: set JVM_OPTS=%JVM_OPTS% -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m
-:: set JVM_OPTS=%JVM_OPTS% -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60
-
-::
-:: Uncomment if you get StackOverflowError.
-:: On 64 bit systems this value can be larger, e.g. -Xss16m
-::
-:: set JVM_OPTS=%JVM_OPTS% -Xss4m
-
-::
-:: Uncomment to set preference to IPv4 stack.
-::
-:: set JVM_OPTS=%JVM_OPTS% -Djava.net.preferIPv4Stack=true
-
-::
-:: Assertions are disabled by default since version 3.5.
-:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-::
-set ENABLE_ASSERTIONS=1
-
-::
-:: Set '-ea' options if assertions are enabled.
-::
-if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS=%JVM_OPTS% -ea
-
-:run_java
-
-::
-:: Set main class to start service (grid node by default).
-::
-
-if "%MAIN_CLASS%" == "" set MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
-
-::
-:: Remote debugging (JPDA).
-:: Uncomment and change if remote debugging is required.
-:: set JVM_OPTS=-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n %JVM_OPTS%
-::
-
-if "%INTERACTIVE%" == "1" (
-    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
-    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
-    -cp "%CP%" %MAIN_CLASS%
-) else (
-    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
-    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
-    -cp "%CP%" %MAIN_CLASS% "%CONFIG%"
-)
-
-set JAVA_ERRORLEVEL=%ERRORLEVEL%
-
-:: errorlevel 130 if aborted with Ctrl+c
-if %JAVA_ERRORLEVEL%==130 goto finish
-
-:: Exit if first run unsuccessful (Loader must create file).
-if not exist %RESTART_SUCCESS_FILE% goto error_finish
-del %RESTART_SUCCESS_FILE%
-
-goto run_java
-
-:finish
-if not exist %RESTART_SUCCESS_FILE% goto error_finish
-del %RESTART_SUCCESS_FILE%
-
-:error_finish
-
-if not "%NO_PAUSE%" == "1" pause
-
-goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggstart.sh
----------------------------------------------------------------------
diff --git a/bin/ggstart.sh b/bin/ggstart.sh
deleted file mode 100755
index 4e2f37c..0000000
--- a/bin/ggstart.sh
+++ /dev/null
@@ -1,176 +0,0 @@
-#!/bin/bash
-#  Licensed to the Apache Software Foundation (ASF) under one or more
-#  contributor license agreements.  See the NOTICE file distributed with
-#  this work for additional information regarding copyright ownership.
-#  The ASF licenses this file to You under the Apache License, Version 2.0
-#  (the "License"); you may not use this file except in compliance with
-#  the License.  You may obtain a copy of the License at
-#
-#       http://www.apache.org/licenses/LICENSE-2.0
-#
-#  Unless required by applicable law or agreed to in writing, software
-#  distributed under the License is distributed on an "AS IS" BASIS,
-#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-
-#
-# Grid command line loader.
-#
-
-#
-# Import common functions.
-#
-if [ "${IGNITE_HOME}" = "" ];
-    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";
-    else IGNITE_HOME_TMP=${IGNITE_HOME};
-fi
-
-#
-# Set SCRIPTS_HOME - base path to scripts.
-#
-SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
-
-source "${SCRIPTS_HOME}"/include/functions.sh
-
-#
-# Discover path to Java executable and check it's version.
-#
-checkJava
-
-#
-# Discover IGNITE_HOME environment variable.
-#
-setGridGainHome
-
-if [ "${DEFAULT_CONFIG}" == "" ]; then
-    DEFAULT_CONFIG=config/default-config.xml
-fi
-
-#
-# Parse command line parameters.
-#
-. "${SCRIPTS_HOME}"/include/parseargs.sh
-
-#
-# Set IGNITE_LIBS.
-#
-. "${SCRIPTS_HOME}"/include/setenv.sh
-. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
-CP="${IGNITE_LIBS}"
-
-RANDOM_NUMBER=$("$JAVA" -cp "${CP}" org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator)
-
-RESTART_SUCCESS_FILE="${IGNITE_HOME}/work/ignite_success_${RANDOM_NUMBER}"
-RESTART_SUCCESS_OPT="-DIGNITE_SUCCESS_FILE=${RESTART_SUCCESS_FILE}"
-
-#
-# Find available port for JMX
-#
-# You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
-#
-findAvailableJmxPort
-
-# Mac OS specific support to display correct name in the dock.
-osname=`uname`
-
-if [ "${DOCK_OPTS}" == "" ]; then
-    DOCK_OPTS="-Xdock:name=GridGain Node"
-fi
-
-#
-# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-#
-# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-#
-if [ -z "$JVM_OPTS" ] ; then
-    JVM_OPTS="-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m"
-fi
-
-#
-# Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
-#
-# JVM_OPTS="$JVM_OPTS -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m"
-# JVM_OPTS="$JVM_OPTS -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60"
-
-#
-# Uncomment if you get StackOverflowError.
-# On 64 bit systems this value can be larger, e.g. -Xss16m
-#
-# JVM_OPTS="${JVM_OPTS} -Xss4m"
-
-#
-# Uncomment to set preference for IPv4 stack.
-#
-# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
-
-#
-# Assertions are disabled by default since version 3.5.
-# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-#
-ENABLE_ASSERTIONS="1"
-
-#
-# Set '-ea' options if assertions are enabled.
-#
-if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
-    JVM_OPTS="${JVM_OPTS} -ea"
-fi
-
-#
-# Set main class to start service (grid node by default).
-#
-if [ "${MAIN_CLASS}" = "" ]; then
-    MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
-fi
-
-#
-# Remote debugging (JPDA).
-# Uncomment and change if remote debugging is required.
-#
-# JVM_OPTS="-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n ${JVM_OPTS}"
-
-ERRORCODE="-1"
-
-while [ "${ERRORCODE}" -ne "130" ]
-do
-    if [ "${INTERACTIVE}" == "1" ] ; then
-        case $osname in
-            Darwin*)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
-            ;;
-            *)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
-            ;;
-        esac
-    else
-        case $osname in
-            Darwin*)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
-            ;;
-            *)
-                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
-                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
-                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
-            ;;
-        esac
-    fi
-
-    ERRORCODE="$?"
-
-    if [ ! -f "${RESTART_SUCCESS_FILE}" ] ; then
-        break
-    else
-        rm -f "${RESTART_SUCCESS_FILE}"
-    fi
-done
-
-if [ -f "${RESTART_SUCCESS_FILE}" ] ; then
-    rm -f "${RESTART_SUCCESS_FILE}"
-fi

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggvisorcmd.bat
----------------------------------------------------------------------
diff --git a/bin/ggvisorcmd.bat b/bin/ggvisorcmd.bat
deleted file mode 100644
index c4c64f9..0000000
--- a/bin/ggvisorcmd.bat
+++ /dev/null
@@ -1,144 +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.
-
-::
-:: Starts GridGain Visor Console.
-::
-
-@echo off
-
-if "%OS%" == "Windows_NT"  setlocal
-
-:: Check JAVA_HOME.
-if not "%JAVA_HOME%" == "" goto checkJdk
-    echo %0, ERROR: JAVA_HOME environment variable is not found.
-    echo %0, ERROR: Please create JAVA_HOME variable pointing to location of JDK 1.7 or JDK 1.8.
-    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
-goto error_finish
-
-:checkJdk
-:: Check that JDK is where it should be.
-if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
-    echo %0, ERROR: The JDK is not found in %JAVA_HOME%.
-    echo %0, ERROR: Please modify your script so that JAVA_HOME would point to valid location of JDK.
-goto error_finish
-
-:checkJdkVersion
-"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
-if %ERRORLEVEL% equ 0 goto checkGridGainHome1
-    echo %0, ERROR: The version of JAVA installed in %JAVA_HOME% is incorrect.
-    echo %0, ERROR: Please install JDK 1.7 or 1.8.
-    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
-goto error_finish
-
-:: Check IGNITE_HOME.
-:checkGridGainHome1
-if not "%IGNITE_HOME%" == "" goto checkGridGainHome2
-    pushd "%~dp0"/..
-    set IGNITE_HOME=%CD%
-    popd
-
-:checkGridGainHome2
-:: Strip double quotes from IGNITE_HOME
-set IGNITE_HOME=%IGNITE_HOME:"=%
-
-:: remove all trailing slashes from IGNITE_HOME.
-if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
-if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
-goto checkGridGainHome3
-
-:removeTrailingSlash
-set IGNITE_HOME=%IGNITE_HOME:~0,-1%
-goto checkGridGainHome2
-
-:checkGridGainHome3
-if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
-    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
-    echo Please create IGNITE_HOME environment variable pointing to location of
-    echo GridGain installation folder.
-    goto error_finish
-
-:checkGridGainHome4
-
-::
-:: Set SCRIPTS_HOME - base path to scripts.
-::
-set SCRIPTS_HOME=%IGNITE_HOME%\bin
-
-:: Remove trailing spaces
-for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
-
-if /i "%SCRIPTS_HOME%\" == "%~dp0" goto run
-    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
-
-:run
-
-::
-:: Set IGNITE_LIBS
-::
-call "%SCRIPTS_HOME%\include\setenv.bat"
-call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
-set CP=%IGNITE_HOME%\bin\include\visor-common\*;%IGNITE_HOME%\bin\include\visorcmd\*;%IGNITE_LIBS%
-
-::
-:: Parse command line parameters.
-::
-call "%SCRIPTS_HOME%\include\parseargs.bat" %*
-if %ERRORLEVEL% neq 0 (
-    echo Arguments parsing failed
-    exit /b %ERRORLEVEL%
-)
-
-::
-:: Set program name.
-::
-set PROG_NAME=gridgain.bat
-if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
-
-::
-:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-::
-:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-::
-if "%JVM_OPTS_VISOR%" == "" set JVM_OPTS_VISOR=-Xms1g -Xmx1g -XX:MaxPermSize=128M
-
-::
-:: Uncomment to set preference to IPv4 stack.
-::
-:: set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -Djava.net.preferIPv4Stack=true
-
-::
-:: Assertions are disabled by default since version 3.5.
-:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-::
-set ENABLE_ASSERTIONS=1
-
-::
-:: Set '-ea' options if assertions are enabled.
-::
-if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -ea
-
-::
-:: Starts Visor console.
-::
-"%JAVA_HOME%\bin\java.exe" %JVM_OPTS_VISOR% -DIGNITE_PROG_NAME="%PROG_NAME%" ^
--DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED %QUIET% %JVM_XOPTS% -cp "%CP%" ^
- org.gridgain.visor.commands.VisorConsole
-
-:error_finish
-
-if not "%NO_PAUSE%" == "1" pause
-
-goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ggvisorcmd.sh
----------------------------------------------------------------------
diff --git a/bin/ggvisorcmd.sh b/bin/ggvisorcmd.sh
deleted file mode 100755
index 319d282..0000000
--- a/bin/ggvisorcmd.sh
+++ /dev/null
@@ -1,124 +0,0 @@
-#!/bin/bash
-#  Licensed to the Apache Software Foundation (ASF) under one or more
-#  contributor license agreements.  See the NOTICE file distributed with
-#  this work for additional information regarding copyright ownership.
-#  The ASF licenses this file to You under the Apache License, Version 2.0
-#  (the "License"); you may not use this file except in compliance with
-#  the License.  You may obtain a copy of the License at
-#
-#       http://www.apache.org/licenses/LICENSE-2.0
-#
-#  Unless required by applicable law or agreed to in writing, software
-#  distributed under the License is distributed on an "AS IS" BASIS,
-#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-
-#
-# Import common functions.
-#
-if [ "${IGNITE_HOME}" = "" ];
-    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
-    else IGNITE_HOME_TMP=${IGNITE_HOME};
-fi
-
-#
-# Set SCRIPTS_HOME - base path to scripts.
-#
-SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
-
-source "${SCRIPTS_HOME}"/include/functions.sh
-
-#
-# Discover path to Java executable and check it's version.
-#
-checkJava
-
-#
-# Discover IGNITE_HOME environment variable.
-#
-setGridGainHome
-
-#
-# Parse command line parameters.
-#
-. "${SCRIPTS_HOME}"/include/parseargs.sh
-
-#
-# Set IGNITE_LIBS.
-#
-. "${SCRIPTS_HOME}"/include/setenv.sh
-. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
-CP="${IGNITE_HOME}/bin/include/visor-common/*${SEP}${IGNITE_HOME}/bin/include/visorcmd/*${SEP}${IGNITE_LIBS}"
-
-#
-# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
-#
-# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
-#
-JVM_OPTS="-Xms1g -Xmx1g -XX:MaxPermSize=128M -server ${JVM_OPTS}"
-
-# Mac OS specific support to display correct name in the dock.
-osname=`uname`
-
-if [ "${DOCK_OPTS}" == "" ]; then
-    DOCK_OPTS="-Xdock:name=Visor - GridGain Shell Console"
-fi
-
-#
-# Uncomment to set preference for IPv4 stack.
-#
-# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
-
-#
-# Assertions are disabled by default since version 3.5.
-# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
-#
-ENABLE_ASSERTIONS="1"
-
-#
-# Set '-ea' options if assertions are enabled.
-#
-if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
-    JVM_OPTS="${JVM_OPTS} -ea"
-fi
-
-#
-# Save terminal setting. Used to restore terminal on finish.
-#
-SAVED_STTY=`stty -g 2>/dev/null`
-
-#
-# Restores terminal.
-#
-function restoreSttySettings() {
-    stty ${SAVED_STTY}
-}
-
-#
-# Trap that restores terminal in case script execution is interrupted.
-#
-trap restoreSttySettings INT
-
-#
-# Start Visor console.
-#
-case $osname in
-    Darwin*)
-        "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" \
-        -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" \
-        -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED ${JVM_XOPTS} -cp "${CP}" \
-        org.apache.ignite.visor.commands.VisorConsole
-    ;;
-    *)
-        "$JAVA" ${JVM_OPTS} ${QUIET} -DIGNITE_UPDATE_NOTIFIER=false \
-        -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED \
-        ${JVM_XOPTS} -cp "${CP}" \
-        org.apache.ignite.visor.commands.VisorConsole
-    ;;
-esac
-
-#
-# Restore terminal.
-#
-restoreSttySettings

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignite.bat
----------------------------------------------------------------------
diff --git a/bin/ignite.bat b/bin/ignite.bat
new file mode 100644
index 0000000..d11dc1b
--- /dev/null
+++ b/bin/ignite.bat
@@ -0,0 +1,228 @@
+::  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.
+
+::
+:: Grid command line loader.
+::
+
+@echo off
+
+if "%OS%" == "Windows_NT"  setlocal
+
+:: Check JAVA_HOME.
+if defined JAVA_HOME  goto checkJdk
+    echo %0, ERROR:
+    echo JAVA_HOME environment variable is not found.
+    echo Please point JAVA_HOME variable to location of JDK 1.7 or JDK 1.8.
+    echo You can also download latest JDK at http://java.com/download.
+goto error_finish
+
+:checkJdk
+:: Check that JDK is where it should be.
+if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
+    echo %0, ERROR:
+    echo JAVA is not found in JAVA_HOME=%JAVA_HOME%.
+    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
+    echo You can also download latest JDK at http://java.com/download.
+goto error_finish
+
+:checkJdkVersion
+"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
+if %ERRORLEVEL% equ 0 goto checkGridGainHome1
+    echo %0, ERROR:
+    echo The version of JAVA installed in %JAVA_HOME% is incorrect.
+    echo Please point JAVA_HOME variable to installation of JDK 1.7 or JDK 1.8.
+    echo You can also download latest JDK at http://java.com/download.
+goto error_finish
+
+:: Check IGNITE_HOME.
+:checkGridGainHome1
+if defined IGNITE_HOME goto checkGridGainHome2
+    pushd "%~dp0"/..
+    set IGNITE_HOME=%CD%
+    popd
+
+:checkGridGainHome2
+:: Strip double quotes from IGNITE_HOME
+set IGNITE_HOME=%IGNITE_HOME:"=%
+
+:: remove all trailing slashes from IGNITE_HOME.
+if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
+if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
+goto checkGridGainHome3
+
+:removeTrailingSlash
+set IGNITE_HOME=%IGNITE_HOME:~0,-1%
+goto checkGridGainHome2
+
+:checkGridGainHome3
+if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
+    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
+    echo Please create IGNITE_HOME environment variable pointing to location of
+    echo GridGain installation folder.
+    goto error_finish
+
+:checkGridGainHome4
+
+::
+:: Set SCRIPTS_HOME - base path to scripts.
+::
+set SCRIPTS_HOME=%IGNITE_HOME%\bin
+
+:: Remove trailing spaces
+for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
+
+if /i "%SCRIPTS_HOME%\" == "%~dp0" goto setProgName
+    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
+
+:setProgName
+::
+:: Set program name.
+::
+set PROG_NAME=ignite.bat
+if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
+
+:run
+
+::
+:: Set IGNITE_LIBS
+::
+call "%SCRIPTS_HOME%\include\setenv.bat"
+call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
+set CP=%IGNITE_LIBS%
+
+::
+:: Parse command line parameters.
+::
+if not defined DEFAULT_CONFIG set "DEFAULT_CONFIG=config\default-config.xml"
+call "%SCRIPTS_HOME%\include\parseargs.bat" %*
+if %ERRORLEVEL% neq 0 (
+    echo Arguments parsing failed
+    exit /b %ERRORLEVEL%
+)
+
+::
+:: Process 'restart'.
+::
+set RANDOM_NUMBER_COMMAND="%JAVA_HOME%\bin\java.exe" -cp %CP% org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
+for /f "usebackq tokens=*" %%i in (`"%RANDOM_NUMBER_COMMAND%"`) do set RANDOM_NUMBER=%%i
+
+set RESTART_SUCCESS_FILE="%IGNITE_HOME%\work\ignite_success_%RANDOM_NUMBER%"
+set RESTART_SUCCESS_OPT=-DIGNITE_SUCCESS_FILE=%RESTART_SUCCESS_FILE%
+
+::
+:: Find available port for JMX
+::
+:: You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
+::
+for /F "tokens=*" %%A in ('""%JAVA_HOME%\bin\java" -cp %CP% org.gridgain.grid.util.portscanner.GridJmxPortFinder"') do (
+    set JMX_PORT=%%A
+)
+
+::
+:: This variable defines necessary parameters for JMX
+:: monitoring and management.
+::
+:: This enables remote unsecure access to JConsole or VisualVM.
+::
+:: ADD YOUR ADDITIONAL PARAMETERS/OPTIONS HERE
+::
+if "%JMX_PORT%" == "" (
+    echo %0, WARN: Failed to resolve JMX host. JMX will be disabled.
+    set JMX_MON=
+) else (
+    set JMX_MON=-Dcom.sun.management.jmxremote -Dcom.sun.management.jmxremote.port=%JMX_PORT% ^
+    -Dcom.sun.management.jmxremote.authenticate=false -Dcom.sun.management.jmxremote.ssl=false
+)
+
+::
+:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+::
+:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+::
+if "%JVM_OPTS%" == "" set JVM_OPTS=-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m
+
+::
+:: Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
+::
+:: set JVM_OPTS=%JVM_OPTS% -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m
+:: set JVM_OPTS=%JVM_OPTS% -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60
+
+::
+:: Uncomment if you get StackOverflowError.
+:: On 64 bit systems this value can be larger, e.g. -Xss16m
+::
+:: set JVM_OPTS=%JVM_OPTS% -Xss4m
+
+::
+:: Uncomment to set preference to IPv4 stack.
+::
+:: set JVM_OPTS=%JVM_OPTS% -Djava.net.preferIPv4Stack=true
+
+::
+:: Assertions are disabled by default since version 3.5.
+:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+::
+set ENABLE_ASSERTIONS=1
+
+::
+:: Set '-ea' options if assertions are enabled.
+::
+if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS=%JVM_OPTS% -ea
+
+:run_java
+
+::
+:: Set main class to start service (grid node by default).
+::
+
+if "%MAIN_CLASS%" == "" set MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
+
+::
+:: Remote debugging (JPDA).
+:: Uncomment and change if remote debugging is required.
+:: set JVM_OPTS=-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n %JVM_OPTS%
+::
+
+if "%INTERACTIVE%" == "1" (
+    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
+    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
+    -cp "%CP%" %MAIN_CLASS%
+) else (
+    "%JAVA_HOME%\bin\java.exe" %JVM_OPTS% %QUIET% %RESTART_SUCCESS_OPT% %JMX_MON% ^
+    -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="%IGNITE_HOME%" -DIGNITE_PROG_NAME="%PROG_NAME%" %JVM_XOPTS% ^
+    -cp "%CP%" %MAIN_CLASS% "%CONFIG%"
+)
+
+set JAVA_ERRORLEVEL=%ERRORLEVEL%
+
+:: errorlevel 130 if aborted with Ctrl+c
+if %JAVA_ERRORLEVEL%==130 goto finish
+
+:: Exit if first run unsuccessful (Loader must create file).
+if not exist %RESTART_SUCCESS_FILE% goto error_finish
+del %RESTART_SUCCESS_FILE%
+
+goto run_java
+
+:finish
+if not exist %RESTART_SUCCESS_FILE% goto error_finish
+del %RESTART_SUCCESS_FILE%
+
+:error_finish
+
+if not "%NO_PAUSE%" == "1" pause
+
+goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignite.sh
----------------------------------------------------------------------
diff --git a/bin/ignite.sh b/bin/ignite.sh
new file mode 100644
index 0000000..4e2f37c
--- /dev/null
+++ b/bin/ignite.sh
@@ -0,0 +1,176 @@
+#!/bin/bash
+#  Licensed to the Apache Software Foundation (ASF) under one or more
+#  contributor license agreements.  See the NOTICE file distributed with
+#  this work for additional information regarding copyright ownership.
+#  The ASF licenses this file to You under the Apache License, Version 2.0
+#  (the "License"); you may not use this file except in compliance with
+#  the License.  You may obtain a copy of the License at
+#
+#       http://www.apache.org/licenses/LICENSE-2.0
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
+
+#
+# Grid command line loader.
+#
+
+#
+# Import common functions.
+#
+if [ "${IGNITE_HOME}" = "" ];
+    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";
+    else IGNITE_HOME_TMP=${IGNITE_HOME};
+fi
+
+#
+# Set SCRIPTS_HOME - base path to scripts.
+#
+SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
+
+source "${SCRIPTS_HOME}"/include/functions.sh
+
+#
+# Discover path to Java executable and check it's version.
+#
+checkJava
+
+#
+# Discover IGNITE_HOME environment variable.
+#
+setGridGainHome
+
+if [ "${DEFAULT_CONFIG}" == "" ]; then
+    DEFAULT_CONFIG=config/default-config.xml
+fi
+
+#
+# Parse command line parameters.
+#
+. "${SCRIPTS_HOME}"/include/parseargs.sh
+
+#
+# Set IGNITE_LIBS.
+#
+. "${SCRIPTS_HOME}"/include/setenv.sh
+. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
+CP="${IGNITE_LIBS}"
+
+RANDOM_NUMBER=$("$JAVA" -cp "${CP}" org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator)
+
+RESTART_SUCCESS_FILE="${IGNITE_HOME}/work/ignite_success_${RANDOM_NUMBER}"
+RESTART_SUCCESS_OPT="-DIGNITE_SUCCESS_FILE=${RESTART_SUCCESS_FILE}"
+
+#
+# Find available port for JMX
+#
+# You can specify IGNITE_JMX_PORT environment variable for overriding automatically found JMX port
+#
+findAvailableJmxPort
+
+# Mac OS specific support to display correct name in the dock.
+osname=`uname`
+
+if [ "${DOCK_OPTS}" == "" ]; then
+    DOCK_OPTS="-Xdock:name=GridGain Node"
+fi
+
+#
+# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+#
+# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+#
+if [ -z "$JVM_OPTS" ] ; then
+    JVM_OPTS="-Xms1g -Xmx1g -server -XX:+AggressiveOpts -XX:MaxPermSize=256m"
+fi
+
+#
+# Uncomment the following GC settings if you see spikes in your throughput due to Garbage Collection.
+#
+# JVM_OPTS="$JVM_OPTS -XX:+UseParNewGC -XX:+UseConcMarkSweepGC -XX:+UseTLAB -XX:NewSize=128m -XX:MaxNewSize=128m"
+# JVM_OPTS="$JVM_OPTS -XX:MaxTenuringThreshold=0 -XX:SurvivorRatio=1024 -XX:+UseCMSInitiatingOccupancyOnly -XX:CMSInitiatingOccupancyFraction=60"
+
+#
+# Uncomment if you get StackOverflowError.
+# On 64 bit systems this value can be larger, e.g. -Xss16m
+#
+# JVM_OPTS="${JVM_OPTS} -Xss4m"
+
+#
+# Uncomment to set preference for IPv4 stack.
+#
+# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
+
+#
+# Assertions are disabled by default since version 3.5.
+# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+#
+ENABLE_ASSERTIONS="1"
+
+#
+# Set '-ea' options if assertions are enabled.
+#
+if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
+    JVM_OPTS="${JVM_OPTS} -ea"
+fi
+
+#
+# Set main class to start service (grid node by default).
+#
+if [ "${MAIN_CLASS}" = "" ]; then
+    MAIN_CLASS=org.apache.ignite.startup.cmdline.CommandLineStartup
+fi
+
+#
+# Remote debugging (JPDA).
+# Uncomment and change if remote debugging is required.
+#
+# JVM_OPTS="-Xdebug -Xrunjdwp:transport=dt_socket,address=8787,server=y,suspend=n ${JVM_OPTS}"
+
+ERRORCODE="-1"
+
+while [ "${ERRORCODE}" -ne "130" ]
+do
+    if [ "${INTERACTIVE}" == "1" ] ; then
+        case $osname in
+            Darwin*)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
+            ;;
+            *)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS}
+            ;;
+        esac
+    else
+        case $osname in
+            Darwin*)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
+            ;;
+            *)
+                "$JAVA" ${JVM_OPTS} ${QUIET} "${RESTART_SUCCESS_OPT}" ${JMX_MON} \
+                 -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" \
+                 -DIGNITE_PROG_NAME="$0" ${JVM_XOPTS} -cp "${CP}" ${MAIN_CLASS} "${CONFIG}"
+            ;;
+        esac
+    fi
+
+    ERRORCODE="$?"
+
+    if [ ! -f "${RESTART_SUCCESS_FILE}" ] ; then
+        break
+    else
+        rm -f "${RESTART_SUCCESS_FILE}"
+    fi
+done
+
+if [ -f "${RESTART_SUCCESS_FILE}" ] ; then
+    rm -f "${RESTART_SUCCESS_FILE}"
+fi

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/igniterouter.bat
----------------------------------------------------------------------
diff --git a/bin/igniterouter.bat b/bin/igniterouter.bat
new file mode 100644
index 0000000..36f1fae
--- /dev/null
+++ b/bin/igniterouter.bat
@@ -0,0 +1,33 @@
+::  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.
+
+::
+:: Grid router command line loader.
+::
+
+@echo off
+
+if "%OS%" == "Windows_NT" setlocal
+
+::
+:: Set router service environment.
+::
+set "DEFAULT_CONFIG=config\router\default-router.xml"
+set MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
+
+::
+:: Start router service.
+::
+call "%~dp0\ignite.bat" %*

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/igniterouter.sh
----------------------------------------------------------------------
diff --git a/bin/igniterouter.sh b/bin/igniterouter.sh
new file mode 100644
index 0000000..b75aec3
--- /dev/null
+++ b/bin/igniterouter.sh
@@ -0,0 +1,50 @@
+#!/bin/bash
+#  Licensed to the Apache Software Foundation (ASF) under one or more
+#  contributor license agreements.  See the NOTICE file distributed with
+#  this work for additional information regarding copyright ownership.
+#  The ASF licenses this file to You under the Apache License, Version 2.0
+#  (the "License"); you may not use this file except in compliance with
+#  the License.  You may obtain a copy of the License at
+#
+#       http://www.apache.org/licenses/LICENSE-2.0
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
+
+#
+# Router command line loader.
+#
+
+#
+# Import common functions.
+#
+if [ "${IGNITE_HOME}" = "" ];
+    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
+    else IGNITE_HOME_TMP=${IGNITE_HOME};
+fi
+
+#
+# Set SCRIPTS_HOME - base path to scripts.
+#
+SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
+
+source "${SCRIPTS_HOME}"/include/functions.sh
+
+#
+# Discover IGNITE_HOME environment variable.
+#
+setGridGainHome
+
+#
+# Set router service environment.
+#
+export DEFAULT_CONFIG=config/router/default-router.xml
+export MAIN_CLASS=org.gridgain.client.router.impl.GridRouterCommandLineStartup
+
+#
+# Start router service.
+#
+. "${SCRIPTS_HOME}"/ignite.sh $@

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignitevisorcmd.bat
----------------------------------------------------------------------
diff --git a/bin/ignitevisorcmd.bat b/bin/ignitevisorcmd.bat
new file mode 100644
index 0000000..c4c64f9
--- /dev/null
+++ b/bin/ignitevisorcmd.bat
@@ -0,0 +1,144 @@
+::  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.
+
+::
+:: Starts GridGain Visor Console.
+::
+
+@echo off
+
+if "%OS%" == "Windows_NT"  setlocal
+
+:: Check JAVA_HOME.
+if not "%JAVA_HOME%" == "" goto checkJdk
+    echo %0, ERROR: JAVA_HOME environment variable is not found.
+    echo %0, ERROR: Please create JAVA_HOME variable pointing to location of JDK 1.7 or JDK 1.8.
+    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
+goto error_finish
+
+:checkJdk
+:: Check that JDK is where it should be.
+if exist "%JAVA_HOME%\bin\java.exe" goto checkJdkVersion
+    echo %0, ERROR: The JDK is not found in %JAVA_HOME%.
+    echo %0, ERROR: Please modify your script so that JAVA_HOME would point to valid location of JDK.
+goto error_finish
+
+:checkJdkVersion
+"%JAVA_HOME%\bin\java.exe" -version 2>&1 | findstr "1\.[78]\." > nul
+if %ERRORLEVEL% equ 0 goto checkGridGainHome1
+    echo %0, ERROR: The version of JAVA installed in %JAVA_HOME% is incorrect.
+    echo %0, ERROR: Please install JDK 1.7 or 1.8.
+    echo %0, ERROR: You can also download latest JDK at: http://java.sun.com/getjava
+goto error_finish
+
+:: Check IGNITE_HOME.
+:checkGridGainHome1
+if not "%IGNITE_HOME%" == "" goto checkGridGainHome2
+    pushd "%~dp0"/..
+    set IGNITE_HOME=%CD%
+    popd
+
+:checkGridGainHome2
+:: Strip double quotes from IGNITE_HOME
+set IGNITE_HOME=%IGNITE_HOME:"=%
+
+:: remove all trailing slashes from IGNITE_HOME.
+if %IGNITE_HOME:~-1,1% == \ goto removeTrailingSlash
+if %IGNITE_HOME:~-1,1% == / goto removeTrailingSlash
+goto checkGridGainHome3
+
+:removeTrailingSlash
+set IGNITE_HOME=%IGNITE_HOME:~0,-1%
+goto checkGridGainHome2
+
+:checkGridGainHome3
+if exist "%IGNITE_HOME%\config" goto checkGridGainHome4
+    echo %0, ERROR: GridGain installation folder is not found or IGNITE_HOME environment variable is not valid.
+    echo Please create IGNITE_HOME environment variable pointing to location of
+    echo GridGain installation folder.
+    goto error_finish
+
+:checkGridGainHome4
+
+::
+:: Set SCRIPTS_HOME - base path to scripts.
+::
+set SCRIPTS_HOME=%IGNITE_HOME%\bin
+
+:: Remove trailing spaces
+for /l %%a in (1,1,31) do if /i "%SCRIPTS_HOME:~-1%" == " " set SCRIPTS_HOME=%SCRIPTS_HOME:~0,-1%
+
+if /i "%SCRIPTS_HOME%\" == "%~dp0" goto run
+    echo %0, WARN: IGNITE_HOME environment variable may be pointing to wrong folder: %IGNITE_HOME%
+
+:run
+
+::
+:: Set IGNITE_LIBS
+::
+call "%SCRIPTS_HOME%\include\setenv.bat"
+call "%SCRIPTS_HOME%\include\target-classpath.bat" &:: Will be removed in release.
+set CP=%IGNITE_HOME%\bin\include\visor-common\*;%IGNITE_HOME%\bin\include\visorcmd\*;%IGNITE_LIBS%
+
+::
+:: Parse command line parameters.
+::
+call "%SCRIPTS_HOME%\include\parseargs.bat" %*
+if %ERRORLEVEL% neq 0 (
+    echo Arguments parsing failed
+    exit /b %ERRORLEVEL%
+)
+
+::
+:: Set program name.
+::
+set PROG_NAME=gridgain.bat
+if "%OS%" == "Windows_NT" set PROG_NAME=%~nx0%
+
+::
+:: JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+::
+:: ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+::
+if "%JVM_OPTS_VISOR%" == "" set JVM_OPTS_VISOR=-Xms1g -Xmx1g -XX:MaxPermSize=128M
+
+::
+:: Uncomment to set preference to IPv4 stack.
+::
+:: set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -Djava.net.preferIPv4Stack=true
+
+::
+:: Assertions are disabled by default since version 3.5.
+:: If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+::
+set ENABLE_ASSERTIONS=1
+
+::
+:: Set '-ea' options if assertions are enabled.
+::
+if %ENABLE_ASSERTIONS% == 1 set JVM_OPTS_VISOR=%JVM_OPTS_VISOR% -ea
+
+::
+:: Starts Visor console.
+::
+"%JAVA_HOME%\bin\java.exe" %JVM_OPTS_VISOR% -DIGNITE_PROG_NAME="%PROG_NAME%" ^
+-DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED %QUIET% %JVM_XOPTS% -cp "%CP%" ^
+ org.gridgain.visor.commands.VisorConsole
+
+:error_finish
+
+if not "%NO_PAUSE%" == "1" pause
+
+goto :eof

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/ignitevisorcmd.sh
----------------------------------------------------------------------
diff --git a/bin/ignitevisorcmd.sh b/bin/ignitevisorcmd.sh
new file mode 100644
index 0000000..319d282
--- /dev/null
+++ b/bin/ignitevisorcmd.sh
@@ -0,0 +1,124 @@
+#!/bin/bash
+#  Licensed to the Apache Software Foundation (ASF) under one or more
+#  contributor license agreements.  See the NOTICE file distributed with
+#  this work for additional information regarding copyright ownership.
+#  The ASF licenses this file to You under the Apache License, Version 2.0
+#  (the "License"); you may not use this file except in compliance with
+#  the License.  You may obtain a copy of the License at
+#
+#       http://www.apache.org/licenses/LICENSE-2.0
+#
+#  Unless required by applicable law or agreed to in writing, software
+#  distributed under the License is distributed on an "AS IS" BASIS,
+#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#  See the License for the specific language governing permissions and
+#  limitations under the License.
+
+#
+# Import common functions.
+#
+if [ "${IGNITE_HOME}" = "" ];
+    then IGNITE_HOME_TMP="$(dirname "$(cd "$(dirname "$0")"; "pwd")")";IGNITE_HOME_TMP="$(dirname "${IGNITE_HOME_TMP}")" # Will be removed in release.
+    else IGNITE_HOME_TMP=${IGNITE_HOME};
+fi
+
+#
+# Set SCRIPTS_HOME - base path to scripts.
+#
+SCRIPTS_HOME="${IGNITE_HOME_TMP}/bin"
+
+source "${SCRIPTS_HOME}"/include/functions.sh
+
+#
+# Discover path to Java executable and check it's version.
+#
+checkJava
+
+#
+# Discover IGNITE_HOME environment variable.
+#
+setGridGainHome
+
+#
+# Parse command line parameters.
+#
+. "${SCRIPTS_HOME}"/include/parseargs.sh
+
+#
+# Set IGNITE_LIBS.
+#
+. "${SCRIPTS_HOME}"/include/setenv.sh
+. "${SCRIPTS_HOME}"/include/target-classpath.sh # Will be removed in release.
+CP="${IGNITE_HOME}/bin/include/visor-common/*${SEP}${IGNITE_HOME}/bin/include/visorcmd/*${SEP}${IGNITE_LIBS}"
+
+#
+# JVM options. See http://java.sun.com/javase/technologies/hotspot/vmoptions.jsp for more details.
+#
+# ADD YOUR/CHANGE ADDITIONAL OPTIONS HERE
+#
+JVM_OPTS="-Xms1g -Xmx1g -XX:MaxPermSize=128M -server ${JVM_OPTS}"
+
+# Mac OS specific support to display correct name in the dock.
+osname=`uname`
+
+if [ "${DOCK_OPTS}" == "" ]; then
+    DOCK_OPTS="-Xdock:name=Visor - GridGain Shell Console"
+fi
+
+#
+# Uncomment to set preference for IPv4 stack.
+#
+# JVM_OPTS="${JVM_OPTS} -Djava.net.preferIPv4Stack=true"
+
+#
+# Assertions are disabled by default since version 3.5.
+# If you want to enable them - set 'ENABLE_ASSERTIONS' flag to '1'.
+#
+ENABLE_ASSERTIONS="1"
+
+#
+# Set '-ea' options if assertions are enabled.
+#
+if [ "${ENABLE_ASSERTIONS}" = "1" ]; then
+    JVM_OPTS="${JVM_OPTS} -ea"
+fi
+
+#
+# Save terminal setting. Used to restore terminal on finish.
+#
+SAVED_STTY=`stty -g 2>/dev/null`
+
+#
+# Restores terminal.
+#
+function restoreSttySettings() {
+    stty ${SAVED_STTY}
+}
+
+#
+# Trap that restores terminal in case script execution is interrupted.
+#
+trap restoreSttySettings INT
+
+#
+# Start Visor console.
+#
+case $osname in
+    Darwin*)
+        "$JAVA" ${JVM_OPTS} ${QUIET} "${DOCK_OPTS}" \
+        -DIGNITE_UPDATE_NOTIFIER=false -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" \
+        -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED ${JVM_XOPTS} -cp "${CP}" \
+        org.apache.ignite.visor.commands.VisorConsole
+    ;;
+    *)
+        "$JAVA" ${JVM_OPTS} ${QUIET} -DIGNITE_UPDATE_NOTIFIER=false \
+        -DIGNITE_HOME="${IGNITE_HOME}" -DIGNITE_PROG_NAME="$0" -DIGNITE_DEPLOYMENT_MODE_OVERRIDE=ISOLATED \
+        ${JVM_XOPTS} -cp "${CP}" \
+        org.apache.ignite.visor.commands.VisorConsole
+    ;;
+esac
+
+#
+# Restore terminal.
+#
+restoreSttySettings

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/setup-hadoop.bat
----------------------------------------------------------------------
diff --git a/bin/setup-hadoop.bat b/bin/setup-hadoop.bat
index fa3ba8e..45b3520 100644
--- a/bin/setup-hadoop.bat
+++ b/bin/setup-hadoop.bat
@@ -23,4 +23,4 @@ if "%OS%" == "Windows_NT" setlocal
 
 set MAIN_CLASS=org.gridgain.grid.hadoop.GridHadoopSetup
 
-call "%~dp0\ggstart.bat" %*
+call "%~dp0\ignite.bat" %*

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/bin/setup-hadoop.sh
----------------------------------------------------------------------
diff --git a/bin/setup-hadoop.sh b/bin/setup-hadoop.sh
index 342916f..f36e4fa 100755
--- a/bin/setup-hadoop.sh
+++ b/bin/setup-hadoop.sh
@@ -57,4 +57,4 @@ export MAIN_CLASS=org.gridgain.grid.hadoop.GridHadoopSetup
 #
 # Start utility.
 #
-. "${SCRIPTS_HOME}/ggstart.sh" $@
+. "${SCRIPTS_HOME}/ignite.sh" $@

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/config/hadoop/default-config.xml
----------------------------------------------------------------------
diff --git a/config/hadoop/default-config.xml b/config/hadoop/default-config.xml
index 03b45fa..1b27ee0 100644
--- a/config/hadoop/default-config.xml
+++ b/config/hadoop/default-config.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/default-config.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/default-config.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/default-config.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/config/router/default-router.xml
----------------------------------------------------------------------
diff --git a/config/router/default-router.xml b/config/router/default-router.xml
index 6a8f831..e40a31f 100644
--- a/config/router/default-router.xml
+++ b/config/router/default-router.xml
@@ -21,7 +21,7 @@
     Default rest router configuration.
 
     This file is automatically scanned by
-    $IGNITE_HOME/bin/ggrouter.sh and $IGNITE_HOME/bin/ggrouter.bat
+    $IGNITE_HOME/bin/igniterouter.sh and $IGNITE_HOME/bin/igniterouter.bat
     for org.gridgain.client.router.GridTcpRestRouterConfiguration  bean definition.
     First found is used to start router instance.
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/docs/hadoop_readme.md
----------------------------------------------------------------------
diff --git a/docs/hadoop_readme.md b/docs/hadoop_readme.md
index 1fda55d..22d52a0 100644
--- a/docs/hadoop_readme.md
+++ b/docs/hadoop_readme.md
@@ -40,7 +40,7 @@ Installation requirements:
 After setup script successfully completed, you can execute the Ignite startup script.
 The following command will startup Ignite node with default configuration using multicast node discovery.
 
-    bin/ggstart.{sh|bat}
+    bin/ignite.{sh|bat}
 
 If Ignite was installed successfully, the output from above commands should produce no exceptions or errors.
 Note that you may see some other warnings during startup, but this is OK as they are meant to inform that certain
@@ -53,7 +53,7 @@ Here is an example of log printout when 2 nodes join topology:
 
 You can also start Ignite Management Console, called Visor, and observe started nodes. To startup Visor, you should execute the following script:
 
-    /bin/ggvisorcmd.{sh|bat} 
+    /bin/ignitevisorcmd.{sh|bat}
 
 ## 3. Configuration
 
@@ -112,6 +112,6 @@ Ignite comes with CLI (command) based DevOps Managements Console, called Visor,
 
 To start Visor in console mode you should execute the following command:
 
-    `bin/ggvisorcmd.sh`
+    `bin/ignitevisorcmd.sh`
 
 On Windows, run the same commands with `.bat` extension.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/docs/ignite_readme.md
----------------------------------------------------------------------
diff --git a/docs/ignite_readme.md b/docs/ignite_readme.md
index 297b8b3..a238109 100644
--- a/docs/ignite_readme.md
+++ b/docs/ignite_readme.md
@@ -37,11 +37,11 @@ To verify Ignite installation, you can execute the Ignite startup script.
 
 The following command will startup Ignite with default configuration using Multicast node discovery.
 
-    bin/ggstart.{sh|bat}
+    bin/ignite.{sh|bat}
 
 The following command will startup Ignite with example configuration.
 
-    bin/ggstart.{sh|bat} examples/config/example-compute.xml
+    bin/ignite.{sh|bat} examples/config/example-compute.xml
 
 If Ignite was installed successfully, the output from above commands should produce no exceptions or errors.
 Note that you may see some warnings during startup, but this is OK as they are meant to inform that certain functionality is turned on or off by default.
@@ -53,7 +53,7 @@ Here is an example of log printout when 2 nodes join topology:
 
 You can also start Ignite Management Console, called Visor, and observe started nodes. To startup Visor, you should execute the following script:
 
-    /bin/ggvisorcmd.{sh|bat} 
+    /bin/ignitevisorcmd.{sh|bat}
 
 ### 2.2 Running Ignite Examples
 
@@ -78,18 +78,18 @@ You can use maven to add Ignite artifacts to your project. Ignite has one main a
 
 
 ## 4. Starting Ignite Nodes
-Ignite nodes can be started by executing `bin/ggstart.{sh|bat}` script and passing a relative path to Ignite configuration file. If no file is passed, then grid nodes are started with default configuration using Multicast discovery protocol.
+Ignite nodes can be started by executing `bin/ignite.{sh|bat}` script and passing a relative path to Ignite configuration file. If no file is passed, then grid nodes are started with default configuration using Multicast discovery protocol.
 
 Here is an example of how to start Ignite node with non-default configuration:
 
-    `bin/ggstart.sh examples/config/example-cache.xml`
+    `bin/ignite.sh examples/config/example-cache.xml`
 
 ## 5. Management & Monitoring with Visor
 Ignite comes with CLI (command) based DevOps Managements Console, called Visor, delivering advance set of management and monitoring capabilities. 
 
 To start Visor in console mode you should execute the following command:
 
-    `bin/ggvisorcmd.sh`
+    `bin/ignitevisorcmd.sh`
 
 On Windows, run the same commands with `.bat` extension.
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/config/example-cache.xml
----------------------------------------------------------------------
diff --git a/examples/config/example-cache.xml b/examples/config/example-cache.xml
index 682a8a3..9ec2ef2 100644
--- a/examples/config/example-cache.xml
+++ b/examples/config/example-cache.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file to GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/config/example-streamer.xml
----------------------------------------------------------------------
diff --git a/examples/config/example-streamer.xml b/examples/config/example-streamer.xml
index 6674b24..c13b90d 100644
--- a/examples/config/example-streamer.xml
+++ b/examples/config/example-streamer.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid with streamers.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-streamer.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-streamer.xml
     When starting nodes this way JAR file containing the examples code
     should be placed to {IGNITE_HOME}/libs folder. You can build
     gridgain-examples.jar by running "mvn package" in {IGNITE_HOME}/examples folder.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/config/filesystem/example-ggfs.xml
----------------------------------------------------------------------
diff --git a/examples/config/filesystem/example-ggfs.xml b/examples/config/filesystem/example-ggfs.xml
index 08ac4cd..fb64227 100644
--- a/examples/config/filesystem/example-ggfs.xml
+++ b/examples/config/filesystem/example-ggfs.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/filesystem/example-ggfs.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/filesystem/example-ggfs.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/filesystem/example-ggfs.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/rest/http-rest-example.php
----------------------------------------------------------------------
diff --git a/examples/rest/http-rest-example.php b/examples/rest/http-rest-example.php
index 9c02a16..26bb394 100644
--- a/examples/rest/http-rest-example.php
+++ b/examples/rest/http-rest-example.php
@@ -22,7 +22,7 @@
  * To execute this script simply start up an instance of GridGain with cache enabled.
  * You can use any cache configuration from examples/config folder as follows:
  * ----
- * ${IGNITE_HOME}/bin/ggstart.sh examples/config/example-cache.xml
+ * ${IGNITE_HOME}/bin/ignite.sh examples/config/example-cache.xml
  * ----
  *
  * Make sure you have correctly specified $CACHE_NAME script global variable

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/rest/memcache-rest-example.php
----------------------------------------------------------------------
diff --git a/examples/rest/memcache-rest-example.php b/examples/rest/memcache-rest-example.php
index 9507e19..b8509cf 100644
--- a/examples/rest/memcache-rest-example.php
+++ b/examples/rest/memcache-rest-example.php
@@ -27,7 +27,7 @@
  * You can use default cache configuration from examples/config folder to
  * start up an instance of GridGain with cache enabled as follows:
  * ----
- * ${IGNITE_HOME}/bin/ggstart.sh examples/config/example-cache-default.xml
+ * ${IGNITE_HOME}/bin/ignite.sh examples/config/example-cache-default.xml
  * ----
  */
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
index cf8e487..a12b6ac 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeBroadcastExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates broadcasting computations within grid projection.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
index 6c70c70..880ed10 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeCallableExample.java
@@ -31,7 +31,7 @@ import java.util.*;
  * word.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
index 0365fb5..d0b2538 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeClosureExample.java
@@ -30,7 +30,7 @@ import java.util.*;
  * nodes and then computes total amount of non-whitespaces characters in the phrase.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
index cea5ee0..cfbbc94 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeContinuousMapperExample.java
@@ -40,7 +40,7 @@ import java.util.concurrent.atomic.*;
  * previous word has been received.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
index 46f6bfa..38f277f 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeExecutorServiceExample.java
@@ -27,7 +27,7 @@ import java.util.concurrent.*;
  * Simple example to demonstrate usage of grid-enabled executor service provided by GridGain.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
index 9301686..6f2ced7 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeFibonacciContinuationExample.java
@@ -37,7 +37,7 @@ import java.util.*;
  * {@link org.apache.ignite.compute.ComputeJobContext#callcc()} method calls in {@link FibonacciClosure} class.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
index 258b5cd..0131003 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeProjectionExample.java
@@ -26,7 +26,7 @@ import org.apache.ignite.lang.*;
  * Demonstrates new functional APIs.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
index 779add0..4942875 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeReducerExample.java
@@ -31,7 +31,7 @@ import java.util.concurrent.atomic.*;
  * calculated. Then total phrase length is calculated using reducer.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
index a7dfad0..e062335 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeRunnableExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple use of {@link org.apache.ignite.lang.IgniteRunnable}.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
index 07f2fa6..7802f75 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeScheduleExample.java
@@ -30,7 +30,7 @@ import java.util.concurrent.*;
  * three times with initial scheduling delay equal to five seconds.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
index eece6f2..bd3fc67 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskMapExample.java
@@ -34,7 +34,7 @@ import java.util.*;
  * calculated on reduce stage.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
index 8bb9191..d6c7d4c 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/ComputeTaskSplitExample.java
@@ -32,7 +32,7 @@ import java.util.*;
  * is calculated on reduce stage.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.


[33/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-72-1

Posted by vo...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-72-1


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

Branch: refs/heads/ignite-16
Commit: ae740876f39f7d937ffc7da07609d73ae5547730
Parents: e19655d ff01e66
Author: avinogradov <av...@gridgain.com>
Authored: Fri Jan 30 15:14:01 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Fri Jan 30 15:14:01 2015 +0300

----------------------------------------------------------------------
 .../util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java    | 2 +-
 .../org/apache/ignite/messaging/GridMessagingSelfTest.java     | 2 +-
 .../internal/processors/hadoop/GridHadoopClassLoader.java      | 4 ++--
 .../marshaller/optimized/OptimizedClassNamesGenerator.java     | 6 +++---
 .../src/main/scala/org/apache/ignite/visor/visor.scala         | 1 -
 5 files changed, 7 insertions(+), 8 deletions(-)
----------------------------------------------------------------------



[20/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into ignite-67

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/ac05bb9c/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
----------------------------------------------------------------------
diff --cc modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
index 0000000,fedf24b..013367f
mode 000000,100644..100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/util/IgniteUtils.java
@@@ -1,0 -1,9141 +1,9141 @@@
+ /*
+  * 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.util;
+ 
+ import org.apache.ignite.*;
+ import org.apache.ignite.cache.*;
+ import org.apache.ignite.cluster.*;
+ import org.apache.ignite.compute.*;
+ import org.apache.ignite.configuration.*;
+ import org.apache.ignite.events.*;
+ import org.apache.ignite.internal.*;
+ import org.apache.ignite.internal.mxbean.*;
+ import org.apache.ignite.internal.processors.cache.*;
+ import org.apache.ignite.internal.processors.cache.version.*;
+ import org.apache.ignite.lang.*;
+ import org.apache.ignite.lifecycle.*;
+ import org.apache.ignite.portables.*;
+ import org.apache.ignite.spi.*;
+ import org.apache.ignite.internal.managers.deployment.*;
+ import org.apache.ignite.internal.processors.streamer.*;
+ import org.apache.ignite.spi.discovery.*;
+ import org.apache.ignite.internal.util.io.*;
+ import org.apache.ignite.internal.util.lang.*;
+ import org.apache.ignite.internal.util.typedef.*;
+ import org.apache.ignite.internal.util.typedef.internal.*;
+ import org.apache.ignite.internal.util.worker.*;
+ import org.jdk8.backport.*;
+ import org.jetbrains.annotations.*;
+ import sun.misc.*;
+ 
+ import javax.management.*;
+ import javax.naming.*;
+ import javax.net.ssl.*;
+ import java.io.*;
+ import java.lang.annotation.Annotation;
+ import java.lang.management.*;
+ import java.lang.reflect.Array;
+ import java.lang.reflect.*;
+ import java.math.*;
+ import java.net.*;
+ import java.nio.*;
+ import java.nio.channels.*;
+ import java.nio.channels.spi.*;
+ import java.nio.charset.*;
+ import java.security.*;
+ import java.security.cert.*;
+ import java.sql.*;
+ import java.sql.Timestamp;
+ import java.text.*;
+ import java.util.*;
+ import java.util.Date;
+ import java.util.concurrent.*;
+ import java.util.concurrent.atomic.*;
+ import java.util.concurrent.locks.*;
+ import java.util.jar.*;
+ import java.util.logging.*;
+ import java.util.regex.*;
+ import java.util.zip.*;
+ 
+ import static org.apache.ignite.IgniteSystemProperties.*;
+ import static org.apache.ignite.events.IgniteEventType.*;
+ import static org.apache.ignite.internal.GridNodeAttributes.*;
+ 
+ /**
+  * Collection of utility methods used throughout the system.
+  */
+ @SuppressWarnings({"UnusedReturnValue", "UnnecessaryFullyQualifiedName"})
+ public abstract class IgniteUtils {
+     /** Unsafe. */
+     private static final Unsafe UNSAFE = GridUnsafe.unsafe();
+ 
+     /** {@code True} if {@code unsafe} should be used for array copy. */
+     private static final boolean UNSAFE_BYTE_ARR_CP = unsafeByteArrayCopyAvailable();
+ 
+     /** Offset. */
+     private static final int BYTE_ARRAY_DATA_OFFSET = UNSAFE.arrayBaseOffset(byte[].class);
+ 
+     /** Sun-specific JDK constructor factory for objects that don't have empty constructor. */
+     private static final Method CTOR_FACTORY;
+ 
+     /** Sun JDK reflection factory. */
+     private static final Object SUN_REFLECT_FACTORY;
+ 
+     /** Public {@code java.lang.Object} no-argument constructor. */
+     private static final Constructor OBJECT_CTOR;
+ 
+     /** All grid event names. */
+     private static final Map<Integer, String> GRID_EVT_NAMES = new HashMap<>();
+ 
+     /** All grid events. */
+     private static final int[] GRID_EVTS;
+ 
+     /** Empty integers array. */
+     private static final int[] EMPTY_INTS = new int[0];
+ 
+     /** Empty  longs. */
+     private static final long[] EMPTY_LONGS = new long[0];
+ 
+     /** System line separator. */
+     private static final String NL = System.getProperty("line.separator");
+ 
+     /** Default user version. */
+     public static final String DFLT_USER_VERSION = "0";
+ 
+     /** Cache for {@link GridPeerDeployAware} fields to speed up reflection. */
+     private static final ConcurrentMap<String, IgniteBiTuple<Class<?>, Collection<Field>>> p2pFields =
+         new ConcurrentHashMap8<>();
+ 
+     /** Secure socket protocol to use. */
+     private static final String HTTPS_PROTOCOL = "TLS";
+ 
+     /** Project home directory. */
+     private static volatile GridTuple<String> ggHome;
+ 
+     /** Project work directory. */
+     private static volatile String ggWork;
+ 
+     /** OS JDK string. */
+     private static String osJdkStr;
+ 
+     /** OS string. */
+     private static String osStr;
+ 
+     /** JDK string. */
+     private static String jdkStr;
+ 
+     /** Indicates whether current OS is Windows 95. */
+     private static boolean win95;
+ 
+     /** Indicates whether current OS is Windows 98. */
+     private static boolean win98;
+ 
+     /** Indicates whether current OS is Windows NT. */
+     private static boolean winNt;
+ 
+     /** Indicates whether current OS is Windows Vista. */
+     private static boolean winVista;
+ 
+     /** Indicates whether current OS is Windows 7. */
+     private static boolean win7;
+ 
+     /** Indicates whether current OS is Windows 8. */
+     private static boolean win8;
+ 
+     /** Indicates whether current OS is Windows 8.1. */
+     private static boolean win81;
+ 
+     /** Indicates whether current OS is some version of Windows. */
+     private static boolean unknownWin;
+ 
+     /** Indicates whether current OS is Windows 2000. */
+     private static boolean win2k;
+ 
+     /** Indicates whether current OS is Windows XP. */
+     private static boolean winXp;
+ 
+     /** Indicates whether current OS is Windows Server 2003. */
+     private static boolean win2003;
+ 
+     /** Indicates whether current OS is Windows Server 2008. */
+     private static boolean win2008;
+ 
+     /** Indicates whether current OS is UNIX flavor. */
+     private static boolean unix;
+ 
+     /** Indicates whether current OS is Solaris. */
+     private static boolean solaris;
+ 
+     /** Indicates whether current OS is Linux flavor. */
+     private static boolean linux;
+ 
+     /** Indicates whether current OS is NetWare. */
+     private static boolean netware;
+ 
+     /** Indicates whether current OS is Mac OS. */
+     private static boolean mac;
+ 
+     /** Indicates whether current OS architecture is Sun Sparc. */
+     private static boolean sparc;
+ 
+     /** Indicates whether current OS architecture is Intel X86. */
+     private static boolean x86;
+ 
+     /** Name of the underlying OS. */
+     private static String osName;
+ 
+     /** Version of the underlying OS. */
+     private static String osVer;
+ 
+     /** CPU architecture of the underlying OS. */
+     private static String osArch;
+ 
+     /** Name of the Java Runtime. */
+     private static String javaRtName;
+ 
+     /** Name of the Java Runtime version. */
+     private static String javaRtVer;
+ 
+     /** Name of the JDK vendor. */
+     private static String jdkVendor;
+ 
+     /** Name of the JDK. */
+     private static String jdkName;
+ 
+     /** Version of the JDK. */
+     private static String jdkVer;
+ 
+     /** Name of JVM specification. */
+     private static String jvmSpecName;
+ 
+     /** Version of JVM implementation. */
+     private static String jvmImplVer;
+ 
+     /** Vendor's name of JVM implementation. */
+     private static String jvmImplVendor;
+ 
+     /** Name of the JVM implementation. */
+     private static String jvmImplName;
+ 
+     /** JMX domain as 'xxx.gridgain'. */
+     public static final String JMX_DOMAIN = IgniteUtils.class.getName().substring(0, IgniteUtils.class.getName().
+         indexOf('.', IgniteUtils.class.getName().indexOf('.') + 1));
+ 
+     /** Network packet header. */
 -    public static final byte[] GG_HEADER = U.intToBytes(0x00004747);
++    public static final byte[] IGNITE_HEADER = U.intToBytes(0x00004747);
+ 
+     /** Default buffer size = 4K. */
+     private static final int BUF_SIZE = 4096;
+ 
+     /** Byte bit-mask. */
+     private static final int MASK = 0xf;
+ 
+     /** Long date format pattern for log messages. */
+     private static final SimpleDateFormat LONG_DATE_FMT = new SimpleDateFormat("MM/dd/yyyy HH:mm:ss");
+ 
+     /**
+      * Short date format pattern for log messages in "quiet" mode.
+      * Only time is included since we don't expect "quiet" mode to be used
+      * for longer runs.
+      */
+     private static final SimpleDateFormat SHORT_DATE_FMT = new SimpleDateFormat("HH:mm:ss");
+ 
+     /** Debug date format. */
+     private static final SimpleDateFormat DEBUG_DATE_FMT = new SimpleDateFormat("HH:mm:ss,SSS");
+ 
+     /** Cached local host address to make sure that every time the same local host is returned. */
+     private static InetAddress locHost;
+ 
+     /** */
+     static volatile long curTimeMillis = System.currentTimeMillis();
+ 
+     /** Primitive class map. */
+     private static final Map<String, Class<?>> primitiveMap = new HashMap<>(16, .5f);
+ 
+     /** Boxed class map. */
+     private static final Map<Class<?>, Class<?>> boxedClsMap = new HashMap<>(16, .5f);
+ 
+     /** Class loader used to load GridGain. */
+     private static final ClassLoader gridClassLoader = IgniteUtils.class.getClassLoader();
+ 
+     /** MAC OS invalid argument socket error message. */
+     public static final String MAC_INVALID_ARG_MSG = "On MAC OS you may have too many file descriptors open " +
+         "(simple restart usually solves the issue)";
+ 
+     /** Default help pages. */
+     public static final List<String> DFLT_HELP_LINKS = Arrays.asList(
+         "Troubleshooting:      http://bit.ly/GridGain-Troubleshooting",
+         "Documentation Center: http://bit.ly/GridGain-Documentation");
+ 
+     /** Portable classes. */
+     private static final Collection<Class<?>> PORTABLE_CLS = new HashSet<>();
+ 
+     /** GridGain Logging Directory. */
 -    public static final String GRIDGAIN_LOG_DIR = System.getenv(GG_LOG_DIR);
++    public static final String IGNITE_LOG_DIR = System.getenv(IgniteSystemProperties.IGNITE_LOG_DIR);
+ 
+     /** GridGain Work Directory. */
 -    public static final String GRIDGAIN_WORK_DIR = System.getenv(GG_WORK_DIR);
++    public static final String IGNITE_WORK_DIR = System.getenv(IgniteSystemProperties.IGNITE_WORK_DIR);
+ 
+     /** Clock timer. */
+     private static Thread timer;
+ 
+     /** Grid counter. */
+     private static int gridCnt;
+ 
+     /** Mutex. */
+     private static final Object mux = new Object();
+ 
+     /**
+      * Initializes enterprise check.
+      */
+     static {
+         String osName = System.getProperty("os.name");
+ 
+         String osLow = osName.toLowerCase();
+ 
+         // OS type detection.
+         if (osLow.contains("win")) {
+             if (osLow.contains("95"))
+                 win95 = true;
+             else if (osLow.contains("98"))
+                 win98 = true;
+             else if (osLow.contains("nt"))
+                 winNt = true;
+             else if (osLow.contains("2000"))
+                 win2k = true;
+             else if (osLow.contains("vista"))
+                 winVista = true;
+             else if (osLow.contains("xp"))
+                 winXp = true;
+             else if (osLow.contains("2003"))
+                 win2003 = true;
+             else if (osLow.contains("2008"))
+                 win2008 = true;
+             else if (osLow.contains("7"))
+                 win7 = true;
+             else if (osLow.contains("8.1"))
+                 win81 = true;
+             else if (osLow.contains("8"))
+                 win8 = true;
+             else
+                 unknownWin = true;
+         }
+         else if (osLow.contains("netware"))
+             netware = true;
+         else if (osLow.contains("mac os"))
+             mac = true;
+         else {
+             // UNIXs flavors tokens.
+             for (CharSequence os : new String[]{"ix", "inux", "olaris", "un", "ux", "sco", "bsd", "att"})
+                 if (osLow.contains(os)) {
+                     unix = true;
+ 
+                     break;
+                 }
+ 
+             // UNIX name detection.
+             if (osLow.contains("olaris"))
+                 solaris = true;
+             else if (osLow.contains("inux"))
+                 linux = true;
+         }
+ 
+         String osArch = System.getProperty("os.arch");
+ 
+         String archStr = osArch.toLowerCase();
+ 
+         // OS architecture detection.
+         if (archStr.contains("x86"))
+             x86 = true;
+         else if (archStr.contains("sparc"))
+             sparc = true;
+ 
+         String javaRtName = System.getProperty("java.runtime.name");
+         String javaRtVer = System.getProperty("java.runtime.version");
+         String jdkVendor = System.getProperty("java.specification.vendor");
+         String jdkName = System.getProperty("java.specification.name");
+         String jdkVer = System.getProperty("java.specification.version");
+         String osVer = System.getProperty("os.version");
+         String jvmSpecName = System.getProperty("java.vm.specification.name");
+         String jvmImplVer = System.getProperty("java.vm.version");
+         String jvmImplVendor = System.getProperty("java.vm.vendor");
+         String jvmImplName = System.getProperty("java.vm.name");
+ 
+         String jdkStr = javaRtName + ' ' + javaRtVer + ' ' + jvmImplVendor + ' ' + jvmImplName + ' ' +
+             jvmImplVer;
+ 
+         osStr = osName + ' ' + osVer + ' ' + osArch;
+         osJdkStr = osLow + ", " + jdkStr;
+ 
+         // Copy auto variables to static ones.
+         IgniteUtils.osName = osName;
+         IgniteUtils.jdkName = jdkName;
+         IgniteUtils.jdkVendor = jdkVendor;
+         IgniteUtils.jdkVer = jdkVer;
+         IgniteUtils.jdkStr = jdkStr;
+         IgniteUtils.osVer = osVer;
+         IgniteUtils.osArch = osArch;
+         IgniteUtils.jvmSpecName = jvmSpecName;
+         IgniteUtils.jvmImplVer = jvmImplVer;
+         IgniteUtils.jvmImplVendor = jvmImplVendor;
+         IgniteUtils.jvmImplName = jvmImplName;
+         IgniteUtils.javaRtName = javaRtName;
+         IgniteUtils.javaRtVer = javaRtVer;
+ 
+         primitiveMap.put("byte", byte.class);
+         primitiveMap.put("short", short.class);
+         primitiveMap.put("int", int.class);
+         primitiveMap.put("long", long.class);
+         primitiveMap.put("float", float.class);
+         primitiveMap.put("double", double.class);
+         primitiveMap.put("char", char.class);
+         primitiveMap.put("boolean", boolean.class);
+ 
+         boxedClsMap.put(byte.class, Byte.class);
+         boxedClsMap.put(short.class, Short.class);
+         boxedClsMap.put(int.class, Integer.class);
+         boxedClsMap.put(long.class, Long.class);
+         boxedClsMap.put(float.class, Float.class);
+         boxedClsMap.put(double.class, Double.class);
+         boxedClsMap.put(char.class, Character.class);
+         boxedClsMap.put(boolean.class, Boolean.class);
+ 
+         try {
+             OBJECT_CTOR = Object.class.getConstructor();
+         }
+         catch (NoSuchMethodException e) {
+             throw withCause(new AssertionError("Object class does not have empty constructor (is JDK corrupted?)."), e);
+         }
+ 
+         // Constructor factory.
+         Method ctorFac = null;
+         Object refFac = null;
+ 
+         try {
+             Class<?> refFactoryCls = Class.forName("sun.reflect.ReflectionFactory");
+ 
+             refFac = refFactoryCls.getMethod("getReflectionFactory").invoke(null);
+ 
+             ctorFac = refFac.getClass().getMethod("newConstructorForSerialization", Class.class,
+                 Constructor.class);
+         }
+         catch (NoSuchMethodException | ClassNotFoundException | IllegalAccessException | InvocationTargetException ignored) {
+             // No-op.
+         }
+ 
+         CTOR_FACTORY = ctorFac;
+         SUN_REFLECT_FACTORY = refFac;
+ 
+         // Disable hostname SSL verification for development and testing with self-signed certificates.
 -        if (Boolean.parseBoolean(System.getProperty(GG_DISABLE_HOSTNAME_VERIFIER))) {
++        if (Boolean.parseBoolean(System.getProperty(IGNITE_DISABLE_HOSTNAME_VERIFIER))) {
+             HttpsURLConnection.setDefaultHostnameVerifier(new HostnameVerifier() {
+                 @Override public boolean verify(String hostname, SSLSession sslSes) {
+                     return true;
+                 }
+             });
+         }
+ 
+         // Event names initialization.
+         for (Field field : IgniteEventType.class.getFields()) {
+             if (field.getType().equals(int.class)) {
+                 try {
+                     assert field.getName().startsWith("EVT_") : "Invalid event name (should start with 'EVT_': " +
+                         field.getName();
+ 
+                     int type = field.getInt(null);
+ 
+                     String prev = GRID_EVT_NAMES.put(type, field.getName().substring(4));
+ 
+                     // Check for duplicate event types.
+                     assert prev == null : "Duplicate event [type=" + type + ", name1=" + prev +
+                         ", name2=" + field.getName() + ']';
+                 }
+                 catch (IllegalAccessException e) {
+                     throw new IgniteException(e);
+                 }
+             }
+         }
+ 
+         // Event array initialization.
+         GRID_EVTS = toIntArray(GRID_EVT_NAMES.keySet());
+ 
+         // Sort for fast event lookup.
+         Arrays.sort(GRID_EVTS);
+ 
+         // We need to re-initialize EVTS_ALL and EVTS_ALL_MINUS_METRIC_UPDATE
+         // because they may have been initialized to null before GRID_EVTS were initialized.
+         if (EVTS_ALL == null || EVTS_ALL_MINUS_METRIC_UPDATE == null) {
+             try {
+                 Field f1 = IgniteEventType.class.getDeclaredField("EVTS_ALL");
+                 Field f2 = IgniteEventType.class.getDeclaredField("EVTS_ALL_MINUS_METRIC_UPDATE");
+ 
+                 assert f1 != null;
+                 assert f2 != null;
+ 
+                 // We use unsafe operations to update static fields on interface because
+                 // they are treated as static final and cannot be updated via standard reflection.
+                 UNSAFE.putObjectVolatile(UNSAFE.staticFieldBase(f1), UNSAFE.staticFieldOffset(f1), gridEvents());
+                 UNSAFE.putObjectVolatile(UNSAFE.staticFieldBase(f2), UNSAFE.staticFieldOffset(f2),
+                     gridEvents(EVT_NODE_METRICS_UPDATED));
+ 
+                 assert EVTS_ALL != null;
+                 assert EVTS_ALL.length == GRID_EVTS.length;
+ 
+                 assert EVTS_ALL_MINUS_METRIC_UPDATE != null;
+                 assert EVTS_ALL_MINUS_METRIC_UPDATE.length == GRID_EVTS.length - 1;
+ 
+                 // Validate correctness.
+                 for (int type : GRID_EVTS) {
+                     assert containsIntArray(EVTS_ALL, type);
+ 
+                     if (type != EVT_NODE_METRICS_UPDATED)
+                         assert containsIntArray(EVTS_ALL_MINUS_METRIC_UPDATE, type);
+                 }
+ 
+                 assert !containsIntArray(EVTS_ALL_MINUS_METRIC_UPDATE, EVT_NODE_METRICS_UPDATED);
+             }
+             catch (NoSuchFieldException e) {
+                 throw new IgniteException(e);
+             }
+         }
+ 
+         PORTABLE_CLS.add(Byte.class);
+         PORTABLE_CLS.add(Short.class);
+         PORTABLE_CLS.add(Integer.class);
+         PORTABLE_CLS.add(Long.class);
+         PORTABLE_CLS.add(Float.class);
+         PORTABLE_CLS.add(Double.class);
+         PORTABLE_CLS.add(Character.class);
+         PORTABLE_CLS.add(Boolean.class);
+         PORTABLE_CLS.add(String.class);
+         PORTABLE_CLS.add(UUID.class);
+         PORTABLE_CLS.add(Date.class);
+         PORTABLE_CLS.add(Timestamp.class);
+         PORTABLE_CLS.add(byte[].class);
+         PORTABLE_CLS.add(short[].class);
+         PORTABLE_CLS.add(int[].class);
+         PORTABLE_CLS.add(long[].class);
+         PORTABLE_CLS.add(float[].class);
+         PORTABLE_CLS.add(double[].class);
+         PORTABLE_CLS.add(char[].class);
+         PORTABLE_CLS.add(boolean[].class);
+         PORTABLE_CLS.add(String[].class);
+         PORTABLE_CLS.add(UUID[].class);
+         PORTABLE_CLS.add(Date[].class);
+         PORTABLE_CLS.add(Timestamp[].class);
+     }
+ 
+     /**
+      * @return System time approximated by 10 ms.
+      */
+     public static long currentTimeMillis() {
+         return curTimeMillis;
+     }
+ 
+     /**
+      * @return Value of {@link System#nanoTime()} in microseconds.
+      */
+     public static long microTime() {
+         return System.nanoTime() / 1000;
+     }
+ 
+     /**
+      * Gets nearest power of 2 larger or equal than v.
+      *
+      * @param v Value.
+      * @return Nearest power of 2.
+      */
+     public static int ceilPow2(int v) {
+         v--;
+ 
+         v |= v >> 1;
+         v |= v >> 2;
+         v |= v >> 4;
+         v |= v >> 8;
+         v |= v >> 16;
+ 
+         return ++v;
+     }
+ 
+     /**
+      * @param i Value.
+      * @return {@code true} If the given value is power of 2 (0 is not power of 2).
+      */
+     public static boolean isPow2(int i) {
+         return i > 0 && (i & (i - 1)) == 0;
+     }
+ 
+     /**
+      * Return SUN specific constructor factory.
+      *
+      * @return SUN specific constructor factory.
+      */
+     @Nullable public static Method ctorFactory() {
+         return CTOR_FACTORY;
+     }
+ 
+     /**
+      * @return Empty constructor for object class.
+      */
+     public static Constructor objectConstructor() {
+         return OBJECT_CTOR;
+     }
+ 
+     /**
+      * SUN JDK specific reflection factory for objects without public constructor.
+      *
+      * @return Reflection factory for objects without public constructor.
+      */
+     @Nullable public static Object sunReflectionFactory() {
+         return SUN_REFLECT_FACTORY;
+     }
+ 
+     /**
+      * Gets name for given grid event type.
+      *
+      * @param type Event type.
+      * @return Event name.
+      */
+     public static String gridEventName(int type) {
+         String name = GRID_EVT_NAMES.get(type);
+ 
+         return name != null ? name : Integer.toString(type);
+     }
+ 
+     /**
+      * Gets all event types.
+      *
+      * @param excl Optional exclude events.
+      * @return All events minus excluded ones.
+      */
+     public static int[] gridEvents(final int... excl) {
+         if (F.isEmpty(excl))
+             return GRID_EVTS;
+ 
+         List<Integer> evts = toIntList(GRID_EVTS, new P1<Integer>() {
+             @Override
+             public boolean apply(Integer i) {
+                 return !containsIntArray(excl, i);
+             }
+         });
+ 
+         return toIntArray(evts);
+     }
+ 
+     /**
+      * @param discoSpi Discovery SPI.
+      * @return {@code True} if ordering is supported.
+      */
+     public static boolean discoOrdered(DiscoverySpi discoSpi) {
+         DiscoverySpiOrderSupport ann = U.getAnnotation(discoSpi.getClass(), DiscoverySpiOrderSupport.class);
+ 
+         return ann != null && ann.value();
+     }
+ 
+     /**
+      * @return Checks if disco ordering should be enforced.
+      */
+     public static boolean relaxDiscoveryOrdered() {
 -        return "true".equalsIgnoreCase(System.getProperty(GG_NO_DISCO_ORDER));
++        return "true".equalsIgnoreCase(System.getProperty(IGNITE_NO_DISCO_ORDER));
+     }
+ 
+     /**
+      * This method should be used for adding quick debug statements in code
+      * while debugging. Calls to this method should never be committed to master.
+      *
+      * @param msg Message to debug.
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @Deprecated
+     public static void debug(Object msg) {
+         X.println(debugPrefix() + msg);
+     }
+ 
+     /**
+      * This method should be used for adding quick debug statements in code
+      * while debugging. Calls to this method should never be committed to master.
+      *
+      * @param msg Message to debug.
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @Deprecated
+     public static void debugx(String msg) {
+         X.printerrln(debugPrefix() + msg);
+     }
+ 
+     /**
+      * This method should be used for adding quick debug statements in code
+      * while debugging. Calls to this method should never be committed to master.
+      *
+      * @param log Logger.
+      * @param msg Message to debug.
+      *
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @Deprecated
+     public static void debug(IgniteLogger log, String msg) {
+         log.info(msg);
+     }
+ 
+     /**
+      * Prints stack trace of the current thread to {@code System.out}.
+      *
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @SuppressWarnings("deprecation")
+     @Deprecated
+     public static void dumpStack() {
+         dumpStack("Dumping stack.");
+     }
+ 
+     /**
+      * Prints stack trace of the current thread to {@code System.out}.
+      *
+      * @param msg Message to print with the stack.
+      *
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @Deprecated
+     public static void dumpStack(String msg) {
+         new Exception(debugPrefix() + msg).printStackTrace(System.out);
+     }
+ 
+     /**
+      * @param log Logger.
+      * @param msg Message.
+      */
+     public static void dumpStack(@Nullable IgniteLogger log, String msg) {
+         U.error(log, "Dumping stack.", new Exception(msg));
+     }
+ 
+     /**
+      * Prints stack trace of the current thread to provided output stream.
+      *
+      * @param msg Message to print with the stack.
+      * @param out Output to dump stack to.
+      *
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @Deprecated
+     public static void dumpStack(String msg, PrintStream out) {
+         new Exception(msg).printStackTrace(out);
+     }
+ 
+     /**
+      * Prints stack trace of the current thread to provided logger.
+      *
+      * @param log Logger.
+      * @param msg Message to print with the stack.
+      *
+      * @deprecated Calls to this method should never be committed to master.
+      */
+     @Deprecated
+     public static void debugStack(IgniteLogger log, String msg) {
+         log.error(msg, new Exception(debugPrefix() + msg));
+     }
+ 
+     /**
+      * @return Common prefix for debug messages.
+      */
+     private static String debugPrefix() {
+         return '<' + DEBUG_DATE_FMT.format(new Date(System.currentTimeMillis())) + "><DEBUG><" +
+             Thread.currentThread().getName() + '>' + ' ';
+     }
+ 
+     /**
+      * Prints heap usage.
+      */
+     public static void debugHeapUsage() {
+         System.gc();
+ 
+         Runtime runtime = Runtime.getRuntime();
+ 
+         X.println('<' + DEBUG_DATE_FMT.format(new Date(System.currentTimeMillis())) + "><DEBUG><" +
+             Thread.currentThread().getName() + "> Heap stats [free=" + runtime.freeMemory() / (1024 * 1024) +
+             "M, total=" + runtime.totalMemory() / (1024 * 1024) + "M]");
+     }
+ 
+     /**
+      * Gets heap size in GB rounded to specified precision.
+      *
+      * @param node Node.
+      * @param precision Precision.
+      * @return Heap size in GB.
+      */
+     public static double heapSize(ClusterNode node, int precision) {
+         return heapSize(Collections.singleton(node), precision);
+     }
+ 
+     /**
+      * Gets total heap size in GB rounded to specified precision.
+      *
+      * @param nodes Nodes.
+      * @param precision Precision.
+      * @return Total heap size in GB.
+      */
+     public static double heapSize(Iterable<ClusterNode> nodes, int precision) {
+         // In bytes.
+         double heap = 0.0;
+ 
+         for (ClusterNode n : nodesPerJvm(nodes)) {
+             ClusterMetrics m = n.metrics();
+ 
+             heap += Math.max(m.getHeapMemoryInitialized(), m.getHeapMemoryMaximum());
+         }
+ 
+         return roundedHeapSize(heap, precision);
+     }
+ 
+     /**
+      * Returns one representative node for each JVM.
+      *
+      * @param nodes Nodes.
+      * @return Collection which contains only one representative node for each JVM.
+      */
+     private static Iterable<ClusterNode> nodesPerJvm(Iterable<ClusterNode> nodes) {
+         Map<String, ClusterNode> grpMap = new HashMap<>();
+ 
+         // Group by mac addresses and pid.
+         for (ClusterNode node : nodes) {
+             String grpId = node.attribute(ATTR_MACS) + "|" + node.attribute(ATTR_JVM_PID);
+ 
+             if (!grpMap.containsKey(grpId))
+                 grpMap.put(grpId, node);
+         }
+ 
+         return grpMap.values();
+     }
+ 
+     /**
+      * Returns current JVM maxMemory in the same format as {@link #heapSize(org.apache.ignite.cluster.ClusterNode, int)}.
+      *
+      * @param precision Precision.
+      * @return Maximum memory size in GB.
+      */
+     public static double heapSize(int precision) {
+         return roundedHeapSize(Runtime.getRuntime().maxMemory(), precision);
+     }
+ 
+     /**
+      * Rounded heap size in gigabytes.
+      *
+      * @param heap Heap.
+      * @param precision Precision.
+      * @return Rounded heap size.
+      */
+     private static double roundedHeapSize(double heap, int precision) {
+         double rounded = new BigDecimal(heap / (1024 * 1024 * 1024d)).round(new MathContext(precision)).doubleValue();
+ 
+         return rounded < 0.1 ? 0.1 : rounded;
+     }
+ 
+     /**
+      * Performs thread dump and prints all available info to the given log.
+      *
+      * @param log Logger.
+      */
+     public static void dumpThreads(@Nullable IgniteLogger log) {
+         ThreadMXBean mxBean = ManagementFactory.getThreadMXBean();
+ 
+         ThreadInfo[] threadInfos =
+             mxBean.dumpAllThreads(mxBean.isObjectMonitorUsageSupported(), mxBean.isSynchronizerUsageSupported());
+ 
+         GridStringBuilder sb = new GridStringBuilder("Thread dump at ")
+             .a(new SimpleDateFormat("yyyy/MM/dd HH:mm:ss z").format(new Date(U.currentTimeMillis()))).a(NL);
+ 
+         for (ThreadInfo info : threadInfos) {
+             printThreadInfo(info, sb);
+ 
+             sb.a(NL);
+ 
+             if (info.getLockedSynchronizers() != null && info.getLockedSynchronizers().length > 0) {
+                 printSynchronizersInfo(info.getLockedSynchronizers(), sb);
+ 
+                 sb.a(NL);
+             }
+         }
+ 
+         sb.a(NL);
+ 
+         warn(log, sb.toString());
+     }
+ 
+     /**
+      * Prints single thread info to a buffer.
+      *
+      * @param threadInfo Thread info.
+      * @param sb Buffer.
+      */
+     private static void printThreadInfo(ThreadInfo threadInfo, GridStringBuilder sb) {
+         sb.a("Thread [name=\"").a(threadInfo.getThreadName())
+             .a("\", id=").a(threadInfo.getThreadId())
+             .a(", state=").a(threadInfo.getThreadState())
+             .a(", blockCnt=").a(threadInfo.getBlockedCount())
+             .a(", waitCnt=").a(threadInfo.getWaitedCount()).a("]").a(NL);
+ 
+         LockInfo lockInfo = threadInfo.getLockInfo();
+ 
+         if (lockInfo != null) {
+             sb.a("    Lock [object=").a(lockInfo)
+                 .a(", ownerName=").a(threadInfo.getLockOwnerName())
+                 .a(", ownerId=").a(threadInfo.getLockOwnerId()).a("]").a(NL);
+         }
+ 
+         MonitorInfo[] monitors = threadInfo.getLockedMonitors();
+         StackTraceElement[] elements = threadInfo.getStackTrace();
+ 
+         for (int i = 0; i < elements.length; i++) {
+             StackTraceElement e = elements[i];
+ 
+             sb.a("        at ").a(e.toString());
+ 
+             for (MonitorInfo monitor : monitors) {
+                 if (monitor.getLockedStackDepth() == i)
+                     sb.a(NL).a("        - locked ").a(monitor);
+             }
+ 
+             sb.a(NL);
+         }
+     }
+ 
+     /**
+      * Prints Synchronizers info to a buffer.
+      *
+      * @param syncs Synchronizers info.
+      * @param sb Buffer.
+      */
+     private static void printSynchronizersInfo(LockInfo[] syncs, GridStringBuilder sb) {
+         sb.a("    Locked synchronizers:");
+ 
+         for (LockInfo info : syncs)
+             sb.a(NL).a("        ").a(info);
+     }
+ 
+     /**
+      * Gets empty constructor for class even if the class does not have empty constructor
+      * declared. This method is guaranteed to work with SUN JDK and other JDKs still need
+      * to be tested.
+      *
+      * @param cls Class to get empty constructor for.
+      * @return Empty constructor if one could be found or {@code null} otherwise.
+      * @throws IgniteCheckedException If failed.
+      */
+     @Nullable public static Constructor<?> forceEmptyConstructor(Class<?> cls) throws IgniteCheckedException {
+         Constructor<?> ctor = null;
+ 
+         try {
+             return cls.getDeclaredConstructor();
+         }
+         catch (Exception ignore) {
+             Method ctorFac = U.ctorFactory();
+             Object sunRefFac = U.sunReflectionFactory();
+ 
+             if (ctorFac != null && sunRefFac != null)
+                 try {
+                     ctor = (Constructor)ctorFac.invoke(sunRefFac, cls, U.objectConstructor());
+                 }
+                 catch (IllegalAccessException | InvocationTargetException e) {
+                     throw new IgniteCheckedException("Failed to get object constructor for class: " + cls, e);
+                 }
+         }
+ 
+         return ctor;
+     }
+ 
+     /**
+      * Creates new instance of a class only if it has an empty constructor (can be non-public).
+      *
+      * @param cls Class name.
+      * @return Instance.
+      * @throws IgniteCheckedException If failed.
+      */
+     @Nullable public static <T> T newInstance(String cls) throws IgniteCheckedException {
+         Class<?> cls0;
+ 
+         try {
+             cls0 = Class.forName(cls);
+         }
+         catch (Exception e) {
+             throw new IgniteCheckedException(e);
+         }
+ 
+         return (T)newInstance(cls0);
+     }
+ 
+     /**
+      * Creates new instance of a class only if it has an empty constructor (can be non-public).
+      *
+      * @param cls Class to instantiate.
+      * @return New instance of the class or {@code null} if empty constructor could not be assigned.
+      * @throws IgniteCheckedException If failed.
+      */
+     @Nullable public static <T> T newInstance(Class<T> cls) throws IgniteCheckedException {
+         boolean set = false;
+ 
+         Constructor<T> ctor = null;
+ 
+         try {
+             ctor = cls.getDeclaredConstructor();
+ 
+             if (ctor == null)
+                 return null;
+ 
+             if (!ctor.isAccessible()) {
+                 ctor.setAccessible(true);
+ 
+                 set = true;
+             }
+ 
+             return ctor.newInstance();
+         }
+         catch (NoSuchMethodException e) {
+             throw new IgniteCheckedException("Failed to find empty constructor for class: " + cls, e);
+         }
+         catch (InstantiationException | InvocationTargetException | IllegalAccessException e) {
+             throw new IgniteCheckedException("Failed to create new instance for class: " + cls, e);
+         } finally {
+             if (ctor != null && set)
+                 ctor.setAccessible(false);
+         }
+     }
+ 
+     /**
+      * Creates new instance of a class even if it does not have public constructor.
+      *
+      * @param cls Class to instantiate.
+      * @return New instance of the class or {@code null} if empty constructor could not be assigned.
+      * @throws IgniteCheckedException If failed.
+      */
+     @SuppressWarnings({"unchecked"})
+     @Nullable public static <T> T forceNewInstance(Class<?> cls) throws IgniteCheckedException {
+         Constructor ctor = forceEmptyConstructor(cls);
+ 
+         if (ctor == null)
+             return null;
+ 
+         boolean set = false;
+ 
+         try {
+ 
+             if (!ctor.isAccessible()) {
+                 ctor.setAccessible(true);
+ 
+                 set = true;
+             }
+ 
+             return (T)ctor.newInstance();
+         }
+         catch (InstantiationException | InvocationTargetException | IllegalAccessException e) {
+             throw new IgniteCheckedException("Failed to create new instance for class: " + cls, e);
+         } finally {
+             if (set)
+                 ctor.setAccessible(false);
+         }
+     }
+ 
+     /**
+      * Pretty-formatting for minutes.
+      *
+      * @param mins Minutes to format.
+      * @return Formatted presentation of minutes.
+      */
+     public static String formatMins(long mins) {
+         assert mins >= 0;
+ 
+         if (mins == 0)
+             return "< 1 min";
+ 
+         SB sb = new SB();
+ 
+         long dd = mins / 1440; // 1440 mins = 60 mins * 24 hours
+ 
+         if (dd > 0)
+             sb.a(dd).a(dd == 1 ? " day " : " days ");
+ 
+         mins %= 1440;
+ 
+         long hh = mins / 60;
+ 
+         if (hh > 0)
+             sb.a(hh).a(hh == 1 ? " hour " : " hours ");
+ 
+         mins %= 60;
+ 
+         if (mins > 0)
+             sb.a(mins).a(mins == 1 ? " min " : " mins ");
+ 
+         return sb.toString().trim();
+     }
+ 
+     /**
+      * Gets 8-character substring of UUID (for terse logging).
+      *
+      * @param id Input ID.
+      * @return 8-character ID substring.
+      */
+     public static String id8(UUID id) {
+         return id.toString().substring(0, 8);
+     }
+ 
+     /**
+      * Gets 8-character substring of {@link org.apache.ignite.lang.IgniteUuid} (for terse logging).
+      * The ID8 will be constructed as follows:
+      * <ul>
+      * <li>Take first 4 digits for global ID, i.e. {@code GridUuid.globalId()}.</li>
+      * <li>Take last 4 digits for local ID, i.e. {@code GridUuid.localId()}.</li>
+      * </ul>
+      *
+      * @param id Input ID.
+      * @return 8-character representation of {@code GridUuid}.
+      */
+     public static String id8(IgniteUuid id) {
+         String s = id.toString();
+ 
+         return s.substring(0, 4) + s.substring(s.length() - 4);
+     }
+ 
+     /**
+      *
+      * @param len Number of characters to fill in.
+      * @param ch Character to fill with.
+      * @return String.
+      */
+     public static String filler(int len, char ch) {
+         char[] a = new char[len];
+ 
+         Arrays.fill(a, ch);
+ 
+         return new String(a);
+     }
+ 
+     /**
+      * Writes array to output stream.
+      *
+      * @param out Output stream.
+      * @param arr Array to write.
+      * @param <T> Array type.
+      * @throws IOException If failed.
+      */
+     public static <T> void writeArray(ObjectOutput out, T[] arr) throws IOException {
+         int len = arr == null ? 0 : arr.length;
+ 
+         out.writeInt(len);
+ 
+         if (arr != null && arr.length > 0)
+             for (T t : arr)
+                 out.writeObject(t);
+     }
+ 
+     /**
+      * Reads array from input stream.
+      *
+      * @param in Input stream.
+      * @return Deserialized array.
+      * @throws IOException If failed.
+      * @throws ClassNotFoundException If class not found.
+      */
+     @Nullable public static Object[] readArray(ObjectInput in) throws IOException, ClassNotFoundException {
+         int len = in.readInt();
+ 
+         Object[] arr = null;
+ 
+         if (len > 0) {
+             arr = new Object[len];
+ 
+             for (int i = 0; i < len; i++)
+                 arr[i] = in.readObject();
+         }
+ 
+         return arr;
+     }
+ 
+     /**
+      * Reads array from input stream.
+      *
+      * @param in Input stream.
+      * @return Deserialized array.
+      * @throws IOException If failed.
+      * @throws ClassNotFoundException If class not found.
+      */
+     @Nullable public static Class<?>[] readClassArray(ObjectInput in) throws IOException, ClassNotFoundException {
+         int len = in.readInt();
+ 
+         Class<?>[] arr = null;
+ 
+         if (len > 0) {
+             arr = new Class<?>[len];
+ 
+             for (int i = 0; i < len; i++)
+                 arr[i] = (Class<?>)in.readObject();
+         }
+ 
+         return arr;
+     }
+ 
+     /**
+      * Reads array from input stream.
+      *
+      * @param in Input stream.
+      * @return Deserialized array.
+      * @throws IOException If failed.
+      * @throws ClassNotFoundException If class not found.
+      */
+     @SuppressWarnings("unchecked")
+     @Nullable public static <K, V> IgnitePredicate<CacheEntry<K, V>>[] readEntryFilterArray(ObjectInput in)
+         throws IOException, ClassNotFoundException {
+         int len = in.readInt();
+ 
+         IgnitePredicate<CacheEntry<K, V>>[] arr = null;
+ 
+         if (len > 0) {
+             arr = new IgnitePredicate[len];
+ 
+             for (int i = 0; i < len; i++)
+                 arr[i] = (IgnitePredicate<CacheEntry<K, V>>)in.readObject();
+         }
+ 
+         return arr;
+     }
+ 
+     /**
+      *
+      * @param out Output.
+      * @param col Set to write.
+      * @throws IOException If write failed.
+      */
+     public static void writeCollection(ObjectOutput out, Collection<?> col) throws IOException {
+         if (col != null) {
+             out.writeInt(col.size());
+ 
+             for (Object o : col)
+                 out.writeObject(o);
+         }
+         else
+             out.writeInt(-1);
+     }
+ 
+     /**
+      * Writes collection of byte arrays to data output.
+      *
+      * @param out Output to write to.
+      * @param bytes Collection with byte arrays.
+      * @throws IOException If write failed.
+      */
+     public static void writeBytesCollection(DataOutput out, Collection<byte[]> bytes) throws IOException {
+         if (bytes != null) {
+             out.writeInt(bytes.size());
+ 
+             for (byte[] b : bytes)
+                 writeByteArray(out, b);
+         }
+         else
+             out.writeInt(-1);
+     }
+ 
+     /**
+      * Reads collection of byte arrays from data input.
+      *
+      * @param in Data input to read from.
+      * @return List of byte arrays.
+      * @throws IOException If read failed.
+      */
+     public static List<byte[]> readBytesList(DataInput in) throws IOException {
+         int size = in.readInt();
+ 
+         if (size < 0)
+             return null;
+ 
+         List<byte[]> res = new ArrayList<>(size);
+ 
+         for (int i = 0; i < size; i++)
+             res.add(readByteArray(in));
+ 
+         return res;
+     }
+ 
+     /**
+      *
+      * @param out Output.
+      * @param col Set to write.
+      * @throws IOException If write failed.
+      */
+     public static void writeIntCollection(DataOutput out, Collection<Integer> col) throws IOException {
+         if (col != null) {
+             out.writeInt(col.size());
+ 
+             for (Integer i : col)
+                 out.writeInt(i);
+         }
+         else
+             out.writeInt(-1);
+     }
+ 
+     /**
+      * @param in Input.
+      * @return Deserialized set.
+      * @throws IOException If deserialization failed.
+      * @throws ClassNotFoundException If deserialized class could not be found.
+      */
+     @Nullable public static <E> Collection<E> readCollection(ObjectInput in)
+         throws IOException, ClassNotFoundException {
+         return readList(in);
+     }
+ 
+     /**
+      * @param in Input.
+      * @return Deserialized set.
+      * @throws IOException If deserialization failed.
+      */
+     @Nullable public static Collection<Integer> readIntCollection(DataInput in) throws IOException {
+         int size = in.readInt();
+ 
+         // Check null flag.
+         if (size == -1)
+             return null;
+ 
+         Collection<Integer> col = new ArrayList<>(size);
+ 
+         for (int i = 0; i < size; i++)
+             col.add(in.readInt());
+ 
+         return col;
+     }
+ 
+     /**
+      *
+      * @param m Map to copy.
+      * @param <K> Key type.
+      * @param <V> Value type
+      * @return Copied map.
+      */
+     public static <K, V> Map<K, V> copyMap(Map<K, V> m) {
+         return new HashMap<>(m);
+     }
+ 
+     /**
+      *
+      * @param m Map to seal.
+      * @param <K> Key type.
+      * @param <V> Value type
+      * @return Sealed map.
+      */
+     public static <K, V> Map<K, V> sealMap(Map<K, V> m) {
+         assert m != null;
+ 
+         return Collections.unmodifiableMap(new HashMap<>(m));
+     }
+ 
+     /**
+      * Seal collection.
+      *
+      * @param c Collection to seal.
+      * @param <E> Entry type
+      * @return Sealed collection.
+      */
+     public static <E> List<E> sealList(Collection<E> c) {
+         return Collections.unmodifiableList(new ArrayList<>(c));
+     }
+ 
+     /**
+      * Convert array to seal list.
+      *
+      * @param a Array for convert to seal list.
+      * @param <E> Entry type
+      * @return Sealed collection.
+      */
+     public static <E> List<E> sealList(E... a) {
+         return Collections.unmodifiableList(Arrays.asList(a));
+     }
+ 
+     /**
+      * Gets display name of the network interface this IP address belongs to.
+      *
+      * @param addr IP address for which to find network interface name.
+      * @return Network interface name or {@code null} if can't be found.
+      */
+     @Nullable public static String getNetworkInterfaceName(String addr) {
+         assert addr != null;
+ 
+         try {
+             InetAddress inetAddr = InetAddress.getByName(addr);
+ 
+             for (NetworkInterface itf : asIterable(NetworkInterface.getNetworkInterfaces()))
+                 for (InetAddress itfAddr : asIterable(itf.getInetAddresses()))
+                     if (itfAddr.equals(inetAddr))
+                         return itf.getDisplayName();
+         }
+         catch (UnknownHostException ignore) {
+             return null;
+         }
+         catch (SocketException ignore) {
+             return null;
+         }
+ 
+         return null;
+     }
+ 
+     /**
+      * Tries to resolve host by name, returning local host if input is empty.
+      * This method reflects how {@link org.apache.ignite.configuration.IgniteConfiguration#getLocalHost()} should
+      * be handled in most places.
+      *
+      * @param hostName Hostname or {@code null} if local host should be returned.
+      * @return Address of given host or of localhost.
+      * @throws IOException If attempt to get local host failed.
+      */
+     public static InetAddress resolveLocalHost(@Nullable String hostName) throws IOException {
+         return F.isEmpty(hostName) ?
+             // Should default to InetAddress#anyLocalAddress which is package-private.
+             new InetSocketAddress(0).getAddress() :
+             InetAddress.getByName(hostName);
+     }
+ 
+     /**
+      * Determines whether current local host is different from previously cached.
+      *
+      * @return {@code true} or {@code false} depending on whether or not local host
+      *      has changed from the cached value.
+      * @throws IOException If attempt to get local host failed.
+      */
+     public static synchronized boolean isLocalHostChanged() throws IOException {
+         InetAddress locHost0 = locHost;
+ 
+         return locHost0 != null && !resetLocalHost().equals(locHost0);
+     }
+ 
+     /**
+      * Returns host names consistent with {@link #resolveLocalHost(String)}. So when it returns
+      * a common address this method returns single host name, and when a wildcard address passed
+      * this method tries to collect addresses of all available interfaces.
+      *
+      * @param locAddr Local address to resolve.
+      * @return Resolved available addresses of given local address.
+      * @throws IOException If failed.
+      * @throws IgniteCheckedException If no network interfaces found.
+      */
+     public static IgniteBiTuple<Collection<String>, Collection<String>> resolveLocalAddresses(InetAddress locAddr)
+         throws IOException, IgniteCheckedException {
+         assert locAddr != null;
+ 
+         Collection<String> addrs = new ArrayList<>();
+         Collection<String> hostNames = new ArrayList<>();
+ 
+         if (locAddr.isAnyLocalAddress()) {
+             // It should not take longer than 2 seconds to reach
+             // local address on any network.
+             int reachTimeout = 2000;
+ 
+             for (NetworkInterface itf : asIterable(NetworkInterface.getNetworkInterfaces())) {
+                 for (InetAddress addr : asIterable(itf.getInetAddresses())) {
+                     if (!addr.isLinkLocalAddress() && reachable(itf, addr, reachTimeout))
+                         addresses(addr, addrs, hostNames);
+                 }
+             }
+ 
+             if (F.isEmpty(addrs))
+                 throw new IgniteCheckedException("No network addresses found (is networking enabled?).");
+         }
+         else
+             addresses(locAddr, addrs, hostNames);
+ 
+         return F.t(addrs, hostNames);
+     }
+ 
+     /**
+      * @param addr Address.
+      * @param addrs Addresses.
+      * @param hostNames Host names.
+      */
+     private static void addresses(InetAddress addr, Collection<String> addrs, Collection<String> hostNames) {
+         String hostName = addr.getHostName();
+ 
+         String ipAddr = addr.getHostAddress();
+ 
+         hostName = F.isEmpty(hostName) || hostName.equals(ipAddr) || addr.isLoopbackAddress() ? "" : hostName;
+ 
+         addrs.add(ipAddr);
+         hostNames.add(hostName);
+     }
+ 
+     /**
+      * Gets local host. Implementation will first attempt to get a non-loopback
+      * address. If that fails, then loopback address will be returned.
+      * <p>
+      * Note that this method is synchronized to make sure that local host
+      * initialization happens only once.
+      *
+      * @return Address representing local host.
+      * @throws IOException If attempt to get local host failed.
+      */
+     public static synchronized InetAddress getLocalHost() throws IOException {
+         if (locHost == null)
+             // Cache it.
+             resetLocalHost();
+ 
+         return locHost;
+     }
+ 
+     /**
+      * @return Local host.
+      * @throws IOException If attempt to get local host failed.
+      */
+     private static synchronized InetAddress resetLocalHost() throws IOException {
+         locHost = null;
+ 
 -        String sysLocHost = IgniteSystemProperties.getString(GG_LOCAL_HOST);
++        String sysLocHost = IgniteSystemProperties.getString(IGNITE_LOCAL_HOST);
+ 
+         if (sysLocHost != null)
+             sysLocHost = sysLocHost.trim();
+ 
+         if (!F.isEmpty(sysLocHost))
+             locHost = InetAddress.getByName(sysLocHost);
+         else {
+             List<NetworkInterface> itfs = new ArrayList<>();
+ 
+             for (NetworkInterface itf : asIterable(NetworkInterface.getNetworkInterfaces()))
+                 itfs.add(itf);
+ 
+             Collections.sort(itfs, new Comparator<NetworkInterface>() {
+                 @Override public int compare(NetworkInterface itf1, NetworkInterface itf2) {
+                     // Interfaces whose name starts with 'e' should go first.
+                     return itf1.getName().compareTo(itf2.getName());
+                 }
+             });
+ 
+             // It should not take longer than 2 seconds to reach
+             // local address on any network.
+             int reachTimeout = 2000;
+ 
+             for (NetworkInterface itf : itfs) {
+                 boolean found = false;
+ 
+                 for (InetAddress addr : asIterable(itf.getInetAddresses())) {
+                     if (!addr.isLoopbackAddress() && !addr.isLinkLocalAddress() && reachable(itf, addr, reachTimeout)) {
+                         locHost = addr;
+ 
+                         found = true;
+ 
+                         break;
+                     }
+                 }
+ 
+                 if (found)
+                     break;
+             }
+         }
+ 
+         if (locHost == null)
+             locHost = InetAddress.getLocalHost();
+ 
+         return locHost;
+     }
+ 
+     /**
+      * Checks if address can be reached using three argument InetAddress.isReachable() version.
+      *
+      * @param itf Network interface to use for test.
+      * @param addr Address to check.
+      * @param reachTimeout Timeout for the check.
+      * @return {@code True} if address is reachable.
+      */
+     public static boolean reachable(NetworkInterface itf, InetAddress addr, int reachTimeout) {
+         try {
+             return addr.isReachable(itf, 0, reachTimeout);
+         }
+         catch (IOException ignore) {
+             return false;
+         }
+     }
+ 
+     /**
+      * Checks if address can be reached using one argument InetAddress.isReachable() version.
+      *
+      * @param addr Address to check.
+      * @param reachTimeout Timeout for the check.
+      * @return {@code True} if address is reachable.
+      */
+     public static boolean reachable(InetAddress addr, int reachTimeout) {
+         try {
+             return addr.isReachable(reachTimeout);
+         }
+         catch (IOException ignore) {
+             return false;
+         }
+     }
+ 
+     /**
+      * @param loc Local node.
+      * @param rmt Remote node.
+      * @return Whether given nodes have the same macs.
+      */
+     public static boolean sameMacs(ClusterNode loc, ClusterNode rmt) {
+         assert loc != null;
+         assert rmt != null;
+ 
+         String locMacs = loc.attribute(GridNodeAttributes.ATTR_MACS);
+         String rmtMacs = rmt.attribute(GridNodeAttributes.ATTR_MACS);
+ 
+         return locMacs != null && locMacs.equals(rmtMacs);
+     }
+ 
+     /**
+      * Gets a list of all local non-loopback IPs known to this JVM.
+      * Note that this will include both IPv4 and IPv6 addresses (even if one "resolves"
+      * into another). Loopbacks will be skipped.
+      *
+      * @return List of all known local IPs (empty list if no addresses available).
+      */
+     public static synchronized Collection<String> allLocalIps() {
+         List<String> ips = new ArrayList<>(4);
+ 
+         try {
+             Enumeration<NetworkInterface> itfs = NetworkInterface.getNetworkInterfaces();
+ 
+             if (itfs != null) {
+                 for (NetworkInterface itf : asIterable(itfs)) {
+                     if (!itf.isLoopback()) {
+                         Enumeration<InetAddress> addrs = itf.getInetAddresses();
+ 
+                         if (addrs != null) {
+                             for (InetAddress addr : asIterable(addrs)) {
+                                 String hostAddr = addr.getHostAddress();
+ 
+                                 if (!addr.isLoopbackAddress() && !ips.contains(hostAddr))
+                                     ips.add(hostAddr);
+                             }
+                         }
+                     }
+                 }
+             }
+         }
+         catch (SocketException ignore) {
+             return Collections.emptyList();
+         }
+ 
+         Collections.sort(ips);
+ 
+         return ips;
+     }
+ 
+     /**
+      * Gets a list of all local enabled MACs known to this JVM. It
+      * is using hardware address of the network interface that is not guaranteed to be
+      * MAC addresses (but in most cases it is).
+      * <p>
+      * Note that if network interface is disabled - its MAC won't be included. All
+      * local network interfaces are probed including loopbacks. Virtual interfaces
+      * (sub-interfaces) are skipped.
+      * <p>
+      * Note that on linux getHardwareAddress() can return null from time to time
+      * if NetworkInterface.getHardwareAddress() method is called from many threads.
+      *
+      * @return List of all known enabled local MACs or empty list
+      *      if no MACs could be found.
+      */
+     public static synchronized Collection<String> allLocalMACs() {
+         List<String> macs = new ArrayList<>(3);
+ 
+         try {
+             Enumeration<NetworkInterface> itfs = NetworkInterface.getNetworkInterfaces();
+ 
+             if (itfs != null) {
+                 for (NetworkInterface itf : asIterable(itfs)) {
+                     byte[] hwAddr = itf.getHardwareAddress();
+ 
+                     // Loopback produces empty MAC.
+                     if (hwAddr != null && hwAddr.length > 0) {
+                         String mac = byteArray2HexString(hwAddr);
+ 
+                         if (!macs.contains(mac))
+                             macs.add(mac);
+                     }
+                 }
+             }
+         }
+         catch (SocketException ignore) {
+             return Collections.emptyList();
+         }
+ 
+         Collections.sort(macs);
+ 
+         return macs;
+     }
+ 
+     /**
+      * Downloads resource by URL.
+      *
+      * @param url URL to download.
+      * @param file File where downloaded resource should be stored.
+      * @return File where downloaded resource should be stored.
+      * @throws IOException If error occurred.
+      */
+     public static File downloadUrl(URL url, File file) throws IOException {
+         assert url != null;
+         assert file != null;
+ 
+         InputStream in = null;
+         OutputStream out = null;
+ 
+         try {
+             URLConnection conn = url.openConnection();
+ 
+             if (conn instanceof HttpsURLConnection) {
+                 HttpsURLConnection https = (HttpsURLConnection)conn;
+ 
+                 https.setHostnameVerifier(new DeploymentHostnameVerifier());
+ 
+                 SSLContext ctx = SSLContext.getInstance(HTTPS_PROTOCOL);
+ 
+                 ctx.init(null, getTrustManagers(), null);
+ 
+                 // Initialize socket factory.
+                 https.setSSLSocketFactory(ctx.getSocketFactory());
+             }
+ 
+             in = conn.getInputStream();
+ 
+             if (in == null)
+                 throw new IOException("Failed to open connection: " + url.toString());
+ 
+             out = new BufferedOutputStream(new FileOutputStream(file));
+ 
+             copy(in, out);
+         }
+         catch (NoSuchAlgorithmException | KeyManagementException e) {
+             throw new IOException("Failed to open HTTPs connection [url=" + url.toString() + ", msg=" + e + ']', e);
+         } finally {
+             close(in, null);
+             close(out, null);
+         }
+ 
+         return file;
+     }
+ 
+     /**
+      * Construct array with one trust manager which don't reject input certificates.
+      *
+      * @return Array with one X509TrustManager implementation of trust manager.
+      */
+     private static TrustManager[] getTrustManagers() {
+         return new TrustManager[]{
+             new X509TrustManager() {
+                 @Nullable @Override public X509Certificate[] getAcceptedIssuers() {
+                     return null;
+                 }
+ 
+                 @Override public void checkClientTrusted(X509Certificate[] certs, String authType) {
+                     /* No-op. */
+                 }
+ 
+                 @Override public void checkServerTrusted(X509Certificate[] certs, String authType) {
+                     /* No-op. */
+                 }
+             }
+         };
+     }
+ 
+     /**
+      * Replace password in URI string with a single '*' character.
+      * <p>
+      * Parses given URI by applying &quot;.*://(.*:.*)@.*&quot;
+      * regular expression pattern and than if URI matches it
+      * replaces password strings between '/' and '@' with '*'.
+      *
+      * @param uri URI which password should be replaced.
+      * @return Converted URI string
+      */
+     @Nullable public static String hidePassword(@Nullable String uri) {
+         if (uri == null)
+             return null;
+ 
+         if (Pattern.matches(".*://(.*:.*)@.*", uri)) {
+             int userInfoLastIdx = uri.indexOf('@');
+ 
+             assert userInfoLastIdx != -1;
+ 
+             String str = uri.substring(0, userInfoLastIdx);
+ 
+             int userInfoStartIdx = str.lastIndexOf('/');
+ 
+             str = str.substring(userInfoStartIdx + 1);
+ 
+             String[] params = str.split(";");
+ 
+             StringBuilder builder = new StringBuilder();
+ 
+             for (int i = 0; i < params.length; i++) {
+                 int idx;
+ 
+                 if ((idx = params[i].indexOf(':')) != -1)
+                     params[i] = params[i].substring(0, idx + 1) + '*';
+ 
+                 builder.append(params[i]);
+ 
+                 if (i != params.length - 1)
+                     builder.append(';');
+             }
+ 
+             return new StringBuilder(uri).replace(userInfoStartIdx + 1, userInfoLastIdx,
+                 builder.toString()).toString();
+         }
+ 
+         return uri;
+     }
+ 
+     /**
+      * @return Class loader used to load GridGain itself.
+      */
+     public static ClassLoader gridClassLoader() {
+         return gridClassLoader;
+     }
+ 
+     /**
+      * @param parent Parent to find.
+      * @param ldr Loader to check.
+      * @return {@code True} if parent found.
+      */
+     public static boolean hasParent(@Nullable ClassLoader parent, ClassLoader ldr) {
+         if (parent != null) {
+             for (; ldr != null; ldr = ldr.getParent()) {
+                 if (ldr.equals(parent))
+                     return true;
+             }
+ 
+             return false;
+         }
+ 
+         return true;
+     }
+ 
+     /**
+      * Verifier always returns successful result for any host.
+      */
+     private static class DeploymentHostnameVerifier implements HostnameVerifier {
+         /** {@inheritDoc} */
+         @Override public boolean verify(String hostname, SSLSession ses) {
+             // Remote host trusted by default.
+             return true;
+         }
+     }
+ 
+     /**
+      * Makes a {@code '+---+'} dash line.
+      *
+      * @param len Length of the dash line to make.
+      * @return Dash line.
+      */
+     public static String dash(int len) {
+         char[] dash = new char[len];
+ 
+         Arrays.fill(dash, '-');
+ 
+         dash[0] = dash[len - 1] = '+';
+ 
+         return new String(dash);
+     }
+ 
+     /**
+      * Creates space filled string of given length.
+      *
+      * @param len Number of spaces.
+      * @return Space filled string of given length.
+      */
+     public static String pad(int len) {
+         char[] dash = new char[len];
+ 
+         Arrays.fill(dash, ' ');
+ 
+         return new String(dash);
+     }
+ 
+     /**
+      * Formats system time in milliseconds for printing in logs.
+      *
+      * @param sysTime System time.
+      * @return Formatted time string.
+      */
+     public static String format(long sysTime) {
+         return LONG_DATE_FMT.format(new java.util.Date(sysTime));
+     }
+ 
+     /**
+      * Takes given collection, shuffles it and returns iterable instance.
+      *
+      * @param <T> Type of elements to create iterator for.
+      * @param col Collection to shuffle.
+      * @return Iterable instance over randomly shuffled collection.
+      */
+     public static <T> Iterable<T> randomIterable(Collection<T> col) {
+         List<T> list = new ArrayList<>(col);
+ 
+         Collections.shuffle(list);
+ 
+         return list;
+     }
+ 
+     /**
+      * Converts enumeration to iterable so it can be used in {@code foreach} construct.
+      *
+      * @param <T> Types of instances for iteration.
+      * @param e Enumeration to convert.
+      * @return Iterable over the given enumeration.
+      */
+     public static <T> Iterable<T> asIterable(final Enumeration<T> e) {
+         return new Iterable<T>() {
+             @Override public Iterator<T> iterator() {
+                 return new Iterator<T>() {
+                     @Override public boolean hasNext() {
+                         return e.hasMoreElements();
+                     }
+ 
+                     @SuppressWarnings({"IteratorNextCanNotThrowNoSuchElementException"})
+                     @Override public T next() {
+                         return e.nextElement();
+                     }
+ 
+                     @Override public void remove() {
+                         throw new UnsupportedOperationException();
+                     }
+                 };
+             }
+         };
+     }
+ 
+     /**
+      * Copy source file (or folder) to destination file (or folder). Supported source & destination:
+      * <ul>
+      * <li>File to File</li>
+      * <li>File to Folder</li>
+      * <li>Folder to Folder (Copy the content of the directory and not the directory itself)</li>
+      * </ul>
+      *
+      * @param src Source file or folder.
+      * @param dest Destination file or folder.
+      * @param overwrite Whether or not overwrite existing files and folders.
+      * @throws IOException Thrown if an I/O error occurs.
+      */
+     public static void copy(File src, File dest, boolean overwrite) throws IOException {
+         assert src != null;
+         assert dest != null;
+ 
+         /*
+          * Supported source & destination:
+          * ===============================
+          * 1. File -> File
+          * 2. File -> Directory
+          * 3. Directory -> Directory
+          */
+ 
+         // Source must exist.
+         if (!src.exists())
+             throw new FileNotFoundException("Source can't be found: " + src);
+ 
+         // Check that source and destination are not the same.
+         if (src.getAbsoluteFile().equals(dest.getAbsoluteFile()))
+             throw new IOException("Source and destination are the same [src=" + src + ", dest=" + dest + ']');
+ 
+         if (dest.exists()) {
+             if (!dest.isDirectory() && !overwrite)
+                 throw new IOException("Destination already exists: " + dest);
+ 
+             if (!dest.canWrite())
+                 throw new IOException("Destination is not writable:" + dest);
+         }
+         else {
+             File parent = dest.getParentFile();
+ 
+             if (parent != null && !parent.exists())
+                 // Ignore any errors here.
+                 // We will get errors when we'll try to open the file stream.
+                 //noinspection ResultOfMethodCallIgnored
+                 parent.mkdirs();
+ 
+             // If source is a directory, we should create destination directory.
+             if (src.isDirectory())
+                 //noinspection ResultOfMethodCallIgnored
+                 dest.mkdir();
+         }
+ 
+         if (src.isDirectory()) {
+             // In this case we have Directory -> Directory.
+             // Note that we copy the content of the directory and not the directory itself.
+ 
+             File[] files = src.listFiles();
+ 
+             for (File file : files) {
+                 if (file.isDirectory()) {
+                     File dir = new File(dest, file.getName());
+ 
+                     if (!dir.exists() && !dir.mkdirs())
+                         throw new IOException("Can't create directory: " + dir);
+ 
+                     copy(file, dir, overwrite);
+                 }
+                 else
+                     copy(file, dest, overwrite);
+             }
+         }
+         else {
+             // In this case we have File -> File or File -> Directory.
+             File file = dest.exists() && dest.isDirectory() ? new File(dest, src.getName()) : dest;
+ 
+             if (!overwrite && file.exists())
+                 throw new IOException("Destination already exists: " + file);
+ 
+             FileInputStream in = null;
+             FileOutputStream out = null;
+ 
+             try {
+                 in = new FileInputStream(src);
+                 out = new FileOutputStream(file);
+ 
+                 copy(in, out);
+             }
+             finally {
+                 if (in != null)
+                     in.close();
+ 
+                 if (out != null) {
+                     out.getFD().sync();
+ 
+                     out.close();
+                 }
+             }
+         }
+     }
+ 
+     /**
+      * Starts clock timer if grid is first.
+      */
+     public static void onGridStart() {
+         synchronized (mux) {
+             if (gridCnt == 0) {
+                 timer = new Thread(new Runnable() {
+                     @SuppressWarnings({"BusyWait", "InfiniteLoopStatement"})
+                     @Override public void run() {
+                         while (true) {
+                             curTimeMillis = System.currentTimeMillis();
+ 
+                             try {
+                                 Thread.sleep(10);
+                             }
+                             catch (InterruptedException ignored) {
+                                 U.log(null, "Timer thread has been interrupted.");
+ 
+                                 break;
+                             }
+                         }
+                     }
+                 }, "gridgain-clock");
+ 
+                 timer.setDaemon(true);
+ 
+                 timer.setPriority(10);
+ 
+                 timer.start();
+             }
+ 
+             ++gridCnt;
+         }
+     }
+ 
+     /**
+      * Stops clock timer if all nodes into JVM were stopped.
+      */
+     public static void onGridStop(){
+         synchronized (mux) {
+             assert gridCnt > 0 : gridCnt;
+ 
+             --gridCnt;
+ 
+             if (gridCnt == 0 && timer != null) {
+                 timer.interrupt();
+ 
+                 timer = null;
+             }
+         }
+     }
+ 
+     /**
+      * Copies input byte stream to output byte stream.
+      *
+      * @param in Input byte stream.
+      * @param out Output byte stream.
+      * @return Number of the copied bytes.
+      * @throws IOException Thrown if an I/O error occurs.
+      */
+     public static int copy(InputStream in, OutputStream out) throws IOException {
+         assert in != null;
+         assert out != null;
+ 
+         byte[] buf = new byte[BUF_SIZE];
+ 
+         int cnt = 0;
+ 
+         for (int n; (n = in.read(buf)) > 0;) {
+             out.write(buf, 0, n);
+ 
+             cnt += n;
+         }
+ 
+         return cnt;
+     }
+ 
+     /**
+      * Copies input character stream to output character stream.
+      *
+      * @param in Input character stream.
+      * @param out Output character stream.
+      * @return Number of the copied characters.
+      * @throws IOException Thrown if an I/O error occurs.
+      */
+     public static int copy(Reader in, Writer out) throws IOException {
+         assert in != null;
+         assert out != null;
+ 
+         char[] buf = new char[BUF_SIZE];
+ 
+         int cnt = 0;
+ 
+         for (int n; (n = in.read(buf)) > 0;) {
+             out.write(buf, 0, n);
+ 
+             cnt += n;
+         }
+ 
+         return cnt;
+     }
+ 
+     /**
+      * Writes string to file.
+      *
+      * @param file File.
+      * @param s String to write.
+      * @throws IOException Thrown if an I/O error occurs.
+      */
+     public static void writeStringToFile(File file, String s) throws IOException {
+         writeStringToFile(file, s, Charset.defaultCharset().toString(), false);
+     }
+ 
+     /**
+      * Writes string to file.
+      *
+      * @param file File.
+      * @param s String to write.
+      * @param charset Encoding.
+      * @throws IOException Thrown if an I/O error occurs.
+      */
+     public static void writeStringToFile(File file, String s, String charset) throws IOException {
+         writeStringToFile(file, s, charset, false);
+     }
+ 
+     /**
+      * Reads file to string using specified charset.
+      *
+      * @param fileName File name.
+      * @param charset File charset.
+      * @return File content.
+      * @throws IOException If error occurred.
+      */
+     public static String readFileToString(String fileName, String charset) throws IOException {
+         Reader input = new InputStreamReader(new FileInputStream(fileName), charset);
+ 
+         StringWriter output = new StringWriter();
+ 
+         char[] buf = new char[4096];
+ 
+         int n;
+ 
+         while ((n = input.read(buf)) != -1)
+             output.write(buf, 0, n);
+ 
+         return output.toString();
+     }
+ 
+     /**
+      * Writes string to file.
+      *
+      * @param file File.
+      * @param s String to write.
+      * @param charset Encoding.
+      * @param append If {@code true}, then specified string will be added to the end of the file.
+      * @throws IOException Thrown if an I/O error occurs.
+      */
+     public static void writeStringToFile(File file, String s, String charset, boolean append) throws IOException {
+         if (s == null)
+             return;
+ 
+         OutputStream out = null;
+ 
+         try {
+             out = new FileOutputStream(file, append);
+ 
+             if (s != null)
+                 out.write(s.getBytes(charset));
+         } finally {
+             closeQuiet(out);
+         }
+     }
+ 
+     /**
+      * Utility method that sets cause into exception and returns it.
+      *
+      * @param e Exception to set cause to and return.
+      * @param cause Optional cause to set (if not {@code null}).
+      * @param <E> Type of the exception.
+      * @return Passed in exception with optionally set cause.
+      */
+     public static <E extends Throwable> E withCause(E e, @Nullable Throwable cause) {
+         assert e != null;
+ 
+         if (cause != null)
+             e.initCause(cause);
+ 
+         return e;
+     }
+ 
+     /**
+      * Deletes file or directory with all sub-directories and files.
+      *
+      * @param file File or directory to delete.
+      * @return {@code true} if and only if the file or directory is successfully deleted,
+      *      {@code false} otherwise
+      */
+     public static boolean delete(File file) {
+         assert file != null;
+ 
+         boolean res = true;
+ 
+         if (file.isDirectory()) {
+             File[] files = file.listFiles();
+ 
+             if (files != null && files.length > 0)
+                 for (File file1 : files)
+                     if (file1.isDirectory())
+                         res &= delete(file1);
+                     else if (file1.getName().endsWith("jar"))
+                         try {
+                             // Why do we do this?
+                             new JarFile(file1, false).close();
+ 
+                             res &= file1.delete();
+                         }
+                         catch (IOException ignore) {
+                             // Ignore it here...
+                         }
+                     else
+                         res &= file1.delete();
+ 
+             res &= file.delete();
+         }
+         else
+             res = file.delete();
+ 
+         return res;
+     }
+ 
+     /**
+      * @param dir Directory to create along with all non-existent parent directories.
+      * @return {@code True} if directory exists (has been created or already existed),
+      *      {@code false} if has not been created and does not exist.
+      */
+     public static boolean mkdirs(File dir) {
+         assert dir != null;
+ 
+         return dir.mkdirs() || dir.exists();
+     }
+ 
+     /**
+      * Resolve project home directory based on source code base.
+      *
+      * @return Project home directory (or {@code null} if it cannot be resolved).
+      */
+     @Nullable private static String resolveProjectHome() {
+         assert Thread.holdsLock(IgniteUtils.class);
+ 
+         // Resolve GridGain home via environment variables.
 -        String ggHome0 = IgniteSystemProperties.getString(GG_HOME);
++        String ggHome0 = IgniteSystemProperties.getString(IGNITE_HOME);
+ 
+         if (!F.isEmpty(ggHome0))
+             return ggHome0;
+ 
+         String appWorkDir = System.getProperty("user.dir");
+ 
+         if (appWorkDir != null) {
+             ggHome0 = findProjectHome(new File(appWorkDir));
+ 
+             if (ggHome0 != null)
+                 return ggHome0;
+         }
+ 
+         URI uri;
+ 
+         Class<IgniteUtils> cls = IgniteUtils.class;
+ 
+         try {
+             ProtectionDomain domain = cls.getProtectionDomain();
+ 
+             // Should not happen, but to make sure our code is not broken.
+             if (domain == null || domain.getCodeSource() == null || domain.getCodeSource().getLocation() == null) {
+                 logResolveFailed(cls, null);
+ 
+                 return null;
+             }
+ 
+             // Resolve path to class-file.
+             uri = domain.getCodeSource().getLocation().toURI();
+ 
+             // Overcome UNC path problem on Windows (http://www.tomergabel.com/JavaMishandlesUNCPathsOnWindows.aspx)
+             if (isWindows() && uri.getAuthority() != null)
+                 uri = new URI(uri.toString().replace("file://", "file:/"));
+         }
+         catch (URISyntaxException | SecurityException e) {
+             logResolveFailed(cls, e);
+ 
+             return null;
+         }
+ 
+         return findProjectHome(new File(uri));
+     }
+ 
+     /**
+      * Tries to find project home starting from specified directory and moving to root.
+      *
+      * @param startDir First directory in search hierarchy.
+      * @return Project home path or {@code null} if it wasn't found.
+      */
+     private static String findProjectHome(File startDir) {
+         for (File cur = startDir.getAbsoluteFile(); cur != null; cur = cur.getParentFile()) {
+             // Check 'cur' is project home directory.
+             if (!new File(cur, "bin").isDirectory() ||
+                 !new File(cur, "libs").isDirectory() ||
+                 !new File(cur, "config").isDirectory())
+                 continue;
+ 
+             return cur.getPath();
+         }
+ 
+         return null;
+     }
+ 
+     /**
+      * @param cls Class.
+      * @param e Exception.
+      */
+     private static void logResolveFailed(Class cls, Exception e) {
 -        warn(null, "Failed to resolve GRIDGAIN_HOME automatically for class codebase " +
++        warn(null, "Failed to resolve IGNITE_HOME automatically for class codebase " +
+             "[class=" + cls + (e == null ? "" : ", e=" + e.getMessage()) + ']');
+     }
+ 
+     /**
 -     * Retrieves {@code GRIDGAIN_HOME} property. The property is retrieved from system
++     * Retrieves {@code IGNITE_HOME} property. The property is retrieved from system
+      * properties or from environment in that order.
+      *
 -     * @return {@code GRIDGAIN_HOME} property.
++     * @return {@code IGNITE_HOME} property.
+      */
+     @Nullable public static String getGridGainHome() {
+         GridTuple<String> ggHomeTup = ggHome;
+ 
+         String ggHome0;
+ 
+         if (ggHomeTup == null) {
+             synchronized (IgniteUtils.class) {
+                 // Double check.
+                 ggHomeTup = ggHome;
+ 
+                 if (ggHomeTup == null) {
+                     // Resolve GridGain installation home directory.
+                     ggHome = F.t(ggHome0 = resolveProjectHome());
+ 
+                     if (ggHome0 != null)
 -                        System.setProperty(GG_HOME, ggHome0);
++                        System.setProperty(IGNITE_HOME, ggHome0);
+                 }
+                 else
+                     ggHome0 = ggHomeTup.get();
+             }
+         }
+         else
+             ggHome0 = ggHomeTup.get();
+ 
+         return ggHome0;
+     }
+ 
+     /**
+      * @param path GridGain home. May be {@code null}.
+      */
+     public static void setGridGainHome(@Nullable String path) {
+         GridTuple<String> ggHomeTup = ggHome;
+ 
+         String ggHome0;
+ 
+         if (ggHomeTup == null) {
+             synchronized (IgniteUtils.class) {
+                 // Double check.
+                 ggHomeTup = ggHome;
+ 
+                 if (ggHomeTup == null) {
+                     if (F.isEmpty(path))
 -                        System.clearProperty(GG_HOME);
++                        System.clearProperty(IGNITE_HOME);
+                     else
 -                        System.setProperty(GG_HOME, path);
++                        System.setProperty(IGNITE_HOME, path);
+ 
+                     ggHome = F.t(path);
+ 
+                     return;
+                 }
+                 else
+                     ggHome0 = ggHomeTup.get();
+             }
+         }
+         else
+             ggHome0 = ggHomeTup.get();
+ 
+         if (ggHome0 != null && !ggHome0.equals(path))
 -            throw new IgniteException("Failed to set GRIDGAIN_HOME after it has been already resolved " +
++            throw new IgniteException("Failed to set IGNITE_HOME after it has been already resolved " +
+                 "[ggHome=" + ggHome0 + ", newGgHome=" + path + ']');
+     }
+ 
+     /**
+      * Gets file associated with path.
+      * <p>
 -     * First check if path is relative to {@code GRIDGAIN_HOME}.
++     * First check if path is relative to {@code IGNITE_HOME}.
+      * If not, check if path is absolute.
+      * If all checks fail, then {@code null} is returned.
+      * <p>
 -     * See {@link #getGridGainHome()} for information on how {@code GRIDGAIN_HOME} is retrieved.
++     * See {@link #getGridGainHome()} for information on how {@code IGNITE_HOME} is retrieved.
+      *
+      * @param path Path to resolve.
+      * @return Resolved path as file, or {@code null} if path cannot be resolved.
+      */
+     @Nullable public static File resolveGridGainPath(String path) {
+         assert path != null;
+ 
+         /*
 -         * 1. Check relative to GRIDGAIN_HOME specified in configuration, if any.
++         * 1. Check relative to IGNITE_HOME specified in configuration, if any.
+          */
+ 
+         String home = getGridGainHome();
+ 
+         if (home != null) {
+             File file = new File(home, path);
+ 
+             if (file.exists())
+                 return file;
+         }
+ 
+         /*
+          * 2. Check given path as absolute.
+          */
+ 
+         File file = new File(path);
+ 
+         if (file.exists())
+             return file;
+ 
+         /*
+          * 3. Check development path.
+          */
+ 
+         if (home != null)
+             file = new File(home, "os/" + path);
+ 
+         return file.exists() ? file : null;
+     }
+ 
+     /**
+      * Gets URL representing the path passed in. First the check is made if path is absolute.
+      * If not, then the check is made if path is relative to {@code META-INF} folder in classpath.
 -     * If not, then the check is made if path is relative to ${GRIDGAIN_HOME}.
++     * If not, then the check is made if path is relative to ${IGNITE_HOME}.
+      * If all checks fail,
+      * then {@code null} is returned, otherwise URL representing path is returned.
+      * <p>
 -     * See {@link #getGridGainHome()} for information on how {@code GRIDGAIN_HOME} is retrieved.
++     * See {@link #getGridGainHome()} for information on how {@code IGNITE_HOME} is retrieved.
+      *
+      * @param path Path to resolve.
+      * @return Resolved path as URL, or {@code null} if path cannot be resolved.
+      * @see #getGridGainHome()
+      */
+     @Nullable public static URL resolveGridGainUrl(String path) {
+         return resolveGridGainUrl(path, true);
+     }
+ 
+     /**
+      * Gets URL representing the path passed in. First the check is made if path is absolute.
+      * If not, then the check is made if path is relative to {@code META-INF} folder in classpath.
 -     * If not, then the check is made if path is relative to ${GRIDGAIN_HOME}.
++     * If not, then the check is made if path is relative to ${IGNITE_HOME}.
+      * If all checks fail,
+      * then {@code null} is returned, otherwise URL representing path is returned.
+      * <p>
 -     * See {@link #getGridGainHome()} for information on how {@code GRIDGAIN_HOME} is retrieved.
++     * See {@link #getGridGainHome()} for information on how {@code IGNITE_HOME} is retrieved.
+      *
+      * @param path Path to resolve.
+      * @param metaInf Flag to indicate whether META-INF folder should be checked or class path root.
+      * @return Resolved path as URL, or {@code null} if path cannot be resolved.
+      * @see #getGridGainHome()
+      */
+     @SuppressWarnings({"UnusedCatchParameter"})
+     @Nullable public static URL resolveGridGainUrl(String path, boolean metaInf) {
+         File f = resolveGridGainPath(path);
+ 
+         if (f == null)
+             f = resolveGridGainPath("os/" + path);
+ 
+         if (f != null) {
+             try {
+                 // Note: we use that method's chain instead of File.getURL() with due
+                 // Sun bug http://bugs.sun.com/bugdatabase/view_bug.do?bug_id=6179468
+                 return f.toURI().toURL();
+             }
+             catch (MalformedURLException e) {
+                 // No-op.
+             }
+         }
+ 
+         String locPath = (metaInf ? "META-INF/" : "") + path.replaceAll("\\\\", "/");
+ 
+         return Thread.currentThread().getContextClassLoader().getResource(locPath);
+     }
+ 
+     /**
+      * Join byte arrays into single one.
+      *
+      * @param bufs list of byte arrays to concatenate.
+      * @return Concatenated byte's array.
+      */
+     public static byte[] join(byte[]... bufs) {
+         int size = 0;
+         for (byte[] buf : bufs) {
+             size += buf.length;
+         }
+ 
+         byte[] res = new byte[size];
+         int position = 0;
+         for (byte[] buf : bufs) {
+             arrayCopy(buf, 0, res, position, buf.length);
+             position += buf.length;
+         }
+ 
+         return res;
+     }
+ 
+     /**
+      * Converts byte array to formatted string. If calling:
+      * <pre name="code" class="java">
+      * ...
+      * byte[] data = {10, 20, 30, 40, 50, 60, 70, 80, 90};
+      *
+      * U.byteArray2String(data, "0x%02X", ",0x%02X")
+      * ...
+      * </pre>
+      * the result will be:
+      * <pre name="code" class="java">
+      * ...
+      * 0x0A, 0x14, 0x1E, 0x28, 0x32, 0x3C, 0x46, 0x50, 0x5A
+      * ...
+      * </pre>
+      *
+      * @param arr Array of byte.
+      * @param hdrFmt C-style string format for the first element.
+      * @param bodyFmt C-style string format for second and following elements, if any.
+      * @return String with converted bytes.
+      */
+     public static String byteArray2String(byte[] arr, String hdrFmt, String bodyFmt) {
+         assert arr != null;
+         assert hdrFmt != null;
+         assert bodyFmt != null;
+ 
+         SB sb = new SB();
+ 
+         sb.a('{');
+ 
+         boolean first = true;
+ 
+         for (byte b : arr)
+             if (first) {
+                 sb.a(String.format(hdrFmt, b));
+ 
+                 first = false;
+             }
+             else
+                 sb.a(String.format(bodyFmt, b));
+ 
+         sb.a('}');
+ 
+         return sb.toString();
+     }
+ 
+     /**
+      * Converts byte array to hex string.
+      *
+      * @param arr Array of bytes.
+      * @return Hex string

<TRUNCATED>

[22/50] [abbrv] incubator-ignite git commit: Tests: Fix GridMessagingSelfTest.

Posted by vo...@apache.org.
Tests: Fix GridMessagingSelfTest.


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

Branch: refs/heads/ignite-16
Commit: 4da5e29a5f4d7e47cf42fdc2daf53370efe0eb6b
Parents: b6eb388
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 30 13:05:59 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 30 13:05:59 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/messaging/GridMessagingSelfTest.java    | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4da5e29a/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java b/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
index 125a438..dea2172 100644
--- a/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/messaging/GridMessagingSelfTest.java
@@ -67,7 +67,7 @@ public class GridMessagingSelfTest extends GridCommonAbstractTest {
     private static final Integer I_TOPIC_2 = 2;
 
     /** */
-    public static final String EXT_RESOURCE_CLS_NAME = "org.apache.ignite.tests.p2p.GridP2PAwareTestUserResource";
+    public static final String EXT_RESOURCE_CLS_NAME = "org.apache.ignite.tests.p2p.TestUserResource";
 
     /** Shared IP finder. */
     private final TcpDiscoveryIpFinder ipFinder = new TcpDiscoveryVmIpFinder(true);


[42/50] [abbrv] incubator-ignite git commit: gg*{sh, bat} renamed to ignite*{sh, bat}

Posted by vo...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/compute/montecarlo/CreditRiskExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/compute/montecarlo/CreditRiskExample.java b/examples/src/main/java/org/apache/ignite/examples/compute/montecarlo/CreditRiskExample.java
index ce36999..49a2667 100644
--- a/examples/src/main/java/org/apache/ignite/examples/compute/montecarlo/CreditRiskExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/compute/montecarlo/CreditRiskExample.java
@@ -27,7 +27,7 @@ import java.util.*;
  * Monte-Carlo example. Demonstrates distributed credit risk calculation.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheAffinityExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheAffinityExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheAffinityExample.java
index a0be78e..8d6b275 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheAffinityExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheAffinityExample.java
@@ -30,7 +30,7 @@ import java.util.*;
  * example is to provide the simplest code example of this logic.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheApiExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheApiExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheApiExample.java
index 218d734..26057c5 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheApiExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheApiExample.java
@@ -28,7 +28,7 @@ import java.util.concurrent.*;
  * This example demonstrates some of the cache rich API capabilities.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheContinuousQueryExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheContinuousQueryExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheContinuousQueryExample.java
index 2084921..d801148 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheContinuousQueryExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheContinuousQueryExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * This examples demonstrates continuous query API.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheDataLoaderExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheDataLoaderExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheDataLoaderExample.java
index 853a72d..b13b625 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheDataLoaderExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheDataLoaderExample.java
@@ -27,7 +27,7 @@ import org.apache.ignite.examples.*;
  * together and properly manages load on remote nodes.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheEventsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheEventsExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheEventsExample.java
index bc2c01e..80b4217 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheEventsExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheEventsExample.java
@@ -31,7 +31,7 @@ import static org.apache.ignite.events.IgniteEventType.*;
  * must be specifically enabled, just like in {@code examples/config/example-cache.xml} file.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePopularNumbersExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePopularNumbersExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePopularNumbersExample.java
index ac73134..1617662 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePopularNumbersExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePopularNumbersExample.java
@@ -30,7 +30,7 @@ import java.util.*;
  * Real time popular numbers counter.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePutGetExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePutGetExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePutGetExample.java
index a6b8f6c..9df8fe5 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePutGetExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CachePutGetExample.java
@@ -26,7 +26,7 @@ import java.util.*;
  * This example demonstrates very basic operations on cache, such as 'put' and 'get'.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
index f7ade22..a0205d6 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
@@ -59,7 +59,7 @@ import java.util.*;
  * </ul>
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheTransactionExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheTransactionExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheTransactionExample.java
index db61b22..1e1793f 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheTransactionExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheTransactionExample.java
@@ -31,7 +31,7 @@ import static org.apache.ignite.transactions.IgniteTxIsolation.*;
  * Demonstrates how to use cache transactions.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicLongExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicLongExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicLongExample.java
index 3e7996e..51359fd 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicLongExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicLongExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple usage of distributed atomic long.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicReferenceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicReferenceExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicReferenceExample.java
index eae31f3..fa86d21 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicReferenceExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicReferenceExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple usage of distributed atomic reference.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicSequenceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicSequenceExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicSequenceExample.java
index d4ad2ce..1e509ba 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicSequenceExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicSequenceExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple usage of distributed atomic sequence.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicStampedExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicStampedExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicStampedExample.java
index eb70edd..696c2fe 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicStampedExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheAtomicStampedExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple usage of distributed atomic stamped.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheCountDownLatchExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheCountDownLatchExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheCountDownLatchExample.java
index 495d8ac..bd3c68b 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheCountDownLatchExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheCountDownLatchExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Demonstrates a simple usage of distributed count down latch.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheQueueExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheQueueExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheQueueExample.java
index 5ab64c6..ae1f3b9 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheQueueExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheQueueExample.java
@@ -29,7 +29,7 @@ import java.util.*;
  * cache queue.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheSetExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheSetExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheSetExample.java
index cff0046..dc68b1e 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheSetExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/datastructures/CacheSetExample.java
@@ -28,7 +28,7 @@ import java.util.*;
  * Grid cache distributed set example.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/datagrid/starschema/CacheStarSchemaExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/starschema/CacheStarSchemaExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/starschema/CacheStarSchemaExample.java
index 65bd6c3..e5a79d4 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/starschema/CacheStarSchemaExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/starschema/CacheStarSchemaExample.java
@@ -42,7 +42,7 @@ import java.util.concurrent.*;
  * in various ways.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link CacheNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-cache.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/events/EventsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/events/EventsExample.java b/examples/src/main/java/org/apache/ignite/examples/events/EventsExample.java
index 6877935..fb30474 100644
--- a/examples/src/main/java/org/apache/ignite/examples/events/EventsExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/events/EventsExample.java
@@ -33,7 +33,7 @@ import static org.apache.ignite.events.IgniteEventType.*;
  * Note that grid events are disabled by default and must be specifically enabled,
  * just like in {@code examples/config/example-compute.xml} file.
  * <p>
- * Remote nodes should always be started with configuration: {@code 'ggstart.sh examples/config/example-compute.xml'}.
+ * Remote nodes should always be started with configuration: {@code 'ignite.sh examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start
  * GridGain node with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsExample.java b/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsExample.java
index 496541c..b8fa35e 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsExample.java
@@ -30,7 +30,7 @@ import java.util.*;
  * files, create, list and delete directories).
  * <p>
  * Remote nodes should always be started with configuration file which includes
- * GGFS: {@code 'ggstart.sh examples/config/filesystem/example-ggfs.xml'}.
+ * GGFS: {@code 'ignite.sh examples/config/filesystem/example-ggfs.xml'}.
  * <p>
  * Alternatively you can run {@link GgfsNodeStartup} in another JVM which will start
  * GridGain node with {@code examples/config/filesystem/example-ggfs.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsMapReduceExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsMapReduceExample.java b/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsMapReduceExample.java
index 1ba193f..3813e2d 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsMapReduceExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsMapReduceExample.java
@@ -31,7 +31,7 @@ import java.util.*;
  * the same way as {@code grep} command does.
  * <p>
  * Remote nodes should always be started with configuration file which includes
- * GGFS: {@code 'ggstart.sh examples/config/filesystem/example-ggfs.xml'}.
+ * GGFS: {@code 'ignite.sh examples/config/filesystem/example-ggfs.xml'}.
  * <p>
  * Alternatively you can run {@link GgfsNodeStartup} in another JVM which will start
  * GridGain node with {@code examples/config/filesystem/example-ggfs.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsNodeStartup.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsNodeStartup.java b/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsNodeStartup.java
index 381de6b..e2cfea6 100644
--- a/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsNodeStartup.java
+++ b/examples/src/main/java/org/apache/ignite/examples/ggfs/GgfsNodeStartup.java
@@ -22,8 +22,8 @@ import org.apache.ignite.*;
 /**
  * Starts up an empty node with GGFS configuration.
  * You can also start a stand-alone GridGain instance by passing the path
- * to configuration file to {@code 'ggstart.{sh|bat}'} script, like so:
- * {@code 'ggstart.sh examples/config/filesystem/example-ggfs.xml'}.
+ * to configuration file to {@code 'ignite.{sh|bat}'} script, like so:
+ * {@code 'ignite.sh examples/config/filesystem/example-ggfs.xml'}.
  * <p>
  * The difference is that running this class from IDE adds all example classes to classpath
  * but running from command line doesn't.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingExample.java b/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingExample.java
index 8aabf4e..2629a64 100644
--- a/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingExample.java
@@ -34,7 +34,7 @@ import java.util.concurrent.*;
  * To run this example you must have at least one remote node started.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongExample.java b/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongExample.java
index 11edc44..a22b2aa 100644
--- a/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongExample.java
@@ -33,7 +33,7 @@ import java.util.concurrent.*;
  * To run this example you must have at least one remote node started.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongListenActorExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongListenActorExample.java b/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongListenActorExample.java
index 65fa6ae..eec94a7 100644
--- a/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongListenActorExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/messaging/MessagingPingPongListenActorExample.java
@@ -31,7 +31,7 @@ import java.util.concurrent.*;
  * To run this example you must have at least one remote node started.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/misc/deployment/DeploymentExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/misc/deployment/DeploymentExample.java b/examples/src/main/java/org/apache/ignite/examples/misc/deployment/DeploymentExample.java
index 873a63f..64151f6 100644
--- a/examples/src/main/java/org/apache/ignite/examples/misc/deployment/DeploymentExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/misc/deployment/DeploymentExample.java
@@ -40,7 +40,7 @@ import java.util.*;
  * in system classpath, so even in this case the deployment step is unnecessary.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-cache.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-cache.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will
  * start GridGain node with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/misc/springbean/SpringBeanExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/misc/springbean/SpringBeanExample.java b/examples/src/main/java/org/apache/ignite/examples/misc/springbean/SpringBeanExample.java
index 83a3e17..709fb2b 100644
--- a/examples/src/main/java/org/apache/ignite/examples/misc/springbean/SpringBeanExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/misc/springbean/SpringBeanExample.java
@@ -36,7 +36,7 @@ import java.util.concurrent.*;
  * apply grid bean destructor and stop the grid.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/services/ServicesExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/services/ServicesExample.java b/examples/src/main/java/org/apache/ignite/examples/services/ServicesExample.java
index c5d0c51..7481137 100644
--- a/examples/src/main/java/org/apache/ignite/examples/services/ServicesExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/services/ServicesExample.java
@@ -34,7 +34,7 @@ import java.util.*;
  * which will start GridGain node with {@code examples/config/example-compute.xml} configuration.
  * <p>
  * NOTE:<br/>
- * Starting {@code ggstart.sh} directly will not work, as distributed services
+ * Starting {@code ignite.sh} directly will not work, as distributed services
  * cannot be peer-deployed and classes must be on the classpath for every node.
  */
 public class ServicesExample {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingCheckInExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingCheckInExample.java b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingCheckInExample.java
index 2b3c0e8..6423d1e 100644
--- a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingCheckInExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingCheckInExample.java
@@ -52,7 +52,7 @@ import java.util.concurrent.*;
  * the users that have checked-in in the known places within the last 10 seconds.
  * <p>
  * Remote nodes should always be started with special configuration file:
- * {@code 'ggstart.{sh|bat} examples/config/example-streamer.xml'}.
+ * {@code 'ignite.{sh|bat} examples/config/example-streamer.xml'}.
  * When starting nodes this way JAR file containing the examples code
  * should be placed to {@code IGNITE_HOME/libs} folder. You can build
  * {@code gridgain-examples.jar} by running {@code mvn package} in

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPopularNumbersExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPopularNumbersExample.java b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPopularNumbersExample.java
index 56712bf..81e91f9 100644
--- a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPopularNumbersExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPopularNumbersExample.java
@@ -35,7 +35,7 @@ import java.util.*;
  * is set to {@code 10,000}.
  * <p>
  * Remote nodes should always be started with special configuration file:
- * {@code 'ggstart.{sh|bat} examples/config/example-streamer.xml'}.
+ * {@code 'ignite.{sh|bat} examples/config/example-streamer.xml'}.
  * When starting nodes this way JAR file containing the examples code
  * should be placed to {@code IGNITE_HOME/libs} folder. You can build
  * {@code gridgain-examples.jar} by running {@code mvn package} in

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPriceBarsExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPriceBarsExample.java b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPriceBarsExample.java
index 708564e..584e55a 100644
--- a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPriceBarsExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingPriceBarsExample.java
@@ -46,7 +46,7 @@ import java.util.concurrent.*;
  * with purpose to demonstrate multi-stage streaming processing.
  * <p>
  * Remote nodes should always be started with special configuration file:
- * {@code 'ggstart.{sh|bat} examples/config/example-streamer.xml'}.
+ * {@code 'ignite.{sh|bat} examples/config/example-streamer.xml'}.
  * When starting nodes this way JAR file containing the examples code
  * should be placed to {@code IGNITE_HOME/libs} folder. You can build
  * {@code gridgain-examples.jar} by running {@code mvn package} in

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingRunningAverageExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingRunningAverageExample.java b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingRunningAverageExample.java
index 3b6f52e..7ccbf42 100644
--- a/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingRunningAverageExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/streaming/StreamingRunningAverageExample.java
@@ -32,7 +32,7 @@ import java.util.concurrent.*;
  * continuously maintains a running average over last {@code 500} numbers.
  * <p>
  * Remote nodes should always be started with special configuration file:
- * {@code 'ggstart.{sh|bat} examples/config/example-streamer.xml'}.
+ * {@code 'ignite.{sh|bat} examples/config/example-streamer.xml'}.
  * When starting nodes this way JAR file containing the examples code
  * should be placed to {@code IGNITE_HOME/libs} folder. You can build
  * {@code gridgain-examples.jar} by running {@code mvn package} in

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java8/org/apache/ignite/examples/ComputeExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java8/org/apache/ignite/examples/ComputeExample.java b/examples/src/main/java8/org/apache/ignite/examples/ComputeExample.java
index 6bcb12c..71b9946 100644
--- a/examples/src/main/java8/org/apache/ignite/examples/ComputeExample.java
+++ b/examples/src/main/java8/org/apache/ignite/examples/ComputeExample.java
@@ -26,7 +26,7 @@ import org.apache.ignite.lang.IgniteCallable;
  * Demonstrates broadcasting and unicasting computations within grid projection.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  */
 public class ComputeExample {
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/java8/org/apache/ignite/examples/MessagingExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java8/org/apache/ignite/examples/MessagingExample.java b/examples/src/main/java8/org/apache/ignite/examples/MessagingExample.java
index dd7e1ea..c69c3ab 100644
--- a/examples/src/main/java8/org/apache/ignite/examples/MessagingExample.java
+++ b/examples/src/main/java8/org/apache/ignite/examples/MessagingExample.java
@@ -31,7 +31,7 @@ import java.util.concurrent.*;
  * To run this example you must have at least one remote node started.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: {@code 'ggstart.{sh|bat} examples/config/example-compute.xml'}.
+ * enables P2P class loading: {@code 'ignite.{sh|bat} examples/config/example-compute.xml'}.
  * <p>
  * Alternatively you can run {@link ComputeNodeStartup} in another JVM which will start GridGain node
  * with {@code examples/config/example-compute.xml} configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample1.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample1.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample1.scala
index 2598e93..b0ca960 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample1.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample1.scala
@@ -34,7 +34,7 @@ import java.util.concurrent.Callable
  * keys.
  *
  * Remote nodes should always be started with configuration file which includes
- * cache: `'ggstart.sh examples/config/example-cache.xml'`. Local node can
+ * cache: `'ignite.sh examples/config/example-cache.xml'`. Local node can
  * be started with or without cache.
  */
 object ScalarCacheAffinityExample1 {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample2.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample2.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample2.scala
index bc6f0a1..e12f3bf 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample2.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinityExample2.scala
@@ -28,7 +28,7 @@ import scala.util.control.Breaks._
  * Note that affinity routing is enabled for all caches.
  *
  * Remote nodes should always be started with configuration file which includes
- * cache: `'ggstart.sh examples/config/example-cache.xml'`. Local node can
+ * cache: `'ignite.sh examples/config/example-cache.xml'`. Local node can
  * be started with or without cache.
  */
 object ScalarCacheAffinityExample2 {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinitySimpleExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinitySimpleExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinitySimpleExample.scala
index 103bcb3..12c2f96 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinitySimpleExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheAffinitySimpleExample.scala
@@ -32,7 +32,7 @@ import org.apache.ignite.scalar.scalar._
  * Note also that for affinity routing is enabled for all caches.
  *
  * Remote nodes should always be started with configuration file which includes
- * cache: `'ggstart.sh examples/config/example-cache.xml'`. Local node can
+ * cache: `'ignite.sh examples/config/example-cache.xml'`. Local node can
  * be started with or without cache.
  */
 object ScalarCacheAffinitySimpleExample extends App {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
index 574006f..22ab99e 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
@@ -30,7 +30,7 @@ import scala.collection.JavaConversions._
  * Demonstrates basic In-Memory Data Grid operations with Scalar.
  * <p>
  * Remote nodes should always be started with configuration file which includes
- * cache: `'ggstart.sh examples/config/example-cache.xml'`. Local node can
+ * cache: `'ignite.sh examples/config/example-cache.xml'`. Local node can
  * be started with or without cache.
  */
 object ScalarCacheExample extends App {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
index 4cf0b04..e52f431 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
@@ -30,7 +30,7 @@ import scala.util.Random
  * Real time popular number counter.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `ggstart.sh examples/config/example-cache.xml`
+ * enables P2P class loading: `ignite.sh examples/config/example-cache.xml`
  * <p>
  * Alternatively you can run [[CacheNodeStartup]] in another JVM which will
  * start GridGain node with `examples/config/example-cache.xml` configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
index 99334f4..d189e9f 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
@@ -31,7 +31,7 @@ import java.util._
  * Demonstrates cache ad-hoc queries with Scalar.
  * <p>
  * Remote nodes should always be started with configuration file which includes
- * cache: `'ggstart.sh examples/config/example-cache.xml'`. Local node can
+ * cache: `'ignite.sh examples/config/example-cache.xml'`. Local node can
  * be started with or without cache.
  */
 object ScalarCacheQueryExample {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarClosureExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarClosureExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarClosureExample.scala
index 3587356..fc4b46b 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarClosureExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarClosureExample.scala
@@ -25,7 +25,7 @@ import org.apache.ignite.scalar.scalar._
  * Demonstrates various closure executions on the cloud using Scalar.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarClosureExample extends App {
     scalar("examples/config/example-compute.xml") {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarContinuationExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarContinuationExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarContinuationExample.scala
index 7218490..1c1dc46 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarContinuationExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarContinuationExample.scala
@@ -40,7 +40,7 @@ import java.util
  * the more values it will be cached on remote nodes.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarContinuationExample {
     def main(args: Array[String]) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCreditRiskExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCreditRiskExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCreditRiskExample.scala
index 1affeb9..65393f7 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCreditRiskExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCreditRiskExample.scala
@@ -27,7 +27,7 @@ import scala.util.control.Breaks._
  * Scalar-based Monte-Carlo example.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarCreditRiskExample {
     def main(args: Array[String]) {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPiCalculationExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPiCalculationExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPiCalculationExample.scala
index 3064108..12b72b7 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPiCalculationExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPiCalculationExample.scala
@@ -28,7 +28,7 @@ import scala.math._
  * or any explicit deployment.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarPiCalculationExample {
     /** Number of iterations per node. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPingPongExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPingPongExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPingPongExample.scala
index bff48a4..dbdd9e0 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPingPongExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPingPongExample.scala
@@ -29,7 +29,7 @@ import java.util.concurrent.CountDownLatch
  * two nodes. It is analogous to `GridMessagingPingPongExample` on Java side.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarPingPongExample extends App {
     scalar("examples/config/example-compute.xml") {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPrimeExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPrimeExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPrimeExample.scala
index 1165ef9..3a29101 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPrimeExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarPrimeExample.scala
@@ -30,7 +30,7 @@ import scala.util.control.Breaks._
  * ==Starting Remote Nodes==
  * To try this example you should (but don't have to) start remote grid instances.
  * You can start as many as you like by executing the following script:
- * `{IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-compute.xml`
+ * `{IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-compute.xml`
  *
  * Once remote instances are started, you can execute this example from
  * Eclipse, IntelliJ IDEA, or NetBeans (and any other Java IDE) by simply hitting run

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarScheduleExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarScheduleExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarScheduleExample.scala
index a5b79ca..299bc0f 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarScheduleExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarScheduleExample.scala
@@ -26,7 +26,7 @@ import org.apache.ignite.scalar.scalar._
  * three times with initial scheduling delay equal to five seconds.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarScheduleExample extends App {
     scalar("examples/config/example-compute.xml") {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
index 574a816..9791d87 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
@@ -44,7 +44,7 @@ import scala.collection.JavaConversions._
  * in various ways.
  * <p>
  * Remote nodes should always be started with configuration file which includes
- * cache: `'ggstart.sh examples/config/example-cache.xml'`.
+ * cache: `'ignite.sh examples/config/example-cache.xml'`.
  */
 object ScalarSnowflakeSchemaExample {
     /** Name of replicated cache specified in spring configuration. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarTaskExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarTaskExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarTaskExample.scala
index cd98f06..7dc8c5f 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarTaskExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarTaskExample.scala
@@ -32,7 +32,7 @@ import scala.collection.JavaConversions._
  * As a trade off in such cases the more code needs to be written vs. simple closure execution.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarTaskExample extends App {
     scalar("examples/config/example-compute.xml") {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarWorldShortestMapReduce.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarWorldShortestMapReduce.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarWorldShortestMapReduce.scala
index 674c69a..8d73cda 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarWorldShortestMapReduce.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarWorldShortestMapReduce.scala
@@ -26,7 +26,7 @@ import org.apache.ignite.scalar.scalar._
  * on thousands requiring no special configuration or deployment.
  * <p>
  * Remote nodes should always be started with special configuration file which
- * enables P2P class loading: `'ggstart.{sh|bat} examples/config/example-compute.xml'`.
+ * enables P2P class loading: `'ignite.{sh|bat} examples/config/example-compute.xml'`.
  */
 object ScalarWorldShortestMapReduce extends App {
     scalar("examples/config/example-compute.xml") {

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/aop/readme.txt
----------------------------------------------------------------------
diff --git a/modules/aop/readme.txt b/modules/aop/readme.txt
index 75c5f49..4d04630 100644
--- a/modules/aop/readme.txt
+++ b/modules/aop/readme.txt
@@ -5,7 +5,7 @@ Apache Ignite AOP module provides capability to turn any Java method to a distri
 adding @Gridify annotation to it.
 
 To enable AOP module when starting a standalone node, move 'optional/ignite-aop' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing AOP Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/aws/readme.txt
----------------------------------------------------------------------
diff --git a/modules/aws/readme.txt b/modules/aws/readme.txt
index 317369c..1819915 100644
--- a/modules/aws/readme.txt
+++ b/modules/aws/readme.txt
@@ -4,7 +4,7 @@ Apache Ignite AWS Module
 Apache Ignite AWS module provides S3-based implementations of checkpoint SPI and IP finder for TCP discovery.
 
 To enable AWS module when starting a standalone node, move 'optional/ignite-aws' folder to
-'libs' folder before running 'ggstart.{sh|bat}' script. The content of the module folder will
+'libs' folder before running 'ignite.{sh|bat}' script. The content of the module folder will
 be added to classpath in this case.
 
 Importing AWS Module In Maven Project

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/bin/start-nodes.cmd
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/bin/start-nodes.cmd b/modules/clients/src/test/bin/start-nodes.cmd
index ece9ee2..5e1fdb2 100644
--- a/modules/clients/src/test/bin/start-nodes.cmd
+++ b/modules/clients/src/test/bin/start-nodes.cmd
@@ -35,9 +35,9 @@ mkdir %IGNITE_HOME%\work\log
 
 set JVM_OPTS=-DCLIENTS_MODULE_PATH=%CLIENTS_MODULE_PATH%
 
-FOR /L %%G IN (1,1,%NODES_COUNT%) DO start "Node #%%G" /low /MIN cmd /C "%BIN_PATH%\ggstart.bat -v %CONFIG_DIR%\spring-server-node.xml >> %IGNITE_HOME%\work\log\node-%%G.log 2>&1"
-FOR /L %%G IN (1,1,%NODES_COUNT%) DO start "SSL Node #%%G" /low /MIN cmd /C "%BIN_PATH%\ggstart.bat -v %CONFIG_DIR%\spring-server-ssl-node.xml >> %IGNITE_HOME%\work\log\node-ssl-%%G.log 2>&1"
-FOR /L %%G IN (1,1,%NODES_COUNT%) DO start "Cache Node #%%G" /low /MIN cmd /C "%BIN_PATH%\ggstart.bat -v %CONFIG_DIR%\spring-cache.xml >> %IGNITE_HOME%\work\log\cache-node-%%G.log 2>&1"
+FOR /L %%G IN (1,1,%NODES_COUNT%) DO start "Node #%%G" /low /MIN cmd /C "%BIN_PATH%\ignite.bat -v %CONFIG_DIR%\spring-server-node.xml >> %IGNITE_HOME%\work\log\node-%%G.log 2>&1"
+FOR /L %%G IN (1,1,%NODES_COUNT%) DO start "SSL Node #%%G" /low /MIN cmd /C "%BIN_PATH%\ignite.bat -v %CONFIG_DIR%\spring-server-ssl-node.xml >> %IGNITE_HOME%\work\log\node-ssl-%%G.log 2>&1"
+FOR /L %%G IN (1,1,%NODES_COUNT%) DO start "Cache Node #%%G" /low /MIN cmd /C "%BIN_PATH%\ignite.bat -v %CONFIG_DIR%\spring-cache.xml >> %IGNITE_HOME%\work\log\cache-node-%%G.log 2>&1"
 
 echo Wait 60 seconds while nodes started.
 ping -n 60 127.0.0.1 > NUL
@@ -45,8 +45,8 @@ ping -n 60 127.0.0.1 > NUL
 rem Disable hostname verification for self-signed certificates.
 set JVM_OPTS=%JVM_OPTS% -DIGNITE_DISABLE_HOSTNAME_VERIFIER=true
 
-FOR /L %%G IN (1,1,1) DO start "Router #%%G" /low /MIN cmd /C "%BIN_PATH%\ggrouter.bat -v %CONFIG_DIR%\spring-router.xml >> %IGNITE_HOME%\work\log\router-%%G.log 2>&1"
-FOR /L %%G IN (1,1,1) DO start "SSL Router #%%G" /low /MIN cmd /C "%BIN_PATH%\ggrouter.bat -v %CONFIG_DIR%\spring-router-ssl.xml >> %IGNITE_HOME%\work\log\router-ssl-%%G.log 2>&1"
+FOR /L %%G IN (1,1,1) DO start "Router #%%G" /low /MIN cmd /C "%BIN_PATH%\igniterouter.bat -v %CONFIG_DIR%\spring-router.xml >> %IGNITE_HOME%\work\log\router-%%G.log 2>&1"
+FOR /L %%G IN (1,1,1) DO start "SSL Router #%%G" /low /MIN cmd /C "%BIN_PATH%\igniterouter.bat -v %CONFIG_DIR%\spring-router-ssl.xml >> %IGNITE_HOME%\work\log\router-ssl-%%G.log 2>&1"
 
 echo Wait 10 seconds while routers started.
 ping -n 10 127.0.0.1 > NUL

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/bin/start-nodes.sh
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/bin/start-nodes.sh b/modules/clients/src/test/bin/start-nodes.sh
index 739a81e..cb68204 100644
--- a/modules/clients/src/test/bin/start-nodes.sh
+++ b/modules/clients/src/test/bin/start-nodes.sh
@@ -63,7 +63,7 @@ do
     LOG_FILE=${IGNITE_HOME}/work/log/node-${iter}.log
 
     echo Start node ${iter}: ${LOG_FILE}
-    nohup /bin/bash $BIN_PATH/ggstart.sh $CONFIG_DIR/spring-server-node.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
+    nohup /bin/bash $BIN_PATH/ignite.sh $CONFIG_DIR/spring-server-node.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
 done
 
 for iter in {1..2}
@@ -71,7 +71,7 @@ do
     LOG_FILE=${IGNITE_HOME}/work/log/node-ssl-${iter}.log
 
     echo Start SSL node ${iter}: ${LOG_FILE}
-    nohup /bin/bash $BIN_PATH/ggstart.sh $CONFIG_DIR/spring-server-ssl-node.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
+    nohup /bin/bash $BIN_PATH/ignite.sh $CONFIG_DIR/spring-server-ssl-node.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
 done
 
 echo Wait 60 seconds while nodes start.
@@ -79,14 +79,14 @@ sleep 60
 
 LOG_FILE=${IGNITE_HOME}/work/log/router.log
 echo Start Router: ${LOG_FILE}
-nohup /bin/bash $BIN_PATH/ggrouter.sh $CONFIG_DIR/spring-router.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
+nohup /bin/bash $BIN_PATH/igniterouter.sh $CONFIG_DIR/spring-router.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
 
 # Disable hostname verification for self-signed certificates.
 export JVM_OPTS="${JVM_OPTS} -DIGNITE_DISABLE_HOSTNAME_VERIFIER=true"
 
 LOG_FILE=${IGNITE_HOME}/work/log/router-ssl.log
 echo Start Router SSL: ${LOG_FILE}
-nohup /bin/bash $BIN_PATH/ggrouter.sh $CONFIG_DIR/spring-router-ssl.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
+nohup /bin/bash $BIN_PATH/igniterouter.sh $CONFIG_DIR/spring-router-ssl.xml -v < /dev/null > ${LOG_FILE} 2>&1 &
 
 echo Wait 30 seconds while router starts.
 sleep 30

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/resources/spring-cache.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-cache.xml b/modules/clients/src/test/resources/spring-cache.xml
index b675635..a2e62a9 100644
--- a/modules/clients/src/test/resources/spring-cache.xml
+++ b/modules/clients/src/test/resources/spring-cache.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} examples/config/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} examples/config/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("examples/config/example-cache.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/resources/spring-router-ssl.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-router-ssl.xml b/modules/clients/src/test/resources/spring-router-ssl.xml
index e4906c9..bf1a342 100644
--- a/modules/clients/src/test/resources/spring-router-ssl.xml
+++ b/modules/clients/src/test/resources/spring-router-ssl.xml
@@ -21,7 +21,7 @@
     Default rest router configuration.
 
     This file is automatically scanned by
-    $IGNITE_HOME/bin/ggrouter.sh and $IGNITE_HOME/bin/ggrouter.bat
+    $IGNITE_HOME/bin/igniterouter.sh and $IGNITE_HOME/bin/igniterouter.bat
     for org.gridgain.client.router.GridTcpRestRouterConfiguration and
     org.gridgain.client.router.GridHttpRestRouterConfiguration bean definitions.
     First found are used to start corresponding router instances.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/resources/spring-router.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-router.xml b/modules/clients/src/test/resources/spring-router.xml
index 09e68d8..ba078f5 100644
--- a/modules/clients/src/test/resources/spring-router.xml
+++ b/modules/clients/src/test/resources/spring-router.xml
@@ -21,7 +21,7 @@
     Default rest router configuration.
 
     This file is automatically scanned by
-    $IGNITE_HOME/bin/ggrouter.sh and $IGNITE_HOME/bin/ggrouter.bat
+    $IGNITE_HOME/bin/igniterouter.sh and $IGNITE_HOME/bin/igniterouter.bat
     for org.gridgain.client.router.GridTcpRestRouterConfiguration and
     org.gridgain.client.router.GridHttpRestRouterConfiguration bean definitions.
     First found are used to start corresponding router instances.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/resources/spring-server-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-node.xml b/modules/clients/src/test/resources/spring-server-node.xml
index 690fd7d..ccfcf0f 100644
--- a/modules/clients/src/test/resources/spring-server-node.xml
+++ b/modules/clients/src/test/resources/spring-server-node.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/clients/src/test/resources/spring-server-ssl-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-ssl-node.xml b/modules/clients/src/test/resources/spring-server-ssl-node.xml
index e02727d..68774da 100644
--- a/modules/clients/src/test/resources/spring-server-ssl-node.xml
+++ b/modules/clients/src/test/resources/spring-server-ssl-node.xml
@@ -21,7 +21,7 @@
     GridGain Spring configuration file to startup grid cache.
 
     When starting a standalone GridGain node, you need to execute the following command:
-    {IGNITE_HOME}/bin/ggstart.{bat|sh} path-to-this-file/example-cache.xml
+    {IGNITE_HOME}/bin/ignite.{bat|sh} path-to-this-file/example-cache.xml
 
     When starting GridGain from Java IDE, pass path to this file into GridGain:
     GridGain.start("path-to-this-file/example-benchmark.xml");

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/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 c518ec8..6613fdd 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteCluster.java
@@ -312,7 +312,7 @@ public interface IgniteCluster extends ClusterGroup, IgniteAsyncSupport {
      * Restarts nodes satisfying optional set of predicates.
      * <p>
      * <b>NOTE:</b> this command only works for grid nodes started with GridGain
-     * {@code ggstart.sh} or {@code ggstart.bat} scripts.
+     * {@code ignite.sh} or {@code ignite.bat} scripts.
      *
      * @throws IgniteCheckedException In case of error.
      */
@@ -322,7 +322,7 @@ public interface IgniteCluster extends ClusterGroup, IgniteAsyncSupport {
      * Restarts nodes defined by provided IDs.
      * <p>
      * <b>NOTE:</b> this command only works for grid nodes started with GridGain
-     * {@code ggstart.sh} or {@code ggstart.bat} scripts.
+     * {@code ignite.sh} or {@code ignite.bat} scripts.
      *
      * @param ids IDs defining nodes to restart.
      * @throws IgniteCheckedException In case of error.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
index ff7a9b6..7e672f1 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteFs.java
@@ -39,8 +39,8 @@ import java.util.*;
  * This API is fully thread-safe and you can use it from several threads.
  * <h1 class="header">GGFS Configuration</h1>
  * The simplest way to run a GridGain node with configured file system is to pass
- * special configuration file included in GridGain distribution to {@code ggstart.sh} or
- * {@code ggstart.bat} scripts, like this: {@code ggstart.sh config/hadoop/default-config.xml}
+ * special configuration file included in GridGain distribution to {@code ignite.sh} or
+ * {@code ignite.bat} scripts, like this: {@code ignite.sh config/hadoop/default-config.xml}
  * <p>
  * {@code GGFS} can be started as a data node or as a client node. Data node is responsible for
  * caching data, while client node is responsible for basic file system operations and accessing

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/IgniteLogger.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteLogger.java b/modules/core/src/main/java/org/apache/ignite/IgniteLogger.java
index 0c7dd32..9245e6b 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteLogger.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteLogger.java
@@ -60,7 +60,7 @@ import org.jetbrains.annotations.*;
  * will operate in normal un-suppressed logging mode. Note that all output in "quiet" mode is
  * done through standard output (STDOUT).
  * <p>
- * Note that GridGain's standard startup scripts <tt>$IGNITE_HOME/bin/ggstart.{sh|bat}</tt> start
+ * Note that GridGain's standard startup scripts <tt>$IGNITE_HOME/bin/ignite.{sh|bat}</tt> start
  * by default in "quiet" mode. Both scripts accept {@code -v} arguments to turn off "quiet" mode.
  */
 @GridToStringExclude

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
index 0af1487..2e3b6aa 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteSystemProperties.java
@@ -114,7 +114,7 @@ public final class IgniteSystemProperties {
      * of Ignite. In quiet mode, only warning and errors are printed into the log
      * additionally to a shortened version of standard output on the start.
      * <p>
-     * Note that if you use <tt>ggstart.{sh|bat}</tt> scripts to start Ignite they
+     * Note that if you use <tt>ignite.{sh|bat}</tt> scripts to start Ignite they
      * start by default in quiet mode. You can supply <tt>-v</tt> flag to override it.
      */
     public static final String IGNITE_QUIET = "IGNITE_QUIET";
@@ -135,7 +135,7 @@ public final class IgniteSystemProperties {
     /**
      * Name of the system property defining success file name. This file
      * is used with auto-restarting functionality when Ignite is started
-     * by supplied <tt>ggstart.{bat|sh}</tt> scripts.
+     * by supplied <tt>ignite.{bat|sh}</tt> scripts.
      */
     public static final String IGNITE_SUCCESS_FILE = "IGNITE_SUCCESS_FILE";
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/Ignition.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/Ignition.java b/modules/core/src/main/java/org/apache/ignite/Ignition.java
index ee878ca..478021c 100644
--- a/modules/core/src/main/java/org/apache/ignite/Ignition.java
+++ b/modules/core/src/main/java/org/apache/ignite/Ignition.java
@@ -85,7 +85,7 @@ public class Ignition {
      * for a JVM to restart itself from Java application and therefore we rely on
      * external tools to provide that capability.
      * <p>
-     * Note that standard <tt>ggstart.{sh|bat}</tt> scripts support restarting when
+     * Note that standard <tt>ignite.{sh|bat}</tt> scripts support restarting when
      * JVM process exits with this code.
      */
     public static final int RESTART_EXIT_CODE = 250;
@@ -226,7 +226,7 @@ public class Ignition {
      * should be responsible for stopping it.
      * <p>
      * Note also that restarting functionality only works with the tools that specifically
-     * support GridGain's protocol for restarting. Currently only standard <tt>ggstart.{sh|bat}</tt>
+     * support GridGain's protocol for restarting. Currently only standard <tt>ignite.{sh|bat}</tt>
      * scripts support restarting of JVM GridGain's process.
      *
      * @param cancel If {@code true} then all jobs currently executing on

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/client/router/GridRouterFactory.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/client/router/GridRouterFactory.java b/modules/core/src/main/java/org/apache/ignite/client/router/GridRouterFactory.java
index d8ea4f4..4d44c2f 100644
--- a/modules/core/src/main/java/org/apache/ignite/client/router/GridRouterFactory.java
+++ b/modules/core/src/main/java/org/apache/ignite/client/router/GridRouterFactory.java
@@ -34,7 +34,7 @@ import java.util.concurrent.*;
  * See {@link GridTcpRouter} for example on how to configure and start embedded router.
  * <h1 class="header">Standalone router startup</h1>
  * Alternatively you can run routers as a standalone processes by executing
- * {@code IGNITE_HOME/bin/ggrouter.sh} or {@code IGNITE_HOME/bin/ggrouter.bat}.
+ * {@code IGNITE_HOME/bin/igniterouter.sh} or {@code IGNITE_HOME/bin/igniterouter.bat}.
  * They both accept path to a configuration file as first command line argument.
  * See {@code IGNITE_HOME/config/router/default-router.xml} for configuration example.
  *

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/configuration/IgniteDeploymentMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteDeploymentMode.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteDeploymentMode.java
index e14066c..ba410bc 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteDeploymentMode.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteDeploymentMode.java
@@ -61,7 +61,7 @@ import org.jetbrains.annotations.*;
  * <ol>
  *  <li>
  *      Simply startup stand-alone GridGain nodes by executing
- *      {@code IGNITE_HOME/ggstart.{sh|bat}} scripts.
+ *      {@code IGNITE_HOME/ignite.{sh|bat}} scripts.
  *  </li>
  *  <li>
  *      Now, all jobs executing locally or remotely can have a single instance of cache

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/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 4bd44d6..dc9d81d 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
@@ -1678,7 +1678,7 @@ public class IgniteKernal extends ClusterGroupAdapter implements IgniteEx, Ignit
         if (ctx.isEnterprise())
             U.quietAndInfo(log, "To start GUI Management & Monitoring run ggvisorui.{sh|bat}");
         else
-            U.quietAndInfo(log, "To start Console Management & Monitoring run ggvisorcmd.{sh|bat}");
+            U.quietAndInfo(log, "To start Console Management & Monitoring run ignitevisorcmd.{sh|bat}");
     }
 
     /**
@@ -1718,7 +1718,7 @@ public class IgniteKernal extends ClusterGroupAdapter implements IgniteEx, Ignit
                     U.quiet(false, "  ^-- Logging to file '" +  fileName + '\'');
 
                 U.quiet(false,
-                    "  ^-- To see **FULL** console log here add -DIGNITE_QUIET=false or \"-v\" to ggstart.{sh|bat}",
+                    "  ^-- To see **FULL** console log here add -DIGNITE_QUIET=false or \"-v\" to ignite.{sh|bat}",
                     "");
             }
 
@@ -2226,7 +2226,7 @@ public class IgniteKernal extends ClusterGroupAdapter implements IgniteEx, Ignit
 
     /**
      * Whether or not node restart is enabled. Node restart us supported when this node was started
-     * with {@code bin/ggstart.{sh|bat}} script using {@code -r} argument. Node can be
+     * with {@code bin/ignite.{sh|bat}} script using {@code -r} argument. Node can be
      * programmatically restarted using {@link org.apache.ignite.Ignition#restart(boolean)}} method.
      *
      * @return {@code True} if restart mode is enabled, {@code false} otherwise.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/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 0f062dd..7dd9e73 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
@@ -336,7 +336,7 @@ public class IgnitionEx {
      * should be responsible for stopping it.
      * <p>
      * Note also that restarting functionality only works with the tools that specifically
-     * support GridGain's protocol for restarting. Currently only standard <tt>ggstart.{sh|bat}</tt>
+     * support GridGain's protocol for restarting. Currently only standard <tt>ignite.{sh|bat}</tt>
      * scripts support restarting of JVM GridGain's process.
      *
      * @param cancel If {@code true} then all jobs currently executing on

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/lifecycle/LifecycleBean.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/lifecycle/LifecycleBean.java b/modules/core/src/main/java/org/apache/ignite/lifecycle/LifecycleBean.java
index b6366b1..0095661 100644
--- a/modules/core/src/main/java/org/apache/ignite/lifecycle/LifecycleBean.java
+++ b/modules/core/src/main/java/org/apache/ignite/lifecycle/LifecycleBean.java
@@ -66,7 +66,7 @@ import org.apache.ignite.*;
  * If you need to tie your application logic into GridGain lifecycle,
  * you can configure lifecycle beans via standard grid configuration, add your
  * application library dependencies into {@code IGNITE_HOME/libs} folder, and
- * simply start {@code IGNITE_HOME/ggstart.{sh|bat}} scripts.
+ * simply start {@code IGNITE_HOME/ignite.{sh|bat}} scripts.
  * <p>
  * <h1 class="header">Configuration</h1>
  * Grid lifecycle beans can be configured programmatically as follows:

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/plugin/segmentation/GridSegmentationPolicy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/plugin/segmentation/GridSegmentationPolicy.java b/modules/core/src/main/java/org/apache/ignite/plugin/segmentation/GridSegmentationPolicy.java
index e1d297c..bed865c 100644
--- a/modules/core/src/main/java/org/apache/ignite/plugin/segmentation/GridSegmentationPolicy.java
+++ b/modules/core/src/main/java/org/apache/ignite/plugin/segmentation/GridSegmentationPolicy.java
@@ -27,7 +27,7 @@ public enum GridSegmentationPolicy {
      * When segmentation policy is {@code RESTART_JVM}, all listeners will receive
      * {@link org.apache.ignite.events.IgniteEventType#EVT_NODE_SEGMENTED} event and then JVM will be restarted.
      * Note, that this will work <b>only</b> if GridGain is started with {@link org.apache.ignite.startup.cmdline.CommandLineStartup}
-     * via standard {@code ggstart.{sh|bat}} shell script.
+     * via standard {@code ignite.{sh|bat}} shell script.
      */
     RESTART_JVM,
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineStartup.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineStartup.java b/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineStartup.java
index 7ee575a..52d5f20 100644
--- a/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineStartup.java
+++ b/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineStartup.java
@@ -47,7 +47,7 @@ import static org.apache.ignite.internal.GridProductImpl.*;
  * parameter which is Spring XML configuration file path. You can run this class from command
  * line without parameters to get help message.
  * <p>
- * Note that scripts {@code ${IGNITE_HOME}/bin/ggstart.{sh|bat}} shipped with GridGain use
+ * Note that scripts {@code ${IGNITE_HOME}/bin/ignite.{sh|bat}} shipped with GridGain use
  * this startup and you can use them as an example.
  */
 @SuppressWarnings({"CallToSystemExit"})
@@ -144,23 +144,23 @@ public final class CommandLineStartup {
         if (errMsg != null)
             X.error(errMsg);
 
-        String runner = System.getProperty(IGNITE_PROG_NAME, "ggstart.{sh|bat}");
+        String runner = System.getProperty(IGNITE_PROG_NAME, "ignite.{sh|bat}");
 
         int space = runner.indexOf(' ');
 
         runner = runner.substring(0, space == -1 ? runner.length() : space);
 
         if (showUsage) {
-            boolean ggstart = runner.contains("ggstart.");
+            boolean ignite = runner.contains("ignite.");
 
             X.error(
                 "Usage:",
-                "    " + runner + (ggstart ? " [?]|[path {-v}]|[-i]" : " [?]|[-v]"),
+                "    " + runner + (ignite ? " [?]|[path {-v}]|[-i]" : " [?]|[-v]"),
                 "    Where:",
                 "    ?, /help, -help - show this message.",
                 "    -v              - verbose mode (quiet by default).");
 
-            if (ggstart) {
+            if (ignite) {
                 X.error(
                     "    -i              - interactive mode (choose configuration file from list).",
                     "    path            - path to Spring XML configuration file.",

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineTransformer.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineTransformer.java b/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineTransformer.java
index e9e3726..2a29095 100644
--- a/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineTransformer.java
+++ b/modules/core/src/main/java/org/apache/ignite/startup/cmdline/CommandLineTransformer.java
@@ -26,12 +26,12 @@ import java.util.*;
  * Windows batch usage variables.
  * <p>
  * The idea behind the workaround is:<br>
- * 1. User runs ggstart.bat with some args.<br>
- * 2. ggstart.bat calls parseargs.bat with all that args.<br>
+ * 1. User runs ignite.bat with some args.<br>
+ * 2. ignite.bat calls parseargs.bat with all that args.<br>
  * 3. parsearg.bat runs this class with all that args.<br>
  * 4. This class transforms the args and prints them out.<br>
  * 5. parseargs.bat splits the output of this class and sets each variable it found.<br>
- * 6. ggstart.bat uses environment variables as if they were defined by a user.
+ * 6. ignite.bat uses environment variables as if they were defined by a user.
  * <p>
  *
  * @see <a href="http://jcommander.org/">JCommander command line parameters parsing library</a>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/bin/start-nodes-custom.bat
----------------------------------------------------------------------
diff --git a/modules/core/src/test/bin/start-nodes-custom.bat b/modules/core/src/test/bin/start-nodes-custom.bat
index ad4829b..51fbce0 100644
--- a/modules/core/src/test/bin/start-nodes-custom.bat
+++ b/modules/core/src/test/bin/start-nodes-custom.bat
@@ -19,4 +19,4 @@ if %SCRIPT_DIR:~-1,1% == \ set SCRIPT_DIR=%SCRIPT_DIR:~0,-1%
 
 :: -np option is mandatory, if it is not provided then we will wait for a user input,
 :: as a result ggservice windows service hangs forever
-call "%SCRIPT_DIR%\..\..\..\..\..\bin\ggstart.bat" -v -np modules\core\src\test\config\spring-start-nodes-attr.xml
+call "%SCRIPT_DIR%\..\..\..\..\..\bin\ignite.bat" -v -np modules\core\src\test\config\spring-start-nodes-attr.xml

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7e8ea4f1/modules/core/src/test/bin/start-nodes-custom.sh
----------------------------------------------------------------------
diff --git a/modules/core/src/test/bin/start-nodes-custom.sh b/modules/core/src/test/bin/start-nodes-custom.sh
index 6845b79..75dba94 100755
--- a/modules/core/src/test/bin/start-nodes-custom.sh
+++ b/modules/core/src/test/bin/start-nodes-custom.sh
@@ -18,4 +18,4 @@ SCRIPT_DIR=$(cd $(dirname "$0"); pwd)
 
 BIN_DIR="${SCRIPT_DIR}"/../../../../..
 
-"${BIN_DIR}"/bin/ggstart.sh -v modules/core/src/test/config/spring-start-nodes-attr.xml
+"${BIN_DIR}"/bin/ignite.sh -v modules/core/src/test/config/spring-start-nodes-attr.xml


[26/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

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


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

Branch: refs/heads/ignite-16
Commit: c98118f0df4cbdad7b66ffa14501f18a72d8df00
Parents: 2ec1cb2 71442e2
Author: AKuznetsov <ak...@gridgain.com>
Authored: Fri Jan 30 17:36:05 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Fri Jan 30 17:36:05 2015 +0700

----------------------------------------------------------------------
 .../util/ipc/shmem/IpcSharedMemoryNativeLoaderSelfTest.java      | 2 +-
 .../java/org/apache/ignite/messaging/GridMessagingSelfTest.java  | 2 +-
 .../ignite/internal/processors/hadoop/GridHadoopClassLoader.java | 4 ++--
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------



[49/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' into ignite-16

Posted by vo...@apache.org.
Merge branch 'sprint-1' into ignite-16

Conflicts:
	modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/SampleValue.java


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

Branch: refs/heads/ignite-16
Commit: 2636e2c1163fac1b86fbcbe0fcec8d4dadaf8aea
Parents: d0444b7 61a70d9
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Mon Feb 2 13:31:31 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Mon Feb 2 13:31:31 2015 +0300

----------------------------------------------------------------------
 assembly/libs/readme.txt                        |     4 +-
 assembly/release-base-fabric.xml                |     4 +-
 assembly/release-base.xml                       |     6 +-
 assembly/release-hadoop.xml                     |     6 +-
 bin/ggrouter.bat                                |    33 -
 bin/ggrouter.sh                                 |    50 -
 bin/ggstart.bat                                 |   228 -
 bin/ggstart.sh                                  |   176 -
 bin/ggvisorcmd.bat                              |   144 -
 bin/ggvisorcmd.sh                               |   124 -
 bin/ignite.bat                                  |   228 +
 bin/ignite.sh                                   |   176 +
 bin/igniterouter.bat                            |    33 +
 bin/igniterouter.sh                             |    50 +
 bin/ignitevisorcmd.bat                          |   144 +
 bin/ignitevisorcmd.sh                           |   124 +
 bin/include/functions.sh                        |    42 +-
 bin/include/hadoop-classpath.bat                |     2 +-
 bin/include/hadoop-classpath.sh                 |     4 +-
 bin/include/parseargs.bat                       |     2 +-
 bin/include/parseargs.sh                        |     6 +-
 bin/include/service.sh                          |    12 +-
 bin/include/setenv.bat                          |    28 +-
 bin/include/setenv.sh                           |    34 +-
 bin/include/target-classpath.bat                |     8 +-
 bin/include/target-classpath.sh                 |    14 +-
 bin/setup-hadoop.bat                            |     2 +-
 bin/setup-hadoop.sh                             |    12 +-
 config/gridgain-log4j.xml                       |   152 -
 config/hadoop/default-config.xml                |     2 +-
 config/ignite-log4j.xml                         |   152 +
 config/java.util.logging.properties             |    16 +-
 config/router/default-router.xml                |     2 +-
 docs/hadoop_readme.md                           |     6 +-
 docs/ignite_readme.md                           |    12 +-
 docs/mapred-site.ignite.xml                     |     2 +-
 examples/config/example-cache.xml               |     2 +-
 examples/config/example-streamer.xml            |     8 +-
 examples/config/filesystem/example-ggfs.xml     |     2 +-
 examples/config/servlet/WEB-INF/web.xml         |     4 +-
 examples/rest/http-rest-example.php             |     2 +-
 examples/rest/memcache-rest-example.php         |     2 +-
 .../compute/ComputeBroadcastExample.java        |     2 +-
 .../compute/ComputeCallableExample.java         |     2 +-
 .../examples/compute/ComputeClosureExample.java |     2 +-
 .../compute/ComputeContinuousMapperExample.java |     2 +-
 .../compute/ComputeExecutorServiceExample.java  |     2 +-
 .../ComputeFibonacciContinuationExample.java    |     2 +-
 .../compute/ComputeProjectionExample.java       |     2 +-
 .../examples/compute/ComputeReducerExample.java |     2 +-
 .../compute/ComputeRunnableExample.java         |     2 +-
 .../compute/ComputeScheduleExample.java         |     2 +-
 .../examples/compute/ComputeTaskMapExample.java |     2 +-
 .../compute/ComputeTaskSplitExample.java        |     2 +-
 .../compute/montecarlo/CreditRiskExample.java   |     2 +-
 .../examples/datagrid/CacheAffinityExample.java |     2 +-
 .../examples/datagrid/CacheApiExample.java      |     2 +-
 .../datagrid/CacheContinuousQueryExample.java   |     2 +-
 .../datagrid/CacheDataLoaderExample.java        |     2 +-
 .../examples/datagrid/CacheEventsExample.java   |     2 +-
 .../datagrid/CachePopularNumbersExample.java    |     2 +-
 .../examples/datagrid/CachePutGetExample.java   |     2 +-
 .../examples/datagrid/CacheQueryExample.java    |     2 +-
 .../datagrid/CacheTransactionExample.java       |     2 +-
 .../datastructures/CacheAtomicLongExample.java  |     2 +-
 .../CacheAtomicReferenceExample.java            |     2 +-
 .../CacheAtomicSequenceExample.java             |     2 +-
 .../CacheAtomicStampedExample.java              |     2 +-
 .../CacheCountDownLatchExample.java             |     2 +-
 .../datastructures/CacheQueueExample.java       |     2 +-
 .../datastructures/CacheSetExample.java         |     2 +-
 .../hibernate/HibernateL2CacheExample.java      |     2 +-
 .../starschema/CacheStarSchemaExample.java      |     2 +-
 .../ignite/examples/events/EventsExample.java   |     2 +-
 .../ignite/examples/ggfs/GgfsExample.java       |     2 +-
 .../examples/ggfs/GgfsMapReduceExample.java     |     2 +-
 .../ignite/examples/ggfs/GgfsNodeStartup.java   |     4 +-
 .../examples/messaging/MessagingExample.java    |     2 +-
 .../messaging/MessagingPingPongExample.java     |     2 +-
 .../MessagingPingPongListenActorExample.java    |     2 +-
 .../misc/deployment/DeploymentExample.java      |     2 +-
 .../misc/springbean/SpringBeanExample.java      |     2 +-
 .../examples/services/ServicesExample.java      |     2 +-
 .../streaming/StreamingCheckInExample.java      |     8 +-
 .../StreamingPopularNumbersExample.java         |     8 +-
 .../streaming/StreamingPriceBarsExample.java    |     8 +-
 .../StreamingRunningAverageExample.java         |     8 +-
 .../apache/ignite/examples/ComputeExample.java  |    59 +
 .../ignite/examples/MessagingExample.java       |   166 +
 .../org/gridgain/examples/ComputeExample.java   |    59 -
 .../org/gridgain/examples/MessagingExample.java |   166 -
 .../examples/ScalarCacheAffinityExample1.scala  |     2 +-
 .../examples/ScalarCacheAffinityExample2.scala  |     2 +-
 .../ScalarCacheAffinitySimpleExample.scala      |     2 +-
 .../scalar/examples/ScalarCacheExample.scala    |     2 +-
 .../ScalarCachePopularNumbersExample.scala      |     2 +-
 .../examples/ScalarCacheQueryExample.scala      |     2 +-
 .../scalar/examples/ScalarClosureExample.scala  |     2 +-
 .../examples/ScalarContinuationExample.scala    |     2 +-
 .../examples/ScalarCreditRiskExample.scala      |     2 +-
 .../examples/ScalarPiCalculationExample.scala   |     2 +-
 .../scalar/examples/ScalarPingPongExample.scala |     2 +-
 .../scalar/examples/ScalarPrimeExample.scala    |     2 +-
 .../scalar/examples/ScalarScheduleExample.scala |     2 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |     2 +-
 .../scalar/examples/ScalarTaskExample.scala     |     2 +-
 .../examples/ScalarWorldShortestMapReduce.scala |     2 +-
 .../GridMonteCarloExamplesSelfTest.java         |     4 +-
 .../testsuites/IgniteExamplesSelfTestSuite.java |     2 +-
 .../ScalarExamplesSelfTestSuite.scala           |     2 +-
 ipc/shmem/Makefile.am                           |     2 +-
 ipc/shmem/Makefile.in                           |     2 +-
 ipc/shmem/configure                             |     4 +-
 ipc/shmem/configure.ac                          |     2 +-
 ipc/shmem/ggshmem/Makefile.am                   |    23 -
 ipc/shmem/ggshmem/Makefile.in                   |   589 -
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |   882 --
 ipc/shmem/igniteshmem/Makefile.am               |    23 +
 ipc/shmem/igniteshmem/Makefile.in               |   589 +
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |   882 ++
 ipc/shmem/include/Makefile.am                   |     2 +-
 ipc/shmem/include/Makefile.in                   |     2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |   117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |   117 -
 ipc/shmem/readme.txt                            |     9 +-
 modules/aop/readme.txt                          |     2 +-
 .../GridifySetToXXXNonSpringAopSelfTest.java    |    20 +-
 .../GridifySetToXXXSpringAopSelfTest.java       |    20 +-
 .../ignite/gridify/NonSpringAopSelfTest.java    |    20 +-
 .../optimized/OptimizedMarshallerAopTest.java   |     4 +-
 .../testsuites/IgniteAopSelfTestSuite.java      |     2 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |    20 +-
 modules/aws/readme.txt                          |     2 +-
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |     4 +-
 modules/clients/src/test/bin/start-nodes-ssh.sh |     2 +-
 modules/clients/src/test/bin/start-nodes.cmd    |    24 +-
 modules/clients/src/test/bin/start-nodes.sh     |    34 +-
 .../client/ClientDefaultCacheSelfTest.java      |     4 +-
 .../client/ClientTopologyCacheSelfTest.java     |     2 +-
 .../ClientPropertiesConfigurationSelfTest.java  |     4 +-
 .../integration/ClientAbstractSelfTest.java     |     6 +-
 .../client/router/ClientFailedInitSelfTest.java |     4 +-
 .../client/router/RouterFactorySelfTest.java    |     4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |     4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |     2 +-
 .../rest/TaskCommandHandlerSelfTest.java        |     4 +-
 .../protocols/tcp/TcpRestParserSelfTest.java    |     6 +-
 .../src/test/resources/jetty/rest-jetty-ssl.xml |    10 +-
 .../src/test/resources/jetty/rest-jetty.xml     |     8 +-
 .../test/resources/jetty/router-jetty-ssl.xml   |     8 +-
 .../src/test/resources/jetty/router-jetty.xml   |     8 +-
 modules/clients/src/test/resources/log4j.xml    |     4 +-
 .../clients/src/test/resources/spring-cache.xml |     2 +-
 .../src/test/resources/spring-router-ssl.xml    |     4 +-
 .../src/test/resources/spring-router.xml        |     4 +-
 .../src/test/resources/spring-server-node.xml   |     2 +-
 .../test/resources/spring-server-ssl-node.xml   |     2 +-
 .../java/META-INF/native/linux64/libggshmem.so  |   Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |   Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |   Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |   Bin 0 -> 33116 bytes
 .../apache/ignite/IgniteBasicWarmupClosure.java |     6 +-
 .../apache/ignite/IgniteCheckedException.java   |     2 +-
 .../java/org/apache/ignite/IgniteCluster.java   |     6 +-
 .../java/org/apache/ignite/IgniteException.java |     2 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |     4 +-
 .../java/org/apache/ignite/IgniteLogger.java    |     6 +-
 .../apache/ignite/IgniteSystemProperties.java   |   192 +-
 .../main/java/org/apache/ignite/Ignition.java   |    16 +-
 .../apache/ignite/cache/CacheConfiguration.java |     3 +-
 .../CacheConsistentHashAffinityFunction.java    |     2 +-
 .../apache/ignite/cache/query/CacheQuery.java   |     3 +-
 .../cache/query/CacheQuerySqlFunction.java      |     4 +-
 .../cache/query/annotations/QuerySqlField.java  |     2 +-
 .../query/annotations/QuerySqlFunction.java     |     2 +-
 .../apache/ignite/cache/store/CacheStore.java   |     2 +-
 .../apache/ignite/client/GridClientCompute.java |     8 +-
 .../ignite/client/router/GridRouterFactory.java |     4 +-
 .../impl/GridRouterCommandLineStartup.java      |     4 +-
 .../router/impl/GridTcpRouterNioParser.java     |     4 +-
 .../apache/ignite/compute/gridify/Gridify.java  |     2 +-
 .../ignite/compute/gridify/GridifySetToSet.java |     4 +-
 .../compute/gridify/GridifySetToValue.java      |     4 +-
 .../ClientConnectionConfiguration.java          |    16 +-
 .../configuration/GridQueryConfiguration.java   |   201 -
 .../configuration/IgniteConfiguration.java      |    80 +-
 .../configuration/IgniteDeploymentMode.java     |     4 +-
 .../configuration/IgniteQueryConfiguration.java |   201 +
 .../apache/ignite/fs/IgniteFsConfiguration.java |     2 +-
 .../ignite/internal/GridKernalContextImpl.java  |     2 +-
 .../apache/ignite/internal/GridLoggerProxy.java |     4 +-
 .../internal/GridPerformanceSuggestions.java    |     4 +-
 .../apache/ignite/internal/GridProductImpl.java |     2 +-
 .../ignite/internal/IgniteInternalFuture.java   |     8 +-
 .../apache/ignite/internal/IgniteKernal.java    |    32 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |    54 +-
 .../GridDeploymentPerLoaderStore.java           |    20 +-
 .../GridDeploymentPerVersionStore.java          |     4 +-
 .../processors/cache/GridCacheAdapter.java      |    23 +-
 .../cache/GridCacheDeploymentManager.java       |   163 +-
 .../cache/GridCacheMvccCandidate.java           |     4 +-
 .../GridCachePartitionExchangeManager.java      |     2 +-
 .../cache/GridCachePreloaderAdapter.java        |     2 +-
 .../processors/cache/GridCacheProcessor.java    |     9 +-
 .../processors/cache/GridCacheStoreManager.java |    49 +-
 .../processors/cache/GridCacheSwapManager.java  |     3 +-
 .../processors/cache/GridCacheUtils.java        |     2 +-
 .../cache/GridCacheWriteBehindStore.java        |    19 +-
 .../processors/cache/IgniteCacheProxy.java      |    24 +-
 .../distributed/dht/GridDhtLocalPartition.java  |     2 +-
 .../dht/GridPartitionedGetFuture.java           |     2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |     4 +-
 .../preloader/GridDhtPartitionDemandPool.java   |     2 +-
 .../distributed/near/GridNearAtomicCache.java   |     2 +-
 .../distributed/near/GridNearGetFuture.java     |     2 +-
 .../transactions/IgniteTxLocalAdapter.java      |    42 +-
 .../cache/transactions/IgniteTxManager.java     |    10 +-
 .../internal/processors/fs/GridGgfsServer.java  |    26 +-
 .../processors/fs/GridGgfsServerManager.java    |     8 +-
 .../processors/fs/IgniteFsNoopProcessor.java    |     2 +-
 .../processors/fs/IgniteFsProcessor.java        |    12 +-
 .../processors/fs/IgniteFsProcessorAdapter.java |     2 +-
 .../processors/job/GridJobProcessor.java        |     2 +-
 .../jobmetrics/GridJobMetricsProcessor.java     |     4 +-
 .../handlers/log/GridLogCommandHandler.java     |     4 +-
 .../handlers/task/GridTaskCommandHandler.java   |     2 +-
 .../protocols/tcp/GridClientPacketType.java     |     4 +-
 .../protocols/tcp/GridMemcachedMessage.java     |     4 +-
 .../rest/protocols/tcp/GridTcpRestParser.java   |    18 +-
 .../service/GridServiceProcessor.java           |     2 +-
 .../streamer/GridStreamProcessor.java           |    11 +-
 .../processors/streamer/IgniteStreamerEx.java   |     3 +-
 .../processors/streamer/IgniteStreamerImpl.java |     5 +-
 .../internal/util/GridConcurrentFactory.java    |     3 +-
 .../internal/util/GridConfigurationFinder.java  |     4 +-
 .../internal/util/GridReflectionCache.java      |     3 +-
 .../apache/ignite/internal/util/GridUtils.java  |  9100 -----------
 .../ignite/internal/util/IgniteUtils.java       |  9141 +++++++++++
 .../util/future/GridFinishedFuture.java         |     2 +-
 .../internal/util/future/GridFutureAdapter.java |     4 +-
 .../internal/util/io/GridUnsafeDataInput.java   |     2 +-
 .../internal/util/io/GridUnsafeDataOutput.java  |     2 +-
 .../internal/util/ipc/GridIpcEndpoint.java      |    49 -
 .../util/ipc/GridIpcEndpointBindException.java  |    47 -
 .../util/ipc/GridIpcEndpointFactory.java        |    84 -
 .../internal/util/ipc/GridIpcEndpointType.java  |    29 -
 .../util/ipc/GridIpcServerEndpoint.java         |    73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |    66 -
 .../internal/util/ipc/GridIpcToNioAdapter.java  |   250 -
 .../ignite/internal/util/ipc/IpcEndpoint.java   |    49 +
 .../util/ipc/IpcEndpointBindException.java      |    47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |    84 +
 .../internal/util/ipc/IpcEndpointType.java      |    29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |    73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |    66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |   250 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |    87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |   179 -
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |    87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |   179 +
 .../GridIpcOutOfSystemResourcesException.java   |    59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |   336 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |    67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |   171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |    99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |   242 -
 ...cSharedMemoryOperationTimedoutException.java |    59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |    80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |   707 -
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |   374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |   242 -
 .../shmem/IpcOutOfSystemResourcesException.java |    59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |   336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |    67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |   171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |    99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |   261 +
 ...cSharedMemoryOperationTimedoutException.java |    59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |    80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   707 +
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |   374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |   242 +
 .../internal/util/nio/GridBufferedParser.java   |     2 +-
 .../nio/GridConnectionBytesVerifyFilter.java    |    18 +-
 .../util/nio/GridShmemCommunicationClient.java  |     4 +-
 .../util/nodestart/GridNodeStartUtils.java      |    10 +-
 .../util/offheap/unsafe/GridUnsafeMemory.java   |     2 +-
 .../util/portscanner/GridJmxPortFinder.java     |     4 +-
 .../apache/ignite/internal/util/typedef/X.java  |     4 +-
 .../internal/util/typedef/internal/U.java       |     4 +-
 .../visor/misc/VisorResolveHostNameTask.java    |     2 +-
 .../visor/node/VisorBasicConfiguration.java     |    26 +-
 .../visor/node/VisorEmailConfiguration.java     |    14 +-
 .../visor/node/VisorLifecycleConfiguration.java |     2 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |     4 +-
 .../visor/node/VisorRestConfiguration.java      |     4 +-
 .../internal/visor/query/VisorQueryUtils.java   |     4 +-
 .../apache/ignite/jdbc/IgniteJdbcDriver.java    |     2 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |    27 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |     4 +-
 .../ignite/logger/java/IgniteJavaLogger.java    |     4 +-
 .../java/IgniteJavaLoggerFileHandler.java       |     4 +-
 .../optimized/IgniteOptimizedMarshaller.java    |     4 +-
 .../segmentation/GridSegmentationPolicy.java    |     2 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |     4 +-
 .../ignite/spi/IgniteSpiManagementMBean.java    |     2 +-
 .../ignite/spi/checkpoint/CheckpointSpi.java    |     2 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |     6 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    36 +-
 .../ignite/spi/deployment/DeploymentSpi.java    |     2 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |     4 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |     2 +-
 .../TcpDiscoveryMulticastIpFinder.java          |    18 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |     2 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |     2 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |     4 +-
 .../ignite/startup/BasicWarmupClosure.java      |     6 +-
 .../startup/cmdline/CommandLineStartup.java     |    18 +-
 .../startup/cmdline/CommandLineTransformer.java |     8 +-
 .../ignite/thread/IgniteThreadFactory.java      |     2 +-
 .../apache/ignite/transactions/IgniteTx.java    |     2 +-
 .../core/src/test/bin/start-nodes-custom.bat    |     2 +-
 modules/core/src/test/bin/start-nodes-custom.sh |     2 +-
 .../spring-cache-client-benchmark-1.xml         |     2 +-
 .../spring-cache-client-benchmark-2.xml         |     2 +-
 .../spring-cache-client-benchmark-3.xml         |     2 +-
 modules/core/src/test/config/example-cache.xml  |     2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |     2 +-
 modules/core/src/test/config/ggfs-shmem.xml     |     2 +-
 modules/core/src/test/config/log4j-test.xml     |     2 +-
 .../core/src/test/config/spring-cache-load.xml  |     2 +-
 .../core/src/test/config/spring-multicache.xml  |     2 +-
 .../average/spring-streamer-average-base.xml    |     2 +-
 .../average/spring-streamer-average-local.xml   |     2 +-
 .../average/spring-streamer-average-random.xml  |     2 +-
 .../config/streamer/spring-streamer-base.xml    |     2 +-
 modules/core/src/test/config/tests.properties   |    10 +-
 .../IgniteExceptionHelpLinksSelfTest.java       |     3 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |     2 +-
 .../internal/GridFactoryVmShutdownTest.java     |     2 +-
 .../ignite/internal/GridHomePathSelfTest.java   |     2 +-
 .../GridNodeVisorAttributesSelfTest.java        |     4 +-
 .../ignite/internal/GridStartStopSelfTest.java  |     2 +-
 .../ignite/internal/GridVersionSelfTest.java    |     8 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |    10 +-
 .../GridCacheAbstractProjectionSelfTest.java    |    50 +
 .../GridCacheAbstractRemoveFailureTest.java     |     6 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |     6 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |     4 +-
 .../GridCacheReturnValueTransferSelfTest.java   |     2 +-
 .../cache/GridCacheSlowTxWarnTest.java          |     2 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |     6 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |     4 +-
 .../GridCacheMultiNodeDataStructureTest.java    |     4 +-
 .../GridCacheNodeFailureAbstractTest.java       |     2 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |   288 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |     2 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |     6 +-
 .../IgniteCacheTxStoreSessionTest.java          |    11 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |     4 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |     4 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    10 +-
 ...artupWithSpecifiedWorkDirectorySelfTest.java |     4 +-
 ...tartupWithUndefinedGridGainHomeSelfTest.java |    10 +-
 .../internal/util/GridTestClockTimer.java       |     6 +-
 .../ignite/internal/util/GridUtilsSelfTest.java |   717 -
 .../internal/util/IgniteUtilsSelfTest.java      |   728 +
 ...GridUnsafeDataOutputArraySizingSelfTest.java |     2 +-
 ...idIpcServerEndpointDeserializerSelfTest.java |   160 -
 .../IpcServerEndpointDeserializerSelfTest.java  |   160 +
 .../ipc/shmem/GgfsSharedMemoryTestClient.java   |    76 +
 .../ipc/shmem/GgfsSharedMemoryTestServer.java   |    71 +
 .../shmem/GridGgfsSharedMemoryTestClient.java   |    76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |    71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |   500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |    36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |    87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |   267 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |    84 -
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |   500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |    36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |    78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |    87 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |   267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |    84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |    65 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |    35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |   133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |   125 -
 .../IpcSharedMemoryBenchmarkParty.java          |    35 +
 .../IpcSharedMemoryBenchmarkReader.java         |   133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |   125 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |     2 +-
 .../loadtest/GridSingleExecutionTest.java       |     4 +-
 .../cache/GridCacheAbstractLoadTest.java        |     2 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |     2 +-
 .../loadtests/cache/GridCacheLoadTest.java      |     2 +-
 .../capacity/spring-capacity-cache.xml          |     2 +-
 .../loadtests/colocation/spring-colocation.xml  |     2 +-
 .../GridContinuousOperationsLoadTest.java       |    18 +-
 .../loadtests/mapper/GridNodeStartup.java       |     4 +-
 .../loadtests/nio/GridNioBenchmarkTest.java     |     2 +-
 .../streamer/GridStreamerIndexLoadTest.java     |     2 +-
 .../ignite/loadtests/util/GridLoadTestArgs.java |     8 +-
 .../ignite/messaging/GridMessagingSelfTest.java |     2 +-
 .../startup/GridRandomCommandLineLoader.java    |    10 +-
 .../ignite/startup/GridVmNodesStarter.java      |     8 +-
 .../GridCommandLineTransformerSelfTest.java     |     6 +-
 .../ignite/testframework/GridTestUtils.java     |    10 +-
 .../config/GridTestProperties.java              |    16 +-
 .../testframework/junits/GridAbstractTest.java  |     4 +-
 .../logger/GridLog4jRollingFileAppender.java    |     4 +-
 .../junits/logger/GridTestLog4jLogger.java      |     8 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |     1 +
 .../ignite/testsuites/IgniteFsTestSuite.java    |     2 +-
 .../IgniteIpcSharedMemorySelfTestSuite.java     |     7 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |     2 +-
 .../src/test/resources/log/gridgain.log.tst     | 13706 -----------------
 .../core/src/test/resources/log/ignite.log.tst  | 13706 +++++++++++++++++
 .../core/src/test/webapp/META-INF/gg-config.xml |     2 +-
 modules/core/src/test/webapp/WEB-INF/web.xml    |     2 +-
 modules/email/readme.txt                        |     2 +-
 modules/hadoop/readme.txt                       |     2 +-
 .../fs/hadoop/v1/GridGgfsHadoopFileSystem.java  |     6 +-
 .../fs/hadoop/v2/GridGgfsHadoopFileSystem.java  |     6 +-
 .../apache/ignite/hadoop/GridHadoopSetup.java   |    16 +-
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |    10 +-
 .../hadoop/GridHadoopClassLoader.java           |     4 +-
 .../GridHadoopExternalTaskExecutor.java         |     2 +-
 .../child/GridHadoopExternalProcessStarter.java |     2 +-
 .../GridHadoopExternalCommunication.java        |    26 +-
 .../GridHadoopIpcToNioAdapter.java              |     6 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |     2 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |     2 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |     2 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |     2 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |     2 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |     2 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |     8 +-
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |     4 +-
 .../ignite/fs/IgniteFsEventsTestSuite.java      |     4 +-
 .../hadoop/GridHadoopPopularWordsTest.java      |     6 +-
 .../hadoop/GridHadoopCommandLineTest.java       |     4 +-
 modules/hibernate/readme.txt                    |     2 +-
 .../hibernate/CacheHibernateBlobStore.java      |   593 +
 .../CacheHibernateBlobStoreEntry.hbm.xml        |    29 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |    86 +
 .../hibernate/GridCacheHibernateBlobStore.java  |   593 -
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |    29 -
 .../GridCacheHibernateBlobStoreEntry.java       |    86 -
 ...idHibernateL2CacheTransactionalSelfTest.java |     2 +-
 .../CacheHibernateBlobStoreSelfTest.java        |   108 +
 .../GridCacheHibernateBlobStoreSelfTest.java    |   108 -
 .../cache/store/hibernate/hibernate.cfg.xml     |     2 +-
 .../testsuites/IgniteHibernateTestSuite.java    |     2 +-
 modules/indexing/readme.txt                     |     2 +-
 .../processors/query/h2/IgniteH2Indexing.java   |     8 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |     2 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |     2 +-
 .../query/h2/sql/GridQueryParsingTest.java      |     2 +-
 modules/jcl/readme.txt                          |     2 +-
 .../apache/ignite/logger/jcl/GridJclLogger.java |     4 +-
 modules/jta/readme.txt                          |     2 +-
 .../apache/ignite/cache/jta/CacheTmLookup.java  |    50 +
 .../ignite/cache/jta/GridCacheTmLookup.java     |    50 -
 .../cache/jta/jndi/CacheJndiTmLookup.java       |    74 +
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |    74 -
 .../jta/reflect/CacheReflectionTmLookup.java    |   115 +
 .../reflect/GridCacheReflectionTmLookup.java    |   115 -
 .../processors/cache/jta/CacheJtaManager.java   |     4 +-
 ...CacheJtaConfigurationValidationSelfTest.java |     2 +-
 .../processors/cache/GridCacheJtaSelfTest.java  |     2 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |     4 +-
 modules/log4j/readme.txt                        |     2 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |     8 +-
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |     8 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |     4 +-
 modules/rest-http/readme.txt                    |     2 +-
 .../http/jetty/GridJettyRestProtocol.java       |    16 +-
 .../rest/protocols/http/jetty/rest.html         |     6 +-
 modules/scalar/pom.xml                          |     6 +-
 modules/scalar/readme.txt                       |     2 +-
 modules/schedule/readme.txt                     |     2 +-
 .../processors/schedule/ScheduleFutureImpl.java |     4 +-
 modules/slf4j/readme.txt                        |     2 +-
 modules/spring/readme.txt                       |     2 +-
 .../java/org/apache/ignite/IgniteSpring.java    |     2 +-
 .../ignite/cache/spring/SpringCacheManager.java |     6 +-
 .../spring/IgniteSpringProcessorImpl.java       |    10 +-
 .../ignite/internal/GridFactorySelfTest.java    |     2 +-
 modules/ssh/readme.txt                          |     2 +-
 .../util/nodestart/GridNodeCallableImpl.java    |    20 +-
 .../internal/GridNodeStartUtilsSelfTest.java    |     6 +-
 .../GridProjectionStartStopRestartSelfTest.java |     4 +-
 .../ignite/tools/javadoc/GridLinkTaglet.java    |   165 -
 .../ignite/tools/javadoc/IgniteLinkTaglet.java  |   165 +
 .../optimized/OptimizedClassNamesGenerator.java |    18 +-
 modules/urideploy/readme.txt                    |     2 +-
 .../uri/GridUriDeploymentFileProcessor.java     |     2 +-
 .../deployment/uri/GridUriDeploymentSpi.java    |  1367 --
 .../uri/GridUriDeploymentSpiMBean.java          |    53 -
 .../spi/deployment/uri/UriDeploymentSpi.java    |  1367 ++
 .../deployment/uri/UriDeploymentSpiMBean.java   |    53 +
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |     2 +-
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |     2 +-
 .../uri/GridUriDeploymentAbstractSelfTest.java  |     2 +-
 .../GridUriDeploymentClassLoaderSelfTest.java   |     2 +-
 ...riDeploymentClassloaderRegisterSelfTest.java |     4 +-
 .../uri/GridUriDeploymentConfigSelfTest.java    |    10 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |     2 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |     2 +-
 ...loymentMultiScannersErrorThrottlingTest.java |     2 +-
 .../GridUriDeploymentMultiScannersSelfTest.java |     2 +-
 .../uri/GridUriDeploymentSimpleSelfTest.java    |    10 +-
 .../file/GridFileDeploymentSelfTest.java        |     6 +-
 .../GridFileDeploymentUndeploySelfTest.java     |     8 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |     2 +-
 .../http/GridHttpDeploymentSelfTest.java        |     2 +-
 .../IgniteUriDeploymentTestSuite.java           |     3 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |     2 +-
 .../ignite/visor/commands/VisorConsole.scala    |     6 +-
 .../commands/alert/VisorAlertCommand.scala      |     2 +-
 .../config/VisorConfigurationCommand.scala      |     6 +-
 .../ignite/visor/commands/deploy/Packet.scala   |     4 +-
 .../commands/deploy/VisorDeployCommand.scala    |    22 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |     4 +-
 .../commands/events/VisorEventsCommand.scala    |     4 +-
 .../visor/commands/gc/VisorGcCommand.scala      |    13 +-
 .../visor/commands/node/VisorNodeCommand.scala  |     4 +-
 .../ignite/visor/commands/start/Packet.scala    |     6 +-
 .../commands/start/VisorStartCommand.scala      |    16 +-
 .../commands/tasks/VisorTasksCommand.scala      |     4 +-
 .../commands/top/VisorTopologyCommand.scala     |     6 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |     8 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    35 +-
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    25 +-
 .../testsuites/VisorConsoleSelfTestSuite.scala  |     2 +-
 modules/web/readme.txt                          |     2 +-
 .../cache/websession/GridWebSessionFilter.java  |    26 +-
 .../GridServletContextListenerStartup.java      |   181 -
 .../startup/servlet/GridServletStartup.java     |   187 -
 .../IgniteServletContextListenerStartup.java    |   181 +
 .../startup/servlet/IgniteServletStartup.java   |   187 +
 .../internal/websession/WebSessionSelfTest.java |     8 +-
 .../websession/WebSessionServerStart.java       |     2 +-
 modules/yardstick/README.md                     |    67 +
 .../config/benchmark-atomic-win.properties      |    42 +
 .../config/benchmark-atomic.properties          |    48 +
 .../config/benchmark-compute-win.properties     |    45 +
 .../config/benchmark-compute.properties         |    51 +
 .../config/benchmark-query-win.properties       |    43 +
 .../yardstick/config/benchmark-query.properties |    49 +
 .../config/benchmark-tx-win.properties          |    42 +
 .../yardstick/config/benchmark-tx.properties    |    48 +
 .../yardstick/config/benchmark-win.properties   |    50 +
 modules/yardstick/config/benchmark.properties   |    61 +
 modules/yardstick/config/ignite-base-config.xml |   118 +
 .../config/ignite-localhost-config.xml          |    55 +
 .../config/ignite-multicast-config.xml          |    38 +
 modules/yardstick/pom.xml                       |   185 +
 .../yardstick/IgniteAbstractBenchmark.java      |   130 +
 .../yardstick/IgniteBenchmarkArguments.java     |   213 +
 .../org/apache/ignite/yardstick/IgniteNode.java |   191 +
 .../cache/IgniteCacheAbstractBenchmark.java     |    44 +
 .../yardstick/cache/IgniteGetBenchmark.java     |    41 +
 .../yardstick/cache/IgnitePutBenchmark.java     |    42 +
 .../yardstick/cache/IgnitePutGetBenchmark.java  |    47 +
 .../cache/IgnitePutGetTxBenchmark.java          |    52 +
 .../yardstick/cache/IgnitePutTxBenchmark.java   |    43 +
 .../cache/IgniteSqlQueryBenchmark.java          |    94 +
 .../cache/IgniteSqlQueryJoinBenchmark.java      |   118 +
 .../cache/IgniteSqlQueryPutBenchmark.java       |    86 +
 .../yardstick/cache/model/Organization.java     |   110 +
 .../ignite/yardstick/cache/model/Person.java    |   191 +
 .../yardstick/cache/model/SampleValue.java      |    62 +
 .../compute/IgniteAffinityCallBenchmark.java    |    36 +
 .../yardstick/compute/IgniteApplyBenchmark.java |    72 +
 .../compute/IgniteBroadcastBenchmark.java       |    35 +
 .../compute/IgniteExecuteBenchmark.java         |    35 +
 .../yardstick/compute/IgniteRunBenchmark.java   |    71 +
 .../yardstick/compute/model/NoopCallable.java   |    41 +
 .../yardstick/compute/model/NoopTask.java       |    97 +
 pom.xml                                         |    35 +-
 583 files changed, 39143 insertions(+), 35758 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2636e2c1/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2636e2c1/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2636e2c1/modules/core/src/main/java/org/apache/ignite/internal/IgniteKernal.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2636e2c1/modules/core/src/main/java/org/apache/ignite/internal/IgnitionEx.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2636e2c1/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheWriteBehindStore.java
----------------------------------------------------------------------