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/01/28 08:28:06 UTC

[ignite] 03/03: ignite-627

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

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

commit fc8941e1f804a5bb81ccbcddef2e5f39d1c1f6fd
Merge: 7bfafda f2c58ab
Author: sboikov <sb...@apache.org>
AuthorDate: Mon Jan 28 11:27:48 2019 +0300

    ignite-627

 .../modelparser/RandomForestFromSparkExample.java  |  85 +++++
 .../models/spark/serialized/rf/data/._SUCCESS.crc  | Bin 0 -> 8 bytes
 ...-411c-8811-c3205434f5fc-c000.snappy.parquet.crc | Bin 0 -> 1256 bytes
 .../models/spark/serialized/rf/data/_SUCCESS       |   0
 ...bc1b-411c-8811-c3205434f5fc-c000.snappy.parquet | Bin 0 -> 159358 bytes
 .../spark/serialized/rf/metadata/._SUCCESS.crc     | Bin 0 -> 8 bytes
 .../spark/serialized/rf/metadata/.part-00000.crc   | Bin 0 -> 16 bytes
 .../models/spark/serialized/rf/metadata/_SUCCESS   |   0
 .../models/spark/serialized/rf/metadata/part-00000 |   1 +
 .../serialized/rf/treesMetadata/._SUCCESS.crc      | Bin 0 -> 8 bytes
 ...-4f5a-b7fc-043c9ab56e1d-c000.snappy.parquet.crc | Bin 0 -> 148 bytes
 .../spark/serialized/rf/treesMetadata/_SUCCESS     |   0
 ...3d4b-4f5a-b7fc-043c9ab56e1d-c000.snappy.parquet | Bin 0 -> 17636 bytes
 .../client/ClientReconnectionSelfTest.java         |   2 +-
 .../internal/client/ClientSslParametersTest.java   |  14 +-
 .../jdbc/thin/JdbcThinStatementSelfTest.java       |   4 +-
 ...dbcThinTransactionsAbstractComplexSelfTest.java |  11 +-
 .../cloud/TcpDiscoveryCloudIpFinderSelfTest.java   |   2 +-
 .../internal/jdbc/thin/JdbcThinConnection.java     |   3 +-
 .../cache/GridCacheSharedTtlCleanupManager.java    |   9 +-
 .../persistence/file/FilePageStoreManager.java     |   6 +-
 .../verify/VerifyBackupPartitionsDumpTask.java     |   4 +-
 .../ignite/cache/ResetLostPartitionTest.java       |   4 +-
 .../ignite/failure/IoomFailureHandlerTest.java     |   4 +-
 .../AuthenticationProcessorNodeRestartTest.java    |   2 +-
 .../cache/CacheConnectionLeakStoreTxTest.java      |   7 +-
 .../cache/CacheEventWithTxLabelTest.java           |   4 +-
 ...InterceptorPartitionCounterLocalSanityTest.java |   7 +-
 ...ceptorPartitionCounterRandomOperationsTest.java |   5 +-
 .../processors/cache/CacheMetricsManageTest.java   |   7 +-
 .../cache/CacheMvccTxFastFinishTest.java           |  13 +-
 .../processors/cache/CacheRemoveAllSelfTest.java   |   4 +-
 .../cache/CacheSerializableTransactionsTest.java   |   3 +
 .../EntryVersionConsistencyReadThroughTest.java    |   9 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java    |  10 +-
 .../cache/GridCacheAbstractIteratorsSelfTest.java  |  16 +-
 .../cache/GridCacheClearAllSelfTest.java           |   4 +-
 .../GridCacheMixedPartitionExchangeSelfTest.java   |   4 +-
 ...ultinodeUpdateNearEnabledNoBackupsSelfTest.java |   8 +-
 ...ridCacheMultinodeUpdateNearEnabledSelfTest.java |   8 +-
 .../GridCacheMvccMultiThreadedUpdateSelfTest.java  |   4 +-
 .../cache/GridCachePartitionedGetSelfTest.java     |   4 +-
 .../GridCacheReturnValueTransferSelfTest.java      |   7 +-
 .../GridCacheValueConsistencyAbstractSelfTest.java |   1 +
 .../cache/GridCacheVariableTopologySelfTest.java   |   4 +-
 .../processors/cache/IgniteCacheGroupsTest.java    |  34 +-
 ...IgniteCacheInvokeReadThroughSingleNodeTest.java |  13 +-
 .../cache/IgniteCacheInvokeReadThroughTest.java    |  16 +-
 .../cache/IgniteClusterActivateDeactivateTest.java |   7 +-
 ...usterActivateDeactivateTestWithPersistence.java |  10 +-
 ...eactivateTestWithPersistenceAndMemoryReuse.java |  10 +-
 ...teDynamicCacheStartFailWithPersistenceTest.java |   4 +-
 .../IgniteMvccTxSingleThreadedAbstractTest.java    |   7 +-
 .../cache/IgnitePdsDataRegionMetricsTxTest.java    |   4 +-
 .../IgniteTopologyValidatorGridSplitCacheTest.java |   4 +-
 .../cache/IgniteTxConfigCacheSelfTest.java         |   4 +-
 .../cache/IgniteTxExceptionAbstractSelfTest.java   |  10 +-
 .../cache/WalModeChangeAdvancedSelfTest.java       |   2 +-
 .../binary/CacheKeepBinaryWithInterceptorTest.java |   4 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java    |   4 +-
 ...dCachePartitionedAtomicSetFailoverSelfTest.java |   4 +-
 .../GridCachePartitionedSetFailoverSelfTest.java   |   4 +-
 .../CacheAsyncOperationsFailoverAbstractTest.java  |   4 +-
 .../cache/distributed/CacheBlockOnGetAllTest.java  |  97 ++++--
 .../cache/distributed/CacheBlockOnScanTest.java    |  13 +-
 .../distributed/CacheBlockOnSingleGetTest.java     |  97 ++++--
 .../CacheDataLossOnPartitionMoveTest.java          |   4 +-
 .../cache/distributed/CacheExchangeMergeTest.java  |   4 +-
 .../CacheGetInsideLockChangingTopologyTest.java    |   4 +-
 .../CacheLateAffinityAssignmentTest.java           |   7 +-
 .../CacheLoadingConcurrentGridStartSelfTest.java   |   4 +-
 .../distributed/GridCacheBasicOpAbstractTest.java  |   4 +-
 .../GridCachePartitionNotLoadedEventSelfTest.java  |   4 +-
 .../GridCachePreloadRestartAbstractSelfTest.java   |   4 +-
 .../GridCacheTransformEventSelfTest.java           |  10 +-
 ...niteCacheGroupsPartitionLossPolicySelfTest.java |   4 +-
 .../IgniteCachePartitionLossPolicySelfTest.java    |  18 +-
 .../distributed/IgniteCacheReadFromBackupTest.java |  13 +-
 .../IgniteCacheSingleGetMessageTest.java           |   4 +-
 .../IgniteCacheSystemTransactionsSelfTest.java     |   4 +-
 .../IgniteMvccTxTimeoutAbstractTest.java           |   4 +-
 ...WriteSynchronizationModesMultithreadedTest.java |   4 +-
 .../IgniteTxRemoveTimeoutObjectsTest.java          |   4 +-
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java     |   7 +-
 ...idCachePartitionedNearDisabledLockSelfTest.java |   4 +-
 ...achePartitionedNearDisabledMetricsSelfTest.java |   4 +-
 .../GridCachePartitionsStateValidationTest.java    |   4 +-
 .../dht/GridCacheTxNodeFailureSelfTest.java        |   4 +-
 .../IgniteAtomicLongChangingTopologySelfTest.java  |   4 +-
 .../dht/IgniteCacheClearDuringRebalanceTest.java   |   4 +-
 .../dht/NotMappedPartitionInTxTest.java            |   7 +-
 .../near/GridPartitionedBackupLoadSelfTest.java    |   4 +-
 .../GridCacheRebalancingSyncSelfTest.java          |   7 +-
 ...dCacheRebalancingWithAsyncClearingMvccTest.java |  15 +-
 ...eRebalanceOnCachesStoppingOrDestroyingTest.java |   7 +-
 .../GridCacheReplicatedLockSelfTest.java           |   4 +-
 .../GridCacheSyncReplicatedPreloadSelfTest.java    |   4 +-
 .../replicated/GridReplicatedTxPreloadTest.java    |   4 +-
 .../GridCacheReplicatedPreloadSelfTest.java        |   4 +-
 .../eviction/paged/PageEvictionMetricTest.java     |   4 +-
 .../PageEvictionPagesRecyclingAndReusingTest.java  |  11 +-
 .../paged/PageEvictionReadThroughTest.java         |  15 +-
 .../eviction/paged/PageEvictionTouchOrderTest.java |  13 +-
 .../PageEvictionWithRebalanceAbstractTest.java     |   4 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java       |   4 +-
 ...heAtomicNearEnabledMultiJvmFullApiSelfTest.java |   4 +-
 .../cache/mvcc/CacheMvccTransactionsTest.java      |  11 +-
 .../cache/mvcc/CacheMvccTxFailoverTest.java        |   4 +-
 .../IgnitePdsCacheAssignmentNodeRestartsTest.java  |   4 +-
 .../IgnitePdsContinuousRestartTest.java            |   7 +-
 .../IgnitePdsPartitionFilesDestroyTest.java        |   4 +-
 .../IgnitePdsPartitionsStateRecoveryTest.java      |   4 +-
 ...gniteRebalanceScheduleResendPartitionsTest.java |   4 +-
 ...ocalWalModeChangeDuringRebalancingSelfTest.java |  19 +-
 .../ClientAffinityAssignmentWithBaselineTest.java  |   4 +-
 .../persistence/db/IgniteLogicalRecoveryTest.java  |   4 +-
 ...itePdsPageEvictionDuringPartitionClearTest.java |   4 +-
 .../db/IgnitePdsPartitionPreloadTest.java          |   7 +-
 ...gnitePdsRebalancingOnNotStableTopologyTest.java |   4 +-
 .../db/IgnitePdsReserveWalSegmentsTest.java        |   6 +-
 .../persistence/db/IgnitePdsWithTtlTest2.java      | 145 +++++++++
 .../wal/IgniteNodeStoppedDuringDisableWALTest.java |   4 +-
 ...eWalFlushMultiNodeFailoverAbstractSelfTest.java |   4 +-
 .../db/wal/IgniteWalFormatFileFailoverTest.java    |   7 +-
 .../db/wal/IgniteWalHistoryReservationsTest.java   |  10 +-
 .../persistence/db/wal/WalCompactionTest.java      |  14 +-
 .../db/wal/reader/IgniteWalReaderTest.java         |   4 +-
 .../IgniteChangeGlobalStateServiceTest.java        |   4 +-
 .../IgniteChangeGlobalStateTest.java               |   4 +-
 .../join/JoinActiveNodeToActiveCluster.java        |   7 +-
 .../join/JoinActiveNodeToInActiveCluster.java      |   7 +-
 .../join/JoinInActiveNodeToActiveCluster.java      |   4 +-
 .../join/JoinInActiveNodeToInActiveCluster.java    |   7 +-
 .../wal/ExplicitWalDeltaConsistencyTest.java       |   4 +-
 ...ContinuousQueryAsyncFailoverMvccTxSelfTest.java |   4 +-
 .../CacheContinuousQueryExecuteInPrimaryTest.java  |   4 +-
 ...CacheContinuousQueryFailoverMvccTxSelfTest.java |   4 +-
 .../CacheContinuousQueryRandomOperationsTest.java  |   7 +-
 .../CacheKeepBinaryIterationStoreEnabledTest.java  |   7 +-
 ...ionIntegrityWithPrimaryIndexCorruptionTest.java |   4 +-
 .../cache/transactions/TxRollbackAsyncTest.java    |  13 +-
 .../TxRollbackOnIncorrectParamsTest.java           |   4 +-
 .../transactions/TxRollbackOnTimeoutTest.java      |   4 +-
 .../TxRollbackOnTopologyChangeTest.java            |   5 +-
 .../TxWithSmallTimeoutAndContentionOneKeyTest.java |   4 +-
 .../continuous/GridEventConsumeSelfTest.java       |   4 +-
 .../processors/database/BPlusTreeSelfTest.java     |   4 +-
 .../database/IgniteDbDynamicCacheSelfTest.java     |   4 +-
 .../database/IgniteDbPutGetAbstractTest.java       |   4 +-
 .../DataStreamerMultiThreadedSelfTest.java         |   4 +-
 .../DataStreamerMultinodeCreateCacheTest.java      |   4 +-
 .../igfs/IgfsPrimaryMultiNodeSelfTest.java         |   4 +-
 ...PrimaryRelaxedConsistencyMultiNodeSelfTest.java |   4 +-
 .../ignite/internal/util/IgniteDevOnlyLogTest.java |   4 +-
 .../IpcSharedMemoryCrashDetectionSelfTest.java     |   4 +-
 .../IgniteClientReconnectMassiveShutdownTest.java  |  96 ++++--
 .../tcp/TcpDiscoveryMultiThreadedTest.java         |  16 +-
 .../ignite/testsuites/IgnitePdsTestSuite.java      |   2 +
 .../apache/ignite/util/GridCommandHandlerTest.java |  61 +++-
 .../GridInternalTaskUnusedWalSegmentsTest.java     |   6 +-
 .../processors/query/h2/dml/UpdatePlanBuilder.java |  87 ++++++
 .../cache/IgniteCacheInsertSqlQuerySelfTest.java   |  38 ++-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java    |  25 --
 .../cache/IgniteCacheSqlDmlErrorSelfTest.java      | 341 +++++++++++++++++++++
 .../cache/IgniteCacheUpdateSqlQuerySelfTest.java   |  89 ++++--
 .../IndexingCachePartitionLossPolicySelfTest.java  |   4 +-
 .../near/IgniteCacheQueryNodeRestartSelfTest2.java |   2 +-
 .../IgniteBinaryCacheQueryTestSuite.java           |   4 +-
 .../ml/sparkmodelparser/SparkModelParser.java      |  70 ++++-
 .../ml/sparkmodelparser/SupportedSparkModels.java  |   5 +-
 .../ignite/stream/mqtt/IgniteMqttStreamerTest.java |   4 +-
 .../Cache/PersistenceTest.cs                       |  48 ++-
 .../GridSpringCacheManagerMultiJvmSelfTest.java    |   4 +-
 parent/pom.xml                                     |   2 +-
 174 files changed, 1547 insertions(+), 642 deletions(-)