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/12/19 12:18:04 UTC

[07/31] ignite git commit: Merge branch 'master' into ignite-4490

Merge branch 'master' into ignite-4490

# Conflicts:
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java


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

Branch: refs/heads/ignite-6022-proto
Commit: e66b664213633bcd48fe21cd8784135ac5080504
Parents: 336ad01 3919d80
Author: Alexander Paschenko <al...@gmail.com>
Authored: Thu Aug 10 20:44:54 2017 +0300
Committer: Alexander Paschenko <al...@gmail.com>
Committed: Thu Aug 10 20:48:51 2017 +0300

----------------------------------------------------------------------
 DEVNOTES.txt                                    |   18 +-
 LICENSE                                         |    7 +
 RELEASE_NOTES.txt                               |   33 +
 examples/config/example-default.xml             |    7 -
 examples/config/example-memory-policies.xml     |    7 +-
 examples/pom.xml                                |    9 +-
 .../datagrid/CacheClientBinaryQueryExample.java |    3 +
 .../store/auto/CacheBinaryAutoStoreExample.java |  170 --
 .../datagrid/store/auto/package-info.java       |   22 -
 .../examples/datagrid/CacheQueryDdlExample.java |  118 +
 .../ignite/examples/datagrid/JdbcExample.java   |  135 +
 .../ml/math/matrix/ExampleMatrixStorage.java    |    6 +-
 .../CacheExamplesMultiNodeSelfTest.java         |    9 +
 .../ignite/examples/CacheExamplesSelfTest.java  |    8 +
 modules/aop/pom.xml                             |    2 +-
 modules/apache-license-gen/pom.xml              |    2 +-
 modules/aws/pom.xml                             |    2 +-
 modules/benchmarks/pom.xml                      |    2 +-
 .../jmh/cache/JmhCacheLocksBenchmark.java       |  119 +
 modules/camel/pom.xml                           |    2 +-
 modules/cassandra/pom.xml                       |    2 +-
 modules/cassandra/serializers/pom.xml           |    4 +-
 modules/cassandra/store/pom.xml                 |    4 +-
 .../ignite/tests/utils/TestTransaction.java     |   10 +
 modules/clients/pom.xml                         |    2 +-
 .../client/suite/IgniteClientTestSuite.java     |    2 +
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   12 +
 .../jdbc2/JdbcDefaultNoOpCacheTest.java         |   33 +
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java |    2 -
 .../jdbc2/JdbcPreparedStatementSelfTest.java    |   35 +
 .../JettyRestProcessorAbstractSelfTest.java     |   70 +-
 .../tcp/redis/RedisProtocolServerSelfTest.java  |  110 +
 .../tcp/redis/RedisProtocolStringSelfTest.java  |   45 +-
 .../ignite/jdbc/JdbcDefaultNoOpCacheTest.java   |   35 +
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |   50 +-
 .../jdbc/JdbcPreparedStatementSelfTest.java     |   35 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    7 +-
 .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java |  333 +++
 .../JdbcThinDynamicIndexAbstractSelfTest.java   |    2 -
 .../thin/JdbcThinPreparedStatementSelfTest.java |   35 +
 modules/cloud/pom.xml                           |    2 +-
 modules/codegen/pom.xml                         |    2 +-
 modules/core/pom.xml                            |    9 +-
 .../java/org/apache/ignite/IgniteCache.java     |    1 -
 .../org/apache/ignite/IgniteDataStreamer.java   |   26 +-
 .../apache/ignite/IgniteSystemProperties.java   |   44 +-
 .../org/apache/ignite/cache/CacheManager.java   |   14 +-
 .../org/apache/ignite/cache/QueryEntity.java    |  229 ++
 .../apache/ignite/cache/affinity/Affinity.java  |   16 +-
 .../rendezvous/RendezvousAffinityFunction.java  |    8 +-
 .../ignite/compute/ComputeJobAdapter.java       |    2 +-
 .../configuration/CacheConfiguration.java       |  620 +---
 .../configuration/IgniteConfiguration.java      |   15 +-
 .../configuration/MemoryConfiguration.java      |    4 +-
 .../MemoryPolicyConfiguration.java              |    4 +-
 .../PersistentStoreConfiguration.java           |  124 +-
 .../org/apache/ignite/events/EventType.java     |   12 +
 .../ignite/events/WalSegmentArchivedEvent.java  |   62 +
 .../apache/ignite/internal/GridComponent.java   |    4 +-
 .../ignite/internal/GridKernalContext.java      |    2 +-
 .../ignite/internal/GridKernalContextImpl.java  |    6 +-
 .../ignite/internal/GridPluginComponent.java    |    2 +-
 .../internal/IgniteDiagnosticMessage.java       |   12 +-
 .../IgniteDiagnosticPrepareContext.java         |    6 +-
 .../apache/ignite/internal/IgniteKernal.java    |  120 +-
 .../ignite/internal/IgniteNodeAttributes.java   |    3 +
 .../org/apache/ignite/internal/IgnitionEx.java  |   66 +-
 .../ignite/internal/MarshallerContextImpl.java  |   14 +-
 .../ignite/internal/binary/BinaryContext.java   |    1 +
 .../ignite/internal/binary/BinaryUtils.java     |   38 +-
 .../internal/binary/BinaryWriterExImpl.java     |    4 +-
 .../internal/binary/GridBinaryMarshaller.java   |    3 +
 .../binary/builder/BinaryBuilderSerializer.java |    6 +-
 .../client/router/impl/GridTcpRouterImpl.java   |   57 +-
 .../internal/jdbc/JdbcPreparedStatement.java    |    6 +-
 .../internal/jdbc/thin/JdbcThinConnection.java  |    7 +-
 .../jdbc/thin/JdbcThinPreparedStatement.java    |   18 +-
 .../internal/jdbc/thin/JdbcThinStatement.java   |   46 +-
 .../internal/jdbc/thin/JdbcThinTcpIo.java       |   20 +
 .../ignite/internal/jdbc2/JdbcConnection.java   |    5 +-
 .../internal/jdbc2/JdbcPreparedStatement.java   |   12 +-
 .../internal/managers/GridManagerAdapter.java   |    2 +-
 .../managers/communication/GridIoManager.java   |    6 +
 .../managers/communication/GridIoMessage.java   |    3 +
 .../communication/GridIoMessageFactory.java     |    2 +-
 .../managers/communication/GridIoPolicy.java    |    3 +
 .../internal/managers/discovery/DiscoCache.java |   17 +-
 .../discovery/DiscoveryLocalJoinData.java       |  104 +
 .../discovery/GridDiscoveryManager.java         |  174 +-
 .../eventstorage/GridEventStorageManager.java   |  323 +-
 .../eventstorage/HighPriorityListener.java      |   28 +
 .../mem/file/MappedFileMemoryProvider.java      |    3 +-
 .../ignite/internal/pagemem/FullPageId.java     |   38 +-
 .../ignite/internal/pagemem/PageIdUtils.java    |   14 +-
 .../ignite/internal/pagemem/PageSupport.java    |   36 +-
 ...ishSnapshotOperationAckDiscoveryMessage.java |   77 -
 .../pagemem/snapshot/SnapshotOperation.java     |  202 --
 .../pagemem/snapshot/SnapshotOperationType.java |   49 -
 ...artSnapshotOperationAckDiscoveryMessage.java |  149 -
 .../StartSnapshotOperationDiscoveryMessage.java |  192 --
 .../pagemem/store/IgnitePageStoreManager.java   |   44 +-
 .../internal/pagemem/store/PageStore.java       |    7 +
 .../internal/pagemem/wal/record/WALRecord.java  |   11 +-
 .../delta/DataPageInsertFragmentRecord.java     |    6 +-
 .../wal/record/delta/DataPageInsertRecord.java  |    6 +-
 .../wal/record/delta/DataPageRemoveRecord.java  |    6 +-
 .../delta/DataPageSetFreeListPageRecord.java    |    6 +-
 .../wal/record/delta/DataPageUpdateRecord.java  |    6 +-
 .../wal/record/delta/FixCountRecord.java        |    6 +-
 .../record/delta/FixLeftmostChildRecord.java    |    6 +-
 .../pagemem/wal/record/delta/FixRemoveId.java   |    6 +-
 .../wal/record/delta/InitNewPageRecord.java     |    6 +-
 .../wal/record/delta/InnerReplaceRecord.java    |    6 +-
 .../pagemem/wal/record/delta/InsertRecord.java  |    6 +-
 .../pagemem/wal/record/delta/MergeRecord.java   |    6 +-
 .../wal/record/delta/MetaPageAddRootRecord.java |    6 +-
 .../wal/record/delta/MetaPageCutRootRecord.java |    6 +-
 .../wal/record/delta/MetaPageInitRecord.java    |    6 +-
 .../delta/MetaPageInitRootInlineRecord.java     |    6 +-
 .../record/delta/MetaPageInitRootRecord.java    |    4 +-
 .../delta/MetaPageUpdateLastAllocatedIndex.java |    6 +-
 ...aPageUpdateLastSuccessfulFullSnapshotId.java |    4 +-
 .../MetaPageUpdateLastSuccessfulSnapshotId.java |    4 +-
 .../delta/MetaPageUpdateNextSnapshotId.java     |    4 +-
 .../MetaPageUpdatePartitionDataRecord.java      |    8 +-
 .../wal/record/delta/NewRootInitRecord.java     |    6 +-
 .../wal/record/delta/PageDeltaRecord.java       |   14 +-
 .../delta/PageListMetaResetCountRecord.java     |    6 +-
 .../record/delta/PagesListAddPageRecord.java    |    6 +-
 .../delta/PagesListInitNewPageRecord.java       |    6 +-
 .../record/delta/PagesListRemovePageRecord.java |    2 +-
 .../record/delta/PagesListSetNextRecord.java    |    6 +-
 .../delta/PagesListSetPreviousRecord.java       |    6 +-
 .../record/delta/PartitionDestroyRecord.java    |   20 +-
 .../record/delta/PartitionMetaStateRecord.java  |   16 +-
 .../pagemem/wal/record/delta/RecycleRecord.java |    6 +-
 .../pagemem/wal/record/delta/RemoveRecord.java  |    6 +-
 .../pagemem/wal/record/delta/ReplaceRecord.java |    6 +-
 .../record/delta/SplitExistingPageRecord.java   |    6 +-
 .../record/delta/SplitForwardPageRecord.java    |    6 +-
 .../record/delta/TrackingPageDeltaRecord.java   |    6 +-
 .../processors/GridProcessorAdapter.java        |    2 +-
 .../affinity/GridAffinityProcessor.java         |    2 +-
 .../cache/CacheAffinitySharedManager.java       |  365 ++-
 .../processors/cache/CacheGroupContext.java     |    4 +-
 .../processors/cache/CacheGroupData.java        |    4 +-
 .../processors/cache/CacheGroupDescriptor.java  |   20 +-
 .../processors/cache/CacheObjectUtils.java      |    4 +-
 .../cache/CacheObjectsReleaseFuture.java        |   60 +
 .../processors/cache/CacheOperationContext.java |   15 +
 .../cache/ChangeGlobalStateMessage.java         |  120 -
 .../processors/cache/ClusterCachesInfo.java     |  643 +++-
 .../internal/processors/cache/ClusterState.java |   38 -
 .../cache/DynamicCacheChangeRequest.java        |   52 +-
 .../cache/DynamicCacheDescriptor.java           |   13 -
 .../processors/cache/ExchangeActions.java       |   71 +-
 .../cache/GatewayProtectedCacheProxy.java       | 1754 +++++++++++
 .../processors/cache/GridCacheAdapter.java      |   78 +-
 .../processors/cache/GridCacheAttributes.java   |   42 +
 .../processors/cache/GridCacheEntryEx.java      |   17 +-
 .../processors/cache/GridCacheEventManager.java |    2 -
 .../cache/GridCacheEvictionManager.java         |    1 -
 .../cache/GridCacheExplicitLockSpan.java        |   10 +-
 .../processors/cache/GridCacheIoManager.java    |   45 +-
 .../processors/cache/GridCacheMapEntry.java     |   59 +-
 .../processors/cache/GridCacheMvccManager.java  |   30 +-
 .../GridCachePartitionExchangeManager.java      |  665 +++--
 .../processors/cache/GridCachePreloader.java    |    8 +-
 .../cache/GridCachePreloaderAdapter.java        |    4 +-
 .../processors/cache/GridCacheProcessor.java    |  332 ++-
 .../cache/GridCacheSharedContext.java           |  103 +-
 .../cache/GridCacheSharedManager.java           |    6 -
 .../cache/GridCacheSharedManagerAdapter.java    |   16 -
 .../processors/cache/GridCacheUtils.java        |    8 +-
 .../cache/GridDeferredAckMessageSender.java     |    3 +-
 .../cache/IgniteCacheOffheapManagerImpl.java    |   33 +-
 .../processors/cache/IgniteCacheProxy.java      | 2817 +-----------------
 .../processors/cache/IgniteCacheProxyImpl.java  | 1828 ++++++++++++
 .../processors/cache/PendingDiscoveryEvent.java |   61 +
 .../processors/cache/StateChangeRequest.java    |   77 +
 .../binary/CacheObjectBinaryProcessorImpl.java  |   12 +-
 .../distributed/GridCacheTxRecoveryFuture.java  |    1 -
 .../GridDistributedTxRemoteAdapter.java         |   13 +-
 .../dht/GridClientPartitionTopology.java        |  101 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |    1 -
 .../distributed/dht/GridDhtCacheEntry.java      |    6 -
 .../cache/distributed/dht/GridDhtGetFuture.java |   15 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |    2 -
 .../distributed/dht/GridDhtLocalPartition.java  |   45 -
 .../dht/GridDhtPartitionTopology.java           |   32 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  268 +-
 .../dht/GridDhtTopologyFutureAdapter.java       |    2 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |    9 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   37 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   13 -
 .../distributed/dht/GridDhtTxPrepareFuture.java |   49 +-
 .../dht/GridPartitionedSingleGetFuture.java     |    3 -
 .../dht/atomic/DhtAtomicUpdateResult.java       |  131 +
 .../dht/atomic/GridDhtAtomicCache.java          |  382 +--
 ...idNearAtomicAbstractSingleUpdateRequest.java |    9 +-
 .../GridNearAtomicAbstractUpdateFuture.java     |    3 +-
 ...GridNearAtomicSingleUpdateInvokeRequest.java |    6 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |    4 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |    2 +-
 .../preloader/ForceRebalanceExchangeTask.java   |   58 +
 .../dht/preloader/GridDhtForceKeysFuture.java   |    1 -
 .../dht/preloader/GridDhtPartitionDemander.java |   29 +-
 .../preloader/GridDhtPartitionExchangeId.java   |   63 +-
 .../dht/preloader/GridDhtPartitionFullMap.java  |   24 +-
 .../dht/preloader/GridDhtPartitionMap.java      |    7 +-
 .../dht/preloader/GridDhtPartitionSupplier.java |    2 +-
 .../GridDhtPartitionSupplyMessage.java          |   20 +-
 .../GridDhtPartitionsExchangeFuture.java        |  581 ++--
 .../preloader/GridDhtPartitionsFullMessage.java |   48 +-
 .../GridDhtPartitionsSingleMessage.java         |   38 +-
 .../dht/preloader/GridDhtPreloader.java         |   35 +-
 .../preloader/GridDhtPreloaderAssignments.java  |   21 +-
 .../RebalanceReassignExchangeTask.java          |   44 +
 .../distributed/near/GridNearCacheEntry.java    |    2 +-
 .../distributed/near/GridNearGetFuture.java     |    2 -
 ...arOptimisticSerializableTxPrepareFuture.java |   11 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   17 +-
 .../GridNearPessimisticTxPrepareFuture.java     |   11 +-
 .../near/GridNearTxFinishFuture.java            |    6 +-
 .../cache/distributed/near/GridNearTxLocal.java |   57 +-
 .../near/GridNearTxPrepareRequest.java          |    9 +-
 .../cache/local/GridLocalLockFuture.java        |    5 -
 .../cache/persistence/DataStructure.java        |   46 +-
 .../cache/persistence/DbCheckpointListener.java |   21 +-
 .../FullPageIdIterableComparator.java           |   51 -
 .../GridCacheDatabaseSharedManager.java         |  279 +-
 .../persistence/GridCacheOffheapManager.java    |  102 +-
 .../IgniteCacheDatabaseSharedManager.java       |  161 +-
 .../persistence/IgniteCacheSnapshotManager.java |  140 -
 .../cache/persistence/MetadataStorage.java      |    2 +-
 .../cache/persistence/file/FileIO.java          |  154 +
 .../cache/persistence/file/FileIODecorator.java |   98 +
 .../cache/persistence/file/FileIOFactory.java   |   45 +
 .../cache/persistence/file/FilePageStore.java   |  107 +-
 .../persistence/file/FilePageStoreFactory.java  |   35 +
 .../persistence/file/FilePageStoreManager.java  |   66 +-
 .../cache/persistence/file/FilePageStoreV2.java |   53 +
 .../file/FileVersionCheckingFactory.java        |  116 +
 .../persistence/file/RandomAccessFileIO.java    |  110 +
 .../file/RandomAccessFileIOFactory.java         |   42 +
 .../persistence/freelist/FreeListImpl.java      |   39 +-
 .../cache/persistence/freelist/PagesList.java   |  103 +-
 .../freelist/io/PagesListMetaIO.java            |    2 +-
 .../persistence/pagemem/FullPageIdTable.java    |   54 +-
 .../cache/persistence/pagemem/PageMemoryEx.java |   12 +-
 .../persistence/pagemem/PageMemoryImpl.java     |  184 +-
 .../persistence/partstate/GroupPartitionId.java |  145 +
 .../partstate/PagesAllocationRange.java         |   68 +
 .../partstate/PartitionAllocationMap.java       |  113 +
 .../snapshot/IgniteCacheSnapshotManager.java    |  168 ++
 .../snapshot/SnapshotDiscoveryMessage.java      |   33 +
 .../persistence/snapshot/SnapshotOperation.java |   44 +
 .../cache/persistence/tree/BPlusTree.java       |   16 +-
 .../cache/persistence/tree/io/PageMetaIO.java   |   27 +-
 .../tree/io/PagePartitionCountersIO.java        |    2 +-
 .../persistence/tree/io/TrackingPageIO.java     |   20 +-
 .../persistence/tree/util/PageHandler.java      |    3 +-
 .../wal/AbstractWalRecordsIterator.java         |  291 ++
 .../persistence/wal/ByteBufferExpander.java     |   64 +
 .../cache/persistence/wal/FileInput.java        |   51 +-
 .../cache/persistence/wal/FileWALPointer.java   |    4 +-
 .../wal/FileWriteAheadLogManager.java           |  851 +++---
 .../cache/persistence/wal/RecordSerializer.java |    5 +
 .../persistence/wal/SegmentArchiveResult.java   |   61 +
 .../persistence/wal/SegmentEofException.java    |    3 +-
 .../wal/reader/IgniteWalIteratorFactory.java    |  107 +
 .../wal/reader/StandaloneGridKernalContext.java |  512 ++++
 ...ndaloneIgniteCacheDatabaseSharedManager.java |   30 +
 .../reader/StandaloneIgnitePluginProcessor.java |   38 +
 .../reader/StandaloneWalRecordsIterator.java    |  265 ++
 .../wal/serializer/RecordV1Serializer.java      |  121 +-
 .../query/GridCacheDistributedQueryManager.java |    4 +-
 .../cache/query/GridCacheQueryManager.java      |   44 +-
 .../cache/query/GridCacheQueryResponse.java     |    4 +-
 .../cache/query/QueryEntityClassProperty.java   |  116 +
 .../cache/query/QueryEntityIndexDescriptor.java |  121 +
 .../cache/query/QueryEntityTypeDescriptor.java  |  219 ++
 .../cache/store/CacheStoreManager.java          |    4 +-
 .../store/GridCacheStoreManagerAdapter.java     |   44 +-
 .../cache/transactions/IgniteTxAdapter.java     |  105 +-
 .../cache/transactions/IgniteTxHandler.java     |  178 +-
 .../IgniteTxImplicitSingleStateImpl.java        |    2 +-
 .../transactions/IgniteTxLocalAdapter.java      |   27 +-
 .../cache/transactions/IgniteTxManager.java     |   91 +-
 .../cache/transactions/IgniteTxMap.java         |    2 +-
 .../IgniteTxRemoteStateAdapter.java             |    2 +-
 .../cache/transactions/IgniteTxState.java       |    2 +-
 .../cache/transactions/IgniteTxStateImpl.java   |    2 +-
 .../transactions/TransactionProxyImpl.java      |   46 +-
 .../cache/version/GridCacheVersionManager.java  |    6 -
 .../cacheobject/IgniteCacheObjectProcessor.java |    5 -
 .../IgniteCacheObjectProcessorImpl.java         |    5 -
 .../cluster/ChangeGlobalStateFinishMessage.java |   86 +
 .../cluster/ChangeGlobalStateMessage.java       |  140 +
 .../processors/cluster/ClusterProcessor.java    |    3 +-
 .../cluster/DiscoveryDataClusterState.java      |  157 +
 .../cluster/GridClusterStateProcessor.java      | 1134 +++----
 .../cluster/IgniteChangeGlobalStateSupport.java |    3 +-
 .../continuous/GridContinuousProcessor.java     |   91 +-
 .../datastreamer/DataStreamProcessor.java       |    3 +-
 .../datastreamer/DataStreamerImpl.java          |  295 +-
 .../datastreamer/DataStreamerRequest.java       |   59 +-
 .../datastructures/DataStructuresProcessor.java |   18 +-
 .../datastructures/GridCacheAtomicLongImpl.java |    2 +-
 .../GridCacheAtomicReferenceImpl.java           |    2 +-
 .../GridCacheAtomicSequenceImpl.java            |    2 +-
 .../GridCacheAtomicStampedImpl.java             |    2 +-
 .../GridCacheCountDownLatchImpl.java            |    2 +-
 .../datastructures/GridCacheLockImpl.java       |   17 +-
 .../datastructures/GridCacheQueueAdapter.java   |    1 -
 .../datastructures/GridCacheSemaphoreImpl.java  |    2 +-
 .../datastructures/GridCacheSetImpl.java        |    1 -
 .../dr/IgniteDrDataStreamerCacheUpdater.java    |    2 +-
 .../processors/igfs/IgfsDataManager.java        |    2 +-
 .../internal/processors/igfs/IgfsImpl.java      |    4 +-
 .../processors/igfs/IgfsNoopProcessor.java      |   11 +
 .../internal/processors/igfs/IgfsProcessor.java |   14 +-
 .../processors/igfs/IgfsProcessorAdapter.java   |    3 +-
 .../processors/job/GridJobProcessor.java        |   15 +-
 .../GridMarshallerMappingProcessor.java         |   16 +-
 .../processors/odbc/SqlListenerProcessor.java   |    3 +-
 .../odbc/jdbc/JdbcBatchExecuteRequest.java      |  109 +
 .../odbc/jdbc/JdbcBatchExecuteResult.java       |   96 +
 .../processors/odbc/jdbc/JdbcQuery.java         |   95 +
 .../processors/odbc/jdbc/JdbcRequest.java       |    8 +
 .../odbc/jdbc/JdbcRequestHandler.java           |   66 +-
 .../processors/odbc/jdbc/JdbcResult.java        |   11 +
 .../platform/PlatformAbstractTarget.java        |    6 +-
 .../processors/platform/PlatformIgnition.java   |    5 +-
 .../platform/PlatformNoopProcessor.java         |  132 -
 .../processors/platform/PlatformProcessor.java  |  216 --
 .../platform/PlatformProcessorImpl.java         |  554 ++--
 .../platform/PlatformTargetProxy.java           |   11 +
 .../platform/PlatformTargetProxyImpl.java       |   79 +-
 .../platform/cache/PlatformCache.java           |   33 +-
 .../platform/cluster/PlatformClusterGroup.java  |   68 +-
 .../datastructures/PlatformAtomicReference.java |   13 +-
 .../dotnet/PlatformDotNetCacheStore.java        |   31 +
 .../transactions/PlatformTransactions.java      |    2 +-
 .../utils/PlatformConfigurationUtils.java       |   24 +-
 .../platform/utils/PlatformUtils.java           |    3 +-
 .../processors/query/GridQueryProcessor.java    |    8 +-
 .../internal/processors/query/QueryUtils.java   |    8 +-
 .../processors/rest/GridRestCommand.java        |    6 +
 .../processors/rest/GridRestProcessor.java      |    4 +-
 .../handlers/cache/GridCacheCommandHandler.java |  202 +-
 .../cluster/GridChangeStateCommandHandler.java  |    2 +-
 .../key/GridRedisExpireCommandHandler.java      |  101 +
 .../rest/handlers/redis/package-info.java       |   22 +
 .../server/GridRedisFlushCommandHandler.java    |  117 +
 .../string/GridRedisIncrDecrCommandHandler.java |    2 +-
 .../protocols/tcp/redis/GridRedisCommand.java   |   10 +-
 .../tcp/redis/GridRedisNioListener.java         |    4 +
 .../service/GridServiceProcessor.java           |   61 +-
 .../processors/service/GridServiceProxy.java    |    9 +-
 .../processors/service/ServiceContextImpl.java  |    2 +
 .../processors/task/GridTaskProcessor.java      |   20 +-
 .../timeout/GridTimeoutProcessor.java           |   18 +-
 .../ignite/internal/util/IgniteUtils.java       |  119 +-
 .../internal/util/MutableSingletonList.java     |   53 +
 .../util/StripedCompositeReadWriteLock.java     |    6 +-
 .../ignite/internal/util/StripedExecutor.java   |   93 +-
 .../util/future/GridCompoundFuture.java         |    6 +-
 .../ignite/internal/util/nio/GridNioServer.java |   21 +-
 .../util/tostring/GridToStringBuilder.java      |    2 +-
 .../visor/VisorCoordinatorNodeTask.java         |   39 +
 .../visor/cache/VisorCacheConfiguration.java    |   11 +-
 .../visor/cache/VisorCacheJdbcType.java         |    2 +-
 .../internal/visor/cache/VisorCacheMetrics.java |   12 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |    2 +-
 .../internal/visor/debug/VisorThreadInfo.java   |   10 +-
 .../visor/node/VisorBasicConfiguration.java     |    2 +-
 .../node/VisorMemoryPolicyConfiguration.java    |   13 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   32 +-
 .../node/VisorNodeDataCollectorJobResult.java   |   73 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |   14 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |   28 +-
 .../visor/node/VisorPersistenceMetrics.java     |  214 ++
 .../node/VisorPersistentStoreConfiguration.java |   36 +-
 .../internal/visor/query/VisorQueryEntity.java  |   32 +-
 .../internal/visor/query/VisorQueryTask.java    |    2 +-
 .../visor/query/VisorScanQueryTask.java         |    2 +-
 .../visor/service/VisorServiceTask.java         |   10 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   10 +-
 .../spi/IgniteSpiOperationTimeoutHelper.java    |    8 +-
 .../communication/tcp/TcpCommunicationSpi.java  |  253 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   12 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  123 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   16 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |    6 +-
 .../spi/failover/always/AlwaysFailoverSpi.java  |    2 +-
 .../org/apache/ignite/thread/IgniteThread.java  |   45 +-
 .../ignite/thread/IgniteThreadFactory.java      |   15 +-
 .../ignite/thread/IgniteThreadPoolExecutor.java |  141 +-
 .../apache/ignite/transactions/Transaction.java |   14 +
 .../ignite/transactions/TransactionState.java   |    7 +-
 .../resources/META-INF/classnames.properties    |   27 +-
 .../core/src/main/resources/ignite.properties   |    2 +-
 .../org.apache.ignite.plugin.PluginProvider     |    3 +-
 .../affinity/AffinityHistoryCleanupTest.java    |  182 --
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |   55 +-
 .../cache/store/jdbc/model/BinaryTest.java      |  121 +
 .../cache/store/jdbc/model/BinaryTestKey.java   |   87 +
 .../ignite/internal/GridVersionSelfTest.java    |    2 +
 .../IgniteClientReconnectAbstractTest.java      |    5 +
 .../internal/IgniteComputeJobOneThreadTest.java |   75 +
 ...UpdateNotifierPerClusterSettingSelfTest.java |    2 +
 .../internal/TestRecordingCommunicationSpi.java |   10 +
 .../internal/binary/BinaryEnumsSelfTest.java    |   71 +
 .../binary/BinaryMarshallerSelfTest.java        |   61 +
 .../BinaryObjectBuilderAdditionalSelfTest.java  |    2 +-
 ...GridManagerLocalMessageListenerSelfTest.java |    4 +-
 ...unicationBalanceMultipleConnectionsTest.java |    5 +
 .../pagemem/impl/PageMemoryNoLoadSelfTest.java  |   52 +-
 .../cache/CacheConnectionLeakStoreTxTest.java   |  291 ++
 .../cache/CacheEntryProcessorCopySelfTest.java  |   11 +-
 .../CacheGroupLocalConfigurationSelfTest.java   |  155 +
 .../cache/CacheStopAndDestroySelfTest.java      |    1 +
 ...idAbstractCacheInterceptorRebalanceTest.java |    2 -
 .../GridCacheAbstractLocalStoreSelfTest.java    |    7 +
 .../cache/GridCacheAbstractMetricsSelfTest.java |   24 -
 .../cache/GridCacheAbstractSelfTest.java        |    1 +
 .../cache/GridCacheDeploymentSelfTest.java      |    7 +-
 .../cache/GridCacheLuceneQueryIndexTest.java    |  466 ---
 .../GridCacheOnCopyFlagAbstractSelfTest.java    |    6 +-
 .../cache/GridCachePutAllFailoverSelfTest.java  |   15 +
 .../GridCacheQueryIndexingDisabledSelfTest.java |   16 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   10 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |    4 +-
 .../cache/IgniteActiveClusterTest.java          |  182 --
 .../cache/IgniteCacheAbstractTest.java          |   17 +
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |    9 +-
 ...acheBinaryObjectsScanWithEventsSelfTest.java |   30 +
 .../IgniteCacheConfigVariationsFullApiTest.java |    6 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |    1 -
 .../processors/cache/IgniteCacheGroupsTest.java |  149 +-
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java |   22 +-
 .../cache/IgniteCachePutAllRestartTest.java     |   15 +
 .../cache/IgniteCacheStartStopLoadTest.java     |    1 -
 .../IgniteClusterActivateDeactivateTest.java    | 1289 ++++++++
 ...erActivateDeactivateTestWithPersistence.java |  197 ++
 .../IgniteDaemonNodeMarshallerCacheTest.java    |   10 -
 .../cache/IgniteDynamicCacheMultinodeTest.java  |  171 ++
 ...iteMarshallerCacheClassNameConflictTest.java |   11 +-
 .../IgniteMarshallerCacheFSRestoreTest.java     |  219 ++
 .../GridCacheBinaryObjectsAbstractSelfTest.java |   28 +
 .../IgniteSemaphoreAbstractSelfTest.java        |   17 +-
 .../CacheGetInsideLockChangingTopologyTest.java |    5 +
 ...ffinityAssignmentNodeJoinValidationTest.java |   46 +-
 .../CacheLateAffinityAssignmentTest.java        |   40 +-
 ...CacheLoadingConcurrentGridStartSelfTest.java |    2 -
 .../distributed/CachePartitionStateTest.java    |  410 +++
 .../GridCacheAbstractNodeRestartSelfTest.java   |   12 +-
 ...titionEvictionDuringReadThroughSelfTest.java |  185 ++
 ...niteBinaryMetadataUpdateNodeRestartTest.java |   10 +
 .../distributed/IgniteCacheGetRestartTest.java  |    5 +
 .../IgniteCacheNearRestartRollbackSelfTest.java |   15 +
 ...ptimisticTxSuspendResumeMultiServerTest.java |   30 +
 .../IgniteOptimisticTxSuspendResumeTest.java    |  751 +++++
 .../IgnitePessimisticTxSuspendResumeTest.java   |   91 +
 .../IgniteRejectConnectOnNodeStopTest.java      |    7 +-
 ...teSynchronizationModesMultithreadedTest.java |    5 +
 ...cOriginatingNodeFailureAbstractSelfTest.java |    2 +-
 .../IgniteTxRemoveTimeoutObjectsTest.java       |  194 ++
 .../TestCacheNodeExcludingFilter.java           |   53 +
 ...idCachePartitionedPreloadEventsSelfTest.java |  143 -
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |    2 -
 .../IgniteCachePutRetryAbstractSelfTest.java    |    5 +
 .../dht/NotMappedPartitionInTxTest.java         |  264 ++
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |   35 -
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |   34 -
 .../GridCachePartitionedTxSalvageSelfTest.java  |    8 +-
 ...cingDelayedPartitionMapExchangeSelfTest.java |   58 +-
 .../GridCacheReplicatedNodeRestartSelfTest.java |    2 +-
 ...acheStoreSessionWriteBehindAbstractTest.java |   62 +-
 ...TxStoreSessionWriteBehindCoalescingTest.java |   88 +
 .../IgnitePdsCacheRebalancingAbstractTest.java  |   76 +
 ...gnitePdsRecoveryAfterFileCorruptionTest.java |   35 +-
 ...IgnitePersistentStoreDataStructuresTest.java |    2 +
 .../MemoryPolicyInitializationTest.java         |    3 +-
 .../db/IgnitePdsCacheRestoreTest.java           |  208 ++
 .../db/IgnitePdsWholeClusterRestartTest.java    |    3 +-
 ...ckpointSimulationWithRealCpDisabledTest.java |   74 +-
 .../db/file/IgnitePdsEvictionTest.java          |   16 +-
 .../persistence/db/wal/IgnitePdsWalTlbTest.java |    2 +-
 .../db/wal/IgniteWalFlushFailoverTest.java      |  195 ++
 .../wal/IgniteWalHistoryReservationsTest.java   |   31 +-
 .../db/wal/IgniteWalRecoveryTest.java           |  110 +-
 .../db/wal/crc/IgniteDataIntegrityTests.java    |   10 +-
 .../db/wal/reader/IgniteWalReaderTest.java      |  388 +++
 .../db/wal/reader/MockWalIteratorFactory.java   |  120 +
 .../pagemem/NoOpPageStoreManager.java           |   34 +-
 .../persistence/pagemem/NoOpWALManager.java     |   23 +-
 .../AbstractNodeJoinTemplate.java               |  149 +-
 .../IgniteChangeGlobalStateAbstractTest.java    |   65 +-
 .../IgniteChangeGlobalStateCacheTest.java       |    2 +-
 ...IgniteChangeGlobalStateDataStreamerTest.java |    5 +-
 ...gniteChangeGlobalStateDataStructureTest.java |    6 +-
 .../IgniteChangeGlobalStateFailOverTest.java    |   68 +-
 .../IgniteChangeGlobalStateTest.java            |  158 +-
 .../IgniteStandByClusterTest.java               |  181 +-
 .../GridActivationPartitionedCacheSuit.java     |    2 -
 .../join/JoinActiveNodeToActiveCluster.java     |   62 +-
 ...ctiveNodeToActiveClusterWithPersistence.java |   17 +
 .../IgniteStandByClientReconnectTest.java       |   13 +-
 ...eStandByClientReconnectToNewClusterTest.java |   13 +-
 .../ScanQueryOffheapExpiryPolicySelfTest.java   |  114 +
 ...ContinuousQueryFailoverAbstractSelfTest.java |    2 -
 ...ClientWriteBehindStoreNonCoalescingTest.java |   30 +-
 .../TxOptimisticDeadlockDetectionTest.java      |    2 +
 .../processors/database/BPlusTreeSelfTest.java  |    4 +-
 .../database/FreeListImplSelfTest.java          |    4 +-
 .../database/SwapPathConstructionSelfTest.java  |  157 +
 .../DataStreamProcessorSelfTest.java            |   14 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |  124 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |    1 -
 .../GridServiceProcessorProxySelfTest.java      |   65 +
 .../timeout/GridTimeoutProcessorSelfTest.java   |   68 +-
 .../internal/util/IgniteUtilsSelfTest.java      |   26 +
 .../loadtests/colocation/GridTestMain.java      |   45 -
 .../loadtests/hashmap/GridCacheTestContext.java |    6 +-
 .../marshaller/GridMarshallerAbstractTest.java  |   10 +-
 .../marshaller/GridMarshallerResourceBean.java  |    5 +-
 .../plugin/PlatformTestPluginTarget.java        |    7 +-
 .../org/apache/ignite/spi/GridTcpForwarder.java |   26 +
 ...cpCommunicationSpiMultithreadedSelfTest.java |    2 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |   15 +
 .../TcpCommunicationSpiFaultyClientTest.java    |   20 +-
 .../ignite/testframework/GridTestUtils.java     |   26 +
 .../testframework/junits/GridAbstractTest.java  |   11 +-
 .../junits/GridTestKernalContext.java           |   10 +
 .../cache/GridAbstractCacheStoreSelfTest.java   |   10 +
 .../junits/common/GridCommonAbstractTest.java   |   15 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    5 +
 .../IgniteCacheFullApiSelfTestSuite.java        |    6 -
 .../IgniteCacheRestartTestSuite2.java           |    2 +
 .../testsuites/IgniteCacheTestSuite2.java       |    4 +-
 .../testsuites/IgniteCacheTestSuite3.java       |    4 +-
 .../testsuites/IgniteCacheTestSuite4.java       |    6 +
 .../testsuites/IgniteCacheTestSuite5.java       |    4 +
 .../testsuites/IgniteCacheTestSuite6.java       |   46 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    3 +
 .../ignite/testsuites/IgnitePdsTestSuite.java   |    8 +-
 .../ignite/testsuites/IgnitePdsTestSuite2.java  |   13 +-
 .../testsuites/IgniteStandByClusterSuite.java   |    5 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +
 .../GridThreadPoolExecutorServiceSelfTest.java  |    9 +-
 .../util/mbeans/GridMBeanDisableSelfTest.java   |  121 +
 modules/docker/2.1.0/Dockerfile                 |   46 +
 modules/docker/2.1.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |    2 +-
 modules/extdata/p2p/pom.xml                     |    2 +-
 .../ignite/tests/p2p/JobStealingTask.java       |   12 +-
 .../org/apache/ignite/tests/p2p/NodeFilter.java |   30 +
 .../extdata/uri/modules/uri-dependency/pom.xml  |    2 +-
 modules/extdata/uri/pom.xml                     |    2 +-
 modules/flink/pom.xml                           |    2 +-
 modules/flume/pom.xml                           |    2 +-
 .../apache/ignite/stream/flume/IgniteSink.java  |    7 +-
 modules/gce/pom.xml                             |    2 +-
 modules/geospatial/pom.xml                      |   26 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |    7 -
 modules/hadoop/pom.xml                          |    2 +-
 .../processors/hadoop/HadoopProcessor.java      |    4 +-
 .../hadoop/jobtracker/HadoopJobTracker.java     |   24 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |    5 +-
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    5 +
 modules/hibernate-4.2/pom.xml                   |   26 +-
 modules/hibernate-5.1/pom.xml                   |   26 +-
 modules/hibernate-core/pom.xml                  |    2 +-
 modules/indexing/pom.xml                        |   14 +-
 .../cache/query/CacheQueryPartitionInfo.java    |   46 +-
 .../query/h2/DmlStatementsProcessor.java        |   29 +-
 .../processors/query/h2/H2DatabaseType.java     |   10 +
 .../processors/query/h2/H2RowDescriptor.java    |   24 +-
 .../processors/query/h2/H2TableEngine.java      |    4 +-
 .../internal/processors/query/h2/H2Utils.java   |   27 +
 .../processors/query/h2/IgniteH2Indexing.java   |   51 +-
 .../query/h2/database/H2PkHashIndex.java        |    7 -
 .../query/h2/database/H2TreeIndex.java          |   32 +-
 .../query/h2/database/InlineIndexHelper.java    |  416 ++-
 .../query/h2/opt/GridH2IndexBase.java           |   93 +-
 .../query/h2/opt/GridH2QueryContext.java        |   59 -
 .../query/h2/opt/GridH2RowDescriptor.java       |    5 -
 .../processors/query/h2/opt/GridH2Table.java    |  221 +-
 .../query/h2/opt/GridH2TreeIndex.java           |  602 ----
 .../query/h2/opt/GridLuceneDirectory.java       |  107 +-
 .../processors/query/h2/opt/GridLuceneFile.java |   91 +-
 .../query/h2/opt/GridLuceneIndex.java           |   78 +-
 .../query/h2/opt/GridLuceneInputStream.java     |  120 +-
 .../query/h2/opt/GridLuceneLockFactory.java     |   45 +-
 .../query/h2/opt/GridLuceneOutputStream.java    |   82 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |    5 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |  526 +---
 .../query/h2/twostep/MapNodeResults.java        |  108 +
 .../query/h2/twostep/MapQueryResult.java        |  258 ++
 .../query/h2/twostep/MapQueryResults.java       |  155 +
 .../h2/twostep/MapReplicatedReservation.java    |   38 +
 .../query/h2/twostep/MapRequestKey.java         |   65 +
 .../query/h2/twostep/MapReservationKey.java     |   73 +
 .../cache/GridCacheFullTextQuerySelfTest.java   |  367 +++
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |   30 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |    3 +-
 ...teCacheFullTextQueryNodeJoiningSelfTest.java |    7 +-
 ...niteCachePartitionedFieldsQuerySelfTest.java |   20 +-
 .../DynamicIndexAbstractConcurrentSelfTest.java |   81 +-
 .../cache/index/H2DynamicTableSelfTest.java     |   85 +
 ...eDbSingleNodeWithIndexingWalRestoreTest.java |  197 ++
 ...oreQueryWithMultipleClassesPerCacheTest.java |  185 ++
 .../processors/query/IgniteSqlRoutingTest.java  |  211 +-
 .../h2/database/InlineIndexHelperTest.java      |  252 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |  172 --
 .../h2/sql/AbstractH2CompareQueryTest.java      |    4 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |    2 +
 .../IgniteCacheQuerySelfTestSuite.java          |    9 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |    3 +
 .../IgniteCacheWithIndexingTestSuite.java       |    3 +
 .../IgnitePdsWithIndexingTestSuite.java         |    4 +
 modules/jcl/pom.xml                             |    2 +-
 modules/jms11/pom.xml                           |    2 +-
 modules/jta/pom.xml                             |    2 +-
 .../processors/cache/jta/CacheJtaManager.java   |    5 +-
 .../processors/cache/jta/CacheJtaResource.java  |   48 +-
 .../cache/AbstractCacheJtaSelfTest.java         |  183 --
 .../GridJtaTransactionManagerSelfTest.java      |  208 ++
 .../GridPartitionedCacheJtaFactorySelfTest.java |   41 -
 ...rtitionedCacheJtaFactoryUseSyncSelfTest.java |   32 -
 ...titionedCacheJtaLookupClassNameSelfTest.java |   83 -
 .../GridReplicatedCacheJtaFactorySelfTest.java  |   32 -
 ...eplicatedCacheJtaFactoryUseSyncSelfTest.java |   32 -
 ...plicatedCacheJtaLookupClassNameSelfTest.java |   32 -
 .../cache/jta/AbstractCacheJtaSelfTest.java     |  248 ++
 .../GridPartitionedCacheJtaFactorySelfTest.java |   41 +
 ...rtitionedCacheJtaFactoryUseSyncSelfTest.java |   32 +
 ...titionedCacheJtaLookupClassNameSelfTest.java |   83 +
 .../GridReplicatedCacheJtaFactorySelfTest.java  |   32 +
 ...eplicatedCacheJtaFactoryUseSyncSelfTest.java |   32 +
 ...plicatedCacheJtaLookupClassNameSelfTest.java |   32 +
 .../processors/cache/jta/package-info.java      |   22 +
 .../ignite/testsuites/IgniteJtaTestSuite.java   |   15 +-
 modules/kafka/pom.xml                           |    2 +-
 modules/kubernetes/pom.xml                      |    2 +-
 modules/log4j/pom.xml                           |    2 +-
 modules/log4j2/pom.xml                          |    2 +-
 modules/mesos/pom.xml                           |    2 +-
 .../apache/ignite/mesos/ClusterProperties.java  |    4 +-
 modules/ml/README.txt                           |    6 +
 modules/ml/licenses/bsd3.txt                    |   51 +
 modules/ml/pom.xml                              |   25 +-
 .../main/java/org/apache/ignite/ml/Model.java   |    1 -
 .../ml/clustering/BaseKMeansClusterer.java      |    2 -
 .../apache/ignite/ml/clustering/Clusterer.java  |    3 +-
 .../clustering/KMeansDistributedClusterer.java  |   52 +-
 .../ml/clustering/KMeansLocalClusterer.java     |   13 +-
 .../java/org/apache/ignite/ml/math/Blas.java    |  355 +++
 .../apache/ignite/ml/math/DistanceMeasure.java  |    3 +-
 .../ignite/ml/math/EuclideanDistance.java       |    5 +-
 .../org/apache/ignite/ml/math/MathUtils.java    |    1 +
 .../java/org/apache/ignite/ml/math/Matrix.java  |   33 +-
 .../apache/ignite/ml/math/MatrixStorage.java    |   12 +-
 .../apache/ignite/ml/math/OrderedMatrix.java    |   24 +
 .../java/org/apache/ignite/ml/math/Tracer.java  |    1 -
 .../java/org/apache/ignite/ml/math/Vector.java  |    8 +
 .../org/apache/ignite/ml/math/VectorUtils.java  |   11 +-
 .../decompositions/CholeskyDecomposition.java   |   11 +-
 .../math/decompositions/EigenDecomposition.java |    2 +-
 .../ml/math/decompositions/LUDecomposition.java |    2 +-
 .../ml/math/decompositions/QRDecomposition.java |    2 +-
 .../math/exceptions/ConvergenceException.java   |    5 +-
 .../exceptions/MathIllegalNumberException.java  |    8 +-
 .../exceptions/MathIllegalStateException.java   |    4 +-
 .../ignite/ml/math/functions/Functions.java     |    8 +-
 .../IgniteIntDoubleToDoubleBiFunction.java      |   27 +
 .../functions/IgniteIntIntToIntBiFunction.java  |   27 +
 .../ml/math/functions/IgniteTriFunction.java    |   35 +
 .../apache/ignite/ml/math/impls/CacheUtils.java |  219 +-
 .../ml/math/impls/matrix/AbstractMatrix.java    |  153 +-
 .../ignite/ml/math/impls/matrix/BlockEntry.java |   50 +
 .../ml/math/impls/matrix/CacheMatrix.java       |    9 +-
 .../impls/matrix/DenseLocalOffHeapMatrix.java   |   29 +
 .../impls/matrix/DenseLocalOnHeapMatrix.java    |   61 +-
 .../matrix/SparseBlockDistributedMatrix.java    |  208 ++
 .../impls/matrix/SparseDistributedMatrix.java   |   59 +-
 .../impls/matrix/SparseLocalOnHeapMatrix.java   |   27 +
 .../storage/matrix/ArrayMatrixStorage.java      |   86 +-
 .../storage/matrix/BaseBlockMatrixKey.java      |   41 +
 .../impls/storage/matrix/BlockMatrixKey.java    |  144 +
 .../storage/matrix/BlockMatrixStorage.java      |  440 +++
 .../storage/matrix/CacheMatrixStorage.java      |    6 +
 .../matrix/DenseOffHeapMatrixStorage.java       |   10 +-
 .../storage/matrix/DiagonalMatrixStorage.java   |   17 +
 .../storage/matrix/FunctionMatrixStorage.java   |    6 +
 .../impls/storage/matrix/MapWrapperStorage.java |    8 +-
 .../storage/matrix/MatrixDelegateStorage.java   |   43 +-
 .../storage/matrix/PivotedMatrixStorage.java    |    5 +
 .../storage/matrix/RandomMatrixStorage.java     |    6 +
 .../matrix/SparseDistributedMatrixStorage.java  |   24 +-
 .../matrix/SparseLocalOnHeapMatrixStorage.java  |   41 +-
 .../vector/DenseLocalOffHeapVectorStorage.java  |    2 +-
 .../storage/vector/MatrixVectorStorage.java     |   11 +
 .../vector/SparseLocalOffHeapVectorStorage.java |    2 +-
 .../vector/SparseLocalOnHeapVectorStorage.java  |   31 +-
 .../impls/vector/AbstractReadOnlyVector.java    |    6 +
 .../ml/math/impls/vector/AbstractVector.java    |    8 +
 .../ml/math/impls/vector/CacheVector.java       |    4 +-
 .../ml/math/impls/vector/DelegatingVector.java  |    6 +
 .../ml/math/impls/vector/MapWrapperVector.java  |    4 +-
 .../ml/math/impls/vector/SparseLocalVector.java |   45 +-
 .../ignite/ml/math/impls/vector/VectorView.java |    2 +-
 .../ignite/ml/math/statistics/Variance.java     |    1 +
 .../ignite/ml/math/statistics/package-info.java |   22 +
 .../org/apache/ignite/ml/math/util/MapUtil.java |    2 +-
 .../apache/ignite/ml/math/util/MatrixUtil.java  |   73 +-
 .../ignite/ml/math/util/package-info.java       |   22 +
 .../java/org/apache/ignite/ml/package-info.java |   22 +
 .../AbstractMultipleLinearRegression.java       |    4 +-
 .../OLSMultipleLinearRegression.java            |    2 +-
 .../ignite/ml/math/d3-matrix-template.html      |    2 +
 .../ignite/ml/math/d3-vector-template.html      |    2 +
 .../org/apache/ignite/ml/IgniteMLTestSuite.java |    4 +-
 .../java/org/apache/ignite/ml/TestUtils.java    |    2 +-
 .../ml/clustering/ClusteringTesetSuite.java     |   32 -
 .../ml/clustering/ClusteringTestSuite.java      |   32 +
 .../KMeansDistributedClustererTest.java         |   43 +-
 .../org/apache/ignite/ml/math/BlasTest.java     |  346 +++
 .../ml/math/MathImplDistributedTestSuite.java   |    2 +
 .../ignite/ml/math/MathImplLocalTestSuite.java  |    1 -
 .../ignite/ml/math/MathImplMainTestSuite.java   |    3 +-
 .../org/apache/ignite/ml/math/TracerTest.java   |    3 +
 .../ignite/ml/math/benchmark/MathBenchmark.java |    2 +-
 .../ml/math/benchmark/VectorBenchmarkTest.java  |    2 +-
 .../decompositions/EigenDecompositionTest.java  |    2 +-
 .../math/impls/matrix/MatrixAttributeTest.java  |    2 -
 .../impls/matrix/MatrixImplementationsTest.java |   12 +-
 .../impls/matrix/MatrixViewConstructorTest.java |    2 +-
 .../SparseDistributedBlockMatrixTest.java       |  379 +++
 .../matrix/SparseDistributedMatrixTest.java     |   56 +-
 .../storage/matrix/MatrixArrayStorageTest.java  |    6 +-
 .../matrix/MatrixStorageImplementationTest.java |    2 +-
 .../RandomAccessSparseVectorStorageTest.java    |    4 +-
 .../math/impls/vector/AbstractVectorTest.java   |    4 +-
 .../PivotedVectorViewConstructorTest.java       |    2 +-
 .../math/impls/vector/VectorAttributesTest.java |    2 +-
 .../ml/math/impls/vector/VectorFoldMapTest.java |    2 +-
 .../impls/vector/VectorImplementationsTest.java |   12 +-
 .../math/impls/vector/VectorIterableTest.java   |    2 +-
 .../math/impls/vector/VectorToMatrixTest.java   |    7 +-
 .../OLSMultipleLinearRegressionTest.java        |    8 +-
 modules/mqtt/pom.xml                            |    2 +-
 .../apache/ignite/stream/mqtt/MqttStreamer.java |    6 +-
 modules/osgi-karaf/pom.xml                      |    2 +-
 modules/osgi-paxlogging/pom.xml                 |    2 +-
 modules/osgi/pom.xml                            |    2 +-
 .../include/ignite/binary/binary_writer.h       |    4 +-
 .../ignite/impl/binary/binary_reader_impl.h     |   50 +-
 .../ignite/impl/binary/binary_type_impl.h       |   67 +
 .../ignite/impl/binary/binary_writer_impl.h     |   43 +-
 .../src/impl/binary/binary_reader_impl.cpp      |   63 +-
 .../src/impl/binary/binary_writer_impl.cpp      |   41 +-
 modules/platforms/cpp/common/configure.ac       |    2 +-
 modules/platforms/cpp/configure.ac              |    2 +-
 modules/platforms/cpp/configure.acrel           |    2 +-
 .../core-test/config/cache-query-default.xml    |   29 +
 modules/platforms/cpp/core-test/configure.ac    |    2 +-
 .../src/binary_reader_writer_raw_test.cpp       |   36 +
 .../core-test/src/binary_reader_writer_test.cpp |  135 +-
 .../cpp/core-test/src/cache_query_test.cpp      |  215 +-
 .../cpp/core-test/src/cluster_test.cpp          |   13 +
 .../cpp/core-test/src/compute_test.cpp          |   91 +-
 modules/platforms/cpp/core/configure.ac         |    2 +-
 modules/platforms/cpp/core/include/Makefile.am  |    2 +
 .../ignite/cache/query/query_fields_row.h       |   28 +
 .../core/include/ignite/cache/query/query_sql.h |    4 +
 .../ignite/cache/query/query_sql_fields.h       |   17 +-
 .../cpp/core/include/ignite/compute/compute.h   |   66 +
 .../platforms/cpp/core/include/ignite/ignite.h  |   21 +-
 .../ignite/impl/cache/query/query_argument.h    |   63 +
 .../impl/cache/query/query_fields_row_impl.h    |   29 +
 .../ignite/impl/cluster/cluster_group_impl.h    |   15 +
 .../include/ignite/impl/compute/compute_impl.h  |  164 +-
 .../ignite/impl/compute/compute_job_result.h    |   54 +-
 .../ignite/impl/compute/compute_task_holder.h   |  204 +-
 .../compute/multiple_job_compute_task_holder.h  |  265 ++
 .../compute/single_job_compute_task_holder.h    |  212 ++
 .../cpp/core/include/ignite/impl/ignite_impl.h  |  106 +-
 .../ignite/impl/interop/interop_target.h        |   16 +-
 .../platforms/cpp/core/project/vs/core.vcxproj  |    2 +
 .../cpp/core/project/vs/core.vcxproj.filters    |    6 +
 modules/platforms/cpp/core/src/ignite.cpp       |   10 +
 modules/platforms/cpp/core/src/ignition.cpp     |   23 +-
 .../src/impl/cluster/cluster_group_impl.cpp     |   26 +-
 .../cpp/core/src/impl/ignite_environment.cpp    |   37 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |   53 +-
 .../core/src/impl/interop/interop_target.cpp    |   18 +-
 modules/platforms/cpp/examples/configure.ac     |    2 +-
 modules/platforms/cpp/ignite/configure.ac       |    2 +-
 .../cpp/jni/include/ignite/jni/exports.h        |   32 +-
 .../platforms/cpp/jni/include/ignite/jni/java.h |   75 +-
 modules/platforms/cpp/jni/project/vs/module.def |   31 +-
 modules/platforms/cpp/jni/src/exports.cpp       |  120 +-
 modules/platforms/cpp/jni/src/java.cpp          |  537 +---
 modules/platforms/cpp/odbc-test/Makefile.am     |    1 +
 .../cpp/odbc-test/include/complex_type.h        |   53 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    1 +
 .../project/vs/odbc-test.vcxproj.filters        |    3 +
 .../cpp/odbc-test/src/meta_queries_test.cpp     |  240 ++
 .../cpp/odbc/install/ignite-odbc-amd64.wxs      |    2 +-
 .../cpp/odbc/install/ignite-odbc-x86.wxs        |    2 +-
 .../platforms/cpp/odbc/src/meta/column_meta.cpp |    3 +
 modules/platforms/cpp/odbc/src/odbc.cpp         |    2 +-
 .../cpp/odbc/src/query/type_info_query.cpp      |    2 +-
 modules/platforms/cpp/odbc/src/statement.cpp    |    2 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.Core.Tests.csproj             |    8 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |   29 +-
 .../Binary/BinaryFooterTest.cs                  |  178 ++
 .../Binary/BinarySelfTest.cs                    |   32 -
 .../Serializable/AdvancedSerializationTest.cs   |   31 +
 .../BasicSerializableObjectsTest.cs             |    7 +-
 .../Cache/CacheAbstractTest.cs                  |   26 +-
 .../Cache/CacheAbstractTransactionalTest.cs     |   53 +-
 .../Cache/CacheConfigurationTest.cs             |   21 +
 .../Cache/PersistentStoreTest.cs                |  122 +-
 .../Cache/Query/CacheQueriesTest.cs             |   37 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   90 +-
 .../Store/CacheStoreSessionTestCodeConfig.cs    |   68 +
 .../Store/CacheStoreSessionTestSharedFactory.cs |   48 +
 .../Cache/Store/CacheStoreTest.cs               |   31 +-
 .../cache-store-session-shared-factory.xml      |   76 +
 .../Config/Cache/Store/cache-store-session.xml  |   20 +-
 .../Config/cache-query.xml                      |    1 -
 .../Config/spring-test.xml                      |    4 +
 .../Deployment/CacheGetFunc.cs                  |   50 +
 .../Deployment/PeerAssemblyLoadingTest.cs       |   24 +
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |   19 +-
 .../IgniteConfigurationSerializerTest.cs        |   13 +-
 .../IgniteConfigurationTest.cs                  |   26 +-
 .../Plugin/PluginTest.cs                        |   13 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |    7 +-
 .../Apache.Ignite.Core.csproj                   |    7 +-
 .../Cache/Configuration/CacheConfiguration.cs   |   78 +-
 .../Apache.Ignite.Core/Common/JavaException.cs  |   15 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |    9 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |   20 +-
 .../IgniteConfigurationSection.xsd              |   15 +
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   21 +-
 .../Impl/Binary/BinaryObject.cs                 |    2 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |    2 +-
 .../Impl/Binary/BinaryObjectSchemaField.cs      |    3 +
 .../Impl/Binary/BinaryObjectSchemaSerializer.cs |   93 +-
 .../Impl/Binary/BinaryProcessor.cs              |    6 +-
 .../Impl/Binary/BinaryReader.cs                 |   49 +-
 .../Impl/Binary/BinaryWriterExtensions.cs       |  107 +
 .../Impl/Binary/SerializableSerializer.cs       |   18 +-
 .../Cache/Affinity/PlatformAffinityFunction.cs  |    7 +-
 .../Impl/Cache/CacheAffinityImpl.cs             |   18 +-
 .../Impl/Cache/CacheEnumerator.cs               |    8 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  115 +-
 .../Impl/Cache/Query/AbstractQueryCursor.cs     |   12 +-
 .../Continuous/ContinuousQueryHandleImpl.cs     |   12 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |    6 +-
 .../Impl/Cache/Query/QueryCursor.cs             |    5 +-
 .../Impl/Cache/Store/CacheStoreInternal.cs      |   14 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |  152 +-
 .../Impl/Common/DelegateTypeDescriptor.cs       |    9 +-
 .../Impl/Common/Listenable.cs                   |    8 +-
 .../Impl/Compute/ComputeImpl.cs                 |   18 +-
 .../Impl/DataStructures/AtomicLong.cs           |    9 +-
 .../Impl/DataStructures/AtomicReference.cs      |    8 +-
 .../Impl/DataStructures/AtomicSequence.cs       |    9 +-
 .../Impl/Datastream/DataStreamerImpl.cs         |   11 +-
 .../Impl/Datastream/StreamReceiverHolder.cs     |   13 +-
 .../Apache.Ignite.Core/Impl/Events/Events.cs    |   11 +-
 .../Impl/Events/RemoteListenEventFilter.cs      |    3 +
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    5 +-
 .../Impl/IPlatformTargetInternal.cs             |  102 +
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |  308 +-
 .../Apache.Ignite.Core/Impl/Log/JavaLogger.cs   |   23 +-
 .../Impl/Messaging/Messaging.cs                 |   10 +-
 .../PersistentStore/PersistentStoreMetrics.cs   |   88 +
 .../Impl/PlatformDisposableTargetAdapter.cs     |   75 +
 .../Impl/PlatformJniTarget.cs                   |  536 ++++
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   | 1070 -------
 .../Impl/PlatformTargetAdapter.cs               |  534 ++++
 .../Impl/Plugin/PluginContext.cs                |    7 +-
 .../Impl/Services/Services.cs                   |   19 +-
 .../Impl/Transactions/TransactionsImpl.cs       |   29 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |   94 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   10 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |  315 +-
 .../Interop/IPlatformTarget.cs                  |   15 +
 .../NuGet/LINQPad/ComputeExample.linq           |    1 +
 .../PersistentStore/IPersistentStoreMetrics.cs  |   87 +
 .../PersistentStoreConfiguration.cs             |  175 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    6 +-
 modules/rest-http/pom.xml                       |    2 +-
 modules/rocketmq/pom.xml                        |    5 +-
 modules/scalar-2.10/pom.xml                     |    2 +-
 modules/scalar/pom.xml                          |    2 +-
 modules/schedule/pom.xml                        |   26 +-
 modules/slf4j/pom.xml                           |    2 +-
 modules/spark-2.10/pom.xml                      |    2 +-
 modules/spark/pom.xml                           |    2 +-
 .../org/apache/ignite/spark/IgniteRDD.scala     |    6 +-
 .../apache/ignite/spark/impl/IgniteSqlRDD.scala |    6 +-
 modules/spring-data/pom.xml                     |    2 +-
 modules/spring/pom.xml                          |    2 +-
 modules/ssh/pom.xml                             |    2 +-
 modules/storm/pom.xml                           |    2 +-
 modules/tools/pom.xml                           |    2 +-
 modules/twitter/pom.xml                         |    2 +-
 modules/urideploy/pom.xml                       |    2 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |    3 +-
 modules/visor-console-2.10/pom.xml              |    2 +-
 modules/visor-console/pom.xml                   |    2 +-
 .../ignite/visor/commands/VisorConsole.scala    |   12 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   20 +-
 modules/visor-plugins/pom.xml                   |    2 +-
 modules/web-console/backend/.eslintrc           |   39 +-
 modules/web-console/backend/app/agentSocket.js  |    4 +-
 .../web-console/backend/app/browsersHandler.js  |    2 +-
 modules/web-console/backend/app/mongo.js        |    6 +-
 modules/web-console/backend/app/settings.js     |    3 +-
 modules/web-console/backend/index.js            |   16 +-
 modules/web-console/backend/middlewares/api.js  |   39 +-
 modules/web-console/backend/package.json        |   27 +-
 .../web-console/backend/services/activities.js  |   12 +-
 modules/web-console/frontend/.eslintrc          |   40 +-
 modules/web-console/frontend/app/app.config.js  |    3 +-
 modules/web-console/frontend/app/app.js         |   39 +-
 .../components/activities-user-dialog/index.js  |   28 +-
 .../app/components/bs-select-menu/style.scss    |   16 +
 .../app/components/bs-select-menu/template.pug  |    2 +
 .../cluster-select/cluster-select.controller.js |   72 +-
 .../cluster-select/cluster-select.pug           |   10 +-
 .../components/grid-item-selected/component.js  |   28 +
 .../components/grid-item-selected/controller.js |   38 +
 .../app/components/grid-item-selected/index.js  |   24 +
 .../components/grid-item-selected/template.pug  |   17 +
 .../list-of-registered-users.tpl.pug            |    4 +-
 .../page-configure-advanced/controller.js       |    9 +-
 .../components/page-configure-basic/service.js  |    8 +-
 .../app/components/page-configure/controller.js |   12 +-
 .../page-configure/controller.spec.js           |   48 -
 .../page-configure/services/PageConfigure.js    |   18 +-
 .../app/components/ui-grid-hovering/cell.js     |   48 +
 .../app/components/ui-grid-hovering/hovering.js |   31 +
 .../app/components/ui-grid-hovering/index.js    |   30 +
 .../app/components/ui-grid-hovering/style.scss  |   22 +
 .../app/components/ui-grid-hovering/viewport.js |   42 +
 .../components/web-console-header/component.js  |   12 +-
 .../app/components/web-console-header/index.js  |    4 +-
 .../components/web-console-header/style.scss    |    6 +-
 .../frontend/app/controllers/auth.controller.js |    9 +-
 .../frontend/app/data/jdbc-types.json           |    6 +-
 .../frontend/app/data/pom-dependencies.json     |   10 +-
 .../frontend/app/decorator/select.js            |   77 -
 .../frontend/app/decorator/tooltip.js           |   73 -
 .../hide-on-state-change.directive.js           |    8 +-
 .../frontend/app/filters/duration.filter.js     |    2 +-
 .../frontend/app/filters/id8.filter.js          |   20 +
 .../helpers/jade/form/form-field-checkbox.pug   |    2 +-
 .../helpers/jade/form/form-field-dropdown.pug   |    1 -
 .../frontend/app/helpers/jade/mixins.pug        |    1 +
 .../frontend/app/modules/ace.module.js          |    6 +-
 .../app/modules/agent/AgentManager.service.js   |   28 +-
 .../app/modules/agent/AgentModal.service.js     |    8 +-
 .../app/modules/branding/branding.module.js     |   16 +-
 .../generator/AbstractTransformer.js            |    4 +-
 .../generator/ConfigurationGenerator.js         |   43 +-
 .../configuration/generator/Maven.service.js    |   39 +-
 .../generator/PlatformGenerator.js              |    4 +-
 .../generator/defaults/Cluster.service.js       |    2 +-
 .../frontend/app/modules/demo/Demo.module.js    |   34 +-
 .../app/modules/dialog/dialog.controller.js     |    4 -
 .../app/modules/form/field/label.directive.js   |    4 +-
 .../app/modules/form/field/tooltip.directive.js |    4 +-
 .../frontend/app/modules/sql/sql.controller.js  |   13 +-
 .../frontend/app/modules/sql/sql.module.js      |   66 +-
 .../frontend/app/modules/states/admin.state.js  |    6 +-
 .../app/modules/states/configuration.state.js   |   35 +-
 .../states/configuration/caches/affinity.pug    |   18 +-
 .../states/configuration/caches/general.pug     |   50 +-
 .../states/configuration/clusters/hadoop.pug    |    2 +-
 .../states/configuration/clusters/memory.pug    |    8 +-
 .../configuration/clusters/persistence.pug      |    2 +-
 .../states/configuration/domains/query.pug      |    9 +
 .../summary/summary-zipper.service.js           |    2 +-
 .../configuration/summary/summary.worker.js     |    4 +-
 .../frontend/app/modules/states/errors.state.js |   12 +-
 .../frontend/app/modules/states/logout.state.js |   12 +-
 .../app/modules/states/password.state.js        |    6 +-
 .../app/modules/states/profile.state.js         |    9 +-
 .../frontend/app/modules/states/signin.state.js |   28 +-
 .../app/modules/user/AclRoute.provider.js       |   52 -
 .../frontend/app/modules/user/user.module.js    |   29 +-
 .../frontend/app/primitives/dropdown/index.scss |   64 -
 .../app/primitives/form-field/index.scss        |   48 +-
 .../frontend/app/primitives/index.js            |    2 +
 .../frontend/app/primitives/modal/index.scss    |    9 +
 .../frontend/app/primitives/panel/index.scss    |    2 +-
 .../frontend/app/primitives/radio/index.pug     |   41 +
 .../frontend/app/primitives/radio/index.scss    |   78 +
 .../frontend/app/primitives/switch/index.pug    |   34 -
 .../frontend/app/primitives/switch/index.scss   |   87 -
 .../frontend/app/primitives/switcher/index.scss |    2 +-
 .../frontend/app/primitives/tooltip/index.scss  |   25 +
 .../app/primitives/typography/index.scss        |    2 +-
 .../app/primitives/ui-grid-settings/index.scss  |   47 +-
 .../frontend/app/primitives/ui-grid/index.scss  |   13 +-
 .../services/AngularStrapSelect.decorator.js    |   77 +
 .../services/AngularStrapTooltip.decorator.js   |  103 +
 .../frontend/app/services/Confirm.service.js    |    2 +-
 .../app/services/CopyToClipboard.service.js     |    4 +-
 .../app/services/LegacyTable.service.js         |    2 +-
 .../frontend/app/services/Messages.service.js   |   10 +
 modules/web-console/frontend/app/vendor.js      |    8 +-
 .../frontend/controllers/domains-controller.js  |    7 +-
 modules/web-console/frontend/package.json       |   59 +-
 .../views/configuration/domains-import.tpl.pug  |    4 +-
 .../frontend/views/includes/header-left.pug     |   41 +-
 modules/web-console/frontend/views/index.pug    |    6 +-
 .../web-console/frontend/views/signin.tpl.pug   |    2 +-
 .../web-console/frontend/views/sql/sql.tpl.pug  |    4 +-
 .../views/templates/agent-download.tpl.pug      |    6 +-
 .../frontend/webpack/webpack.common.js          |    4 +-
 modules/web-console/pom.xml                     |    2 +-
 modules/web-console/web-agent/pom.xml           |    2 +-
 .../console/agent/handlers/RestListener.java    |    7 +-
 .../ignite/console/agent/rest/RestExecutor.java |   49 +-
 .../ignite/console/demo/AgentClusterDemo.java   |   12 +
 .../demo/service/DemoCachesLoadService.java     |    1 +
 modules/web/ignite-appserver-test/pom.xml       |    2 +-
 modules/web/ignite-websphere-test/pom.xml       |    2 +-
 modules/web/pom.xml                             |    2 +-
 .../cache/websession/WebSessionFilter.java      |    2 +-
 modules/yardstick/pom.xml                       |    2 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   79 +
 .../cache/IgniteCacheLockBenchmark.java         |   57 +
 .../yardstick/cache/IgniteLockBenchmark.java    |   47 +
 .../cache/IgnitePutTxLoadBenchmark.java         |  118 +
 .../cache/IgniteStreamerBenchmark.java          |  234 ++
 modules/yarn/pom.xml                            |    2 +-
 modules/zeromq/pom.xml                          |    2 +-
 modules/zookeeper/pom.xml                       |    2 +-
 parent/pom.xml                                  |    4 +-
 pom.xml                                         |    2 +-
 1063 files changed, 40439 insertions(+), 19954 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/e66b6642/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java
----------------------------------------------------------------------
diff --cc modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java
index 09b4a27,4f7c288..a7c44c9
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java
@@@ -80,8 -81,13 +82,12 @@@ import org.h2.command.dml.Insert
  import org.h2.command.dml.Merge;
  import org.h2.command.dml.Update;
  import org.h2.table.Column;
- import org.h2.value.DataType;
+ import org.h2.util.DateTimeUtils;
+ import org.h2.util.LocalDateTimeUtils;
 -import org.h2.value.DataType;
  import org.h2.value.Value;
+ import org.h2.value.ValueDate;
+ import org.h2.value.ValueTime;
+ import org.h2.value.ValueTimestamp;
  import org.jetbrains.annotations.NotNull;
  import org.jetbrains.annotations.Nullable;
  
@@@ -757,21 -748,7 +775,14 @@@ public class DmlStatementsProcessor 
              return newArr;
          }
  
-         int objType = DataType.getTypeFromClass(val.getClass());
- 
-         if (objType == type)
-             return val;
- 
-         Value h2Val = desc.wrap(val, objType);
- 
-         Object res = h2Val.convertTo(type).getObject();
 -        return H2Utils.convert(val, desc, type);
++        Object res = H2Utils.convert(val, desc, type);
 +
 +        if (res instanceof Date && res.getClass() != Date.class && expCls == Date.class) {
 +            // We can get a Timestamp instead of Date when converting a String to Date without query - let's handle this
 +            return new Date(((Date) res).getTime());
 +        }
 +
 +        return res;
      }
  
      /**