You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vo...@apache.org on 2017/04/26 13:26:01 UTC

[50/50] [abbrv] ignite git commit: Merge branch 'ignite-2.0'

Merge branch 'ignite-2.0'

# Conflicts:
#	modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServiceProcessorMultiNodeConfigSelfTest.java
#	modules/core/src/test/java/org/apache/ignite/internal/processors/service/GridServiceProcessorMultiNodeSelfTest.java
#	modules/hibernate-4.2/pom.xml
#	modules/hibernate-5.1/pom.xml
#	modules/ml/src/main/java/org/apache/ignite/ml/math/ValueMapper.java
#	modules/ml/src/main/java/org/apache/ignite/ml/math/impls/vector/RandomVector.java
#	modules/ml/src/main/java/org/apache/ignite/ml/math/impls/vector/SingleElementVector.java
#	modules/ml/src/test/java/org/apache/ignite/ml/math/impls/storage/matrix/MatrixStorageFixtures.java
#	pom.xml


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

Branch: refs/heads/master
Commit: 402154c657a06e581e4a0bf24ada42010ec60ac0
Parents: f328c4e 6998785
Author: devozerov <vo...@gridgain.com>
Authored: Wed Apr 26 16:13:13 2017 +0300
Committer: devozerov <vo...@gridgain.com>
Committed: Wed Apr 26 16:13:13 2017 +0300

----------------------------------------------------------------------
 assembly/dependencies-fabric.xml                |    5 +-
 assembly/release-fabric-base.xml                |    5 -
 config/dotnet/default-dotnet.xml                |   45 -
 examples/pom-standalone-lgpl.xml                |    2 +-
 examples/pom-standalone.xml                     |    2 +-
 examples/pom.xml                                |   38 +-
 .../hibernate/HibernateL2CacheExample.java      |   12 +-
 .../examples/datagrid/CacheQueryExample.java    |   54 +-
 .../streaming/wordcount/QueryWords.java         |    3 +-
 .../examples/IndexingBridgeMethodTest.java      |   93 -
 .../IgniteExamplesJ8SelfTestSuite.java          |    2 -
 .../apache/ignite/gridify/AbstractAopTest.java  |    4 +-
 .../gridify/ExternalNonSpringAopSelfTest.java   |    6 +-
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java |    1 +
 .../cassandra/common/PropertyMappingHelper.java |   21 +-
 .../persistence/KeyPersistenceSettings.java     |   18 +-
 .../store/cassandra/persistence/PojoField.java  |   21 +-
 .../cassandra/persistence/PojoKeyField.java     |    7 -
 .../cassandra/persistence/PojoValueField.java   |    6 -
 .../persistence/ValuePersistenceSettings.java   |   12 +-
 .../org/apache/ignite/tests/pojos/Person.java   |   10 +-
 .../org/apache/ignite/tests/pojos/Product.java  |    7 -
 .../apache/ignite/tests/pojos/ProductOrder.java |    8 -
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   92 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |    9 +-
 ...cBinaryMarshallerMergeStatementSelfTest.java |    9 +-
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java |  367 ++++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...bcDynamicIndexAtomicPartitionedSelfTest.java |   39 +
 ...dbcDynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 .../jdbc2/JdbcInsertStatementSelfTest.java      |    4 +-
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |    2 +-
 .../JettyRestProcessorAbstractSelfTest.java     |   10 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    8 +
 .../clients/src/test/resources/spring-cache.xml |    1 -
 .../src/main/java/org/apache/ignite/Ignite.java |    1 -
 .../java/org/apache/ignite/IgniteCache.java     |   11 -
 .../java/org/apache/ignite/IgniteCompute.java   |   14 +
 .../org/apache/ignite/IgniteFileSystem.java     |    6 +-
 .../apache/ignite/IgniteSystemProperties.java   |    8 +
 .../org/apache/ignite/cache/QueryEntity.java    |  101 +-
 .../org/apache/ignite/cache/QueryIndex.java     |    9 +
 .../org/apache/ignite/cache/query/Query.java    |   48 +
 .../ignite/cache/query/SqlFieldsQuery.java      |   26 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   26 +
 .../cache/query/annotations/QuerySqlField.java  |    2 +-
 .../cache/query/annotations/QueryTextField.java |    4 +-
 .../store/jdbc/CacheAbstractJdbcStore.java      |   66 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |    1 -
 .../apache/ignite/cluster/ClusterMetrics.java   |    4 +-
 .../org/apache/ignite/cluster/ClusterNode.java  |   11 +-
 .../configuration/CacheConfiguration.java       |  138 +-
 .../configuration/DataPageEvictionMode.java     |   10 +-
 .../configuration/ExecutorConfiguration.java    |  115 +
 .../configuration/FileSystemConfiguration.java  |  259 +--
 .../configuration/IgniteConfiguration.java      |   82 +-
 .../configuration/MemoryConfiguration.java      |   27 +-
 .../MemoryPolicyConfiguration.java              |   40 +-
 .../org/apache/ignite/events/CacheEvent.java    |    3 -
 .../java/org/apache/ignite/events/Event.java    |    1 -
 .../org/apache/ignite/events/EventType.java     |  111 +-
 .../apache/ignite/events/SwapSpaceEvent.java    |  105 -
 .../org/apache/ignite/igfs/IgfsMetrics.java     |    5 +-
 .../igfs/secondary/IgfsSecondaryFileSystem.java |    4 +-
 .../local/LocalIgfsSecondaryFileSystem.java     |    2 +-
 .../ignite/internal/ExecutorAwareMessage.java   |   31 +
 .../apache/ignite/internal/GridComponent.java   |    5 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   32 +-
 .../ignite/internal/GridKernalContext.java      |   15 +
 .../ignite/internal/GridKernalContextImpl.java  |   25 +-
 .../ignite/internal/GridTaskSessionImpl.java    |   15 +-
 .../org/apache/ignite/internal/GridTopic.java   |    5 +-
 .../ignite/internal/IgniteComputeImpl.java      |   71 +-
 .../org/apache/ignite/internal/IgniteEx.java    |    2 +-
 .../apache/ignite/internal/IgniteKernal.java    |   38 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   84 +
 .../managers/communication/GridIoManager.java   |   25 +-
 .../managers/communication/GridIoMessage.java   |   13 +
 .../communication/GridIoMessageFactory.java     |   14 +-
 .../managers/communication/GridIoPolicy.java    |    3 +
 .../managers/indexing/GridIndexingManager.java  |   44 -
 .../optimized/OptimizedMarshaller.java          |    3 +-
 .../mem/IgniteOutOfMemoryException.java         |   51 +
 .../internal/mem/OutOfMemoryException.java      |   51 -
 .../pagemem/impl/PageMemoryNoStoreImpl.java     |   16 +-
 .../cache/CacheAffinitySharedManager.java       |    3 +-
 .../processors/cache/CacheMetricsImpl.java      |   21 -
 .../cache/CachePartitionExchangeWorkerTask.java |    6 +-
 .../cache/DynamicCacheChangeRequest.java        |   23 +-
 .../cache/DynamicCacheDescriptor.java           |   50 +-
 .../processors/cache/GridCacheAdapter.java      |   29 +-
 .../processors/cache/GridCacheAtomicFuture.java |    5 -
 .../cache/GridCacheBatchSwapEntry.java          |   76 -
 .../processors/cache/GridCacheContext.java      |   23 -
 .../processors/cache/GridCacheEntryEx.java      |   36 +-
 .../GridCacheEntryInfoCollectSwapListener.java  |   70 -
 .../cache/GridCacheEvictionManager.java         |   95 +-
 .../processors/cache/GridCacheMapEntry.java     |   92 +-
 .../processors/cache/GridCacheMvccManager.java  |   10 +-
 .../GridCachePartitionExchangeManager.java      |   36 +-
 .../processors/cache/GridCacheProcessor.java    |  156 +-
 .../processors/cache/GridCacheProxyImpl.java    |   24 -
 .../cache/GridCacheSharedContext.java           |    8 +-
 .../processors/cache/GridCacheSwapEntry.java    |   82 -
 .../cache/GridCacheSwapEntryImpl.java           |  339 ---
 .../processors/cache/GridCacheSwapListener.java |   33 -
 .../cache/GridCacheTryPutFailedException.java   |   28 -
 .../processors/cache/GridCacheUtils.java        |  209 +-
 .../cache/IgniteCacheOffheapManager.java        |    3 -
 .../cache/IgniteCacheOffheapManagerImpl.java    |    5 -
 .../processors/cache/IgniteCacheProxy.java      |   28 +-
 .../processors/cache/IgniteInternalCache.java   |   18 -
 .../IgniteCacheDatabaseSharedManager.java       |  146 +-
 .../CacheDataStructuresManager.java             |   34 +
 .../distributed/GridDistributedLockRequest.java |   14 +-
 .../distributed/GridDistributedTxMapping.java   |   68 +-
 .../GridDistributedTxRemoteAdapter.java         |    2 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |   37 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |    1 -
 .../cache/distributed/dht/GridDhtTxLocal.java   |    2 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   28 +-
 .../dht/GridPartitionedSingleGetFuture.java     |    3 -
 .../GridDhtAtomicAbstractUpdateFuture.java      |    9 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   92 +-
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |    3 -
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    3 -
 .../GridNearAtomicAbstractUpdateFuture.java     |   79 +-
 .../GridNearAtomicSingleUpdateFuture.java       |  134 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |  159 +-
 .../dht/preloader/GridDhtPartitionDemander.java |   12 -
 .../GridDhtPartitionsExchangeFuture.java        |    5 -
 .../dht/preloader/GridDhtPreloader.java         |   18 +-
 .../distributed/near/GridNearAtomicCache.java   |    5 -
 .../distributed/near/GridNearCacheAdapter.java  |    5 -
 .../distributed/near/GridNearCacheEntry.java    |    4 +-
 ...arOptimisticSerializableTxPrepareFuture.java |  218 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   95 +-
 .../GridNearPessimisticTxPrepareFuture.java     |  186 +-
 .../near/GridNearSingleGetRequest.java          |    4 +-
 .../near/GridNearTxFinishFuture.java            |    6 +-
 .../cache/distributed/near/GridNearTxLocal.java |   30 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |   30 +-
 .../cache/local/GridLocalLockFuture.java        |    3 -
 .../local/atomic/GridLocalAtomicCache.java      |   35 +-
 .../cache/query/GridCacheQueryManager.java      |   66 +-
 .../cache/query/IgniteQueryErrorCode.java       |   27 +-
 .../cache/store/CacheOsStoreManager.java        |    3 +
 .../store/GridCacheStoreManagerAdapter.java     |   11 +-
 .../cache/store/GridCacheWriteBehindStore.java  |  614 +++++-
 .../cache/transactions/IgniteTxAdapter.java     |   16 +-
 .../cache/transactions/IgniteTxEntry.java       |   39 +-
 .../cache/transactions/IgniteTxHandler.java     |   49 +-
 .../IgniteTxImplicitSingleStateImpl.java        |    6 +
 .../transactions/IgniteTxLocalAdapter.java      |    7 +-
 .../cache/transactions/IgniteTxLocalState.java  |   10 +
 .../cache/transactions/IgniteTxManager.java     |    7 +-
 .../cache/transactions/IgniteTxState.java       |    2 +-
 .../cache/transactions/IgniteTxStateImpl.java   |   52 +-
 .../closure/GridClosureProcessor.java           |  154 +-
 .../datastructures/DataStructuresProcessor.java |   64 +-
 .../datastructures/GridCacheAtomicLongImpl.java |  626 +++---
 .../GridCacheAtomicReferenceImpl.java           |  356 +++-
 .../GridCacheAtomicSequenceImpl.java            |   88 +-
 .../GridCacheAtomicStampedImpl.java             |  341 +--
 .../GridCacheCountDownLatchImpl.java            |   58 +-
 .../datastructures/GridCacheLockImpl.java       |  103 +-
 .../datastructures/GridCacheQueueProxy.java     |  292 +--
 .../datastructures/GridCacheSemaphoreImpl.java  |  292 ++-
 .../datastructures/GridCacheSetProxy.java       |  152 +-
 .../GridTransactionalCacheQueueImpl.java        |    8 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java |    6 +-
 .../processors/igfs/IgfsDataManager.java        |   36 +-
 .../internal/processors/igfs/IgfsImpl.java      |   30 +-
 .../processors/igfs/IgfsIpcHandler.java         |    2 +-
 .../processors/igfs/IgfsMetaManager.java        |    6 +-
 .../processors/igfs/IgfsNoopProcessor.java      |    4 +-
 .../internal/processors/igfs/IgfsProcessor.java |   30 +-
 .../processors/igfs/IgfsProcessorAdapter.java   |    4 +-
 .../igfs/IgfsSecondaryFileSystemImpl.java       |    4 +-
 .../internal/processors/igfs/IgfsUtils.java     |    3 +
 .../igfs/client/IgfsClientSetTimesCallable.java |    2 +-
 .../IgfsMetaDirectoryListingAddProcessor.java   |    5 +-
 .../processors/job/GridJobProcessor.java        |   41 +-
 .../internal/processors/job/GridJobWorker.java  |   15 +-
 .../platform/PlatformContextImpl.java           |   11 -
 .../platform/cache/PlatformCache.java           |   33 +-
 .../platform/cluster/PlatformClusterGroup.java  |   17 +
 .../utils/PlatformConfigurationUtils.java       |  202 +-
 .../internal/processors/pool/PoolProcessor.java |   30 +
 .../query/GridQueryIndexDescriptor.java         |    5 +
 .../processors/query/GridQueryIndexing.java     |   62 +-
 .../processors/query/GridQueryProcessor.java    | 1765 ++++++++++++++--
 .../query/GridQueryTypeDescriptor.java          |    7 +
 .../processors/query/IgniteSQLException.java    |    7 +
 .../query/QueryIndexDescriptorImpl.java         |   42 +-
 .../processors/query/QueryIndexKey.java         |   85 +
 .../internal/processors/query/QuerySchema.java  |  166 ++
 .../query/QueryTypeDescriptorImpl.java          |  150 +-
 .../internal/processors/query/QueryUtils.java   |  298 ++-
 .../query/schema/SchemaExchangeWorkerTask.java  |   53 +
 .../query/schema/SchemaIndexCacheVisitor.java   |   33 +
 .../schema/SchemaIndexCacheVisitorClosure.java  |   42 +
 .../schema/SchemaIndexCacheVisitorImpl.java     |  197 ++
 .../SchemaIndexOperationCancellationToken.java  |   53 +
 .../processors/query/schema/SchemaKey.java      |   59 +
 .../SchemaNodeLeaveExchangeWorkerTask.java      |   53 +
 .../schema/SchemaOperationClientFuture.java     |   52 +
 .../query/schema/SchemaOperationException.java  |  138 ++
 .../query/schema/SchemaOperationManager.java    |  292 +++
 .../query/schema/SchemaOperationWorker.java     |  205 ++
 .../message/SchemaAbstractDiscoveryMessage.java |   70 +
 .../message/SchemaFinishDiscoveryMessage.java   |   98 +
 .../message/SchemaOperationStatusMessage.java   |  168 ++
 .../message/SchemaProposeDiscoveryMessage.java  |  133 ++
 .../operation/SchemaAbstractOperation.java      |   67 +
 .../operation/SchemaIndexAbstractOperation.java |   40 +
 .../operation/SchemaIndexCreateOperation.java   |   91 +
 .../operation/SchemaIndexDropOperation.java     |   68 +
 .../handlers/cache/GridCacheCommandHandler.java |    4 +-
 .../session/GridTaskSessionProcessor.java       |   10 +-
 .../processors/task/GridTaskProcessor.java      |   69 +-
 .../processors/task/GridTaskWorker.java         |    3 +-
 .../ignite/internal/util/GridIntIterator.java   |   33 +
 .../ignite/internal/util/GridIntList.java       |   26 +-
 .../ignite/internal/util/IgniteUtils.java       |   21 +-
 .../lang/gridfunc/PredicateCollectionView.java  |    7 +-
 .../util/lang/gridfunc/PredicateMapView.java    |    6 -
 .../util/lang/gridfunc/PredicateSetView.java    |    6 -
 .../lang/gridfunc/ReadOnlyCollectionView.java   |    6 -
 .../lang/gridfunc/ReadOnlyCollectionView2X.java |    6 -
 .../lang/gridfunc/TransformCollectionView.java  |    7 +-
 .../util/lang/gridfunc/TransformMapView.java    |    6 -
 .../internal/visor/VisorDataTransferObject.java |   15 +-
 .../visor/binary/VisorBinaryMetadata.java       |    3 +-
 .../visor/cache/VisorCacheConfiguration.java    |    3 +-
 .../visor/cache/VisorCachePartition.java        |   87 -
 .../visor/cache/VisorCachePartitions.java       |   28 +-
 .../visor/cache/VisorCachePartitionsTask.java   |   20 +-
 .../cache/VisorCachePartitionsTaskArg.java      |   72 +
 .../visor/compute/VisorGatewayTask.java         |   91 +-
 .../internal/visor/igfs/VisorIgfsMetrics.java   |    3 +-
 .../visor/node/VisorIgfsConfiguration.java      |   78 -
 .../visor/node/VisorNodeDataCollectorTask.java  |    4 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |    4 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   32 +
 .../spi/IgniteSpiOperationTimeoutHelper.java    |    8 +-
 .../jobstealing/JobStealingCollisionSpi.java    |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    6 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   31 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  142 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |  143 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java |   26 +-
 .../tcp/internal/TcpDiscoveryNode.java          |   33 +-
 .../TcpDiscoveryClientHeartbeatMessage.java     |   72 -
 .../TcpDiscoveryClientMetricsUpdateMessage.java |   72 +
 .../messages/TcpDiscoveryHeartbeatMessage.java  |  338 ---
 .../TcpDiscoveryMetricsUpdateMessage.java       |  338 +++
 .../apache/ignite/spi/indexing/IndexingSpi.java |   19 -
 .../spi/indexing/noop/NoopIndexingSpi.java      |   10 -
 .../adaptive/AdaptiveLoadBalancingSpi.java      |   12 +-
 .../resources/META-INF/classnames.properties    |   58 +-
 .../core/src/test/config/load/dsi-load-base.xml |    3 +-
 .../src/test/config/load/merge-sort-base.xml    |    7 +-
 .../test/config/loaders/grid-cfg-2-grids.xml    |    6 +-
 .../config/streamer/spring-streamer-base.xml    |    5 +-
 .../java/org/apache/ignite/GridTestJob.java     |   19 +
 .../java/org/apache/ignite/GridTestTask.java    |   18 +-
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   19 +-
 ...BinaryMarshallerStoreKeepBinarySelfTest.java |   28 +
 ...lerStoreKeepBinaryWithSqlEscapeSelfTest.java |   28 +
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |  147 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |   10 +-
 .../ignite/internal/GridAffinityMappedTest.java |    5 +-
 .../internal/GridAffinityP2PSelfTest.java       |    3 +-
 .../ignite/internal/GridAffinitySelfTest.java   |    3 +-
 .../internal/GridCacheRecreateLockTest.java     |   78 -
 .../GridCancelledJobsMetricsSelfTest.java       |    4 +-
 ...ridFailFastNodeFailureDetectionSelfTest.java |    4 +-
 .../GridJobCollisionCancelSelfTest.java         |    2 +-
 .../IgniteClientReconnectAtomicsTest.java       |   15 +-
 .../internal/TestRecordingCommunicationSpi.java |   38 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |    4 +-
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java  |    2 +-
 ...CacheExchangeMessageDuplicatedStateTest.java |    8 +-
 .../CacheMemoryPolicyConfigurationTest.java     |    6 +-
 ...sCacheTxNearEnabledRandomOperationsTest.java |   28 +
 .../cache/CrossCacheTxRandomOperationsTest.java |   23 +-
 .../GridCacheAbstractFailoverSelfTest.java      |    4 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   45 -
 .../cache/GridCacheAbstractSelfTest.java        |    4 +-
 .../cache/GridCacheMvccManagerSelfTest.java     |    3 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   22 +-
 .../cache/IgniteCacheAbstractTest.java          |   10 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |   11 +-
 .../IgniteCacheConfigVariationsFullApiTest.java |   45 -
 .../IgniteCacheEntryListenerAbstractTest.java   |    2 +-
 .../IgniteCacheStoreValueAbstractTest.java      |    4 -
 .../cache/IgniteOnePhaseCommitInvokeTest.java   |  211 ++
 .../IgniteTxExceptionAbstractSelfTest.java      |   10 -
 .../cache/MemoryPolicyConfigValidationTest.java |    6 +-
 .../binary/BinaryMetadataUpdatesFlowTest.java   |    4 +-
 .../MemoryPolicyInitializationTest.java         |  307 +++
 ...eAbstractDataStructuresFailoverSelfTest.java |   64 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |    4 +-
 ...IgniteDataStructuresNoClassOnServerTest.java |   30 +
 .../CacheLateAffinityAssignmentTest.java        |   37 +-
 .../CacheNoValueClassOnServerNodeTest.java      |  112 +-
 ...tractDistributedByteArrayValuesSelfTest.java |   43 -
 .../GridCacheNodeFailureAbstractTest.java       |    3 +-
 .../distributed/IgniteCache150ClientsTest.java  |    2 +-
 ...heClientMultiNodeUpdateTopologyLockTest.java |  201 ++
 .../distributed/IgniteCacheGetRestartTest.java  |    2 +-
 .../IgniteCacheNearRestartRollbackSelfTest.java |    2 +-
 .../IgniteCacheReadFromBackupTest.java          |   15 +-
 .../IgniteNoClassOnServerAbstractTest.java      |  135 ++
 .../IgniteTxCachePrimarySyncTest.java           |   17 +-
 ...dCacheColocatedTxSingleThreadedSelfTest.java |    2 +-
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |    2 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |    2 +-
 .../dht/GridNearCacheTxNodeFailureSelfTest.java |   31 -
 .../IgniteCachePutRetryAbstractSelfTest.java    |   25 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |    2 +-
 .../dht/IgniteCacheTxRecoveryRollbackTest.java  |   17 +-
 .../dht/IgniteCrossCacheTxSelfTest.java         |    8 +
 .../atomic/IgniteCacheAtomicProtocolTest.java   |   76 +-
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   51 +-
 .../near/GridCacheNearMultiGetSelfTest.java     |    2 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |    2 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |   59 -
 .../GridCachePartitionedTxSalvageSelfTest.java  |    2 +-
 ...achePartitionedTxSingleThreadedSelfTest.java |    2 +-
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |  151 --
 .../cache/query/IndexingSpiQuerySelfTest.java   |   26 +-
 .../cache/query/IndexingSpiQueryTxSelfTest.java |   10 -
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   24 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |    4 +
 ...heWriteBehindStoreMultithreadedSelfTest.java |   88 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |  159 +-
 ...ClientWriteBehindStoreNonCoalescingTest.java |  168 ++
 ...puteCustomExecutorConfigurationSelfTest.java |   85 +
 .../IgniteComputeCustomExecutorSelfTest.java    |  245 +++
 .../processors/database/BPlusTreeSelfTest.java  |    7 +-
 .../database/FreeListImplSelfTest.java          |    8 +-
 .../database/MetadataStorageSelfTest.java       |    2 +-
 ...faultIgfsSecondaryFileSystemTestAdapter.java |    2 +-
 .../igfs/IgfsAbstractBaseSelfTest.java          |    9 -
 .../processors/igfs/IgfsAbstractSelfTest.java   |   17 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |    8 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |   39 +-
 .../processors/igfs/IgfsIgniteMock.java         |    2 +-
 ...IgfsLocalSecondaryFileSystemTestAdapter.java |    2 +-
 .../processors/igfs/IgfsMaxSizeSelfTest.java    |  121 --
 .../internal/processors/igfs/IgfsMock.java      |    2 +-
 .../processors/igfs/IgfsModesSelfTest.java      |  130 --
 .../igfs/IgfsProcessorValidationSelfTest.java   |   19 +-
 ...gfsSecondaryFileSystemInjectionSelfTest.java |    2 +-
 .../IgfsSecondaryFileSystemTestAdapter.java     |    2 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |   55 +-
 .../service/GridServiceClientNodeTest.java      |    7 +-
 ...ServiceProcessorMultiNodeConfigSelfTest.java |   23 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |   31 +-
 .../loadtests/cache/GridCacheSwapLoadTest.java  |  320 ---
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   11 +-
 ...idSingleSplitsNewNodesMulticastLoadTest.java |    9 +-
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |    2 +-
 .../discovery/AbstractDiscoverySelfTest.java    |   19 +-
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |  245 ++-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |   79 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |   18 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |    4 +-
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |   51 +-
 .../ignite/testframework/GridTestNode.java      |    7 +
 .../testframework/junits/GridAbstractTest.java  |   19 +-
 .../junits/GridTestKernalContext.java           |    6 +-
 .../ignite/testframework/junits/IgniteMock.java |    4 +
 .../junits/common/GridCommonAbstractTest.java   |  189 +-
 .../multijvm/IgniteCacheProcessProxy.java       |    5 -
 .../junits/multijvm/IgniteProcessProxy.java     |    2 +-
 ...ObjectsCacheDataStructuresSelfTestSuite.java |    7 +-
 .../IgniteCacheFailoverTestSuite.java           |    2 -
 .../ignite/testsuites/IgniteCacheTestSuite.java |    4 +
 .../testsuites/IgniteCacheTestSuite2.java       |    7 +
 .../testsuites/IgniteCacheTestSuite3.java       |    2 -
 .../IgniteCacheWriteBehindTestSuite.java        |    2 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    7 +-
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |    3 -
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +
 .../apache/ignite/util/GridIntListSelfTest.java |  153 ++
 .../webapp/META-INF/ignite-webapp-config.xml    |    1 -
 modules/extdata/p2p/pom.xml                     |    6 +
 .../p2p/NoValueClassOnServerAbstractClient.java |   90 +
 .../CacheNoValueClassOnServerTestClient.java    |   79 +-
 ...DataStructuresNoClassOnServerTestClient.java |  181 ++
 .../query/h2/opt/GridH2SpatialIndex.java        |   32 +-
 .../h2/GridBinaryH2IndexingGeoSelfTest.java     |   35 -
 .../query/h2/GridH2IndexingGeoSelfTest.java     |  470 -----
 .../h2/GridH2IndexingSegmentedGeoSelfTest.java  |   37 -
 .../query/h2/H2IndexingAbstractGeoSelfTest.java |  673 ++++++
 .../query/h2/H2IndexingBinaryGeoSelfTest.java   |   30 +
 .../H2IndexingBinarySegmentedGeoSelfTest.java   |   30 +
 .../query/h2/H2IndexingGeoSelfTest.java         |   30 +
 .../h2/H2IndexingSegmentedGeoSelfTest.java      |   30 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |   16 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |    4 +-
 .../org/apache/ignite/hadoop/package-info.java  |   22 -
 .../hadoop/igfs/HadoopIgfsEndpoint.java         |    6 +-
 ...doopIgfsSecondaryFileSystemDelegateImpl.java |    2 +-
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |    2 +-
 .../resources/META-INF/classnames.properties    |    1 +
 .../hadoop/impl/HadoopAbstractSelfTest.java     |    4 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |   16 +-
 ...opClientProtocolMultipleServersSelfTest.java |    8 +-
 .../client/HadoopClientProtocolSelfTest.java    |    7 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   12 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |    1 -
 ...adoopIgfsSecondaryFileSystemTestAdapter.java |    2 +-
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |  119 +-
 modules/hibernate-4.2/README.txt                |   48 +
 modules/hibernate-4.2/licenses/apache-2.0.txt   |  202 ++
 modules/hibernate-4.2/pom.xml                   |  159 ++
 .../HibernateAbstractRegionAccessStrategy.java  |  102 +
 .../hibernate/HibernateCollectionRegion.java    |  100 +
 .../cache/hibernate/HibernateEntityRegion.java  |  112 +
 .../hibernate/HibernateGeneralDataRegion.java   |   76 +
 .../cache/hibernate/HibernateKeyWrapper.java    |   73 +
 .../hibernate/HibernateNaturalIdRegion.java     |  103 +
 .../hibernate/HibernateQueryResultsRegion.java  |   70 +
 .../ignite/cache/hibernate/HibernateRegion.java |   99 +
 .../cache/hibernate/HibernateRegionFactory.java |  179 ++
 .../hibernate/HibernateTimestampsRegion.java    |   39 +
 .../HibernateTransactionalDataRegion.java       |   84 +
 .../ignite/cache/hibernate/package-info.java    |   24 +
 .../hibernate/CacheHibernateBlobStore.java      |  542 +++++
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 +
 .../CacheHibernateBlobStoreFactory.java         |  235 +++
 .../CacheHibernateStoreSessionListener.java     |  222 ++
 .../cache/store/hibernate/package-info.java     |   22 +
 .../src/test/config/factory-cache.xml           |   59 +
 .../src/test/config/factory-cache1.xml          |   61 +
 .../config/factory-incorrect-store-cache.xml    |   56 +
 .../HibernateL2CacheConfigurationSelfTest.java  |  409 ++++
 .../hibernate/HibernateL2CacheMultiJvmTest.java |  440 ++++
 .../hibernate/HibernateL2CacheSelfTest.java     | 1954 +++++++++++++++++
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 ++
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 +
 .../CacheHibernateBlobStoreNodeRestartTest.java |   46 +
 .../CacheHibernateBlobStoreSelfTest.java        |  113 +
 .../CacheHibernateStoreFactorySelfTest.java     |  288 +++
 ...heHibernateStoreSessionListenerSelfTest.java |  238 +++
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 +
 .../cache/store/hibernate/package-info.java     |   22 +
 .../IgniteBinaryHibernateTestSuite.java         |   37 +
 .../testsuites/IgniteHibernateTestSuite.java    |   57 +
 modules/hibernate-5.1/README.txt                |   48 +
 modules/hibernate-5.1/licenses/apache-2.0.txt   |  202 ++
 modules/hibernate-5.1/pom.xml                   |  159 ++
 .../HibernateAbstractRegionAccessStrategy.java  |  103 +
 .../hibernate/HibernateCollectionRegion.java    |  114 +
 .../cache/hibernate/HibernateEntityRegion.java  |  128 ++
 .../hibernate/HibernateGeneralDataRegion.java   |   79 +
 .../cache/hibernate/HibernateKeyWrapper.java    |  109 +
 .../hibernate/HibernateNaturalIdRegion.java     |  113 +
 .../hibernate/HibernateQueryResultsRegion.java  |   70 +
 .../ignite/cache/hibernate/HibernateRegion.java |   99 +
 .../cache/hibernate/HibernateRegionFactory.java |  168 ++
 .../hibernate/HibernateTimestampsRegion.java    |   39 +
 .../HibernateTransactionalDataRegion.java       |   84 +
 .../ignite/cache/hibernate/package-info.java    |   24 +
 .../hibernate/CacheHibernateBlobStore.java      |  543 +++++
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 +
 .../CacheHibernateBlobStoreFactory.java         |  235 +++
 .../CacheHibernateStoreSessionListener.java     |  224 ++
 .../cache/store/hibernate/package-info.java     |   22 +
 .../src/test/config/factory-cache.xml           |   59 +
 .../src/test/config/factory-cache1.xml          |   61 +
 .../config/factory-incorrect-store-cache.xml    |   56 +
 .../HibernateL2CacheConfigurationSelfTest.java  |  407 ++++
 .../hibernate/HibernateL2CacheMultiJvmTest.java |  429 ++++
 .../hibernate/HibernateL2CacheSelfTest.java     | 1960 ++++++++++++++++++
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 ++
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 +
 .../CacheHibernateBlobStoreNodeRestartTest.java |   46 +
 .../CacheHibernateBlobStoreSelfTest.java        |  114 +
 .../CacheHibernateStoreFactorySelfTest.java     |  256 +++
 ...heHibernateStoreSessionListenerSelfTest.java |  242 +++
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 +
 .../cache/store/hibernate/package-info.java     |   22 +
 .../IgniteBinaryHibernate5TestSuite.java        |   37 +
 .../testsuites/IgniteHibernate5TestSuite.java   |   57 +
 modules/hibernate-core/pom.xml                  |   76 +
 .../HibernateAccessStrategyAdapter.java         |  340 +++
 .../HibernateAccessStrategyFactory.java         |  235 +++
 .../cache/hibernate/HibernateCacheProxy.java    |  801 +++++++
 .../hibernate/HibernateExceptionConverter.java  |   29 +
 .../hibernate/HibernateKeyTransformer.java      |   29 +
 .../HibernateNonStrictAccessStrategy.java       |  230 ++
 .../HibernateReadOnlyAccessStrategy.java        |  105 +
 .../HibernateReadWriteAccessStrategy.java       |  326 +++
 .../HibernateTransactionalAccessStrategy.java   |  141 ++
 .../ignite/cache/hibernate/package-info.java    |   24 +
 modules/hibernate/README.txt                    |   48 -
 modules/hibernate/licenses/apache-2.0.txt       |  202 --
 modules/hibernate/pom.xml                       |  146 --
 .../HibernateAbstractRegionAccessStrategy.java  |   98 -
 .../HibernateAccessStrategyAdapter.java         |  379 ----
 .../cache/hibernate/HibernateCacheProxy.java    |  811 --------
 .../hibernate/HibernateCollectionRegion.java    |  100 -
 .../cache/hibernate/HibernateEntityRegion.java  |  112 -
 .../hibernate/HibernateGeneralDataRegion.java   |   71 -
 .../hibernate/HibernateKeyTransformer.java      |   28 -
 .../cache/hibernate/HibernateKeyWrapper.java    |   72 -
 .../hibernate/HibernateNaturalIdRegion.java     |  100 -
 .../HibernateNonStrictAccessStrategy.java       |  222 --
 .../hibernate/HibernateQueryResultsRegion.java  |   70 -
 .../HibernateReadOnlyAccessStrategy.java        |  107 -
 .../HibernateReadWriteAccessStrategy.java       |  328 ---
 .../ignite/cache/hibernate/HibernateRegion.java |   99 -
 .../cache/hibernate/HibernateRegionFactory.java |  266 ---
 .../hibernate/HibernateTimestampsRegion.java    |   39 -
 .../HibernateTransactionalAccessStrategy.java   |  141 --
 .../HibernateTransactionalDataRegion.java       |  107 -
 .../ignite/cache/hibernate/package-info.java    |   24 -
 .../hibernate/CacheHibernateBlobStore.java      |  542 -----
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 -
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 -
 .../CacheHibernateBlobStoreFactory.java         |  235 ---
 .../CacheHibernateStoreSessionListener.java     |  222 --
 .../cache/store/hibernate/package-info.java     |   22 -
 .../hibernate/src/test/config/factory-cache.xml |   59 -
 .../src/test/config/factory-cache1.xml          |   61 -
 .../config/factory-incorrect-store-cache.xml    |   56 -
 .../HibernateL2CacheConfigurationSelfTest.java  |  408 ----
 .../hibernate/HibernateL2CacheSelfTest.java     | 1949 -----------------
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 --
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |   46 -
 .../CacheHibernateBlobStoreSelfTest.java        |  113 -
 .../CacheHibernateStoreFactorySelfTest.java     |  285 ---
 ...heHibernateStoreSessionListenerSelfTest.java |  238 ---
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 -
 .../cache/store/hibernate/package-info.java     |   22 -
 .../IgniteBinaryHibernateTestSuite.java         |   37 -
 .../testsuites/IgniteHibernateTestSuite.java    |   57 -
 modules/hibernate5/README.txt                   |   48 -
 modules/hibernate5/licenses/apache-2.0.txt      |  202 --
 modules/hibernate5/pom.xml                      |  146 --
 .../HibernateAbstractRegionAccessStrategy.java  |   99 -
 .../HibernateAccessStrategyAdapter.java         |  379 ----
 .../cache/hibernate/HibernateCacheProxy.java    |  811 --------
 .../hibernate/HibernateCollectionRegion.java    |  114 -
 .../cache/hibernate/HibernateEntityRegion.java  |  129 --
 .../hibernate/HibernateGeneralDataRegion.java   |   72 -
 .../hibernate/HibernateKeyTransformer.java      |   28 -
 .../cache/hibernate/HibernateKeyWrapper.java    |  108 -
 .../hibernate/HibernateNaturalIdRegion.java     |  113 -
 .../HibernateNonStrictAccessStrategy.java       |  222 --
 .../hibernate/HibernateQueryResultsRegion.java  |   70 -
 .../HibernateReadOnlyAccessStrategy.java        |  107 -
 .../HibernateReadWriteAccessStrategy.java       |  328 ---
 .../ignite/cache/hibernate/HibernateRegion.java |   99 -
 .../cache/hibernate/HibernateRegionFactory.java |  255 ---
 .../hibernate/HibernateTimestampsRegion.java    |   39 -
 .../HibernateTransactionalAccessStrategy.java   |  141 --
 .../HibernateTransactionalDataRegion.java       |  107 -
 .../ignite/cache/hibernate/package-info.java    |   24 -
 .../hibernate/CacheHibernateBlobStore.java      |  542 -----
 .../CacheHibernateBlobStoreEntry.hbm.xml        |   31 -
 .../hibernate/CacheHibernateBlobStoreEntry.java |   89 -
 .../CacheHibernateBlobStoreFactory.java         |  235 ---
 .../CacheHibernateStoreSessionListener.java     |  223 --
 .../cache/store/hibernate/package-info.java     |   22 -
 .../src/test/config/factory-cache.xml           |   59 -
 .../src/test/config/factory-cache1.xml          |   61 -
 .../config/factory-incorrect-store-cache.xml    |   56 -
 .../HibernateL2CacheConfigurationSelfTest.java  |  409 ----
 .../hibernate/HibernateL2CacheSelfTest.java     | 1948 -----------------
 .../HibernateL2CacheTransactionalSelfTest.java  |  154 --
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |   46 -
 .../CacheHibernateBlobStoreSelfTest.java        |  113 -
 .../CacheHibernateStoreFactorySelfTest.java     |  326 ---
 ...heHibernateStoreSessionListenerSelfTest.java |  241 ---
 .../cache/store/hibernate/hibernate.cfg.xml     |   42 -
 .../cache/store/hibernate/package-info.java     |   22 -
 .../IgniteBinaryHibernate5TestSuite.java        |   37 -
 .../testsuites/IgniteHibernate5TestSuite.java   |   57 -
 .../query/h2/DmlStatementsProcessor.java        |   49 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  774 ++++---
 .../query/h2/database/H2PkHashIndex.java        |    6 +-
 .../query/h2/database/H2TreeIndex.java          |    6 +-
 .../query/h2/database/InlineIndexHelper.java    |   14 -
 .../query/h2/ddl/DdlStatementsProcessor.java    |  211 ++
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   89 +-
 .../query/h2/opt/GridH2IndexBase.java           |   40 +-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   70 -
 .../query/h2/opt/GridH2MetaTable.java           |    8 +-
 .../query/h2/opt/GridH2PrimaryScanIndex.java    |   90 +
 .../processors/query/h2/opt/GridH2Row.java      |    2 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |   11 -
 .../query/h2/opt/GridH2ScanIndex.java           |    4 +-
 .../query/h2/opt/GridH2SystemIndexFactory.java  |   38 +
 .../processors/query/h2/opt/GridH2Table.java    |  472 ++---
 .../query/h2/opt/GridH2TreeIndex.java           |    7 +-
 .../query/h2/opt/GridLuceneIndex.java           |   10 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |    3 -
 .../processors/query/h2/sql/GridSqlAlias.java   |   20 +-
 .../query/h2/sql/GridSqlCreateIndex.java        |  121 ++
 .../query/h2/sql/GridSqlDropIndex.java          |   82 +
 .../query/h2/sql/GridSqlQueryParser.java        |  127 ++
 .../processors/query/h2/sql/GridSqlTable.java   |   46 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |    5 +-
 .../query/h2/twostep/GridMergeIndex.java        |    1 +
 .../query/h2/twostep/GridMergeIndexSorted.java  |    6 +-
 .../h2/twostep/GridMergeIndexUnsorted.java      |    6 +-
 .../query/h2/twostep/GridMergeTable.java        |   12 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  251 ++-
 .../query/h2/twostep/GridThreadLocalTable.java  |   14 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   64 +-
 ...ryDuplicateIndexObjectsAbstractSelfTest.java |  159 --
 .../cache/GridCacheOffHeapSelfTest.java         |  476 -----
 .../cache/GridCacheQueryTestValue.java          |    2 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |   39 +-
 .../cache/IgniteCacheDistributedJoinTest.java   |    6 +-
 ...IgniteCacheJoinQueryWithAffinityKeyTest.java |   20 +-
 .../IgniteCacheQueryMultiThreadedSelfTest.java  |   25 -
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |   77 +-
 ...ateIndexObjectPartitionedAtomicSelfTest.java |   38 -
 ...xObjectPartitionedTransactionalSelfTest.java |   41 -
 ...stributedPartitionQueryAbstractSelfTest.java |  655 ++++++
 ...utedPartitionQueryConfigurationSelfTest.java |   92 +
 ...butedPartitionQueryNodeRestartsSelfTest.java |  114 +
 ...eCacheDistributedPartitionQuerySelfTest.java |   90 +
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |    8 +
 .../cache/index/AbstractSchemaSelfTest.java     |  534 +++++
 .../index/DuplicateKeyValueClassesSelfTest.java |   94 +
 .../DynamicIndexAbstractBasicSelfTest.java      | 1078 ++++++++++
 .../DynamicIndexAbstractConcurrentSelfTest.java | 1043 ++++++++++
 .../index/DynamicIndexAbstractSelfTest.java     |  452 ++++
 .../index/DynamicIndexClientBasicSelfTest.java  |   28 +
 ...ndexPartitionedAtomicConcurrentSelfTest.java |   33 +
 ...titionedTransactionalConcurrentSelfTest.java |   33 +
 ...IndexReplicatedAtomicConcurrentSelfTest.java |   33 +
 ...plicatedTransactionalConcurrentSelfTest.java |   33 +
 .../index/DynamicIndexServerBasicSelfTest.java  |   28 +
 ...amicIndexServerCoordinatorBasicSelfTest.java |   28 +
 ...namicIndexServerNodeFIlterBasicSelfTest.java |   28 +
 ...erverNodeFilterCoordinatorBasicSelfTest.java |   30 +
 .../index/H2DynamicIndexAbstractSelfTest.java   |  400 ++++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...H2DynamicIndexAtomicPartitionedSelfTest.java |   39 +
 .../H2DynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 .../index/QueryEntityValidationSelfTest.java    |  162 ++
 .../cache/index/SchemaExchangeSelfTest.java     |  632 ++++++
 .../local/IgniteCacheLocalQuerySelfTest.java    |    2 +-
 .../query/IgniteQueryDedicatedPoolTest.java     |   11 -
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |    2 +-
 .../query/IgniteSqlSplitterSelfTest.java        |   82 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  109 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java      |   16 +-
 .../h2/database/InlineIndexHelperTest.java      |   11 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |  171 +-
 .../query/h2/sql/GridQueryParsingTest.java      |  239 ++-
 .../IgniteBinaryCacheQueryTestSuite.java        |    5 -
 .../IgniteCacheQuerySelfTestSuite.java          |   50 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |   11 +
 .../stream/kafka/connect/IgniteSourceTask.java  |    4 -
 .../java/org/apache/ignite/ml/math/Algebra.java |  107 +-
 .../org/apache/ignite/ml/math/Constants.java    |   35 +-
 .../ignite/ml/math/IdentityValueMapper.java     |    3 +-
 .../java/org/apache/ignite/ml/math/Matrix.java  |   40 +-
 .../org/apache/ignite/ml/math/MurmurHash.java   |   47 +-
 .../java/org/apache/ignite/ml/math/Tracer.java  |    4 +-
 .../org/apache/ignite/ml/math/ValueMapper.java  |    6 +-
 .../java/org/apache/ignite/ml/math/Vector.java  |    3 +-
 .../decompositions/CholeskyDecomposition.java   |   10 +-
 .../math/decompositions/EigenDecomposition.java |   19 +-
 .../ml/math/decompositions/LUDecomposition.java |   18 +-
 .../ignite/ml/math/functions/Functions.java     |   28 +-
 .../functions/IntIntDoubleToVoidFunction.java   |    6 +-
 .../ml/math/impls/matrix/CacheMatrix.java       |   19 +-
 .../ml/math/impls/matrix/PivotedMatrixView.java |   38 +-
 .../impls/matrix/SparseDistributedMatrix.java   |   29 +-
 .../storage/matrix/CacheMatrixStorage.java      |   25 +-
 .../matrix/DenseOffHeapMatrixStorage.java       |   23 +-
 .../storage/matrix/FunctionMatrixStorage.java   |   16 +-
 .../matrix/SparseLocalOnHeapMatrixStorage.java  |   18 +-
 .../storage/vector/CacheVectorStorage.java      |   20 +-
 .../storage/vector/ConstantVectorStorage.java   |    9 +-
 .../storage/vector/DelegateVectorStorage.java   |   12 +-
 .../storage/vector/FunctionVectorStorage.java   |   16 +-
 .../storage/vector/MatrixVectorStorage.java     |   45 +-
 .../storage/vector/PivotedVectorStorage.java    |   15 +-
 .../SingleElementVectorDelegateStorage.java     |   12 +-
 .../vector/SingleElementVectorStorage.java      |   10 +-
 .../vector/SparseLocalOffHeapVectorStorage.java |    6 +-
 .../vector/SparseLocalOnHeapVectorStorage.java  |    9 +-
 .../ml/math/impls/vector/AbstractVector.java    |   16 +-
 .../ml/math/impls/vector/CacheVector.java       |   10 +-
 .../ml/math/impls/vector/ConstantVector.java    |    4 +-
 .../ml/math/impls/vector/DelegatingVector.java  |    2 +-
 .../ml/math/impls/vector/MatrixVectorView.java  |   27 +-
 .../ml/math/impls/vector/PivotedVectorView.java |   32 +-
 .../ml/math/impls/vector/RandomVector.java      |   15 +-
 .../math/impls/vector/SingleElementVector.java  |   10 +-
 .../impls/vector/SingleElementVectorView.java   |    4 +-
 .../ml/math/impls/vector/SparseLocalVector.java |    4 +-
 .../org/apache/ignite/ml/math/TracerTest.java   |   11 +-
 .../ml/math/impls/matrix/CacheMatrixTest.java   |   14 +-
 .../impls/matrix/MatrixKeyMapperForTests.java   |   19 +-
 .../storage/matrix/MatrixStorageFixtures.java   |   18 +-
 .../SparseLocalOffHeapVectorStorageTest.java    |    3 +-
 .../math/impls/vector/AbstractVectorTest.java   |   47 +-
 .../ml/math/impls/vector/CacheVectorTest.java   |    4 +-
 .../osgi-karaf/src/main/resources/features.xml  |    2 +-
 modules/platforms/cpp/odbc/README.txt           |   17 +-
 .../ExpiryCacheHolderTest.cs                    |   10 +
 .../Apache.Ignite.Core.Tests.csproj             |    9 +
 .../Binary/BinaryBuilderSelfTest.cs             |    3 +-
 .../BinaryBuilderSelfTestDynamicRegistration.cs |    2 +
 .../Binary/BinaryBuilderSelfTestSimpleName.cs   |    2 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |    4 +-
 .../BinaryConfigurationTest.cs                  |    4 +-
 .../Cache/AddArgCacheEntryProcessor.cs          |   91 +
 .../Cache/Affinity/AffinityFunctionTest.cs      |    3 +-
 .../Cache/Affinity/AffinityTest.cs              |   10 +-
 .../BinarizableAddArgCacheEntryProcessor.cs     |   53 +
 .../Cache/BinarizableTestException.cs           |   51 +
 .../Cache/CacheAbstractTest.cs                  |  476 +----
 .../Cache/CacheConfigurationTest.cs             |   21 +-
 .../Cache/CacheDynamicStartTest.cs              |  164 +-
 .../Cache/CacheForkedTest.cs                    |    6 +-
 .../Cache/CacheMetricsTest.cs                   |    3 +-
 .../Cache/CacheTestAsyncWrapper.cs              |   22 +-
 .../Cache/CacheTestKey.cs                       |   68 +
 .../Cache/NonSerializableCacheEntryProcessor.cs |   40 +
 .../Cache/NonSerializableException.cs           |   40 +
 .../Cache/PartitionLossTest.cs                  |  260 +++
 .../Cache/Query/CacheQueriesTest.cs             |   35 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |   45 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |   21 +-
 .../Query/Continuous/ContinuousQueryTest.cs     |  115 +
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |    9 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   15 +-
 .../Cache/Store/CacheStoreTest.cs               |   17 +-
 .../Cache/TestReferenceObject.cs                |   40 +
 .../Compute/AbstractTaskTest.cs                 |   29 +-
 .../Compute/BinarizableClosureTaskTest.cs       |   14 +-
 .../Compute/BinarizableTaskTest.cs              |   15 -
 .../Compute/ComputeApiTest.cs                   |    9 +-
 .../Compute/ComputeApiTestFullFooter.cs         |    4 +-
 .../Compute/FailoverTaskSelfTest.cs             |    6 -
 .../Compute/ResourceTaskTest.cs                 |   60 +-
 .../Compute/SerializableClosureTaskTest.cs      |    1 +
 .../Compute/TaskAdapterTest.cs                  |    6 -
 .../Compute/TaskResultTest.cs                   |   12 -
 .../DataStructures/AtomicReferenceTest.cs       |    2 -
 .../Dataload/DataStreamerTest.cs                |   55 +-
 .../Apache.Ignite.Core.Tests/DeploymentTest.cs  |    4 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |   65 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   13 +-
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |   57 +-
 .../Apache.Ignite.Core.Tests/FutureTest.cs      |   18 +-
 .../IgniteConfigurationSerializerTest.cs        |   58 +-
 .../IgniteConfigurationTest.cs                  |   57 +-
 .../IgniteStartStopTest.cs                      |   55 +-
 .../Apache.Ignite.Core.Tests/IgniteTestBase.cs  |   51 +-
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |   45 +-
 .../Apache.Ignite.Core.Tests/LoadDllTest.cs     |   11 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |   30 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |    5 +-
 .../Apache.Ignite.Core.csproj                   |    4 +
 .../Cache/Configuration/CacheConfiguration.cs   |   35 +
 .../Cache/Configuration/DataPageEvictionMode.cs |   59 +
 .../Cache/Configuration/MemoryConfiguration.cs  |  158 ++
 .../Configuration/MemoryPolicyConfiguration.cs  |  122 ++
 .../Cache/Configuration/PartitionLossPolicy.cs  |   68 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |   21 +-
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |   15 -
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   12 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |   21 +
 .../IgniteConfigurationSection.xsd              |  112 +-
 .../Impl/Binary/BinaryUtils.cs                  |  207 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   56 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |    6 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |   27 +
 .../Impl/Common/DelegateConverter.cs            |    1 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   16 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   10 +-
 .../Apache.Ignite.Core/Impl/NativeMethods.cs    |    6 +
 .../Impl/Unmanaged/UnmanagedUtils.cs            |    8 +-
 modules/platforms/dotnet/build.ps1              |   12 +-
 .../Datagrid/MultiTieredCacheExample.cs         |    2 +-
 modules/rocketmq/README.txt                     |   25 +
 modules/rocketmq/pom.xml                        |   81 +
 .../stream/rocketmq/RocketMQStreamer.java       |  151 ++
 .../ignite/stream/rocketmq/package-info.java    |   21 +
 .../stream/rocketmq/RocketMQStreamerTest.java   |  214 ++
 .../rocketmq/RocketMQStreamerTestSuite.java     |   37 +
 .../stream/rocketmq/TestRocketMQServer.java     |  148 ++
 .../ignite/stream/rocketmq/package-info.java    |   21 +
 modules/spring-data/pom.xml                     |    2 +-
 .../support/IgniteRepositoryFactoryBean.java    |    7 +
 .../apache/ignite/cache/spring/SpringCache.java |    6 +
 .../GridSpringResourceInjectionSelfTest.java    |   20 +-
 .../org/apache/ignite/spring/sprint-exclude.xml |    2 -
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |    4 +-
 modules/web-console/backend/app/mongo.js        |    4 -
 modules/web-console/backend/index.js            |    5 +-
 .../list-of-registered-users.column-defs.js     |   26 +-
 .../list-of-registered-users.controller.js      |  163 +-
 .../list-of-registered-users.tpl.pug            |   25 +-
 .../frontend/app/data/event-groups.json         |   14 -
 .../frontend/app/modules/cluster/Cache.js       |    4 -
 .../app/modules/cluster/CacheMetrics.js         |    4 -
 .../generator/AbstractTransformer.js            |    5 -
 .../generator/ConfigurationGenerator.js         |   11 -
 .../generator/defaults/IGFS.service.js          |    3 -
 .../modules/states/configuration/igfs/dual.pug  |   42 -
 .../modules/states/configuration/igfs/misc.pug  |    2 -
 .../frontend/app/primitives/badge/index.scss    |    1 +
 .../frontend/app/primitives/btn/index.scss      |   24 +-
 .../frontend/app/primitives/dropdown/index.pug  |    2 +-
 .../frontend/app/primitives/dropdown/index.scss |   26 +-
 .../frontend/app/primitives/panel/index.scss    |    2 +-
 .../app/primitives/ui-grid-header/index.scss    |   10 +-
 .../app/primitives/ui-grid-header/index.tpl.pug |   10 +-
 .../app/primitives/ui-grid-settings/index.scss  |   58 +-
 .../frontend/app/primitives/ui-grid/index.scss  |  149 +-
 .../frontend/gulpfile.babel.js/paths.js         |    1 +
 .../frontend/gulpfile.babel.js/tasks/bundle.js  |    2 +-
 .../webpack/environments/development.js         |    4 +-
 .../frontend/public/images/icons/cross.svg      |    1 +
 .../frontend/public/images/icons/export.svg     |    1 +
 .../frontend/public/images/icons/gear.svg       |    1 +
 .../stylesheets/_bootstrap-variables.scss       |    4 +-
 .../frontend/views/configuration/igfs.tpl.pug   |    1 -
 .../views/templates/agent-download.tpl.pug      |    6 +-
 modules/web-console/licenses/cc-by-3.0.txt      |  319 +++
 modules/web-console/web-agent/pom.xml           |    2 +-
 .../ignite/console/agent/AgentLauncher.java     |   10 +-
 .../webapp2/META-INF/ignite-webapp-config.xml   |    1 -
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |    5 +-
 parent/pom.xml                                  |   11 +-
 pom.xml                                         |   20 +-
 852 files changed, 42002 insertions(+), 29237 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/examples/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/modules/extdata/p2p/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/modules/hibernate-4.2/pom.xml
----------------------------------------------------------------------
diff --cc modules/hibernate-4.2/pom.xml
index 0000000,c597b21..adcf1b1
mode 000000,100644..100644
--- a/modules/hibernate-4.2/pom.xml
+++ b/modules/hibernate-4.2/pom.xml
@@@ -1,0 -1,159 +1,159 @@@
+ <?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-parent</artifactId>
+         <version>1</version>
+         <relativePath>../../parent</relativePath>
+     </parent>
+ 
+     <artifactId>ignite-hibernate_4.2</artifactId>
 -    <version>2.0.0-SNAPSHOT</version>
++    <version>2.1.0-SNAPSHOT</version>
+     <url>http://ignite.apache.org</url>
+ 
+     <dependencies>
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-core</artifactId>
+             <version>${project.version}</version>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-hibernate-core</artifactId>
+             <version>${project.version}</version>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.hibernate</groupId>
+             <artifactId>hibernate-core</artifactId>
+             <version>4.2.21.Final</version>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-jta</artifactId>
+             <version>${project.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.ow2.jotm</groupId>
+             <artifactId>jotm-core</artifactId>
+             <version>2.1.9</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>commons-dbcp</groupId>
+             <artifactId>commons-dbcp</artifactId>
+             <version>1.4</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>com.h2database</groupId>
+             <artifactId>h2</artifactId>
+             <version>${h2.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>javax.resource</groupId>
+             <artifactId>connector-api</artifactId>
+             <version>1.5</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-core</artifactId>
+             <version>${project.version}</version>
+             <type>test-jar</type>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-spring</artifactId>
+             <version>${project.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-log4j</artifactId>
+             <version>${project.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.springframework</groupId>
+             <artifactId>spring-beans</artifactId>
+             <version>${spring.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.springframework</groupId>
+             <artifactId>spring-context</artifactId>
+             <version>${spring.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>com.thoughtworks.xstream</groupId>
+             <artifactId>xstream</artifactId>
+             <version>1.4.8</version>
+             <scope>test</scope>
+         </dependency>
+     </dependencies>
+ 
+     <build>
+         <testResources>
+             <testResource>
+                 <directory>src/main/java</directory>
+                 <excludes>
+                     <exclude>**/*.java</exclude>
+                 </excludes>
+             </testResource>
+             <testResource>
+                 <directory>src/test/java</directory>
+                 <excludes>
+                     <exclude>**/*.java</exclude>
+                 </excludes>
+             </testResource>
+         </testResources>
+ 
+         <plugins>
+             <!-- Generate the OSGi MANIFEST.MF for this bundle. -->
+             <plugin>
+                 <groupId>org.apache.felix</groupId>
+                 <artifactId>maven-bundle-plugin</artifactId>
+             </plugin>
+         </plugins>
+     </build>
+ </project>

http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/modules/hibernate-5.1/pom.xml
----------------------------------------------------------------------
diff --cc modules/hibernate-5.1/pom.xml
index 0000000,80299bc..8424806
mode 000000,100644..100644
--- a/modules/hibernate-5.1/pom.xml
+++ b/modules/hibernate-5.1/pom.xml
@@@ -1,0 -1,159 +1,159 @@@
+ <?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-parent</artifactId>
+         <version>1</version>
+         <relativePath>../../parent</relativePath>
+     </parent>
+ 
+     <artifactId>ignite-hibernate_5.1</artifactId>
 -    <version>2.0.0-SNAPSHOT</version>
++    <version>2.1.0-SNAPSHOT</version>
+     <url>http://ignite.apache.org</url>
+ 
+     <dependencies>
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-core</artifactId>
+             <version>${project.version}</version>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-hibernate-core</artifactId>
+             <version>${project.version}</version>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.hibernate</groupId>
+             <artifactId>hibernate-core</artifactId>
+             <version>5.1.5.Final</version>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-jta</artifactId>
+             <version>${project.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.ow2.jotm</groupId>
+             <artifactId>jotm-core</artifactId>
+             <version>2.1.9</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>commons-dbcp</groupId>
+             <artifactId>commons-dbcp</artifactId>
+             <version>1.4</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>com.h2database</groupId>
+             <artifactId>h2</artifactId>
+             <version>${h2.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>javax.resource</groupId>
+             <artifactId>connector-api</artifactId>
+             <version>1.5</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-core</artifactId>
+             <version>${project.version}</version>
+             <type>test-jar</type>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-spring</artifactId>
+             <version>${project.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.apache.ignite</groupId>
+             <artifactId>ignite-log4j</artifactId>
+             <version>${project.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.springframework</groupId>
+             <artifactId>spring-beans</artifactId>
+             <version>${spring.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>org.springframework</groupId>
+             <artifactId>spring-context</artifactId>
+             <version>${spring.version}</version>
+             <scope>test</scope>
+         </dependency>
+ 
+         <dependency>
+             <groupId>com.thoughtworks.xstream</groupId>
+             <artifactId>xstream</artifactId>
+             <version>1.4.8</version>
+             <scope>test</scope>
+         </dependency>
+     </dependencies>
+ 
+     <build>
+         <testResources>
+             <testResource>
+                 <directory>src/main/java</directory>
+                 <excludes>
+                     <exclude>**/*.java</exclude>
+                 </excludes>
+             </testResource>
+             <testResource>
+                 <directory>src/test/java</directory>
+                 <excludes>
+                     <exclude>**/*.java</exclude>
+                 </excludes>
+             </testResource>
+         </testResources>
+ 
+         <plugins>
+             <!-- Generate the OSGi MANIFEST.MF for this bundle. -->
+             <plugin>
+                 <groupId>org.apache.felix</groupId>
+                 <artifactId>maven-bundle-plugin</artifactId>
+             </plugin>
+         </plugins>
+     </build>
+ </project>

http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/vector/SingleElementVector.java
----------------------------------------------------------------------
diff --cc modules/ml/src/main/java/org/apache/ignite/ml/math/impls/vector/SingleElementVector.java
index cae5ca3,3ec14a2..a5dc64b
--- a/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/vector/SingleElementVector.java
+++ b/modules/ml/src/main/java/org/apache/ignite/ml/math/impls/vector/SingleElementVector.java
@@@ -1,102 -1,1 +1,102 @@@
 -/*
 * 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.ml.math.impls.vector;

import java.util.Map;
import org.apache.ignite.ml.math.Matrix;
import org.apache.ignite.ml.math.Vector;
import org.apache.ignite.ml.math.except
 ions.UnsupportedOperationException;
import org.apache.ignite.ml.math.impls.storage.vector.SingleElementVectorStorage;

/**
 * Read-write vector holding a single non-zero value at some index.
 */
public class SingleElementVector extends AbstractVector {
    /**
     *
     */
    public SingleElementVector() {
        // No-op
    }

    /**
     * @param size Parent vector size.
     * @param idx Index of the parent vector element.
     * @param val Value of the vector element.
     */
    public SingleElementVector(int size, int idx, double val) {
        super(new SingleElementVectorStorage(size, idx, val));
    }

    /**
     * @param args Parameters to create new vector instance.
     */
    public SingleElementVector(Map<String, Object> args) {
        assert args != null;

        if (args.containsKey("size") && args.containsKey("index") && args.containsKey("value")) {
            int size = (int)args.get("size");
            int idx = (int)args.get("index");
            doub
 le val = (double)args.get("value");

            setStorage(new SingleElementVectorStorage(size, idx, val));
        }
        else
            throw new UnsupportedOperationException("Invalid constructor argument(s).");
    }

    /**
     *
     *
     */
    private SingleElementVectorStorage storage() {
        return (SingleElementVectorStorage)getStorage();
    }

    /** {@inheritDoc} */
    @Override public Element minElement() {
        return makeElement(storage().index());
    }

    /** {@inheritDoc} */
    @Override public Element maxElement() {
        return makeElement(storage().index());
    }

    /** {@inheritDoc} */
    @Override public double sum() {
        return getX(storage().index());
    }

    /** {@inheritDoc} */
    @Override public int nonZeroElements() {
        return isZero(get(storage().index())) ? 0 : 1;
    }

    /** {@inheritDoc} */
    @Override public Vector like(int crd) {
        int idx = storage().index();

        return new SingleElemen
 tVector(crd, idx, getX(idx));
    }

    /** {@inheritDoc} */
    @Override public Matrix likeMatrix(int rows, int cols) {
        throw new UnsupportedOperationException();
    }
}
 +/*
 + * 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.ml.math.impls.vector;
 +
 +import java.util.Map;
 +import org.apache.ignite.ml.math.Matrix;
 +import org.apache.ignite.ml.math.Vector;
 +import org.apache.ignite.ml.math.exceptions.UnsupportedOperationException;
 +import org.apache.ignite.ml.math.impls.storage.vector.SingleElementVectorStorage;
 +
 +/**
 + * Read-write vector holding a single non-zero value at some index.
 + */
 +public class SingleElementVector extends AbstractVector {
 +    /**
 +     *
 +     */
 +    public SingleElementVector() {
 +        // No-op
 +    }
 +
 +    /**
-      * @param size
-      * @param idx
-      * @param val
++     * @param size Parent vector size.
++     * @param idx Index of the parent vector element.
++     * @param val Value of the vector element.
 +     */
 +    public SingleElementVector(int size, int idx, double val) {
 +        super(new SingleElementVectorStorage(size, idx, val));
 +    }
 +
 +    /**
-      * @param args
++     * @param args Parameters to create new vector instance.
 +     */
 +    public SingleElementVector(Map<String, Object> args) {
 +        assert args != null;
 +
 +        if (args.containsKey("size") && args.containsKey("index") && args.containsKey("value")) {
 +            int size = (int)args.get("size");
 +            int idx = (int)args.get("index");
 +            double val = (double)args.get("value");
 +
 +            setStorage(new SingleElementVectorStorage(size, idx, val));
 +        }
 +        else
 +            throw new UnsupportedOperationException("Invalid constructor argument(s).");
 +    }
 +
 +    /**
 +     *
 +     *
 +     */
 +    private SingleElementVectorStorage storage() {
 +        return (SingleElementVectorStorage)getStorage();
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public Element minElement() {
 +        return makeElement(storage().index());
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public Element maxElement() {
 +        return makeElement(storage().index());
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public double sum() {
 +        return getX(storage().index());
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public int nonZeroElements() {
 +        return isZero(get(storage().index())) ? 0 : 1;
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public Vector like(int crd) {
 +        int idx = storage().index();
 +
 +        return new SingleElementVector(crd, idx, getX(idx));
 +    }
 +
 +    /** {@inheritDoc} */
 +    @Override public Matrix likeMatrix(int rows, int cols) {
 +        throw new UnsupportedOperationException();
 +    }
- }
++}

http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/modules/spring-data/pom.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/402154c6/modules/web-console/web-agent/pom.xml
----------------------------------------------------------------------

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