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

[01/45] incubator-ignite git commit: #IGNITE-86: Do not write log if nothing was undeployed or it was system cache.

Repository: incubator-ignite
Updated Branches:
  refs/heads/ignite-121-logging 42dc66f25 -> e7562eb3a


#IGNITE-86: Do not write log if nothing was undeployed or it was system cache.


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

Branch: refs/heads/ignite-121-logging
Commit: edf0b1851ed95f6819f038e0e870f932af977004
Parents: cd86285
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jan 20 16:24:35 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jan 20 16:24:35 2015 +0300

----------------------------------------------------------------------
 .../grid/kernal/processors/cache/GridCacheDeploymentManager.java  | 3 +++
 1 file changed, 3 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/edf0b185/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
index 92052f5..58fe292 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
@@ -298,6 +298,9 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
                 cacheCtx.near().dht().context().swap().onUndeploy(leftNodeId, ldr) :
                 cacheCtx.swap().onUndeploy(leftNodeId, ldr);
 
+            if (keys.size() == 0 || cacheCtx.system())
+                continue;
+
             U.quietAndWarn(log, "");
             U.quietAndWarn(
                 log,


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

Posted by sb...@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/641a4c87
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/641a4c87
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/641a4c87

Branch: refs/heads/ignite-121-logging
Commit: 641a4c87c91c2a260a7960e8ec942cd0bd97f2d0
Parents: c2c2e7f 673d11b
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 10:02:23 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 10:02:23 2015 +0700

----------------------------------------------------------------------
 .../hibernate/example-hibernate-L2-cache.xml    |  14 +-
 .../ComputeFibonacciContinuationExample.java    |   2 +-
 .../compute/ComputeRunnableExample.java         |   2 +-
 .../datagrid/CacheDataLoaderExample.java        |  15 +-
 .../HibernateL2CacheExampleNodeStartup.java     |   6 +-
 .../examples/ScalarContinuationExample.scala    |   2 +-
 .../apache/ignite/gridify/AbstractAopTest.java  |   2 +-
 .../apache/ignite/gridify/TestGridifyTask.java  |   2 +-
 .../singlesplit/SingleSplitsLoadTest.java       |   2 +-
 .../ignite/client/ClientStartNodeTask.java      |   2 +-
 .../ClientAbstractMultiNodeSelfTest.java        |   1 +
 .../java/org/apache/ignite/IgniteCache.java     |  40 ++-
 .../java/org/apache/ignite/IgniteCluster.java   |   2 +-
 .../java/org/apache/ignite/IgniteCompute.java   |   2 +-
 .../java/org/apache/ignite/IgniteEvents.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/cache/CacheLock.java |  57 ----
 .../ignite/cache/GridCacheVersionedEntry.java   |  82 ++++++
 .../org/apache/ignite/internal/GridKernal.java  |  32 +--
 .../ignite/internal/IgniteClusterAsyncImpl.java |   9 +-
 .../ignite/internal/IgniteComputeImpl.java      |  70 ++---
 .../ignite/internal/IgniteEventsImpl.java       |   9 +-
 .../ignite/internal/IgniteManagedImpl.java      |   2 +-
 .../ignite/internal/IgniteMessagingImpl.java    |  12 +-
 .../internal/executor/GridExecutorService.java  |   2 +-
 .../managers/communication/GridIoManager.java   |   3 +-
 .../processors/cache/CacheLockImpl.java         | 132 ++++++---
 .../processors/cache/GridCacheAdapter.java      |   8 +-
 .../cache/GridCacheAtomicVersionComparator.java |   2 +
 .../cache/GridCacheBatchSwapEntry.java          |   1 +
 .../cache/GridCacheClearAllRunnable.java        |   1 +
 .../processors/cache/GridCacheContext.java      |  44 +++
 .../processors/cache/GridCacheEntryEx.java      |   9 +
 .../processors/cache/GridCacheEntryInfo.java    |   1 +
 .../cache/GridCacheEvictionManager.java         |   1 +
 .../cache/GridCacheEvictionRequest.java         |   1 +
 .../cache/GridCacheExplicitLockSpan.java        |   1 +
 .../processors/cache/GridCacheFuture.java       |   1 +
 .../cache/GridCacheLockTimeoutException.java    |   2 +
 .../processors/cache/GridCacheMapEntry.java     | 117 ++++++--
 .../processors/cache/GridCacheMvcc.java         |   1 +
 .../cache/GridCacheMvccCandidate.java           |   1 +
 .../processors/cache/GridCacheMvccManager.java  |   1 +
 .../cache/GridCacheOffheapSwapEntry.java        |   1 +
 .../processors/cache/GridCacheProcessor.java    |   1 +
 .../processors/cache/GridCacheProjectionEx.java |   1 +
 .../cache/GridCacheProjectionImpl.java          |   1 +
 .../processors/cache/GridCacheProxyImpl.java    |   1 +
 .../cache/GridCacheSharedContext.java           |   1 +
 .../processors/cache/GridCacheStoreManager.java |  19 +-
 .../processors/cache/GridCacheSwapEntry.java    |   1 +
 .../cache/GridCacheSwapEntryImpl.java           |   1 +
 .../processors/cache/GridCacheSwapManager.java  |   1 +
 .../processors/cache/GridCacheTtlManager.java   |   1 +
 .../cache/GridCacheUpdateAtomicResult.java      |   7 +-
 .../processors/cache/GridCacheUtils.java        |   1 +
 .../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      |  33 +--
 .../distributed/GridCacheCommittedTxInfo.java   |   2 +-
 .../distributed/GridCacheMappedVersion.java     |   2 +-
 ...ridCacheOptimisticCheckPreparedTxFuture.java |   1 +
 ...idCacheOptimisticCheckPreparedTxRequest.java |   2 +-
 ...dCacheOptimisticCheckPreparedTxResponse.java |   2 +-
 .../GridCachePerThreadTxCommitBuffer.java       |   1 +
 ...dCachePessimisticCheckCommittedTxFuture.java |   1 +
 ...CachePessimisticCheckCommittedTxRequest.java |   2 +-
 ...achePessimisticCheckCommittedTxResponse.java |   1 +
 .../distributed/GridCacheTtlUpdateRequest.java  |   1 +
 .../distributed/GridCacheTxCommitBuffer.java    |   2 +-
 .../distributed/GridDistributedBaseMessage.java |   1 +
 .../GridDistributedCacheAdapter.java            |   1 +
 .../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         |  48 ++--
 .../distributed/dht/GridDhtCacheAdapter.java    |   1 +
 .../distributed/dht/GridDhtCacheEntry.java      |   1 +
 .../cache/distributed/dht/GridDhtGetFuture.java |   1 +
 .../distributed/dht/GridDhtLocalPartition.java  |   1 +
 .../distributed/dht/GridDhtLockFuture.java      |   1 +
 .../distributed/dht/GridDhtLockRequest.java     |   1 +
 .../distributed/dht/GridDhtLockResponse.java    |   1 +
 .../dht/GridDhtTransactionalCacheAdapter.java   |   1 +
 .../distributed/dht/GridDhtTxFinishFuture.java  |   1 +
 .../distributed/dht/GridDhtTxFinishRequest.java |   1 +
 .../dht/GridDhtTxFinishResponse.java            |   2 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   1 +
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   1 +
 .../distributed/dht/GridDhtTxPrepareFuture.java |   1 +
 .../dht/GridDhtTxPrepareRequest.java            |   1 +
 .../dht/GridDhtTxPrepareResponse.java           |   1 +
 .../cache/distributed/dht/GridDhtTxRemote.java  |   1 +
 .../dht/GridPartitionedGetFuture.java           |   1 +
 .../dht/atomic/GridDhtAtomicCache.java          |  11 +-
 .../GridDhtAtomicDeferredUpdateResponse.java    |   1 +
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   1 +
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   1 +
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   1 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   1 +
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   1 +
 .../atomic/GridNearAtomicUpdateResponse.java    |   1 +
 .../dht/colocated/GridDhtColocatedCache.java    |   1 +
 .../colocated/GridDhtColocatedLockFuture.java   |   1 +
 .../colocated/GridDhtDetachedCacheEntry.java    |   1 +
 .../GridDhtPartitionsAbstractMessage.java       |   1 +
 .../GridDhtPartitionsExchangeFuture.java        |   1 +
 .../preloader/GridDhtPartitionsFullMessage.java |   1 +
 .../GridDhtPartitionsSingleMessage.java         |   1 +
 .../distributed/near/GridNearAtomicCache.java   |   1 +
 .../distributed/near/GridNearCacheAdapter.java  |   1 +
 .../near/GridNearCacheClearAllRunnable.java     |   1 +
 .../distributed/near/GridNearCacheEntry.java    |   1 +
 .../distributed/near/GridNearGetFuture.java     |   1 +
 .../distributed/near/GridNearGetRequest.java    |   1 +
 .../distributed/near/GridNearGetResponse.java   |   1 +
 .../distributed/near/GridNearLockFuture.java    |   1 +
 .../distributed/near/GridNearLockRequest.java   |   1 +
 .../distributed/near/GridNearLockResponse.java  |   1 +
 .../near/GridNearTransactionalCache.java        |   1 +
 .../near/GridNearTxFinishFuture.java            |   1 +
 .../near/GridNearTxFinishRequest.java           |   2 +-
 .../near/GridNearTxFinishResponse.java          |   1 +
 .../cache/distributed/near/GridNearTxLocal.java |   1 +
 .../near/GridNearTxPrepareFuture.java           |   1 +
 .../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  |   1 +
 .../cache/local/GridLocalCacheEntry.java        |   1 +
 .../cache/local/GridLocalLockFuture.java        |   1 +
 .../cache/local/GridLocalTxFuture.java          |   1 +
 .../local/atomic/GridLocalAtomicCache.java      |   1 +
 .../cache/query/GridCacheQueryManager.java      |   4 +-
 .../cache/transactions/IgniteTxAdapter.java     |  52 +++-
 .../cache/transactions/IgniteTxEntry.java       |   1 +
 .../cache/transactions/IgniteTxEx.java          |   1 +
 .../cache/transactions/IgniteTxHandler.java     |   1 +
 .../transactions/IgniteTxLocalAdapter.java      |  53 ++--
 .../cache/transactions/IgniteTxLocalEx.java     |   1 +
 .../cache/transactions/IgniteTxManager.java     |   1 +
 .../cache/transactions/IgniteTxProxyImpl.java   |   2 +-
 .../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 ++
 .../dataload/IgniteDataLoaderImpl.java          |  29 +-
 .../dr/GridDrDataLoadCacheUpdater.java          |   3 +-
 .../processors/dr/GridRawVersionedEntry.java    | 210 --------------
 .../processors/dr/GridVersionedEntry.java       |  80 ------
 .../processors/fs/GridGgfsAsyncImpl.java        |   7 +-
 .../internal/processors/fs/GridGgfsImpl.java    |   2 +-
 .../handlers/cache/GridCacheCommandHandler.java |   4 +-
 .../cache/GridCacheQueryCommandHandler.java     |   4 +-
 .../handlers/task/GridTaskCommandHandler.java   |   4 +-
 .../apache/ignite/internal/util/GridUtils.java  |  15 +-
 .../GridTcpCommunicationMessageAdapter.java     |   1 +
 .../GridTcpCommunicationMessageState.java       |   3 +-
 .../apache/ignite/lang/IgniteAsyncSupport.java  |   2 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |  35 ++-
 .../ignite/lang/IgniteAsyncSupported.java       |   2 +-
 .../ignite/IgniteCacheAffinitySelfTest.java     | 283 +++++++++++++++++++
 .../apache/ignite/IgniteCacheAffinityTest.java  | 283 -------------------
 .../internal/GridCancelOnGridStopSelfTest.java  |   2 +-
 .../GridCancelledJobsMetricsSelfTest.java       |   2 +-
 .../internal/GridContinuousTaskSelfTest.java    |   4 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |   2 +-
 .../GridFailoverCustomTopologySelfTest.java     |   2 +-
 .../GridJobMasterLeaveAwareSelfTest.java        |  34 +--
 .../internal/GridMultipleJobsSelfTest.java      |   2 +-
 .../internal/GridProjectionAbstractTest.java    |  20 +-
 .../ignite/internal/GridReduceSelfTest.java     |   2 +-
 .../GridTaskCancelSingleNodeSelfTest.java       |   2 +-
 .../internal/GridTaskExecutionSelfTest.java     |   2 +-
 .../GridTaskInstanceExecutionSelfTest.java      |   2 +-
 .../internal/GridTaskJobRejectSelfTest.java     |   2 +-
 .../GridDeploymentMessageCountSelfTest.java     |   4 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  92 +++---
 .../cache/GridCacheBasicApiAbstractTest.java    | 229 ++++++++-------
 .../GridCacheConcurrentTxMultiNodeTest.java     |   2 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |   3 +-
 .../GridCacheFinishPartitionsSelfTest.java      |  25 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |  13 +-
 .../GridCacheGroupLockFailoverSelfTest.java     |   2 +-
 .../cache/GridCacheMvccFlagsTest.java           |   1 +
 .../cache/GridCacheMvccPartitionedSelfTest.java |   1 +
 .../processors/cache/GridCacheMvccSelfTest.java |   1 +
 .../cache/GridCacheNestedTxAbstractTest.java    |  13 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |  11 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   4 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   6 +
 .../cache/GridCacheVersionSelfTest.java         |   1 +
 .../cache/IgniteCacheInvokeAbstractTest.java    |   4 +-
 .../GridCacheCountDownLatchSelfTest.java        |   2 +-
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   4 +-
 .../GridCacheAbstractJobExecutionTest.java      |   2 +-
 .../distributed/GridCacheLockAbstractTest.java  |  62 ++--
 .../GridCacheMultiNodeLockAbstractTest.java     | 139 +++++----
 ...cOriginatingNodeFailureAbstractSelfTest.java |   2 +-
 .../dht/GridCacheColocatedDebugTest.java        |  43 +--
 .../dht/GridCacheGlobalLoadTest.java            |   2 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   1 +
 .../near/GridCacheNearMultiNodeSelfTest.java    |  25 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |  42 +--
 .../near/GridCacheNearReadersSelfTest.java      |  13 +-
 .../near/GridCachePartitionedBasicApiTest.java  |   4 +-
 .../GridCachePartitionedEntryLockSelfTest.java  |   2 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |   2 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |   2 +-
 .../GridCacheReplicatedBasicApiTest.java        |   4 +-
 .../GridCacheEvictionLockUnlockSelfTest.java    |   7 +-
 .../local/GridCacheLocalBasicApiSelfTest.java   |   4 +-
 .../cache/local/GridCacheLocalLockSelfTest.java |  81 +++---
 .../GridCacheLocalMultithreadedSelfTest.java    |  85 +++---
 .../closure/GridClosureProcessorSelfTest.java   |  16 +-
 .../continuous/GridEventConsumeSelfTest.java    |   8 +-
 .../continuous/GridMessageListenSelfTest.java   |   4 +-
 .../processors/fs/GridGgfsTaskSelfTest.java     |   2 +-
 .../GridServiceProcessorAbstractSelfTest.java   |  18 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |   6 +-
 .../streamer/GridStreamerSelfTest.java          |   2 +-
 .../loadtest/GridSingleExecutionTest.java       |   2 +-
 .../loadtests/colocation/GridTestMain.java      |   2 +-
 .../multisplit/GridMultiSplitsLoadTest.java     |   2 +-
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   2 +-
 .../ignite/loadtests/dsi/GridDsiClient.java     |   2 +-
 .../loadtests/hashmap/GridCacheTestContext.java |   1 +
 .../loadtests/hashmap/GridHashMapLoadTest.java  |   1 +
 ...GridJobExecutionLoadTestClientSemaphore.java |   2 +-
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |   2 +-
 .../loadtests/job/GridJobLoadTestSubmitter.java |   2 +-
 .../mergesort/GridMergeSortLoadTask.java        |   2 +-
 .../ignite/messaging/GridMessagingSelfTest.java |   4 +-
 .../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 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |  21 +-
 ...ClusterMetricsSnapshotSerializeSelfTest.java |  52 +++-
 .../cache/GridAbstractCacheStoreSelfTest.java   |   2 +-
 .../junits/common/GridCommonAbstractTest.java   |   8 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   2 +-
 .../hadoop/GridHadoopClassLoader.java           |   2 +-
 .../hadoop/GridHadoopPopularWordsTest.java      |   4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   4 +-
 .../hibernate/GridHibernateRegionFactory.java   |  10 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |   8 +-
 .../GridProjectionStartStopRestartSelfTest.java |   2 +-
 .../commands/tasks/VisorTasksCommandSpec.scala  |   2 +-
 pom.xml                                         |   4 +-
 296 files changed, 3269 insertions(+), 2290 deletions(-)
----------------------------------------------------------------------


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


[07/45] incubator-ignite git commit: #IGNITE-86: remove unused param leftNodeId from onUndeploy function

Posted by sb...@apache.org.
#IGNITE-86: remove  unused param leftNodeId from  onUndeploy function


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

Branch: refs/heads/ignite-121-logging
Commit: 581949346ac506a13569f51c43a95a642e9e6c74
Parents: 4174a74
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 14:49:12 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 14:49:12 2015 +0300

----------------------------------------------------------------------
 .../deployment/GridDeploymentPerLoaderStore.java    | 16 ++++++----------
 1 file changed, 6 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/58194934/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
index 9deb83c..a079e02 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
@@ -29,8 +29,6 @@ import org.gridgain.grid.kernal.managers.eventstorage.*;
 import org.gridgain.grid.kernal.processors.timeout.*;
 import org.gridgain.grid.util.*;
 import org.gridgain.grid.util.typedef.internal.*;
-import org.jetbrains.annotations.*;
-
 import java.util.*;
 
 import static org.apache.ignite.events.IgniteEventType.*;
@@ -91,7 +89,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
                     }
 
                     for (IsolatedDeployment dep : rmv)
-                        dep.recordUndeployed(nodeId);
+                        dep.recordUndeployed();
                 }
             }
         };
@@ -122,7 +120,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         for (IsolatedDeployment dep : cp)
-            dep.recordUndeployed(null);
+            dep.recordUndeployed();
 
         if (log.isDebugEnabled())
             log.debug(stopInfo());
@@ -150,7 +148,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         for (IsolatedDeployment dep : rmv)
-            dep.recordUndeployed(null);
+            dep.recordUndeployed();
 
         if (log.isDebugEnabled())
             log.debug("Registered deployment discovery listener: " + discoLsnr);
@@ -351,7 +349,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
                     }
 
                     if (rmv)
-                        dep.recordUndeployed(null);
+                        dep.recordUndeployed();
                 }
             });
         }
@@ -384,7 +382,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         for (IsolatedDeployment dep : undeployed)
-            dep.recordUndeployed(null);
+            dep.recordUndeployed();
     }
 
     /** {@inheritDoc} */
@@ -462,10 +460,8 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
 
         /**
          * Called to record all undeployed classes..
-         *
-         * @param leftNodeId Left node ID.
          */
-        void recordUndeployed(@Nullable UUID leftNodeId) {
+        void recordUndeployed() {
             assert !Thread.holdsLock(mux);
 
             GridEventStorageManager evts = ctx.event();


[41/45] incubator-ignite git commit: #ignite-16: Finished.

Posted by sb...@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-121-logging
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;
         }


[03/45] incubator-ignite git commit: ignite-86 review

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


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

Branch: refs/heads/ignite-121-logging
Commit: c7db90e636a1a2c6c8258aa9d9397d6277a641f0
Parents: 173726f
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Wed Jan 21 20:47:33 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Wed Jan 21 20:47:33 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheDeploymentManager.java     | 11 ++++++-----
 1 file changed, 6 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c7db90e6/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
index 58fe292..17a116e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
@@ -212,7 +212,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
         for (GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
             // Unwind immediately for local and replicate caches.
             // We go through preloader for proper synchronization.
-            if (cacheCtx.isLocal() || cacheCtx.isReplicated())
+            if (cacheCtx.isLocal())
                 cacheCtx.preloader().unwindUndeploys();
         }
     }
@@ -275,7 +275,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
                     }
                 }));
 
-            Collection<K> keys = new LinkedList<>();
+            Collection<K> keys = new ArrayList<>();
 
             for (K k : keySet)
                 keys.add(k);
@@ -298,19 +298,20 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
                 cacheCtx.near().dht().context().swap().onUndeploy(leftNodeId, ldr) :
                 cacheCtx.swap().onUndeploy(leftNodeId, ldr);
 
-            if (keys.size() == 0 || cacheCtx.system())
+            if (cacheCtx.system())
                 continue;
 
             U.quietAndWarn(log, "");
             U.quietAndWarn(
                 log,
-                "Cleared all cache entries for undeployed class loader [[cacheName=" + cacheCtx.namexx() +
+                "Cleared all cache entries for undeployed class loader [cacheName=" + cacheCtx.namexx() +
                     ", undeployCnt=" + keys.size() + ", swapUndeployCnt=" + swapUndeployCnt +
                     ", clsLdr=" + ldr.getClass().getName() + ']',
                 "Cleared all cache entries for undeployed class loader for cache: " + cacheCtx.namexx());
             U.quietAndWarn(
                 log,
-                "  ^-- Cache auto-undeployment happens in SHARED deployment mode (to turn off, switch to CONTINUOUS mode)");
+                "  ^-- Cache auto-undeployment happens in SHARED deployment mode " +
+                    "(to turn off, switch to CONTINUOUS mode)");
             U.quietAndWarn(log, "");
         }
 


[06/45] incubator-ignite git commit: #IGNITE-86: remove unused param leftNodeId from onUndeploy function

Posted by sb...@apache.org.
#IGNITE-86: remove  unused param leftNodeId from  onUndeploy function


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

Branch: refs/heads/ignite-121-logging
Commit: 4174a74c0eca6a1b39c9c9b2ce9edde77379ce7e
Parents: 65200e2
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 14:15:42 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 14:15:42 2015 +0300

----------------------------------------------------------------------
 .../deployment/GridDeploymentPerLoaderStore.java        |  4 ++--
 .../deployment/GridDeploymentPerVersionStore.java       |  4 ++--
 .../grid/kernal/processors/cache/GridCacheAdapter.java  |  5 ++---
 .../processors/cache/GridCacheDeploymentManager.java    | 12 +++++-------
 .../kernal/processors/cache/GridCacheProcessor.java     |  5 ++---
 .../kernal/processors/cache/GridCacheSwapManager.java   |  3 +--
 .../kernal/processors/streamer/GridStreamProcessor.java |  5 ++---
 .../kernal/processors/streamer/IgniteStreamerEx.java    |  3 +--
 .../kernal/processors/streamer/IgniteStreamerImpl.java  |  5 ++---
 9 files changed, 19 insertions(+), 27 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
index 41c7c1b..9deb83c 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
@@ -499,8 +499,8 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
 
                 ClassLoader ldr = classLoader();
 
-                ctx.cache().onUndeployed(leftNodeId, ldr);
-                ctx.stream().onUndeployed(leftNodeId, ldr);
+                ctx.cache().onUndeployed(ldr);
+                ctx.stream().onUndeployed(ldr);
 
                 // Clear optimized marshaller's cache. If another marshaller is used, this is no-op.
                 IgniteOptimizedMarshaller.onUndeploy(ldr);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerVersionStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerVersionStore.java b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerVersionStore.java
index 5dbbfaa..317d476 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerVersionStore.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerVersionStore.java
@@ -1259,8 +1259,8 @@ public class GridDeploymentPerVersionStore extends GridDeploymentStoreAdapter {
 
                 ClassLoader ldr = classLoader();
 
-                ctx.cache().onUndeployed(leftNodeId, ldr);
-                ctx.stream().onUndeployed(leftNodeId, ldr);
+                ctx.cache().onUndeployed(ldr);
+                ctx.stream().onUndeployed(ldr);
 
                 // Clear optimized marshaller's cache. If another marshaller is used, this is no-op.
                 IgniteOptimizedMarshaller.onUndeploy(ldr);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
index 4fdfc19..16ee7a7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
@@ -951,11 +951,10 @@ public abstract class GridCacheAdapter<K, V> implements GridCache<K, V>,
     /**
      * Undeploys and removes all entries for class loader.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader to undeploy.
      */
-    public void onUndeploy(@Nullable UUID leftNodeId, ClassLoader ldr) {
-        ctx.deploy().onUndeploy(leftNodeId, ldr);
+    public void onUndeploy(ClassLoader ldr) {
+        ctx.deploy().onUndeploy(ldr);
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
index 17a116e..39d998e 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
@@ -194,10 +194,9 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     /**
      * Undeploys given class loader.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader to undeploy.
      */
-    public void onUndeploy(@Nullable final UUID leftNodeId, final ClassLoader ldr) {
+    public void onUndeploy(final ClassLoader ldr) {
         assert ldr != null;
 
         if (log.isDebugEnabled())
@@ -205,7 +204,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
 
         undeploys.add(new CA() {
             @Override public void apply() {
-                onUndeploy0(leftNodeId, ldr);
+                onUndeploy0(ldr);
             }
         });
 
@@ -218,10 +217,9 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     }
 
     /**
-     * @param leftNodeId Left node ID.
      * @param ldr Loader.
      */
-    private void onUndeploy0(@Nullable final UUID leftNodeId, final ClassLoader ldr) {
+    private void onUndeploy0(final ClassLoader ldr) {
         for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
             GridCacheAdapter<K, V> cache = cacheCtx.cache();
 
@@ -295,8 +293,8 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
 
             // Examine swap for entries to undeploy.
             int swapUndeployCnt = cacheCtx.isNear() ?
-                cacheCtx.near().dht().context().swap().onUndeploy(leftNodeId, ldr) :
-                cacheCtx.swap().onUndeploy(leftNodeId, ldr);
+                cacheCtx.near().dht().context().swap().onUndeploy(ldr) :
+                cacheCtx.swap().onUndeploy(ldr);
 
             if (cacheCtx.system())
                 continue;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
index cb683d1..ab845b8 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
@@ -1766,13 +1766,12 @@ public class GridCacheProcessor extends GridProcessorAdapter {
      * Callback invoked by deployment manager for whenever a class loader
      * gets undeployed.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader.
      */
-    public void onUndeployed(@Nullable UUID leftNodeId, ClassLoader ldr) {
+    public void onUndeployed(ClassLoader ldr) {
         if (!ctx.isStopping())
             for (GridCacheAdapter<?, ?> cache : caches.values())
-                cache.onUndeploy(leftNodeId, ldr);
+                cache.onUndeploy(ldr);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheSwapManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheSwapManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheSwapManager.java
index 5cbfb30..cde0bbe 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheSwapManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheSwapManager.java
@@ -1434,11 +1434,10 @@ public class GridCacheSwapManager<K, V> extends GridCacheManagerAdapter<K, V> {
     }
 
     /**
-     * @param leftNodeId Left Node ID.
      * @param ldr Undeployed class loader.
      * @return Undeploy count.
      */
-    public int onUndeploy(UUID leftNodeId, ClassLoader ldr) {
+    public int onUndeploy(ClassLoader ldr) {
         if (cctx.portableEnabled())
             return 0;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/GridStreamProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/GridStreamProcessor.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/GridStreamProcessor.java
index c687610..b5857f4 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/GridStreamProcessor.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/GridStreamProcessor.java
@@ -351,11 +351,10 @@ public class GridStreamProcessor extends GridProcessorAdapter {
     /**
      * Callback for undeployed class loaders.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader.
      */
-    public void onUndeployed(UUID leftNodeId, ClassLoader ldr) {
+    public void onUndeployed(ClassLoader ldr) {
         for (IgniteStreamerEx streamer : map.values())
-            streamer.onUndeploy(leftNodeId, ldr);
+            streamer.onUndeploy(ldr);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerEx.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerEx.java
index de11622..6c729e7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerEx.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerEx.java
@@ -81,10 +81,9 @@ public interface IgniteStreamerEx extends IgniteStreamer {
     /**
      * Callback for undeployed class loaders. All deployed events will be removed from window and local storage.
      *
-     * @param leftNodeId Left node ID which caused undeployment.
      * @param undeployedLdr Undeployed class loader.
      */
-    public void onUndeploy(UUID leftNodeId, ClassLoader undeployedLdr);
+    public void onUndeploy(ClassLoader undeployedLdr);
 
     /**
      * Callback executed when streamer query completes.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4174a74c/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
index eb77b51..542fc49 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.java
@@ -689,10 +689,9 @@ public class IgniteStreamerImpl implements IgniteStreamerEx, Externalizable {
     }
 
     /** {@inheritDoc} */
-    @Override public void onUndeploy(UUID leftNodeId, ClassLoader undeployedLdr) {
+    @Override public void onUndeploy(ClassLoader undeployedLdr) {
         if (log.isDebugEnabled())
-            log.debug("Processing undeployment event [leftNodeId=" + leftNodeId +
-                ", undeployedLdr=" + undeployedLdr + ']');
+            log.debug("Processing undeployment event undeployedLdr=" + undeployedLdr + ']');
 
         unwindUndeploys(undeployedLdr, true);
     }


[45/45] incubator-ignite git commit: # ignite-121 : fix review comments

Posted by sb...@apache.org.
# ignite-121 : fix review comments


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

Branch: refs/heads/ignite-121-logging
Commit: e7562eb3adfae95e30980de650f8db4a73940d74
Parents: 72b557a
Author: Artem SHutak <as...@gridgain.com>
Authored: Mon Feb 2 19:54:47 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Mon Feb 2 19:54:47 2015 +0300

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


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/e7562eb3/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 b7c57cc..1dcbab9 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
@@ -2007,7 +2007,7 @@ public class IgnitionEx {
                 Exception log4jInitException = null;
 
                 if (cfgLog == null) {
-                    Class<?> log4jCls = null;
+                    Class<?> log4jCls;
 
                     try {
                         log4jCls = Class.forName("org.apache.ignite.logger.log4j.IgniteLog4jLogger");
@@ -2065,8 +2065,8 @@ public class IgnitionEx {
                     ((IgniteLoggerNodeIdAware)cfgLog).setNodeId(nodeId);
 
                 if (log4jInitException != null)
-                    U.warn(cfgLog, "Failed to initialize IgniteLog4jLogger (falling back to standard java logging): " +
-                            log4jInitException.getCause());
+                    U.warn(cfgLog, "Failed to initialize IgniteLog4jLogger (falling back to standard java logging): "
+                            + log4jInitException.getCause());
 
                 return cfgLog;
             }


[23/45] incubator-ignite git commit: # IGNITE-102: Added configs.

Posted by sb...@apache.org.
# IGNITE-102: Added configs.


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

Branch: refs/heads/ignite-121-logging
Commit: c9aadf0778d818b00fe20d549dc81f7082d79652
Parents: 99e3fa6
Author: AKuznetsov <ak...@gridgain.com>
Authored: Wed Jan 28 13:05:49 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Wed Jan 28 13:05:49 2015 +0700

----------------------------------------------------------------------
 .../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 ++++++
 .../yardstick/cache/GetBenchmarkIgnite.java     |  41 -------
 .../yardstick/cache/IgniteGetBenchmark.java     |  41 +++++++
 15 files changed, 731 insertions(+), 41 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-atomic-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-atomic-win.properties b/modules/yardstick/config/benchmark-atomic-win.properties
new file mode 100644
index 0000000..97132f0
--- /dev/null
+++ b/modules/yardstick/config/benchmark-atomic-win.properties
@@ -0,0 +1,42 @@
+::
+:: Contains benchmarks for ATOMIC cache.
+::
+
+:: JVM options.
+set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
+
+:: Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+:: set JVM_OPTS=%JVM_OPTS%^
+::  -XX:+UseParNewGC^
+::  -XX:+UseConcMarkSweepGC^
+::  -XX:+UseTLAB^
+::  -XX:NewSize=128m^
+::  -XX:MaxNewSize=128m^
+::  -XX:MaxTenuringThreshold=0^
+::  -XX:SurvivorRatio=1024^
+::  -XX:+UseCMSInitiatingOccupancyOnly^
+::  -XX:CMSInitiatingOccupancyFraction=60
+
+:: List of default probes.
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+:: Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+:: Probe point writer class name.
+:: BENCHMARK_WRITER=
+
+:: Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+set SERVER_HOSTS=localhost,localhost
+
+:: Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+set DRIVER_HOSTS=localhost
+
+:: Remote username.
+:: set REMOTE_USER=
+
+:: Run configuration which contains all benchmarks.
+:: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+set CONFIGS=^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-atomic.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-atomic.properties b/modules/yardstick/config/benchmark-atomic.properties
new file mode 100644
index 0000000..d10259d
--- /dev/null
+++ b/modules/yardstick/config/benchmark-atomic.properties
@@ -0,0 +1,48 @@
+#
+# Contains benchmarks for ATOMIC cache.
+#
+
+# JVM options.
+JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
+
+# Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+# JVM_OPTS=${JVM_OPTS}" \
+#  -XX:+UseParNewGC \
+#  -XX:+UseConcMarkSweepGC \
+#  -XX:+UseTLAB \
+#  -XX:NewSize=128m \
+#  -XX:MaxNewSize=128m \
+#  -XX:MaxTenuringThreshold=0 \
+#  -XX:SurvivorRatio=1024 \
+#  -XX:+UseCMSInitiatingOccupancyOnly \
+#  -XX:CMSInitiatingOccupancyFraction=60 \
+#"
+
+# List of default probes.
+# Add DStatProbe or VmStatProbe if your OS supports it (e.g. if running on Linux).
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+# Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+# Probe point writer class name.
+# BENCHMARK_WRITER=
+
+# Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+SERVER_HOSTS=localhost,localhost
+
+# Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+DRIVER_HOSTS=localhost
+
+# Remote username.
+# REMOTE_USER=
+
+# Number of nodes, used to wait for the specified number of nodes to start.
+nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS} | tr ',' '\n' | wc -l`))
+
+# Run configuration.
+# Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+CONFIGS="\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup\
+"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-compute-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-compute-win.properties b/modules/yardstick/config/benchmark-compute-win.properties
new file mode 100644
index 0000000..06c7f6a
--- /dev/null
+++ b/modules/yardstick/config/benchmark-compute-win.properties
@@ -0,0 +1,45 @@
+::
+:: Contains benchmarks for distributed computations.
+::
+
+:: JVM options.
+set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
+
+:: Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+:: set JVM_OPTS=%JVM_OPTS%^
+::  -XX:+UseParNewGC^
+::  -XX:+UseConcMarkSweepGC^
+::  -XX:+UseTLAB^
+::  -XX:NewSize=128m^
+::  -XX:MaxNewSize=128m^
+::  -XX:MaxTenuringThreshold=0^
+::  -XX:SurvivorRatio=1024^
+::  -XX:+UseCMSInitiatingOccupancyOnly^
+::  -XX:CMSInitiatingOccupancyFraction=60
+
+:: List of default probes.
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+:: Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+:: Probe point writer class name.
+:: BENCHMARK_WRITER=
+
+:: Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+set SERVER_HOSTS=localhost,localhost
+
+:: Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+set DRIVER_HOSTS=localhost
+
+:: Remote username.
+:: set REMOTE_USER=
+
+:: Run configuration which contains all benchmarks.
+:: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+set CONFIGS=^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-compute.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-compute.properties b/modules/yardstick/config/benchmark-compute.properties
new file mode 100644
index 0000000..d90a954
--- /dev/null
+++ b/modules/yardstick/config/benchmark-compute.properties
@@ -0,0 +1,51 @@
+#
+# Contains benchmarks for distributed computations.
+#
+
+# JVM options.
+JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
+
+# Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+# JVM_OPTS=${JVM_OPTS}" \
+#  -XX:+UseParNewGC \
+#  -XX:+UseConcMarkSweepGC \
+#  -XX:+UseTLAB \
+#  -XX:NewSize=128m \
+#  -XX:MaxNewSize=128m \
+#  -XX:MaxTenuringThreshold=0 \
+#  -XX:SurvivorRatio=1024 \
+#  -XX:+UseCMSInitiatingOccupancyOnly \
+#  -XX:CMSInitiatingOccupancyFraction=60 \
+#"
+
+# List of default probes.
+# Add DStatProbe or VmStatProbe if your OS supports it (e.g. if running on Linux).
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+# Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+# Probe point writer class name.
+# BENCHMARK_WRITER=
+
+# Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+SERVER_HOSTS=localhost,localhost
+
+# Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+DRIVER_HOSTS=localhost
+
+# Remote username.
+# REMOTE_USER=
+
+# Number of nodes, used to wait for the specified number of nodes to start.
+nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS} | tr ',' '\n' | wc -l`))
+
+# Run configuration.
+# Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+CONFIGS="\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup\
+"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-query-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query-win.properties b/modules/yardstick/config/benchmark-query-win.properties
new file mode 100644
index 0000000..377bac0
--- /dev/null
+++ b/modules/yardstick/config/benchmark-query-win.properties
@@ -0,0 +1,43 @@
+::
+:: Contains benchmarks for SQL queries.
+::
+
+:: JVM options.
+:: set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
+
+:: Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+set JVM_OPTS=%JVM_OPTS%^
+  -XX:+UseParNewGC^
+  -XX:+UseConcMarkSweepGC^
+  -XX:+UseTLAB^
+  -XX:NewSize=128m^
+  -XX:MaxNewSize=128m^
+  -XX:MaxTenuringThreshold=0^
+  -XX:SurvivorRatio=1024^
+  -XX:+UseCMSInitiatingOccupancyOnly^
+  -XX:CMSInitiatingOccupancyFraction=60
+
+:: List of default probes.
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+:: Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+:: Probe point writer class name.
+:: BENCHMARK_WRITER=
+
+:: Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+set SERVER_HOSTS=localhost,localhost
+
+:: Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+set DRIVER_HOSTS=localhost
+
+:: Remote username.
+:: set REMOTE_USER=
+
+:: Run configuration which contains all benchmarks.
+:: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+set CONFIGS=^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-query.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query.properties b/modules/yardstick/config/benchmark-query.properties
new file mode 100644
index 0000000..b467e0b
--- /dev/null
+++ b/modules/yardstick/config/benchmark-query.properties
@@ -0,0 +1,49 @@
+#
+# Contains benchmarks for SQL queries.
+#
+
+# JVM options.
+# JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
+
+# Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false" \
+  -XX:+UseParNewGC \
+  -XX:+UseConcMarkSweepGC \
+  -XX:+UseTLAB \
+  -XX:NewSize=128m \
+  -XX:MaxNewSize=128m \
+  -XX:MaxTenuringThreshold=0 \
+  -XX:SurvivorRatio=1024 \
+  -XX:+UseCMSInitiatingOccupancyOnly \
+  -XX:CMSInitiatingOccupancyFraction=60 \
+"
+
+# List of default probes.
+# Add DStatProbe or VmStatProbe if your OS supports it (e.g. if running on Linux).
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+# Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+# Probe point writer class name.
+# BENCHMARK_WRITER=
+
+# Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+SERVER_HOSTS=localhost,localhost
+
+# Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+DRIVER_HOSTS=localhost
+
+# Remote username.
+# REMOTE_USER=
+
+# Number of nodes, used to wait for the specified number of nodes to start.
+nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS} | tr ',' '\n' | wc -l`))
+
+# Run configuration.
+# Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+CONFIGS="\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup\
+"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-tx-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-tx-win.properties b/modules/yardstick/config/benchmark-tx-win.properties
new file mode 100644
index 0000000..7e098a5
--- /dev/null
+++ b/modules/yardstick/config/benchmark-tx-win.properties
@@ -0,0 +1,42 @@
+::
+:: Contains benchmarks for TRANSACTIONAL cache.
+::
+
+:: JVM options.
+set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
+
+:: Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+:: set JVM_OPTS=%JVM_OPTS%^
+::  -XX:+UseParNewGC^
+::  -XX:+UseConcMarkSweepGC^
+::  -XX:+UseTLAB^
+::  -XX:NewSize=128m^
+::  -XX:MaxNewSize=128m^
+::  -XX:MaxTenuringThreshold=0^
+::  -XX:SurvivorRatio=1024^
+::  -XX:+UseCMSInitiatingOccupancyOnly^
+::  -XX:CMSInitiatingOccupancyFraction=60
+
+:: List of default probes.
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+:: Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+:: Probe point writer class name.
+:: BENCHMARK_WRITER=
+
+:: Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+set SERVER_HOSTS=localhost,localhost
+
+:: Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+set DRIVER_HOSTS=localhost
+
+:: Remote username.
+:: set REMOTE_USER=
+
+:: Run configuration which contains all benchmarks.
+:: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+set CONFIGS=^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-tx.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-tx.properties b/modules/yardstick/config/benchmark-tx.properties
new file mode 100644
index 0000000..83be491
--- /dev/null
+++ b/modules/yardstick/config/benchmark-tx.properties
@@ -0,0 +1,48 @@
+#
+# Contains benchmarks for TRANSACTIONAL cache.
+#
+
+# JVM options.
+JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
+
+# Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+# JVM_OPTS=${JVM_OPTS}" \
+#  -XX:+UseParNewGC \
+#  -XX:+UseConcMarkSweepGC \
+#  -XX:+UseTLAB \
+#  -XX:NewSize=128m \
+#  -XX:MaxNewSize=128m \
+#  -XX:MaxTenuringThreshold=0 \
+#  -XX:SurvivorRatio=1024 \
+#  -XX:+UseCMSInitiatingOccupancyOnly \
+#  -XX:CMSInitiatingOccupancyFraction=60 \
+#"
+
+# List of default probes, comma separated.
+# Add DStatProbe or VmStatProbe if your OS supports it (e.g. if running on Linux).
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+# Packages where the specified benchmark is searched by reflection mechanism, comma separated.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+# Probe point writer class name.
+# BENCHMARK_WRITER=
+
+# Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+SERVER_HOSTS=localhost,localhost
+
+# Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+DRIVER_HOSTS=localhost
+
+# Remote username.
+# REMOTE_USER=
+
+# Number of nodes, used to wait for the specified number of nodes to start.
+nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS} | tr ',' '\n' | wc -l`))
+
+# Run configuration.
+# Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+CONFIGS="\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup\
+"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-win.properties b/modules/yardstick/config/benchmark-win.properties
new file mode 100644
index 0000000..ba77c84
--- /dev/null
+++ b/modules/yardstick/config/benchmark-win.properties
@@ -0,0 +1,50 @@
+::
+:: Contains all benchmarks for:
+:: - ATOMIC cache
+:: - TRANSACTIONAL cache
+:: - SQL queries
+::
+
+:: JVM options.
+set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
+
+:: Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+:: set JVM_OPTS=%JVM_OPTS%^
+::  -XX:+UseParNewGC^
+::  -XX:+UseConcMarkSweepGC^
+::  -XX:+UseTLAB^
+::  -XX:NewSize=128m^
+::  -XX:MaxNewSize=128m^
+::  -XX:MaxTenuringThreshold=0^
+::  -XX:SurvivorRatio=1024^
+::  -XX:+UseCMSInitiatingOccupancyOnly^
+::  -XX:CMSInitiatingOccupancyFraction=60
+
+:: List of default probes.
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+:: Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+:: Probe point writer class name.
+:: BENCHMARK_WRITER=
+
+:: Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+set SERVER_HOSTS=localhost,localhost
+
+:: Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+set DRIVER_HOSTS=localhost
+
+:: Remote username.
+:: set REMOTE_USER=
+
+:: Run configuration which contains all benchmarks.
+:: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+set CONFIGS=^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,^
+-ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/benchmark.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark.properties b/modules/yardstick/config/benchmark.properties
new file mode 100644
index 0000000..bbe9ff0
--- /dev/null
+++ b/modules/yardstick/config/benchmark.properties
@@ -0,0 +1,61 @@
+#
+# Contains all benchmarks for:
+# - ATOMIC cache
+# - TRANSACTIONAL cache
+# - SQL queries
+#
+
+# JVM options.
+JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
+
+# Uncomment to enable concurrent garbage collection (GC) if you encounter long GC pauses.
+# JVM_OPTS=${JVM_OPTS}" \
+#  -XX:+UseParNewGC \
+#  -XX:+UseConcMarkSweepGC \
+#  -XX:+UseTLAB \
+#  -XX:NewSize=128m \
+#  -XX:MaxNewSize=128m \
+#  -XX:MaxTenuringThreshold=0 \
+#  -XX:SurvivorRatio=1024 \
+#  -XX:+UseCMSInitiatingOccupancyOnly \
+#  -XX:CMSInitiatingOccupancyFraction=60 \
+#"
+
+# List of default probes.
+# Add DStatProbe or VmStatProbe if your OS supports it (e.g. if running on Linux).
+BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
+
+# Packages where the specified benchmark is searched by reflection mechanism.
+BENCHMARK_PACKAGES=org.yardstickframework
+
+# Probe point writer class name.
+# BENCHMARK_WRITER=
+
+# Comma-separated list of the hosts to run BenchmarkServers on. 2 nodes on local host are enabled by default.
+SERVER_HOSTS=localhost,localhost
+
+# Comma-separated list of the hosts to run BenchmarkDrivers on. 1 node on local host is enabled by default.
+DRIVER_HOSTS=localhost
+
+# Remote username.
+# REMOTE_USER=
+
+# Number of nodes, used to wait for the specified number of nodes to start.
+nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS} | tr ',' '\n' | wc -l`))
+
+# Run configuration which contains all benchmarks.
+# Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
+CONFIGS="\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,\
+-ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup\
+"

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/ignite-base-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-base-config.xml b/modules/yardstick/config/ignite-base-config.xml
new file mode 100644
index 0000000..69fe9b1
--- /dev/null
+++ b/modules/yardstick/config/ignite-base-config.xml
@@ -0,0 +1,118 @@
+<?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.
+-->
+
+<!--
+    Ignite Spring configuration file to startup grid.
+-->
+<beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+       xsi:schemaLocation="
+        http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
+    <bean id="base-grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" abstract="true">
+        <property name="peerClassLoadingEnabled" value="false"/>
+
+        <!--property name="marshaller">
+            <bean class="org.gridgain.grid.marshaller.optimized.GridOptimizedMarshaller">
+                <property name="requireSerializable" value="true"/>
+                <property name="classNames">
+                    <list>
+                        <value>org.yardstickframework.gridgain.cache.model.SampleValue</value>
+                        <value>org.yardstickframework.gridgain.cache.model.Person</value>
+                        <value>org.yardstickframework.gridgain.cache.model.Organization</value>
+                        <value>org.yardstickframework.gridgain.compute.model.NoopTask$NoopJob</value>
+                        <value>org.yardstickframework.gridgain.compute.model.NoopCallable</value>
+                        <value>org.yardstickframework.gridgain.compute.GridGainRunBenchmark$NoopRunnable</value>
+                        <value>org.yardstickframework.gridgain.compute.GridGainApplyBenchmark$NoopClosure</value>
+                    </list>
+                </property>
+            </bean>
+        </property-->
+
+        <property name="cacheConfiguration">
+            <list>
+                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                    <property name="name" value="atomic"/>
+
+                    <property name="cacheMode" value="PARTITIONED"/>
+
+                    <property name="atomicityMode" value="ATOMIC"/>
+
+                    <property name="swapEnabled" value="false"/>
+
+                    <property name="queryIndexEnabled" value="false"/>
+                </bean>
+
+                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                    <property name="name" value="tx"/>
+
+                    <property name="cacheMode" value="PARTITIONED"/>
+
+                    <property name="atomicityMode" value="TRANSACTIONAL"/>
+
+                    <property name="swapEnabled" value="false"/>
+
+                    <property name="queryIndexEnabled" value="false"/>
+                </bean>
+
+                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                    <property name="name" value="query"/>
+
+                    <property name="cacheMode" value="PARTITIONED"/>
+
+                    <property name="atomicityMode" value="ATOMIC"/>
+
+                    <property name="swapEnabled" value="false"/>
+
+                    <!-- Enable query indexing for query cache. -->
+                    <property name="queryIndexEnabled" value="true"/>
+                </bean>
+
+                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                    <property name="name" value="compute"/>
+
+                    <property name="cacheMode" value="PARTITIONED"/>
+
+                    <property name="atomicityMode" value="TRANSACTIONAL"/>
+
+                    <property name="swapEnabled" value="false"/>
+
+                    <property name="queryIndexEnabled" value="false"/>
+                </bean>
+            </list>
+        </property>
+
+        <property name="restEnabled" value="false"/>
+
+        <property name="includeEventTypes">
+            <list/>
+        </property>
+
+        <property name="loadBalancingSpi">
+            <bean class="org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi">
+                <property name="perTask" value="false"/>
+            </bean>
+        </property>
+
+        <property name="communicationSpi">
+            <bean class="org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi">
+                <property name="sharedMemoryPort" value="-1"/>
+            </bean>
+        </property>
+    </bean>
+</beans>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/ignite-localhost-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-localhost-config.xml b/modules/yardstick/config/ignite-localhost-config.xml
new file mode 100644
index 0000000..7a51bb0
--- /dev/null
+++ b/modules/yardstick/config/ignite-localhost-config.xml
@@ -0,0 +1,55 @@
+<?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.
+-->
+
+<!--
+    Ignite Spring configuration file to startup grid.
+-->
+<beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+       xsi:schemaLocation="
+        http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
+    <import resource="gridgain-base-config.xml"/>
+
+    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" parent="base-grid.cfg">
+        <property name="localHost" value="127.0.0.1"/>
+
+        <property name="discoverySpi">
+            <bean class="org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi">
+                <property name="ipFinder">
+                    <bean class="org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder">
+                        <property name="addresses">
+                            <list>
+                                <value>127.0.0.1:47500</value>
+                                <value>127.0.0.1:47501</value>
+                                <value>127.0.0.1:47502</value>
+                                <value>127.0.0.1:47503</value>
+                                <value>127.0.0.1:47504</value>
+                                <value>127.0.0.1:47505</value>
+                                <value>127.0.0.1:47506</value>
+                                <value>127.0.0.1:47507</value>
+                                <value>127.0.0.1:47508</value>
+                                <value>127.0.0.1:47509</value>
+                            </list>
+                        </property>
+                    </bean>
+                </property>
+            </bean>
+        </property>
+    </bean>
+</beans>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/config/ignite-multicast-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-multicast-config.xml b/modules/yardstick/config/ignite-multicast-config.xml
new file mode 100644
index 0000000..a81b0d5
--- /dev/null
+++ b/modules/yardstick/config/ignite-multicast-config.xml
@@ -0,0 +1,38 @@
+<?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.
+-->
+
+<!--
+    Ignite Spring configuration file to startup grid.
+-->
+<beans xmlns="http://www.springframework.org/schema/beans"
+       xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+       xsi:schemaLocation="
+        http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
+    <import resource="gridgain-base-config.xml"/>
+
+    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" parent="base-grid.cfg">
+        <property name="discoverySpi">
+            <bean class="org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi">
+                <property name="ipFinder">
+                    <bean class="org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder"/>
+                </property>
+            </bean>
+        </property>
+    </bean>
+</beans>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java
deleted file mode 100644
index bbbf4d6..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java
+++ /dev/null
@@ -1,41 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-
-import java.util.*;
-
-/**
- * GridGain benchmark that performs get operations.
- */
-public class GetBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = nextRandom(args.range());
-
-        cache.get(key);
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("atomic");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c9aadf07/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
new file mode 100644
index 0000000..30a8eb5
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
@@ -0,0 +1,41 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs get operations.
+ */
+public class IgniteGetBenchmark extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        cache.get(key);
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("atomic");
+    }
+}


[30/45] incubator-ignite git commit: # IGNITE-32: Fixed profile.

Posted by sb...@apache.org.
# IGNITE-32: Fixed profile.


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

Branch: refs/heads/ignite-121-logging
Commit: b82eea32318a786cc5f5d352d18981220adf77ee
Parents: 8112a50
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 13:50:02 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 13:50:02 2015 +0700

----------------------------------------------------------------------
 pom.xml | 6 +-----
 1 file changed, 1 insertion(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b82eea32/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 4f64724..06c9d42 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1280,11 +1280,7 @@
         </profile>
 
         <profile>
-            <id>ignite-yardstick</id>
-            <activation>
-                <activeByDefault>false</activeByDefault>
-            </activation>
-
+            <id>benchmarks</id>
             <modules>
                 <module>modules/yardstick</module>
             </modules>


[17/45] incubator-ignite git commit: # IGNITE-102: Initial benchmark code.

Posted by sb...@apache.org.
# IGNITE-102: Initial benchmark code.


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

Branch: refs/heads/ignite-121-logging
Commit: b0031ccda7379a80047ae429ccb7da7be2a0139e
Parents: 9660a1c
Author: AKuznetsov <ak...@gridgain.com>
Authored: Tue Jan 27 16:16:31 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Tue Jan 27 16:16:31 2015 +0700

----------------------------------------------------------------------
 modules/yardstick/README.md                     |  67 ++++++
 modules/yardstick/pom.xml                       | 177 +++++++++++++++
 .../yardstick/IgniteAbstractBenchmark.java      | 130 +++++++++++
 .../yardstick/IgniteBenchmarkArguments.java     | 213 +++++++++++++++++++
 .../org/apache/ignite/yardstick/IgniteNode.java | 191 +++++++++++++++++
 .../yardstick/cache/GetBenchmarkIgnite.java     |  41 ++++
 .../cache/IgniteCacheAbstractBenchmark.java     |  44 ++++
 .../cache/IgnitePutBenchmarkIgnite.java         |  42 ++++
 .../cache/IgnitePutGetBenchmarkIgnite.java      |  47 ++++
 .../cache/IgnitePutGetTxBenchmarkIgnite.java    |  52 +++++
 .../cache/IgnitePutTxBenchmarkIgnite.java       |  43 ++++
 .../cache/IgniteSqlQueryBenchmarkIgnite.java    |  94 ++++++++
 .../IgniteSqlQueryJoinBenchmarkIgnite.java      | 118 ++++++++++
 .../cache/IgniteSqlQueryPutBenchmarkIgnite.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                                         |  13 +-
 25 files changed, 2107 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/README.md
----------------------------------------------------------------------
diff --git a/modules/yardstick/README.md b/modules/yardstick/README.md
new file mode 100644
index 0000000..d2aebc0
--- /dev/null
+++ b/modules/yardstick/README.md
@@ -0,0 +1,67 @@
+# Yardstick Ignite Benchmarks
+Yardstick Ignite is a set of <a href="http://ignite.incubator.apache.org/">Ignite Grid</a> benchmarks written on top of Yardstick framework.
+
+## Yardstick Framework
+Visit <a href="https://github.com/gridgain/yardstick" target="_blank">Yardstick Repository</a> for detailed information on how to run Yardstick benchmarks and how to generate graphs.
+
+The documentation below describes configuration parameters in addition to standard Yardstick parameters.
+
+## Installation
+1. Create a local clone of Ignite repository
+2. Run `mvn package` command for Yardstick Ignite POM
+
+## Provided Benchmarks
+The following benchmarks are provided:
+
+1. `GetBenchmark` - benchmarks atomic distributed cache get operation
+2. `PutBenchmark` - benchmarks atomic distributed cache put operation
+3. `PutGetBenchmark` - benchmarks atomic distributed cache put and get operations together
+4. `PutTxBenchmark` - benchmarks transactional distributed cache put operation
+5. `PutGetTxBenchmark` - benchmarks transactional distributed cache put and get operations together
+6. `SqlQueryBenchmark` - benchmarks distributed SQL query over cached data
+7. `SqlQueryJoinBenchmark` - benchmarks distributed SQL query with a Join over cached data
+8. `SqlQueryPutBenchmark` - benchmarks distributed SQL query with simultaneous cache updates
+
+## Writing Ignite Benchmarks
+All benchmarks extend `AbstractBenchmark` class. A new benchmark should also extend this abstract class and implement `test` method. This is the method that is actually benchmarked.
+
+## Running Ignite Benchmarks
+Before running Ignite benchmarks, run `mvn package` command. This command will compile the project and also will unpack scripts from `yardstick-resources.zip` file to `bin` directory.
+
+### Properties And Command Line Arguments
+> Note that this section only describes configuration parameters specific to Ignite benchmarks, and not for Yardstick framework. To run Ignite benchmarks and generate graphs, you will need to run them using Yardstick framework scripts in `bin` folder.
+
+> Refer to [Yardstick Documentation](https://github.com/gridgain/yardstick) for common Yardstick properties and command line arguments for running Yardstick scripts.
+
+The following Ignite benchmark properties can be defined in the benchmark configuration:
+
+* `-nn <num>` or `--nodeNumber <num>` - Number of nodes (automatically set in `benchmark.properties`), used to wait for the specified number of nodes to start
+* `-b <num>` or `--backups <num>` - Number of backups for every key
+* `-ggcfg <path>` or `--ggConfig <path>` - Path to Ignite configuration file
+* `-sm <mode>` or `-syncMode <mode>` - Synchronization mode (defined in `CacheWriteSynchronizationMode`)
+* `-dm <mode>` or `--distroMode <mode>` - Distribution mode (defined in `CacheDistributionMode`)
+* `-wom <mode>` or `--writeOrderMode <mode>` - Write order mode for ATOMIC caches (defined in `CacheAtomicWriteOrderMode`)
+* `-txc <value>` or `--txConcurrency <value>` - Cache transaction concurrency control, either `OPTIMISTIC` or `PESSIMISTIC` (defined in `CacheTxConcurrency`)
+* `-txi <value>` or `--txIsolation <value>` - Cache transaction isolation (defined in `CacheTxIsolation`)
+* `-ot` or `--offheapTiered` - Flag indicating whether tiered off-heap mode is on
+* `-ov` or `--offheapValuesOnly` - Flag indicating whether off-heap mode is on and only cache values are stored off-heap
+* `-rtp <num>`  or `--restPort <num>` - REST TCP port, indicates that a Ignite node is ready to process Ignite Clients
+* `-rth <host>` or `--restHost <host>` - REST TCP host
+* `-ss` or `--syncSend` - Flag indicating whether synchronous send is used in `TcpCommunicationSpi`
+* `-r <num>` or `--range` - Range of keys that are randomly generated for cache operations
+
+For example if we need to run 2 `IgniteNode` servers on localhost with `PutBenchmark` benchmark on localhost, with number of backups set to 1, synchronization mode set to `PRIMARY_SYNC`, then the following configuration should be specified in `benchmark.properties` file:
+
+```
+SERVER_HOSTS=localhost,localhost
+    
+# Note that -dn and -sn, which stand for data node and server node, are 
+# native Yardstick parameters and are documented in Yardstick framework.
+CONFIGS="-b 1 -sm PRIMARY_SYNC -dn PutBenchmark -sn IgniteNode"
+```
+
+## Issues
+Use Ignite Apache JIRA (https://issues.apache.org/jira/browse/IGNITE) to file bugs.
+
+## License
+Yardstick Ignite is available under [Apache 2.0](http://www.apache.org/licenses/LICENSE-2.0.html) Open Source license.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/pom.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/pom.xml b/modules/yardstick/pom.xml
new file mode 100644
index 0000000..67052dc
--- /dev/null
+++ b/modules/yardstick/pom.xml
@@ -0,0 +1,177 @@
+<?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.
+-->
+
+<!--
+    POM file.
+-->
+<project
+    xmlns="http://maven.apache.org/POM/4.0.0"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+
+    <parent>
+        <groupId>org.apache.ignite</groupId>
+        <artifactId>ignite</artifactId>
+        <version>${ignite.version}</version>
+        <relativePath>../..</relativePath>
+    </parent>
+
+    <artifactId>ignite-yardstick</artifactId>
+
+    <properties>
+        <yardstick.version>0.7.0</yardstick.version>
+    </properties>
+
+
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-core</artifactId>
+            <version>${ignite.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-spring</artifactId>
+            <version>${ignite.version}</version>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.apache.ignite</groupId>
+            <artifactId>ignite-indexing</artifactId>
+            <version>${ignite.version}</version>
+            <scope>test</scope>
+        </dependency>
+
+        <dependency>
+            <groupId>org.yardstickframework</groupId>
+            <artifactId>yardstick</artifactId>
+            <version>${yardstick.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>com.beust</groupId>
+            <artifactId>jcommander</artifactId>
+            <version>1.32</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.springframework</groupId>
+            <artifactId>spring-core</artifactId>
+            <version>${spring.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.springframework</groupId>
+            <artifactId>spring-beans</artifactId>
+            <version>${spring.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.springframework</groupId>
+            <artifactId>spring-context</artifactId>
+            <version>${spring.version}</version>
+        </dependency>
+
+        <dependency>
+            <groupId>org.springframework</groupId>
+            <artifactId>spring-expression</artifactId>
+            <version>${spring.version}</version>
+        </dependency>
+    </dependencies>
+
+    <build>
+        <plugins>
+            <plugin>
+                <artifactId>maven-compiler-plugin</artifactId>
+                <version>3.1</version>
+                <configuration >
+                    <source>1.7</source>
+                    <target>1.7</target>
+                </configuration>
+            </plugin>
+
+            <plugin>
+                <artifactId>maven-dependency-plugin</artifactId>
+                <version>2.8</version>
+                <executions>
+                    <execution>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>copy-dependencies</goal>
+                        </goals>
+                        <configuration>
+                            <outputDirectory>${basedir}/libs</outputDirectory>
+                            <excludeTypes>pom</excludeTypes>
+                        </configuration>
+                    </execution>
+                    <execution>
+                        <id>unpack</id>
+                        <phase>package</phase>
+                        <goals>
+                            <goal>unpack</goal>
+                        </goals>
+                        <configuration>
+                            <artifactItems>
+                                <artifactItem>
+                                    <groupId>org.yardstickframework</groupId>
+                                    <artifactId>yardstick</artifactId>
+                                    <version>${yardstick.version}</version>
+                                    <type>zip</type>
+                                    <classifier>resources</classifier>
+                                    <outputDirectory>${basedir}</outputDirectory>
+                                </artifactItem>
+                            </artifactItems>
+                        </configuration>
+                    </execution>
+                </executions>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-jar-plugin</artifactId>
+                <version>2.4</version>
+                <configuration>
+                    <outputDirectory>${basedir}/libs</outputDirectory>
+                </configuration>
+            </plugin>
+
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-clean-plugin</artifactId>
+                <version>2.5</version>
+                <configuration>
+                    <filesets>
+                        <fileset>
+                            <directory>${basedir}/bin</directory>
+                        </fileset>
+                        <fileset>
+                            <directory>${basedir}/libs</directory>
+                            <includes>
+                                <include>**/*.jar</include>
+                            </includes>
+                        </fileset>
+                    </filesets>
+                </configuration>
+            </plugin>
+        </plugins>
+    </build>
+</project>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
new file mode 100644
index 0000000..5cbfee1
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
@@ -0,0 +1,130 @@
+/*
+ * 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.yardstick;
+
+import org.apache.ignite.*;
+import org.apache.ignite.events.*;
+import org.apache.ignite.lang.*;
+import org.yardstickframework.*;
+
+import java.util.concurrent.*;
+
+import static org.apache.ignite.events.IgniteEventType.*;
+import static org.apache.ignite.cache.CacheDistributionMode.*;
+import static org.yardstickframework.BenchmarkUtils.*;
+
+/**
+ * Abstract class for GridGain benchmarks.
+ */
+public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
+    /** Arguments. */
+    protected final IgniteBenchmarkArguments args = new IgniteBenchmarkArguments();
+
+    /** Node. */
+    private IgniteNode node;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        jcommander(cfg.commandLineArguments(), args, "<gridgain-driver>");
+
+        if (Ignition.state() != IgniteState.STARTED) {
+            node = new IgniteNode(args.distributionMode() == CLIENT_ONLY);
+
+            node.start(cfg);
+        }
+        else
+            // Support for mixed benchmarks mode.
+            node = new IgniteNode(args.distributionMode() == CLIENT_ONLY, Ignition.ignite());
+
+        waitForNodes();
+    }
+
+    /** {@inheritDoc} */
+    @Override public void tearDown() throws Exception {
+        if (node != null)
+            node.stop();
+    }
+
+    /** {@inheritDoc} */
+    @Override public String description() {
+        String desc = BenchmarkUtils.description(cfg, this);
+
+        return desc.isEmpty() ?
+            getClass().getSimpleName() + args.description() + cfg.defaultDescription() : desc;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String usage() {
+        return BenchmarkUtils.usage(args);
+    }
+
+    /**
+     * @return Grid.
+     */
+    protected Ignite grid() {
+        return node.grid();
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
+    private void waitForNodes() throws Exception {
+        final CountDownLatch nodesStartedLatch = new CountDownLatch(1);
+
+        grid().events().localListen(new IgnitePredicate<IgniteEvent>() {
+            @Override public boolean apply(IgniteEvent gridEvt) {
+                if (nodesStarted())
+                    nodesStartedLatch.countDown();
+
+                return true;
+            }
+        }, EVT_NODE_JOINED);
+
+        if (!nodesStarted()) {
+            println(cfg, "Waiting for " + (args.nodes() - 1) + " nodes to start...");
+
+            nodesStartedLatch.await();
+        }
+    }
+
+    /**
+     * @return {@code True} if all nodes are started, {@code false} otherwise.
+     */
+    private boolean nodesStarted() {
+        return grid().cluster().nodes().size() >= args.nodes();
+    }
+
+    /**
+     * @param max Key range.
+     * @return Next key.
+     */
+    protected int nextRandom(int max) {
+        return ThreadLocalRandom.current().nextInt(max);
+    }
+
+    /**
+     * @param min Minimum key in range.
+     * @param max Maximum key in range.
+     * @return Next key.
+     */
+    protected int nextRandom(int min, int max) {
+        return ThreadLocalRandom.current().nextInt(max - min) + min;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
new file mode 100644
index 0000000..ebcddf3
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
@@ -0,0 +1,213 @@
+/*
+ * 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.yardstick;
+
+import com.beust.jcommander.*;
+import org.apache.ignite.cache.*;
+import org.apache.ignite.internal.util.tostring.*;
+import org.apache.ignite.transactions.*;
+
+/**
+ * Input arguments for GridGain benchmarks.
+ */
+@SuppressWarnings({"UnusedDeclaration", "FieldCanBeLocal"})
+public class IgniteBenchmarkArguments {
+    /** */
+    @Parameter(names = {"-nn", "--nodeNumber"}, description = "Node number")
+    private int nodes = 1;
+
+    /** */
+    @Parameter(names = {"-b", "--backups"}, description = "Backups")
+    private int backups;
+
+    @Parameter(names = {"-ggcfg", "--ggConfig"}, description = "Configuration file")
+    private String ggcfg = "config/gridgain-localhost-config.xml";
+
+    /** */
+    @Parameter(names = {"-sm", "--syncMode"}, description = "Synchronization mode")
+    private CacheWriteSynchronizationMode syncMode = CacheWriteSynchronizationMode.PRIMARY_SYNC;
+
+    /** */
+    @Parameter(names = {"-dm", "--distroMode"}, description = "Distribution mode")
+    private CacheDistributionMode distroMode = CacheDistributionMode.PARTITIONED_ONLY;
+
+    /** */
+    @Parameter(names = {"-wom", "--writeOrderMode"}, description = "Write ordering mode")
+    private CacheAtomicWriteOrderMode orderMode;
+
+    /** */
+    @Parameter(names = {"-txc", "--txConcurrency"}, description = "Transaction concurrency")
+    private IgniteTxConcurrency txConcurrency = IgniteTxConcurrency.OPTIMISTIC;
+
+    /** */
+    @Parameter(names = {"-txi", "--txIsolation"}, description = "Transaction isolation")
+    private IgniteTxIsolation txIsolation = IgniteTxIsolation.REPEATABLE_READ;
+
+    /** */
+    @Parameter(names = {"-ot", "--offheapTiered"}, description = "Tiered offheap")
+    private boolean offheapTiered;
+
+    /** */
+    @Parameter(names = {"-ov", "--offheapValuesOnly"}, description = "Offheap values only")
+    private boolean offheapVals;
+
+    /** */
+    @Parameter(names = {"-rtp", "--restPort"}, description = "REST TCP port")
+    private int restTcpPort;
+
+    /** */
+    @Parameter(names = {"-rth", "--restHost"}, description = "REST TCP host")
+    private String restTcpHost;
+
+    /** */
+    @Parameter(names = {"-ss", "--syncSend"}, description = "Synchronous send")
+    private boolean syncSnd;
+
+    /** */
+    @Parameter(names = {"-r", "--range"}, description = "Key range")
+    private int range = 1_000_000;
+
+    /** */
+    @Parameter(names = {"-j", "--jobs"}, description = "Number of jobs for compute benchmarks")
+    private int jobs = 10;
+
+    /**
+     * @return Transaction concurrency.
+     */
+    public IgniteTxConcurrency txConcurrency() {
+        return txConcurrency;
+    }
+
+    /**
+     * @return Transaction isolation.
+     */
+    public IgniteTxIsolation txIsolation() {
+        return txIsolation;
+    }
+
+    /**
+     * @return REST TCP port.
+     */
+    public int restTcpPort() {
+        return restTcpPort;
+    }
+
+    /**
+     * @return REST TCP host.
+     */
+    public String restTcpHost() {
+        return restTcpHost;
+    }
+
+    /**
+     * @return Distribution.
+     */
+    public CacheDistributionMode distributionMode() {
+        return distroMode;
+    }
+
+    /**
+     * @return Synchronization.
+     */
+    public CacheWriteSynchronizationMode syncMode() {
+        return syncMode;
+    }
+
+    /**
+     * @return Cache write ordering mode.
+     */
+    public CacheAtomicWriteOrderMode orderMode() {
+        return orderMode;
+    }
+
+    /**
+     * @return Backups.
+     */
+    public int backups() {
+        return backups;
+    }
+
+    /**
+     * @return Offheap tiered.
+     */
+    public boolean isOffheapTiered() {
+        return offheapTiered;
+    }
+
+    /**
+     * @return Offheap values.
+     */
+    public boolean isOffheapValues() {
+        return offheapVals;
+    }
+
+    /**
+     * @return {@code True} if any offheap is enabled.
+     */
+    public boolean isOffHeap() {
+        return offheapTiered || offheapVals;
+    }
+
+    /**
+     * @return Nodes.
+     */
+    public int nodes() {
+        return nodes;
+    }
+
+    /**
+     * @return {@code True} if sending is synchronous.
+     */
+    public boolean isSyncSend() {
+        return syncSnd;
+    }
+
+    /**
+     * @return Key range, from {@code 0} to this number.
+     */
+    public int range() {
+        return range;
+    }
+
+    /**
+     * @return Configuration file.
+     */
+    public String configuration() {
+        return ggcfg;
+    }
+
+    /**
+     * @return Number of jobs
+     */
+    public int jobs() {
+        return jobs;
+    }
+
+    /**
+     * @return Description.
+     */
+    public String description() {
+        return "-nn=" + nodes + "-b=" + backups + "-sm=" + syncMode + "-dm=" + distroMode +
+            (orderMode == null ? "" : "-wom=" + orderMode) + "-txc=" + txConcurrency;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return GridToStringBuilder.toString(IgniteBenchmarkArguments.class, this);
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/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
new file mode 100644
index 0000000..38a61be
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteNode.java
@@ -0,0 +1,191 @@
+/*
+ * 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.yardstick;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.*;
+import org.apache.ignite.cache.eviction.lru.*;
+import org.apache.ignite.configuration.*;
+import org.apache.ignite.internal.util.*;
+import org.apache.ignite.spi.communication.tcp.*;
+import org.springframework.beans.*;
+import org.springframework.beans.factory.xml.*;
+import org.springframework.context.support.*;
+import org.springframework.core.io.*;
+import org.yardstickframework.*;
+
+import java.net.*;
+import java.util.*;
+
+import static org.apache.ignite.cache.CacheDistributionMode.*;
+import static org.apache.ignite.cache.CacheMemoryMode.*;
+
+/**
+ * Standalone GridGain node.
+ */
+public class IgniteNode implements BenchmarkServer {
+    /** Grid instance. */
+    private Ignite grid;
+
+    /** Client mode. */
+    private boolean clientMode;
+
+    /** */
+    public IgniteNode() {
+        // No-op.
+    }
+
+    /** */
+    public IgniteNode(boolean clientMode) {
+        this.clientMode = clientMode;
+    }
+
+    /** */
+    public IgniteNode(boolean clientMode, Ignite grid) {
+        this.clientMode = clientMode;
+        this.grid = grid;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void start(BenchmarkConfiguration cfg) throws Exception {
+        IgniteBenchmarkArguments args = new IgniteBenchmarkArguments();
+
+        BenchmarkUtils.jcommander(cfg.commandLineArguments(), args, "<gridgain-node>");
+
+        IgniteConfiguration c = loadConfiguration(args.configuration());
+
+        assert c != null;
+
+        for (CacheConfiguration cc : c.getCacheConfiguration()) {
+            // IgniteNode can not run in CLIENT_ONLY mode,
+            // except the case when it's used inside GridGainAbstractBenchmark.
+            CacheDistributionMode distroMode = args.distributionMode() == CLIENT_ONLY && !clientMode ?
+                PARTITIONED_ONLY : args.distributionMode();
+
+            cc.setWriteSynchronizationMode(args.syncMode());
+            cc.setDistributionMode(distroMode);
+
+            if (args.orderMode() != null)
+                cc.setAtomicWriteOrderMode(args.orderMode());
+
+            cc.setBackups(args.backups());
+
+            if (args.restTcpPort() != 0) {
+                ClientConnectionConfiguration ccc = new ClientConnectionConfiguration();
+
+                ccc.setRestTcpPort(args.restTcpPort());
+
+                if (args.restTcpHost() != null)
+                    ccc.setRestTcpHost(args.restTcpHost());
+
+                c.setClientConnectionConfiguration(ccc);
+            }
+
+            if (args.isOffHeap()) {
+                cc.setOffHeapMaxMemory(0);
+
+                if (args.isOffheapValues())
+                    cc.setMemoryMode(OFFHEAP_VALUES);
+                else
+                    cc.setEvictionPolicy(new CacheLruEvictionPolicy(50000));
+            }
+
+        }
+
+        TransactionsConfiguration tc = c.getTransactionsConfiguration();
+
+        tc.setDefaultTxConcurrency(args.txConcurrency());
+        tc.setDefaultTxIsolation(args.txIsolation());
+
+        TcpCommunicationSpi commSpi = (TcpCommunicationSpi)c.getCommunicationSpi();
+
+        if (commSpi == null)
+            commSpi = new TcpCommunicationSpi();
+
+        c.setCommunicationSpi(commSpi);
+
+        grid = Ignition.start(c);
+    }
+
+    /**
+     * @param springCfgPath Spring configuration file path.
+     * @return Grid configuration.
+     * @throws Exception If failed.
+     */
+    private static IgniteConfiguration loadConfiguration(String springCfgPath) throws Exception {
+        URL url;
+
+        try {
+            url = new URL(springCfgPath);
+        }
+        catch (MalformedURLException e) {
+            url = GridUtils.resolveGridGainUrl(springCfgPath);
+
+            if (url == null)
+                throw new IgniteCheckedException("Spring XML configuration path is invalid: " + springCfgPath +
+                    ". Note that this path should be either absolute or a relative local file system path, " +
+                    "relative to META-INF in classpath or valid URL to GRIDGAIN_HOME.", e);
+        }
+
+        GenericApplicationContext springCtx;
+
+        try {
+            springCtx = new GenericApplicationContext();
+
+            new XmlBeanDefinitionReader(springCtx).loadBeanDefinitions(new UrlResource(url));
+
+            springCtx.refresh();
+        }
+        catch (BeansException e) {
+            throw new Exception("Failed to instantiate Spring XML application context [springUrl=" +
+                url + ", err=" + e.getMessage() + ']', e);
+        }
+
+        Map<String, IgniteConfiguration> cfgMap;
+
+        try {
+            cfgMap = springCtx.getBeansOfType(IgniteConfiguration.class);
+        }
+        catch (BeansException e) {
+            throw new Exception("Failed to instantiate bean [type=" + IgniteConfiguration.class + ", err=" +
+                e.getMessage() + ']', e);
+        }
+
+        if (cfgMap == null || cfgMap.isEmpty())
+            throw new Exception("Failed to find grid configuration in: " + url);
+
+        return cfgMap.values().iterator().next();
+    }
+
+    /** {@inheritDoc} */
+    @Override public void stop() throws Exception {
+        Ignition.stopAll(true);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String usage() {
+        return BenchmarkUtils.usage(new IgniteBenchmarkArguments());
+    }
+
+    /**
+     * @return Grid.
+     */
+    public Ignite grid() {
+        return grid;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java
new file mode 100644
index 0000000..bbbf4d6
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/GetBenchmarkIgnite.java
@@ -0,0 +1,41 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs get operations.
+ */
+public class GetBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        cache.get(key);
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("atomic");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
new file mode 100644
index 0000000..636057c
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
@@ -0,0 +1,44 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.*;
+import org.yardstickframework.*;
+
+/**
+ * Abstract class for GridGain benchmarks which use cache.
+ */
+public abstract class IgniteCacheAbstractBenchmark extends IgniteAbstractBenchmark {
+    /** Cache. */
+    protected IgniteCache<Integer, Object> cache;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        cache = cache();
+    }
+
+    /**
+     * Each benchmark must determine which cache will be used.
+     *
+     * @return GridCache Cache to use.
+     */
+    protected abstract IgniteCache<Integer, Object> cache();
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java
new file mode 100644
index 0000000..fbe55f3
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java
@@ -0,0 +1,42 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs put operations.
+ */
+public class IgnitePutBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        cache.put(key, new SampleValue(key));
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("atomic");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java
new file mode 100644
index 0000000..a3b3486
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java
@@ -0,0 +1,47 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs put and get operations.
+ */
+public class IgnitePutGetBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        Object val = cache.get(key);
+
+        if (val != null)
+            key = nextRandom(args.range());
+
+        cache.put(key, new SampleValue(key));
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("atomic");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java
new file mode 100644
index 0000000..3cad7d7
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java
@@ -0,0 +1,52 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.transactions.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs transactional put and get operations.
+ */
+public class IgnitePutGetTxBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(0, args.range() / 2);
+
+        try (IgniteTx tx = grid().transactions().txStart()) {
+            Object val = cache.get(key);
+
+            if (val != null)
+                key = nextRandom(args.range() / 2, args.range());
+
+            cache.put(key, new SampleValue(key));
+
+            tx.commit();
+        }
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("tx");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java
new file mode 100644
index 0000000..dd2fd58
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java
@@ -0,0 +1,43 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs transactional put operations.
+ */
+public class IgnitePutTxBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        // Implicit transaction is used.
+        cache.put(key, new SampleValue(key));
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("tx");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java
new file mode 100644
index 0000000..c769e53
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java
@@ -0,0 +1,94 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.query.*;
+import org.apache.ignite.yardstick.cache.model.*;
+import org.yardstickframework.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+import static org.yardstickframework.BenchmarkUtils.*;
+
+/**
+ * GridGain benchmark that performs query operations.
+ */
+public class IgniteSqlQueryBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** */
+    private CacheQuery qry;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        println(cfg, "Populating query data...");
+
+        long start = System.nanoTime();
+
+        try (IgniteDataLoader<Integer, Person> dataLdr = grid().dataLoader(cache.getName())) {
+            for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
+                dataLdr.addData(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
+
+                if (i % 100000 == 0)
+                    println(cfg, "Populated persons: " + i);
+            }
+        }
+
+        println(cfg, "Finished populating query data in " + ((System.nanoTime() - start) / 1_000_000) + " ms.");
+
+        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlQuery(Person.class, "salary >= ? and salary <= ?");
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        double salary = ThreadLocalRandom.current().nextDouble() * args.range() * 1000;
+
+        double maxSalary = salary + 1000;
+
+        Collection<Map.Entry<Integer, Person>> entries = executeQuery(salary, maxSalary);
+
+        for (Map.Entry<Integer, Person> entry : entries) {
+            Person p = entry.getValue();
+
+            if (p.getSalary() < salary || p.getSalary() > maxSalary)
+                throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
+                        ", person=" + p + ']');
+        }
+
+        return true;
+    }
+
+    /**
+     * @param minSalary Min salary.
+     * @param maxSalary Max salary.
+     * @return Query result.
+     * @throws Exception If failed.
+     */
+    private Collection<Map.Entry<Integer, Person>> executeQuery(double minSalary, double maxSalary) throws Exception {
+        CacheQuery<Map.Entry<Integer, Person>> q = (CacheQuery<Map.Entry<Integer, Person>>)qry;
+
+        return q.execute(minSalary, maxSalary).get();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("query");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java
new file mode 100644
index 0000000..4405afa
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java
@@ -0,0 +1,118 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.query.*;
+import org.apache.ignite.yardstick.cache.model.*;
+import org.yardstickframework.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+import static org.yardstickframework.BenchmarkUtils.*;
+
+/**
+ * GridGain benchmark that performs query operations with joins.
+ */
+public class IgniteSqlQueryJoinBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** */
+    private CacheQuery qry;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        println(cfg, "Populating query data...");
+
+        long start = System.nanoTime();
+
+        try (IgniteDataLoader<Object, Object> dataLdr = grid().dataLoader(cache.getName())) {
+            final int orgRange = args.range() / 10;
+
+            // Populate organizations.
+            for (int i = 0; i < orgRange && !Thread.currentThread().isInterrupted(); i++)
+                dataLdr.addData(i, new Organization(i, "org" + i));
+
+            dataLdr.flush();
+
+            // Populate persons.
+            for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
+                Person p =
+                    new Person(i, ThreadLocalRandom.current().nextInt(orgRange), "firstName" + i, "lastName" + i, i * 1000);
+
+                dataLdr.addData(i, p);
+
+                if (i % 100000 == 0)
+                    println(cfg, "Populated persons: " + i);
+            }
+        }
+
+        println(cfg, "Finished populating join query data in " + ((System.nanoTime() - start) / 1_000_000) + " ms.");
+
+        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlFieldsQuery(
+            // "select p.id, p.orgId, p.firstName, p.lastName, p.salary, o.name " +
+            //    "from Person p, Organization o " +
+            //    "where p.id = o.id and salary >= ? and salary <= ?");
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        double salary = ThreadLocalRandom.current().nextDouble() * args.range() * 1000;
+
+        double maxSalary = salary + 1000;
+
+        Collection<List<?>> lists = executeQueryJoin(salary, maxSalary);
+
+        for (List<?> l : lists) {
+            double sal = (Double)l.get(4);
+
+            if (sal < salary || sal > maxSalary) {
+                Person p = new Person();
+
+                p.setId((Integer)l.get(0));
+                p.setOrganizationId((Integer)l.get(1));
+                p.setFirstName((String)l.get(2));
+                p.setLastName((String)l.get(3));
+                p.setSalary(sal);
+
+                throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
+                    ", person=" + p + ']');
+            }
+        }
+
+        return true;
+    }
+
+    /**
+     * @param minSalary Min salary.
+     * @param maxSalary Max salary.
+     * @return Query results.
+     * @throws Exception If failed.
+     */
+    private Collection<List<?>> executeQueryJoin(double minSalary, double maxSalary) throws Exception {
+        CacheQuery<List<?>> q = (CacheQuery<List<?>>)qry;
+
+        return q.execute(minSalary, maxSalary).get();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("query");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java
new file mode 100644
index 0000000..8bef1e5
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java
@@ -0,0 +1,86 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.query.*;
+import org.apache.ignite.yardstick.cache.model.*;
+import org.yardstickframework.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * GridGain benchmark that performs put and query operations.
+ */
+public class IgniteSqlQueryPutBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
+    /** */
+    private CacheQuery qry;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlQuery(Person.class, "salary >= ? and salary <= ?");
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        ThreadLocalRandom rnd = ThreadLocalRandom.current();
+
+        if (rnd.nextBoolean()) {
+            double salary = rnd.nextDouble() * args.range() * 1000;
+
+            double maxSalary = salary + 1000;
+
+            Collection<Map.Entry<Integer, Person>> entries = executeQuery(salary, maxSalary);
+
+            for (Map.Entry<Integer, Person> entry : entries) {
+                Person p = entry.getValue();
+
+                if (p.getSalary() < salary || p.getSalary() > maxSalary)
+                    throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
+                            ", person=" + p + ']');
+            }
+        }
+        else {
+            int i = rnd.nextInt(args.range());
+
+            cache.put(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
+        }
+
+        return true;
+    }
+
+    /**
+     * @param minSalary Min salary.
+     * @param maxSalary Max salary.
+     * @return Query result.
+     * @throws Exception If failed.
+     */
+    private Collection<Map.Entry<Integer, Person>> executeQuery(double minSalary, double maxSalary) throws Exception {
+        CacheQuery<Map.Entry<Integer, Person>> q = (CacheQuery<Map.Entry<Integer, Person>>)qry;
+
+        return q.execute(minSalary, maxSalary).get();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("query");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Organization.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Organization.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Organization.java
new file mode 100644
index 0000000..b0c3e8d
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Organization.java
@@ -0,0 +1,110 @@
+/*
+ * 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.yardstick.cache.model;
+
+import org.apache.ignite.cache.query.*;
+
+import java.io.*;
+
+/**
+ * Organization record used for query test.
+ */
+public class Organization implements Externalizable {
+    /** Organization ID. */
+    @CacheQuerySqlField(index = true)
+    private int id;
+
+    /** Organization name. */
+    @CacheQuerySqlField(index = true)
+    private String name;
+
+    /**
+     * Constructs empty organization.
+     */
+    public Organization() {
+        // No-op.
+    }
+
+    /**
+     * Constructs organization with given ID.
+     *
+     * @param id Organization ID.
+     * @param name Organization name.
+     */
+    public Organization(int id, String name) {
+        this.id = id;
+        this.name = name;
+    }
+
+    /**
+     * @return Organization id.
+     */
+    public int getId() {
+        return id;
+    }
+
+    /**
+     * @param id Organization id.
+     */
+    public void setId(int id) {
+        this.id = id;
+    }
+
+    /**
+     * @return Organization name.
+     */
+    public String getName() {
+        return name;
+    }
+
+    /**
+     * @param name Organization name.
+     */
+    public void setName(String name) {
+        this.name = name;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeInt(id);
+        out.writeUTF(name);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        id = in.readInt();
+        name = in.readUTF();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object o) {
+        return this == o || (o instanceof Organization) && id == ((Organization)o).id;
+
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        return id;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return "Organization [id=" + id +
+            ", name=" + name + ']';
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Person.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Person.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Person.java
new file mode 100644
index 0000000..fd7cd73
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/Person.java
@@ -0,0 +1,191 @@
+/*
+ * 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.yardstick.cache.model;
+
+import org.apache.ignite.cache.query.*;
+
+import java.io.*;
+
+/**
+ * Person record used for query test.
+ */
+public class Person implements Externalizable {
+    /** Person ID. */
+    @CacheQuerySqlField(index = true)
+    private int id;
+
+    /** Organization ID. */
+    @CacheQuerySqlField(index = true)
+    private int orgId;
+
+    /** First name (not-indexed). */
+    @CacheQuerySqlField
+    private String firstName;
+
+    /** Last name (not indexed). */
+    @CacheQuerySqlField
+    private String lastName;
+
+    /** Salary. */
+    @CacheQuerySqlField(index = true)
+    private double salary;
+
+    /**
+     * Constructs empty person.
+     */
+    public Person() {
+        // No-op.
+    }
+
+    /**
+     * Constructs person record that is not linked to any organization.
+     *
+     * @param id Person ID.
+     * @param firstName First name.
+     * @param lastName Last name.
+     * @param salary Salary.
+     */
+    public Person(int id, String firstName, String lastName, double salary) {
+        this(id, 0, firstName, lastName, salary);
+    }
+
+    /**
+     * Constructs person record.
+     *
+     * @param id Person ID.
+     * @param orgId Organization ID.
+     * @param firstName First name.
+     * @param lastName Last name.
+     * @param salary Salary.
+     */
+    public Person(int id, int orgId, String firstName, String lastName, double salary) {
+        this.id = id;
+        this.orgId = orgId;
+        this.firstName = firstName;
+        this.lastName = lastName;
+        this.salary = salary;
+    }
+
+    /**
+     * @return Person id.
+     */
+    public int getId() {
+        return id;
+    }
+
+    /**
+     * @param id Person id.
+     */
+    public void setId(int id) {
+        this.id = id;
+    }
+
+    /**
+     * @return Organization id.
+     */
+    public int getOrganizationId() {
+        return orgId;
+    }
+
+    /**
+     * @param orgId Organization id.
+     */
+    public void setOrganizationId(int orgId) {
+        this.orgId = orgId;
+    }
+
+    /**
+     * @return Person first name.
+     */
+    public String getFirstName() {
+        return firstName;
+    }
+
+    /**
+     * @param firstName Person first name.
+     */
+    public void setFirstName(String firstName) {
+        this.firstName = firstName;
+    }
+
+    /**
+     * @return Person last name.
+     */
+    public String getLastName() {
+        return lastName;
+    }
+
+    /**
+     * @param lastName Person last name.
+     */
+    public void setLastName(String lastName) {
+        this.lastName = lastName;
+    }
+
+    /**
+     * @return Salary.
+     */
+    public double getSalary() {
+        return salary;
+    }
+
+    /**
+     * @param salary Salary.
+     */
+    public void setSalary(double salary) {
+        this.salary = salary;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeInt(id);
+        out.writeInt(orgId);
+        out.writeUTF(firstName);
+        out.writeUTF(lastName);
+        out.writeDouble(salary);
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        id = in.readInt();
+        orgId = in.readInt();
+        firstName = in.readUTF();
+        lastName = in.readUTF();
+        salary = in.readDouble();
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean equals(Object o) {
+        return this == o || (o instanceof Person) && id == ((Person)o).id;
+    }
+
+    /** {@inheritDoc} */
+    @Override public int hashCode() {
+        return id;
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return "Person [firstName=" + firstName +
+            ", id=" + id +
+            ", orgId=" + orgId +
+            ", lastName=" + lastName +
+            ", salary=" + salary +
+            ']';
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/SampleValue.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/SampleValue.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/SampleValue.java
new file mode 100644
index 0000000..b6cb5d1
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/model/SampleValue.java
@@ -0,0 +1,62 @@
+/*
+ * 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.yardstick.cache.model;
+
+import java.io.*;
+
+/**
+ * Entity class for benchmark.
+ */
+public class SampleValue implements Externalizable {
+    /** */
+    private int id;
+
+    /** */
+    public SampleValue() {
+        // No-op.
+    }
+
+    /**
+     * @param id Id.
+     */
+    public SampleValue(int id) {
+        this.id = id;
+    }
+
+    /**
+     * @return Id.
+     */
+    public int id() {
+        return id;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        id = in.readInt();
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        out.writeInt(id);
+    }
+
+    /** {@inheritDoc} */
+    @Override public String toString() {
+        return "Value [id=" + id + ']';
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
new file mode 100644
index 0000000..28ac816
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
@@ -0,0 +1,36 @@
+/*
+ * 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.yardstick.compute;
+
+import org.apache.ignite.yardstick.*;
+import org.apache.ignite.yardstick.compute.model.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * GridGain benchmark that performs affinity call operations.
+ */
+public class IgniteAffinityCallBenchmark extends IgniteAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        grid().compute().affinityCall("compute", ThreadLocalRandom.current().nextInt(), new NoopCallable());
+
+        return true;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
new file mode 100644
index 0000000..0b40cdd
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
@@ -0,0 +1,72 @@
+/*
+ * 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.yardstick.compute;
+
+import org.apache.ignite.lang.*;
+import org.apache.ignite.yardstick.*;
+import org.yardstickframework.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs apply operations.
+ */
+public class IgniteApplyBenchmark extends IgniteAbstractBenchmark {
+    /** Args for apply. */
+    private List<Integer> applyArgs;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        assert args.jobs() > 0;
+
+        applyArgs = new ArrayList<>(args.jobs());
+
+        for (int i = 0; i < args.jobs(); ++i)
+            applyArgs.add(null);
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        grid().compute().apply(new NoopClosure(), applyArgs);
+
+        return true;
+    }
+
+    /**
+     *
+     */
+    public static class NoopClosure implements IgniteClosure<Integer, Object>, Externalizable {
+        /** {@inheritDoc} */
+        @Override public Object apply(Integer o) {
+            return null;
+        }
+
+        /** {@inheritDoc} */
+        @Override public void writeExternal(ObjectOutput out) throws IOException {
+            //No-op
+        }
+
+        /** {@inheritDoc} */
+        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+            //No-op
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
new file mode 100644
index 0000000..0e37efa
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
@@ -0,0 +1,35 @@
+/*
+ * 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.yardstick.compute;
+
+import org.apache.ignite.yardstick.*;
+import org.apache.ignite.yardstick.compute.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs broadcast operations.
+ */
+public class IgniteBroadcastBenchmark extends IgniteAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        grid().compute().broadcast(new NoopCallable());
+
+        return true;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
new file mode 100644
index 0000000..4fc4530
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
@@ -0,0 +1,35 @@
+/*
+ * 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.yardstick.compute;
+
+import org.apache.ignite.yardstick.*;
+import org.apache.ignite.yardstick.compute.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs execute operations.
+ */
+public class IgniteExecuteBenchmark extends IgniteAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        grid().compute().execute(new NoopTask(args.jobs()), null);
+
+        return true;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
new file mode 100644
index 0000000..d0ca63e
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
@@ -0,0 +1,71 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.yardstick.compute;
+
+import org.apache.ignite.yardstick.*;
+import org.yardstickframework.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs run operations.
+ */
+public class IgniteRunBenchmark extends IgniteAbstractBenchmark {
+    /** Jobs for run */
+    private List<Runnable> jobs;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        assert args.jobs() > 0;
+
+        jobs = new ArrayList<>(args.jobs());
+
+        for (int i = 0; i < args.jobs(); ++i)
+            jobs.add(new NoopRunnable());
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        grid().compute().run(jobs);
+        
+        return true;
+    }
+
+    /**
+     *
+     */
+    public static class NoopRunnable implements Runnable, Externalizable {
+        /** {@inheritDoc} */
+        @Override public void run() {
+            //No-op
+        }
+
+        /** {@inheritDoc} */
+        @Override public void writeExternal(ObjectOutput out) throws IOException {
+            //No-op
+        }
+
+        /** {@inheritDoc} */
+        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+            //No-op
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopCallable.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopCallable.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopCallable.java
new file mode 100644
index 0000000..5a32618
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopCallable.java
@@ -0,0 +1,41 @@
+/*
+ * 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.yardstick.compute.model;
+
+import java.io.*;
+import java.util.concurrent.*;
+
+/**
+ *
+ */
+public class NoopCallable implements Callable<Object>, Externalizable {
+    /** {@inheritDoc} */
+    @Override public Object call() {
+        return null;
+    }
+
+    /** {@inheritDoc} */
+    @Override public void writeExternal(ObjectOutput out) throws IOException {
+        //No-op
+    }
+
+    /** {@inheritDoc} */
+    @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+        //No-op
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopTask.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopTask.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopTask.java
new file mode 100644
index 0000000..34ab2ad
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/model/NoopTask.java
@@ -0,0 +1,97 @@
+/*
+ * 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.yardstick.compute.model;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cluster.*;
+import org.apache.ignite.compute.*;
+import org.jetbrains.annotations.*;
+
+import java.io.*;
+import java.util.*;
+
+/**
+ * Assigns {@link NoopJob} job for each node.
+ */
+public class NoopTask implements ComputeTask<Object, Object> {
+    /** Number of jobs */
+    private int jobs;
+
+    /**
+     * @param jobs Number of jobs
+     */
+    public NoopTask(int jobs) {
+        assert jobs > 0;
+
+        this.jobs = jobs;
+    }
+
+    /** {@inheritDoc} */
+    @Override public ComputeJobResultPolicy result(
+        ComputeJobResult res,
+        List<ComputeJobResult> rcvd
+    ) throws IgniteCheckedException {
+        return ComputeJobResultPolicy.WAIT;
+    }
+
+    /** {@inheritDoc} */
+    @Nullable @Override public Map<? extends ComputeJob, ClusterNode> map(
+        List<ClusterNode> subgrid,
+        @Nullable Object arg
+    ) throws IgniteCheckedException {
+        Map<ComputeJob, ClusterNode> map = new HashMap<>((int)(subgrid.size() * jobs / 0.75));
+
+        for (ClusterNode gridNode : subgrid) {
+            //assigns jobs for each node
+            for (int i = 0; i < jobs; ++i)
+                map.put(new NoopJob(), gridNode);
+        }
+
+        return map;
+    }
+
+    /** {@inheritDoc} */
+    @Nullable @Override public Object reduce(List<ComputeJobResult> results) throws IgniteCheckedException {
+        return null;
+    }
+
+    /**
+     *
+     */
+    public static class NoopJob implements ComputeJob, Externalizable {
+        /** {@inheritDoc} */
+        @Nullable @Override public Object execute() throws IgniteCheckedException {
+            return null;
+        }
+
+        /** {@inheritDoc} */
+        @Override public void cancel() {
+            //No-op
+        }
+
+        /** {@inheritDoc} */
+        @Override public void writeExternal(ObjectOutput out) throws IOException {
+            //No-op
+        }
+
+        /** {@inheritDoc} */
+        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {
+            //No-op
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b0031ccd/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index b071a30..85d8321 100644
--- a/pom.xml
+++ b/pom.xml
@@ -15,7 +15,7 @@
   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.
-  -->
+-->
 
 <!--
     POM file.
@@ -1264,5 +1264,16 @@
                 </plugins>
             </build>
         </profile>
+
+        <profile>
+            <id>ignite-yardstick</id>
+            <activation>
+                <activeByDefault>false</activeByDefault>
+            </activation>
+
+            <modules>
+                <module>modules/yardstick</module>
+            </modules>
+        </profile>
     </profiles>
 </project>


[43/45] incubator-ignite git commit: # ignite-121 : fix review comments

Posted by sb...@apache.org.
# ignite-121 : fix review comments


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

Branch: refs/heads/ignite-121-logging
Commit: 7c7ec7dc5b0d20cf19b2c9a0b1d647896c96909f
Parents: b9722c4
Author: Artem SHutak <as...@gridgain.com>
Authored: Mon Feb 2 19:35:03 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Mon Feb 2 19:35:03 2015 +0300

----------------------------------------------------------------------
 .../impl/GridRouterCommandLineStartup.java      | 16 +++++---
 .../org/apache/ignite/internal/IgnitionEx.java  | 40 ++++++++++----------
 2 files changed, 32 insertions(+), 24 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7c7ec7dc/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java b/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
index 255e563..6dfe62b 100644
--- a/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
+++ b/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
@@ -18,19 +18,19 @@
 package org.apache.ignite.client.router.impl;
 
 import org.apache.ignite.*;
-import org.apache.ignite.lang.*;
-import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.client.router.*;
 import org.apache.ignite.internal.processors.spring.*;
 import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
+import org.apache.ignite.lang.*;
+import org.apache.ignite.lifecycle.*;
 
 import java.net.*;
 import java.util.*;
 import java.util.logging.*;
 
-import static org.apache.ignite.internal.IgniteComponentType.*;
 import static org.apache.ignite.internal.GridProductImpl.*;
+import static org.apache.ignite.internal.IgniteComponentType.*;
 
 /**
  * Loader class for router.
@@ -134,8 +134,14 @@ public class GridRouterCommandLineStartup {
         Collection<Handler> savedHnds = null;
 
         if (isLog4jUsed)
-            t = U.addLog4jNoOpLogger();
-        else
+            try {
+                t = U.addLog4jNoOpLogger();
+            }
+            catch (Exception e) {
+                isLog4jUsed = false;
+            }
+
+        if (!isLog4jUsed)
             savedHnds = U.addJavaNoOpLogger();
 
         Map<Class<?>, Object> beans;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7c7ec7dc/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 f8e0992..605bce0 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
@@ -725,17 +725,15 @@ public class IgnitionEx {
 
         Collection<Handler> savedHnds = null;
 
-        boolean log4jAdditionFailed = false;
-
-        if (isLog4jUsed) {
+        if (isLog4jUsed)
             try {
                 t = U.addLog4jNoOpLogger();
-            } catch (IgniteCheckedException e) {
-                System.out.println("[WARNING] Could not initialize log4j. Fallback to standard java logging.");
-                log4jAdditionFailed = true;
             }
-        }
-        if (!isLog4jUsed || log4jAdditionFailed)
+            catch (IgniteCheckedException e) {
+                isLog4jUsed = false;
+            }
+
+        if (!isLog4jUsed)
             savedHnds = U.addJavaNoOpLogger();
 
         IgniteBiTuple<Collection<IgniteConfiguration>, ? extends GridSpringResourceContext> cfgMap;
@@ -2005,19 +2003,19 @@ public class IgnitionEx {
          */
         private IgniteLogger initLogger(@Nullable IgniteLogger cfgLog, UUID nodeId) throws IgniteCheckedException {
             try {
-                boolean log4jInitFailed = false;
+                Exception log4jInitException = null;
 
                 if (cfgLog == null) {
                     Class<?> log4jCls = null;
 
                     try {
-                        try {
-                            log4jCls = Class.forName("org.apache.ignite.logger.log4j.IgniteLog4jLogger");
-                        }
-                        catch (ClassNotFoundException | NoClassDefFoundError ignored) {
-                            log4jCls = null;
-                        }
+                        log4jCls = Class.forName("org.apache.ignite.logger.log4j.IgniteLog4jLogger");
+                    }
+                    catch (ClassNotFoundException | NoClassDefFoundError ignored) {
+                        log4jCls = null;
+                    }
 
+                    try {
                         if (log4jCls != null) {
                             URL url = U.resolveGridGainUrl("config/ignite-log4j.xml");
 
@@ -2052,12 +2050,12 @@ public class IgnitionEx {
                             else
                                 cfgLog = (IgniteLogger)log4jCls.newInstance();
                         }
-                    } catch (Exception e) {
-                        System.out.println("[WARNING] Could not initialize log4j. Fallback to standard java logging.");
-                        log4jInitFailed = true;
+                    }
+                    catch (Exception e) {
+                        log4jInitException = e;
                     }
 
-                    if (log4jCls == null || log4jInitFailed)
+                    if (log4jCls == null || log4jInitException != null)
                         cfgLog = new IgniteJavaLogger();
                 }
 
@@ -2065,6 +2063,10 @@ public class IgnitionEx {
                 if (cfgLog instanceof IgniteLoggerNodeIdAware)
                     ((IgniteLoggerNodeIdAware)cfgLog).setNodeId(nodeId);
 
+                if (log4jInitException != null)
+                    U.warn(cfgLog, "Failed to initialize IgniteLog4jLogger (falling back to standard java logging): " +
+                            log4jInitException.getCause());
+
                 return cfgLog;
             }
             catch (Exception e) {


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

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

Branch: refs/heads/ignite-121-logging
Commit: 7e1ed4e7b619d75fc03c4e259df11caeb0e2a330
Parents: 0349c85 17a1aa2
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jan 27 19:11:46 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jan 27 19:11:46 2015 +0300

----------------------------------------------------------------------
 .../apache/ignite/cache/CacheEntryEvent.java    |   2 +-
 .../ignite/cache/store/CacheStoreSession.java   |   2 +-
 .../configuration/IgniteConfiguration.java      |  27 +-
 .../ignite/dotnet/GridDotNetConfiguration.java  | 113 -----
 .../dotnet/GridDotNetPortableConfiguration.java | 207 --------
 .../GridDotNetPortableTypeConfiguration.java    | 219 --------
 .../java/org/apache/ignite/dotnet/package.html  |  23 -
 .../org/apache/ignite/internal/GridGainEx.java  |   4 +-
 .../org/apache/ignite/internal/GridTopic.java   |   5 +-
 .../cache/query/GridCacheQueriesEx.java         |  16 +
 .../cache/query/GridCacheQueriesImpl.java       |  15 +
 .../cache/query/GridCacheQueriesProxy.java      |  24 +
 .../cache/query/GridCacheQueryManager.java      |  64 +--
 .../cache/query/GridCacheSqlQuery.java          |  99 ++++
 .../cache/query/GridCacheSqlResult.java         |  21 +
 .../cache/query/GridCacheTwoStepQuery.java      |  74 +++
 .../processors/query/GridQueryIndexing.java     |  19 +
 .../processors/query/GridQueryProcessor.java    |  36 ++
 .../ignite/interop/InteropConfiguration.java    |  30 ++
 .../java/org/apache/ignite/interop/package.html |  15 +
 .../apache/ignite/mxbean/IgniteCacheMXBean.java |   2 +-
 .../transactions/IgniteTxConcurrency.java       |   2 +-
 .../query/h2/GridH2ResultSetIterator.java       |   2 +-
 .../processors/query/h2/IgniteH2Indexing.java   | 173 ++++---
 .../query/h2/opt/GridH2IndexBase.java           |   5 +-
 .../query/h2/sql/GridSqlAggregateFunction.java  |  76 +++
 .../processors/query/h2/sql/GridSqlAlias.java   |  55 +++
 .../processors/query/h2/sql/GridSqlColumn.java  |  57 +++
 .../processors/query/h2/sql/GridSqlConst.java   |  39 ++
 .../processors/query/h2/sql/GridSqlElement.java |  73 +++
 .../query/h2/sql/GridSqlFunction.java           | 142 ++++++
 .../query/h2/sql/GridSqlFunctionType.java       |  78 +++
 .../processors/query/h2/sql/GridSqlJoin.java    |  68 +++
 .../query/h2/sql/GridSqlOperation.java          |  73 +++
 .../query/h2/sql/GridSqlOperationType.java      | 202 ++++++++
 .../query/h2/sql/GridSqlParameter.java          |  44 ++
 .../query/h2/sql/GridSqlQueryParser.java        | 495 +++++++++++++++++++
 .../query/h2/sql/GridSqlQuerySplitter.java      | 252 ++++++++++
 .../processors/query/h2/sql/GridSqlSelect.java  | 287 +++++++++++
 .../query/h2/sql/GridSqlSubquery.java           |  44 ++
 .../processors/query/h2/sql/GridSqlTable.java   |  55 +++
 .../processors/query/h2/sql/GridSqlValue.java   |  17 +
 .../query/h2/twostep/GridMapQueryExecutor.java  | 270 ++++++++++
 .../query/h2/twostep/GridMergeIndex.java        | 290 +++++++++++
 .../h2/twostep/GridMergeIndexUnsorted.java      |  85 ++++
 .../query/h2/twostep/GridMergeTable.java        | 178 +++++++
 .../h2/twostep/GridReduceQueryExecutor.java     | 242 +++++++++
 .../query/h2/twostep/GridResultPage.java        |  59 +++
 .../twostep/messages/GridNextPageRequest.java   |  59 +++
 .../twostep/messages/GridNextPageResponse.java  | 180 +++++++
 .../query/h2/twostep/messages/GridQueryAck.java |  34 ++
 .../twostep/messages/GridQueryFailResponse.java |  46 ++
 .../h2/twostep/messages/GridQueryRequest.java   |  61 +++
 .../cache/GridCacheCrossCacheQuerySelfTest.java | 111 ++++-
 .../query/h2/sql/GridQueryParsingTest.java      | 289 +++++++++++
 .../IgniteCacheQuerySelfTestSuite.java          |   4 +
 pom.xml                                         | 132 ++---
 57 files changed, 4526 insertions(+), 770 deletions(-)
----------------------------------------------------------------------



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

Posted by sb...@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/65200e26
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/65200e26
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/65200e26

Branch: refs/heads/ignite-121-logging
Commit: 65200e2644783bb43d6f2f8c81686f344b4acabd
Parents: fd1e80a 8795b0f
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 12:59:24 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 12:59:24 2015 +0300

----------------------------------------------------------------------
 assembly/libs/readme.txt                        |   12 +-
 config/fabric/default-config.xml                |    6 +-
 config/hadoop/default-config.xml                |    8 +-
 docs/gridgain_readme.md                         |    4 +-
 examples/config/example-cache.xml               |    2 +-
 examples/config/filesystem/example-ggfs.xml     |    4 +-
 examples/pom-standalone.xml                     |   18 +-
 .../examples/datagrid/CacheApiExample.java      |   10 -
 .../HibernateL2CacheExampleNodeStartup.java     |    6 +-
 .../store/CacheNodeWithStoreStartup.java        |   19 +-
 .../store/dummy/CacheDummyPersonStore.java      |   33 +-
 .../hibernate/CacheHibernatePersonStore.java    |   68 +-
 .../store/jdbc/CacheJdbcPersonStore.java        |   66 +-
 .../MemcacheRestExampleNodeStartup.java         |    5 +-
 modules/aop/readme.txt                          |    4 +-
 modules/aws/readme.txt                          |    4 +-
 .../spi/checkpoint/s3/GridS3CheckpointSpi.java  |   17 +-
 ...GridClientAbstractMultiThreadedSelfTest.java |    7 +-
 .../client/GridClientTopologyCacheSelfTest.java |    4 +-
 .../org/gridgain/client/GridHashMapStore.java   |   22 +-
 .../GridClientAbstractMultiNodeSelfTest.java    |   11 +-
 .../integration/GridClientAbstractSelfTest.java |   32 +-
 .../rest/GridAbstractRestProcessorSelfTest.java |    3 +-
 .../rest/GridRestBinaryProtocolSelfTest.java    |    6 +-
 .../rest/GridRestMemcacheProtocolSelfTest.java  |    7 +-
 .../rest/GridTaskCommandHandlerSelfTest.java    |    7 +-
 .../jdbc/GridJdbcComplexQuerySelfTest.java      |    3 +-
 .../jdbc/GridJdbcConnectionSelfTest.java        |    6 +-
 .../jdbc/GridJdbcEmptyCacheSelfTest.java        |    4 +-
 .../jdbc/GridJdbcLocalCachesSelfTest.java       |    3 +-
 .../gridgain/jdbc/GridJdbcMetadataSelfTest.java |    3 +-
 .../jdbc/GridJdbcPreparedStatementSelfTest.java |    3 +-
 .../jdbc/GridJdbcResultSetSelfTest.java         |    3 +-
 .../jdbc/GridJdbcStatementSelfTest.java         |    3 +-
 .../clients/src/test/resources/spring-cache.xml |    8 +-
 .../src/test/resources/spring-server-node.xml   |   12 +-
 .../test/resources/spring-server-ssl-node.xml   |   10 +-
 .../java/org/apache/ignite/IgniteCache.java     |  197 +-
 .../org/apache/ignite/IgniteCacheManager.java   |   12 +-
 .../apache/ignite/IgniteCachingProvider.java    |    2 +-
 .../java/org/apache/ignite/IgniteCompute.java   |    9 +-
 .../org/apache/ignite/IgniteDataLoader.java     |   20 +-
 .../java/org/apache/ignite/IgniteManaged.java   |   11 +-
 .../java/org/apache/ignite/IgnitePortables.java |    3 +-
 .../org/apache/ignite/IgniteTransactions.java   |    3 +-
 .../apache/ignite/cache/CacheConfiguration.java | 1784 +++++++++++++++++-
 .../java/org/apache/ignite/cache/CacheFlag.java |   74 -
 .../cache/store/CacheLoadOnlyStoreAdapter.java  |  324 ++++
 .../ignite/cache/store/CacheLocalStore.java     |   31 +
 .../apache/ignite/cache/store/CacheStore.java   |  179 ++
 .../ignite/cache/store/CacheStoreAdapter.java   |   95 +
 .../cache/store/CacheStoreBalancingWrapper.java |  297 +++
 .../ignite/cache/store/CacheStoreSession.java   |   43 +
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |  586 ++++++
 .../apache/ignite/cache/store/jdbc/package.html |   24 +
 .../org/apache/ignite/cache/store/package.html  |   23 +
 .../org/apache/ignite/cluster/ClusterNode.java  |   41 +-
 .../ignite/cluster/ClusterNodeLocalMap.java     |    3 +-
 .../org/apache/ignite/compute/ComputeJob.java   |   11 +-
 .../ignite/compute/ComputeJobSibling.java       |    3 +-
 .../ignite/compute/ComputeLoadBalancer.java     |    7 +-
 .../org/apache/ignite/compute/ComputeTask.java  |   17 +-
 .../ignite/compute/ComputeTaskAdapter.java      |    8 +-
 .../compute/ComputeTaskContinuousMapper.java    |    8 +-
 .../ignite/compute/ComputeTaskSession.java      |    6 +-
 .../configuration/IgniteConfiguration.java      |   10 +-
 .../configuration/IgniteDeploymentMode.java     |   35 +-
 .../processors/cache/IgniteCacheProxy.java      |  133 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |   13 +-
 .../ignite/logger/java/IgniteJavaLogger.java    |    4 +-
 .../apache/ignite/managed/ManagedService.java   |    4 +-
 .../ignite/marshaller/IgniteMarshaller.java     |   27 -
 .../marshaller/jdk/IgniteJdkMarshaller.java     |   25 -
 .../optimized/IgniteOptimizedClassResolver.java |    2 +-
 .../optimized/IgniteOptimizedMarshaller.java    |   23 -
 .../org/apache/ignite/mbean/IgniteMBean.java    |    2 +-
 .../IgniteAddressResolverResource.java          |   58 -
 .../resources/IgniteCacheNameResource.java      |   13 +-
 .../IgniteExecutorServiceResource.java          |   66 -
 .../ignite/resources/IgniteHomeResource.java    |   65 -
 .../resources/IgniteInstanceResource.java       |   17 +-
 .../resources/IgniteJobContextResource.java     |   10 +-
 .../resources/IgniteLoadBalancerResource.java   |   14 +-
 .../resources/IgniteLocalHostResource.java      |   66 -
 .../resources/IgniteLocalNodeIdResource.java    |   66 -
 .../ignite/resources/IgniteLoggerResource.java  |    9 +-
 .../resources/IgniteMBeanServerResource.java    |    5 +-
 .../resources/IgniteMarshallerResource.java     |   65 -
 .../ignite/resources/IgniteNameResource.java    |   65 -
 .../ignite/resources/IgniteServiceResource.java |    4 +-
 .../IgniteSpringApplicationContextResource.java |    5 +-
 .../ignite/resources/IgniteSpringResource.java  |   18 +-
 .../IgniteTaskContinuousMapperResource.java     |   10 +-
 .../resources/IgniteTaskSessionResource.java    |   10 +-
 .../ignite/resources/IgniteUserResource.java    |  132 --
 .../resources/IgniteUserResourceOnDeployed.java |   54 -
 .../IgniteUserResourceOnUndeployed.java         |   53 -
 .../java/org/apache/ignite/spi/IgniteSpi.java   |   10 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   23 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |   13 +-
 .../PriorityQueueCollisionSpi.java              |   16 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   38 +-
 .../discovery/tcp/TcpClientDiscoverySpi.java    |   54 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  111 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |   27 +-
 .../TcpDiscoveryMulticastIpFinder.java          |   10 +-
 .../spi/loadbalancing/LoadBalancingSpi.java     |    8 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |    4 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |   10 +-
 .../WeightedRandomLoadBalancingSpi.java         |    8 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |   19 +-
 .../apache/ignite/transactions/IgniteTx.java    |   37 +-
 .../gridgain/grid/GridBasicWarmupClosure.java   |   19 +-
 .../org/gridgain/grid/GridMetadataAware.java    |  187 --
 .../java/org/gridgain/grid/cache/GridCache.java |   23 +-
 .../grid/cache/GridCacheAtomicityMode.java      |    3 +-
 .../grid/cache/GridCacheConfiguration.java      | 1750 -----------------
 .../grid/cache/GridCacheDistributionMode.java   |    7 +-
 .../org/gridgain/grid/cache/GridCacheEntry.java |   77 +-
 .../org/gridgain/grid/cache/GridCacheFlag.java  |    5 +-
 .../grid/cache/GridCacheInterceptor.java        |    5 +-
 .../org/gridgain/grid/cache/GridCacheMBean.java |    3 +-
 .../org/gridgain/grid/cache/GridCacheMode.java  |    5 +-
 .../grid/cache/GridCachePreloadMode.java        |    5 +-
 .../grid/cache/GridCacheProjection.java         |  159 +-
 .../GridCacheWriteSynchronizationMode.java      |    2 +-
 .../grid/cache/affinity/GridCacheAffinity.java  |   38 +-
 .../affinity/GridCacheAffinityFunction.java     |    3 +-
 .../affinity/GridCacheAffinityKeyMapper.java    |    4 +-
 ...GridCacheConsistentHashAffinityFunction.java |    4 +-
 .../fair/GridCachePartitionFairAffinity.java    |    4 +-
 .../GridCacheRendezvousAffinityFunction.java    |    5 +-
 .../grid/cache/cloner/GridCacheCloner.java      |    7 +-
 .../cache/eviction/GridCacheEvictionFilter.java |    3 +-
 .../fifo/GridCacheFifoEvictionPolicy.java       |    4 +-
 .../lru/GridCacheLruEvictionPolicy.java         |    3 +-
 .../random/GridCacheRandomEvictionPolicy.java   |    4 +-
 .../store/GridCacheLoadOnlyStoreAdapter.java    |  328 ----
 .../grid/cache/store/GridCacheLocalStore.java   |   31 -
 .../grid/cache/store/GridCacheStore.java        |  220 ---
 .../grid/cache/store/GridCacheStoreAdapter.java |  100 -
 .../store/GridCacheStoreBalancingWrapper.java   |  278 ---
 .../store/jdbc/GridCacheJdbcBlobStore.java      |  552 ------
 .../gridgain/grid/cache/store/jdbc/package.html |   24 -
 .../org/gridgain/grid/cache/store/package.html  |   23 -
 .../grid/kernal/ClusterNodeLocalMapImpl.java    |   80 -
 .../org/gridgain/grid/kernal/GridGainEx.java    |   37 +-
 .../grid/kernal/GridJobContextImpl.java         |    4 +-
 .../grid/kernal/GridJobSiblingImpl.java         |    3 +-
 .../org/gridgain/grid/kernal/GridKernal.java    |   14 +-
 .../gridgain/grid/kernal/GridKernalContext.java |    3 +-
 .../grid/kernal/GridKernalContextImpl.java      |    6 +-
 .../gridgain/grid/kernal/GridLoggerProxy.java   |    5 +-
 .../gridgain/grid/kernal/GridProductImpl.java   |   12 +-
 .../gridgain/grid/kernal/GridProperties.java    |    2 +-
 .../grid/kernal/GridUpdateNotifier.java         |    4 +-
 .../kernal/executor/GridExecutorService.java    |    4 +-
 .../loadbalancer/GridLoadBalancerAdapter.java   |    4 +-
 .../kernal/processors/cache/CacheEntryImpl.java |   60 +
 .../processors/cache/CacheInvokeEntry.java      |    5 +-
 .../cache/CacheStorePartialUpdateException.java |   48 +
 .../processors/cache/GridCacheAdapter.java      |  395 +++-
 .../processors/cache/GridCacheAttributes.java   |   53 +-
 .../processors/cache/GridCacheContext.java      |   41 +-
 .../GridCacheDefaultAffinityKeyMapper.java      |    5 +-
 .../processors/cache/GridCacheEntryEx.java      |   85 +-
 .../processors/cache/GridCacheEntryImpl.java    |   54 +-
 .../cache/GridCacheEvictionEntry.java           |   36 -
 .../cache/GridCacheEvictionManager.java         |    3 +-
 .../cache/GridCacheFilterEvaluationEntry.java   |   36 -
 .../cache/GridCacheLoaderWriterStore.java       |  140 ++
 .../processors/cache/GridCacheLogger.java       |    3 +-
 .../processors/cache/GridCacheMapEntry.java     |   96 +-
 .../processors/cache/GridCacheProcessor.java    |  175 +-
 .../processors/cache/GridCacheProjectionEx.java |   18 +-
 .../processors/cache/GridCacheProxyImpl.java    |    3 +-
 .../processors/cache/GridCacheStoreManager.java |  775 +++++++-
 .../processors/cache/GridCacheTtlManager.java   |    4 +-
 .../kernal/processors/cache/GridCacheUtils.java |   19 +-
 .../cache/GridCacheWriteBehindStore.java        |  200 +-
 .../GridPartitionedCacheEntryImpl.java          |  147 --
 .../distributed/dht/GridDhtCacheAdapter.java    |  119 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |   12 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |    2 +-
 .../dht/GridPartitionedGetFuture.java           |    8 +
 .../dht/atomic/GridDhtAtomicCache.java          |   52 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |    6 +-
 .../dht/colocated/GridDhtColocatedCache.java    |    4 +
 .../colocated/GridDhtColocatedLockFuture.java   |    4 +-
 .../distributed/near/GridNearCacheAdapter.java  |    6 +
 .../distributed/near/GridNearGetFuture.java     |    8 +
 .../distributed/near/GridNearGetRequest.java    |   89 +-
 .../near/GridNearTransactionalCache.java        |    3 +
 .../cache/distributed/near/GridNearTxLocal.java |    9 +-
 .../cache/jta/GridCacheJtaManagerAdapter.java   |    4 +-
 .../cache/jta/GridCacheNoopJtaManager.java      |    4 +-
 .../local/atomic/GridLocalAtomicCache.java      |   66 +-
 .../cache/query/GridCacheQueryManager.java      |   37 -
 .../GridCacheContinuousQueryEntry.java          |   50 -
 .../cache/transactions/IgniteTxAdapter.java     |    3 +-
 .../cache/transactions/IgniteTxEx.java          |    5 +
 .../transactions/IgniteTxLocalAdapter.java      |   26 +-
 .../cache/transactions/IgniteTxLocalEx.java     |    2 +
 .../cache/transactions/IgniteTxProxyImpl.java   |   59 -
 .../dataload/GridDataLoadCacheUpdaters.java     |    9 +-
 .../dataload/GridDataLoadRequest.java           |   36 +-
 .../dataload/GridDataLoadUpdateJob.java         |   12 +-
 .../dataload/GridDataLoaderProcessor.java       |   13 +-
 .../dataload/IgniteDataLoaderImpl.java          |   20 +-
 .../dr/GridDrDataLoadCacheUpdater.java          |    7 +-
 .../kernal/processors/ggfs/GridGgfsHelper.java  |    6 +-
 .../processors/ggfs/GridGgfsHelperImpl.java     |    6 +-
 .../kernal/processors/ggfs/GridGgfsImpl.java    |    5 +-
 .../processors/ggfs/GridGgfsProcessor.java      |   10 +-
 .../processors/ggfs/GridNoopGgfsHelper.java     |    7 +-
 .../processors/query/GridQueryProcessor.java    |    8 +-
 .../resource/GridResourceCustomInjector.java    |  555 ------
 .../GridResourceJobContextInjector.java         |    2 +-
 .../resource/GridResourceProcessor.java         |  197 +-
 .../grid/kernal/visor/cache/VisorCache.java     |    4 +-
 .../cache/VisorCacheAffinityConfiguration.java  |    4 +-
 .../visor/cache/VisorCacheConfiguration.java    |    7 +-
 .../cache/VisorCacheDefaultConfiguration.java   |   10 +-
 .../visor/cache/VisorCacheDgcConfiguration.java |    4 +-
 .../cache/VisorCacheEvictionConfiguration.java  |   10 +-
 .../cache/VisorCacheNearConfiguration.java      |    4 +-
 .../cache/VisorCachePreloadConfiguration.java   |    3 +-
 .../cache/VisorCacheStoreConfiguration.java     |   12 +-
 .../VisorCacheWriteBehindConfiguration.java     |    4 +-
 .../java/org/gridgain/grid/util/GridUtils.java  |   19 -
 .../GridIpcSharedMemoryServerEndpoint.java      |   21 +-
 .../grid/util/lang/GridComputeJobWrapper.java   |   14 +-
 .../org/gridgain/grid/util/lang/GridFunc.java   |  146 --
 .../util/lang/GridMetadataAwareAdapter.java     |  159 +-
 .../core/src/main/resources/gridgain.properties |   22 -
 .../core/src/main/resources/ignite.properties   |   22 +
 .../spring-cache-client-benchmark-1.xml         |    4 +-
 .../spring-cache-client-benchmark-2.xml         |    4 +-
 .../spring-cache-client-benchmark-3.xml         |    4 +-
 .../core/src/test/config/discovery-stress.xml   |    2 +-
 modules/core/src/test/config/example-cache.xml  |    2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |    4 +-
 .../core/src/test/config/ggfs-no-endpoint.xml   |    4 +-
 modules/core/src/test/config/ggfs-shmem.xml     |    4 +-
 .../src/test/config/load/cache-benchmark.xml    |    4 +-
 .../test/config/load/cache-client-benchmark.xml |    4 +-
 .../config/load/dsi-49-server-production.xml    |    4 +-
 .../src/test/config/load/dsi-load-client.xml    |    4 +-
 .../src/test/config/load/dsi-load-server.xml    |    4 +-
 .../test/config/load/mongo-multinode-foster.xml |    4 +-
 .../core/src/test/config/spring-cache-load.xml  |    2 +-
 .../config/spring-cache-put-remove-load.xml     |    2 +-
 .../core/src/test/config/spring-cache-swap.xml  |    2 +-
 .../src/test/config/spring-cache-teststore.xml  |    2 +-
 .../core/src/test/config/spring-multicache.xml  |   18 +-
 .../test/config/websession/spring-cache-1.xml   |    6 +-
 .../test/config/websession/spring-cache-2.xml   |    6 +-
 .../test/config/websession/spring-cache-3.xml   |    6 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |  250 +++
 .../jdbc/GridCacheJdbcBlobStoreSelfTest.java    |   51 +
 .../apache/ignite/cache/store/jdbc/package.html |   23 +
 .../cache/IgniteCacheAbstractTest.java          |   58 +-
 ...niteCacheAtomicLocalWithStoreInvokeTest.java |    4 +-
 ...micPrimaryWriteOrderWithStoreInvokeTest.java |    4 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |    8 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |    4 +-
 .../cache/IgniteCacheInvokeReadThroughTest.java |    4 +-
 .../cache/IgniteCachingProviderSelfTest.java    |    9 +-
 ...maryWriteOrderWithStoreExpiryPolicyTest.java |    4 +-
 ...iteCacheAtomicWithStoreExpiryPolicyTest.java |    4 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    5 +-
 .../IgniteCacheTxWithStoreExpiryPolicyTest.java |    4 +-
 .../IgniteCacheAtomicLoadAllTest.java           |   55 +
 .../IgniteCacheAtomicLoaderWriterTest.java      |   55 +
 .../IgniteCacheAtomicLocalLoadAllTest.java      |   49 +
 ...CacheAtomicLocalNoLoadPreviousValueTest.java |   49 +
 ...IgniteCacheAtomicLocalNoReadThroughTest.java |   49 +
 ...gniteCacheAtomicLocalNoWriteThroughTest.java |   49 +
 ...tomicNearEnabledNoLoadPreviousValueTest.java |   32 +
 ...CacheAtomicNearEnabledNoReadThroughTest.java |   32 +
 ...acheAtomicNearEnabledNoWriteThroughTest.java |   32 +
 ...gniteCacheAtomicNoLoadPreviousValueTest.java |   55 +
 .../IgniteCacheAtomicNoReadThroughTest.java     |   55 +
 .../IgniteCacheAtomicNoWriteThroughTest.java    |   55 +
 .../IgniteCacheAtomicStoreSessionTest.java      |   55 +
 .../IgniteCacheLoadAllAbstractTest.java         |  236 +++
 .../IgniteCacheLoaderWriterAbstractTest.java    |  377 ++++
 ...iteCacheNoLoadPreviousValueAbstractTest.java |  213 +++
 .../IgniteCacheNoReadThroughAbstractTest.java   |  322 ++++
 .../IgniteCacheNoWriteThroughAbstractTest.java  |  345 ++++
 .../IgniteCacheStoreSessionAbstractTest.java    |  303 +++
 .../integration/IgniteCacheTxLoadAllTest.java   |   50 +
 .../IgniteCacheTxLoaderWriterTest.java          |   49 +
 .../IgniteCacheTxLocalLoadAllTest.java          |   49 +
 ...niteCacheTxLocalNoLoadPreviousValueTest.java |   49 +
 .../IgniteCacheTxLocalNoReadThroughTest.java    |   49 +
 .../IgniteCacheTxLocalNoWriteThroughTest.java   |   49 +
 ...cheTxNearEnabledNoLoadPreviousValueTest.java |   32 +
 ...niteCacheTxNearEnabledNoReadThroughTest.java |   32 +
 ...iteCacheTxNearEnabledNoWriteThroughTest.java |   32 +
 .../IgniteCacheTxNoLoadPreviousValueTest.java   |   49 +
 .../IgniteCacheTxNoReadThroughTest.java         |   49 +
 .../IgniteCacheTxNoWriteThroughTest.java        |   49 +
 .../IgniteCacheTxStoreSessionTest.java          |  286 +++
 ...idCacheCheckpointSpiSecondCacheSelfTest.java |    5 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    7 +-
 .../tcp/GridTcpClientDiscoverySelfTest.java     |    6 +-
 .../GridCacheStoreValueBytesNode.java           |    4 +-
 .../grid/GridCacheAffinityBackupsSelfTest.java  |    4 +-
 .../org/gridgain/grid/GridTestJobContext.java   |    3 +-
 ...CachePartitionFairAffinityNodesSelfTest.java |    7 +-
 .../store/GridCacheBalancingStoreSelfTest.java  |   42 +-
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |   20 +-
 .../cache/store/GridGeneratingTestStore.java    |   38 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |  243 ---
 .../jdbc/GridCacheJdbcBlobStoreSelfTest.java    |   51 -
 .../gridgain/grid/cache/store/jdbc/package.html |   23 -
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   11 +-
 .../GridGgfsFragmentizerAbstractSelfTest.java   |    9 +-
 .../grid/kernal/GridAffinityMappedTest.java     |    5 +-
 .../grid/kernal/GridAffinityP2PSelfTest.java    |    4 +-
 .../grid/kernal/GridAffinitySelfTest.java       |   11 +-
 .../kernal/GridCancelOnGridStopSelfTest.java    |    6 +-
 .../grid/kernal/GridDiscoverySelfTest.java      |    3 +-
 .../GridExplicitImplicitDeploymentSelfTest.java |    6 +-
 .../GridFailoverCustomTopologySelfTest.java     |   16 +-
 .../grid/kernal/GridFailoverSelfTest.java       |    8 +-
 .../GridFailoverTaskWithPredicateSelfTest.java  |    4 -
 .../kernal/GridFailoverTopologySelfTest.java    |   18 +-
 .../grid/kernal/GridJobContextSelfTest.java     |    8 +-
 .../kernal/GridJobMasterLeaveAwareSelfTest.java |    8 +-
 .../grid/kernal/GridMultipleJobsSelfTest.java   |    5 +-
 .../grid/kernal/GridMultipleSpisSelfTest.java   |   10 +-
 .../GridMultipleVersionsDeploymentSelfTest.java |   12 +-
 .../kernal/GridProjectionForCachesSelfTest.java |    6 +-
 ...ectionLocalJobMultipleArgumentsSelfTest.java |    4 +-
 .../kernal/GridRuntimeExceptionSelfTest.java    |    8 +-
 .../grid/kernal/GridStartStopSelfTest.java      |    6 +-
 .../grid/kernal/GridStopWithCancelSelfTest.java |    8 +-
 .../grid/kernal/GridStopWithWaitSelfTest.java   |   20 +-
 .../kernal/GridTaskInstantiationSelfTest.java   |    8 +-
 .../grid/kernal/GridUpdateNotifierSelfTest.java |    2 +-
 .../GridCheckpointManagerAbstractSelfTest.java  |    4 +-
 .../checkpoint/GridCheckpointTaskSelfTest.java  |   21 +-
 .../GridDeploymentMessageCountSelfTest.java     |    3 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    4 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |    5 +-
 .../GridAffinityProcessorAbstractSelfTest.java  |    3 +-
 .../GridCacheAbstractFailoverSelfTest.java      |    6 +-
 .../cache/GridCacheAbstractFlagsTest.java       |    9 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |    4 +-
 .../GridCacheAbstractProjectionSelfTest.java    |    9 +-
 .../cache/GridCacheAbstractSelfTest.java        |   34 +-
 .../cache/GridCacheAbstractTxReadTest.java      |    7 +-
 .../cache/GridCacheAffinityApiSelfTest.java     |    5 +-
 .../cache/GridCacheAffinityRoutingSelfTest.java |    6 +-
 .../GridCacheAsyncOperationsLimitSelfTest.java  |    6 +-
 .../GridCacheAtomicMessageCountSelfTest.java    |    3 +-
 .../cache/GridCacheBasicStoreAbstractTest.java  |   15 +-
 ...acheBasicStoreMultithreadedAbstractTest.java |   25 +-
 .../cache/GridCacheClearAllSelfTest.java        |    9 +-
 .../cache/GridCacheConcurrentMapSelfTest.java   |    3 +-
 .../cache/GridCacheConcurrentMapTest.java       |    3 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    3 +-
 ...idCacheConfigurationConsistencySelfTest.java |  264 +--
 ...ridCacheConfigurationValidationSelfTest.java |    6 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |    3 +-
 .../GridCacheDeploymentOffHeapSelfTest.java     |    6 +-
 .../cache/GridCacheDeploymentSelfTest.java      |    5 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |    3 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |    3 +-
 .../GridCacheEvictionEventAbstractTest.java     |    3 +-
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    4 +-
 .../GridCacheFinishPartitionsSelfTest.java      |    4 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |    5 +-
 .../cache/GridCacheGenericTestStore.java        |   78 +-
 ...idCacheGetAndTransformStoreAbstractTest.java |   10 +-
 .../cache/GridCacheGlobalClearAllSelfTest.java  |    3 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |   65 +-
 .../GridCacheGroupLockFailoverSelfTest.java     |    3 +-
 .../cache/GridCacheIncrementTransformTest.java  |    3 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |   54 +-
 ...cheInterceptorAtomicNearEnabledSelfTest.java |    1 +
 .../cache/GridCacheIteratorPerformanceTest.java |    5 +-
 .../cache/GridCacheKeyCheckSelfTest.java        |    5 +-
 .../processors/cache/GridCacheLeakTest.java     |    5 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   60 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |    5 +-
 .../cache/GridCacheMemoryModeSelfTest.java      |    6 +-
 .../GridCacheMissingCommitVersionSelfTest.java  |    3 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    5 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |    5 +-
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |    4 +-
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    6 +-
 .../cache/GridCacheMvccFlagsTest.java           |    4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    5 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |    4 +-
 .../processors/cache/GridCacheMvccSelfTest.java |    4 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    3 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |    5 +-
 .../cache/GridCacheOffHeapSelfTest.java         |    3 +-
 .../processors/cache/GridCacheOffHeapTest.java  |    3 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |    6 +-
 ...heOffHeapTieredEvictionAbstractSelfTest.java |    5 +-
 .../cache/GridCacheOffheapUpdateSelfTest.java   |    3 +-
 .../GridCacheOrderedPreloadingSelfTest.java     |    5 +-
 .../cache/GridCacheP2PUndeploySelfTest.java     |    6 +-
 .../cache/GridCachePartitionedGetSelfTest.java  |    5 +-
 ...hePartitionedProjectionAffinitySelfTest.java |    3 +-
 .../cache/GridCachePartitionedWritesTest.java   |   26 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |    3 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    3 +-
 .../GridCacheQueryIndexingDisabledSelfTest.java |    6 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |    5 +-
 .../GridCacheReferenceCleanupSelfTest.java      |    3 +-
 .../cache/GridCacheReloadSelfTest.java          |   28 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |    3 +-
 .../GridCacheReturnValueTransferSelfTest.java   |    6 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    7 +-
 .../processors/cache/GridCacheStopSelfTest.java |    3 +-
 .../cache/GridCacheStorePutxSelfTest.java       |   48 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |    5 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |    3 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |   29 +-
 .../processors/cache/GridCacheTestStore.java    |   97 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |    4 +-
 .../GridCacheValueBytesPreloadingSelfTest.java  |    5 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |    5 +-
 .../GridCacheVariableTopologySelfTest.java      |    3 +-
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   13 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |   10 +-
 ...BehindStorePartitionedMultiNodeSelfTest.java |   14 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |   50 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |   11 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |    3 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   48 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |    6 +-
 ...actQueueFailoverDataConsistencySelfTest.java |   13 +-
 .../GridCacheAtomicLongApiSelfTest.java         |    7 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   37 +-
 .../GridCacheCountDownLatchSelfTest.java        |    8 +-
 .../GridCacheQueueCleanupSelfTest.java          |    5 +-
 ...dCacheQueueMultiNodeConsistencySelfTest.java |    3 +-
 .../GridCacheSetAbstractSelfTest.java           |    9 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |   14 +-
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    4 +-
 .../local/GridCacheLocalQueueApiSelfTest.java   |    4 +-
 .../GridCacheLocalSequenceApiSelfTest.java      |    4 +-
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    4 +-
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    6 +-
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    4 +-
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    4 +-
 ...hePartitionedAtomicReferenceApiSelfTest.java |    4 +-
 ...PartitionedAtomicReferenceMultiNodeTest.java |    5 +-
 ...titionedAtomicSequenceMultiThreadedTest.java |    3 +-
 .../GridCachePartitionedAtomicSetSelfTest.java  |    5 +-
 ...achePartitionedAtomicStampedApiSelfTest.java |    4 +-
 ...GridCachePartitionedNodeRestartSelfTest.java |    4 +-
 ...idCachePartitionedNodeRestartTxSelfTest.java |    4 +-
 .../GridCachePartitionedQueueApiSelfTest.java   |    4 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |    5 +-
 ...dCachePartitionedQueueEntryMoveSelfTest.java |    5 +-
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    4 +-
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    4 +-
 ...hePartitionedQueueRotativeMultiNodeTest.java |    4 +-
 ...GridCachePartitionedSequenceApiSelfTest.java |    4 +-
 ...chePartitionedSequenceMultiNodeSelfTest.java |    4 +-
 ...cheReplicatedAtomicReferenceApiSelfTest.java |    4 +-
 ...eReplicatedAtomicReferenceMultiNodeTest.java |    4 +-
 ...CacheReplicatedAtomicStampedApiSelfTest.java |    4 +-
 .../GridCacheReplicatedQueueApiSelfTest.java    |    4 +-
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    4 +-
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    4 +-
 .../GridCacheReplicatedSequenceApiSelfTest.java |    4 +-
 ...acheReplicatedSequenceMultiNodeSelfTest.java |    4 +-
 ...tractDistributedByteArrayValuesSelfTest.java |   19 +-
 .../GridCacheAbstractNodeRestartSelfTest.java   |    2 +-
 ...tractPartitionedByteArrayValuesSelfTest.java |   13 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java   |    3 +-
 .../GridCacheAtomicTimeoutSelfTest.java         |    4 +-
 .../GridCacheClientModesAbstractSelfTest.java   |   15 +-
 ...acheEntrySetIterationPreloadingSelfTest.java |    5 +-
 ...heExpiredEntriesPreloadAbstractSelfTest.java |    9 +-
 .../distributed/GridCacheLockAbstractTest.java  |    9 +-
 .../distributed/GridCacheMixedModeSelfTest.java |    5 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    3 +-
 ...dCachePartitionedAffinityFilterSelfTest.java |    3 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |   31 +-
 .../GridCachePreloadEventsAbstractSelfTest.java |    5 +-
 ...GridCachePreloadRestartAbstractSelfTest.java |    5 +-
 .../GridCacheTransformEventSelfTest.java        |    3 +-
 ...iteTxConsistencyRestartAbstractSelfTest.java |    5 +-
 ...xOriginatingNodeFailureAbstractSelfTest.java |    9 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |    9 +-
 .../IgniteTxPreloadAbstractTest.java            |   13 +-
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |    7 +-
 ...heAbstractTransformWriteThroughSelfTest.java |   11 +-
 .../dht/GridCacheAtomicFullApiSelfTest.java     |    5 +-
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |    3 +-
 .../dht/GridCacheColocatedDebugTest.java        |   30 +-
 ...eColocatedOptimisticTransactionSelfTest.java |    3 +-
 ...dCacheColocatedTxSingleThreadedSelfTest.java |    3 +-
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    6 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |    3 +-
 .../dht/GridCacheDhtEntrySetSelfTest.java       |    6 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |    4 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |    4 +-
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |    3 +-
 .../dht/GridCacheDhtInternalEntrySelfTest.java  |    4 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |    3 +-
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |    6 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |    3 +-
 .../GridCacheDhtPreloadDisabledSelfTest.java    |    4 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |    3 +-
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |    3 +-
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |    6 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |    3 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |    8 +-
 .../GridCacheDhtPreloadStartStopSelfTest.java   |    8 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |    6 +-
 .../dht/GridCacheDhtRemoveFailureTest.java      |    5 +-
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    5 +-
 .../dht/GridCacheGlobalLoadTest.java            |   16 +-
 ...ePartitionedNearDisabledMetricsSelfTest.java |    5 +-
 ...isabledTxOriginatingNodeFailureSelfTest.java |    1 -
 ...idCachePartitionedPreloadEventsSelfTest.java |    5 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |    3 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |    5 +-
 ...ridCachePartitionedUnloadEventsSelfTest.java |    5 +-
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    5 +-
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |    3 +-
 ...GridCacheValueConsistencyAtomicSelfTest.java |    4 +-
 ...unctionExcludeNeighborsAbstractSelfTest.java |    4 +-
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |    5 +-
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |    5 +-
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |    5 +-
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |    5 +-
 .../GridCacheAtomicNearRemoveFailureTest.java   |    5 +-
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |    5 +-
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |    5 +-
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    6 +-
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |    5 +-
 .../near/GridCacheGetStoreErrorSelfTest.java    |   29 +-
 .../near/GridCacheNearEvictionSelfTest.java     |    3 +-
 .../near/GridCacheNearJobExecutionSelfTest.java |    3 +-
 .../near/GridCacheNearMetricsSelfTest.java      |    5 +-
 .../near/GridCacheNearMultiGetSelfTest.java     |    3 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |   24 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |   26 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |    5 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |    3 +-
 .../GridCacheNearPartitionedClearSelfTest.java  |   14 +-
 .../GridCacheNearReaderPreloadSelfTest.java     |    4 +-
 .../near/GridCacheNearReadersSelfTest.java      |    3 +-
 .../near/GridCacheNearRemoveFailureTest.java    |    6 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |    3 +-
 .../near/GridCacheNearTxPreloadSelfTest.java    |    5 +-
 ...AffinityExcludeNeighborsPerformanceTest.java |    4 +-
 ...rtitionedAffinityHashIdResolverSelfTest.java |    4 +-
 .../GridCachePartitionedAffinitySelfTest.java   |    4 +-
 .../near/GridCachePartitionedBasicApiTest.java  |    4 +-
 .../GridCachePartitionedBasicOpSelfTest.java    |    3 +-
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |  108 +-
 .../near/GridCachePartitionedEventSelfTest.java |    6 +-
 .../GridCachePartitionedEvictionSelfTest.java   |    4 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    3 +-
 ...GridCachePartitionedFilteredPutSelfTest.java |    5 +-
 .../GridCachePartitionedFullApiSelfTest.java    |    5 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |   34 +-
 .../near/GridCachePartitionedLockSelfTest.java  |    3 +-
 .../GridCachePartitionedMetricsSelfTest.java    |    6 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |    3 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |    5 +-
 ...idCachePartitionedMultiNodeLockSelfTest.java |    4 +-
 .../GridCachePartitionedMultiNodeSelfTest.java  |    3 +-
 ...ePartitionedMultiThreadedPutGetSelfTest.java |    3 +-
 .../near/GridCachePartitionedNestedTxTest.java  |    4 +-
 ...GridCachePartitionedNodeFailureSelfTest.java |    3 +-
 .../GridCachePartitionedNodeRestartTest.java    |    4 +-
 ...ePartitionedOptimisticTxNodeRestartTest.java |    4 +-
 ...achePartitionedPreloadLifecycleSelfTest.java |    7 +-
 .../GridCachePartitionedProjectionSelfTest.java |    5 +-
 ...hePartitionedQueryMultiThreadedSelfTest.java |    3 +-
 .../GridCachePartitionedStorePutSelfTest.java   |   28 +-
 ...GridCachePartitionedTxConcurrentGetTest.java |    4 +-
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    4 +-
 ...CachePartitionedTxMultiThreadedSelfTest.java |    4 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    3 +-
 ...achePartitionedTxSingleThreadedSelfTest.java |    3 +-
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    4 +-
 .../near/GridCachePutArrayValueSelfTest.java    |    5 +-
 ...idCacheRendezvousAffinityClientSelfTest.java |    3 +-
 .../near/GridPartitionedBackupLoadSelfTest.java |   30 +-
 ...stractReplicatedByteArrayValuesSelfTest.java |   14 +-
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    6 +-
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |    5 +-
 .../GridCacheReplicatedBasicApiTest.java        |    4 +-
 .../GridCacheReplicatedBasicOpSelfTest.java     |    4 +-
 .../GridCacheReplicatedClientOnlySelfTest.java  |    5 +-
 .../GridCacheReplicatedEvictionSelfTest.java    |    5 +-
 .../GridCacheReplicatedFullApiSelfTest.java     |    5 +-
 .../GridCacheReplicatedInvalidateSelfTest.java  |    3 +-
 .../GridCacheReplicatedJobExecutionTest.java    |    3 +-
 .../GridCacheReplicatedMarshallerTxTest.java    |    4 +-
 .../GridCacheReplicatedMetricsSelfTest.java     |    6 +-
 ...ridCacheReplicatedMultiNodeLockSelfTest.java |    4 +-
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    4 +-
 .../GridCacheReplicatedNearOnlySelfTest.java    |    5 +-
 .../GridCacheReplicatedNodeFailureSelfTest.java |    4 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java |    4 +-
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |    6 +-
 .../GridCacheReplicatedTxConcurrentGetTest.java |    4 +-
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    4 +-
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |    4 +-
 ...CacheReplicatedTxSingleThreadedSelfTest.java |    4 +-
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    4 +-
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |    3 +-
 .../GridCacheSyncReplicatedPreloadSelfTest.java |    4 +-
 ...CacheReplicatedPreloadLifecycleSelfTest.java |    7 +-
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |    7 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |    5 +-
 ...eplicatedPreloadStartStopEventsSelfTest.java |    4 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |   30 +-
 ...heConcurrentEvictionConsistencySelfTest.java |    3 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |    3 +-
 .../GridCacheDistributedEvictionsSelfTest.java  |    3 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   32 +-
 .../eviction/GridCacheEvictionAbstractTest.java |    3 +-
 .../GridCacheEvictionFilterSelfTest.java        |    3 +-
 .../GridCacheEvictionLockUnlockSelfTest.java    |    3 +-
 .../GridCacheEvictionTouchSelfTest.java         |   27 +-
 ...cheSynchronousEvictionsFailoverSelfTest.java |    5 +-
 .../GridCacheLruNearEvictionPolicySelfTest.java |    3 +-
 ...heNearOnlyLruNearEvictionPolicySelfTest.java |    3 +-
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |    4 +-
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    6 +-
 .../local/GridCacheLocalBasicApiSelfTest.java   |    4 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java  |    5 +-
 .../local/GridCacheLocalFullApiSelfTest.java    |    5 +-
 .../local/GridCacheLocalLoadAllSelfTest.java    |   39 +-
 .../cache/local/GridCacheLocalLockSelfTest.java |    5 +-
 .../local/GridCacheLocalMetricsSelfTest.java    |    6 +-
 .../GridCacheLocalMultithreadedSelfTest.java    |    2 +-
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    4 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    4 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |    3 +-
 .../GridCacheSwapScanQueryAbstractSelfTest.java |    5 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |   28 +-
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |    5 +-
 .../continuous/GridMessageListenSelfTest.java   |   13 +-
 .../dataload/GridDataLoaderImplSelfTest.java    |    5 +-
 .../dataload/GridDataLoaderPerformanceTest.java |    4 +-
 .../GridDataLoaderProcessorSelfTest.java        |  104 +-
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |    9 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |    5 +-
 .../processors/ggfs/GridGgfsCacheSelfTest.java  |    5 +-
 .../ggfs/GridGgfsDataManagerSelfTest.java       |    5 +-
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |    6 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |    9 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |    9 +-
 .../ggfs/GridGgfsProcessorSelfTest.java         |    6 +-
 .../GridGgfsProcessorValidationSelfTest.java    |   78 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |    5 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |    5 +-
 .../ggfs/GridGgfsStreamsSelfTest.java           |    6 +-
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |    6 +-
 .../GridGgfsAbstractRecordResolverSelfTest.java |    6 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    3 +-
 .../GridServiceProcessorAbstractSelfTest.java   |    4 +-
 .../gridgain/grid/lang/GridFuncSelfTest.java    |    4 +-
 .../gridgain/grid/lang/GridTupleSelfTest.java   |   85 -
 .../marshaller/GridMarshallerAbstractTest.java  |    6 +-
 .../p2p/GridAbstractMultinodeRedeployTest.java  |   10 +-
 .../GridP2PContinuousDeploymentSelfTest.java    |    6 +-
 .../GridP2PDifferentClassLoaderSelfTest.java    |    8 +-
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |   35 +-
 .../grid/p2p/GridP2PJobClassLoaderSelfTest.java |   20 +-
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |   54 +-
 .../grid/p2p/GridP2PNodeLeftSelfTest.java       |   21 +-
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |    8 +-
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   33 +-
 .../org/gridgain/grid/p2p/GridP2PTestJob.java   |    9 +-
 .../org/gridgain/grid/p2p/GridP2PTestTask.java  |    8 +-
 .../GridSessionCheckpointAbstractSelfTest.java  |   15 +-
 .../session/GridSessionCheckpointSelfTest.java  |    4 +-
 .../session/GridSessionJobFailoverSelfTest.java |    5 +-
 .../util/future/GridEmbeddedFutureSelfTest.java |    2 +-
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |    4 +-
 .../loadtests/GridCacheMultiNodeLoadTest.java   |    4 +-
 ...ridCacheAffinityTransactionsOffHeapTest.java |    3 +-
 .../cache/GridCachePutRemoveLoadTest.java       |    3 +-
 .../cache/GridCacheSingleNodeLoadTest.java      |    3 +-
 .../GridCacheWriteBehindStoreLoadTest.java      |   23 +-
 .../capacity/spring-capacity-cache.xml          |    4 +-
 .../colocation/GridTestCacheStore.java          |   23 +-
 .../loadtests/colocation/spring-colocation.xml  |    4 +-
 .../GridCachePartitionedAtomicLongLoadTest.java |    3 +-
 .../stealing/GridStealingLoadTestJob.java       |    8 +-
 .../loadtests/dsi/GridDsiLifecycleBean.java     |    2 +-
 .../loadtests/hashmap/GridCacheTestContext.java |   13 +-
 .../loadtests/hashmap/GridHashMapLoadTest.java  |   14 +-
 .../loadtests/job/GridJobLoadTestJob.java       |   12 +-
 .../swap/GridSwapEvictAllBenchmark.java         |   28 +-
 .../gridgain/testframework/GridTestUtils.java   |   39 +
 .../testframework/junits/GridAbstractTest.java  |    7 +-
 .../testframework/junits/GridTestIgnite.java    |  224 +++
 .../junits/GridTestKernalContext.java           |    4 +-
 .../testframework/junits/GridTestResources.java |   23 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |  252 ++-
 .../junits/cache/TestCacheSession.java          |   65 +
 .../cache/TestThreadLocalCacheSession.java      |   65 +
 .../GridAbstractLifecycleAwareSelfTest.java     |    7 +
 .../junits/common/GridCommonAbstractTest.java   |    9 +-
 .../junits/logger/GridTestLog4jLogger.java      |    4 +-
 .../GridCacheGroupLockSelfTestSuite.java        |    2 +-
 .../bamboo/GridDataGridTestSuite.java           |   34 +-
 .../core/src/test/webapp/META-INF/gg-config.xml |   10 +-
 modules/email/readme.txt                        |    4 +-
 .../GridExternalCacheQueryReducerClosure.java   |   43 -
 .../tests/p2p/GridP2PAwareTestUserResource.java |   20 -
 .../p2p/GridP2PEventFilterExternalPath1.java    |    5 -
 .../p2p/GridP2PEventFilterExternalPath2.java    |    5 -
 .../tests/p2p/GridP2PTestTaskExternalPath1.java |   22 +-
 .../tests/p2p/GridP2PTestTaskExternalPath2.java |   24 +-
 modules/hadoop/readme.txt                       |    4 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   13 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |    5 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |   13 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   10 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |    6 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |    9 +-
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |    5 +-
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |    9 +-
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |    5 +-
 .../hadoop/GridHadoopAbstractSelfTest.java      |   10 +-
 modules/hibernate/readme.txt                    |    4 +-
 .../hibernate/GridCacheHibernateBlobStore.java  |   95 +-
 ...idHibernateL2CacheConfigurationSelfTest.java |    5 +-
 .../hibernate/GridHibernateL2CacheSelfTest.java |    9 +-
 ...idHibernateL2CacheTransactionalSelfTest.java |    5 +-
 .../GridCacheHibernateBlobStoreSelfTest.java    |    6 +-
 modules/indexing/readme.txt                     |    4 +-
 .../processors/query/h2/GridH2Indexing.java     |   29 +-
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    8 +-
 .../GridCacheAbstractFieldsQuerySelfTest.java   |    5 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |   30 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |    5 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    3 +-
 .../cache/GridCacheQueryLoadSelfTest.java       |   41 +-
 .../cache/GridCacheQueryMetricsSelfTest.java    |    3 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |    3 +-
 .../GridCacheQueryUserResourceSelfTest.java     |  180 --
 ...idCacheReduceQueryMultithreadedSelfTest.java |    5 +-
 .../GridCacheSqlQueryMultiThreadedSelfTest.java |    3 +-
 .../processors/cache/GridCacheSwapSelfTest.java |    3 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java |    3 +-
 ...GridCachePartitionedFieldsQuerySelfTest.java |    5 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |    5 +-
 .../near/GridCacheQueryNodeRestartSelfTest.java |    3 +-
 .../testsuites/GridCacheQuerySelfTestSuite.java |    1 -
 modules/jcl/readme.txt                          |    4 +-
 .../gridgain/grid/logger/jcl/GridJclLogger.java |    3 +-
 modules/jta/readme.txt                          |    4 +-
 .../grid/cache/jta/GridCacheTmLookup.java       |    5 +-
 .../cache/jta/GridCacheJtaManager.java          |    4 +-
 ...CacheJtaConfigurationValidationSelfTest.java |    4 +-
 .../processors/cache/GridCacheJtaSelfTest.java  |    9 +-
 .../GridTmLookupLifecycleAwareSelfTest.java     |    4 +-
 modules/log4j/readme.txt                        |    4 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |    4 +-
 modules/rest-http/readme.txt                    |    4 +-
 modules/scalar/pom.xml                          |    4 +-
 modules/scalar/readme.txt                       |    4 +-
 .../scalar/src/test/resources/spring-cache.xml  |    2 +-
 modules/schedule/readme.txt                     |    4 +-
 .../processors/schedule/ScheduleFutureImpl.java |    6 +-
 modules/slf4j/readme.txt                        |    4 +-
 .../grid/logger/slf4j/GridSlf4jLogger.java      |    3 +-
 modules/spring/readme.txt                       |    4 +-
 .../java/org/gridgain/grid/GridGainSpring.java  |    8 +-
 .../java/org/gridgain/grid/GridSpringBean.java  |    3 +-
 .../spring/GridSpringCacheManagerSelfTest.java  |    3 +-
 .../GridSpringDynamicCacheManagerSelfTest.java  |    3 +-
 .../GridAbstractUserExternalResource.java       |  155 --
 .../resource/GridUserExternalResource1.java     |   25 -
 .../resource/GridUserExternalResource2.java     |   25 -
 .../resource/GridUserExternalResourceTask1.java |  157 --
 .../resource/GridUserExternalResourceTask2.java |  169 --
 .../grid/external/resource/package.html         |   23 -
 .../grid/kernal/GridFactorySelfTest.java        |   33 +-
 .../resource/GridAbstractUserResource.java      |  151 --
 .../GridResourceConcurrentUndeploySelfTest.java |  466 -----
 .../GridResourceEventFilterSelfTest.java        |  186 --
 .../GridResourceFieldInjectionSelfTest.java     |  638 -------
 ...dResourceFieldOverrideInjectionSelfTest.java |  202 --
 .../resource/GridResourceIocSelfTest.java       |  487 -----
 ...GridResourceIsolatedClassLoaderSelfTest.java |  762 --------
 .../GridResourceIsolatedTaskSelfTest.java       |  742 --------
 .../GridResourceMethodInjectionSelfTest.java    |  616 ------
 ...ResourceMethodOverrideInjectionSelfTest.java |  489 -----
 .../resource/GridResourceProcessorSelfTest.java |    8 +-
 .../GridResourceSharedUndeploySelfTest.java     |  673 -------
 .../resource/GridResourceUserExternalTest.java  |   94 -
 .../grid/p2p/GridP2PAbstractUserResource.java   |  184 --
 .../GridP2PContinuousLocalDeploySelfTest.java   |  319 ----
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   25 +-
 .../testsuites/GridResourceSelfTestSuite.java   |   11 -
 .../testsuites/bamboo/GridSpringTestSuite.java  |    1 -
 modules/ssh/readme.txt                          |    4 +-
 modules/urideploy/readme.txt                    |    4 +-
 .../deployment/uri/GridUriDeploymentSpi.java    |    7 +-
 .../grid/p2p/GridP2PDisabledSelfTest.java       |    3 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    4 +-
 .../cache/VisorCacheClearCommandSpec.scala      |    5 +-
 .../cache/VisorCacheCompactCommandSpec.scala    |    5 +-
 .../cswap/VisorCacheSwapCommandSpec.scala       |    7 +-
 modules/web/readme.txt                          |    4 +-
 .../cache/websession/GridWebSessionFilter.java  |    3 +-
 pom.xml                                         |   10 +-
 819 files changed, 13473 insertions(+), 16909 deletions(-)
----------------------------------------------------------------------



[10/45] incubator-ignite git commit: #IGNITE-86: refactoring

Posted by sb...@apache.org.
#IGNITE-86:  refactoring


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

Branch: refs/heads/ignite-121-logging
Commit: 6e1aa2a538f5109ed64f4c8a981e65502780c16a
Parents: 958401d
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 17:03:14 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 17:03:14 2015 +0300

----------------------------------------------------------------------
 .../grid/kernal/processors/cache/GridCacheDeploymentManager.java | 4 +---
 1 file changed, 1 insertion(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/6e1aa2a5/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
index c3578b7..7563ee9 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
@@ -182,10 +182,8 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
-        //TODO:
-        if (undeploys.get(ctx) == null) {
+        if (undeploys.get(ctx) == null)
             return;
-        }
 
         for (CA c = undeploys.get(ctx).poll(); c != null; c = undeploys.get(ctx).poll()) {
             c.apply();


[09/45] incubator-ignite git commit: #IGNITE-86: wip

Posted by sb...@apache.org.
#IGNITE-86:  wip


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

Branch: refs/heads/ignite-121-logging
Commit: 958401d8c3824f8c8d0ef7dbd22c30b7e95ded2e
Parents: 42d94fe
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 15:59:49 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 15:59:49 2015 +0300

----------------------------------------------------------------------
 .../kernal/processors/cache/GridCacheDeploymentManager.java     | 5 +++++
 1 file changed, 5 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/958401d8/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
index 5d9759f..c3578b7 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
@@ -182,6 +182,11 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
+        //TODO:
+        if (undeploys.get(ctx) == null) {
+            return;
+        }
+
         for (CA c = undeploys.get(ctx).poll(); c != null; c = undeploys.get(ctx).poll()) {
             c.apply();
 


[22/45] incubator-ignite git commit: Merge branches 'ignite-102' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-102

Posted by sb...@apache.org.
Merge branches 'ignite-102' and '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/99e3fa61
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/99e3fa61
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/99e3fa61

Branch: refs/heads/ignite-121-logging
Commit: 99e3fa618bcb4581626188046933b157a2acc577
Parents: b0031cc c224017
Author: AKuznetsov <ak...@gridgain.com>
Authored: Wed Jan 28 10:24:53 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Wed Jan 28 10:24:53 2015 +0700

----------------------------------------------------------------------
 NOTICE.txt                                      |   14 +-
 examples/config/example-cache.xml               |    9 +-
 examples/config/example-compute.xml             |    9 +-
 examples/config/example-streamer.xml            |    9 +-
 examples/config/filesystem/example-ggfs.xml     |    9 +-
 .../examples/misc/springbean/spring-bean.xml    |    9 +-
 .../examples/ScalarStartStopExample.scala       |   73 -
 .../examples/IgniteFsExamplesSelfTest.java      |   26 +-
 .../tests/examples/ScalarExamplesSelfTest.scala |    5 -
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java |   12 +-
 .../integration/ClientAbstractSelfTest.java     |   20 +-
 .../rest/AbstractRestProcessorSelfTest.java     |    2 +
 .../rest/ClientMemcachedProtocolSelfTest.java   |    4 +-
 .../rest/RestBinaryProtocolSelfTest.java        |    9 +-
 .../rest/RestMemcacheProtocolSelfTest.java      |    9 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   10 +
 .../java/org/apache/ignite/IgniteCache.java     |   15 +
 .../apache/ignite/cache/CacheEntryEvent.java    |    2 +-
 .../org/apache/ignite/cache/CacheMBean.java     |  295 ----
 .../org/apache/ignite/cache/CacheManager.java   |  164 +-
 .../org/apache/ignite/cache/CacheMetrics.java   |  416 +++++-
 .../java/org/apache/ignite/cache/GridCache.java |   15 +-
 .../ignite/cache/affinity/CacheAffinity.java    |    9 +-
 .../fifo/CacheFifoEvictionPolicyMBean.java      |   10 +-
 ...CacheGgfsPerBlockLruEvictionPolicyMBean.java |   18 +-
 .../lru/CacheLruEvictionPolicyMBean.java        |   10 +-
 .../random/CacheRandomEvictionPolicyMBean.java  |    6 +-
 .../ignite/cache/store/CacheStoreSession.java   |    2 +-
 .../client/router/GridTcpRouterMBean.java       |   16 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |  697 +++++----
 .../org/apache/ignite/cluster/ClusterNode.java  |   40 +-
 .../ignite/cluster/ClusterNodeMetrics.java      |  695 ---------
 .../configuration/IgniteConfiguration.java      |   27 +-
 .../ignite/dotnet/GridDotNetConfiguration.java  |  113 --
 .../dotnet/GridDotNetPortableConfiguration.java |  207 ---
 .../GridDotNetPortableTypeConfiguration.java    |  219 ---
 .../java/org/apache/ignite/dotnet/package.html  |   23 -
 .../ignite/internal/ClusterGroupAdapter.java    |    2 +-
 .../internal/ClusterLocalNodeMetrics.java       |  311 ----
 .../ClusterLocalNodeMetricsMXBeanImpl.java      |  309 ++++
 .../ignite/internal/ClusterMetricsImpl.java     |  813 ----------
 .../ignite/internal/ClusterMetricsSnapshot.java | 1397 ++++++++++++++++++
 .../internal/ClusterNodeMetricsMBean.java       |   29 -
 .../org/apache/ignite/internal/GridGainEx.java  |    8 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   95 +-
 .../internal/GridJobExecuteRequestV2.java       |  185 ---
 .../org/apache/ignite/internal/GridKernal.java  |   32 +-
 .../org/apache/ignite/internal/GridTopic.java   |    5 +-
 .../ignite/internal/IgniteClusterAsyncImpl.java |    1 -
 .../internal/IgniteThreadPoolMBeanAdapter.java  |  149 --
 .../internal/IgniteThreadPoolMXBeanAdapter.java |  129 ++
 .../ignite/internal/IgnitionMBeanAdapter.java   |   59 -
 .../ignite/internal/IgnitionMXBeanAdapter.java  |   59 +
 .../discovery/GridDiscoveryManager.java         |    4 +-
 .../internal/mxbean/IgniteStandardMXBean.java   |  277 ++++
 .../apache/ignite/internal/mxbean/package.html  |   24 +
 .../affinity/GridAffinityAssignment.java        |   10 +-
 .../affinity/GridAffinityProcessor.java         |  330 ++++-
 .../processors/cache/CacheMetricsImpl.java      |  586 ++++++++
 .../cache/CacheMetricsMXBeanImpl.java           |  310 ++++
 .../processors/cache/CacheMetricsSnapshot.java  |  518 +++++++
 .../processors/cache/GridCacheAdapter.java      |  377 ++++-
 .../cache/GridCacheEvictionManager.java         |    3 +
 .../processors/cache/GridCacheMBeanAdapter.java |  217 ---
 .../processors/cache/GridCacheMapEntry.java     |   55 +-
 .../cache/GridCacheMetricsAdapter.java          |  260 ----
 .../processors/cache/GridCacheProcessor.java    |   37 -
 .../processors/cache/GridCacheProxyImpl.java    |   25 +-
 .../processors/cache/GridCacheTtlManager.java   |    3 +
 .../processors/cache/GridCacheVersionEx.java    |    9 +
 .../processors/cache/IgniteCacheProxy.java      |   28 +-
 .../cache/distributed/dht/GridDhtCache.java     |   12 +-
 .../dht/GridPartitionedGetFuture.java           |    2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   30 +-
 .../dht/colocated/GridDhtColocatedCache.java    |    4 +-
 .../distributed/near/GridNearCacheAdapter.java  |    7 -
 .../distributed/near/GridNearCacheEntry.java    |    3 +-
 .../distributed/near/GridNearGetFuture.java     |    8 +-
 .../distributed/near/GridNearLockFuture.java    |    6 +-
 .../local/atomic/GridLocalAtomicCache.java      |   24 +-
 .../cache/query/GridCacheQueriesEx.java         |   16 +
 .../cache/query/GridCacheQueriesImpl.java       |   15 +
 .../cache/query/GridCacheQueriesProxy.java      |   24 +
 .../cache/query/GridCacheQueryManager.java      |   64 +-
 .../cache/query/GridCacheSqlQuery.java          |   99 ++
 .../cache/query/GridCacheSqlResult.java         |   21 +
 .../cache/query/GridCacheTwoStepQuery.java      |   74 +
 .../GridCacheContinuousQueryManager.java        |   11 -
 .../cache/transactions/IgniteTxManager.java     |    5 +-
 .../closure/GridClosureProcessor.java           |  624 ++++++--
 .../GridMasterLeaveAwareComputeJobAdapter.java  |   36 -
 .../processors/query/GridQueryIndexing.java     |   19 +
 .../processors/query/GridQueryProcessor.java    |   36 +
 .../processors/resource/GridResourceUtils.java  |    4 +-
 .../handlers/cache/GridCacheCommandHandler.java |    7 +-
 .../handlers/cache/GridCacheRestMetrics.java    |   77 +-
 .../top/GridTopologyCommandHandler.java         |    2 +-
 .../processors/task/GridTaskWorker.java         |   52 +-
 .../apache/ignite/internal/util/GridUtils.java  |   19 +-
 .../GridTcpCommunicationMessageFactory.java     |    5 +-
 .../internal/visor/cache/VisorCacheMetrics.java |   37 +-
 .../visor/cache/VisorCacheResetMetricsTask.java |    2 +-
 .../internal/visor/node/VisorNodeGcTask.java    |    2 +-
 .../ignite/interop/InteropConfiguration.java    |   30 +
 .../java/org/apache/ignite/interop/package.html |   15 +
 .../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/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 +-
 .../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      |   12 +-
 .../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 +-
 .../transactions/IgniteTxConcurrency.java       |    2 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   41 +-
 .../core/src/test/config/ggfs-no-endpoint.xml   |  199 ---
 modules/core/src/test/config/ggfs-shmem.xml     |   41 +-
 .../apache/ignite/IgniteCacheAffinityTest.java  |  266 ++++
 .../ignite/internal/ClusterMetricsSelfTest.java |  124 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |    6 +-
 .../ignite/internal/GridDiscoverySelfTest.java  |    2 +-
 .../internal/GridNonHistoryMetricsSelfTest.java |    4 +-
 .../GridCheckpointManagerAbstractSelfTest.java  |    2 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |  752 +++++++++-
 ...cheTransactionalAbstractMetricsSelfTest.java |   20 +-
 .../cache/GridCacheVersionSelfTest.java         |   23 +-
 ...ePartitionedNearDisabledMetricsSelfTest.java |   14 +-
 ...AtomicPartitionedTckMetricsSelfTestImpl.java |  183 +++
 .../near/GridCacheNearMetricsSelfTest.java      |  163 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |   38 +-
 ...dCacheAtomicLocalTckMetricsSelfTestImpl.java |  161 ++
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java |    2 +-
 ...bStealingCollisionSpiAttributesSelfTest.java |    4 +-
 ...alingCollisionSpiCustomTopologySelfTest.java |    4 +-
 .../GridJobStealingCollisionSpiSelfTest.java    |    4 +-
 ...ClusterMetricsSnapshotSerializeSelfTest.java |  126 ++
 .../GridDiscoveryMetricsHelperSelfTest.java     |  149 --
 .../testframework/GridSpiTestContext.java       |    6 +-
 .../ignite/testframework/GridTestNode.java      |    8 +-
 .../testframework/junits/GridTestIgnite.java    |    6 +
 .../junits/spi/GridSpiAbstractTest.java         |    2 +-
 .../IgniteCacheMetricsSelfTestSuite.java        |    4 +-
 .../testsuites/IgniteComputeGridTestSuite.java  |    2 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +-
 .../util/GridTopologyHeapSizeSelfTest.java      |    4 +-
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   49 +-
 .../query/h2/GridH2ResultSetIterator.java       |    2 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  173 ++-
 .../query/h2/opt/GridH2IndexBase.java           |    5 +-
 .../query/h2/sql/GridSqlAggregateFunction.java  |   76 +
 .../processors/query/h2/sql/GridSqlAlias.java   |   55 +
 .../processors/query/h2/sql/GridSqlColumn.java  |   57 +
 .../processors/query/h2/sql/GridSqlConst.java   |   39 +
 .../processors/query/h2/sql/GridSqlElement.java |   73 +
 .../query/h2/sql/GridSqlFunction.java           |  142 ++
 .../query/h2/sql/GridSqlFunctionType.java       |   78 +
 .../processors/query/h2/sql/GridSqlJoin.java    |   68 +
 .../query/h2/sql/GridSqlOperation.java          |   73 +
 .../query/h2/sql/GridSqlOperationType.java      |  202 +++
 .../query/h2/sql/GridSqlParameter.java          |   44 +
 .../query/h2/sql/GridSqlQueryParser.java        |  495 +++++++
 .../query/h2/sql/GridSqlQuerySplitter.java      |  252 ++++
 .../processors/query/h2/sql/GridSqlSelect.java  |  287 ++++
 .../query/h2/sql/GridSqlSubquery.java           |   44 +
 .../processors/query/h2/sql/GridSqlTable.java   |   55 +
 .../processors/query/h2/sql/GridSqlValue.java   |   17 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |  270 ++++
 .../query/h2/twostep/GridMergeIndex.java        |  290 ++++
 .../h2/twostep/GridMergeIndexUnsorted.java      |   85 ++
 .../query/h2/twostep/GridMergeTable.java        |  178 +++
 .../h2/twostep/GridReduceQueryExecutor.java     |  242 +++
 .../query/h2/twostep/GridResultPage.java        |   59 +
 .../twostep/messages/GridNextPageRequest.java   |   59 +
 .../twostep/messages/GridNextPageResponse.java  |  180 +++
 .../query/h2/twostep/messages/GridQueryAck.java |   34 +
 .../twostep/messages/GridQueryFailResponse.java |   46 +
 .../h2/twostep/messages/GridQueryRequest.java   |   61 +
 .../cache/GridCacheCrossCacheQuerySelfTest.java |  111 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |    5 +-
 .../query/h2/sql/GridQueryParsingTest.java      |  289 ++++
 .../IgniteCacheQuerySelfTestSuite.java          |    4 +
 .../test/resources/spring-ping-pong-partner.xml |   38 +-
 .../org/apache/ignite/IgniteSpringBean.java     |    6 +
 .../uri/GridUriDeploymentSpiMBean.java          |    8 +-
 .../commands/alert/VisorAlertCommand.scala      |    7 +-
 .../commands/top/VisorTopologyCommand.scala     |   11 +-
 .../scala/org/apache/ignite/visor/visor.scala   |    6 +-
 pom.xml                                         |  132 +-
 231 files changed, 13838 insertions(+), 8565 deletions(-)
----------------------------------------------------------------------


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


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

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

Branch: refs/heads/ignite-121-logging
Commit: fb37ccf14771a9a1c3348415d525314e7faa32ac
Parents: 2042476 7454803
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Jan 26 13:22:04 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Jan 26 13:22:04 2015 +0300

----------------------------------------------------------------------
 .../examples/ScalarCacheAffinityExample1.scala  |   9 +-
 .../examples/ScalarCacheAffinityExample2.scala  |   9 +-
 .../ScalarCacheAffinitySimpleExample.scala      |   4 +-
 .../scalar/examples/ScalarCacheExample.scala    |  13 +-
 .../ScalarCachePopularNumbersExample.scala      |  14 +-
 .../examples/ScalarCacheQueryExample.scala      |  11 +-
 .../scalar/examples/ScalarClosureExample.scala  |   6 +-
 .../examples/ScalarContinuationExample.scala    |  11 +-
 .../examples/ScalarCreditRiskExample.scala      |   7 +-
 .../scalar/examples/ScalarJvmCloudExample.scala |  13 +-
 .../examples/ScalarPiCalculationExample.scala   |   7 +-
 .../scalar/examples/ScalarPingPongExample.scala |   7 +-
 .../scalar/examples/ScalarPrimeExample.scala    |  10 +-
 .../scalar/examples/ScalarScheduleExample.scala |   6 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |  15 +-
 .../examples/ScalarStartStopExample.scala       |   6 +-
 .../scalar/examples/ScalarTaskExample.scala     |  12 +-
 .../examples/ScalarWorldShortestMapReduce.scala |   6 +-
 .../tests/examples/ScalarExamplesSelfTest.scala |   7 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   2 +-
 .../java/org/apache/ignite/IgniteCache.java     |  79 +++++
 .../apache/ignite/cache/CacheProjection.java    |   6 +
 .../org/apache/ignite/cluster/ClusterNode.java  |   2 +-
 .../org/apache/ignite/internal/GridKernal.java  |   2 +-
 .../ignite/internal/GridKernalContext.java      |   2 +-
 .../ignite/internal/GridKernalContextImpl.java  |   2 +-
 .../apache/ignite/internal/GridProductImpl.java |   6 +-
 .../ignite/internal/GridUpdateNotifier.java     |   2 +-
 .../discovery/GridDiscoveryManager.java         |   1 -
 .../processors/cache/GridCacheAdapter.java      | 117 +++++++-
 .../cache/GridCacheProjectionImpl.java          |   5 +
 .../processors/cache/GridCacheProxyImpl.java    |  12 +
 .../processors/cache/IgniteCacheProxy.java      | 229 +++++++++------
 .../dataload/IgniteDataLoaderImpl.java          |   1 -
 .../processors/job/GridJobProcessor.java        |   1 -
 .../license/GridLicenseProcessor.java           |   6 +-
 .../license/os/GridOsLicenseProcessor.java      |   2 +-
 .../ignite/internal/product/IgniteProduct.java  |  67 +++++
 .../internal/product/IgniteProductLicense.java  | 183 ++++++++++++
 .../product/IgniteProductLicenseException.java  |  70 +++++
 .../apache/ignite/internal/product/package.html |  23 ++
 .../apache/ignite/internal/util/GridUtils.java  |   1 -
 .../ignite/lang/IgniteProductVersion.java       | 291 +++++++++++++++++++
 .../apache/ignite/product/IgniteProduct.java    |  66 -----
 .../ignite/product/IgniteProductLicense.java    | 183 ------------
 .../product/IgniteProductLicenseException.java  |  70 -----
 .../ignite/product/IgniteProductVersion.java    | 291 -------------------
 .../java/org/apache/ignite/product/package.html |  23 --
 .../communication/tcp/TcpCommunicationSpi.java  |   1 -
 .../ignite/spi/discovery/DiscoverySpi.java      |   2 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |   2 +-
 .../tcp/internal/TcpDiscoveryNode.java          |   1 -
 .../ignite/internal/GridDiscoverySelfTest.java  |   3 +-
 .../internal/GridReleaseTypeSelfTest.java       |   3 +-
 .../GridTopologyBuildVersionSelfTest.java       |   3 +-
 .../ignite/internal/GridVersionSelfTest.java    |   2 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  14 +-
 .../dht/GridCacheGlobalLoadTest.java            |  78 ++++-
 ...unctionExcludeNeighborsAbstractSelfTest.java |   2 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |  25 +-
 .../product/GridProductVersionSelfTest.java     | 111 +++++++
 .../marshaller/GridMarshallerAbstractTest.java  |   2 +-
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java |   4 +-
 .../product/GridProductVersionSelfTest.java     | 111 -------
 .../GridAbstractDiscoverySelfTest.java          |   2 +-
 .../ignite/testframework/GridTestNode.java      |   4 +-
 .../testframework/junits/GridTestIgnite.java    |   2 +-
 .../junits/spi/GridSpiAbstractTest.java         |   4 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |   2 +-
 modules/scalar/readme.txt                       |   4 +-
 .../ignite/scalar/ScalarConversions.scala       |  19 +-
 .../org/apache/ignite/scalar/lang/Packet.scala  |   4 +-
 .../ignite/scalar/lang/ScalarAbsClosure.scala   |   4 +-
 .../scalar/lang/ScalarAbsClosureFunction.scala  |   2 +-
 .../ignite/scalar/lang/ScalarAbsClosureX.scala  |   2 +-
 .../scalar/lang/ScalarAbsClosureXFunction.scala |   4 +-
 .../ignite/scalar/lang/ScalarAbsPredicate.scala |   2 +-
 .../lang/ScalarAbsPredicateFunction.scala       |   4 +-
 .../scalar/lang/ScalarAbsPredicateX.scala       |   2 +-
 .../lang/ScalarAbsPredicateXFunction.scala      |   2 +-
 .../ignite/scalar/lang/ScalarClosure.scala      |   2 +-
 .../ignite/scalar/lang/ScalarClosure2.scala     |   2 +-
 .../scalar/lang/ScalarClosure2Function.scala    |   2 +-
 .../ignite/scalar/lang/ScalarClosure2X.scala    |   2 +-
 .../scalar/lang/ScalarClosure2XFunction.scala   |   4 +-
 .../ignite/scalar/lang/ScalarClosure3.scala     |   2 +-
 .../scalar/lang/ScalarClosure3Function.scala    |   4 +-
 .../ignite/scalar/lang/ScalarClosure3X.scala    |   2 +-
 .../scalar/lang/ScalarClosure3XFunction.scala   |   4 +-
 .../scalar/lang/ScalarClosureFunction.scala     |   2 +-
 .../ignite/scalar/lang/ScalarClosureX.scala     |   2 +-
 .../scalar/lang/ScalarClosureXFunction.scala    |   2 +-
 .../ignite/scalar/lang/ScalarInClosure.scala    |   2 +-
 .../ignite/scalar/lang/ScalarInClosure2.scala   |   2 +-
 .../scalar/lang/ScalarInClosure2Function.scala  |   2 +-
 .../ignite/scalar/lang/ScalarInClosure2X.scala  |   2 +-
 .../scalar/lang/ScalarInClosure2XFunction.scala |   2 +-
 .../ignite/scalar/lang/ScalarInClosure3.scala   |   2 +-
 .../scalar/lang/ScalarInClosure3Function.scala  |   4 +-
 .../ignite/scalar/lang/ScalarInClosure3X.scala  |   2 +-
 .../scalar/lang/ScalarInClosure3XFunction.scala |   4 +-
 .../scalar/lang/ScalarInClosureFunction.scala   |   2 +-
 .../ignite/scalar/lang/ScalarInClosureX.scala   |   2 +-
 .../scalar/lang/ScalarInClosureXFunction.scala  |   4 +-
 .../apache/ignite/scalar/lang/ScalarJob.scala   |   2 +-
 .../ignite/scalar/lang/ScalarOutClosure.scala   |   7 +-
 .../scalar/lang/ScalarOutClosureFunction.scala  |   2 +-
 .../ignite/scalar/lang/ScalarOutClosureX.scala  |   2 +-
 .../scalar/lang/ScalarOutClosureXFunction.scala |   4 +-
 .../ignite/scalar/lang/ScalarPredicate.scala    |   2 +-
 .../ignite/scalar/lang/ScalarPredicate2.scala   |   2 +-
 .../scalar/lang/ScalarPredicate2Function.scala  |   2 +-
 .../ignite/scalar/lang/ScalarPredicate2X.scala  |   2 +-
 .../scalar/lang/ScalarPredicate2XFunction.scala |   2 +-
 .../ignite/scalar/lang/ScalarPredicate3.scala   |   2 +-
 .../scalar/lang/ScalarPredicate3Function.scala  |   4 +-
 .../ignite/scalar/lang/ScalarPredicate3X.scala  |   2 +-
 .../scalar/lang/ScalarPredicate3XFunction.scala |   4 +-
 .../scalar/lang/ScalarPredicateFunction.scala   |   2 +-
 .../ignite/scalar/lang/ScalarPredicateX.scala   |   2 +-
 .../scalar/lang/ScalarPredicateXFunction.scala  |   2 +-
 .../ignite/scalar/lang/ScalarReducer.scala      |   4 +-
 .../ignite/scalar/lang/ScalarReducer2.scala     |   5 +-
 .../scalar/lang/ScalarReducer2Function.scala    |   4 +-
 .../ignite/scalar/lang/ScalarReducer3.scala     |   5 +-
 .../scalar/lang/ScalarReducer3Function.scala    |   4 +-
 .../scalar/lang/ScalarReducerFunction.scala     |   2 +-
 .../org/apache/ignite/scalar/pimps/Packet.scala |   4 +-
 .../apache/ignite/scalar/pimps/PimpedType.scala |   2 +-
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |   2 +-
 .../pimps/ScalarCacheProjectionPimp.scala       |  18 +-
 .../ignite/scalar/pimps/ScalarGridPimp.scala    |   5 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |  64 ++--
 .../scalar/pimps/ScalarTaskThreadContext.scala  |   5 +-
 .../scala/org/apache/ignite/scalar/scalar.scala |  14 +-
 .../test/resources/spring-ping-pong-partner.xml |   2 +-
 .../tests/ScalarAffinityRoutingSpec.scala       |  13 +-
 .../tests/ScalarCacheProjectionSpec.scala       |   8 +-
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |   9 +-
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |  17 +-
 .../scalar/tests/ScalarConversionsSpec.scala    |  12 +-
 .../scalar/tests/ScalarProjectionSpec.scala     |  14 +-
 .../scalar/tests/ScalarReturnableSpec.scala     |  11 +-
 .../apache/ignite/scalar/tests/ScalarSpec.scala |   8 +-
 .../scalar/testsuites/ScalarSelfTestSuite.scala |   4 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   2 +-
 .../config/VisorConfigurationCommand.scala      |   3 +-
 147 files changed, 1511 insertions(+), 1180 deletions(-)
----------------------------------------------------------------------


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


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

Posted by sb...@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/09b09b71
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/09b09b71
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/09b09b71

Branch: refs/heads/ignite-121-logging
Commit: 09b09b712c6c1fb6ce4a089d8b2580e6fe26b7b2
Parents: cb767aa 9fd191a
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Jan 26 12:35:35 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Jan 26 12:35:35 2015 +0300

----------------------------------------------------------------------
 LICENSE.txt                                     |  27 ++
 NOTICE.txt                                      |  15 +
 examples/pom-standalone.xml                     |  32 +-
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java |   2 +-
 .../services/javax.cache.spi.CachingProvider    |   2 +-
 .../org/apache/ignite/IgniteCacheMXBean.java    |  72 ----
 .../org/apache/ignite/IgniteCacheManager.java   | 372 ------------------
 .../apache/ignite/IgniteCachingProvider.java    | 189 ---------
 .../org/apache/ignite/cache/CacheMBean.java     |   2 +-
 .../org/apache/ignite/cache/CacheManager.java   | 372 ++++++++++++++++++
 .../apache/ignite/cache/CachingProvider.java    | 189 +++++++++
 .../cache/GridCachePartialUpdateException.java  |  64 ---
 .../fifo/CacheFifoEvictionPolicyMBean.java      |   2 +-
 ...CacheGgfsPerBlockLruEvictionPolicyMBean.java |   2 +-
 .../lru/CacheLruEvictionPolicyMBean.java        |   2 +-
 .../random/CacheRandomEvictionPolicyMBean.java  |   2 +-
 .../client/router/GridTcpRouterMBean.java       |   2 +-
 .../ignite/cluster/ClusterNodeMetrics.java      |   2 +-
 .../internal/ClusterNodeMetricsMBean.java       |   2 +-
 .../org/apache/ignite/internal/GridGainEx.java  |   2 +-
 .../org/apache/ignite/internal/GridKernal.java  |   2 +-
 .../internal/IgniteThreadPoolMBeanAdapter.java  |   4 +-
 .../ignite/internal/IgnitionMBeanAdapter.java   |   2 +-
 .../processors/cache/CacheEntryImpl.java        |   8 +-
 .../cache/CacheIteratorConverter.java           |  39 ++
 .../cache/CacheWeakQueryIteratorsHolder.java    | 228 +++++++++++
 .../processors/cache/GridCacheAdapter.java      |  31 ++
 .../processors/cache/GridCacheContext.java      |  12 +
 .../processors/cache/GridCacheGateway.java      |   2 +
 .../processors/cache/IgniteCacheProxy.java      |  27 +-
 .../cache/datastructures/GridCacheSetImpl.java  | 175 +--------
 .../cache/query/GridCacheQueryAdapter.java      |  14 +-
 .../query/GridCacheQueryFutureAdapter.java      |   7 +-
 .../cache/query/GridCacheQueryManager.java      |   4 +-
 .../apache/ignite/internal/util/GridUtils.java  |   2 +-
 .../org/apache/ignite/mbean/IgniteMBean.java    | 386 -------------------
 .../ignite/mbean/IgniteMBeanDescription.java    |  34 --
 .../IgniteMBeanParametersDescriptions.java      |  34 --
 .../mbean/IgniteMBeanParametersNames.java       |  34 --
 .../ignite/mbean/IgniteStandardMBean.java       | 275 -------------
 .../ignite/mbean/IgniteThreadPoolMBean.java     | 152 --------
 .../org/apache/ignite/mbean/IgnitionMBean.java  | 151 --------
 .../java/org/apache/ignite/mbean/package.html   |  23 --
 .../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 ++
 .../ignite/mxbean/IgniteStandardMBean.java      | 275 +++++++++++++
 .../ignite/mxbean/IgniteThreadPoolMBean.java    | 152 ++++++++
 .../org/apache/ignite/mxbean/IgnitionMBean.java | 151 ++++++++
 .../java/org/apache/ignite/mxbean/package.html  |  23 ++
 .../ignite/spi/IgniteSpiManagementMBean.java    |   2 +-
 .../noop/NoopAuthenticationSpiMBean.java        |   2 +-
 .../cache/CacheCheckpointSpiMBean.java          |   2 +-
 .../checkpoint/jdbc/JdbcCheckpointSpiMBean.java |   2 +-
 .../sharedfs/SharedFsCheckpointSpiMBean.java    |   2 +-
 .../fifoqueue/FifoQueueCollisionSpiMBean.java   |   2 +-
 .../JobStealingCollisionSpiMBean.java           |   2 +-
 .../PriorityQueueCollisionSpiMBean.java         |   2 +-
 .../tcp/TcpCommunicationSpiMBean.java           |   2 +-
 .../local/LocalDeploymentSpiMBean.java          |   2 +-
 .../tcp/TcpClientDiscoverySpiMBean.java         |   2 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java |   2 +-
 .../memory/MemoryEventStorageSpiMBean.java      |   2 +-
 .../failover/always/AlwaysFailoverSpiMBean.java |   2 +-
 .../JobStealingFailoverSpiMBean.java            |   2 +-
 .../failover/never/NeverFailoverSpiMBean.java   |   2 +-
 .../adaptive/AdaptiveLoadBalancingSpiMBean.java |   2 +-
 .../RoundRobinLoadBalancingSpiMBean.java        |   2 +-
 .../WeightedRandomLoadBalancingSpiMBean.java    |   2 +-
 .../noop/NoopSecureSessionSpiMBean.java         |   2 +-
 .../swapspace/file/FileSwapSpaceSpiMBean.java   |   2 +-
 .../apache/ignite/streamer/StreamerMBean.java   |   2 +-
 .../ignite/streamer/StreamerStageMBean.java     |   2 +-
 .../ignite/streamer/StreamerWindowMBean.java    |   2 +-
 .../index/StreamerIndexProviderMBean.java       |   2 +-
 .../GridCheckpointManagerAbstractSelfTest.java  |   2 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java | 178 +++++++++
 .../cache/GridCacheDeploymentSelfTest.java      |  12 +-
 .../cache/IgniteCachingProviderSelfTest.java    |  14 +-
 .../optimized/GridOptimizedMarshallerTest.java  |   4 +-
 .../GridP2PDifferentClassLoaderSelfTest.java    |   4 +-
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |   2 +-
 .../ignite/p2p/GridP2PNodeLeftSelfTest.java     |   2 +-
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   4 +-
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   2 +-
 modules/extdata/p2p/META-INF/gridgain.xml       |   4 +-
 .../tests/p2p/CacheDeploymentTestKey.java       |  63 +++
 .../tests/p2p/CacheDeploymentTestTask1.java     |  65 ++++
 .../tests/p2p/CacheDeploymentTestTask2.java     |  56 +++
 .../tests/p2p/CacheDeploymentTestTask3.java     |  61 +++
 .../tests/p2p/CacheDeploymentTestValue.java     |  27 ++
 .../tests/p2p/CacheDeploymentTestValue2.java    |  25 ++
 .../tests/p2p/GridCacheDeploymentTestKey.java   |  63 ---
 .../tests/p2p/GridCacheDeploymentTestTask1.java |  65 ----
 .../tests/p2p/GridCacheDeploymentTestTask2.java |  56 ---
 .../tests/p2p/GridCacheDeploymentTestTask3.java |  61 ---
 .../tests/p2p/GridCacheDeploymentTestValue.java |  26 --
 .../p2p/GridCacheDeploymentTestValue2.java      |  24 --
 .../tests/p2p/GridP2PTestTaskExternalPath2.java | 137 -------
 .../tests/p2p/GridSingleSplitTestTask.java      |  76 ----
 .../tests/p2p/P2PTestTaskExternalPath2.java     | 137 +++++++
 .../ignite/tests/p2p/SingleSplitTestTask.java   |  76 ++++
 .../GridSpringDynamicCacheManagerSelfTest.java  |   4 +-
 .../uri/GridUriDeploymentSpiMBean.java          |   2 +-
 .../deployment/uri/META-INF/p2p-gridgain.xml    |   2 +-
 107 files changed, 2887 insertions(+), 2578 deletions(-)
----------------------------------------------------------------------


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


[39/45] incubator-ignite git commit: #gg-9757: Removed "GridInteropAware".

Posted by sb...@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-121-logging
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;
-}


[34/45] incubator-ignite git commit: #Tests: Fix GridCacheCommandHandlerSelfTest.

Posted by sb...@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-121-logging
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;


[44/45] incubator-ignite git commit: # ignite-121 : fix review comments

Posted by sb...@apache.org.
# ignite-121 : fix review comments


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

Branch: refs/heads/ignite-121-logging
Commit: 72b557a8cbd4826f67a5b7d8b1fd811936f92b5c
Parents: 7c7ec7d
Author: Artem SHutak <as...@gridgain.com>
Authored: Mon Feb 2 19:47:09 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Mon Feb 2 19:47:09 2015 +0300

----------------------------------------------------------------------
 .../router/impl/GridRouterCommandLineStartup.java      |  3 ++-
 .../java/org/apache/ignite/internal/IgnitionEx.java    | 13 +++++++------
 2 files changed, 9 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/72b557a8/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java b/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
index 6dfe62b..676b750 100644
--- a/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
+++ b/modules/core/src/main/java/org/apache/ignite/client/router/impl/GridRouterCommandLineStartup.java
@@ -133,13 +133,14 @@ public class GridRouterCommandLineStartup {
         IgniteBiTuple<Object, Object> t = null;
         Collection<Handler> savedHnds = null;
 
-        if (isLog4jUsed)
+        if (isLog4jUsed) {
             try {
                 t = U.addLog4jNoOpLogger();
             }
             catch (Exception e) {
                 isLog4jUsed = false;
             }
+        }
 
         if (!isLog4jUsed)
             savedHnds = U.addJavaNoOpLogger();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/72b557a8/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 605bce0..b7c57cc 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
@@ -725,13 +725,14 @@ public class IgnitionEx {
 
         Collection<Handler> savedHnds = null;
 
-        if (isLog4jUsed)
+        if (isLog4jUsed) {
             try {
                 t = U.addLog4jNoOpLogger();
             }
             catch (IgniteCheckedException e) {
                 isLog4jUsed = false;
             }
+        }
 
         if (!isLog4jUsed)
             savedHnds = U.addJavaNoOpLogger();
@@ -2015,8 +2016,8 @@ public class IgnitionEx {
                         log4jCls = null;
                     }
 
-                    try {
-                        if (log4jCls != null) {
+                    if (log4jCls != null) {
+                        try {
                             URL url = U.resolveGridGainUrl("config/ignite-log4j.xml");
 
                             if (url == null) {
@@ -2050,9 +2051,9 @@ public class IgnitionEx {
                             else
                                 cfgLog = (IgniteLogger)log4jCls.newInstance();
                         }
-                    }
-                    catch (Exception e) {
-                        log4jInitException = e;
+                        catch (Exception e) {
+                            log4jInitException = e;
+                        }
                     }
 
                     if (log4jCls == null || log4jInitException != null)


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

Posted by sb...@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-121-logging
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(-)
----------------------------------------------------------------------



[15/45] incubator-ignite git commit: #IGNITE-86: Change using cache context to ctx.namexx() as a key for map.

Posted by sb...@apache.org.
#IGNITE-86: Change using cache context to ctx.namexx() as a key for map.


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

Branch: refs/heads/ignite-121-logging
Commit: 20424760d6827a26399080d72a0fbf0a9c1239b9
Parents: 09b09b7
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Jan 26 13:01:09 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Jan 26 13:01:09 2015 +0300

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


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/20424760/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
index 2df866d..8729b86 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
@@ -182,7 +182,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
-        ConcurrentLinkedQueue<CA> q = undeploys.get(ctx);
+        ConcurrentLinkedQueue<CA> q = undeploys.get(ctx.namexx());
 
         if (q == null)
             return;
@@ -209,9 +209,9 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
         for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            undeploys.putIfAbsent(cacheCtx.namexx(), new ConcurrentLinkedQueue<CA>()); // TODO
+            undeploys.putIfAbsent(cacheCtx.namexx(), new ConcurrentLinkedQueue<CA>());
 
-            undeploys.get(cacheCtx).add(new CA() {
+            undeploys.get(cacheCtx.namexx()).add(new CA() {
                 @Override
                 public void apply() {
                     onUndeploy0(ldr, cacheCtx);


[24/45] incubator-ignite git commit: # IGNITE-102. Fixes to make benchmarks runnable.

Posted by sb...@apache.org.
# IGNITE-102. Fixes to make benchmarks runnable.


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

Branch: refs/heads/ignite-121-logging
Commit: aee11a01f1c937a8cdef5ae88a465848be8ea533
Parents: c9aadf0
Author: AKuznetsov <ak...@gridgain.com>
Authored: Wed Jan 28 15:17:37 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Wed Jan 28 15:17:37 2015 +0700

----------------------------------------------------------------------
 .../config/benchmark-atomic-win.properties      |   2 +-
 .../config/benchmark-atomic.properties          |   2 +-
 .../config/benchmark-compute-win.properties     |   2 +-
 .../config/benchmark-compute.properties         |   2 +-
 .../config/benchmark-query-win.properties       |   2 +-
 .../yardstick/config/benchmark-query.properties |   2 +-
 .../config/benchmark-tx-win.properties          |   2 +-
 .../yardstick/config/benchmark-tx.properties    |   2 +-
 .../yardstick/config/benchmark-win.properties   |   2 +-
 modules/yardstick/config/benchmark.properties   |   2 +-
 modules/yardstick/config/ignite-base-config.xml |  10 +-
 .../config/ignite-localhost-config.xml          |   4 +-
 .../config/ignite-multicast-config.xml          |   4 +-
 modules/yardstick/pom.xml                       |   8 ++
 .../yardstick/IgniteAbstractBenchmark.java      |   6 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |  18 +--
 .../yardstick/cache/IgnitePutBenchmark.java     |  42 +++++++
 .../cache/IgnitePutBenchmarkIgnite.java         |  42 -------
 .../yardstick/cache/IgnitePutGetBenchmark.java  |  47 ++++++++
 .../cache/IgnitePutGetBenchmarkIgnite.java      |  47 --------
 .../cache/IgnitePutGetTxBenchmark.java          |  52 ++++++++
 .../cache/IgnitePutGetTxBenchmarkIgnite.java    |  52 --------
 .../yardstick/cache/IgnitePutTxBenchmark.java   |  43 +++++++
 .../cache/IgnitePutTxBenchmarkIgnite.java       |  43 -------
 .../cache/IgniteSqlQueryBenchmark.java          |  94 +++++++++++++++
 .../cache/IgniteSqlQueryBenchmarkIgnite.java    |  94 ---------------
 .../cache/IgniteSqlQueryJoinBenchmark.java      | 118 +++++++++++++++++++
 .../IgniteSqlQueryJoinBenchmarkIgnite.java      | 118 -------------------
 .../cache/IgniteSqlQueryPutBenchmark.java       |  86 ++++++++++++++
 .../cache/IgniteSqlQueryPutBenchmarkIgnite.java |  86 --------------
 30 files changed, 521 insertions(+), 513 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-atomic-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-atomic-win.properties b/modules/yardstick/config/benchmark-atomic-win.properties
index 97132f0..96dde32 100644
--- a/modules/yardstick/config/benchmark-atomic-win.properties
+++ b/modules/yardstick/config/benchmark-atomic-win.properties
@@ -21,7 +21,7 @@ set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 :: Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 :: Probe point writer class name.
 :: BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-atomic.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-atomic.properties b/modules/yardstick/config/benchmark-atomic.properties
index d10259d..1f93d5c 100644
--- a/modules/yardstick/config/benchmark-atomic.properties
+++ b/modules/yardstick/config/benchmark-atomic.properties
@@ -23,7 +23,7 @@ JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 # Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 # Probe point writer class name.
 # BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-compute-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-compute-win.properties b/modules/yardstick/config/benchmark-compute-win.properties
index 06c7f6a..35e8873 100644
--- a/modules/yardstick/config/benchmark-compute-win.properties
+++ b/modules/yardstick/config/benchmark-compute-win.properties
@@ -21,7 +21,7 @@ set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 :: Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 :: Probe point writer class name.
 :: BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-compute.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-compute.properties b/modules/yardstick/config/benchmark-compute.properties
index d90a954..1f38eb6 100644
--- a/modules/yardstick/config/benchmark-compute.properties
+++ b/modules/yardstick/config/benchmark-compute.properties
@@ -23,7 +23,7 @@ JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 # Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 # Probe point writer class name.
 # BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-query-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query-win.properties b/modules/yardstick/config/benchmark-query-win.properties
index 377bac0..a2c102c 100644
--- a/modules/yardstick/config/benchmark-query-win.properties
+++ b/modules/yardstick/config/benchmark-query-win.properties
@@ -21,7 +21,7 @@ set JVM_OPTS=%JVM_OPTS%^
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 :: Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 :: Probe point writer class name.
 :: BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-query.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query.properties b/modules/yardstick/config/benchmark-query.properties
index b467e0b..c3e7a6e 100644
--- a/modules/yardstick/config/benchmark-query.properties
+++ b/modules/yardstick/config/benchmark-query.properties
@@ -23,7 +23,7 @@ JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false" \
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 # Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 # Probe point writer class name.
 # BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-tx-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-tx-win.properties b/modules/yardstick/config/benchmark-tx-win.properties
index 7e098a5..7b12202 100644
--- a/modules/yardstick/config/benchmark-tx-win.properties
+++ b/modules/yardstick/config/benchmark-tx-win.properties
@@ -21,7 +21,7 @@ set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 :: Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 :: Probe point writer class name.
 :: BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-tx.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-tx.properties b/modules/yardstick/config/benchmark-tx.properties
index 83be491..c3d69f2 100644
--- a/modules/yardstick/config/benchmark-tx.properties
+++ b/modules/yardstick/config/benchmark-tx.properties
@@ -23,7 +23,7 @@ JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 # Packages where the specified benchmark is searched by reflection mechanism, comma separated.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 # Probe point writer class name.
 # BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-win.properties b/modules/yardstick/config/benchmark-win.properties
index ba77c84..00a3c17 100644
--- a/modules/yardstick/config/benchmark-win.properties
+++ b/modules/yardstick/config/benchmark-win.properties
@@ -24,7 +24,7 @@ set JVM_OPTS=%JVM_OPTS% -DGRIDGAIN_QUIET=false
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 :: Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 :: Probe point writer class name.
 :: BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/benchmark.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark.properties b/modules/yardstick/config/benchmark.properties
index bbe9ff0..034eb46 100644
--- a/modules/yardstick/config/benchmark.properties
+++ b/modules/yardstick/config/benchmark.properties
@@ -26,7 +26,7 @@ JVM_OPTS=${JVM_OPTS}" -DGRIDGAIN_QUIET=false"
 BENCHMARK_DEFAULT_PROBES=ThroughputLatencyProbe,PercentileProbe
 
 # Packages where the specified benchmark is searched by reflection mechanism.
-BENCHMARK_PACKAGES=org.yardstickframework
+BENCHMARK_PACKAGES=org.yardstickframework,org.apache.ignite.yardstick
 
 # Probe point writer class name.
 # BENCHMARK_WRITER=

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/ignite-base-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-base-config.xml b/modules/yardstick/config/ignite-base-config.xml
index 69fe9b1..16d0a70 100644
--- a/modules/yardstick/config/ignite-base-config.xml
+++ b/modules/yardstick/config/ignite-base-config.xml
@@ -24,7 +24,7 @@
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xsi:schemaLocation="
         http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
-    <bean id="base-grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" abstract="true">
+    <bean id="base-ignite.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" abstract="true">
         <property name="peerClassLoadingEnabled" value="false"/>
 
         <!--property name="marshaller">
@@ -46,7 +46,7 @@
 
         <property name="cacheConfiguration">
             <list>
-                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                <bean class="org.apache.ignite.cache.CacheConfiguration">
                     <property name="name" value="atomic"/>
 
                     <property name="cacheMode" value="PARTITIONED"/>
@@ -58,7 +58,7 @@
                     <property name="queryIndexEnabled" value="false"/>
                 </bean>
 
-                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                <bean class="org.apache.ignite.cache.CacheConfiguration">
                     <property name="name" value="tx"/>
 
                     <property name="cacheMode" value="PARTITIONED"/>
@@ -70,7 +70,7 @@
                     <property name="queryIndexEnabled" value="false"/>
                 </bean>
 
-                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                <bean class="org.apache.ignite.cache.CacheConfiguration">
                     <property name="name" value="query"/>
 
                     <property name="cacheMode" value="PARTITIONED"/>
@@ -83,7 +83,7 @@
                     <property name="queryIndexEnabled" value="true"/>
                 </bean>
 
-                <bean class="org.gridgain.grid.cache.GridCacheConfiguration">
+                <bean class="org.apache.ignite.cache.CacheConfiguration">
                     <property name="name" value="compute"/>
 
                     <property name="cacheMode" value="PARTITIONED"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/ignite-localhost-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-localhost-config.xml b/modules/yardstick/config/ignite-localhost-config.xml
index 7a51bb0..95d881c 100644
--- a/modules/yardstick/config/ignite-localhost-config.xml
+++ b/modules/yardstick/config/ignite-localhost-config.xml
@@ -24,9 +24,9 @@
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xsi:schemaLocation="
         http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
-    <import resource="gridgain-base-config.xml"/>
+    <import resource="ignite-base-config.xml"/>
 
-    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" parent="base-grid.cfg">
+    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" parent="base-ignite.cfg">
         <property name="localHost" value="127.0.0.1"/>
 
         <property name="discoverySpi">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/config/ignite-multicast-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-multicast-config.xml b/modules/yardstick/config/ignite-multicast-config.xml
index a81b0d5..89710c7 100644
--- a/modules/yardstick/config/ignite-multicast-config.xml
+++ b/modules/yardstick/config/ignite-multicast-config.xml
@@ -24,9 +24,9 @@
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xsi:schemaLocation="
         http://www.springframework.org/schema/beans http://www.springframework.org/schema/beans/spring-beans-2.5.xsd">
-    <import resource="gridgain-base-config.xml"/>
+    <import resource="ignite-base-config.xml"/>
 
-    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" parent="base-grid.cfg">
+    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration" parent="base-ignite.cfg">
         <property name="discoverySpi">
             <bean class="org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi">
                 <property name="ipFinder">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/pom.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/pom.xml b/modules/yardstick/pom.xml
index 67052dc..22ce876 100644
--- a/modules/yardstick/pom.xml
+++ b/modules/yardstick/pom.xml
@@ -172,6 +172,14 @@
                     </filesets>
                 </configuration>
             </plugin>
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-javadoc-plugin</artifactId>
+                <version>2.9.1</version>
+                <configuration>
+                    <skip>true</skip>
+                </configuration>
+            </plugin>
         </plugins>
     </build>
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
index 5cbfee1..cca6935 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
@@ -24,8 +24,8 @@ import org.yardstickframework.*;
 
 import java.util.concurrent.*;
 
-import static org.apache.ignite.events.IgniteEventType.*;
 import static org.apache.ignite.cache.CacheDistributionMode.*;
+import static org.apache.ignite.events.IgniteEventType.*;
 import static org.yardstickframework.BenchmarkUtils.*;
 
 /**
@@ -42,7 +42,7 @@ public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
     @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
         super.setUp(cfg);
 
-        jcommander(cfg.commandLineArguments(), args, "<gridgain-driver>");
+        jcommander(cfg.commandLineArguments(), args, "<ignite-driver>");
 
         if (Ignition.state() != IgniteState.STARTED) {
             node = new IgniteNode(args.distributionMode() == CLIENT_ONLY);
@@ -79,7 +79,7 @@ public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
      * @return Grid.
      */
     protected Ignite grid() {
-        return node.grid();
+        return node.ignite();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/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 38a61be..b80e7bf 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
@@ -40,7 +40,7 @@ import static org.apache.ignite.cache.CacheMemoryMode.*;
  */
 public class IgniteNode implements BenchmarkServer {
     /** Grid instance. */
-    private Ignite grid;
+    private Ignite ignite;
 
     /** Client mode. */
     private boolean clientMode;
@@ -56,16 +56,16 @@ public class IgniteNode implements BenchmarkServer {
     }
 
     /** */
-    public IgniteNode(boolean clientMode, Ignite grid) {
+    public IgniteNode(boolean clientMode, Ignite ignite) {
         this.clientMode = clientMode;
-        this.grid = grid;
+        this.ignite = ignite;
     }
 
     /** {@inheritDoc} */
     @Override public void start(BenchmarkConfiguration cfg) throws Exception {
         IgniteBenchmarkArguments args = new IgniteBenchmarkArguments();
 
-        BenchmarkUtils.jcommander(cfg.commandLineArguments(), args, "<gridgain-node>");
+        BenchmarkUtils.jcommander(cfg.commandLineArguments(), args, "<ignite-node>");
 
         IgniteConfiguration c = loadConfiguration(args.configuration());
 
@@ -119,7 +119,7 @@ public class IgniteNode implements BenchmarkServer {
 
         c.setCommunicationSpi(commSpi);
 
-        grid = Ignition.start(c);
+        ignite = Ignition.start(c);
     }
 
     /**
@@ -167,7 +167,7 @@ public class IgniteNode implements BenchmarkServer {
         }
 
         if (cfgMap == null || cfgMap.isEmpty())
-            throw new Exception("Failed to find grid configuration in: " + url);
+            throw new Exception("Failed to find ignite configuration in: " + url);
 
         return cfgMap.values().iterator().next();
     }
@@ -183,9 +183,9 @@ public class IgniteNode implements BenchmarkServer {
     }
 
     /**
-     * @return Grid.
+     * @return Ignite.
      */
-    public Ignite grid() {
-        return grid;
+    public Ignite ignite() {
+        return ignite;
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
new file mode 100644
index 0000000..5136bde
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
@@ -0,0 +1,42 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs put operations.
+ */
+public class IgnitePutBenchmark extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        cache.put(key, new SampleValue(key));
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("atomic");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java
deleted file mode 100644
index fbe55f3..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmarkIgnite.java
+++ /dev/null
@@ -1,42 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.yardstick.cache.model.*;
-
-import java.util.*;
-
-/**
- * GridGain benchmark that performs put operations.
- */
-public class IgnitePutBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = nextRandom(args.range());
-
-        cache.put(key, new SampleValue(key));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("atomic");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
new file mode 100644
index 0000000..2b9fa02
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
@@ -0,0 +1,47 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs put and get operations.
+ */
+public class IgnitePutGetBenchmark extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        Object val = cache.get(key);
+
+        if (val != null)
+            key = nextRandom(args.range());
+
+        cache.put(key, new SampleValue(key));
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("atomic");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java
deleted file mode 100644
index a3b3486..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmarkIgnite.java
+++ /dev/null
@@ -1,47 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.yardstick.cache.model.*;
-
-import java.util.*;
-
-/**
- * GridGain benchmark that performs put and get operations.
- */
-public class IgnitePutGetBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = nextRandom(args.range());
-
-        Object val = cache.get(key);
-
-        if (val != null)
-            key = nextRandom(args.range());
-
-        cache.put(key, new SampleValue(key));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("atomic");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
new file mode 100644
index 0000000..30acb41
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
@@ -0,0 +1,52 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.transactions.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs transactional put and get operations.
+ */
+public class IgnitePutGetTxBenchmark extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(0, args.range() / 2);
+
+        try (IgniteTx tx = grid().transactions().txStart()) {
+            Object val = cache.get(key);
+
+            if (val != null)
+                key = nextRandom(args.range() / 2, args.range());
+
+            cache.put(key, new SampleValue(key));
+
+            tx.commit();
+        }
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("tx");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java
deleted file mode 100644
index 3cad7d7..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmarkIgnite.java
+++ /dev/null
@@ -1,52 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.transactions.*;
-import org.apache.ignite.yardstick.cache.model.*;
-
-import java.util.*;
-
-/**
- * GridGain benchmark that performs transactional put and get operations.
- */
-public class IgnitePutGetTxBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = nextRandom(0, args.range() / 2);
-
-        try (IgniteTx tx = grid().transactions().txStart()) {
-            Object val = cache.get(key);
-
-            if (val != null)
-                key = nextRandom(args.range() / 2, args.range());
-
-            cache.put(key, new SampleValue(key));
-
-            tx.commit();
-        }
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("tx");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
new file mode 100644
index 0000000..e1cefbc
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
@@ -0,0 +1,43 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.yardstick.cache.model.*;
+
+import java.util.*;
+
+/**
+ * GridGain benchmark that performs transactional put operations.
+ */
+public class IgnitePutTxBenchmark extends IgniteCacheAbstractBenchmark {
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        int key = nextRandom(args.range());
+
+        // Implicit transaction is used.
+        cache.put(key, new SampleValue(key));
+
+        return true;
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("tx");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java
deleted file mode 100644
index dd2fd58..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmarkIgnite.java
+++ /dev/null
@@ -1,43 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.yardstick.cache.model.*;
-
-import java.util.*;
-
-/**
- * GridGain benchmark that performs transactional put operations.
- */
-public class IgnitePutTxBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        int key = nextRandom(args.range());
-
-        // Implicit transaction is used.
-        cache.put(key, new SampleValue(key));
-
-        return true;
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("tx");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
new file mode 100644
index 0000000..38aa632
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
@@ -0,0 +1,94 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.query.*;
+import org.apache.ignite.yardstick.cache.model.*;
+import org.yardstickframework.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+import static org.yardstickframework.BenchmarkUtils.*;
+
+/**
+ * GridGain benchmark that performs query operations.
+ */
+public class IgniteSqlQueryBenchmark extends IgniteCacheAbstractBenchmark {
+    /** */
+    private CacheQuery qry;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        println(cfg, "Populating query data...");
+
+        long start = System.nanoTime();
+
+        try (IgniteDataLoader<Integer, Person> dataLdr = grid().dataLoader(cache.getName())) {
+            for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
+                dataLdr.addData(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
+
+                if (i % 100000 == 0)
+                    println(cfg, "Populated persons: " + i);
+            }
+        }
+
+        println(cfg, "Finished populating query data in " + ((System.nanoTime() - start) / 1_000_000) + " ms.");
+
+        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlQuery(Person.class, "salary >= ? and salary <= ?");
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        double salary = ThreadLocalRandom.current().nextDouble() * args.range() * 1000;
+
+        double maxSalary = salary + 1000;
+
+        Collection<Map.Entry<Integer, Person>> entries = executeQuery(salary, maxSalary);
+
+        for (Map.Entry<Integer, Person> entry : entries) {
+            Person p = entry.getValue();
+
+            if (p.getSalary() < salary || p.getSalary() > maxSalary)
+                throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
+                        ", person=" + p + ']');
+        }
+
+        return true;
+    }
+
+    /**
+     * @param minSalary Min salary.
+     * @param maxSalary Max salary.
+     * @return Query result.
+     * @throws Exception If failed.
+     */
+    private Collection<Map.Entry<Integer, Person>> executeQuery(double minSalary, double maxSalary) throws Exception {
+        CacheQuery<Map.Entry<Integer, Person>> q = (CacheQuery<Map.Entry<Integer, Person>>)qry;
+
+        return q.execute(minSalary, maxSalary).get();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("query");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java
deleted file mode 100644
index c769e53..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmarkIgnite.java
+++ /dev/null
@@ -1,94 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cache.query.*;
-import org.apache.ignite.yardstick.cache.model.*;
-import org.yardstickframework.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-import static org.yardstickframework.BenchmarkUtils.*;
-
-/**
- * GridGain benchmark that performs query operations.
- */
-public class IgniteSqlQueryBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** */
-    private CacheQuery qry;
-
-    /** {@inheritDoc} */
-    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
-        super.setUp(cfg);
-
-        println(cfg, "Populating query data...");
-
-        long start = System.nanoTime();
-
-        try (IgniteDataLoader<Integer, Person> dataLdr = grid().dataLoader(cache.getName())) {
-            for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
-                dataLdr.addData(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
-
-                if (i % 100000 == 0)
-                    println(cfg, "Populated persons: " + i);
-            }
-        }
-
-        println(cfg, "Finished populating query data in " + ((System.nanoTime() - start) / 1_000_000) + " ms.");
-
-        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlQuery(Person.class, "salary >= ? and salary <= ?");
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        double salary = ThreadLocalRandom.current().nextDouble() * args.range() * 1000;
-
-        double maxSalary = salary + 1000;
-
-        Collection<Map.Entry<Integer, Person>> entries = executeQuery(salary, maxSalary);
-
-        for (Map.Entry<Integer, Person> entry : entries) {
-            Person p = entry.getValue();
-
-            if (p.getSalary() < salary || p.getSalary() > maxSalary)
-                throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
-                        ", person=" + p + ']');
-        }
-
-        return true;
-    }
-
-    /**
-     * @param minSalary Min salary.
-     * @param maxSalary Max salary.
-     * @return Query result.
-     * @throws Exception If failed.
-     */
-    private Collection<Map.Entry<Integer, Person>> executeQuery(double minSalary, double maxSalary) throws Exception {
-        CacheQuery<Map.Entry<Integer, Person>> q = (CacheQuery<Map.Entry<Integer, Person>>)qry;
-
-        return q.execute(minSalary, maxSalary).get();
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("query");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
new file mode 100644
index 0000000..7b4262b
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
@@ -0,0 +1,118 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.query.*;
+import org.apache.ignite.yardstick.cache.model.*;
+import org.yardstickframework.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+import static org.yardstickframework.BenchmarkUtils.*;
+
+/**
+ * GridGain benchmark that performs query operations with joins.
+ */
+public class IgniteSqlQueryJoinBenchmark extends IgniteCacheAbstractBenchmark {
+    /** */
+    private CacheQuery qry;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        println(cfg, "Populating query data...");
+
+        long start = System.nanoTime();
+
+        try (IgniteDataLoader<Object, Object> dataLdr = grid().dataLoader(cache.getName())) {
+            final int orgRange = args.range() / 10;
+
+            // Populate organizations.
+            for (int i = 0; i < orgRange && !Thread.currentThread().isInterrupted(); i++)
+                dataLdr.addData(i, new Organization(i, "org" + i));
+
+            dataLdr.flush();
+
+            // Populate persons.
+            for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
+                Person p =
+                    new Person(i, ThreadLocalRandom.current().nextInt(orgRange), "firstName" + i, "lastName" + i, i * 1000);
+
+                dataLdr.addData(i, p);
+
+                if (i % 100000 == 0)
+                    println(cfg, "Populated persons: " + i);
+            }
+        }
+
+        println(cfg, "Finished populating join query data in " + ((System.nanoTime() - start) / 1_000_000) + " ms.");
+
+        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlFieldsQuery(
+            // "select p.id, p.orgId, p.firstName, p.lastName, p.salary, o.name " +
+            //    "from Person p, Organization o " +
+            //    "where p.id = o.id and salary >= ? and salary <= ?");
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        double salary = ThreadLocalRandom.current().nextDouble() * args.range() * 1000;
+
+        double maxSalary = salary + 1000;
+
+        Collection<List<?>> lists = executeQueryJoin(salary, maxSalary);
+
+        for (List<?> l : lists) {
+            double sal = (Double)l.get(4);
+
+            if (sal < salary || sal > maxSalary) {
+                Person p = new Person();
+
+                p.setId((Integer)l.get(0));
+                p.setOrganizationId((Integer)l.get(1));
+                p.setFirstName((String)l.get(2));
+                p.setLastName((String)l.get(3));
+                p.setSalary(sal);
+
+                throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
+                    ", person=" + p + ']');
+            }
+        }
+
+        return true;
+    }
+
+    /**
+     * @param minSalary Min salary.
+     * @param maxSalary Max salary.
+     * @return Query results.
+     * @throws Exception If failed.
+     */
+    private Collection<List<?>> executeQueryJoin(double minSalary, double maxSalary) throws Exception {
+        CacheQuery<List<?>> q = (CacheQuery<List<?>>)qry;
+
+        return q.execute(minSalary, maxSalary).get();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("query");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java
deleted file mode 100644
index 4405afa..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmarkIgnite.java
+++ /dev/null
@@ -1,118 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cache.query.*;
-import org.apache.ignite.yardstick.cache.model.*;
-import org.yardstickframework.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-import static org.yardstickframework.BenchmarkUtils.*;
-
-/**
- * GridGain benchmark that performs query operations with joins.
- */
-public class IgniteSqlQueryJoinBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** */
-    private CacheQuery qry;
-
-    /** {@inheritDoc} */
-    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
-        super.setUp(cfg);
-
-        println(cfg, "Populating query data...");
-
-        long start = System.nanoTime();
-
-        try (IgniteDataLoader<Object, Object> dataLdr = grid().dataLoader(cache.getName())) {
-            final int orgRange = args.range() / 10;
-
-            // Populate organizations.
-            for (int i = 0; i < orgRange && !Thread.currentThread().isInterrupted(); i++)
-                dataLdr.addData(i, new Organization(i, "org" + i));
-
-            dataLdr.flush();
-
-            // Populate persons.
-            for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
-                Person p =
-                    new Person(i, ThreadLocalRandom.current().nextInt(orgRange), "firstName" + i, "lastName" + i, i * 1000);
-
-                dataLdr.addData(i, p);
-
-                if (i % 100000 == 0)
-                    println(cfg, "Populated persons: " + i);
-            }
-        }
-
-        println(cfg, "Finished populating join query data in " + ((System.nanoTime() - start) / 1_000_000) + " ms.");
-
-        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlFieldsQuery(
-            // "select p.id, p.orgId, p.firstName, p.lastName, p.salary, o.name " +
-            //    "from Person p, Organization o " +
-            //    "where p.id = o.id and salary >= ? and salary <= ?");
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        double salary = ThreadLocalRandom.current().nextDouble() * args.range() * 1000;
-
-        double maxSalary = salary + 1000;
-
-        Collection<List<?>> lists = executeQueryJoin(salary, maxSalary);
-
-        for (List<?> l : lists) {
-            double sal = (Double)l.get(4);
-
-            if (sal < salary || sal > maxSalary) {
-                Person p = new Person();
-
-                p.setId((Integer)l.get(0));
-                p.setOrganizationId((Integer)l.get(1));
-                p.setFirstName((String)l.get(2));
-                p.setLastName((String)l.get(3));
-                p.setSalary(sal);
-
-                throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
-                    ", person=" + p + ']');
-            }
-        }
-
-        return true;
-    }
-
-    /**
-     * @param minSalary Min salary.
-     * @param maxSalary Max salary.
-     * @return Query results.
-     * @throws Exception If failed.
-     */
-    private Collection<List<?>> executeQueryJoin(double minSalary, double maxSalary) throws Exception {
-        CacheQuery<List<?>> q = (CacheQuery<List<?>>)qry;
-
-        return q.execute(minSalary, maxSalary).get();
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("query");
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
new file mode 100644
index 0000000..9d8ef4f
--- /dev/null
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
@@ -0,0 +1,86 @@
+/*
+ * 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.yardstick.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.query.*;
+import org.apache.ignite.yardstick.cache.model.*;
+import org.yardstickframework.*;
+
+import java.util.*;
+import java.util.concurrent.*;
+
+/**
+ * GridGain benchmark that performs put and query operations.
+ */
+public class IgniteSqlQueryPutBenchmark extends IgniteCacheAbstractBenchmark {
+    /** */
+    private CacheQuery qry;
+
+    /** {@inheritDoc} */
+    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
+        super.setUp(cfg);
+
+        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlQuery(Person.class, "salary >= ? and salary <= ?");
+    }
+
+    /** {@inheritDoc} */
+    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
+        ThreadLocalRandom rnd = ThreadLocalRandom.current();
+
+        if (rnd.nextBoolean()) {
+            double salary = rnd.nextDouble() * args.range() * 1000;
+
+            double maxSalary = salary + 1000;
+
+            Collection<Map.Entry<Integer, Person>> entries = executeQuery(salary, maxSalary);
+
+            for (Map.Entry<Integer, Person> entry : entries) {
+                Person p = entry.getValue();
+
+                if (p.getSalary() < salary || p.getSalary() > maxSalary)
+                    throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
+                            ", person=" + p + ']');
+            }
+        }
+        else {
+            int i = rnd.nextInt(args.range());
+
+            cache.put(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
+        }
+
+        return true;
+    }
+
+    /**
+     * @param minSalary Min salary.
+     * @param maxSalary Max salary.
+     * @return Query result.
+     * @throws Exception If failed.
+     */
+    private Collection<Map.Entry<Integer, Person>> executeQuery(double minSalary, double maxSalary) throws Exception {
+        CacheQuery<Map.Entry<Integer, Person>> q = (CacheQuery<Map.Entry<Integer, Person>>)qry;
+
+        return q.execute(minSalary, maxSalary).get();
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteCache<Integer, Object> cache() {
+        return grid().jcache("query");
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/aee11a01/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java
deleted file mode 100644
index 8bef1e5..0000000
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmarkIgnite.java
+++ /dev/null
@@ -1,86 +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.yardstick.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cache.query.*;
-import org.apache.ignite.yardstick.cache.model.*;
-import org.yardstickframework.*;
-
-import java.util.*;
-import java.util.concurrent.*;
-
-/**
- * GridGain benchmark that performs put and query operations.
- */
-public class IgniteSqlQueryPutBenchmarkIgnite extends IgniteCacheAbstractBenchmark {
-    /** */
-    private CacheQuery qry;
-
-    /** {@inheritDoc} */
-    @Override public void setUp(BenchmarkConfiguration cfg) throws Exception {
-        super.setUp(cfg);
-
-        qry = null; // TODO: should be fixed after IGNITE-2 cache.queries().createSqlQuery(Person.class, "salary >= ? and salary <= ?");
-    }
-
-    /** {@inheritDoc} */
-    @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        ThreadLocalRandom rnd = ThreadLocalRandom.current();
-
-        if (rnd.nextBoolean()) {
-            double salary = rnd.nextDouble() * args.range() * 1000;
-
-            double maxSalary = salary + 1000;
-
-            Collection<Map.Entry<Integer, Person>> entries = executeQuery(salary, maxSalary);
-
-            for (Map.Entry<Integer, Person> entry : entries) {
-                Person p = entry.getValue();
-
-                if (p.getSalary() < salary || p.getSalary() > maxSalary)
-                    throw new Exception("Invalid person retrieved [min=" + salary + ", max=" + maxSalary +
-                            ", person=" + p + ']');
-            }
-        }
-        else {
-            int i = rnd.nextInt(args.range());
-
-            cache.put(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
-        }
-
-        return true;
-    }
-
-    /**
-     * @param minSalary Min salary.
-     * @param maxSalary Max salary.
-     * @return Query result.
-     * @throws Exception If failed.
-     */
-    private Collection<Map.Entry<Integer, Person>> executeQuery(double minSalary, double maxSalary) throws Exception {
-        CacheQuery<Map.Entry<Integer, Person>> q = (CacheQuery<Map.Entry<Integer, Person>>)qry;
-
-        return q.execute(minSalary, maxSalary).get();
-    }
-
-    /** {@inheritDoc} */
-    @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("query");
-    }
-}


[18/45] incubator-ignite git commit: #IGNITE-86: Change undeploys from concurrentMap to Map

Posted by sb...@apache.org.
#IGNITE-86: Change undeploys from concurrentMap to Map


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

Branch: refs/heads/ignite-121-logging
Commit: 4b690fc4217e26a27f7385f1c3ecb0b006e9eb15
Parents: fb37ccf
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jan 27 15:56:35 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jan 27 15:56:35 2015 +0300

----------------------------------------------------------------------
 .../cache/GridCacheDeploymentManager.java       | 31 +++++++++++++-------
 1 file changed, 21 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4b690fc4/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
index 8729b86..fa0f65f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
@@ -53,7 +53,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     private volatile ClassLoader globalLdr;
 
     /** Undeploys. */
-    private final ConcurrentMap<String, ConcurrentLinkedQueue<CA>> undeploys = new ConcurrentHashMap8<>();
+    private final Map<String, List<CA>> undeploys = new HashMap<>();
 
     /** Per-thread deployment context. */
     private ConcurrentMap<IgniteUuid, CachedDeploymentInfo<K, V>> deps = new ConcurrentHashMap8<>();
@@ -182,12 +182,16 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
-        ConcurrentLinkedQueue<CA> q = undeploys.get(ctx.namexx());
+        List<CA> q;
+
+        synchronized (undeploys) {
+            q = undeploys.remove(ctx.namexx());
+        }
 
         if (q == null)
             return;
 
-        for (CA c = q.poll(); c != null; c = q.poll()) {
+        for (CA c : q) {
             c.apply();
 
             cnt++;
@@ -209,14 +213,21 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
         for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            undeploys.putIfAbsent(cacheCtx.namexx(), new ConcurrentLinkedQueue<CA>());
+            synchronized (undeploys) {
+                List<CA> queue = new ArrayList<>();
 
-            undeploys.get(cacheCtx.namexx()).add(new CA() {
-                @Override
-                public void apply() {
-                    onUndeploy0(ldr, cacheCtx);
-                }
-            });
+                if (undeploys.containsKey(cacheCtx.namexx()))
+                    queue = undeploys.get(cacheCtx.namexx());
+                else
+                    undeploys.put(cacheCtx.namexx(), queue);
+
+                queue.add(new CA() {
+                    @Override
+                    public void apply() {
+                        onUndeploy0(ldr, cacheCtx);
+                    }
+                });
+            }
         }
 
         for (GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {


[20/45] incubator-ignite git commit: ignite-86 review

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


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

Branch: refs/heads/ignite-121-logging
Commit: 0349c858bd60202880a8e5d6631eac9d62d7e5dc
Parents: ff5c7a4
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Tue Jan 27 16:10:43 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Tue Jan 27 16:10:43 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheDeploymentManager.java  | 14 ++++++--------
 1 file changed, 6 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0349c858/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
index fa0f65f..2253d88 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
@@ -185,7 +185,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
         List<CA> q;
 
         synchronized (undeploys) {
-            q = undeploys.remove(ctx.namexx());
+            q = undeploys.remove(ctx.name());
         }
 
         if (q == null)
@@ -212,14 +212,12 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
         if (log.isDebugEnabled())
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
-        for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            synchronized (undeploys) {
-                List<CA> queue = new ArrayList<>();
+        synchronized (undeploys) {
+            for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
+                List<CA> queue = undeploys.get(cacheCtx.name());
 
-                if (undeploys.containsKey(cacheCtx.namexx()))
-                    queue = undeploys.get(cacheCtx.namexx());
-                else
-                    undeploys.put(cacheCtx.namexx(), queue);
+                if (queue == null)
+                    undeploys.put(cacheCtx.name(), queue = new ArrayList<>());
 
                 queue.add(new CA() {
                     @Override


[12/45] incubator-ignite git commit: #IGNITE-86: merge

Posted by sb...@apache.org.
#IGNITE-86: merge


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

Branch: refs/heads/ignite-121-logging
Commit: 7cccef78212abde41e57bf3b323647e86d5dceba
Parents: 117037d
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 19:28:24 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 19:28:24 2015 +0300

----------------------------------------------------------------------
 .../GridDeploymentPerLoaderStore.java           |  20 ++-
 .../GridDeploymentPerVersionStore.java          |   4 +-
 .../processors/cache/GridCacheAdapter.java      |   5 +-
 .../cache/GridCacheDeploymentManager.java       | 150 ++++++++++---------
 .../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, 103 insertions(+), 101 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerLoaderStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerLoaderStore.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerLoaderStore.java
index 9ea3fd3..aaf0b5d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerLoaderStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerLoaderStore.java
@@ -91,7 +91,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
                     }
 
                     for (IsolatedDeployment dep : rmv)
-                        dep.recordUndeployed(nodeId);
+                        dep.recordUndeployed();
                 }
             }
         };
@@ -122,7 +122,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         for (IsolatedDeployment dep : cp)
-            dep.recordUndeployed(null);
+            dep.recordUndeployed();
 
         if (log.isDebugEnabled())
             log.debug(stopInfo());
@@ -150,7 +150,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         for (IsolatedDeployment dep : rmv)
-            dep.recordUndeployed(null);
+            dep.recordUndeployed();
 
         if (log.isDebugEnabled())
             log.debug("Registered deployment discovery listener: " + discoLsnr);
@@ -351,7 +351,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
                     }
 
                     if (rmv)
-                        dep.recordUndeployed(null);
+                        dep.recordUndeployed();
                 }
             });
         }
@@ -384,7 +384,7 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         for (IsolatedDeployment dep : undeployed)
-            dep.recordUndeployed(null);
+            dep.recordUndeployed();
     }
 
     /** {@inheritDoc} */
@@ -461,11 +461,9 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
         }
 
         /**
-         * Called to record all undeployed classes..
-         *
-         * @param leftNodeId Left node ID.
+         * Called to record all undeployed classes.
          */
-        void recordUndeployed(@Nullable UUID leftNodeId) {
+        void recordUndeployed() {
             assert !Thread.holdsLock(mux);
 
             GridEventStorageManager evts = ctx.event();
@@ -499,8 +497,8 @@ public class GridDeploymentPerLoaderStore extends GridDeploymentStoreAdapter {
 
                 ClassLoader ldr = classLoader();
 
-                ctx.cache().onUndeployed(leftNodeId, ldr);
-                ctx.stream().onUndeployed(leftNodeId, ldr);
+                ctx.cache().onUndeployed(ldr);
+                ctx.stream().onUndeployed(ldr);
 
                 // Clear optimized marshaller's cache. If another marshaller is used, this is no-op.
                 IgniteOptimizedMarshaller.onUndeploy(ldr);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java b/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
index a37c02c..b615e74 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/managers/deployment/GridDeploymentPerVersionStore.java
@@ -1259,8 +1259,8 @@ public class GridDeploymentPerVersionStore extends GridDeploymentStoreAdapter {
 
                 ClassLoader ldr = classLoader();
 
-                ctx.cache().onUndeployed(leftNodeId, ldr);
-                ctx.stream().onUndeployed(leftNodeId, ldr);
+                ctx.cache().onUndeployed(ldr);
+                ctx.stream().onUndeployed(ldr);
 
                 // Clear optimized marshaller's cache. If another marshaller is used, this is no-op.
                 IgniteOptimizedMarshaller.onUndeploy(ldr);

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/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 112483a..2a60c13 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
@@ -948,11 +948,10 @@ public abstract class GridCacheAdapter<K, V> implements GridCache<K, V>,
     /**
      * Undeploys and removes all entries for class loader.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader to undeploy.
      */
-    public void onUndeploy(@Nullable UUID leftNodeId, ClassLoader ldr) {
-        ctx.deploy().onUndeploy(leftNodeId, ldr);
+    public void onUndeploy(ClassLoader ldr) {
+        ctx.deploy().onUndeploy(ldr);
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
index d5ffb0d..2f007f2 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
@@ -53,7 +53,8 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     private volatile ClassLoader globalLdr;
 
     /** Undeploys. */
-    private final ConcurrentLinkedQueue<CA> undeploys = new ConcurrentLinkedQueue<>();
+    private final ConcurrentHashMap8<GridCacheContext, ConcurrentLinkedQueue<CA>> undeploys
+        = new ConcurrentHashMap8<>();
 
     /** Per-thread deployment context. */
     private ConcurrentMap<IgniteUuid, CachedDeploymentInfo<K, V>> deps =
@@ -177,11 +178,16 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
 
     /**
      * Undeploy all queued up closures.
+     *
+     * @param ctx Cache context.
      */
-    public void unwind() {
+    public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
-        for (CA c = undeploys.poll(); c != null; c = undeploys.poll()) {
+        if (undeploys.get(ctx) == null)
+            return;
+
+        for (CA c = undeploys.get(ctx).poll(); c != null; c = undeploys.get(ctx).poll()) {
             c.apply();
 
             cnt++;
@@ -194,110 +200,114 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     /**
      * Undeploys given class loader.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader to undeploy.
      */
-    public void onUndeploy(@Nullable final UUID leftNodeId, final ClassLoader ldr) {
+    public void onUndeploy(final ClassLoader ldr) {
         assert ldr != null;
 
         if (log.isDebugEnabled())
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
-        undeploys.add(new CA() {
-            @Override public void apply() {
-                onUndeploy0(leftNodeId, ldr);
-            }
-        });
+        for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
+            undeploys.putIfAbsent(cacheCtx, new ConcurrentLinkedQueue<CA>());
+
+            undeploys.get(cacheCtx).add(new CA() {
+                @Override
+                public void apply() {
+                    onUndeploy0(ldr, cacheCtx);
+                }
+            });
+        }
 
         for (GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
             // Unwind immediately for local and replicate caches.
             // We go through preloader for proper synchronization.
-            if (cacheCtx.isLocal() || cacheCtx.isReplicated())
+            if (cacheCtx.isLocal())
                 cacheCtx.preloader().unwindUndeploys();
         }
     }
 
     /**
-     * @param leftNodeId Left node ID.
      * @param ldr Loader.
+     * @param cacheCtx Cache context.
      */
-    private void onUndeploy0(@Nullable final UUID leftNodeId, final ClassLoader ldr) {
-        for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            GridCacheAdapter<K, V> cache = cacheCtx.cache();
-
-            Set<K> keySet = cache.keySet(cacheCtx.vararg(
-                new P1<CacheEntry<K, V>>() {
-                    @Override public boolean apply(CacheEntry<K, V> e) {
-                        return cacheCtx.isNear() ? undeploy(e, cacheCtx.near()) || undeploy(e, cacheCtx.near().dht()) :
-                            undeploy(e, cacheCtx.cache());
-                    }
+    private void onUndeploy0(final ClassLoader ldr, final GridCacheContext<K, V> cacheCtx) {
+        GridCacheAdapter<K, V> cache = cacheCtx.cache();
+
+        Set<K> keySet = cache.keySet(cacheCtx.vararg(
+            new P1<CacheEntry<K, V>>() {
+                @Override public boolean apply(CacheEntry<K, V> e) {
+                    return cacheCtx.isNear() ? undeploy(e, cacheCtx.near()) || undeploy(e, cacheCtx.near().dht()) :
+                        undeploy(e, cacheCtx.cache());
+                }
 
-                    /**
-                     * @param e Entry.
-                     * @param cache Cache.
-                     * @return {@code True} if entry should be undeployed.
-                     */
-                    private boolean undeploy(CacheEntry<K, V> e, GridCacheAdapter<K, V> cache) {
-                        K k = e.getKey();
+                /**
+                 * @param e Entry.
+                 * @param cache Cache.
+                 * @return {@code True} if entry should be undeployed.
+                 */
+                private boolean undeploy(CacheEntry<K, V> e, GridCacheAdapter<K, V> cache) {
+                    K k = e.getKey();
 
-                        GridCacheEntryEx<K, V> entry = cache.peekEx(e.getKey());
+                    GridCacheEntryEx<K, V> entry = cache.peekEx(e.getKey());
 
-                        if (entry == null)
-                            return false;
+                    if (entry == null)
+                        return false;
 
-                        V v;
+                    V v;
 
-                        try {
-                            v = entry.peek(GridCachePeekMode.GLOBAL, CU.<K, V>empty());
-                        }
-                        catch (GridCacheEntryRemovedException ignore) {
-                            return false;
-                        }
-                        catch (IgniteException ignore) {
-                            // Peek can throw runtime exception if unmarshalling failed.
-                            return true;
-                        }
+                    try {
+                        v = entry.peek(GridCachePeekMode.GLOBAL, CU.<K, V>empty());
+                    }
+                    catch (GridCacheEntryRemovedException ignore) {
+                        return false;
+                    }
+                    catch (IgniteException ignore) {
+                        // Peek can throw runtime exception if unmarshalling failed.
+                        return true;
+                    }
 
-                        assert k != null : "Key cannot be null for cache entry: " + e;
+                    assert k != null : "Key cannot be null for cache entry: " + e;
 
-                        ClassLoader keyLdr = U.detectObjectClassLoader(k);
-                        ClassLoader valLdr = U.detectObjectClassLoader(v);
+                    ClassLoader keyLdr = U.detectObjectClassLoader(k);
+                    ClassLoader valLdr = U.detectObjectClassLoader(v);
 
-                        boolean res = F.eq(ldr, keyLdr) || F.eq(ldr, valLdr);
+                    boolean res = F.eq(ldr, keyLdr) || F.eq(ldr, valLdr);
 
-                        if (log.isDebugEnabled())
-                            log.debug("Finished examining entry [entryCls=" + e.getClass() +
-                                ", key=" + k + ", keyCls=" + k.getClass() +
-                                ", valCls=" + (v != null ? v.getClass() : "null") +
-                                ", keyLdr=" + keyLdr + ", valLdr=" + valLdr + ", res=" + res + ']');
+                    if (log.isDebugEnabled())
+                        log.debug("Finished examining entry [entryCls=" + e.getClass() +
+                            ", key=" + k + ", keyCls=" + k.getClass() +
+                            ", valCls=" + (v != null ? v.getClass() : "null") +
+                            ", keyLdr=" + keyLdr + ", valLdr=" + valLdr + ", res=" + res + ']');
 
-                        return res;
-                    }
-                }));
+                    return res;
+                }
+            }));
 
-            Collection<K> keys = new LinkedList<>();
+        Collection<K> keys = new ArrayList<>();
 
-            for (K k : keySet)
-                keys.add(k);
+        for (K k : keySet)
+            keys.add(k);
 
-            if (log.isDebugEnabled())
-                log.debug("Finished searching keys for undeploy [keysCnt=" + keys.size() + ']');
+        if (log.isDebugEnabled())
+            log.debug("Finished searching keys for undeploy [keysCnt=" + keys.size() + ']');
 
-            cache.clearAll(keys, true);
+        cache.clearAll(keys, true);
 
-            if (cacheCtx.isNear())
-                cacheCtx.near().dht().clearAll(keys, true);
+        if (cacheCtx.isNear())
+            cacheCtx.near().dht().clearAll(keys, true);
 
-            GridCacheQueryManager<K, V> qryMgr = cacheCtx.queries();
+        GridCacheQueryManager<K, V> qryMgr = cacheCtx.queries();
 
-            if (qryMgr != null)
-                qryMgr.onUndeploy(ldr);
+        if (qryMgr != null)
+            qryMgr.onUndeploy(ldr);
 
-            // Examine swap for entries to undeploy.
-            int swapUndeployCnt = cacheCtx.isNear() ?
-                cacheCtx.near().dht().context().swap().onUndeploy(leftNodeId, ldr) :
-                cacheCtx.swap().onUndeploy(leftNodeId, ldr);
+        // Examine swap for entries to undeploy.
+        int swapUndeployCnt = cacheCtx.isNear() ?
+            cacheCtx.near().dht().context().swap().onUndeploy(ldr) :
+            cacheCtx.swap().onUndeploy(ldr);
 
+        if (!cacheCtx.system()) {
             U.quietAndWarn(log, "");
             U.quietAndWarn(
                 log,

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePreloaderAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePreloaderAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePreloaderAdapter.java
index 8128b3b..29b4b4a 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePreloaderAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePreloaderAdapter.java
@@ -106,7 +106,7 @@ public class GridCachePreloaderAdapter<K, V> implements GridCachePreloader<K, V>
 
     /** {@inheritDoc} */
     @Override public void unwindUndeploys() {
-        cctx.deploy().unwind();
+        cctx.deploy().unwind(cctx);
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
index a893ef3..cd1abab 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
@@ -1764,13 +1764,12 @@ public class GridCacheProcessor extends GridProcessorAdapter {
      * Callback invoked by deployment manager for whenever a class loader
      * gets undeployed.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader.
      */
-    public void onUndeployed(@Nullable UUID leftNodeId, ClassLoader ldr) {
+    public void onUndeployed(ClassLoader ldr) {
         if (!ctx.isStopping())
             for (GridCacheAdapter<?, ?> cache : caches.values())
-                cache.onUndeploy(leftNodeId, ldr);
+                cache.onUndeploy(ldr);
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheSwapManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheSwapManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheSwapManager.java
index d1d55c7..135c305 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheSwapManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheSwapManager.java
@@ -1434,11 +1434,10 @@ public class GridCacheSwapManager<K, V> extends GridCacheManagerAdapter<K, V> {
     }
 
     /**
-     * @param leftNodeId Left Node ID.
      * @param ldr Undeployed class loader.
      * @return Undeploy count.
      */
-    public int onUndeploy(UUID leftNodeId, ClassLoader ldr) {
+    public int onUndeploy(ClassLoader ldr) {
         if (cctx.portableEnabled())
             return 0;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
index 30b536c..7839bd8 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
@@ -389,7 +389,7 @@ public class GridDhtPartitionDemandPool<K, V> {
         demandLock.writeLock().lock();
 
         try {
-            cctx.deploy().unwind();
+            cctx.deploy().unwind(cctx);
         }
         finally {
             demandLock.writeLock().unlock();

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/GridStreamProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/GridStreamProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/GridStreamProcessor.java
index 5af5d5b..84c9e57 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/GridStreamProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/GridStreamProcessor.java
@@ -350,11 +350,10 @@ public class GridStreamProcessor extends GridProcessorAdapter {
     /**
      * Callback for undeployed class loaders.
      *
-     * @param leftNodeId Left node ID.
      * @param ldr Class loader.
      */
-    public void onUndeployed(UUID leftNodeId, ClassLoader ldr) {
+    public void onUndeployed(ClassLoader ldr) {
         for (IgniteStreamerEx streamer : map.values())
-            streamer.onUndeploy(leftNodeId, ldr);
+            streamer.onUndeploy(ldr);
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerEx.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerEx.java
index 4fee074..0158fab 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerEx.java
@@ -80,10 +80,9 @@ public interface IgniteStreamerEx extends IgniteStreamer {
     /**
      * Callback for undeployed class loaders. All deployed events will be removed from window and local storage.
      *
-     * @param leftNodeId Left node ID which caused undeployment.
      * @param undeployedLdr Undeployed class loader.
      */
-    public void onUndeploy(UUID leftNodeId, ClassLoader undeployedLdr);
+    public void onUndeploy(ClassLoader undeployedLdr);
 
     /**
      * Callback executed when streamer query completes.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/7cccef78/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerImpl.java
index 3542615..58fb036 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/streamer/IgniteStreamerImpl.java
@@ -688,10 +688,9 @@ public class IgniteStreamerImpl implements IgniteStreamerEx, Externalizable {
     }
 
     /** {@inheritDoc} */
-    @Override public void onUndeploy(UUID leftNodeId, ClassLoader undeployedLdr) {
+    @Override public void onUndeploy(ClassLoader undeployedLdr) {
         if (log.isDebugEnabled())
-            log.debug("Processing undeployment event [leftNodeId=" + leftNodeId +
-                ", undeployedLdr=" + undeployedLdr + ']');
+            log.debug("Processing undeployment event undeployedLdr=" + undeployedLdr + ']');
 
         unwindUndeploys(undeployedLdr, true);
     }


[28/45] incubator-ignite git commit: # IGNITE-102: Renaming + debug.

Posted by sb...@apache.org.
# IGNITE-102: Renaming + debug.


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

Branch: refs/heads/ignite-121-logging
Commit: fa4ac59ac62e5fe2a14405e1cac51bfe94f5cb58
Parents: 641a4c8
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 10:13:29 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 10:13:29 2015 +0700

----------------------------------------------------------------------
 .../ignite/yardstick/IgniteAbstractBenchmark.java       |  6 +++---
 .../ignite/yardstick/cache/IgniteGetBenchmark.java      |  2 +-
 .../ignite/yardstick/cache/IgnitePutBenchmark.java      |  2 +-
 .../ignite/yardstick/cache/IgnitePutGetBenchmark.java   |  2 +-
 .../ignite/yardstick/cache/IgnitePutGetTxBenchmark.java | 12 ++++++++++--
 .../ignite/yardstick/cache/IgnitePutTxBenchmark.java    |  2 +-
 .../ignite/yardstick/cache/IgniteSqlQueryBenchmark.java |  4 ++--
 .../yardstick/cache/IgniteSqlQueryJoinBenchmark.java    |  4 ++--
 .../yardstick/cache/IgniteSqlQueryPutBenchmark.java     |  2 +-
 .../yardstick/compute/IgniteAffinityCallBenchmark.java  |  2 +-
 .../ignite/yardstick/compute/IgniteApplyBenchmark.java  |  2 +-
 .../yardstick/compute/IgniteBroadcastBenchmark.java     |  2 +-
 .../yardstick/compute/IgniteExecuteBenchmark.java       |  2 +-
 .../ignite/yardstick/compute/IgniteRunBenchmark.java    |  2 +-
 14 files changed, 27 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
index 6f9f903..c09d185 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
@@ -78,7 +78,7 @@ public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
     /**
      * @return Grid.
      */
-    protected Ignite grid() {
+    protected Ignite ignite() {
         return node.ignite();
     }
 
@@ -88,7 +88,7 @@ public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
     private void waitForNodes() throws Exception {
         final CountDownLatch nodesStartedLatch = new CountDownLatch(1);
 
-        grid().events().localListen(new IgnitePredicate<IgniteEvent>() {
+        ignite().events().localListen(new IgnitePredicate<IgniteEvent>() {
             @Override public boolean apply(IgniteEvent gridEvt) {
                 if (nodesStarted())
                     nodesStartedLatch.countDown();
@@ -108,7 +108,7 @@ public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
      * @return {@code True} if all nodes are started, {@code false} otherwise.
      */
     private boolean nodesStarted() {
-        return grid().cluster().nodes().size() >= args.nodes();
+        return ignite().cluster().nodes().size() >= args.nodes();
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
index 783523b..4e4ee9d 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
@@ -36,6 +36,6 @@ public class IgniteGetBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("atomic");
+        return ignite().jcache("atomic");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
index ee55d57..1993ac8 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
@@ -37,6 +37,6 @@ public class IgnitePutBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("atomic");
+        return ignite().jcache("atomic");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
index 73b183f..cb6e220 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
@@ -42,6 +42,6 @@ public class IgnitePutGetBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("atomic");
+        return ignite().jcache("atomic");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
index a274b5b..944d6a4 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
@@ -31,15 +31,23 @@ public class IgnitePutGetTxBenchmark extends IgniteCacheAbstractBenchmark {
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
         int key = nextRandom(0, args.range() / 2);
 
-        try (IgniteTx tx = grid().transactions().txStart()) {
+        ignite().log().debug("IgnitePutGetTxBenchmark - key: " + key);
+
+        try (IgniteTx tx = ignite().transactions().txStart()) {
+            ignite().log().debug("IgnitePutGetTxBenchmark: txStart()");
+
             Object val = cache.get(key);
 
+            ignite().log().debug("IgnitePutGetTxBenchmark - get():" + val);
+
             if (val != null)
                 key = nextRandom(args.range() / 2, args.range());
 
             cache.put(key, new SampleValue(key));
 
             tx.commit();
+
+            ignite().log().debug("IgnitePutGetTxBenchmark - txCommit");
         }
 
         return true;
@@ -47,6 +55,6 @@ public class IgnitePutGetTxBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("tx");
+        return ignite().jcache("tx");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
index 1f92392..ebf4f20 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
@@ -38,6 +38,6 @@ public class IgnitePutTxBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("tx");
+        return ignite().jcache("tx");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
index 3bca3d6..967197f 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
@@ -42,7 +42,7 @@ public class IgniteSqlQueryBenchmark extends IgniteCacheAbstractBenchmark {
 
         long start = System.nanoTime();
 
-        try (IgniteDataLoader<Integer, Person> dataLdr = grid().dataLoader(cache.getName())) {
+        try (IgniteDataLoader<Integer, Person> dataLdr = ignite().dataLoader(cache.getName())) {
             for (int i = 0; i < args.range() && !Thread.currentThread().isInterrupted(); i++) {
                 dataLdr.addData(i, new Person(i, "firstName" + i, "lastName" + i, i * 1000));
 
@@ -89,6 +89,6 @@ public class IgniteSqlQueryBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("query");
+        return ignite().jcache("query");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
index 5f8cc77..d74c56d 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
@@ -42,7 +42,7 @@ public class IgniteSqlQueryJoinBenchmark extends IgniteCacheAbstractBenchmark {
 
         long start = System.nanoTime();
 
-        try (IgniteDataLoader<Object, Object> dataLdr = grid().dataLoader(cache.getName())) {
+        try (IgniteDataLoader<Object, Object> dataLdr = ignite().dataLoader(cache.getName())) {
             final int orgRange = args.range() / 10;
 
             // Populate organizations.
@@ -113,6 +113,6 @@ public class IgniteSqlQueryJoinBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("query");
+        return ignite().jcache("query");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
index fcb8f2e..d4a7221 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
@@ -81,6 +81,6 @@ public class IgniteSqlQueryPutBenchmark extends IgniteCacheAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override protected IgniteCache<Integer, Object> cache() {
-        return grid().jcache("query");
+        return ignite().jcache("query");
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
index 7008d52..eeff847 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
@@ -29,7 +29,7 @@ import java.util.concurrent.*;
 public class IgniteAffinityCallBenchmark extends IgniteAbstractBenchmark {
     /** {@inheritDoc} */
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        grid().compute().affinityCall("compute", ThreadLocalRandom.current().nextInt(), new NoopCallable());
+        ignite().compute().affinityCall("compute", ThreadLocalRandom.current().nextInt(), new NoopCallable());
 
         return true;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
index 816d0d0..d42b356 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
@@ -45,7 +45,7 @@ public class IgniteApplyBenchmark extends IgniteAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        grid().compute().apply(new NoopClosure(), applyArgs);
+        ignite().compute().apply(new NoopClosure(), applyArgs);
 
         return true;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
index 1be6c44..0104a7b 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
@@ -28,7 +28,7 @@ import java.util.*;
 public class IgniteBroadcastBenchmark extends IgniteAbstractBenchmark {
     /** {@inheritDoc} */
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        grid().compute().broadcast(new NoopCallable());
+        ignite().compute().broadcast(new NoopCallable());
 
         return true;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
index 125ea6a..c2dc4d4 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
@@ -28,7 +28,7 @@ import java.util.*;
 public class IgniteExecuteBenchmark extends IgniteAbstractBenchmark {
     /** {@inheritDoc} */
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        grid().compute().execute(new NoopTask(args.jobs()), null);
+        ignite().compute().execute(new NoopTask(args.jobs()), null);
 
         return true;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/fa4ac59a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
index b9b43b3..0da0670 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
@@ -44,7 +44,7 @@ public class IgniteRunBenchmark extends IgniteAbstractBenchmark {
 
     /** {@inheritDoc} */
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
-        grid().compute().run(jobs);
+        ignite().compute().run(jobs);
         
         return true;
     }


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

Posted by sb...@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-121-logging
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
----------------------------------------------------------------------


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

Posted by sb...@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-121-logging
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
----------------------------------------------------------------------


[32/45] incubator-ignite git commit: #Tests: Fix hadoop tests.

Posted by sb...@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-121-logging
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));


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

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

Conflicts:
	modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerLoaderStore.java
	modules/core/src/main/java/org/gridgain/grid/kernal/managers/deployment/GridDeploymentPerVersionStore.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheAdapter.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePreloaderAdapter.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheProcessor.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheSwapManager.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/GridStreamProcessor.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerEx.java
	modules/core/src/main/java/org/gridgain/grid/kernal/processors/streamer/IgniteStreamerImpl.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/117037df
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/117037df
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/117037df

Branch: refs/heads/ignite-121-logging
Commit: 117037df1ba7927114420e61ded42806c451410b
Parents: 6e1aa2a 15cbff4
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 19:27:50 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 19:27:50 2015 +0300

----------------------------------------------------------------------
 bin/ggvisorcmd.sh                               |     4 +-
 config/hadoop/default-config.xml                |     2 +-
 config/router/default-router.xml                |     2 +-
 docs/core-site.gridgain.xml                     |     6 +-
 examples/config/example-cache.xml               |     2 +-
 examples/config/example-streamer.xml            |    18 +-
 examples/config/filesystem/core-site.xml        |     4 +-
 .../hibernate/example-hibernate-L2-cache.xml    |     2 +-
 examples/config/servlet/WEB-INF/web.xml         |     2 +-
 .../ignite/examples/ComputeNodeStartup.java     |    35 +
 .../apache/ignite/examples/ExamplesUtils.java   |    99 +
 .../compute/ComputeBroadcastExample.java        |   114 +
 .../compute/ComputeCallableExample.java         |    79 +
 .../examples/compute/ComputeClosureExample.java |    77 +
 .../compute/ComputeContinuousMapperExample.java |   162 +
 .../compute/ComputeExecutorServiceExample.java  |    71 +
 .../ComputeFibonacciContinuationExample.java    |   188 +
 .../compute/ComputeProjectionExample.java       |    94 +
 .../examples/compute/ComputeReducerExample.java |    89 +
 .../compute/ComputeRunnableExample.java         |    74 +
 .../compute/ComputeScheduleExample.java         |    86 +
 .../examples/compute/ComputeTaskMapExample.java |   113 +
 .../compute/ComputeTaskSplitExample.java        |   102 +
 .../failover/ComputeFailoverExample.java        |   143 +
 .../failover/ComputeFailoverNodeStartup.java    |    77 +
 .../examples/compute/failover/package.html      |    23 +
 .../examples/compute/montecarlo/Credit.java     |   110 +
 .../compute/montecarlo/CreditRiskExample.java   |   153 +
 .../compute/montecarlo/CreditRiskManager.java   |   153 +
 .../examples/compute/montecarlo/package.html    |    24 +
 .../apache/ignite/examples/compute/package.html |    23 +
 .../examples/datagrid/CacheAffinityExample.java |   138 +
 .../examples/datagrid/CacheApiExample.java      |   170 +
 .../datagrid/CacheContinuousQueryExample.java   |    97 +
 .../datagrid/CacheDataLoaderExample.java        |    81 +
 .../examples/datagrid/CacheEventsExample.java   |    95 +
 .../examples/datagrid/CacheNodeStartup.java     |    35 +
 .../datagrid/CachePopularNumbersExample.java    |   179 +
 .../examples/datagrid/CachePutGetExample.java   |   114 +
 .../examples/datagrid/CacheQueryExample.java    |   476 +
 .../datagrid/CacheTransactionExample.java       |   148 +
 .../datastructures/CacheAtomicLongExample.java  |    78 +
 .../CacheAtomicReferenceExample.java            |   126 +
 .../CacheAtomicSequenceExample.java             |   112 +
 .../CacheAtomicStampedExample.java              |   132 +
 .../CacheCountDownLatchExample.java             |   112 +
 .../datastructures/CacheQueueExample.java       |   214 +
 .../datastructures/CacheSetExample.java         |   193 +
 .../datagrid/datastructures/package.html        |    23 +
 .../hibernate/HibernateL2CacheExample.java      |   204 +
 .../HibernateL2CacheExampleNodeStartup.java     |    97 +
 .../examples/datagrid/hibernate/Post.java       |   126 +
 .../examples/datagrid/hibernate/User.java       |   151 +
 .../examples/datagrid/hibernate/package.html    |    23 +
 .../ignite/examples/datagrid/package.html       |    23 +
 .../starschema/CacheStarSchemaExample.java      |   227 +
 .../datagrid/starschema/DimProduct.java         |   100 +
 .../examples/datagrid/starschema/DimStore.java  |   100 +
 .../datagrid/starschema/FactPurchase.java       |   102 +
 .../examples/datagrid/starschema/package.html   |    24 +
 .../store/CacheNodeWithStoreStartup.java        |    89 +
 .../datagrid/store/CacheStoreExample.java       |    88 +
 .../store/CacheStoreLoadDataExample.java        |    76 +
 .../ignite/examples/datagrid/store/Person.java  |   103 +
 .../store/dummy/CacheDummyPersonStore.java      |   112 +
 .../examples/datagrid/store/dummy/package.html  |    24 +
 .../hibernate/CacheHibernatePersonStore.java    |   278 +
 .../datagrid/store/hibernate/Person.hbm.xml     |    32 +
 .../datagrid/store/hibernate/hibernate.cfg.xml  |    44 +
 .../datagrid/store/hibernate/package.html       |    24 +
 .../store/jdbc/CacheJdbcPersonStore.java        |   305 +
 .../examples/datagrid/store/jdbc/package.html   |    24 +
 .../ignite/examples/datagrid/store/package.html |    24 +
 .../ignite/examples/events/EventsExample.java   |   144 +
 .../apache/ignite/examples/events/package.html  |    24 +
 .../ignite/examples/ggfs/GgfsExample.java       |   278 +
 .../examples/ggfs/GgfsMapReduceExample.java     |   249 +
 .../ignite/examples/ggfs/GgfsNodeStartup.java   |    41 +
 .../apache/ignite/examples/ggfs/package.html    |    23 +
 .../examples/messaging/MessagingExample.java    |   174 +
 .../messaging/MessagingPingPongExample.java     |   133 +
 .../MessagingPingPongListenActorExample.java    |   107 +
 .../ignite/examples/messaging/package.html      |    24 +
 .../client/memcache/MemcacheRestExample.java    |   127 +
 .../MemcacheRestExampleNodeStartup.java         |    99 +
 .../examples/misc/client/memcache/package.html  |    23 +
 .../ignite/examples/misc/client/package.html    |    24 +
 .../misc/deployment/DeploymentExample.java      |   129 +
 .../examples/misc/deployment/package.html       |    24 +
 .../misc/lifecycle/LifecycleExample.java        |    92 +
 .../ignite/examples/misc/lifecycle/package.html |    24 +
 .../apache/ignite/examples/misc/package.html    |    24 +
 .../misc/springbean/SpringBeanExample.java      |    88 +
 .../examples/misc/springbean/package.html       |    24 +
 .../examples/misc/springbean/spring-bean.xml    |    73 +
 .../org/apache/ignite/examples/package.html     |    24 +
 .../examples/services/ServicesExample.java      |   161 +
 .../examples/services/SimpleMapService.java     |    49 +
 .../examples/services/SimpleMapServiceImpl.java |    71 +
 .../streaming/StreamingCheckInExample.java      |   582 +
 .../streaming/StreamingNodeStartup.java         |    35 +
 .../StreamingPopularNumbersExample.java         |   251 +
 .../streaming/StreamingPriceBarsExample.java    |   453 +
 .../StreamingRunningAverageExample.java         |   248 +
 .../ignite/examples/streaming/package.html      |    24 +
 .../gridgain/examples/ComputeNodeStartup.java   |    36 -
 .../org/gridgain/examples/ExamplesUtils.java    |    99 -
 .../compute/ComputeBroadcastExample.java        |   115 -
 .../compute/ComputeCallableExample.java         |    80 -
 .../examples/compute/ComputeClosureExample.java |    78 -
 .../compute/ComputeContinuousMapperExample.java |   163 -
 .../compute/ComputeExecutorServiceExample.java  |    72 -
 .../ComputeFibonacciContinuationExample.java    |   189 -
 .../compute/ComputeProjectionExample.java       |    95 -
 .../examples/compute/ComputeReducerExample.java |    90 -
 .../compute/ComputeRunnableExample.java         |    75 -
 .../compute/ComputeScheduleExample.java         |    87 -
 .../examples/compute/ComputeTaskMapExample.java |   114 -
 .../compute/ComputeTaskSplitExample.java        |   103 -
 .../failover/ComputeFailoverExample.java        |   144 -
 .../failover/ComputeFailoverNodeStartup.java    |    78 -
 .../examples/compute/failover/package.html      |    23 -
 .../examples/compute/montecarlo/Credit.java     |   110 -
 .../compute/montecarlo/CreditRiskExample.java   |   154 -
 .../compute/montecarlo/CreditRiskManager.java   |   153 -
 .../examples/compute/montecarlo/package.html    |    24 -
 .../org/gridgain/examples/compute/package.html  |    23 -
 .../examples/datagrid/CacheAffinityExample.java |   139 -
 .../examples/datagrid/CacheApiExample.java      |   170 -
 .../datagrid/CacheContinuousQueryExample.java   |    98 -
 .../datagrid/CacheDataLoaderExample.java        |    82 -
 .../examples/datagrid/CacheEventsExample.java   |    96 -
 .../examples/datagrid/CacheNodeStartup.java     |    36 -
 .../datagrid/CachePopularNumbersExample.java    |   179 -
 .../examples/datagrid/CachePutGetExample.java   |   115 -
 .../examples/datagrid/CacheQueryExample.java    |   477 -
 .../datagrid/CacheTransactionExample.java       |   148 -
 .../datastructures/CacheAtomicLongExample.java  |    79 -
 .../CacheAtomicReferenceExample.java            |   127 -
 .../CacheAtomicSequenceExample.java             |   113 -
 .../CacheAtomicStampedExample.java              |   133 -
 .../CacheCountDownLatchExample.java             |   113 -
 .../datastructures/CacheQueueExample.java       |   215 -
 .../datastructures/CacheSetExample.java         |   194 -
 .../datagrid/datastructures/package.html        |    23 -
 .../hibernate/HibernateL2CacheExample.java      |   205 -
 .../HibernateL2CacheExampleNodeStartup.java     |    98 -
 .../examples/datagrid/hibernate/Post.java       |   126 -
 .../examples/datagrid/hibernate/User.java       |   151 -
 .../examples/datagrid/hibernate/package.html    |    23 -
 .../org/gridgain/examples/datagrid/package.html |    23 -
 .../starschema/CacheStarSchemaExample.java      |   228 -
 .../datagrid/starschema/DimProduct.java         |   101 -
 .../examples/datagrid/starschema/DimStore.java  |   101 -
 .../datagrid/starschema/FactPurchase.java       |   103 -
 .../examples/datagrid/starschema/package.html   |    24 -
 .../store/CacheNodeWithStoreStartup.java        |    89 -
 .../datagrid/store/CacheStoreExample.java       |    88 -
 .../store/CacheStoreLoadDataExample.java        |    77 -
 .../examples/datagrid/store/Person.java         |   103 -
 .../store/dummy/CacheDummyPersonStore.java      |   113 -
 .../examples/datagrid/store/dummy/package.html  |    24 -
 .../hibernate/CacheHibernatePersonStore.java    |   278 -
 .../datagrid/store/hibernate/Person.hbm.xml     |    32 -
 .../datagrid/store/hibernate/hibernate.cfg.xml  |    44 -
 .../datagrid/store/hibernate/package.html       |    24 -
 .../store/jdbc/CacheJdbcPersonStore.java        |   305 -
 .../examples/datagrid/store/jdbc/package.html   |    24 -
 .../examples/datagrid/store/package.html        |    24 -
 .../gridgain/examples/events/EventsExample.java |   145 -
 .../org/gridgain/examples/events/package.html   |    24 -
 .../org/gridgain/examples/ggfs/GgfsExample.java |   279 -
 .../examples/ggfs/GgfsMapReduceExample.java     |   250 -
 .../gridgain/examples/ggfs/GgfsNodeStartup.java |    42 -
 .../org/gridgain/examples/ggfs/package.html     |    23 -
 .../examples/messaging/MessagingExample.java    |   175 -
 .../messaging/MessagingPingPongExample.java     |   134 -
 .../MessagingPingPongListenActorExample.java    |   108 -
 .../gridgain/examples/messaging/package.html    |    24 -
 .../client/memcache/MemcacheRestExample.java    |   127 -
 .../MemcacheRestExampleNodeStartup.java         |    99 -
 .../examples/misc/client/memcache/package.html  |    23 -
 .../gridgain/examples/misc/client/package.html  |    24 -
 .../misc/deployment/DeploymentExample.java      |   130 -
 .../examples/misc/deployment/package.html       |    24 -
 .../misc/lifecycle/LifecycleExample.java        |    93 -
 .../examples/misc/lifecycle/package.html        |    24 -
 .../org/gridgain/examples/misc/package.html     |    24 -
 .../misc/springbean/SpringBeanExample.java      |    89 -
 .../examples/misc/springbean/package.html       |    24 -
 .../examples/misc/springbean/spring-bean.xml    |    73 -
 .../java/org/gridgain/examples/package.html     |    24 -
 .../examples/services/ServicesExample.java      |   161 -
 .../examples/services/SimpleMapService.java     |    49 -
 .../examples/services/SimpleMapServiceImpl.java |    71 -
 .../streaming/StreamingCheckInExample.java      |   583 -
 .../streaming/StreamingNodeStartup.java         |    36 -
 .../StreamingPopularNumbersExample.java         |   252 -
 .../streaming/StreamingPriceBarsExample.java    |   454 -
 .../StreamingRunningAverageExample.java         |   249 -
 .../gridgain/examples/streaming/package.html    |    24 -
 .../org/gridgain/examples/MessagingExample.java |     2 +-
 .../examples/ScalarCacheAffinityExample1.scala  |   123 +
 .../examples/ScalarCacheAffinityExample2.scala  |   115 +
 .../ScalarCacheAffinitySimpleExample.scala      |    83 +
 .../scalar/examples/ScalarCacheExample.scala    |   149 +
 .../ScalarCachePopularNumbersExample.scala      |   121 +
 .../examples/ScalarCacheQueryExample.scala      |   204 +
 .../scalar/examples/ScalarClosureExample.scala  |    97 +
 .../examples/ScalarContinuationExample.scala    |   159 +
 .../examples/ScalarCreditRiskExample.scala      |   245 +
 .../scalar/examples/ScalarJvmCloudExample.scala |    94 +
 .../examples/ScalarPiCalculationExample.scala   |    54 +
 .../scalar/examples/ScalarPingPongExample.scala |   156 +
 .../scalar/examples/ScalarPrimeExample.scala    |   132 +
 .../scalar/examples/ScalarScheduleExample.scala |    63 +
 .../examples/ScalarSnowflakeSchemaExample.scala |   292 +
 .../examples/ScalarStartStopExample.scala       |    73 +
 .../scalar/examples/ScalarTaskExample.scala     |    50 +
 .../examples/ScalarWorldShortestMapReduce.scala |    39 +
 .../examples/ScalarCacheAffinityExample1.scala  |   123 -
 .../examples/ScalarCacheAffinityExample2.scala  |   117 -
 .../ScalarCacheAffinitySimpleExample.scala      |    83 -
 .../scalar/examples/ScalarCacheExample.scala    |   149 -
 .../ScalarCachePopularNumbersExample.scala      |   120 -
 .../examples/ScalarCacheQueryExample.scala      |   203 -
 .../scalar/examples/ScalarClosureExample.scala  |    99 -
 .../examples/ScalarContinuationExample.scala    |   159 -
 .../examples/ScalarCreditRiskExample.scala      |   245 -
 .../scalar/examples/ScalarJvmCloudExample.scala |    94 -
 .../examples/ScalarPiCalculationExample.scala   |    54 -
 .../scalar/examples/ScalarPingPongExample.scala |   156 -
 .../scalar/examples/ScalarPrimeExample.scala    |   132 -
 .../scalar/examples/ScalarScheduleExample.scala |    63 -
 .../examples/ScalarSnowflakeSchemaExample.scala |   292 -
 .../examples/ScalarStartStopExample.scala       |    73 -
 .../scalar/examples/ScalarTaskExample.scala     |    50 -
 .../examples/ScalarWorldShortestMapReduce.scala |    39 -
 .../GridBasicExamplesMultiNodeSelfTest.java     |    28 +
 .../examples/GridBasicExamplesSelfTest.java     |    82 +
 .../GridCacheExamplesMultiNodeSelfTest.java     |    48 +
 .../examples/GridCacheExamplesSelfTest.java     |   155 +
 ...heStoreLoadDataExampleMultiNodeSelfTest.java |    39 +
 .../GridCheckpointExamplesSelfTest.java         |    45 +
 ...idContinuationExamplesMultiNodeSelfTest.java |    28 +
 .../GridContinuationExamplesSelfTest.java       |    33 +
 ...ntinuousMapperExamplesMultiNodeSelfTest.java |    28 +
 .../GridContinuousMapperExamplesSelfTest.java   |    33 +
 ...GridDeploymentExamplesMultiNodeSelfTest.java |    30 +
 .../GridDeploymentExamplesSelfTest.java         |    33 +
 .../GridEventsExamplesMultiNodeSelfTest.java    |    28 +
 .../examples/GridEventsExamplesSelfTest.java    |    33 +
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |    31 +
 .../GridHibernateL2CacheExampleSelfTest.java    |    33 +
 .../examples/GridLifecycleExamplesSelfTest.java |    33 +
 ...idMemcacheRestExamplesMultiNodeSelfTest.java |    31 +
 .../GridMemcacheRestExamplesSelfTest.java       |    41 +
 .../examples/GridMessagingExamplesSelfTest.java |    52 +
 ...GridMonteCarloExamplesMultiNodeSelfTest.java |    28 +
 .../GridMonteCarloExamplesSelfTest.java         |    74 +
 .../examples/GridProjectionExampleSelfTest.java |    39 +
 .../GridSpringBeanExamplesSelfTest.java         |    33 +
 .../GridTaskExamplesMultiNodeSelfTest.java      |    28 +
 .../examples/GridTaskExamplesSelfTest.java      |    40 +
 .../examples/IgniteFsExamplesSelfTest.java      |    67 +
 .../testsuites/IgniteExamplesSelfTestSuite.java |    74 +
 .../GridBasicExamplesMultiNodeSelfTest.java     |    28 -
 .../examples/GridBasicExamplesSelfTest.java     |    82 -
 .../GridCacheExamplesMultiNodeSelfTest.java     |    48 -
 .../examples/GridCacheExamplesSelfTest.java     |   155 -
 ...heStoreLoadDataExampleMultiNodeSelfTest.java |    39 -
 .../GridCheckpointExamplesSelfTest.java         |    45 -
 ...idContinuationExamplesMultiNodeSelfTest.java |    28 -
 .../GridContinuationExamplesSelfTest.java       |    33 -
 ...ntinuousMapperExamplesMultiNodeSelfTest.java |    28 -
 .../GridContinuousMapperExamplesSelfTest.java   |    33 -
 ...GridDeploymentExamplesMultiNodeSelfTest.java |    30 -
 .../GridDeploymentExamplesSelfTest.java         |    33 -
 .../GridEventsExamplesMultiNodeSelfTest.java    |    28 -
 .../examples/GridEventsExamplesSelfTest.java    |    33 -
 .../examples/GridGgfsExamplesSelfTest.java      |    67 -
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |    31 -
 .../GridHibernateL2CacheExampleSelfTest.java    |    33 -
 .../examples/GridLifecycleExamplesSelfTest.java |    33 -
 ...idMemcacheRestExamplesMultiNodeSelfTest.java |    31 -
 .../GridMemcacheRestExamplesSelfTest.java       |    41 -
 .../examples/GridMessagingExamplesSelfTest.java |    52 -
 ...GridMonteCarloExamplesMultiNodeSelfTest.java |    28 -
 .../GridMonteCarloExamplesSelfTest.java         |    74 -
 .../examples/GridProjectionExampleSelfTest.java |    39 -
 .../GridSpringBeanExamplesSelfTest.java         |    33 -
 .../GridTaskExamplesMultiNodeSelfTest.java      |    28 -
 .../examples/GridTaskExamplesSelfTest.java      |    40 -
 .../testsuites/GridExamplesSelfTestSuite.java   |    74 -
 .../ScalarExamplesMultiNodeSelfTest.scala       |    33 +
 .../tests/examples/ScalarExamplesSelfTest.scala |   119 +
 .../ScalarExamplesSelfTestSuite.scala           |    38 +
 .../ScalarExamplesMultiNodeSelfTest.scala       |    33 -
 .../tests/examples/ScalarExamplesSelfTest.scala |   118 -
 .../ScalarExamplesSelfTestSuite.scala           |    39 -
 .../aop/aspectj/GridifyAspectJAspect.java       |   123 +
 .../aspectj/GridifySetToSetAspectJAspect.java   |   134 +
 .../aspectj/GridifySetToValueAspectJAspect.java |   134 +
 .../compute/gridify/aop/aspectj/package.html    |    24 +
 .../aop/spring/GridifySetToSetSpringAspect.java |   129 +
 .../spring/GridifySetToValueSpringAspect.java   |   129 +
 .../gridify/aop/spring/GridifySpringAspect.java |   118 +
 .../aop/spring/GridifySpringEnhancer.java       |    81 +
 .../aop/spring/GridifySpringPointcut.java       |   136 +
 .../compute/gridify/aop/spring/package.html     |    23 +
 .../aop/aspectj/GridifyAspectJAspect.java       |   124 -
 .../aspectj/GridifySetToSetAspectJAspect.java   |   135 -
 .../aspectj/GridifySetToValueAspectJAspect.java |   135 -
 .../compute/gridify/aop/aspectj/package.html    |    24 -
 .../aop/spring/GridifySetToSetSpringAspect.java |   130 -
 .../spring/GridifySetToValueSpringAspect.java   |   130 -
 .../gridify/aop/spring/GridifySpringAspect.java |   119 -
 .../aop/spring/GridifySpringEnhancer.java       |    82 -
 .../aop/spring/GridifySpringPointcut.java       |   136 -
 .../compute/gridify/aop/spring/package.html     |    23 -
 .../test/config/aop/aspectj/META-INF/aop.xml    |     8 +-
 .../apache/ignite/gridify/AbstractAopTest.java  |   734 +
 .../apache/ignite/gridify/BasicAopSelfTest.java |    77 +
 .../ignite/gridify/GridifySetToSetTarget.java   |   372 +
 .../gridify/GridifySetToSetTargetInterface.java |   109 +
 .../ignite/gridify/GridifySetToValueTarget.java |   199 +
 .../GridifySetToValueTargetInterface.java       |   100 +
 .../GridifySetToXXXNonSpringAopSelfTest.java    |   203 +
 .../GridifySetToXXXSpringAopSelfTest.java       |   204 +
 .../ignite/gridify/NonSpringAopSelfTest.java    |    57 +
 .../ignite/gridify/SpringAopSelfTest.java       |    52 +
 .../apache/ignite/gridify/TestAopTarget.java    |   138 +
 .../ignite/gridify/TestAopTargetInterface.java  |    87 +
 .../ignite/gridify/TestGridifyException.java    |    38 +
 .../apache/ignite/gridify/TestGridifyJob.java   |    67 +
 .../apache/ignite/gridify/TestGridifyTask.java  |    47 +
 .../gridify/hierarchy/GridifyHierarchyTest.java |    51 +
 .../ignite/gridify/hierarchy/SuperTarget.java   |    53 +
 .../apache/ignite/gridify/hierarchy/Target.java |    45 +
 .../ignite/gridify/hierarchy/package.html       |    23 +
 .../java/org/apache/ignite/gridify/package.html |    23 +
 .../ignite/gridify/test_resource.properties     |    18 +
 .../optimized/OptimizedMarshallerAopTest.java   |   104 +
 .../apache/ignite/p2p/P2PGridifySelfTest.java   |   241 +
 .../testsuites/IgniteAopSelfTestSuite.java      |    52 +
 .../singlesplit/SingleSplitTestJobTarget.java   |    46 +
 .../direct/singlesplit/SingleSplitTestTask.java |    94 +
 .../singlesplit/SingleSplitsLoadTest.java       |   135 +
 .../loadtests/direct/singlesplit/package.html   |    24 +
 .../gridify/GridifyLoadTestJobTarget.java       |    37 +
 .../loadtests/gridify/GridifyLoadTestTask.java  |    70 +
 .../gridify/GridifySingleSplitLoadTest.java     |   157 +
 .../grid/gridify/GridAbstractAopTest.java       |   734 -
 .../grid/gridify/GridBasicAopSelfTest.java      |    77 -
 .../grid/gridify/GridNonSpringAopSelfTest.java  |    57 -
 .../grid/gridify/GridSpringAopSelfTest.java     |    52 -
 .../grid/gridify/GridTestAopTarget.java         |   138 -
 .../gridify/GridTestAopTargetInterface.java     |    87 -
 .../grid/gridify/GridTestGridifyException.java  |    38 -
 .../grid/gridify/GridTestGridifyJob.java        |    68 -
 .../grid/gridify/GridTestGridifyTask.java       |    47 -
 .../grid/gridify/GridifySetToSetTarget.java     |   372 -
 .../gridify/GridifySetToSetTargetInterface.java |   109 -
 .../grid/gridify/GridifySetToValueTarget.java   |   199 -
 .../GridifySetToValueTargetInterface.java       |   100 -
 .../GridifySetToXXXNonSpringAopSelfTest.java    |   203 -
 .../GridifySetToXXXSpringAopSelfTest.java       |   204 -
 .../grid/gridify/hierarchy/GridSuperTarget.java |    53 -
 .../grid/gridify/hierarchy/GridTarget.java      |    45 -
 .../gridify/hierarchy/GridifyHierarchyTest.java |    51 -
 .../grid/gridify/hierarchy/package.html         |    23 -
 .../java/org/gridgain/grid/gridify/package.html |    23 -
 .../grid/gridify/test_resource.properties       |    18 -
 .../GridOptimizedMarshallerAopTest.java         |   105 -
 .../grid/p2p/GridP2PGridifySelfTest.java        |   241 -
 .../GridSingleSplitTestJobTarget.java           |    46 -
 .../singlesplit/GridSingleSplitTestTask.java    |    94 -
 .../singlesplit/GridSingleSplitsLoadTest.java   |   136 -
 .../loadtests/direct/singlesplit/package.html   |    24 -
 .../gridify/GridifyLoadTestJobTarget.java       |    37 -
 .../loadtests/gridify/GridifyLoadTestTask.java  |    70 -
 .../gridify/GridifySingleSplitLoadTest.java     |   157 -
 .../testsuites/GridAopSelfTestSuite.java        |    52 -
 .../org/test/gridify/ExternalAopTarget.java     |   134 +
 .../test/gridify/ExternalGridifyException.java  |    38 +
 .../org/test/gridify/ExternalGridifyTask.java   |    79 +
 .../gridify/ExternalNonSpringAopSelfTest.java   |   539 +
 .../org/test/gridify/GridExternalAopTarget.java |   134 -
 .../gridify/GridExternalGridifyException.java   |    38 -
 .../test/gridify/GridExternalGridifyTask.java   |    80 -
 .../GridExternalNonSpringAopSelfTest.java       |   539 -
 .../spi/checkpoint/s3/GridS3CheckpointData.java |    90 -
 .../spi/checkpoint/s3/GridS3CheckpointSpi.java  |   679 -
 .../checkpoint/s3/GridS3CheckpointSpiMBean.java |    59 -
 .../spi/checkpoint/s3/GridS3TimeData.java       |    79 -
 .../spi/checkpoint/s3/S3CheckpointData.java     |    90 +
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |   678 +
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java |    59 +
 .../ignite/spi/checkpoint/s3/S3TimeData.java    |    79 +
 .../ipfinder/s3/GridTcpDiscoveryS3IpFinder.java |   320 -
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   319 +
 .../s3/GridS3CheckpointManagerSelfTest.java     |    66 -
 .../s3/GridS3CheckpointSpiConfigSelfTest.java   |    33 -
 .../s3/GridS3CheckpointSpiSelfTest.java         |   215 -
 .../GridS3CheckpointSpiStartStopSelfTest.java   |    41 -
 .../s3/GridS3SessionCheckpointSelfTest.java     |    50 -
 .../s3/S3CheckpointManagerSelfTest.java         |    66 +
 .../s3/S3CheckpointSpiConfigSelfTest.java       |    33 +
 .../checkpoint/s3/S3CheckpointSpiSelfTest.java  |   214 +
 .../s3/S3CheckpointSpiStartStopSelfTest.java    |    41 +
 .../s3/S3SessionCheckpointSelfTest.java         |    50 +
 .../s3/GridTcpDiscoveryS3IpFinderSelfTest.java  |    72 -
 .../s3/TcpDiscoveryS3IpFinderSelfTest.java      |    72 +
 .../ignite/testsuites/IgniteS3TestSuite.java    |    69 +
 .../testsuites/bamboo/GridS3TestSuite.java      |    69 -
 .../config/grid-client-spring-config.xml        |     6 +-
 .../ClientAbstractMultiThreadedSelfTest.java    |   617 +
 .../client/ClientDefaultCacheSelfTest.java      |   156 +
 .../ignite/client/ClientGetAffinityTask.java    |    64 +
 .../apache/ignite/client/ClientHttpTask.java    |    59 +
 .../apache/ignite/client/ClientNodeStartup.java |    57 +
 .../client/ClientPortableArgumentTask.java      |    53 +
 .../ignite/client/ClientPutPortableTask.java    |    44 +
 .../client/ClientReconnectionSelfTest.java      |   235 +
 .../ignite/client/ClientSslNodeStartup.java     |    59 +
 .../ignite/client/ClientStartNodeTask.java      |   180 +
 .../ignite/client/ClientStopNodeTask.java       |   127 +
 .../ignite/client/ClientStringLengthTask.java   |    73 +
 .../client/ClientTcpMultiThreadedSelfTest.java  |    45 +
 .../ClientTcpSslAuthenticationSelfTest.java     |   265 +
 .../ClientTcpSslMultiThreadedSelfTest.java      |    46 +
 .../org/apache/ignite/client/ClientTcpTask.java |    73 +
 ...skExecutionAfterTopologyRestartSelfTest.java |    75 +
 .../ignite/client/ClientTestPortable.java       |   490 +
 .../ClientTestPortableAffinityKeyTask.java      |    85 +
 .../ignite/client/ClientTestRestServer.java     |   275 +
 .../client/ClientTopologyCacheSelfTest.java     |   289 +
 .../org/apache/ignite/client/HashMapStore.java  |    53 +
 .../org/apache/ignite/client/SleepTestTask.java |    68 +
 .../client/TaskSingleJobSplitAdapter.java       |    75 +
 .../client/impl/ClientCacheFlagsCodecTest.java  |    83 +
 .../client/impl/ClientComputeImplSelfTest.java  |   167 +
 .../client/impl/ClientDataImplSelfTest.java     |   268 +
 .../impl/ClientFutureAdapterSelfTest.java       |   115 +
 .../impl/ClientPartitionAffinitySelfTest.java   |   406 +
 .../ClientPropertiesConfigurationSelfTest.java  |   232 +
 .../ClientAbstractConnectivitySelfTest.java     |   303 +
 .../ClientAbstractMultiNodeSelfTest.java        |   856 ++
 .../integration/ClientAbstractSelfTest.java     |  1598 ++
 .../integration/ClientPreferDirectSelfTest.java |   193 +
 .../ClientTcpConnectivitySelfTest.java          |    75 +
 .../ClientTcpDirectMultiNodeSelfTest.java       |    55 +
 .../integration/ClientTcpDirectSelfTest.java    |    58 +
 .../integration/ClientTcpMultiNodeSelfTest.java |    35 +
 .../client/integration/ClientTcpSelfTest.java   |    46 +
 .../ClientTcpSslDirectMultiNodeSelfTest.java    |    62 +
 .../integration/ClientTcpSslDirectSelfTest.java |    59 +
 .../ClientTcpSslMultiNodeSelfTest.java          |    42 +
 .../integration/ClientTcpSslSelfTest.java       |    47 +
 .../ClientTcpUnreachableMultiNodeSelfTest.java  |   146 +
 .../ignite/client/integration/package.html      |    24 +
 .../client/router/ClientFailedInitSelfTest.java |   275 +
 .../client/router/RouterFactorySelfTest.java    |   107 +
 .../router/TcpRouterAbstractSelfTest.java       |   125 +
 .../router/TcpRouterMultiNodeSelfTest.java      |   110 +
 .../ignite/client/router/TcpRouterSelfTest.java |    35 +
 .../client/router/TcpSslRouterSelfTest.java     |    48 +
 .../apache/ignite/client/router/package.html    |    24 +
 .../testsuites/IgniteRouterTestSuite.java       |    41 +
 .../client/suite/IgniteClientTestSuite.java     |   118 +
 .../ignite/client/util/ClientByteUtilsTest.java |   172 +
 .../util/ClientConsistentHashSelfTest.java      |   281 +
 .../client/util/ClientJavaHasherSelfTest.java   |    84 +
 .../internal/TaskEventSubjectIdSelfTest.java    |   392 +
 .../rest/AbstractRestProcessorSelfTest.java     |    95 +
 .../rest/ClientMemcachedProtocolSelfTest.java   |   443 +
 .../JettyRestProcessorAbstractSelfTest.java     |   724 +
 .../rest/JettyRestProcessorSignedSelfTest.java  |   103 +
 .../JettyRestProcessorUnsignedSelfTest.java     |    36 +
 .../rest/MemcacheRestProcessorTest.java         |    76 +
 .../rest/RestBinaryProtocolSelfTest.java        |   633 +
 .../rest/RestMemcacheProtocolSelfTest.java      |   331 +
 .../rest/RestProcessorMultiStartSelfTest.java   |    55 +
 .../rest/RestProcessorStartSelfTest.java        |   163 +
 .../processors/rest/RestProcessorTest.java      |   346 +
 .../rest/TaskCommandHandlerSelfTest.java        |   211 +
 .../processors/rest/TestBinaryClient.java       |   651 +
 .../processors/rest/TestMemcacheClient.java     |   898 ++
 .../internal/processors/rest/TestTask1.java     |    52 +
 .../internal/processors/rest/TestTask2.java     |    54 +
 .../rest/protocols/tcp/MockNioSession.java      |   155 +
 .../protocols/tcp/TcpRestParserSelfTest.java    |   451 +
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java   |   316 +
 .../ignite/jdbc/JdbcConnectionSelfTest.java     |   219 +
 .../ignite/jdbc/JdbcEmptyCacheSelfTest.java     |   136 +
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java    |   158 +
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |   336 +
 .../jdbc/JdbcPreparedStatementSelfTest.java     |   726 +
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |   715 +
 .../ignite/jdbc/JdbcStatementSelfTest.java      |   286 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    45 +
 .../loadtests/client/ClientCacheBenchmark.java  |   259 +
 .../client/ClientMarshallerBenchmarkTest.java   |   156 +
 .../loadtests/client/ClientTcpSslLoadTest.java  |    83 +
 ...GridClientAbstractMultiThreadedSelfTest.java |   617 -
 .../client/GridClientDefaultCacheSelfTest.java  |   157 -
 .../client/GridClientGetAffinityTask.java       |    65 -
 .../org/gridgain/client/GridClientHttpTask.java |    59 -
 .../gridgain/client/GridClientNodeStartup.java  |    58 -
 .../client/GridClientPortableArgumentTask.java  |    53 -
 .../client/GridClientPutPortableTask.java       |    45 -
 .../client/GridClientReconnectionSelfTest.java  |   235 -
 .../client/GridClientSslNodeStartup.java        |    60 -
 .../client/GridClientStartNodeTask.java         |   181 -
 .../gridgain/client/GridClientStopNodeTask.java |   128 -
 .../client/GridClientStringLengthTask.java      |    73 -
 .../GridClientTcpMultiThreadedSelfTest.java     |    45 -
 .../GridClientTcpSslAuthenticationSelfTest.java |   265 -
 .../GridClientTcpSslMultiThreadedSelfTest.java  |    46 -
 .../org/gridgain/client/GridClientTcpTask.java  |    73 -
 ...skExecutionAfterTopologyRestartSelfTest.java |    75 -
 .../gridgain/client/GridClientTestPortable.java |   490 -
 .../GridClientTestPortableAffinityKeyTask.java  |    86 -
 .../client/GridClientTestRestServer.java        |   276 -
 .../client/GridClientTopologyCacheSelfTest.java |   289 -
 .../org/gridgain/client/GridHashMapStore.java   |    53 -
 .../org/gridgain/client/GridSleepTestTask.java  |    68 -
 .../client/GridTaskSingleJobSplitAdapter.java   |    75 -
 .../impl/GridClientCacheFlagsCodecTest.java     |    83 -
 .../impl/GridClientComputeImplSelfTest.java     |   167 -
 .../client/impl/GridClientDataImplSelfTest.java |   268 -
 .../impl/GridClientFutureAdapterSelfTest.java   |   115 -
 .../GridClientPartitionAffinitySelfTest.java    |   406 -
 ...idClientPropertiesConfigurationSelfTest.java |   232 -
 .../GridClientAbstractConnectivitySelfTest.java |   303 -
 .../GridClientAbstractMultiNodeSelfTest.java    |   857 --
 .../integration/GridClientAbstractSelfTest.java |  1599 --
 .../GridClientPreferDirectSelfTest.java         |   194 -
 .../GridClientTcpConnectivitySelfTest.java      |    75 -
 .../GridClientTcpDirectMultiNodeSelfTest.java   |    55 -
 .../GridClientTcpDirectSelfTest.java            |    58 -
 .../GridClientTcpMultiNodeSelfTest.java         |    35 -
 .../integration/GridClientTcpSelfTest.java      |    46 -
 ...GridClientTcpSslDirectMultiNodeSelfTest.java |    62 -
 .../GridClientTcpSslDirectSelfTest.java         |    59 -
 .../GridClientTcpSslMultiNodeSelfTest.java      |    42 -
 .../integration/GridClientTcpSslSelfTest.java   |    47 -
 ...idClientTcpUnreachableMultiNodeSelfTest.java |   146 -
 .../gridgain/client/integration/package.html    |    24 -
 .../router/GridClientFailedInitSelfTest.java    |   276 -
 .../router/GridRouterFactorySelfTest.java       |   107 -
 .../router/GridTcpRouterAbstractSelfTest.java   |   125 -
 .../router/GridTcpRouterMultiNodeSelfTest.java  |   110 -
 .../client/router/GridTcpRouterSelfTest.java    |    35 -
 .../client/router/GridTcpSslRouterSelfTest.java |    49 -
 .../org/gridgain/client/router/package.html     |    24 -
 .../router/testsuites/GridRouterTestSuite.java  |    41 -
 .../client/suite/GridClientTestSuite.java       |   118 -
 .../client/util/GridClientByteUtilsTest.java    |   172 -
 .../util/GridClientConsistentHashSelfTest.java  |   281 -
 .../util/GridClientJavaHasherSelfTest.java      |    84 -
 .../kernal/GridTaskEventSubjectIdSelfTest.java  |   393 -
 .../rest/GridAbstractRestProcessorSelfTest.java |    96 -
 .../GridClientMemcachedProtocolSelfTest.java    |   443 -
 .../GridJettyRestProcessorAbstractSelfTest.java |   724 -
 .../GridJettyRestProcessorSignedSelfTest.java   |   103 -
 .../GridJettyRestProcessorUnsignedSelfTest.java |    36 -
 .../rest/GridMemcacheRestProcessorTest.java     |    76 -
 .../rest/GridRestBinaryProtocolSelfTest.java    |   633 -
 .../rest/GridRestMemcacheProtocolSelfTest.java  |   331 -
 .../GridRestProcessorMultiStartSelfTest.java    |    55 -
 .../rest/GridRestProcessorStartSelfTest.java    |   163 -
 .../processors/rest/GridRestProcessorTest.java  |   346 -
 .../rest/GridTaskCommandHandlerSelfTest.java    |   211 -
 .../processors/rest/GridTestBinaryClient.java   |   652 -
 .../processors/rest/GridTestMemcacheClient.java |   899 --
 .../grid/kernal/processors/rest/TestTask1.java  |    52 -
 .../grid/kernal/processors/rest/TestTask2.java  |    54 -
 .../rest/protocols/tcp/GridMockNioSession.java  |   155 -
 .../tcp/GridTcpRestParserSelfTest.java          |   451 -
 .../jdbc/GridJdbcComplexQuerySelfTest.java      |   317 -
 .../jdbc/GridJdbcConnectionSelfTest.java        |   219 -
 .../jdbc/GridJdbcEmptyCacheSelfTest.java        |   136 -
 .../jdbc/GridJdbcLocalCachesSelfTest.java       |   159 -
 .../gridgain/jdbc/GridJdbcMetadataSelfTest.java |   337 -
 .../jdbc/GridJdbcPreparedStatementSelfTest.java |   727 -
 .../jdbc/GridJdbcResultSetSelfTest.java         |   716 -
 .../jdbc/GridJdbcStatementSelfTest.java         |   287 -
 .../jdbc/suite/GridJdbcDriverTestSuite.java     |    45 -
 .../client/GridClientCacheBenchmark.java        |   259 -
 .../GridClientMarshallerBenchmarkTest.java      |   156 -
 .../client/GridClientTcpSslLoadTest.java        |    83 -
 .../clients/src/test/resources/spring-cache.xml |     4 +-
 .../src/test/resources/spring-router-ssl.xml    |     4 +-
 .../src/test/resources/spring-router.xml        |     2 +-
 .../src/test/resources/spring-server-node.xml   |    20 +-
 .../test/resources/spring-server-ssl-node.xml   |    16 +-
 .../src/main/java/org/apache/ignite/Ignite.java |     9 +-
 .../ignite/IgniteAuthenticationException.java   |    35 +
 .../apache/ignite/IgniteBasicWarmupClosure.java |   560 +
 .../java/org/apache/ignite/IgniteCache.java     |    39 +-
 .../org/apache/ignite/IgniteCacheManager.java   |     2 +-
 .../apache/ignite/IgniteCachingProvider.java    |     4 +-
 .../apache/ignite/IgniteCheckedException.java   |     4 +-
 .../java/org/apache/ignite/IgniteCluster.java   |     8 +-
 .../org/apache/ignite/IgniteDataLoader.java     |    32 +-
 .../ignite/IgniteDeploymentException.java       |    57 +
 .../java/org/apache/ignite/IgniteEvents.java    |     1 -
 .../java/org/apache/ignite/IgniteException.java |     4 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |     5 +-
 .../ignite/IgniteIllegalStateException.java     |    84 +
 .../ignite/IgniteInterruptedException.java      |    56 +
 .../java/org/apache/ignite/IgniteLogger.java    |     2 +-
 .../java/org/apache/ignite/IgniteMessaging.java |     1 -
 .../apache/ignite/IgniteNotPeerDeployable.java  |    41 +
 .../java/org/apache/ignite/IgnitePortables.java |    16 +-
 .../java/org/apache/ignite/IgniteStreamer.java  |     1 -
 .../org/apache/ignite/IgniteTransactions.java   |    11 +-
 .../main/java/org/apache/ignite/Ignition.java   |    15 +-
 .../CacheAtomicUpdateTimeoutException.java      |    47 +
 .../ignite/cache/CacheAtomicWriteOrderMode.java |    64 +
 .../apache/ignite/cache/CacheAtomicityMode.java |    79 +
 .../apache/ignite/cache/CacheConfiguration.java |   177 +-
 .../ignite/cache/CacheDistributionMode.java     |    69 +
 .../org/apache/ignite/cache/CacheEntry.java     |   621 +
 .../apache/ignite/cache/CacheEntryEvent.java    |     6 +-
 .../apache/ignite/cache/CacheInterceptor.java   |   120 +
 .../ignite/cache/CacheInterceptorAdapter.java   |    52 +
 .../org/apache/ignite/cache/CacheMBean.java     |   295 +
 .../apache/ignite/cache/CacheMemoryMode.java    |    59 +
 .../org/apache/ignite/cache/CacheMetrics.java   |   103 +
 .../java/org/apache/ignite/cache/CacheMode.java |    73 +
 .../java/org/apache/ignite/cache/CacheName.java |    41 +
 .../cache/CachePartialUpdateException.java      |     6 +-
 .../org/apache/ignite/cache/CachePeekMode.java  |     8 +-
 .../apache/ignite/cache/CachePreloadMode.java   |    67 +
 .../apache/ignite/cache/CacheProjection.java    |  1913 +++
 .../cache/CacheWriteSynchronizationMode.java    |    69 +
 .../java/org/apache/ignite/cache/GridCache.java |   278 +
 .../cache/GridCachePartialUpdateException.java  |    64 +
 .../apache/ignite/cache/GridCachePeekMode.java  |    85 +
 .../ignite/cache/affinity/CacheAffinity.java    |   262 +
 .../cache/affinity/CacheAffinityFunction.java   |   111 +
 .../affinity/CacheAffinityFunctionContext.java  |    71 +
 .../ignite/cache/affinity/CacheAffinityKey.java |   189 +
 .../cache/affinity/CacheAffinityKeyMapped.java  |   156 +
 .../cache/affinity/CacheAffinityKeyMapper.java  |    64 +
 .../CacheAffinityNodeAddressHashResolver.java   |    39 +
 .../affinity/CacheAffinityNodeHashResolver.java |    43 +
 .../CacheAffinityNodeIdHashResolver.java        |    40 +
 .../CacheCentralizedAffinityFunction.java       |    31 +
 .../CacheConsistentHashAffinityFunction.java    |   702 +
 .../cache/affinity/consistenthash/package.html  |    24 +
 .../fair/CachePartitionFairAffinity.java        |   805 +
 .../ignite/cache/affinity/fair/package.html     |    24 +
 .../apache/ignite/cache/affinity/package.html   |    24 +
 .../CacheRendezvousAffinityFunction.java        |   502 +
 .../cache/affinity/rendezvous/package.html      |    23 +
 .../ignite/cache/cloner/CacheBasicCloner.java   |    34 +
 .../apache/ignite/cache/cloner/CacheCloner.java |    58 +
 .../ignite/cache/cloner/CacheDeepCloner.java    |    87 +
 .../org/apache/ignite/cache/cloner/package.html |    24 +
 .../cache/datastructures/CacheAtomicLong.java   |   157 +
 .../datastructures/CacheAtomicReference.java    |    93 +
 .../datastructures/CacheAtomicSequence.java     |   130 +
 .../datastructures/CacheAtomicStamped.java      |   121 +
 .../datastructures/CacheCountDownLatch.java     |   226 +
 .../CacheDataStructureInvalidException.java     |    66 +
 ...cheDataStructureInvalidRuntimeException.java |    66 +
 .../CacheDataStructureRemovedException.java     |    61 +
 ...cheDataStructureRemovedRuntimeException.java |    61 +
 .../datastructures/CacheDataStructures.java     |   220 +
 .../ignite/cache/datastructures/CacheQueue.java |   182 +
 .../ignite/cache/datastructures/CacheSet.java   |    61 +
 .../ignite/cache/datastructures/package.html    |    24 +
 .../cache/eviction/CacheEvictionFilter.java     |    40 +
 .../cache/eviction/CacheEvictionPolicy.java     |    53 +
 .../ignite/cache/eviction/EvictableEntry.java   |     2 +-
 .../eviction/fifo/CacheFifoEvictionPolicy.java  |   207 +
 .../fifo/CacheFifoEvictionPolicyMBean.java      |    58 +
 .../ignite/cache/eviction/fifo/package.html     |    23 +
 .../eviction/ggfs/CacheGgfsEvictionFilter.java  |    34 +
 .../CacheGgfsPerBlockLruEvictionPolicy.java     |   353 +
 ...CacheGgfsPerBlockLruEvictionPolicyMBean.java |    93 +
 .../ignite/cache/eviction/ggfs/package.html     |    23 +
 .../eviction/lru/CacheLruEvictionPolicy.java    |   193 +
 .../lru/CacheLruEvictionPolicyMBean.java        |    58 +
 .../ignite/cache/eviction/lru/package.html      |    23 +
 .../apache/ignite/cache/eviction/package.html   |    23 +
 .../random/CacheRandomEvictionPolicy.java       |   118 +
 .../random/CacheRandomEvictionPolicyMBean.java  |    42 +
 .../ignite/cache/eviction/random/package.html   |    23 +
 .../java/org/apache/ignite/cache/package.html   |    24 +
 .../cache/query/CacheContinuousQuery.java       |   341 +
 .../cache/query/CacheContinuousQueryEntry.java  |    49 +
 .../apache/ignite/cache/query/CacheQueries.java |   151 +
 .../apache/ignite/cache/query/CacheQuery.java   |   295 +
 .../cache/query/CacheQueryConfiguration.java    |   203 +
 .../ignite/cache/query/CacheQueryFuture.java    |    66 +
 .../cache/query/CacheQueryGroupIndex.java       |    58 +
 .../ignite/cache/query/CacheQueryMetrics.java   |    60 +
 .../ignite/cache/query/CacheQuerySqlField.java  |   133 +
 .../cache/query/CacheQuerySqlFunction.java      |    69 +
 .../ignite/cache/query/CacheQueryTextField.java |    33 +
 .../ignite/cache/query/CacheQueryType.java      |    47 +
 .../cache/query/CacheQueryTypeMetadata.java     |   196 +
 .../cache/query/CacheQueryTypeResolver.java     |    32 +
 .../cache/query/QueryAffinityPredicate.java     |     2 +-
 .../cache/query/QueryContinuousPredicate.java   |     8 +-
 .../ignite/cache/query/QueryPredicate.java      |     2 +-
 .../ignite/cache/query/QuerySqlPredicate.java   |     2 +-
 .../ignite/cache/query/QueryTextPredicate.java  |     2 +-
 .../cache/query/annotations/QuerySqlField.java  |     4 +-
 .../query/annotations/QuerySqlFunction.java     |     2 +-
 .../cache/query/annotations/QueryTextField.java |     4 +-
 .../org/apache/ignite/cache/query/package.html  |    23 +
 .../cache/store/CacheLoadOnlyStoreAdapter.java  |     9 +-
 .../apache/ignite/cache/store/CacheStore.java   |     5 +-
 .../ignite/cache/store/CacheStoreAdapter.java   |     3 +-
 .../cache/store/CacheStoreBalancingWrapper.java |     5 +-
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |    10 +-
 .../org/apache/ignite/client/GridClient.java    |   148 +
 .../GridClientAuthenticationException.java      |    35 +
 .../ignite/client/GridClientCacheFlag.java      |    65 +
 .../ignite/client/GridClientCacheMode.java      |    32 +
 .../client/GridClientClosedException.java       |    35 +
 .../apache/ignite/client/GridClientCompute.java |   476 +
 .../ignite/client/GridClientConfiguration.java  |   868 ++
 .../apache/ignite/client/GridClientData.java    |   443 +
 .../ignite/client/GridClientDataAffinity.java   |    39 +
 .../client/GridClientDataConfiguration.java     |   118 +
 .../ignite/client/GridClientDataMetrics.java    |    77 +
 .../client/GridClientDisconnectedException.java |    36 +
 .../ignite/client/GridClientException.java      |   111 +
 .../apache/ignite/client/GridClientFactory.java |   138 +
 .../apache/ignite/client/GridClientFuture.java  |    68 +
 .../ignite/client/GridClientFutureListener.java |    30 +
 .../GridClientFutureTimeoutException.java       |    45 +
 .../client/GridClientHandshakeException.java    |    48 +
 .../apache/ignite/client/GridClientNode.java    |   152 +
 .../ignite/client/GridClientNodeMetrics.java    |   524 +
 .../client/GridClientPartitionAffinity.java     |   369 +
 .../ignite/client/GridClientPredicate.java      |    38 +
 .../ignite/client/GridClientProtocol.java       |    30 +
 .../client/GridClientTopologyListener.java      |    41 +
 .../client/GridServerUnreachableException.java  |    45 +
 .../balancer/GridClientBalancerAdapter.java     |    76 +
 .../client/balancer/GridClientLoadBalancer.java |    44 +
 .../balancer/GridClientRandomBalancer.java      |    75 +
 .../balancer/GridClientRoundRobinBalancer.java  |   111 +
 .../apache/ignite/client/balancer/package.html  |    24 +
 .../impl/GridClientAbstractProjection.java      |   458 +
 .../client/impl/GridClientAndPredicate.java     |    52 +
 .../client/impl/GridClientComputeImpl.java      |   293 +
 .../ignite/client/impl/GridClientDataImpl.java  |   389 +
 .../impl/GridClientDataMetricsAdapter.java      |   160 +
 .../client/impl/GridClientFutureAdapter.java    |   349 +
 .../client/impl/GridClientFutureCallback.java   |    35 +
 .../ignite/client/impl/GridClientImpl.java      |   524 +
 .../ignite/client/impl/GridClientNodeImpl.java  |   411 +
 .../impl/GridClientNodeMetricsAdapter.java      |   990 ++
 .../client/impl/GridClientThreadFactory.java    |    62 +
 .../impl/connection/GridClientConnection.java   |   531 +
 .../GridClientConnectionCloseReason.java        |    32 +
 .../connection/GridClientConnectionManager.java |    71 +
 .../GridClientConnectionManagerAdapter.java     |   763 +
 .../GridClientConnectionManagerOsImpl.java      |    47 +
 .../GridClientConnectionResetException.java     |    48 +
 .../connection/GridClientNioTcpConnection.java  |  1159 ++
 .../impl/connection/GridClientTopology.java     |   450 +
 .../GridConnectionIdleClosedException.java      |    36 +
 .../org/apache/ignite/client/impl/package.html  |    23 +
 .../client/marshaller/GridClientMarshaller.java |    45 +
 .../marshaller/jdk/GridClientJdkMarshaller.java |    68 +
 .../ignite/client/marshaller/jdk/package.html   |    24 +
 .../GridClientOptimizedMarshaller.java          |   103 +
 .../client/marshaller/optimized/package.html    |    24 +
 .../ignite/client/marshaller/package.html       |    23 +
 .../java/org/apache/ignite/client/package.html  |    23 +
 .../ignite/client/router/GridRouterFactory.java |   121 +
 .../ignite/client/router/GridTcpRouter.java     |    76 +
 .../router/GridTcpRouterConfiguration.java      |   306 +
 .../client/router/GridTcpRouterMBean.java       |    88 +
 .../router/impl/GridRouterClientImpl.java       |   200 +
 .../impl/GridRouterCommandLineStartup.java      |   164 +
 .../client/router/impl/GridTcpRouterImpl.java   |   348 +
 .../impl/GridTcpRouterNioListenerAdapter.java   |   203 +
 .../impl/GridTcpRouterNioListenerOsImpl.java    |    38 +
 .../router/impl/GridTcpRouterNioParser.java     |   109 +
 .../ignite/client/router/impl/package.html      |    23 +
 .../apache/ignite/client/router/package.html    |    23 +
 .../client/ssl/GridSslBasicContextFactory.java  |   438 +
 .../client/ssl/GridSslContextFactory.java       |    36 +
 .../org/apache/ignite/client/ssl/package.html   |    24 +
 .../client/util/GridClientConsistentHash.java   |   440 +
 .../client/util/GridClientStripedLock.java      |   135 +
 .../ignite/client/util/GridClientUtils.java     |   171 +
 .../client/util/GridConcurrentHashSet.java      |   113 +
 .../org/apache/ignite/client/util/package.html  |    24 +
 .../org/apache/ignite/cluster/ClusterGroup.java |     1 -
 .../org/apache/ignite/cluster/ClusterNode.java  |     4 +-
 .../ignite/compute/ComputeJobAdapter.java       |     2 +-
 .../ignite/compute/ComputeTaskAdapter.java      |     1 -
 .../ignite/compute/ComputeTaskSplitAdapter.java |     4 +-
 .../gridify/aop/GridifyArgumentAdapter.java     |     2 +-
 .../gridify/aop/GridifyDefaultRangeTask.java    |     9 +-
 .../compute/gridify/aop/GridifyDefaultTask.java |     7 +-
 .../aop/GridifySetToSetAbstractAspect.java      |     7 +-
 .../aop/GridifySetToValueAbstractAspect.java    |     7 +-
 .../ClientConnectionConfiguration.java          |     2 +-
 .../configuration/GridQueryConfiguration.java   |     5 +-
 .../configuration/IgniteConfiguration.java      |    10 +-
 .../ignite/dotnet/GridDotNetConfiguration.java  |   113 +
 .../dotnet/GridDotNetPortableConfiguration.java |   207 +
 .../GridDotNetPortableTypeConfiguration.java    |   219 +
 .../java/org/apache/ignite/dotnet/package.html  |    23 +
 .../events/IgniteAuthenticationEvent.java       |     4 +-
 .../ignite/events/IgniteAuthorizationEvent.java |     2 +-
 .../apache/ignite/events/IgniteCacheEvent.java  |     4 +-
 .../events/IgniteCachePreloadingEvent.java      |     2 +-
 .../events/IgniteCacheQueryExecutedEvent.java   |    18 +-
 .../events/IgniteCacheQueryReadEvent.java       |    18 +-
 .../ignite/events/IgniteCheckpointEvent.java    |     2 +-
 .../ignite/events/IgniteDeploymentEvent.java    |     2 +-
 .../ignite/events/IgniteDiscoveryEvent.java     |     4 +-
 .../ignite/events/IgniteEventAdapter.java       |     2 +-
 .../apache/ignite/events/IgniteEventType.java   |     2 +-
 .../org/apache/ignite/events/IgniteFsEvent.java |     4 +-
 .../apache/ignite/events/IgniteJobEvent.java    |     2 +-
 .../ignite/events/IgniteLicenseEvent.java       |     2 +-
 .../ignite/events/IgniteSecureSessionEvent.java |     2 +-
 .../ignite/events/IgniteSwapSpaceEvent.java     |     2 +-
 .../apache/ignite/events/IgniteTaskEvent.java   |     2 +-
 .../apache/ignite/fs/IgniteFsConfiguration.java |     6 +-
 .../fs/IgniteFsGroupDataBlocksKeyMapper.java    |     6 +-
 .../java/org/apache/ignite/fs/IgniteFsPath.java |     6 +-
 .../apache/ignite/fs/IgniteFsPathSummary.java   |     2 +-
 .../ignite/fs/mapreduce/IgniteFsFileRange.java  |     2 +-
 .../IgniteFsInputStreamJobAdapter.java          |     3 +-
 .../apache/ignite/fs/mapreduce/IgniteFsJob.java |     1 -
 .../fs/mapreduce/IgniteFsRangeInputStream.java  |     2 +-
 .../fs/mapreduce/IgniteFsRecordResolver.java    |     1 -
 .../ignite/fs/mapreduce/IgniteFsTask.java       |     9 +-
 .../IgniteFsByteDelimiterRecordResolver.java    |     7 +-
 .../IgniteFsFixedLengthRecordResolver.java      |     3 +-
 .../records/IgniteFsNewLineRecordResolver.java  |     2 +-
 .../IgniteFsStringDelimiterRecordResolver.java  |     2 +-
 .../org/apache/ignite/hadoop/GridHadoop.java    |    86 +
 .../ignite/hadoop/GridHadoopConfiguration.java  |   172 +
 .../apache/ignite/hadoop/GridHadoopCounter.java |    44 +
 .../ignite/hadoop/GridHadoopCounterWriter.java  |    36 +
 .../ignite/hadoop/GridHadoopCounters.java       |    49 +
 .../ignite/hadoop/GridHadoopFileBlock.java      |   162 +
 .../ignite/hadoop/GridHadoopInputSplit.java     |    54 +
 .../org/apache/ignite/hadoop/GridHadoopJob.java |   102 +
 .../apache/ignite/hadoop/GridHadoopJobId.java   |   102 +
 .../apache/ignite/hadoop/GridHadoopJobInfo.java |    83 +
 .../ignite/hadoop/GridHadoopJobPhase.java       |    38 +
 .../ignite/hadoop/GridHadoopJobProperty.java    |   138 +
 .../ignite/hadoop/GridHadoopJobStatus.java      |   207 +
 .../ignite/hadoop/GridHadoopMapReducePlan.java  |    80 +
 .../hadoop/GridHadoopMapReducePlanner.java      |    40 +
 .../ignite/hadoop/GridHadoopPartitioner.java    |    33 +
 .../ignite/hadoop/GridHadoopSerialization.java  |    54 +
 .../apache/ignite/hadoop/GridHadoopTask.java    |    72 +
 .../ignite/hadoop/GridHadoopTaskContext.java    |   189 +
 .../ignite/hadoop/GridHadoopTaskInfo.java       |   153 +
 .../ignite/hadoop/GridHadoopTaskInput.java      |    55 +
 .../ignite/hadoop/GridHadoopTaskOutput.java     |    40 +
 .../ignite/hadoop/GridHadoopTaskType.java       |    56 +
 .../java/org/apache/ignite/hadoop/package.html  |    24 +
 .../ignite/internal/ClusterGroupAdapter.java    |   851 ++
 .../apache/ignite/internal/ClusterGroupEx.java  |    35 +
 .../internal/ClusterLocalNodeMetrics.java       |   311 +
 .../ignite/internal/ClusterMetricsImpl.java     |   813 +
 .../internal/ClusterNodeLocalMapImpl.java       |   103 +
 .../internal/ClusterNodeMetricsMBean.java       |    29 +
 .../ignite/internal/GridClosureCallMode.java    |    61 +
 .../apache/ignite/internal/GridComponent.java   |    96 +
 .../apache/ignite/internal/GridDiagnostic.java  |   172 +
 .../ignite/internal/GridDirectCollection.java   |    32 +
 .../apache/ignite/internal/GridDirectMap.java   |    37 +
 .../ignite/internal/GridDirectTransient.java    |    29 +
 .../ignite/internal/GridDirectVersion.java      |    32 +
 .../internal/GridEventConsumeHandler.java       |   415 +
 .../java/org/apache/ignite/internal/GridEx.java |   143 +
 .../org/apache/ignite/internal/GridGainEx.java  |  2399 +++
 .../ignite/internal/GridInternalException.java  |    69 +
 .../ignite/internal/GridInternalWrapper.java    |    30 +
 .../ignite/internal/GridJobCancelRequest.java   |   215 +
 .../ignite/internal/GridJobContextImpl.java     |   282 +
 .../ignite/internal/GridJobExecuteRequest.java  |   918 ++
 .../internal/GridJobExecuteRequestV2.java       |   185 +
 .../ignite/internal/GridJobExecuteResponse.java |   374 +
 .../ignite/internal/GridJobResultImpl.java      |   182 +
 .../ignite/internal/GridJobSessionImpl.java     |   288 +
 .../ignite/internal/GridJobSiblingImpl.java     |   190 +
 .../ignite/internal/GridJobSiblingsRequest.java |   175 +
 .../internal/GridJobSiblingsResponse.java       |   151 +
 .../org/apache/ignite/internal/GridKernal.java  |  3308 +++++
 .../ignite/internal/GridKernalContext.java      |   515 +
 .../ignite/internal/GridKernalContextImpl.java  |   905 ++
 .../ignite/internal/GridKernalGateway.java      |   131 +
 .../ignite/internal/GridKernalGatewayImpl.java  |   227 +
 .../apache/ignite/internal/GridKernalState.java |    51 +
 .../apache/ignite/internal/GridKillTask.java    |   105 +
 .../apache/ignite/internal/GridLoggerProxy.java |   217 +
 .../internal/GridMessageListenHandler.java      |   200 +
 .../ignite/internal/GridNodeAttributes.java     |   145 +
 .../internal/GridNodeOrderComparator.java       |    36 +
 .../internal/GridPerformanceSuggestions.java    |    90 +
 .../ignite/internal/GridPluginComponent.java    |    97 +
 .../ignite/internal/GridPluginContext.java      |   102 +
 .../ignite/internal/GridPortablesImpl.java      |   174 +
 .../apache/ignite/internal/GridProductImpl.java |   191 +
 .../apache/ignite/internal/GridProperties.java  |    82 +
 .../ignite/internal/GridProxyListener.java      |    51 +
 .../ignite/internal/GridTaskCancelRequest.java  |   134 +
 .../ignite/internal/GridTaskFutureImpl.java     |   122 +
 .../apache/ignite/internal/GridTaskMessage.java |    30 +
 .../ignite/internal/GridTaskNameHashKey.java    |    75 +
 .../ignite/internal/GridTaskSessionImpl.java    |   839 ++
 .../internal/GridTaskSessionInternal.java       |    69 +
 .../ignite/internal/GridTaskSessionRequest.java |   206 +
 .../org/apache/ignite/internal/GridTopic.java   |   829 ++
 .../ignite/internal/GridUpdateNotifier.java     |   376 +
 .../ignite/internal/IgniteClusterAsyncImpl.java |   239 +
 .../ignite/internal/IgniteComponentType.java    |   283 +
 .../ignite/internal/IgniteComputeImpl.java      |   476 +
 .../ignite/internal/IgniteEventsImpl.java       |   299 +
 .../ignite/internal/IgniteManagedImpl.java      |   264 +
 .../ignite/internal/IgniteMessagingImpl.java    |   221 +
 .../ignite/internal/IgniteSchedulerImpl.java    |   142 +
 .../internal/IgniteThreadPoolMBeanAdapter.java  |   149 +
 .../ignite/internal/IgniteTransactionsEx.java   |    41 +
 .../ignite/internal/IgnitionMBeanAdapter.java   |    59 +
 .../internal/executor/GridExecutorService.java  |   735 +
 .../ignite/internal/executor/package.html       |    23 +
 .../fs/common/GridGgfsControlResponse.java      |   633 +
 .../fs/common/GridGgfsDataInputStream.java      |    40 +
 .../fs/common/GridGgfsDataOutputStream.java     |    43 +
 .../fs/common/GridGgfsHandshakeRequest.java     |    93 +
 .../internal/fs/common/GridGgfsIpcCommand.java  |    98 +
 .../internal/fs/common/GridGgfsLogger.java      |   767 +
 .../internal/fs/common/GridGgfsMarshaller.java  |   374 +
 .../internal/fs/common/GridGgfsMessage.java     |    41 +
 .../fs/common/GridGgfsPathControlRequest.java   |   238 +
 .../fs/common/GridGgfsStatusRequest.java        |    35 +
 .../fs/common/GridGgfsStreamControlRequest.java |   101 +
 .../ignite/internal/fs/common/package.html      |    23 +
 .../ignite/internal/managers/GridManager.java   |    46 +
 .../internal/managers/GridManagerAdapter.java   |   612 +
 .../managers/GridNoopManagerAdapter.java        |    88 +
 .../checkpoint/GridCheckpointManager.java       |   447 +
 .../checkpoint/GridCheckpointRequest.java       |   191 +
 .../internal/managers/checkpoint/package.html   |    23 +
 .../GridCollisionJobContextAdapter.java         |    62 +
 .../collision/GridCollisionManager.java         |   133 +
 .../internal/managers/collision/package.html    |    23 +
 .../communication/GridDisconnectListener.java   |    34 +
 .../managers/communication/GridIoManager.java   |  2205 +++
 .../managers/communication/GridIoMessage.java   |   361 +
 .../managers/communication/GridIoPolicy.java    |    57 +
 .../communication/GridIoUserMessage.java        |   445 +
 .../communication/GridMessageListener.java      |    34 +
 .../managers/communication/package.html         |    23 +
 .../managers/deployment/GridDeployment.java     |   775 +
 .../deployment/GridDeploymentClassLoader.java   |   801 +
 .../deployment/GridDeploymentCommunication.java |   485 +
 .../managers/deployment/GridDeploymentInfo.java |    58 +
 .../deployment/GridDeploymentInfoBean.java      |   359 +
 .../deployment/GridDeploymentLocalStore.java    |   557 +
 .../deployment/GridDeploymentManager.java       |   614 +
 .../deployment/GridDeploymentMetadata.java      |   290 +
 .../GridDeploymentPerLoaderStore.java           |   521 +
 .../GridDeploymentPerVersionStore.java          |  1281 ++
 .../deployment/GridDeploymentRequest.java       |   336 +
 .../deployment/GridDeploymentResponse.java      |   212 +
 .../deployment/GridDeploymentStore.java         |    98 +
 .../deployment/GridDeploymentStoreAdapter.java  |   158 +
 .../internal/managers/deployment/package.html   |    23 +
 .../protocol/gg/GridProtocolHandler.java        |    53 +
 .../protocol/gg/GridUrlConnection.java          |    74 +
 .../deployment/protocol/gg/package.html         |    23 +
 .../discovery/GridDiscoveryManager.java         |  2179 +++
 .../GridDiscoveryTopologySnapshot.java          |    62 +
 .../managers/discovery/GridLocalMetrics.java    |   216 +
 .../internal/managers/discovery/package.html    |    23 +
 .../eventstorage/GridEventStorageManager.java   |  1152 ++
 .../eventstorage/GridEventStorageMessage.java   |   537 +
 .../eventstorage/GridLocalEventListener.java    |    39 +
 .../internal/managers/eventstorage/package.html |    23 +
 .../failover/GridFailoverContextImpl.java       |    82 +
 .../managers/failover/GridFailoverManager.java  |    66 +
 .../internal/managers/failover/package.html     |    24 +
 .../managers/indexing/GridIndexingManager.java  |   232 +
 .../internal/managers/indexing/package.html     |    24 +
 .../loadbalancer/GridLoadBalancerAdapter.java   |    50 +
 .../loadbalancer/GridLoadBalancerManager.java   |   163 +
 .../internal/managers/loadbalancer/package.html |    23 +
 .../ignite/internal/managers/package.html       |    23 +
 .../securesession/GridSecureSession.java        |    54 +
 .../securesession/GridSecureSessionManager.java |    54 +
 .../os/GridOsSecureSessionManager.java          |    56 +
 .../managers/securesession/os/package.html      |    23 +
 .../managers/securesession/package.html         |    23 +
 .../security/GridAllowAllPermissionSet.java     |    55 +
 .../managers/security/GridSecurityContext.java  |   248 +
 .../managers/security/GridSecurityImpl.java     |    84 +
 .../managers/security/GridSecurityManager.java  |    93 +
 .../security/GridSecuritySubjectAdapter.java    |   131 +
 .../security/os/GridOsSecurityManager.java      |    97 +
 .../internal/managers/security/os/package.html  |    23 +
 .../internal/managers/security/package.html     |    23 +
 .../swapspace/GridSwapSpaceManager.java         |   426 +
 .../internal/managers/swapspace/package.html    |    23 +
 .../org/apache/ignite/internal/package.html     |    24 +
 .../internal/processors/GridProcessor.java      |    38 +
 .../processors/GridProcessorAdapter.java        |   125 +
 .../affinity/GridAffinityAssignment.java        |   168 +
 .../affinity/GridAffinityAssignmentCache.java   |   409 +
 .../affinity/GridAffinityMessage.java           |   164 +
 .../affinity/GridAffinityProcessor.java         |   528 +
 .../processors/affinity/GridAffinityUtils.java  |   187 +
 .../GridCacheAffinityFunctionContextImpl.java   |    83 +
 .../internal/processors/affinity/package.html   |    23 +
 .../processors/cache/CacheEntryImpl.java        |    60 +
 .../internal/processors/cache/CacheFlag.java    |   110 +
 .../processors/cache/CacheFlagException.java    |    67 +
 .../processors/cache/CacheInvokeEntry.java      |   100 +
 .../processors/cache/CacheInvokeResult.java     |   104 +
 .../processors/cache/CacheLockImpl.java         |     8 +-
 .../CachePartialUpdateCheckedException.java     |    64 +
 .../cache/CacheStorePartialUpdateException.java |    48 +
 .../processors/cache/GridCacheAdapter.java      |  5338 +++++++
 .../cache/GridCacheAffinityManager.java         |   378 +
 .../processors/cache/GridCacheAtomicFuture.java |    47 +
 .../cache/GridCacheAtomicVersionComparator.java |    58 +
 .../processors/cache/GridCacheAttributes.java   |   634 +
 .../cache/GridCacheBatchSwapEntry.java          |    89 +
 .../cache/GridCacheClearAllRunnable.java        |   173 +
 .../cache/GridCacheConcurrentMap.java           |  2418 +++
 .../processors/cache/GridCacheContext.java      |  1856 +++
 .../GridCacheDefaultAffinityKeyMapper.java      |   136 +
 .../processors/cache/GridCacheDeployable.java   |    37 +
 .../cache/GridCacheDeploymentManager.java       |   951 ++
 .../processors/cache/GridCacheEntryEx.java      |   991 ++
 .../processors/cache/GridCacheEntryImpl.java    |   728 +
 .../processors/cache/GridCacheEntryInfo.java    |   334 +
 .../GridCacheEntryInfoCollectSwapListener.java  |    88 +
 .../cache/GridCacheEntryRedeployException.java  |    35 +
 .../cache/GridCacheEntryRemovedException.java   |    28 +
 .../processors/cache/GridCacheEntrySet.java     |   111 +
 .../processors/cache/GridCacheEventManager.java |   254 +
 .../cache/GridCacheEvictionEntry.java           |   493 +
 .../cache/GridCacheEvictionManager.java         |  2037 +++
 .../cache/GridCacheEvictionRequest.java         |   251 +
 .../cache/GridCacheEvictionResponse.java        |   281 +
 .../cache/GridCacheExplicitLockSpan.java        |   278 +
 .../cache/GridCacheFilterEvaluationEntry.java   |   399 +
 .../cache/GridCacheFilterFailedException.java   |    58 +
 .../processors/cache/GridCacheFuture.java       |    61 +
 .../processors/cache/GridCacheGateway.java      |   153 +
 .../cache/GridCacheIndexUpdateException.java    |    45 +
 .../processors/cache/GridCacheInternal.java     |    27 +
 .../processors/cache/GridCacheIoManager.java    |   865 ++
 .../processors/cache/GridCacheIterator.java     |    86 +
 .../processors/cache/GridCacheKeySet.java       |   110 +
 .../cache/GridCacheLoaderWriterStore.java       |   140 +
 .../cache/GridCacheLockTimeoutException.java    |    33 +
 .../processors/cache/GridCacheLogger.java       |   188 +
 .../processors/cache/GridCacheMBeanAdapter.java |   217 +
 .../processors/cache/GridCacheManager.java      |    57 +
 .../cache/GridCacheManagerAdapter.java          |   166 +
 .../processors/cache/GridCacheMapAdapter.java   |   173 +
 .../processors/cache/GridCacheMapEntry.java     |  4182 ++++++
 .../cache/GridCacheMapEntryFactory.java         |    39 +
 .../processors/cache/GridCacheMessage.java      |   734 +
 .../cache/GridCacheMetricsAdapter.java          |   260 +
 .../cache/GridCacheMultiTxFuture.java           |   146 +
 .../processors/cache/GridCacheMvcc.java         |  1258 ++
 .../processors/cache/GridCacheMvccCallback.java |    53 +
 .../cache/GridCacheMvccCandidate.java           |   707 +
 .../processors/cache/GridCacheMvccFuture.java   |    30 +
 .../processors/cache/GridCacheMvccManager.java  |  1178 ++
 .../cache/GridCacheOffheapSwapEntry.java        |   193 +
 .../processors/cache/GridCacheOperation.java    |    60 +
 .../GridCachePartitionExchangeManager.java      |  1022 ++
 .../processors/cache/GridCachePreloader.java    |   128 +
 .../cache/GridCachePreloaderAdapter.java        |   140 +
 .../processors/cache/GridCacheProcessor.java    |  1930 +++
 .../processors/cache/GridCacheProjectionEx.java |   454 +
 .../cache/GridCacheProjectionImpl.java          |  1431 ++
 .../processors/cache/GridCacheProxy.java        |    27 +
 .../processors/cache/GridCacheProxyImpl.java    |  1903 +++
 .../processors/cache/GridCacheReturn.java       |   170 +
 .../cache/GridCacheSharedContext.java           |   507 +
 .../cache/GridCacheSharedManager.java           |    57 +
 .../cache/GridCacheSharedManagerAdapter.java    |   166 +
 .../processors/cache/GridCacheStoreManager.java |  1117 ++
 .../processors/cache/GridCacheSwapEntry.java    |    81 +
 .../cache/GridCacheSwapEntryImpl.java           |   344 +
 .../processors/cache/GridCacheSwapListener.java |    31 +
 .../processors/cache/GridCacheSwapManager.java  |  1615 ++
 .../processors/cache/GridCacheTtlManager.java   |   215 +
 .../cache/GridCacheUpdateAtomicResult.java      |   161 +
 .../cache/GridCacheUpdateTxResult.java          |    64 +
 .../processors/cache/GridCacheUtilityKey.java   |    45 +
 .../processors/cache/GridCacheUtils.java        |  1682 +++
 .../processors/cache/GridCacheValueBytes.java   |   120 +
 .../cache/GridCacheValueCollection.java         |   167 +
 .../processors/cache/GridCacheVersion.java      |   256 +
 .../processors/cache/GridCacheVersionEx.java    |    95 +
 .../cache/GridCacheVersionManager.java          |   281 +
 .../processors/cache/GridCacheVersionable.java  |    28 +
 .../cache/GridCacheWriteBehindStore.java        |  1022 ++
 .../processors/cache/GridDrResolveResult.java   |    63 +
 .../processors/cache/GridPartitionLockKey.java  |   104 +
 .../cache/IgniteCacheExpiryPolicy.java          |    73 +
 .../processors/cache/IgniteCacheProxy.java      |    31 +-
 .../cache/affinity/GridCacheAffinityImpl.java   |   222 +
 .../cache/affinity/GridCacheAffinityProxy.java  |   262 +
 .../GridAtomicCacheQueueImpl.java               |   256 +
 .../GridCacheAnnotationHelper.java              |   240 +
 .../datastructures/GridCacheAtomicLongEx.java   |    32 +
 .../datastructures/GridCacheAtomicLongImpl.java |   527 +
 .../GridCacheAtomicLongValue.java               |    84 +
 .../GridCacheAtomicReferenceEx.java             |    32 +
 .../GridCacheAtomicReferenceImpl.java           |   320 +
 .../GridCacheAtomicReferenceValue.java          |   106 +
 .../GridCacheAtomicSequenceEx.java              |    32 +
 .../GridCacheAtomicSequenceImpl.java            |   516 +
 .../GridCacheAtomicSequenceValue.java           |    84 +
 .../GridCacheAtomicStampedEx.java               |    32 +
 .../GridCacheAtomicStampedImpl.java             |   350 +
 .../GridCacheAtomicStampedValue.java            |   135 +
 .../GridCacheCountDownLatchEx.java              |    39 +
 .../GridCacheCountDownLatchImpl.java            |   359 +
 .../GridCacheCountDownLatchValue.java           |   115 +
 .../GridCacheDataStructuresImpl.java            |   119 +
 .../GridCacheDataStructuresManager.java         |  1592 ++
 .../GridCacheDataStructuresProxy.java           |   267 +
 .../datastructures/GridCacheInternalKey.java    |    31 +
 .../GridCacheInternalKeyImpl.java               |    89 +
 .../datastructures/GridCacheQueueAdapter.java   |  1007 ++
 .../datastructures/GridCacheQueueHeader.java    |   199 +
 .../datastructures/GridCacheQueueHeaderKey.java |    88 +
 .../datastructures/GridCacheQueueItemKey.java   |   121 +
 .../datastructures/GridCacheQueueProxy.java     |   746 +
 .../datastructures/GridCacheRemovable.java      |    37 +
 .../datastructures/GridCacheSetHeader.java      |    85 +
 .../datastructures/GridCacheSetHeaderKey.java   |    88 +
 .../cache/datastructures/GridCacheSetImpl.java  |   723 +
 .../datastructures/GridCacheSetItemKey.java     |   109 +
 .../cache/datastructures/GridCacheSetProxy.java |   537 +
 .../datastructures/GridSetQueryPredicate.java   |   115 +
 .../GridTransactionalCacheQueueImpl.java        |   262 +
 .../distributed/GridCacheCommittedTxInfo.java   |   112 +
 .../distributed/GridCacheMappedVersion.java     |    33 +
 ...ridCacheOptimisticCheckPreparedTxFuture.java |   388 +
 ...idCacheOptimisticCheckPreparedTxRequest.java |   227 +
 ...dCacheOptimisticCheckPreparedTxResponse.java |   198 +
 .../GridCachePerThreadTxCommitBuffer.java       |   185 +
 ...dCachePessimisticCheckCommittedTxFuture.java |   380 +
 ...CachePessimisticCheckCommittedTxRequest.java |   292 +
 ...achePessimisticCheckCommittedTxResponse.java |   231 +
 .../distributed/GridCacheTtlUpdateRequest.java  |   500 +
 .../distributed/GridCacheTxCommitBuffer.java    |    60 +
 .../distributed/GridCacheTxFinishSync.java      |   292 +
 .../distributed/GridDistributedBaseMessage.java |   456 +
 .../GridDistributedCacheAdapter.java            |   127 +
 .../distributed/GridDistributedCacheEntry.java  |   850 ++
 .../GridDistributedLockCancelledException.java  |    40 +
 .../distributed/GridDistributedLockRequest.java |   833 ++
 .../GridDistributedLockResponse.java            |   436 +
 .../GridDistributedTxFinishRequest.java         |   695 +
 .../GridDistributedTxFinishResponse.java        |   172 +
 .../distributed/GridDistributedTxMapping.java   |   302 +
 .../GridDistributedTxPrepareRequest.java        |   776 +
 .../GridDistributedTxPrepareResponse.java       |   250 +
 .../GridDistributedTxRemoteAdapter.java         |   775 +
 .../GridDistributedUnlockRequest.java           |   239 +
 .../GridPartitionedCacheEntryImpl.java          |   423 +
 .../IgniteExternalizableExpiryPolicy.java       |   174 +
 .../dht/GridClientPartitionTopology.java        |   816 ++
 .../dht/GridDhtAffinityAssignmentRequest.java   |   139 +
 .../dht/GridDhtAffinityAssignmentResponse.java  |   196 +
 .../dht/GridDhtAssignmentFetchFuture.java       |   183 +
 .../cache/distributed/dht/GridDhtCache.java     |   103 +
 .../distributed/dht/GridDhtCacheAdapter.java    |  1017 ++
 .../distributed/dht/GridDhtCacheEntry.java      |   760 +
 .../distributed/dht/GridDhtCacheEntryImpl.java  |   172 +
 .../distributed/dht/GridDhtEmbeddedFuture.java  |    92 +
 .../distributed/dht/GridDhtFinishedFuture.java  |    66 +
 .../cache/distributed/dht/GridDhtFuture.java    |    36 +
 .../cache/distributed/dht/GridDhtGetFuture.java |   451 +
 .../dht/GridDhtInvalidPartitionException.java   |    51 +
 .../distributed/dht/GridDhtLocalPartition.java  |   594 +
 .../distributed/dht/GridDhtLockFuture.java      |  1235 ++
 .../distributed/dht/GridDhtLockRequest.java     |   596 +
 .../distributed/dht/GridDhtLockResponse.java    |   453 +
 .../distributed/dht/GridDhtPartitionState.java  |    55 +
 .../dht/GridDhtPartitionTopology.java           |   207 +
 .../dht/GridDhtPartitionTopologyImpl.java       |  1195 ++
 .../distributed/dht/GridDhtTopologyFuture.java  |    44 +
 .../dht/GridDhtTransactionalCacheAdapter.java   |  1492 ++
 .../distributed/dht/GridDhtTxFinishFuture.java  |   532 +
 .../distributed/dht/GridDhtTxFinishRequest.java |   702 +
 .../dht/GridDhtTxFinishResponse.java            |   145 +
 .../cache/distributed/dht/GridDhtTxLocal.java   |   656 +
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   831 ++
 .../cache/distributed/dht/GridDhtTxMapping.java |   169 +
 .../distributed/dht/GridDhtTxPrepareFuture.java |  1074 ++
 .../dht/GridDhtTxPrepareRequest.java            |   613 +
 .../dht/GridDhtTxPrepareResponse.java           |   471 +
 .../cache/distributed/dht/GridDhtTxRemote.java  |   332 +
 .../distributed/dht/GridDhtUnlockRequest.java   |   221 +
 .../distributed/dht/GridNoStorageCacheMap.java  |   109 +
 .../dht/GridPartitionedGetFuture.java           |   715 +
 .../dht/atomic/GridDhtAtomicCache.java          |  3005 ++++
 .../dht/atomic/GridDhtAtomicCacheEntry.java     |    75 +
 .../GridDhtAtomicDeferredUpdateResponse.java    |   188 +
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   442 +
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  1412 ++
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   353 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   887 ++
 .../dht/atomic/GridNearAtomicUpdateRequest.java |  1126 ++
 .../atomic/GridNearAtomicUpdateResponse.java    |   797 +
 .../dht/colocated/GridDhtColocatedCache.java    |   818 ++
 .../colocated/GridDhtColocatedCacheEntry.java   |    67 +
 .../colocated/GridDhtColocatedLockFuture.java   |  1333 ++
 .../colocated/GridDhtDetachedCacheEntry.java    |   108 +
 .../dht/preloader/GridDhtForceKeysFuture.java   |   565 +
 .../dht/preloader/GridDhtForceKeysRequest.java  |   333 +
 .../dht/preloader/GridDhtForceKeysResponse.java |   339 +
 .../GridDhtPartitionDemandMessage.java          |   390 +
 .../preloader/GridDhtPartitionDemandPool.java   |  1139 ++
 .../preloader/GridDhtPartitionExchangeId.java   |   151 +
 .../dht/preloader/GridDhtPartitionFullMap.java  |   238 +
 .../dht/preloader/GridDhtPartitionMap.java      |   159 +
 .../GridDhtPartitionSupplyMessage.java          |   519 +
 .../preloader/GridDhtPartitionSupplyPool.java   |   575 +
 .../GridDhtPartitionsAbstractMessage.java       |   157 +
 .../GridDhtPartitionsExchangeFuture.java        |  1106 ++
 .../preloader/GridDhtPartitionsFullMessage.java |   258 +
 .../GridDhtPartitionsSingleMessage.java         |   176 +
 .../GridDhtPartitionsSingleRequest.java         |   101 +
 .../dht/preloader/GridDhtPreloader.java         |   572 +
 .../preloader/GridDhtPreloaderAssignments.java  |    73 +
 .../distributed/near/GridNearAtomicCache.java   |   686 +
 .../distributed/near/GridNearCacheAdapter.java  |   792 +
 .../near/GridNearCacheClearAllRunnable.java     |    62 +
 .../distributed/near/GridNearCacheEntry.java    |   626 +
 .../distributed/near/GridNearGetFuture.java     |   866 ++
 .../distributed/near/GridNearGetRequest.java    |   596 +
 .../distributed/near/GridNearGetResponse.java   |   422 +
 .../distributed/near/GridNearLockFuture.java    |  1468 ++
 .../distributed/near/GridNearLockMapping.java   |   116 +
 .../distributed/near/GridNearLockRequest.java   |   666 +
 .../distributed/near/GridNearLockResponse.java  |   449 +
 .../near/GridNearTransactionalCache.java        |   699 +
 .../near/GridNearTxFinishFuture.java            |   500 +
 .../near/GridNearTxFinishRequest.java           |   317 +
 .../near/GridNearTxFinishResponse.java          |   227 +
 .../cache/distributed/near/GridNearTxLocal.java |  1302 ++
 .../near/GridNearTxPrepareFuture.java           |   898 ++
 .../near/GridNearTxPrepareRequest.java          |   449 +
 .../near/GridNearTxPrepareResponse.java         |   510 +
 .../distributed/near/GridNearTxRemote.java      |   392 +
 .../distributed/near/GridNearUnlockRequest.java |   103 +
 .../cache/dr/GridCacheDrExpirationInfo.java     |    90 +
 .../processors/cache/dr/GridCacheDrInfo.java    |   103 +
 .../processors/cache/dr/GridCacheDrManager.java |   143 +
 .../cache/dr/os/GridOsCacheDrManager.java       |   126 +
 .../extras/GridCacheAttributesEntryExtras.java  |    83 +
 .../GridCacheAttributesMvccEntryExtras.java     |   101 +
 ...dCacheAttributesMvccObsoleteEntryExtras.java |   119 +
 ...cheAttributesMvccObsoleteTtlEntryExtras.java |   146 +
 .../GridCacheAttributesMvccTtlEntryExtras.java  |   130 +
 .../GridCacheAttributesObsoleteEntryExtras.java |   101 +
 ...idCacheAttributesObsoleteTtlEntryExtras.java |   130 +
 .../GridCacheAttributesTtlEntryExtras.java      |   112 +
 .../cache/extras/GridCacheEntryExtras.java      |    82 +
 .../extras/GridCacheEntryExtrasAdapter.java     |    51 +
 .../cache/extras/GridCacheMvccEntryExtras.java  |    82 +
 .../GridCacheMvccObsoleteEntryExtras.java       |    99 +
 .../GridCacheMvccObsoleteTtlEntryExtras.java    |   129 +
 .../extras/GridCacheMvccTtlEntryExtras.java     |   112 +
 .../extras/GridCacheObsoleteEntryExtras.java    |    82 +
 .../extras/GridCacheObsoleteTtlEntryExtras.java |   111 +
 .../cache/extras/GridCacheTtlEntryExtras.java   |    93 +
 .../cache/jta/CacheJtaManagerAdapter.java       |    50 +
 .../cache/jta/CacheNoopJtaManager.java          |    42 +
 .../processors/cache/local/GridLocalCache.java  |   205 +
 .../cache/local/GridLocalCacheEntry.java        |   386 +
 .../cache/local/GridLocalLockCallback.java      |    38 +
 .../cache/local/GridLocalLockFuture.java        |   451 +
 .../processors/cache/local/GridLocalTx.java     |   206 +
 .../cache/local/GridLocalTxFuture.java          |   350 +
 .../local/atomic/GridLocalAtomicCache.java      |  1517 ++
 .../GridCacheDistributedFieldsQueryFuture.java  |   105 +
 .../query/GridCacheDistributedQueryFuture.java  |   258 +
 .../query/GridCacheDistributedQueryManager.java |   793 +
 .../query/GridCacheFieldsQueryErrorFuture.java  |    54 +
 .../query/GridCacheLocalFieldsQueryFuture.java  |    85 +
 .../cache/query/GridCacheLocalQueryFuture.java  |   140 +
 .../cache/query/GridCacheLocalQueryManager.java |   145 +
 .../cache/query/GridCacheQueriesEx.java         |    52 +
 .../cache/query/GridCacheQueriesImpl.java       |   249 +
 .../cache/query/GridCacheQueriesProxy.java      |   273 +
 .../cache/query/GridCacheQueryAdapter.java      |   508 +
 .../cache/query/GridCacheQueryBean.java         |    90 +
 .../cache/query/GridCacheQueryErrorFuture.java  |    52 +
 .../query/GridCacheQueryFutureAdapter.java      |   558 +
 .../cache/query/GridCacheQueryInfo.java         |   184 +
 .../cache/query/GridCacheQueryManager.java      |  3160 ++++
 .../query/GridCacheQueryMetadataAware.java      |    33 +
 .../query/GridCacheQueryMetricsAdapter.java     |   150 +
 .../cache/query/GridCacheQueryMetricsKey.java   |   117 +
 .../cache/query/GridCacheQueryRequest.java      |   818 ++
 .../cache/query/GridCacheQueryResponse.java     |   445 +
 .../query/GridCacheQueryResponseEntry.java      |   114 +
 .../cache/query/GridCacheQueryType.java         |    70 +
 .../cache/query/GridCacheSqlIndexMetadata.java  |    59 +
 .../cache/query/GridCacheSqlMetadata.java       |    89 +
 .../GridCacheContinuousQueryAdapter.java        |   384 +
 .../GridCacheContinuousQueryEntry.java          |   765 +
 .../GridCacheContinuousQueryFilterEx.java       |    33 +
 .../GridCacheContinuousQueryHandler.java        |   557 +
 .../GridCacheContinuousQueryListener.java       |    41 +
 .../GridCacheContinuousQueryManager.java        |   794 +
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |   166 +
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   342 +
 .../jdbc/GridCacheQueryJdbcValidationTask.java  |    64 +
 .../transactions/IgniteTransactionsImpl.java    |   253 +
 .../cache/transactions/IgniteTxAdapter.java     |  1570 ++
 .../cache/transactions/IgniteTxEntry.java       |  1141 ++
 .../cache/transactions/IgniteTxEx.java          |   539 +
 .../cache/transactions/IgniteTxHandler.java     |  1519 ++
 .../cache/transactions/IgniteTxKey.java         |   105 +
 .../transactions/IgniteTxLocalAdapter.java      |  3574 +++++
 .../cache/transactions/IgniteTxLocalEx.java     |   180 +
 .../cache/transactions/IgniteTxManager.java     |  2221 +++
 .../cache/transactions/IgniteTxMap.java         |   187 +
 .../transactions/IgniteTxMetricsAdapter.java    |   116 +
 .../cache/transactions/IgniteTxProxy.java       |    27 +
 .../cache/transactions/IgniteTxProxyImpl.java   |   313 +
 .../cache/transactions/IgniteTxRemoteEx.java    |    47 +
 .../clock/GridClockDeltaSnapshot.java           |   231 +
 .../clock/GridClockDeltaSnapshotMessage.java    |   226 +
 .../processors/clock/GridClockDeltaVersion.java |   117 +
 .../processors/clock/GridClockMessage.java      |   171 +
 .../processors/clock/GridClockServer.java       |   206 +
 .../processors/clock/GridClockSource.java       |    30 +
 .../clock/GridClockSyncProcessor.java           |   458 +
 .../processors/clock/GridJvmClockSource.java    |    28 +
 .../processors/closure/GridClosurePolicy.java   |    51 +
 .../closure/GridClosureProcessor.java           |  1744 +++
 .../GridMasterLeaveAwareComputeJobAdapter.java  |    36 +
 .../closure/GridPeerDeployAwareTaskAdapter.java |    60 +
 .../internal/processors/closure/package.html    |    23 +
 .../continuous/GridContinuousHandler.java       |   105 +
 .../continuous/GridContinuousMessage.java       |   256 +
 .../continuous/GridContinuousMessageType.java   |    56 +
 .../continuous/GridContinuousProcessor.java     |  1846 +++
 .../dataload/GridDataLoadCacheUpdaters.java     |   292 +
 .../dataload/GridDataLoadRequest.java           |   548 +
 .../dataload/GridDataLoadResponse.java          |   181 +
 .../dataload/GridDataLoadUpdateJob.java         |   120 +
 .../dataload/GridDataLoaderFuture.java          |    75 +
 .../dataload/GridDataLoaderProcessor.java       |   318 +
 .../dataload/IgniteDataLoaderImpl.java          |  1347 ++
 .../internal/processors/dataload/package.html   |    23 +
 .../dr/GridDrDataLoadCacheUpdater.java          |    77 +
 .../internal/processors/dr/GridDrType.java      |    38 +
 .../processors/dr/GridRawVersionedEntry.java    |   210 +
 .../processors/dr/GridVersionedEntry.java       |    80 +
 .../ignite/internal/processors/dr/package.html  |    25 +
 .../processors/email/GridEmailHolder.java       |   111 +
 .../email/IgniteEmailProcessorAdapter.java      |    85 +
 .../email/IgniteNoopEmailProcessor.java         |    56 +
 .../internal/processors/email/package.html      |    24 +
 .../processors/fs/GridGgfsAckMessage.java       |   212 +
 .../processors/fs/GridGgfsAsyncImpl.java        |   297 +
 .../processors/fs/GridGgfsAttributes.java       |   186 +
 .../processors/fs/GridGgfsBlockKey.java         |   279 +
 .../fs/GridGgfsBlockLocationImpl.java           |   258 +
 .../processors/fs/GridGgfsBlocksMessage.java    |   257 +
 .../processors/fs/GridGgfsClientSession.java    |    75 +
 .../fs/GridGgfsCommunicationMessage.java        |    75 +
 .../internal/processors/fs/GridGgfsContext.java |   205 +
 .../processors/fs/GridGgfsDataManager.java      |  1918 +++
 .../processors/fs/GridGgfsDeleteMessage.java    |   206 +
 .../processors/fs/GridGgfsDeleteWorker.java     |   350 +
 .../fs/GridGgfsDirectoryNotEmptyException.java  |    44 +
 .../internal/processors/fs/GridGgfsEx.java      |   142 +
 .../fs/GridGgfsFileAffinityRange.java           |   396 +
 .../processors/fs/GridGgfsFileInfo.java         |   568 +
 .../internal/processors/fs/GridGgfsFileMap.java |   361 +
 .../processors/fs/GridGgfsFileWorker.java       |   182 +
 .../processors/fs/GridGgfsFileWorkerBatch.java  |   235 +
 .../processors/fs/GridGgfsFileWorkerTask.java   |    32 +
 .../fs/GridGgfsFragmentizerManager.java         |   829 ++
 .../fs/GridGgfsFragmentizerRequest.java         |   212 +
 .../fs/GridGgfsFragmentizerResponse.java        |   131 +
 .../fs/GridGgfsHandshakeResponse.java           |   122 +
 .../internal/processors/fs/GridGgfsImpl.java    |  2152 +++
 .../fs/GridGgfsInputStreamAdapter.java          |    49 +
 .../fs/GridGgfsInputStreamDescriptor.java       |    78 +
 .../processors/fs/GridGgfsInputStreamImpl.java  |   532 +
 .../fs/GridGgfsInvalidRangeException.java       |    43 +
 .../processors/fs/GridGgfsIpcHandler.java       |   564 +
 .../internal/processors/fs/GridGgfsJobImpl.java |   117 +
 .../processors/fs/GridGgfsListingEntry.java     |   197 +
 .../processors/fs/GridGgfsLocalMetrics.java     |   212 +
 .../internal/processors/fs/GridGgfsManager.java |   155 +
 .../processors/fs/GridGgfsMetaManager.java      |  2992 ++++
 .../processors/fs/GridGgfsModeResolver.java     |   177 +
 .../internal/processors/fs/GridGgfsPaths.java   |   124 +
 .../processors/fs/GridGgfsSamplingKey.java      |    83 +
 .../GridGgfsSecondaryInputStreamDescriptor.java |    59 +
 ...GridGgfsSecondaryOutputStreamDescriptor.java |    74 +
 .../internal/processors/fs/GridGgfsServer.java  |   427 +
 .../processors/fs/GridGgfsServerHandler.java    |    57 +
 .../processors/fs/GridGgfsServerManager.java    |   211 +
 .../internal/processors/fs/GridGgfsStatus.java  |    76 +
 .../processors/fs/GridGgfsSyncMessage.java      |   161 +
 .../internal/processors/fs/GridGgfsThread.java  |    82 +
 .../processors/fs/IgniteFsFileImpl.java         |   245 +
 .../internal/processors/fs/IgniteFsHelper.java  |    49 +
 .../processors/fs/IgniteFsHelperImpl.java       |    54 +
 .../processors/fs/IgniteFsMetricsAdapter.java   |   239 +
 .../processors/fs/IgniteFsNoopHelper.java       |    41 +
 .../processors/fs/IgniteFsNoopProcessor.java    |    71 +
 .../fs/IgniteFsOutputStreamAdapter.java         |   263 +
 .../processors/fs/IgniteFsOutputStreamImpl.java |   504 +
 .../processors/fs/IgniteFsProcessor.java        |   463 +
 .../processors/fs/IgniteFsProcessorAdapter.java |    80 +
 .../processors/fs/IgniteFsTaskArgsImpl.java     |   135 +
 .../ignite/internal/processors/fs/package.html  |    23 +
 .../hadoop/IgniteHadoopNoopProcessor.java       |    76 +
 .../hadoop/IgniteHadoopProcessorAdapter.java    |    96 +
 .../processors/interop/GridInteropAware.java    |    49 +
 .../interop/GridInteropProcessor.java           |    82 +
 .../interop/GridInteropProcessorAdapter.java    |    31 +
 .../processors/interop/GridInteropTarget.java   |   109 +
 .../interop/os/GridOsInteropProcessor.java      |    80 +
 .../internal/processors/interop/os/package.html |    23 +
 .../internal/processors/interop/package.html    |    23 +
 .../processors/job/GridJobEventListener.java    |    40 +
 .../processors/job/GridJobHoldListener.java     |    36 +
 .../processors/job/GridJobProcessor.java        |  1869 +++
 .../internal/processors/job/GridJobWorker.java  |   894 ++
 .../ignite/internal/processors/job/package.html |    23 +
 .../processors/jobmetrics/GridJobMetrics.java   |   448 +
 .../jobmetrics/GridJobMetricsProcessor.java     |   404 +
 .../jobmetrics/GridJobMetricsSnapshot.java      |   227 +
 .../internal/processors/jobmetrics/package.html |    24 +
 .../license/GridLicenseProcessor.java           |    69 +
 .../license/GridLicenseSubsystem.java           |    53 +
 .../license/GridLicenseUseRegistry.java         |    90 +
 .../license/os/GridOsLicenseProcessor.java      |    66 +
 .../internal/processors/license/os/package.html |    23 +
 .../internal/processors/license/package.html    |    24 +
 .../offheap/GridOffHeapProcessor.java           |   326 +
 .../ignite/internal/processors/package.html     |    23 +
 .../plugin/IgnitePluginProcessor.java           |   211 +
 .../processors/port/GridPortListener.java       |    28 +
 .../processors/port/GridPortProcessor.java      |   195 +
 .../processors/port/GridPortRecord.java         |    72 +
 .../internal/processors/port/package.html       |    24 +
 .../portable/GridPortableInputStream.java       |   177 +
 .../portable/GridPortableOutputStream.java      |   172 +
 .../portable/GridPortableProcessor.java         |   150 +
 .../processors/portable/GridPortableStream.java |    53 +
 .../portable/os/GridOsPortableProcessor.java    |   126 +
 .../processors/portable/os/package.html         |    23 +
 .../internal/processors/portable/package.html   |    23 +
 .../query/GridQueryFieldMetadata.java           |    54 +
 .../processors/query/GridQueryFieldsResult.java |    42 +
 .../query/GridQueryFieldsResultAdapter.java     |    57 +
 .../query/GridQueryIndexDescriptor.java         |    50 +
 .../processors/query/GridQueryIndexType.java    |    32 +
 .../processors/query/GridQueryIndexing.java     |   170 +
 .../processors/query/GridQueryProcessor.java    |  1680 +++
 .../query/GridQueryTypeDescriptor.java          |    86 +
 .../resource/GridResourceBasicInjector.java     |    71 +
 .../processors/resource/GridResourceField.java  |    71 +
 .../resource/GridResourceInjector.java          |    56 +
 .../processors/resource/GridResourceIoc.java    |   437 +
 .../GridResourceJobContextInjector.java         |    54 +
 .../resource/GridResourceLoggerInjector.java    |    68 +
 .../processors/resource/GridResourceMethod.java |    71 +
 .../resource/GridResourceProcessor.java         |   607 +
 .../resource/GridResourceServiceInjector.java   |    84 +
 .../processors/resource/GridResourceUtils.java  |   104 +
 .../resource/GridSpringResourceContext.java     |    48 +
 .../internal/processors/resource/package.html   |    23 +
 .../processors/rest/GridRestCommand.java        |   160 +
 .../processors/rest/GridRestProcessor.java      |   697 +
 .../processors/rest/GridRestProtocol.java       |    59 +
 .../rest/GridRestProtocolHandler.java           |    40 +
 .../processors/rest/GridRestResponse.java       |   177 +
 .../message/GridClientAbstractMessage.java      |   117 +
 .../GridClientAuthenticationRequest.java        |    85 +
 .../message/GridClientCacheQueryRequest.java    |   414 +
 .../client/message/GridClientCacheRequest.java  |   319 +
 .../message/GridClientGetMetaDataRequest.java   |    64 +
 .../message/GridClientHandshakeRequest.java     |   108 +
 .../GridClientHandshakeRequestWrapper.java      |   129 +
 .../message/GridClientHandshakeResponse.java    |    66 +
 .../GridClientHandshakeResponseWrapper.java     |    96 +
 .../client/message/GridClientLogRequest.java    |   141 +
 .../rest/client/message/GridClientMessage.java  |    82 +
 .../message/GridClientMessageWrapper.java       |   266 +
 .../message/GridClientMetaDataResponse.java     |    57 +
 .../rest/client/message/GridClientNodeBean.java |   342 +
 .../message/GridClientNodeMetricsBean.java      |  1578 ++
 .../client/message/GridClientPingPacket.java    |    37 +
 .../message/GridClientPingPacketWrapper.java    |    89 +
 .../message/GridClientPortableMetaData.java     |    93 +
 .../message/GridClientPutMetaDataRequest.java   |    64 +
 .../rest/client/message/GridClientResponse.java |   145 +
 .../client/message/GridClientTaskRequest.java   |   152 +
 .../message/GridClientTaskResultBean.java       |   147 +
 .../message/GridClientTopologyRequest.java      |   174 +
 .../rest/client/message/GridRouterRequest.java  |    57 +
 .../rest/client/message/GridRouterResponse.java |    84 +
 .../processors/rest/client/message/package.html |    23 +
 .../rest/handlers/GridRestCommandHandler.java   |    40 +
 .../handlers/GridRestCommandHandlerAdapter.java |    51 +
 .../cache/GridCacheClientQueryResult.java       |   119 +
 .../handlers/cache/GridCacheCommandHandler.java |  1149 ++
 .../cache/GridCacheQueryCommandHandler.java     |   493 +
 .../handlers/cache/GridCacheRestMetrics.java    |   215 +
 .../handlers/cache/GridCacheRestResponse.java   |    67 +
 .../processors/rest/handlers/cache/package.html |    23 +
 .../handlers/log/GridLogCommandHandler.java     |   307 +
 .../processors/rest/handlers/log/package.html   |    23 +
 .../metadata/GridPortableMetadataHandler.java   |   104 +
 .../processors/rest/handlers/package.html       |    23 +
 .../handlers/task/GridTaskCommandHandler.java   |   638 +
 .../handlers/task/GridTaskResultRequest.java    |   185 +
 .../handlers/task/GridTaskResultResponse.java   |   233 +
 .../top/GridTopologyCommandHandler.java         |   335 +
 .../processors/rest/handlers/top/package.html   |    23 +
 .../version/GridVersionCommandHandler.java      |    60 +
 .../rest/handlers/version/package.html          |    23 +
 .../internal/processors/rest/package.html       |    23 +
 .../rest/protocols/GridRestProtocolAdapter.java |   196 +
 .../processors/rest/protocols/package.html      |    23 +
 .../protocols/tcp/GridClientPacketType.java     |    32 +
 .../protocols/tcp/GridMemcachedMessage.java     |   485 +
 .../tcp/GridMemcachedMessageWrapper.java        |   269 +
 .../tcp/GridTcpMemcachedNioListener.java        |   442 +
 .../protocols/tcp/GridTcpRestDirectParser.java  |   519 +
 .../protocols/tcp/GridTcpRestNioListener.java   |   386 +
 .../rest/protocols/tcp/GridTcpRestParser.java   |   878 ++
 .../rest/protocols/tcp/GridTcpRestProtocol.java |   335 +
 .../processors/rest/protocols/tcp/package.html  |    23 +
 .../rest/request/GridRestCacheQueryRequest.java |   143 +
 .../rest/request/GridRestCacheRequest.java      |   182 +
 .../rest/request/GridRestLogRequest.java        |    81 +
 .../GridRestPortableGetMetaDataRequest.java     |    44 +
 .../GridRestPortablePutMetaDataRequest.java     |    44 +
 .../rest/request/GridRestRequest.java           |   167 +
 .../rest/request/GridRestTaskRequest.java       |   134 +
 .../rest/request/GridRestTopologyRequest.java   |   100 +
 .../processors/rest/request/package.html        |    23 +
 .../schedule/GridScheduleStatistics.java        |   182 +
 .../schedule/IgniteNoopScheduleProcessor.java   |    54 +
 .../IgniteScheduleProcessorAdapter.java         |    53 +
 .../internal/processors/schedule/package.html   |    24 +
 .../segmentation/GridSegmentationProcessor.java |    51 +
 .../os/GridOsSegmentationProcessor.java         |    39 +
 .../processors/segmentation/package.html        |    23 +
 .../service/GridServiceAssignments.java         |   135 +
 .../service/GridServiceAssignmentsKey.java      |    63 +
 .../service/GridServiceDeployment.java          |    95 +
 .../service/GridServiceDeploymentFuture.java    |    56 +
 .../service/GridServiceDeploymentKey.java       |    63 +
 .../GridServiceMethodNotFoundException.java     |    43 +
 .../service/GridServiceMethodReflectKey.java    |    77 +
 .../service/GridServiceNotFoundException.java   |    40 +
 .../service/GridServiceProcessor.java           |  1289 ++
 .../processors/service/GridServiceProxy.java    |   380 +
 .../service/ManagedServiceContextImpl.java      |   156 +
 .../service/ManagedServiceDescriptorImpl.java   |   101 +
 .../session/GridTaskSessionProcessor.java       |   178 +
 .../internal/processors/session/package.html    |    24 +
 .../spring/IgniteSpringProcessor.java           |    73 +
 .../streamer/GridStreamProcessor.java           |   360 +
 .../streamer/GridStreamerAttributes.java        |   127 +
 .../streamer/GridStreamerCancelRequest.java     |   123 +
 .../streamer/GridStreamerContextDelegate.java   |   106 +
 .../streamer/GridStreamerContextImpl.java       |   205 +
 .../streamer/GridStreamerExecutionBatch.java    |   185 +
 .../streamer/GridStreamerExecutionRequest.java  |   382 +
 .../streamer/GridStreamerResponse.java          |   160 +
 .../GridStreamerRouteFailedException.java       |    36 +
 .../GridStreamerStageExecutionFuture.java       |   362 +
 .../streamer/GridStreamerWindowIterator.java    |    40 +
 .../processors/streamer/IgniteStreamerEx.java   |    95 +
 .../processors/streamer/IgniteStreamerImpl.java |  1415 ++
 .../streamer/StreamerMBeanAdapter.java          |   116 +
 .../streamer/StreamerMetricsAdapter.java        |   272 +
 .../streamer/StreamerMetricsHolder.java         |   424 +
 .../streamer/StreamerStageMBeanAdapter.java     |   101 +
 .../streamer/StreamerStageMetricsAdapter.java   |   135 +
 .../streamer/StreamerStageMetricsHolder.java    |   167 +
 .../streamer/StreamerStageWrapper.java          |    92 +
 .../streamer/StreamerWindowMetricsAdapter.java  |    65 +
 .../streamer/StreamerWindowMetricsHolder.java   |    50 +
 .../internal/processors/streamer/package.html   |    23 +
 .../task/GridStreamerBroadcastTask.java         |   138 +
 .../streamer/task/GridStreamerQueryTask.java    |   141 +
 .../streamer/task/GridStreamerReduceTask.java   |   145 +
 .../internal/processors/task/GridInternal.java  |    35 +
 .../processors/task/GridTaskEventListener.java  |    56 +
 .../processors/task/GridTaskProcessor.java      |  1295 ++
 .../task/GridTaskThreadContextKey.java          |    38 +
 .../processors/task/GridTaskWorker.java         |  1371 ++
 .../internal/processors/task/package.html       |    23 +
 .../processors/timeout/GridTimeoutObject.java   |    40 +
 .../timeout/GridTimeoutObjectAdapter.java       |    61 +
 .../timeout/GridTimeoutProcessor.java           |   173 +
 .../internal/processors/timeout/package.html    |    23 +
 .../version/GridVersionConverter.java           |    46 +
 .../internal/tck/TCKMBeanServerBuilder.java     |   118 +
 .../org/apache/ignite/internal/util/F0.java     |   368 +
 .../internal/util/GridAnnotationsCache.java     |    84 +
 .../ignite/internal/util/GridArgumentCheck.java |   149 +
 .../internal/util/GridAtomicInitializer.java    |   112 +
 .../ignite/internal/util/GridAtomicInteger.java |   249 +
 .../ignite/internal/util/GridAtomicLong.java    |   249 +
 .../GridBoundedConcurrentLinkedHashMap.java     |   124 +
 .../GridBoundedConcurrentLinkedHashSet.java     |   162 +
 .../util/GridBoundedConcurrentOrderedMap.java   |   242 +
 .../util/GridBoundedConcurrentOrderedSet.java   |   179 +
 .../internal/util/GridBoundedLinkedHashMap.java |   129 +
 .../internal/util/GridBoundedLinkedHashSet.java |   207 +
 .../ignite/internal/util/GridBusyLock.java      |    83 +
 .../ignite/internal/util/GridByteArrayList.java |   412 +
 .../internal/util/GridCircularBuffer.java       |   230 +
 .../internal/util/GridClassLoaderCache.java     |   131 +
 .../internal/util/GridClientByteUtils.java      |   238 +
 .../util/GridCloseableIteratorAdapter.java      |   110 +
 .../util/GridCloseableIteratorAdapterEx.java    |   127 +
 .../ignite/internal/util/GridCollections.java   |   644 +
 .../internal/util/GridConcurrentFactory.java    |   110 +
 .../internal/util/GridConcurrentHashSet.java    |   119 +
 .../util/GridConcurrentLinkedHashSet.java       |   131 +
 .../util/GridConcurrentPhantomHashSet.java      |   402 +
 .../util/GridConcurrentSkipListSet.java         |   302 +
 .../util/GridConcurrentWeakHashSet.java         |   402 +
 .../internal/util/GridConfigurationFinder.java  |   151 +
 .../internal/util/GridConsistentHash.java       |   672 +
 .../apache/ignite/internal/util/GridDebug.java  |   303 +
 .../util/GridEmptyCloseableIterator.java        |    43 +
 .../ignite/internal/util/GridEmptyIterator.java |    51 +
 .../ignite/internal/util/GridEnumCache.java     |    57 +
 .../internal/util/GridExecutionStatistics.java  |   105 +
 .../internal/util/GridFixedSizeInputStream.java |    85 +
 .../ignite/internal/util/GridHandleTable.java   |   199 +
 .../internal/util/GridIdentityHashSet.java      |    63 +
 .../ignite/internal/util/GridJavaProcess.java   |   259 +
 .../ignite/internal/util/GridKeyLock.java       |   154 +
 .../ignite/internal/util/GridLeanMap.java       |  1266 ++
 .../ignite/internal/util/GridLeanSet.java       |    83 +
 .../ignite/internal/util/GridListSet.java       |   529 +
 .../ignite/internal/util/GridLogThrottle.java   |   221 +
 .../ignite/internal/util/GridLongList.java      |   500 +
 .../apache/ignite/internal/util/GridMutex.java  |    55 +
 .../apache/ignite/internal/util/GridQueue.java  |   348 +
 .../apache/ignite/internal/util/GridRandom.java |    57 +
 .../internal/util/GridReflectionCache.java      |   251 +
 .../util/GridSerializableCollection.java        |    33 +
 .../internal/util/GridSerializableFuture.java   |    28 +
 .../internal/util/GridSerializableIterable.java |    28 +
 .../internal/util/GridSerializableIterator.java |    29 +
 .../internal/util/GridSerializableList.java     |    33 +
 .../internal/util/GridSerializableMap.java      |    37 +
 .../internal/util/GridSerializableSet.java      |    37 +
 .../ignite/internal/util/GridSetWrapper.java    |   136 +
 .../ignite/internal/util/GridSnapshotLock.java  |   219 +
 .../util/GridSpiCloseableIteratorWrapper.java   |    58 +
 .../ignite/internal/util/GridSpinBusyLock.java  |    84 +
 .../internal/util/GridSpinReadWriteLock.java    |   413 +
 .../ignite/internal/util/GridStringBuilder.java |   447 +
 .../internal/util/GridStringBuilderFactory.java |    98 +
 .../ignite/internal/util/GridStripedLock.java   |   143 +
 .../internal/util/GridStripedReadWriteLock.java |   100 +
 .../internal/util/GridSynchronizedMap.java      |   100 +
 .../ignite/internal/util/GridThreadLocal.java   |   175 +
 .../ignite/internal/util/GridThreadLocalEx.java |   210 +
 .../apache/ignite/internal/util/GridTimer.java  |   154 +
 .../ignite/internal/util/GridTimerTask.java     |    40 +
 .../apache/ignite/internal/util/GridUnsafe.java |    61 +
 .../apache/ignite/internal/util/GridUtils.java  |  9101 ++++++++++++
 .../ignite/internal/util/GridUuidCache.java     |    59 +
 .../ignite/internal/util/GridWeakIterator.java  |    55 +
 .../GridTcpCommunicationMessageAdapter.java     |   217 +
 .../GridTcpCommunicationMessageFactory.java     |   362 +
 .../GridTcpCommunicationMessageProducer.java    |    31 +
 .../GridTcpCommunicationMessageState.java       |  1598 ++
 .../util/direct/GridTcpMessageFactory.java      |    29 +
 .../util/future/GridCompoundFuture.java         |   383 +
 .../util/future/GridCompoundIdentityFuture.java |    68 +
 .../util/future/GridEmbeddedFuture.java         |   321 +
 .../util/future/GridFinishedFuture.java         |   224 +
 .../util/future/GridFinishedFutureEx.java       |   196 +
 .../internal/util/future/GridFutureAdapter.java |   626 +
 .../util/future/GridFutureAdapterEx.java        |   515 +
 .../util/future/GridFutureChainListener.java    |    72 +
 .../ignite/internal/util/future/package.html    |    23 +
 .../util/gridify/GridifyArgumentBuilder.java    |   186 +
 .../util/gridify/GridifyJobAdapter.java         |   107 +
 .../util/gridify/GridifyRangeArgument.java      |   103 +
 .../internal/util/gridify/GridifyUtils.java     |   521 +
 .../ignite/internal/util/gridify/package.html   |    23 +
 .../util/io/GridByteArrayInputStream.java       |   209 +
 .../util/io/GridByteArrayOutputStream.java      |   167 +
 .../ignite/internal/util/io/GridDataInput.java  |   132 +
 .../ignite/internal/util/io/GridDataOutput.java |   119 +
 .../internal/util/io/GridFilenameUtils.java     |  1560 ++
 .../util/io/GridReversedLinesFileReader.java    |   333 +
 .../internal/util/io/GridUnsafeDataInput.java   |   603 +
 .../internal/util/io/GridUnsafeDataOutput.java  |   500 +
 .../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 +
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |    87 +
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |   179 +
 .../internal/util/ipc/loopback/package.html     |    23 +
 .../ignite/internal/util/ipc/package.html       |    23 +
 .../GridIpcOutOfSystemResourcesException.java   |    59 +
 .../GridIpcSharedMemoryClientEndpoint.java      |   336 +
 .../shmem/GridIpcSharedMemoryInitRequest.java   |    67 +
 .../shmem/GridIpcSharedMemoryInitResponse.java  |   171 +
 .../shmem/GridIpcSharedMemoryInputStream.java   |    99 +
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |   243 +
 ...cSharedMemoryOperationTimedoutException.java |    59 +
 .../shmem/GridIpcSharedMemoryOutputStream.java  |    80 +
 .../GridIpcSharedMemoryServerEndpoint.java      |   707 +
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |   374 +
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |   242 +
 .../ignite/internal/util/ipc/shmem/package.html |    23 +
 .../internal/util/lang/GridAbsClosure.java      |    52 +
 .../internal/util/lang/GridAbsClosureX.java     |    48 +
 .../internal/util/lang/GridAbsPredicate.java    |    44 +
 .../internal/util/lang/GridAbsPredicateX.java   |    46 +
 .../util/lang/GridCloseableIterator.java        |    62 +
 .../ignite/internal/util/lang/GridClosure3.java |    52 +
 .../internal/util/lang/GridClosure3X.java       |    51 +
 .../util/lang/GridClosureException.java         |    50 +
 .../util/lang/GridComputeJobWrapper.java        |    98 +
 .../util/lang/GridFilteredIterator.java         |    87 +
 .../ignite/internal/util/lang/GridFunc.java     |  8608 +++++++++++
 .../internal/util/lang/GridInClosure3.java      |    49 +
 .../internal/util/lang/GridInClosure3X.java     |    50 +
 .../ignite/internal/util/lang/GridIterable.java |    35 +
 .../internal/util/lang/GridIterableAdapter.java |   120 +
 .../ignite/internal/util/lang/GridIterator.java |    67 +
 .../internal/util/lang/GridIteratorAdapter.java |    66 +
 .../ignite/internal/util/lang/GridMapEntry.java |    92 +
 .../util/lang/GridMetadataAwareAdapter.java     |   437 +
 .../internal/util/lang/GridNodePredicate.java   |   156 +
 .../internal/util/lang/GridPeerDeployAware.java |    52 +
 .../util/lang/GridPeerDeployAwareAdapter.java   |    69 +
 .../internal/util/lang/GridPlainAbsClosure.java |    33 +
 .../internal/util/lang/GridPlainCallable.java   |    27 +
 .../internal/util/lang/GridPlainClosure.java    |    32 +
 .../internal/util/lang/GridPlainClosure2.java   |    33 +
 .../internal/util/lang/GridPlainFuture.java     |    79 +
 .../util/lang/GridPlainFutureAdapter.java       |   299 +
 .../internal/util/lang/GridPlainInClosure.java  |    31 +
 .../internal/util/lang/GridPlainOutClosure.java |    31 +
 .../internal/util/lang/GridPlainRunnable.java   |    25 +
 .../internal/util/lang/GridPredicate3.java      |    57 +
 .../internal/util/lang/GridPredicate3X.java     |    51 +
 .../ignite/internal/util/lang/GridTriple.java   |    54 +
 .../ignite/internal/util/lang/GridTuple.java    |   147 +
 .../ignite/internal/util/lang/GridTuple3.java   |   226 +
 .../ignite/internal/util/lang/GridTuple4.java   |   257 +
 .../ignite/internal/util/lang/GridTuple5.java   |   288 +
 .../ignite/internal/util/lang/GridTuple6.java   |   322 +
 .../ignite/internal/util/lang/GridTupleV.java   |   188 +
 .../internal/util/lang/IgniteClosure2X.java     |    53 +
 .../internal/util/lang/IgniteClosureX.java      |    52 +
 .../internal/util/lang/IgniteInClosure2X.java   |    52 +
 .../internal/util/lang/IgniteInClosureX.java    |    51 +
 .../internal/util/lang/IgniteOutClosureX.java   |    50 +
 .../ignite/internal/util/lang/IgnitePair.java   |    53 +
 .../internal/util/lang/IgnitePredicate2X.java   |    53 +
 .../internal/util/lang/IgnitePredicateX.java    |    52 +
 .../internal/util/lang/IgniteReducer2.java      |    53 +
 .../internal/util/lang/IgniteReducer2X.java     |    50 +
 .../internal/util/lang/IgniteReducer3.java      |    55 +
 .../internal/util/lang/IgniteReducer3X.java     |    50 +
 .../internal/util/lang/IgniteReducerX.java      |    51 +
 .../nio/GridAbstractCommunicationClient.java    |   112 +
 .../internal/util/nio/GridBufferedParser.java   |    96 +
 .../util/nio/GridCommunicationClient.java       |   112 +
 .../nio/GridConnectionBytesVerifyFilter.java    |   139 +
 .../internal/util/nio/GridDirectParser.java     |    84 +
 .../util/nio/GridNioAsyncNotifyFilter.java      |   141 +
 .../util/nio/GridNioBackPressureControl.java    |    56 +
 .../internal/util/nio/GridNioCodecFilter.java   |   139 +
 .../util/nio/GridNioEmbeddedFuture.java         |    72 +
 .../internal/util/nio/GridNioException.java     |    58 +
 .../ignite/internal/util/nio/GridNioFilter.java |   244 +
 .../internal/util/nio/GridNioFilterAdapter.java |   183 +
 .../internal/util/nio/GridNioFilterChain.java   |   292 +
 .../util/nio/GridNioFinishedFuture.java         |   116 +
 .../ignite/internal/util/nio/GridNioFuture.java |   120 +
 .../internal/util/nio/GridNioFutureImpl.java    |   326 +
 .../internal/util/nio/GridNioMessageReader.java |    42 +
 .../util/nio/GridNioMessageTracker.java         |   121 +
 .../internal/util/nio/GridNioMessageWriter.java |    49 +
 .../util/nio/GridNioMetricsListener.java        |    33 +
 .../ignite/internal/util/nio/GridNioParser.java |    62 +
 .../util/nio/GridNioRecoveryDescriptor.java     |   364 +
 .../ignite/internal/util/nio/GridNioServer.java |  2305 +++
 .../internal/util/nio/GridNioServerBuffer.java  |   117 +
 .../util/nio/GridNioServerListener.java         |    64 +
 .../util/nio/GridNioServerListenerAdapter.java  |    33 +
 .../internal/util/nio/GridNioSession.java       |   168 +
 .../internal/util/nio/GridNioSessionImpl.java   |   312 +
 .../util/nio/GridNioSessionMetaKey.java         |    66 +
 .../util/nio/GridSelectorNioSessionImpl.java    |   297 +
 .../util/nio/GridShmemCommunicationClient.java  |   148 +
 .../util/nio/GridTcpCommunicationClient.java    |   555 +
 .../util/nio/GridTcpNioCommunicationClient.java |   163 +
 .../ignite/internal/util/nio/package.html       |    23 +
 .../internal/util/nio/ssl/GridNioSslFilter.java |   418 +
 .../util/nio/ssl/GridNioSslHandler.java         |   615 +
 .../ignite/internal/util/nio/ssl/package.html   |    23 +
 .../util/nodestart/GridNodeCallable.java        |    29 +
 .../util/nodestart/GridNodeStartUtils.java      |   390 +
 .../nodestart/GridRemoteStartSpecification.java |   279 +
 .../util/nodestart/IgniteSshProcessor.java      |    34 +
 .../internal/util/offheap/GridOffHeapEvent.java |    47 +
 .../util/offheap/GridOffHeapEventListener.java  |    26 +
 .../util/offheap/GridOffHeapEvictListener.java  |    33 +
 .../internal/util/offheap/GridOffHeapMap.java   |   200 +
 .../util/offheap/GridOffHeapMapFactory.java     |   225 +
 .../GridOffHeapOutOfMemoryException.java        |    50 +
 .../util/offheap/GridOffHeapPartitionedMap.java |   218 +
 .../offheap/unsafe/GridOffHeapSmartPointer.java |    38 +
 .../unsafe/GridOffHeapSmartPointerFactory.java  |    29 +
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |  4457 ++++++
 .../unsafe/GridUnsafeCompoundMemory.java        |    35 +
 .../util/offheap/unsafe/GridUnsafeGuard.java    |   374 +
 .../util/offheap/unsafe/GridUnsafeLru.java      |   627 +
 .../offheap/unsafe/GridUnsafeLruPoller.java     |    30 +
 .../util/offheap/unsafe/GridUnsafeMap.java      |  1743 +++
 .../util/offheap/unsafe/GridUnsafeMemory.java   |   721 +
 .../unsafe/GridUnsafePartitionedMap.java        |   423 +
 .../apache/ignite/internal/util/package.html    |    24 +
 .../util/portable/PortableRawReaderEx.java      |    32 +
 .../util/portable/PortableRawWriterEx.java      |    43 +
 .../util/portscanner/GridJmxPortFinder.java     |   176 +
 .../internal/util/portscanner/package.html      |    23 +
 .../apache/ignite/internal/util/scala/impl.java |    35 +
 .../ignite/internal/util/scala/package.html     |    24 +
 .../util/snaptree/CopyOnWriteManager.java       |   390 +
 .../ignite/internal/util/snaptree/Epoch.java    |   131 +
 .../internal/util/snaptree/EpochNode.java       |   432 +
 .../internal/util/snaptree/SnapTreeMap.java     |  2897 ++++
 .../ignite/internal/util/snaptree/package.html  |    24 +
 .../internal/util/test/GridTestPrintStream.java |   293 +
 .../util/test/GridTestPrintStreamFactory.java   |   128 +
 .../ignite/internal/util/test/package.html      |    24 +
 .../util/tostring/GridToStringBuilder.java      |   588 +
 .../tostring/GridToStringClassDescriptor.java   |    85 +
 .../util/tostring/GridToStringExclude.java      |    32 +
 .../tostring/GridToStringFieldDescriptor.java   |    53 +
 .../util/tostring/GridToStringInclude.java      |    32 +
 .../util/tostring/GridToStringOrder.java        |    37 +
 .../util/tostring/GridToStringThreadLocal.java  |    55 +
 .../ignite/internal/util/tostring/package.html  |    23 +
 .../apache/ignite/internal/util/typedef/C1.java |    32 +
 .../apache/ignite/internal/util/typedef/C2.java |    33 +
 .../apache/ignite/internal/util/typedef/C3.java |    35 +
 .../apache/ignite/internal/util/typedef/CA.java |    32 +
 .../ignite/internal/util/typedef/CAX.java       |    32 +
 .../ignite/internal/util/typedef/CI1.java       |    31 +
 .../ignite/internal/util/typedef/CI2.java       |    32 +
 .../ignite/internal/util/typedef/CI3.java       |    32 +
 .../ignite/internal/util/typedef/CIX1.java      |    33 +
 .../ignite/internal/util/typedef/CIX2.java      |    32 +
 .../ignite/internal/util/typedef/CIX3.java      |    29 +
 .../apache/ignite/internal/util/typedef/CO.java |    31 +
 .../ignite/internal/util/typedef/COX.java       |    33 +
 .../ignite/internal/util/typedef/CX1.java       |    34 +
 .../ignite/internal/util/typedef/CX2.java       |    35 +
 .../ignite/internal/util/typedef/CX3.java       |    33 +
 .../apache/ignite/internal/util/typedef/F.java  |    29 +
 .../apache/ignite/internal/util/typedef/G.java  |    29 +
 .../apache/ignite/internal/util/typedef/P1.java |    31 +
 .../apache/ignite/internal/util/typedef/P2.java |    32 +
 .../apache/ignite/internal/util/typedef/P3.java |    32 +
 .../apache/ignite/internal/util/typedef/PA.java |    29 +
 .../ignite/internal/util/typedef/PAX.java       |    29 +
 .../ignite/internal/util/typedef/PCE.java       |    33 +
 .../apache/ignite/internal/util/typedef/PE.java |    33 +
 .../ignite/internal/util/typedef/PKV.java       |    31 +
 .../apache/ignite/internal/util/typedef/PN.java |    33 +
 .../ignite/internal/util/typedef/PX1.java       |    33 +
 .../ignite/internal/util/typedef/PX2.java       |    34 +
 .../ignite/internal/util/typedef/PX3.java       |    32 +
 .../apache/ignite/internal/util/typedef/R1.java |    32 +
 .../apache/ignite/internal/util/typedef/R2.java |    31 +
 .../apache/ignite/internal/util/typedef/R3.java |    31 +
 .../ignite/internal/util/typedef/RX1.java       |    34 +
 .../ignite/internal/util/typedef/RX2.java       |    34 +
 .../ignite/internal/util/typedef/RX3.java       |    34 +
 .../apache/ignite/internal/util/typedef/T1.java |    51 +
 .../apache/ignite/internal/util/typedef/T2.java |    52 +
 .../apache/ignite/internal/util/typedef/T3.java |    52 +
 .../apache/ignite/internal/util/typedef/T4.java |    53 +
 .../apache/ignite/internal/util/typedef/T5.java |    54 +
 .../apache/ignite/internal/util/typedef/T6.java |    55 +
 .../apache/ignite/internal/util/typedef/X.java  |   936 ++
 .../internal/util/typedef/internal/A.java       |    28 +
 .../internal/util/typedef/internal/CU.java      |    30 +
 .../internal/util/typedef/internal/D.java       |    28 +
 .../internal/util/typedef/internal/GPC.java     |    27 +
 .../internal/util/typedef/internal/GPR.java     |    27 +
 .../internal/util/typedef/internal/LT.java      |    28 +
 .../internal/util/typedef/internal/S.java       |    28 +
 .../internal/util/typedef/internal/SB.java      |    63 +
 .../internal/util/typedef/internal/U.java       |    28 +
 .../internal/util/typedef/internal/package.html |    23 +
 .../ignite/internal/util/typedef/package.html   |    23 +
 .../ignite/internal/util/worker/GridWorker.java |   304 +
 .../internal/util/worker/GridWorkerFuture.java  |    70 +
 .../util/worker/GridWorkerListener.java         |    35 +
 .../util/worker/GridWorkerListenerAdapter.java  |    33 +
 .../internal/util/worker/GridWorkerPool.java    |   116 +
 .../ignite/internal/util/worker/package.html    |    24 +
 .../apache/ignite/internal/visor/VisorJob.java  |    77 +
 .../internal/visor/VisorMultiNodeTask.java      |   127 +
 .../ignite/internal/visor/VisorOneNodeTask.java |    42 +
 .../internal/visor/VisorTaskArgument.java       |   106 +
 .../ignite/internal/visor/cache/VisorCache.java |   484 +
 .../cache/VisorCacheAffinityConfiguration.java  |   171 +
 .../cache/VisorCacheAggregatedMetrics.java      |   471 +
 .../visor/cache/VisorCacheClearTask.java        |    88 +
 .../visor/cache/VisorCacheCompactTask.java      |    86 +
 .../visor/cache/VisorCacheConfiguration.java    |   664 +
 .../cache/VisorCacheDefaultConfiguration.java   |   158 +
 .../visor/cache/VisorCacheDgcConfiguration.java |    97 +
 .../cache/VisorCacheEvictionConfiguration.java  |   215 +
 .../visor/cache/VisorCacheLoadTask.java         |    88 +
 .../visor/cache/VisorCacheMetadataTask.java     |    76 +
 .../internal/visor/cache/VisorCacheMetrics.java |   270 +
 .../cache/VisorCacheMetricsCollectorTask.java   |   112 +
 .../cache/VisorCacheNearConfiguration.java      |   123 +
 .../cache/VisorCachePreloadConfiguration.java   |   155 +
 .../visor/cache/VisorCachePreloadTask.java      |    77 +
 .../visor/cache/VisorCacheQueryMetrics.java     |   102 +
 .../visor/cache/VisorCacheResetMetricsTask.java |    69 +
 .../cache/VisorCacheStoreConfiguration.java     |    90 +
 .../visor/cache/VisorCacheSwapBackupsTask.java  |    90 +
 .../VisorCacheWriteBehindConfiguration.java     |   137 +
 .../compute/VisorComputeCancelSessionsTask.java |    89 +
 .../compute/VisorComputeMonitoringHolder.java   |   118 +
 .../compute/VisorComputeResetMetricsTask.java   |    65 +
 .../VisorComputeToggleMonitoringTask.java       |   112 +
 .../visor/debug/VisorThreadDumpTask.java        |    75 +
 .../internal/visor/debug/VisorThreadInfo.java   |   328 +
 .../visor/debug/VisorThreadLockInfo.java        |    73 +
 .../visor/debug/VisorThreadMonitorInfo.java     |    72 +
 .../event/VisorGridAuthenticationEvent.java     |   106 +
 .../event/VisorGridAuthorizationEvent.java      |    89 +
 .../visor/event/VisorGridDeploymentEvent.java   |    74 +
 .../visor/event/VisorGridDiscoveryEvent.java    |   100 +
 .../internal/visor/event/VisorGridEvent.java    |   130 +
 .../visor/event/VisorGridEventsLost.java        |    45 +
 .../internal/visor/event/VisorGridJobEvent.java |   113 +
 .../visor/event/VisorGridLicenseEvent.java      |    74 +
 .../event/VisorGridSecuritySessionEvent.java    |    91 +
 .../visor/event/VisorGridTaskEvent.java         |   113 +
 .../internal/visor/file/VisorFileBlock.java     |   114 +
 .../internal/visor/file/VisorFileBlockTask.java |   126 +
 .../visor/file/VisorLatestTextFilesTask.java    |    98 +
 .../ignite/internal/visor/ggfs/VisorGgfs.java   |   113 +
 .../internal/visor/ggfs/VisorGgfsEndpoint.java  |   106 +
 .../visor/ggfs/VisorGgfsFormatTask.java         |    70 +
 .../internal/visor/ggfs/VisorGgfsMetrics.java   |   350 +
 .../internal/visor/ggfs/VisorGgfsProfiler.java  |    88 +
 .../visor/ggfs/VisorGgfsProfilerClearTask.java  |   111 +
 .../visor/ggfs/VisorGgfsProfilerEntry.java      |   238 +
 .../visor/ggfs/VisorGgfsProfilerTask.java       |   504 +
 .../VisorGgfsProfilerUniformityCounters.java    |   197 +
 .../visor/ggfs/VisorGgfsResetMetricsTask.java   |    73 +
 .../visor/ggfs/VisorGgfsSamplingStateTask.java  |    74 +
 .../ignite/internal/visor/log/VisorLogFile.java |    87 +
 .../visor/log/VisorLogSearchResult.java         |   156 +
 .../internal/visor/log/VisorLogSearchTask.java  |   270 +
 .../internal/visor/misc/VisorAckTask.java       |    76 +
 .../visor/misc/VisorLatestVersionTask.java      |    63 +
 .../internal/visor/misc/VisorNopTask.java       |    90 +
 .../visor/misc/VisorResolveHostNameTask.java    |   104 +
 .../visor/node/VisorBasicConfiguration.java     |   451 +
 .../visor/node/VisorEmailConfiguration.java     |   177 +
 .../node/VisorExecutorServiceConfiguration.java |   200 +
 .../visor/node/VisorGgfsConfiguration.java      |   573 +
 .../visor/node/VisorGridConfiguration.java      |   361 +
 .../visor/node/VisorLifecycleConfiguration.java |    87 +
 .../visor/node/VisorMetricsConfiguration.java   |    95 +
 .../VisorNodeConfigurationCollectorJob.java     |    47 +
 .../VisorNodeConfigurationCollectorTask.java    |    35 +
 .../visor/node/VisorNodeDataCollectorJob.java   |   218 +
 .../node/VisorNodeDataCollectorJobResult.java   |   158 +
 .../visor/node/VisorNodeDataCollectorTask.java  |   127 +
 .../node/VisorNodeDataCollectorTaskArg.java     |   140 +
 .../node/VisorNodeDataCollectorTaskResult.java  |   184 +
 .../node/VisorNodeEventsCollectorTask.java      |   365 +
 .../internal/visor/node/VisorNodeGcTask.java    |   100 +
 .../internal/visor/node/VisorNodePingTask.java  |    81 +
 .../visor/node/VisorNodeRestartTask.java        |    78 +
 .../internal/visor/node/VisorNodeStopTask.java  |    78 +
 .../node/VisorPeerToPeerConfiguration.java      |   105 +
 .../visor/node/VisorRestConfiguration.java      |   221 +
 .../node/VisorSegmentationConfiguration.java    |   141 +
 .../visor/node/VisorSpisConfiguration.java      |   334 +
 .../visor/portable/VisorPortableMetadata.java   |    72 +
 .../VisorPortableMetadataCollectorTask.java     |    94 +
 .../portable/VisorPortableMetadataField.java    |    71 +
 .../visor/query/VisorQueryCleanupTask.java      |   102 +
 .../internal/visor/query/VisorQueryField.java   |    66 +
 .../visor/query/VisorQueryNextPageTask.java     |   117 +
 .../internal/visor/query/VisorQueryResult.java  |    79 +
 .../visor/query/VisorQueryResultEx.java         |    88 +
 .../internal/visor/query/VisorQueryTask.java    |   310 +
 .../internal/visor/query/VisorQueryUtils.java   |   204 +
 .../internal/visor/streamer/VisorStreamer.java  |   104 +
 .../streamer/VisorStreamerConfiguration.java    |   178 +
 .../visor/streamer/VisorStreamerMetrics.java    |   350 +
 .../streamer/VisorStreamerMetricsResetTask.java |    75 +
 .../visor/streamer/VisorStreamerResetTask.java  |    75 +
 .../streamer/VisorStreamerStageMetrics.java     |   277 +
 .../internal/visor/util/VisorMimeTypes.java     |  1004 ++
 .../internal/visor/util/VisorTaskUtils.java     |   830 ++
 .../ignite/jdbc/IgniteJdbcConnection.java       |   547 +
 .../ignite/jdbc/IgniteJdbcConnectionInfo.java   |    91 +
 .../ignite/jdbc/IgniteJdbcDatabaseMetadata.java |  1314 ++
 .../apache/ignite/jdbc/IgniteJdbcDriver.java    |   482 +
 .../jdbc/IgniteJdbcPreparedStatement.java       |   411 +
 .../apache/ignite/jdbc/IgniteJdbcResultSet.java |  1520 ++
 .../jdbc/IgniteJdbcResultSetMetadata.java       |   172 +
 .../apache/ignite/jdbc/IgniteJdbcStatement.java |   449 +
 .../java/org/apache/ignite/jdbc/package.html    |    23 +
 .../java/org/apache/ignite/jdbc/typedef/JU.java |    28 +
 .../org/apache/ignite/jdbc/typedef/package.html |    23 +
 .../ignite/jdbc/util/IgniteJdbcUtils.java       |   232 +
 .../org/apache/ignite/jdbc/util/package.html    |    23 +
 .../org/apache/ignite/lang/IgniteBiTuple.java   |     6 +-
 .../org/apache/ignite/lang/IgniteFuture.java    |     7 +-
 .../org/apache/ignite/lang/IgnitePredicate.java |     4 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java |     6 +-
 .../ignite/logger/java/IgniteJavaLogger.java    |     4 +-
 .../java/IgniteJavaLoggerFileHandler.java       |     4 +-
 .../logger/java/IgniteJavaLoggerFormatter.java  |     2 +-
 .../managed/ManagedServiceConfiguration.java    |     4 +-
 .../marshaller/IgniteAbstractMarshaller.java    |     6 +-
 .../ignite/marshaller/IgniteMarshaller.java     |     2 +-
 .../marshaller/IgniteMarshallerExclusions.java  |     8 +-
 .../marshaller/jdk/IgniteJdkMarshaller.java     |     4 +-
 .../IgniteOptimizedClassDescriptor.java         |     4 +-
 .../optimized/IgniteOptimizedClassResolver.java |     6 +-
 .../optimized/IgniteOptimizedMarshaller.java    |     8 +-
 .../IgniteOptimizedMarshallerUtils.java         |     4 +-
 .../IgniteOptimizedObjectInputStream.java       |     8 +-
 .../IgniteOptimizedObjectOutputStream.java      |     6 +-
 .../IgniteOptimizedObjectStreamRegistry.java    |    19 +-
 .../ignite/mbean/IgniteStandardMBean.java       |     2 +-
 .../ignite/messaging/MessagingListenActor.java  |     3 +-
 .../main/java/org/apache/ignite/package.html    |    23 +
 .../org/apache/ignite/plugin/PluginContext.java |     2 +-
 .../plugin/PluginValidationException.java       |     1 -
 .../security/GridSecurityCredentials.java       |     6 +-
 .../ignite/portables/PortableConfiguration.java |     2 +-
 .../apache/ignite/portables/PortableObject.java |     6 +-
 .../portables/PortableTypeConfiguration.java    |     2 +-
 .../product/IgniteProductLicenseException.java  |     2 +-
 .../ignite/product/IgniteProductVersion.java    |     2 +-
 .../ignite/scheduler/SchedulerFuture.java       |     7 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |    12 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |     6 +-
 .../org/apache/ignite/spi/IgniteSpiThread.java  |     2 +-
 .../noop/NoopAuthenticationSpi.java             |     6 +-
 .../checkpoint/cache/CacheCheckpointSpi.java    |     7 +-
 .../spi/checkpoint/jdbc/JdbcCheckpointSpi.java  |     4 +-
 .../spi/checkpoint/noop/NoopCheckpointSpi.java  |     2 +-
 .../sharedfs/SharedFsCheckpointData.java        |     2 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |     4 +-
 .../checkpoint/sharedfs/SharedFsTimeData.java   |     2 +-
 .../sharedfs/SharedFsTimeoutTask.java           |     3 +-
 .../spi/checkpoint/sharedfs/SharedFsUtils.java  |     3 +-
 .../fifoqueue/FifoQueueCollisionSpi.java        |     2 +-
 .../jobstealing/JobStealingCollisionSpi.java    |    10 +-
 .../jobstealing/JobStealingRequest.java         |     4 +-
 .../spi/collision/noop/NoopCollisionSpi.java    |     2 +-
 .../PriorityQueueCollisionSpi.java              |     4 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    25 +-
 .../deployment/DeploymentResourceAdapter.java   |     2 +-
 .../deployment/local/LocalDeploymentSpi.java    |     6 +-
 .../spi/discovery/DiscoveryMetricsHelper.java   |     2 +-
 .../spi/discovery/DiscoveryMetricsProvider.java |     2 +-
 .../discovery/DiscoveryNodeMetricsAdapter.java  |     4 +-
 .../DiscoverySpiNodeAuthenticator.java          |     2 +-
 .../discovery/tcp/TcpClientDiscoverySpi.java    |    15 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    27 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |    13 +-
 .../tcp/internal/TcpDiscoveryNode.java          |    12 +-
 .../tcp/internal/TcpDiscoveryNodesRing.java     |     6 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |     8 +-
 .../ipfinder/TcpDiscoveryIpFinderAdapter.java   |     4 +-
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |     9 +-
 .../TcpDiscoveryMulticastIpFinder.java          |     9 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |     9 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |     6 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |     4 +-
 .../messages/TcpDiscoveryAuthFailedMessage.java |     2 +-
 .../TcpDiscoveryCheckFailedMessage.java         |     2 +-
 .../TcpDiscoveryClientReconnectMessage.java     |     4 +-
 .../messages/TcpDiscoveryDiscardMessage.java    |     2 +-
 .../TcpDiscoveryDuplicateIdMessage.java         |     2 +-
 .../messages/TcpDiscoveryHandshakeRequest.java  |     2 +-
 .../messages/TcpDiscoveryHandshakeResponse.java |     2 +-
 .../messages/TcpDiscoveryHeartbeatMessage.java  |     6 +-
 .../TcpDiscoveryJoinRequestMessage.java         |     2 +-
 .../TcpDiscoveryLoopbackProblemMessage.java     |     2 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |     2 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |     4 +-
 .../messages/TcpDiscoveryNodeFailedMessage.java |     2 +-
 .../messages/TcpDiscoveryNodeLeftMessage.java   |     2 +-
 .../tcp/messages/TcpDiscoveryPingRequest.java   |     2 +-
 .../TcpDiscoveryStatusCheckMessage.java         |     2 +-
 .../memory/MemoryEventStorageSpi.java           |     4 +-
 .../spi/failover/always/AlwaysFailoverSpi.java  |     5 +-
 .../jobstealing/JobStealingFailoverSpi.java     |     5 +-
 .../spi/failover/never/NeverFailoverSpi.java    |     2 +-
 .../adaptive/AdaptiveCpuLoadProbe.java          |     2 +-
 .../adaptive/AdaptiveJobCountLoadProbe.java     |     2 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |     7 +-
 .../AdaptiveProcessingTimeLoadProbe.java        |     2 +-
 .../RoundRobinGlobalLoadBalancer.java           |     7 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |     5 +-
 .../WeightedRandomLoadBalancingSpi.java         |     6 +-
 .../noop/NoopSecureSessionSpi.java              |     2 +-
 .../ignite/spi/swapspace/SwapContext.java       |     2 +-
 .../apache/ignite/spi/swapspace/SwapKey.java    |     4 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |    13 +-
 .../spi/swapspace/noop/NoopSwapSpaceSpi.java    |     4 +-
 .../startup/cmdline/CommandLineStartup.java     |    10 +-
 .../ignite/streamer/StreamerConfiguration.java  |     4 +-
 .../streamer/StreamerEventRouterAdapter.java    |     4 +-
 .../index/StreamerIndexProviderAdapter.java     |     6 +-
 .../streamer/index/StreamerIndexUpdateSync.java |     2 +-
 .../index/hash/StreamerHashIndexProvider.java   |     4 +-
 .../index/tree/StreamerTreeIndexProvider.java   |     6 +-
 .../router/StreamerAffinityEventRouter.java     |     6 +-
 .../StreamerCacheAffinityEventRouter.java       |     4 +-
 .../router/StreamerLocalEventRouter.java        |     2 +-
 .../router/StreamerRandomEventRouter.java       |     2 +-
 .../window/StreamerBoundedSizeBatchWindow.java  |    19 +-
 .../window/StreamerBoundedSizeSortedWindow.java |     6 +-
 .../window/StreamerBoundedSizeWindow.java       |     2 +-
 .../StreamerBoundedSizeWindowAdapter.java       |     6 +-
 .../window/StreamerBoundedTimeBatchWindow.java  |    19 +-
 .../window/StreamerBoundedTimeWindow.java       |     8 +-
 .../window/StreamerUnboundedWindow.java         |     2 +-
 .../streamer/window/StreamerWindowAdapter.java  |     8 +-
 .../thread/IgniteStripedThreadPoolExecutor.java |     2 +-
 .../org/apache/ignite/thread/IgniteThread.java  |     4 +-
 .../apache/ignite/transactions/IgniteTx.java    |    15 +-
 .../transactions/IgniteTxSynchronization.java   |     3 +-
 .../java/org/gridgain/client/GridClient.java    |   148 -
 .../GridClientAuthenticationException.java      |    35 -
 .../gridgain/client/GridClientCacheFlag.java    |    65 -
 .../gridgain/client/GridClientCacheMode.java    |    32 -
 .../client/GridClientClosedException.java       |    35 -
 .../org/gridgain/client/GridClientCompute.java  |   476 -
 .../client/GridClientConfiguration.java         |   868 --
 .../org/gridgain/client/GridClientData.java     |   443 -
 .../gridgain/client/GridClientDataAffinity.java |    39 -
 .../client/GridClientDataConfiguration.java     |   118 -
 .../gridgain/client/GridClientDataMetrics.java  |    77 -
 .../client/GridClientDisconnectedException.java |    36 -
 .../gridgain/client/GridClientException.java    |   111 -
 .../org/gridgain/client/GridClientFactory.java  |   138 -
 .../org/gridgain/client/GridClientFuture.java   |    68 -
 .../client/GridClientFutureListener.java        |    30 -
 .../GridClientFutureTimeoutException.java       |    45 -
 .../client/GridClientHandshakeException.java    |    48 -
 .../org/gridgain/client/GridClientNode.java     |   152 -
 .../gridgain/client/GridClientNodeMetrics.java  |   524 -
 .../client/GridClientPartitionAffinity.java     |   369 -
 .../gridgain/client/GridClientPredicate.java    |    38 -
 .../org/gridgain/client/GridClientProtocol.java |    30 -
 .../client/GridClientTopologyListener.java      |    41 -
 .../client/GridServerUnreachableException.java  |    45 -
 .../balancer/GridClientBalancerAdapter.java     |    76 -
 .../client/balancer/GridClientLoadBalancer.java |    44 -
 .../balancer/GridClientRandomBalancer.java      |    75 -
 .../balancer/GridClientRoundRobinBalancer.java  |   111 -
 .../org/gridgain/client/balancer/package.html   |    24 -
 .../impl/GridClientAbstractProjection.java      |   458 -
 .../client/impl/GridClientAndPredicate.java     |    52 -
 .../client/impl/GridClientComputeImpl.java      |   293 -
 .../client/impl/GridClientDataImpl.java         |   389 -
 .../impl/GridClientDataMetricsAdapter.java      |   160 -
 .../client/impl/GridClientFutureAdapter.java    |   349 -
 .../client/impl/GridClientFutureCallback.java   |    35 -
 .../gridgain/client/impl/GridClientImpl.java    |   524 -
 .../client/impl/GridClientNodeImpl.java         |   411 -
 .../impl/GridClientNodeMetricsAdapter.java      |   990 --
 .../client/impl/GridClientThreadFactory.java    |    62 -
 .../impl/connection/GridClientConnection.java   |   531 -
 .../GridClientConnectionCloseReason.java        |    32 -
 .../connection/GridClientConnectionManager.java |    71 -
 .../GridClientConnectionManagerAdapter.java     |   764 -
 .../GridClientConnectionManagerOsImpl.java      |    47 -
 .../GridClientConnectionResetException.java     |    48 -
 .../connection/GridClientNioTcpConnection.java  |  1160 --
 .../impl/connection/GridClientTopology.java     |   450 -
 .../GridConnectionIdleClosedException.java      |    36 -
 .../java/org/gridgain/client/impl/package.html  |    23 -
 .../client/marshaller/GridClientMarshaller.java |    45 -
 .../marshaller/jdk/GridClientJdkMarshaller.java |    68 -
 .../gridgain/client/marshaller/jdk/package.html |    24 -
 .../GridClientOptimizedMarshaller.java          |   104 -
 .../client/marshaller/optimized/package.html    |    24 -
 .../org/gridgain/client/marshaller/package.html |    23 -
 .../main/java/org/gridgain/client/package.html  |    23 -
 .../client/router/GridRouterFactory.java        |   121 -
 .../gridgain/client/router/GridTcpRouter.java   |    76 -
 .../router/GridTcpRouterConfiguration.java      |   306 -
 .../client/router/GridTcpRouterMBean.java       |    88 -
 .../router/impl/GridRouterClientImpl.java       |   200 -
 .../impl/GridRouterCommandLineStartup.java      |   165 -
 .../client/router/impl/GridTcpRouterImpl.java   |   349 -
 .../impl/GridTcpRouterNioListenerAdapter.java   |   203 -
 .../impl/GridTcpRouterNioListenerOsImpl.java    |    38 -
 .../router/impl/GridTcpRouterNioParser.java     |   109 -
 .../gridgain/client/router/impl/package.html    |    23 -
 .../org/gridgain/client/router/package.html     |    23 -
 .../client/ssl/GridSslBasicContextFactory.java  |   438 -
 .../client/ssl/GridSslContextFactory.java       |    36 -
 .../java/org/gridgain/client/ssl/package.html   |    24 -
 .../client/util/GridClientConsistentHash.java   |   440 -
 .../client/util/GridClientStripedLock.java      |   135 -
 .../gridgain/client/util/GridClientUtils.java   |   172 -
 .../client/util/GridConcurrentHashSet.java      |   113 -
 .../java/org/gridgain/client/util/package.html  |    24 -
 .../grid/GridAuthenticationException.java       |    37 -
 .../gridgain/grid/GridBasicWarmupClosure.java   |   562 -
 .../gridgain/grid/GridDeploymentException.java  |    58 -
 .../grid/GridIllegalStateException.java         |    84 -
 .../gridgain/grid/GridInterruptedException.java |    58 -
 .../gridgain/grid/GridNotPeerDeployable.java    |    41 -
 .../java/org/gridgain/grid/cache/GridCache.java |   280 -
 .../GridCacheAtomicUpdateTimeoutException.java  |    47 -
 .../cache/GridCacheAtomicWriteOrderMode.java    |    64 -
 .../grid/cache/GridCacheAtomicityMode.java      |    80 -
 .../grid/cache/GridCacheDistributionMode.java   |    70 -
 .../org/gridgain/grid/cache/GridCacheEntry.java |   622 -
 .../org/gridgain/grid/cache/GridCacheFlag.java  |   111 -
 .../grid/cache/GridCacheFlagException.java      |    67 -
 .../grid/cache/GridCacheInterceptor.java        |   121 -
 .../grid/cache/GridCacheInterceptorAdapter.java |    52 -
 .../org/gridgain/grid/cache/GridCacheMBean.java |   296 -
 .../grid/cache/GridCacheMemoryMode.java         |    61 -
 .../gridgain/grid/cache/GridCacheMetrics.java   |   103 -
 .../org/gridgain/grid/cache/GridCacheMode.java  |    75 -
 .../org/gridgain/grid/cache/GridCacheName.java  |    43 -
 .../cache/GridCachePartialUpdateException.java  |    64 -
 .../gridgain/grid/cache/GridCachePeekMode.java  |    85 -
 .../grid/cache/GridCachePreloadMode.java        |    69 -
 .../grid/cache/GridCacheProjection.java         |  1914 ---
 .../GridCacheWriteSynchronizationMode.java      |    69 -
 .../grid/cache/affinity/GridCacheAffinity.java  |   262 -
 .../affinity/GridCacheAffinityFunction.java     |   112 -
 .../GridCacheAffinityFunctionContext.java       |    71 -
 .../cache/affinity/GridCacheAffinityKey.java    |   189 -
 .../affinity/GridCacheAffinityKeyMapped.java    |   158 -
 .../affinity/GridCacheAffinityKeyMapper.java    |    64 -
 ...ridCacheAffinityNodeAddressHashResolver.java |    39 -
 .../GridCacheAffinityNodeHashResolver.java      |    43 -
 .../GridCacheAffinityNodeIdHashResolver.java    |    40 -
 .../GridCacheCentralizedAffinityFunction.java   |    31 -
 ...GridCacheConsistentHashAffinityFunction.java |   703 -
 .../cache/affinity/consistenthash/package.html  |    24 -
 .../fair/GridCachePartitionFairAffinity.java    |   805 -
 .../grid/cache/affinity/fair/package.html       |    24 -
 .../gridgain/grid/cache/affinity/package.html   |    24 -
 .../GridCacheRendezvousAffinityFunction.java    |   502 -
 .../grid/cache/affinity/rendezvous/package.html |    23 -
 .../grid/cache/cloner/GridCacheBasicCloner.java |    34 -
 .../grid/cache/cloner/GridCacheCloner.java      |    59 -
 .../grid/cache/cloner/GridCacheDeepCloner.java  |    87 -
 .../org/gridgain/grid/cache/cloner/package.html |    24 -
 .../datastructures/GridCacheAtomicLong.java     |   157 -
 .../GridCacheAtomicReference.java               |    93 -
 .../datastructures/GridCacheAtomicSequence.java |   130 -
 .../datastructures/GridCacheAtomicStamped.java  |   121 -
 .../datastructures/GridCacheCountDownLatch.java |   227 -
 .../GridCacheDataStructureInvalidException.java |    66 -
 ...cheDataStructureInvalidRuntimeException.java |    66 -
 .../GridCacheDataStructureRemovedException.java |    61 -
 ...cheDataStructureRemovedRuntimeException.java |    61 -
 .../datastructures/GridCacheDataStructures.java |   221 -
 .../cache/datastructures/GridCacheQueue.java    |   182 -
 .../grid/cache/datastructures/GridCacheSet.java |    61 -
 .../grid/cache/datastructures/package.html      |    24 -
 .../cache/eviction/GridCacheEvictionFilter.java |    41 -
 .../cache/eviction/GridCacheEvictionPolicy.java |    56 -
 .../fifo/GridCacheFifoEvictionPolicy.java       |   210 -
 .../fifo/GridCacheFifoEvictionPolicyMBean.java  |    58 -
 .../grid/cache/eviction/fifo/package.html       |    23 -
 .../ggfs/GridCacheGgfsEvictionFilter.java       |    34 -
 .../GridCacheGgfsPerBlockLruEvictionPolicy.java |   353 -
 ...CacheGgfsPerBlockLruEvictionPolicyMBean.java |    93 -
 .../grid/cache/eviction/ggfs/package.html       |    23 -
 .../lru/GridCacheLruEvictionPolicy.java         |   194 -
 .../lru/GridCacheLruEvictionPolicyMBean.java    |    58 -
 .../grid/cache/eviction/lru/package.html        |    23 -
 .../gridgain/grid/cache/eviction/package.html   |    23 -
 .../random/GridCacheRandomEvictionPolicy.java   |   121 -
 .../GridCacheRandomEvictionPolicyMBean.java     |    42 -
 .../grid/cache/eviction/random/package.html     |    23 -
 .../java/org/gridgain/grid/cache/package.html   |    24 -
 .../cache/query/GridCacheContinuousQuery.java   |   342 -
 .../query/GridCacheContinuousQueryEntry.java    |    49 -
 .../grid/cache/query/GridCacheQueries.java      |   151 -
 .../grid/cache/query/GridCacheQuery.java        |   297 -
 .../query/GridCacheQueryConfiguration.java      |   203 -
 .../grid/cache/query/GridCacheQueryFuture.java  |    66 -
 .../cache/query/GridCacheQueryGroupIndex.java   |    58 -
 .../grid/cache/query/GridCacheQueryMetrics.java |    60 -
 .../cache/query/GridCacheQuerySqlField.java     |   133 -
 .../cache/query/GridCacheQuerySqlFunction.java  |    69 -
 .../cache/query/GridCacheQueryTextField.java    |    33 -
 .../grid/cache/query/GridCacheQueryType.java    |    47 -
 .../cache/query/GridCacheQueryTypeMetadata.java |   196 -
 .../cache/query/GridCacheQueryTypeResolver.java |    32 -
 .../org/gridgain/grid/cache/query/package.html  |    23 -
 .../grid/dotnet/GridDotNetConfiguration.java    |   113 -
 .../dotnet/GridDotNetPortableConfiguration.java |   207 -
 .../GridDotNetPortableTypeConfiguration.java    |   219 -
 .../java/org/gridgain/grid/dotnet/package.html  |    23 -
 .../org/gridgain/grid/hadoop/GridHadoop.java    |    86 -
 .../grid/hadoop/GridHadoopConfiguration.java    |   172 -
 .../gridgain/grid/hadoop/GridHadoopCounter.java |    44 -
 .../grid/hadoop/GridHadoopCounterWriter.java    |    36 -
 .../grid/hadoop/GridHadoopCounters.java         |    49 -
 .../grid/hadoop/GridHadoopFileBlock.java        |   162 -
 .../grid/hadoop/GridHadoopInputSplit.java       |    54 -
 .../org/gridgain/grid/hadoop/GridHadoopJob.java |   102 -
 .../gridgain/grid/hadoop/GridHadoopJobId.java   |   102 -
 .../gridgain/grid/hadoop/GridHadoopJobInfo.java |    84 -
 .../grid/hadoop/GridHadoopJobPhase.java         |    38 -
 .../grid/hadoop/GridHadoopJobProperty.java      |   138 -
 .../grid/hadoop/GridHadoopJobStatus.java        |   207 -
 .../grid/hadoop/GridHadoopMapReducePlan.java    |    80 -
 .../grid/hadoop/GridHadoopMapReducePlanner.java |    40 -
 .../grid/hadoop/GridHadoopPartitioner.java      |    33 -
 .../grid/hadoop/GridHadoopSerialization.java    |    54 -
 .../gridgain/grid/hadoop/GridHadoopTask.java    |    73 -
 .../grid/hadoop/GridHadoopTaskContext.java      |   189 -
 .../grid/hadoop/GridHadoopTaskInfo.java         |   153 -
 .../grid/hadoop/GridHadoopTaskInput.java        |    55 -
 .../grid/hadoop/GridHadoopTaskOutput.java       |    40 -
 .../grid/hadoop/GridHadoopTaskType.java         |    56 -
 .../java/org/gridgain/grid/hadoop/package.html  |    24 -
 .../grid/kernal/ClusterGroupAdapter.java        |   852 --
 .../gridgain/grid/kernal/ClusterGroupEx.java    |    35 -
 .../grid/kernal/ClusterLocalNodeMetrics.java    |   311 -
 .../grid/kernal/ClusterMetricsImpl.java         |   813 -
 .../grid/kernal/ClusterNodeLocalMapImpl.java    |   103 -
 .../grid/kernal/ClusterNodeMetricsMBean.java    |    29 -
 .../grid/kernal/GridClosureCallMode.java        |    61 -
 .../org/gridgain/grid/kernal/GridComponent.java |    96 -
 .../gridgain/grid/kernal/GridComponentType.java |   283 -
 .../gridgain/grid/kernal/GridDiagnostic.java    |   172 -
 .../grid/kernal/GridDirectCollection.java       |    32 -
 .../org/gridgain/grid/kernal/GridDirectMap.java |    37 -
 .../grid/kernal/GridDirectTransient.java        |    29 -
 .../gridgain/grid/kernal/GridDirectVersion.java |    32 -
 .../grid/kernal/GridEventConsumeHandler.java    |   416 -
 .../java/org/gridgain/grid/kernal/GridEx.java   |   143 -
 .../org/gridgain/grid/kernal/GridGainEx.java    |  2401 ---
 .../grid/kernal/GridInternalException.java      |    69 -
 .../grid/kernal/GridInternalWrapper.java        |    30 -
 .../grid/kernal/GridJobCancelRequest.java       |   215 -
 .../grid/kernal/GridJobContextImpl.java         |   282 -
 .../grid/kernal/GridJobExecuteRequest.java      |   918 --
 .../grid/kernal/GridJobExecuteRequestV2.java    |   185 -
 .../grid/kernal/GridJobExecuteResponse.java     |   374 -
 .../gridgain/grid/kernal/GridJobResultImpl.java |   182 -
 .../grid/kernal/GridJobSessionImpl.java         |   288 -
 .../grid/kernal/GridJobSiblingImpl.java         |   190 -
 .../grid/kernal/GridJobSiblingsRequest.java     |   175 -
 .../grid/kernal/GridJobSiblingsResponse.java    |   151 -
 .../org/gridgain/grid/kernal/GridKernal.java    |  3310 -----
 .../gridgain/grid/kernal/GridKernalContext.java |   515 -
 .../grid/kernal/GridKernalContextImpl.java      |   906 --
 .../gridgain/grid/kernal/GridKernalGateway.java |   131 -
 .../grid/kernal/GridKernalGatewayImpl.java      |   229 -
 .../gridgain/grid/kernal/GridKernalState.java   |    51 -
 .../org/gridgain/grid/kernal/GridKillTask.java  |   105 -
 .../gridgain/grid/kernal/GridLoggerProxy.java   |   217 -
 .../grid/kernal/GridMessageListenHandler.java   |   201 -
 .../grid/kernal/GridNodeAttributes.java         |   145 -
 .../grid/kernal/GridNodeOrderComparator.java    |    36 -
 .../grid/kernal/GridPerformanceSuggestions.java |    90 -
 .../grid/kernal/GridPluginComponent.java        |    96 -
 .../gridgain/grid/kernal/GridPluginContext.java |   101 -
 .../gridgain/grid/kernal/GridPortablesImpl.java |   174 -
 .../gridgain/grid/kernal/GridProductImpl.java   |   190 -
 .../gridgain/grid/kernal/GridProperties.java    |    82 -
 .../gridgain/grid/kernal/GridProxyListener.java |    51 -
 .../grid/kernal/GridTaskCancelRequest.java      |   134 -
 .../grid/kernal/GridTaskFutureImpl.java         |   122 -
 .../gridgain/grid/kernal/GridTaskMessage.java   |    30 -
 .../grid/kernal/GridTaskNameHashKey.java        |    75 -
 .../grid/kernal/GridTaskSessionImpl.java        |   839 --
 .../grid/kernal/GridTaskSessionInternal.java    |    69 -
 .../grid/kernal/GridTaskSessionRequest.java     |   206 -
 .../org/gridgain/grid/kernal/GridTopic.java     |   829 --
 .../grid/kernal/GridUpdateNotifier.java         |   377 -
 .../grid/kernal/IgniteClusterAsyncImpl.java     |   239 -
 .../gridgain/grid/kernal/IgniteComputeImpl.java |   477 -
 .../gridgain/grid/kernal/IgniteEventsImpl.java  |   300 -
 .../gridgain/grid/kernal/IgniteManagedImpl.java |   265 -
 .../grid/kernal/IgniteMessagingImpl.java        |   222 -
 .../grid/kernal/IgniteSchedulerImpl.java        |   141 -
 .../kernal/IgniteThreadPoolMBeanAdapter.java    |   149 -
 .../grid/kernal/IgniteTransactionsEx.java       |    42 -
 .../grid/kernal/IgnitionMBeanAdapter.java       |    59 -
 .../kernal/executor/GridExecutorService.java    |   735 -
 .../gridgain/grid/kernal/executor/package.html  |    23 -
 .../ggfs/common/GridGgfsControlResponse.java    |   633 -
 .../ggfs/common/GridGgfsDataInputStream.java    |    40 -
 .../ggfs/common/GridGgfsDataOutputStream.java   |    43 -
 .../ggfs/common/GridGgfsHandshakeRequest.java   |    93 -
 .../kernal/ggfs/common/GridGgfsIpcCommand.java  |    98 -
 .../grid/kernal/ggfs/common/GridGgfsLogger.java |   767 -
 .../kernal/ggfs/common/GridGgfsMarshaller.java  |   374 -
 .../kernal/ggfs/common/GridGgfsMessage.java     |    41 -
 .../ggfs/common/GridGgfsPathControlRequest.java |   238 -
 .../ggfs/common/GridGgfsStatusRequest.java      |    35 -
 .../common/GridGgfsStreamControlRequest.java    |   101 -
 .../grid/kernal/ggfs/common/package.html        |    23 -
 .../grid/kernal/managers/GridManager.java       |    46 -
 .../kernal/managers/GridManagerAdapter.java     |   613 -
 .../kernal/managers/GridNoopManagerAdapter.java |    88 -
 .../checkpoint/GridCheckpointManager.java       |   447 -
 .../checkpoint/GridCheckpointRequest.java       |   191 -
 .../kernal/managers/checkpoint/package.html     |    23 -
 .../GridCollisionJobContextAdapter.java         |    62 -
 .../collision/GridCollisionManager.java         |   133 -
 .../grid/kernal/managers/collision/package.html |    23 -
 .../communication/GridDisconnectListener.java   |    34 -
 .../managers/communication/GridIoManager.java   |  2206 ---
 .../managers/communication/GridIoMessage.java   |   361 -
 .../managers/communication/GridIoPolicy.java    |    57 -
 .../communication/GridIoUserMessage.java        |   445 -
 .../communication/GridMessageListener.java      |    34 -
 .../kernal/managers/communication/package.html  |    23 -
 .../managers/deployment/GridDeployment.java     |   775 -
 .../deployment/GridDeploymentClassLoader.java   |   802 -
 .../deployment/GridDeploymentCommunication.java |   486 -
 .../managers/deployment/GridDeploymentInfo.java |    58 -
 .../deployment/GridDeploymentInfoBean.java      |   359 -
 .../deployment/GridDeploymentLocalStore.java    |   558 -
 .../deployment/GridDeploymentManager.java       |   614 -
 .../deployment/GridDeploymentMetadata.java      |   290 -
 .../GridDeploymentPerLoaderStore.java           |   517 -
 .../GridDeploymentPerVersionStore.java          |  1281 --
 .../deployment/GridDeploymentRequest.java       |   336 -
 .../deployment/GridDeploymentResponse.java      |   212 -
 .../deployment/GridDeploymentStore.java         |    98 -
 .../deployment/GridDeploymentStoreAdapter.java  |   159 -
 .../kernal/managers/deployment/package.html     |    23 -
 .../protocol/gg/GridProtocolHandler.java        |    53 -
 .../protocol/gg/GridUrlConnection.java          |    74 -
 .../deployment/protocol/gg/package.html         |    23 -
 .../discovery/GridDiscoveryManager.java         |  2180 ---
 .../GridDiscoveryTopologySnapshot.java          |    62 -
 .../managers/discovery/GridLocalMetrics.java    |   216 -
 .../grid/kernal/managers/discovery/package.html |    23 -
 .../eventstorage/GridEventStorageManager.java   |  1153 --
 .../eventstorage/GridEventStorageMessage.java   |   537 -
 .../eventstorage/GridLocalEventListener.java    |    39 -
 .../kernal/managers/eventstorage/package.html   |    23 -
 .../failover/GridFailoverContextImpl.java       |    82 -
 .../managers/failover/GridFailoverManager.java  |    66 -
 .../grid/kernal/managers/failover/package.html  |    24 -
 .../managers/indexing/GridIndexingManager.java  |   232 -
 .../grid/kernal/managers/indexing/package.html  |    24 -
 .../loadbalancer/GridLoadBalancerAdapter.java   |    50 -
 .../loadbalancer/GridLoadBalancerManager.java   |   163 -
 .../kernal/managers/loadbalancer/package.html   |    23 -
 .../gridgain/grid/kernal/managers/package.html  |    23 -
 .../securesession/GridSecureSession.java        |    54 -
 .../securesession/GridSecureSessionManager.java |    54 -
 .../os/GridOsSecureSessionManager.java          |    56 -
 .../managers/securesession/os/package.html      |    23 -
 .../kernal/managers/securesession/package.html  |    23 -
 .../security/GridAllowAllPermissionSet.java     |    55 -
 .../managers/security/GridSecurityContext.java  |   248 -
 .../managers/security/GridSecurityImpl.java     |    84 -
 .../managers/security/GridSecurityManager.java  |    93 -
 .../security/GridSecuritySubjectAdapter.java    |   131 -
 .../security/os/GridOsSecurityManager.java      |    97 -
 .../kernal/managers/security/os/package.html    |    23 -
 .../grid/kernal/managers/security/package.html  |    23 -
 .../swapspace/GridSwapSpaceManager.java         |   426 -
 .../grid/kernal/managers/swapspace/package.html |    23 -
 .../java/org/gridgain/grid/kernal/package.html  |    24 -
 .../grid/kernal/processors/GridProcessor.java   |    38 -
 .../kernal/processors/GridProcessorAdapter.java |   126 -
 .../affinity/GridAffinityAssignment.java        |   168 -
 .../affinity/GridAffinityAssignmentCache.java   |   409 -
 .../affinity/GridAffinityMessage.java           |   164 -
 .../affinity/GridAffinityProcessor.java         |   528 -
 .../processors/affinity/GridAffinityUtils.java  |   189 -
 .../GridCacheAffinityFunctionContextImpl.java   |    83 -
 .../kernal/processors/affinity/package.html     |    23 -
 .../kernal/processors/cache/CacheEntryImpl.java |    60 -
 .../processors/cache/CacheInvokeEntry.java      |   100 -
 .../processors/cache/CacheInvokeResult.java     |   104 -
 .../cache/CacheStorePartialUpdateException.java |    48 -
 .../processors/cache/GridCacheAdapter.java      |  5340 -------
 .../cache/GridCacheAffinityManager.java         |   378 -
 .../processors/cache/GridCacheAtomicFuture.java |    47 -
 .../cache/GridCacheAtomicVersionComparator.java |    58 -
 .../processors/cache/GridCacheAttributes.java   |   635 -
 .../cache/GridCacheBatchSwapEntry.java          |    89 -
 .../cache/GridCacheClearAllRunnable.java        |   174 -
 .../cache/GridCacheConcurrentMap.java           |  2419 ---
 .../processors/cache/GridCacheContext.java      |  1857 ---
 .../GridCacheDefaultAffinityKeyMapper.java      |   136 -
 .../processors/cache/GridCacheDeployable.java   |    37 -
 .../cache/GridCacheDeploymentManager.java       |   959 --
 .../processors/cache/GridCacheEntryEx.java      |   991 --
 .../processors/cache/GridCacheEntryImpl.java    |   728 -
 .../processors/cache/GridCacheEntryInfo.java    |   334 -
 .../GridCacheEntryInfoCollectSwapListener.java  |    89 -
 .../cache/GridCacheEntryRedeployException.java  |    35 -
 .../cache/GridCacheEntryRemovedException.java   |    28 -
 .../processors/cache/GridCacheEntrySet.java     |   112 -
 .../processors/cache/GridCacheEventManager.java |   254 -
 .../cache/GridCacheEvictionEntry.java           |   493 -
 .../cache/GridCacheEvictionManager.java         |  2039 ---
 .../cache/GridCacheEvictionRequest.java         |   251 -
 .../cache/GridCacheEvictionResponse.java        |   281 -
 .../cache/GridCacheExplicitLockSpan.java        |   278 -
 .../cache/GridCacheFilterEvaluationEntry.java   |   399 -
 .../cache/GridCacheFilterFailedException.java   |    58 -
 .../processors/cache/GridCacheFuture.java       |    61 -
 .../processors/cache/GridCacheGateway.java      |   153 -
 .../cache/GridCacheIndexUpdateException.java    |    45 -
 .../processors/cache/GridCacheInternal.java     |    27 -
 .../processors/cache/GridCacheIoManager.java    |   866 --
 .../processors/cache/GridCacheIterator.java     |    86 -
 .../processors/cache/GridCacheKeySet.java       |   111 -
 .../cache/GridCacheLoaderWriterStore.java       |   140 -
 .../cache/GridCacheLockTimeoutException.java    |    33 -
 .../processors/cache/GridCacheLogger.java       |   188 -
 .../processors/cache/GridCacheMBeanAdapter.java |   217 -
 .../processors/cache/GridCacheManager.java      |    57 -
 .../cache/GridCacheManagerAdapter.java          |   167 -
 .../processors/cache/GridCacheMapAdapter.java   |   174 -
 .../processors/cache/GridCacheMapEntry.java     |  4183 ------
 .../cache/GridCacheMapEntryFactory.java         |    39 -
 .../processors/cache/GridCacheMessage.java      |   734 -
 .../cache/GridCacheMetricsAdapter.java          |   260 -
 .../cache/GridCacheMultiTxFuture.java           |   146 -
 .../kernal/processors/cache/GridCacheMvcc.java  |  1258 --
 .../processors/cache/GridCacheMvccCallback.java |    53 -
 .../cache/GridCacheMvccCandidate.java           |   707 -
 .../processors/cache/GridCacheMvccFuture.java   |    30 -
 .../processors/cache/GridCacheMvccManager.java  |  1179 --
 .../cache/GridCacheOffheapSwapEntry.java        |   195 -
 .../processors/cache/GridCacheOperation.java    |    60 -
 .../GridCachePartitionExchangeManager.java      |  1023 --
 .../processors/cache/GridCachePreloader.java    |   128 -
 .../cache/GridCachePreloaderAdapter.java        |   141 -
 .../processors/cache/GridCacheProcessor.java    |  1931 ---
 .../processors/cache/GridCacheProjectionEx.java |   454 -
 .../cache/GridCacheProjectionImpl.java          |  1431 --
 .../kernal/processors/cache/GridCacheProxy.java |    27 -
 .../processors/cache/GridCacheProxyImpl.java    |  1904 ---
 .../processors/cache/GridCacheReturn.java       |   170 -
 .../cache/GridCacheSharedContext.java           |   508 -
 .../cache/GridCacheSharedManager.java           |    57 -
 .../cache/GridCacheSharedManagerAdapter.java    |   167 -
 .../processors/cache/GridCacheStoreManager.java |  1117 --
 .../processors/cache/GridCacheSwapEntry.java    |    81 -
 .../cache/GridCacheSwapEntryImpl.java           |   344 -
 .../processors/cache/GridCacheSwapListener.java |    31 -
 .../processors/cache/GridCacheSwapManager.java  |  1614 --
 .../processors/cache/GridCacheTtlManager.java   |   216 -
 .../cache/GridCacheUpdateAtomicResult.java      |   161 -
 .../cache/GridCacheUpdateTxResult.java          |    64 -
 .../processors/cache/GridCacheUtilityKey.java   |    45 -
 .../kernal/processors/cache/GridCacheUtils.java |  1683 ---
 .../processors/cache/GridCacheValueBytes.java   |   120 -
 .../cache/GridCacheValueCollection.java         |   167 -
 .../processors/cache/GridCacheVersion.java      |   256 -
 .../processors/cache/GridCacheVersionEx.java    |    95 -
 .../cache/GridCacheVersionManager.java          |   281 -
 .../processors/cache/GridCacheVersionable.java  |    28 -
 .../cache/GridCacheWriteBehindStore.java        |  1024 --
 .../processors/cache/GridDrResolveResult.java   |    63 -
 .../processors/cache/GridPartitionLockKey.java  |   104 -
 .../cache/IgniteCacheExpiryPolicy.java          |    73 -
 .../cache/affinity/GridCacheAffinityImpl.java   |   222 -
 .../cache/affinity/GridCacheAffinityProxy.java  |   262 -
 .../GridAtomicCacheQueueImpl.java               |   257 -
 .../GridCacheAnnotationHelper.java              |   240 -
 .../datastructures/GridCacheAtomicLongEx.java   |    32 -
 .../datastructures/GridCacheAtomicLongImpl.java |   527 -
 .../GridCacheAtomicLongValue.java               |    84 -
 .../GridCacheAtomicReferenceEx.java             |    33 -
 .../GridCacheAtomicReferenceImpl.java           |   320 -
 .../GridCacheAtomicReferenceValue.java          |   106 -
 .../GridCacheAtomicSequenceEx.java              |    32 -
 .../GridCacheAtomicSequenceImpl.java            |   516 -
 .../GridCacheAtomicSequenceValue.java           |    84 -
 .../GridCacheAtomicStampedEx.java               |    32 -
 .../GridCacheAtomicStampedImpl.java             |   350 -
 .../GridCacheAtomicStampedValue.java            |   135 -
 .../GridCacheCountDownLatchEx.java              |    39 -
 .../GridCacheCountDownLatchImpl.java            |   359 -
 .../GridCacheCountDownLatchValue.java           |   115 -
 .../GridCacheDataStructuresImpl.java            |   119 -
 .../GridCacheDataStructuresManager.java         |  1592 --
 .../GridCacheDataStructuresProxy.java           |   267 -
 .../datastructures/GridCacheInternalKey.java    |    31 -
 .../GridCacheInternalKeyImpl.java               |    89 -
 .../datastructures/GridCacheQueueAdapter.java   |  1007 --
 .../datastructures/GridCacheQueueHeader.java    |   199 -
 .../datastructures/GridCacheQueueHeaderKey.java |    88 -
 .../datastructures/GridCacheQueueItemKey.java   |   121 -
 .../datastructures/GridCacheQueueProxy.java     |   746 -
 .../datastructures/GridCacheRemovable.java      |    37 -
 .../datastructures/GridCacheSetHeader.java      |    85 -
 .../datastructures/GridCacheSetHeaderKey.java   |    88 -
 .../cache/datastructures/GridCacheSetImpl.java  |   724 -
 .../datastructures/GridCacheSetItemKey.java     |   109 -
 .../cache/datastructures/GridCacheSetProxy.java |   538 -
 .../datastructures/GridSetQueryPredicate.java   |   116 -
 .../GridTransactionalCacheQueueImpl.java        |   263 -
 .../distributed/GridCacheCommittedTxInfo.java   |   112 -
 .../distributed/GridCacheMappedVersion.java     |    33 -
 ...ridCacheOptimisticCheckPreparedTxFuture.java |   388 -
 ...idCacheOptimisticCheckPreparedTxRequest.java |   227 -
 ...dCacheOptimisticCheckPreparedTxResponse.java |   198 -
 .../GridCachePerThreadTxCommitBuffer.java       |   185 -
 ...dCachePessimisticCheckCommittedTxFuture.java |   380 -
 ...CachePessimisticCheckCommittedTxRequest.java |   292 -
 ...achePessimisticCheckCommittedTxResponse.java |   231 -
 .../distributed/GridCacheTtlUpdateRequest.java  |   500 -
 .../distributed/GridCacheTxCommitBuffer.java    |    60 -
 .../distributed/GridCacheTxFinishSync.java      |   293 -
 .../distributed/GridDistributedBaseMessage.java |   456 -
 .../GridDistributedCacheAdapter.java            |   127 -
 .../distributed/GridDistributedCacheEntry.java  |   850 --
 .../GridDistributedLockCancelledException.java  |    40 -
 .../distributed/GridDistributedLockRequest.java |   833 --
 .../GridDistributedLockResponse.java            |   436 -
 .../GridDistributedTxFinishRequest.java         |   695 -
 .../GridDistributedTxFinishResponse.java        |   172 -
 .../distributed/GridDistributedTxMapping.java   |   302 -
 .../GridDistributedTxPrepareRequest.java        |   776 -
 .../GridDistributedTxPrepareResponse.java       |   250 -
 .../GridDistributedTxRemoteAdapter.java         |   775 -
 .../GridDistributedUnlockRequest.java           |   239 -
 .../GridPartitionedCacheEntryImpl.java          |   423 -
 .../IgniteExternalizableExpiryPolicy.java       |   174 -
 .../dht/GridClientPartitionTopology.java        |   817 --
 .../dht/GridDhtAffinityAssignmentRequest.java   |   139 -
 .../dht/GridDhtAffinityAssignmentResponse.java  |   196 -
 .../dht/GridDhtAssignmentFetchFuture.java       |   184 -
 .../cache/distributed/dht/GridDhtCache.java     |   103 -
 .../distributed/dht/GridDhtCacheAdapter.java    |  1017 --
 .../distributed/dht/GridDhtCacheEntry.java      |   760 -
 .../distributed/dht/GridDhtCacheEntryImpl.java  |   172 -
 .../distributed/dht/GridDhtEmbeddedFuture.java  |    92 -
 .../distributed/dht/GridDhtFinishedFuture.java  |    66 -
 .../cache/distributed/dht/GridDhtFuture.java    |    36 -
 .../cache/distributed/dht/GridDhtGetFuture.java |   451 -
 .../dht/GridDhtInvalidPartitionException.java   |    51 -
 .../distributed/dht/GridDhtLocalPartition.java  |   595 -
 .../distributed/dht/GridDhtLockFuture.java      |  1235 --
 .../distributed/dht/GridDhtLockRequest.java     |   596 -
 .../distributed/dht/GridDhtLockResponse.java    |   453 -
 .../distributed/dht/GridDhtPartitionState.java  |    55 -
 .../dht/GridDhtPartitionTopology.java           |   207 -
 .../dht/GridDhtPartitionTopologyImpl.java       |  1196 --
 .../distributed/dht/GridDhtTopologyFuture.java  |    44 -
 .../dht/GridDhtTransactionalCacheAdapter.java   |  1492 --
 .../distributed/dht/GridDhtTxFinishFuture.java  |   532 -
 .../distributed/dht/GridDhtTxFinishRequest.java |   702 -
 .../dht/GridDhtTxFinishResponse.java            |   145 -
 .../cache/distributed/dht/GridDhtTxLocal.java   |   656 -
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   831 --
 .../cache/distributed/dht/GridDhtTxMapping.java |   169 -
 .../distributed/dht/GridDhtTxPrepareFuture.java |  1075 --
 .../dht/GridDhtTxPrepareRequest.java            |   613 -
 .../dht/GridDhtTxPrepareResponse.java           |   471 -
 .../cache/distributed/dht/GridDhtTxRemote.java  |   332 -
 .../distributed/dht/GridDhtUnlockRequest.java   |   221 -
 .../distributed/dht/GridNoStorageCacheMap.java  |   109 -
 .../dht/GridPartitionedGetFuture.java           |   715 -
 .../dht/atomic/GridDhtAtomicCache.java          |  3006 ----
 .../dht/atomic/GridDhtAtomicCacheEntry.java     |    75 -
 .../GridDhtAtomicDeferredUpdateResponse.java    |   188 -
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   442 -
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  1412 --
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   353 -
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   888 --
 .../dht/atomic/GridNearAtomicUpdateRequest.java |  1126 --
 .../atomic/GridNearAtomicUpdateResponse.java    |   797 -
 .../dht/colocated/GridDhtColocatedCache.java    |   818 --
 .../colocated/GridDhtColocatedCacheEntry.java   |    67 -
 .../colocated/GridDhtColocatedLockFuture.java   |  1333 --
 .../colocated/GridDhtDetachedCacheEntry.java    |   108 -
 .../dht/preloader/GridDhtForceKeysFuture.java   |   566 -
 .../dht/preloader/GridDhtForceKeysRequest.java  |   333 -
 .../dht/preloader/GridDhtForceKeysResponse.java |   339 -
 .../GridDhtPartitionDemandMessage.java          |   390 -
 .../preloader/GridDhtPartitionDemandPool.java   |  1141 --
 .../preloader/GridDhtPartitionExchangeId.java   |   151 -
 .../dht/preloader/GridDhtPartitionFullMap.java  |   238 -
 .../dht/preloader/GridDhtPartitionMap.java      |   159 -
 .../GridDhtPartitionSupplyMessage.java          |   519 -
 .../preloader/GridDhtPartitionSupplyPool.java   |   576 -
 .../GridDhtPartitionsAbstractMessage.java       |   157 -
 .../GridDhtPartitionsExchangeFuture.java        |  1107 --
 .../preloader/GridDhtPartitionsFullMessage.java |   258 -
 .../GridDhtPartitionsSingleMessage.java         |   176 -
 .../GridDhtPartitionsSingleRequest.java         |   101 -
 .../dht/preloader/GridDhtPreloader.java         |   572 -
 .../preloader/GridDhtPreloaderAssignments.java  |    73 -
 .../distributed/near/GridNearAtomicCache.java   |   686 -
 .../distributed/near/GridNearCacheAdapter.java  |   792 -
 .../near/GridNearCacheClearAllRunnable.java     |    62 -
 .../distributed/near/GridNearCacheEntry.java    |   626 -
 .../distributed/near/GridNearGetFuture.java     |   866 --
 .../distributed/near/GridNearGetRequest.java    |   596 -
 .../distributed/near/GridNearGetResponse.java   |   422 -
 .../distributed/near/GridNearLockFuture.java    |  1468 --
 .../distributed/near/GridNearLockMapping.java   |   116 -
 .../distributed/near/GridNearLockRequest.java   |   666 -
 .../distributed/near/GridNearLockResponse.java  |   449 -
 .../near/GridNearTransactionalCache.java        |   699 -
 .../near/GridNearTxFinishFuture.java            |   500 -
 .../near/GridNearTxFinishRequest.java           |   317 -
 .../near/GridNearTxFinishResponse.java          |   227 -
 .../cache/distributed/near/GridNearTxLocal.java |  1302 --
 .../near/GridNearTxPrepareFuture.java           |   898 --
 .../near/GridNearTxPrepareRequest.java          |   449 -
 .../near/GridNearTxPrepareResponse.java         |   510 -
 .../distributed/near/GridNearTxRemote.java      |   392 -
 .../distributed/near/GridNearUnlockRequest.java |   103 -
 .../cache/dr/GridCacheDrExpirationInfo.java     |    90 -
 .../processors/cache/dr/GridCacheDrInfo.java    |   103 -
 .../processors/cache/dr/GridCacheDrManager.java |   143 -
 .../cache/dr/os/GridOsCacheDrManager.java       |   126 -
 .../extras/GridCacheAttributesEntryExtras.java  |    83 -
 .../GridCacheAttributesMvccEntryExtras.java     |   101 -
 ...dCacheAttributesMvccObsoleteEntryExtras.java |   119 -
 ...cheAttributesMvccObsoleteTtlEntryExtras.java |   146 -
 .../GridCacheAttributesMvccTtlEntryExtras.java  |   130 -
 .../GridCacheAttributesObsoleteEntryExtras.java |   101 -
 ...idCacheAttributesObsoleteTtlEntryExtras.java |   130 -
 .../GridCacheAttributesTtlEntryExtras.java      |   112 -
 .../cache/extras/GridCacheEntryExtras.java      |    82 -
 .../extras/GridCacheEntryExtrasAdapter.java     |    51 -
 .../cache/extras/GridCacheMvccEntryExtras.java  |    82 -
 .../GridCacheMvccObsoleteEntryExtras.java       |    99 -
 .../GridCacheMvccObsoleteTtlEntryExtras.java    |   129 -
 .../extras/GridCacheMvccTtlEntryExtras.java     |   112 -
 .../extras/GridCacheObsoleteEntryExtras.java    |    82 -
 .../extras/GridCacheObsoleteTtlEntryExtras.java |   111 -
 .../cache/extras/GridCacheTtlEntryExtras.java   |    93 -
 .../cache/jta/GridCacheJtaManagerAdapter.java   |    50 -
 .../cache/jta/GridCacheNoopJtaManager.java      |    42 -
 .../processors/cache/local/GridLocalCache.java  |   205 -
 .../cache/local/GridLocalCacheEntry.java        |   386 -
 .../cache/local/GridLocalLockCallback.java      |    38 -
 .../cache/local/GridLocalLockFuture.java        |   451 -
 .../processors/cache/local/GridLocalTx.java     |   206 -
 .../cache/local/GridLocalTxFuture.java          |   350 -
 .../local/atomic/GridLocalAtomicCache.java      |  1517 --
 .../GridCacheDistributedFieldsQueryFuture.java  |   105 -
 .../query/GridCacheDistributedQueryFuture.java  |   259 -
 .../query/GridCacheDistributedQueryManager.java |   794 -
 .../query/GridCacheFieldsQueryErrorFuture.java  |    54 -
 .../query/GridCacheLocalFieldsQueryFuture.java  |    85 -
 .../cache/query/GridCacheLocalQueryFuture.java  |   140 -
 .../cache/query/GridCacheLocalQueryManager.java |   145 -
 .../cache/query/GridCacheQueriesEx.java         |    52 -
 .../cache/query/GridCacheQueriesImpl.java       |   249 -
 .../cache/query/GridCacheQueriesProxy.java      |   273 -
 .../cache/query/GridCacheQueryAdapter.java      |   508 -
 .../cache/query/GridCacheQueryBean.java         |    90 -
 .../cache/query/GridCacheQueryErrorFuture.java  |    52 -
 .../query/GridCacheQueryFutureAdapter.java      |   559 -
 .../cache/query/GridCacheQueryInfo.java         |   184 -
 .../cache/query/GridCacheQueryManager.java      |  3160 ----
 .../query/GridCacheQueryMetadataAware.java      |    33 -
 .../query/GridCacheQueryMetricsAdapter.java     |   150 -
 .../cache/query/GridCacheQueryMetricsKey.java   |   117 -
 .../cache/query/GridCacheQueryRequest.java      |   818 --
 .../cache/query/GridCacheQueryResponse.java     |   445 -
 .../query/GridCacheQueryResponseEntry.java      |   114 -
 .../cache/query/GridCacheQueryType.java         |    71 -
 .../cache/query/GridCacheSqlIndexMetadata.java  |    59 -
 .../cache/query/GridCacheSqlMetadata.java       |    89 -
 .../GridCacheContinuousQueryAdapter.java        |   385 -
 .../GridCacheContinuousQueryEntry.java          |   764 -
 .../GridCacheContinuousQueryFilterEx.java       |    32 -
 .../GridCacheContinuousQueryHandler.java        |   558 -
 .../GridCacheContinuousQueryListener.java       |    41 -
 .../GridCacheContinuousQueryManager.java        |   795 -
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |   167 -
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   343 -
 .../jdbc/GridCacheQueryJdbcValidationTask.java  |    65 -
 .../transactions/IgniteTransactionsImpl.java    |   253 -
 .../cache/transactions/IgniteTxAdapter.java     |  1570 --
 .../cache/transactions/IgniteTxEntry.java       |  1141 --
 .../cache/transactions/IgniteTxEx.java          |   539 -
 .../cache/transactions/IgniteTxHandler.java     |  1519 --
 .../cache/transactions/IgniteTxKey.java         |   105 -
 .../transactions/IgniteTxLocalAdapter.java      |  3574 -----
 .../cache/transactions/IgniteTxLocalEx.java     |   180 -
 .../cache/transactions/IgniteTxManager.java     |  2221 ---
 .../cache/transactions/IgniteTxMap.java         |   187 -
 .../transactions/IgniteTxMetricsAdapter.java    |   116 -
 .../cache/transactions/IgniteTxProxy.java       |    27 -
 .../cache/transactions/IgniteTxProxyImpl.java   |   313 -
 .../cache/transactions/IgniteTxRemoteEx.java    |    47 -
 .../clock/GridClockDeltaSnapshot.java           |   231 -
 .../clock/GridClockDeltaSnapshotMessage.java    |   226 -
 .../processors/clock/GridClockDeltaVersion.java |   117 -
 .../processors/clock/GridClockMessage.java      |   171 -
 .../processors/clock/GridClockServer.java       |   207 -
 .../processors/clock/GridClockSource.java       |    30 -
 .../clock/GridClockSyncProcessor.java           |   459 -
 .../processors/clock/GridJvmClockSource.java    |    28 -
 .../processors/closure/GridClosurePolicy.java   |    51 -
 .../closure/GridClosureProcessor.java           |  1744 ---
 .../GridMasterLeaveAwareComputeJobAdapter.java  |    36 -
 .../closure/GridPeerDeployAwareTaskAdapter.java |    60 -
 .../grid/kernal/processors/closure/package.html |    23 -
 .../continuous/GridContinuousHandler.java       |   105 -
 .../continuous/GridContinuousMessage.java       |   256 -
 .../continuous/GridContinuousMessageType.java   |    56 -
 .../continuous/GridContinuousProcessor.java     |  1847 ---
 .../dataload/GridDataLoadCacheUpdaters.java     |   293 -
 .../dataload/GridDataLoadRequest.java           |   548 -
 .../dataload/GridDataLoadResponse.java          |   181 -
 .../dataload/GridDataLoadUpdateJob.java         |   120 -
 .../dataload/GridDataLoaderFuture.java          |    76 -
 .../dataload/GridDataLoaderProcessor.java       |   319 -
 .../dataload/IgniteDataLoaderImpl.java          |  1348 --
 .../kernal/processors/dataload/package.html     |    23 -
 .../dr/GridDrDataLoadCacheUpdater.java          |    77 -
 .../grid/kernal/processors/dr/GridDrType.java   |    38 -
 .../processors/dr/GridRawVersionedEntry.java    |   210 -
 .../processors/dr/GridVersionedEntry.java       |    80 -
 .../grid/kernal/processors/dr/package.html      |    25 -
 .../processors/email/GridEmailHolder.java       |   111 -
 .../email/GridEmailProcessorAdapter.java        |    86 -
 .../email/GridNoopEmailProcessor.java           |    56 -
 .../grid/kernal/processors/email/package.html   |    24 -
 .../processors/ggfs/GridGgfsAckMessage.java     |   212 -
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   298 -
 .../processors/ggfs/GridGgfsAttributes.java     |   186 -
 .../processors/ggfs/GridGgfsBlockKey.java       |   279 -
 .../ggfs/GridGgfsBlockLocationImpl.java         |   258 -
 .../processors/ggfs/GridGgfsBlocksMessage.java  |   257 -
 .../processors/ggfs/GridGgfsClientSession.java  |    75 -
 .../ggfs/GridGgfsCommunicationMessage.java      |    75 -
 .../kernal/processors/ggfs/GridGgfsContext.java |   205 -
 .../processors/ggfs/GridGgfsDataManager.java    |  1919 ---
 .../processors/ggfs/GridGgfsDeleteMessage.java  |   206 -
 .../processors/ggfs/GridGgfsDeleteWorker.java   |   351 -
 .../GridGgfsDirectoryNotEmptyException.java     |    44 -
 .../grid/kernal/processors/ggfs/GridGgfsEx.java |   143 -
 .../ggfs/GridGgfsFileAffinityRange.java         |   396 -
 .../processors/ggfs/GridGgfsFileInfo.java       |   568 -
 .../kernal/processors/ggfs/GridGgfsFileMap.java |   361 -
 .../processors/ggfs/GridGgfsFileWorker.java     |   182 -
 .../ggfs/GridGgfsFileWorkerBatch.java           |   236 -
 .../processors/ggfs/GridGgfsFileWorkerTask.java |    32 -
 .../ggfs/GridGgfsFragmentizerManager.java       |   830 --
 .../ggfs/GridGgfsFragmentizerRequest.java       |   212 -
 .../ggfs/GridGgfsFragmentizerResponse.java      |   131 -
 .../ggfs/GridGgfsHandshakeResponse.java         |   122 -
 .../kernal/processors/ggfs/GridGgfsHelper.java  |    49 -
 .../processors/ggfs/GridGgfsHelperImpl.java     |    54 -
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  2152 ---
 .../ggfs/GridGgfsInputStreamAdapter.java        |    49 -
 .../ggfs/GridGgfsInputStreamDescriptor.java     |    78 -
 .../ggfs/GridGgfsInputStreamImpl.java           |   533 -
 .../ggfs/GridGgfsInvalidRangeException.java     |    43 -
 .../processors/ggfs/GridGgfsIpcHandler.java     |   565 -
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   118 -
 .../processors/ggfs/GridGgfsListingEntry.java   |   197 -
 .../processors/ggfs/GridGgfsLocalMetrics.java   |   212 -
 .../kernal/processors/ggfs/GridGgfsManager.java |   156 -
 .../processors/ggfs/GridGgfsMetaManager.java    |  2993 ----
 .../processors/ggfs/GridGgfsModeResolver.java   |   177 -
 .../kernal/processors/ggfs/GridGgfsPaths.java   |   124 -
 .../processors/ggfs/GridGgfsProcessor.java      |   464 -
 .../ggfs/GridGgfsProcessorAdapter.java          |    80 -
 .../processors/ggfs/GridGgfsSamplingKey.java    |    83 -
 .../GridGgfsSecondaryInputStreamDescriptor.java |    59 -
 ...GridGgfsSecondaryOutputStreamDescriptor.java |    74 -
 .../kernal/processors/ggfs/GridGgfsServer.java  |   428 -
 .../processors/ggfs/GridGgfsServerHandler.java  |    57 -
 .../processors/ggfs/GridGgfsServerManager.java  |   211 -
 .../kernal/processors/ggfs/GridGgfsStatus.java  |    76 -
 .../processors/ggfs/GridGgfsSyncMessage.java    |   161 -
 .../kernal/processors/ggfs/GridGgfsThread.java  |    82 -
 .../processors/ggfs/GridNoopGgfsHelper.java     |    41 -
 .../processors/ggfs/GridNoopGgfsProcessor.java  |    71 -
 .../processors/ggfs/IgniteFsFileImpl.java       |   245 -
 .../processors/ggfs/IgniteFsMetricsAdapter.java |   239 -
 .../ggfs/IgniteFsOutputStreamAdapter.java       |   263 -
 .../ggfs/IgniteFsOutputStreamImpl.java          |   505 -
 .../processors/ggfs/IgniteFsTaskArgsImpl.java   |   135 -
 .../grid/kernal/processors/ggfs/package.html    |    23 -
 .../hadoop/GridHadoopNoopProcessor.java         |    76 -
 .../hadoop/GridHadoopProcessorAdapter.java      |    96 -
 .../processors/interop/GridInteropAware.java    |    49 -
 .../interop/GridInteropProcessor.java           |    82 -
 .../interop/GridInteropProcessorAdapter.java    |    31 -
 .../processors/interop/GridInteropTarget.java   |   109 -
 .../interop/os/GridOsInteropProcessor.java      |    81 -
 .../kernal/processors/interop/os/package.html   |    23 -
 .../grid/kernal/processors/interop/package.html |    23 -
 .../processors/job/GridJobEventListener.java    |    40 -
 .../processors/job/GridJobHoldListener.java     |    36 -
 .../kernal/processors/job/GridJobProcessor.java |  1873 ---
 .../kernal/processors/job/GridJobWorker.java    |   895 --
 .../grid/kernal/processors/job/package.html     |    23 -
 .../processors/jobmetrics/GridJobMetrics.java   |   448 -
 .../jobmetrics/GridJobMetricsProcessor.java     |   404 -
 .../jobmetrics/GridJobMetricsSnapshot.java      |   227 -
 .../kernal/processors/jobmetrics/package.html   |    24 -
 .../license/GridLicenseProcessor.java           |    69 -
 .../license/GridLicenseSubsystem.java           |    53 -
 .../license/GridLicenseUseRegistry.java         |    90 -
 .../license/os/GridOsLicenseProcessor.java      |    66 -
 .../kernal/processors/license/os/package.html   |    23 -
 .../grid/kernal/processors/license/package.html |    24 -
 .../offheap/GridOffHeapProcessor.java           |   326 -
 .../grid/kernal/processors/package.html         |    23 -
 .../plugin/IgnitePluginProcessor.java           |   211 -
 .../processors/port/GridPortListener.java       |    28 -
 .../processors/port/GridPortProcessor.java      |   196 -
 .../kernal/processors/port/GridPortRecord.java  |    72 -
 .../grid/kernal/processors/port/package.html    |    24 -
 .../portable/GridPortableInputStream.java       |   177 -
 .../portable/GridPortableOutputStream.java      |   172 -
 .../portable/GridPortableProcessor.java         |   150 -
 .../processors/portable/GridPortableStream.java |    53 -
 .../portable/os/GridOsPortableProcessor.java    |   126 -
 .../kernal/processors/portable/os/package.html  |    23 -
 .../kernal/processors/portable/package.html     |    23 -
 .../query/GridQueryFieldMetadata.java           |    54 -
 .../processors/query/GridQueryFieldsResult.java |    42 -
 .../query/GridQueryFieldsResultAdapter.java     |    57 -
 .../query/GridQueryIndexDescriptor.java         |    50 -
 .../processors/query/GridQueryIndexType.java    |    32 -
 .../processors/query/GridQueryIndexing.java     |   170 -
 .../processors/query/GridQueryProcessor.java    |  1681 ---
 .../query/GridQueryTypeDescriptor.java          |    86 -
 .../resource/GridResourceBasicInjector.java     |    71 -
 .../processors/resource/GridResourceField.java  |    71 -
 .../resource/GridResourceInjector.java          |    56 -
 .../processors/resource/GridResourceIoc.java    |   437 -
 .../GridResourceJobContextInjector.java         |    54 -
 .../resource/GridResourceLoggerInjector.java    |    69 -
 .../processors/resource/GridResourceMethod.java |    71 -
 .../resource/GridResourceProcessor.java         |   607 -
 .../resource/GridResourceServiceInjector.java   |    85 -
 .../processors/resource/GridResourceUtils.java  |   104 -
 .../resource/GridSpringResourceContext.java     |    48 -
 .../kernal/processors/resource/package.html     |    23 -
 .../kernal/processors/rest/GridRestCommand.java |   160 -
 .../processors/rest/GridRestProcessor.java      |   697 -
 .../processors/rest/GridRestProtocol.java       |    59 -
 .../rest/GridRestProtocolHandler.java           |    40 -
 .../processors/rest/GridRestResponse.java       |   177 -
 .../message/GridClientAbstractMessage.java      |   117 -
 .../GridClientAuthenticationRequest.java        |    85 -
 .../message/GridClientCacheQueryRequest.java    |   414 -
 .../client/message/GridClientCacheRequest.java  |   319 -
 .../message/GridClientGetMetaDataRequest.java   |    64 -
 .../message/GridClientHandshakeRequest.java     |   108 -
 .../GridClientHandshakeRequestWrapper.java      |   129 -
 .../message/GridClientHandshakeResponse.java    |    66 -
 .../GridClientHandshakeResponseWrapper.java     |    96 -
 .../client/message/GridClientLogRequest.java    |   141 -
 .../rest/client/message/GridClientMessage.java  |    82 -
 .../message/GridClientMessageWrapper.java       |   266 -
 .../message/GridClientMetaDataResponse.java     |    57 -
 .../rest/client/message/GridClientNodeBean.java |   342 -
 .../message/GridClientNodeMetricsBean.java      |  1578 --
 .../client/message/GridClientPingPacket.java    |    37 -
 .../message/GridClientPingPacketWrapper.java    |    89 -
 .../message/GridClientPortableMetaData.java     |    93 -
 .../message/GridClientPutMetaDataRequest.java   |    64 -
 .../rest/client/message/GridClientResponse.java |   145 -
 .../client/message/GridClientTaskRequest.java   |   152 -
 .../message/GridClientTaskResultBean.java       |   147 -
 .../message/GridClientTopologyRequest.java      |   174 -
 .../rest/client/message/GridRouterRequest.java  |    57 -
 .../rest/client/message/GridRouterResponse.java |    84 -
 .../processors/rest/client/message/package.html |    23 -
 .../rest/handlers/GridRestCommandHandler.java   |    40 -
 .../handlers/GridRestCommandHandlerAdapter.java |    51 -
 .../cache/GridCacheClientQueryResult.java       |   119 -
 .../handlers/cache/GridCacheCommandHandler.java |  1149 --
 .../cache/GridCacheQueryCommandHandler.java     |   494 -
 .../handlers/cache/GridCacheRestMetrics.java    |   215 -
 .../handlers/cache/GridCacheRestResponse.java   |    67 -
 .../processors/rest/handlers/cache/package.html |    23 -
 .../handlers/log/GridLogCommandHandler.java     |   307 -
 .../processors/rest/handlers/log/package.html   |    23 -
 .../metadata/GridPortableMetadataHandler.java   |   105 -
 .../processors/rest/handlers/package.html       |    23 -
 .../handlers/task/GridTaskCommandHandler.java   |   639 -
 .../handlers/task/GridTaskResultRequest.java    |   185 -
 .../handlers/task/GridTaskResultResponse.java   |   233 -
 .../top/GridTopologyCommandHandler.java         |   335 -
 .../processors/rest/handlers/top/package.html   |    23 -
 .../version/GridVersionCommandHandler.java      |    60 -
 .../rest/handlers/version/package.html          |    23 -
 .../grid/kernal/processors/rest/package.html    |    23 -
 .../rest/protocols/GridRestProtocolAdapter.java |   197 -
 .../processors/rest/protocols/package.html      |    23 -
 .../protocols/tcp/GridClientPacketType.java     |    32 -
 .../protocols/tcp/GridMemcachedMessage.java     |   485 -
 .../tcp/GridMemcachedMessageWrapper.java        |   269 -
 .../tcp/GridTcpMemcachedNioListener.java        |   443 -
 .../protocols/tcp/GridTcpRestDirectParser.java  |   519 -
 .../protocols/tcp/GridTcpRestNioListener.java   |   387 -
 .../rest/protocols/tcp/GridTcpRestParser.java   |   878 --
 .../rest/protocols/tcp/GridTcpRestProtocol.java |   335 -
 .../processors/rest/protocols/tcp/package.html  |    23 -
 .../rest/request/GridRestCacheQueryRequest.java |   143 -
 .../rest/request/GridRestCacheRequest.java      |   182 -
 .../rest/request/GridRestLogRequest.java        |    81 -
 .../GridRestPortableGetMetaDataRequest.java     |    44 -
 .../GridRestPortablePutMetaDataRequest.java     |    44 -
 .../rest/request/GridRestRequest.java           |   167 -
 .../rest/request/GridRestTaskRequest.java       |   134 -
 .../rest/request/GridRestTopologyRequest.java   |   100 -
 .../kernal/processors/rest/request/package.html |    23 -
 .../schedule/GridNoopScheduleProcessor.java     |    54 -
 .../schedule/GridScheduleProcessorAdapter.java  |    53 -
 .../schedule/GridScheduleStatistics.java        |   182 -
 .../kernal/processors/schedule/package.html     |    24 -
 .../segmentation/GridSegmentationProcessor.java |    51 -
 .../os/GridOsSegmentationProcessor.java         |    39 -
 .../kernal/processors/segmentation/package.html |    23 -
 .../service/GridServiceAssignments.java         |   135 -
 .../service/GridServiceAssignmentsKey.java      |    63 -
 .../service/GridServiceDeployment.java          |    95 -
 .../service/GridServiceDeploymentFuture.java    |    56 -
 .../service/GridServiceDeploymentKey.java       |    63 -
 .../GridServiceMethodNotFoundException.java     |    43 -
 .../service/GridServiceMethodReflectKey.java    |    77 -
 .../service/GridServiceNotFoundException.java   |    40 -
 .../service/GridServiceProcessor.java           |  1290 --
 .../processors/service/GridServiceProxy.java    |   381 -
 .../service/ManagedServiceContextImpl.java      |   156 -
 .../service/ManagedServiceDescriptorImpl.java   |   101 -
 .../session/GridTaskSessionProcessor.java       |   178 -
 .../grid/kernal/processors/session/package.html |    24 -
 .../processors/spring/GridSpringProcessor.java  |    74 -
 .../streamer/GridStreamProcessor.java           |   360 -
 .../streamer/GridStreamerAttributes.java        |   127 -
 .../streamer/GridStreamerCancelRequest.java     |   123 -
 .../streamer/GridStreamerContextDelegate.java   |   106 -
 .../streamer/GridStreamerContextImpl.java       |   205 -
 .../streamer/GridStreamerExecutionBatch.java    |   185 -
 .../streamer/GridStreamerExecutionRequest.java  |   382 -
 .../streamer/GridStreamerResponse.java          |   160 -
 .../GridStreamerRouteFailedException.java       |    36 -
 .../GridStreamerStageExecutionFuture.java       |   363 -
 .../streamer/GridStreamerWindowIterator.java    |    40 -
 .../processors/streamer/IgniteStreamerEx.java   |    95 -
 .../processors/streamer/IgniteStreamerImpl.java |  1415 --
 .../streamer/StreamerMBeanAdapter.java          |   116 -
 .../streamer/StreamerMetricsAdapter.java        |   272 -
 .../streamer/StreamerMetricsHolder.java         |   424 -
 .../streamer/StreamerStageMBeanAdapter.java     |   101 -
 .../streamer/StreamerStageMetricsAdapter.java   |   135 -
 .../streamer/StreamerStageMetricsHolder.java    |   167 -
 .../streamer/StreamerStageWrapper.java          |    92 -
 .../streamer/StreamerWindowMetricsAdapter.java  |    65 -
 .../streamer/StreamerWindowMetricsHolder.java   |    50 -
 .../kernal/processors/streamer/package.html     |    23 -
 .../task/GridStreamerBroadcastTask.java         |   139 -
 .../streamer/task/GridStreamerQueryTask.java    |   142 -
 .../streamer/task/GridStreamerReduceTask.java   |   146 -
 .../kernal/processors/task/GridInternal.java    |    35 -
 .../processors/task/GridTaskEventListener.java  |    55 -
 .../processors/task/GridTaskProcessor.java      |  1296 --
 .../task/GridTaskThreadContextKey.java          |    38 -
 .../kernal/processors/task/GridTaskWorker.java  |  1398 --
 .../grid/kernal/processors/task/package.html    |    23 -
 .../processors/timeout/GridTimeoutObject.java   |    40 -
 .../timeout/GridTimeoutObjectAdapter.java       |    61 -
 .../timeout/GridTimeoutProcessor.java           |   173 -
 .../grid/kernal/processors/timeout/package.html |    23 -
 .../version/GridVersionConverter.java           |    46 -
 .../grid/kernal/tck/TCKMBeanServerBuilder.java  |   118 -
 .../gridgain/grid/kernal/visor/VisorJob.java    |    77 -
 .../grid/kernal/visor/VisorMultiNodeTask.java   |   127 -
 .../grid/kernal/visor/VisorOneNodeTask.java     |    42 -
 .../grid/kernal/visor/VisorTaskArgument.java    |   106 -
 .../grid/kernal/visor/cache/VisorCache.java     |   485 -
 .../cache/VisorCacheAffinityConfiguration.java  |   171 -
 .../cache/VisorCacheAggregatedMetrics.java      |   471 -
 .../kernal/visor/cache/VisorCacheClearTask.java |    88 -
 .../visor/cache/VisorCacheCompactTask.java      |    86 -
 .../visor/cache/VisorCacheConfiguration.java    |   665 -
 .../cache/VisorCacheDefaultConfiguration.java   |   158 -
 .../visor/cache/VisorCacheDgcConfiguration.java |    97 -
 .../cache/VisorCacheEvictionConfiguration.java  |   215 -
 .../kernal/visor/cache/VisorCacheLoadTask.java  |    88 -
 .../visor/cache/VisorCacheMetadataTask.java     |    76 -
 .../kernal/visor/cache/VisorCacheMetrics.java   |   270 -
 .../cache/VisorCacheMetricsCollectorTask.java   |   112 -
 .../cache/VisorCacheNearConfiguration.java      |   123 -
 .../cache/VisorCachePreloadConfiguration.java   |   156 -
 .../visor/cache/VisorCachePreloadTask.java      |    77 -
 .../visor/cache/VisorCacheQueryMetrics.java     |   102 -
 .../visor/cache/VisorCacheResetMetricsTask.java |    69 -
 .../cache/VisorCacheStoreConfiguration.java     |    90 -
 .../visor/cache/VisorCacheSwapBackupsTask.java  |    90 -
 .../VisorCacheWriteBehindConfiguration.java     |   137 -
 .../compute/VisorComputeCancelSessionsTask.java |    90 -
 .../compute/VisorComputeMonitoringHolder.java   |   118 -
 .../compute/VisorComputeResetMetricsTask.java   |    65 -
 .../VisorComputeToggleMonitoringTask.java       |   112 -
 .../kernal/visor/debug/VisorThreadDumpTask.java |    75 -
 .../kernal/visor/debug/VisorThreadInfo.java     |   328 -
 .../kernal/visor/debug/VisorThreadLockInfo.java |    73 -
 .../visor/debug/VisorThreadMonitorInfo.java     |    72 -
 .../event/VisorGridAuthenticationEvent.java     |   106 -
 .../event/VisorGridAuthorizationEvent.java      |    89 -
 .../visor/event/VisorGridDeploymentEvent.java   |    74 -
 .../visor/event/VisorGridDiscoveryEvent.java    |   100 -
 .../grid/kernal/visor/event/VisorGridEvent.java |   130 -
 .../kernal/visor/event/VisorGridEventsLost.java |    45 -
 .../kernal/visor/event/VisorGridJobEvent.java   |   113 -
 .../visor/event/VisorGridLicenseEvent.java      |    74 -
 .../event/VisorGridSecuritySessionEvent.java    |    91 -
 .../kernal/visor/event/VisorGridTaskEvent.java  |   113 -
 .../grid/kernal/visor/file/VisorFileBlock.java  |   114 -
 .../kernal/visor/file/VisorFileBlockTask.java   |   126 -
 .../visor/file/VisorLatestTextFilesTask.java    |    98 -
 .../grid/kernal/visor/ggfs/VisorGgfs.java       |   114 -
 .../kernal/visor/ggfs/VisorGgfsEndpoint.java    |   106 -
 .../kernal/visor/ggfs/VisorGgfsFormatTask.java  |    70 -
 .../kernal/visor/ggfs/VisorGgfsMetrics.java     |   350 -
 .../kernal/visor/ggfs/VisorGgfsProfiler.java    |    88 -
 .../visor/ggfs/VisorGgfsProfilerClearTask.java  |   112 -
 .../visor/ggfs/VisorGgfsProfilerEntry.java      |   238 -
 .../visor/ggfs/VisorGgfsProfilerTask.java       |   504 -
 .../VisorGgfsProfilerUniformityCounters.java    |   197 -
 .../visor/ggfs/VisorGgfsResetMetricsTask.java   |    73 -
 .../visor/ggfs/VisorGgfsSamplingStateTask.java  |    74 -
 .../grid/kernal/visor/log/VisorLogFile.java     |    87 -
 .../kernal/visor/log/VisorLogSearchResult.java  |   156 -
 .../kernal/visor/log/VisorLogSearchTask.java    |   270 -
 .../grid/kernal/visor/misc/VisorAckTask.java    |    76 -
 .../visor/misc/VisorLatestVersionTask.java      |    63 -
 .../grid/kernal/visor/misc/VisorNopTask.java    |    90 -
 .../visor/misc/VisorResolveHostNameTask.java    |   104 -
 .../visor/node/VisorBasicConfiguration.java     |   451 -
 .../visor/node/VisorEmailConfiguration.java     |   177 -
 .../node/VisorExecutorServiceConfiguration.java |   200 -
 .../visor/node/VisorGgfsConfiguration.java      |   573 -
 .../visor/node/VisorGridConfiguration.java      |   361 -
 .../visor/node/VisorLifecycleConfiguration.java |    87 -
 .../visor/node/VisorMetricsConfiguration.java   |    95 -
 .../VisorNodeConfigurationCollectorJob.java     |    47 -
 .../VisorNodeConfigurationCollectorTask.java    |    35 -
 .../visor/node/VisorNodeDataCollectorJob.java   |   219 -
 .../node/VisorNodeDataCollectorJobResult.java   |   158 -
 .../visor/node/VisorNodeDataCollectorTask.java  |   127 -
 .../node/VisorNodeDataCollectorTaskArg.java     |   140 -
 .../node/VisorNodeDataCollectorTaskResult.java  |   184 -
 .../node/VisorNodeEventsCollectorTask.java      |   365 -
 .../grid/kernal/visor/node/VisorNodeGcTask.java |   100 -
 .../kernal/visor/node/VisorNodePingTask.java    |    81 -
 .../kernal/visor/node/VisorNodeRestartTask.java |    79 -
 .../kernal/visor/node/VisorNodeStopTask.java    |    79 -
 .../node/VisorPeerToPeerConfiguration.java      |   105 -
 .../visor/node/VisorRestConfiguration.java      |   221 -
 .../node/VisorSegmentationConfiguration.java    |   141 -
 .../visor/node/VisorSpisConfiguration.java      |   334 -
 .../visor/portable/VisorPortableMetadata.java   |    72 -
 .../VisorPortableMetadataCollectorTask.java     |    95 -
 .../portable/VisorPortableMetadataField.java    |    71 -
 .../visor/query/VisorQueryCleanupTask.java      |   102 -
 .../kernal/visor/query/VisorQueryField.java     |    66 -
 .../visor/query/VisorQueryNextPageTask.java     |   117 -
 .../kernal/visor/query/VisorQueryResult.java    |    79 -
 .../kernal/visor/query/VisorQueryResultEx.java  |    88 -
 .../grid/kernal/visor/query/VisorQueryTask.java |   310 -
 .../kernal/visor/query/VisorQueryUtils.java     |   204 -
 .../kernal/visor/streamer/VisorStreamer.java    |   104 -
 .../streamer/VisorStreamerConfiguration.java    |   178 -
 .../visor/streamer/VisorStreamerMetrics.java    |   350 -
 .../streamer/VisorStreamerMetricsResetTask.java |    76 -
 .../visor/streamer/VisorStreamerResetTask.java  |    76 -
 .../streamer/VisorStreamerStageMetrics.java     |   277 -
 .../grid/kernal/visor/util/VisorMimeTypes.java  |  1004 --
 .../grid/kernal/visor/util/VisorTaskUtils.java  |   831 --
 .../main/java/org/gridgain/grid/package.html    |    23 -
 .../main/java/org/gridgain/grid/util/F0.java    |   368 -
 .../grid/util/GridAnnotationsCache.java         |    84 -
 .../gridgain/grid/util/GridArgumentCheck.java   |   149 -
 .../grid/util/GridAtomicInitializer.java        |   113 -
 .../gridgain/grid/util/GridAtomicInteger.java   |   249 -
 .../org/gridgain/grid/util/GridAtomicLong.java  |   249 -
 .../GridBoundedConcurrentLinkedHashMap.java     |   124 -
 .../GridBoundedConcurrentLinkedHashSet.java     |   162 -
 .../util/GridBoundedConcurrentOrderedMap.java   |   242 -
 .../util/GridBoundedConcurrentOrderedSet.java   |   179 -
 .../grid/util/GridBoundedLinkedHashMap.java     |   129 -
 .../grid/util/GridBoundedLinkedHashSet.java     |   207 -
 .../org/gridgain/grid/util/GridBusyLock.java    |    83 -
 .../gridgain/grid/util/GridByteArrayList.java   |   412 -
 .../gridgain/grid/util/GridCircularBuffer.java  |   230 -
 .../grid/util/GridClassLoaderCache.java         |   131 -
 .../gridgain/grid/util/GridClientByteUtils.java |   238 -
 .../grid/util/GridCloseableIteratorAdapter.java |   110 -
 .../util/GridCloseableIteratorAdapterEx.java    |   127 -
 .../org/gridgain/grid/util/GridCollections.java |   644 -
 .../grid/util/GridConcurrentFactory.java        |   109 -
 .../grid/util/GridConcurrentHashSet.java        |   119 -
 .../grid/util/GridConcurrentLinkedHashSet.java  |   131 -
 .../grid/util/GridConcurrentPhantomHashSet.java |   402 -
 .../grid/util/GridConcurrentSkipListSet.java    |   302 -
 .../grid/util/GridConcurrentWeakHashSet.java    |   402 -
 .../grid/util/GridConfigurationFinder.java      |   151 -
 .../gridgain/grid/util/GridConsistentHash.java  |   672 -
 .../java/org/gridgain/grid/util/GridDebug.java  |   303 -
 .../grid/util/GridEmptyCloseableIterator.java   |    42 -
 .../gridgain/grid/util/GridEmptyIterator.java   |    51 -
 .../org/gridgain/grid/util/GridEnumCache.java   |    57 -
 .../grid/util/GridExecutionStatistics.java      |   105 -
 .../grid/util/GridFixedSizeInputStream.java     |    85 -
 .../org/gridgain/grid/util/GridHandleTable.java |   198 -
 .../gridgain/grid/util/GridIdentityHashSet.java |    63 -
 .../org/gridgain/grid/util/GridJavaProcess.java |   259 -
 .../org/gridgain/grid/util/GridKeyLock.java     |   154 -
 .../org/gridgain/grid/util/GridLeanMap.java     |  1266 --
 .../org/gridgain/grid/util/GridLeanSet.java     |    83 -
 .../org/gridgain/grid/util/GridListSet.java     |   529 -
 .../org/gridgain/grid/util/GridLogThrottle.java |   221 -
 .../org/gridgain/grid/util/GridLongList.java    |   500 -
 .../java/org/gridgain/grid/util/GridMutex.java  |    55 -
 .../java/org/gridgain/grid/util/GridQueue.java  |   348 -
 .../java/org/gridgain/grid/util/GridRandom.java |    57 -
 .../gridgain/grid/util/GridReflectionCache.java |   250 -
 .../grid/util/GridSerializableCollection.java   |    33 -
 .../grid/util/GridSerializableFuture.java       |    28 -
 .../grid/util/GridSerializableIterable.java     |    28 -
 .../grid/util/GridSerializableIterator.java     |    29 -
 .../grid/util/GridSerializableList.java         |    33 -
 .../gridgain/grid/util/GridSerializableMap.java |    37 -
 .../gridgain/grid/util/GridSerializableSet.java |    37 -
 .../org/gridgain/grid/util/GridSetWrapper.java  |   136 -
 .../gridgain/grid/util/GridSnapshotLock.java    |   219 -
 .../util/GridSpiCloseableIteratorWrapper.java   |    57 -
 .../gridgain/grid/util/GridSpinBusyLock.java    |    84 -
 .../grid/util/GridSpinReadWriteLock.java        |   413 -
 .../gridgain/grid/util/GridStringBuilder.java   |   447 -
 .../grid/util/GridStringBuilderFactory.java     |    98 -
 .../org/gridgain/grid/util/GridStripedLock.java |   143 -
 .../grid/util/GridStripedReadWriteLock.java     |   100 -
 .../gridgain/grid/util/GridSynchronizedMap.java |   100 -
 .../org/gridgain/grid/util/GridThreadLocal.java |   175 -
 .../gridgain/grid/util/GridThreadLocalEx.java   |   210 -
 .../java/org/gridgain/grid/util/GridTimer.java  |   154 -
 .../org/gridgain/grid/util/GridTimerTask.java   |    40 -
 .../java/org/gridgain/grid/util/GridUnsafe.java |    61 -
 .../java/org/gridgain/grid/util/GridUtils.java  |  9101 ------------
 .../org/gridgain/grid/util/GridUuidCache.java   |    59 -
 .../gridgain/grid/util/GridWeakIterator.java    |    55 -
 .../GridTcpCommunicationMessageAdapter.java     |   217 -
 .../GridTcpCommunicationMessageFactory.java     |   362 -
 .../GridTcpCommunicationMessageProducer.java    |    31 -
 .../GridTcpCommunicationMessageState.java       |  1598 --
 .../grid/util/direct/GridTcpMessageFactory.java |    29 -
 .../grid/util/future/GridCompoundFuture.java    |   383 -
 .../util/future/GridCompoundIdentityFuture.java |    68 -
 .../grid/util/future/GridEmbeddedFuture.java    |   322 -
 .../grid/util/future/GridFinishedFuture.java    |   225 -
 .../grid/util/future/GridFinishedFutureEx.java  |   196 -
 .../grid/util/future/GridFutureAdapter.java     |   627 -
 .../grid/util/future/GridFutureAdapterEx.java   |   516 -
 .../util/future/GridFutureChainListener.java    |    72 -
 .../org/gridgain/grid/util/future/package.html  |    23 -
 .../util/gridify/GridifyArgumentBuilder.java    |   186 -
 .../grid/util/gridify/GridifyJobAdapter.java    |   107 -
 .../grid/util/gridify/GridifyRangeArgument.java |   103 -
 .../grid/util/gridify/GridifyUtils.java         |   521 -
 .../org/gridgain/grid/util/gridify/package.html |    23 -
 .../grid/util/io/GridByteArrayInputStream.java  |   209 -
 .../grid/util/io/GridByteArrayOutputStream.java |   167 -
 .../gridgain/grid/util/io/GridDataInput.java    |   132 -
 .../gridgain/grid/util/io/GridDataOutput.java   |   119 -
 .../grid/util/io/GridFilenameUtils.java         |  1560 --
 .../util/io/GridReversedLinesFileReader.java    |   333 -
 .../grid/util/io/GridUnsafeDataInput.java       |   603 -
 .../grid/util/io/GridUnsafeDataOutput.java      |   500 -
 .../gridgain/grid/util/ipc/GridIpcEndpoint.java |    49 -
 .../util/ipc/GridIpcEndpointBindException.java  |    47 -
 .../grid/util/ipc/GridIpcEndpointFactory.java   |    85 -
 .../grid/util/ipc/GridIpcEndpointType.java      |    29 -
 .../grid/util/ipc/GridIpcServerEndpoint.java    |    73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |    66 -
 .../grid/util/ipc/GridIpcToNioAdapter.java      |   251 -
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |    87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |   180 -
 .../grid/util/ipc/loopback/package.html         |    23 -
 .../org/gridgain/grid/util/ipc/package.html     |    23 -
 .../GridIpcOutOfSystemResourcesException.java   |    59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |   337 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |    67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |   171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |    99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |   243 -
 ...cSharedMemoryOperationTimedoutException.java |    59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |    80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |   708 -
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |   374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |   242 -
 .../gridgain/grid/util/ipc/shmem/package.html   |    23 -
 .../gridgain/grid/util/lang/GridAbsClosure.java |    52 -
 .../grid/util/lang/GridAbsClosureX.java         |    48 -
 .../grid/util/lang/GridAbsPredicate.java        |    44 -
 .../grid/util/lang/GridAbsPredicateX.java       |    46 -
 .../grid/util/lang/GridCloseableIterator.java   |    62 -
 .../gridgain/grid/util/lang/GridClosure3.java   |    52 -
 .../gridgain/grid/util/lang/GridClosure3X.java  |    51 -
 .../grid/util/lang/GridClosureException.java    |    50 -
 .../grid/util/lang/GridComputeJobWrapper.java   |    98 -
 .../grid/util/lang/GridFilteredIterator.java    |    87 -
 .../org/gridgain/grid/util/lang/GridFunc.java   |  8609 -----------
 .../gridgain/grid/util/lang/GridInClosure3.java |    49 -
 .../grid/util/lang/GridInClosure3X.java         |    50 -
 .../gridgain/grid/util/lang/GridIterable.java   |    35 -
 .../grid/util/lang/GridIterableAdapter.java     |   120 -
 .../gridgain/grid/util/lang/GridIterator.java   |    67 -
 .../grid/util/lang/GridIteratorAdapter.java     |    66 -
 .../gridgain/grid/util/lang/GridMapEntry.java   |    92 -
 .../util/lang/GridMetadataAwareAdapter.java     |   437 -
 .../grid/util/lang/GridNodePredicate.java       |   156 -
 .../grid/util/lang/GridPeerDeployAware.java     |    52 -
 .../util/lang/GridPeerDeployAwareAdapter.java   |    69 -
 .../grid/util/lang/GridPlainAbsClosure.java     |    33 -
 .../grid/util/lang/GridPlainCallable.java       |    27 -
 .../grid/util/lang/GridPlainClosure.java        |    32 -
 .../grid/util/lang/GridPlainClosure2.java       |    33 -
 .../grid/util/lang/GridPlainFuture.java         |    79 -
 .../grid/util/lang/GridPlainFutureAdapter.java  |   299 -
 .../grid/util/lang/GridPlainInClosure.java      |    31 -
 .../grid/util/lang/GridPlainOutClosure.java     |    31 -
 .../grid/util/lang/GridPlainRunnable.java       |    25 -
 .../gridgain/grid/util/lang/GridPredicate3.java |    57 -
 .../grid/util/lang/GridPredicate3X.java         |    51 -
 .../org/gridgain/grid/util/lang/GridTriple.java |    54 -
 .../org/gridgain/grid/util/lang/GridTuple.java  |   147 -
 .../org/gridgain/grid/util/lang/GridTuple3.java |   226 -
 .../org/gridgain/grid/util/lang/GridTuple4.java |   257 -
 .../org/gridgain/grid/util/lang/GridTuple5.java |   288 -
 .../org/gridgain/grid/util/lang/GridTuple6.java |   322 -
 .../org/gridgain/grid/util/lang/GridTupleV.java |   189 -
 .../grid/util/lang/IgniteClosure2X.java         |    53 -
 .../gridgain/grid/util/lang/IgniteClosureX.java |    52 -
 .../grid/util/lang/IgniteInClosure2X.java       |    52 -
 .../grid/util/lang/IgniteInClosureX.java        |    51 -
 .../grid/util/lang/IgniteOutClosureX.java       |    50 -
 .../org/gridgain/grid/util/lang/IgnitePair.java |    53 -
 .../grid/util/lang/IgnitePredicate2X.java       |    53 -
 .../grid/util/lang/IgnitePredicateX.java        |    52 -
 .../gridgain/grid/util/lang/IgniteReducer2.java |    53 -
 .../grid/util/lang/IgniteReducer2X.java         |    50 -
 .../gridgain/grid/util/lang/IgniteReducer3.java |    55 -
 .../grid/util/lang/IgniteReducer3X.java         |    50 -
 .../gridgain/grid/util/lang/IgniteReducerX.java |    51 -
 .../nio/GridAbstractCommunicationClient.java    |   112 -
 .../grid/util/nio/GridBufferedParser.java       |    96 -
 .../grid/util/nio/GridCommunicationClient.java  |   112 -
 .../nio/GridConnectionBytesVerifyFilter.java    |   140 -
 .../grid/util/nio/GridDirectParser.java         |    84 -
 .../grid/util/nio/GridNioAsyncNotifyFilter.java |   142 -
 .../util/nio/GridNioBackPressureControl.java    |    56 -
 .../grid/util/nio/GridNioCodecFilter.java       |   140 -
 .../grid/util/nio/GridNioEmbeddedFuture.java    |    72 -
 .../grid/util/nio/GridNioException.java         |    58 -
 .../gridgain/grid/util/nio/GridNioFilter.java   |   244 -
 .../grid/util/nio/GridNioFilterAdapter.java     |   183 -
 .../grid/util/nio/GridNioFilterChain.java       |   293 -
 .../grid/util/nio/GridNioFinishedFuture.java    |   116 -
 .../gridgain/grid/util/nio/GridNioFuture.java   |   121 -
 .../grid/util/nio/GridNioFutureImpl.java        |   327 -
 .../grid/util/nio/GridNioMessageReader.java     |    42 -
 .../grid/util/nio/GridNioMessageTracker.java    |   121 -
 .../grid/util/nio/GridNioMessageWriter.java     |    49 -
 .../grid/util/nio/GridNioMetricsListener.java   |    33 -
 .../gridgain/grid/util/nio/GridNioParser.java   |    62 -
 .../util/nio/GridNioRecoveryDescriptor.java     |   364 -
 .../gridgain/grid/util/nio/GridNioServer.java   |  2306 ---
 .../grid/util/nio/GridNioServerBuffer.java      |   117 -
 .../grid/util/nio/GridNioServerListener.java    |    64 -
 .../util/nio/GridNioServerListenerAdapter.java  |    33 -
 .../gridgain/grid/util/nio/GridNioSession.java  |   168 -
 .../grid/util/nio/GridNioSessionImpl.java       |   312 -
 .../grid/util/nio/GridNioSessionMetaKey.java    |    66 -
 .../util/nio/GridSelectorNioSessionImpl.java    |   297 -
 .../util/nio/GridShmemCommunicationClient.java  |   149 -
 .../util/nio/GridTcpCommunicationClient.java    |   555 -
 .../util/nio/GridTcpNioCommunicationClient.java |   163 -
 .../org/gridgain/grid/util/nio/package.html     |    23 -
 .../grid/util/nio/ssl/GridNioSslFilter.java     |   419 -
 .../grid/util/nio/ssl/GridNioSslHandler.java    |   616 -
 .../org/gridgain/grid/util/nio/ssl/package.html |    23 -
 .../grid/util/nodestart/GridNodeCallable.java   |    29 -
 .../grid/util/nodestart/GridNodeStartUtils.java |   391 -
 .../nodestart/GridRemoteStartSpecification.java |   279 -
 .../grid/util/nodestart/GridSshProcessor.java   |    34 -
 .../grid/util/offheap/GridOffHeapEvent.java     |    47 -
 .../util/offheap/GridOffHeapEventListener.java  |    26 -
 .../util/offheap/GridOffHeapEvictListener.java  |    33 -
 .../grid/util/offheap/GridOffHeapMap.java       |   200 -
 .../util/offheap/GridOffHeapMapFactory.java     |   225 -
 .../GridOffHeapOutOfMemoryException.java        |    50 -
 .../util/offheap/GridOffHeapPartitionedMap.java |   218 -
 .../offheap/unsafe/GridOffHeapSmartPointer.java |    38 -
 .../unsafe/GridOffHeapSmartPointerFactory.java  |    29 -
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |  4457 ------
 .../unsafe/GridUnsafeCompoundMemory.java        |    35 -
 .../util/offheap/unsafe/GridUnsafeGuard.java    |   374 -
 .../grid/util/offheap/unsafe/GridUnsafeLru.java |   627 -
 .../offheap/unsafe/GridUnsafeLruPoller.java     |    30 -
 .../grid/util/offheap/unsafe/GridUnsafeMap.java |  1743 ---
 .../util/offheap/unsafe/GridUnsafeMemory.java   |   721 -
 .../unsafe/GridUnsafePartitionedMap.java        |   424 -
 .../java/org/gridgain/grid/util/package.html    |    24 -
 .../grid/util/portable/PortableRawReaderEx.java |    32 -
 .../grid/util/portable/PortableRawWriterEx.java |    43 -
 .../util/portscanner/GridJmxPortFinder.java     |   176 -
 .../gridgain/grid/util/portscanner/package.html |    23 -
 .../java/org/gridgain/grid/util/scala/impl.java |    35 -
 .../org/gridgain/grid/util/scala/package.html   |    24 -
 .../grid/util/snaptree/CopyOnWriteManager.java  |   390 -
 .../org/gridgain/grid/util/snaptree/Epoch.java  |   131 -
 .../gridgain/grid/util/snaptree/EpochNode.java  |   432 -
 .../grid/util/snaptree/SnapTreeMap.java         |  2897 ----
 .../gridgain/grid/util/snaptree/package.html    |    24 -
 .../grid/util/test/GridTestPrintStream.java     |   293 -
 .../util/test/GridTestPrintStreamFactory.java   |   128 -
 .../org/gridgain/grid/util/test/package.html    |    24 -
 .../grid/util/tostring/GridToStringBuilder.java |   588 -
 .../tostring/GridToStringClassDescriptor.java   |    85 -
 .../grid/util/tostring/GridToStringExclude.java |    32 -
 .../tostring/GridToStringFieldDescriptor.java   |    53 -
 .../grid/util/tostring/GridToStringInclude.java |    32 -
 .../grid/util/tostring/GridToStringOrder.java   |    37 -
 .../util/tostring/GridToStringThreadLocal.java  |    55 -
 .../gridgain/grid/util/tostring/package.html    |    23 -
 .../java/org/gridgain/grid/util/typedef/C1.java |    32 -
 .../java/org/gridgain/grid/util/typedef/C2.java |    33 -
 .../java/org/gridgain/grid/util/typedef/C3.java |    35 -
 .../java/org/gridgain/grid/util/typedef/CA.java |    32 -
 .../org/gridgain/grid/util/typedef/CAX.java     |    32 -
 .../org/gridgain/grid/util/typedef/CI1.java     |    31 -
 .../org/gridgain/grid/util/typedef/CI2.java     |    32 -
 .../org/gridgain/grid/util/typedef/CI3.java     |    32 -
 .../org/gridgain/grid/util/typedef/CIX1.java    |    33 -
 .../org/gridgain/grid/util/typedef/CIX2.java    |    32 -
 .../org/gridgain/grid/util/typedef/CIX3.java    |    29 -
 .../java/org/gridgain/grid/util/typedef/CO.java |    31 -
 .../org/gridgain/grid/util/typedef/COX.java     |    33 -
 .../org/gridgain/grid/util/typedef/CX1.java     |    34 -
 .../org/gridgain/grid/util/typedef/CX2.java     |    35 -
 .../org/gridgain/grid/util/typedef/CX3.java     |    33 -
 .../java/org/gridgain/grid/util/typedef/F.java  |    29 -
 .../java/org/gridgain/grid/util/typedef/G.java  |    29 -
 .../java/org/gridgain/grid/util/typedef/P1.java |    31 -
 .../java/org/gridgain/grid/util/typedef/P2.java |    32 -
 .../java/org/gridgain/grid/util/typedef/P3.java |    32 -
 .../java/org/gridgain/grid/util/typedef/PA.java |    29 -
 .../org/gridgain/grid/util/typedef/PAX.java     |    29 -
 .../org/gridgain/grid/util/typedef/PCE.java     |    33 -
 .../java/org/gridgain/grid/util/typedef/PE.java |    33 -
 .../org/gridgain/grid/util/typedef/PKV.java     |    31 -
 .../java/org/gridgain/grid/util/typedef/PN.java |    33 -
 .../org/gridgain/grid/util/typedef/PX1.java     |    33 -
 .../org/gridgain/grid/util/typedef/PX2.java     |    34 -
 .../org/gridgain/grid/util/typedef/PX3.java     |    32 -
 .../java/org/gridgain/grid/util/typedef/R1.java |    32 -
 .../java/org/gridgain/grid/util/typedef/R2.java |    31 -
 .../java/org/gridgain/grid/util/typedef/R3.java |    31 -
 .../org/gridgain/grid/util/typedef/RX1.java     |    34 -
 .../org/gridgain/grid/util/typedef/RX2.java     |    34 -
 .../org/gridgain/grid/util/typedef/RX3.java     |    34 -
 .../java/org/gridgain/grid/util/typedef/T1.java |    51 -
 .../java/org/gridgain/grid/util/typedef/T2.java |    52 -
 .../java/org/gridgain/grid/util/typedef/T3.java |    52 -
 .../java/org/gridgain/grid/util/typedef/T4.java |    53 -
 .../java/org/gridgain/grid/util/typedef/T5.java |    54 -
 .../java/org/gridgain/grid/util/typedef/T6.java |    55 -
 .../java/org/gridgain/grid/util/typedef/X.java  |   937 --
 .../gridgain/grid/util/typedef/internal/A.java  |    28 -
 .../gridgain/grid/util/typedef/internal/CU.java |    30 -
 .../gridgain/grid/util/typedef/internal/D.java  |    28 -
 .../grid/util/typedef/internal/GPC.java         |    27 -
 .../grid/util/typedef/internal/GPR.java         |    27 -
 .../gridgain/grid/util/typedef/internal/LT.java |    28 -
 .../gridgain/grid/util/typedef/internal/S.java  |    28 -
 .../gridgain/grid/util/typedef/internal/SB.java |    63 -
 .../gridgain/grid/util/typedef/internal/U.java  |    28 -
 .../grid/util/typedef/internal/package.html     |    23 -
 .../org/gridgain/grid/util/typedef/package.html |    23 -
 .../gridgain/grid/util/worker/GridWorker.java   |   305 -
 .../grid/util/worker/GridWorkerFuture.java      |    70 -
 .../grid/util/worker/GridWorkerListener.java    |    35 -
 .../util/worker/GridWorkerListenerAdapter.java  |    33 -
 .../grid/util/worker/GridWorkerPool.java        |   117 -
 .../org/gridgain/grid/util/worker/package.html  |    24 -
 .../org/gridgain/jdbc/GridJdbcConnection.java   |   547 -
 .../gridgain/jdbc/GridJdbcConnectionInfo.java   |    91 -
 .../gridgain/jdbc/GridJdbcDatabaseMetadata.java |  1314 --
 .../java/org/gridgain/jdbc/GridJdbcDriver.java  |   483 -
 .../jdbc/GridJdbcPreparedStatement.java         |   411 -
 .../org/gridgain/jdbc/GridJdbcResultSet.java    |  1520 --
 .../jdbc/GridJdbcResultSetMetadata.java         |   172 -
 .../org/gridgain/jdbc/GridJdbcStatement.java    |   449 -
 .../main/java/org/gridgain/jdbc/package.html    |    23 -
 .../main/java/org/gridgain/jdbc/typedef/JU.java |    28 -
 .../java/org/gridgain/jdbc/typedef/package.html |    23 -
 .../org/gridgain/jdbc/util/GridJdbcUtils.java   |   233 -
 .../java/org/gridgain/jdbc/util/package.html    |    23 -
 .../core/src/test/config/discovery-stress.xml   |     2 +-
 .../hadoop/core-site-loopback-secondary.xml     |     4 +-
 .../test/config/hadoop/core-site-loopback.xml   |     4 +-
 .../test/config/hadoop/core-site-secondary.xml  |     4 +-
 .../core/src/test/config/hadoop/core-site.xml   |     4 +-
 .../src/test/config/io-manager-benchmark.xml    |     2 +-
 modules/core/src/test/config/jobs-load-base.xml |     2 +-
 .../config/load/dsi-49-server-production.xml    |     4 +-
 .../core/src/test/config/load/dsi-load-base.xml |    14 +-
 .../src/test/config/load/dsi-load-server.xml    |     4 +-
 .../core/src/test/config/spring-cache-swap.xml  |     2 +-
 .../src/test/config/spring-cache-teststore.xml  |     2 +-
 .../core/src/test/config/spring-multicache.xml  |    16 +-
 .../average/spring-streamer-average-base.xml    |    10 +-
 modules/core/src/test/config/tests.properties   |     2 +-
 .../GridCacheAffinityBackupsSelfTest.java       |   112 +
 .../ignite/GridExceptionHelpLinksSelfTest.java  |   106 +
 .../ignite/GridExternalizableAbstractTest.java  |    41 +
 .../ignite/GridSuppressedExceptionSelfTest.java |   141 +
 .../java/org/apache/ignite/GridTestIoUtils.java |   198 +
 .../java/org/apache/ignite/GridTestJob.java     |    51 +
 .../org/apache/ignite/GridTestJobContext.java   |   103 +
 .../org/apache/ignite/GridTestJobResult.java    |    91 +
 .../org/apache/ignite/GridTestNodeStartup.java  |    49 +
 .../apache/ignite/GridTestStoreNodeStartup.java |    58 +
 .../java/org/apache/ignite/GridTestTask.java    |    53 +
 .../org/apache/ignite/GridTestTaskSession.java  |   235 +
 ...CachePartitionFairAffinityNodesSelfTest.java |   242 +
 .../GridCachePartitionFairAffinitySelfTest.java |   261 +
 .../store/GridCacheBalancingStoreSelfTest.java  |   199 +
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |   114 +
 .../cache/store/GridGeneratingTestStore.java    |   102 +
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |    21 +-
 .../jdbc/GridCacheJdbcBlobStoreSelfTest.java    |     2 +-
 .../org/apache/ignite/cache/store/package.html  |    23 +
 .../fs/GridGgfsEventsAbstractSelfTest.java      |   849 ++
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   168 +
 .../ignite/fs/GridGgfsFragmentizerSelfTest.java |   268 +
 .../GridGgfsFragmentizerTopologySelfTest.java   |    49 +
 .../apache/ignite/fs/GridGgfsPathSelfTest.java  |   162 +
 .../ignite/fs/GridGgfsTestInputGenerator.java   |    51 +
 .../ignite/internal/ClusterMetricsSelfTest.java |   353 +
 .../internal/ClusterNodeMetricsSelfTest.java    |   246 +
 .../ignite/internal/GridAffinityMappedTest.java |   164 +
 .../internal/GridAffinityP2PSelfTest.java       |   205 +
 .../ignite/internal/GridAffinitySelfTest.java   |   118 +
 .../GridAlwaysFailoverSpiFailSelfTest.java      |   159 +
 .../internal/GridCacheProjectionRemoveTest.java |    41 +
 .../internal/GridCancelOnGridStopSelfTest.java  |   107 +
 .../internal/GridCancelUnusedJobSelfTest.java   |   220 +
 .../GridCancelledJobsMetricsSelfTest.java       |   214 +
 .../GridCollisionJobsContextSelfTest.java       |   112 +
 .../internal/GridCommunicationSelfTest.java     |   121 +
 .../GridContinuousJobAnnotationSelfTest.java    |   215 +
 .../GridContinuousJobSiblingsSelfTest.java      |   145 +
 .../internal/GridContinuousTaskSelfTest.java    |   348 +
 .../GridDeploymentMultiThreadedSelfTest.java    |   121 +
 .../ignite/internal/GridDeploymentSelfTest.java |   535 +
 .../internal/GridDiscoveryEventSelfTest.java    |   421 +
 .../ignite/internal/GridDiscoverySelfTest.java  |   418 +
 .../GridEventStorageCheckAllEventsSelfTest.java |   433 +
 ...ventStorageRuntimeConfigurationSelfTest.java |   347 +
 .../internal/GridEventStorageSelfTest.java      |   268 +
 .../internal/GridExecutorServiceTest.java       |   315 +
 .../GridExplicitImplicitDeploymentSelfTest.java |   476 +
 .../internal/GridFactoryVmShutdownTest.java     |   101 +
 .../GridFailedInputParametersSelfTest.java      |   154 +
 .../GridFailoverCustomTopologySelfTest.java     |   188 +
 .../ignite/internal/GridFailoverSelfTest.java   |   151 +
 .../GridFailoverTaskWithPredicateSelfTest.java  |   252 +
 .../internal/GridFailoverTopologySelfTest.java  |   160 +
 .../ignite/internal/GridHomePathSelfTest.java   |    75 +
 .../GridJobCheckpointCleanupSelfTest.java       |   164 +
 .../GridJobCollisionCancelSelfTest.java         |   276 +
 .../ignite/internal/GridJobContextSelfTest.java |   121 +
 .../GridJobMasterLeaveAwareSelfTest.java        |   801 +
 .../internal/GridJobStealingSelfTest.java       |   439 +
 .../GridJobStealingZeroActiveJobsSelfTest.java  |   169 +
 .../internal/GridJobSubjectIdSelfTest.java      |   153 +
 .../GridKernalConcurrentAccessStopSelfTest.java |    63 +
 .../ignite/internal/GridKernalTestUtils.java    |    45 +
 .../internal/GridLifecycleAwareSelfTest.java    |   196 +
 .../internal/GridLifecycleBeanSelfTest.java     |   312 +
 .../internal/GridListenActorSelfTest.java       |   233 +
 .../GridLocalEventListenerSelfTest.java         |    73 +
 .../internal/GridManagementJobSelfTest.java     |   167 +
 .../internal/GridMultipleJobsSelfTest.java      |   231 +
 .../internal/GridMultipleSpisSelfTest.java      |   302 +
 .../GridMultipleVersionsDeploymentSelfTest.java |   306 +
 .../GridMultithreadedJobStealingSelfTest.java   |   240 +
 .../ignite/internal/GridNodeFilterSelfTest.java |    78 +
 .../ignite/internal/GridNodeLocalSelfTest.java  |    65 +
 .../GridNodeVisorAttributesSelfTest.java        |   114 +
 .../internal/GridNonHistoryMetricsSelfTest.java |   124 +
 .../internal/GridProjectionAbstractTest.java    |   768 +
 .../GridProjectionForCachesSelfTest.java        |   256 +
 ...ectionLocalJobMultipleArgumentsSelfTest.java |   156 +
 .../ignite/internal/GridProjectionSelfTest.java |   145 +
 .../ignite/internal/GridReduceSelfTest.java     |   194 +
 .../internal/GridReleaseTypeSelfTest.java       |   135 +
 .../internal/GridRuntimeExceptionSelfTest.java  |   302 +
 .../internal/GridSameVmStartupSelfTest.java     |   107 +
 .../apache/ignite/internal/GridSelfTest.java    |   166 +
 .../internal/GridSpiExceptionSelfTest.java      |   174 +
 .../ignite/internal/GridStartStopSelfTest.java  |   182 +
 .../apache/ignite/internal/GridStartupMain.java |    57 +
 .../apache/ignite/internal/GridStartupTest.java |    69 +
 .../internal/GridStopWithCancelSelfTest.java    |   122 +
 .../internal/GridStopWithWaitSelfTest.java      |   263 +
 .../GridTaskCancelSingleNodeSelfTest.java       |   185 +
 .../GridTaskContinuousMapperSelfTest.java       |   331 +
 .../GridTaskExecutionContextSelfTest.java       |   178 +
 .../internal/GridTaskExecutionSelfTest.java     |    68 +
 .../internal/GridTaskFailoverSelfTest.java      |   117 +
 .../GridTaskFutureImplStopGridSelfTest.java     |   213 +
 .../GridTaskInstanceExecutionSelfTest.java      |   121 +
 .../internal/GridTaskInstantiationSelfTest.java |   117 +
 .../internal/GridTaskJobRejectSelfTest.java     |   160 +
 .../internal/GridTaskListenerSelfTest.java      |   106 +
 .../internal/GridTaskMapAsyncSelfTest.java      |   141 +
 .../GridTaskNameAnnotationSelfTest.java         |   124 +
 .../internal/GridTaskResultCacheSelfTest.java   |   129 +
 .../internal/GridTaskTimeoutSelfTest.java       |   223 +
 .../GridTopicExternalizableSelfTest.java        |   166 +
 .../GridTopologyBuildVersionSelfTest.java       |   102 +
 .../internal/GridUpdateNotifierSelfTest.java    |    92 +
 .../ignite/internal/GridVersionSelfTest.java    |    69 +
 .../managers/GridManagerStopSelfTest.java       |   225 +
 .../managers/GridNoopManagerSelfTest.java       |    96 +
 .../GridCheckpointManagerAbstractSelfTest.java  |   755 +
 .../GridCheckpointManagerSelfTest.java          |    68 +
 .../checkpoint/GridCheckpointTaskSelfTest.java  |   233 +
 .../internal/managers/checkpoint/package.html   |    23 +
 ...idCommunicationManagerListenersSelfTest.java |   158 +
 .../GridCommunicationSendMessageSelfTest.java   |   173 +
 .../communication/GridIoManagerSelfTest.java    |   249 +
 .../managers/communication/package.html         |    23 +
 .../GridDeploymentManagerStopSelfTest.java      |    99 +
 .../GridDeploymentMessageCountSelfTest.java     |   210 +
 .../managers/deployment/GridTestDeployment.java |    39 +
 .../internal/managers/deployment/package.html   |    23 +
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   237 +
 .../GridDiscoveryManagerAttributesSelfTest.java |   171 +
 .../discovery/GridDiscoveryManagerSelfTest.java |   154 +
 .../events/GridEventStorageManagerSelfTest.java |   125 +
 .../ignite/internal/managers/package.html       |    23 +
 .../GridSwapSpaceCustomLocalValue.java          |    85 +
 .../swapspace/GridSwapSpaceManagerSelfTest.java |   164 +
 .../internal/managers/swapspace/package.html    |    23 +
 .../org/apache/ignite/internal/package.html     |    24 +
 .../GridAffinityProcessorAbstractSelfTest.java  |   194 +
 ...AffinityProcessorConsistentHashSelfTest.java |    31 +
 ...GridAffinityProcessorRendezvousSelfTest.java |    31 +
 ...ridCacheAbstractByteArrayValuesSelfTest.java |    83 +
 .../GridCacheAbstractFailoverSelfTest.java      |   431 +
 .../cache/GridCacheAbstractFlagsTest.java       |    98 +
 ...cheAbstractFullApiMultithreadedSelfTest.java |   402 +
 .../cache/GridCacheAbstractFullApiSelfTest.java |  5090 +++++++
 .../GridCacheAbstractIteratorsSelfTest.java     |   349 +
 .../cache/GridCacheAbstractMetricsSelfTest.java |   218 +
 .../GridCacheAbstractProjectionSelfTest.java    |   834 ++
 .../GridCacheAbstractRemoveFailureTest.java     |   322 +
 .../cache/GridCacheAbstractSelfTest.java        |   603 +
 .../cache/GridCacheAbstractTxReadTest.java      |   137 +
 .../cache/GridCacheAffinityApiSelfTest.java     |   361 +
 .../cache/GridCacheAffinityMapperSelfTest.java  |   132 +
 .../cache/GridCacheAffinityRoutingSelfTest.java |   689 +
 .../cache/GridCacheAlwaysEvictionPolicy.java    |    34 +
 .../GridCacheAsyncOperationsLimitSelfTest.java  |    76 +
 .../GridCacheAtomicMessageCountSelfTest.java    |   233 +
 .../cache/GridCacheBasicApiAbstractTest.java    |   663 +
 .../cache/GridCacheBasicStoreAbstractTest.java  |   589 +
 ...acheBasicStoreMultithreadedAbstractTest.java |   132 +
 .../cache/GridCacheClearAllSelfTest.java        |   335 +
 ...dCacheColocatedTxStoreExceptionSelfTest.java |    38 +
 .../cache/GridCacheConcurrentMapSelfTest.java   |   384 +
 .../cache/GridCacheConcurrentMapTest.java       |   137 +
 .../GridCacheConcurrentTxMultiNodeTest.java     |   856 ++
 ...idCacheConfigurationConsistencySelfTest.java |  1073 ++
 ...ridCacheConfigurationValidationSelfTest.java |   196 +
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   189 +
 .../GridCacheDeploymentOffHeapSelfTest.java     |    42 +
 .../cache/GridCacheDeploymentSelfTest.java      |   485 +
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   314 +
 .../cache/GridCacheEntryVersionSelfTest.java    |   158 +
 .../GridCacheEvictionEventAbstractTest.java     |   121 +
 .../GridCacheExAbstractFullApiSelfTest.java     |   103 +
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    82 +
 .../GridCacheFinishPartitionsSelfTest.java      |   312 +
 ...CacheFullTextQueryMultithreadedSelfTest.java |   156 +
 .../cache/GridCacheGenericTestStore.java        |   274 +
 ...idCacheGetAndTransformStoreAbstractTest.java |   176 +
 .../cache/GridCacheGlobalClearAllSelfTest.java  |   167 +
 .../GridCacheGroupLockAbstractSelfTest.java     |  1328 ++
 ...heGroupLockFailoverOptimisticTxSelfTest.java |    28 +
 .../GridCacheGroupLockFailoverSelfTest.java     |   532 +
 ...CacheGroupLockMultiNodeAbstractSelfTest.java |    28 +
 .../cache/GridCacheGroupLockPutTask.java        |   157 +
 .../cache/GridCacheIncrementTransformTest.java  |   233 +
 .../GridCacheInterceptorAbstractSelfTest.java   |  1648 +++
 ...cheInterceptorAtomicNearEnabledSelfTest.java |    32 +
 ...erceptorAtomicPrimaryWriteOrderSelfTest.java |    45 +
 ...omicReplicatedPrimaryWriteOrderSelfTest.java |    46 +
 ...acheInterceptorAtomicReplicatedSelfTest.java |    45 +
 .../GridCacheInterceptorAtomicSelfTest.java     |    45 +
 ...ceptorAtomicWithStoreReplicatedSelfTest.java |    29 +
 ...CacheInterceptorAtomicWithStoreSelfTest.java |    28 +
 ...GridCacheInterceptorLocalAtomicSelfTest.java |    50 +
 ...InterceptorLocalAtomicWithStoreSelfTest.java |    28 +
 .../GridCacheInterceptorLocalSelfTest.java      |    44 +
 ...dCacheInterceptorLocalWithStoreSelfTest.java |    28 +
 ...GridCacheInterceptorNearEnabledSelfTest.java |    30 +
 .../GridCacheInterceptorReplicatedSelfTest.java |    39 +
 ...eInterceptorReplicatedWithStoreSelfTest.java |    28 +
 .../cache/GridCacheInterceptorSelfTest.java     |    39 +
 .../GridCacheInterceptorWithStoreSelfTest.java  |    28 +
 .../cache/GridCacheIteratorPerformanceTest.java |   277 +
 .../GridCacheKeyCheckNearEnabledSelfTest.java   |    30 +
 .../cache/GridCacheKeyCheckSelfTest.java        |   205 +
 .../processors/cache/GridCacheLeakTest.java     |   150 +
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   367 +
 .../GridCacheLocalTxStoreExceptionSelfTest.java |    37 +
 .../cache/GridCacheLuceneQueryIndexTest.java    |   465 +
 .../GridCacheMarshallerTxAbstractTest.java      |   132 +
 .../cache/GridCacheMemoryModeSelfTest.java      |   268 +
 .../GridCacheMissingCommitVersionSelfTest.java  |   127 +
 ...GridCacheMixedPartitionExchangeSelfTest.java |   152 +
 .../cache/GridCacheMultiUpdateLockSelfTest.java |   203 +
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |   134 +
 ...ultinodeUpdateAtomicNearEnabledSelfTest.java |    39 +
 .../GridCacheMultinodeUpdateAtomicSelfTest.java |    38 +
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    39 +
 ...CacheMultinodeUpdateNearEnabledSelfTest.java |    40 +
 .../cache/GridCacheMultinodeUpdateSelfTest.java |    39 +
 .../cache/GridCacheMvccFlagsTest.java           |   141 +
 .../cache/GridCacheMvccManagerSelfTest.java     |   115 +
 .../cache/GridCacheMvccPartitionedSelfTest.java |   687 +
 .../processors/cache/GridCacheMvccSelfTest.java |  1850 +++
 .../GridCacheNearTxStoreExceptionSelfTest.java  |    32 +
 .../cache/GridCacheNestedTxAbstractTest.java    |   279 +
 .../cache/GridCacheObjectToStringSelfTest.java  |   193 +
 ...ffHeapAtomicMultiThreadedUpdateSelfTest.java |    33 +
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |   398 +
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   270 +
 .../cache/GridCacheOffHeapSelfTest.java         |   654 +
 .../processors/cache/GridCacheOffHeapTest.java  |   257 +
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   682 +
 .../GridCacheOffHeapTieredAtomicSelfTest.java   |    32 +
 ...heOffHeapTieredEvictionAbstractSelfTest.java |   422 +
 ...acheOffHeapTieredEvictionAtomicSelfTest.java |    32 +
 .../GridCacheOffHeapTieredEvictionSelfTest.java |    33 +
 .../cache/GridCacheOffHeapTieredSelfTest.java   |    33 +
 .../cache/GridCacheOffheapUpdateSelfTest.java   |   139 +
 .../GridCacheOrderedPreloadingSelfTest.java     |   157 +
 .../cache/GridCacheP2PUndeploySelfTest.java     |   305 +
 .../GridCachePartitionedAffinitySpreadTest.java |   167 +
 .../cache/GridCachePartitionedGetSelfTest.java  |   252 +
 ...hePartitionedProjectionAffinitySelfTest.java |   118 +
 .../cache/GridCachePartitionedWritesTest.java   |   148 +
 .../GridCachePreloadingEvictionsSelfTest.java   |   261 +
 .../cache/GridCachePutAllFailoverSelfTest.java  |   707 +
 .../processors/cache/GridCachePutAllTask.java   |   132 +
 .../cache/GridCacheQueryEmbeddedValue.java      |    49 +
 .../cache/GridCacheQueryIndexSelfTest.java      |   124 +
 .../GridCacheQueryIndexingDisabledSelfTest.java |    98 +
 .../GridCacheQueryInternalKeysSelfTest.java     |   112 +
 .../GridCacheReferenceCleanupSelfTest.java      |   502 +
 .../cache/GridCacheReloadSelfTest.java          |   178 +
 ...ridCacheReplicatedSynchronousCommitTest.java |   202 +
 ...CacheReplicatedTxStoreExceptionSelfTest.java |    38 +
 .../GridCacheReturnValueTransferSelfTest.java   |   206 +
 .../cache/GridCacheSlowTxWarnTest.java          |   147 +
 .../processors/cache/GridCacheStopSelfTest.java |   201 +
 .../cache/GridCacheStorePutxSelfTest.java       |   159 +
 .../cache/GridCacheStoreValueBytesSelfTest.java |   111 +
 .../cache/GridCacheSwapPreloadSelfTest.java     |   223 +
 .../cache/GridCacheSwapReloadSelfTest.java      |   240 +
 .../processors/cache/GridCacheTestEntryEx.java  |   820 ++
 .../processors/cache/GridCacheTestKey.java      |    64 +
 .../processors/cache/GridCacheTestStore.java    |   334 +
 .../processors/cache/GridCacheTestValue.java    |    77 +
 .../processors/cache/GridCacheTestValue2.java   |    67 +
 ...cheTransactionalAbstractMetricsSelfTest.java |   280 +
 .../cache/GridCacheTtlManagerLoadTest.java      |    85 +
 .../cache/GridCacheTtlManagerSelfTest.java      |   120 +
 .../cache/GridCacheUtilsSelfTest.java           |   261 +
 .../GridCacheValueBytesPreloadingSelfTest.java  |   151 +
 ...idCacheValueConsistencyAbstractSelfTest.java |   322 +
 ...istencyTransactionalNearEnabledSelfTest.java |    31 +
 ...heValueConsistencyTransactionalSelfTest.java |    37 +
 .../GridCacheVariableTopologySelfTest.java      |   191 +
 .../cache/GridCacheVersionSelfTest.java         |    81 +
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   189 +
 .../GridCacheWriteBehindStoreAbstractTest.java  |   358 +
 .../GridCacheWriteBehindStoreLocalTest.java     |    30 +
 ...heWriteBehindStoreMultithreadedSelfTest.java |   164 +
 ...BehindStorePartitionedMultiNodeSelfTest.java |   216 +
 ...ridCacheWriteBehindStorePartitionedTest.java |    30 +
 ...GridCacheWriteBehindStoreReplicatedTest.java |    30 +
 .../GridCacheWriteBehindStoreSelfTest.java      |   267 +
 .../cache/IgniteCacheAbstractTest.java          |    19 +-
 .../cache/IgniteCacheAtomicInvokeTest.java      |    18 +-
 .../cache/IgniteCacheAtomicLocalInvokeTest.java |    14 +-
 .../IgniteCacheAtomicNearEnabledInvokeTest.java |     6 +-
 ...eCacheAtomicPrimaryWriteOrderInvokeTest.java |    18 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |    13 +-
 ...IgniteCacheEntryListenerAtomicLocalTest.java |    14 +-
 ...eCacheEntryListenerAtomicReplicatedTest.java |     6 +-
 .../IgniteCacheEntryListenerAtomicTest.java     |    18 +-
 ...eCacheEntryListenerEagerTtlDisabledTest.java |     1 -
 .../IgniteCacheEntryListenerTxLocalTest.java    |    14 +-
 ...gniteCacheEntryListenerTxReplicatedTest.java |     6 +-
 .../cache/IgniteCacheEntryListenerTxTest.java   |    14 +-
 .../IgniteCacheInterceptorSelfTestSuite.java    |    56 +
 .../cache/IgniteCacheInvokeAbstractTest.java    |    12 +-
 .../cache/IgniteCacheInvokeReadThroughTest.java |    14 +-
 .../cache/IgniteCacheTxInvokeTest.java          |    14 +-
 .../cache/IgniteCacheTxLocalInvokeTest.java     |    14 +-
 .../IgniteCacheTxNearEnabledInvokeTest.java     |     6 +-
 .../cache/IgniteCachingProviderSelfTest.java    |    13 +-
 .../processors/cache/IgniteTxAbstractTest.java  |   492 +
 .../IgniteTxConcurrentGetAbstractTest.java      |   143 +
 .../IgniteTxExceptionAbstractSelfTest.java      |   648 +
 .../cache/IgniteTxMultiNodeAbstractTest.java    |   926 ++
 .../IgniteTxMultiThreadedAbstractTest.java      |   283 +
 .../cache/IgniteTxReentryAbstractSelfTest.java  |   177 +
 .../IgniteTxSingleThreadedAbstractTest.java     |   137 +
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   658 +
 ...eAbstractDataStructuresFailoverSelfTest.java |   994 ++
 ...actQueueFailoverDataConsistencySelfTest.java |   379 +
 .../GridCacheAtomicLongApiSelfTest.java         |   484 +
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   213 +
 ...cheAtomicReferenceMultiNodeAbstractTest.java |   201 +
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   153 +
 .../GridCacheCountDownLatchSelfTest.java        |   410 +
 .../GridCacheMultiNodeDataStructureTest.java    |    78 +
 .../GridCacheQueueApiSelfAbstractTest.java      |   712 +
 .../GridCacheQueueCleanupSelfTest.java          |   235 +
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   305 +
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |   831 ++
 ...dCacheQueueMultiNodeConsistencySelfTest.java |   255 +
 ...CacheQueueRotativeMultiNodeAbstractTest.java |   441 +
 .../GridCacheSequenceApiSelfAbstractTest.java   |   572 +
 ...dCacheSequenceMultiNodeAbstractSelfTest.java |   289 +
 .../GridCacheSetAbstractSelfTest.java           |   897 ++
 .../GridCacheSetFailoverAbstractSelfTest.java   |   245 +
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    39 +
 .../local/GridCacheLocalAtomicSetSelfTest.java  |    44 +
 .../local/GridCacheLocalQueueApiSelfTest.java   |    44 +
 .../GridCacheLocalSequenceApiSelfTest.java      |    46 +
 .../local/GridCacheLocalSetSelfTest.java        |    38 +
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    41 +
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    39 +
 ...micQueueFailoverDataConsistencySelfTest.java |    34 +
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    41 +
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    42 +
 ...hePartitionedAtomicReferenceApiSelfTest.java |    48 +
 ...PartitionedAtomicReferenceMultiNodeTest.java |    46 +
 ...titionedAtomicSequenceMultiThreadedTest.java |   359 +
 ...chePartitionedAtomicSetFailoverSelfTest.java |    39 +
 .../GridCachePartitionedAtomicSetSelfTest.java  |    49 +
 ...achePartitionedAtomicStampedApiSelfTest.java |    52 +
 ...rtitionedDataStructuresFailoverSelfTest.java |    34 +
 ...GridCachePartitionedNodeRestartSelfTest.java |    68 +
 ...idCachePartitionedNodeRestartTxSelfTest.java |   294 +
 .../GridCachePartitionedQueueApiSelfTest.java   |    52 +
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   194 +
 ...dCachePartitionedQueueEntryMoveSelfTest.java |   254 +
 ...nedQueueFailoverDataConsistencySelfTest.java |    27 +
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    52 +
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    50 +
 ...hePartitionedQueueRotativeMultiNodeTest.java |    49 +
 ...GridCachePartitionedSequenceApiSelfTest.java |    51 +
 ...chePartitionedSequenceMultiNodeSelfTest.java |    51 +
 ...GridCachePartitionedSetFailoverSelfTest.java |    33 +
 .../GridCachePartitionedSetSelfTest.java        |    33 +
 ...cheReplicatedAtomicReferenceApiSelfTest.java |    45 +
 ...eReplicatedAtomicReferenceMultiNodeTest.java |    45 +
 ...CacheReplicatedAtomicStampedApiSelfTest.java |    44 +
 ...eplicatedDataStructuresFailoverSelfTest.java |    34 +
 .../GridCacheReplicatedQueueApiSelfTest.java    |    47 +
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    47 +
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    47 +
 .../GridCacheReplicatedSequenceApiSelfTest.java |    46 +
 ...acheReplicatedSequenceMultiNodeSelfTest.java |    46 +
 .../GridCacheReplicatedSetSelfTest.java         |    33 +
 ...tractDistributedByteArrayValuesSelfTest.java |   389 +
 .../GridCacheAbstractJobExecutionTest.java      |   183 +
 .../GridCacheAbstractNodeRestartSelfTest.java   |   886 ++
 ...tractPartitionedByteArrayValuesSelfTest.java |   100 +
 .../GridCacheAbstractPrimarySyncSelfTest.java   |   108 +
 .../GridCacheAtomicTimeoutSelfTest.java         |   296 +
 .../GridCacheBasicOpAbstractTest.java           |   388 +
 .../GridCacheClientModesAbstractSelfTest.java   |   209 +
 .../GridCacheEntrySetAbstractSelfTest.java      |   117 +
 ...acheEntrySetIterationPreloadingSelfTest.java |    90 +
 .../distributed/GridCacheEventAbstractTest.java |   964 ++
 ...heExpiredEntriesPreloadAbstractSelfTest.java |   118 +
 .../distributed/GridCacheLockAbstractTest.java  |   462 +
 .../distributed/GridCacheMixedModeSelfTest.java |    81 +
 .../GridCacheModuloAffinityFunction.java        |   200 +
 .../GridCacheMultiNodeAbstractTest.java         |   490 +
 .../GridCacheMultiNodeLockAbstractTest.java     |   634 +
 ...dCacheMultithreadedFailoverAbstractTest.java |   606 +
 .../GridCacheNodeFailureAbstractTest.java       |   296 +
 ...dCachePartitionedAffinityFilterSelfTest.java |   144 +
 ...chePartitionedReloadAllAbstractSelfTest.java |   248 +
 .../GridCachePreloadEventsAbstractSelfTest.java |   131 +
 .../GridCachePreloadLifecycleAbstractTest.java  |   231 +
 ...GridCachePreloadRestartAbstractSelfTest.java |   322 +
 .../GridCacheTransformEventSelfTest.java        |   609 +
 ...iteTxConsistencyRestartAbstractSelfTest.java |   202 +
 ...xOriginatingNodeFailureAbstractSelfTest.java |   305 +
 ...cOriginatingNodeFailureAbstractSelfTest.java |   503 +
 .../IgniteTxPreloadAbstractTest.java            |   220 +
 .../IgniteTxTimeoutAbstractTest.java            |   155 +
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |   168 +
 ...heAbstractTransformWriteThroughSelfTest.java |   336 +
 ...acheAtomicExpiredEntriesPreloadSelfTest.java |    45 +
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   100 +
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |   820 ++
 ...idCacheAtomicNearEnabledFullApiSelfTest.java |    32 +
 ...EnabledPrimaryWriteOrderFullApiSelfTest.java |    33 +
 ...eAtomicPrimaryWriteOrderFullApiSelfTest.java |    32 +
 ...tomicPrimaryWriteOrderReloadAllSelfTest.java |    32 +
 .../dht/GridCacheAtomicReloadAllSelfTest.java   |    38 +
 .../dht/GridCacheClientOnlySelfTest.java        |    38 +
 .../dht/GridCacheColocatedDebugTest.java        |   977 ++
 .../dht/GridCacheColocatedFailoverSelfTest.java |    39 +
 ...eColocatedOptimisticTransactionSelfTest.java |   156 +
 ...ridCacheColocatedPreloadRestartSelfTest.java |    30 +
 .../GridCacheColocatedPrimarySyncSelfTest.java  |    33 +
 .../GridCacheColocatedReloadAllSelfTest.java    |    30 +
 .../GridCacheColocatedTxExceptionSelfTest.java  |    39 +
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 +
 ...dCacheColocatedTxSingleThreadedSelfTest.java |   107 +
 .../GridCacheDaemonNodePartitionedSelfTest.java |    31 +
 ...cheDhtAtomicEvictionNearReadersSelfTest.java |    32 +
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    50 +
 .../dht/GridCacheDhtEntrySelfTest.java          |   314 +
 .../dht/GridCacheDhtEntrySetSelfTest.java       |    45 +
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   297 +
 .../dht/GridCacheDhtEvictionSelfTest.java       |   363 +
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |   125 +
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java |    39 +
 .../dht/GridCacheDhtInternalEntrySelfTest.java  |   225 +
 .../dht/GridCacheDhtMappingSelfTest.java        |   105 +
 .../dht/GridCacheDhtMultiBackupTest.java        |   135 +
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |   228 +
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |   459 +
 .../GridCacheDhtPreloadDisabledSelfTest.java    |   278 +
 .../GridCacheDhtPreloadMessageCountTest.java    |   175 +
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   175 +
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |    39 +
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |   275 +
 .../dht/GridCacheDhtPreloadSelfTest.java        |   674 +
 .../GridCacheDhtPreloadStartStopSelfTest.java   |   269 +
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |   321 +
 .../dht/GridCacheDhtRemoveFailureTest.java      |    44 +
 .../distributed/dht/GridCacheDhtTestUtils.java  |   231 +
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    44 +
 .../GridCacheExColocatedFullApiSelfTest.java    |    33 +
 .../dht/GridCacheGlobalLoadTest.java            |   171 +
 .../GridCacheGroupLockColocatedSelfTest.java    |    38 +
 ...acheGroupLockMultiNodeColocatedSelfTest.java |    29 +
 ...cheGroupLockPartitionedAbstractSelfTest.java |   136 +
 ...ockPartitionedMultiNodeAbstractSelfTest.java |   173 +
 ...ePartitionedNearDisabledFullApiSelfTest.java |    33 +
 ...ePartitionedNearDisabledMetricsSelfTest.java |   119 +
 ...nedNearDisabledMultiNodeFullApiSelfTest.java |    34 +
 ...bledMultiNodeP2PDisabledFullApiSelfTest.java |    34 +
 ...ionedNearDisabledOffHeapFullApiSelfTest.java |    29 +
 ...DisabledOffHeapMultiNodeFullApiSelfTest.java |    29 +
 ...isabledTxOriginatingNodeFailureSelfTest.java |    31 +
 ...dOnlyP2PDisabledByteArrayValuesSelfTest.java |    29 +
 ...edOnlyP2PEnabledByteArrayValuesSelfTest.java |    29 +
 ...dCachePartitionedOnlyProjectionSelfTest.java |    32 +
 ...idCachePartitionedPreloadEventsSelfTest.java |   124 +
 ...dCachePartitionedTopologyChangeSelfTest.java |   596 +
 ...ransformWriteThroughBatchUpdateSelfTest.java |    29 +
 ...itionedTxOriginatingNodeFailureSelfTest.java |   161 +
 ...ridCachePartitionedUnloadEventsSelfTest.java |   151 +
 ...teTxConsistencyColocatedRestartSelfTest.java |    36 +
 .../dht/IgniteTxReentryColocatedSelfTest.java   |    79 +
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   326 +
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |   214 +
 ...lueConsistencyAtomicNearEnabledSelfTest.java |    38 +
 ...micPrimaryWriteOrderNearEnabledSelfTest.java |    39 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |   139 +
 ...tNearPartitionedByteArrayValuesSelfTest.java |    34 +
 ...unctionExcludeNeighborsAbstractSelfTest.java |   184 +
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   501 +
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |    68 +
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |    66 +
 ...omicNearEnabledMultiNodeFullApiSelfTest.java |    32 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 +
 ...ridCacheAtomicNearEvictionEventSelfTest.java |    39 +
 .../GridCacheAtomicNearEvictionSelfTest.java    |    32 +
 .../GridCacheAtomicNearMultiNodeSelfTest.java   |    32 +
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |   192 +
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 .../near/GridCacheAtomicNearOnlySelfTest.java   |    32 +
 .../GridCacheAtomicNearReadersSelfTest.java     |    32 +
 .../GridCacheAtomicNearRemoveFailureTest.java   |    51 +
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |    65 +
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |    66 +
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    64 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    32 +
 ...rderMultiNodeP2PDisabledFullApiSelfTest.java |    33 +
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |    51 +
 ...PrimaryWriteOrderOffHeapFullApiSelfTest.java |    32 +
 ...ityOrderOffHeapMultiNodeFullApiSelfTest.java |    33 +
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 +
 .../near/GridCacheExNearFullApiSelfTest.java    |    39 +
 .../near/GridCacheGetStoreErrorSelfTest.java    |   151 +
 ...GridCacheGroupLockMultiNodeNearSelfTest.java |    30 +
 .../near/GridCacheGroupLockNearSelfTest.java    |    38 +
 .../GridCacheNearEvictionEventSelfTest.java     |    48 +
 .../near/GridCacheNearEvictionSelfTest.java     |   186 +
 ...dCacheNearExpiredEntriesPreloadSelfTest.java |    39 +
 .../near/GridCacheNearJobExecutionSelfTest.java |    48 +
 .../near/GridCacheNearMetricsSelfTest.java      |   395 +
 .../near/GridCacheNearMultiGetSelfTest.java     |   308 +
 .../near/GridCacheNearMultiNodeSelfTest.java    |   967 ++
 .../near/GridCacheNearOneNodeSelfTest.java      |   390 +
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   423 +
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    34 +
 .../near/GridCacheNearOnlySelfTest.java         |    68 +
 .../near/GridCacheNearOnlyTopologySelfTest.java |   233 +
 .../GridCacheNearPartitionedClearSelfTest.java  |   155 +
 ...ionedP2PDisabledByteArrayValuesSelfTest.java |    29 +
 ...tionedP2PEnabledByteArrayValuesSelfTest.java |    29 +
 .../GridCacheNearPreloadRestartSelfTest.java    |    30 +
 .../near/GridCacheNearPrimarySyncSelfTest.java  |    33 +
 .../GridCacheNearReaderPreloadSelfTest.java     |   199 +
 .../near/GridCacheNearReadersSelfTest.java      |   584 +
 .../near/GridCacheNearReloadAllSelfTest.java    |    30 +
 .../near/GridCacheNearRemoveFailureTest.java    |    44 +
 .../near/GridCacheNearTxExceptionSelfTest.java  |    33 +
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   246 +
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 +
 .../near/GridCacheNearTxPreloadSelfTest.java    |    44 +
 ...AffinityExcludeNeighborsPerformanceTest.java |   254 +
 ...rtitionedAffinityHashIdResolverSelfTest.java |    97 +
 .../GridCachePartitionedAffinitySelfTest.java   |   515 +
 ...ionedAtomicGetAndTransformStoreSelfTest.java |    33 +
 .../near/GridCachePartitionedBasicApiTest.java  |    47 +
 .../GridCachePartitionedBasicOpSelfTest.java    |    67 +
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |   357 +
 .../GridCachePartitionedBasicStoreSelfTest.java |    33 +
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |    67 +
 .../GridCachePartitionedEntryLockSelfTest.java  |   111 +
 .../near/GridCachePartitionedEventSelfTest.java |    59 +
 .../GridCachePartitionedEvictionSelfTest.java   |   216 +
 ...titionedExplicitLockNodeFailureSelfTest.java |   164 +
 .../GridCachePartitionedFailoverSelfTest.java   |    33 +
 ...GridCachePartitionedFilteredPutSelfTest.java |   165 +
 .../near/GridCachePartitionedFlagsTest.java     |    41 +
 ...PartitionedFullApiMultithreadedSelfTest.java |    38 +
 .../GridCachePartitionedFullApiSelfTest.java    |   251 +
 ...PartitionedGetAndTransformStoreSelfTest.java |    34 +
 .../GridCachePartitionedIteratorsSelfTest.java  |    43 +
 .../GridCachePartitionedLoadCacheSelfTest.java  |   155 +
 .../near/GridCachePartitionedLockSelfTest.java  |    86 +
 .../GridCachePartitionedMetricsSelfTest.java    |    60 +
 ...achePartitionedMultiNodeCounterSelfTest.java |   779 +
 ...achePartitionedMultiNodeFullApiSelfTest.java |   596 +
 ...idCachePartitionedMultiNodeLockSelfTest.java |    78 +
 ...onedMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 .../GridCachePartitionedMultiNodeSelfTest.java  |    48 +
 ...ePartitionedMultiThreadedPutGetSelfTest.java |   204 +
 ...NearDisabledBasicStoreMultiNodeSelfTest.java |    33 +
 ...itionedNearOnlyNoPrimaryFullApiSelfTest.java |    31 +
 .../near/GridCachePartitionedNestedTxTest.java  |    50 +
 ...GridCachePartitionedNodeFailureSelfTest.java |    50 +
 .../GridCachePartitionedNodeRestartTest.java    |   131 +
 ...dCachePartitionedOffHeapFullApiSelfTest.java |    28 +
 ...titionedOffHeapMultiNodeFullApiSelfTest.java |    28 +
 ...ePartitionedOptimisticTxNodeRestartTest.java |   127 +
 ...achePartitionedPreloadLifecycleSelfTest.java |   278 +
 .../GridCachePartitionedProjectionSelfTest.java |   155 +
 ...hePartitionedQueryMultiThreadedSelfTest.java |   304 +
 .../GridCachePartitionedStorePutSelfTest.java   |   148 +
 ...GridCachePartitionedTxConcurrentGetTest.java |    46 +
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    81 +
 ...CachePartitionedTxMultiThreadedSelfTest.java |   105 +
 .../near/GridCachePartitionedTxReadTest.java    |    33 +
 .../GridCachePartitionedTxSalvageSelfTest.java  |   284 +
 ...achePartitionedTxSingleThreadedSelfTest.java |   106 +
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    67 +
 .../near/GridCachePutArrayValueSelfTest.java    |   116 +
 ...idCacheRendezvousAffinityClientSelfTest.java |   105 +
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 +
 .../near/GridPartitionedBackupLoadSelfTest.java |   165 +
 .../near/IgniteTxReentryNearSelfTest.java       |    79 +
 ...stractReplicatedByteArrayValuesSelfTest.java |    84 +
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    59 +
 .../GridCacheDaemonNodeReplicatedSelfTest.java  |    31 +
 .../GridCacheExReplicatedFullApiSelfTest.java   |    33 +
 ...cheGroupLockMultiNodeReplicatedSelfTest.java |    45 +
 .../GridCacheGroupLockReplicatedSelfTest.java   |    39 +
 ...ridCacheReplicatedAtomicFullApiSelfTest.java |    42 +
 ...catedAtomicGetAndTransformStoreSelfTest.java |    33 +
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |    59 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 +
 .../GridCacheReplicatedBasicApiTest.java        |    42 +
 .../GridCacheReplicatedBasicOpSelfTest.java     |    42 +
 .../GridCacheReplicatedBasicStoreSelfTest.java  |    33 +
 .../GridCacheReplicatedClientOnlySelfTest.java  |    42 +
 .../GridCacheReplicatedEntrySetSelfTest.java    |    33 +
 .../GridCacheReplicatedEventSelfTest.java       |    38 +
 ...ridCacheReplicatedEvictionEventSelfTest.java |    38 +
 .../GridCacheReplicatedEvictionSelfTest.java    |   130 +
 .../GridCacheReplicatedFailoverSelfTest.java    |    33 +
 .../GridCacheReplicatedFlagsTest.java           |    28 +
 ...eReplicatedFullApiMultithreadedSelfTest.java |    38 +
 ...ReplicatedFullApiMultithreadedSelfTest1.java |  1980 +++
 .../GridCacheReplicatedFullApiSelfTest.java     |    57 +
 ...eReplicatedGetAndTransformStoreSelfTest.java |    39 +
 .../GridCacheReplicatedInvalidateSelfTest.java  |   244 +
 .../GridCacheReplicatedIteratorsSelfTest.java   |    43 +
 .../GridCacheReplicatedJobExecutionTest.java    |    45 +
 .../GridCacheReplicatedLockSelfTest.java        |    33 +
 .../GridCacheReplicatedMarshallerTxTest.java    |    47 +
 .../GridCacheReplicatedMetricsSelfTest.java     |    54 +
 ...CacheReplicatedMultiNodeFullApiSelfTest.java |    28 +
 ...ridCacheReplicatedMultiNodeLockSelfTest.java |    42 +
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    42 +
 ...licatedNearOnlyMultiNodeFullApiSelfTest.java |    39 +
 .../GridCacheReplicatedNearOnlySelfTest.java    |    42 +
 .../GridCacheReplicatedNodeFailureSelfTest.java |    46 +
 .../GridCacheReplicatedNodeRestartSelfTest.java |    54 +
 ...idCacheReplicatedOffHeapFullApiSelfTest.java |    28 +
 ...plicatedOffHeapMultiNodeFullApiSelfTest.java |    28 +
 ...catedP2PDisabledByteArrayValuesSelfTest.java |    29 +
 ...icatedP2PEnabledByteArrayValuesSelfTest.java |    29 +
 ...ridCacheReplicatedPreloadEventsSelfTest.java |    32 +
 .../GridCacheReplicatedProjectionSelfTest.java  |    66 +
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |    35 +
 .../GridCacheReplicatedTxConcurrentGetTest.java |    45 +
 .../GridCacheReplicatedTxExceptionSelfTest.java |    39 +
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    81 +
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |   111 +
 ...licatedTxOriginatingNodeFailureSelfTest.java |    37 +
 ...ssimisticOriginatingNodeFailureSelfTest.java |    47 +
 .../GridCacheReplicatedTxReadTest.java          |    33 +
 ...CacheReplicatedTxSingleThreadedSelfTest.java |   102 +
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    60 +
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |   171 +
 .../GridCacheSyncReplicatedPreloadSelfTest.java |   166 +
 .../replicated/GridReplicatedTxPreloadTest.java |    33 +
 ...CacheReplicatedPreloadLifecycleSelfTest.java |   293 +
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |    39 +
 .../GridCacheReplicatedPreloadSelfTest.java     |   582 +
 ...eplicatedPreloadStartStopEventsSelfTest.java |    95 +
 ...GridCacheReplicatedPreloadUndeploysTest.java |    87 +
 .../GridCacheBatchEvictUnswapSelfTest.java      |   193 +
 ...heConcurrentEvictionConsistencySelfTest.java |   267 +
 .../GridCacheConcurrentEvictionsSelfTest.java   |   183 +
 .../GridCacheDistributedEvictionsSelfTest.java  |   265 +
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   304 +
 .../GridCacheEmptyEntriesLocalSelfTest.java     |    41 +
 ...ridCacheEmptyEntriesPartitionedSelfTest.java |    41 +
 .../eviction/GridCacheEvictionAbstractTest.java |   462 +
 .../GridCacheEvictionFilterSelfTest.java        |   249 +
 .../GridCacheEvictionLockUnlockSelfTest.java    |   175 +
 .../GridCacheEvictionTouchSelfTest.java         |   347 +
 .../cache/eviction/GridCacheMockEntry.java      |   365 +
 ...cheSynchronousEvictionsFailoverSelfTest.java |   160 +
 .../GridCacheFifoEvictionPolicySelfTest.java    |   380 +
 .../lru/GridCacheLruEvictionPolicySelfTest.java |   426 +
 .../GridCacheLruNearEvictionPolicySelfTest.java |   136 +
 ...heNearOnlyLruNearEvictionPolicySelfTest.java |   167 +
 .../GridCacheRandomEvictionPolicySelfTest.java  |   265 +
 .../IgniteCacheAtomicExpiryPolicyTest.java      |    18 +-
 .../IgniteCacheAtomicLocalExpiryPolicyTest.java |    14 +-
 ...AtomicPrimaryWriteOrderExpiryPolicyTest.java |     6 +-
 ...teCacheAtomicReplicatedExpiryPolicyTest.java |     6 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    20 +-
 .../expiry/IgniteCacheTxExpiryPolicyTest.java   |    14 +-
 .../IgniteCacheTxLocalExpiryPolicyTest.java     |    14 +-
 ...IgniteCacheTxReplicatedExpiryPolicyTest.java |     8 +-
 .../IgniteCacheAtomicLoadAllTest.java           |    18 +-
 .../IgniteCacheAtomicLoaderWriterTest.java      |    18 +-
 .../IgniteCacheAtomicLocalLoadAllTest.java      |    14 +-
 ...CacheAtomicLocalNoLoadPreviousValueTest.java |    14 +-
 ...IgniteCacheAtomicLocalNoReadThroughTest.java |    14 +-
 ...gniteCacheAtomicLocalNoWriteThroughTest.java |    14 +-
 ...tomicNearEnabledNoLoadPreviousValueTest.java |     6 +-
 ...CacheAtomicNearEnabledNoReadThroughTest.java |     6 +-
 ...acheAtomicNearEnabledNoWriteThroughTest.java |     6 +-
 ...gniteCacheAtomicNoLoadPreviousValueTest.java |    18 +-
 .../IgniteCacheAtomicNoReadThroughTest.java     |    18 +-
 .../IgniteCacheAtomicNoWriteThroughTest.java    |    18 +-
 .../IgniteCacheAtomicStoreSessionTest.java      |    18 +-
 .../IgniteCacheLoadAllAbstractTest.java         |     4 +-
 ...iteCacheNoLoadPreviousValueAbstractTest.java |     6 +-
 .../IgniteCacheNoReadThroughAbstractTest.java   |     7 +-
 .../IgniteCacheNoWriteThroughAbstractTest.java  |     6 +-
 .../IgniteCacheStoreSessionAbstractTest.java    |     4 +-
 .../integration/IgniteCacheTxLoadAllTest.java   |    15 +-
 .../IgniteCacheTxLoaderWriterTest.java          |    14 +-
 .../IgniteCacheTxLocalLoadAllTest.java          |    14 +-
 ...niteCacheTxLocalNoLoadPreviousValueTest.java |    14 +-
 .../IgniteCacheTxLocalNoReadThroughTest.java    |    14 +-
 .../IgniteCacheTxLocalNoWriteThroughTest.java   |    14 +-
 ...cheTxNearEnabledNoLoadPreviousValueTest.java |     6 +-
 ...niteCacheTxNearEnabledNoReadThroughTest.java |     6 +-
 ...iteCacheTxNearEnabledNoWriteThroughTest.java |     6 +-
 .../IgniteCacheTxNoLoadPreviousValueTest.java   |    14 +-
 .../IgniteCacheTxNoReadThroughTest.java         |    14 +-
 .../IgniteCacheTxNoWriteThroughTest.java        |    14 +-
 .../IgniteCacheTxStoreSessionTest.java          |    16 +-
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |    29 +
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    59 +
 .../local/GridCacheDaemonNodeLocalSelfTest.java |    64 +
 .../local/GridCacheExLocalFullApiSelfTest.java  |    30 +
 .../GridCacheLocalAtomicBasicStoreSelfTest.java |    32 +
 .../GridCacheLocalAtomicFullApiSelfTest.java    |    42 +
 ...LocalAtomicGetAndTransformStoreSelfTest.java |    33 +
 ...dCacheLocalAtomicOffHeapFullApiSelfTest.java |    42 +
 .../GridCacheLocalAtomicProjectionSelfTest.java |    32 +
 .../local/GridCacheLocalBasicApiSelfTest.java   |    42 +
 ...cheLocalBasicStoreMultithreadedSelfTest.java |    30 +
 .../local/GridCacheLocalBasicStoreSelfTest.java |    33 +
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   258 +
 .../local/GridCacheLocalEventSelfTest.java      |    38 +
 .../GridCacheLocalEvictionEventSelfTest.java    |    38 +
 ...dCacheLocalFullApiMultithreadedSelfTest.java |    38 +
 .../local/GridCacheLocalFullApiSelfTest.java    |   141 +
 ...dCacheLocalGetAndTransformStoreSelfTest.java |    33 +
 .../local/GridCacheLocalIteratorsSelfTest.java  |   172 +
 .../local/GridCacheLocalLoadAllSelfTest.java    |   111 +
 .../cache/local/GridCacheLocalLockSelfTest.java |   315 +
 .../local/GridCacheLocalMetricsSelfTest.java    |    55 +
 .../GridCacheLocalMultithreadedSelfTest.java    |   337 +
 .../GridCacheLocalOffHeapFullApiSelfTest.java   |    28 +
 .../local/GridCacheLocalProjectionSelfTest.java |    38 +
 .../GridCacheLocalTxExceptionSelfTest.java      |    38 +
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    91 +
 .../cache/local/GridCacheLocalTxReadTest.java   |    33 +
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    86 +
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |   164 +
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   445 +
 .../query/GridCacheSwapScanQuerySelfTest.java   |    28 +
 .../cache/query/GridCircularQueueTest.java      |   119 +
 ...ridCacheContinuousQueryAbstractSelfTest.java |  1538 ++
 ...ontinuousQueryAtomicNearEnabledSelfTest.java |    32 +
 ...ontinuousQueryAtomicP2PDisabledSelfTest.java |    29 +
 .../GridCacheContinuousQueryAtomicSelfTest.java |    43 +
 ...CacheContinuousQueryLocalAtomicSelfTest.java |    32 +
 .../GridCacheContinuousQueryLocalSelfTest.java  |    37 +
 ...eContinuousQueryPartitionedOnlySelfTest.java |    48 +
 ...uousQueryPartitionedP2PDisabledSelfTest.java |    29 +
 ...CacheContinuousQueryPartitionedSelfTest.java |    37 +
 ...ContinuousQueryReplicatedAtomicSelfTest.java |    37 +
 ...nuousQueryReplicatedP2PDisabledSelfTest.java |    28 +
 ...dCacheContinuousQueryReplicatedSelfTest.java |    82 +
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |   426 +
 ...ridCacheReduceFieldsQueryAtomicSelfTest.java |    38 +
 ...GridCacheReduceFieldsQueryLocalSelfTest.java |    37 +
 ...cheReduceFieldsQueryPartitionedSelfTest.java |    58 +
 ...acheReduceFieldsQueryReplicatedSelfTest.java |    37 +
 .../clock/GridTimeSyncProcessorSelfTest.java    |   223 +
 .../closure/GridClosureProcessorRemoteTest.java |   119 +
 .../closure/GridClosureProcessorSelfTest.java   |   541 +
 .../internal/processors/closure/package.html    |    23 +
 .../continuous/GridEventConsumeSelfTest.java    |  1079 ++
 .../continuous/GridMessageListenSelfTest.java   |   489 +
 .../dataload/GridDataLoaderImplSelfTest.java    |   215 +
 .../dataload/GridDataLoaderPerformanceTest.java |   215 +
 .../GridDataLoaderProcessorSelfTest.java        |   883 ++
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   489 +
 .../processors/fs/GridGgfsAbstractSelfTest.java |  2453 ++++
 .../fs/GridGgfsAttributesSelfTest.java          |    75 +
 .../processors/fs/GridGgfsCacheSelfTest.java    |   133 +
 .../fs/GridGgfsCommonAbstractTest.java          |    67 +
 .../fs/GridGgfsDataManagerSelfTest.java         |   599 +
 .../fs/GridGgfsDualAbstractSelfTest.java        |  1601 ++
 .../fs/GridGgfsDualAsyncSelfTest.java           |    32 +
 .../processors/fs/GridGgfsDualSyncSelfTest.java |    32 +
 .../processors/fs/GridGgfsFileInfoSelfTest.java |    88 +
 .../processors/fs/GridGgfsFileMapSelfTest.java  |   337 +
 ...GgfsGroupDataBlockKeyMapperHashSelfTest.java |   136 +
 .../fs/GridGgfsMetaManagerSelfTest.java         |   470 +
 .../processors/fs/GridGgfsMetricsSelfTest.java  |   536 +
 .../fs/GridGgfsModeResolverSelfTest.java        |    77 +
 .../processors/fs/GridGgfsModesSelfTest.java    |   604 +
 .../GridGgfsPrimaryOffheapTieredSelfTest.java   |    33 +
 .../GridGgfsPrimaryOffheapValuesSelfTest.java   |    33 +
 .../processors/fs/GridGgfsPrimarySelfTest.java  |    32 +
 .../fs/GridGgfsProcessorSelfTest.java           |   977 ++
 .../fs/GridGgfsProcessorValidationSelfTest.java |   535 +
 ...IpcEndpointRegistrationAbstractSelfTest.java |   185 +
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |    50 +
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    53 +
 .../processors/fs/GridGgfsSizeSelfTest.java     |   875 ++
 .../processors/fs/GridGgfsStreamsSelfTest.java  |   472 +
 .../processors/fs/GridGgfsTaskSelfTest.java     |   316 +
 .../processors/fs/GridGgfsTestInputStream.java  |    66 +
 .../ignite/internal/processors/fs/package.html  |    23 +
 .../GridGgfsAbstractRecordResolverSelfTest.java |   187 +
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   335 +
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   147 +
 ...sNewLineDelimiterRecordResolverSelfTest.java |   129 +
 ...fsStringDelimiterRecordResolverSelfTest.java |   137 +
 .../GridJobMetricsProcessorLoadTest.java        |    89 +
 .../port/GridPortProcessorSelfTest.java         |   129 +
 .../cache/GridCacheCommandHandlerSelfTest.java  |   263 +
 .../processors/service/DummyService.java        |   148 +
 .../GridServiceProcessorAbstractSelfTest.java   |   676 +
 ...ServiceProcessorMultiNodeConfigSelfTest.java |   200 +
 .../GridServiceProcessorMultiNodeSelfTest.java  |   170 +
 .../GridServiceProcessorProxySelfTest.java      |   376 +
 .../GridServiceProcessorSingleNodeSelfTest.java |    57 +
 .../GridServiceReassignmentSelfTest.java        |   211 +
 .../streamer/GridStreamerEvictionSelfTest.java  |   164 +
 .../streamer/GridStreamerFailoverSelfTest.java  |   267 +
 .../GridStreamerLifecycleAwareSelfTest.java     |   212 +
 .../streamer/GridStreamerSelfTest.java          |   795 +
 .../processors/streamer/GridTestStage.java      |    54 +
 .../streamer/GridTestStreamerEventRouter.java   |    49 +
 .../ignite/internal/processors/streamer/SC.java |    31 +
 .../timeout/GridTimeoutProcessorSelfTest.java   |   609 +
 .../apache/ignite/internal/updatestatus.html    |    28 +
 ...artupWithSpecifiedWorkDirectorySelfTest.java |   163 +
 ...tartupWithUndefinedGridGainHomeSelfTest.java |   106 +
 .../internal/util/GridTestClockTimer.java       |    41 +
 .../ignite/internal/util/GridUtilsSelfTest.java |   717 +
 .../util/future/GridCompoundFutureSelfTest.java |   204 +
 .../util/future/GridEmbeddedFutureSelfTest.java |   137 +
 .../util/future/GridFinishedFutureSelfTest.java |   104 +
 .../util/future/GridFutureAdapterSelfTest.java  |   441 +
 .../future/GridFutureListenPerformanceTest.java |   107 +
 .../util/future/GridFutureQueueTest.java        |   183 +
 .../nio/GridNioEmbeddedFutureSelfTest.java      |    59 +
 .../util/future/nio/GridNioFutureSelfTest.java  |   210 +
 ...GridUnsafeDataOutputArraySizingSelfTest.java |   161 +
 ...idIpcServerEndpointDeserializerSelfTest.java |   160 +
 .../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 +
 .../GridIpcSharedMemoryBenchmarkParty.java      |    35 +
 .../GridIpcSharedMemoryBenchmarkReader.java     |   133 +
 .../GridIpcSharedMemoryBenchmarkWriter.java     |   125 +
 .../internal/util/nio/GridNioSelfTest.java      |  1441 ++
 .../util/nio/GridNioSessionMetaKeySelfTest.java |    58 +
 .../internal/util/nio/GridNioSslSelfTest.java   |    88 +
 .../internal/util/nio/GridRoundTripTest.java    |   226 +
 .../nio/impl/GridNioFilterChainSelfTest.java    |   390 +
 .../ignite/internal/util/nio/package.html       |    23 +
 .../util/offheap/GridByteArrayWrapper.java      |    63 +
 .../offheap/GridOffHeapMapAbstractSelfTest.java |   812 +
 .../GridOffHeapMapPerformanceAbstractTest.java  |   289 +
 ...idOffHeapPartitionedMapAbstractSelfTest.java |  1133 ++
 ...apPartitionedMapPerformanceAbstractTest.java |   429 +
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |   321 +
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 +
 .../offheap/unsafe/GridUnsafeMapSelfTest.java   |    30 +
 .../unsafe/GridUnsafeMemorySelfTest.java        |   542 +
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 +
 .../GridUnsafePartitionedMapSelfTest.java       |    30 +
 .../unsafe/GridUnsafeStripedLruSefTest.java     |   229 +
 .../tostring/GridToStringBuilderSelfTest.java   |   205 +
 .../ignite/internal/util/tostring/package.html  |    23 +
 .../ignite/jvmtest/BlockingQueueTest.java       |   144 +
 .../ignite/jvmtest/ConcurrentMapTest.java       |   193 +
 .../org/apache/ignite/jvmtest/FileIOTest.java   |   138 +
 .../apache/ignite/jvmtest/FileLocksTest.java    |   121 +
 .../ignite/jvmtest/LinkedHashMapTest.java       |    87 +
 .../ignite/jvmtest/MultipleFileIOTest.java      |   134 +
 .../ignite/jvmtest/NetworkFailureTest.java      |   370 +
 .../QueueSizeCounterMultiThreadedTest.java      |   102 +
 .../jvmtest/ReadWriteLockMultiThreadedTest.java |   207 +
 .../org/apache/ignite/jvmtest/RegExpTest.java   |    56 +
 .../jvmtest/ServerSocketMultiThreadedTest.java  |   102 +
 .../ignite/lang/GridBasicPerformanceTest.java   |  1076 ++
 .../ignite/lang/GridByteArrayListSelfTest.java  |   213 +
 .../ignite/lang/GridFuncPerformanceTest.java    |   100 +
 .../apache/ignite/lang/GridFuncSelfTest.java    |  3253 ++++
 .../lang/GridFutureListenPerformanceTest.java   |   111 +
 .../GridImmutableCollectionsPerfomanceTest.java |   120 +
 .../lang/GridMetadataAwareAdapterSelfTest.java  |   118 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |   224 +
 .../lang/GridSystemCurrentTimeMillisTest.java   |   107 +
 .../ignite/lang/GridThreadPriorityTest.java     |    72 +
 .../apache/ignite/lang/GridTupleSelfTest.java   |   164 +
 .../org/apache/ignite/lang/GridXSelfTest.java   |   262 +
 .../apache/ignite/lang/IgniteUuidSelfTest.java  |   325 +
 .../java/org/apache/ignite/lang/package.html    |    23 +
 ...dBoundedConcurrentLinkedHashMapSelfTest.java |    55 +
 ...GridBoundedConcurrentOrderedMapSelfTest.java |    81 +
 .../GridCircularBufferPerformanceTest.java      |   226 +
 .../lang/utils/GridCircularBufferSelfTest.java  |   176 +
 .../utils/GridConcurrentHashMapSelfTest.java    |   109 +
 .../GridConcurrentLinkedHashMapSelfTest.java    |   246 +
 .../GridConcurrentWeakHashSetSelfTest.java      |   394 +
 .../lang/utils/GridConsistentHashSelfTest.java  |   332 +
 .../lang/utils/GridLeanMapPerformanceTest.java  |    84 +
 .../ignite/lang/utils/GridLeanMapSelfTest.java  |   658 +
 .../ignite/lang/utils/GridListSetSelfTest.java  |   286 +
 .../ignite/lang/utils/GridPCollectionsTest.java |    54 +
 .../lang/utils/GridStripedLockSelfTest.java     |   200 +
 .../ignite/lang/utils/GridTrieMapSelfTest.java  |   242 +
 .../org/apache/ignite/lang/utils/package.html   |    24 +
 .../ignite/loadtest/GridLoadTestStatistics.java |   210 +
 .../loadtest/GridSingleExecutionTest.java       |   324 +
 .../org/apache/ignite/loadtest/package.html     |    23 +
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |   247 +
 .../loadtests/GridCacheLoadPopulationTask.java  |   152 +
 .../loadtests/GridCacheMultiNodeLoadTest.java   |   106 +
 .../cache/GridCacheAbstractLoadTest.java        |   376 +
 ...ridCacheAffinityTransactionsOffHeapTest.java |   258 +
 .../loadtests/cache/GridCacheBenchmark.java     |   202 +
 .../cache/GridCacheDataStructuresLoadTest.java  |   364 +
 .../cache/GridCacheGroupLockComparisonTest.java |   203 +
 .../loadtests/cache/GridCacheLoadTest.java      |   161 +
 .../cache/GridCachePutRemoveLoadTest.java       |   373 +
 .../cache/GridCacheSingleNodeLoadTest.java      |   184 +
 .../loadtests/cache/GridCacheSwapLoadTest.java  |   310 +
 .../GridCacheWriteBehindStoreLoadTest.java      |   210 +
 .../capacity/GridCapacityLoadTest.java          |    95 +
 .../capacity/spring-capacity-cache.xml          |   124 +
 .../colocation/GridTestCacheStore.java          |   134 +
 .../loadtests/colocation/GridTestConstants.java |    35 +
 .../loadtests/colocation/GridTestKey.java       |    92 +
 .../colocation/GridTestLifecycleBean.java       |    41 +
 .../loadtests/colocation/GridTestMain.java      |   207 +
 .../loadtests/colocation/spring-colocation.xml  |   182 +
 .../communication/GridIoManagerBenchmark.java   |   337 +
 .../communication/GridIoManagerBenchmark0.java  |   469 +
 .../GridTcpCommunicationBenchmark.java          |   586 +
 .../communication/GridTestMessage.java          |   135 +
 .../GridContinuousOperationsLoadTest.java       |   211 +
 .../GridCachePartitionedAtomicLongLoadTest.java |   129 +
 .../direct/multisplit/GridLoadTestJob.java      |    58 +
 .../multisplit/GridLoadTestJobTarget.java       |    33 +
 .../direct/multisplit/GridLoadTestTask.java     |    83 +
 .../multisplit/GridMultiSplitsLoadTest.java     |   160 +
 .../GridMultiSplitsRedeployLoadTest.java        |   162 +
 .../loadtests/direct/multisplit/package.html    |    24 +
 .../GridSingleSplitNewNodesTestJobTarget.java   |    50 +
 .../GridSingleSplitNewNodesTestTask.java        |    95 +
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   188 +
 ...idSingleSplitsNewNodesMulticastLoadTest.java |    45 +
 .../loadtests/direct/newnodes/package.html      |    24 +
 .../GridSingleSplitsRedeployLoadTest.java       |   174 +
 .../loadtests/direct/redeploy/package.html      |    24 +
 .../direct/session/GridSessionLoadTest.java     |   112 +
 .../direct/session/GridSessionLoadTestJob.java  |    76 +
 .../direct/session/GridSessionLoadTestTask.java |   136 +
 .../loadtests/direct/session/package.html       |    24 +
 .../direct/stealing/GridStealingLoadTest.java   |   154 +
 .../stealing/GridStealingLoadTestJob.java       |    61 +
 .../stealing/GridStealingLoadTestTask.java      |    96 +
 .../loadtests/direct/stealing/package.html      |    24 +
 .../loadtests/discovery/GridGcTimeoutTest.java  |    63 +
 .../ignite/loadtests/dsi/GridDsiClient.java     |   419 +
 .../loadtests/dsi/GridDsiLifecycleBean.java     |    59 +
 .../ignite/loadtests/dsi/GridDsiMessage.java    |    74 +
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |   341 +
 .../ignite/loadtests/dsi/GridDsiRequest.java    |    93 +
 .../loadtests/dsi/GridDsiRequestTask.java       |    41 +
 .../ignite/loadtests/dsi/GridDsiResponse.java   |    87 +
 .../loadtests/dsi/GridDsiResponseTask.java      |    41 +
 .../ignite/loadtests/dsi/GridDsiSession.java    |    84 +
 .../cacheget/GridBenchmarkCacheGetLoadTest.java |   119 +
 .../apache/ignite/loadtests/dsi/package.html    |    23 +
 ...dBoundedConcurrentLinkedHashSetLoadTest.java |   118 +
 .../loadtests/hashmap/GridCacheTestContext.java |    72 +
 .../loadtests/hashmap/GridHashMapLoadTest.java  |   100 +
 .../job/GridJobExecutionLoadTestClient.java     |   219 +
 ...GridJobExecutionLoadTestClientSemaphore.java |   239 +
 .../job/GridJobExecutionLoadTestJob.java        |    48 +
 .../job/GridJobExecutionLoadTestServer.java     |    40 +
 .../job/GridJobExecutionLoadTestTask.java       |    50 +
 .../job/GridJobExecutionSingleNodeLoadTest.java |   237 +
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |   226 +
 .../ignite/loadtests/job/GridJobLoadTest.java   |   201 +
 .../loadtests/job/GridJobLoadTestJob.java       |   162 +
 .../loadtests/job/GridJobLoadTestParams.java    |    84 +
 .../loadtests/job/GridJobLoadTestSubmitter.java |   142 +
 .../loadtests/job/GridJobLoadTestTask.java      |    73 +
 .../apache/ignite/loadtests/job/package.html    |    23 +
 .../GridConcurrentLinkedHashMapBenchmark.java   |   238 +
 .../mapper/GridContinuousMapperLoadTest1.java   |    50 +
 .../mapper/GridContinuousMapperLoadTest2.java   |    91 +
 .../mapper/GridContinuousMapperTask1.java       |   149 +
 .../mapper/GridContinuousMapperTask2.java       |    87 +
 .../loadtests/mapper/GridNodeStartup.java       |    55 +
 .../ignite/loadtests/mapper/TestObject.java     |    58 +
 .../mergesort/GridMergeSortLoadTask.java        |   188 +
 .../mergesort/GridMergeSortLoadTest.java        |   143 +
 .../loadtests/nio/GridNioBenchmarkClient.java   |   167 +
 .../loadtests/nio/GridNioBenchmarkTest.java     |   119 +
 .../GridOffHeapMapPerformanceAbstractTest.java  |   290 +
 ...apPartitionedMapPerformanceAbstractTest.java |   430 +
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 +
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 +
 .../ignite/loadtests/streamer/EventClosure.java |    60 +
 .../streamer/GridStreamerBenchmark.java         |   140 +
 .../streamer/GridStreamerIndexLoadTest.java     |   179 +
 .../loadtests/streamer/GridStreamerLoad.java    |    62 +
 .../ignite/loadtests/streamer/IndexUpdater.java |    46 +
 .../ignite/loadtests/streamer/QueryClosure.java |   106 +
 .../loadtests/streamer/average/TestAverage.java |    70 +
 .../loadtests/streamer/average/TestStage.java   |    65 +
 .../swap/GridSwapEvictAllBenchmark.java         |   299 +
 .../loadtests/util/GridCumulativeAverage.java   |    63 +
 .../ignite/loadtests/util/GridLoadTestArgs.java |   283 +
 .../ignite/logger/java/GridJavaLoggerTest.java  |    65 +
 .../org/apache/ignite/logger/java/package.html  |    23 +
 .../marshaller/GridMarshallerAbstractTest.java  |  1039 ++
 .../GridMarshallerExternalizableBean.java       |    63 +
 .../GridMarshallerPerformanceTest.java          |   514 +
 .../marshaller/GridMarshallerResourceBean.java  |   103 +
 .../GridMarshallerTestAbstractBean.java         |    40 +
 .../marshaller/GridMarshallerTestBean.java      |   148 +
 .../GridMarshallerTestInheritedBean.java        |    25 +
 .../jdk/GridJdkMarshallerSelfTest.java          |    33 +
 .../apache/ignite/marshaller/jdk/package.html   |    23 +
 .../GridOptimizedMarshallerSelfTest.java        |     7 +-
 .../optimized/GridOptimizedMarshallerTest.java  |     6 +-
 .../GridOptimizedObjectStreamSelfTest.java      |    10 +-
 .../org/apache/ignite/marshaller/package.html   |    23 +
 ...GridMessagingNoPeerClassLoadingSelfTest.java |    90 +
 .../ignite/messaging/GridMessagingSelfTest.java |  1088 ++
 .../p2p/GridAbstractMultinodeRedeployTest.java  |   125 +
 ...MultinodeRedeployContinuousModeSelfTest.java |    37 +
 ...idMultinodeRedeployIsolatedModeSelfTest.java |    37 +
 ...ridMultinodeRedeployPrivateModeSelfTest.java |    37 +
 ...GridMultinodeRedeploySharedModeSelfTest.java |    37 +
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java |   157 +
 .../GridP2PContinuousDeploymentSelfTest.java    |   118 +
 .../GridP2PDifferentClassLoaderSelfTest.java    |   220 +
 .../p2p/GridP2PDoubleDeploymentSelfTest.java    |   140 +
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |   232 +
 .../p2p/GridP2PJobClassLoaderSelfTest.java      |   141 +
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |   254 +
 .../GridP2PMissedResourceCacheSizeSelfTest.java |   292 +
 .../ignite/p2p/GridP2PNodeLeftSelfTest.java     |   120 +
 .../p2p/GridP2PRecursionTaskSelfTest.java       |   193 +
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |   282 +
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   163 +
 .../org/apache/ignite/p2p/GridP2PTestJob.java   |   128 +
 .../org/apache/ignite/p2p/GridP2PTestTask.java  |    82 +
 .../p2p/GridP2PTestTaskExecutionTest.java       |    50 +
 .../ignite/p2p/GridP2PTimeoutSelfTest.java      |   205 +
 .../ignite/p2p/GridP2PUndeploySelfTest.java     |   237 +
 .../ignite/p2p/GridSwapSpaceCustomKey.java      |    58 +
 .../ignite/p2p/GridSwapSpaceCustomValue.java    |    64 +
 .../java/org/apache/ignite/p2p/p2p.properties   |     1 +
 .../java/org/apache/ignite/p2p/package.html     |    23 +
 .../test/java/org/apache/ignite/package.html    |    23 +
 .../product/GridProductVersionSelfTest.java     |   111 +
 ...SessionCancelSiblingsFromFutureSelfTest.java |   280 +
 ...ridSessionCancelSiblingsFromJobSelfTest.java |   291 +
 ...idSessionCancelSiblingsFromTaskSelfTest.java |   298 +
 .../GridSessionCheckpointAbstractSelfTest.java  |   231 +
 .../session/GridSessionCheckpointSelfTest.java  |    96 +
 .../GridSessionCollisionSpiSelfTest.java        |   143 +
 ...idSessionFutureWaitJobAttributeSelfTest.java |   251 +
 ...dSessionFutureWaitTaskAttributeSelfTest.java |   250 +
 .../session/GridSessionJobFailoverSelfTest.java |   162 +
 ...GridSessionJobWaitTaskAttributeSelfTest.java |   220 +
 .../ignite/session/GridSessionLoadSelfTest.java |   264 +
 .../GridSessionSetFutureAttributeSelfTest.java  |   254 +
 ...nSetFutureAttributeWaitListenerSelfTest.java |   242 +
 .../GridSessionSetJobAttribute2SelfTest.java    |   134 +
 ...GridSessionSetJobAttributeOrderSelfTest.java |   153 +
 .../GridSessionSetJobAttributeSelfTest.java     |   209 +
 ...sionSetJobAttributeWaitListenerSelfTest.java |   244 +
 .../GridSessionSetTaskAttributeSelfTest.java    |   197 +
 ...GridSessionTaskWaitJobAttributeSelfTest.java |   190 +
 .../GridSessionWaitAttributeSelfTest.java       |   480 +
 .../ignite/session/GridThreadSerialNumber.java  |    40 +
 .../java/org/apache/ignite/session/package.html |    24 +
 .../spi/GridSpiLocalHostInjectionTest.java      |   156 +
 .../spi/GridSpiStartStopAbstractTest.java       |    80 +
 .../org/apache/ignite/spi/GridTcpForwarder.java |   169 +
 .../spi/GridTcpSpiForwardingSelfTest.java       |   163 +
 .../GridCheckpointSpiAbstractTest.java          |     4 +-
 .../GridCacheCheckpointSpiConfigSelfTest.java   |     2 +-
 ...idCacheCheckpointSpiSecondCacheSelfTest.java |     7 +-
 .../cache/GridCacheCheckpointSpiSelfTest.java   |     2 +-
 ...GridCacheCheckpointSpiStartStopSelfTest.java |     4 +-
 .../GridJdbcCheckpointSpiConfigSelfTest.java    |     2 +-
 ...idJdbcCheckpointSpiCustomConfigSelfTest.java |     2 +-
 ...dJdbcCheckpointSpiDefaultConfigSelfTest.java |     2 +-
 .../GridJdbcCheckpointSpiStartStopSelfTest.java |     4 +-
 ...GridSharedFsCheckpointSpiConfigSelfTest.java |     2 +-
 ...redFsCheckpointSpiMultiThreadedSelfTest.java |     6 +-
 ...heckpointSpiMultipleDirectoriesSelfTest.java |     5 +-
 .../GridSharedFsCheckpointSpiSelfTest.java      |     4 +-
 ...dSharedFsCheckpointSpiStartStopSelfTest.java |     4 +-
 .../collision/GridTestCollisionJobContext.java  |     2 +-
 ...GridFifoQueueCollisionSpiConfigSelfTest.java |     2 +-
 .../GridFifoQueueCollisionSpiSelfTest.java      |     4 +-
 ...dFifoQueueCollisionSpiStartStopSelfTest.java |     4 +-
 ...bStealingCollisionSpiAttributesSelfTest.java |    10 +-
 ...idJobStealingCollisionSpiConfigSelfTest.java |     2 +-
 ...alingCollisionSpiCustomTopologySelfTest.java |    10 +-
 .../GridJobStealingCollisionSpiSelfTest.java    |    12 +-
 ...obStealingCollisionSpiStartStopSelfTest.java |    10 +-
 ...PriorityQueueCollisionSpiConfigSelfTest.java |     2 +-
 .../GridPriorityQueueCollisionSpiSelfTest.java  |     4 +-
 ...orityQueueCollisionSpiStartStopSelfTest.java |     4 +-
 .../GridAbstractCommunicationSelfTest.java      |    14 +-
 .../spi/communication/GridTestMessage.java      |     4 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    19 +-
 .../GridTcpCommunicationSpiAbstractTest.java    |     8 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |    14 +-
 .../GridTcpCommunicationSpiConfigSelfTest.java  |     2 +-
 .../tcp/GridTcpCommunicationSpiLanTest.java     |    12 +-
 ...cpCommunicationSpiMultithreadedSelfTest.java |    21 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    14 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |    14 +-
 .../GridTcpCommunicationSpiShmemSelfTest.java   |     2 +-
 ...ridTcpCommunicationSpiStartStopSelfTest.java |     6 +-
 .../tcp/GridTcpCommunicationSpiTcpSelfTest.java |     2 +-
 .../local/GridLocalDeploymentSpiSelfTest.java   |     2 +-
 ...GridLocalDeploymentSpiStartStopSelfTest.java |     4 +-
 ...ridAbstractDiscoveryRandomStartStopTest.java |     4 +-
 .../GridAbstractDiscoverySelfTest.java          |    10 +-
 .../discovery/GridAbstractDiscoveryTest.java    |     4 +-
 .../GridDiscoveryMetricsHelperSelfTest.java     |     2 +-
 .../tcp/GridTcpClientDiscoverySelfTest.java     |    10 +-
 .../GridTcpDiscoveryConcurrentStartTest.java    |     2 +-
 ...GridTcpDiscoveryMarshallerCheckSelfTest.java |     2 +-
 .../tcp/GridTcpDiscoveryMultiThreadedTest.java  |     6 +-
 .../discovery/tcp/GridTcpDiscoverySelfTest.java |    13 +-
 .../GridTcpDiscoverySnapshotHistoryTest.java    |     4 +-
 .../tcp/GridTcpDiscoverySpiConfigSelfTest.java  |     2 +-
 .../GridTcpDiscoverySpiRandomStartStopTest.java |     2 +-
 .../tcp/GridTcpDiscoverySpiSelfTest.java        |     2 +-
 .../GridTcpDiscoverySpiStartStopSelfTest.java   |     6 +-
 .../GridTcpDiscoverySpiWildcardSelfTest.java    |     2 +-
 ...ridTcpDiscoveryIpFinderAbstractSelfTest.java |     4 +-
 ...idTcpDiscoveryMulticastIpFinderSelfTest.java |     2 +-
 ...MemoryEventStorageMultiThreadedSelfTest.java |     6 +-
 ...GridMemoryEventStorageSpiConfigSelfTest.java |     2 +-
 .../GridMemoryEventStorageSpiSelfTest.java      |     4 +-
 ...dMemoryEventStorageSpiStartStopSelfTest.java |     4 +-
 .../GridAlwaysFailoverSpiConfigSelfTest.java    |     2 +-
 .../always/GridAlwaysFailoverSpiSelfTest.java   |     6 +-
 .../GridAlwaysFailoverSpiStartStopSelfTest.java |     4 +-
 ...ridJobStealingFailoverSpiConfigSelfTest.java |     2 +-
 ...idJobStealingFailoverSpiOneNodeSelfTest.java |    10 +-
 .../GridJobStealingFailoverSpiSelfTest.java     |    10 +-
 ...JobStealingFailoverSpiStartStopSelfTest.java |     8 +-
 .../never/GridNeverFailoverSpiSelfTest.java     |     6 +-
 .../GridNeverFailoverSpiStartStopSelfTest.java  |     4 +-
 ...dAdaptiveLoadBalancingSpiConfigSelfTest.java |     2 +-
 ...iveLoadBalancingSpiMultipleNodeSelfTest.java |     6 +-
 .../GridAdaptiveLoadBalancingSpiSelfTest.java   |     6 +-
 ...aptiveLoadBalancingSpiStartStopSelfTest.java |     4 +-
 ...alancingNotPerTaskMultithreadedSelfTest.java |     6 +-
 ...dRobinLoadBalancingSpiLocalNodeSelfTest.java |     4 +-
 ...inLoadBalancingSpiMultipleNodesSelfTest.java |     6 +-
 ...RobinLoadBalancingSpiNotPerTaskSelfTest.java |     5 +-
 ...dRobinLoadBalancingSpiStartStopSelfTest.java |     4 +-
 ...nLoadBalancingSpiTopologyChangeSelfTest.java |     6 +-
 .../roundrobin/GridRoundRobinTestUtils.java     |     1 -
 ...tedRandomLoadBalancingSpiConfigSelfTest.java |     2 +-
 ...dWeightedRandomLoadBalancingSpiSelfTest.java |     6 +-
 ...RandomLoadBalancingSpiStartStopSelfTest.java |     4 +-
 ...dRandomLoadBalancingSpiWeightedSelfTest.java |     8 +-
 .../java/org/apache/ignite/spi/package.html     |    24 +
 .../GridSwapSpaceSpiAbstractSelfTest.java       |     6 +-
 .../file/GridFileSwapCompactionSelfTest.java    |     4 +-
 .../file/GridFileSwapSpaceSpiSelfTest.java      |     4 +-
 .../inmemory/GridTestSwapSpaceSpi.java          |     2 +-
 .../noop/GridNoopSwapSpaceSpiSelfTest.java      |     2 +-
 .../startup/GridRandomCommandLineLoader.java    |   400 +
 .../ignite/startup/GridVmNodesStarter.java      |   271 +
 .../cmdline/GridCommandLineLoaderTest.java      |     6 +-
 .../GridCommandLineTransformerSelfTest.java     |     4 +-
 .../java/org/apache/ignite/startup/package.html |    23 +
 .../startup/servlet/GridServletLoaderTest.java  |   171 +
 .../apache/ignite/startup/servlet/package.html  |    23 +
 .../GridCacheStoreValueBytesNode.java           |   140 +
 .../GridCacheStoreValueBytesTest.java           |   340 +
 .../index/GridStreamerIndexSelfTest.java        |    11 +-
 .../window/GridStreamerWindowSelfTest.java      |    10 +-
 .../ignite/testframework/GridFileLock.java      |   110 +
 .../testframework/GridJarClassLoader.java       |   178 +
 .../ignite/testframework/GridLoadTestUtils.java |   152 +
 .../testframework/GridSpiTestContext.java       |   563 +
 .../ignite/testframework/GridStringLogger.java  |   167 +
 .../testframework/GridTestClassLoader.java      |   110 +
 .../GridTestExternalClassLoader.java            |   194 +
 .../ignite/testframework/GridTestNode.java      |   254 +
 .../GridTestSafeThreadFactory.java              |   213 +
 .../ignite/testframework/GridTestThread.java    |   147 +
 .../ignite/testframework/GridTestUtils.java     |  1438 ++
 .../config/GridTestProperties.java              |   304 +
 .../ignite/testframework/config/package.html    |    23 +
 .../http/GridEmbeddedHttpServer.java            |   189 +
 .../ignite/testframework/http/package.html      |    23 +
 .../testframework/junits/GridAbstractTest.java  |  1434 ++
 .../testframework/junits/GridTestIgnite.java    |   224 +
 .../junits/GridTestKernalContext.java           |    85 +
 .../testframework/junits/GridTestResources.java |   255 +
 .../cache/GridAbstractCacheStoreSelfTest.java   |   563 +
 .../junits/cache/TestCacheSession.java          |    65 +
 .../cache/TestThreadLocalCacheSession.java      |    65 +
 .../junits/common/GridAbstractExamplesTest.java |    79 +
 .../GridAbstractLifecycleAwareSelfTest.java     |   127 +
 .../junits/common/GridCommonAbstractTest.java   |   676 +
 .../junits/common/GridCommonTest.java           |    36 +
 .../testframework/junits/common/package.html    |    23 +
 .../logger/GridLog4jRollingFileAppender.java    |   114 +
 .../junits/logger/GridTestLog4jLogger.java      |   514 +
 .../ignite/testframework/junits/package.html    |    24 +
 .../junits/spi/GridSpiAbstractConfigTest.java   |   110 +
 .../junits/spi/GridSpiAbstractTest.java         |   692 +
 .../testframework/junits/spi/GridSpiTest.java   |    62 +
 .../junits/spi/GridSpiTestConfig.java           |    48 +
 .../testframework/junits/spi/package.html       |    23 +
 .../apache/ignite/testframework/package.html    |    23 +
 .../ignite/testsuites/IgniteBasicTestSuite.java |    81 +
 .../IgniteCacheDataStructuresSelfTestSuite.java |    99 +
 .../IgniteCacheEvictionSelfTestSuite.java       |    62 +
 .../IgniteCacheFailoverTestSuite.java           |    56 +
 .../IgniteCacheFullApiSelfTestSuite.java        |   119 +
 .../IgniteCacheGroupLockSelfTestSuite.java      |    48 +
 .../IgniteCacheIteratorsSelfTestSuite.java      |    42 +
 .../IgniteCacheMetricsSelfTestSuite.java        |    49 +
 .../IgniteCacheNearOnlySelfTestSuite.java       |    45 +
 .../testsuites/IgniteCacheRestartTestSuite.java |    49 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |   373 +
 .../IgniteCacheTxRecoverySelfTestSuite.java     |    46 +
 .../IgniteCacheWriteBehindTestSuite.java        |    45 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    98 +
 .../IgniteContinuousTaskSelfTestSuite.java      |    42 +
 .../IgniteExternalizableSelfTestSuite.java      |    37 +
 .../ignite/testsuites/IgniteFsTestSuite.java    |    79 +
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    40 +
 .../IgniteJobMetricsSelfTestSuite.java          |    38 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    80 +
 .../testsuites/IgniteLangSelfTestSuite.java     |    71 +
 .../testsuites/IgniteLoggingSelfTestSuite.java  |    38 +
 .../IgniteMarshallerSelfTestSuite.java          |    45 +
 .../testsuites/IgniteP2PSelfTestSuite.java      |    54 +
 .../testsuites/IgniteRestHandlerTestSuite.java  |    38 +
 .../IgniteSpiCheckpointSelfTestSuite.java       |    56 +
 .../IgniteSpiCollisionSelfTestSuite.java        |    55 +
 .../IgniteSpiCommunicationSelfTestSuite.java    |    52 +
 .../IgniteSpiDeploymentSelfTestSuite.java       |    40 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    56 +
 .../IgniteSpiEventStorageSelfTestSuite.java     |    41 +
 .../IgniteSpiFailoverSelfTestSuite.java         |    53 +
 .../IgniteSpiIndexingSelfTestSuite.java         |    38 +
 .../IgniteSpiLoadBalancingSelfTestSuite.java    |    64 +
 .../IgniteSpiSwapSpaceSelfTestSuite.java        |    41 +
 .../ignite/testsuites/IgniteSpiTestSuite.java   |    69 +
 .../testsuites/IgniteStartUpTestSuite.java      |    38 +
 .../testsuites/IgniteStreamerSelfTestSuite.java |    46 +
 .../IgniteTaskSessionSelfTestSuite.java         |    56 +
 .../IgniteTimeoutProcessorSelfTestSuite.java    |    38 +
 .../testsuites/IgniteUtilSelfTestSuite.java     |    72 +
 .../org/apache/ignite/testsuites/package.html   |    24 +
 .../GridThreadPoolExecutorServiceSelfTest.java  |   187 +
 .../apache/ignite/thread/GridThreadTest.java    |    52 +
 ...dConcurrentLinkedDequeMultiThreadedTest.java |   101 +
 .../util/GridConcurrentLinkedDequeSelfTest.java |   236 +
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |   551 +
 .../apache/ignite/util/GridIndexFillTest.java   |   256 +
 .../apache/ignite/util/GridLogThrottleTest.java |   123 +
 .../ignite/util/GridLongListSelfTest.java       |   153 +
 .../apache/ignite/util/GridQueueSelfTest.java   |    71 +
 .../apache/ignite/util/GridRandomSelfTest.java  |    69 +
 .../ignite/util/GridSnapshotLockSelfTest.java   |   113 +
 .../util/GridSpinReadWriteLockSelfTest.java     |   144 +
 .../util/GridStringBuilderFactorySelfTest.java  |    72 +
 .../util/GridTopologyHeapSizeSelfTest.java      |   120 +
 .../apache/ignite/util/GridTransientTest.java   |    68 +
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   344 +
 .../java/org/apache/ignite/util/package.html    |    24 +
 .../GridCacheStoreValueBytesNode.java           |   140 -
 .../GridCacheStoreValueBytesTest.java           |   340 -
 .../grid/GridCacheAffinityBackupsSelfTest.java  |   113 -
 .../grid/GridExceptionHelpLinksSelfTest.java    |   106 -
 .../grid/GridExternalizableAbstractTest.java    |    41 -
 .../grid/GridSuppressedExceptionSelfTest.java   |   141 -
 .../java/org/gridgain/grid/GridTestIoUtils.java |   198 -
 .../java/org/gridgain/grid/GridTestJob.java     |    51 -
 .../org/gridgain/grid/GridTestJobContext.java   |   103 -
 .../org/gridgain/grid/GridTestJobResult.java    |    92 -
 .../org/gridgain/grid/GridTestNodeStartup.java  |    49 -
 .../gridgain/grid/GridTestStoreNodeStartup.java |    58 -
 .../java/org/gridgain/grid/GridTestTask.java    |    54 -
 .../org/gridgain/grid/GridTestTaskSession.java  |   235 -
 ...CachePartitionFairAffinityNodesSelfTest.java |   243 -
 .../GridCachePartitionFairAffinitySelfTest.java |   261 -
 .../store/GridCacheBalancingStoreSelfTest.java  |   200 -
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |   115 -
 .../cache/store/GridGeneratingTestStore.java    |   102 -
 .../org/gridgain/grid/cache/store/package.html  |    23 -
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   850 --
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   170 -
 .../grid/ggfs/GridGgfsFragmentizerSelfTest.java |   269 -
 .../GridGgfsFragmentizerTopologySelfTest.java   |    50 -
 .../grid/ggfs/GridGgfsPathSelfTest.java         |   163 -
 .../grid/ggfs/GridGgfsTestInputGenerator.java   |    51 -
 .../grid/kernal/ClusterMetricsSelfTest.java     |   354 -
 .../grid/kernal/ClusterNodeMetricsSelfTest.java |   247 -
 .../grid/kernal/GridAffinityMappedTest.java     |   164 -
 .../grid/kernal/GridAffinityP2PSelfTest.java    |   205 -
 .../grid/kernal/GridAffinitySelfTest.java       |   118 -
 .../GridAlwaysFailoverSpiFailSelfTest.java      |   160 -
 .../kernal/GridCacheProjectionRemoveTest.java   |    41 -
 .../kernal/GridCancelOnGridStopSelfTest.java    |   108 -
 .../kernal/GridCancelUnusedJobSelfTest.java     |   221 -
 .../GridCancelledJobsMetricsSelfTest.java       |   215 -
 .../GridCollisionJobsContextSelfTest.java       |   113 -
 .../grid/kernal/GridCommunicationSelfTest.java  |   122 -
 .../GridContinuousJobAnnotationSelfTest.java    |   216 -
 .../GridContinuousJobSiblingsSelfTest.java      |   146 -
 .../grid/kernal/GridContinuousTaskSelfTest.java |   349 -
 .../GridDeploymentMultiThreadedSelfTest.java    |   122 -
 .../grid/kernal/GridDeploymentSelfTest.java     |   536 -
 .../grid/kernal/GridDiscoveryEventSelfTest.java |   421 -
 .../grid/kernal/GridDiscoverySelfTest.java      |   419 -
 .../GridEventStorageCheckAllEventsSelfTest.java |   434 -
 ...ventStorageRuntimeConfigurationSelfTest.java |   348 -
 .../grid/kernal/GridEventStorageSelfTest.java   |   269 -
 .../grid/kernal/GridExecutorServiceTest.java    |   314 -
 .../GridExplicitImplicitDeploymentSelfTest.java |   477 -
 .../grid/kernal/GridFactoryVmShutdownTest.java  |   102 -
 .../GridFailedInputParametersSelfTest.java      |   155 -
 .../GridFailoverCustomTopologySelfTest.java     |   189 -
 .../grid/kernal/GridFailoverSelfTest.java       |   152 -
 .../GridFailoverTaskWithPredicateSelfTest.java  |   252 -
 .../kernal/GridFailoverTopologySelfTest.java    |   161 -
 .../grid/kernal/GridHomePathSelfTest.java       |    75 -
 .../GridJobCheckpointCleanupSelfTest.java       |   165 -
 .../kernal/GridJobCollisionCancelSelfTest.java  |   277 -
 .../grid/kernal/GridJobContextSelfTest.java     |   122 -
 .../kernal/GridJobMasterLeaveAwareSelfTest.java |   803 -
 .../grid/kernal/GridJobStealingSelfTest.java    |   440 -
 .../GridJobStealingZeroActiveJobsSelfTest.java  |   170 -
 .../grid/kernal/GridJobSubjectIdSelfTest.java   |   153 -
 .../GridKernalConcurrentAccessStopSelfTest.java |    63 -
 .../grid/kernal/GridKernalTestUtils.java        |    44 -
 .../grid/kernal/GridLifecycleAwareSelfTest.java |   196 -
 .../grid/kernal/GridLifecycleBeanSelfTest.java  |   313 -
 .../grid/kernal/GridListenActorSelfTest.java    |   232 -
 .../kernal/GridLocalEventListenerSelfTest.java  |    73 -
 .../grid/kernal/GridManagementJobSelfTest.java  |   167 -
 .../grid/kernal/GridMultipleJobsSelfTest.java   |   231 -
 .../grid/kernal/GridMultipleSpisSelfTest.java   |   303 -
 .../GridMultipleVersionsDeploymentSelfTest.java |   307 -
 .../GridMultithreadedJobStealingSelfTest.java   |   241 -
 .../grid/kernal/GridNodeFilterSelfTest.java     |    78 -
 .../grid/kernal/GridNodeLocalSelfTest.java      |    65 -
 .../kernal/GridNodeVisorAttributesSelfTest.java |   114 -
 .../kernal/GridNonHistoryMetricsSelfTest.java   |   125 -
 .../grid/kernal/GridProjectionAbstractTest.java |   769 -
 .../kernal/GridProjectionForCachesSelfTest.java |   256 -
 ...ectionLocalJobMultipleArgumentsSelfTest.java |   156 -
 .../grid/kernal/GridProjectionSelfTest.java     |   145 -
 .../grid/kernal/GridReduceSelfTest.java         |   194 -
 .../grid/kernal/GridReleaseTypeSelfTest.java    |   134 -
 .../kernal/GridRuntimeExceptionSelfTest.java    |   303 -
 .../grid/kernal/GridSameVmStartupSelfTest.java  |   107 -
 .../org/gridgain/grid/kernal/GridSelfTest.java  |   166 -
 .../grid/kernal/GridSpiExceptionSelfTest.java   |   175 -
 .../grid/kernal/GridStartStopSelfTest.java      |   182 -
 .../gridgain/grid/kernal/GridStartupMain.java   |    57 -
 .../gridgain/grid/kernal/GridStartupTest.java   |    69 -
 .../grid/kernal/GridStopWithCancelSelfTest.java |   123 -
 .../grid/kernal/GridStopWithWaitSelfTest.java   |   264 -
 .../GridTaskCancelSingleNodeSelfTest.java       |   186 -
 .../GridTaskContinuousMapperSelfTest.java       |   332 -
 .../GridTaskExecutionContextSelfTest.java       |   179 -
 .../grid/kernal/GridTaskExecutionSelfTest.java  |    69 -
 .../grid/kernal/GridTaskFailoverSelfTest.java   |   118 -
 .../GridTaskFutureImplStopGridSelfTest.java     |   214 -
 .../GridTaskInstanceExecutionSelfTest.java      |   122 -
 .../kernal/GridTaskInstantiationSelfTest.java   |   117 -
 .../grid/kernal/GridTaskJobRejectSelfTest.java  |   161 -
 .../grid/kernal/GridTaskListenerSelfTest.java   |   107 -
 .../grid/kernal/GridTaskMapAsyncSelfTest.java   |   142 -
 .../kernal/GridTaskNameAnnotationSelfTest.java  |   124 -
 .../kernal/GridTaskResultCacheSelfTest.java     |   130 -
 .../grid/kernal/GridTaskTimeoutSelfTest.java    |   224 -
 .../kernal/GridTopicExternalizableSelfTest.java |   165 -
 .../GridTopologyBuildVersionSelfTest.java       |   101 -
 .../grid/kernal/GridUpdateNotifierSelfTest.java |    91 -
 .../grid/kernal/GridVersionSelfTest.java        |    69 -
 .../managers/GridManagerStopSelfTest.java       |   225 -
 .../managers/GridNoopManagerSelfTest.java       |    96 -
 .../GridCheckpointManagerAbstractSelfTest.java  |   756 -
 .../GridCheckpointManagerSelfTest.java          |    68 -
 .../checkpoint/GridCheckpointTaskSelfTest.java  |   233 -
 .../kernal/managers/checkpoint/package.html     |    23 -
 ...idCommunicationManagerListenersSelfTest.java |   159 -
 .../GridCommunicationSendMessageSelfTest.java   |   173 -
 .../communication/GridIoManagerSelfTest.java    |   249 -
 .../kernal/managers/communication/package.html  |    23 -
 .../GridDeploymentManagerStopSelfTest.java      |    99 -
 .../GridDeploymentMessageCountSelfTest.java     |   211 -
 .../managers/deployment/GridTestDeployment.java |    39 -
 .../kernal/managers/deployment/package.html     |    23 -
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   237 -
 .../GridDiscoveryManagerAttributesSelfTest.java |   172 -
 .../discovery/GridDiscoveryManagerSelfTest.java |   155 -
 .../events/GridEventStorageManagerSelfTest.java |   125 -
 .../gridgain/grid/kernal/managers/package.html  |    23 -
 .../GridSwapSpaceCustomLocalValue.java          |    85 -
 .../swapspace/GridSwapSpaceManagerSelfTest.java |   164 -
 .../grid/kernal/managers/swapspace/package.html |    23 -
 .../java/org/gridgain/grid/kernal/package.html  |    24 -
 .../GridAffinityProcessorAbstractSelfTest.java  |   195 -
 ...AffinityProcessorConsistentHashSelfTest.java |    31 -
 ...GridAffinityProcessorRendezvousSelfTest.java |    31 -
 ...ridCacheAbstractByteArrayValuesSelfTest.java |    83 -
 .../GridCacheAbstractFailoverSelfTest.java      |   432 -
 .../cache/GridCacheAbstractFlagsTest.java       |    99 -
 ...cheAbstractFullApiMultithreadedSelfTest.java |   402 -
 .../cache/GridCacheAbstractFullApiSelfTest.java |  5091 -------
 .../GridCacheAbstractIteratorsSelfTest.java     |   349 -
 .../cache/GridCacheAbstractMetricsSelfTest.java |   218 -
 .../GridCacheAbstractProjectionSelfTest.java    |   835 --
 .../GridCacheAbstractRemoveFailureTest.java     |   322 -
 .../cache/GridCacheAbstractSelfTest.java        |   604 -
 .../cache/GridCacheAbstractTxReadTest.java      |   138 -
 .../cache/GridCacheAffinityApiSelfTest.java     |   362 -
 .../cache/GridCacheAffinityMapperSelfTest.java  |   132 -
 .../cache/GridCacheAffinityRoutingSelfTest.java |   690 -
 .../cache/GridCacheAlwaysEvictionPolicy.java    |    34 -
 .../GridCacheAsyncOperationsLimitSelfTest.java  |    76 -
 .../GridCacheAtomicMessageCountSelfTest.java    |   234 -
 .../cache/GridCacheBasicApiAbstractTest.java    |   663 -
 .../cache/GridCacheBasicStoreAbstractTest.java  |   591 -
 ...acheBasicStoreMultithreadedAbstractTest.java |   133 -
 .../cache/GridCacheClearAllSelfTest.java        |   336 -
 ...dCacheColocatedTxStoreExceptionSelfTest.java |    38 -
 .../cache/GridCacheConcurrentMapSelfTest.java   |   385 -
 .../cache/GridCacheConcurrentMapTest.java       |   138 -
 .../GridCacheConcurrentTxMultiNodeTest.java     |   857 --
 ...idCacheConfigurationConsistencySelfTest.java |  1074 --
 ...ridCacheConfigurationValidationSelfTest.java |   196 -
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   190 -
 .../GridCacheDeploymentOffHeapSelfTest.java     |    42 -
 .../cache/GridCacheDeploymentSelfTest.java      |   486 -
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   315 -
 .../cache/GridCacheEntryVersionSelfTest.java    |   159 -
 .../GridCacheEvictionEventAbstractTest.java     |   122 -
 .../GridCacheExAbstractFullApiSelfTest.java     |   103 -
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    82 -
 .../GridCacheFinishPartitionsSelfTest.java      |   313 -
 ...CacheFullTextQueryMultithreadedSelfTest.java |   157 -
 .../cache/GridCacheGenericTestStore.java        |   275 -
 ...idCacheGetAndTransformStoreAbstractTest.java |   177 -
 .../cache/GridCacheGlobalClearAllSelfTest.java  |   168 -
 .../GridCacheGroupLockAbstractSelfTest.java     |  1328 --
 ...heGroupLockFailoverOptimisticTxSelfTest.java |    28 -
 .../GridCacheGroupLockFailoverSelfTest.java     |   533 -
 ...CacheGroupLockMultiNodeAbstractSelfTest.java |    28 -
 .../cache/GridCacheGroupLockPutTask.java        |   157 -
 .../cache/GridCacheIncrementTransformTest.java  |   233 -
 .../GridCacheInterceptorAbstractSelfTest.java   |  1650 ---
 ...cheInterceptorAtomicNearEnabledSelfTest.java |    32 -
 ...erceptorAtomicPrimaryWriteOrderSelfTest.java |    45 -
 ...omicReplicatedPrimaryWriteOrderSelfTest.java |    46 -
 ...acheInterceptorAtomicReplicatedSelfTest.java |    45 -
 .../GridCacheInterceptorAtomicSelfTest.java     |    45 -
 ...ceptorAtomicWithStoreReplicatedSelfTest.java |    31 -
 ...CacheInterceptorAtomicWithStoreSelfTest.java |    30 -
 ...GridCacheInterceptorLocalAtomicSelfTest.java |    50 -
 ...InterceptorLocalAtomicWithStoreSelfTest.java |    30 -
 .../GridCacheInterceptorLocalSelfTest.java      |    44 -
 ...dCacheInterceptorLocalWithStoreSelfTest.java |    30 -
 ...GridCacheInterceptorNearEnabledSelfTest.java |    30 -
 .../GridCacheInterceptorReplicatedSelfTest.java |    39 -
 ...eInterceptorReplicatedWithStoreSelfTest.java |    30 -
 .../cache/GridCacheInterceptorSelfTest.java     |    39 -
 .../GridCacheInterceptorSelfTestSuite.java      |    56 -
 .../GridCacheInterceptorWithStoreSelfTest.java  |    30 -
 .../cache/GridCacheIteratorPerformanceTest.java |   278 -
 .../GridCacheKeyCheckNearEnabledSelfTest.java   |    30 -
 .../cache/GridCacheKeyCheckSelfTest.java        |   206 -
 .../processors/cache/GridCacheLeakTest.java     |   151 -
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   368 -
 .../GridCacheLocalTxStoreExceptionSelfTest.java |    37 -
 .../cache/GridCacheLuceneQueryIndexTest.java    |   466 -
 .../GridCacheMarshallerTxAbstractTest.java      |   132 -
 .../cache/GridCacheMemoryModeSelfTest.java      |   269 -
 .../GridCacheMissingCommitVersionSelfTest.java  |   128 -
 ...GridCacheMixedPartitionExchangeSelfTest.java |   153 -
 .../cache/GridCacheMultiUpdateLockSelfTest.java |   204 -
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |   134 -
 ...ultinodeUpdateAtomicNearEnabledSelfTest.java |    39 -
 .../GridCacheMultinodeUpdateAtomicSelfTest.java |    38 -
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    39 -
 ...CacheMultinodeUpdateNearEnabledSelfTest.java |    40 -
 .../cache/GridCacheMultinodeUpdateSelfTest.java |    39 -
 .../cache/GridCacheMvccFlagsTest.java           |   141 -
 .../cache/GridCacheMvccManagerSelfTest.java     |   116 -
 .../cache/GridCacheMvccPartitionedSelfTest.java |   687 -
 .../processors/cache/GridCacheMvccSelfTest.java |  1850 ---
 .../GridCacheNearTxStoreExceptionSelfTest.java  |    32 -
 .../cache/GridCacheNestedTxAbstractTest.java    |   279 -
 .../cache/GridCacheObjectToStringSelfTest.java  |   194 -
 ...ffHeapAtomicMultiThreadedUpdateSelfTest.java |    33 -
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |   399 -
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   270 -
 .../cache/GridCacheOffHeapSelfTest.java         |   655 -
 .../processors/cache/GridCacheOffHeapTest.java  |   258 -
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   683 -
 .../GridCacheOffHeapTieredAtomicSelfTest.java   |    32 -
 ...heOffHeapTieredEvictionAbstractSelfTest.java |   423 -
 ...acheOffHeapTieredEvictionAtomicSelfTest.java |    32 -
 .../GridCacheOffHeapTieredEvictionSelfTest.java |    33 -
 .../cache/GridCacheOffHeapTieredSelfTest.java   |    33 -
 .../cache/GridCacheOffheapUpdateSelfTest.java   |   140 -
 .../GridCacheOrderedPreloadingSelfTest.java     |   158 -
 .../cache/GridCacheP2PUndeploySelfTest.java     |   306 -
 .../GridCachePartitionedAffinitySpreadTest.java |   167 -
 .../cache/GridCachePartitionedGetSelfTest.java  |   253 -
 ...hePartitionedProjectionAffinitySelfTest.java |   119 -
 .../cache/GridCachePartitionedWritesTest.java   |   149 -
 .../GridCachePreloadingEvictionsSelfTest.java   |   263 -
 .../cache/GridCachePutAllFailoverSelfTest.java  |   708 -
 .../processors/cache/GridCachePutAllTask.java   |   133 -
 .../cache/GridCacheQueryEmbeddedValue.java      |    49 -
 .../cache/GridCacheQueryIndexSelfTest.java      |   124 -
 .../GridCacheQueryIndexingDisabledSelfTest.java |    99 -
 .../GridCacheQueryInternalKeysSelfTest.java     |   113 -
 .../GridCacheReferenceCleanupSelfTest.java      |   503 -
 .../cache/GridCacheReloadSelfTest.java          |   179 -
 ...ridCacheReplicatedSynchronousCommitTest.java |   203 -
 ...CacheReplicatedTxStoreExceptionSelfTest.java |    38 -
 .../GridCacheReturnValueTransferSelfTest.java   |   208 -
 .../cache/GridCacheSlowTxWarnTest.java          |   148 -
 .../processors/cache/GridCacheStopSelfTest.java |   202 -
 .../cache/GridCacheStorePutxSelfTest.java       |   160 -
 .../cache/GridCacheStoreValueBytesSelfTest.java |   112 -
 .../cache/GridCacheSwapPreloadSelfTest.java     |   224 -
 .../cache/GridCacheSwapReloadSelfTest.java      |   240 -
 .../processors/cache/GridCacheTestEntryEx.java  |   820 --
 .../processors/cache/GridCacheTestKey.java      |    64 -
 .../processors/cache/GridCacheTestStore.java    |   335 -
 .../processors/cache/GridCacheTestValue.java    |    77 -
 .../processors/cache/GridCacheTestValue2.java   |    67 -
 ...cheTransactionalAbstractMetricsSelfTest.java |   280 -
 .../cache/GridCacheTtlManagerLoadTest.java      |    85 -
 .../cache/GridCacheTtlManagerSelfTest.java      |   121 -
 .../cache/GridCacheUtilsSelfTest.java           |   261 -
 .../GridCacheValueBytesPreloadingSelfTest.java  |   152 -
 ...idCacheValueConsistencyAbstractSelfTest.java |   323 -
 ...istencyTransactionalNearEnabledSelfTest.java |    31 -
 ...heValueConsistencyTransactionalSelfTest.java |    37 -
 .../GridCacheVariableTopologySelfTest.java      |   192 -
 .../cache/GridCacheVersionSelfTest.java         |    80 -
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   189 -
 .../GridCacheWriteBehindStoreAbstractTest.java  |   359 -
 .../GridCacheWriteBehindStoreLocalTest.java     |    30 -
 ...heWriteBehindStoreMultithreadedSelfTest.java |   163 -
 ...BehindStorePartitionedMultiNodeSelfTest.java |   217 -
 ...ridCacheWriteBehindStorePartitionedTest.java |    30 -
 ...GridCacheWriteBehindStoreReplicatedTest.java |    30 -
 .../GridCacheWriteBehindStoreSelfTest.java      |   267 -
 .../processors/cache/IgniteTxAbstractTest.java  |   492 -
 .../IgniteTxConcurrentGetAbstractTest.java      |   142 -
 .../IgniteTxExceptionAbstractSelfTest.java      |   648 -
 .../cache/IgniteTxMultiNodeAbstractTest.java    |   926 --
 .../IgniteTxMultiThreadedAbstractTest.java      |   283 -
 .../cache/IgniteTxReentryAbstractSelfTest.java  |   178 -
 .../IgniteTxSingleThreadedAbstractTest.java     |   137 -
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   658 -
 ...eAbstractDataStructuresFailoverSelfTest.java |   994 --
 ...actQueueFailoverDataConsistencySelfTest.java |   380 -
 .../GridCacheAtomicLongApiSelfTest.java         |   485 -
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   214 -
 ...cheAtomicReferenceMultiNodeAbstractTest.java |   202 -
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   153 -
 .../GridCacheCountDownLatchSelfTest.java        |   410 -
 .../GridCacheMultiNodeDataStructureTest.java    |    79 -
 .../GridCacheQueueApiSelfAbstractTest.java      |   712 -
 .../GridCacheQueueCleanupSelfTest.java          |   236 -
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   306 -
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |   832 --
 ...dCacheQueueMultiNodeConsistencySelfTest.java |   256 -
 ...CacheQueueRotativeMultiNodeAbstractTest.java |   442 -
 .../GridCacheSequenceApiSelfAbstractTest.java   |   572 -
 ...dCacheSequenceMultiNodeAbstractSelfTest.java |   290 -
 .../GridCacheSetAbstractSelfTest.java           |   898 --
 .../GridCacheSetFailoverAbstractSelfTest.java   |   245 -
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    39 -
 .../local/GridCacheLocalAtomicSetSelfTest.java  |    44 -
 .../local/GridCacheLocalQueueApiSelfTest.java   |    44 -
 .../GridCacheLocalSequenceApiSelfTest.java      |    46 -
 .../local/GridCacheLocalSetSelfTest.java        |    38 -
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    41 -
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    39 -
 ...micQueueFailoverDataConsistencySelfTest.java |    34 -
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    41 -
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    42 -
 ...hePartitionedAtomicReferenceApiSelfTest.java |    48 -
 ...PartitionedAtomicReferenceMultiNodeTest.java |    46 -
 ...titionedAtomicSequenceMultiThreadedTest.java |   360 -
 ...chePartitionedAtomicSetFailoverSelfTest.java |    39 -
 .../GridCachePartitionedAtomicSetSelfTest.java  |    50 -
 ...achePartitionedAtomicStampedApiSelfTest.java |    52 -
 ...rtitionedDataStructuresFailoverSelfTest.java |    34 -
 ...GridCachePartitionedNodeRestartSelfTest.java |    68 -
 ...idCachePartitionedNodeRestartTxSelfTest.java |   294 -
 .../GridCachePartitionedQueueApiSelfTest.java   |    52 -
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   195 -
 ...dCachePartitionedQueueEntryMoveSelfTest.java |   254 -
 ...nedQueueFailoverDataConsistencySelfTest.java |    27 -
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    52 -
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    50 -
 ...hePartitionedQueueRotativeMultiNodeTest.java |    49 -
 ...GridCachePartitionedSequenceApiSelfTest.java |    51 -
 ...chePartitionedSequenceMultiNodeSelfTest.java |    51 -
 ...GridCachePartitionedSetFailoverSelfTest.java |    33 -
 .../GridCachePartitionedSetSelfTest.java        |    33 -
 ...cheReplicatedAtomicReferenceApiSelfTest.java |    45 -
 ...eReplicatedAtomicReferenceMultiNodeTest.java |    45 -
 ...CacheReplicatedAtomicStampedApiSelfTest.java |    44 -
 ...eplicatedDataStructuresFailoverSelfTest.java |    34 -
 .../GridCacheReplicatedQueueApiSelfTest.java    |    47 -
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    47 -
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    47 -
 .../GridCacheReplicatedSequenceApiSelfTest.java |    46 -
 ...acheReplicatedSequenceMultiNodeSelfTest.java |    46 -
 .../GridCacheReplicatedSetSelfTest.java         |    33 -
 ...tractDistributedByteArrayValuesSelfTest.java |   390 -
 .../GridCacheAbstractJobExecutionTest.java      |   183 -
 .../GridCacheAbstractNodeRestartSelfTest.java   |   886 --
 ...tractPartitionedByteArrayValuesSelfTest.java |   101 -
 .../GridCacheAbstractPrimarySyncSelfTest.java   |   109 -
 .../GridCacheAtomicTimeoutSelfTest.java         |   297 -
 .../GridCacheBasicOpAbstractTest.java           |   388 -
 .../GridCacheClientModesAbstractSelfTest.java   |   210 -
 .../GridCacheEntrySetAbstractSelfTest.java      |   117 -
 ...acheEntrySetIterationPreloadingSelfTest.java |    91 -
 .../distributed/GridCacheEventAbstractTest.java |   964 --
 ...heExpiredEntriesPreloadAbstractSelfTest.java |   119 -
 .../distributed/GridCacheLockAbstractTest.java  |   464 -
 .../distributed/GridCacheMixedModeSelfTest.java |    82 -
 .../GridCacheModuloAffinityFunction.java        |   200 -
 .../GridCacheMultiNodeAbstractTest.java         |   490 -
 .../GridCacheMultiNodeLockAbstractTest.java     |   634 -
 ...dCacheMultithreadedFailoverAbstractTest.java |   607 -
 .../GridCacheNodeFailureAbstractTest.java       |   296 -
 ...dCachePartitionedAffinityFilterSelfTest.java |   145 -
 ...chePartitionedReloadAllAbstractSelfTest.java |   249 -
 .../GridCachePreloadEventsAbstractSelfTest.java |   132 -
 .../GridCachePreloadLifecycleAbstractTest.java  |   231 -
 ...GridCachePreloadRestartAbstractSelfTest.java |   323 -
 .../GridCacheTransformEventSelfTest.java        |   610 -
 ...iteTxConsistencyRestartAbstractSelfTest.java |   203 -
 ...xOriginatingNodeFailureAbstractSelfTest.java |   306 -
 ...cOriginatingNodeFailureAbstractSelfTest.java |   504 -
 .../IgniteTxPreloadAbstractTest.java            |   221 -
 .../IgniteTxTimeoutAbstractTest.java            |   155 -
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |   169 -
 ...heAbstractTransformWriteThroughSelfTest.java |   336 -
 ...acheAtomicExpiredEntriesPreloadSelfTest.java |    45 -
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   101 -
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |   821 --
 ...idCacheAtomicNearEnabledFullApiSelfTest.java |    32 -
 ...EnabledPrimaryWriteOrderFullApiSelfTest.java |    33 -
 ...eAtomicPrimaryWriteOrderFullApiSelfTest.java |    32 -
 ...tomicPrimaryWriteOrderReloadAllSelfTest.java |    32 -
 .../dht/GridCacheAtomicReloadAllSelfTest.java   |    38 -
 .../dht/GridCacheClientOnlySelfTest.java        |    38 -
 .../dht/GridCacheColocatedDebugTest.java        |   978 --
 .../dht/GridCacheColocatedFailoverSelfTest.java |    39 -
 ...eColocatedOptimisticTransactionSelfTest.java |   157 -
 ...ridCacheColocatedPreloadRestartSelfTest.java |    30 -
 .../GridCacheColocatedPrimarySyncSelfTest.java  |    33 -
 .../GridCacheColocatedReloadAllSelfTest.java    |    30 -
 .../GridCacheColocatedTxExceptionSelfTest.java  |    39 -
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 -
 ...dCacheColocatedTxSingleThreadedSelfTest.java |   108 -
 .../GridCacheDaemonNodePartitionedSelfTest.java |    31 -
 ...cheDhtAtomicEvictionNearReadersSelfTest.java |    32 -
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    51 -
 .../dht/GridCacheDhtEntrySelfTest.java          |   315 -
 .../dht/GridCacheDhtEntrySetSelfTest.java       |    46 -
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   298 -
 .../dht/GridCacheDhtEvictionSelfTest.java       |   364 -
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |   126 -
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java |    39 -
 .../dht/GridCacheDhtInternalEntrySelfTest.java  |   226 -
 .../dht/GridCacheDhtMappingSelfTest.java        |   106 -
 .../dht/GridCacheDhtMultiBackupTest.java        |   136 -
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |   229 -
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |   461 -
 .../GridCacheDhtPreloadDisabledSelfTest.java    |   279 -
 .../GridCacheDhtPreloadMessageCountTest.java    |   176 -
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   176 -
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |    39 -
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |   276 -
 .../dht/GridCacheDhtPreloadSelfTest.java        |   675 -
 .../GridCacheDhtPreloadStartStopSelfTest.java   |   270 -
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |   322 -
 .../dht/GridCacheDhtRemoveFailureTest.java      |    45 -
 .../distributed/dht/GridCacheDhtTestUtils.java  |   232 -
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    45 -
 .../GridCacheExColocatedFullApiSelfTest.java    |    33 -
 .../dht/GridCacheGlobalLoadTest.java            |   171 -
 .../GridCacheGroupLockColocatedSelfTest.java    |    38 -
 ...acheGroupLockMultiNodeColocatedSelfTest.java |    29 -
 ...cheGroupLockPartitionedAbstractSelfTest.java |   136 -
 ...ockPartitionedMultiNodeAbstractSelfTest.java |   173 -
 ...ePartitionedNearDisabledFullApiSelfTest.java |    33 -
 ...ePartitionedNearDisabledMetricsSelfTest.java |   120 -
 ...nedNearDisabledMultiNodeFullApiSelfTest.java |    34 -
 ...bledMultiNodeP2PDisabledFullApiSelfTest.java |    34 -
 ...ionedNearDisabledOffHeapFullApiSelfTest.java |    29 -
 ...DisabledOffHeapMultiNodeFullApiSelfTest.java |    29 -
 ...isabledTxOriginatingNodeFailureSelfTest.java |    31 -
 ...dOnlyP2PDisabledByteArrayValuesSelfTest.java |    29 -
 ...edOnlyP2PEnabledByteArrayValuesSelfTest.java |    29 -
 ...dCachePartitionedOnlyProjectionSelfTest.java |    32 -
 ...idCachePartitionedPreloadEventsSelfTest.java |   125 -
 ...dCachePartitionedTopologyChangeSelfTest.java |   597 -
 ...ransformWriteThroughBatchUpdateSelfTest.java |    29 -
 ...itionedTxOriginatingNodeFailureSelfTest.java |   162 -
 ...ridCachePartitionedUnloadEventsSelfTest.java |   152 -
 ...teTxConsistencyColocatedRestartSelfTest.java |    36 -
 .../dht/IgniteTxReentryColocatedSelfTest.java   |    79 -
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   327 -
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |   215 -
 ...lueConsistencyAtomicNearEnabledSelfTest.java |    38 -
 ...micPrimaryWriteOrderNearEnabledSelfTest.java |    39 -
 ...GridCacheValueConsistencyAtomicSelfTest.java |   140 -
 ...tNearPartitionedByteArrayValuesSelfTest.java |    34 -
 ...unctionExcludeNeighborsAbstractSelfTest.java |   184 -
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   502 -
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |    69 -
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |    67 -
 ...omicNearEnabledMultiNodeFullApiSelfTest.java |    32 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 -
 ...ridCacheAtomicNearEvictionEventSelfTest.java |    39 -
 .../GridCacheAtomicNearEvictionSelfTest.java    |    32 -
 .../GridCacheAtomicNearMultiNodeSelfTest.java   |    32 -
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |   193 -
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 .../near/GridCacheAtomicNearOnlySelfTest.java   |    32 -
 .../GridCacheAtomicNearReadersSelfTest.java     |    32 -
 .../GridCacheAtomicNearRemoveFailureTest.java   |    52 -
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |    66 -
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |    67 -
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    64 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    32 -
 ...rderMultiNodeP2PDisabledFullApiSelfTest.java |    33 -
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |    52 -
 ...PrimaryWriteOrderOffHeapFullApiSelfTest.java |    32 -
 ...ityOrderOffHeapMultiNodeFullApiSelfTest.java |    33 -
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 -
 .../near/GridCacheExNearFullApiSelfTest.java    |    39 -
 .../near/GridCacheGetStoreErrorSelfTest.java    |   152 -
 ...GridCacheGroupLockMultiNodeNearSelfTest.java |    30 -
 .../near/GridCacheGroupLockNearSelfTest.java    |    38 -
 .../GridCacheNearEvictionEventSelfTest.java     |    48 -
 .../near/GridCacheNearEvictionSelfTest.java     |   187 -
 ...dCacheNearExpiredEntriesPreloadSelfTest.java |    39 -
 .../near/GridCacheNearJobExecutionSelfTest.java |    49 -
 .../near/GridCacheNearMetricsSelfTest.java      |   396 -
 .../near/GridCacheNearMultiGetSelfTest.java     |   309 -
 .../near/GridCacheNearMultiNodeSelfTest.java    |   968 --
 .../near/GridCacheNearOneNodeSelfTest.java      |   391 -
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   424 -
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    34 -
 .../near/GridCacheNearOnlySelfTest.java         |    68 -
 .../near/GridCacheNearOnlyTopologySelfTest.java |   234 -
 .../GridCacheNearPartitionedClearSelfTest.java  |   156 -
 ...ionedP2PDisabledByteArrayValuesSelfTest.java |    29 -
 ...tionedP2PEnabledByteArrayValuesSelfTest.java |    29 -
 .../GridCacheNearPreloadRestartSelfTest.java    |    30 -
 .../near/GridCacheNearPrimarySyncSelfTest.java  |    33 -
 .../GridCacheNearReaderPreloadSelfTest.java     |   200 -
 .../near/GridCacheNearReadersSelfTest.java      |   585 -
 .../near/GridCacheNearReloadAllSelfTest.java    |    30 -
 .../near/GridCacheNearRemoveFailureTest.java    |    45 -
 .../near/GridCacheNearTxExceptionSelfTest.java  |    33 -
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   246 -
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 -
 .../near/GridCacheNearTxPreloadSelfTest.java    |    45 -
 ...AffinityExcludeNeighborsPerformanceTest.java |   254 -
 ...rtitionedAffinityHashIdResolverSelfTest.java |    97 -
 .../GridCachePartitionedAffinitySelfTest.java   |   516 -
 ...ionedAtomicGetAndTransformStoreSelfTest.java |    33 -
 .../near/GridCachePartitionedBasicApiTest.java  |    47 -
 .../GridCachePartitionedBasicOpSelfTest.java    |    68 -
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |   358 -
 .../GridCachePartitionedBasicStoreSelfTest.java |    33 -
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |    67 -
 .../GridCachePartitionedEntryLockSelfTest.java  |   111 -
 .../near/GridCachePartitionedEventSelfTest.java |    60 -
 .../GridCachePartitionedEvictionSelfTest.java   |   216 -
 ...titionedExplicitLockNodeFailureSelfTest.java |   166 -
 .../GridCachePartitionedFailoverSelfTest.java   |    33 -
 ...GridCachePartitionedFilteredPutSelfTest.java |   166 -
 .../near/GridCachePartitionedFlagsTest.java     |    41 -
 ...PartitionedFullApiMultithreadedSelfTest.java |    38 -
 .../GridCachePartitionedFullApiSelfTest.java    |   252 -
 ...PartitionedGetAndTransformStoreSelfTest.java |    34 -
 .../GridCachePartitionedIteratorsSelfTest.java  |    43 -
 .../GridCachePartitionedLoadCacheSelfTest.java  |   156 -
 .../near/GridCachePartitionedLockSelfTest.java  |    87 -
 .../GridCachePartitionedMetricsSelfTest.java    |    60 -
 ...achePartitionedMultiNodeCounterSelfTest.java |   780 -
 ...achePartitionedMultiNodeFullApiSelfTest.java |   597 -
 ...idCachePartitionedMultiNodeLockSelfTest.java |    78 -
 ...onedMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 .../GridCachePartitionedMultiNodeSelfTest.java  |    49 -
 ...ePartitionedMultiThreadedPutGetSelfTest.java |   205 -
 ...NearDisabledBasicStoreMultiNodeSelfTest.java |    33 -
 ...itionedNearOnlyNoPrimaryFullApiSelfTest.java |    31 -
 .../near/GridCachePartitionedNestedTxTest.java  |    50 -
 ...GridCachePartitionedNodeFailureSelfTest.java |    51 -
 .../GridCachePartitionedNodeRestartTest.java    |   131 -
 ...dCachePartitionedOffHeapFullApiSelfTest.java |    28 -
 ...titionedOffHeapMultiNodeFullApiSelfTest.java |    28 -
 ...ePartitionedOptimisticTxNodeRestartTest.java |   127 -
 ...achePartitionedPreloadLifecycleSelfTest.java |   279 -
 .../GridCachePartitionedProjectionSelfTest.java |   156 -
 ...hePartitionedQueryMultiThreadedSelfTest.java |   305 -
 .../GridCachePartitionedStorePutSelfTest.java   |   149 -
 ...GridCachePartitionedTxConcurrentGetTest.java |    46 -
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    81 -
 ...CachePartitionedTxMultiThreadedSelfTest.java |   105 -
 .../near/GridCachePartitionedTxReadTest.java    |    33 -
 .../GridCachePartitionedTxSalvageSelfTest.java  |   285 -
 ...achePartitionedTxSingleThreadedSelfTest.java |   107 -
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    67 -
 .../near/GridCachePutArrayValueSelfTest.java    |   117 -
 ...idCacheRendezvousAffinityClientSelfTest.java |   106 -
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 -
 .../near/GridPartitionedBackupLoadSelfTest.java |   166 -
 .../near/IgniteTxReentryNearSelfTest.java       |    79 -
 ...stractReplicatedByteArrayValuesSelfTest.java |    84 -
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    59 -
 .../GridCacheDaemonNodeReplicatedSelfTest.java  |    31 -
 .../GridCacheExReplicatedFullApiSelfTest.java   |    33 -
 ...cheGroupLockMultiNodeReplicatedSelfTest.java |    45 -
 .../GridCacheGroupLockReplicatedSelfTest.java   |    39 -
 ...ridCacheReplicatedAtomicFullApiSelfTest.java |    42 -
 ...catedAtomicGetAndTransformStoreSelfTest.java |    33 -
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |    60 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 -
 .../GridCacheReplicatedBasicApiTest.java        |    42 -
 .../GridCacheReplicatedBasicOpSelfTest.java     |    42 -
 .../GridCacheReplicatedBasicStoreSelfTest.java  |    33 -
 .../GridCacheReplicatedClientOnlySelfTest.java  |    43 -
 .../GridCacheReplicatedEntrySetSelfTest.java    |    33 -
 .../GridCacheReplicatedEventSelfTest.java       |    38 -
 ...ridCacheReplicatedEvictionEventSelfTest.java |    38 -
 .../GridCacheReplicatedEvictionSelfTest.java    |   131 -
 .../GridCacheReplicatedFailoverSelfTest.java    |    33 -
 .../GridCacheReplicatedFlagsTest.java           |    28 -
 ...eReplicatedFullApiMultithreadedSelfTest.java |    38 -
 ...ReplicatedFullApiMultithreadedSelfTest1.java |  1980 ---
 .../GridCacheReplicatedFullApiSelfTest.java     |    58 -
 ...eReplicatedGetAndTransformStoreSelfTest.java |    39 -
 .../GridCacheReplicatedInvalidateSelfTest.java  |   245 -
 .../GridCacheReplicatedIteratorsSelfTest.java   |    43 -
 .../GridCacheReplicatedJobExecutionTest.java    |    46 -
 .../GridCacheReplicatedLockSelfTest.java        |    33 -
 .../GridCacheReplicatedMarshallerTxTest.java    |    47 -
 .../GridCacheReplicatedMetricsSelfTest.java     |    54 -
 ...CacheReplicatedMultiNodeFullApiSelfTest.java |    28 -
 ...ridCacheReplicatedMultiNodeLockSelfTest.java |    42 -
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    42 -
 ...licatedNearOnlyMultiNodeFullApiSelfTest.java |    39 -
 .../GridCacheReplicatedNearOnlySelfTest.java    |    43 -
 .../GridCacheReplicatedNodeFailureSelfTest.java |    46 -
 .../GridCacheReplicatedNodeRestartSelfTest.java |    54 -
 ...idCacheReplicatedOffHeapFullApiSelfTest.java |    28 -
 ...plicatedOffHeapMultiNodeFullApiSelfTest.java |    28 -
 ...catedP2PDisabledByteArrayValuesSelfTest.java |    29 -
 ...icatedP2PEnabledByteArrayValuesSelfTest.java |    29 -
 ...ridCacheReplicatedPreloadEventsSelfTest.java |    32 -
 .../GridCacheReplicatedProjectionSelfTest.java  |    66 -
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |    35 -
 .../GridCacheReplicatedTxConcurrentGetTest.java |    45 -
 .../GridCacheReplicatedTxExceptionSelfTest.java |    39 -
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    81 -
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |   111 -
 ...licatedTxOriginatingNodeFailureSelfTest.java |    37 -
 ...ssimisticOriginatingNodeFailureSelfTest.java |    47 -
 .../GridCacheReplicatedTxReadTest.java          |    33 -
 ...CacheReplicatedTxSingleThreadedSelfTest.java |   102 -
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    60 -
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |   172 -
 .../GridCacheSyncReplicatedPreloadSelfTest.java |   166 -
 .../replicated/GridReplicatedTxPreloadTest.java |    33 -
 ...CacheReplicatedPreloadLifecycleSelfTest.java |   294 -
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |    39 -
 .../GridCacheReplicatedPreloadSelfTest.java     |   583 -
 ...eplicatedPreloadStartStopEventsSelfTest.java |    95 -
 ...GridCacheReplicatedPreloadUndeploysTest.java |    87 -
 .../GridCacheBatchEvictUnswapSelfTest.java      |   194 -
 ...heConcurrentEvictionConsistencySelfTest.java |   268 -
 .../GridCacheConcurrentEvictionsSelfTest.java   |   184 -
 .../GridCacheDistributedEvictionsSelfTest.java  |   266 -
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   306 -
 .../GridCacheEmptyEntriesLocalSelfTest.java     |    41 -
 ...ridCacheEmptyEntriesPartitionedSelfTest.java |    41 -
 .../eviction/GridCacheEvictionAbstractTest.java |   463 -
 .../GridCacheEvictionFilterSelfTest.java        |   250 -
 .../GridCacheEvictionLockUnlockSelfTest.java    |   176 -
 .../GridCacheEvictionTouchSelfTest.java         |   348 -
 .../cache/eviction/GridCacheMockEntry.java      |   365 -
 ...cheSynchronousEvictionsFailoverSelfTest.java |   161 -
 .../GridCacheFifoEvictionPolicySelfTest.java    |   380 -
 .../lru/GridCacheLruEvictionPolicySelfTest.java |   426 -
 .../GridCacheLruNearEvictionPolicySelfTest.java |   137 -
 ...heNearOnlyLruNearEvictionPolicySelfTest.java |   168 -
 .../GridCacheRandomEvictionPolicySelfTest.java  |   266 -
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |    29 -
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    59 -
 .../local/GridCacheDaemonNodeLocalSelfTest.java |    65 -
 .../local/GridCacheExLocalFullApiSelfTest.java  |    30 -
 .../GridCacheLocalAtomicBasicStoreSelfTest.java |    32 -
 .../GridCacheLocalAtomicFullApiSelfTest.java    |    42 -
 ...LocalAtomicGetAndTransformStoreSelfTest.java |    33 -
 ...dCacheLocalAtomicOffHeapFullApiSelfTest.java |    42 -
 .../GridCacheLocalAtomicProjectionSelfTest.java |    32 -
 .../local/GridCacheLocalBasicApiSelfTest.java   |    42 -
 ...cheLocalBasicStoreMultithreadedSelfTest.java |    30 -
 .../local/GridCacheLocalBasicStoreSelfTest.java |    33 -
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   259 -
 .../local/GridCacheLocalEventSelfTest.java      |    38 -
 .../GridCacheLocalEvictionEventSelfTest.java    |    38 -
 ...dCacheLocalFullApiMultithreadedSelfTest.java |    38 -
 .../local/GridCacheLocalFullApiSelfTest.java    |   142 -
 ...dCacheLocalGetAndTransformStoreSelfTest.java |    33 -
 .../local/GridCacheLocalIteratorsSelfTest.java  |   172 -
 .../local/GridCacheLocalLoadAllSelfTest.java    |   111 -
 .../cache/local/GridCacheLocalLockSelfTest.java |   315 -
 .../local/GridCacheLocalMetricsSelfTest.java    |    55 -
 .../GridCacheLocalMultithreadedSelfTest.java    |   339 -
 .../GridCacheLocalOffHeapFullApiSelfTest.java   |    28 -
 .../local/GridCacheLocalProjectionSelfTest.java |    38 -
 .../GridCacheLocalTxExceptionSelfTest.java      |    38 -
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    91 -
 .../cache/local/GridCacheLocalTxReadTest.java   |    33 -
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    86 -
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |   165 -
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   446 -
 .../query/GridCacheSwapScanQuerySelfTest.java   |    28 -
 .../cache/query/GridCircularQueueTest.java      |   119 -
 ...ridCacheContinuousQueryAbstractSelfTest.java |  1539 --
 ...ontinuousQueryAtomicNearEnabledSelfTest.java |    32 -
 ...ontinuousQueryAtomicP2PDisabledSelfTest.java |    29 -
 .../GridCacheContinuousQueryAtomicSelfTest.java |    43 -
 ...CacheContinuousQueryLocalAtomicSelfTest.java |    32 -
 .../GridCacheContinuousQueryLocalSelfTest.java  |    37 -
 ...eContinuousQueryPartitionedOnlySelfTest.java |    48 -
 ...uousQueryPartitionedP2PDisabledSelfTest.java |    29 -
 ...CacheContinuousQueryPartitionedSelfTest.java |    37 -
 ...ContinuousQueryReplicatedAtomicSelfTest.java |    37 -
 ...nuousQueryReplicatedP2PDisabledSelfTest.java |    28 -
 ...dCacheContinuousQueryReplicatedSelfTest.java |    82 -
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |   427 -
 ...ridCacheReduceFieldsQueryAtomicSelfTest.java |    38 -
 ...GridCacheReduceFieldsQueryLocalSelfTest.java |    37 -
 ...cheReduceFieldsQueryPartitionedSelfTest.java |    58 -
 ...acheReduceFieldsQueryReplicatedSelfTest.java |    37 -
 .../clock/GridTimeSyncProcessorSelfTest.java    |   224 -
 .../closure/GridClosureProcessorRemoteTest.java |   119 -
 .../closure/GridClosureProcessorSelfTest.java   |   542 -
 .../grid/kernal/processors/closure/package.html |    23 -
 .../continuous/GridEventConsumeSelfTest.java    |  1080 --
 .../continuous/GridMessageListenSelfTest.java   |   489 -
 .../dataload/GridDataLoaderImplSelfTest.java    |   216 -
 .../dataload/GridDataLoaderPerformanceTest.java |   215 -
 .../GridDataLoaderProcessorSelfTest.java        |   884 --
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   491 -
 .../ggfs/GridGgfsAbstractSelfTest.java          |  2455 ----
 .../ggfs/GridGgfsAttributesSelfTest.java        |    75 -
 .../processors/ggfs/GridGgfsCacheSelfTest.java  |   134 -
 .../ggfs/GridGgfsCommonAbstractTest.java        |    67 -
 .../ggfs/GridGgfsDataManagerSelfTest.java       |   600 -
 .../ggfs/GridGgfsDualAbstractSelfTest.java      |  1601 --
 .../ggfs/GridGgfsDualAsyncSelfTest.java         |    32 -
 .../ggfs/GridGgfsDualSyncSelfTest.java          |    32 -
 .../ggfs/GridGgfsFileInfoSelfTest.java          |    88 -
 .../ggfs/GridGgfsFileMapSelfTest.java           |   337 -
 ...GgfsGroupDataBlockKeyMapperHashSelfTest.java |   136 -
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |   468 -
 .../ggfs/GridGgfsMetricsSelfTest.java           |   537 -
 .../ggfs/GridGgfsModeResolverSelfTest.java      |    77 -
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   605 -
 .../GridGgfsPrimaryOffheapTieredSelfTest.java   |    33 -
 .../GridGgfsPrimaryOffheapValuesSelfTest.java   |    33 -
 .../ggfs/GridGgfsPrimarySelfTest.java           |    32 -
 .../ggfs/GridGgfsProcessorSelfTest.java         |   978 --
 .../GridGgfsProcessorValidationSelfTest.java    |   535 -
 ...IpcEndpointRegistrationAbstractSelfTest.java |   186 -
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |    50 -
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    54 -
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |   876 --
 .../ggfs/GridGgfsStreamsSelfTest.java           |   473 -
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   317 -
 .../ggfs/GridGgfsTestInputStream.java           |    66 -
 .../grid/kernal/processors/ggfs/package.html    |    23 -
 .../GridGgfsAbstractRecordResolverSelfTest.java |   187 -
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   335 -
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   147 -
 ...sNewLineDelimiterRecordResolverSelfTest.java |   129 -
 ...fsStringDelimiterRecordResolverSelfTest.java |   137 -
 .../GridJobMetricsProcessorLoadTest.java        |    89 -
 .../port/GridPortProcessorSelfTest.java         |   129 -
 .../cache/GridCacheCommandHandlerSelfTest.java  |   264 -
 .../kernal/processors/service/DummyService.java |   148 -
 .../GridServiceProcessorAbstractSelfTest.java   |   677 -
 ...ServiceProcessorMultiNodeConfigSelfTest.java |   200 -
 .../GridServiceProcessorMultiNodeSelfTest.java  |   170 -
 .../GridServiceProcessorProxySelfTest.java      |   376 -
 .../GridServiceProcessorSingleNodeSelfTest.java |    58 -
 .../GridServiceReassignmentSelfTest.java        |   212 -
 .../streamer/GridStreamerEvictionSelfTest.java  |   164 -
 .../streamer/GridStreamerFailoverSelfTest.java  |   267 -
 .../GridStreamerLifecycleAwareSelfTest.java     |   212 -
 .../streamer/GridStreamerSelfTest.java          |   796 -
 .../processors/streamer/GridTestStage.java      |    54 -
 .../streamer/GridTestStreamerEventRouter.java   |    49 -
 .../grid/kernal/processors/streamer/SC.java     |    31 -
 .../timeout/GridTimeoutProcessorSelfTest.java   |   609 -
 .../org/gridgain/grid/kernal/updatestatus.html  |    28 -
 .../grid/lang/GridBasicPerformanceTest.java     |  1077 --
 .../grid/lang/GridByteArrayListSelfTest.java    |   213 -
 .../grid/lang/GridFuncPerformanceTest.java      |   101 -
 .../gridgain/grid/lang/GridFuncSelfTest.java    |  3255 ----
 .../lang/GridFutureListenPerformanceTest.java   |   112 -
 .../GridImmutableCollectionsPerfomanceTest.java |   120 -
 .../lang/GridMetadataAwareAdapterSelfTest.java  |   118 -
 .../grid/lang/GridSetWrapperSelfTest.java       |   224 -
 .../lang/GridSystemCurrentTimeMillisTest.java   |   107 -
 .../grid/lang/GridThreadPriorityTest.java       |    72 -
 .../gridgain/grid/lang/GridTupleSelfTest.java   |   165 -
 .../org/gridgain/grid/lang/GridXSelfTest.java   |   262 -
 .../gridgain/grid/lang/IgniteUuidSelfTest.java  |   326 -
 .../java/org/gridgain/grid/lang/package.html    |    23 -
 ...dBoundedConcurrentLinkedHashMapSelfTest.java |    55 -
 ...GridBoundedConcurrentOrderedMapSelfTest.java |    81 -
 .../GridCircularBufferPerformanceTest.java      |   226 -
 .../lang/utils/GridCircularBufferSelfTest.java  |   176 -
 .../utils/GridConcurrentHashMapSelfTest.java    |   109 -
 .../GridConcurrentLinkedHashMapSelfTest.java    |   246 -
 .../GridConcurrentWeakHashSetSelfTest.java      |   394 -
 .../lang/utils/GridConsistentHashSelfTest.java  |   332 -
 .../lang/utils/GridLeanMapPerformanceTest.java  |    84 -
 .../grid/lang/utils/GridLeanMapSelfTest.java    |   658 -
 .../grid/lang/utils/GridListSetSelfTest.java    |   286 -
 .../grid/lang/utils/GridPCollectionsTest.java   |    54 -
 .../lang/utils/GridStripedLockSelfTest.java     |   200 -
 .../grid/lang/utils/GridTrieMapSelfTest.java    |   242 -
 .../org/gridgain/grid/lang/utils/package.html   |    24 -
 .../grid/loadtest/GridLoadTestStatistics.java   |   210 -
 .../grid/loadtest/GridSingleExecutionTest.java  |   325 -
 .../org/gridgain/grid/loadtest/package.html     |    23 -
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |   247 -
 .../grid/logger/java/GridJavaLoggerTest.java    |    64 -
 .../org/gridgain/grid/logger/java/package.html  |    23 -
 .../marshaller/GridMarshallerAbstractTest.java  |  1041 --
 .../GridMarshallerExternalizableBean.java       |    63 -
 .../GridMarshallerPerformanceTest.java          |   514 -
 .../marshaller/GridMarshallerResourceBean.java  |   105 -
 .../GridMarshallerTestAbstractBean.java         |    40 -
 .../grid/marshaller/GridMarshallerTestBean.java |   148 -
 .../GridMarshallerTestInheritedBean.java        |    25 -
 .../jdk/GridJdkMarshallerSelfTest.java          |    35 -
 .../gridgain/grid/marshaller/jdk/package.html   |    23 -
 .../org/gridgain/grid/marshaller/package.html   |    23 -
 ...GridMessagingNoPeerClassLoadingSelfTest.java |    90 -
 .../grid/messaging/GridMessagingSelfTest.java   |  1088 --
 .../p2p/GridAbstractMultinodeRedeployTest.java  |   126 -
 ...MultinodeRedeployContinuousModeSelfTest.java |    37 -
 ...idMultinodeRedeployIsolatedModeSelfTest.java |    37 -
 ...ridMultinodeRedeployPrivateModeSelfTest.java |    37 -
 ...GridMultinodeRedeploySharedModeSelfTest.java |    37 -
 .../grid/p2p/GridP2PClassLoadingSelfTest.java   |   157 -
 .../GridP2PContinuousDeploymentSelfTest.java    |   118 -
 .../GridP2PDifferentClassLoaderSelfTest.java    |   221 -
 .../p2p/GridP2PDoubleDeploymentSelfTest.java    |   140 -
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |   232 -
 .../grid/p2p/GridP2PJobClassLoaderSelfTest.java |   141 -
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |   255 -
 .../GridP2PMissedResourceCacheSizeSelfTest.java |   293 -
 .../grid/p2p/GridP2PNodeLeftSelfTest.java       |   121 -
 .../grid/p2p/GridP2PRecursionTaskSelfTest.java  |   194 -
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |   283 -
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   164 -
 .../org/gridgain/grid/p2p/GridP2PTestJob.java   |   130 -
 .../org/gridgain/grid/p2p/GridP2PTestTask.java  |    83 -
 .../grid/p2p/GridP2PTestTaskExecutionTest.java  |    51 -
 .../grid/p2p/GridP2PTimeoutSelfTest.java        |   206 -
 .../grid/p2p/GridP2PUndeploySelfTest.java       |   237 -
 .../grid/p2p/GridSwapSpaceCustomKey.java        |    58 -
 .../grid/p2p/GridSwapSpaceCustomValue.java      |    64 -
 .../java/org/gridgain/grid/p2p/p2p.properties   |     1 -
 .../java/org/gridgain/grid/p2p/package.html     |    23 -
 .../test/java/org/gridgain/grid/package.html    |    23 -
 .../product/GridProductVersionSelfTest.java     |   111 -
 ...SessionCancelSiblingsFromFutureSelfTest.java |   281 -
 ...ridSessionCancelSiblingsFromJobSelfTest.java |   292 -
 ...idSessionCancelSiblingsFromTaskSelfTest.java |   299 -
 .../GridSessionCheckpointAbstractSelfTest.java  |   232 -
 .../session/GridSessionCheckpointSelfTest.java  |    96 -
 .../GridSessionCollisionSpiSelfTest.java        |   144 -
 ...idSessionFutureWaitJobAttributeSelfTest.java |   252 -
 ...dSessionFutureWaitTaskAttributeSelfTest.java |   251 -
 .../session/GridSessionJobFailoverSelfTest.java |   163 -
 ...GridSessionJobWaitTaskAttributeSelfTest.java |   221 -
 .../grid/session/GridSessionLoadSelfTest.java   |   265 -
 .../GridSessionSetFutureAttributeSelfTest.java  |   255 -
 ...nSetFutureAttributeWaitListenerSelfTest.java |   243 -
 .../GridSessionSetJobAttribute2SelfTest.java    |   135 -
 ...GridSessionSetJobAttributeOrderSelfTest.java |   154 -
 .../GridSessionSetJobAttributeSelfTest.java     |   210 -
 ...sionSetJobAttributeWaitListenerSelfTest.java |   245 -
 .../GridSessionSetTaskAttributeSelfTest.java    |   198 -
 ...GridSessionTaskWaitJobAttributeSelfTest.java |   191 -
 .../GridSessionWaitAttributeSelfTest.java       |   481 -
 .../grid/session/GridThreadSerialNumber.java    |    40 -
 .../java/org/gridgain/grid/session/package.html |    24 -
 .../grid/spi/GridSpiLocalHostInjectionTest.java |   156 -
 .../grid/spi/GridSpiStartStopAbstractTest.java  |    80 -
 .../org/gridgain/grid/spi/GridTcpForwarder.java |   169 -
 .../grid/spi/GridTcpSpiForwardingSelfTest.java  |   164 -
 .../java/org/gridgain/grid/spi/package.html     |    24 -
 .../startup/servlet/GridServletLoaderTest.java  |   171 -
 .../gridgain/grid/startup/servlet/package.html  |    23 -
 .../GridThreadPoolExecutorServiceSelfTest.java  |   188 -
 .../gridgain/grid/thread/GridThreadTest.java    |    53 -
 ...dConcurrentLinkedDequeMultiThreadedTest.java |   101 -
 .../util/GridConcurrentLinkedDequeSelfTest.java |   236 -
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |   551 -
 .../gridgain/grid/util/GridIndexFillTest.java   |   255 -
 .../gridgain/grid/util/GridLogThrottleTest.java |   123 -
 .../grid/util/GridLongListSelfTest.java         |   152 -
 .../gridgain/grid/util/GridQueueSelfTest.java   |    70 -
 .../gridgain/grid/util/GridRandomSelfTest.java  |    68 -
 .../grid/util/GridSnapshotLockSelfTest.java     |   112 -
 .../util/GridSpinReadWriteLockSelfTest.java     |   143 -
 ...artupWithSpecifiedWorkDirectorySelfTest.java |   163 -
 ...tartupWithUndefinedGridGainHomeSelfTest.java |   106 -
 .../util/GridStringBuilderFactorySelfTest.java  |    71 -
 .../gridgain/grid/util/GridTestClockTimer.java  |    39 -
 .../grid/util/GridTopologyHeapSizeSelfTest.java |   120 -
 .../gridgain/grid/util/GridTransientTest.java   |    68 -
 .../gridgain/grid/util/GridUtilsSelfTest.java   |   717 -
 .../util/future/GridCompoundFutureSelfTest.java |   204 -
 .../util/future/GridEmbeddedFutureSelfTest.java |   137 -
 .../util/future/GridFinishedFutureSelfTest.java |   104 -
 .../util/future/GridFutureAdapterSelfTest.java  |   441 -
 .../future/GridFutureListenPerformanceTest.java |   107 -
 .../grid/util/future/GridFutureQueueTest.java   |   183 -
 .../nio/GridNioEmbeddedFutureSelfTest.java      |    59 -
 .../util/future/nio/GridNioFutureSelfTest.java  |   210 -
 ...GridUnsafeDataOutputArraySizingSelfTest.java |   161 -
 ...idIpcServerEndpointDeserializerSelfTest.java |   160 -
 .../shmem/GridGgfsSharedMemoryTestClient.java   |    76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |    71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |   500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |    36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |    87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |   260 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |    84 -
 .../GridIpcSharedMemoryBenchmarkParty.java      |    35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |   133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |   125 -
 .../grid/util/mbeans/GridMBeanSelfTest.java     |   344 -
 .../gridgain/grid/util/nio/GridNioSelfTest.java |  1441 --
 .../util/nio/GridNioSessionMetaKeySelfTest.java |    58 -
 .../grid/util/nio/GridNioSslSelfTest.java       |    88 -
 .../grid/util/nio/GridRoundTripTest.java        |   226 -
 .../nio/impl/GridNioFilterChainSelfTest.java    |   390 -
 .../org/gridgain/grid/util/nio/package.html     |    23 -
 .../grid/util/offheap/GridByteArrayWrapper.java |    63 -
 .../offheap/GridOffHeapMapAbstractSelfTest.java |   812 -
 .../GridOffHeapMapPerformanceAbstractTest.java  |   289 -
 ...idOffHeapPartitionedMapAbstractSelfTest.java |  1133 --
 ...apPartitionedMapPerformanceAbstractTest.java |   429 -
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |   321 -
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 -
 .../offheap/unsafe/GridUnsafeMapSelfTest.java   |    30 -
 .../unsafe/GridUnsafeMemorySelfTest.java        |   542 -
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 -
 .../GridUnsafePartitionedMapSelfTest.java       |    30 -
 .../unsafe/GridUnsafeStripedLruSefTest.java     |   229 -
 .../java/org/gridgain/grid/util/package.html    |    24 -
 .../tostring/GridToStringBuilderSelfTest.java   |   205 -
 .../gridgain/grid/util/tostring/package.html    |    23 -
 .../org/gridgain/jvmtest/BlockingQueueTest.java |   144 -
 .../org/gridgain/jvmtest/ConcurrentMapTest.java |   193 -
 .../java/org/gridgain/jvmtest/FileIOTest.java   |   138 -
 .../org/gridgain/jvmtest/FileLocksTest.java     |   121 -
 .../org/gridgain/jvmtest/LinkedHashMapTest.java |    87 -
 .../gridgain/jvmtest/MultipleFileIOTest.java    |   134 -
 .../gridgain/jvmtest/NetworkFailureTest.java    |   370 -
 .../QueueSizeCounterMultiThreadedTest.java      |   102 -
 .../jvmtest/ReadWriteLockMultiThreadedTest.java |   207 -
 .../java/org/gridgain/jvmtest/RegExpTest.java   |    56 -
 .../jvmtest/ServerSocketMultiThreadedTest.java  |   102 -
 .../loadtests/GridCacheLoadPopulationTask.java  |   153 -
 .../loadtests/GridCacheMultiNodeLoadTest.java   |   106 -
 .../cache/GridCacheAbstractLoadTest.java        |   376 -
 ...ridCacheAffinityTransactionsOffHeapTest.java |   259 -
 .../loadtests/cache/GridCacheBenchmark.java     |   202 -
 .../cache/GridCacheDataStructuresLoadTest.java  |   365 -
 .../cache/GridCacheGroupLockComparisonTest.java |   203 -
 .../loadtests/cache/GridCacheLoadTest.java      |   162 -
 .../cache/GridCachePutRemoveLoadTest.java       |   374 -
 .../cache/GridCacheSingleNodeLoadTest.java      |   185 -
 .../loadtests/cache/GridCacheSwapLoadTest.java  |   311 -
 .../GridCacheWriteBehindStoreLoadTest.java      |   211 -
 .../capacity/GridCapacityLoadTest.java          |    95 -
 .../capacity/spring-capacity-cache.xml          |   124 -
 .../colocation/GridTestCacheStore.java          |   135 -
 .../loadtests/colocation/GridTestConstants.java |    35 -
 .../loadtests/colocation/GridTestKey.java       |    92 -
 .../colocation/GridTestLifecycleBean.java       |    42 -
 .../loadtests/colocation/GridTestMain.java      |   208 -
 .../loadtests/colocation/spring-colocation.xml  |   182 -
 .../communication/GridIoManagerBenchmark.java   |   338 -
 .../communication/GridIoManagerBenchmark0.java  |   470 -
 .../GridTcpCommunicationBenchmark.java          |   586 -
 .../communication/GridTestMessage.java          |   135 -
 .../GridContinuousOperationsLoadTest.java       |   212 -
 .../GridCachePartitionedAtomicLongLoadTest.java |   130 -
 .../direct/multisplit/GridLoadTestJob.java      |    59 -
 .../multisplit/GridLoadTestJobTarget.java       |    33 -
 .../direct/multisplit/GridLoadTestTask.java     |    84 -
 .../multisplit/GridMultiSplitsLoadTest.java     |   161 -
 .../GridMultiSplitsRedeployLoadTest.java        |   163 -
 .../loadtests/direct/multisplit/package.html    |    24 -
 .../GridSingleSplitNewNodesTestJobTarget.java   |    50 -
 .../GridSingleSplitNewNodesTestTask.java        |    95 -
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   188 -
 ...idSingleSplitsNewNodesMulticastLoadTest.java |    45 -
 .../loadtests/direct/newnodes/package.html      |    24 -
 .../GridSingleSplitsRedeployLoadTest.java       |   175 -
 .../loadtests/direct/redeploy/package.html      |    24 -
 .../direct/session/GridSessionLoadTest.java     |   112 -
 .../direct/session/GridSessionLoadTestJob.java  |    77 -
 .../direct/session/GridSessionLoadTestTask.java |   137 -
 .../loadtests/direct/session/package.html       |    24 -
 .../direct/stealing/GridStealingLoadTest.java   |   154 -
 .../stealing/GridStealingLoadTestJob.java       |    62 -
 .../stealing/GridStealingLoadTestTask.java      |    96 -
 .../loadtests/direct/stealing/package.html      |    24 -
 .../loadtests/discovery/GridGcTimeoutTest.java  |    64 -
 .../gridgain/loadtests/dsi/GridDsiClient.java   |   420 -
 .../loadtests/dsi/GridDsiLifecycleBean.java     |    59 -
 .../gridgain/loadtests/dsi/GridDsiMessage.java  |    74 -
 .../gridgain/loadtests/dsi/GridDsiPerfJob.java  |   341 -
 .../gridgain/loadtests/dsi/GridDsiRequest.java  |    93 -
 .../loadtests/dsi/GridDsiRequestTask.java       |    41 -
 .../gridgain/loadtests/dsi/GridDsiResponse.java |    87 -
 .../loadtests/dsi/GridDsiResponseTask.java      |    41 -
 .../gridgain/loadtests/dsi/GridDsiSession.java  |    84 -
 .../cacheget/GridBenchmarkCacheGetLoadTest.java |   119 -
 .../org/gridgain/loadtests/dsi/package.html     |    23 -
 ...dBoundedConcurrentLinkedHashSetLoadTest.java |   118 -
 .../loadtests/hashmap/GridCacheTestContext.java |    72 -
 .../loadtests/hashmap/GridHashMapLoadTest.java  |   100 -
 .../job/GridJobExecutionLoadTestClient.java     |   220 -
 ...GridJobExecutionLoadTestClientSemaphore.java |   240 -
 .../job/GridJobExecutionLoadTestJob.java        |    48 -
 .../job/GridJobExecutionLoadTestServer.java     |    40 -
 .../job/GridJobExecutionLoadTestTask.java       |    50 -
 .../job/GridJobExecutionSingleNodeLoadTest.java |   238 -
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |   227 -
 .../gridgain/loadtests/job/GridJobLoadTest.java |   201 -
 .../loadtests/job/GridJobLoadTestJob.java       |   163 -
 .../loadtests/job/GridJobLoadTestParams.java    |    84 -
 .../loadtests/job/GridJobLoadTestSubmitter.java |   143 -
 .../loadtests/job/GridJobLoadTestTask.java      |    73 -
 .../org/gridgain/loadtests/job/package.html     |    23 -
 .../GridConcurrentLinkedHashMapBenchmark.java   |   238 -
 .../mapper/GridContinuousMapperLoadTest1.java   |    51 -
 .../mapper/GridContinuousMapperLoadTest2.java   |    91 -
 .../mapper/GridContinuousMapperTask1.java       |   150 -
 .../mapper/GridContinuousMapperTask2.java       |    88 -
 .../loadtests/mapper/GridNodeStartup.java       |    56 -
 .../gridgain/loadtests/mapper/TestObject.java   |    58 -
 .../mergesort/GridMergeSortLoadTask.java        |   189 -
 .../mergesort/GridMergeSortLoadTest.java        |   144 -
 .../loadtests/nio/GridNioBenchmarkClient.java   |   167 -
 .../loadtests/nio/GridNioBenchmarkTest.java     |   120 -
 .../GridOffHeapMapPerformanceAbstractTest.java  |   290 -
 ...apPartitionedMapPerformanceAbstractTest.java |   430 -
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 -
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 -
 .../loadtests/streamer/EventClosure.java        |    61 -
 .../streamer/GridStreamerBenchmark.java         |   140 -
 .../streamer/GridStreamerIndexLoadTest.java     |   180 -
 .../loadtests/streamer/GridStreamerLoad.java    |    62 -
 .../loadtests/streamer/IndexUpdater.java        |    46 -
 .../loadtests/streamer/QueryClosure.java        |   107 -
 .../loadtests/streamer/average/TestAverage.java |    70 -
 .../loadtests/streamer/average/TestStage.java   |    65 -
 .../swap/GridSwapEvictAllBenchmark.java         |   300 -
 .../loadtests/util/GridCumulativeAverage.java   |    63 -
 .../loadtests/util/GridLoadTestArgs.java        |   283 -
 .../startup/GridRandomCommandLineLoader.java    |   401 -
 .../gridgain/startup/GridVmNodesStarter.java    |   271 -
 .../test/java/org/gridgain/startup/package.html |    23 -
 .../gridgain/testframework/GridFileLock.java    |   110 -
 .../testframework/GridJarClassLoader.java       |   178 -
 .../testframework/GridLoadTestUtils.java        |   153 -
 .../testframework/GridSpiTestContext.java       |   563 -
 .../testframework/GridStringLogger.java         |   167 -
 .../testframework/GridTestClassLoader.java      |   110 -
 .../GridTestExternalClassLoader.java            |   194 -
 .../gridgain/testframework/GridTestNode.java    |   254 -
 .../GridTestSafeThreadFactory.java              |   214 -
 .../gridgain/testframework/GridTestThread.java  |   147 -
 .../gridgain/testframework/GridTestUtils.java   |  1439 --
 .../config/GridTestProperties.java              |   304 -
 .../gridgain/testframework/config/package.html  |    23 -
 .../http/GridEmbeddedHttpServer.java            |   189 -
 .../gridgain/testframework/http/package.html    |    23 -
 .../testframework/junits/GridAbstractTest.java  |  1434 --
 .../testframework/junits/GridTestIgnite.java    |   224 -
 .../junits/GridTestKernalContext.java           |    85 -
 .../testframework/junits/GridTestResources.java |   255 -
 .../cache/GridAbstractCacheStoreSelfTest.java   |   563 -
 .../junits/cache/TestCacheSession.java          |    65 -
 .../cache/TestThreadLocalCacheSession.java      |    65 -
 .../junits/common/GridAbstractExamplesTest.java |    79 -
 .../GridAbstractLifecycleAwareSelfTest.java     |   127 -
 .../junits/common/GridCommonAbstractTest.java   |   677 -
 .../junits/common/GridCommonTest.java           |    36 -
 .../testframework/junits/common/package.html    |    23 -
 .../logger/GridLog4jRollingFileAppender.java    |   114 -
 .../junits/logger/GridTestLog4jLogger.java      |   514 -
 .../gridgain/testframework/junits/package.html  |    24 -
 .../junits/spi/GridSpiAbstractConfigTest.java   |   110 -
 .../junits/spi/GridSpiAbstractTest.java         |   692 -
 .../testframework/junits/spi/GridSpiTest.java   |    62 -
 .../junits/spi/GridSpiTestConfig.java           |    48 -
 .../testframework/junits/spi/package.html       |    23 -
 .../org/gridgain/testframework/package.html     |    23 -
 .../GridCacheDataStructuresSelfTestSuite.java   |    99 -
 .../GridCacheEvictionSelfTestSuite.java         |    62 -
 .../GridCacheFullApiSelfTestSuite.java          |   119 -
 .../GridCacheGroupLockSelfTestSuite.java        |    48 -
 .../GridCacheIteratorsSelfTestSuite.java        |    42 -
 .../GridCacheMetricsSelfTestSuite.java          |    49 -
 .../GridCacheNearOnlySelfTestSuite.java         |    45 -
 .../GridCacheTxRecoverySelfTestSuite.java       |    46 -
 .../GridCacheWriteBehindTestSuite.java          |    45 -
 .../GridContinuousTaskSelfTestSuite.java        |    42 -
 .../GridExternalizableSelfTestSuite.java        |    37 -
 .../GridIpcSharedMemorySelfTestSuite.java       |    40 -
 .../testsuites/GridJobMetricsSelfTestSuite.java |    38 -
 .../testsuites/GridKernalSelfTestSuite.java     |    80 -
 .../testsuites/GridLangSelfTestSuite.java       |    71 -
 .../testsuites/GridLoadersSelfTestSuite.java    |    38 -
 .../testsuites/GridLoggingSelfTestSuite.java    |    38 -
 .../testsuites/GridMarshallerSelfTestSuite.java |    45 -
 .../testsuites/GridP2PSelfTestSuite.java        |    54 -
 .../testsuites/GridRichSelfTestSuite.java       |    42 -
 .../GridSpiCheckpointSelfTestSuite.java         |    56 -
 .../GridSpiCollisionSelfTestSuite.java          |    55 -
 .../GridSpiCommunicationSelfTestSuite.java      |    52 -
 .../GridSpiDeploymentSelfTestSuite.java         |    40 -
 .../GridSpiDiscoverySelfTestSuite.java          |    56 -
 .../GridSpiEventStorageSelfTestSuite.java       |    41 -
 .../GridSpiFailoverSelfTestSuite.java           |    53 -
 .../GridSpiIndexingSelfTestSuite.java           |    38 -
 .../GridSpiLoadBalancingSelfTestSuite.java      |    64 -
 .../GridSpiSwapSpaceSelfTestSuite.java          |    41 -
 .../testsuites/GridStreamerSelfTestSuite.java   |    46 -
 .../GridTaskSessionSelfTestSuite.java           |    56 -
 .../GridTimeoutProcessorSelfTestSuite.java      |    38 -
 .../testsuites/GridUtilSelfTestSuite.java       |    71 -
 .../testsuites/bamboo/GridBasicTestSuite.java   |    77 -
 .../bamboo/GridCacheFailoverTestSuite.java      |    57 -
 .../bamboo/GridComputeGridTestSuite.java        |   100 -
 .../bamboo/GridDataGridRestartTestSuite.java    |    49 -
 .../bamboo/GridDataGridTestSuite.java           |   375 -
 .../testsuites/bamboo/GridGgfsTestSuite.java    |    79 -
 .../bamboo/GridRestHandlerTestSuite.java        |    38 -
 .../testsuites/bamboo/GridSpiTestSuite.java     |    70 -
 .../org/gridgain/testsuites/bamboo/package.html |    23 -
 .../java/org/gridgain/testsuites/package.html   |    24 -
 .../core/src/test/webapp/META-INF/gg-config.xml |     8 +-
 modules/core/src/test/webapp/WEB-INF/web.xml    |     4 +-
 .../processors/email/IgniteEmailProcessor.java  |   297 +
 .../processors/email/GridEmailProcessor.java    |   297 -
 modules/extdata/p2p/META-INF/gridgain.xml       |     6 +-
 modules/extdata/p2p/pom.xml                     |     2 +-
 .../ignite/tests/p2p/ExcludeNodeFilter.java     |    52 +
 .../tests/p2p/GridCacheDeploymentTestKey.java   |    63 +
 .../tests/p2p/GridCacheDeploymentTestTask1.java |    65 +
 .../tests/p2p/GridCacheDeploymentTestTask2.java |    56 +
 .../tests/p2p/GridCacheDeploymentTestTask3.java |    61 +
 .../tests/p2p/GridCacheDeploymentTestValue.java |    26 +
 .../p2p/GridCacheDeploymentTestValue2.java      |    24 +
 .../p2p/GridCacheDeploymentTestValue3.java      |    42 +
 .../tests/p2p/GridEventConsumeFilter.java       |    31 +
 .../GridEventConsumeProjectionPredicate.java    |    31 +
 .../tests/p2p/GridExternalAffinityFunction.java |   161 +
 .../p2p/GridExternalAffinityKeyMapper.java      |    38 +
 .../tests/p2p/GridP2PAwareTestUserResource.java |    64 +
 .../p2p/GridP2PContinuousDeploymentTask1.java   |    52 +
 .../p2p/GridP2PContinuousDeploymentTask2.java   |    46 +
 .../p2p/GridP2PEventFilterExternalPath1.java    |    49 +
 .../p2p/GridP2PEventFilterExternalPath2.java    |    49 +
 .../tests/p2p/GridP2PTestTaskExternalPath2.java |   137 +
 .../tests/p2p/GridSingleSplitTestJobTarget.java |    34 +
 .../tests/p2p/GridSingleSplitTestTask.java      |    76 +
 .../tests/p2p/GridTestMessageListener.java      |    56 +
 .../ignite/tests/p2p/GridTestMessageTopic.java  |    35 +
 .../ignite/tests/p2p/JobStealingTask.java       |   119 +
 .../tests/p2p/P2PTestTaskExternalPath1.java     |   144 +
 .../ignite/tests/p2p/TestUserResource.java      |    27 +
 .../org/apache/ignite/tests/p2p/package.html    |    23 +
 .../tests/p2p/GridCacheDeploymentTestKey.java   |    63 -
 .../tests/p2p/GridCacheDeploymentTestTask1.java |    66 -
 .../tests/p2p/GridCacheDeploymentTestTask2.java |    57 -
 .../tests/p2p/GridCacheDeploymentTestTask3.java |    62 -
 .../tests/p2p/GridCacheDeploymentTestValue.java |    26 -
 .../p2p/GridCacheDeploymentTestValue2.java      |    24 -
 .../p2p/GridCacheDeploymentTestValue3.java      |    42 -
 .../grid/tests/p2p/GridEventConsumeFilter.java  |    31 -
 .../GridEventConsumeProjectionPredicate.java    |    31 -
 .../grid/tests/p2p/GridExcludeNodeFilter.java   |    52 -
 .../tests/p2p/GridExternalAffinityFunction.java |   161 -
 .../p2p/GridExternalAffinityKeyMapper.java      |    38 -
 .../tests/p2p/GridP2PAwareTestUserResource.java |    64 -
 .../p2p/GridP2PContinuousDeploymentTask1.java   |    53 -
 .../p2p/GridP2PContinuousDeploymentTask2.java   |    47 -
 .../p2p/GridP2PEventFilterExternalPath1.java    |    50 -
 .../p2p/GridP2PEventFilterExternalPath2.java    |    50 -
 .../tests/p2p/GridP2PTestTaskExternalPath1.java |   144 -
 .../tests/p2p/GridP2PTestTaskExternalPath2.java |   137 -
 .../tests/p2p/GridSingleSplitTestJobTarget.java |    34 -
 .../grid/tests/p2p/GridSingleSplitTestTask.java |    77 -
 .../grid/tests/p2p/GridTestMessageListener.java |    56 -
 .../grid/tests/p2p/GridTestMessageTopic.java    |    35 -
 .../grid/tests/p2p/GridTestUserResource.java    |    27 -
 .../grid/tests/p2p/JobStealingTask.java         |   120 -
 .../org/gridgain/grid/tests/p2p/package.html    |    23 -
 modules/extdata/uri/pom.xml                     |     2 +-
 .../GridUriDeploymentAbstractTestTask.java      |     1 -
 .../uri/tasks/GridUriDeploymentDependency1.java |     2 +-
 .../uri/tasks/GridUriDeploymentDependency2.java |     2 +-
 .../tasks/GridUriDeploymentInnerTestTask.java   |     1 -
 .../GridUriDeploymentNonePublicTestTask.java    |     1 -
 .../uri/tasks/GridUriDeploymentTestTask0.java   |     1 -
 .../uri/tasks/GridUriDeploymentTestTask1.java   |     1 -
 .../uri/tasks/GridUriDeploymentTestTask2.java   |     1 -
 .../uri/tasks/GridUriDeploymentTestTask3.java   |     1 -
 .../uri/tasks/GridUriDeploymentTestTask4.java   |     1 -
 .../uri/tasks/GridUriDeploymentTestTask5.java   |     1 -
 .../uri/tasks/GridUriDeploymentTestTask6.java   |     1 -
 .../GridUriDeploymentTestWithNameTask0.java     |     1 -
 .../GridUriDeploymentTestWithNameTask3.java     |     1 -
 .../GridUriDeploymentTestWithNameTask4.java     |     1 -
 .../GridUriDeploymentTestWithNameTask5.java     |     1 -
 .../GridUriDeploymentTestWithNameTask6.java     |     1 -
 .../GridUriDeploymentTestWithNameTask7.java     |     1 -
 .../java/org/apache/ignite/test/test.properties |    23 +
 .../main/java/org/gridgain/test/test.properties |    23 -
 .../client/hadoop/GridHadoopClientProtocol.java |   333 +
 .../GridHadoopClientProtocolProvider.java       |   137 +
 .../counter/GridHadoopClientCounterGroup.java   |   121 +
 .../counter/GridHadoopClientCounters.java       |   217 +
 .../apache/ignite/client/hadoop/package.html    |    23 +
 .../fs/hadoop/GridGgfsHadoopParameters.java     |    94 +
 .../org/apache/ignite/fs/hadoop/package.html    |    23 +
 .../fs/hadoop/v1/GridGgfsHadoopFileSystem.java  |  1253 ++
 .../org/apache/ignite/fs/hadoop/v1/package.html |    23 +
 .../fs/hadoop/v2/GridGgfsHadoopFileSystem.java  |  1007 ++
 .../org/apache/ignite/fs/hadoop/v2/package.html |    23 +
 .../main/java/org/apache/ignite/fs/package.html |    23 +
 .../ignite/hadoop/GridHadoopDefaultJobInfo.java |   163 +
 .../apache/ignite/hadoop/GridHadoopSetup.java   |   506 +
 .../internal/fs/hadoop/GridGgfsHadoop.java      |   198 +
 .../GridGgfsHadoopCommunicationException.java   |    57 +
 .../fs/hadoop/GridGgfsHadoopEndpoint.java       |   210 +
 .../internal/fs/hadoop/GridGgfsHadoopEx.java    |    88 +
 .../fs/hadoop/GridGgfsHadoopFSProperties.java   |    88 +
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |   413 +
 .../fs/hadoop/GridGgfsHadoopFuture.java         |    94 +
 .../fs/hadoop/GridGgfsHadoopInProc.java         |   366 +
 .../fs/hadoop/GridGgfsHadoopInputStream.java    |   626 +
 .../internal/fs/hadoop/GridGgfsHadoopIo.java    |    76 +
 .../internal/fs/hadoop/GridGgfsHadoopIpcIo.java |   599 +
 .../fs/hadoop/GridGgfsHadoopIpcIoListener.java  |    36 +
 .../fs/hadoop/GridGgfsHadoopJclLogger.java      |   115 +
 .../fs/hadoop/GridGgfsHadoopOutProc.java        |   466 +
 .../fs/hadoop/GridGgfsHadoopOutputStream.java   |   201 +
 .../hadoop/GridGgfsHadoopProxyInputStream.java  |   335 +
 .../hadoop/GridGgfsHadoopProxyOutputStream.java |   165 +
 .../fs/hadoop/GridGgfsHadoopReader.java         |   103 +
 .../fs/hadoop/GridGgfsHadoopStreamDelegate.java |    96 +
 .../GridGgfsHadoopStreamEventListener.java      |    39 +
 .../internal/fs/hadoop/GridGgfsHadoopUtils.java |   131 +
 .../fs/hadoop/GridGgfsHadoopWrapper.java        |   511 +
 .../ignite/internal/fs/hadoop/package.html      |    23 +
 .../org/apache/ignite/internal/fs/package.html  |    23 +
 .../hadoop/GridHadoopClassLoader.java           |   552 +
 .../processors/hadoop/GridHadoopComponent.java  |    61 +
 .../processors/hadoop/GridHadoopContext.java    |   197 +
 .../processors/hadoop/GridHadoopImpl.java       |   133 +
 .../GridHadoopTaskCancelledException.java       |    35 +
 .../processors/hadoop/GridHadoopUtils.java      |   306 +
 .../hadoop/IgniteHadoopProcessor.java           |   227 +
 .../counter/GridHadoopCounterAdapter.java       |   128 +
 .../hadoop/counter/GridHadoopCountersImpl.java  |   198 +
 .../counter/GridHadoopFSCounterWriter.java      |    90 +
 .../hadoop/counter/GridHadoopLongCounter.java   |    91 +
 .../counter/GridHadoopPerformanceCounter.java   |   279 +
 .../fs/GridHadoopDistributedFileSystem.java     |    91 +
 .../hadoop/fs/GridHadoopFileSystemsUtils.java   |    57 +
 .../hadoop/fs/GridHadoopLocalFileSystemV1.java  |    39 +
 .../hadoop/fs/GridHadoopLocalFileSystemV2.java  |    86 +
 .../hadoop/fs/GridHadoopRawLocalFileSystem.java |   304 +
 .../jobtracker/GridHadoopJobMetadata.java       |   305 +
 .../hadoop/jobtracker/GridHadoopJobTracker.java |  1627 ++
 .../hadoop/message/GridHadoopMessage.java       |    27 +
 .../planner/GridHadoopDefaultMapReducePlan.java |   107 +
 .../GridHadoopDefaultMapReducePlanner.java      |   429 +
 .../GridHadoopProtocolJobCountersTask.java      |    45 +
 .../proto/GridHadoopProtocolJobStatusTask.java  |    80 +
 .../proto/GridHadoopProtocolKillJobTask.java    |    46 +
 .../proto/GridHadoopProtocolNextTaskIdTask.java |    36 +
 .../proto/GridHadoopProtocolSubmitJobTask.java  |    57 +
 .../proto/GridHadoopProtocolTaskAdapter.java    |   105 +
 .../proto/GridHadoopProtocolTaskArguments.java  |    81 +
 .../hadoop/shuffle/GridHadoopShuffle.java       |   257 +
 .../hadoop/shuffle/GridHadoopShuffleAck.java    |    91 +
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |   592 +
 .../shuffle/GridHadoopShuffleMessage.java       |   241 +
 .../GridHadoopConcurrentHashMultimap.java       |   611 +
 .../collections/GridHadoopHashMultimap.java     |   174 +
 .../collections/GridHadoopHashMultimapBase.java |   208 +
 .../shuffle/collections/GridHadoopMultimap.java |   112 +
 .../collections/GridHadoopMultimapBase.java     |   368 +
 .../shuffle/collections/GridHadoopSkipList.java |   726 +
 .../shuffle/streams/GridHadoopDataInStream.java |   170 +
 .../streams/GridHadoopDataOutStream.java        |   131 +
 .../streams/GridHadoopOffheapBuffer.java        |   122 +
 .../GridHadoopEmbeddedTaskExecutor.java         |   146 +
 .../taskexecutor/GridHadoopExecutorService.java |   231 +
 .../taskexecutor/GridHadoopRunnableTask.java    |   269 +
 .../GridHadoopTaskExecutorAdapter.java          |    58 +
 .../taskexecutor/GridHadoopTaskState.java       |    38 +
 .../taskexecutor/GridHadoopTaskStatus.java      |   114 +
 .../GridHadoopExternalTaskExecutor.java         |   961 ++
 .../GridHadoopExternalTaskMetadata.java         |    68 +
 .../GridHadoopJobInfoUpdateRequest.java         |   109 +
 .../GridHadoopPrepareForJobRequest.java         |   126 +
 .../external/GridHadoopProcessDescriptor.java   |   150 +
 .../external/GridHadoopProcessStartedAck.java   |    46 +
 .../GridHadoopTaskExecutionRequest.java         |   110 +
 .../external/GridHadoopTaskFinishedMessage.java |    92 +
 .../child/GridHadoopChildProcessRunner.java     |   440 +
 .../child/GridHadoopExternalProcessStarter.java |   296 +
 .../GridHadoopAbstractCommunicationClient.java  |    96 +
 .../GridHadoopCommunicationClient.java          |    72 +
 .../GridHadoopExternalCommunication.java        |  1420 ++
 .../GridHadoopHandshakeTimeoutException.java    |    42 +
 .../GridHadoopIpcToNioAdapter.java              |   239 +
 .../GridHadoopMarshallerFilter.java             |    84 +
 .../GridHadoopMessageListener.java              |    39 +
 .../GridHadoopTcpNioCommunicationClient.java    |    99 +
 .../hadoop/v1/GridHadoopV1CleanupTask.java      |    62 +
 .../hadoop/v1/GridHadoopV1Counter.java          |   105 +
 .../hadoop/v1/GridHadoopV1MapTask.java          |   108 +
 .../hadoop/v1/GridHadoopV1OutputCollector.java  |   133 +
 .../hadoop/v1/GridHadoopV1Partitioner.java      |    44 +
 .../hadoop/v1/GridHadoopV1ReduceTask.java       |    93 +
 .../hadoop/v1/GridHadoopV1Reporter.java         |    79 +
 .../hadoop/v1/GridHadoopV1SetupTask.java        |    56 +
 .../hadoop/v1/GridHadoopV1Splitter.java         |    98 +
 .../processors/hadoop/v1/GridHadoopV1Task.java  |    97 +
 .../hadoop/v2/GridHadoopExternalSplit.java      |    87 +
 .../hadoop/v2/GridHadoopNativeCodeLoader.java   |    74 +
 .../v2/GridHadoopSerializationWrapper.java      |   133 +
 .../v2/GridHadoopShutdownHookManager.java       |    96 +
 .../hadoop/v2/GridHadoopSplitWrapper.java       |   119 +
 .../hadoop/v2/GridHadoopV2CleanupTask.java      |    70 +
 .../hadoop/v2/GridHadoopV2Context.java          |   231 +
 .../hadoop/v2/GridHadoopV2Counter.java          |    87 +
 .../processors/hadoop/v2/GridHadoopV2Job.java   |   281 +
 .../v2/GridHadoopV2JobResourceManager.java      |   304 +
 .../hadoop/v2/GridHadoopV2MapTask.java          |   104 +
 .../hadoop/v2/GridHadoopV2Partitioner.java      |    44 +
 .../hadoop/v2/GridHadoopV2ReduceTask.java       |    86 +
 .../hadoop/v2/GridHadoopV2SetupTask.java        |    64 +
 .../hadoop/v2/GridHadoopV2Splitter.java         |   105 +
 .../processors/hadoop/v2/GridHadoopV2Task.java  |   181 +
 .../hadoop/v2/GridHadoopV2TaskContext.java      |   444 +
 .../v2/GridHadoopWritableSerialization.java     |    74 +
 .../client/hadoop/GridHadoopClientProtocol.java |   334 -
 .../GridHadoopClientProtocolProvider.java       |   138 -
 .../counter/GridHadoopClientCounterGroup.java   |   121 -
 .../counter/GridHadoopClientCounters.java       |   217 -
 .../org/gridgain/client/hadoop/package.html     |    23 -
 .../ggfs/hadoop/GridGgfsHadoopParameters.java   |    94 -
 .../org/gridgain/grid/ggfs/hadoop/package.html  |    23 -
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |  1254 --
 .../gridgain/grid/ggfs/hadoop/v1/package.html   |    23 -
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |  1008 --
 .../gridgain/grid/ggfs/hadoop/v2/package.html   |    23 -
 .../java/org/gridgain/grid/ggfs/package.html    |    23 -
 .../grid/hadoop/GridHadoopDefaultJobInfo.java   |   164 -
 .../gridgain/grid/hadoop/GridHadoopSetup.java   |   506 -
 .../grid/kernal/ggfs/hadoop/GridGgfsHadoop.java |   199 -
 .../GridGgfsHadoopCommunicationException.java   |    60 -
 .../ggfs/hadoop/GridGgfsHadoopEndpoint.java     |   211 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopEx.java    |    88 -
 .../ggfs/hadoop/GridGgfsHadoopFSProperties.java |    89 -
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |   414 -
 .../ggfs/hadoop/GridGgfsHadoopFuture.java       |    94 -
 .../ggfs/hadoop/GridGgfsHadoopInProc.java       |   367 -
 .../ggfs/hadoop/GridGgfsHadoopInputStream.java  |   627 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopIo.java    |    77 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopIpcIo.java |   600 -
 .../hadoop/GridGgfsHadoopIpcIoListener.java     |    36 -
 .../ggfs/hadoop/GridGgfsHadoopJclLogger.java    |   115 -
 .../ggfs/hadoop/GridGgfsHadoopOutProc.java      |   467 -
 .../ggfs/hadoop/GridGgfsHadoopOutputStream.java |   202 -
 .../hadoop/GridGgfsHadoopProxyInputStream.java  |   335 -
 .../hadoop/GridGgfsHadoopProxyOutputStream.java |   165 -
 .../ggfs/hadoop/GridGgfsHadoopReader.java       |   103 -
 .../hadoop/GridGgfsHadoopStreamDelegate.java    |    96 -
 .../GridGgfsHadoopStreamEventListener.java      |    40 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopUtils.java |   132 -
 .../ggfs/hadoop/GridGgfsHadoopWrapper.java      |   512 -
 .../grid/kernal/ggfs/hadoop/package.html        |    23 -
 .../org/gridgain/grid/kernal/ggfs/package.html  |    23 -
 .../hadoop/GridHadoopClassLoader.java           |   553 -
 .../processors/hadoop/GridHadoopComponent.java  |    62 -
 .../processors/hadoop/GridHadoopContext.java    |   197 -
 .../processors/hadoop/GridHadoopImpl.java       |   134 -
 .../processors/hadoop/GridHadoopProcessor.java  |   228 -
 .../GridHadoopTaskCancelledException.java       |    36 -
 .../processors/hadoop/GridHadoopUtils.java      |   307 -
 .../counter/GridHadoopCounterAdapter.java       |   128 -
 .../hadoop/counter/GridHadoopCountersImpl.java  |   199 -
 .../counter/GridHadoopFSCounterWriter.java      |    91 -
 .../hadoop/counter/GridHadoopLongCounter.java   |    91 -
 .../counter/GridHadoopPerformanceCounter.java   |   279 -
 .../fs/GridHadoopDistributedFileSystem.java     |    91 -
 .../hadoop/fs/GridHadoopFileSystemsUtils.java   |    57 -
 .../hadoop/fs/GridHadoopLocalFileSystemV1.java  |    39 -
 .../hadoop/fs/GridHadoopLocalFileSystemV2.java  |    86 -
 .../hadoop/fs/GridHadoopRawLocalFileSystem.java |   304 -
 .../jobtracker/GridHadoopJobMetadata.java       |   305 -
 .../hadoop/jobtracker/GridHadoopJobTracker.java |  1627 --
 .../hadoop/message/GridHadoopMessage.java       |    27 -
 .../planner/GridHadoopDefaultMapReducePlan.java |   107 -
 .../GridHadoopDefaultMapReducePlanner.java      |   430 -
 .../GridHadoopProtocolJobCountersTask.java      |    46 -
 .../proto/GridHadoopProtocolJobStatusTask.java  |    81 -
 .../proto/GridHadoopProtocolKillJobTask.java    |    47 -
 .../proto/GridHadoopProtocolNextTaskIdTask.java |    37 -
 .../proto/GridHadoopProtocolSubmitJobTask.java  |    58 -
 .../proto/GridHadoopProtocolTaskAdapter.java    |   106 -
 .../proto/GridHadoopProtocolTaskArguments.java  |    81 -
 .../hadoop/shuffle/GridHadoopShuffle.java       |   258 -
 .../hadoop/shuffle/GridHadoopShuffleAck.java    |    91 -
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |   593 -
 .../shuffle/GridHadoopShuffleMessage.java       |   242 -
 .../GridHadoopConcurrentHashMultimap.java       |   612 -
 .../collections/GridHadoopHashMultimap.java     |   175 -
 .../collections/GridHadoopHashMultimapBase.java |   209 -
 .../shuffle/collections/GridHadoopMultimap.java |   113 -
 .../collections/GridHadoopMultimapBase.java     |   369 -
 .../shuffle/collections/GridHadoopSkipList.java |   727 -
 .../shuffle/streams/GridHadoopDataInStream.java |   170 -
 .../streams/GridHadoopDataOutStream.java        |   131 -
 .../streams/GridHadoopOffheapBuffer.java        |   122 -
 .../GridHadoopEmbeddedTaskExecutor.java         |   147 -
 .../taskexecutor/GridHadoopExecutorService.java |   232 -
 .../taskexecutor/GridHadoopRunnableTask.java    |   270 -
 .../GridHadoopTaskExecutorAdapter.java          |    59 -
 .../taskexecutor/GridHadoopTaskState.java       |    38 -
 .../taskexecutor/GridHadoopTaskStatus.java      |   114 -
 .../GridHadoopExternalTaskExecutor.java         |   962 --
 .../GridHadoopExternalTaskMetadata.java         |    68 -
 .../GridHadoopJobInfoUpdateRequest.java         |   109 -
 .../GridHadoopPrepareForJobRequest.java         |   126 -
 .../external/GridHadoopProcessDescriptor.java   |   150 -
 .../external/GridHadoopProcessStartedAck.java   |    46 -
 .../GridHadoopTaskExecutionRequest.java         |   110 -
 .../external/GridHadoopTaskFinishedMessage.java |    92 -
 .../child/GridHadoopChildProcessRunner.java     |   441 -
 .../child/GridHadoopExternalProcessStarter.java |   297 -
 .../GridHadoopAbstractCommunicationClient.java  |    96 -
 .../GridHadoopCommunicationClient.java          |    73 -
 .../GridHadoopExternalCommunication.java        |  1421 --
 .../GridHadoopHandshakeTimeoutException.java    |    43 -
 .../GridHadoopIpcToNioAdapter.java              |   240 -
 .../GridHadoopMarshallerFilter.java             |    85 -
 .../GridHadoopMessageListener.java              |    39 -
 .../GridHadoopTcpNioCommunicationClient.java    |   100 -
 .../hadoop/v1/GridHadoopV1CleanupTask.java      |    63 -
 .../hadoop/v1/GridHadoopV1Counter.java          |   105 -
 .../hadoop/v1/GridHadoopV1MapTask.java          |   109 -
 .../hadoop/v1/GridHadoopV1OutputCollector.java  |   134 -
 .../hadoop/v1/GridHadoopV1Partitioner.java      |    44 -
 .../hadoop/v1/GridHadoopV1ReduceTask.java       |    94 -
 .../hadoop/v1/GridHadoopV1Reporter.java         |    79 -
 .../hadoop/v1/GridHadoopV1SetupTask.java        |    57 -
 .../hadoop/v1/GridHadoopV1Splitter.java         |    99 -
 .../processors/hadoop/v1/GridHadoopV1Task.java  |    97 -
 .../hadoop/v2/GridHadoopExternalSplit.java      |    87 -
 .../hadoop/v2/GridHadoopNativeCodeLoader.java   |    74 -
 .../v2/GridHadoopSerializationWrapper.java      |   134 -
 .../v2/GridHadoopShutdownHookManager.java       |    96 -
 .../hadoop/v2/GridHadoopSplitWrapper.java       |   119 -
 .../hadoop/v2/GridHadoopV2CleanupTask.java      |    71 -
 .../hadoop/v2/GridHadoopV2Context.java          |   232 -
 .../hadoop/v2/GridHadoopV2Counter.java          |    87 -
 .../processors/hadoop/v2/GridHadoopV2Job.java   |   282 -
 .../v2/GridHadoopV2JobResourceManager.java      |   304 -
 .../hadoop/v2/GridHadoopV2MapTask.java          |   105 -
 .../hadoop/v2/GridHadoopV2Partitioner.java      |    44 -
 .../hadoop/v2/GridHadoopV2ReduceTask.java       |    87 -
 .../hadoop/v2/GridHadoopV2SetupTask.java        |    65 -
 .../hadoop/v2/GridHadoopV2Splitter.java         |   106 -
 .../processors/hadoop/v2/GridHadoopV2Task.java  |   182 -
 .../hadoop/v2/GridHadoopV2TaskContext.java      |   444 -
 .../v2/GridHadoopWritableSerialization.java     |    75 -
 ...op.mapreduce.protocol.ClientProtocolProvider |     2 +-
 ...ridHadoopClientProtocolEmbeddedSelfTest.java |    34 +
 .../GridHadoopClientProtocolSelfTest.java       |   633 +
 .../apache/ignite/fs/GridFileSystemLoad.java    |   548 +
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |  1967 +++
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    74 +
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    74 +
 .../fs/GridGgfsHadoopDualAbstractSelfTest.java  |   303 +
 .../fs/GridGgfsHadoopDualAsyncSelfTest.java     |    32 +
 .../fs/GridGgfsHadoopDualSyncSelfTest.java      |    32 +
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |  2365 +++
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   200 +
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   311 +
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   207 +
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   288 +
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   325 +
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    46 +
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |    33 +
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |    33 +
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |    33 +
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |    34 +
 ...SystemLoopbackExternalDualAsyncSelfTest.java |    33 +
 ...eSystemLoopbackExternalDualSyncSelfTest.java |    33 +
 ...leSystemLoopbackExternalPrimarySelfTest.java |    33 +
 ...SystemLoopbackExternalSecondarySelfTest.java |    34 +
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   319 +
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    88 +
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 +
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 +
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 +
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 +
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    33 +
 ...FileSystemShmemExternalDualSyncSelfTest.java |    33 +
 ...pFileSystemShmemExternalPrimarySelfTest.java |    33 +
 ...ileSystemShmemExternalSecondarySelfTest.java |    33 +
 .../fs/GridGgfsNearOnlyMultiNodeSelfTest.java   |   212 +
 .../ignite/fs/IgniteFsEventsTestSuite.java      |   267 +
 .../hadoop/GridHadoopPopularWordsTest.java      |   294 +
 .../ignite/hadoop/GridHadoopTestUtils.java      |   102 +
 .../ignite/hadoop/books/alice-in-wonderland.txt |  3735 +++++
 .../apache/ignite/hadoop/books/art-of-war.txt   |  6982 +++++++++
 .../ignite/hadoop/books/huckleberry-finn.txt    | 11733 +++++++++++++++
 .../ignite/hadoop/books/sherlock-holmes.txt     | 13052 +++++++++++++++++
 .../apache/ignite/hadoop/books/tom-sawyer.txt   |  8858 +++++++++++
 .../hadoop/GridHadoopAbstractSelfTest.java      |   210 +
 .../hadoop/GridHadoopAbstractWordCountTest.java |   138 +
 .../hadoop/GridHadoopClassLoaderTest.java       |    69 +
 .../hadoop/GridHadoopCommandLineTest.java       |   441 +
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  1222 ++
 .../hadoop/GridHadoopFileSystemsTest.java       |   176 +
 .../hadoop/GridHadoopGroupingTest.java          |   287 +
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |   332 +
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |   246 +
 .../hadoop/GridHadoopMapReduceTest.java         |   201 +
 .../GridHadoopSerializationWrapperSelfTest.java |    75 +
 .../processors/hadoop/GridHadoopSharedMap.java  |    67 +
 .../hadoop/GridHadoopSortingExternalTest.java   |    34 +
 .../hadoop/GridHadoopSortingTest.java           |   283 +
 .../hadoop/GridHadoopSplitWrapperSelfTest.java  |    68 +
 .../processors/hadoop/GridHadoopStartup.java    |    54 +
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   550 +
 .../hadoop/GridHadoopTasksAllVersionsTest.java  |   260 +
 .../hadoop/GridHadoopTasksV1Test.java           |    58 +
 .../hadoop/GridHadoopTasksV2Test.java           |    76 +
 .../GridHadoopTestRoundRobinMrPlanner.java      |    67 +
 .../hadoop/GridHadoopTestTaskContext.java       |   220 +
 .../hadoop/GridHadoopV2JobSelfTest.java         |    89 +
 .../hadoop/GridHadoopValidationSelfTest.java    |    53 +
 .../hadoop/examples/GridHadoopWordCount1.java   |    88 +
 .../examples/GridHadoopWordCount1Map.java       |    62 +
 .../examples/GridHadoopWordCount1Reduce.java    |    51 +
 .../hadoop/examples/GridHadoopWordCount2.java   |    95 +
 .../examples/GridHadoopWordCount2Mapper.java    |    72 +
 .../examples/GridHadoopWordCount2Reducer.java   |    71 +
 .../collections/GridHadoopAbstractMapTest.java  |   152 +
 ...ridHadoopConcurrentHashMultimapSelftest.java |   267 +
 .../collections/GridHadoopHashMapSelfTest.java  |   170 +
 .../collections/GridHadoopSkipListSelfTest.java |   303 +
 .../streams/GridHadoopDataStreamSelfTest.java   |   151 +
 .../GridHadoopExecutorServiceTest.java          |   119 +
 ...GridHadoopExternalTaskExecutionSelfTest.java |   211 +
 ...GridHadoopExternalCommunicationSelfTest.java |   209 +
 .../loadtests/ggfs/GridGgfsNodeStartup.java     |    49 +
 .../ggfs/GridGgfsPerformanceBenchmark.java      |   273 +
 .../IgniteFsLinuxAndMacOSTestSuite.java         |    63 +
 .../testsuites/IgniteHadoopTestSuite.java       |   263 +
 ...ridHadoopClientProtocolEmbeddedSelfTest.java |    34 -
 .../GridHadoopClientProtocolSelfTest.java       |   633 -
 .../gridgain/grid/ggfs/GridFileSystemLoad.java  |   548 -
 .../grid/ggfs/GridGgfsEventsTestSuite.java      |   268 -
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |  1969 ---
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    74 -
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    74 -
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   305 -
 .../ggfs/GridGgfsHadoopDualAsyncSelfTest.java   |    32 -
 .../ggfs/GridGgfsHadoopDualSyncSelfTest.java    |    32 -
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |  2368 ---
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   201 -
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   312 -
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   209 -
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   288 -
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   327 -
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    48 -
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |    33 -
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |    33 -
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |    33 -
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |    34 -
 ...SystemLoopbackExternalDualAsyncSelfTest.java |    33 -
 ...eSystemLoopbackExternalDualSyncSelfTest.java |    33 -
 ...leSystemLoopbackExternalPrimarySelfTest.java |    33 -
 ...SystemLoopbackExternalSecondarySelfTest.java |    34 -
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   321 -
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    90 -
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 -
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 -
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemExternalDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemExternalPrimarySelfTest.java |    33 -
 ...ileSystemShmemExternalSecondarySelfTest.java |    33 -
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |   214 -
 .../grid/hadoop/GridHadoopPopularWordsTest.java |   294 -
 .../grid/hadoop/GridHadoopTestUtils.java        |   102 -
 .../grid/hadoop/books/alice-in-wonderland.txt   |  3735 -----
 .../gridgain/grid/hadoop/books/art-of-war.txt   |  6982 ---------
 .../grid/hadoop/books/huckleberry-finn.txt      | 11733 ---------------
 .../grid/hadoop/books/sherlock-holmes.txt       | 13052 -----------------
 .../gridgain/grid/hadoop/books/tom-sawyer.txt   |  8858 -----------
 .../hadoop/GridHadoopAbstractSelfTest.java      |   210 -
 .../hadoop/GridHadoopAbstractWordCountTest.java |   138 -
 .../hadoop/GridHadoopClassLoaderTest.java       |    69 -
 .../hadoop/GridHadoopCommandLineTest.java       |   441 -
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  1223 --
 .../hadoop/GridHadoopFileSystemsTest.java       |   176 -
 .../hadoop/GridHadoopGroupingTest.java          |   287 -
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |   332 -
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |   246 -
 .../hadoop/GridHadoopMapReduceTest.java         |   201 -
 .../GridHadoopSerializationWrapperSelfTest.java |    76 -
 .../processors/hadoop/GridHadoopSharedMap.java  |    67 -
 .../hadoop/GridHadoopSortingExternalTest.java   |    34 -
 .../hadoop/GridHadoopSortingTest.java           |   283 -
 .../hadoop/GridHadoopSplitWrapperSelfTest.java  |    69 -
 .../processors/hadoop/GridHadoopStartup.java    |    55 -
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   551 -
 .../hadoop/GridHadoopTasksAllVersionsTest.java  |   261 -
 .../hadoop/GridHadoopTasksV1Test.java           |    58 -
 .../hadoop/GridHadoopTasksV2Test.java           |    76 -
 .../GridHadoopTestRoundRobinMrPlanner.java      |    68 -
 .../hadoop/GridHadoopTestTaskContext.java       |   221 -
 .../hadoop/GridHadoopV2JobSelfTest.java         |    90 -
 .../hadoop/GridHadoopValidationSelfTest.java    |    53 -
 .../hadoop/examples/GridHadoopWordCount1.java   |    88 -
 .../examples/GridHadoopWordCount1Map.java       |    62 -
 .../examples/GridHadoopWordCount1Reduce.java    |    51 -
 .../hadoop/examples/GridHadoopWordCount2.java   |    95 -
 .../examples/GridHadoopWordCount2Mapper.java    |    72 -
 .../examples/GridHadoopWordCount2Reducer.java   |    71 -
 .../collections/GridHadoopAbstractMapTest.java  |   153 -
 ...ridHadoopConcurrentHashMultimapSelftest.java |   267 -
 .../collections/GridHadoopHashMapSelfTest.java  |   170 -
 .../collections/GridHadoopSkipListSelfTest.java |   303 -
 .../streams/GridHadoopDataStreamSelfTest.java   |   151 -
 .../GridHadoopExecutorServiceTest.java          |   119 -
 ...GridHadoopExternalTaskExecutionSelfTest.java |   212 -
 ...GridHadoopExternalCommunicationSelfTest.java |   209 -
 .../loadtests/ggfs/GridGgfsNodeStartup.java     |    50 -
 .../ggfs/GridGgfsPerformanceBenchmark.java      |   273 -
 .../bamboo/GridGgfsLinuxAndMacOSTestSuite.java  |    63 -
 .../testsuites/bamboo/GridHadoopTestSuite.java  |   263 -
 ...idHibernateAbstractRegionAccessStrategy.java |    97 +
 .../GridHibernateAccessStrategyAdapter.java     |   367 +
 .../GridHibernateCollectionRegion.java          |    99 +
 .../hibernate/GridHibernateEntityRegion.java    |   110 +
 .../GridHibernateGeneralDataRegion.java         |    69 +
 .../hibernate/GridHibernateNaturalIdRegion.java |    98 +
 .../GridHibernateNonStrictAccessStrategy.java   |   220 +
 .../GridHibernateQueryResultsRegion.java        |    71 +
 .../GridHibernateReadOnlyAccessStrategy.java    |   106 +
 .../GridHibernateReadWriteAccessStrategy.java   |   282 +
 .../cache/hibernate/GridHibernateRegion.java    |   101 +
 .../hibernate/GridHibernateRegionFactory.java   |   230 +
 .../GridHibernateTimestampsRegion.java          |    40 +
 ...ridHibernateTransactionalAccessStrategy.java |   139 +
 .../GridHibernateTransactionalDataRegion.java   |    96 +
 .../apache/ignite/cache/hibernate/package.html  |    26 +
 .../hibernate/GridCacheHibernateBlobStore.java  |   593 +
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |    29 +
 .../GridCacheHibernateBlobStoreEntry.java       |    86 +
 .../ignite/cache/store/hibernate/package.html   |    23 +
 ...idHibernateAbstractRegionAccessStrategy.java |    97 -
 .../GridHibernateAccessStrategyAdapter.java     |   368 -
 .../GridHibernateCollectionRegion.java          |    99 -
 .../hibernate/GridHibernateEntityRegion.java    |   110 -
 .../GridHibernateGeneralDataRegion.java         |    70 -
 .../hibernate/GridHibernateNaturalIdRegion.java |    98 -
 .../GridHibernateNonStrictAccessStrategy.java   |   221 -
 .../GridHibernateQueryResultsRegion.java        |    71 -
 .../GridHibernateReadOnlyAccessStrategy.java    |   107 -
 .../GridHibernateReadWriteAccessStrategy.java   |   282 -
 .../cache/hibernate/GridHibernateRegion.java    |   101 -
 .../hibernate/GridHibernateRegionFactory.java   |   230 -
 .../GridHibernateTimestampsRegion.java          |    40 -
 ...ridHibernateTransactionalAccessStrategy.java |   140 -
 .../GridHibernateTransactionalDataRegion.java   |    96 -
 .../gridgain/grid/cache/hibernate/package.html  |    26 -
 .../hibernate/GridCacheHibernateBlobStore.java  |   594 -
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |    29 -
 .../GridCacheHibernateBlobStoreEntry.java       |    86 -
 .../grid/cache/store/hibernate/package.html     |    23 -
 ...idHibernateL2CacheConfigurationSelfTest.java |   380 +
 .../hibernate/GridHibernateL2CacheSelfTest.java |  1923 +++
 ...idHibernateL2CacheTransactionalSelfTest.java |   135 +
 .../GridCacheHibernateBlobStoreSelfTest.java    |   108 +
 .../cache/store/hibernate/hibernate.cfg.xml     |    40 +
 .../ignite/cache/store/hibernate/package.html   |    23 +
 .../testsuites/IgniteHibernateTestSuite.java    |    44 +
 ...idHibernateL2CacheConfigurationSelfTest.java |   380 -
 .../hibernate/GridHibernateL2CacheSelfTest.java |  1923 ---
 ...idHibernateL2CacheTransactionalSelfTest.java |   136 -
 .../GridCacheHibernateBlobStoreSelfTest.java    |   108 -
 .../cache/store/hibernate/hibernate.cfg.xml     |    40 -
 .../grid/cache/store/hibernate/package.html     |    23 -
 .../bamboo/GridHibernateTestSuite.java          |    44 -
 .../query/h2/GridH2ResultSetIterator.java       |   130 +
 .../processors/query/h2/IgniteH2Indexing.java   |  2004 +++
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   455 +
 .../processors/query/h2/opt/GridH2Cursor.java   |    70 +
 .../query/h2/opt/GridH2IndexBase.java           |   206 +
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   356 +
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |    54 +
 .../processors/query/h2/opt/GridH2Row.java      |    48 +
 .../query/h2/opt/GridH2RowDescriptor.java       |   110 +
 .../query/h2/opt/GridH2SpatialIndex.java        |   326 +
 .../processors/query/h2/opt/GridH2Table.java    |   896 ++
 .../query/h2/opt/GridH2TreeIndex.java           |   477 +
 .../processors/query/h2/opt/GridH2Utils.java    |   133 +
 .../query/h2/opt/GridLuceneDirectory.java       |   197 +
 .../processors/query/h2/opt/GridLuceneFile.java |   194 +
 .../query/h2/opt/GridLuceneIndex.java           |   392 +
 .../query/h2/opt/GridLuceneInputStream.java     |   228 +
 .../query/h2/opt/GridLuceneLockFactory.java     |    72 +
 .../query/h2/opt/GridLuceneOutputStream.java    |   238 +
 .../query/h2/opt/GridSearchRowPointer.java      |    28 +
 .../internal/processors/query/h2/package.html   |    24 +
 .../processors/query/h2/GridH2Indexing.java     |  2005 ---
 .../query/h2/GridH2ResultSetIterator.java       |   130 -
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   455 -
 .../processors/query/h2/opt/GridH2Cursor.java   |    70 -
 .../query/h2/opt/GridH2IndexBase.java           |   206 -
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   356 -
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |    54 -
 .../processors/query/h2/opt/GridH2Row.java      |    48 -
 .../query/h2/opt/GridH2RowDescriptor.java       |   110 -
 .../query/h2/opt/GridH2SpatialIndex.java        |   326 -
 .../processors/query/h2/opt/GridH2Table.java    |   896 --
 .../query/h2/opt/GridH2TreeIndex.java           |   477 -
 .../processors/query/h2/opt/GridH2Utils.java    |   133 -
 .../query/h2/opt/GridLuceneDirectory.java       |   197 -
 .../processors/query/h2/opt/GridLuceneFile.java |   194 -
 .../query/h2/opt/GridLuceneIndex.java           |   392 -
 .../query/h2/opt/GridLuceneInputStream.java     |   228 -
 .../query/h2/opt/GridLuceneLockFactory.java     |    72 -
 .../query/h2/opt/GridLuceneOutputStream.java    |   238 -
 .../query/h2/opt/GridSearchRowPointer.java      |    28 -
 .../kernal/processors/query/h2/package.html     |    24 -
 .../GridCacheAbstractFieldsQuerySelfTest.java   |  1305 ++
 .../cache/GridCacheAbstractQuerySelfTest.java   |  2094 +++
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   352 +
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |   571 +
 ...idCacheQueryEvictsMultiThreadedSelfTest.java |    28 +
 .../cache/GridCacheQueryLoadSelfTest.java       |   458 +
 .../cache/GridCacheQueryMetricsSelfTest.java    |   161 +
 .../GridCacheQueryMultiThreadedSelfTest.java    |   859 ++
 ...QueryOffheapEvictsMultiThreadedSelfTest.java |    28 +
 ...dCacheQueryOffheapMultiThreadedSelfTest.java |    28 +
 .../cache/GridCacheQueryTestValue.java          |   172 +
 ...idCacheReduceQueryMultithreadedSelfTest.java |   158 +
 .../GridCacheSqlQueryMultiThreadedSelfTest.java |   140 +
 .../processors/cache/GridCacheSwapSelfTest.java |   722 +
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   117 +
 .../GridCacheAtomicFieldsQuerySelfTest.java     |    65 +
 ...cheAtomicNearEnabledFieldsQuerySelfTest.java |    32 +
 ...GridCacheAtomicNearEnabledQuerySelfTest.java |    38 +
 .../near/GridCacheAtomicQuerySelfTest.java      |    38 +
 ...rtitionedFieldsQueryP2PDisabledSelfTest.java |    34 +
 ...GridCachePartitionedFieldsQuerySelfTest.java |   109 +
 ...idCachePartitionedHitsAndMissesSelfTest.java |   178 +
 ...achePartitionedQueryP2PDisabledSelfTest.java |    34 +
 .../near/GridCachePartitionedQuerySelfTest.java |   479 +
 .../near/GridCacheQueryNodeRestartSelfTest.java |   224 +
 ...eplicatedFieldsQueryP2PDisabledSelfTest.java |    34 +
 .../GridCacheReplicatedFieldsQuerySelfTest.java |   157 +
 ...CacheReplicatedQueryP2PDisabledSelfTest.java |    34 +
 .../GridCacheReplicatedQuerySelfTest.java       |   683 +
 .../GridCacheLocalAtomicQuerySelfTest.java      |    32 +
 .../GridCacheLocalFieldsQuerySelfTest.java      |    38 +
 .../local/GridCacheLocalQuerySelfTest.java      |   106 +
 .../query/h2/GridH2IndexRebuildTest.java        |   249 +
 .../query/h2/GridH2IndexingGeoSelfTest.java     |   248 +
 .../query/h2/GridH2IndexingInMemSelfTest.java   |    25 +
 .../query/h2/GridH2IndexingOffheapSelfTest.java |    44 +
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   559 +
 .../query/h2/opt/GridH2TableSelfTest.java       |   621 +
 .../loadtests/h2indexing/GridTestEntity.java    |    68 +
 .../loadtests/h2indexing/GridTreeBenchmark.java |   276 +
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    22 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   101 +
 .../IgniteH2IndexingSpiTestSuite.java           |    61 +
 .../GridCacheAbstractFieldsQuerySelfTest.java   |  1306 --
 .../cache/GridCacheAbstractQuerySelfTest.java   |  2095 ---
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   353 -
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |   572 -
 ...idCacheQueryEvictsMultiThreadedSelfTest.java |    28 -
 .../cache/GridCacheQueryLoadSelfTest.java       |   459 -
 .../cache/GridCacheQueryMetricsSelfTest.java    |   162 -
 .../GridCacheQueryMultiThreadedSelfTest.java    |   860 --
 ...QueryOffheapEvictsMultiThreadedSelfTest.java |    28 -
 ...dCacheQueryOffheapMultiThreadedSelfTest.java |    28 -
 .../cache/GridCacheQueryTestValue.java          |   172 -
 ...idCacheReduceQueryMultithreadedSelfTest.java |   159 -
 .../GridCacheSqlQueryMultiThreadedSelfTest.java |   141 -
 .../processors/cache/GridCacheSwapSelfTest.java |   723 -
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   118 -
 .../GridCacheAtomicFieldsQuerySelfTest.java     |    65 -
 ...cheAtomicNearEnabledFieldsQuerySelfTest.java |    32 -
 ...GridCacheAtomicNearEnabledQuerySelfTest.java |    38 -
 .../near/GridCacheAtomicQuerySelfTest.java      |    38 -
 ...rtitionedFieldsQueryP2PDisabledSelfTest.java |    34 -
 ...GridCachePartitionedFieldsQuerySelfTest.java |   110 -
 ...idCachePartitionedHitsAndMissesSelfTest.java |   179 -
 ...achePartitionedQueryP2PDisabledSelfTest.java |    34 -
 .../near/GridCachePartitionedQuerySelfTest.java |   479 -
 .../near/GridCacheQueryNodeRestartSelfTest.java |   225 -
 ...eplicatedFieldsQueryP2PDisabledSelfTest.java |    34 -
 .../GridCacheReplicatedFieldsQuerySelfTest.java |   158 -
 ...CacheReplicatedQueryP2PDisabledSelfTest.java |    34 -
 .../GridCacheReplicatedQuerySelfTest.java       |   683 -
 .../GridCacheLocalAtomicQuerySelfTest.java      |    32 -
 .../GridCacheLocalFieldsQuerySelfTest.java      |    38 -
 .../local/GridCacheLocalQuerySelfTest.java      |   107 -
 .../query/h2/GridH2IndexRebuildTest.java        |   249 -
 .../query/h2/GridH2IndexingGeoSelfTest.java     |   248 -
 .../query/h2/GridH2IndexingInMemSelfTest.java   |    25 -
 .../query/h2/GridH2IndexingOffheapSelfTest.java |    44 -
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   561 -
 .../query/h2/opt/GridH2TableSelfTest.java       |   621 -
 .../loadtests/h2indexing/GridTestEntity.java    |    68 -
 .../loadtests/h2indexing/GridTreeBenchmark.java |   276 -
 .../testsuites/GridCacheQuerySelfTestSuite.java |   101 -
 .../bamboo/GridH2IndexingSpiTestSuite.java      |    61 -
 .../apache/ignite/logger/jcl/GridJclLogger.java |   170 +
 .../org/apache/ignite/logger/jcl/package.html   |    23 +
 .../gridgain/grid/logger/jcl/GridJclLogger.java |   170 -
 .../org/gridgain/grid/logger/jcl/package.html   |    23 -
 .../ignite/logger/jcl/GridJclLoggerTest.java    |    48 +
 .../org/apache/ignite/logger/jcl/package.html   |    23 +
 .../ignite/testsuites/IgniteJclTestSuite.java   |    38 +
 .../grid/logger/jcl/GridJclLoggerTest.java      |    48 -
 .../org/gridgain/grid/logger/jcl/package.html   |    23 -
 .../testsuites/bamboo/GridJclTestSuite.java     |    38 -
 .../ignite/cache/jta/GridCacheTmLookup.java     |    50 +
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |    74 +
 .../apache/ignite/cache/jta/jndi/package.html   |    24 +
 .../org/apache/ignite/cache/jta/package.html    |    24 +
 .../reflect/GridCacheReflectionTmLookup.java    |   115 +
 .../ignite/cache/jta/reflect/package.html       |    24 +
 .../processors/cache/jta/CacheJtaManager.java   |   113 +
 .../cache/jta/GridCacheXAResource.java          |   248 +
 .../grid/cache/jta/GridCacheTmLookup.java       |    52 -
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |    74 -
 .../gridgain/grid/cache/jta/jndi/package.html   |    24 -
 .../org/gridgain/grid/cache/jta/package.html    |    24 -
 .../reflect/GridCacheReflectionTmLookup.java    |   115 -
 .../grid/cache/jta/reflect/package.html         |    24 -
 .../cache/jta/GridCacheJtaManager.java          |   113 -
 .../cache/jta/GridCacheXAResource.java          |   248 -
 ...CacheJtaConfigurationValidationSelfTest.java |    74 +
 .../processors/cache/GridCacheJtaSelfTest.java  |   186 +
 .../cache/GridCacheReplicatedJtaSelfTest.java   |    32 +
 .../GridTmLookupLifecycleAwareSelfTest.java     |   102 +
 .../ignite/testsuites/IgniteJtaTestSuite.java   |    41 +
 ...CacheJtaConfigurationValidationSelfTest.java |    74 -
 .../processors/cache/GridCacheJtaSelfTest.java  |   187 -
 .../cache/GridCacheReplicatedJtaSelfTest.java   |    32 -
 .../GridTmLookupLifecycleAwareSelfTest.java     |   103 -
 .../testsuites/bamboo/GridJtaTestSuite.java     |    41 -
 .../IgniteLog4jDailyRollingFileAppender.java    |     2 +-
 ...IgniteLog4jExternallyRolledFileAppender.java |     2 +-
 .../logger/log4j/IgniteLog4jFileAppender.java   |     2 +-
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |     8 +-
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |     4 +-
 .../log4j/IgniteLog4jRollingFileAppender.java   |     2 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |   137 +
 .../logger/log4j/GridLog4jInitializedTest.java  |    55 +
 .../logger/log4j/GridLog4jLoggingFileTest.java  |    59 +
 .../logger/log4j/GridLog4jLoggingPathTest.java  |    53 +
 .../logger/log4j/GridLog4jLoggingUrlTest.java   |    59 +
 .../log4j/GridLog4jNotInitializedTest.java      |    46 +
 .../org/apache/ignite/logger/log4j/package.html |    23 +
 .../ignite/testsuites/IgniteLog4jTestSuite.java |    40 +
 .../log4j/GridLog4jCorrectFileNameTest.java     |   137 -
 .../logger/log4j/GridLog4jInitializedTest.java  |    56 -
 .../logger/log4j/GridLog4jLoggingFileTest.java  |    59 -
 .../logger/log4j/GridLog4jLoggingPathTest.java  |    53 -
 .../logger/log4j/GridLog4jLoggingUrlTest.java   |    59 -
 .../log4j/GridLog4jNotInitializedTest.java      |    47 -
 .../org/gridgain/grid/logger/log4j/package.html |    23 -
 .../testsuites/bamboo/GridLog4jTestSuite.java   |    40 -
 .../http/jetty/GridJettyJsonConfig.java         |    50 +
 .../http/jetty/GridJettyRestHandler.java        |   595 +
 .../http/jetty/GridJettyRestProtocol.java       |   409 +
 .../rest/protocols/http/jetty/favicon.ico       |   Bin 0 -> 1406 bytes
 .../rest/protocols/http/jetty/package.html      |    23 +
 .../rest/protocols/http/jetty/rest.html         |    96 +
 .../http/jetty/GridJettyJsonConfig.java         |    50 -
 .../http/jetty/GridJettyRestHandler.java        |   596 -
 .../http/jetty/GridJettyRestProtocol.java       |   410 -
 .../rest/protocols/http/jetty/favicon.ico       |   Bin 1406 -> 0 bytes
 .../rest/protocols/http/jetty/package.html      |    23 -
 .../rest/protocols/http/jetty/rest.html         |    96 -
 modules/scalar/pom.xml                          |     2 +-
 .../ignite/scalar/ScalarConversions.scala       |  1235 ++
 .../org/apache/ignite/scalar/lang/Packet.scala  |    23 +
 .../ignite/scalar/lang/ScalarAbsClosure.scala   |    37 +
 .../scalar/lang/ScalarAbsClosureFunction.scala  |    32 +
 .../ignite/scalar/lang/ScalarAbsClosureX.scala  |    36 +
 .../scalar/lang/ScalarAbsClosureXFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarAbsPredicate.scala |    34 +
 .../lang/ScalarAbsPredicateFunction.scala       |    34 +
 .../scalar/lang/ScalarAbsPredicateX.scala       |    36 +
 .../lang/ScalarAbsPredicateXFunction.scala      |    34 +
 .../ignite/scalar/lang/ScalarClosure.scala      |    34 +
 .../ignite/scalar/lang/ScalarClosure2.scala     |    34 +
 .../scalar/lang/ScalarClosure2Function.scala    |    34 +
 .../ignite/scalar/lang/ScalarClosure2X.scala    |    36 +
 .../scalar/lang/ScalarClosure2XFunction.scala   |    34 +
 .../ignite/scalar/lang/ScalarClosure3.scala     |    34 +
 .../scalar/lang/ScalarClosure3Function.scala    |    34 +
 .../ignite/scalar/lang/ScalarClosure3X.scala    |    36 +
 .../scalar/lang/ScalarClosure3XFunction.scala   |    34 +
 .../scalar/lang/ScalarClosureFunction.scala     |    34 +
 .../ignite/scalar/lang/ScalarClosureX.scala     |    36 +
 .../scalar/lang/ScalarClosureXFunction.scala    |    34 +
 .../ignite/scalar/lang/ScalarInClosure.scala    |    34 +
 .../ignite/scalar/lang/ScalarInClosure2.scala   |    34 +
 .../scalar/lang/ScalarInClosure2Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarInClosure2X.scala  |    36 +
 .../scalar/lang/ScalarInClosure2XFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarInClosure3.scala   |    34 +
 .../scalar/lang/ScalarInClosure3Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarInClosure3X.scala  |    36 +
 .../scalar/lang/ScalarInClosure3XFunction.scala |    34 +
 .../scalar/lang/ScalarInClosureFunction.scala   |    34 +
 .../ignite/scalar/lang/ScalarInClosureX.scala   |    36 +
 .../scalar/lang/ScalarInClosureXFunction.scala  |    34 +
 .../apache/ignite/scalar/lang/ScalarJob.scala   |    32 +
 .../ignite/scalar/lang/ScalarOutClosure.scala   |    46 +
 .../scalar/lang/ScalarOutClosureFunction.scala  |    33 +
 .../ignite/scalar/lang/ScalarOutClosureX.scala  |    36 +
 .../scalar/lang/ScalarOutClosureXFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarPredicate.scala    |    32 +
 .../ignite/scalar/lang/ScalarPredicate2.scala   |    32 +
 .../scalar/lang/ScalarPredicate2Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarPredicate2X.scala  |    36 +
 .../scalar/lang/ScalarPredicate2XFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarPredicate3.scala   |    32 +
 .../scalar/lang/ScalarPredicate3Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarPredicate3X.scala  |    36 +
 .../scalar/lang/ScalarPredicate3XFunction.scala |    34 +
 .../scalar/lang/ScalarPredicateFunction.scala   |    34 +
 .../ignite/scalar/lang/ScalarPredicateX.scala   |    36 +
 .../scalar/lang/ScalarPredicateXFunction.scala  |    34 +
 .../ignite/scalar/lang/ScalarReducer.scala      |    47 +
 .../ignite/scalar/lang/ScalarReducer2.scala     |    49 +
 .../scalar/lang/ScalarReducer2Function.scala    |    36 +
 .../ignite/scalar/lang/ScalarReducer3.scala     |    53 +
 .../scalar/lang/ScalarReducer3Function.scala    |    37 +
 .../scalar/lang/ScalarReducerFunction.scala     |    36 +
 .../org/apache/ignite/scalar/pimps/Packet.scala |    23 +
 .../apache/ignite/scalar/pimps/PimpedType.scala |    32 +
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |    69 +
 .../pimps/ScalarCacheProjectionPimp.scala       |  2004 +++
 .../ignite/scalar/pimps/ScalarGridPimp.scala    |    93 +
 .../scalar/pimps/ScalarProjectionPimp.scala     |   658 +
 .../scalar/pimps/ScalarTaskThreadContext.scala  |    46 +
 .../scala/org/apache/ignite/scalar/scalar.scala |   457 +
 .../org/gridgain/scalar/ScalarConversions.scala |  1235 --
 .../scala/org/gridgain/scalar/lang/Packet.scala |    23 -
 .../gridgain/scalar/lang/ScalarAbsClosure.scala |    37 -
 .../scalar/lang/ScalarAbsClosureFunction.scala  |    32 -
 .../scalar/lang/ScalarAbsClosureX.scala         |    37 -
 .../scalar/lang/ScalarAbsClosureXFunction.scala |    34 -
 .../scalar/lang/ScalarAbsPredicate.scala        |    34 -
 .../lang/ScalarAbsPredicateFunction.scala       |    34 -
 .../scalar/lang/ScalarAbsPredicateX.scala       |    37 -
 .../lang/ScalarAbsPredicateXFunction.scala      |    34 -
 .../gridgain/scalar/lang/ScalarClosure.scala    |    34 -
 .../gridgain/scalar/lang/ScalarClosure2.scala   |    34 -
 .../scalar/lang/ScalarClosure2Function.scala    |    34 -
 .../gridgain/scalar/lang/ScalarClosure2X.scala  |    37 -
 .../scalar/lang/ScalarClosure2XFunction.scala   |    34 -
 .../gridgain/scalar/lang/ScalarClosure3.scala   |    34 -
 .../scalar/lang/ScalarClosure3Function.scala    |    34 -
 .../gridgain/scalar/lang/ScalarClosure3X.scala  |    37 -
 .../scalar/lang/ScalarClosure3XFunction.scala   |    34 -
 .../scalar/lang/ScalarClosureFunction.scala     |    34 -
 .../gridgain/scalar/lang/ScalarClosureX.scala   |    37 -
 .../scalar/lang/ScalarClosureXFunction.scala    |    34 -
 .../gridgain/scalar/lang/ScalarInClosure.scala  |    34 -
 .../gridgain/scalar/lang/ScalarInClosure2.scala |    34 -
 .../scalar/lang/ScalarInClosure2Function.scala  |    34 -
 .../scalar/lang/ScalarInClosure2X.scala         |    37 -
 .../scalar/lang/ScalarInClosure2XFunction.scala |    34 -
 .../gridgain/scalar/lang/ScalarInClosure3.scala |    34 -
 .../scalar/lang/ScalarInClosure3Function.scala  |    34 -
 .../scalar/lang/ScalarInClosure3X.scala         |    37 -
 .../scalar/lang/ScalarInClosure3XFunction.scala |    34 -
 .../scalar/lang/ScalarInClosureFunction.scala   |    34 -
 .../gridgain/scalar/lang/ScalarInClosureX.scala |    37 -
 .../scalar/lang/ScalarInClosureXFunction.scala  |    34 -
 .../org/gridgain/scalar/lang/ScalarJob.scala    |    33 -
 .../gridgain/scalar/lang/ScalarOutClosure.scala |    46 -
 .../scalar/lang/ScalarOutClosureFunction.scala  |    33 -
 .../scalar/lang/ScalarOutClosureX.scala         |    37 -
 .../scalar/lang/ScalarOutClosureXFunction.scala |    34 -
 .../gridgain/scalar/lang/ScalarPredicate.scala  |    32 -
 .../gridgain/scalar/lang/ScalarPredicate2.scala |    32 -
 .../scalar/lang/ScalarPredicate2Function.scala  |    34 -
 .../scalar/lang/ScalarPredicate2X.scala         |    37 -
 .../scalar/lang/ScalarPredicate2XFunction.scala |    34 -
 .../gridgain/scalar/lang/ScalarPredicate3.scala |    32 -
 .../scalar/lang/ScalarPredicate3Function.scala  |    34 -
 .../scalar/lang/ScalarPredicate3X.scala         |    37 -
 .../scalar/lang/ScalarPredicate3XFunction.scala |    34 -
 .../scalar/lang/ScalarPredicateFunction.scala   |    34 -
 .../gridgain/scalar/lang/ScalarPredicateX.scala |    37 -
 .../scalar/lang/ScalarPredicateXFunction.scala  |    34 -
 .../gridgain/scalar/lang/ScalarReducer.scala    |    47 -
 .../gridgain/scalar/lang/ScalarReducer2.scala   |    49 -
 .../scalar/lang/ScalarReducer2Function.scala    |    36 -
 .../gridgain/scalar/lang/ScalarReducer3.scala   |    53 -
 .../scalar/lang/ScalarReducer3Function.scala    |    37 -
 .../scalar/lang/ScalarReducerFunction.scala     |    36 -
 .../org/gridgain/scalar/pimps/Packet.scala      |    23 -
 .../org/gridgain/scalar/pimps/PimpedType.scala  |    32 -
 .../gridgain/scalar/pimps/ScalarCachePimp.scala |    69 -
 .../pimps/ScalarCacheProjectionPimp.scala       |  2005 ---
 .../gridgain/scalar/pimps/ScalarGridPimp.scala  |    94 -
 .../scalar/pimps/ScalarProjectionPimp.scala     |   659 -
 .../scalar/pimps/ScalarTaskThreadContext.scala  |    47 -
 .../main/scala/org/gridgain/scalar/scalar.scala |   459 -
 .../tests/ScalarAffinityRoutingSpec.scala       |    68 +
 .../tests/ScalarCacheProjectionSpec.scala       |    39 +
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |   597 +
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |    79 +
 .../scalar/tests/ScalarConversionsSpec.scala    |   254 +
 .../scalar/tests/ScalarProjectionSpec.scala     |   147 +
 .../scalar/tests/ScalarReturnableSpec.scala     |    58 +
 .../apache/ignite/scalar/tests/ScalarSpec.scala |    37 +
 .../scalar/testsuites/ScalarSelfTestSuite.scala |    38 +
 .../tests/ScalarAffinityRoutingSpec.scala       |    68 -
 .../tests/ScalarCacheProjectionSpec.scala       |    39 -
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |   600 -
 .../gridgain/scalar/tests/ScalarCacheSpec.scala |    79 -
 .../scalar/tests/ScalarConversionsSpec.scala    |   254 -
 .../scalar/tests/ScalarProjectionSpec.scala     |   150 -
 .../scalar/tests/ScalarReturnableSpec.scala     |    58 -
 .../org/gridgain/scalar/tests/ScalarSpec.scala  |    37 -
 .../scalar/testsuites/ScalarSelfTestSuite.scala |    38 -
 .../schedule/IgniteScheduleProcessor.java       |   130 +
 .../processors/schedule/ScheduleFutureImpl.java |  1004 ++
 .../schedule/GridScheduleProcessor.java         |   130 -
 .../processors/schedule/ScheduleFutureImpl.java |  1005 --
 .../schedule/GridScheduleSelfTest.java          |   401 +
 .../testsuites/IgniteSchedulerTestSuite.java    |    38 +
 .../grid/kernal/GridScheduleSelfTest.java       |   402 -
 .../bamboo/GridSchedulerTestSuite.java          |    38 -
 .../ignite/logger/slf4j/GridSlf4jLogger.java    |   141 +
 .../org/apache/ignite/logger/slf4j/package.html |    23 +
 .../grid/logger/slf4j/GridSlf4jLogger.java      |   141 -
 .../org/gridgain/grid/logger/slf4j/package.html |    23 -
 .../java/org/apache/ignite/IgniteSpring.java    |   117 +
 .../org/apache/ignite/IgniteSpringBean.java     |   342 +
 .../apache/ignite/cache/spring/SpringCache.java |   185 +
 .../ignite/cache/spring/SpringCacheManager.java |   241 +
 .../cache/spring/SpringDynamicCacheManager.java |   315 +
 .../org/apache/ignite/cache/spring/package.html |    23 +
 .../GridResourceSpringBeanInjector.java         |   100 +
 .../resource/GridSpringResourceContextImpl.java |    67 +
 .../spring/IgniteSpringProcessorImpl.java       |   268 +
 .../java/org/gridgain/grid/GridGainSpring.java  |   118 -
 .../java/org/gridgain/grid/GridSpringBean.java  |   343 -
 .../grid/cache/spring/GridSpringCache.java      |   185 -
 .../cache/spring/GridSpringCacheManager.java    |   241 -
 .../spring/GridSpringDynamicCacheManager.java   |   316 -
 .../org/gridgain/grid/cache/spring/package.html |    23 -
 .../GridResourceSpringBeanInjector.java         |   100 -
 .../resource/GridSpringResourceContextImpl.java |    67 -
 .../spring/GridSpringProcessorImpl.java         |   269 -
 .../ignite/internal/GridFactorySelfTest.java    |   790 +
 .../GridSpringBeanSerializationSelfTest.java    |    92 +
 .../resource/GridLoggerInjectionSelfTest.java   |   137 +
 .../resource/GridResourceProcessorSelfTest.java |   465 +
 .../resource/GridResourceTestUtils.java         |    51 +
 .../resource/GridServiceInjectionSelfTest.java  |   309 +
 .../processors/resource/TestClosure.java        |    45 +
 .../internal/processors/resource/package.html   |    24 +
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   357 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   237 +
 .../ignite/spring/GridSpringCacheTestKey.java   |    59 +
 .../spring/GridSpringCacheTestKeyGenerator.java |    41 +
 .../spring/GridSpringCacheTestService.java      |   124 +
 .../GridSpringDynamicCacheManagerSelfTest.java  |   220 +
 .../GridSpringDynamicCacheTestService.java      |    62 +
 .../org/apache/ignite/spring/spring-caching.xml |    47 +
 .../ignite/spring/spring-dynamic-caching.xml    |    43 +
 .../testsuites/IgniteResourceSelfTestSuite.java |    41 +
 .../testsuites/IgniteSpringTestSuite.java       |    50 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   238 -
 .../cache/spring/GridSpringCacheTestKey.java    |    59 -
 .../spring/GridSpringCacheTestKeyGenerator.java |    41 -
 .../spring/GridSpringCacheTestService.java      |   124 -
 .../GridSpringDynamicCacheManagerSelfTest.java  |   219 -
 .../GridSpringDynamicCacheTestService.java      |    62 -
 .../grid/cache/spring/spring-caching.xml        |    47 -
 .../cache/spring/spring-dynamic-caching.xml     |    43 -
 .../grid/kernal/GridFactorySelfTest.java        |   791 -
 .../GridSpringBeanSerializationSelfTest.java    |    92 -
 .../resource/GridLoggerInjectionSelfTest.java   |   137 -
 .../resource/GridResourceProcessorSelfTest.java |   466 -
 .../resource/GridResourceTestUtils.java         |    51 -
 .../resource/GridServiceInjectionSelfTest.java  |   309 -
 .../kernal/processors/resource/TestClosure.java |    45 -
 .../kernal/processors/resource/package.html     |    24 -
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   358 -
 .../testsuites/GridResourceSelfTestSuite.java   |    41 -
 .../testsuites/bamboo/GridSpringTestSuite.java  |    50 -
 .../util/nodestart/GridNodeCallableImpl.java    |   343 +
 .../util/nodestart/IgniteSshProcessorImpl.java  |    28 +
 .../util/nodestart/GridNodeCallableImpl.java    |   344 -
 .../util/nodestart/GridSshProcessorImpl.java    |    28 -
 .../internal/GridNodeStartUtilsSelfTest.java    |    89 +
 .../GridProjectionStartStopRestartSelfTest.java |  1032 ++
 .../IgniteStartStopRestartTestSuite.java        |    39 +
 .../grid/kernal/GridNodeStartUtilsSelfTest.java |    89 -
 .../GridProjectionStartStopRestartSelfTest.java |  1033 --
 .../kernal/GridStartStopRestartTestSuite.java   |    39 -
 .../ant/beautifier/GridJavadocAntTask.java      |   465 +
 .../GridJavadocCharArrayLexReader.java          |    93 +
 .../tools/ant/beautifier/GridJavadocToken.java  |    70 +
 .../ant/beautifier/GridJavadocTokenType.java    |    38 +
 .../ignite/tools/ant/beautifier/package.html    |    24 +
 .../ignite/tools/javadoc/GridLinkTaglet.java    |   165 +
 .../optimized/OptimizedClassNamesGenerator.java |   325 +
 .../util/antgar/IgniteDeploymentGarAntTask.java |   172 +
 .../org/apache/ignite/util/antgar/package.html  |    23 +
 .../ant/beautifier/GridJavadocAntTask.java      |   465 -
 .../GridJavadocCharArrayLexReader.java          |    93 -
 .../tools/ant/beautifier/GridJavadocToken.java  |    70 -
 .../ant/beautifier/GridJavadocTokenType.java    |    38 -
 .../grid/tools/ant/beautifier/package.html      |    24 -
 .../grid/tools/javadoc/GridLinkTaglet.java      |   165 -
 .../optimized/OptimizedClassNamesGenerator.java |   325 -
 .../util/antgar/GridDeploymentGarAntTask.java   |   172 -
 .../org/gridgain/grid/util/antgar/package.html  |    23 -
 .../uri/GridUriDeploymentClassLoader.java       |     2 +-
 .../uri/GridUriDeploymentDiscovery.java         |     2 +-
 .../uri/GridUriDeploymentFileProcessor.java     |     5 +-
 .../GridUriDeploymentFileProcessorResult.java   |     2 +-
 .../uri/GridUriDeploymentJarVerifier.java       |     2 +-
 .../deployment/uri/GridUriDeploymentSpi.java    |     7 +-
 .../uri/GridUriDeploymentSpringDocument.java    |     2 +-
 .../uri/GridUriDeploymentSpringParser.java      |     2 +-
 .../uri/GridUriDeploymentUnitDescriptor.java    |     6 +-
 .../uri/GridUriDeploymentUriParser.java         |     4 +-
 .../uri/scanners/GridUriDeploymentScanner.java  |     4 +-
 .../file/GridUriDeploymentFileScanner.java      |     6 +-
 .../ftp/GridUriDeploymentFtpClient.java         |     2 +-
 .../ftp/GridUriDeploymentFtpConfiguration.java  |     4 +-
 .../scanners/ftp/GridUriDeploymentFtpFile.java  |     2 +-
 .../ftp/GridUriDeploymentFtpScanner.java        |     3 +-
 .../http/GridUriDeploymentHttpScanner.java      |     6 +-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |   110 +
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |   211 +
 .../uri/GridUriDeploymentAbstractSelfTest.java  |     4 +-
 ...loymentClassLoaderMultiThreadedSelfTest.java |     6 +-
 .../GridUriDeploymentClassLoaderSelfTest.java   |     8 +-
 ...riDeploymentClassloaderRegisterSelfTest.java |     6 +-
 .../uri/GridUriDeploymentConfigSelfTest.java    |     2 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |    10 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |     6 +-
 ...loymentMultiScannersErrorThrottlingTest.java |     4 +-
 .../GridUriDeploymentMultiScannersSelfTest.java |     6 +-
 .../uri/GridUriDeploymentSimpleSelfTest.java    |     6 +-
 .../deployment/uri/META-INF/p2p-gridgain.xml    |     4 +-
 .../file/GridFileDeploymentSelfTest.java        |     4 +-
 .../GridFileDeploymentUndeploySelfTest.java     |     6 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |     4 +-
 .../http/GridHttpDeploymentSelfTest.java        |     6 +-
 .../testsuites/IgniteToolsSelfTestSuite.java    |    38 +
 .../IgniteUriDeploymentTestSuite.java           |    59 +
 .../apache/ignite/tools/GridToolsSelfTest.java  |   384 +
 .../ignite/tools/gartask/META-INF/gridgain.xml  |    38 +
 .../java/org/apache/ignite/tools/package.html   |    24 +
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |   110 -
 .../grid/p2p/GridP2PDisabledSelfTest.java       |   212 -
 .../gridgain/grid/tools/GridToolsSelfTest.java  |   384 -
 .../grid/tools/gartask/META-INF/gridgain.xml    |    38 -
 .../java/org/gridgain/grid/tools/package.html   |    24 -
 .../testsuites/GridToolsSelfTestSuite.java      |    38 -
 .../bamboo/GridUriDeploymentTestSuite.java      |    59 -
 .../scala/org/apache/ignite/visor/Packet.scala  |    38 +
 .../ignite/visor/commands/VisorConsole.scala    |   344 +
 .../visor/commands/VisorConsoleCommand.scala    |    77 +
 .../ignite/visor/commands/VisorTextTable.scala  |   539 +
 .../ignite/visor/commands/ack/Packet.scala      |    55 +
 .../visor/commands/ack/VisorAckCommand.scala    |   162 +
 .../ignite/visor/commands/alert/Packet.scala    |   108 +
 .../commands/alert/VisorAlertCommand.scala      |   839 ++
 .../ignite/visor/commands/cache/Packet.scala    |   127 +
 .../commands/cache/VisorCacheClearCommand.scala |   151 +
 .../commands/cache/VisorCacheCommand.scala      |   893 ++
 .../cache/VisorCacheCompactCommand.scala        |   151 +
 .../commands/cache/VisorCacheScanCommand.scala  |   237 +
 .../commands/cache/VisorCacheSwapCommand.scala  |   151 +
 .../ignite/visor/commands/config/Packet.scala   |    55 +
 .../config/VisorConfigurationCommand.scala      |   501 +
 .../ignite/visor/commands/deploy/Packet.scala   |    76 +
 .../commands/deploy/VisorDeployCommand.scala    |   612 +
 .../ignite/visor/commands/disco/Packet.scala    |    72 +
 .../commands/disco/VisorDiscoveryCommand.scala  |   306 +
 .../ignite/visor/commands/events/Packet.scala   |    97 +
 .../commands/events/VisorEventsCommand.scala    |   530 +
 .../ignite/visor/commands/gc/Packet.scala       |    61 +
 .../visor/commands/gc/VisorGcCommand.scala      |   244 +
 .../ignite/visor/commands/ggcube_128x128.png    |   Bin 0 -> 11444 bytes
 .../ignite/visor/commands/ggcube_48x48.png      |   Bin 0 -> 3365 bytes
 .../ignite/visor/commands/kill/Packet.scala     |    78 +
 .../visor/commands/kill/VisorKillCommand.scala  |   356 +
 .../ignite/visor/commands/node/Packet.scala     |    60 +
 .../visor/commands/node/VisorNodeCommand.scala  |   342 +
 .../ignite/visor/commands/ping/Packet.scala     |    50 +
 .../visor/commands/ping/VisorPingCommand.scala  |   228 +
 .../ignite/visor/commands/start/Packet.scala    |    90 +
 .../commands/start/VisorStartCommand.scala      |   429 +
 .../ignite/visor/commands/tasks/Packet.scala    |   116 +
 .../commands/tasks/VisorTasksCommand.scala      |  1488 ++
 .../ignite/visor/commands/top/Packet.scala      |    87 +
 .../commands/top/VisorTopologyCommand.scala     |   432 +
 .../ignite/visor/commands/vvm/Packet.scala      |    61 +
 .../visor/commands/vvm/VisorVvmCommand.scala    |   308 +
 .../scala/org/apache/ignite/visor/visor.scala   |  2676 ++++
 .../main/scala/org/gridgain/visor/Packet.scala  |    38 -
 .../gridgain/visor/commands/VisorConsole.scala  |   343 -
 .../visor/commands/VisorConsoleCommand.scala    |    78 -
 .../visor/commands/VisorTextTable.scala         |   540 -
 .../gridgain/visor/commands/ack/Packet.scala    |    55 -
 .../visor/commands/ack/VisorAckCommand.scala    |   162 -
 .../gridgain/visor/commands/alert/Packet.scala  |   108 -
 .../commands/alert/VisorAlertCommand.scala      |   839 --
 .../gridgain/visor/commands/cache/Packet.scala  |   127 -
 .../commands/cache/VisorCacheClearCommand.scala |   150 -
 .../commands/cache/VisorCacheCommand.scala      |   893 --
 .../cache/VisorCacheCompactCommand.scala        |   150 -
 .../commands/cache/VisorCacheScanCommand.scala  |   236 -
 .../commands/cache/VisorCacheSwapCommand.scala  |   150 -
 .../gridgain/visor/commands/config/Packet.scala |    55 -
 .../config/VisorConfigurationCommand.scala      |   500 -
 .../gridgain/visor/commands/deploy/Packet.scala |    76 -
 .../commands/deploy/VisorDeployCommand.scala    |   611 -
 .../gridgain/visor/commands/disco/Packet.scala  |    72 -
 .../commands/disco/VisorDiscoveryCommand.scala  |   305 -
 .../gridgain/visor/commands/events/Packet.scala |    97 -
 .../commands/events/VisorEventsCommand.scala    |   529 -
 .../org/gridgain/visor/commands/gc/Packet.scala |    61 -
 .../visor/commands/gc/VisorGcCommand.scala      |   244 -
 .../gridgain/visor/commands/ggcube_128x128.png  |   Bin 11444 -> 0 bytes
 .../gridgain/visor/commands/ggcube_48x48.png    |   Bin 3365 -> 0 bytes
 .../gridgain/visor/commands/kill/Packet.scala   |    78 -
 .../visor/commands/kill/VisorKillCommand.scala  |   355 -
 .../gridgain/visor/commands/node/Packet.scala   |    60 -
 .../visor/commands/node/VisorNodeCommand.scala  |   340 -
 .../gridgain/visor/commands/ping/Packet.scala   |    50 -
 .../visor/commands/ping/VisorPingCommand.scala  |   228 -
 .../gridgain/visor/commands/start/Packet.scala  |    90 -
 .../commands/start/VisorStartCommand.scala      |   429 -
 .../gridgain/visor/commands/tasks/Packet.scala  |   116 -
 .../commands/tasks/VisorTasksCommand.scala      |  1487 --
 .../gridgain/visor/commands/top/Packet.scala    |    87 -
 .../commands/top/VisorTopologyCommand.scala     |   430 -
 .../gridgain/visor/commands/vvm/Packet.scala    |    61 -
 .../visor/commands/vvm/VisorVvmCommand.scala    |   306 -
 .../main/scala/org/gridgain/visor/visor.scala   |  2678 ----
 .../ignite/visor/VisorRuntimeBaseSpec.scala     |    75 +
 .../ignite/visor/VisorTextTableSpec.scala       |    44 +
 .../visor/commands/VisorArgListSpec.scala       |    72 +
 .../commands/VisorFileNameCompleterSpec.scala   |    58 +
 .../commands/ack/VisorAckCommandSpec.scala      |    40 +
 .../commands/alert/VisorAlertCommandSpec.scala  |   154 +
 .../cache/VisorCacheClearCommandSpec.scala      |   114 +
 .../commands/cache/VisorCacheCommandSpec.scala  |   102 +
 .../cache/VisorCacheCompactCommandSpec.scala    |   104 +
 .../config/VisorConfigurationCommandSpec.scala  |    51 +
 .../cswap/VisorCacheSwapCommandSpec.scala       |    91 +
 .../deploy/VisorDeployCommandSpec.scala         |    34 +
 .../disco/VisorDiscoveryCommandSpec.scala       |    86 +
 .../events/VisorEventsCommandSpec.scala         |    63 +
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    57 +
 .../commands/help/VisorHelpCommandSpec.scala    |    68 +
 .../commands/kill/VisorKillCommandSpec.scala    |    58 +
 .../commands/log/VisorLogCommandSpec.scala      |    32 +
 .../commands/mem/VisorMemoryCommandSpec.scala   |    75 +
 .../commands/node/VisorNodeCommandSpec.scala    |    42 +
 .../commands/open/VisorOpenCommandSpec.scala    |    40 +
 .../commands/ping/VisorPingCommandSpec.scala    |    38 +
 .../commands/start/VisorStartCommandSpec.scala  |   123 +
 .../commands/tasks/VisorTasksCommandSpec.scala  |   231 +
 .../commands/top/VisorTopologyCommandSpec.scala |    62 +
 .../commands/vvm/VisorVvmCommandSpec.scala      |    46 +
 .../testsuites/VisorConsoleSelfTestSuite.scala  |    95 +
 .../gridgain/visor/VisorRuntimeBaseSpec.scala   |    75 -
 .../org/gridgain/visor/VisorTextTableSpec.scala |    45 -
 .../visor/commands/VisorArgListSpec.scala       |    71 -
 .../commands/VisorFileNameCompleterSpec.scala   |    58 -
 .../commands/ack/VisorAckCommandSpec.scala      |    40 -
 .../commands/alert/VisorAlertCommandSpec.scala  |   154 -
 .../cache/VisorCacheClearCommandSpec.scala      |   114 -
 .../commands/cache/VisorCacheCommandSpec.scala  |   103 -
 .../cache/VisorCacheCompactCommandSpec.scala    |   104 -
 .../config/VisorConfigurationCommandSpec.scala  |    51 -
 .../cswap/VisorCacheSwapCommandSpec.scala       |    91 -
 .../deploy/VisorDeployCommandSpec.scala         |    34 -
 .../disco/VisorDiscoveryCommandSpec.scala       |    86 -
 .../events/VisorEventsCommandSpec.scala         |    63 -
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    57 -
 .../commands/help/VisorHelpCommandSpec.scala    |    69 -
 .../commands/kill/VisorKillCommandSpec.scala    |    58 -
 .../commands/log/VisorLogCommandSpec.scala      |    33 -
 .../commands/mem/VisorMemoryCommandSpec.scala   |    76 -
 .../commands/node/VisorNodeCommandSpec.scala    |    42 -
 .../commands/open/VisorOpenCommandSpec.scala    |    41 -
 .../commands/ping/VisorPingCommandSpec.scala    |    38 -
 .../commands/start/VisorStartCommandSpec.scala  |   123 -
 .../commands/tasks/VisorTasksCommandSpec.scala  |   231 -
 .../commands/top/VisorTopologyCommandSpec.scala |    62 -
 .../commands/vvm/VisorVvmCommandSpec.scala      |    46 -
 .../testsuites/VisorConsoleSelfTestSuite.scala  |    97 -
 .../visor/plugin/VisorExtensionPoint.java       |    75 +
 .../ignite/visor/plugin/VisorPluggableTab.java  |    63 +
 .../apache/ignite/visor/plugin/VisorPlugin.java |    45 +
 .../visor/plugin/VisorPluginComponent.java      |    30 +
 .../plugin/VisorPluginComponentsFactory.java    |    49 +
 .../visor/plugin/VisorPluginLogPanel.java       |    26 +
 .../ignite/visor/plugin/VisorPluginModel.java   |    97 +
 .../visor/plugin/VisorPluginNodesPanel.java     |    48 +
 .../visor/plugin/VisorSelectionListener.java    |    32 +
 .../visor/plugin/VisorTopologyListener.java     |    53 +
 .../org/apache/ignite/visor/plugin/package.html |    23 +
 .../visor/plugin/VisorExtensionPoint.java       |    75 -
 .../visor/plugin/VisorPluggableTab.java         |    63 -
 .../org/gridgain/visor/plugin/VisorPlugin.java  |    45 -
 .../visor/plugin/VisorPluginComponent.java      |    30 -
 .../plugin/VisorPluginComponentsFactory.java    |    49 -
 .../visor/plugin/VisorPluginLogPanel.java       |    26 -
 .../gridgain/visor/plugin/VisorPluginModel.java |    97 -
 .../visor/plugin/VisorPluginNodesPanel.java     |    48 -
 .../visor/plugin/VisorSelectionListener.java    |    32 -
 .../visor/plugin/VisorTopologyListener.java     |    53 -
 .../java/org/gridgain/visor/plugin/package.html |    23 -
 .../ignite/cache/websession/GridWebSession.java |   286 +
 .../cache/websession/GridWebSessionFilter.java  |   465 +
 .../websession/GridWebSessionListener.java      |   195 +
 .../apache/ignite/cache/websession/package.html |    24 +
 .../GridServletContextListenerStartup.java      |   181 +
 .../startup/servlet/GridServletStartup.java     |   187 +
 .../apache/ignite/startup/servlet/package.html  |    23 +
 .../grid/cache/websession/GridWebSession.java   |   286 -
 .../cache/websession/GridWebSessionFilter.java  |   467 -
 .../websession/GridWebSessionListener.java      |   195 -
 .../gridgain/grid/cache/websession/package.html |    24 -
 .../GridServletContextListenerStartup.java      |   182 -
 .../startup/servlet/GridServletStartup.java     |   188 -
 .../gridgain/grid/startup/servlet/package.html  |    23 -
 .../IgniteWebSessionSelfTestSuite.java          |    65 +
 .../internal/websession/WebSessionSelfTest.java |   327 +
 .../websession/WebSessionServerStart.java       |   130 +
 .../internal/websession/WebSessionTest.java     |    62 +
 .../websession/GridWebSessionSelfTest.java      |   327 -
 .../websession/GridWebSessionSelfTestSuite.java |    65 -
 .../websession/GridWebSessionServerStart.java   |   130 -
 .../kernal/websession/GridWebSessionTest.java   |    62 -
 pom.xml                                         |    45 +-
 7207 files changed, 788004 insertions(+), 789047 deletions(-)
----------------------------------------------------------------------



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

Posted by sb...@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-121-logging
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
----------------------------------------------------------------------


[08/45] incubator-ignite git commit: #IGNITE-86: wip

Posted by sb...@apache.org.
#IGNITE-86:  wip


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

Branch: refs/heads/ignite-121-logging
Commit: 42d94fe229477d9048d9b389a2472ff6f6ff2596
Parents: 5819493
Author: ivasilinets <iv...@gridgain.com>
Authored: Fri Jan 23 15:48:07 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Fri Jan 23 15:48:07 2015 +0300

----------------------------------------------------------------------
 .../cache/GridCacheDeploymentManager.java       | 141 ++++++++++---------
 .../cache/GridCachePreloaderAdapter.java        |   2 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   2 +-
 3 files changed, 74 insertions(+), 71 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/42d94fe2/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
index 39d998e..5d9759f 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCacheDeploymentManager.java
@@ -53,7 +53,8 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     private volatile ClassLoader globalLdr;
 
     /** Undeploys. */
-    private final ConcurrentLinkedQueue<CA> undeploys = new ConcurrentLinkedQueue<>();
+    private final ConcurrentHashMap8<GridCacheContext, ConcurrentLinkedQueue<CA>> undeploys
+        = new ConcurrentHashMap8<>();
 
     /** Per-thread deployment context. */
     private ConcurrentMap<IgniteUuid, CachedDeploymentInfo<K, V>> deps =
@@ -178,10 +179,10 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     /**
      * Undeploy all queued up closures.
      */
-    public void unwind() {
+    public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
-        for (CA c = undeploys.poll(); c != null; c = undeploys.poll()) {
+        for (CA c = undeploys.get(ctx).poll(); c != null; c = undeploys.get(ctx).poll()) {
             c.apply();
 
             cnt++;
@@ -202,11 +203,16 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
         if (log.isDebugEnabled())
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
-        undeploys.add(new CA() {
-            @Override public void apply() {
-                onUndeploy0(ldr);
-            }
-        });
+        for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
+            undeploys.putIfAbsent(cacheCtx, new ConcurrentLinkedQueue<CA>());
+
+            undeploys.get(cacheCtx).add(new CA() {
+                @Override
+                public void apply() {
+                    onUndeploy0(ldr, cacheCtx);
+                }
+            });
+        }
 
         for (GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
             // Unwind immediately for local and replicate caches.
@@ -219,86 +225,83 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     /**
      * @param ldr Loader.
      */
-    private void onUndeploy0(final ClassLoader ldr) {
-        for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            GridCacheAdapter<K, V> cache = cacheCtx.cache();
-
-            Set<K> keySet = cache.keySet(cacheCtx.vararg(
-                new P1<GridCacheEntry<K, V>>() {
-                    @Override public boolean apply(GridCacheEntry<K, V> e) {
-                        return cacheCtx.isNear() ? undeploy(e, cacheCtx.near()) || undeploy(e, cacheCtx.near().dht()) :
-                            undeploy(e, cacheCtx.cache());
-                    }
-
-                    /**
-                     * @param e Entry.
-                     * @param cache Cache.
-                     * @return {@code True} if entry should be undeployed.
-                     */
-                    private boolean undeploy(GridCacheEntry<K, V> e, GridCacheAdapter<K, V> cache) {
-                        K k = e.getKey();
+    private void onUndeploy0(final ClassLoader ldr, final GridCacheContext<K, V> cacheCtx) {
+        GridCacheAdapter<K, V> cache = cacheCtx.cache();
+
+        Set<K> keySet = cache.keySet(cacheCtx.vararg(
+            new P1<GridCacheEntry<K, V>>() {
+                @Override public boolean apply(GridCacheEntry<K, V> e) {
+                    return cacheCtx.isNear() ? undeploy(e, cacheCtx.near()) || undeploy(e, cacheCtx.near().dht()) :
+                        undeploy(e, cacheCtx.cache());
+                }
 
-                        GridCacheEntryEx<K, V> entry = cache.peekEx(e.getKey());
+                /**
+                 * @param e Entry.
+                 * @param cache Cache.
+                 * @return {@code True} if entry should be undeployed.
+                 */
+                private boolean undeploy(GridCacheEntry<K, V> e, GridCacheAdapter<K, V> cache) {
+                    K k = e.getKey();
 
-                        if (entry == null)
-                            return false;
+                    GridCacheEntryEx<K, V> entry = cache.peekEx(e.getKey());
 
-                        V v;
+                    if (entry == null)
+                        return false;
 
-                        try {
-                            v = entry.peek(GridCachePeekMode.GLOBAL, CU.<K, V>empty());
-                        }
-                        catch (GridCacheEntryRemovedException ignore) {
-                            return false;
-                        }
-                        catch (IgniteException ignore) {
-                            // Peek can throw runtime exception if unmarshalling failed.
-                            return true;
-                        }
+                    V v;
 
-                        assert k != null : "Key cannot be null for cache entry: " + e;
+                    try {
+                        v = entry.peek(GridCachePeekMode.GLOBAL, CU.<K, V>empty());
+                    }
+                    catch (GridCacheEntryRemovedException ignore) {
+                        return false;
+                    }
+                    catch (IgniteException ignore) {
+                        // Peek can throw runtime exception if unmarshalling failed.
+                        return true;
+                    }
 
-                        ClassLoader keyLdr = U.detectObjectClassLoader(k);
-                        ClassLoader valLdr = U.detectObjectClassLoader(v);
+                    assert k != null : "Key cannot be null for cache entry: " + e;
 
-                        boolean res = F.eq(ldr, keyLdr) || F.eq(ldr, valLdr);
+                    ClassLoader keyLdr = U.detectObjectClassLoader(k);
+                    ClassLoader valLdr = U.detectObjectClassLoader(v);
 
-                        if (log.isDebugEnabled())
-                            log.debug("Finished examining entry [entryCls=" + e.getClass() +
-                                ", key=" + k + ", keyCls=" + k.getClass() +
-                                ", valCls=" + (v != null ? v.getClass() : "null") +
-                                ", keyLdr=" + keyLdr + ", valLdr=" + valLdr + ", res=" + res + ']');
+                    boolean res = F.eq(ldr, keyLdr) || F.eq(ldr, valLdr);
 
-                        return res;
-                    }
-                }));
+                    if (log.isDebugEnabled())
+                        log.debug("Finished examining entry [entryCls=" + e.getClass() +
+                            ", key=" + k + ", keyCls=" + k.getClass() +
+                            ", valCls=" + (v != null ? v.getClass() : "null") +
+                            ", keyLdr=" + keyLdr + ", valLdr=" + valLdr + ", res=" + res + ']');
 
-            Collection<K> keys = new ArrayList<>();
+                    return res;
+                }
+            }));
 
-            for (K k : keySet)
-                keys.add(k);
+        Collection<K> keys = new ArrayList<>();
 
-            if (log.isDebugEnabled())
-                log.debug("Finished searching keys for undeploy [keysCnt=" + keys.size() + ']');
+        for (K k : keySet)
+            keys.add(k);
 
-            cache.clearAll(keys, true);
+        if (log.isDebugEnabled())
+            log.debug("Finished searching keys for undeploy [keysCnt=" + keys.size() + ']');
 
-            if (cacheCtx.isNear())
-                cacheCtx.near().dht().clearAll(keys, true);
+        cache.clearAll(keys, true);
 
-            GridCacheQueryManager<K, V> qryMgr = cacheCtx.queries();
+        if (cacheCtx.isNear())
+            cacheCtx.near().dht().clearAll(keys, true);
 
-            if (qryMgr != null)
-                qryMgr.onUndeploy(ldr);
+        GridCacheQueryManager<K, V> qryMgr = cacheCtx.queries();
 
-            // Examine swap for entries to undeploy.
-            int swapUndeployCnt = cacheCtx.isNear() ?
-                cacheCtx.near().dht().context().swap().onUndeploy(ldr) :
-                cacheCtx.swap().onUndeploy(ldr);
+        if (qryMgr != null)
+            qryMgr.onUndeploy(ldr);
 
-            if (cacheCtx.system())
-                continue;
+        // Examine swap for entries to undeploy.
+        int swapUndeployCnt = cacheCtx.isNear() ?
+            cacheCtx.near().dht().context().swap().onUndeploy(ldr) :
+            cacheCtx.swap().onUndeploy(ldr);
 
+        if (!cacheCtx.system()) {
             U.quietAndWarn(log, "");
             U.quietAndWarn(
                 log,

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/42d94fe2/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePreloaderAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePreloaderAdapter.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePreloaderAdapter.java
index 950092e..e574ab6 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePreloaderAdapter.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/GridCachePreloaderAdapter.java
@@ -107,7 +107,7 @@ public class GridCachePreloaderAdapter<K, V> implements GridCachePreloader<K, V>
 
     /** {@inheritDoc} */
     @Override public void unwindUndeploys() {
-        cctx.deploy().unwind();
+        cctx.deploy().unwind(cctx);
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/42d94fe2/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
index 7bbf102..f347450 100644
--- a/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
+++ b/modules/core/src/main/java/org/gridgain/grid/kernal/processors/cache/distributed/dht/preloader/GridDhtPartitionDemandPool.java
@@ -391,7 +391,7 @@ public class GridDhtPartitionDemandPool<K, V> {
         demandLock.writeLock().lock();
 
         try {
-            cctx.deploy().unwind();
+            cctx.deploy().unwind(cctx);
         }
         finally {
             demandLock.writeLock().unlock();


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

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

Branch: refs/heads/ignite-121-logging
Commit: fd1e80a6e3cbef9704c36c41ecfbf551725f8bba
Parents: c7db90e f8ecd87
Author: ivasilinets <iv...@gridgain.com>
Authored: Thu Jan 22 14:07:14 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Thu Jan 22 14:07:14 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/IgniteCluster.java   |  15 ++-
 .../java/org/apache/ignite/IgniteEvents.java    |  22 +++-
 .../main/java/org/apache/ignite/IgniteFs.java   |   5 +
 .../java/org/apache/ignite/IgniteManaged.java   |  18 ++-
 .../java/org/apache/ignite/IgniteMessaging.java |   5 +-
 .../cache/IgniteCacheInvokeReadThroughTest.java | 121 +++++++++++++++++++
 .../cache/GridCacheAbstractFullApiSelfTest.java |   4 +-
 .../bamboo/GridDataGridTestSuite.java           |   3 +
 8 files changed, 178 insertions(+), 15 deletions(-)
----------------------------------------------------------------------



[02/45] incubator-ignite git commit: Merge branches 'ignite-86' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-86

Posted by sb...@apache.org.
Merge branches 'ignite-86' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite 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/173726f9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/173726f9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/173726f9

Branch: refs/heads/ignite-121-logging
Commit: 173726f926a085660b4c3af466ad107ad47249ca
Parents: edf0b18 e466b24
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Wed Jan 21 20:34:08 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Wed Jan 21 20:34:08 2015 +0300

----------------------------------------------------------------------
 assembly/release-base.xml                       |   2 +-
 docs/core-site.gridgain.xml                     |  21 ++
 .../main/java/org/apache/ignite/CacheLock.java  |  86 -----
 .../java/org/apache/ignite/IgniteCache.java     |   1 -
 .../java/org/apache/ignite/cache/CacheFlag.java |   3 -
 .../java/org/apache/ignite/cache/CacheLock.java |  57 ++++
 .../cache/CachePartialUpdateException.java      |  22 +-
 .../processors/cache/CacheLockImpl.java         | 150 +++++++++
 .../processors/cache/IgniteCacheProxy.java      | 104 +-----
 .../grid/cache/GridCacheConfiguration.java      |  32 ++
 .../org/gridgain/grid/cache/GridCacheFlag.java  |   3 -
 .../processors/cache/CacheInvokeEntry.java      |  22 +-
 .../processors/cache/CacheInvokeResult.java     |  22 +-
 .../processors/cache/GridCacheAdapter.java      |   8 +-
 .../cache/IgniteCacheExpiryPolicy.java          |  22 +-
 .../distributed/GridCacheTtlUpdateRequest.java  |  22 +-
 .../IgniteExternalizableExpiryPolicy.java       |  22 +-
 .../cache/IgniteCacheAbstractTest.java          |  22 +-
 .../cache/IgniteCacheAtomicInvokeTest.java      |  22 +-
 .../cache/IgniteCacheAtomicLocalInvokeTest.java |  22 +-
 ...niteCacheAtomicLocalWithStoreInvokeTest.java |  22 +-
 .../IgniteCacheAtomicNearEnabledInvokeTest.java |  22 +-
 ...eCacheAtomicPrimaryWriteOrderInvokeTest.java |  22 +-
 ...micPrimaryWriteOrderWithStoreInvokeTest.java |  22 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |  22 +-
 .../cache/IgniteCacheTxInvokeTest.java          |  22 +-
 .../cache/IgniteCacheTxLocalInvokeTest.java     |  22 +-
 .../IgniteCacheTxNearEnabledInvokeTest.java     |  22 +-
 .../IgniteCacheAtomicExpiryPolicyTest.java      |  22 +-
 .../IgniteCacheAtomicLocalExpiryPolicyTest.java |  22 +-
 ...AtomicPrimaryWriteOrderExpiryPolicyTest.java |  22 +-
 ...maryWriteOrderWithStoreExpiryPolicyTest.java |  22 +-
 ...teCacheAtomicReplicatedExpiryPolicyTest.java |  22 +-
 ...iteCacheAtomicWithStoreExpiryPolicyTest.java |  22 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |  22 +-
 .../IgniteCacheExpiryPolicyTestSuite.java       |  22 +-
 .../expiry/IgniteCacheTxExpiryPolicyTest.java   |  22 +-
 .../IgniteCacheTxLocalExpiryPolicyTest.java     |  22 +-
 ...IgniteCacheTxReplicatedExpiryPolicyTest.java |  22 +-
 .../IgniteCacheTxWithStoreExpiryPolicyTest.java |  22 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  65 ++--
 .../GridCacheMultiNodeLockAbstractTest.java     | 137 +-------
 .../dht/GridCacheColocatedDebugTest.java        |  20 +-
 .../dht/GridCacheGlobalLoadTest.java            |  22 +-
 .../near/GridCachePartitionedLockSelfTest.java  |  23 +-
 ...idCachePartitionedMultiNodeLockSelfTest.java |  10 -
 .../GridCacheLocalMultithreadedSelfTest.java    | 135 +-------
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |  15 +-
 .../ggfs/GridGgfsAbstractSelfTest.java          |  20 +-
 .../ggfs/GridGgfsMetricsSelfTest.java           |  10 +-
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   6 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |  33 +-
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |   6 +-
 ...pcEndpointRegistrationOnWindowsSelfTest.java |   4 +-
 ...idIpcServerEndpointDeserializerSelfTest.java |  76 ++---
 .../testframework/GridGgfsTestUtils.java        |  55 ----
 .../counter/GridHadoopFSCounterWriter.java      |   4 +-
 .../counter/GridHadoopPerformanceCounter.java   |  18 +-
 .../v2/GridHadoopV2JobResourceManager.java      |  13 +-
 .../grid/ggfs/GridGgfsEventsTestSuite.java      |  26 +-
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |   9 +-
 ...doop20FileSystemLoopbackPrimarySelfTest.java |  11 +-
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |  11 +-
 .../GridGgfsHadoopDualAbstractSelfTest.java     |  19 +-
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |  15 +-
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   6 +-
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   7 +-
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   7 +-
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   7 +-
 ...adoopFileSystemLoopbackAbstractSelfTest.java |   9 +-
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |  12 +-
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |   7 +-
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |   7 +-
 .../grid/hadoop/GridHadoopTestUtils.java        |  20 +-
 .../hadoop/GridHadoopCommandLineTest.java       |   2 +-
 .../hadoop/GridHadoopMapReduceTest.java         |   5 +-
 .../grid/cache/spring/GridSpringCache.java      | 185 +++++++++++
 .../cache/spring/GridSpringCacheManager.java    | 190 ++---------
 .../spring/GridSpringDynamicCacheManager.java   | 316 +++++++++++++++++++
 .../spring/GridSpringCacheManagerSelfTest.java  |   2 +-
 .../GridSpringDynamicCacheManagerSelfTest.java  | 218 +++++++++++++
 .../GridSpringDynamicCacheTestService.java      |  62 ++++
 .../cache/spring/spring-dynamic-caching.xml     |  43 +++
 .../testsuites/bamboo/GridSpringTestSuite.java  |   1 +
 84 files changed, 1861 insertions(+), 1113 deletions(-)
----------------------------------------------------------------------



[26/45] incubator-ignite git commit: # IGNITE-102: Replace GridGain to Ignite.

Posted by sb...@apache.org.
# IGNITE-102: Replace GridGain to Ignite.


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

Branch: refs/heads/ignite-121-logging
Commit: c2c2e7ffa3d3e773880a0c2dd8928f031998b2fc
Parents: 786193f
Author: AKuznetsov <ak...@gridgain.com>
Authored: Wed Jan 28 16:21:32 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Wed Jan 28 16:21:32 2015 +0700

----------------------------------------------------------------------
 modules/yardstick/README.md                     |  2 +-
 .../config/benchmark-atomic-win.properties      |  4 ++--
 .../config/benchmark-atomic.properties          |  4 ++--
 .../config/benchmark-compute-win.properties     | 10 ++++----
 .../config/benchmark-compute.properties         | 10 ++++----
 .../config/benchmark-query-win.properties       |  6 ++---
 .../yardstick/config/benchmark-query.properties |  6 ++---
 .../config/benchmark-tx-win.properties          |  4 ++--
 .../yardstick/config/benchmark-tx.properties    |  4 ++--
 .../yardstick/config/benchmark-win.properties   | 14 ++++++------
 modules/yardstick/config/benchmark.properties   | 24 ++++++++++----------
 modules/yardstick/config/ignite-base-config.xml | 16 ++++++-------
 .../yardstick/IgniteAbstractBenchmark.java      |  2 +-
 .../yardstick/IgniteBenchmarkArguments.java     |  8 +++----
 .../org/apache/ignite/yardstick/IgniteNode.java |  4 ++--
 .../cache/IgniteCacheAbstractBenchmark.java     |  2 +-
 .../yardstick/cache/IgniteGetBenchmark.java     |  2 +-
 .../yardstick/cache/IgnitePutBenchmark.java     |  2 +-
 .../yardstick/cache/IgnitePutGetBenchmark.java  |  2 +-
 .../cache/IgnitePutGetTxBenchmark.java          |  2 +-
 .../yardstick/cache/IgnitePutTxBenchmark.java   |  2 +-
 .../cache/IgniteSqlQueryBenchmark.java          |  2 +-
 .../cache/IgniteSqlQueryJoinBenchmark.java      |  2 +-
 .../cache/IgniteSqlQueryPutBenchmark.java       |  2 +-
 .../compute/IgniteAffinityCallBenchmark.java    |  2 +-
 .../yardstick/compute/IgniteApplyBenchmark.java |  2 +-
 .../compute/IgniteBroadcastBenchmark.java       |  2 +-
 .../compute/IgniteExecuteBenchmark.java         |  2 +-
 .../yardstick/compute/IgniteRunBenchmark.java   |  2 +-
 29 files changed, 73 insertions(+), 73 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/README.md
----------------------------------------------------------------------
diff --git a/modules/yardstick/README.md b/modules/yardstick/README.md
index d2aebc0..660c453 100644
--- a/modules/yardstick/README.md
+++ b/modules/yardstick/README.md
@@ -37,7 +37,7 @@ The following Ignite benchmark properties can be defined in the benchmark config
 
 * `-nn <num>` or `--nodeNumber <num>` - Number of nodes (automatically set in `benchmark.properties`), used to wait for the specified number of nodes to start
 * `-b <num>` or `--backups <num>` - Number of backups for every key
-* `-ggcfg <path>` or `--ggConfig <path>` - Path to Ignite configuration file
+* `-cfg <path>` or `--Config <path>` - Path to Ignite configuration file
 * `-sm <mode>` or `-syncMode <mode>` - Synchronization mode (defined in `CacheWriteSynchronizationMode`)
 * `-dm <mode>` or `--distroMode <mode>` - Distribution mode (defined in `CacheDistributionMode`)
 * `-wom <mode>` or `--writeOrderMode <mode>` - Write order mode for ATOMIC caches (defined in `CacheAtomicWriteOrderMode`)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-atomic-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-atomic-win.properties b/modules/yardstick/config/benchmark-atomic-win.properties
index 96dde32..d816e62 100644
--- a/modules/yardstick/config/benchmark-atomic-win.properties
+++ b/modules/yardstick/config/benchmark-atomic-win.properties
@@ -38,5 +38,5 @@ set DRIVER_HOSTS=localhost
 :: Run configuration which contains all benchmarks.
 :: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 set CONFIGS=^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-atomic.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-atomic.properties b/modules/yardstick/config/benchmark-atomic.properties
index 1f93d5c..aaa9946 100644
--- a/modules/yardstick/config/benchmark-atomic.properties
+++ b/modules/yardstick/config/benchmark-atomic.properties
@@ -43,6 +43,6 @@ nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS}
 # Run configuration.
 # Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 CONFIGS="\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup\
 "

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-compute-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-compute-win.properties b/modules/yardstick/config/benchmark-compute-win.properties
index 35e8873..5c41110 100644
--- a/modules/yardstick/config/benchmark-compute-win.properties
+++ b/modules/yardstick/config/benchmark-compute-win.properties
@@ -38,8 +38,8 @@ set DRIVER_HOSTS=localhost
 :: Run configuration which contains all benchmarks.
 :: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 set CONFIGS=^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 1 -d 30 -t 1 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-compute.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-compute.properties b/modules/yardstick/config/benchmark-compute.properties
index 1f38eb6..45aadcb 100644
--- a/modules/yardstick/config/benchmark-compute.properties
+++ b/modules/yardstick/config/benchmark-compute.properties
@@ -43,9 +43,9 @@ nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS}
 # Run configuration.
 # Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 CONFIGS="\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup\
 "

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-query-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query-win.properties b/modules/yardstick/config/benchmark-query-win.properties
index a2c102c..6164038 100644
--- a/modules/yardstick/config/benchmark-query-win.properties
+++ b/modules/yardstick/config/benchmark-query-win.properties
@@ -38,6 +38,6 @@ set DRIVER_HOSTS=localhost
 :: Run configuration which contains all benchmarks.
 :: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 set CONFIGS=^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-query.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-query.properties b/modules/yardstick/config/benchmark-query.properties
index c3e7a6e..18440af 100644
--- a/modules/yardstick/config/benchmark-query.properties
+++ b/modules/yardstick/config/benchmark-query.properties
@@ -43,7 +43,7 @@ nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS}
 # Run configuration.
 # Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 CONFIGS="\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup\
 "

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-tx-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-tx-win.properties b/modules/yardstick/config/benchmark-tx-win.properties
index 7b12202..9d01d47 100644
--- a/modules/yardstick/config/benchmark-tx-win.properties
+++ b/modules/yardstick/config/benchmark-tx-win.properties
@@ -38,5 +38,5 @@ set DRIVER_HOSTS=localhost
 :: Run configuration which contains all benchmarks.
 :: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 set CONFIGS=^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-tx.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-tx.properties b/modules/yardstick/config/benchmark-tx.properties
index c3d69f2..2f22f65 100644
--- a/modules/yardstick/config/benchmark-tx.properties
+++ b/modules/yardstick/config/benchmark-tx.properties
@@ -43,6 +43,6 @@ nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS}
 # Run configuration.
 # Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 CONFIGS="\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup\
 "

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark-win.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark-win.properties b/modules/yardstick/config/benchmark-win.properties
index 00a3c17..740a132 100644
--- a/modules/yardstick/config/benchmark-win.properties
+++ b/modules/yardstick/config/benchmark-win.properties
@@ -41,10 +41,10 @@ set DRIVER_HOSTS=localhost
 :: Run configuration which contains all benchmarks.
 :: Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 set CONFIGS=^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,^
--ggcfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,^
+-cfg %SCRIPT_DIR%\..\config\ignite-localhost-config.xml -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/benchmark.properties
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/benchmark.properties b/modules/yardstick/config/benchmark.properties
index 034eb46..b731953 100644
--- a/modules/yardstick/config/benchmark.properties
+++ b/modules/yardstick/config/benchmark.properties
@@ -46,16 +46,16 @@ nodesNum=$((`echo ${SERVER_HOSTS} | tr ',' '\n' | wc -l` + `echo ${DRIVER_HOSTS}
 # Run configuration which contains all benchmarks.
 # Note that each benchmark is set to run for 300 seconds (5 mins) with warm-up set to 60 seconds (1 minute).
 CONFIGS="\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,\
--ggcfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutBenchmark -sn IgniteNode -ds atomic-put-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetBenchmark -sn IgniteNode -ds atomic-put-get-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutTxBenchmark -sn IgniteNode -ds tx-put-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgnitePutGetTxBenchmark -sn IgniteNode -ds tx-put-get-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryBenchmark -sn IgniteNode -ds sql-query-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryJoinBenchmark -sn IgniteNode -ds sql-query-join-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -dn IgniteSqlQueryPutBenchmark -sn IgniteNode -ds sql-query-put-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteAffinityCallBenchmark -sn IgniteNode -ds affcall-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteApplyBenchmark -sn IgniteNode -ds apply-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteBroadcastBenchmark -sn IgniteNode -ds broad-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteExecuteBenchmark -sn IgniteNode -ds exec-compute-1-backup,\
+-cfg ${SCRIPT_DIR}/../config/ignite-localhost-config.xml -nn ${nodesNum} -b 1 -w 60 -d 300 -t 64 -sm PRIMARY_SYNC -j 10 -dn IgniteRunBenchmark -sn IgniteNode -ds run-compute-1-backup\
 "

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/config/ignite-base-config.xml
----------------------------------------------------------------------
diff --git a/modules/yardstick/config/ignite-base-config.xml b/modules/yardstick/config/ignite-base-config.xml
index 16d0a70..c92f630 100644
--- a/modules/yardstick/config/ignite-base-config.xml
+++ b/modules/yardstick/config/ignite-base-config.xml
@@ -28,17 +28,17 @@
         <property name="peerClassLoadingEnabled" value="false"/>
 
         <!--property name="marshaller">
-            <bean class="org.gridgain.grid.marshaller.optimized.GridOptimizedMarshaller">
+            <bean class="org.apache.ignite.marshaller.optimized.IgniteOptimizedMarshaller">
                 <property name="requireSerializable" value="true"/>
                 <property name="classNames">
                     <list>
-                        <value>org.yardstickframework.gridgain.cache.model.SampleValue</value>
-                        <value>org.yardstickframework.gridgain.cache.model.Person</value>
-                        <value>org.yardstickframework.gridgain.cache.model.Organization</value>
-                        <value>org.yardstickframework.gridgain.compute.model.NoopTask$NoopJob</value>
-                        <value>org.yardstickframework.gridgain.compute.model.NoopCallable</value>
-                        <value>org.yardstickframework.gridgain.compute.GridGainRunBenchmark$NoopRunnable</value>
-                        <value>org.yardstickframework.gridgain.compute.GridGainApplyBenchmark$NoopClosure</value>
+                        <value>org.apache.ignite.yardstick.cache.model.SampleValue</value>
+                        <value>org.apache.ignite.yardstick.cache.model.Person</value>
+                        <value>org.apache.ignite.yardstick.cache.model.Organization</value>
+                        <value>org.apache.ignite.yardstick.compute.model.NoopTask$NoopJob</value>
+                        <value>org.apache.ignite.yardstick.compute.model.NoopCallable</value>
+                        <value>org.apache.ignite.yardstick.compute.IgniteRunBenchmark$NoopRunnable</value>
+                        <value>org.apache.ignite.yardstick.compute.IgniteApplyBenchmark$NoopClosure</value>
                     </list>
                 </property>
             </bean>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
index cca6935..6f9f903 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteAbstractBenchmark.java
@@ -29,7 +29,7 @@ import static org.apache.ignite.events.IgniteEventType.*;
 import static org.yardstickframework.BenchmarkUtils.*;
 
 /**
- * Abstract class for GridGain benchmarks.
+ * Abstract class for Ignite benchmarks.
  */
 public abstract class IgniteAbstractBenchmark extends BenchmarkDriverAdapter {
     /** Arguments. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
index ebcddf3..1204720 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/IgniteBenchmarkArguments.java
@@ -23,7 +23,7 @@ import org.apache.ignite.internal.util.tostring.*;
 import org.apache.ignite.transactions.*;
 
 /**
- * Input arguments for GridGain benchmarks.
+ * Input arguments for Ignite benchmarks.
  */
 @SuppressWarnings({"UnusedDeclaration", "FieldCanBeLocal"})
 public class IgniteBenchmarkArguments {
@@ -35,8 +35,8 @@ public class IgniteBenchmarkArguments {
     @Parameter(names = {"-b", "--backups"}, description = "Backups")
     private int backups;
 
-    @Parameter(names = {"-ggcfg", "--ggConfig"}, description = "Configuration file")
-    private String ggcfg = "config/gridgain-localhost-config.xml";
+    @Parameter(names = {"-cfg", "--Config"}, description = "Configuration file")
+    private String cfg = "config/ignite-localhost-config.xml";
 
     /** */
     @Parameter(names = {"-sm", "--syncMode"}, description = "Synchronization mode")
@@ -188,7 +188,7 @@ public class IgniteBenchmarkArguments {
      * @return Configuration file.
      */
     public String configuration() {
-        return ggcfg;
+        return cfg;
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/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 b80e7bf..ad71ca2 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
@@ -36,7 +36,7 @@ import static org.apache.ignite.cache.CacheDistributionMode.*;
 import static org.apache.ignite.cache.CacheMemoryMode.*;
 
 /**
- * Standalone GridGain node.
+ * Standalone Ignite node.
  */
 public class IgniteNode implements BenchmarkServer {
     /** Grid instance. */
@@ -73,7 +73,7 @@ public class IgniteNode implements BenchmarkServer {
 
         for (CacheConfiguration cc : c.getCacheConfiguration()) {
             // IgniteNode can not run in CLIENT_ONLY mode,
-            // except the case when it's used inside GridGainAbstractBenchmark.
+            // except the case when it's used inside IgniteAbstractBenchmark.
             CacheDistributionMode distroMode = args.distributionMode() == CLIENT_ONLY && !clientMode ?
                 PARTITIONED_ONLY : args.distributionMode();
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
index 636057c..7b3d202 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteCacheAbstractBenchmark.java
@@ -22,7 +22,7 @@ import org.apache.ignite.yardstick.*;
 import org.yardstickframework.*;
 
 /**
- * Abstract class for GridGain benchmarks which use cache.
+ * Abstract class for Ignite benchmarks which use cache.
  */
 public abstract class IgniteCacheAbstractBenchmark extends IgniteAbstractBenchmark {
     /** Cache. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
index 30a8eb5..783523b 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteGetBenchmark.java
@@ -22,7 +22,7 @@ import org.apache.ignite.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs get operations.
+ * Ignite benchmark that performs get operations.
  */
 public class IgniteGetBenchmark extends IgniteCacheAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
index 5136bde..ee55d57 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutBenchmark.java
@@ -23,7 +23,7 @@ import org.apache.ignite.yardstick.cache.model.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs put operations.
+ * Ignite benchmark that performs put operations.
  */
 public class IgnitePutBenchmark extends IgniteCacheAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
index 2b9fa02..73b183f 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetBenchmark.java
@@ -23,7 +23,7 @@ import org.apache.ignite.yardstick.cache.model.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs put and get operations.
+ * Ignite benchmark that performs put and get operations.
  */
 public class IgnitePutGetBenchmark extends IgniteCacheAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
index 30acb41..a274b5b 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
@@ -24,7 +24,7 @@ import org.apache.ignite.yardstick.cache.model.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs transactional put and get operations.
+ * Ignite benchmark that performs transactional put and get operations.
  */
 public class IgnitePutGetTxBenchmark extends IgniteCacheAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
index e1cefbc..1f92392 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutTxBenchmark.java
@@ -23,7 +23,7 @@ import org.apache.ignite.yardstick.cache.model.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs transactional put operations.
+ * Ignite benchmark that performs transactional put operations.
  */
 public class IgnitePutTxBenchmark extends IgniteCacheAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
index 38aa632..3bca3d6 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryBenchmark.java
@@ -28,7 +28,7 @@ import java.util.concurrent.*;
 import static org.yardstickframework.BenchmarkUtils.*;
 
 /**
- * GridGain benchmark that performs query operations.
+ * Ignite benchmark that performs query operations.
  */
 public class IgniteSqlQueryBenchmark extends IgniteCacheAbstractBenchmark {
     /** */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
index 7b4262b..5f8cc77 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryJoinBenchmark.java
@@ -28,7 +28,7 @@ import java.util.concurrent.*;
 import static org.yardstickframework.BenchmarkUtils.*;
 
 /**
- * GridGain benchmark that performs query operations with joins.
+ * Ignite benchmark that performs query operations with joins.
  */
 public class IgniteSqlQueryJoinBenchmark extends IgniteCacheAbstractBenchmark {
     /** */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
index 9d8ef4f..fcb8f2e 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgniteSqlQueryPutBenchmark.java
@@ -26,7 +26,7 @@ import java.util.*;
 import java.util.concurrent.*;
 
 /**
- * GridGain benchmark that performs put and query operations.
+ * Ignite benchmark that performs put and query operations.
  */
 public class IgniteSqlQueryPutBenchmark extends IgniteCacheAbstractBenchmark {
     /** */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
index 28ac816..7008d52 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteAffinityCallBenchmark.java
@@ -24,7 +24,7 @@ import java.util.*;
 import java.util.concurrent.*;
 
 /**
- * GridGain benchmark that performs affinity call operations.
+ * Ignite benchmark that performs affinity call operations.
  */
 public class IgniteAffinityCallBenchmark extends IgniteAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
index 0b40cdd..816d0d0 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteApplyBenchmark.java
@@ -25,7 +25,7 @@ import java.io.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs apply operations.
+ * Ignite benchmark that performs apply operations.
  */
 public class IgniteApplyBenchmark extends IgniteAbstractBenchmark {
     /** Args for apply. */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
index 0e37efa..1be6c44 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteBroadcastBenchmark.java
@@ -23,7 +23,7 @@ import org.apache.ignite.yardstick.compute.model.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs broadcast operations.
+ * Ignite benchmark that performs broadcast operations.
  */
 public class IgniteBroadcastBenchmark extends IgniteAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
index 4fc4530..125ea6a 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteExecuteBenchmark.java
@@ -23,7 +23,7 @@ import org.apache.ignite.yardstick.compute.model.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs execute operations.
+ * Ignite benchmark that performs execute operations.
  */
 public class IgniteExecuteBenchmark extends IgniteAbstractBenchmark {
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/c2c2e7ff/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
index d0ca63e..b9b43b3 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/compute/IgniteRunBenchmark.java
@@ -24,7 +24,7 @@ import java.io.*;
 import java.util.*;
 
 /**
- * GridGain benchmark that performs run operations.
+ * Ignite benchmark that performs run operations.
  */
 public class IgniteRunBenchmark extends IgniteAbstractBenchmark {
     /** Jobs for run */


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

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

Branch: refs/heads/ignite-121-logging
Commit: ff5c7a4e6f1dc259438db17bac0c73409f528cb3
Parents: 4b690fc b4da38a
Author: ivasilinets <iv...@gridgain.com>
Authored: Tue Jan 27 15:57:17 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Tue Jan 27 15:57:17 2015 +0300

----------------------------------------------------------------------
 examples/config/example-cache.xml               |   9 +-
 examples/config/example-compute.xml             |   9 +-
 examples/config/example-streamer.xml            |   9 +-
 examples/config/filesystem/example-ggfs.xml     |   9 +-
 .../examples/misc/springbean/spring-bean.xml    |   9 +-
 .../examples/ScalarStartStopExample.scala       |  73 ---
 .../examples/IgniteFsExamplesSelfTest.java      |  26 +-
 .../tests/examples/ScalarExamplesSelfTest.scala |   5 -
 .../apache/ignite/IgniteNotPeerDeployable.java  |  41 --
 .../org/apache/ignite/internal/GridGainEx.java  |   2 +-
 .../ignite/internal/GridJobExecuteRequest.java  |  95 +--
 .../internal/GridJobExecuteRequestV2.java       | 185 ------
 .../managers/communication/GridIoManager.java   | 563 ++++++-----------
 .../managers/communication/GridIoMessage.java   |  53 +-
 .../processors/cache/GridCacheAdapter.java      |   4 +-
 .../processors/cache/GridCacheIoManager.java    |  22 +-
 .../processors/cache/GridCacheVersionEx.java    |   9 +
 .../preloader/GridDhtPartitionDemandPool.java   |  24 +-
 .../preloader/GridDhtPartitionSupplyPool.java   |  10 +-
 .../query/GridCacheDistributedQueryManager.java |  23 -
 .../GridCacheContinuousQueryManager.java        |  11 -
 .../closure/GridClosureProcessor.java           | 624 ++++++++++++++-----
 .../GridMasterLeaveAwareComputeJobAdapter.java  |  36 --
 .../continuous/GridContinuousProcessor.java     |   1 -
 .../processors/job/GridJobProcessor.java        |   9 -
 .../internal/processors/job/GridJobWorker.java  |   6 -
 .../processors/resource/GridResourceUtils.java  |   4 +-
 .../processors/task/GridTaskProcessor.java      |  15 +-
 .../processors/task/GridTaskWorker.java         |  57 +-
 .../GridTcpCommunicationMessageFactory.java     |   5 +-
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |   3 +-
 .../ignite/lang/IgniteNotPeerDeployable.java    |  41 ++
 .../ignite/startup/BasicWarmupClosure.java      | 561 +++++++++++++++++
 modules/core/src/test/config/ggfs-loopback.xml  |  41 +-
 .../core/src/test/config/ggfs-no-endpoint.xml   | 199 ------
 modules/core/src/test/config/ggfs-shmem.xml     |  41 +-
 .../communication/GridIoManagerSelfTest.java    |   2 +-
 .../cache/GridCacheVersionSelfTest.java         |  23 +-
 .../GridCacheSyncReplicatedPreloadSelfTest.java |   1 -
 .../ignite/session/GridSessionLoadSelfTest.java |  11 +-
 .../test/resources/spring-ping-pong-partner.xml |  38 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 42 files changed, 1476 insertions(+), 1435 deletions(-)
----------------------------------------------------------------------


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

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


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

Posted by sb...@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/786193fe
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/786193fe
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/786193fe

Branch: refs/heads/ignite-121-logging
Commit: 786193fead9e530f60eeda0f1a898b5d2970f536
Parents: aee11a0 d97965b
Author: AKuznetsov <ak...@gridgain.com>
Authored: Wed Jan 28 16:08:47 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Wed Jan 28 16:08:47 2015 +0700

----------------------------------------------------------------------
 .../java/org/apache/ignite/cache/CacheManager.java | 10 +++++++++-
 .../org/apache/ignite/IgniteCacheAffinityTest.java | 17 +++++++++++++++++
 .../ignite/testsuites/IgniteCacheTestSuite.java    |  1 +
 3 files changed, 27 insertions(+), 1 deletion(-)
----------------------------------------------------------------------



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

Posted by sb...@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-121-logging
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 +


[40/45] incubator-ignite git commit: Merge branch 'sprint-1' into ignite-16

Posted by sb...@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-121-logging
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
----------------------------------------------------------------------


[33/45] incubator-ignite git commit: #ignite-16: WIP.

Posted by sb...@apache.org.
#ignite-16: WIP.


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

Branch: refs/heads/ignite-121-logging
Commit: d0444b79c5028074128f56f555b0414041dc878d
Parents: 9ea9607
Author: vozerov-gridgain <vo...@gridgain.com>
Authored: Fri Jan 30 17:05:00 2015 +0300
Committer: vozerov-gridgain <vo...@gridgain.com>
Committed: Fri Jan 30 17:05:00 2015 +0300

----------------------------------------------------------------------
 .../configuration/IgniteConfiguration.java      |  22 ----
 .../ignite/internal/GridKernalContext.java      |   8 --
 .../ignite/internal/GridKernalContextImpl.java  |  12 --
 .../org/apache/ignite/internal/IgniteEx.java    |   8 --
 .../apache/ignite/internal/IgniteKernal.java    |   7 --
 .../org/apache/ignite/internal/IgnitionEx.java  |   1 -
 .../processors/cache/GridCacheStoreManager.java |   1 -
 .../cache/GridCacheWriteBehindStore.java        |   1 -
 .../processors/interop/GridInteropAware.java    |  49 ---------
 .../interop/GridInteropProcessor.java           |  82 --------------
 .../interop/GridInteropProcessorAdapter.java    |  31 ------
 .../processors/interop/GridInteropTarget.java   | 109 -------------------
 .../interop/os/GridOsInteropProcessor.java      |  80 --------------
 .../internal/processors/interop/os/package.html |  23 ----
 .../internal/processors/interop/package.html    |  23 ----
 .../plugin/IgnitePluginProcessor.java           |  10 +-
 16 files changed, 6 insertions(+), 461 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
index 778ca62..e6d513b 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/IgniteConfiguration.java
@@ -389,9 +389,6 @@ public class IgniteConfiguration {
     /** Transactions configuration. */
     private TransactionsConfiguration txCfg = new TransactionsConfiguration();
 
-    /** Interop configuration. */
-    private InteropConfiguration interopCfg;
-
     /** */
     private Collection<? extends PluginConfiguration> pluginCfgs;
 
@@ -585,7 +582,6 @@ public class IgniteConfiguration {
         hadoopCfg = cfg.getHadoopConfiguration();
         inclEvtTypes = cfg.getIncludeEventTypes();
         includeProps = cfg.getIncludeProperties();
-        interopCfg = cfg.getInteropConfiguration() != null ? cfg.getInteropConfiguration().copy() : null;
         jettyPath = cfg.getRestJettyPath();
         licUrl = cfg.getLicenseUrl();
         lifecycleBeans = cfg.getLifecycleBeans();
@@ -3117,24 +3113,6 @@ public class IgniteConfiguration {
     }
 
     /**
-     * Gets interop configuration.
-     *
-     * @return Interop configuration.
-     */
-    @Nullable public InteropConfiguration getInteropConfiguration() {
-        return interopCfg;
-    }
-
-    /**
-     * Sets interop configuration.
-     *
-     * @param interopCfg Interop configuration.
-     */
-    public void setInteropConfiguration(@Nullable InteropConfiguration interopCfg) {
-        this.interopCfg = interopCfg;
-    }
-
-    /**
      * Gets transactions configuration.
      *
      * @return Transactions configuration.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
index 17f3ec8..58923b6 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContext.java
@@ -43,7 +43,6 @@ 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.hadoop.*;
-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.*;
@@ -330,13 +329,6 @@ public interface GridKernalContext extends Iterable<GridComponent> {
     public GridPortableProcessor portable();
 
     /**
-     * Gets interop processor.
-     *
-     * @return Interop processor.
-     */
-    public GridInteropProcessor interop();
-
-    /**
      * Gets query processor.
      *
      * @return Query processor.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
index 88dbef6..13eb341 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/GridKernalContextImpl.java
@@ -46,7 +46,6 @@ 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.hadoop.*;
-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.*;
@@ -255,10 +254,6 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
 
     /** */
     @GridToStringExclude
-    private GridInteropProcessor interopProc;
-
-    /** */
-    @GridToStringExclude
     private IgniteSpringProcessor spring;
 
     /** */
@@ -444,8 +439,6 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
             hadoopProc = (IgniteHadoopProcessorAdapter)comp;
         else if (comp instanceof GridPortableProcessor)
             portableProc = (GridPortableProcessor)comp;
-        else if (comp instanceof GridInteropProcessor)
-            interopProc = (GridInteropProcessor)comp;
         else if (comp instanceof IgnitePluginProcessor)
             pluginProc = (IgnitePluginProcessor)comp;
         else if (comp instanceof GridQueryProcessor)
@@ -697,11 +690,6 @@ public class GridKernalContextImpl implements GridKernalContext, Externalizable
     }
 
     /** {@inheritDoc} */
-    @Override public GridInteropProcessor interop() {
-        return interopProc;
-    }
-
-    /** {@inheritDoc} */
     @Override public GridQueryProcessor query() {
         return qryProc;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/IgniteEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/IgniteEx.java b/modules/core/src/main/java/org/apache/ignite/internal/IgniteEx.java
index 6aa8bf5..aa94560 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/IgniteEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/IgniteEx.java
@@ -21,7 +21,6 @@ import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.lang.*;
-import org.apache.ignite.internal.processors.interop.*;
 import org.jetbrains.annotations.*;
 
 import java.util.*;
@@ -133,11 +132,4 @@ public interface IgniteEx extends Ignite, ClusterGroupEx, IgniteCluster {
      * @return GGFS.
      */
     @Nullable public IgniteFs ggfsx(@Nullable String name);
-
-    /**
-     * Gets interop processor.
-     *
-     * @return Interop processor.
-     */
-    public GridInteropProcessor interop();
 }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/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 7854bd9..0df86f9 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
@@ -56,7 +56,6 @@ 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.*;
@@ -742,7 +741,6 @@ public class IgniteKernal extends ClusterGroupAdapter implements IgniteEx, Ignit
             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);
@@ -3104,11 +3102,6 @@ public class IgniteKernal extends ClusterGroupAdapter implements IgniteEx, Ignit
     }
 
     /** {@inheritDoc} */
-    @Override public GridInteropProcessor interop() {
-        return ctx.interop();
-    }
-
-    /** {@inheritDoc} */
     @Override public <K> Map<ClusterNode, Collection<K>> mapKeysToNodes(String cacheName,
         @Nullable Collection<? extends K> keys) throws IgniteCheckedException {
         if (F.isEmpty(keys))

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/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 d962de0..3857851 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
@@ -1418,7 +1418,6 @@ public class IgnitionEx {
             myCfg.setSecurityCredentialsProvider(cfg.getSecurityCredentialsProvider());
             myCfg.setServiceConfiguration(cfg.getServiceConfiguration());
             myCfg.setWarmupClosure(cfg.getWarmupClosure());
-            myCfg.setInteropConfiguration(cfg.getInteropConfiguration());
             myCfg.setPluginConfigurations(cfg.getPluginConfigurations());
             myCfg.setTransactionsConfiguration(new TransactionsConfiguration(cfg.getTransactionsConfiguration()));
             myCfg.setQueryConfiguration(cfg.getQueryConfiguration());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/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 61408cb..f7fe02e 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
@@ -26,7 +26,6 @@ import org.apache.ignite.internal.util.*;
 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.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/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..4999ce0 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
@@ -24,7 +24,6 @@ import org.apache.ignite.internal.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.lifecycle.*;
 import org.apache.ignite.thread.*;
-import org.apache.ignite.internal.processors.interop.*;
 import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
 import org.apache.ignite.internal.util.tostring.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/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;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessor.java
deleted file mode 100644
index 33c841a..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessor.java
+++ /dev/null
@@ -1,82 +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.processors.*;
-import org.jetbrains.annotations.*;
-
-/**
- * Interop processor.
- */
-public interface GridInteropProcessor extends GridProcessor {
-    /**
-     * Release start latch.
-     */
-    public void releaseStart();
-
-    /**
-     * Await start on native side.
-     *
-     * @throws IgniteCheckedException If failed.
-     */
-    public void awaitStart() throws IgniteCheckedException;
-
-    /**
-     * @return Environment pointer.
-     */
-    public long environmentPointer() throws IgniteCheckedException;
-
-    /**
-     * @return Grid name.
-     */
-    public String gridName();
-
-    /**
-     * Gets native wrapper for default Grid projection.
-     *
-     * @return Native compute wrapper.
-     * @throws IgniteCheckedException If failed.
-     */
-    public GridInteropTarget projection() throws IgniteCheckedException;
-
-    /**
-     * Gets native wrapper for cache with the given name.
-     *
-     * @param name Cache name ({@code null} for default cache).
-     * @return Native cache wrapper.
-     * @throws IgniteCheckedException If failed.
-     */
-    public GridInteropTarget cache(@Nullable String name) throws IgniteCheckedException;
-
-    /**
-     * Gets native wrapper for data loader for cache with the given name.
-     *
-     * @param cacheName Cache name ({@code null} for default cache).
-     * @return Native data loader wrapper.
-     * @throws IgniteCheckedException If failed.
-     */
-    public GridInteropTarget dataLoader(@Nullable String cacheName) throws IgniteCheckedException;
-
-    /**
-     * Stops grid.
-     *
-     * @param cancel Cancel flag.
-     */
-    public void close(boolean cancel);
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessorAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessorAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessorAdapter.java
deleted file mode 100644
index 91ea27e..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropProcessorAdapter.java
+++ /dev/null
@@ -1,31 +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.internal.*;
-import org.apache.ignite.internal.processors.*;
-
-/**
- * Interop processor adapter.
- */
-public abstract class GridInteropProcessorAdapter extends GridProcessorAdapter implements GridInteropProcessor {
-    /** {@inheritDoc} */
-    protected GridInteropProcessorAdapter(GridKernalContext ctx) {
-        super(ctx);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropTarget.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropTarget.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropTarget.java
deleted file mode 100644
index af8b5d2..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/GridInteropTarget.java
+++ /dev/null
@@ -1,109 +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.processors.portable.*;
-import org.jetbrains.annotations.*;
-
-/**
- * Interop target abstraction.
- */
-public interface GridInteropTarget {
-    /**
-     * Synchronous IN operation.
-     *
-     * @param type Operation type.
-     * @param stream Input stream.
-     * @return Value specific for the given operation otherwise.
-     * @throws IgniteCheckedException In case of failure.
-     */
-    public int inOp(int type, GridPortableInputStream stream) throws IgniteCheckedException;
-
-    /**
-     * Synchronous IN operation which returns managed object as result.
-     *
-     * @param type Operation type.
-     * @param stream Input stream.
-     * @return Managed result.
-     * @throws IgniteCheckedException If case of failure.
-     */
-    public Object inOpObject(int type, GridPortableInputStream stream) throws IgniteCheckedException;
-
-    /**
-     * Synchronous OUT operation.
-     *
-     * @param type Operation type.
-     * @param stream Native stream address.
-     * @param arr Native array address.
-     * @param cap Capacity.
-     * @throws IgniteCheckedException In case of failure.
-     */
-    public void outOp(int type, long stream, long arr, int cap) throws IgniteCheckedException;
-
-    /**
-     * Synchronous IN-OUT operation.
-     *
-     * @param type Operation type.
-     * @param inStream Input stream.
-     * @param outStream Native stream address.
-     * @param outArr Native array address.
-     * @param outCap Capacity.
-     * @throws IgniteCheckedException In case of failure.
-     */
-    public void inOutOp(int type, GridPortableInputStream inStream, long outStream, long outArr, int outCap)
-        throws IgniteCheckedException;
-
-    /**
-     * Synchronous IN-OUT operation with optional argument.
-     *
-     * @param type Operation type.
-     * @param inStream Input stream.
-     * @param outStream Native stream address.
-     * @param outArr Native array address.
-     * @param outCap Capacity.
-     * @param arg Argument (optional).
-     * @throws IgniteCheckedException In case of failure.
-     */
-    public void inOutOp(int type, GridPortableInputStream inStream, long outStream, long outArr, int outCap,
-        @Nullable Object arg) throws IgniteCheckedException;
-
-    /**
-     * Asynchronous IN operation.
-     *
-     * @param type Operation type.
-     * @param futId Future ID.
-     * @param in Input stream.
-     * @throws IgniteCheckedException In case of failure.
-     */
-    public void inOpAsync(int type, long futId, GridPortableInputStream in) throws IgniteCheckedException;
-
-    /**
-     * Asynchronous IN-OUT operation.
-     *
-     * @param type Operation type.
-     * @param futId Future ID.
-     * @param in Input stream.
-     * @param outStream Native stream address.
-     * @param outArr Native array address.
-     * @param outCap Capacity.
-     * @throws IgniteCheckedException In case of failure.
-     */
-    public void inOutOpAsync(int type, long futId, GridPortableInputStream in, long outStream, long outArr, int outCap)
-        throws IgniteCheckedException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/GridOsInteropProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/GridOsInteropProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/GridOsInteropProcessor.java
deleted file mode 100644
index 6a592d1..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/GridOsInteropProcessor.java
+++ /dev/null
@@ -1,80 +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.os;
-
-import org.apache.ignite.*;
-import org.apache.ignite.internal.*;
-import org.apache.ignite.internal.processors.interop.*;
-import org.jetbrains.annotations.*;
-
-/**
- * OS interop processor.
- */
-public class GridOsInteropProcessor extends GridInteropProcessorAdapter {
-    /** Common error message. */
-    private static final String ERR_MSG = "Interop feature is not supported in OS edition.";
-
-    /**
-     * Constructor.
-     *
-     * @param ctx Context.
-     */
-    public GridOsInteropProcessor(GridKernalContext ctx) {
-        super(ctx);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void releaseStart() {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void awaitStart() throws IgniteCheckedException {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public long environmentPointer() throws IgniteCheckedException {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public String gridName() {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public void close(boolean cancel) {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public GridInteropTarget projection() throws IgniteCheckedException {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public GridInteropTarget cache(@Nullable String name) throws IgniteCheckedException {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-
-    /** {@inheritDoc} */
-    @Override public GridInteropTarget dataLoader(@Nullable String cacheName) throws IgniteCheckedException {
-        throw new UnsupportedOperationException(ERR_MSG);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/package.html b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/package.html
deleted file mode 100644
index 20815a0..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/os/package.html
+++ /dev/null
@@ -1,23 +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.
-  -->
-<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
-<html>
-<body>
-    <!-- Package description. -->
-    No-op implementation of interop processor.
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/package.html
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/package.html b/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/package.html
deleted file mode 100644
index 57a4e47..0000000
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/interop/package.html
+++ /dev/null
@@ -1,23 +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.
-  -->
-<!DOCTYPE html PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
-<html>
-<body>
-    <!-- Package description. -->
-    Interop processor.
-</body>
-</html>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d0444b79/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
index 5d3ad42..9cd7943 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/plugin/IgnitePluginProcessor.java
@@ -132,8 +132,9 @@ public class IgnitePluginProcessor extends GridProcessorAdapter {
      * @param name Plugin name.
      * @return Plugin provider.
      */
-    @Nullable public PluginProvider pluginProvider(String name) {
-        return plugins.get(name);
+    @SuppressWarnings("unchecked")
+    @Nullable public <T extends PluginProvider> T pluginProvider(String name) {
+        return (T)plugins.get(name);
     }
 
     /**
@@ -147,8 +148,9 @@ public class IgnitePluginProcessor extends GridProcessorAdapter {
      * @param provider Plugin context.
      * @return Plugin context.
      */
-    public PluginContext pluginContextForProvider(PluginProvider provider) {
-        return pluginCtxMap.get(provider);
+    @SuppressWarnings("unchecked")
+    public <T extends PluginContext> T pluginContextForProvider(PluginProvider provider) {
+        return (T)pluginCtxMap.get(provider);
     }
 
     /**


[29/45] incubator-ignite git commit: # IGNITE-102: Remove debug.

Posted by sb...@apache.org.
# IGNITE-102: Remove debug.


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

Branch: refs/heads/ignite-121-logging
Commit: 8112a5062adcd0931caafd166c0e2bf6e2b2674e
Parents: fa4ac59
Author: AKuznetsov <ak...@gridgain.com>
Authored: Thu Jan 29 10:27:23 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Thu Jan 29 10:27:23 2015 +0700

----------------------------------------------------------------------
 .../ignite/yardstick/cache/IgnitePutGetTxBenchmark.java      | 8 --------
 1 file changed, 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/8112a506/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
----------------------------------------------------------------------
diff --git a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
index 944d6a4..206dabc 100644
--- a/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
+++ b/modules/yardstick/src/main/java/org/apache/ignite/yardstick/cache/IgnitePutGetTxBenchmark.java
@@ -31,23 +31,15 @@ public class IgnitePutGetTxBenchmark extends IgniteCacheAbstractBenchmark {
     @Override public boolean test(Map<Object, Object> ctx) throws Exception {
         int key = nextRandom(0, args.range() / 2);
 
-        ignite().log().debug("IgnitePutGetTxBenchmark - key: " + key);
-
         try (IgniteTx tx = ignite().transactions().txStart()) {
-            ignite().log().debug("IgnitePutGetTxBenchmark: txStart()");
-
             Object val = cache.get(key);
 
-            ignite().log().debug("IgnitePutGetTxBenchmark - get():" + val);
-
             if (val != null)
                 key = nextRandom(args.range() / 2, args.range());
 
             cache.put(key, new SampleValue(key));
 
             tx.commit();
-
-            ignite().log().debug("IgnitePutGetTxBenchmark - txCommit");
         }
 
         return true;


[13/45] incubator-ignite git commit: Ignite-86 review

Posted by sb...@apache.org.
Ignite-86 review


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

Branch: refs/heads/ignite-121-logging
Commit: cb767aaadc36d1efbeff5605f85c6668128c3b70
Parents: 7cccef7
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Fri Jan 23 20:08:36 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Fri Jan 23 20:08:36 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheDeploymentManager.java  | 14 +++++++-------
 1 file changed, 7 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/cb767aaa/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
index 2f007f2..2df866d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
@@ -53,12 +53,10 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     private volatile ClassLoader globalLdr;
 
     /** Undeploys. */
-    private final ConcurrentHashMap8<GridCacheContext, ConcurrentLinkedQueue<CA>> undeploys
-        = new ConcurrentHashMap8<>();
+    private final ConcurrentMap<String, ConcurrentLinkedQueue<CA>> undeploys = new ConcurrentHashMap8<>();
 
     /** Per-thread deployment context. */
-    private ConcurrentMap<IgniteUuid, CachedDeploymentInfo<K, V>> deps =
-        new ConcurrentHashMap8<>();
+    private ConcurrentMap<IgniteUuid, CachedDeploymentInfo<K, V>> deps = new ConcurrentHashMap8<>();
 
     /** Collection of all known participants (Node ID -> Loader ID). */
     private Map<UUID, IgniteUuid> allParticipants = new ConcurrentHashMap8<>();
@@ -184,10 +182,12 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
     public void unwind(GridCacheContext ctx) {
         int cnt = 0;
 
-        if (undeploys.get(ctx) == null)
+        ConcurrentLinkedQueue<CA> q = undeploys.get(ctx);
+
+        if (q == null)
             return;
 
-        for (CA c = undeploys.get(ctx).poll(); c != null; c = undeploys.get(ctx).poll()) {
+        for (CA c = q.poll(); c != null; c = q.poll()) {
             c.apply();
 
             cnt++;
@@ -209,7 +209,7 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
         for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            undeploys.putIfAbsent(cacheCtx, new ConcurrentLinkedQueue<CA>());
+            undeploys.putIfAbsent(cacheCtx.namexx(), new ConcurrentLinkedQueue<CA>()); // TODO
 
             undeploys.get(cacheCtx).add(new CA() {
                 @Override


[42/45] incubator-ignite git commit: Merge branch 'sprint-1' into ignite-121-logging

Posted by sb...@apache.org.
Merge branch 'sprint-1' into ignite-121-logging


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

Branch: refs/heads/ignite-121-logging
Commit: b9722c4fc2303283ff9180ca1b46070a95c837bf
Parents: 42dc66f ff7ee6d
Author: Artem SHutak <as...@gridgain.com>
Authored: Mon Feb 2 17:55:04 2015 +0300
Committer: Artem SHutak <as...@gridgain.com>
Committed: Mon Feb 2 17:55:04 2015 +0300

----------------------------------------------------------------------
 .../configuration/IgniteConfiguration.java      |  22 --
 .../ignite/internal/GridKernalContext.java      |   8 -
 .../ignite/internal/GridKernalContextImpl.java  |  12 --
 .../org/apache/ignite/internal/IgniteEx.java    |   8 -
 .../apache/ignite/internal/IgniteKernal.java    |   7 -
 .../org/apache/ignite/internal/IgnitionEx.java  |   1 -
 .../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/GridCacheStoreManager.java |  25 ++-
 .../processors/cache/GridCacheSwapManager.java  |   3 +-
 .../cache/GridCacheWriteBehindStore.java        |  21 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   2 +-
 .../processors/interop/GridInteropAware.java    |  49 -----
 .../interop/GridInteropProcessor.java           |  82 -------
 .../interop/GridInteropProcessorAdapter.java    |  31 ---
 .../processors/interop/GridInteropTarget.java   | 109 ----------
 .../interop/os/GridOsInteropProcessor.java      |  80 -------
 .../internal/processors/interop/os/package.html |  23 --
 .../internal/processors/interop/package.html    |  23 --
 .../plugin/IgnitePluginProcessor.java           |  10 +-
 .../streamer/GridStreamProcessor.java           |   5 +-
 .../processors/streamer/IgniteStreamerEx.java   |   3 +-
 .../processors/streamer/IgniteStreamerImpl.java |   5 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |  10 +-
 .../hadoop/GridHadoopCommandLineTest.java       |   4 +-
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   6 -
 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                                         |   9 +-
 68 files changed, 2948 insertions(+), 600 deletions(-)
----------------------------------------------------------------------


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