You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2017/04/19 14:48:10 UTC

[49/50] [abbrv] ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-2.0' into ignite-1561

Merge remote-tracking branch 'remotes/origin/ignite-2.0' into ignite-1561


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

Branch: refs/heads/ignite-1561
Commit: df28c1adc87cfe1af9e5b18269733426c26fdda4
Parents: 63001f1 5dab5fb
Author: sboikov <sb...@gridgain.com>
Authored: Wed Apr 19 17:45:05 2017 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Wed Apr 19 17:45:05 2017 +0300

----------------------------------------------------------------------
 doap_Ignite.rdf                                 |   11 +-
 examples/README.txt                             |   10 +-
 examples/config/example-memory-policies.xml     |  105 +
 examples/config/filesystem/example-igfs.xml     |    7 -
 examples/pom-standalone-lgpl.xml                |   19 +
 examples/pom-standalone.xml                     |   19 +
 examples/pom.xml                                |   30 +
 .../datagrid/MemoryPoliciesExample.java         |  114 +
 .../MemcacheRestExampleNodeStartup.java         |    7 -
 .../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  |   66 +
 .../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 +
 .../examples/ScalarCacheAffinityExample.scala   |    2 +-
 .../ignite/examples/CacheExamplesSelfTest.java  |    8 +
 .../optimized/OptimizedMarshallerAopTest.java   |  105 +
 .../optimized/OptimizedMarshallerAopTest.java   |  104 -
 .../store/cassandra/datasource/DataSource.java  |   50 +-
 .../cassandra/session/CassandraSessionImpl.java |   23 +-
 .../cassandra/session/pool/SessionPool.java     |    6 +-
 .../cassandra/session/pool/SessionWrapper.java  |   15 +-
 .../ignite/ignite-cassandra-server-template.xml |    6 -
 .../tests/ignite-cassandra-client-template.xml  |    6 -
 modules/clients/src/test/config/jdbc-config.xml |    2 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   92 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |    9 +-
 ...cBinaryMarshallerMergeStatementSelfTest.java |    9 +-
 .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java |  367 +++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...bcDynamicIndexAtomicPartitionedSelfTest.java |   39 +
 ...dbcDynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 .../jdbc2/JdbcInsertStatementSelfTest.java      |    4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |  102 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    8 +
 .../ignite/codegen/MessageCodeGenerator.java    |    4 +
 modules/core/pom.xml                            |    3 +
 .../java/org/apache/ignite/IgniteCache.java     |   13 -
 .../java/org/apache/ignite/IgniteCluster.java   |   52 -
 .../apache/ignite/IgniteSystemProperties.java   |   10 +-
 .../ignite/binary/BinaryBasicNameMapper.java    |    3 +
 .../ignite/cache/CacheAtomicWriteOrderMode.java |   64 -
 .../org/apache/ignite/cache/CacheEntry.java     |   12 -
 .../ignite/cache/PartitionLossPolicy.java       |   16 +-
 .../org/apache/ignite/cache/QueryEntity.java    |   82 +-
 .../org/apache/ignite/cache/QueryIndex.java     |    9 +
 .../org/apache/ignite/cache/QueryIndexType.java |   17 +-
 .../AffinityNodeAddressHashResolver.java        |   44 -
 .../affinity/AffinityNodeHashResolver.java      |   47 -
 .../affinity/AffinityNodeIdHashResolver.java    |   45 -
 .../rendezvous/RendezvousAffinityFunction.java  |   51 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |   25 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   31 +-
 .../configuration/CacheConfiguration.java       |   84 +-
 .../configuration/DataPageEvictionMode.java     |   33 +-
 .../configuration/FileSystemConfiguration.java  |  226 +-
 .../configuration/IgniteConfiguration.java      |  102 +-
 .../configuration/MemoryConfiguration.java      |   87 +-
 .../MemoryPolicyConfiguration.java              |  112 +-
 .../org/apache/ignite/hadoop/package-info.java  |   22 +
 .../java/org/apache/ignite/igfs/IgfsPath.java   |   31 +-
 .../apache/ignite/internal/GridComponent.java   |    5 +-
 .../ignite/internal/GridKernalContext.java      |   23 +-
 .../ignite/internal/GridKernalContextImpl.java  |   44 +-
 .../org/apache/ignite/internal/GridTopic.java   |    5 +-
 .../apache/ignite/internal/IgniteKernal.java    |   87 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   24 +-
 .../apache/ignite/internal/LessNamingBean.java  |   28 -
 .../internal/binary/BinaryClassDescriptor.java  |    2 +-
 .../ignite/internal/binary/BinaryContext.java   |    2 +-
 .../GridClientOptimizedMarshaller.java          |    2 +-
 .../GridClientZipOptimizedMarshaller.java       |    2 +-
 .../cluster/IgniteClusterAsyncImpl.java         |   11 -
 .../internal/cluster/IgniteClusterImpl.java     |   38 -
 .../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 +
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |   41 +-
 .../ignite/internal/jdbc2/JdbcQueryTaskV2.java  |  406 ----
 .../ignite/internal/jdbc2/JdbcResultSet.java    |   64 +-
 .../ignite/internal/jdbc2/JdbcStatement.java    |   12 +-
 .../managers/communication/GridIoManager.java   |    2 +
 .../communication/GridIoMessageFactory.java     |   26 +-
 .../managers/communication/GridIoPolicy.java    |    3 +
 .../optimized/OptimizedClassDescriptor.java     | 1141 +++++++++
 .../optimized/OptimizedFieldType.java           |   50 +
 .../optimized/OptimizedMarshaller.java          |  313 +++
 .../optimized/OptimizedMarshallerIdMapper.java  |   33 +
 .../optimized/OptimizedMarshallerUtils.java     |  551 +++++
 .../optimized/OptimizedObjectInputStream.java   | 1231 ++++++++++
 .../optimized/OptimizedObjectOutputStream.java  |  875 +++++++
 .../OptimizedObjectStreamRegistry.java          |  244 ++
 .../cache/CacheAffinitySharedManager.java       |   11 +-
 .../processors/cache/CacheEntryImplEx.java      |    8 +-
 .../cache/CachePartitionExchangeWorkerTask.java |    6 +-
 .../cache/DynamicCacheChangeRequest.java        |   23 +-
 .../cache/DynamicCacheDescriptor.java           |   50 +-
 .../processors/cache/GridCacheAdapter.java      |   61 +-
 .../cache/GridCacheAtomicVersionComparator.java |   24 +-
 .../processors/cache/GridCacheAttributes.java   |   16 -
 .../cache/GridCacheConcurrentMap.java           |    5 -
 .../cache/GridCacheConcurrentMapImpl.java       |   10 -
 .../processors/cache/GridCacheEntryEx.java      |   13 +-
 .../processors/cache/GridCacheMapEntry.java     |   38 +-
 .../processors/cache/GridCacheMvcc.java         |   23 +-
 .../GridCachePartitionExchangeManager.java      |   36 +-
 .../processors/cache/GridCacheProcessor.java    |  285 +--
 .../cache/GridCacheSharedContext.java           |    2 +
 .../cache/GridCacheSwapEntryImpl.java           |    4 +-
 .../processors/cache/GridCacheUtils.java        |    7 +-
 .../processors/cache/GridNoStorageCacheMap.java |    5 -
 .../processors/cache/IgniteCacheProxy.java      |   25 +-
 .../IgniteCacheDatabaseSharedManager.java       |   14 +-
 .../cache/database/tree/io/CacheVersionIO.java  |   14 +-
 .../dht/GridCachePartitionedConcurrentMap.java  |    5 -
 .../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 +-
 .../GridDhtPartitionsExchangeFuture.java        |    5 -
 .../distributed/near/GridNearAtomicCache.java   |   16 +-
 .../distributed/near/GridNearCacheAdapter.java  |    6 -
 .../near/GridNearTransactionalCache.java        |    2 +-
 .../local/atomic/GridLocalAtomicCache.java      |    6 +-
 .../cache/query/GridCacheQueryManager.java      |    7 +-
 .../cache/query/GridCacheSqlIndexMetadata.java  |    3 +-
 .../cache/query/GridCacheSqlMetadata.java       |    3 +-
 .../cache/query/GridCacheSqlQuery.java          |  114 +-
 .../cache/query/IgniteQueryErrorCode.java       |   27 +-
 .../cache/store/GridCacheWriteBehindStore.java  |  614 ++++-
 .../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      |   45 +-
 .../processors/igfs/IgfsIpcHandler.java         |   20 +-
 .../processors/igfs/IgfsModeResolver.java       |   91 +-
 .../internal/processors/igfs/IgfsPaths.java     |  152 --
 .../internal/processors/igfs/IgfsUtils.java     |    2 -
 .../callback/PlatformCallbackGateway.java       |   68 -
 .../PlatformDotNetConfigurationClosure.java     |   66 +-
 .../cache/PlatformCachePluginProvider.java      |  121 -
 .../utils/PlatformConfigurationUtils.java       |   11 +-
 .../internal/processors/pool/PoolProcessor.java |    5 +
 .../query/GridQueryIndexDescriptor.java         |    5 +
 .../processors/query/GridQueryIndexing.java     |   43 +-
 .../processors/query/GridQueryProcessor.java    | 1707 +++++++++++++-
 .../query/GridQueryTypeDescriptor.java          |    7 +
 .../processors/query/IgniteSQLException.java    |    7 +
 .../query/QueryIndexDescriptorImpl.java         |   42 +-
 .../processors/query/QueryIndexKey.java         |   85 +
 .../internal/processors/query/QuerySchema.java  |  168 ++
 .../query/QueryTypeDescriptorImpl.java          |  150 +-
 .../internal/processors/query/QueryUtils.java   |  224 +-
 .../query/schema/SchemaExchangeWorkerTask.java  |   53 +
 .../query/schema/SchemaIndexCacheVisitor.java   |   33 +
 .../schema/SchemaIndexCacheVisitorClosure.java  |   42 +
 .../schema/SchemaIndexCacheVisitorImpl.java     |  197 ++
 .../SchemaIndexOperationCancellationToken.java  |   53 +
 .../processors/query/schema/SchemaKey.java      |   59 +
 .../SchemaNodeLeaveExchangeWorkerTask.java      |   53 +
 .../schema/SchemaOperationClientFuture.java     |   52 +
 .../query/schema/SchemaOperationException.java  |  138 ++
 .../query/schema/SchemaOperationManager.java    |  292 +++
 .../query/schema/SchemaOperationWorker.java     |  205 ++
 .../message/SchemaAbstractDiscoveryMessage.java |   70 +
 .../message/SchemaFinishDiscoveryMessage.java   |   98 +
 .../message/SchemaOperationStatusMessage.java   |  168 ++
 .../message/SchemaProposeDiscoveryMessage.java  |  133 ++
 .../operation/SchemaAbstractOperation.java      |   67 +
 .../operation/SchemaIndexAbstractOperation.java |   40 +
 .../operation/SchemaIndexCreateOperation.java   |   91 +
 .../operation/SchemaIndexDropOperation.java     |   68 +
 .../processors/rest/GridRestProcessor.java      |   19 +-
 .../rest/client/message/GridClientNodeBean.java |    2 +-
 .../top/GridTopologyCommandHandler.java         |    4 +
 .../service/GridServiceProcessor.java           |   13 +-
 .../ignite/internal/util/GridIntList.java       |  586 +++++
 .../internal/util/IgniteExceptionRegistry.java  |    3 +-
 .../ignite/internal/util/IgniteUtils.java       |   26 +-
 .../ignite/internal/util/lang/GridTupleV.java   |  194 --
 .../internal/visor/VisorDataTransferObject.java |   87 +
 .../visor/VisorDataTransferObjectInput.java     |  156 ++
 .../visor/VisorDataTransferObjectOutput.java    |  141 ++
 .../ignite/internal/visor/VisorEither.java      |  103 +
 .../internal/visor/VisorMultiNodeTask.java      |    6 +-
 .../ignite/internal/visor/VisorOneNodeTask.java |    5 +-
 .../internal/visor/VisorTaskArgument.java       |   51 +-
 .../visor/binary/VisorBinaryMetadata.java       |  139 ++
 .../VisorBinaryMetadataCollectorTask.java       |   70 +
 .../VisorBinaryMetadataCollectorTaskResult.java |   87 +
 .../visor/binary/VisorBinaryMetadataField.java  |  101 +
 .../ignite/internal/visor/cache/VisorCache.java |  124 +-
 .../cache/VisorCacheAffinityConfiguration.java  |   91 +-
 .../visor/cache/VisorCacheAffinityNodeTask.java |   13 +-
 .../cache/VisorCacheAffinityNodeTaskArg.java    |   86 +
 .../cache/VisorCacheAggregatedMetrics.java      |  205 +-
 .../visor/cache/VisorCacheClearTask.java        |  100 +-
 .../visor/cache/VisorCacheClearTaskResult.java  |   85 +
 .../visor/cache/VisorCacheConfiguration.java    |  284 ++-
 .../VisorCacheConfigurationCollectorJob.java    |    4 +-
 .../cache/VisorCacheDefaultConfiguration.java   |   58 -
 .../cache/VisorCacheEvictionConfiguration.java  |   52 +-
 .../visor/cache/VisorCacheJdbcType.java         |  189 ++
 .../visor/cache/VisorCacheJdbcTypeField.java    |  117 +
 .../visor/cache/VisorCacheLoadTask.java         |   20 +-
 .../visor/cache/VisorCacheLoadTaskArg.java      |  101 +
 .../visor/cache/VisorCacheMetadataTask.java     |   18 +-
 .../internal/visor/cache/VisorCacheMetrics.java |  208 +-
 .../cache/VisorCacheMetricsCollectorTask.java   |   29 +-
 .../VisorCacheMetricsCollectorTaskArg.java      |   87 +
 .../cache/VisorCacheNearConfiguration.java      |   59 +-
 .../visor/cache/VisorCachePartition.java        |   78 -
 .../visor/cache/VisorCachePartitions.java       |   55 +-
 .../visor/cache/VisorCachePartitionsTask.java   |   25 +-
 .../cache/VisorCachePartitionsTaskArg.java      |   72 +
 .../cache/VisorCacheQueryConfiguration.java     |  122 -
 .../cache/VisorCacheQueryDetailMetrics.java     |  167 --
 ...sorCacheQueryDetailMetricsCollectorTask.java |  146 --
 .../visor/cache/VisorCacheQueryMetrics.java     |  102 -
 .../cache/VisorCacheRebalanceConfiguration.java |   71 +-
 .../VisorCacheResetQueryDetailMetricsTask.java  |   71 -
 .../cache/VisorCacheResetQueryMetricsTask.java  |   69 -
 .../visor/cache/VisorCacheSqlIndexMetadata.java |  115 +
 .../visor/cache/VisorCacheSqlMetadata.java      |  162 ++
 .../visor/cache/VisorCacheStartArg.java         |  100 +
 .../visor/cache/VisorCacheStartTask.java        |   68 +-
 .../visor/cache/VisorCacheStartTaskArg.java     |  100 +
 .../cache/VisorCacheStoreConfiguration.java     |   77 +-
 .../cache/VisorCacheTypeFieldMetadata.java      |   92 -
 .../visor/cache/VisorCacheTypeMetadata.java     |  294 ---
 .../internal/visor/cache/VisorPartitionMap.java |   90 +
 .../compute/VisorComputeMonitoringHolder.java   |    8 +-
 .../VisorComputeToggleMonitoringTask.java       |   52 +-
 .../VisorComputeToggleMonitoringTaskArg.java    |   86 +
 .../visor/compute/VisorGatewayTask.java         |   97 +-
 .../visor/debug/VisorThreadDumpTask.java        |   13 +-
 .../visor/debug/VisorThreadDumpTaskResult.java  |   88 +
 .../internal/visor/debug/VisorThreadInfo.java   |  234 +-
 .../visor/debug/VisorThreadLockInfo.java        |   51 +-
 .../visor/debug/VisorThreadMonitorInfo.java     |   76 +-
 .../visor/event/VisorGridDeploymentEvent.java   |   43 +-
 .../visor/event/VisorGridDiscoveryEvent.java    |   59 +-
 .../internal/visor/event/VisorGridEvent.java    |   66 +-
 .../visor/event/VisorGridEventsLost.java        |   15 +-
 .../internal/visor/event/VisorGridJobEvent.java |   61 +-
 .../visor/event/VisorGridTaskEvent.java         |   61 +-
 .../internal/visor/file/VisorFileBlock.java     |   60 +-
 .../internal/visor/file/VisorFileBlockArg.java  |  114 +
 .../internal/visor/file/VisorFileBlockTask.java |   68 +-
 .../visor/file/VisorFileBlockTaskArg.java       |  114 +
 .../visor/file/VisorLatestTextFilesTask.java    |   17 +-
 .../visor/file/VisorLatestTextFilesTaskArg.java |   86 +
 .../ignite/internal/visor/igfs/VisorIgfs.java   |   76 +-
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |   72 +-
 .../internal/visor/igfs/VisorIgfsMetrics.java   |  118 +-
 .../internal/visor/igfs/VisorIgfsProfiler.java  |   24 +-
 .../visor/igfs/VisorIgfsProfilerClearTask.java  |   11 +-
 .../igfs/VisorIgfsProfilerClearTaskResult.java  |   85 +
 .../visor/igfs/VisorIgfsProfilerEntry.java      |  106 +-
 .../visor/igfs/VisorIgfsProfilerTask.java       |   41 +-
 .../VisorIgfsProfilerUniformityCounters.java    |   38 +-
 .../visor/igfs/VisorIgfsSamplingStateTask.java  |   17 +-
 .../igfs/VisorIgfsSamplingStateTaskArg.java     |   86 +
 .../ignite/internal/visor/log/VisorLogFile.java |   43 +-
 .../internal/visor/log/VisorLogSearchArg.java   |  114 +
 .../visor/log/VisorLogSearchResult.java         |   80 +-
 .../internal/visor/log/VisorLogSearchTask.java  |   81 +-
 .../visor/log/VisorLogSearchTaskArg.java        |  114 +
 .../visor/log/VisorLogSearchTaskResult.java     |   92 +
 .../visor/node/VisorAtomicConfiguration.java    |   49 +-
 .../visor/node/VisorBasicConfiguration.java     |  163 +-
 .../node/VisorExecutorServiceConfiguration.java |   81 +-
 .../visor/node/VisorGridConfiguration.java      |  126 +-
 .../visor/node/VisorIgfsConfiguration.java      |  222 +-
 .../visor/node/VisorLifecycleConfiguration.java |   39 +-
 .../visor/node/VisorMemoryConfiguration.java    |   60 +-
 .../node/VisorMemoryPolicyConfiguration.java    |   37 +-
 .../visor/node/VisorMetricsConfiguration.java   |   50 +-
 .../VisorNodeConfigurationCollectorJob.java     |    4 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   63 +-
 .../node/VisorNodeDataCollectorJobResult.java   |  109 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |   40 +-
 .../node/VisorNodeDataCollectorTaskArg.java     |   54 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |  110 +-
 .../node/VisorNodeEventsCollectorTask.java      |  133 +-
 .../node/VisorNodeEventsCollectorTaskArg.java   |  163 ++
 .../internal/visor/node/VisorNodeGcTask.java    |   18 +-
 .../visor/node/VisorNodeGcTaskResult.java       |   85 +
 .../internal/visor/node/VisorNodePingTask.java  |   15 +-
 .../visor/node/VisorNodePingTaskResult.java     |   99 +
 .../visor/node/VisorNodeSuppressedErrors.java   |   89 +
 .../node/VisorNodeSuppressedErrorsTask.java     |   23 +-
 .../node/VisorPeerToPeerConfiguration.java      |   57 +-
 .../visor/node/VisorRestConfiguration.java      |   93 +-
 .../node/VisorSegmentationConfiguration.java    |   67 +-
 .../visor/node/VisorSpiDescription.java         |   89 +
 .../visor/node/VisorSpisConfiguration.java      |  128 +-
 .../visor/node/VisorSuppressedError.java        |  147 ++
 .../node/VisorTransactionConfiguration.java     |  104 +-
 .../visor/query/VisorCancelQueriesTask.java     |   72 -
 .../query/VisorCollectRunningQueriesTask.java   |   96 -
 .../internal/visor/query/VisorQueryArg.java     |   81 +-
 .../visor/query/VisorQueryCancelTask.java       |   72 +
 .../visor/query/VisorQueryCleanupTask.java      |    6 +-
 .../visor/query/VisorQueryConfiguration.java    |  142 ++
 .../visor/query/VisorQueryDetailMetrics.java    |  205 ++
 .../VisorQueryDetailMetricsCollectorTask.java   |  146 ++
 .../internal/visor/query/VisorQueryEntity.java  |  188 ++
 .../internal/visor/query/VisorQueryField.java   |   42 +-
 .../internal/visor/query/VisorQueryIndex.java   |  105 +
 .../visor/query/VisorQueryIndexField.java       |  106 +
 .../internal/visor/query/VisorQueryJob.java     |  275 ---
 .../internal/visor/query/VisorQueryMetrics.java |  125 +
 .../visor/query/VisorQueryNextPageTask.java     |   33 +-
 .../visor/query/VisorQueryNextPageTaskArg.java  |   86 +
 .../query/VisorQueryResetDetailMetricsTask.java |   71 +
 .../visor/query/VisorQueryResetMetricsTask.java |   69 +
 .../internal/visor/query/VisorQueryResult.java  |   97 +-
 .../visor/query/VisorQueryResultEx.java         |   89 -
 .../visor/query/VisorQueryScanRegexFilter.java  |   59 +
 .../query/VisorQueryScanSubstringFilter.java    |   64 -
 .../internal/visor/query/VisorQueryTask.java    |  103 +-
 .../internal/visor/query/VisorQueryTaskArg.java |  155 ++
 .../internal/visor/query/VisorQueryUtils.java   |   43 +-
 .../query/VisorRunningQueriesCollectorTask.java |   96 +
 .../internal/visor/query/VisorRunningQuery.java |   47 +-
 .../internal/visor/query/VisorScanQueryArg.java |  157 ++
 .../visor/query/VisorScanQueryTask.java         |  185 ++
 .../visor/query/VisorScanQueryTaskArg.java      |  157 ++
 .../visor/service/VisorServiceDescriptor.java   |   40 +-
 .../internal/visor/util/VisorTaskUtils.java     |   38 +-
 .../apache/ignite/marshaller/Marshaller.java    |    3 +-
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    3 +-
 .../optimized/OptimizedClassDescriptor.java     | 1141 ---------
 .../optimized/OptimizedFieldType.java           |   50 -
 .../optimized/OptimizedMarshaller.java          |  313 ---
 .../optimized/OptimizedMarshallerIdMapper.java  |   33 -
 .../optimized/OptimizedMarshallerUtils.java     |  551 -----
 .../optimized/OptimizedObjectInputStream.java   | 1231 ----------
 .../optimized/OptimizedObjectOutputStream.java  |  875 -------
 .../OptimizedObjectStreamRegistry.java          |  244 --
 .../marshaller/optimized/package-info.java      |   22 -
 .../ignite/plugin/platform/package-info.java    |   22 +
 .../plugin/security/SecurityPermissionSet.java  |    3 +-
 .../ignite/plugin/security/SecuritySubject.java |    3 +-
 .../plugin/segmentation/SegmentationPolicy.java |   18 +-
 .../communication/tcp/TcpCommunicationSpi.java  |  109 -
 .../tcp/TcpCommunicationSpiMBean.java           |   54 -
 .../ignite/startup/BasicWarmupClosure.java      |    3 +-
 .../resources/META-INF/classnames.properties    |  252 +-
 modules/core/src/test/config/example-cache.xml  |    2 +-
 modules/core/src/test/config/igfs-loopback.xml  |    2 +-
 modules/core/src/test/config/igfs-shmem.xml     |    2 +-
 .../src/test/config/spring-start-nodes-attr.xml |    2 +-
 .../core/src/test/config/spring-start-nodes.xml |    2 +-
 .../config/websession/example-cache-base.xml    |    3 +-
 .../test/config/websession/spring-cache-1.xml   |    6 -
 .../test/config/websession/spring-cache-2.xml   |    6 -
 .../test/config/websession/spring-cache-3.xml   |    6 -
 .../IgniteExternalizableAbstractTest.java       |    2 +-
 ...ndezvousAffinityFunctionSimpleBenchmark.java |   48 +-
 ...dbcPojoStoreOptimizedMarshallerSelfTest.java |    2 +-
 .../apache/ignite/igfs/IgfsPathSelfTest.java    |    2 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |   37 +-
 .../internal/GridLifecycleAwareSelfTest.java    |    2 +-
 .../IgniteClientReconnectCacheTest.java         |   87 +-
 .../internal/TestRecordingCommunicationSpi.java |   16 +-
 ...ryConfigurationCustomSerializerSelfTest.java |  147 ++
 .../managers/GridManagerStopSelfTest.java       |    2 +-
 .../GridCommunicationSendMessageSelfTest.java   |    2 -
 .../GridDiscoveryManagerAttributesSelfTest.java |    2 +-
 .../OptimizedMarshallerEnumSelfTest.java        |   87 +
 .../OptimizedMarshallerNodeFailoverTest.java    |  358 +++
 .../OptimizedMarshallerPooledSelfTest.java      |   46 +
 .../optimized/OptimizedMarshallerSelfTest.java  |  284 +++
 ...arshallerSerialPersistentFieldsSelfTest.java |  116 +
 .../optimized/OptimizedMarshallerTest.java      |  790 +++++++
 .../OptimizedObjectStreamSelfTest.java          | 2162 ++++++++++++++++++
 .../TestTcpDiscoveryIpFinderAdapter.java        |   43 +
 .../CacheAtomicSingleMessageCountSelfTest.java  |    2 -
 .../cache/CacheEnumOperationsAbstractTest.java  |    2 -
 ...CacheExchangeMessageDuplicatedStateTest.java |   41 +-
 ...torPartitionCounterRandomOperationsTest.java |    2 -
 .../CacheStartupInDeploymentModesTest.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/GridCacheConcurrentMapTest.java       |  138 --
 ...idCacheConfigurationConsistencySelfTest.java |   14 -
 .../cache/GridCacheDeploymentSelfTest.java      |    2 +-
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   82 +-
 .../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 +-
 .../GridCachePreloadingEvictionsSelfTest.java   |    3 +-
 ...ridCacheReplicatedSynchronousCommitTest.java |    2 +-
 .../GridCacheReturnValueTransferSelfTest.java   |   15 +-
 ...ridCacheStoreManagerDeserializationTest.java |   12 +-
 .../processors/cache/GridCacheTestEntryEx.java  |    9 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |   10 -
 .../cache/GridCacheVersionMultinodeTest.java    |   40 -
 .../cache/GridCacheVersionSelfTest.java         |    6 +-
 .../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 +
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |   11 +-
 .../IgniteCacheConfigVariationsFullApiTest.java |    6 -
 .../IgniteCacheEntryListenerAbstractTest.java   |    2 +-
 .../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 +-
 .../distributed/CacheAffinityEarlyTest.java     |    2 +-
 ...CacheAtomicNearUpdateTopologyChangeTest.java |    7 -
 .../CacheGetFutureHangsSelfTest.java            |    2 +-
 .../CacheLateAffinityAssignmentTest.java        |    2 -
 ...NearDisabledAtomicInvokeRestartSelfTest.java |    6 -
 ...acheEntrySetIterationPreloadingSelfTest.java |    6 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |   18 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |   11 -
 .../GridCacheTransformEventSelfTest.java        |    2 -
 .../IgniteCacheAtomicNodeJoinTest.java          |    6 -
 ...niteCacheClientNodeChangingTopologyTest.java |   92 +-
 .../IgniteCacheCreatePutMultiNodeSelfTest.java  |    2 +-
 .../distributed/IgniteCacheCreatePutTest.java   |    2 +-
 .../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 -
 .../near/GridCacheNearTxForceKeyTest.java       |    1 -
 ...rtitionedAffinityHashIdResolverSelfTest.java |  102 -
 ...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 -
 .../CacheEntryProcessorNonSerializableTest.java |    2 +-
 .../CacheKeepBinaryIterationTest.java           |    2 -
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   24 +-
 .../GridCacheWriteBehindStoreAbstractTest.java  |    4 +
 ...heWriteBehindStoreMultithreadedSelfTest.java |   88 +-
 .../GridCacheWriteBehindStoreSelfTest.java      |  159 +-
 ...teCacheClientWriteBehindStoreAtomicTest.java |    7 -
 ...ClientWriteBehindStoreNonCoalescingTest.java |  168 ++
 .../transactions/DepthFirstSearchTest.java      |   18 +-
 .../CacheVersionedEntryAbstractTest.java        |   13 -
 .../clock/GridTimeSyncProcessorSelfTest.java    |  224 --
 .../database/FreeListImplSelfTest.java          |    2 +-
 .../IgniteDbMemoryLeakAbstractTest.java         |   14 +-
 .../DataStreamerUpdateAfterLoadTest.java        |   18 +-
 .../igfs/IgfsAbstractBaseSelfTest.java          |   11 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |   33 -
 .../processors/igfs/IgfsFileInfoSelfTest.java   |    2 +-
 ...fsLocalSecondaryFileSystemProxySelfTest.java |    1 -
 .../internal/processors/igfs/IgfsMock.java      |    7 -
 .../processors/igfs/IgfsModesSelfTest.java      |  130 --
 .../processors/igfs/IgfsSizeSelfTest.java       |    5 -
 .../service/ClosureServiceClientsNodesTest.java |    2 +-
 .../GridServiceProcessorAbstractSelfTest.java   |   28 +
 ...ServiceProcessorMultiNodeConfigSelfTest.java |  156 +-
 .../GridServiceProcessorMultiNodeSelfTest.java  |  188 +-
 ...ent2ClassLoadersOptimizedMarshallerTest.java |    2 +-
 ...mentClassLoadingOptimizedMarshallerTest.java |    2 +-
 .../ServicePredicateAccessCacheTest.java        |    4 +-
 .../apache/ignite/lang/GridTupleSelfTest.java   |   35 -
 .../communication/GridIoManagerBenchmark0.java  |    1 -
 ...namicProxySerializationMultiJvmSelfTest.java |    2 +-
 .../GridMarshallerPerformanceTest.java          |    2 +-
 .../OptimizedMarshallerEnumSelfTest.java        |   87 -
 .../OptimizedMarshallerNodeFailoverTest.java    |  357 ---
 .../OptimizedMarshallerPooledSelfTest.java      |   44 -
 .../optimized/OptimizedMarshallerSelfTest.java  |  283 ---
 ...arshallerSerialPersistentFieldsSelfTest.java |  114 -
 .../optimized/OptimizedMarshallerTest.java      |  790 -------
 .../OptimizedObjectStreamSelfTest.java          | 2157 -----------------
 .../TestTcpDiscoveryIpFinderAdapter.java        |   43 -
 .../marshaller/optimized/package-info.java      |   22 -
 .../IgniteMessagingWithClientTest.java          |    2 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |    1 -
 .../TcpCommunicationSpiFaultyClientTest.java    |    1 -
 ...pClientDiscoveryMarshallerCheckSelfTest.java |    2 +-
 .../TcpDiscoveryMarshallerCheckSelfTest.java    |    2 +-
 .../GridInternalTasksLoadBalancingSelfTest.java |   21 +-
 .../configvariations/ConfigVariations.java      |    5 +-
 .../testframework/junits/GridAbstractTest.java  |    2 -
 .../junits/GridTestKernalContext.java           |    1 +
 .../junits/IgniteTestResources.java             |    2 +-
 .../junits/common/GridCommonAbstractTest.java   |   52 +-
 .../multijvm/IgniteCacheProcessProxy.java       |    5 -
 .../multijvm/IgniteClusterProcessProxy.java     |   11 -
 .../testsuites/IgniteBinaryBasicTestSuite.java  |   14 +-
 .../IgniteBinaryObjectsTestSuite.java           |    2 +
 .../IgniteCacheFailoverTestSuite.java           |    4 -
 .../IgniteCacheFailoverTestSuite2.java          |    2 -
 .../IgniteCacheFailoverTestSuite3.java          |    2 -
 ...IgniteCacheFullApiMultiJvmSelfTestSuite.java |   10 -
 .../IgniteCacheFullApiSelfTestSuite.java        |   24 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    6 +-
 .../testsuites/IgniteCacheTestSuite2.java       |    2 -
 .../testsuites/IgniteCacheTestSuite3.java       |    4 -
 .../IgniteCacheWriteBehindTestSuite.java        |    2 +
 .../IgniteMarshallerSelfTestSuite.java          |   14 +-
 .../testsuites/IgniteUtilSelfTestSuite.java     |    2 +
 .../apache/ignite/util/GridIntListSelfTest.java |  153 ++
 .../webapp/META-INF/ignite-webapp-config.xml    |    2 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |    4 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |    9 +-
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |  698 ++----
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |  481 +---
 .../ignite/hadoop/planner/package-info.java     |   22 +
 ...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 +
 .../resources/META-INF/classnames.properties    |    8 -
 .../test/config/hadoop-fs-open-test/grid-0.xml  |    2 +-
 .../test/config/hadoop-fs-open-test/grid-1.xml  |    2 +-
 .../test/config/hadoop-fs-open-test/grid-2.xml  |    2 +-
 .../test/config/igfs-cli-config-dual-async.xml  |    2 +-
 .../test/config/igfs-cli-config-dual-sync.xml   |    2 +-
 .../src/test/config/igfs-cli-config-primary.xml |    2 +-
 .../src/test/config/igfs-cli-config-proxy.xml   |    2 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   26 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |   12 +-
 .../IgniteHadoopFileSystemLoggerSelfTest.java   |   32 +-
 ...condaryFileSystemInitializationSelfTest.java |  213 --
 .../testsuites/IgniteHadoopTestSuite.java       |    3 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |    8 -
 .../CacheHibernateBlobStoreNodeRestartTest.java |    8 -
 .../cache/query/GridCacheTwoStepQuery.java      |   26 +-
 .../query/h2/DmlStatementsProcessor.java        |   49 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  706 ++++--
 .../query/h2/ddl/DdlStatementsProcessor.java    |  208 ++
 .../query/h2/opt/GridH2IndexBase.java           |   33 +-
 .../query/h2/opt/GridH2PrimaryScanIndex.java    |   87 +
 .../query/h2/opt/GridH2SystemIndexFactory.java  |   38 +
 .../processors/query/h2/opt/GridH2Table.java    |  382 ++--
 .../query/h2/opt/GridH2TreeIndex.java           |    2 +-
 .../query/h2/opt/GridLuceneIndex.java           |   10 +-
 .../query/h2/sql/GridSqlCreateIndex.java        |  121 +
 .../query/h2/sql/GridSqlDropIndex.java          |   82 +
 .../query/h2/sql/GridSqlQueryParser.java        |  123 +
 .../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 |   14 +-
 .../cache/IgniteCacheNoClassQuerySelfTest.java  |    2 +-
 ...iteCacheReplicatedFieldsQueryROSelfTest.java |   27 +
 .../cache/index/AbstractSchemaSelfTest.java     |  512 +++++
 .../DynamicIndexAbstractBasicSelfTest.java      |  950 ++++++++
 .../DynamicIndexAbstractConcurrentSelfTest.java |  921 ++++++++
 .../index/DynamicIndexAbstractSelfTest.java     |  467 ++++
 .../index/DynamicIndexClientBasicSelfTest.java  |   28 +
 ...ndexPartitionedAtomicConcurrentSelfTest.java |   33 +
 ...titionedTransactionalConcurrentSelfTest.java |   33 +
 ...IndexReplicatedAtomicConcurrentSelfTest.java |   33 +
 ...plicatedTransactionalConcurrentSelfTest.java |   33 +
 .../index/DynamicIndexServerBasicSelfTest.java  |   28 +
 ...amicIndexServerCoordinatorBasicSelfTest.java |   28 +
 ...namicIndexServerNodeFIlterBasicSelfTest.java |   28 +
 ...erverNodeFilterCoordinatorBasicSelfTest.java |   30 +
 .../index/H2DynamicIndexAbstractSelfTest.java   |  400 ++++
 ...namicIndexAtomicPartitionedNearSelfTest.java |   26 +
 ...H2DynamicIndexAtomicPartitionedSelfTest.java |   39 +
 .../H2DynamicIndexAtomicReplicatedSelfTest.java |   39 +
 ...dexTransactionalPartitionedNearSelfTest.java |   26 +
 ...icIndexTransactionalPartitionedSelfTest.java |   39 +
 ...micIndexTransactionalReplicatedSelfTest.java |   39 +
 .../cache/index/SchemaExchangeSelfTest.java     |  589 +++++
 .../local/IgniteCacheLocalQuerySelfTest.java    |    2 +-
 .../database/IgniteDbMemoryLeakIndexedTest.java |    2 +-
 .../IgniteDbMemoryLeakSqlQueryTest.java         |    2 +-
 .../query/IgniteQueryDedicatedPoolTest.java     |    1 -
 ...gniteSqlSegmentedIndexMultiNodeSelfTest.java |   28 +
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  154 +-
 .../query/IgniteSqlSplitterSelfTest.java        |  127 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  109 +-
 .../query/h2/IgniteSqlQueryMinMaxTest.java      |   16 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |  171 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |    2 +-
 .../query/h2/sql/GridQueryParsingTest.java      |  212 +-
 .../FetchingQueryCursorStressTest.java          |    2 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   43 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |   11 +
 .../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                              |  103 +
 .../java/org/apache/ignite/ml/math/Algebra.java |  571 +++++
 .../org/apache/ignite/ml/math/Constants.java    |   42 +
 .../org/apache/ignite/ml/math/Destroyable.java  |   30 +
 .../ignite/ml/math/IdentityValueMapper.java     |   53 +
 .../org/apache/ignite/ml/math/KeyMapper.java    |   33 +
 .../java/org/apache/ignite/ml/math/Matrix.java  |  518 +++++
 .../apache/ignite/ml/math/MatrixKeyMapper.java  |   30 +
 .../apache/ignite/ml/math/MatrixStorage.java    |   58 +
 .../apache/ignite/ml/math/MetaAttributes.java   |   76 +
 .../org/apache/ignite/ml/math/MurmurHash.java   |  246 ++
 .../apache/ignite/ml/math/StorageConstants.java |   49 +
 .../ignite/ml/math/StorageOpsMetrics.java       |   49 +
 .../java/org/apache/ignite/ml/math/Tracer.java  |  456 ++++
 .../org/apache/ignite/ml/math/ValueMapper.java  |   35 +
 .../java/org/apache/ignite/ml/math/Vector.java  |  498 ++++
 .../apache/ignite/ml/math/VectorKeyMapper.java  |   29 +
 .../apache/ignite/ml/math/VectorStorage.java    |   53 +
 .../decompositions/CholeskyDecomposition.java   |  306 +++
 .../decompositions/DecompositionSupport.java    |  105 +
 .../math/decompositions/EigenDecomposition.java |  923 ++++++++
 .../ml/math/decompositions/LUDecomposition.java |  366 +++
 .../ml/math/decompositions/QRDecomposition.java |  186 ++
 .../SingularValueDecomposition.java             |  620 +++++
 .../ml/math/decompositions/package-info.java    |   22 +
 .../math/exceptions/CardinalityException.java   |   38 +
 .../math/exceptions/ColumnIndexException.java   |   35 +
 .../ml/math/exceptions/IndexException.java      |   35 +
 .../NonPositiveDefiniteMatrixException.java     |   37 +
 .../exceptions/NonSymmetricMatrixException.java |   35 +
 .../ml/math/exceptions/RowIndexException.java   |   35 +
 .../exceptions/SingularMatrixException.java     |   30 +
 .../exceptions/UnknownProviderException.java    |   35 +
 .../UnsupportedOperationException.java          |   44 +
 .../ignite/ml/math/exceptions/package-info.java |   22 +
 .../ignite/ml/math/functions/Functions.java     |  136 ++
 .../ml/math/functions/IgniteBiConsumer.java     |   29 +
 .../ml/math/functions/IgniteBiFunction.java     |   29 +
 .../ml/math/functions/IgniteConsumer.java       |   29 +
 .../ml/math/functions/IgniteDoubleFunction.java |   29 +
 .../ml/math/functions/IgniteFunction.java       |   30 +
 .../math/functions/IntDoubleToVoidFunction.java |   25 +
 .../functions/IntIntDoubleToVoidFunction.java   |   28 +
 .../math/functions/IntIntToDoubleFunction.java  |   24 +
 .../ignite/ml/math/functions/package-info.java  |   22 +
 .../apache/ignite/ml/math/impls/CacheUtils.java |  356 +++
 .../ml/math/impls/matrix/AbstractMatrix.java    |  880 +++++++
 .../ml/math/impls/matrix/CacheMatrix.java       |  158 ++
 .../impls/matrix/DenseLocalOffHeapMatrix.java   |   90 +
 .../impls/matrix/DenseLocalOnHeapMatrix.java    |   86 +
 .../ml/math/impls/matrix/DiagonalMatrix.java    |  101 +
 .../ml/math/impls/matrix/FunctionMatrix.java    |   95 +
 .../ignite/ml/math/impls/matrix/MatrixView.java |   84 +
 .../ml/math/impls/matrix/PivotedMatrixView.java |  243 ++
 .../ml/math/impls/matrix/RandomMatrix.java      |   97 +
 .../impls/matrix/SparseDistributedMatrix.java   |  155 ++
 .../impls/matrix/SparseLocalOnHeapMatrix.java   |   72 +
 .../math/impls/matrix/TransposedMatrixView.java |   84 +
 .../ml/math/impls/matrix/package-info.java      |   22 +
 .../ignite/ml/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  |  290 +++
 .../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 |  149 ++
 .../vector/SparseLocalOnHeapVectorStorage.java  |  152 ++
 .../math/impls/storage/vector/package-info.java |   22 +
 .../impls/vector/AbstractReadOnlyVector.java    |  125 +
 .../ml/math/impls/vector/AbstractVector.java    |  903 ++++++++
 .../ml/math/impls/vector/CacheVector.java       |  140 ++
 .../ml/math/impls/vector/ConstantVector.java    |   84 +
 .../ml/math/impls/vector/DelegatingVector.java  |  391 ++++
 .../impls/vector/DenseLocalOffHeapVector.java   |   89 +
 .../impls/vector/DenseLocalOnHeapVector.java    |  104 +
 .../ml/math/impls/vector/FunctionVector.java    |  112 +
 .../ml/math/impls/vector/MatrixVectorView.java  |  139 ++
 .../ml/math/impls/vector/PivotedVectorView.java |  163 ++
 .../ml/math/impls/vector/RandomVector.java      |  129 ++
 .../math/impls/vector/SingleElementVector.java  |  102 +
 .../impls/vector/SingleElementVectorView.java   |   97 +
 .../impls/vector/SparseLocalOffHeapVector.java  |   47 +
 .../ml/math/impls/vector/SparseLocalVector.java |   71 +
 .../ignite/ml/math/impls/vector/VectorView.java |   85 +
 .../ml/math/impls/vector/package-info.java      |   22 +
 .../org/apache/ignite/ml/math/package-info.java |   22 +
 .../ignite/ml/math/d3-matrix-template.html      |  128 ++
 .../ignite/ml/math/d3-vector-template.html      |  111 +
 .../apache/ignite/ml/math/ExternalizeTest.java  |   66 +
 .../ml/math/MathImplDistributedTestSuite.java   |   39 +
 .../ignite/ml/math/MathImplLocalTestSuite.java  |  123 +
 .../ignite/ml/math/MathImplMainTestSuite.java   |   33 +
 .../org/apache/ignite/ml/math/TracerTest.java   |  195 ++
 .../ignite/ml/math/benchmark/MathBenchmark.java |  205 ++
 .../math/benchmark/MathBenchmarkSelfTest.java   |  100 +
 .../ignite/ml/math/benchmark/ResultsWriter.java |  127 +
 .../ml/math/benchmark/VectorBenchmarkTest.java  |  138 ++
 .../ignite/ml/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/ml/math/impls/MathTestConstants.java |   88 +
 .../ml/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       |  129 ++
 .../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   |  137 ++
 .../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 +++++
 .../ml/math/impls/vector/CacheVectorTest.java   |  434 ++++
 .../vector/ConstantVectorConstructorTest.java   |   52 +
 .../vector/DelegatingVectorConstructorTest.java |   62 +
 .../DenseLocalOffHeapVectorConstructorTest.java |   59 +
 .../DenseLocalOnHeapVectorConstructorTest.java  |  163 ++
 .../vector/FunctionVectorConstructorTest.java   |  121 +
 .../math/impls/vector/MatrixVectorViewTest.java |  226 ++
 .../PivotedVectorViewConstructorTest.java       |  211 ++
 .../vector/RandomVectorConstructorTest.java     |  145 ++
 .../SingleElementVectorConstructorTest.java     |  159 ++
 .../SingleElementVectorViewConstructorTest.java |  137 ++
 .../SparseLocalVectorConstructorTest.java       |   54 +
 .../math/impls/vector/VectorAttributesTest.java |  217 ++
 .../ml/math/impls/vector/VectorFoldMapTest.java |  122 +
 .../vector/VectorImplementationsFixtures.java   |  655 ++++++
 .../impls/vector/VectorImplementationsTest.java |  861 +++++++
 .../math/impls/vector/VectorIterableTest.java   |  376 +++
 .../ml/math/impls/vector/VectorNormTest.java    |  247 ++
 .../math/impls/vector/VectorToMatrixTest.java   |  308 +++
 .../ml/math/impls/vector/VectorViewTest.java    |  162 ++
 .../cpp/core-test/config/cache-test-default.xml |    3 -
 .../platforms/cpp/core-test/src/cache_test.cpp  |   38 +-
 .../Apache.Ignite.Core.Tests.csproj             |   10 +-
 .../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/marshaller-invalid.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        |   38 +-
 .../IgniteStartStopTest.cs                      |   24 +
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |   15 +-
 .../Log/CustomLoggerTest.cs                     |    8 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |   13 +-
 .../Plugin/Cache/CachePlugin.cs                 |  127 -
 .../Plugin/Cache/CachePluginConfiguration.cs    |   64 -
 .../Plugin/Cache/CachePluginTest.cs             |  218 --
 .../Services/ServicesTest.cs                    |    3 +
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |    4 +-
 .../Apache.Ignite.Core.csproj                   |   15 +-
 .../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   |   30 +-
 .../IgniteConfigurationSection.xsd              |   23 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |  101 +-
 .../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    |   30 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |  464 ----
 .../Impl/LifecycleBeanHolder.cs                 |   66 -
 .../Impl/LifecycleHandlerHolder.cs              |   66 +
 .../Impl/Plugin/Cache/CachePluginContext.cs     |   82 -
 .../Impl/Plugin/Cache/CachePluginProcessor.cs   |   77 -
 .../Plugin/Cache/CachePluginProviderProxy.cs    |   75 -
 .../Plugin/Cache/ICachePluginProviderProxy.cs   |   52 -
 .../Impl/Resource/ResourceProcessor.cs          |   10 -
 .../Impl/Resource/ResourceTypeDescriptor.cs     |   12 +-
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |    4 -
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   58 +-
 .../Lifecycle/ILifecycleBean.cs                 |   64 -
 .../Lifecycle/ILifecycleHandler.cs              |   64 +
 .../Lifecycle/LifecycleEventType.cs             |    2 +-
 .../Cache/CachePluginProviderTypeAttribute.cs   |   52 -
 .../Plugin/Cache/ICachePluginConfiguration.cs   |   21 -
 .../Plugin/Cache/ICachePluginContext.cs         |   47 -
 .../Plugin/Cache/ICachePluginProvider.cs        |   52 -
 .../Impl/CacheFieldsQueryProvider.cs            |   24 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |    4 +-
 .../Impl/CacheQueryModelVisitor.cs              |   15 +
 .../Apache.Ignite/Service/IgniteService.cs      |    6 +-
 .../Misc/LifecycleExample.cs                    |   12 +-
 .../http/jetty/GridJettyObjectMapper.java       |  119 +-
 .../config/EnableIgniteRepositories.java        |   10 +-
 .../repository/query/IgniteQueryGenerator.java  |    8 +-
 .../support/IgniteRepositoryFactory.java        |    8 +-
 .../GridSpringBeanSerializationSelfTest.java    |    2 +-
 .../commands/cache/VisorCacheClearCommand.scala |    2 +-
 .../commands/cache/VisorCacheCommand.scala      |  290 ++-
 .../commands/cache/VisorCacheScanCommand.scala  |   19 +-
 .../config/VisorConfigurationCommand.scala      |  183 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |   22 +-
 .../commands/events/VisorEventsCommand.scala    |   30 +-
 .../visor/commands/gc/VisorGcCommand.scala      |    4 +-
 .../commands/tasks/VisorTasksCommand.scala      |   61 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   34 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |    4 +
 .../commands/open/VisorOpenCommandSpec.scala    |    6 +-
 modules/web-console/backend/app/agent.js        |  934 --------
 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      |  523 -----
 .../web-console/backend/app/browsersHandler.js  |  279 +++
 modules/web-console/backend/app/mongo.js        |   36 +-
 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 +-
 .../frontend/app/data/pom-dependencies.json     |    1 +
 .../app/helpers/jade/form/form-field-text.pug   |   55 +-
 .../frontend/app/helpers/jade/mixins.pug        |   26 +-
 .../app/modules/agent/AgentManager.service.js   |  529 +++++
 .../app/modules/agent/AgentModal.service.js     |   89 +
 .../frontend/app/modules/agent/agent.module.js  |  312 +--
 .../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/AbstractTransformer.js            |   10 -
 .../generator/ConfigurationGenerator.js         |   74 +-
 .../generator/JavaTransformer.service.js        |    3 +
 .../generator/PlatformGenerator.js              |   11 +-
 .../defaults/Cache.platform.service.js          |    9 -
 .../generator/defaults/Cache.service.js         |   13 +-
 .../generator/defaults/Cluster.service.js       |    9 +-
 .../generator/defaults/IGFS.service.js          |    5 +-
 .../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  |  101 +-
 .../frontend/app/modules/states/admin.state.js  |    4 +-
 .../app/modules/states/configuration.state.js   |   17 +-
 .../states/configuration/caches/affinity.pug    |    2 +-
 .../states/configuration/caches/concurrency.pug |   11 -
 .../states/configuration/caches/general.pug     |   25 +
 .../states/configuration/caches/memory.pug      |   64 +-
 .../states/configuration/caches/query.pug       |    3 +
 .../states/configuration/clusters/events.pug    |    6 +-
 .../states/configuration/clusters/general.pug   |    3 +
 .../clusters/general/discovery/kubernetes.pug   |   37 +
 .../configuration/clusters/marshaller.pug       |    6 -
 .../states/configuration/clusters/swap.pug      |   72 -
 .../states/configuration/clusters/time.pug      |   10 +-
 .../modules/states/configuration/igfs/dual.pug  |   42 -
 .../modules/states/configuration/igfs/misc.pug  |    4 +-
 .../configuration/summary/summary.controller.js |    3 +
 .../configuration/summary/summary.worker.js     |   22 +
 .../app/modules/states/profile.state.js         |    2 +-
 .../frontend/app/modules/user/Auth.service.js   |    6 +-
 .../frontend/app/primitives/btn-group/index.pug |   35 +
 .../frontend/app/services/Confirm.service.js    |    2 +-
 .../app/services/ConfirmBatch.service.js        |    1 -
 .../frontend/controllers/caches-controller.js   |   31 +-
 .../frontend/controllers/clusters-controller.js |   41 +-
 .../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 +-
 .../views/configuration/clusters.tpl.pug        |    1 -
 .../views/configuration/domains-import.tpl.pug  |    2 +-
 .../views/configuration/domains.tpl.pug         |    1 -
 .../frontend/views/configuration/igfs.tpl.pug   |    1 -
 .../frontend/views/includes/header.pug          |   23 +-
 .../web-console/frontend/views/sql/sql.tpl.pug  |   12 +-
 .../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   |  177 +-
 .../ignite/console/demo/AgentDemoUtils.java     |    2 +-
 .../demo/service/DemoCachesLoadService.java     |   35 +-
 .../src/main/resources/log4j.properties         |    1 -
 .../webapp2/META-INF/ignite-webapp-config.xml   |    2 +-
 modules/yardstick/README.txt                    |    1 -
 modules/yardstick/config/ignite-base-config.xml |   25 +-
 .../ignite-int-max-values-onheap-config.xml     |    2 +-
 modules/yardstick/config/ignite-jdbc-config.xml |    2 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   15 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    3 -
 pom.xml                                         |   36 +
 1128 files changed, 69715 insertions(+), 28278 deletions(-)
----------------------------------------------------------------------