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 2019/03/01 09:46:30 UTC

[ignite] 02/02: Merge remote-tracking branch 'remotes/origin/master' into ignite-invokeAll

This is an automated email from the ASF dual-hosted git repository.

sboikov pushed a commit to branch ignite-invokeAll
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit 0529ee08c70efe6da97ab3222de457a94791968d
Merge: 2eddbf8 efc6b96
Author: sboikov <sb...@apache.org>
AuthorDate: Fri Mar 1 12:39:18 2019 +0300

    Merge remote-tracking branch 'remotes/origin/master' into ignite-invokeAll

 assembly/release-apache-ignite-base.xml            |     5 +
 bin/control.sh                                     |    40 +-
 bin/ignite-tf.sh                                   |    24 +-
 bin/ignitevisorcmd.sh                              |    12 +-
 bin/include/parseargs.sh                           |     2 +-
 .../ml/clustering/GmmClusterizationExample.java    |   107 +
 .../spark/LogRegFromSparkThroughPMMLExample.java   |    15 +-
 .../modelparser/DecisionTreeFromSparkExample.java  |     9 +-
 .../spark/modelparser/GBTFromSparkExample.java     |     9 +-
 .../spark/modelparser/LogRegFromSparkExample.java  |     9 +-
 .../modelparser/RandomForestFromSparkExample.java  |     9 +-
 .../spark/modelparser/SVMFromSparkExample.java     |     9 +-
 .../examples/ml/knn/KNNClassificationExample.java  |     7 +-
 .../examples/ml/knn/KNNRegressionExample.java      |    59 +-
 .../DiscreteNaiveBayesTrainerExample.java          |     7 +-
 .../GaussianNaiveBayesTrainerExample.java          |     7 +-
 .../linear/LinearRegressionLSQRTrainerExample.java |    35 +-
 ...gressionLSQRTrainerWithMinMaxScalerExample.java |    33 +-
 .../linear/LinearRegressionSGDTrainerExample.java  |    39 +-
 .../BaggedLogisticRegressionSGDTrainerExample.java |    11 +-
 .../LogisticRegressionSGDTrainerExample.java       |     7 +-
 .../ml/selection/cv/CrossValidationExample.java    |    13 +-
 .../ml/selection/scoring/EvaluatorExample.java     |    11 +-
 .../selection/scoring/MultipleMetricsExample.java  |     9 +-
 .../scoring/RegressionMetricExample.java}          |    66 +-
 .../ml/svm/SVMBinaryClassificationExample.java     |     7 +-
 .../ml/tutorial/Step_10_Scaling_With_Stacking.java |    11 +-
 .../ml/tutorial/Step_1_Read_and_Learn.java         |    11 +-
 .../examples/ml/tutorial/Step_2_Imputing.java      |    11 +-
 .../examples/ml/tutorial/Step_3_Categorial.java    |    11 +-
 .../Step_3_Categorial_with_One_Hot_Encoder.java    |    11 +-
 .../examples/ml/tutorial/Step_4_Add_age_fare.java  |    11 +-
 .../examples/ml/tutorial/Step_5_Scaling.java       |    11 +-
 .../ml/tutorial/Step_5_Scaling_with_Pipeline.java  |    11 +-
 .../ignite/examples/ml/tutorial/Step_6_KNN.java    |    11 +-
 .../ml/tutorial/Step_7_Split_train_test.java       |    11 +-
 .../ignite/examples/ml/tutorial/Step_8_CV.java     |    13 +-
 .../ml/tutorial/Step_8_CV_with_Param_Grid.java     |    13 +-
 .../Step_8_CV_with_Param_Grid_and_metrics.java     |    19 +-
 .../examples/ml/tutorial/Step_9_Go_to_LogReg.java  |    13 +-
 .../rest/JettyRestProcessorAbstractSelfTest.java   |    79 +
 ...stProcessorAuthenticationWithTokenSelfTest.java |    34 +-
 .../rest/JettyRestProcessorBaselineSelfTest.java   |    10 +
 .../jdbc/thin/JdbcThinStatementCancelSelfTest.java |     4 +-
 .../org/apache/ignite/IgniteSystemProperties.java  |    28 +-
 .../ignite/cache/query/QueryRetryException.java}   |    24 +-
 .../apache/ignite/cache/query/SqlFieldsQuery.java  |     8 +-
 .../ignite/configuration/IgniteConfiguration.java  |    77 -
 .../org/apache/ignite/internal/GridComponent.java  |     3 +
 .../org/apache/ignite/internal/IgniteFeatures.java |    28 +-
 .../org/apache/ignite/internal/IgniteKernal.java   |     9 +-
 .../ignite/internal/MarshallerContextImpl.java     |    29 +-
 .../main/java/org/apache/ignite/internal/README.md |    12 +-
 .../internal/UnregisteredBinaryTypeException.java  |    59 +-
 .../internal/binary/BinaryClassDescriptor.java     |     8 +-
 .../ignite/internal/binary/BinaryContext.java      |    12 +-
 .../internal/binary/BinaryFieldAccessor.java       |     6 +-
 .../binary/builder/BinaryObjectBuilderImpl.java    |     2 +-
 .../internal/client/thin/TcpIgniteClient.java      |    15 +-
 .../cluster/DistributedBaselineConfiguration.java  |    76 +-
 .../ignite/internal/cluster/IgniteClusterImpl.java |    21 +-
 .../ignite/internal/commandline/Command.java       |     5 +-
 .../internal/commandline/CommandHandler.java       |   124 +-
 .../optimized/OptimizedMarshallerUtils.java        |     2 +-
 .../optimized/OptimizedObjectOutputStream.java     |     2 +-
 .../pagemem/impl/PageMemoryNoStoreImpl.java        |    29 +
 .../processors/affinity/GridAffinityProcessor.java |    70 +-
 .../cache/CacheAffinitySharedManager.java          |   695 +-
 .../processors/cache/CacheGroupContext.java        |    27 +-
 .../processors/cache/CacheMetricsSnapshot.java     |    49 +-
 .../ClientCacheChangeDummyDiscoveryMessage.java    |     6 +-
 .../internal/processors/cache/ExchangeContext.java |     4 +-
 .../processors/cache/GridCacheEventManager.java    |     2 +-
 .../processors/cache/GridCacheIoManager.java       |     4 +
 .../processors/cache/GridCacheMapEntry.java        |    16 +-
 .../cache/GridCachePartitionExchangeManager.java   |   174 +-
 .../processors/cache/GridCacheProcessor.java       |    83 +-
 .../processors/cache/IgniteCacheProxyImpl.java     |    14 +-
 .../ignite/internal/processors/cache/README.md     |     3 +
 .../binary/CacheObjectBinaryProcessorImpl.java     |    11 +-
 .../cache/distributed/dht/GridDhtLockFuture.java   |    73 +-
 .../dht/GridDhtTopologyFutureAdapter.java          |     8 +
 .../dht/GridDhtTransactionalCacheAdapter.java      |     6 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java    |     8 +-
 .../dht/GridPartitionedSingleGetFuture.java        |     4 +-
 .../distributed/dht/atomic/GridDhtAtomicCache.java |    17 +-
 .../dht/colocated/GridDhtColocatedCache.java       |     4 +-
 .../dht/colocated/GridDhtColocatedLockFuture.java  |    73 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |   109 +-
 .../preloader/GridDhtPartitionsFullMessage.java    |    10 +-
 .../dht/topology/GridClientPartitionTopology.java  |    14 +
 .../dht/topology/GridDhtPartitionTopology.java     |     5 +
 .../dht/topology/GridDhtPartitionTopologyImpl.java |     9 +
 .../cache/distributed/near/GridNearTxLocal.java    |     4 +-
 .../near/GridNearTxQueryEnlistFuture.java          |     2 +-
 .../internal/processors/cache/mvcc/MvccUtils.java  |    19 +-
 .../processors/cache/mvcc/txlog/TxLog.java         |    14 +-
 .../cache/persistence/CheckpointFuture.java        |     7 +-
 .../CheckpointWriteProgressSupplier.java           |     6 +-
 .../cache/persistence/DbCheckpointListener.java    |     8 +
 .../GridCacheDatabaseSharedManager.java            |   387 +-
 .../cache/persistence/GridCacheOffheapManager.java |    33 +-
 .../cache/persistence/freelist/PagesList.java      |   143 +-
 .../cache/persistence/metastorage/MetaStorage.java |     5 +
 .../pagemem/CheckpointMetricsTracker.java          |    24 +
 .../cache/persistence/pagemem/PageMemoryImpl.java  |    42 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |    98 +-
 .../cache/query/GridCacheQueryAdapter.java         |     2 +-
 .../continuous/CacheContinuousQueryHandler.java    |     2 +-
 .../continuous/CacheContinuousQueryHandlerV3.java  |     1 -
 .../continuous/CacheContinuousQueryManager.java    |     5 -
 .../cache/transactions/IgniteTxManager.java        |    24 +
 .../cache/verify/VerifyBackupPartitionsTaskV2.java |     4 +
 .../cluster/BaselineAdjustForbiddenException.java} |    21 +-
 .../cluster/ChangeGlobalStateFinishMessage.java    |     5 +-
 .../cluster/ChangeGlobalStateMessage.java          |     4 +-
 .../processors/cluster/ClusterProcessor.java       |    10 +-
 .../cluster/GridClusterStateProcessor.java         |    27 +-
 .../autoadjust/BaselineAutoAdjustData.java         |    75 +
 .../autoadjust/BaselineAutoAdjustExecutor.java     |    84 +
 .../autoadjust/BaselineAutoAdjustScheduler.java    |    63 +
 .../baseline/autoadjust/ChangeTopologyWatcher.java |   126 +
 .../distributed/DistributedBooleanProperty.java    |     2 +-
 .../DistributedConfigurationProcessor.java         |     4 +-
 .../distributed/DistributedLongProperty.java       |     2 +-
 .../distributed/DistributedProperty.java           |    47 +-
 ...erty.java => NotWritablePropertyException.java} |    22 +-
 .../distributed/PropertyUpdateClosure.java}        |    22 +-
 .../metastorage/DistributedMetaStorage.java        |    26 +
 .../DistributedMetaStorageCasAckMessage.java       |     5 +-
 .../DistributedMetaStorageCasMessage.java          |     2 +-
 .../persistence/DistributedMetaStorageImpl.java    |   234 +-
 .../DistributedMetaStorageUpdateAckMessage.java    |    10 +-
 .../DistributedMetaStorageUpdateMessage.java       |    12 +-
 .../processors/odbc/ClientListenerProcessor.java   |     4 +-
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |     8 +-
 .../processors/odbc/odbc/OdbcRequestHandler.java   |     7 +-
 .../platform/binary/PlatformBinaryProcessor.java   |     2 +-
 .../processors/platform/cache/PlatformCache.java   |    33 +
 .../binary/ClientBinaryTypeNamePutRequest.java     |     3 +-
 .../platform/utils/PlatformConfigurationUtils.java |    12 -
 .../processors/query/GridQueryProcessor.java       |   118 +-
 .../h2/twostep/messages/GridQueryFailResponse.java |    12 +-
 .../internal/processors/rest/GridRestCommand.java  |     8 +-
 .../processors/rest/GridRestProcessor.java         |     4 +
 .../memory/MemoryMetricsCommandHandler.java        |    80 +
 .../sql/optimizer/affinity/PartitionResult.java    |    44 +
 .../apache/ignite/internal/util/IgniteUtils.java   |    55 +-
 .../util/lang/IgniteThrowableConsumer.java         |     9 +-
 ...iConsumer.java => IgniteThrowableFunction.java} |    17 +-
 .../internal/util/nio/GridCommunicationClient.java |     2 +-
 .../ignite/internal/util/nio/GridDirectParser.java |     6 +-
 .../util/nio/GridNioAsyncNotifyFilter.java         |     3 +-
 .../internal/util/nio/GridNioCodecFilter.java      |     3 +-
 .../internal/util/nio/GridNioDelimitedBuffer.java  |     2 +-
 .../internal/util/nio/GridNioEmbeddedFuture.java   |    20 +-
 .../internal/util/nio/GridNioMessageTracker.java   |     2 +-
 .../util/nio/GridNioRecoveryDescriptor.java        |     2 +-
 .../ignite/internal/util/nio/GridNioServer.java    |    36 +-
 .../internal/util/nio/GridNioSessionImpl.java      |     2 +-
 .../util/nio/GridSelectorNioSessionImpl.java       |     2 +-
 .../util/nio/GridShmemCommunicationClient.java     |     3 +-
 .../util/nio/GridTcpNioCommunicationClient.java    |     2 +-
 .../internal/util/nio/SelectedSelectionKeySet.java |     5 +-
 .../ignite/internal/util/nio/package-info.java     |     3 +-
 .../internal/util/nio/ssl/BlockingSslHandler.java  |    11 +-
 .../internal/util/nio/ssl/GridNioSslFilter.java    |     5 +-
 .../internal/util/nio/ssl/GridNioSslHandler.java   |    14 +-
 .../ignite/internal/util/nio/ssl/package-info.java |     3 +-
 .../baseline/VisorBaselineAutoAdjustSettings.java  |    72 +
 .../visor/baseline/VisorBaselineOperation.java     |     4 +-
 .../internal/visor/baseline/VisorBaselineTask.java |    35 +-
 .../visor/baseline/VisorBaselineTaskArg.java       |    29 +-
 .../visor/baseline/VisorBaselineTaskResult.java    |    24 +-
 .../visor/baseline/VisorBaselineViewTask.java      |     8 +-
 .../ignite/marshaller/MarshallerContext.java       |    26 +-
 .../spi/communication/tcp/TcpCommunicationSpi.java |    22 +-
 .../ignite/spi/discovery/DiscoverySpiMBean.java    |     8 +
 .../ignite/spi/discovery/tcp/ClientImpl.java       |     5 +
 .../ignite/spi/discovery/tcp/ServerImpl.java       |   158 +-
 .../ignite/spi/discovery/tcp/TcpDiscoveryImpl.java |     5 +-
 .../ignite/spi/discovery/tcp/TcpDiscoverySpi.java  |    66 +-
 .../tcp/internal/DiscoveryDataPacket.java          |    54 +-
 .../discovery/tcp/internal/TcpDiscoveryNode.java   |    23 +-
 .../tcp/messages/TcpDiscoveryAbstractMessage.java  |     3 +
 .../messages/TcpDiscoveryCustomEventMessage.java   |    18 +
 .../messages/TcpDiscoveryHandshakeResponse.java    |    14 +
 .../org/apache/ignite/thread/IgniteThread.java     |     9 +
 .../ignite/cache/NodeWithFilterRestartTest.java    |   152 +
 .../ClusterBaselineNodesMetricsSelfTest.java       |    16 +
 ...dCachePartitionExchangeManagerWarningsTest.java |   329 +
 .../internal/binary/BinaryMarshallerSelfTest.java  |     4 +-
 .../GridBinaryMarshallerCtxDisabledSelfTest.java   |     6 +-
 .../managers/IgniteDiagnosticMessagesTest.java     |   106 +
 ...tadataRegistrationInsideEntryProcessorTest.java |   118 +
 .../cache/GridCacheEntryMemorySizeSelfTest.java    |     6 +-
 ...usterActivateDeactivateTestWithPersistence.java |    15 +
 ...teDynamicCacheStartFailWithPersistenceTest.java |     6 +
 .../distributed/CacheBaselineTopologyTest.java     |    15 +
 .../CacheDataLossOnPartitionMoveTest.java          |    15 +
 .../distributed/CacheRentingStateRepairTest.java   |    15 +
 .../GridCacheRebalancingWithAsyncClearingTest.java |    16 +
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |     6 +-
 .../processors/cache/mvcc/CacheMvccVacuumTest.java |    15 +
 ...niteBaselineAffinityTopologyActivationTest.java |    15 +
 .../persistence/IgnitePdsCorruptedIndexTest.java   |    16 +
 .../IgnitePdsPartitionFilesDestroyTest.java        |    15 +
 ...gniteRebalanceScheduleResendPartitionsTest.java |    15 +
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |     5 +
 .../ClientAffinityAssignmentWithBaselineTest.java  |    15 +
 .../IgniteAbsentEvictionNodeOutOfBaselineTest.java |    11 +
 ...hangingBaselineDownCachePutAllFailoverTest.java |     6 +
 ...hangingBaselineDownCacheRemoveFailoverTest.java |     5 +
 ...eChangingBaselineUpCachePutAllFailoverTest.java |     6 +
 ...eChangingBaselineUpCacheRemoveFailoverTest.java |     5 +
 .../persistence/db/IgniteLogicalRecoveryTest.java  |    16 +
 ...IgnitePdsCacheWalDisabledOnRebalancingTest.java |    15 +
 .../db/IgnitePdsDataRegionMetricsTest.java         |    14 +
 .../cache/persistence/db/IgnitePdsWithTtlTest.java |    16 +
 .../SlowHistoricalRebalanceSmallHistoryTest.java   |    16 +
 .../db/checkpoint/CheckpointFreeListTest.java      |   344 +
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |    16 +
 .../persistence/db/wal/WalCompactionTest.java      |    16 +
 .../pagemem/IgniteThrottlingUnitTest.java          |    10 +-
 .../pagemem/PagesWriteThrottleSandboxTest.java     |    45 +-
 .../wal/memtracker/PageMemoryTracker.java          |     4 +
 .../GridCacheContinuousQueryAbstractSelfTest.java  |   175 +
 .../TxRollbackOnTimeoutOnePhaseCommitTest.java     |     2 +-
 .../cluster/ChangeTopologyWatcherTest.java         |   350 +
 ...a => DistributedConfigurationAbstractTest.java} |    69 +-
 .../DistributedConfigurationInMemoryTest.java}     |    12 +-
 .../DistributedConfigurationPersistentTest.java}   |    12 +-
 .../metastorage/DistributedMetaStorageTest.java    |     6 +-
 .../service/IgniteServiceReassignmentTest.java     |    16 +
 .../ServiceDeploymentOutsideBaselineTest.java      |    18 +
 .../ignite/internal/util/IgniteUtilsSelfTest.java  |    10 +-
 .../marshaller/MarshallerContextTestImpl.java      |     2 +-
 ...rMetricsSnapshotSerializeCompatibilityTest.java |    90 +
 .../discovery/tcp/TcpDiscoveryFailedJoinTest.java  |   209 +
 .../discovery/tcp/TcpDiscoverySpiMBeanTest.java    |    97 +
 .../apache/ignite/testframework/GridTestUtils.java |     3 +-
 .../junits/JUnit3TestLegacySupport.java            |    16 +-
 ...TestLegacyAssert.java => JUnitAssertAware.java} |   186 +-
 .../common/GridRollingRestartAbstractTest.java     |     2 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java    |     2 +
 .../ignite/testsuites/IgniteCacheTestSuite5.java   |     3 +
 .../testsuites/IgniteKernalSelfTestSuite.java      |     5 +
 .../ignite/testsuites/IgnitePdsTestSuite.java      |     2 +
 .../ignite/testsuites/IgnitePdsTestSuite2.java     |     3 +
 .../ignite/testsuites/IgnitePdsUnitTestSuite.java  |     1 -
 .../IgniteSpiDiscoverySelfTestSuite.java           |     3 +
 .../ignite/testsuites/IgniteUtilSelfTestSuite.java |     2 +
 .../apache/ignite/util/GridCommandHandlerTest.java |   133 +
 .../query/h2/H2IndexesSystemViewTest.java          |   108 +
 .../query/h2/H2IndexingAbstractGeoSelfTest.java    |    39 -
 .../testsuites/GeoSpatialIndexingTestSuite.java    |     4 +-
 .../cache/query/GridCacheTwoStepQuery.java         |    22 +-
 .../processors/query/h2/CommandProcessor.java      |    18 +-
 .../processors/query/h2/ConnectionManager.java     |    73 +-
 .../processors/query/h2/H2CachedStatementKey.java  |    13 +-
 .../processors/query/h2/H2ConnectionWrapper.java   |     5 +-
 .../processors/query/h2/H2FieldsIterator.java      |     5 +-
 .../processors/query/h2/H2TableDescriptor.java     |     6 +
 .../internal/processors/query/h2/H2Utils.java      |   148 +-
 .../processors/query/h2/IgniteH2Indexing.java      |   769 +-
 .../processors/query/h2/PreparedStatementEx.java   |    48 -
 .../query/h2/PreparedStatementExImpl.java          |   648 -
 .../internal/processors/query/h2/QueryParser.java  |   354 +-
 .../processors/query/h2/QueryParserResult.java     |     8 +
 .../processors/query/h2/QueryParserResultDml.java  |    64 +-
 .../query/h2/QueryParserResultSelect.java          |    84 +-
 .../processors/query/h2/SchemaManager.java         |     2 +
 .../processors/query/h2/database/H2IndexType.java} |    20 +-
 .../query/h2/database/H2PkHashIndex.java           |    21 +-
 .../processors/query/h2/database/H2Tree.java       |     2 +-
 .../query/h2/database/H2TreeClientIndex.java       |    36 +-
 .../processors/query/h2/database/H2TreeIndex.java  |   127 +-
 .../query/h2/database/H2TreeIndexBase.java         |    90 +
 .../query/h2/database/IndexInformation.java        |   106 +
 .../query/h2/dml/DmlDistributedPlanInfo.java       |    17 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |   202 +-
 .../query/h2/opt/GridH2RowDescriptor.java          |     9 +
 .../processors/query/h2/opt/GridH2Table.java       |   253 +-
 .../processors/query/h2/opt/H2TableScanIndex.java  |     2 +-
 .../processors/query/h2/opt/QueryContext.java      |    21 -
 .../query/h2/opt/QueryContextRegistry.java         |     7 +-
 .../query/h2/opt/join/DistributedJoinContext.java  |    22 +-
 .../query/h2/opt/join/DistributedLookupBatch.java  |    88 +-
 .../query/h2/sql/GridSqlCreateTable.java           |    18 +
 .../query/h2/sql/GridSqlQueryParser.java           |    74 +-
 .../query/h2/sql/GridSqlQuerySplitter.java         |   113 +-
 .../processors/query/h2/sql/SplitterUtils.java     |    40 +-
 .../h2/sys/view/SqlAbstractLocalSystemView.java    |    14 -
 .../query/h2/sys/view/SqlSystemViewIndexes.java    |   124 +
 .../h2/sys/view/SqlSystemViewNodeMetrics.java      |    44 +-
 .../query/h2/twostep/GridMapQueryExecutor.java     |   560 +-
 .../query/h2/twostep/GridReduceQueryExecutor.java  |    98 +-
 .../query/h2/twostep/MapNodeResults.java           |    12 +-
 .../query/h2/twostep/MapQueryLazyWorker.java       |   200 -
 .../query/h2/twostep/MapQueryLazyWorkerKey.java    |    97 -
 .../query/h2/twostep/MapQueryResult.java           |   200 +-
 .../query/h2/twostep/MapQueryResults.java          |   137 +-
 .../query/h2/twostep/PartitionReservation.java     |    17 +-
 .../h2/twostep/PartitionReservationManager.java    |    18 +-
 .../query/h2/twostep/ReduceResultPage.java         |    22 +-
 .../query/h2/twostep/msg/GridH2QueryRequest.java   |    11 +-
 .../visor/verify/ValidateIndexesClosure.java       |     4 +
 .../apache/ignite/client/FunctionalQueryTest.java  |    71 +-
 .../GridCacheLazyQueryPartitionsReleaseTest.java   |     2 -
 ...tributedQueryStopOnCancelOrTimeoutSelfTest.java |    46 +-
 ...eCacheQueryAbstractDistributedJoinSelfTest.java |     5 +
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |    16 +-
 ...opOnCancelOrTimeoutDistributedJoinSelfTest.java |    26 +-
 .../DynamicColumnsAbstractConcurrentSelfTest.java  |    28 +-
 .../cache/index/DynamicIndexAbstractSelfTest.java  |    37 +-
 .../cache/index/H2ConnectionLeaksSelfTest.java     |     2 +-
 .../cache/index/H2DynamicTableSelfTest.java        |    87 +-
 .../cache/index/H2RowExpireTimeIndexSelfTest.java  |   230 +
 ...niteCacheLocalQueryCancelOrTimeoutSelfTest.java |     3 +-
 ...xingMultithreadedLoadContinuousRestartTest.java |   282 +
 .../IgnitePersistentStoreSchemaLoadTest.java       |     5 +
 ...ngingBaselineCacheQueryNodeRestartSelfTest.java |     6 +
 ...actQueryTableLockAndConnectionPoolSelfTest.java |   854 ++
 .../query/IgniteQueryDedicatedPoolTest.java        |     1 -
 ...TableLockAndConnectionPoolLazyModeOffTest.java} |    16 +-
 ...yTableLockAndConnectionPoolLazyModeOnTest.java} |    13 +-
 .../query/IgniteSqlSegmentedIndexSelfTest.java     |   107 +-
 .../processors/query/LazyQuerySelfTest.java        |   392 -
 .../processors/query/RunningQueriesTest.java       |    50 -
 .../processors/query/SqlSystemViewsSelfTest.java   |   316 +-
 .../query/h2/H2StatementCacheSelfTest.java         |    86 -
 .../query/h2/PreparedStatementExSelfTest.java      |    64 -
 .../processors/query/h2/QueryDataPageScanTest.java |     2 +-
 .../query/h2/sql/BaseH2CompareQueryTest.java       |     5 +-
 .../query/h2/sql/ParameterTypeInferenceTest.java   |   196 +
 .../DisappearedCacheCauseRetryMessageSelfTest.java |    15 +-
 .../h2/twostep/JoinPartitionPruningSelfTest.java   |     5 +-
 .../twostep/MvccDmlPartitionPruningSelfTest.java   |   255 +
 .../h2/twostep/RetryCauseMessageSelfTest.java      |    26 -
 .../processors/query/oom/AbstractQueryOOMTest.java |   429 +
 .../query/oom/IgniteQueryOOMTestSuite.java}        |    13 +-
 .../oom/QueryOOMWithQueryParallelismTest.java}     |    15 +-
 .../oom/QueryOOMWithoutQueryParallelismTest.java}  |    15 +-
 .../IgniteBinaryCacheQueryTestSuite.java           |    18 +-
 .../testsuites/IgnitePdsWithIndexingTestSuite.java |     4 +-
 .../IgniteBinaryCacheQueryLazyTestSuite.java}      |    22 +-
 .../IgniteBinaryCacheQueryLazyTestSuite2.java}     |    22 +-
 .../ml/sparkmodelparser/SparkModelParser.java      |    57 +-
 .../ml/sparkmodelparser/SupportedSparkModels.java  |    36 +-
 .../ml/sparkmodelparser/SparkModelParserTest.java  |    24 +-
 .../ignite/ml/clustering/gmm/GmmPartitionData.java |    45 +-
 .../ignite/ml/clustering/gmm/GmmTrainer.java       |   219 +-
 .../gmm/MeanWithClusterProbAggregator.java         |    13 +-
 .../gmm/NewComponentStatisticsAggregator.java      |   169 +
 .../DefaultLearningEnvironmentBuilder.java         |     2 +-
 .../vector/impl/DelegatingNamedVector.java         |     8 +-
 .../ignite/ml/math/stat/DistributionMixture.java   |     5 +-
 .../stat/MultivariateGaussianDistribution.java     |    11 +
 .../org/apache/ignite/ml/math/util/MatrixUtil.java |    15 +-
 .../java/org/apache/ignite/ml/nn/MLPTrainer.java   |    16 +-
 .../logistic/LogisticRegressionSGDTrainer.java     |     8 +-
 ...ClassificationEvaluator.java => Evaluator.java} |    11 +-
 .../metric/{Accuracy.java => AbstractMetrics.java} |    51 +-
 .../metric/{ClassMetric.java => MetricValues.java} |    30 +-
 .../metric/{ => classification}/Accuracy.java      |     6 +-
 .../BinaryClassificationMetricValues.java          |    20 +-
 .../BinaryClassificationMetrics.java               |    30 +-
 .../metric/{ => classification}/ClassMetric.java   |     4 +-
 .../metric/{ => classification}/Fmeasure.java      |     5 +-
 .../metric/{ => classification}/Precision.java     |     5 +-
 .../metric/{ => classification}/Recall.java        |     5 +-
 .../metric/classification}/package-info.java       |     4 +-
 .../UnknownClassLabelException.java                |     2 +-
 .../scoring/metric/exceptions}/package-info.java   |     4 +-
 .../metric/regression/RegressionMetricValues.java  |    71 +
 .../metric/regression/RegressionMetrics.java       |    66 +
 .../scoring/metric/regression}/package-info.java   |     4 +-
 .../ml/trainers/AdaptableDatasetTrainer.java       |    16 +-
 .../primitives/vector/VectorGeneratorsFamily.java  |     6 +-
 .../test/java/org/apache/ignite/ml/TestUtils.java  |    28 +-
 .../ignite/ml/clustering/ClusteringTestSuite.java  |     4 +-
 .../gmm/MeanWithClusterProbAggregatorTest.java     |     2 +-
 .../gmm/NewComponentStatisticsAggregatorTest.java  |   147 +
 .../ml/composition/CompositionTestSuite.java       |     1 +
 .../ml/composition/{ => bagging}/BaggingTest.java  |    35 +-
 .../ignite/ml/selection/SelectionTestSuite.java    |     9 +-
 .../ml/selection/cv/CrossValidationTest.java       |    15 +-
 .../BinaryClassificationEvaluatorTest.java         |    13 +-
 .../selection/scoring/evaluator/EvaluatorTest.java |    21 +-
 .../scoring/evaluator/RegressionEvaluatorTest.java |   131 +
 .../metric/{ => classification}/AccuracyTest.java  |     6 +-
 .../BinaryClassificationMetricsTest.java           |    14 +-
 .../BinaryClassificationMetricsValuesTest.java     |     2 +-
 .../metric/{ => classification}/FmeasureTest.java  |     5 +-
 .../metric/{ => classification}/PrecisionTest.java |     5 +-
 .../metric/{ => classification}/RecallTest.java    |     5 +-
 .../metric/regression/RegressionMetricsTest.java   |   103 +
 .../data/impurity/MSEHistogramTest.java            |     9 +-
 .../ExpiryCacheHolderTest.cs                       |    30 +
 .../Common/TestUtils.DotNetCore.cs                 |     1 +
 .../ApiParity/CacheParityTest.cs                   |     3 -
 .../Cache/CacheAbstractTest.cs                     |    49 +-
 .../Cache/CacheTestAsyncWrapper.cs                 |    38 +-
 .../Cache/DataRegionMetricsTest.cs                 |     4 +-
 .../Cache/PersistenceTest.cs                       |     4 +
 .../Cache/Query/CacheQueriesTest.cs                |     6 +-
 .../Query/CacheQueriesWithRestartServerTest.cs     |     2 +-
 .../Cache/Store/CacheStoreTest.cs                  |     2 +
 .../Client/Cache/SqlQueryTest.cs                   |     4 +-
 .../IgniteConfigurationTest.cs                     |     4 -
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs      |    53 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs      |    60 -
 .../IgniteConfigurationSection.xsd                 |    15 -
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs     |   109 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs       |     5 +-
 .../Impl/Unmanaged/Jni/ConsoleWriter.cs            |    44 +
 .../nodejs/spec/query/SqlFieldsQuery.spec.js       |    23 +-
 modules/platforms/php/tests/SqlFieldsQueryTest.php |    32 +-
 .../protocols/http/jetty/GridJettyRestHandler.java |     2 +
 modules/sqlline/bin/sqlline.bat                    |    51 +-
 modules/sqlline/bin/sqlline.sh                     |    51 +-
 modules/tools/pom.xml                              |    53 +
 .../ignite/tools/javadoc/IgniteLinkTaglet.java     |    65 +-
 .../ignite/tools/javadoc/IgniteLinkTaglet.java     |     0
 modules/web-console/backend/app/agentSocket.js     |    23 -
 modules/web-console/backend/app/agentsHandler.js   |    13 +-
 modules/web-console/backend/app/browsersHandler.js |     9 +-
 modules/web-console/backend/app/schemas.js         |     2 +-
 .../1547440382485-account-make-email-unique.js     |    85 +
 modules/web-console/frontend/.gitignore            |     1 +
 modules/web-console/frontend/app/app.js            |    17 +-
 .../frontend/app/browserUpdate/style.scss          |     2 +-
 .../frontend/app/components/breadcrumbs/style.scss |     1 -
 .../app/components/bs-select-menu/style.scss       |     1 -
 .../app/components/cluster-selector/style.scss     |     1 -
 .../components/global-progress-line/controller.ts  |    24 +-
 .../{component.js => component.ts}                 |    27 +-
 .../{index.js => index.ts}                         |     0
 .../list-editable-add-item-button/style.scss       |     1 -
 .../{directive.js => directive.ts}                 |    31 +-
 .../list-editable-one-way/{index.js => index.ts}   |     0
 .../{directives.js => directives.ts}               |    25 +-
 .../{index.js => index.ts}                         |     0
 .../{directive.js => directive.ts}                 |    27 +-
 .../{index.js => index.ts}                         |     0
 .../list-editable/{controller.js => controller.ts} |    85 +-
 .../list-editable/{index.js => index.ts}           |     0
 .../app/components/list-editable/template.pug      |    14 +-
 .../app/components/page-landing/style.scss         |     1 -
 .../components/ignite-information/information.scss |     2 -
 .../components/queries-notebook/controller.ts      |     6 +-
 .../app/components/panel-collapsible/style.scss    |     1 -
 .../permanent-notifications/controller.ts          |     4 +-
 .../permanent-notifications/template.pug           |     2 +-
 .../app/components/timed-redirection/controller.ts |    16 +-
 .../frontend/app/components/ui-grid/style.scss     |     1 -
 .../components/web-console-footer/controller.ts    |     7 +-
 .../components/demo-mode-button/controller.ts      |    31 +-
 .../components/user-menu/controller.ts             |     5 +-
 .../web-console-header-content/controller.ts       |     3 +-
 .../app/components/web-console-header/style.scss   |     1 -
 .../components/web-console-sidebar/controller.ts   |     7 +-
 .../web-console-sidebar-navigation/controller.ts   |     6 +-
 .../web-console-sidebar-overflow/controller.ts     |    11 +-
 .../components/modal-preview-project/style.scss    |     1 +
 .../page-configure-advanced/controller.ts          |     2 +-
 .../components/page-configure-advanced/style.scss  |    38 +-
 .../configuration/services/ConfigChangesGuard.ts   |     2 +-
 .../app/configuration/services/ConfigureState.ts   |     2 +-
 .../app/modules/agent/AgentManager.service.js      |     8 +-
 .../frontend/app/modules/user/user.module.js       |     2 +-
 .../frontend/app/primitives/badge/index.scss       |     1 -
 .../frontend/app/primitives/btn/index.scss         |     1 -
 .../frontend/app/primitives/form-field/index.scss  |     1 -
 .../frontend/app/primitives/modal/index.scss       |     3 -
 .../frontend/app/primitives/page/index.scss        |     1 -
 .../frontend/app/primitives/panel/index.scss       |     2 -
 .../frontend/app/primitives/table/index.scss       |     1 -
 .../frontend/app/primitives/tabs/index.scss        |     1 -
 .../frontend/app/primitives/tooltip/index.scss     |     2 -
 .../app/primitives/ui-grid-settings/index.scss     |     1 -
 .../frontend/app/primitives/ui-grid/index.scss     |     1 -
 .../web-console/frontend/app/store/effects/ui.ts   |     2 +-
 modules/web-console/frontend/app/vendor.js         |     1 -
 modules/web-console/frontend/package-lock.json     | 14251 +++++++++++++++++++
 modules/web-console/frontend/package.json          |     7 +-
 .../public/stylesheets/_bootstrap-variables.scss   |     4 +-
 .../frontend/public/stylesheets/style.scss         |     8 +-
 modules/web-console/frontend/views/index.pug       |     3 +-
 .../console/agent/handlers/RestListener.java       |     3 +
 .../benchmark-native-sql-select-join.properties    |     6 +-
 .../config/benchmark-native-sql-select.properties  |     6 +-
 .../apache/ignite/yardstick/jdbc/JdbcUtils.java    |    62 +-
 .../jdbc/NativeSqlJoinQueryRangeBenchmark.java     |    80 +-
 .../spi/discovery/zk/ZookeeperDiscoverySpi.java    |    21 +
 .../zk/internal/ZookeeperDiscoveryImpl.java        |     2 +-
 .../zk/ZookeeperDiscoverySpiTestSuite1.java        |     2 +
 .../ZookeeperDiscoveryClientDisconnectTest.java    |   158 +-
 .../ZookeeperDiscoveryClientReconnectTest.java     |   192 +
 parent/pom.xml                                     |    68 +-
 500 files changed, 28877 insertions(+), 6412 deletions(-)