You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vo...@apache.org on 2019/03/19 07:30:00 UTC

[ignite] branch ignite-11564 created (now b7f563a)

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

vozerov pushed a change to branch ignite-11564
in repository https://gitbox.apache.org/repos/asf/ignite.git.


      at b7f563a  Merge branch 'master' into ignite-10161

This branch includes the following new commits:

     new e091770  Merge branch 'master' into ignite-10161
     new 0ea7630  Merge branch 'master' into ignite-10161
     new 8b84603  Merge branch 'master' into ignite-10161
     new 7090a40  Merge remote-tracking branch 'upstream/ignite-10161' into ignite-10161
     new b7f563a  Merge branch 'master' into ignite-10161

The 5 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.



[ignite] 02/05: Merge branch 'master' into ignite-10161

Posted by vo...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 0ea763059098e1eecba796bd90687e5f63cf27fb
Merge: 8ffd36b 08f8b4e
Author: Yury Gerzhedovich <yg...@gridgain.com>
AuthorDate: Fri Mar 15 12:34:38 2019 +0300

    Merge branch 'master' into ignite-10161

 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |   2 +
 .../thin/JdbcThinStreamingResetStreamTest.java     | 142 +++++++
 .../org/apache/ignite/internal/IgniteKernal.java   |   8 +-
 .../ignite/internal/commandline/Arguments.java     |  25 +-
 .../internal/commandline/CommandHandler.java       | 407 +++++++--------------
 .../commandline/baseline/AutoAdjustCommandArg.java |  50 +++
 .../commandline/baseline/BaselineArguments.java    | 165 +++++++++
 .../commandline/baseline/BaselineCommand.java      | 103 ++++++
 .../internal/jdbc/thin/JdbcThinConnection.java     |   5 +-
 .../cache/persistence/file/FilePageStore.java      |   2 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |  11 +-
 .../cluster/BaselineConfigurationMXBeanImpl.java   |  69 ++++
 .../processors/cluster/ClusterProcessor.java       |  16 +-
 .../autoadjust/BaselineAutoAdjustData.java         |  45 ++-
 .../autoadjust/BaselineAutoAdjustExecutor.java     |   2 +
 .../autoadjust/BaselineAutoAdjustScheduler.java    |  17 +-
 .../autoadjust/BaselineAutoAdjustStatistic.java    |  90 +++++
 .../baseline/autoadjust/ChangeTopologyWatcher.java |  24 +-
 .../odbc/jdbc/JdbcBatchExecuteRequest.java         |   2 +-
 .../odbc/jdbc/JdbcBatchExecuteResult.java          |   2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteRequest.java  |   2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteResult.java   |   2 +-
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |   2 +-
 .../odbc/jdbc/JdbcQueryExecuteResult.java          |   2 +-
 .../internal/processors/odbc/jdbc/JdbcRequest.java |   6 +
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |  29 +-
 .../internal/processors/odbc/jdbc/JdbcResult.java  |   6 +
 .../processors/odbc/odbc/OdbcRequestHandler.java   |  19 +-
 .../processors/query/QueryHistoryMetrics.java      |  15 +-
 .../processors/query/QueryHistoryMetricsValue.java |  10 +-
 .../processors/query/SqlClientContext.java         |  25 +-
 .../processors/service/IgniteServiceProcessor.java |   8 +-
 .../baseline/VisorBaselineAutoAdjustSettings.java  |  30 +-
 .../internal/visor/baseline/VisorBaselineTask.java |  19 +-
 .../visor/baseline/VisorBaselineTaskResult.java    |  39 +-
 .../visor/baseline/VisorBaselineViewTask.java      |   7 +-
 .../ignite/mxbean/BaselineConfigurationMXBean.java |  45 +++
 .../commandline/CommandHandlerParsingTest.java     |   4 +-
 .../db/checkpoint/CheckpointFreeListTest.java      |   7 +-
 .../IgniteCacheContinuousQueryBackupQueueTest.java |   7 +-
 .../cluster/BaselineConfigurationMXBeanTest.java   |  84 +++++
 ...ServiceHotRedeploymentViaDeploymentSpiTest.java | 161 ++++++++
 .../apache/ignite/testframework/GridTestUtils.java |  38 ++
 .../ignite/testsuites/IgniteBasicTestSuite.java    |   2 +
 .../testsuites/IgniteServiceGridTestSuite.java     |   2 +
 .../apache/ignite/util/GridCommandHandlerTest.java |  46 ++-
 .../processors/query/h2/IgniteH2Indexing.java      |   3 +
 .../processors/query/h2/SchemaManager.java         |   2 +
 .../sys/view/SqlSystemViewQueryHistoryMetrics.java |  92 +++++
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |  36 +-
 .../processors/query/LocalQueryLazyTest.java       | 108 ++++++
 .../processors/query/SqlQueryHistorySelfTest.java  |   2 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  92 ++++-
 .../processors/query/oom/AbstractQueryOOMTest.java |  69 ++--
 .../IgniteBinaryCacheQueryTestSuite2.java          |   3 +
 .../cpp/odbc/src/streaming/streaming_context.cpp   |   2 +
 56 files changed, 1746 insertions(+), 467 deletions(-)



[ignite] 05/05: Merge branch 'master' into ignite-10161

Posted by vo...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit b7f563ae81b3ee5a34398ef5f3a18e20338cc60d
Merge: 7090a40 4e95bb4
Author: devozerov <vo...@gridgain.com>
AuthorDate: Tue Mar 19 10:21:05 2019 +0300

    Merge branch 'master' into ignite-10161

 .../internal/jdbc2/JdbcDefaultNoOpCacheTest.java   |  33 --
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |   1 -
 .../cache/IgniteCacheOffheapManagerImpl.java       | 132 +++---
 .../processors/cache/mvcc/MvccProcessorImpl.java   |  41 +-
 .../cache/persistence/pagemem/PageMemoryImpl.java  |   2 +-
 .../processors/query/GridQueryProcessor.java       |  37 +-
 .../ignite/cache/NodeWithFilterRestartTest.java    |   6 +-
 .../GridHistoryAffinityAssignmentTest.java         |   6 -
 ...istoryAffinityAssignmentTestNoOptimization.java |   3 -
 .../processors/cache/CacheNamesSelfTest.java       |  85 ----
 .../cache/CacheNamesWithSpecialCharactersTest.java |  74 ----
 .../GridCacheConfigurationValidationSelfTest.java  |  64 ++-
 .../IgniteClientCacheInitializationFailTest.java   |   2 +-
 .../IgnitePdsBinarySortObjectFieldsTest.java       | 123 +++---
 .../IgnitePdsSporadicDataRecordsOnBackupTest.java  | 491 ++++++++++-----------
 .../ClientAffinityAssignmentWithBaselineTest.java  |   4 +
 .../db/checkpoint/CheckpointFreeListTest.java      |   3 -
 .../wal/ExplicitWalDeltaConsistencyTest.java       |   2 -
 .../PageMemoryTrackerPluginProvider.java           |   6 +-
 .../IgniteCacheContinuousQueryClientTest.java      |   6 +
 .../cluster/ChangeTopologyWatcherTest.java         |   5 +-
 .../spi/ExponentialBackoffTimeoutStrategyTest.java |   3 -
 .../TcpCommunicationSpiFaultyClientSslTest.java    |   3 -
 .../tcp/TcpCommunicationSpiFreezingClientTest.java |   3 -
 .../tcp/TcpDiscoveryCoordinatorFailureTest.java    |   3 -
 .../testsuites/IgniteCacheMvccTestSuite1.java      |   4 -
 .../ignite/testsuites/IgniteCacheTestSuite.java    |   4 -
 .../cache/index/H2DynamicTableSelfTest.java        |   2 +-
 .../mvcc/CacheMvccContinuousQueryClientTest.java   |   9 -
 .../mvcc/MvccDeadlockDetectionConfigTest.java      |   3 -
 .../processors/query/SqlSystemViewsSelfTest.java   |  20 +-
 .../twostep/AbstractPartitionPruningBaseTest.java  |   3 -
 .../twostep/DmlSelectPartitionPruningSelfTest.java |   6 +-
 .../twostep/MvccDmlPartitionPruningSelfTest.java   |   3 -
 .../processors/query/oom/AbstractQueryOOMTest.java |   3 -
 .../oom/QueryOOMWithQueryParallelismTest.java      |   4 -
 .../oom/QueryOOMWithoutQueryParallelismTest.java   |   4 -
 .../components/modal-import-models/component.js    |   5 +-
 38 files changed, 532 insertions(+), 676 deletions(-)


[ignite] 03/05: Merge branch 'master' into ignite-10161

Posted by vo...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 8b846035944093d198639e85465f544d352d78bd
Merge: 0ea7630 eb3a9aa
Author: Yury Gerzhedovich <yg...@gridgain.com>
AuthorDate: Mon Mar 18 12:00:03 2019 +0300

    Merge branch 'master' into ignite-10161

 examples/README.md                                 |   8 +-
 examples/pom-standalone-lgpl.xml                   |  44 +++++
 examples/pom-standalone.xml                        |   1 -
 .../tcp/redis/RedisProtocolGetAllAsArrayTest.java  |  17 +-
 .../cache/binary/BinaryMetadataTransport.java      |  28 ++-
 .../binary/CacheObjectBinaryProcessorImpl.java     |  67 ++++---
 .../cache/persistence/GridCacheOffheapManager.java |   9 +
 .../cache/persistence/file/FileDownloader.java     | 166 +++++++++++-------
 .../cache/persistence/file/FilePageStore.java      |   2 +-
 .../cache/persistence/file/FileUploader.java       |  40 ++---
 .../affinity/AffinityDistributionLoggingTest.java  |  37 +---
 .../cache/affinity/AffinityHistoryCleanupTest.java | 138 +++++++--------
 .../failure/FailureHandlingConfigurationTest.java  |  54 ++----
 .../ConsistentIdImplicitlyExplicitlyTest.java      |  18 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |  23 +--
 .../ignite/internal/GridVersionSelfTest.java       |  11 +-
 .../ignite/internal/IgniteClientRejoinTest.java    |  14 +-
 .../IgniteDiscoveryMassiveNodeFailTest.java        |  19 +-
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |  20 +--
 .../BinaryConfigurationConsistencySelfTest.java    |  28 ++-
 .../IgniteTxConcurrentRemoveObjectsTest.java       |  24 +--
 .../cache/persistence/file/FileDownloaderTest.java |  15 +-
 .../apache/ignite/testframework/GridTestUtils.java |  37 ----
 .../testframework/junits/GridAbstractTest.java     |  68 +++++++-
 .../junits/SystemPropertiesList.java}              |  28 ++-
 .../testframework/junits/WithSystemProperty.java}  |  31 ++--
 modules/dev-utils/ignite-modules-test/README.md    |  16 ++
 modules/dev-utils/ignite-modules-test/build.gradle | 139 +++++++++++++++
 .../src/test/java/module-info.java}                |  26 +--
 .../modulestest/IgniteLaunchInModularEnvTest.java  |  97 +++++++++++
 .../cache/BinaryTypeRegistrationTest.java          | 194 +++++++++++++++++++++
 .../cache/StartCachesInParallelTest.java           |  43 ++---
 ...tributedPartitionQueryNodeRestartsSelfTest.java |  22 +--
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |  27 ++-
 .../index/DynamicIndexAbstractBasicSelfTest.java   |  67 +++----
 .../persistence/db/wal/IgniteWalRecoveryTest.java  | 140 ++++++++-------
 .../transaction/DmlInsideTransactionTest.java      |  26 ++-
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |   8 +-
 .../IgnitePersistentStoreSchemaLoadTest.java       |   6 +-
 .../DisappearedCacheCauseRetryMessageSelfTest.java |   4 +-
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |   4 +-
 .../twostep/NonCollocatedRetryMessageSelfTest.java |  17 +-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |   4 +-
 .../IgniteCacheWithIndexingTestSuite.java          |   3 +
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java     |   5 +-
 ...erDiscoveryConcurrentStartAndStartStopTest.java |  13 +-
 ...coverySegmentationAndConnectionRestoreTest.java | 108 ++++++------
 .../ZookeeperDiscoverySpiSaslFailedAuthTest.java   |  13 +-
 ...ookeeperDiscoverySpiSaslSuccessfulAuthTest.java |   8 +-
 49 files changed, 1145 insertions(+), 792 deletions(-)


[ignite] 01/05: Merge branch 'master' into ignite-10161

Posted by vo...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit e091770cd26dd9a53990ef6161b4fb3d0b0565ba
Merge: 8ffd36b 42633b5
Author: devozerov <vo...@gridgain.com>
AuthorDate: Thu Mar 14 12:46:02 2019 +0300

    Merge branch 'master' into ignite-10161

 .../jdbc/suite/IgniteJdbcDriverTestSuite.java      |   2 +
 .../thin/JdbcThinStreamingResetStreamTest.java     | 142 +++++++
 .../org/apache/ignite/internal/IgniteKernal.java   |   8 +-
 .../ignite/internal/commandline/Arguments.java     |  25 +-
 .../internal/commandline/CommandHandler.java       | 407 +++++++--------------
 .../commandline/baseline/AutoAdjustCommandArg.java |  50 +++
 .../commandline/baseline/BaselineArguments.java    | 165 +++++++++
 .../commandline/baseline/BaselineCommand.java      | 103 ++++++
 .../internal/jdbc/thin/JdbcThinConnection.java     |   5 +-
 .../cache/persistence/file/FilePageStore.java      |   2 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |  11 +-
 .../cluster/BaselineConfigurationMXBeanImpl.java   |  69 ++++
 .../processors/cluster/ClusterProcessor.java       |  16 +-
 .../autoadjust/BaselineAutoAdjustData.java         |  45 ++-
 .../autoadjust/BaselineAutoAdjustExecutor.java     |   2 +
 .../autoadjust/BaselineAutoAdjustScheduler.java    |  17 +-
 .../autoadjust/BaselineAutoAdjustStatistic.java    |  90 +++++
 .../baseline/autoadjust/ChangeTopologyWatcher.java |  24 +-
 .../odbc/jdbc/JdbcBatchExecuteRequest.java         |   2 +-
 .../odbc/jdbc/JdbcBatchExecuteResult.java          |   2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteRequest.java  |   2 +-
 .../odbc/jdbc/JdbcOrderedBatchExecuteResult.java   |   2 +-
 .../odbc/jdbc/JdbcQueryExecuteRequest.java         |   2 +-
 .../odbc/jdbc/JdbcQueryExecuteResult.java          |   2 +-
 .../internal/processors/odbc/jdbc/JdbcRequest.java |   6 +
 .../processors/odbc/jdbc/JdbcRequestHandler.java   |  29 +-
 .../internal/processors/odbc/jdbc/JdbcResult.java  |   6 +
 .../processors/odbc/odbc/OdbcRequestHandler.java   |  19 +-
 .../processors/query/SqlClientContext.java         |  25 +-
 .../processors/service/IgniteServiceProcessor.java |   8 +-
 .../baseline/VisorBaselineAutoAdjustSettings.java  |  30 +-
 .../internal/visor/baseline/VisorBaselineTask.java |  19 +-
 .../visor/baseline/VisorBaselineTaskResult.java    |  39 +-
 .../visor/baseline/VisorBaselineViewTask.java      |   7 +-
 .../ignite/mxbean/BaselineConfigurationMXBean.java |  45 +++
 .../commandline/CommandHandlerParsingTest.java     |   4 +-
 .../db/checkpoint/CheckpointFreeListTest.java      |   7 +-
 .../IgniteCacheContinuousQueryBackupQueueTest.java |   7 +-
 .../cluster/BaselineConfigurationMXBeanTest.java   |  84 +++++
 ...ServiceHotRedeploymentViaDeploymentSpiTest.java | 161 ++++++++
 .../ignite/testsuites/IgniteBasicTestSuite.java    |   2 +
 .../testsuites/IgniteServiceGridTestSuite.java     |   2 +
 .../apache/ignite/util/GridCommandHandlerTest.java |  46 ++-
 .../mvcc/CacheMvccBasicContinuousQueryTest.java    |  36 +-
 .../processors/query/oom/AbstractQueryOOMTest.java |  69 ++--
 .../cpp/odbc/src/streaming/streaming_context.cpp   |   2 +
 46 files changed, 1397 insertions(+), 451 deletions(-)


[ignite] 04/05: Merge remote-tracking branch 'upstream/ignite-10161' into ignite-10161

Posted by vo...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

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

commit 7090a4020a4f767a96303a18b4c0a6d77edc8c02
Merge: e091770 8b84603
Author: devozerov <vo...@gridgain.com>
AuthorDate: Tue Mar 19 10:20:42 2019 +0300

    Merge remote-tracking branch 'upstream/ignite-10161' into ignite-10161

 examples/README.md                                 |   8 +-
 examples/pom-standalone-lgpl.xml                   |  44 +++++
 examples/pom-standalone.xml                        |   1 -
 .../tcp/redis/RedisProtocolGetAllAsArrayTest.java  |  17 +-
 .../cache/binary/BinaryMetadataTransport.java      |  28 ++-
 .../binary/CacheObjectBinaryProcessorImpl.java     |  67 ++++---
 .../cache/persistence/GridCacheOffheapManager.java |   9 +
 .../cache/persistence/file/FileDownloader.java     | 166 +++++++++++-------
 .../cache/persistence/file/FilePageStore.java      |   2 +-
 .../cache/persistence/file/FileUploader.java       |  40 ++---
 .../processors/query/QueryHistoryMetrics.java      |  15 +-
 .../processors/query/QueryHistoryMetricsValue.java |  10 +-
 .../affinity/AffinityDistributionLoggingTest.java  |  37 +---
 .../cache/affinity/AffinityHistoryCleanupTest.java | 138 +++++++--------
 .../failure/FailureHandlingConfigurationTest.java  |  54 ++----
 .../ConsistentIdImplicitlyExplicitlyTest.java      |  18 +-
 ...dCachePartitionExchangeManagerHistSizeTest.java |  23 +--
 .../ignite/internal/GridVersionSelfTest.java       |  11 +-
 .../ignite/internal/IgniteClientRejoinTest.java    |  14 +-
 .../IgniteDiscoveryMassiveNodeFailTest.java        |  19 +-
 ...iteUpdateNotifierPerClusterSettingSelfTest.java |  20 +--
 .../BinaryConfigurationConsistencySelfTest.java    |  28 ++-
 .../IgniteTxConcurrentRemoveObjectsTest.java       |  24 +--
 .../cache/persistence/file/FileDownloaderTest.java |  15 +-
 .../apache/ignite/testframework/GridTestUtils.java |  75 ++++----
 .../testframework/junits/GridAbstractTest.java     |  68 +++++++-
 .../junits/SystemPropertiesList.java}              |  28 ++-
 .../testframework/junits/WithSystemProperty.java}  |  31 ++--
 modules/dev-utils/ignite-modules-test/README.md    |  16 ++
 modules/dev-utils/ignite-modules-test/build.gradle | 139 +++++++++++++++
 .../src/test/java/module-info.java}                |  26 +--
 .../modulestest/IgniteLaunchInModularEnvTest.java  |  97 +++++++++++
 .../processors/query/h2/IgniteH2Indexing.java      |   3 +
 .../processors/query/h2/SchemaManager.java         |   2 +
 .../sys/view/SqlSystemViewQueryHistoryMetrics.java |  92 ++++++++++
 .../cache/BinaryTypeRegistrationTest.java          | 194 +++++++++++++++++++++
 .../cache/StartCachesInParallelTest.java           |  43 ++---
 ...tributedPartitionQueryNodeRestartsSelfTest.java |  22 +--
 ...cheQueryNodeRestartDistributedJoinSelfTest.java |  27 ++-
 .../index/DynamicIndexAbstractBasicSelfTest.java   |  67 +++----
 .../persistence/db/wal/IgniteWalRecoveryTest.java  | 140 ++++++++-------
 .../transaction/DmlInsideTransactionTest.java      |  26 ++-
 ...tStoreQueryWithMultipleClassesPerCacheTest.java |   8 +-
 .../IgnitePersistentStoreSchemaLoadTest.java       |   6 +-
 .../processors/query/LocalQueryLazyTest.java       | 108 ++++++++++++
 .../processors/query/SqlQueryHistorySelfTest.java  |   2 +-
 .../processors/query/SqlSystemViewsSelfTest.java   |  92 +++++++++-
 .../DisappearedCacheCauseRetryMessageSelfTest.java |   4 +-
 ...DisappearedCacheWasNotFoundMessageSelfTest.java |   4 +-
 .../twostep/NonCollocatedRetryMessageSelfTest.java |  17 +-
 .../h2/twostep/RetryCauseMessageSelfTest.java      |   4 +-
 .../IgniteBinaryCacheQueryTestSuite2.java          |   3 +
 .../IgniteCacheWithIndexingTestSuite.java          |   3 +
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java     |   5 +-
 ...erDiscoveryConcurrentStartAndStartStopTest.java |  13 +-
 ...coverySegmentationAndConnectionRestoreTest.java | 108 ++++++------
 .../ZookeeperDiscoverySpiSaslFailedAuthTest.java   |  13 +-
 ...ookeeperDiscoverySpiSaslSuccessfulAuthTest.java |   8 +-
 58 files changed, 1494 insertions(+), 808 deletions(-)