You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by se...@apache.org on 2014/12/23 21:36:29 UTC

[46/53] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/master'

Merge remote-tracking branch 'origin/master'

Conflicts:
	modules/indexing/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheAbstractQuerySelfTest.java
	modules/indexing/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/replicated/GridCacheReplicatedQuerySelfTest.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/49f0fa42
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/49f0fa42
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/49f0fa42

Branch: refs/heads/ignite-gg9499
Commit: 49f0fa42d49e3afd5d274a8020902b605eb86fcc
Parents: 1483feb 92b73ff
Author: Valentin Kulichenko <vk...@gridgain.com>
Authored: Mon Dec 22 16:00:57 2014 -0800
Committer: Valentin Kulichenko <vk...@gridgain.com>
Committed: Mon Dec 22 16:00:57 2014 -0800

----------------------------------------------------------------------
 .../datagrid/CacheTransactionExample.java       |    8 +-
 .../datagrid/store/CacheStoreExample.java       |    4 +-
 .../store/dummy/CacheDummyPersonStore.java      |    8 +-
 .../hibernate/CacheHibernatePersonStore.java    |   16 +-
 .../store/jdbc/CacheJdbcPersonStore.java        |   14 +-
 .../org/gridgain/client/GridHashMapStore.java   |    8 +-
 .../GridClientAbstractMultiNodeSelfTest.java    |   14 +-
 .../integration/GridClientAbstractSelfTest.java |    7 +-
 .../client/suite/GridClientTestSuite.java       |    4 -
 .../java/org/apache/ignite/IgniteCache.java     |   14 +-
 .../java/org/apache/ignite/IgniteCompute.java   |   91 +-
 .../java/org/apache/ignite/IgniteManaged.java   |   47 +-
 .../org/apache/ignite/IgniteTransactions.java   |   33 +-
 .../java/org/apache/ignite/cache/CacheFlag.java |    3 +-
 .../configuration/IgniteConfiguration.java      |    6 +-
 .../TransactionsConfiguration.java              |  194 ++
 .../processors/cache/IgniteCacheProxy.java      |  601 ++++
 .../ignite/lang/IgniteAsyncSupported.java       |   29 +
 .../org/apache/ignite/lang/IgniteFuture.java    |   10 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    2 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |    7 +-
 .../apache/ignite/transactions/IgniteTx.java    |  239 ++
 .../transactions/IgniteTxConcurrency.java       |   37 +
 .../IgniteTxHeuristicException.java             |   43 +
 .../ignite/transactions/IgniteTxIsolation.java  |   41 +
 .../ignite/transactions/IgniteTxMetrics.java    |   45 +
 .../IgniteTxOptimisticException.java            |   39 +
 .../transactions/IgniteTxRollbackException.java |   39 +
 .../ignite/transactions/IgniteTxState.java      |   57 +
 .../transactions/IgniteTxSynchronization.java   |   38 +
 .../transactions/IgniteTxTimeoutException.java  |   39 +
 .../java/org/gridgain/grid/cache/GridCache.java |   11 +-
 .../grid/cache/GridCacheAtomicityMode.java      |    3 +-
 .../grid/cache/GridCacheConfiguration.java      |  123 +-
 .../org/gridgain/grid/cache/GridCacheEntry.java |    9 +-
 .../org/gridgain/grid/cache/GridCacheFlag.java  |    3 +-
 .../grid/cache/GridCacheProjection.java         |  129 +-
 .../org/gridgain/grid/cache/GridCacheTx.java    |  243 --
 .../grid/cache/GridCacheTxConcurrency.java      |   37 -
 .../cache/GridCacheTxHeuristicException.java    |   43 -
 .../grid/cache/GridCacheTxIsolation.java        |   41 -
 .../gridgain/grid/cache/GridCacheTxMetrics.java |   45 -
 .../grid/cache/GridCacheTxMetricsAdapter.java   |  108 -
 .../cache/GridCacheTxOptimisticException.java   |   39 -
 .../cache/GridCacheTxRollbackException.java     |   39 -
 .../gridgain/grid/cache/GridCacheTxState.java   |   57 -
 .../grid/cache/GridCacheTxSynchronization.java  |   37 -
 .../grid/cache/GridCacheTxTimeoutException.java |   39 -
 .../GridCacheWriteSynchronizationMode.java      |    5 +-
 .../cache/GridTransactionsConfiguration.java    |  190 --
 .../store/GridCacheLoadOnlyStoreAdapter.java    |   16 +-
 .../grid/cache/store/GridCacheStore.java        |   27 +-
 .../grid/cache/store/GridCacheStoreAdapter.java |   17 +-
 .../store/GridCacheStoreBalancingWrapper.java   |   16 +-
 .../store/jdbc/GridCacheJdbcBlobStore.java      |   15 +-
 .../org/gridgain/grid/kernal/GridGainEx.java    |    2 +-
 .../org/gridgain/grid/kernal/GridKernal.java    |   15 +-
 .../gridgain/grid/kernal/GridKernalContext.java |    2 +-
 .../grid/kernal/GridNodeAttributes.java         |    3 +
 .../grid/kernal/IgniteTransactionsEx.java       |   34 +
 .../affinity/GridAffinityAssignmentCache.java   |    1 -
 .../processors/cache/GridCacheAdapter.java      |  296 +-
 .../processors/cache/GridCacheAttributes.java   |   40 -
 .../processors/cache/GridCacheContext.java      |   34 +-
 .../processors/cache/GridCacheEntryEx.java      |   15 +-
 .../processors/cache/GridCacheEntryImpl.java    |   11 +-
 .../processors/cache/GridCacheEventManager.java |    8 +-
 .../cache/GridCacheEvictionEntry.java           |    9 +-
 .../cache/GridCacheEvictionManager.java         |   73 +-
 .../processors/cache/GridCacheIoManager.java    |   32 +-
 .../processors/cache/GridCacheMapEntry.java     |   56 +-
 .../processors/cache/GridCacheMessage.java      |    9 +-
 .../cache/GridCacheMultiTxFuture.java           |   19 +-
 .../kernal/processors/cache/GridCacheMvcc.java  |    3 +-
 .../processors/cache/GridCacheMvccManager.java  |   19 +-
 .../GridCachePartitionExchangeManager.java      |   35 +-
 .../processors/cache/GridCacheProcessor.java    |  124 +-
 .../processors/cache/GridCacheProjectionEx.java |    9 +-
 .../cache/GridCacheProjectionImpl.java          |   29 +-
 .../processors/cache/GridCacheProxyImpl.java    |   23 +-
 .../cache/GridCacheSharedContext.java           |   61 +-
 .../processors/cache/GridCacheStoreManager.java |   27 +-
 .../processors/cache/GridCacheTxAdapter.java    | 1479 --------
 .../processors/cache/GridCacheTxEntry.java      | 1059 ------
 .../kernal/processors/cache/GridCacheTxEx.java  |  503 ---
 .../processors/cache/GridCacheTxHandler.java    | 1478 --------
 .../kernal/processors/cache/GridCacheTxKey.java |   97 -
 .../cache/GridCacheTxLocalAdapter.java          | 3183 ------------------
 .../processors/cache/GridCacheTxLocalEx.java    |  166 -
 .../processors/cache/GridCacheTxManager.java    | 2194 ------------
 .../kernal/processors/cache/GridCacheTxMap.java |  179 -
 .../processors/cache/GridCacheTxProxy.java      |   19 -
 .../processors/cache/GridCacheTxProxyImpl.java  |  303 --
 .../processors/cache/GridCacheTxRemoteEx.java   |   37 -
 .../kernal/processors/cache/GridCacheUtils.java |   89 +-
 .../cache/GridCacheVersionManager.java          |    2 +-
 .../cache/GridCacheWriteBehindStore.java        |   15 +-
 .../datastructures/GridCacheAtomicLongImpl.java |   21 +-
 .../GridCacheAtomicReferenceImpl.java           |   10 +-
 .../GridCacheAtomicSequenceImpl.java            |    8 +-
 .../GridCacheAtomicStampedImpl.java             |   10 +-
 .../GridCacheCountDownLatchImpl.java            |   10 +-
 .../GridCacheDataStructuresManager.java         |   29 +-
 .../GridTransactionalCacheQueueImpl.java        |   14 +-
 .../distributed/GridCacheCommittedTxInfo.java   |    9 +-
 ...ridCacheOptimisticCheckPreparedTxFuture.java |    6 +-
 ...idCacheOptimisticCheckPreparedTxRequest.java |    3 +-
 .../GridCachePerThreadTxCommitBuffer.java       |    3 +-
 ...dCachePessimisticCheckCommittedTxFuture.java |    9 +-
 ...CachePessimisticCheckCommittedTxRequest.java |    3 +-
 .../distributed/GridCacheTxCommitBuffer.java    |    3 +-
 .../GridDistributedCacheAdapter.java            |   12 +-
 .../distributed/GridDistributedCacheEntry.java  |   47 +-
 .../distributed/GridDistributedLockRequest.java |   23 +-
 .../GridDistributedTxFinishRequest.java         |   57 +-
 .../distributed/GridDistributedTxMapping.java   |   31 +-
 .../GridDistributedTxPrepareRequest.java        |   91 +-
 .../GridDistributedTxRemoteAdapter.java         |   87 +-
 .../distributed/dht/GridDhtCacheEntry.java      |   65 +-
 .../distributed/dht/GridDhtCacheEntryImpl.java  |    2 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |    5 +-
 .../distributed/dht/GridDhtLockFuture.java      |   12 +-
 .../distributed/dht/GridDhtLockRequest.java     |    9 +-
 .../distributed/dht/GridDhtLockResponse.java    |    7 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   53 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   28 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |   79 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   91 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   79 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   84 +-
 .../dht/GridDhtTxPrepareRequest.java            |   73 +-
 .../dht/GridDhtTxPrepareResponse.java           |    7 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |   37 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   69 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   12 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   19 +-
 .../preloader/GridDhtPartitionDemandPool.java   |    2 +-
 .../GridDhtPartitionsExchangeFuture.java        |   11 +-
 .../distributed/near/GridNearAtomicCache.java   |    6 +-
 .../distributed/near/GridNearCacheAdapter.java  |    7 +-
 .../distributed/near/GridNearCacheEntry.java    |   16 +-
 .../distributed/near/GridNearGetFuture.java     |    8 +-
 .../distributed/near/GridNearLockFuture.java    |   17 +-
 .../distributed/near/GridNearLockRequest.java   |   33 +-
 .../near/GridNearTransactionalCache.java        |   23 +-
 .../near/GridNearTxFinishFuture.java            |   33 +-
 .../near/GridNearTxFinishRequest.java           |   55 +-
 .../cache/distributed/near/GridNearTxLocal.java |  160 +-
 .../near/GridNearTxPrepareFuture.java           |  110 +-
 .../near/GridNearTxPrepareRequest.java          |   47 +-
 .../near/GridNearTxPrepareResponse.java         |   15 +-
 .../distributed/near/GridNearTxRemote.java      |   53 +-
 .../processors/cache/dr/GridCacheDrManager.java |    3 +-
 .../cache/dr/os/GridOsCacheDrManager.java       |    3 +-
 .../processors/cache/local/GridLocalCache.java  |   10 +-
 .../cache/local/GridLocalCacheEntry.java        |    5 +-
 .../cache/local/GridLocalLockFuture.java        |    6 +-
 .../processors/cache/local/GridLocalTx.java     |   32 +-
 .../cache/local/GridLocalTxFuture.java          |   28 +-
 .../local/atomic/GridLocalAtomicCache.java      |    6 +-
 .../GridCacheContinuousQueryManager.java        |   11 +-
 .../transactions/IgniteTransactionsImpl.java    |  165 +-
 .../cache/transactions/IgniteTxAdapter.java     | 1548 +++++++++
 .../cache/transactions/IgniteTxEntry.java       | 1060 ++++++
 .../cache/transactions/IgniteTxEx.java          |  526 +++
 .../cache/transactions/IgniteTxHandler.java     | 1493 ++++++++
 .../cache/transactions/IgniteTxKey.java         |   97 +
 .../transactions/IgniteTxLocalAdapter.java      | 3179 +++++++++++++++++
 .../cache/transactions/IgniteTxLocalEx.java     |  162 +
 .../cache/transactions/IgniteTxManager.java     | 2213 ++++++++++++
 .../cache/transactions/IgniteTxMap.java         |  179 +
 .../transactions/IgniteTxMetricsAdapter.java    |  108 +
 .../cache/transactions/IgniteTxProxy.java       |   19 +
 .../cache/transactions/IgniteTxProxyImpl.java   |  364 ++
 .../cache/transactions/IgniteTxRemoteEx.java    |   39 +
 .../dataload/GridDataLoadCacheUpdaters.java     |    7 +-
 .../processors/ggfs/GridGgfsDataManager.java    |    9 +-
 .../processors/ggfs/GridGgfsMetaManager.java    |   31 +-
 .../handlers/cache/GridCacheCommandHandler.java |    8 +-
 .../service/GridServiceProcessor.java           |    7 +-
 .../cache/VisorCacheDefaultConfiguration.java   |   13 +-
 .../visor/cache/VisorCacheDgcConfiguration.java |    4 -
 .../grid/util/future/GridCompoundFuture.java    |    4 +-
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |    1 -
 .../core/src/test/config/spring-multicache.xml  |   16 -
 .../processors/cache/IgniteCacheTest.java       |  113 +
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    7 -
 .../store/GridCacheBalancingStoreSelfTest.java  |   16 +-
 .../cache/store/GridGeneratingTestStore.java    |   16 +-
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |    3 +-
 .../grid/kernal/GridStartStopSelfTest.java      |    7 +-
 .../GridDeploymentMessageCountSelfTest.java     |    2 +-
 .../GridCacheAbstractFailoverSelfTest.java      |   19 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |  238 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |    9 +-
 .../GridCacheAbstractProjectionSelfTest.java    |   12 +-
 .../GridCacheAbstractRemoveFailureTest.java     |    9 -
 .../cache/GridCacheAbstractSelfTest.java        |    9 +-
 .../cache/GridCacheAbstractTtlSelfTest.java     |    3 +-
 .../cache/GridCacheAbstractTxReadTest.java      |   17 +-
 .../cache/GridCacheBasicStoreAbstractTest.java  |   11 +-
 ...acheBasicStoreMultithreadedAbstractTest.java |    7 +-
 .../cache/GridCacheClearAllSelfTest.java        |    3 +-
 ...dCacheColocatedTxStoreExceptionSelfTest.java |    2 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |    8 +-
 ...idCacheConfigurationConsistencySelfTest.java |   16 +-
 .../GridCacheDaemonNodeAbstractSelfTest.java    |    9 +-
 .../cache/GridCacheDeploymentSelfTest.java      |    7 +-
 .../GridCacheExAbstractFullApiSelfTest.java     |    7 +-
 .../GridCacheFinishPartitionsSelfTest.java      |    9 +-
 .../cache/GridCacheGenericTestStore.java        |   32 +-
 .../GridCacheGroupLockAbstractSelfTest.java     |  118 +-
 .../GridCacheGroupLockFailoverSelfTest.java     |    3 -
 .../cache/GridCacheGroupLockPutTask.java        |    8 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |   13 +-
 .../GridCacheInterceptorSelfTestSuite.java      |    6 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   18 +-
 .../GridCacheLocalTxStoreExceptionSelfTest.java |    2 +-
 .../GridCacheMarshallerTxAbstractTest.java      |    8 +-
 ...GridCacheMixedPartitionExchangeSelfTest.java |    7 +-
 .../cache/GridCacheMultiUpdateLockSelfTest.java |    9 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    3 +-
 .../GridCacheNearTxStoreExceptionSelfTest.java  |    2 +-
 .../cache/GridCacheNestedTxAbstractTest.java    |   11 +-
 .../cache/GridCacheObjectToStringSelfTest.java  |    7 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |    2 +-
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   21 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   23 +-
 .../cache/GridCacheOffheapUpdateSelfTest.java   |   15 +-
 .../cache/GridCachePartitionedWritesTest.java   |    9 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |    3 -
 .../GridCacheReferenceCleanupSelfTest.java      |   12 +-
 .../GridCacheRefreshAheadAbstractSelfTest.java  |    7 +-
 .../cache/GridCacheReloadSelfTest.java          |    7 +-
 ...CacheReplicatedTxStoreExceptionSelfTest.java |    2 +-
 .../cache/GridCacheSlowTxWarnTest.java          |    3 +-
 .../processors/cache/GridCacheStopSelfTest.java |    3 +-
 .../cache/GridCacheStorePutxSelfTest.java       |   17 +-
 .../cache/GridCacheSwapReloadSelfTest.java      |    7 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   17 +-
 .../processors/cache/GridCacheTestStore.java    |   37 +-
 ...cheTransactionalAbstractMetricsSelfTest.java |   43 +-
 .../cache/GridCacheTxAbstractTest.java          |  484 ---
 .../GridCacheTxConcurrentGetAbstractTest.java   |  134 -
 .../GridCacheTxExceptionAbstractSelfTest.java   |  630 ----
 .../cache/GridCacheTxMultiNodeAbstractTest.java |  918 -----
 .../GridCacheTxMultiThreadedAbstractTest.java   |  275 --
 .../GridCacheTxReentryAbstractSelfTest.java     |  168 -
 .../GridCacheTxSingleThreadedAbstractTest.java  |  129 -
 ...idCacheTxStoreExceptionAbstractSelfTest.java |  630 ----
 .../GridCacheVariableTopologySelfTest.java      |    5 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |    9 +-
 ...BehindStorePartitionedMultiNodeSelfTest.java |    9 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |    4 +-
 .../processors/cache/IgniteTxAbstractTest.java  |  484 +++
 .../IgniteTxConcurrentGetAbstractTest.java      |  134 +
 .../IgniteTxExceptionAbstractSelfTest.java      |  631 ++++
 .../cache/IgniteTxMultiNodeAbstractTest.java    |  918 +++++
 .../IgniteTxMultiThreadedAbstractTest.java      |  275 ++
 .../cache/IgniteTxReentryAbstractSelfTest.java  |  169 +
 .../IgniteTxSingleThreadedAbstractTest.java     |  129 +
 .../IgniteTxStoreExceptionAbstractSelfTest.java |  631 ++++
 .../GridCacheAtomicLongApiSelfTest.java         |    3 +-
 ...dCacheQueueMultiNodeConsistencySelfTest.java |    1 -
 .../GridCacheSequenceApiSelfAbstractTest.java   |    8 +-
 ...idCachePartitionedNodeRestartTxSelfTest.java |   13 +-
 ...PartitionedQueueCreateMultiNodeSelfTest.java |    7 +-
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    1 -
 ...tractDistributedByteArrayValuesSelfTest.java |   11 +-
 .../GridCacheAbstractJobExecutionTest.java      |   12 +-
 .../GridCacheAbstractNodeRestartSelfTest.java   |   13 +-
 ...tractPartitionedByteArrayValuesSelfTest.java |    2 +-
 .../GridCacheAbstractPrimarySyncSelfTest.java   |    7 +-
 .../GridCacheBasicOpAbstractTest.java           |   10 +-
 .../GridCacheEntrySetAbstractSelfTest.java      |    7 +-
 .../distributed/GridCacheEventAbstractTest.java |   25 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    8 +-
 .../GridCacheNodeFailureAbstractTest.java       |   12 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |    7 +-
 .../GridCacheTransformEventSelfTest.java        |   20 +-
 ...cheTxConsistencyRestartAbstractSelfTest.java |  193 --
 ...xOriginatingNodeFailureAbstractSelfTest.java |  294 --
 ...cOriginatingNodeFailureAbstractSelfTest.java |  488 ---
 .../GridCacheTxPreloadAbstractTest.java         |  191 --
 .../GridCacheTxTimeoutAbstractTest.java         |  147 -
 ...iteTxConsistencyRestartAbstractSelfTest.java |  194 ++
 ...xOriginatingNodeFailureAbstractSelfTest.java |  295 ++
 ...cOriginatingNodeFailureAbstractSelfTest.java |  493 +++
 .../IgniteTxPreloadAbstractTest.java            |  192 ++
 .../IgniteTxTimeoutAbstractTest.java            |  147 +
 ...heAbstractTransformWriteThroughSelfTest.java |    9 +-
 .../dht/GridCacheColocatedDebugTest.java        |   34 +-
 ...eColocatedOptimisticTransactionSelfTest.java |    7 +-
 .../GridCacheColocatedTxExceptionSelfTest.java  |    2 +-
 ...ssimisticOriginatingNodeFailureSelfTest.java |    2 +-
 ...dCacheColocatedTxSingleThreadedSelfTest.java |    2 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |    3 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |    2 +-
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   17 +-
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    3 +-
 ...cheGroupLockPartitionedAbstractSelfTest.java |   11 +-
 ...ockPartitionedMultiNodeAbstractSelfTest.java |   14 +-
 ...dCachePartitionedTopologyChangeSelfTest.java |   14 +-
 ...itionedTxOriginatingNodeFailureSelfTest.java |    2 +-
 ...heTxConsistencyColocatedRestartSelfTest.java |   28 -
 .../GridCacheTxReentryColocatedSelfTest.java    |   71 -
 ...teTxConsistencyColocatedRestartSelfTest.java |   28 +
 .../dht/IgniteTxReentryColocatedSelfTest.java   |   71 +
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |   13 +-
 .../near/GridCacheGetStoreErrorSelfTest.java    |    7 +-
 .../near/GridCacheNearMultiGetSelfTest.java     |   14 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |   30 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |   38 +-
 .../near/GridCacheNearOnlyTopologySelfTest.java |    9 +-
 .../GridCacheNearPartitionedClearSelfTest.java  |  142 +
 .../near/GridCacheNearTxExceptionSelfTest.java  |    2 +-
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   21 +-
 ...ssimisticOriginatingNodeFailureSelfTest.java |    2 +-
 .../near/GridCacheNearTxPreloadSelfTest.java    |    3 +-
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |   23 +-
 .../GridCachePartitionedEvictionSelfTest.java   |    9 +-
 ...titionedExplicitLockNodeFailureSelfTest.java |    1 -
 ...GridCachePartitionedFilteredPutSelfTest.java |    5 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |    7 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |   14 +-
 ...idCachePartitionedMultiNodeLockSelfTest.java |    1 -
 ...ePartitionedMultiThreadedPutGetSelfTest.java |    9 +-
 ...GridCachePartitionedNodeFailureSelfTest.java |    1 -
 .../GridCachePartitionedNodeRestartTest.java    |    3 +-
 ...ePartitionedOptimisticTxNodeRestartTest.java |    6 +-
 ...achePartitionedPreloadLifecycleSelfTest.java |    6 +-
 .../GridCachePartitionedStorePutSelfTest.java   |    7 +-
 ...GridCachePartitionedTxConcurrentGetTest.java |    2 +-
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    2 +-
 ...CachePartitionedTxMultiThreadedSelfTest.java |    2 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |   24 +-
 ...achePartitionedTxSingleThreadedSelfTest.java |    2 +-
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    4 +-
 .../near/GridCachePutArrayValueSelfTest.java    |    2 -
 .../near/GridCacheTxReentryNearSelfTest.java    |   71 -
 .../near/GridPartitionedBackupLoadSelfTest.java |    7 +-
 .../near/IgniteTxReentryNearSelfTest.java       |   71 +
 .../GridCacheReplicatedEvictionSelfTest.java    |    8 +-
 .../GridCacheReplicatedInvalidateSelfTest.java  |   14 +-
 .../GridCacheReplicatedTxConcurrentGetTest.java |    2 +-
 .../GridCacheReplicatedTxExceptionSelfTest.java |    2 +-
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    2 +-
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |    4 +-
 ...licatedTxOriginatingNodeFailureSelfTest.java |    2 +-
 ...ssimisticOriginatingNodeFailureSelfTest.java |    2 +-
 ...CacheReplicatedTxSingleThreadedSelfTest.java |    2 +-
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    2 +-
 .../replicated/GridReplicatedTxPreloadTest.java |    2 +-
 ...CacheReplicatedPreloadLifecycleSelfTest.java |    5 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |    5 +-
 .../GridCacheBatchEvictUnswapSelfTest.java      |    8 +-
 ...heConcurrentEvictionConsistencySelfTest.java |    7 +-
 .../GridCacheConcurrentEvictionsSelfTest.java   |    4 +-
 .../GridCacheDistributedEvictionsSelfTest.java  |    7 +-
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   21 +-
 .../eviction/GridCacheEvictionAbstractTest.java |    9 +-
 .../GridCacheEvictionFilterSelfTest.java        |    2 +-
 .../GridCacheEvictionTouchSelfTest.java         |   21 +-
 .../GridCacheLruNearEvictionPolicySelfTest.java |    2 +-
 .../GridCacheRandomEvictionPolicySelfTest.java  |    2 +-
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   11 +-
 .../local/GridCacheLocalLoadAllSelfTest.java    |   10 +-
 .../GridCacheLocalTxExceptionSelfTest.java      |    2 +-
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    4 +-
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    2 +-
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |   16 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    8 +-
 .../GridDataLoaderProcessorSelfTest.java        |   12 +-
 .../ggfs/GridGgfsDataManagerSelfTest.java       |    7 +-
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |    9 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |    2 +-
 .../cache/GridCacheAbstractLoadTest.java        |   14 +-
 ...ridCacheAffinityTransactionsOffHeapTest.java |    8 +-
 .../cache/GridCacheGroupLockComparisonTest.java |    7 +-
 .../GridCacheWriteBehindStoreLoadTest.java      |    7 +-
 .../colocation/GridTestCacheStore.java          |    8 +-
 .../GridCachePartitionedAtomicLongLoadTest.java |    7 +-
 .../gridgain/loadtests/dsi/GridDsiPerfJob.java  |    4 +-
 .../loadtests/hashmap/GridCacheTestContext.java |    4 +-
 .../loadtests/hashmap/GridHashMapLoadTest.java  |    5 +-
 .../swap/GridSwapEvictAllBenchmark.java         |    8 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |   30 +-
 .../GridCacheDataStructuresSelfTestSuite.java   |   15 +-
 .../GridCacheEvictionSelfTestSuite.java         |    6 +-
 .../GridCacheFullApiSelfTestSuite.java          |    6 +-
 .../GridCacheMetricsSelfTestSuite.java          |    4 +-
 .../GridCacheWriteBehindTestSuite.java          |    4 +-
 .../bamboo/GridCacheFailoverTestSuite.java      |    4 -
 .../bamboo/GridDataGridRestartTestSuite.java    |    4 -
 .../bamboo/GridDataGridTestSuite.java           |   48 +-
 .../GridHibernateReadWriteAccessStrategy.java   |   10 +-
 .../hibernate/GridHibernateRegionFactory.java   |   15 +-
 .../hibernate/GridCacheHibernateBlobStore.java  |   17 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    7 +-
 .../cache/GridCacheQueryLoadSelfTest.java       |    7 +-
 .../GridCacheQueryMultiThreadedSelfTest.java    |    9 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |    8 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    5 +-
 .../testsuites/GridCacheQuerySelfTestSuite.java |   10 +-
 .../cache/jta/GridCacheJtaManager.java          |   24 +-
 .../cache/jta/GridCacheXAResource.java          |   12 +-
 .../processors/cache/GridCacheJtaSelfTest.java  |    5 +-
 .../java/org/gridgain/grid/GridSpringBean.java  |    4 +-
 .../cache/spring/GridSpringCacheManager.java    |    5 +-
 .../cache/websession/GridWebSessionFilter.java  |    8 +-
 410 files changed, 20796 insertions(+), 19232 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/49f0fa42/modules/indexing/src/test/java/org/gridgain/grid/kernal/processors/cache/GridCacheAbstractQuerySelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/49f0fa42/modules/indexing/src/test/java/org/gridgain/grid/kernal/processors/cache/distributed/replicated/GridCacheReplicatedQuerySelfTest.java
----------------------------------------------------------------------