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

[62/62] [abbrv] ignite git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-4938

Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/ignite into ignite-4938


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

Branch: refs/heads/ignite-4938
Commit: f4558d844d318a130a5cb437254bcc9277b0012a
Parents: c89cc39 36a6cd0
Author: Alexey Goncharuk <al...@gmail.com>
Authored: Tue Apr 18 16:46:05 2017 +0300
Committer: Alexey Goncharuk <al...@gmail.com>
Committed: Tue Apr 18 16:46:05 2017 +0300

----------------------------------------------------------------------
 doap_Ignite.rdf                                 |   11 +-
 examples/README.txt                             |   10 +-
 examples/config/example-memory-policies.xml     |  105 ++
 examples/pom-standalone-lgpl.xml                |   23 +
 examples/pom-standalone.xml                     |   23 +
 examples/pom.xml                                |   34 +
 .../datagrid/MemoryPoliciesExample.java         |  114 ++
 .../CholeskyDecompositionExample.java           |   80 ++
 .../EigenDecompositionExample.java              |   69 ++
 .../decompositions/LUDecompositionExample.java  |   83 ++
 .../SingularValueDecompositionExample.java      |   70 ++
 .../ml/math/decompositions/package-info.java    |   22 +
 .../ml/math/matrix/CacheMatrixExample.java      |   91 ++
 .../ml/math/matrix/ExampleMatrixStorage.java    |  162 +++
 .../math/matrix/MatrixCustomStorageExample.java |  141 +++
 .../examples/ml/math/matrix/MatrixExample.java  |   79 ++
 .../ml/math/matrix/MatrixExampleUtil.java       |   52 +
 .../ml/math/matrix/OffHeapMatrixExample.java    |   84 ++
 .../matrix/SparseDistributedMatrixExample.java  |   65 +
 .../ml/math/matrix/SparseMatrixExample.java     |   84 ++
 .../examples/ml/math/matrix/package-info.java   |   22 +
 .../ignite/examples/ml/math/package-info.java   |   22 +
 .../examples/ml/math/tracer/TracerExample.java  |   63 +
 .../examples/ml/math/tracer/package-info.java   |   22 +
 .../ml/math/vector/CacheVectorExample.java      |  102 ++
 .../ml/math/vector/ExampleVectorStorage.java    |  126 ++
 .../ml/math/vector/OffHeapVectorExample.java    |   78 ++
 .../ml/math/vector/SparseVectorExample.java     |   80 ++
 .../math/vector/VectorCustomStorageExample.java |  124 ++
 .../examples/ml/math/vector/VectorExample.java  |   75 ++
 .../examples/ml/math/vector/package-info.java   |   22 +
 .../ignite/examples/CacheExamplesSelfTest.java  |    8 +
 .../JettyRestProcessorAbstractSelfTest.java     |   92 +-
 .../ignite/codegen/MessageCodeGenerator.java    |    4 +
 modules/core/pom.xml                            |    3 +
 .../ignite/binary/BinaryBasicNameMapper.java    |    3 +
 .../ignite/cache/CacheAtomicWriteOrderMode.java |   64 -
 .../org/apache/ignite/cache/CacheEntry.java     |   11 -
 .../ignite/cache/query/SqlFieldsQuery.java      |   25 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   31 +-
 .../configuration/CacheConfiguration.java       |   44 +-
 .../configuration/DataPageEvictionMode.java     |   33 +-
 .../configuration/IgniteConfiguration.java      |   78 +-
 .../configuration/MemoryConfiguration.java      |   87 +-
 .../MemoryPolicyConfiguration.java              |  112 +-
 .../ignite/internal/GridKernalContext.java      |   16 -
 .../ignite/internal/GridKernalContextImpl.java  |   31 -
 .../apache/ignite/internal/IgniteKernal.java    |   58 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |    6 +-
 .../igfs/common/IgfsControlResponse.java        |   28 +
 .../internal/igfs/common/IgfsIpcCommand.java    |    5 +-
 .../ignite/internal/igfs/common/IgfsLogger.java |   60 +-
 .../internal/igfs/common/IgfsMarshaller.java    |   12 +
 .../igfs/common/IgfsModeResolverRequest.java    |   35 +
 .../communication/GridIoMessageFactory.java     |   12 -
 .../cache/CacheAffinitySharedManager.java       |    8 +-
 .../processors/cache/CacheEntryImplEx.java      |    8 +-
 .../processors/cache/GridCacheAdapter.java      |   41 +-
 .../cache/GridCacheAtomicVersionComparator.java |   24 +-
 .../processors/cache/GridCacheMapEntry.java     |   21 +-
 .../processors/cache/GridCacheMvcc.java         |   23 +-
 .../processors/cache/GridCacheProcessor.java    |   20 +-
 .../cache/GridCacheSwapEntryImpl.java           |    4 +-
 .../processors/cache/GridCacheUtils.java        |    7 +-
 .../processors/cache/IgniteCacheProxy.java      |    4 +-
 .../IgniteCacheDatabaseSharedManager.java       |   14 +-
 .../cache/database/tree/io/CacheVersionIO.java  |   14 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |   14 +
 .../dht/atomic/GridDhtAtomicCache.java          |   25 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |   21 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   52 +-
 ...idNearAtomicAbstractSingleUpdateRequest.java |    1 -
 .../atomic/GridNearAtomicFullUpdateRequest.java |    3 +-
 ...GridNearAtomicSingleUpdateFilterRequest.java |    3 +-
 ...GridNearAtomicSingleUpdateInvokeRequest.java |    3 +-
 .../dht/colocated/GridDhtColocatedCache.java    |    6 +-
 .../distributed/near/GridNearAtomicCache.java   |   16 +-
 .../near/GridNearTransactionalCache.java        |    2 +-
 .../local/atomic/GridLocalAtomicCache.java      |    6 +-
 .../cache/query/GridCacheSqlQuery.java          |  114 +-
 .../cache/transactions/IgniteTxEntry.java       |    8 +-
 .../cache/transactions/IgniteTxManager.java     |    2 +-
 .../version/GridCachePlainVersionedEntry.java   |    5 -
 .../version/GridCacheRawVersionedEntry.java     |    5 -
 .../cache/version/GridCacheVersion.java         |   47 +-
 .../cache/version/GridCacheVersionEx.java       |   19 +-
 .../cache/version/GridCacheVersionManager.java  |    9 +-
 .../cache/version/GridCacheVersionedEntry.java  |    7 -
 .../clock/GridClockDeltaSnapshot.java           |  235 ----
 .../clock/GridClockDeltaSnapshotMessage.java    |  154 ---
 .../processors/clock/GridClockDeltaVersion.java |  194 ---
 .../processors/clock/GridClockMessage.java      |  171 ---
 .../processors/clock/GridClockServer.java       |  222 ----
 .../processors/clock/GridClockSource.java       |   30 -
 .../clock/GridClockSyncProcessor.java           |  481 --------
 .../processors/clock/GridJvmClockSource.java    |   28 -
 .../datastructures/DataStructuresProcessor.java |    2 -
 .../processors/hadoop/HadoopPayloadAware.java   |   28 -
 .../internal/processors/igfs/IgfsAsyncImpl.java |    5 -
 .../ignite/internal/processors/igfs/IgfsEx.java |    7 -
 .../processors/igfs/IgfsHandshakeResponse.java  |   22 +-
 .../internal/processors/igfs/IgfsImpl.java      |   23 +-
 .../processors/igfs/IgfsIpcHandler.java         |   20 +-
 .../processors/igfs/IgfsModeResolver.java       |   91 +-
 .../internal/processors/igfs/IgfsPaths.java     |  152 ---
 .../internal/processors/igfs/IgfsUtils.java     |    2 -
 .../PlatformDotNetConfigurationClosure.java     |   66 +-
 .../utils/PlatformConfigurationUtils.java       |   11 +-
 .../internal/processors/query/QueryUtils.java   |    5 +
 .../processors/rest/GridRestProcessor.java      |   19 +-
 .../service/GridServiceProcessor.java           |   13 +-
 .../ignite/internal/util/GridIntList.java       |  587 +++++++++
 .../ignite/internal/util/IgniteUtils.java       |   26 +-
 .../visor/cache/VisorCacheConfiguration.java    |   13 +-
 .../visor/cache/VisorCacheLoadTaskArg.java      |    2 +-
 .../visor/cache/VisorCacheStartTask.java        |   10 +-
 .../visor/cache/VisorCacheStartTaskArg.java     |  100 ++
 .../visor/compute/VisorGatewayTask.java         |    2 +-
 .../internal/visor/file/VisorFileBlockTask.java |   10 +-
 .../visor/file/VisorFileBlockTaskArg.java       |  114 ++
 .../visor/igfs/VisorIgfsProfilerTask.java       |   10 +-
 .../internal/visor/log/VisorLogSearchTask.java  |   11 +-
 .../visor/log/VisorLogSearchTaskArg.java        |  114 ++
 .../internal/visor/query/VisorQueryArg.java     |   16 +-
 .../internal/visor/query/VisorQueryTask.java    |   31 +-
 .../internal/visor/query/VisorQueryTaskArg.java |  155 +++
 .../visor/query/VisorScanQueryTask.java         |   12 +-
 .../visor/query/VisorScanQueryTaskArg.java      |  157 +++
 .../ignite/startup/BasicWarmupClosure.java      |    3 +-
 .../resources/META-INF/classnames.properties    |   15 +-
 .../config/websession/example-cache-base.xml    |    1 -
 .../test/config/websession/spring-cache-1.xml   |    6 -
 .../test/config/websession/spring-cache-2.xml   |    6 -
 .../test/config/websession/spring-cache-3.xml   |    6 -
 .../internal/ClusterNodeMetricsSelfTest.java    |   37 +-
 .../IgniteClientReconnectCacheTest.java         |   87 +-
 .../internal/TestRecordingCommunicationSpi.java |   16 +-
 .../CacheAtomicSingleMessageCountSelfTest.java  |    2 -
 .../cache/CacheEnumOperationsAbstractTest.java  |    2 -
 ...CacheExchangeMessageDuplicatedStateTest.java |   41 +-
 ...torPartitionCounterRandomOperationsTest.java |    2 -
 .../CacheStoreUsageMultinodeAbstractTest.java   |    2 -
 .../EntryVersionConsistencyReadThroughTest.java |    2 -
 ...idAbstractCacheInterceptorRebalanceTest.java |    2 -
 .../cache/GridCacheAbstractFullApiSelfTest.java |   15 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    |   16 +-
 .../GridCacheAbstractRemoveFailureTest.java     |    9 -
 .../GridCacheAtomicMessageCountSelfTest.java    |   54 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   80 +-
 .../cache/GridCacheEntryVersionSelfTest.java    |    2 -
 .../cache/GridCacheIncrementTransformTest.java  |    2 -
 .../GridCacheInterceptorAbstractSelfTest.java   |   24 +-
 ...erceptorAtomicPrimaryWriteOrderSelfTest.java |   47 -
 ...omicReplicatedPrimaryWriteOrderSelfTest.java |   48 -
 ...acheInterceptorAtomicReplicatedSelfTest.java |    8 -
 .../GridCacheInterceptorAtomicSelfTest.java     |    8 -
 ...GridCacheInterceptorLocalAtomicSelfTest.java |    8 -
 .../cache/GridCacheMvccFlagsTest.java           |    4 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |   24 +-
 .../processors/cache/GridCacheMvccSelfTest.java |    8 +-
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |    6 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |    2 +-
 .../GridCacheReturnValueTransferSelfTest.java   |   15 +-
 ...ridCacheStoreManagerDeserializationTest.java |   10 -
 .../processors/cache/GridCacheTestEntryEx.java  |    2 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |   10 -
 .../cache/GridCacheVersionMultinodeTest.java    |   40 -
 .../cache/GridCacheVersionSelfTest.java         |    4 +-
 .../GridCacheVersionTopologyChangeTest.java     |    2 -
 .../cache/IgniteCacheAbstractTest.java          |   14 -
 .../cache/IgniteCacheAtomicInvokeTest.java      |    7 -
 .../cache/IgniteCacheAtomicPeekModesTest.java   |    7 -
 ...eCacheAtomicPrimaryWriteOrderInvokeTest.java |   57 -
 ...maryWriteOrderNearEnabledStoreValueTest.java |   31 -
 ...heAtomicPrimaryWriteOrderStoreValueTest.java |   32 -
 ...micPrimaryWriteOrderWithStoreInvokeTest.java |   32 -
 .../cache/IgniteCacheAtomicStoreValueTest.java  |    7 -
 .../IgniteCacheAtomicWithStoreInvokeTest.java   |   32 +
 .../IgniteCacheConfigVariationsFullApiTest.java |    6 -
 .../IgniteCacheEntryListenerAtomicTest.java     |    7 -
 ...niteCacheEntryListenerExpiredEventsTest.java |    2 -
 .../IgniteCacheEntryProcessorCallTest.java      |    3 -
 .../IgniteCacheInterceptorSelfTestSuite.java    |    2 -
 ...gniteCacheInvokeReadThroughAbstractTest.java |    2 -
 .../IgniteCacheP2pUnmarshallingErrorTest.java   |    6 -
 .../IgniteCacheReadThroughStoreCallTest.java    |    2 -
 .../IgniteCacheStoreValueAbstractTest.java      |    4 -
 .../cache/IgniteCacheTxPeekModesTest.java       |    7 -
 .../cache/IgniteExchangeFutureHistoryTest.java  |    6 -
 ...logyValidatorPartitionedAtomicCacheTest.java |    7 -
 ...ologyValidatorReplicatedAtomicCacheTest.java |    7 -
 ...sExchangeOnDiscoveryHistoryOverflowTest.java |    7 -
 .../IgniteCacheAtomicExecutionContextTest.java  |    7 -
 ...iteCachePartitionedExecutionContextTest.java |    7 -
 ...niteCacheReplicatedExecutionContextTest.java |    7 -
 .../IgniteCacheTxExecutionContextTest.java      |    7 -
 ...eAbstractDataStructuresFailoverSelfTest.java |    2 +-
 ...CacheAtomicNearUpdateTopologyChangeTest.java |    7 -
 .../CacheLateAffinityAssignmentTest.java        |    2 -
 ...NearDisabledAtomicInvokeRestartSelfTest.java |    6 -
 ...dCacheMultithreadedFailoverAbstractTest.java |   18 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |   11 -
 .../GridCacheTransformEventSelfTest.java        |    2 -
 .../IgniteCacheAtomicNodeJoinTest.java          |    6 -
 ...niteCacheClientNodeChangingTopologyTest.java |   92 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java |    2 -
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |    2 -
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   19 -
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |   52 +-
 ...EnabledPrimaryWriteOrderFullApiSelfTest.java |   31 -
 ...eAtomicPrimaryWriteOrderFullApiSelfTest.java |   32 -
 ...tomicPrimaryWriteOrderReloadAllSelfTest.java |   32 -
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    7 -
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |    2 -
 ...artitionedBackupNodeFailureRecoveryTest.java |    7 -
 .../IgniteCachePutRetryAbstractSelfTest.java    |   16 -
 .../atomic/GridCacheAtomicFailoverSelfTest.java |    3 -
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   39 +-
 ...AtomicPrimaryWriteOrderFailoverSelfTest.java |   36 -
 ...tomicPrimaryWriteOrderRemoveFailureTest.java |   53 -
 .../GridCacheAtomicRemoveFailureTest.java       |    7 -
 ...micPrimaryWriteOrderNearEnabledSelfTest.java |   39 -
 ...sistencyAtomicPrimaryWriteOrderSelfTest.java |   32 -
 ...PutRetryAtomicPrimaryWriteOrderSelfTest.java |   32 -
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |   35 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   35 -
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |   10 -
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |   19 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   31 -
 .../GridCacheAtomicNearRemoveFailureTest.java   |    7 -
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    2 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   32 -
 ...rderMultiNodeP2PDisabledFullApiSelfTest.java |   33 -
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |   52 -
 ...cPrimaryWriteOrderOnheapFullApiSelfTest.java |   28 -
 ...riteOrderOnheapMultiNodeFullApiSelfTest.java |   29 -
 .../near/GridCacheNearEvictionSelfTest.java     |    2 -
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |    2 -
 ...achePartitionedMultiNodeFullApiSelfTest.java |    4 -
 .../near/NearCacheSyncUpdateTest.java           |   27 +-
 .../GridCacheRebalancingOrderingTest.java       |    2 -
 ...cheRebalancingPartitionDistributionTest.java |    2 -
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    2 -
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |   19 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   33 -
 .../IgniteCacheAtomicExpiryPolicyTest.java      |    7 -
 ...iteCacheAtomicExpiryPolicyWithStoreTest.java |    7 -
 ...AtomicPrimaryWriteOrderExpiryPolicyTest.java |   32 -
 ...maryWriteOrderWithStoreExpiryPolicyTest.java |   32 -
 .../IgniteCacheExpiryPolicyAbstractTest.java    |   57 +-
 .../IgniteCacheExpiryPolicyTestSuite.java       |    2 -
 .../IgniteCacheAtomicLoadAllTest.java           |    7 -
 .../IgniteCacheAtomicLoaderWriterTest.java      |    7 -
 ...gniteCacheAtomicNoLoadPreviousValueTest.java |    7 -
 .../IgniteCacheAtomicNoReadThroughTest.java     |    7 -
 .../IgniteCacheAtomicNoWriteThroughTest.java    |    7 -
 .../IgniteCacheAtomicStoreSessionTest.java      |    7 -
 ...eCacheAtomicStoreSessionWriteBehindTest.java |    7 -
 ...IgniteCacheJdbcBlobStoreNodeRestartTest.java |    8 -
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    2 -
 ...rimaryWriteOrderMultiJvmFullApiSelfTest.java |   31 -
 ...rimaryWriteOrderMultiJvmFullApiSelfTest.java |   31 -
 ...OrderMultiJvmP2PDisabledFullApiSelfTest.java |   31 -
 ...WriteOrderOnheapMultiJvmFullApiSelfTest.java |   29 -
 ...rimaryWriteOrderMultiJvmFullApiSelfTest.java |   31 -
 ...FailoverAtomicPrimaryWriteOrderSelfTest.java |   50 -
 ...tinuousQueryAsyncFailoverAtomicSelfTest.java |   43 +
 ...eContinuousQueryAsyncFilterListenerTest.java |    2 -
 ...acheContinuousQueryExecuteInPrimaryTest.java |    2 -
 ...ContinuousQueryFailoverAbstractSelfTest.java |   10 -
 ...ryFailoverAtomicNearEnabledSelfSelfTest.java |    9 +-
 ...FailoverAtomicPrimaryWriteOrderSelfTest.java |   44 -
 ...usQueryFailoverAtomicReplicatedSelfTest.java |    9 +-
 ...heContinuousQueryFailoverAtomicSelfTest.java |   36 +
 ...ontinuousQueryOperationFromCallbackTest.java |    2 -
 .../CacheContinuousQueryOperationP2PTest.java   |    2 -
 .../CacheContinuousQueryOrderingEventTest.java  |    2 -
 ...acheContinuousQueryRandomOperationsTest.java |    2 -
 .../CacheKeepBinaryIterationTest.java           |    2 -
 ...teCacheClientWriteBehindStoreAtomicTest.java |    7 -
 .../transactions/DepthFirstSearchTest.java      |   18 +-
 .../CacheVersionedEntryAbstractTest.java        |    2 -
 .../clock/GridTimeSyncProcessorSelfTest.java    |  224 ----
 .../database/FreeListImplSelfTest.java          |    2 +-
 .../IgniteDbMemoryLeakAbstractTest.java         |   14 +-
 .../DataStreamerUpdateAfterLoadTest.java        |   18 +-
 ...fsLocalSecondaryFileSystemProxySelfTest.java |    1 -
 .../internal/processors/igfs/IgfsMock.java      |    7 -
 .../GridServiceProcessorAbstractSelfTest.java   |   11 +
 ...ServiceProcessorMultiNodeConfigSelfTest.java |  155 ++-
 .../GridServiceProcessorMultiNodeSelfTest.java  |  192 ++-
 .../ServicePredicateAccessCacheTest.java        |    4 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |    1 -
 .../TcpCommunicationSpiFaultyClientTest.java    |    1 -
 .../GridInternalTasksLoadBalancingSelfTest.java |   21 +-
 .../configvariations/ConfigVariations.java      |    3 -
 .../testframework/junits/GridAbstractTest.java  |    2 -
 .../junits/common/GridCommonAbstractTest.java   |   18 -
 .../IgniteCacheFailoverTestSuite.java           |    4 -
 .../IgniteCacheFailoverTestSuite2.java          |    2 -
 .../IgniteCacheFailoverTestSuite3.java          |    2 -
 ...IgniteCacheFullApiMultiJvmSelfTestSuite.java |   10 -
 .../IgniteCacheFullApiSelfTestSuite.java        |   24 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    6 +-
 .../testsuites/IgniteCacheTestSuite3.java       |    4 -
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |    9 +-
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |  698 ++---------
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |  481 ++------
 ...doopIgfsSecondaryFileSystemDelegateImpl.java |   11 +-
 .../hadoop/impl/igfs/HadoopIgfsEx.java          |    8 +
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |   23 +-
 .../hadoop/impl/igfs/HadoopIgfsOutProc.java     |   12 +
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java     |   14 +
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   14 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |   10 +
 .../IgniteHadoopFileSystemLoggerSelfTest.java   |   32 +-
 ...condaryFileSystemInitializationSelfTest.java |  213 ----
 .../testsuites/IgniteHadoopTestSuite.java       |    3 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |    8 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |    8 -
 .../cache/query/GridCacheTwoStepQuery.java      |   26 +-
 .../processors/query/h2/IgniteH2Indexing.java   |   34 +-
 .../query/h2/opt/GridH2TreeIndex.java           |    2 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |   85 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |   68 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  154 +--
 .../h2/twostep/msg/GridH2QueryRequest.java      |  109 +-
 .../CacheOperationsWithExpirationTest.java      |    2 -
 .../CacheRandomOperationsMultithreadedTest.java |    2 -
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |   51 +-
 .../IgniteCacheCrossCacheJoinRandomTest.java    |    2 -
 ...acheDistributedJoinCollocatedAndNotTest.java |    2 -
 ...acheDistributedJoinCustomAffinityMapper.java |    2 -
 .../IgniteCacheDistributedJoinNoIndexTest.java  |    2 -
 ...ributedJoinPartitionedAndReplicatedTest.java |    2 -
 ...CacheDistributedJoinQueryConditionsTest.java |    2 -
 ...PartitionedAndReplicatedCollocationTest.java |    2 -
 ...teCacheJoinPartitionedAndReplicatedTest.java |   12 +-
 ...iteCacheReplicatedFieldsQueryROSelfTest.java |   27 +
 .../database/IgniteDbMemoryLeakIndexedTest.java |    2 +-
 .../IgniteDbMemoryLeakSqlQueryTest.java         |    2 +-
 ...gniteSqlSegmentedIndexMultiNodeSelfTest.java |   28 +
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  154 +--
 .../query/IgniteSqlSplitterSelfTest.java        |  125 +-
 .../IgniteCacheQuerySelfTestSuite.java          |    6 +-
 .../IgniteCacheQuerySelfTestSuite4.java         |    8 +-
 modules/ml/README.txt                           |   15 +
 modules/ml/licenses/apache-2.0.txt              |  202 ++++
 modules/ml/licenses/mit.txt                     |    7 +
 modules/ml/pom.xml                              |  109 ++
 .../java/org/apache/ignite/math/Algebra.java    |  571 +++++++++
 .../java/org/apache/ignite/math/Constants.java  |   42 +
 .../org/apache/ignite/math/Destroyable.java     |   30 +
 .../apache/ignite/math/IdentityValueMapper.java |   53 +
 .../java/org/apache/ignite/math/KeyMapper.java  |   33 +
 .../java/org/apache/ignite/math/Matrix.java     |  518 ++++++++
 .../org/apache/ignite/math/MatrixKeyMapper.java |   30 +
 .../org/apache/ignite/math/MatrixStorage.java   |   58 +
 .../org/apache/ignite/math/MetaAttributes.java  |   76 ++
 .../java/org/apache/ignite/math/MurmurHash.java |  246 ++++
 .../apache/ignite/math/StorageConstants.java    |   49 +
 .../apache/ignite/math/StorageOpsMetrics.java   |   49 +
 .../java/org/apache/ignite/math/Tracer.java     |  456 +++++++
 .../org/apache/ignite/math/ValueMapper.java     |   27 +
 .../java/org/apache/ignite/math/Vector.java     |  498 ++++++++
 .../org/apache/ignite/math/VectorKeyMapper.java |   29 +
 .../org/apache/ignite/math/VectorStorage.java   |   53 +
 .../decompositions/CholeskyDecomposition.java   |  306 +++++
 .../decompositions/DecompositionSupport.java    |  105 ++
 .../math/decompositions/EigenDecomposition.java |  923 +++++++++++++++
 .../math/decompositions/LUDecomposition.java    |  366 ++++++
 .../math/decompositions/QRDecomposition.java    |  186 +++
 .../SingularValueDecomposition.java             |  620 ++++++++++
 .../math/decompositions/package-info.java       |   22 +
 .../math/exceptions/CardinalityException.java   |   38 +
 .../math/exceptions/ColumnIndexException.java   |   35 +
 .../ignite/math/exceptions/IndexException.java  |   35 +
 .../NonPositiveDefiniteMatrixException.java     |   20 +
 .../exceptions/NonSymmetricMatrixException.java |   18 +
 .../math/exceptions/RowIndexException.java      |   35 +
 .../exceptions/SingularMatrixException.java     |   30 +
 .../exceptions/UnknownProviderException.java    |   35 +
 .../UnsupportedOperationException.java          |   44 +
 .../ignite/math/exceptions/package-info.java    |   22 +
 .../apache/ignite/math/functions/Functions.java |  136 +++
 .../ignite/math/functions/IgniteBiConsumer.java |   12 +
 .../ignite/math/functions/IgniteBiFunction.java |   29 +
 .../ignite/math/functions/IgniteConsumer.java   |   29 +
 .../math/functions/IgniteDoubleFunction.java    |   29 +
 .../ignite/math/functions/IgniteFunction.java   |   30 +
 .../math/functions/IntDoubleToVoidFunction.java |   25 +
 .../functions/IntIntDoubleToVoidFunction.java   |   28 +
 .../math/functions/IntIntToDoubleFunction.java  |   24 +
 .../ignite/math/functions/package-info.java     |   22 +
 .../apache/ignite/math/impls/CacheUtils.java    |  356 ++++++
 .../math/impls/matrix/AbstractMatrix.java       |  880 ++++++++++++++
 .../ignite/math/impls/matrix/CacheMatrix.java   |  158 +++
 .../impls/matrix/DenseLocalOffHeapMatrix.java   |   90 ++
 .../impls/matrix/DenseLocalOnHeapMatrix.java    |   86 ++
 .../math/impls/matrix/DiagonalMatrix.java       |  101 ++
 .../math/impls/matrix/FunctionMatrix.java       |   95 ++
 .../ignite/math/impls/matrix/MatrixView.java    |   84 ++
 .../math/impls/matrix/PivotedMatrixView.java    |  243 ++++
 .../ignite/math/impls/matrix/RandomMatrix.java  |   97 ++
 .../impls/matrix/SparseDistributedMatrix.java   |  155 +++
 .../impls/matrix/SparseLocalOnHeapMatrix.java   |   72 ++
 .../math/impls/matrix/TransposedMatrixView.java |   84 ++
 .../ignite/math/impls/matrix/package-info.java  |   22 +
 .../apache/ignite/math/impls/package-info.java  |   22 +
 .../storage/matrix/ArrayMatrixStorage.java      |  161 +++
 .../storage/matrix/CacheMatrixStorage.java      |  180 +++
 .../matrix/DenseOffHeapMatrixStorage.java       |  197 ++++
 .../storage/matrix/DiagonalMatrixStorage.java   |  136 +++
 .../storage/matrix/FunctionMatrixStorage.java   |  175 +++
 .../storage/matrix/MatrixDelegateStorage.java   |  205 ++++
 .../storage/matrix/PivotedMatrixStorage.java    |  256 ++++
 .../storage/matrix/RandomMatrixStorage.java     |  176 +++
 .../matrix/SparseDistributedMatrixStorage.java  |  281 +++++
 .../matrix/SparseLocalOnHeapMatrixStorage.java  |  226 ++++
 .../math/impls/storage/matrix/package-info.java |   22 +
 .../storage/vector/ArrayVectorStorage.java      |  135 +++
 .../storage/vector/CacheVectorStorage.java      |  175 +++
 .../storage/vector/ConstantVectorStorage.java   |  133 +++
 .../storage/vector/DelegateVectorStorage.java   |  157 +++
 .../vector/DenseLocalOffHeapVectorStorage.java  |  172 +++
 .../storage/vector/FunctionVectorStorage.java   |  141 +++
 .../storage/vector/MatrixVectorStorage.java     |  185 +++
 .../storage/vector/PivotedVectorStorage.java    |  175 +++
 .../storage/vector/RandomVectorStorage.java     |  152 +++
 .../SingleElementVectorDelegateStorage.java     |  145 +++
 .../vector/SingleElementVectorStorage.java      |  143 +++
 .../vector/SparseLocalOffHeapVectorStorage.java |  148 +++
 .../vector/SparseLocalOnHeapVectorStorage.java  |  152 +++
 .../math/impls/storage/vector/package-info.java |   22 +
 .../impls/vector/AbstractReadOnlyVector.java    |  108 ++
 .../math/impls/vector/AbstractVector.java       |  903 ++++++++++++++
 .../ignite/math/impls/vector/CacheVector.java   |  140 +++
 .../math/impls/vector/ConstantVector.java       |   84 ++
 .../math/impls/vector/DelegatingVector.java     |  391 ++++++
 .../impls/vector/DenseLocalOffHeapVector.java   |   89 ++
 .../impls/vector/DenseLocalOnHeapVector.java    |  104 ++
 .../math/impls/vector/FunctionVector.java       |  112 ++
 .../math/impls/vector/MatrixVectorView.java     |  139 +++
 .../math/impls/vector/PivotedVectorView.java    |  163 +++
 .../ignite/math/impls/vector/RandomVector.java  |  128 ++
 .../math/impls/vector/SingleElementVector.java  |  102 ++
 .../impls/vector/SingleElementVectorView.java   |   97 ++
 .../impls/vector/SparseLocalOffHeapVector.java  |   47 +
 .../math/impls/vector/SparseLocalVector.java    |   71 ++
 .../ignite/math/impls/vector/VectorView.java    |   85 ++
 .../ignite/math/impls/vector/package-info.java  |   22 +
 .../org/apache/ignite/math/package-info.java    |   22 +
 .../apache/ignite/math/d3-matrix-template.html  |  128 ++
 .../apache/ignite/math/d3-vector-template.html  |  111 ++
 .../org/apache/ignite/math/ExternalizeTest.java |   66 ++
 .../math/MathImplDistributedTestSuite.java      |   39 +
 .../ignite/math/MathImplLocalTestSuite.java     |  123 ++
 .../ignite/math/MathImplMainTestSuite.java      |   33 +
 .../java/org/apache/ignite/math/TracerTest.java |  195 +++
 .../ignite/math/benchmark/MathBenchmark.java    |  205 ++++
 .../math/benchmark/MathBenchmarkSelfTest.java   |  100 ++
 .../ignite/math/benchmark/ResultsWriter.java    |  127 ++
 .../math/benchmark/VectorBenchmarkTest.java     |  138 +++
 .../ignite/math/benchmark/package-info.java     |   18 +
 .../CholeskyDecompositionTest.java              |  158 +++
 .../decompositions/EigenDecompositionTest.java  |  193 +++
 .../decompositions/LUDecompositionTest.java     |  250 ++++
 .../decompositions/QRDecompositionTest.java     |  139 +++
 .../SingularValueDecompositionTest.java         |  120 ++
 .../ignite/math/impls/MathTestConstants.java    |   88 ++
 .../math/impls/matrix/CacheMatrixTest.java      |  369 ++++++
 .../DenseLocalOffHeapMatrixConstructorTest.java |   65 +
 .../DenseLocalOnHeapMatrixConstructorTest.java  |   71 ++
 .../math/impls/matrix/DiagonalMatrixTest.java   |  209 ++++
 .../matrix/FunctionMatrixConstructorTest.java   |  113 ++
 .../math/impls/matrix/MatrixAttributeTest.java  |  156 +++
 .../matrix/MatrixImplementationFixtures.java    |  381 ++++++
 .../impls/matrix/MatrixImplementationsTest.java | 1113 ++++++++++++++++++
 .../impls/matrix/MatrixKeyMapperForTests.java   |   69 ++
 .../impls/matrix/MatrixViewConstructorTest.java |  114 ++
 .../PivotedMatrixViewConstructorTest.java       |  128 ++
 .../matrix/RandomMatrixConstructorTest.java     |   71 ++
 .../matrix/SparseDistributedMatrixTest.java     |  265 +++++
 .../SparseLocalOnHeapMatrixConstructorTest.java |   53 +
 .../impls/matrix/TransposedMatrixViewTest.java  |   87 ++
 .../storage/matrix/MatrixArrayStorageTest.java  |   63 +
 .../storage/matrix/MatrixBaseStorageTest.java   |   89 ++
 .../matrix/MatrixOffHeapStorageTest.java        |   39 +
 .../storage/matrix/MatrixStorageFixtures.java   |  141 +++
 .../matrix/MatrixStorageImplementationTest.java |   73 ++
 .../SparseDistributedMatrixStorageTest.java     |  126 ++
 .../RandomAccessSparseVectorStorageTest.java    |   60 +
 .../SparseLocalOffHeapVectorStorageTest.java    |   78 ++
 .../storage/vector/VectorArrayStorageTest.java  |   58 +
 .../storage/vector/VectorBaseStorageTest.java   |   69 ++
 .../vector/VectorOffheapStorageTest.java        |   73 ++
 .../math/impls/vector/AbstractVectorTest.java   |  543 +++++++++
 .../math/impls/vector/CacheVectorTest.java      |  417 +++++++
 .../vector/ConstantVectorConstructorTest.java   |   52 +
 .../vector/DelegatingVectorConstructorTest.java |   62 +
 .../DenseLocalOffHeapVectorConstructorTest.java |   59 +
 .../DenseLocalOnHeapVectorConstructorTest.java  |  163 +++
 .../vector/FunctionVectorConstructorTest.java   |  121 ++
 .../math/impls/vector/MatrixVectorViewTest.java |  209 ++++
 .../PivotedVectorViewConstructorTest.java       |  211 ++++
 .../vector/RandomVectorConstructorTest.java     |  145 +++
 .../SingleElementVectorConstructorTest.java     |  159 +++
 .../SingleElementVectorViewConstructorTest.java |  137 +++
 .../SparseLocalVectorConstructorTest.java       |   54 +
 .../math/impls/vector/VectorAttributesTest.java |  217 ++++
 .../math/impls/vector/VectorFoldMapTest.java    |  122 ++
 .../vector/VectorImplementationsFixtures.java   |  655 +++++++++++
 .../impls/vector/VectorImplementationsTest.java |  860 ++++++++++++++
 .../math/impls/vector/VectorIterableTest.java   |  376 ++++++
 .../math/impls/vector/VectorNormTest.java       |  247 ++++
 .../math/impls/vector/VectorToMatrixTest.java   |  291 +++++
 .../math/impls/vector/VectorViewTest.java       |  162 +++
 .../cpp/core-test/config/cache-test-default.xml |    3 -
 .../Apache.Ignite.Core.Tests.csproj             |    7 +
 .../Binary/BinaryBuilderSelfTest.cs             |  122 +-
 .../Binary/BinaryBuilderSelfTestSimpleName.cs   |   33 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |    3 +
 .../Binary/BinaryDynamicRegistrationTest.cs     |   10 +-
 .../Binary/BinaryNameMapperTest.cs              |  108 ++
 .../Binary/BinarySelfTest.cs                    |   40 +-
 .../Binary/BinarySelfTestSimpleName.cs          |   33 +
 .../Binary/Serializable/SqlDmlTest.cs           |    3 +
 .../Binary/TypeNameParserTest.cs                |  232 ++++
 .../Cache/Affinity/AffinityFunctionTest.cs      |   26 +-
 .../Cache/CacheConfigurationTest.cs             |   16 +-
 .../Cache/CacheDynamicStartTest.cs              |    4 +-
 .../Cache/Query/CacheDmlQueriesTest.cs          |   15 +
 .../Query/CacheDmlQueriesTestSimpleName.cs      |   35 +
 .../Cache/Query/CacheLinqTest.cs                |   29 +-
 .../Cache/Query/CacheLinqTestSimpleName.cs      |   35 +
 .../Query/CacheQueriesCodeConfigurationTest.cs  |   10 +-
 .../Cache/Query/CacheQueriesTest.cs             |   13 +-
 .../Cache/Query/CacheQueriesTestSimpleName.cs   |   35 +
 .../Continuous/ContinuousQueryAbstractTest.cs   |   36 +-
 .../Cache/Store/CacheStoreTest.cs               |    4 +-
 .../Compute/ComputeApiTest.cs                   |    3 +-
 .../Config/Compute/compute-grid2.xml            |   10 -
 .../Config/cache-binarizables.xml               |   16 +-
 .../Config/cache-query-continuous.xml           |    8 +-
 .../Config/cache-query.xml                      |    2 +-
 .../Config/native-client-test-cache.xml         |    3 -
 .../ConsoleRedirectTest.cs                      |    5 +-
 .../DataStructures/AtomicLongTest.cs            |    1 +
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |    5 +-
 .../IgniteConfigurationSerializerTest.cs        |   26 +-
 .../IgniteStartStopTest.cs                      |   24 +
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |    7 -
 .../Log/CustomLoggerTest.cs                     |    4 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |   13 +-
 .../Services/ServicesTest.cs                    |    3 +
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |    2 +-
 .../Apache.Ignite.Core.csproj                   |    4 +-
 .../Binary/BinaryBasicNameMapper.cs             |  129 ++
 .../Configuration/CacheAtomicWriteOrderMode.cs  |   43 -
 .../Cache/Configuration/CacheConfiguration.cs   |   13 -
 .../Cache/Configuration/QueryEntity.cs          |    4 +-
 .../Cache/Configuration/QueryField.cs           |    2 +-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |   24 +
 .../IgniteConfigurationSection.xsd              |   17 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   69 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |   10 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |    4 +-
 .../Binary/BinarySurrogateTypeDescriptor.cs     |   15 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |   10 +
 .../Impl/Binary/BinaryUtils.cs                  |  125 +-
 .../Impl/Binary/Marshaller.cs                   |   96 +-
 .../Impl/Binary/TypeNameParser.cs               |  384 ++++++
 .../Impl/Binary/TypeResolver.cs                 |   95 +-
 .../Impl/Compute/ComputeFunc.cs                 |    2 +-
 .../Impl/Compute/ComputeJob.cs                  |    2 +-
 .../Impl/Compute/ComputeOutFunc.cs              |    2 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   14 -
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |  464 --------
 .../Impl/Resource/ResourceProcessor.cs          |   10 -
 .../Impl/Resource/ResourceTypeDescriptor.cs     |   12 +-
 .../Impl/CacheFieldsQueryProvider.cs            |   24 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |    4 +-
 .../Impl/CacheQueryModelVisitor.cs              |   15 +
 .../config/EnableIgniteRepositories.java        |   10 +-
 .../repository/query/IgniteQueryGenerator.java  |    8 +-
 .../commands/cache/VisorCacheCommand.scala      |    1 -
 .../commands/cache/VisorCacheScanCommand.scala  |    3 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |    4 +
 .../commands/open/VisorOpenCommandSpec.scala    |    6 +-
 modules/web-console/backend/app/agent.js        |  926 ---------------
 modules/web-console/backend/app/agentSocket.js  |  249 ++++
 .../web-console/backend/app/agentsHandler.js    |  400 +++++++
 modules/web-console/backend/app/apiServer.js    |   68 ++
 modules/web-console/backend/app/app.js          |   63 -
 modules/web-console/backend/app/browser.js      |  539 ---------
 .../web-console/backend/app/browsersHandler.js  |  279 +++++
 modules/web-console/backend/app/mongo.js        |    3 -
 modules/web-console/backend/app/routes.js       |    6 +-
 modules/web-console/backend/index.js            |   44 +-
 modules/web-console/backend/package.json        |   52 +-
 modules/web-console/backend/routes/agent.js     |   57 -
 modules/web-console/backend/routes/demo.js      |   14 +-
 modules/web-console/backend/routes/downloads.js |   57 +
 modules/web-console/backend/services/agents.js  |   83 --
 .../web-console/backend/services/downloads.js   |   80 ++
 modules/web-console/backend/services/users.js   |   10 +-
 .../web-console/backend/test/app/httpAgent.js   |    6 +-
 .../web-console/backend/test/routes/clusters.js |    4 +-
 modules/web-console/frontend/app/app.config.js  |    1 +
 modules/web-console/frontend/app/app.js         |   12 +-
 .../components/activities-user-dialog/index.js  |    1 -
 .../cluster-select/cluster-select.controller.js |   55 +
 .../cluster-select/cluster-select.pug           |   40 +
 .../app/components/cluster-select/index.js      |   28 +
 .../input-dialog/input-dialog.service.js        |    1 -
 .../list-of-registered-users.column-defs.js     |    2 +-
 .../app/helpers/jade/form/form-field-text.pug   |   19 +-
 .../frontend/app/helpers/jade/mixins.pug        |    6 +
 .../app/modules/agent/AgentManager.service.js   |  529 +++++++++
 .../app/modules/agent/AgentModal.service.js     |   89 ++
 .../frontend/app/modules/agent/agent.module.js  |  347 +-----
 .../frontend/app/modules/cluster/Cache.js       |   59 +
 .../app/modules/cluster/CacheMetrics.js         |   59 +
 .../frontend/app/modules/cluster/Node.js        |   54 +
 .../frontend/app/modules/cluster/NodeMetrics.js |   19 +
 .../generator/ConfigurationGenerator.js         |    5 +-
 .../generator/PlatformGenerator.js              |    1 -
 .../defaults/Cache.platform.service.js          |    4 -
 .../generator/defaults/Cache.service.js         |    3 -
 .../generator/defaults/Cluster.service.js       |    2 -
 .../frontend/app/modules/demo/Demo.module.js    |    5 +-
 .../app/modules/dialog/dialog.factory.js        |    1 -
 .../getting-started/GettingStarted.provider.js  |    2 +-
 .../app/modules/navbar/userbar.directive.js     |    4 +-
 .../frontend/app/modules/nodes/Nodes.service.js |    1 -
 .../app/modules/sql/notebook.controller.js      |    2 +-
 .../frontend/app/modules/sql/sql.controller.js  |   49 +-
 .../frontend/app/modules/states/admin.state.js  |    4 +-
 .../app/modules/states/configuration.state.js   |   17 +-
 .../states/configuration/caches/concurrency.pug |   11 -
 .../states/configuration/clusters/time.pug      |   10 +-
 .../app/modules/states/profile.state.js         |    2 +-
 .../frontend/app/modules/user/Auth.service.js   |    6 +-
 .../frontend/app/services/Confirm.service.js    |    2 +-
 .../app/services/ConfirmBatch.service.js        |    1 -
 .../frontend/controllers/caches-controller.js   |    2 +-
 .../frontend/controllers/domains-controller.js  |   20 +-
 modules/web-console/frontend/package.json       |   62 +-
 .../stylesheets/_bootstrap-variables.scss       |    2 +-
 .../stylesheets/_font-awesome-custom.scss       |    5 +
 .../frontend/public/stylesheets/style.scss      |   57 +-
 .../frontend/views/includes/header.pug          |   23 +-
 .../views/templates/agent-download.tpl.pug      |   39 +-
 .../frontend/views/templates/demo-info.tpl.pug  |    2 +-
 modules/web-console/web-agent/pom.xml           |   16 +-
 .../console/agent/AgentConfiguration.java       |   47 +-
 .../ignite/console/agent/AgentLauncher.java     |  196 ++-
 .../apache/ignite/console/agent/AgentUtils.java |    6 +-
 .../console/agent/handlers/ClusterListener.java |  266 +++++
 .../agent/handlers/DatabaseListener.java        |    6 +-
 .../console/agent/handlers/DemoListener.java    |  131 +++
 .../console/agent/handlers/RestListener.java    |  229 +---
 .../ignite/console/agent/rest/RestExecutor.java |  197 ++++
 .../ignite/console/agent/rest/RestResult.java   |   81 ++
 .../ignite/console/demo/AgentClusterDemo.java   |  175 +--
 .../ignite/console/demo/AgentDemoUtils.java     |    2 +-
 .../demo/service/DemoCachesLoadService.java     |   35 +-
 modules/yardstick/README.txt                    |    1 -
 .../yardstick/IgniteBenchmarkArguments.java     |   15 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    3 -
 pom.xml                                         |    7 +
 671 files changed, 38338 insertions(+), 10335 deletions(-)
----------------------------------------------------------------------


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

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/main/resources/META-INF/classnames.properties
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/config/websession/example-cache-base.xml
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheEntryMemorySizeSelfTest.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheEntryMemorySizeSelfTest.java
index f4fdb19,d361d45..3241985
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheEntryMemorySizeSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheEntryMemorySizeSelfTest.java
@@@ -133,10 -141,10 +141,10 @@@ public class GridCacheEntryMemorySizeSe
      /**
       * Creates an instance of Marshaller that is used by caches during the test run.
       *
-      * @return
+      * @return Marshaller.
       */
      protected Marshaller createMarshaller() throws IgniteCheckedException {
 -        Marshaller marsh = new OptimizedMarshaller();
 +        Marshaller marsh = createStandaloneBinaryMarshaller();
  
          marsh.setContext(new MarshallerContext() {
              @Override public boolean registerClassName(byte platformId, int typeId, String clsName) {

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheStoreManagerDeserializationTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVersionSelfTest.java
----------------------------------------------------------------------
diff --cc modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVersionSelfTest.java
index b4223e5,b69255f..9cec7ec
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVersionSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheVersionSelfTest.java
@@@ -78,9 -79,11 +78,9 @@@ public class GridCacheVersionSelfTest e
       */
      public void testMarshalling() throws Exception {
          GridCacheVersion ver = version(1, 1);
-         GridCacheVersionEx verEx = new GridCacheVersionEx(2, 2, 0, 0, ver);
+         GridCacheVersionEx verEx = new GridCacheVersionEx(2, 2, 0, ver);
  
 -        OptimizedMarshaller marsh = new OptimizedMarshaller(false);
 -
 -        marsh.setContext(new MarshallerContextTestImpl());
 +        Marshaller marsh = createStandaloneBinaryMarshaller();
  
          byte[] verBytes = marsh.marshal(ver);
          byte[] verExBytes = marsh.marshal(verEx);

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/java/org/apache/ignite/testframework/configvariations/ConfigVariations.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/java/org/apache/ignite/testframework/junits/GridAbstractTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheTestSuite.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/f4558d84/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/impl/igfs/IgniteHadoopFileSystemAbstractSelfTest.java
----------------------------------------------------------------------
diff --cc modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/impl/igfs/IgniteHadoopFileSystemAbstractSelfTest.java
index 79a7830,2214b5b..cc3f9f4
--- a/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/impl/igfs/IgniteHadoopFileSystemAbstractSelfTest.java
+++ b/modules/hadoop/src/test/java/org/apache/ignite/internal/processors/hadoop/impl/igfs/IgniteHadoopFileSystemAbstractSelfTest.java
@@@ -70,8 -70,8 +70,9 @@@ import org.apache.ignite.igfs.IgfsIpcEn
  import org.apache.ignite.igfs.IgfsIpcEndpointType;
  import org.apache.ignite.igfs.IgfsMode;
  import org.apache.ignite.igfs.IgfsPath;
 +import org.apache.ignite.internal.binary.BinaryMarshaller;
  import org.apache.ignite.internal.processors.igfs.IgfsCommonAbstractTest;
+ import org.apache.ignite.internal.processors.igfs.IgfsModeResolver;
  import org.apache.ignite.internal.util.GridConcurrentHashSet;
  import org.apache.ignite.internal.util.lang.GridAbsPredicate;
  import org.apache.ignite.internal.util.typedef.F;