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/05/12 13:30:21 UTC

[02/37] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-sprint-4' into ignite-478

Merge remote-tracking branch 'remotes/origin/ignite-sprint-4' into ignite-478


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

Branch: refs/heads/ignite-373
Commit: eae6f5e6636a2548518fc012331ab90b6186b111
Parents: 830a102 dc455be
Author: sevdokimov <se...@gridgain.com>
Authored: Tue Apr 21 19:13:44 2015 +0300
Committer: sevdokimov <se...@gridgain.com>
Committed: Tue Apr 21 19:13:44 2015 +0300

----------------------------------------------------------------------
 .gitignore                                      |    2 +-
 DEVNOTES.txt                                    |   87 +-
 RELEASE_NOTES.txt                               |   33 +-
 assembly/dependencies-fabric.xml                |   50 +
 assembly/dependencies-hadoop.xml                |    1 -
 assembly/dependencies-optional-fabric.xml       |   82 -
 assembly/dependencies-optional-hadoop.xml       |   83 -
 assembly/libs/README.txt                        |    1 -
 assembly/release-base.xml                       |    5 -
 assembly/release-fabric.xml                     |   10 +-
 assembly/release-hadoop.xml                     |    4 -
 bin/ignite.bat                                  |    2 +-
 bin/ignite.sh                                   |    2 +-
 bin/ignitevisorcmd.bat                          |   39 +-
 bin/include/service.sh                          |    8 +-
 config/hadoop/default-config.xml                |   15 +-
 examples/README.txt                             |   11 +-
 examples/config/example-ignite.xml              |    2 +-
 examples/pom-standalone.xml                     |   17 +-
 examples/pom.xml                                |  105 +-
 examples/schema-import/bin/db-init.sql          |   17 +
 examples/schema-import/pom.xml                  |   11 +-
 .../examples/datagrid/CacheAffinityExample.java |    9 +-
 .../examples/datagrid/CacheApiExample.java      |    9 +-
 .../examples/datagrid/CacheAsyncApiExample.java |    9 +-
 .../datagrid/CacheContinuousQueryExample.java   |    8 +-
 .../datagrid/CacheDataStreamerExample.java      |    9 +-
 .../examples/datagrid/CacheEventsExample.java   |    9 +-
 .../examples/datagrid/CachePutGetExample.java   |   10 +-
 .../examples/datagrid/CacheQueryExample.java    |   12 +-
 .../datagrid/CacheTransactionExample.java       |    8 +-
 .../hibernate/HibernateL2CacheExample.java      |    5 +-
 .../starschema/CacheStarSchemaExample.java      |   10 +-
 .../store/auto/CacheAutoStoreExample.java       |    8 +-
 .../auto/CacheAutoStoreLoadDataExample.java     |    5 +-
 .../datagrid/store/auto/CacheConfig.java        |    4 +-
 .../store/dummy/CacheDummyStoreExample.java     |    5 +-
 .../hibernate/CacheHibernateStoreExample.java   |    8 +-
 .../store/jdbc/CacheJdbcStoreExample.java       |    8 +-
 .../datastructures/IgniteQueueExample.java      |   28 +-
 .../datastructures/IgniteSetExample.java        |   30 +-
 .../streaming/StreamTransformerExample.java     |  100 +
 .../streaming/StreamVisitorExample.java         |  168 +
 .../streaming/marketdata/CacheConfig.java       |   44 -
 .../streaming/marketdata/Instrument.java        |  106 -
 .../marketdata/QueryTopInstruments.java         |   73 -
 .../streaming/marketdata/StreamMarketData.java  |  103 -
 .../examples/streaming/numbers/CacheConfig.java |   46 -
 .../streaming/numbers/QueryPopularNumbers.java  |   74 -
 .../streaming/numbers/StreamRandomNumbers.java  |   78 -
 .../streaming/wordcount/CacheConfig.java        |   53 +
 .../streaming/wordcount/QueryWords.java         |   79 +
 .../streaming/wordcount/StreamWords.java        |   68 +
 .../streaming/wordcount/alice-in-wonderland.txt | 3735 ++++++++++++++++++
 .../streaming/wordcount/package-info.java       |   22 +
 .../streaming/StreamTransformerExample.java     |   97 +
 .../java8/streaming/StreamVisitorExample.java   |  168 +
 .../java8/streaming/marketdata/CacheConfig.java |   44 -
 .../java8/streaming/marketdata/Instrument.java  |  106 -
 .../marketdata/QueryTopInstruments.java         |   73 -
 .../streaming/marketdata/StreamMarketData.java  |  101 -
 .../java8/streaming/numbers/CacheConfig.java    |   46 -
 .../streaming/numbers/QueryPopularNumbers.java  |   74 -
 .../streaming/numbers/StreamRandomNumbers.java  |   74 -
 .../examples/ScalarContinuationExample.scala    |   10 +-
 .../examples/MessagingExamplesSelfTest.java     |    2 +-
 .../java8/examples/BasicExamplesSelfTest.java   |    3 +
 .../java8/examples/CacheExamplesSelfTest.java   |    4 +
 .../examples/CheckpointExamplesSelfTest.java    |    3 +
 .../examples/ClusterGroupExampleSelfTest.java   |    3 +-
 .../examples/ContinuationExamplesSelfTest.java  |    3 +
 .../ContinuousMapperExamplesSelfTest.java       |    4 +-
 .../DeploymentExamplesMultiNodeSelfTest.java    |    2 +
 .../examples/DeploymentExamplesSelfTest.java    |    2 +
 .../HibernateL2CacheExampleSelfTest.java        |    3 +
 .../java8/examples/IgfsExamplesSelfTest.java    |    3 +
 .../examples/LifecycleExamplesSelfTest.java     |    3 +
 .../MemcacheRestExamplesMultiNodeSelfTest.java  |    2 +
 .../examples/MemcacheRestExamplesSelfTest.java  |    2 +
 .../examples/MessagingExamplesSelfTest.java     |    4 +-
 .../examples/MonteCarloExamplesSelfTest.java    |    3 +
 .../examples/SpringBeanExamplesSelfTest.java    |    3 +
 .../java8/examples/TaskExamplesSelfTest.java    |    2 +
 ipc/shmem/README.txt                            |    2 +-
 modules/aop/pom.xml                             |   25 +-
 modules/aws/pom.xml                             |   43 +-
 .../s3/S3CheckpointManagerSelfTest.java         |    2 +-
 .../checkpoint/s3/S3CheckpointSpiSelfTest.java  |   14 +-
 .../s3/S3SessionCheckpointSelfTest.java         |    2 +-
 modules/clients/pom.xml                         |   43 +-
 modules/clients/readme.md                       |    2 -
 .../client/ClientReconnectionSelfTest.java      |   69 +-
 .../client/impl/ClientCacheFlagsCodecTest.java  |   18 +-
 .../rest/AbstractRestProcessorSelfTest.java     |   11 +-
 .../JettyRestProcessorAbstractSelfTest.java     |    5 -
 modules/codegen/pom.xml                         |   27 +-
 .../ignite/codegen/MessageCodeGenerator.java    |    1 -
 modules/core/pom.xml                            |   90 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   26 +
 .../java/org/apache/ignite/IgniteCache.java     |   30 +-
 .../java/org/apache/ignite/IgniteCluster.java   |   11 +-
 .../java/org/apache/ignite/IgniteState.java     |    2 +-
 .../apache/ignite/IgniteSystemProperties.java   |   13 +-
 .../apache/ignite/cache/CacheTypeMetadata.java  |    4 +-
 .../apache/ignite/cache/CachingProvider.java    |    2 +-
 .../ignite/cache/affinity/AffinityUuid.java     |   50 +
 .../cache/eviction/fifo/FifoEvictionPolicy.java |   57 +-
 .../eviction/fifo/FifoEvictionPolicyMBean.java  |   16 +
 .../igfs/IgfsPerBlockLruEvictionPolicy.java     |    3 +-
 .../cache/eviction/lru/LruEvictionPolicy.java   |    5 +-
 .../eviction/sorted/SortedEvictionPolicy.java   |  431 ++
 .../sorted/SortedEvictionPolicyMBean.java       |   66 +
 .../cache/eviction/sorted/package-info.java     |   21 +
 .../apache/ignite/cache/query/QueryMetrics.java |    4 +-
 .../apache/ignite/cache/query/ScanQuery.java    |    2 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |   55 +-
 .../store/jdbc/CacheAbstractJdbcStore.java      |  106 +-
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |    9 +-
 .../ignite/cluster/ClusterStartNodeResult.java  |   46 +
 .../ignite/compute/ComputeJobContinuation.java  |    2 +
 .../configuration/CacheConfiguration.java       |  128 +-
 .../configuration/CollectionConfiguration.java  |  114 +-
 .../configuration/FileSystemConfiguration.java  |    6 +
 .../configuration/IgniteConfiguration.java      |   35 +-
 .../org/apache/ignite/events/CacheEvent.java    |   25 +-
 .../ignite/events/CacheQueryExecutedEvent.java  |   11 +-
 .../ignite/events/CacheQueryReadEvent.java      |   11 +-
 .../ignite/events/CacheRebalancingEvent.java    |   27 +-
 .../org/apache/ignite/events/EventType.java     |  129 +-
 .../ignite/internal/ClusterMetricsSnapshot.java |  385 +-
 .../internal/ComputeTaskInternalFuture.java     |    2 +-
 .../ignite/internal/GridCachePluginContext.java |   78 +
 .../apache/ignite/internal/GridComponent.java   |    7 +-
 .../ignite/internal/GridJobContextImpl.java     |  100 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   10 +-
 .../ignite/internal/GridJobExecuteResponse.java |    4 +-
 .../ignite/internal/GridKernalContextImpl.java  |   20 +-
 .../ignite/internal/GridPluginComponent.java    |    9 +-
 .../ignite/internal/GridPluginContext.java      |   15 +-
 .../apache/ignite/internal/GridTaskMessage.java |   30 -
 .../ignite/internal/GridTaskSessionRequest.java |    6 +-
 .../org/apache/ignite/internal/IgniteEx.java    |   19 +-
 .../apache/ignite/internal/IgniteKernal.java    |  120 +-
 .../ignite/internal/IgniteNodeAttributes.java   |    3 -
 .../org/apache/ignite/internal/IgnitionEx.java  |  181 +-
 .../internal/MarshallerContextAdapter.java      |   11 +-
 .../ignite/internal/MarshallerContextImpl.java  |  154 +-
 .../internal/client/GridClientCacheFlag.java    |   13 -
 .../client/GridClientConfiguration.java         |   14 +-
 .../impl/connection/GridClientConnection.java   |    9 -
 .../GridClientConnectionManagerAdapter.java     |    2 +-
 .../router/GridTcpRouterConfiguration.java      |    6 +-
 .../internal/cluster/ClusterGroupAdapter.java   |  147 +-
 .../cluster/ClusterStartNodeResultImpl.java     |   87 +
 .../cluster/IgniteClusterAsyncImpl.java         |    5 +-
 .../internal/cluster/IgniteClusterImpl.java     |   37 +-
 .../internal/managers/GridManagerAdapter.java   |   60 +-
 .../discovery/GridDiscoveryManager.java         |  109 +-
 .../eventstorage/GridEventStorageManager.java   |    4 +-
 .../swapspace/GridSwapSpaceManager.java         |    6 +-
 .../processors/GridProcessorAdapter.java        |    7 +-
 .../affinity/GridAffinityAssignmentCache.java   |    7 +-
 .../affinity/GridAffinityProcessor.java         |    5 +-
 .../cache/CacheConflictResolutionManager.java   |   30 +
 .../processors/cache/CacheDistributionMode.java |   67 -
 .../processors/cache/CacheEntryImpl.java        |   29 +-
 .../cache/CacheEvictableEntryImpl.java          |   11 +-
 .../internal/processors/cache/CacheFlag.java    |  108 -
 .../processors/cache/CacheFlagException.java    |   67 -
 .../processors/cache/CacheLazyEntry.java        |   10 +-
 .../processors/cache/CacheLockImpl.java         |   20 +-
 .../processors/cache/CacheMetricsImpl.java      |    8 +-
 .../processors/cache/CacheMetricsSnapshot.java  |  223 +-
 .../cache/CacheObjectByteArrayImpl.java         |    2 +-
 .../processors/cache/CacheObjectContext.java    |   14 +-
 .../processors/cache/CacheObjectImpl.java       |   10 +-
 .../processors/cache/CacheOperationContext.java |  170 +
 .../cache/CacheOsConflictResolutionManager.java |   58 +
 .../processors/cache/CacheProjection.java       | 1859 ---------
 .../cache/CacheStorePartialUpdateException.java |    2 +-
 .../internal/processors/cache/CacheType.java    |   77 +
 .../cache/CacheVersionedEntryImpl.java          |   29 +-
 .../cache/DynamicCacheChangeRequest.java        |   36 +-
 .../cache/DynamicCacheDescriptor.java           |   32 +-
 .../internal/processors/cache/GridCache.java    |  227 --
 .../processors/cache/GridCacheAdapter.java      | 1361 ++-----
 .../processors/cache/GridCacheAtomicFuture.java |    7 -
 .../processors/cache/GridCacheAttributes.java   |    8 -
 .../cache/GridCacheConcurrentMap.java           |  100 +-
 .../processors/cache/GridCacheContext.java      |  415 +-
 .../cache/GridCacheDeploymentManager.java       |    9 +-
 .../processors/cache/GridCacheEntryEx.java      |   58 +-
 .../processors/cache/GridCacheEventManager.java |    4 +-
 .../cache/GridCacheEvictionManager.java         |   17 +-
 .../cache/GridCacheExplicitLockSpan.java        |    2 +-
 .../processors/cache/GridCacheGateway.java      |  119 +-
 .../processors/cache/GridCacheIoManager.java    |   89 +-
 .../processors/cache/GridCacheMapAdapter.java   |  238 --
 .../processors/cache/GridCacheMapEntry.java     |  345 +-
 .../cache/GridCacheMapEntryFactory.java         |    2 -
 .../processors/cache/GridCacheMessage.java      |    7 +
 .../processors/cache/GridCacheMvcc.java         |    2 +-
 .../cache/GridCacheMvccCandidate.java           |   50 +-
 .../processors/cache/GridCacheMvccManager.java  |   44 +-
 .../GridCachePartitionExchangeManager.java      |  136 +-
 .../processors/cache/GridCachePeekMode.java     |   81 -
 .../processors/cache/GridCacheProcessor.java    |  785 +++-
 .../processors/cache/GridCacheProjectionEx.java |  509 ---
 .../cache/GridCacheProjectionImpl.java          | 1198 ------
 .../processors/cache/GridCacheProxy.java        |   27 -
 .../processors/cache/GridCacheProxyImpl.java    |  900 +----
 .../cache/GridCacheSharedContext.java           |   25 +-
 .../processors/cache/GridCacheStoreManager.java | 1202 ------
 .../processors/cache/GridCacheSwapManager.java  |    4 +-
 .../processors/cache/GridCacheUtils.java        |   89 +-
 .../cache/GridCacheWriteBehindStore.java        | 1015 -----
 .../cache/GridLoadCacheCloseablePredicate.java  |   30 +
 .../processors/cache/IgniteCacheProxy.java      |  518 +--
 .../processors/cache/IgniteInternalCache.java   | 1816 +++++++++
 .../processors/cache/KeyCacheObjectImpl.java    |   13 +-
 .../cache/affinity/GridCacheAffinityProxy.java  |   30 +-
 .../CacheDataStructuresManager.java             |   14 +-
 .../GridDistributedCacheAdapter.java            |   15 +-
 .../distributed/GridDistributedCacheEntry.java  |   16 +-
 .../GridDistributedTxRemoteAdapter.java         |    2 +-
 .../dht/GridClientPartitionTopology.java        |    6 +-
 .../dht/GridDhtAffinityAssignmentRequest.java   |    5 +
 .../dht/GridDhtAffinityAssignmentResponse.java  |   26 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   82 +-
 .../distributed/dht/GridDhtCacheEntry.java      |   44 +-
 .../distributed/dht/GridDhtLocalPartition.java  |  105 +-
 .../distributed/dht/GridDhtLockFuture.java      |   30 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |   11 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   23 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   24 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |    2 +
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   81 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   36 +-
 .../distributed/dht/GridNoStorageCacheMap.java  |   11 +-
 .../dht/GridPartitionedGetFuture.java           |   23 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  256 +-
 .../dht/atomic/GridDhtAtomicCacheEntry.java     |    4 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   21 -
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   17 -
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   78 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   86 +-
 .../colocated/GridDhtColocatedCacheEntry.java   |    4 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   46 +-
 .../colocated/GridDhtDetachedCacheEntry.java    |    7 +-
 .../preloader/GridDhtPartitionDemandPool.java   |   15 +-
 .../GridDhtPartitionsAbstractMessage.java       |   15 +-
 .../GridDhtPartitionsExchangeFuture.java        |   48 +-
 .../distributed/near/GridNearAtomicCache.java   |  143 +-
 .../distributed/near/GridNearCacheAdapter.java  |  142 +-
 .../distributed/near/GridNearCacheEntry.java    |   30 +-
 .../distributed/near/GridNearGetFuture.java     |   23 +-
 .../distributed/near/GridNearLockFuture.java    |   13 +-
 .../near/GridNearTransactionalCache.java        |   21 +-
 .../near/GridNearTxFinishFuture.java            |    8 +-
 .../cache/distributed/near/GridNearTxLocal.java |   11 +-
 .../near/GridNearTxPrepareFuture.java           |  124 +-
 .../near/GridNearTxPrepareRequest.java          |   64 +-
 .../distributed/near/GridNearTxRemote.java      |   11 +-
 .../processors/cache/dr/GridCacheDrManager.java |    5 -
 .../cache/dr/GridOsCacheDrManager.java          |  106 +
 .../cache/dr/os/GridOsCacheDrManager.java       |  111 -
 .../processors/cache/local/GridLocalCache.java  |   19 +-
 .../cache/local/GridLocalCacheEntry.java        |    4 +-
 .../cache/local/GridLocalLockFuture.java        |    2 +
 .../local/atomic/GridLocalAtomicCache.java      |  228 +-
 .../processors/cache/query/CacheQueries.java    |  143 -
 .../processors/cache/query/CacheQuery.java      |   12 +-
 .../CacheQueryCloseableScanBiPredicate.java     |   30 +
 .../cache/query/GridCacheQueriesEx.java         |   68 -
 .../cache/query/GridCacheQueriesImpl.java       |  238 --
 .../cache/query/GridCacheQueriesProxy.java      |  285 --
 .../cache/query/GridCacheQueryAdapter.java      |    2 +-
 .../cache/query/GridCacheQueryManager.java      |  156 +-
 .../continuous/CacheContinuousQueryHandler.java |    9 +-
 .../CacheContinuousQueryListener.java           |    3 +
 .../continuous/CacheContinuousQueryManager.java |    4 +-
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |    4 +-
 .../cache/store/CacheOsStoreManager.java        |   59 +
 .../cache/store/CacheStoreManager.java          |  182 +
 .../store/GridCacheStoreManagerAdapter.java     | 1111 ++++++
 .../cache/store/GridCacheWriteBehindStore.java  | 1015 +++++
 .../transactions/IgniteTransactionsImpl.java    |   18 +-
 .../cache/transactions/IgniteTxAdapter.java     |   10 +-
 .../cache/transactions/IgniteTxHandler.java     |  120 +-
 .../transactions/IgniteTxLocalAdapter.java      |  170 +-
 .../cache/transactions/IgniteTxManager.java     |   71 +-
 .../version/CacheVersionConflictResolver.java   |   40 +
 ...ridCacheVersionAbstractConflictResolver.java |   56 -
 .../GridCacheVersionConflictResolver.java       |   59 -
 .../cache/version/GridCacheVersionEx.java       |    2 +-
 .../cacheobject/IgniteCacheObjectProcessor.java |   22 +-
 .../IgniteCacheObjectProcessorImpl.java         |  225 +-
 .../continuous/GridContinuousProcessor.java     |    4 +-
 .../datastreamer/DataStreamerCacheUpdaters.java |   15 +-
 .../datastreamer/DataStreamerImpl.java          |   80 +-
 .../datastreamer/DataStreamerUpdateJob.java     |   16 +-
 .../CacheDataStructuresCacheKey.java            |   62 +
 .../CacheDataStructuresConfigurationKey.java    |    2 +-
 .../datastructures/DataStructuresProcessor.java |  271 +-
 .../GridAtomicCacheQueueImpl.java               |   12 +-
 .../datastructures/GridCacheAtomicLongImpl.java |    6 +-
 .../GridCacheAtomicReferenceImpl.java           |    6 +-
 .../GridCacheAtomicReferenceValue.java          |   15 +-
 .../GridCacheAtomicSequenceImpl.java            |    4 +-
 .../GridCacheAtomicStampedImpl.java             |    6 +-
 .../GridCacheAtomicStampedValue.java            |   15 +-
 .../GridCacheCountDownLatchImpl.java            |    4 +-
 .../datastructures/GridCacheQueueAdapter.java   |    2 +-
 .../datastructures/GridCacheSetImpl.java        |    6 +-
 .../GridTransactionalCacheQueueImpl.java        |    8 +-
 .../dr/IgniteDrDataStreamerCacheUpdater.java    |    2 -
 .../internal/processors/igfs/IgfsAsyncImpl.java |    4 +-
 .../processors/igfs/IgfsDataManager.java        |   23 +-
 .../ignite/internal/processors/igfs/IgfsEx.java |    4 +-
 .../processors/igfs/IgfsFileAffinityRange.java  |   23 +-
 .../processors/igfs/IgfsFileWorker.java         |  180 -
 .../processors/igfs/IgfsFileWorkerBatch.java    |  225 +-
 .../processors/igfs/IgfsFileWorkerTask.java     |   32 -
 .../processors/igfs/IgfsHelperImpl.java         |    3 +-
 .../internal/processors/igfs/IgfsImpl.java      |  150 +-
 .../processors/igfs/IgfsInputStreamImpl.java    |    2 +-
 .../processors/igfs/IgfsMetaManager.java        |   47 +-
 .../processors/igfs/IgfsOutputStreamImpl.java   |    6 +-
 .../internal/processors/igfs/IgfsProcessor.java |    2 +-
 .../processors/job/GridJobHoldListener.java     |    6 +-
 .../processors/job/GridJobProcessor.java        |   22 +-
 .../internal/processors/job/GridJobWorker.java  |   23 +-
 .../DiscoveryNodeValidationProcessor.java       |   27 +
 .../OsDiscoveryNodeValidationProcessor.java     |   72 +
 .../processors/plugin/CachePluginManager.java   |  142 +
 .../plugin/IgnitePluginProcessor.java           |   71 +-
 .../query/GridQueryFieldMetadata.java           |    2 +-
 .../processors/query/GridQueryIndexing.java     |    3 +-
 .../processors/query/GridQueryProcessor.java    |  224 +-
 .../messages/GridQueryNextPageResponse.java     |   34 +-
 .../processors/rest/GridRestCommand.java        |   11 +-
 .../processors/rest/GridRestProcessor.java      |   40 +-
 .../message/GridClientCacheQueryRequest.java    |  366 --
 .../cache/GridCacheClientQueryResult.java       |   97 -
 .../handlers/cache/GridCacheCommandHandler.java |  140 +-
 .../cache/GridCacheQueryCommandHandler.java     |  480 ---
 .../protocols/tcp/GridTcpRestNioListener.java   |   24 -
 .../rest/request/GridRestCacheQueryRequest.java |  143 -
 .../security/GridSecurityProcessor.java         |   13 +-
 .../processors/security/SecurityContext.java    |    8 +-
 .../security/os/GridOsSecurityProcessor.java    |   11 +-
 .../service/GridServiceProcessor.java           |   15 +-
 .../processors/task/GridTaskProcessor.java      |   40 +-
 .../ignite/internal/util/GridJavaProcess.java   |   38 +-
 .../ignite/internal/util/IgniteUtils.java       |   48 +-
 .../util/future/GridCompoundFuture.java         |    9 +-
 .../internal/util/future/GridFutureAdapter.java |   20 +-
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |   48 +-
 .../ignite/internal/util/lang/GridFunc.java     |   47 +
 .../util/lang/GridMetadataAwareAdapter.java     |    2 +-
 .../util/nodestart/IgniteNodeCallable.java      |   30 -
 .../util/nodestart/IgniteSshHelper.java         |    2 +-
 .../util/nodestart/StartNodeCallable.java       |   30 +
 .../ignite/internal/util/worker/GridWorker.java |    6 +-
 .../ignite/internal/visor/cache/VisorCache.java |   23 +-
 .../cache/VisorCacheAggregatedMetrics.java      |   38 +-
 .../visor/cache/VisorCacheClearTask.java        |    3 +
 .../visor/cache/VisorCacheConfiguration.java    |   94 +-
 .../VisorCacheConfigurationCollectorJob.java    |   76 +
 .../VisorCacheConfigurationCollectorTask.java   |   39 +
 .../cache/VisorCacheDefaultConfiguration.java   |   21 -
 .../visor/cache/VisorCacheMetadataTask.java     |    9 +-
 .../internal/visor/cache/VisorCacheMetrics.java |   55 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |   59 +-
 .../cache/VisorCacheNearConfiguration.java      |   11 +-
 .../cache/VisorCacheQueryConfiguration.java     |    9 -
 .../visor/cache/VisorCacheRebalanceTask.java    |    4 +-
 .../visor/cache/VisorCacheResetMetricsTask.java |    2 +-
 .../visor/cache/VisorCacheStopTask.java         |   69 +
 .../cache/VisorCacheStoreConfiguration.java     |   18 +-
 .../visor/cache/VisorCacheSwapBackupsTask.java  |    2 +-
 .../visor/event/VisorGridEventsLost.java        |    7 +-
 .../event/VisorGridSecuritySessionEvent.java    |   91 -
 .../VisorIgfsProfilerUniformityCounters.java    |    6 +-
 .../internal/visor/log/VisorLogSearchTask.java  |   15 +-
 .../visor/node/VisorGridConfiguration.java      |   12 -
 .../visor/node/VisorIgfsConfiguration.java      |    2 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |    1 +
 .../node/VisorNodeEventsCollectorTask.java      |    3 +
 .../visor/node/VisorRestConfiguration.java      |    1 +
 .../node/VisorSegmentationConfiguration.java    |    4 +-
 .../internal/visor/query/VisorQueryArg.java     |   82 +
 .../visor/query/VisorQueryCleanupTask.java      |   10 +-
 .../internal/visor/query/VisorQueryCursor.java  |   96 +
 .../internal/visor/query/VisorQueryField.java   |   66 +-
 .../internal/visor/query/VisorQueryJob.java     |  174 +
 .../visor/query/VisorQueryNextPageTask.java     |   80 +-
 .../internal/visor/query/VisorQueryResult.java  |    6 +-
 .../visor/query/VisorQueryResultEx.java         |   16 +-
 .../internal/visor/query/VisorQueryTask.java    |  283 +-
 .../internal/visor/query/VisorQueryUtils.java   |   55 +-
 .../internal/visor/util/VisorMimeTypes.java     |    4 +-
 .../internal/visor/util/VisorTaskUtils.java     |   24 +-
 .../org/apache/ignite/lang/IgniteImmutable.java |   49 -
 .../ignite/lang/IgniteProductVersion.java       |    2 +-
 .../ignite/marshaller/MarshallerContext.java    |    8 +-
 .../optimized/OptimizedMarshallerUtils.java     |   11 +-
 .../ignite/plugin/CachePluginConfiguration.java |   36 +
 .../ignite/plugin/CachePluginContext.java       |   65 +
 .../ignite/plugin/CachePluginProvider.java      |   84 +
 .../org/apache/ignite/plugin/IgnitePlugin.java  |    3 -
 .../ignite/plugin/PluginConfiguration.java      |   10 +-
 .../org/apache/ignite/plugin/PluginContext.java |   16 +-
 .../apache/ignite/plugin/PluginProvider.java    |    9 +-
 .../plugin/security/AuthenticationContext.java  |   12 +-
 .../security/GridSecurityCredentials.java       |  184 -
 .../GridSecurityCredentialsBasicProvider.java   |   44 -
 .../GridSecurityCredentialsProvider.java        |   44 -
 .../plugin/security/GridSecurityException.java  |   58 -
 .../plugin/security/GridSecurityPermission.java |   69 -
 .../security/GridSecurityPermissionSet.java     |   66 -
 .../plugin/security/GridSecuritySubject.java    |   62 -
 .../security/GridSecuritySubjectType.java       |   48 -
 .../plugin/security/SecurityCredentials.java    |  191 +
 .../SecurityCredentialsBasicProvider.java       |   44 +
 .../security/SecurityCredentialsProvider.java   |   44 +
 .../plugin/security/SecurityException.java      |   61 +
 .../plugin/security/SecurityPermission.java     |   69 +
 .../plugin/security/SecurityPermissionSet.java  |   66 +
 .../ignite/plugin/security/SecuritySubject.java |   62 +
 .../plugin/security/SecuritySubjectType.java    |   48 +
 .../segmentation/GridSegmentationPolicy.java    |   47 -
 .../segmentation/GridSegmentationResolver.java  |   64 -
 .../plugin/segmentation/SegmentationPolicy.java |   49 +
 .../segmentation/SegmentationResolver.java      |   65 +
 .../ignite/spi/IgniteNodeValidationResult.java  |   66 +
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   58 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |   17 +-
 .../spi/IgniteSpiNodeValidationResult.java      |   66 -
 .../communication/tcp/TcpCommunicationSpi.java  |   99 +-
 .../tcp/TcpCommunicationSpiMBean.java           |    9 -
 .../spi/discovery/DiscoveryMetricsProvider.java |   10 +
 .../ignite/spi/discovery/DiscoverySpi.java      |    7 +
 .../spi/discovery/DiscoverySpiDataExchange.java |    5 +-
 .../DiscoverySpiNodeAuthenticator.java          |    2 +-
 .../discovery/tcp/TcpClientDiscoverySpi.java    |  102 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  375 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |   37 +-
 .../tcp/internal/TcpDiscoveryNode.java          |   82 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |   24 +-
 .../messages/TcpDiscoveryAuthFailedMessage.java |   25 +-
 .../TcpDiscoveryCheckFailedMessage.java         |   24 +-
 .../TcpDiscoveryClientReconnectMessage.java     |   30 +-
 .../TcpDiscoveryCustomEventMessage.java         |   32 +-
 .../messages/TcpDiscoveryDiscardMessage.java    |   24 +-
 .../TcpDiscoveryDuplicateIdMessage.java         |   24 +-
 .../messages/TcpDiscoveryHandshakeRequest.java  |    8 -
 .../messages/TcpDiscoveryHandshakeResponse.java |   22 -
 .../messages/TcpDiscoveryHeartbeatMessage.java  |   95 +-
 .../TcpDiscoveryJoinRequestMessage.java         |   32 +-
 .../TcpDiscoveryLoopbackProblemMessage.java     |   28 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |   24 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |   76 +-
 .../messages/TcpDiscoveryNodeFailedMessage.java |   28 +-
 .../messages/TcpDiscoveryNodeLeftMessage.java   |    8 -
 .../tcp/messages/TcpDiscoveryPingRequest.java   |   25 +-
 .../tcp/messages/TcpDiscoveryPingResponse.java  |   14 -
 .../TcpDiscoveryStatusCheckMessage.java         |   30 +-
 .../spi/swapspace/SwapSpaceSpiListener.java     |    3 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |    6 +-
 .../ignite/startup/BasicWarmupClosure.java      |   39 +-
 .../startup/cmdline/CommandLineStartup.java     |    7 +-
 .../org/apache/ignite/stream/StreamVisitor.java |    2 +-
 .../TransactionSynchronization.java             |   45 -
 .../org/jsr166/ConcurrentLinkedHashMap.java     |    9 +
 .../resources/META-INF/classnames.properties    |  133 +-
 .../GridCacheAffinityBackupsSelfTest.java       |   15 +-
 .../ignite/IgniteCacheAffinitySelfTest.java     |   52 +-
 .../cache/IgniteWarmupClosureSelfTest.java      |   82 +
 .../fair/GridFairAffinityFunctionSelfTest.java  |    2 -
 .../IgniteFairAffinityDynamicCacheSelfTest.java |   97 +
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   11 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |    3 +-
 .../internal/GridCacheProjectionRemoveTest.java |   41 -
 .../internal/GridContinuousTaskSelfTest.java    |  114 +
 ...ridFailFastNodeFailureDetectionSelfTest.java |  117 +
 .../internal/GridLifecycleAwareSelfTest.java    |    2 +-
 .../internal/GridLifecycleBeanSelfTest.java     |   36 +
 .../GridProjectionForCachesSelfTest.java        |   14 +-
 .../ignite/internal/GridProjectionSelfTest.java |   82 +
 .../ignite/internal/GridStartStopSelfTest.java  |    8 +-
 .../internal/IgniteInternalCacheRemoveTest.java |   41 +
 .../managers/GridNoopManagerSelfTest.java       |    2 +-
 .../communication/GridIoManagerSelfTest.java    |    9 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    6 +-
 .../CacheMetricsForClusterGroupSelfTest.java    |  252 ++
 .../GridCacheAbstractFailoverSelfTest.java      |  178 +-
 .../GridCacheAbstractFailoverTxSelfTest.java    |  110 +
 .../cache/GridCacheAbstractFlagsTest.java       |   97 -
 .../cache/GridCacheAbstractFullApiSelfTest.java |  217 +-
 .../GridCacheAbstractIteratorsSelfTest.java     |    3 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |    4 +
 .../cache/GridCacheAbstractSelfTest.java        |  111 +-
 .../cache/GridCacheBasicApiAbstractTest.java    |    4 +-
 .../cache/GridCacheClearAllSelfTest.java        |    2 +-
 .../cache/GridCacheClearLocallySelfTest.java    |   81 +-
 .../GridCacheConcurrentTxMultiNodeTest.java     |   30 +-
 ...idCacheConfigurationConsistencySelfTest.java |    3 -
 .../cache/GridCacheDeploymentSelfTest.java      |    9 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |    4 +-
 .../GridCacheExAbstractFullApiSelfTest.java     |   10 +-
 ...CacheFullTextQueryMultithreadedSelfTest.java |    8 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |    2 +
 .../cache/GridCacheLuceneQueryIndexTest.java    |   20 +-
 .../cache/GridCacheMemoryModeSelfTest.java      |   40 +-
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   47 +-
 .../cache/GridCacheOffHeapSelfTest.java         |  662 ----
 .../processors/cache/GridCacheOffHeapTest.java  |    8 +-
 .../GridCacheOffHeapTieredAbstractSelfTest.java |    8 +-
 .../GridCacheOnCopyFlagAbstractSelfTest.java    |  130 +-
 .../cache/GridCachePartitionedWritesTest.java   |    3 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |   31 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   40 +-
 .../processors/cache/GridCachePutAllTask.java   |   56 +-
 .../GridCacheQueryIndexingDisabledSelfTest.java |   19 +-
 .../GridCacheQueryInternalKeysSelfTest.java     |    4 +-
 .../cache/GridCacheReloadSelfTest.java          |    3 +-
 .../GridCacheReturnValueTransferSelfTest.java   |   46 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |   19 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   42 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |  104 +-
 ...heValueConsistencyTransactionalSelfTest.java |    2 +-
 ...idCacheWriteBehindStoreAbstractSelfTest.java |  189 -
 .../GridCacheWriteBehindStoreAbstractTest.java  |  349 --
 .../GridCacheWriteBehindStoreLocalTest.java     |   30 -
 ...heWriteBehindStoreMultithreadedSelfTest.java |  163 -
 ...BehindStorePartitionedMultiNodeSelfTest.java |  215 -
 ...ridCacheWriteBehindStorePartitionedTest.java |   30 -
 ...GridCacheWriteBehindStoreReplicatedTest.java |   30 -
 .../GridCacheWriteBehindStoreSelfTest.java      |  267 --
 .../IgniteCacheAtomicLocalStoreValueTest.java   |   49 +
 ...iteCacheAtomicNearEnabledStoreValueTest.java |   30 +
 ...maryWriteOrderNearEnabledStoreValueTest.java |   31 +
 ...heAtomicPrimaryWriteOrderStoreValueTest.java |   32 +
 ...IgniteCacheAtomicPutAllFailoverSelfTest.java |   32 +
 .../cache/IgniteCacheAtomicStoreValueTest.java  |   55 +
 ...teCacheConfigurationDefaultTemplateTest.java |  111 +
 .../IgniteCacheConfigurationTemplateTest.java   |  448 +++
 .../IgniteCacheContainsKeyAbstractSelfTest.java |   15 +-
 .../cache/IgniteCacheDynamicStopSelfTest.java   |   19 +-
 .../cache/IgniteCacheInvokeAbstractTest.java    |   11 -
 .../cache/IgniteCachePeekModesAbstractTest.java |   40 +-
 .../IgniteCacheStoreValueAbstractTest.java      |  495 +++
 .../cache/IgniteCacheTxLocalStoreValueTest.java |   49 +
 .../IgniteCacheTxNearEnabledStoreValueTest.java |   30 +
 .../cache/IgniteCacheTxStoreValueTest.java      |   49 +
 .../IgniteClientAffinityAssignmentSelfTest.java |  103 +-
 .../cache/IgniteDynamicCacheStartSelfTest.java  |   74 +-
 .../cache/IgniteInternalCacheTypesTest.java     |  159 +
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |   16 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |    5 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |   53 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |    5 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    4 +-
 .../GridCacheQueueApiSelfAbstractTest.java      |   80 +
 .../GridCacheQueueCleanupSelfTest.java          |   11 +-
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |    5 +-
 ...dCacheQueueMultiNodeConsistencySelfTest.java |   11 +-
 .../GridCacheSequenceApiSelfAbstractTest.java   |    2 +-
 .../GridCacheSetAbstractSelfTest.java           |   15 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |    8 +-
 .../IgniteCollectionAbstractTest.java           |  181 +-
 .../IgniteDataStructureUniqueNameTest.java      |   47 +-
 .../GridCacheLocalAtomicOffheapSetSelfTest.java |   32 +
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    6 +
 .../local/GridCacheLocalAtomicSetSelfTest.java  |    6 +
 .../GridCacheLocalOffheapQueueApiSelfTest.java  |   31 +
 .../local/GridCacheLocalQueueApiSelfTest.java   |    6 +
 .../local/GridCacheLocalSetSelfTest.java        |    6 +
 ...artitionedAtomicOffheapQueueApiSelfTest.java |   32 +
 ...omicOffheapQueueCreateMultiNodeSelfTest.java |   32 +
 ...onedAtomicOffheapQueueMultiNodeSelfTest.java |   32 +
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    6 +
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    6 +
 ...micQueueFailoverDataConsistencySelfTest.java |    6 +
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    6 +
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    6 +
 ...chePartitionedAtomicSetFailoverSelfTest.java |    6 +
 ...rtitionedDataStructuresFailoverSelfTest.java |    6 +
 ...GridCachePartitionedNodeRestartSelfTest.java |   67 -
 ...artitionedOffHeapValuesQueueApiSelfTest.java |   31 +
 ...achePartitionedOffHeapValuesSetSelfTest.java |   32 +
 ...edOffheapDataStructuresFailoverSelfTest.java |   34 +
 ...hePartitionedOffheapSetFailoverSelfTest.java |   32 +
 .../GridCachePartitionedQueueApiSelfTest.java   |    6 +
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   12 +-
 ...dCachePartitionedQueueEntryMoveSelfTest.java |   10 +-
 ...nedQueueFailoverDataConsistencySelfTest.java |    6 +
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    6 +
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    6 +
 ...hePartitionedQueueRotativeMultiNodeTest.java |    6 +
 ...GridCachePartitionedSetFailoverSelfTest.java |    6 +
 .../GridCachePartitionedSetSelfTest.java        |    6 +
 .../IgnitePartitionedSetNoBackupsSelfTest.java  |    5 +-
 ...eplicatedDataStructuresFailoverSelfTest.java |    6 +
 .../GridCacheReplicatedQueueApiSelfTest.java    |   11 +
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    6 +
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    6 +
 .../GridCacheReplicatedSetSelfTest.java         |    6 +
 .../GridCacheAbstractNodeRestartSelfTest.java   |   23 +-
 .../GridCacheAtomicTimeoutSelfTest.java         |  314 --
 .../GridCacheClientModesAbstractSelfTest.java   |    6 +-
 .../distributed/GridCacheEventAbstractTest.java |  295 +-
 .../GridCacheMultiNodeAbstractTest.java         |   13 +-
 .../GridCacheMultiNodeLockAbstractTest.java     |   14 +-
 .../GridCacheNodeFailureAbstractTest.java       |   23 +-
 ...ridCachePartitionNotLoadedEventSelfTest.java |   30 +-
 ...GridCachePreloadRestartAbstractSelfTest.java |    9 -
 .../IgniteCacheAtomicMessageRecoveryTest.java   |   32 +
 .../IgniteCacheAtomicNodeJoinTest.java          |   44 +
 .../IgniteCacheAtomicNodeRestartTest.java       |   33 +
 .../IgniteCacheMessageRecoveryAbstractTest.java |  175 +
 .../IgniteCacheNodeJoinAbstractTest.java        |  109 +
 .../IgniteCachePutGetRestartAbstractTest.java   |  234 ++
 .../IgniteCacheSystemTransactionsSelfTest.java  |   41 +-
 .../IgniteCacheTxFairAffinityNodeJoinTest.java  |   35 +
 .../IgniteCacheTxMessageRecoveryTest.java       |   32 +
 ...iteCacheTxNearDisabledPutGetRestartTest.java |   30 +
 .../distributed/IgniteCacheTxNodeJoinTest.java  |   38 +
 ...xOriginatingNodeFailureAbstractSelfTest.java |    4 +-
 ...cOriginatingNodeFailureAbstractSelfTest.java |    4 +-
 .../IgniteTxTimeoutAbstractTest.java            |    8 -
 ...heAbstractTransformWriteThroughSelfTest.java |    2 +-
 .../dht/GridCacheColocatedFailoverSelfTest.java |    2 +-
 .../dht/GridCacheDhtEntrySelfTest.java          |   12 +-
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   18 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |   28 +-
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |   14 +-
 .../dht/GridCacheDhtMappingSelfTest.java        |    2 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |    8 +-
 .../dht/GridCacheDhtPreloadSelfTest.java        |   12 +-
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |    2 +-
 .../distributed/dht/GridCacheDhtTestUtils.java  |   12 +-
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |   36 +
 ...itionedTxOriginatingNodeFailureSelfTest.java |   17 +-
 .../dht/IgniteCacheLockFailoverSelfTest.java    |  156 +
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |  219 +
 .../atomic/GridCacheAtomicFailoverSelfTest.java |   52 +
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   19 +-
 ...AtomicPrimaryWriteOrderFailoverSelfTest.java |   36 +
 ...idCacheAtomicReplicatedFailoverSelfTest.java |   32 +
 ...sistencyAtomicPrimaryWriteOrderSelfTest.java |   32 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |  103 +-
 ...nlyFairAffinityMultiNodeFullApiSelfTest.java |   36 +
 ...micFairAffinityMultiNodeFullApiSelfTest.java |   35 +
 ...ledFairAffinityMultiNodeFullApiSelfTest.java |   36 +
 ...derFairAffinityMultiNodeFullApiSelfTest.java |   36 +
 .../near/GridCacheNearEvictionSelfTest.java     |    4 +-
 .../near/GridCacheNearMetricsSelfTest.java      |    2 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |  131 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |   35 +-
 ...nlyFairAffinityMultiNodeFullApiSelfTest.java |   35 +
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   29 +-
 .../near/GridCacheNearReadersSelfTest.java      |  154 +-
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |  118 +-
 .../GridCachePartitionedFailoverSelfTest.java   |    2 +-
 ...GridCachePartitionedFilteredPutSelfTest.java |    5 +-
 .../near/GridCachePartitionedFlagsTest.java     |   41 -
 .../GridCachePartitionedFullApiSelfTest.java    |    2 +-
 .../GridCachePartitionedLoadCacheSelfTest.java  |    2 +-
 ...achePartitionedMultiNodeCounterSelfTest.java |    8 -
 ...achePartitionedMultiNodeFullApiSelfTest.java |   70 +-
 ...ePartitionedMultiThreadedPutGetSelfTest.java |    4 +-
 ...NearDisabledBasicStoreMultiNodeSelfTest.java |    8 +-
 .../GridCachePartitionedNodeRestartTest.java    |    1 +
 ...achePartitionedPreloadLifecycleSelfTest.java |    4 +-
 .../GridCachePartitionedTxSalvageSelfTest.java  |    4 +
 .../near/GridPartitionedBackupLoadSelfTest.java |    2 +-
 .../near/IgniteCacheNearReadCommittedTest.java  |    4 +-
 ...nedFairAffinityMultiNodeFullApiSelfTest.java |   37 +
 .../GridCacheReplicatedEvictionSelfTest.java    |    8 +-
 .../GridCacheReplicatedFailoverSelfTest.java    |    2 +-
 .../GridCacheReplicatedFlagsTest.java           |   28 -
 .../GridCacheReplicatedInvalidateSelfTest.java  |   13 +-
 ...licatedNearOnlyMultiNodeFullApiSelfTest.java |    2 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java |    2 +
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |   35 -
 ...acheAtomicReplicatedNodeRestartSelfTest.java |   32 +
 ...CacheReplicatedPreloadLifecycleSelfTest.java |    9 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |   38 +-
 .../eviction/GridCacheEvictionAbstractTest.java |   11 +-
 ...ridCacheFifoBatchEvictionPolicySelfTest.java |  384 ++
 ...dCacheSortedBatchEvictionPolicySelfTest.java |  385 ++
 ...acheSortedEvictionPolicyPerformanceTest.java |  136 +
 .../GridCacheSortedEvictionPolicySelfTest.java  |  373 ++
 .../IgniteCacheExpiryPolicyAbstractTest.java    |   10 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |    4 +-
 ...IgniteCacheJdbcBlobStoreNodeRestartTest.java |   52 +
 ...IgniteCacheStoreNodeRestartAbstractTest.java |  116 +
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   58 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |   26 +-
 ...idCacheWriteBehindStoreAbstractSelfTest.java |  191 +
 .../GridCacheWriteBehindStoreAbstractTest.java  |  350 ++
 .../GridCacheWriteBehindStoreLocalTest.java     |   30 +
 ...heWriteBehindStoreMultithreadedSelfTest.java |  163 +
 ...BehindStorePartitionedMultiNodeSelfTest.java |  216 +
 ...ridCacheWriteBehindStorePartitionedTest.java |   30 +
 ...GridCacheWriteBehindStoreReplicatedTest.java |   30 +
 .../GridCacheWriteBehindStoreSelfTest.java      |  268 ++
 .../continuous/GridEventConsumeSelfTest.java    |   10 +-
 .../DataStreamProcessorSelfTest.java            |    8 +-
 .../processors/igfs/IgfsAbstractSelfTest.java   |   26 +-
 .../igfs/IgfsDataManagerSelfTest.java           |    6 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |    2 +-
 .../processors/igfs/IgfsProcessorSelfTest.java  |   11 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |   56 +-
 .../processors/igfs/IgfsStartCacheTest.java     |  158 +
 .../processors/igfs/IgfsStreamsSelfTest.java    |    7 +-
 .../cache/GridCacheCommandHandlerSelfTest.java  |   12 +-
 .../GridServiceReassignmentSelfTest.java        |    5 +-
 .../internal/util/IgniteUtilsSelfTest.java      |    2 +-
 .../tostring/GridToStringBuilderSelfTest.java   |    5 +-
 .../GridConcurrentLinkedHashMapSelfTest.java    |   17 +
 .../GridContinuousOperationsLoadTest.java       |    3 +-
 .../loadtests/hashmap/GridCacheTestContext.java |   17 +-
 .../loadtests/hashmap/GridHashMapLoadTest.java  |    2 +-
 .../OptimizedMarshallerNodeFailoverTest.java    |   71 +-
 .../OptimizedObjectStreamSelfTest.java          |    4 -
 .../ignite/messaging/GridMessagingSelfTest.java |   50 +
 .../GridP2PMissedResourceCacheSizeSelfTest.java |    2 +-
 .../spi/GridSpiLocalHostInjectionTest.java      |    2 +-
 .../GridPriorityQueueCollisionSpiSelfTest.java  |    2 +-
 .../GridAbstractCommunicationSelfTest.java      |    3 +-
 .../GridTcpCommunicationSpiAbstractTest.java    |    5 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |    3 +-
 .../GridTcpCommunicationSpiConfigSelfTest.java  |    1 -
 ...cpCommunicationSpiMultithreadedSelfTest.java |    3 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    3 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |    2 +-
 .../discovery/AbstractDiscoverySelfTest.java    |    4 +-
 ...ClusterMetricsSnapshotSerializeSelfTest.java |   28 +
 .../tcp/TcpClientDiscoverySelfTest.java         |    5 +-
 .../tcp/TcpDiscoverySpiStartStopSelfTest.java   |    5 +-
 ...RobinLoadBalancingSpiNotPerTaskSelfTest.java |    2 +-
 .../GridSwapSpaceSpiAbstractSelfTest.java       |    9 +-
 .../inmemory/GridTestSwapSpaceSpi.java          |    2 +-
 .../testframework/GridSpiTestContext.java       |   29 +-
 .../ignite/testframework/GridTestUtils.java     |   14 +-
 .../testframework/junits/GridAbstractTest.java  |   34 +-
 .../junits/GridTestKernalContext.java           |    2 +-
 .../ignite/testframework/junits/IgniteMock.java |   15 +
 .../junits/IgniteTestResources.java             |    8 +-
 .../junits/common/GridCommonAbstractTest.java   |  176 +-
 .../junits/spi/GridSpiAbstractTest.java         |   89 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    1 +
 .../IgniteCacheDataStructuresSelfTestSuite.java |   10 +
 .../IgniteCacheEvictionSelfTestSuite.java       |    4 +
 .../IgniteCacheFailoverTestSuite.java           |   26 +-
 .../IgniteCacheFullApiSelfTestSuite.java        |    9 +-
 .../IgniteCacheMetricsSelfTestSuite.java        |    4 +
 .../testsuites/IgniteCacheRestartTestSuite.java |   20 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   33 +-
 .../IgniteCacheWriteBehindTestSuite.java        |    3 +-
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |    2 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    2 +
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |    4 +-
 .../ignite/util/TestTcpCommunicationSpi.java    |   54 +
 modules/extdata/p2p/pom.xml                     |   23 +-
 .../p2p/startcache/CacheAllNodesFilter.java     |   31 +
 .../CacheConfigurationP2PTestClient.java        |  118 +
 .../tests/p2p/startcache/Organization1.java     |   52 +
 .../tests/p2p/startcache/Organization2.java     |   52 +
 modules/extdata/uri/pom.xml                     |   25 +-
 modules/geospatial/README.txt                   |   15 +
 modules/geospatial/pom.xml                      |   43 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |   70 +-
 modules/hadoop/docs/hadoop_readme.pdf           |  Bin 82297 -> 82219 bytes
 modules/hadoop/pom.xml                          |   38 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |    3 +
 .../processors/hadoop/HadoopClassLoader.java    |   21 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java |    2 +-
 .../hadoop/jobtracker/HadoopJobTracker.java     |   27 +-
 .../processors/hadoop/v2/HadoopDaemon.java      |  125 +
 .../processors/hadoop/v2/HadoopV2Job.java       |   58 +-
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |    3 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |    4 +-
 .../hadoop/HadoopClassLoaderTest.java           |    2 +-
 .../HadoopDefaultMapReducePlannerSelfTest.java  |   16 +-
 .../testsuites/IgniteHadoopTestSuite.java       |    2 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |    2 +-
 modules/hibernate/README.txt                    |   15 +
 modules/hibernate/pom.xml                       |   32 +-
 .../HibernateAccessStrategyAdapter.java         |   14 +-
 .../hibernate/HibernateCollectionRegion.java    |    2 +-
 .../cache/hibernate/HibernateEntityRegion.java  |    2 +-
 .../hibernate/HibernateGeneralDataRegion.java   |    4 +-
 .../hibernate/HibernateNaturalIdRegion.java     |    2 +-
 .../HibernateNonStrictAccessStrategy.java       |    6 +-
 .../hibernate/HibernateQueryResultsRegion.java  |    2 +-
 .../HibernateReadOnlyAccessStrategy.java        |    4 +-
 .../HibernateReadWriteAccessStrategy.java       |   10 +-
 .../ignite/cache/hibernate/HibernateRegion.java |    6 +-
 .../cache/hibernate/HibernateRegionFactory.java |   10 +-
 .../hibernate/HibernateTimestampsRegion.java    |    2 +-
 .../HibernateTransactionalAccessStrategy.java   |   12 +-
 .../HibernateTransactionalDataRegion.java       |    2 +-
 .../hibernate/CacheHibernateBlobStore.java      |    9 +-
 .../HibernateL2CacheConfigurationSelfTest.java  |    2 +-
 .../hibernate/HibernateL2CacheSelfTest.java     |    2 +-
 .../CacheHibernateBlobStoreNodeRestartTest.java |   52 +
 .../testsuites/IgniteHibernateTestSuite.java    |    2 +
 modules/indexing/pom.xml                        |   43 +-
 .../processors/query/h2/IgniteH2Indexing.java   |   80 +-
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   95 +-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   64 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |    2 +-
 .../processors/query/h2/opt/GridH2Table.java    |   31 +-
 .../query/h2/opt/GridH2TreeIndex.java           |    4 +-
 .../processors/query/h2/sql/GridSqlElement.java |    8 -
 .../query/h2/sql/GridSqlFunction.java           |    6 +-
 .../query/h2/sql/GridSqlPlaceholder.java        |   51 +
 .../processors/query/h2/sql/GridSqlQuery.java   |  183 +
 .../query/h2/sql/GridSqlQueryParser.java        |  121 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |  149 +-
 .../processors/query/h2/sql/GridSqlSelect.java  |  209 +-
 .../query/h2/sql/GridSqlSubquery.java           |    8 +-
 .../processors/query/h2/sql/GridSqlUnion.java   |  134 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |   88 +-
 .../query/h2/twostep/GridMergeIndex.java        |   17 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |   13 +-
 .../query/h2/twostep/GridResultPage.java        |    9 +-
 .../cache/CacheConfigurationP2PTest.java        |  179 +
 .../cache/CacheConfigurationP2PTestServer.java  |   49 +
 .../GridCacheAbstractFieldsQuerySelfTest.java   |  120 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |  122 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |  129 +-
 .../cache/GridCacheOffHeapSelfTest.java         |  624 +++
 .../cache/GridCacheQueryMetricsSelfTest.java    |   32 +-
 .../GridCacheQuerySerializationSelfTest.java    |  144 +
 ...idCacheReduceQueryMultithreadedSelfTest.java |   15 +-
 .../processors/cache/GridCacheSwapSelfTest.java |  143 +-
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   19 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   30 +-
 .../IgniteCacheCollocatedQuerySelfTest.java     |  209 +
 .../cache/IgniteCacheLargeResultSelfTest.java   |  104 +
 ...CacheOffheapTieredMultithreadedSelfTest.java |  319 ++
 ...hePartitionedQueryMultiThreadedSelfTest.java |    2 +-
 .../cache/IgniteCacheQueryIndexSelfTest.java    |    3 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java     |   26 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |   81 +-
 ...GridCachePartitionedFieldsQuerySelfTest.java |    9 +-
 ...niteCacheAtomicNearEnabledQuerySelfTest.java |    7 +-
 .../near/IgniteCacheAtomicQuerySelfTest.java    |    7 +-
 .../IgniteCachePartitionedQuerySelfTest.java    |    5 +-
 .../GridCacheReplicatedFieldsQuerySelfTest.java |   12 +-
 .../IgniteCacheReplicatedQuerySelfTest.java     |   18 +-
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |   27 +-
 ...cheReduceFieldsQueryPartitionedSelfTest.java |    5 +-
 .../cache/ttl/CacheTtlAbstractSelfTest.java     |  368 ++
 .../ttl/CacheTtlOffheapAbstractSelfTest.java    |   29 +
 .../CacheTtlOffheapAtomicAbstractSelfTest.java  |   29 +
 .../ttl/CacheTtlOffheapAtomicLocalSelfTest.java |   34 +
 ...acheTtlOffheapAtomicPartitionedSelfTest.java |   34 +
 ...TtlOffheapTransactionalAbstractSelfTest.java |   29 +
 ...cheTtlOffheapTransactionalLocalSelfTest.java |   34 +
 ...OffheapTransactionalPartitionedSelfTest.java |   34 +
 .../ttl/CacheTtlOnheapAbstractSelfTest.java     |   29 +
 .../CacheTtlOnheapAtomicAbstractSelfTest.java   |   29 +
 .../ttl/CacheTtlOnheapAtomicLocalSelfTest.java  |   34 +
 ...CacheTtlOnheapAtomicPartitionedSelfTest.java |   34 +
 ...eTtlOnheapTransactionalAbstractSelfTest.java |   29 +
 ...acheTtlOnheapTransactionalLocalSelfTest.java |   34 +
 ...lOnheapTransactionalPartitionedSelfTest.java |   34 +
 .../query/h2/GridH2IndexRebuildTest.java        |   74 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |    8 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |  375 ++
 .../query/h2/sql/BaseH2CompareQueryTest.java    |  856 ++++
 .../query/h2/sql/GridQueryParsingTest.java      |   36 +-
 .../query/h2/sql/H2CompareBigQueryTest.java     |  677 ++++
 .../IgniteCacheQuerySelfTestSuite.java          |   13 +-
 .../IgniteCacheWithIndexingTestSuite.java       |   53 +
 .../IgniteH2IndexingSpiTestSuite.java           |    7 -
 .../processors/query/h2/sql/bigQuery.sql        |   55 +
 modules/jcl/pom.xml                             |   16 +-
 modules/jta/pom.xml                             |   30 +-
 .../processors/cache/jta/CacheJtaManager.java   |    1 -
 .../processors/cache/GridCacheJtaSelfTest.java  |    6 +-
 modules/log4j/pom.xml                           |   16 +-
 modules/rest-http/pom.xml                       |   14 +-
 .../http/jetty/GridJettyRestHandler.java        |    8 +-
 modules/scalar/pom.xml                          |   51 +-
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |   36 -
 modules/schedule/README.txt                     |   15 +
 modules/schedule/pom.xml                        |   36 +-
 modules/schema-import/pom.xml                   |   14 +-
 modules/slf4j/pom.xml                           |   14 +-
 modules/spring/pom.xml                          |   20 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   21 +
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |    8 +-
 modules/ssh/pom.xml                             |   20 +-
 .../util/nodestart/IgniteNodeCallableImpl.java  |  308 --
 .../util/nodestart/IgniteSshHelperImpl.java     |    4 +-
 .../util/nodestart/StartNodeCallableImpl.java   |  309 ++
 ...gniteProjectionStartStopRestartSelfTest.java |  261 +-
 .../IgniteStartStopRestartTestSuite.java        |    1 +
 modules/tools/pom.xml                           |   11 +-
 .../ant/beautifier/GridJavadocAntTask.java      |   10 +-
 .../ignite/tools/classgen/ClassesGenerator.java |    2 +-
 .../ignite/tools/javadoc/IgniteLinkTaglet.java  |   20 +-
 modules/urideploy/README.txt                    |    2 +-
 modules/urideploy/licenses/edtftp-license.pdf   |  Bin 58355 -> 0 bytes
 modules/urideploy/licenses/jtidy-license.txt    |   50 -
 .../urideploy/licenses/jtidy-mit-license.txt    |   50 +
 modules/urideploy/pom.xml                       |   58 +-
 .../GridUriDeploymentFileResourceLoader.java    |    2 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |  182 +-
 .../uri/scanners/GridUriDeploymentScanner.java  |  286 --
 .../GridUriDeploymentScannerListener.java       |    2 +-
 .../uri/scanners/UriDeploymentScanner.java      |   47 +
 .../scanners/UriDeploymentScannerContext.java   |   92 +
 .../scanners/UriDeploymentScannerManager.java   |  221 ++
 .../file/GridUriDeploymentFileScanner.java      |  311 --
 .../scanners/file/UriDeploymentFileScanner.java |  327 ++
 .../ftp/GridUriDeploymentFtpClient.java         |  199 -
 .../ftp/GridUriDeploymentFtpConfiguration.java  |  115 -
 .../ftp/GridUriDeploymentFtpException.java      |   43 -
 .../scanners/ftp/GridUriDeploymentFtpFile.java  |  119 -
 .../ftp/GridUriDeploymentFtpScanner.java        |  234 --
 .../uri/scanners/ftp/package-info.java          |   22 -
 .../http/GridUriDeploymentHttpScanner.java      |  423 --
 .../scanners/http/UriDeploymentHttpScanner.java |  478 +++
 ...loymentMultiScannersErrorThrottlingTest.java |    3 -
 .../GridUriDeploymentMultiScannersSelfTest.java |    3 +-
 .../GridFileDeploymentUndeploySelfTest.java     |    4 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |   46 -
 .../uri/scanners/ftp/package-info.java          |   22 -
 modules/visor-console/pom.xml                   |   28 +-
 .../ignite/visor/commands/VisorConsole.scala    |   43 +-
 .../commands/cache/VisorCacheClearCommand.scala |    3 +-
 .../commands/cache/VisorCacheCommand.scala      |  433 +-
 .../commands/cache/VisorCacheScanCommand.scala  |   13 +-
 .../commands/cache/VisorCacheStopCommand.scala  |  145 +
 .../config/VisorConfigurationCommand.scala      |   15 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    8 +-
 .../commands/events/VisorEventsCommand.scala    |   24 +-
 .../visor/commands/gc/VisorGcCommand.scala      |   15 +-
 .../commands/start/VisorStartCommand.scala      |   21 +-
 .../commands/tasks/VisorTasksCommand.scala      |    6 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   47 +-
 modules/visor-plugins/pom.xml                   |   14 +-
 modules/web/pom.xml                             |   26 +-
 modules/yardstick/README.md                     |    3 +-
 .../yardstick/config/benchmark-store.properties |    5 +-
 modules/yardstick/pom.xml                       |   22 +-
 .../yardstick/IgniteAbstractBenchmark.java      |    5 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   22 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |   11 +-
 .../cache/IgniteCacheAbstractBenchmark.java     |    2 +-
 .../jdbc/IgniteJdbcStoreAbstractBenchmark.java  |    4 +-
 parent/pom.xml                                  |  709 ++++
 pom.xml                                         | 1325 ++-----
 scripts/git-apply-patch.sh                      |   94 +
 scripts/git-format-patch.sh                     |   87 +
 scripts/git-patch-functions.sh                  |  171 +
 scripts/git-patch-prop.sh                       |   24 +
 965 files changed, 40114 insertions(+), 29032 deletions(-)
----------------------------------------------------------------------


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