From commits-return-122792-archive-asf-public=cust-asf.ponee.io@ignite.apache.org Wed Dec 19 13:20:15 2018 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id A04E11807A6 for ; Wed, 19 Dec 2018 13:20:08 +0100 (CET) Received: (qmail 63301 invoked by uid 500); 19 Dec 2018 12:20:02 -0000 Mailing-List: contact commits-help@ignite.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@ignite.apache.org Delivered-To: mailing list commits@ignite.apache.org Received: (qmail 62311 invoked by uid 99); 19 Dec 2018 12:20:02 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 19 Dec 2018 12:20:02 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id F013CE148C; Wed, 19 Dec 2018 12:20:00 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: dpavlov@apache.org To: commits@ignite.apache.org Date: Wed, 19 Dec 2018 12:20:23 -0000 Message-Id: <46f2ff5bca024c37a6608e58f6097f39@git.apache.org> In-Reply-To: <8980337683674821b6912dcdc3d76fed@git.apache.org> References: <8980337683674821b6912dcdc3d76fed@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [24/61] [abbrv] ignite git commit: IGNITE-10176 migrate non-core modules tests from Junit 3 to 4 - Fixes #5659. IGNITE-10176 migrate non-core modules tests from Junit 3 to 4 - Fixes #5659. Signed-off-by: Ivan Rakov Project: http://git-wip-us.apache.org/repos/asf/ignite/repo Commit: http://git-wip-us.apache.org/repos/asf/ignite/commit/c5197e0a Tree: http://git-wip-us.apache.org/repos/asf/ignite/tree/c5197e0a Diff: http://git-wip-us.apache.org/repos/asf/ignite/diff/c5197e0a Branch: refs/heads/ignite-10639 Commit: c5197e0a607c6b04b5ed5edd3ff62909b0e861ea Parents: 93ed0d5 Author: Oleg Ignatenko Authored: Fri Dec 14 20:17:28 2018 +0300 Committer: Ivan Rakov Committed: Fri Dec 14 20:17:28 2018 +0300 ---------------------------------------------------------------------- .../testsuites/IgniteExamplesSelfTestSuite.java | 2 +- .../apache/ignite/gridify/AbstractAopTest.java | 44 + .../apache/ignite/gridify/BasicAopSelfTest.java | 7 +- .../GridifySetToXXXNonSpringAopSelfTest.java | 8 +- .../GridifySetToXXXSpringAopSelfTest.java | 8 +- .../gridify/hierarchy/GridifyHierarchyTest.java | 7 +- .../optimized/OptimizedMarshallerAopTest.java | 7 +- .../apache/ignite/p2p/P2PGridifySelfTest.java | 14 +- .../testsuites/IgniteAopSelfTestSuite.java | 18 +- .../singlesplit/SingleSplitsLoadTest.java | 5 + .../gridify/GridifySingleSplitLoadTest.java | 5 + .../gridify/ExternalNonSpringAopSelfTest.java | 36 + .../s3/S3CheckpointManagerSelfTest.java | 8 +- .../s3/S3CheckpointSpiConfigSelfTest.java | 7 +- .../checkpoint/s3/S3CheckpointSpiSelfTest.java | 9 +- ...pointSpiStartStopBucketEndpointSelfTest.java | 12 +- ...ckpointSpiStartStopSSEAlgorithmSelfTest.java | 11 +- .../s3/S3CheckpointSpiStartStopSelfTest.java | 7 +- .../s3/S3SessionCheckpointSelfTest.java | 7 +- .../elb/TcpDiscoveryElbIpFinderSelfTest.java | 7 +- .../TcpDiscoveryS3IpFinderAbstractSelfTest.java | 5 + ...3IpFinderAwsCredentialsProviderSelfTest.java | 7 +- ...scoveryS3IpFinderAwsCredentialsSelfTest.java | 7 +- ...scoveryS3IpFinderBucketEndpointSelfTest.java | 5 + ...TcpDiscoveryS3IpFinderKeyPrefixSelfTest.java | 5 + ...DiscoveryS3IpFinderSSEAlgorithmSelfTest.java | 7 +- .../s3/client/DummyObjectListingTest.java | 5 + .../ipfinder/s3/client/DummyS3ClientTest.java | 8 + .../ignite/testsuites/IgniteElbTestSuite.java | 6 +- .../ignite/testsuites/IgniteS3TestSuite.java | 32 +- .../stream/camel/IgniteCamelStreamerTest.java | 10 + .../camel/IgniteCamelStreamerTestSuite.java | 11 +- .../ignite/tests/CassandraConfigTest.java | 5 + .../internal/TaskEventSubjectIdSelfTest.java | 9 + .../ClientAbstractMultiThreadedSelfTest.java | 7 +- .../client/ClientDefaultCacheSelfTest.java | 5 + .../client/ClientReconnectionSelfTest.java | 12 +- .../ClientTcpSslAuthenticationSelfTest.java | 10 +- ...skExecutionAfterTopologyRestartSelfTest.java | 7 +- .../client/impl/ClientCacheFlagsCodecTest.java | 6 + .../client/impl/ClientComputeImplSelfTest.java | 18 +- .../client/impl/ClientDataImplSelfTest.java | 23 +- .../impl/ClientFutureAdapterSelfTest.java | 8 +- .../ClientPropertiesConfigurationSelfTest.java | 8 +- .../ClientAbstractConnectivitySelfTest.java | 12 +- .../ClientAbstractMultiNodeSelfTest.java | 7 + .../integration/ClientAbstractSelfTest.java | 11 + .../integration/ClientPreferDirectSelfTest.java | 8 +- .../client/router/ClientFailedInitSelfTest.java | 10 +- .../client/router/RouterFactorySelfTest.java | 7 +- .../router/TcpRouterAbstractSelfTest.java | 7 +- .../client/suite/IgniteClientTestSuite.java | 101 +-- .../client/util/ClientByteUtilsTest.java | 10 +- .../util/ClientConsistentHashSelfTest.java | 10 +- .../client/util/ClientJavaHasherSelfTest.java | 7 +- .../ignite/internal/jdbc2/JdbcBlobTest.java | 15 +- .../internal/jdbc2/JdbcBulkLoadSelfTest.java | 5 + .../jdbc2/JdbcComplexQuerySelfTest.java | 9 + .../jdbc2/JdbcConnectionReopenTest.java | 5 + .../internal/jdbc2/JdbcConnectionSelfTest.java | 15 + .../jdbc2/JdbcDeleteStatementSelfTest.java | 7 + .../jdbc2/JdbcDistributedJoinsQueryTest.java | 9 + .../jdbc2/JdbcDynamicIndexAbstractSelfTest.java | 11 + .../internal/jdbc2/JdbcEmptyCacheSelfTest.java | 6 + .../internal/jdbc2/JdbcErrorsSelfTest.java | 6 + .../jdbc2/JdbcInsertStatementSelfTest.java | 12 + .../internal/jdbc2/JdbcLocalCachesSelfTest.java | 7 + .../jdbc2/JdbcMergeStatementSelfTest.java | 7 + .../internal/jdbc2/JdbcMetadataSelfTest.java | 15 + .../jdbc2/JdbcNoCacheStreamingSelfTest.java | 6 + .../internal/jdbc2/JdbcNoDefaultCacheTest.java | 6 + .../jdbc2/JdbcPreparedStatementSelfTest.java | 20 + .../internal/jdbc2/JdbcResultSetSelfTest.java | 27 + .../internal/jdbc2/JdbcSpringSelfTest.java | 6 + .../jdbc2/JdbcStatementBatchingSelfTest.java | 8 + .../internal/jdbc2/JdbcStatementSelfTest.java | 10 + .../internal/jdbc2/JdbcStreamingSelfTest.java | 8 + .../jdbc2/JdbcStreamingToPublicCacheTest.java | 5 + .../jdbc2/JdbcUpdateStatementSelfTest.java | 7 + .../rest/ChangeStateCommandHandlerTest.java | 5 + .../rest/ClientMemcachedProtocolSelfTest.java | 23 + .../JettyRestProcessorAbstractSelfTest.java | 64 ++ ...RestProcessorAuthenticationAbstractTest.java | 6 + ...rocessorAuthenticationWithTokenSelfTest.java | 5 + .../JettyRestProcessorGetAllAsArrayTest.java | 5 + .../rest/JettyRestProcessorSignedSelfTest.java | 5 + .../rest/RestBinaryProtocolSelfTest.java | 21 +- .../rest/RestMemcacheProtocolSelfTest.java | 19 +- .../rest/RestProcessorMultiStartSelfTest.java | 6 + .../rest/RestProcessorStartSelfTest.java | 7 +- .../rest/TaskCommandHandlerSelfTest.java | 7 +- .../rest/TcpRestUnmarshalVulnerabilityTest.java | 12 +- .../protocols/tcp/TcpRestParserSelfTest.java | 12 +- .../tcp/redis/RedisProtocolConnectSelfTest.java | 7 + .../tcp/redis/RedisProtocolServerSelfTest.java | 7 + ...tocolStringAtomicDatastructuresSelfTest.java | 5 + .../tcp/redis/RedisProtocolStringSelfTest.java | 19 + .../ignite/jdbc/JdbcComplexQuerySelfTest.java | 11 +- .../ignite/jdbc/JdbcConnectionSelfTest.java | 14 +- .../ignite/jdbc/JdbcEmptyCacheSelfTest.java | 8 +- .../ignite/jdbc/JdbcErrorsAbstractSelfTest.java | 36 + .../ignite/jdbc/JdbcLocalCachesSelfTest.java | 8 +- .../ignite/jdbc/JdbcMetadataSelfTest.java | 9 + .../ignite/jdbc/JdbcNoDefaultCacheTest.java | 6 + .../jdbc/JdbcPojoLegacyQuerySelfTest.java | 5 + .../ignite/jdbc/JdbcPojoQuerySelfTest.java | 6 + .../jdbc/JdbcPreparedStatementSelfTest.java | 21 +- .../ignite/jdbc/JdbcResultSetSelfTest.java | 23 +- .../ignite/jdbc/JdbcStatementSelfTest.java | 9 +- .../jdbc/JdbcVersionMismatchSelfTest.java | 5 + .../suite/IgniteJdbcDriverMvccTestSuite.java | 17 +- .../jdbc/suite/IgniteJdbcDriverTestSuite.java | 199 ++--- .../JdbcThinAuthenticateConnectionSelfTest.java | 11 +- .../thin/JdbcThinAutoCloseServerCursorTest.java | 8 + .../ignite/jdbc/thin/JdbcThinBatchSelfTest.java | 25 + .../thin/JdbcThinBulkLoadAbstractSelfTest.java | 35 + ...bcThinComplexDmlDdlCustomSchemaSelfTest.java | 8 +- .../thin/JdbcThinComplexDmlDdlSelfTest.java | 7 +- .../jdbc/thin/JdbcThinComplexQuerySelfTest.java | 11 +- ...JdbcThinConnectionMultipleAddressesTest.java | 19 +- .../JdbcThinConnectionMvccEnabledSelfTest.java | 13 +- .../jdbc/thin/JdbcThinConnectionSSLTest.java | 17 +- .../jdbc/thin/JdbcThinConnectionSelfTest.java | 58 ++ .../jdbc/thin/JdbcThinDataSourceSelfTest.java | 12 +- .../thin/JdbcThinDeleteStatementSelfTest.java | 6 + .../JdbcThinDynamicIndexAbstractSelfTest.java | 11 + .../jdbc/thin/JdbcThinEmptyCacheSelfTest.java | 8 +- .../jdbc/thin/JdbcThinErrorsSelfTest.java | 9 + .../thin/JdbcThinInsertStatementSelfTest.java | 9 + .../jdbc/thin/JdbcThinLocalQueriesSelfTest.java | 5 + .../thin/JdbcThinMergeStatementSelfTest.java | 6 + .../JdbcThinMetadataPrimaryKeysSelfTest.java | 8 + .../jdbc/thin/JdbcThinMetadataSelfTest.java | 24 +- .../JdbcThinMissingLongArrayResultsTest.java | 5 + .../jdbc/thin/JdbcThinNoDefaultSchemaTest.java | 9 + .../thin/JdbcThinPreparedStatementSelfTest.java | 23 +- .../jdbc/thin/JdbcThinResultSetSelfTest.java | 26 +- .../jdbc/thin/JdbcThinSchemaCaseTest.java | 5 + .../thin/JdbcThinSelectAfterAlterTable.java | 8 +- .../jdbc/thin/JdbcThinStatementSelfTest.java | 38 +- .../thin/JdbcThinStreamingAbstractSelfTest.java | 17 +- .../ignite/jdbc/thin/JdbcThinTcpIoTest.java | 6 + ...ThinTransactionsAbstractComplexSelfTest.java | 34 + .../jdbc/thin/JdbcThinTransactionsSelfTest.java | 22 + ...ThinTransactionsWithMvccEnabledSelfTest.java | 21 + .../thin/JdbcThinUpdateStatementSelfTest.java | 6 + ...ctionFinishOnDeactivatedClusterSelfTest.java | 6 + .../client/ClientMarshallerBenchmarkTest.java | 7 +- .../loadtests/client/ClientTcpSslLoadTest.java | 7 +- .../TcpDiscoveryCloudIpFinderSelfTest.java | 10 +- .../ignite/testsuites/IgniteCloudTestSuite.java | 10 +- .../PdsWithTtlCompatibilityTest.java | 5 + .../FoldersReuseCompatibilityTest.java | 6 + .../IgnitePKIndexesMigrationToUnwrapPkTest.java | 6 + ...tingToWalV2SerializerWithCompactionTest.java | 5 + .../PersistenceBasicCompatibilityTest.java | 10 + .../IgniteCompatibilityBasicTestSuite.java | 12 +- .../compress/CompressionProcessorTest.java | 64 ++ .../DiskPageCompressionIntegrationTest.java | 12 + .../compress/FileSystemUtilsTest.java | 5 + .../IgnitePdsCompressionTestSuite.java | 9 +- .../CacheContinuousQueryLostPartitionTest.java | 1 - ...lWalModeChangeDuringRebalancingSelfTest.java | 6 + .../persistence/file/IgniteFileIOTest.java | 8 + .../IgniteNativeIoWithNoPersistenceTest.java | 5 + .../testsuites/IgnitePdsNativeIoTestSuite.java | 7 +- .../testsuites/IgnitePdsNativeIoTestSuite2.java | 9 +- .../IgnitePdsReplacementNativeIoTest.java | 5 + .../sink/flink/FlinkIgniteSinkSelfTest.java | 8 +- .../flink/FlinkIgniteSinkSelfTestSuite.java | 7 +- .../ignite/stream/flume/IgniteSinkTest.java | 5 + .../stream/flume/IgniteSinkTestSuite.java | 6 +- .../ignite/testsuites/IgniteGCETestSuite.java | 8 +- .../query/h2/H2IndexingAbstractGeoSelfTest.java | 15 +- .../testsuites/GeoSpatialIndexingTestSuite.java | 10 +- .../hadoop/impl/HadoopCommandLineTest.java | 8 +- .../hadoop/impl/HadoopFileSystemsTest.java | 7 +- .../hadoop/impl/HadoopGroupingTest.java | 10 +- .../hadoop/impl/HadoopJobTrackerSelfTest.java | 8 +- .../impl/HadoopMapReduceEmbeddedSelfTest.java | 8 +- .../HadoopMapReduceErrorResilienceTest.java | 12 +- .../hadoop/impl/HadoopMapReduceTest.java | 7 +- .../impl/HadoopNoHadoopMapReduceTest.java | 5 + .../HadoopSerializationWrapperSelfTest.java | 8 +- .../hadoop/impl/HadoopSnappyTest.java | 5 + .../hadoop/impl/HadoopSortingTest.java | 7 +- .../hadoop/impl/HadoopSplitWrapperSelfTest.java | 7 +- .../impl/HadoopTaskExecutionSelfTest.java | 11 +- .../impl/HadoopTasksVersionsAbstractTest.java | 8 + .../hadoop/impl/HadoopTeraSortTest.java | 6 + .../hadoop/impl/HadoopTxConfigCacheTest.java | 9 +- .../hadoop/impl/HadoopUserLibsSelfTest.java | 10 + .../hadoop/impl/HadoopV2JobSelfTest.java | 7 +- .../hadoop/impl/HadoopValidationSelfTest.java | 7 +- .../HadoopWeightedMapReducePlannerTest.java | 7 + ...opClientProtocolMultipleServersSelfTest.java | 9 +- .../client/HadoopClientProtocolSelfTest.java | 7 +- ...KerberosHadoopFileSystemFactorySelfTest.java | 8 +- .../impl/igfs/Hadoop1OverIgfsProxyTest.java | 7 +- .../igfs/HadoopFIleSystemFactorySelfTest.java | 5 + .../HadoopIgfs20FileSystemAbstractSelfTest.java | 62 ++ .../igfs/HadoopIgfsDualAbstractSelfTest.java | 7 +- ...oopSecondaryFileSystemConfigurationTest.java | 8 +- .../hadoop/impl/igfs/IgfsEventsTestSuite.java | 21 +- .../igfs/IgfsNearOnlyMultiNodeSelfTest.java | 5 + .../IgniteHadoopFileSystemAbstractSelfTest.java | 78 +- ...opFileSystemClientBasedAbstractSelfTest.java | 8 +- ...niteHadoopFileSystemClientBasedOpenTest.java | 7 + .../IgniteHadoopFileSystemClientSelfTest.java | 5 + ...IgniteHadoopFileSystemHandshakeSelfTest.java | 8 +- .../IgniteHadoopFileSystemIpcCacheSelfTest.java | 7 +- .../IgniteHadoopFileSystemLoggerSelfTest.java | 10 +- ...niteHadoopFileSystemLoggerStateSelfTest.java | 14 +- ...teHadoopFileSystemShmemAbstractSelfTest.java | 7 +- ...emShmemExternalToClientAbstractSelfTest.java | 7 +- .../HadoopConcurrentHashMultimapSelftest.java | 8 +- .../collections/HadoopHashMapSelfTest.java | 7 +- .../collections/HadoopSkipListSelfTest.java | 8 +- .../streams/HadoopDataStreamSelfTest.java | 9 +- .../taskexecutor/HadoopExecutorServiceTest.java | 7 +- .../HadoopExternalTaskExecutionSelfTest.java | 8 +- .../HadoopExternalCommunicationSelfTest.java | 8 +- .../impl/util/BasicUserNameMapperSelfTest.java | 7 + .../util/ChainedUserNameMapperSelfTest.java | 7 + .../util/KerberosUserNameMapperSelfTest.java | 8 + .../testsuites/IgniteHadoopTestSuite.java | 135 ++-- .../IgniteIgfsLinuxAndMacOSTestSuite.java | 25 +- .../HibernateL2CacheConfigurationSelfTest.java | 8 +- .../hibernate/HibernateL2CacheMultiJvmTest.java | 5 + .../hibernate/HibernateL2CacheSelfTest.java | 14 +- .../HibernateL2CacheStrategySelfTest.java | 7 +- .../CacheHibernateStoreFactorySelfTest.java | 9 +- .../testsuites/IgniteHibernateTestSuite.java | 22 +- .../HibernateL2CacheConfigurationSelfTest.java | 8 +- .../hibernate/HibernateL2CacheMultiJvmTest.java | 5 + .../hibernate/HibernateL2CacheSelfTest.java | 14 +- .../HibernateL2CacheStrategySelfTest.java | 7 +- .../CacheHibernateBlobStoreSelfTest.java | 8 + .../CacheHibernateStoreFactorySelfTest.java | 9 +- .../testsuites/IgniteHibernate5TestSuite.java | 24 +- ...ityKeyNameAndValueFieldNameConflictTest.java | 10 +- .../processors/cache/BigEntryQueryTest.java | 5 + ...MetadataConcurrentUpdateWithIndexesTest.java | 5 + .../cache/BinarySerializationQuerySelfTest.java | 9 + .../cache/BinaryTypeMismatchLoggingTest.java | 15 +- ...CacheAbstractQueryDetailMetricsSelfTest.java | 20 + .../CacheAbstractQueryMetricsSelfTest.java | 19 + .../CacheBinaryKeyConcurrentQueryTest.java | 5 + .../cache/CacheConfigurationP2PTest.java | 7 +- .../cache/CacheIndexStreamerTest.java | 6 + .../cache/CacheIteratorScanQueryTest.java | 6 + .../CacheOffheapBatchIndexingMultiTypeTest.java | 8 +- ...CacheOffheapBatchIndexingSingleTypeTest.java | 9 +- .../CacheOperationsWithExpirationTest.java | 6 + .../cache/CacheQueryBuildValueTest.java | 5 + .../cache/CacheQueryEvictDataLostTest.java | 5 + .../cache/CacheQueryFilterExpiredTest.java | 5 + .../cache/CacheQueryNewClientSelfTest.java | 6 + .../CacheRandomOperationsMultithreadedTest.java | 8 + ...CacheScanPartitionQueryFallbackSelfTest.java | 13 +- .../cache/CacheSqlQueryValueCopySelfTest.java | 12 + .../ClientReconnectAfterClusterRestartTest.java | 5 + .../cache/ClusterReadOnlyModeSqlTest.java | 5 + .../cache/DdlTransactionSelfTest.java | 10 + .../cache/GridCacheCrossCacheQuerySelfTest.java | 7 + .../cache/GridCacheFullTextQuerySelfTest.java | 11 +- ...GridCacheLazyQueryPartitionsReleaseTest.java | 6 + .../cache/GridCacheOffHeapSelfTest.java | 7 +- .../GridCacheOffheapIndexEntryEvictTest.java | 8 +- .../cache/GridCacheOffheapIndexGetSelfTest.java | 9 +- .../GridCacheQueryIndexDisabledSelfTest.java | 12 + .../GridCacheQuerySerializationSelfTest.java | 7 +- .../cache/GridCacheQuerySimpleBenchmark.java | 7 +- .../cache/GridIndexingWithNoopSwapSelfTest.java | 7 +- .../IgniteBinaryObjectFieldsQuerySelfTest.java | 12 + .../IgniteBinaryObjectQueryArgumentsTest.java | 13 + ...eBinaryWrappedObjectFieldsQuerySelfTest.java | 2 +- .../IgniteCacheAbstractFieldsQuerySelfTest.java | 26 + .../IgniteCacheCollocatedQuerySelfTest.java | 6 + .../IgniteCacheConfigVariationsQueryTest.java | 10 + ...acheConfigurationPrimitiveTypesSelfTest.java | 7 +- .../IgniteCacheCrossCacheJoinRandomTest.java | 8 + .../IgniteCacheDeleteSqlQuerySelfTest.java | 7 + ...acheDistributedJoinCollocatedAndNotTest.java | 5 + ...acheDistributedJoinCustomAffinityMapper.java | 5 + .../IgniteCacheDistributedJoinNoIndexTest.java | 5 + ...ributedJoinPartitionedAndReplicatedTest.java | 7 + ...CacheDistributedJoinQueryConditionsTest.java | 9 + .../cache/IgniteCacheDistributedJoinTest.java | 5 + ...cheDuplicateEntityConfigurationSelfTest.java | 6 + .../IgniteCacheFieldsQueryNoDataSelfTest.java | 7 +- ...teCacheFullTextQueryNodeJoiningSelfTest.java | 7 +- .../cache/IgniteCacheGroupsSqlTest.java | 11 + .../IgniteCacheInsertSqlQuerySelfTest.java | 15 + ...PartitionedAndReplicatedCollocationTest.java | 5 + ...teCacheJoinPartitionedAndReplicatedTest.java | 6 + ...IgniteCacheJoinQueryWithAffinityKeyTest.java | 10 + .../cache/IgniteCacheLargeResultSelfTest.java | 7 +- ...PartitionOnAffinityRunAtomicCacheOpTest.java | 7 + ...niteCacheLockPartitionOnAffinityRunTest.java | 13 + ...titionOnAffinityRunWithCollisionSpiTest.java | 6 + .../cache/IgniteCacheMergeSqlQuerySelfTest.java | 11 + .../IgniteCacheMultipleIndexedTypesTest.java | 5 + .../cache/IgniteCacheNoClassQuerySelfTest.java | 5 + .../IgniteCacheObjectKeyIndexingSelfTest.java | 9 +- .../cache/IgniteCacheOffheapEvictQueryTest.java | 5 + .../cache/IgniteCacheOffheapIndexScanTest.java | 7 +- ...niteCacheP2pUnmarshallingQueryErrorTest.java | 6 + ...hePartitionedQueryMultiThreadedSelfTest.java | 7 +- ...IgniteCachePrimitiveFieldsQuerySelfTest.java | 7 +- .../cache/IgniteCacheQueriesLoadTest1.java | 5 + .../IgniteCacheQueryH2IndexingLeakTest.java | 8 +- .../cache/IgniteCacheQueryIndexSelfTest.java | 8 +- .../cache/IgniteCacheQueryLoadSelfTest.java | 12 +- .../IgniteCacheQueryMultiThreadedSelfTest.java | 12 + .../cache/IgniteCacheSqlQueryErrorSelfTest.java | 13 + ...gniteCacheSqlQueryMultiThreadedSelfTest.java | 8 +- .../IgniteCacheStarvationOnRebalanceTest.java | 7 +- .../IgniteCacheUpdateSqlQuerySelfTest.java | 10 + ...CheckClusterStateBeforeExecuteQueryTest.java | 5 + ...ClientReconnectCacheQueriesFailoverTest.java | 6 + .../cache/IgniteClientReconnectQueriesTest.java | 11 +- .../cache/IgniteCrossCachesJoinsQueryTest.java | 10 + .../cache/IgniteDynamicSqlRestoreTest.java | 13 + .../cache/IgniteErrorOnRebalanceTest.java | 5 + .../cache/IncorrectQueryEntityTest.java | 5 + .../cache/QueryEntityCaseMismatchTest.java | 5 + .../QueryJoinWithDifferentNodeFiltersTest.java | 7 +- .../cache/SqlFieldsQuerySelfTest.java | 7 + .../cache/StartCachesInParallelTest.java | 9 +- .../authentication/SqlUserCommandSelfTest.java | 11 + .../CacheBlockOnCreateDestoryIndexTest.java | 36 + .../distributed/CacheBlockOnSqlQueryTest.java | 14 + ...lientQueryReplicatedNodeRestartSelfTest.java | 7 +- ...utedPartitionQueryConfigurationSelfTest.java | 7 +- ...butedPartitionQueryNodeRestartsSelfTest.java | 7 +- ...eCacheDistributedPartitionQuerySelfTest.java | 13 +- ...niteCacheDistributedQueryCancelSelfTest.java | 6 + ...butedQueryStopOnCancelOrTimeoutSelfTest.java | 19 + ...niteCachePartitionedFieldsQuerySelfTest.java | 8 +- .../IgniteCachePartitionedQuerySelfTest.java | 2 +- .../IgniteCacheQueryNoRebalanceSelfTest.java | 5 + .../near/IgniteCacheQueryNodeFailTest.java | 6 + ...QueryNodeRestartDistributedJoinSelfTest.java | 8 +- .../IgniteCacheQueryNodeRestartSelfTest.java | 7 +- .../IgniteCacheQueryNodeRestartSelfTest2.java | 5 + ...nCancelOrTimeoutDistributedJoinSelfTest.java | 12 + .../near/IgniteSqlQueryWithBaselineTest.java | 9 +- ...ldsQueryJoinNoPrimaryPartitionsSelfTest.java | 7 +- ...gniteCacheReplicatedFieldsQuerySelfTest.java | 7 +- .../processors/cache/index/BasicIndexTest.java | 13 + .../index/ComplexPrimaryKeyUnwrapSelfTest.java | 9 + .../ComplexSecondaryKeyUnwrapSelfTest.java | 6 + .../index/DuplicateKeyValueClassesSelfTest.java | 6 + ...ynamicColumnsAbstractConcurrentSelfTest.java | 20 + .../DynamicIndexAbstractBasicSelfTest.java | 73 ++ .../DynamicIndexAbstractConcurrentSelfTest.java | 18 +- .../cache/index/H2ConnectionLeaksSelfTest.java | 6 + .../H2DynamicColumnsAbstractBasicSelfTest.java | 32 + .../index/H2DynamicIndexAbstractSelfTest.java | 11 + .../H2DynamicIndexingComplexAbstractTest.java | 5 + .../cache/index/H2DynamicTableSelfTest.java | 66 ++ .../cache/index/H2RowCachePageEvictionTest.java | 8 + .../cache/index/H2RowCacheSelfTest.java | 12 + .../cache/index/IgniteDecimalSelfTest.java | 9 + .../cache/index/LongIndexNameTest.java | 5 + .../index/MvccEmptyTransactionSelfTest.java | 5 + .../index/OptimizedMarshallerIndexNameTest.java | 5 + .../index/QueryEntityValidationSelfTest.java | 7 + .../cache/index/SchemaExchangeSelfTest.java | 16 + ...sactionCommandsWithMvccDisabledSelfTest.java | 7 + ...sactionsCommandsWithMvccEnabledSelfTest.java | 10 + .../cache/index/SqlTransactionsSelfTest.java | 11 + .../IgniteCacheLocalFieldsQuerySelfTest.java | 7 +- ...eCacheLocalQueryCancelOrTimeoutSelfTest.java | 9 +- .../local/IgniteCacheLocalQuerySelfTest.java | 7 + ...acheMvccAbstractContinuousQuerySelfTest.java | 16 +- ...eMvccAbstractSqlCoordinatorFailoverTest.java | 18 + .../mvcc/CacheMvccBackupsAbstractTest.java | 17 + .../mvcc/CacheMvccBasicContinuousQueryTest.java | 10 + .../cache/mvcc/CacheMvccBulkLoadTest.java | 7 + ...ContinuousWithTransformerClientSelfTest.java | 5 + ...nuousWithTransformerPartitionedSelfTest.java | 5 + ...inuousWithTransformerReplicatedSelfTest.java | 5 + .../cache/mvcc/CacheMvccDmlSimpleTest.java | 8 + ...MvccPartitionedSelectForUpdateQueryTest.java | 8 +- ...ccPartitionedSqlCoordinatorFailoverTest.java | 22 + ...cPartitionedSqlTxQueriesWithReducerTest.java | 7 +- .../CacheMvccReplicatedSqlTxQueriesTest.java | 9 +- ...cheMvccSelectForUpdateQueryAbstractTest.java | 13 + .../cache/mvcc/CacheMvccSizeTest.java | 11 + ...CacheMvccSqlConfigurationValidationTest.java | 7 + .../cache/mvcc/CacheMvccSqlLockTimeoutTest.java | 10 + .../mvcc/CacheMvccSqlQueriesAbstractTest.java | 31 + .../mvcc/CacheMvccSqlTxQueriesAbstractTest.java | 58 ++ ...MvccSqlTxQueriesWithReducerAbstractTest.java | 20 + .../mvcc/CacheMvccSqlUpdateCountersTest.java | 9 + .../mvcc/CacheMvccStreamingInsertTest.java | 6 + .../cache/mvcc/CacheMvccTxNodeMappingTest.java | 6 + .../cache/mvcc/CacheMvccTxRecoveryTest.java | 15 + .../mvcc/MvccRepeatableReadBulkOpsTest.java | 16 + .../mvcc/MvccRepeatableReadOperationsTest.java | 9 +- .../db/wal/IgniteWalRecoveryTest.java | 29 + .../transaction/DmlInsideTransactionTest.java | 8 + .../cache/ttl/CacheTtlAbstractSelfTest.java | 13 +- ...onnectorConfigurationValidationSelfTest.java | 21 + .../client/IgniteDataStreamerTest.java | 5 + ...gniteDbSingleNodeWithIndexingPutGetTest.java | 6 + ...eDbSingleNodeWithIndexingWalRestoreTest.java | 6 + ...oreQueryWithMultipleClassesPerCacheTest.java | 7 +- .../IgnitePersistentStoreSchemaLoadTest.java | 7 + .../IgniteTwoRegionsRebuildIndexTest.java | 5 + ...iteCacheGroupsSqlSegmentedIndexSelfTest.java | 5 + .../query/IgniteCachelessQueriesSelfTest.java | 24 + .../query/IgniteQueryDedicatedPoolTest.java | 7 + .../query/IgniteSqlDefaultValueTest.java | 9 + .../query/IgniteSqlDistributedJoinSelfTest.java | 5 + .../IgniteSqlEntryCacheModeAgnosticTest.java | 5 + .../IgniteSqlGroupConcatCollocatedTest.java | 7 + .../IgniteSqlGroupConcatNotCollocatedTest.java | 7 + .../query/IgniteSqlKeyValueFieldsTest.java | 795 ++++++++++--------- .../query/IgniteSqlNotNullConstraintTest.java | 46 ++ .../query/IgniteSqlParameterizedQueryTest.java | 5 + .../query/IgniteSqlQueryParallelismTest.java | 8 +- .../processors/query/IgniteSqlRoutingTest.java | 18 + .../query/IgniteSqlSchemaIndexingTest.java | 8 + .../query/IgniteSqlSegmentedIndexSelfTest.java | 10 + ...teSqlSkipReducerOnUpdateDmlFlagSelfTest.java | 24 + ...IgniteSqlSkipReducerOnUpdateDmlSelfTest.java | 13 + .../query/IgniteSqlSplitterSelfTest.java | 48 ++ .../processors/query/LazyQuerySelfTest.java | 8 + .../MultipleStatementsSqlQuerySelfTest.java | 8 + .../processors/query/RunningQueriesTest.java | 5 + .../query/SqlIllegalSchemaSelfTest.java | 12 + .../query/SqlNestedQuerySelfTest.java | 5 + .../query/SqlPushDownFunctionTest.java | 5 + .../processors/query/SqlSchemaSelfTest.java | 12 + .../query/SqlSystemViewsSelfTest.java | 12 +- .../query/h2/GridIndexRebuildSelfTest.java | 5 + ...GridIndexRebuildWithMvccEnabledSelfTest.java | 5 + .../h2/GridIndexingSpiAbstractSelfTest.java | 5 + ...H2ResultSetIteratorNullifyOnEndSelfTest.java | 8 + .../query/h2/H2StatementCacheSelfTest.java | 9 +- .../query/h2/IgniteSqlBigIntegerKeyTest.java | 7 + .../query/h2/IgniteSqlQueryMinMaxTest.java | 13 + .../query/h2/PreparedStatementExSelfTest.java | 8 +- .../query/h2/ThreadLocalObjectPoolSelfTest.java | 9 + .../h2/database/InlineIndexHelperTest.java | 30 + .../query/h2/sql/BaseH2CompareQueryTest.java | 21 +- .../query/h2/sql/ExplainSelfTest.java | 10 + .../query/h2/sql/GridQueryParsingTest.java | 17 + .../query/h2/sql/H2CompareBigQueryTest.java | 5 + .../h2/twostep/CacheQueryMemoryLeakTest.java | 5 + .../twostep/CreateTableWithDateKeySelfTest.java | 7 + ...sappearedCacheCauseRetryMessageSelfTest.java | 5 + ...appearedCacheWasNotFoundMessageSelfTest.java | 5 + .../InOperationExtractPartitionSelfTest.java | 8 + .../NonCollocatedRetryMessageSelfTest.java | 5 + .../h2/twostep/RetryCauseMessageSelfTest.java | 11 +- .../h2/twostep/TableViewSubquerySelfTest.java | 5 + ...ePartitionedAtomicColumnConstraintsTest.java | 31 + ...ionedTransactionalColumnConstraintsTest.java | 4 +- ...ansactionalSnapshotColumnConstraintTest.java | 22 + ...ansactionalSnapshotColumnConstraintTest.java | 22 + .../sql/IgniteSQLColumnConstraintsTest.java | 19 +- ...gniteTransactionSQLColumnConstraintTest.java | 6 + ...onnectorConfigurationValidationSelfTest.java | 11 + .../tcp/GridOrderedMessageCancelSelfTest.java | 8 +- .../org/apache/ignite/sqltests/BaseSqlTest.java | 23 + .../ignite/sqltests/PartitionedSqlTest.java | 10 + .../ignite/sqltests/ReplicatedSqlTest.java | 19 + .../IgniteBinaryCacheQueryTestSuite.java | 30 +- .../IgniteBinaryCacheQueryTestSuite2.java | 84 +- .../IgniteCacheAffinityRunTestSuite.java | 18 +- ...ockExchangeOnSqlReadOperationsTestSuite.java | 5 +- .../testsuites/IgniteCacheMvccSqlTestSuite.java | 101 +-- .../IgniteCacheQuerySelfTestSuite3.java | 66 +- .../IgniteCacheQuerySelfTestSuite4.java | 24 +- .../IgniteCacheQuerySelfTestSuite5.java | 40 +- .../IgniteCacheQuerySelfTestSuite6.java | 40 +- ...acheWithIndexingAndPersistenceTestSuite.java | 8 +- .../IgniteCacheWithIndexingTestSuite.java | 52 +- ...IgniteDbMemoryLeakWithIndexingTestSuite.java | 8 +- .../IgnitePdsWithIndexingCoreTestSuite.java | 56 +- .../IgnitePdsWithIndexingTestSuite.java | 20 +- .../util/GridCommandHandlerIndexingTest.java | 8 + ...ityWithJsr310Java8DateTimeApiFieldsTest.java | 9 + ...yJsr310Java8DateTimeApiSupportTestSuite.java | 3 +- .../apache/ignite/logger/jcl/JclLoggerTest.java | 7 +- .../ignite/testsuites/IgniteJclTestSuite.java | 8 +- .../stream/jms11/IgniteJmsStreamerTest.java | 26 +- .../cache/CacheJndiTmFactorySelfTest.java | 6 + ...CacheJtaConfigurationValidationSelfTest.java | 5 + ...CacheJtaFactoryConfigValidationSelfTest.java | 7 + .../cache/GridJtaLifecycleAwareSelfTest.java | 8 + .../GridJtaTransactionManagerSelfTest.java | 6 + .../ignite/testsuites/IgniteJtaTestSuite.java | 18 +- .../kafka/IgniteKafkaStreamerSelfTestSuite.java | 10 +- .../kafka/KafkaIgniteStreamerSelfTest.java | 5 + .../kafka/connect/IgniteSinkConnectorTest.java | 6 + .../connect/IgniteSourceConnectorTest.java | 6 + .../TcpDiscoveryKubernetesIpFinderSelfTest.java | 7 +- .../testsuites/IgniteKubernetesTestSuite.java | 8 +- .../logger/log4j/GridLog4jConfigUpdateTest.java | 8 + .../log4j/GridLog4jCorrectFileNameTest.java | 24 +- .../logger/log4j/GridLog4jInitializedTest.java | 7 +- .../logger/log4j/GridLog4jLoggingFileTest.java | 17 +- .../logger/log4j/GridLog4jLoggingPathTest.java | 17 +- .../logger/log4j/GridLog4jLoggingUrlTest.java | 17 +- .../log4j/GridLog4jNotInitializedTest.java | 7 +- .../logger/log4j2/Log4j2ConfigUpdateTest.java | 7 + .../logger/log4j2/Log4j2LoggerMarkerTest.java | 24 +- .../logger/log4j2/Log4j2LoggerSelfTest.java | 26 +- .../log4j2/Log4j2LoggerVerboseModeSelfTest.java | 11 +- .../testsuites/IgniteLog4j2TestSuite.java | 14 +- .../org/apache/ignite/IgniteMesosTestSuite.java | 8 +- .../org/apache/ignite/ml/IgniteMLTestSuite.java | 55 +- .../ignite/ml/dataset/DatasetTestSuite.java | 40 +- .../impl/cache/util/ComputeUtilsTest.java | 4 +- .../ignite/ml/inference/InferenceTestSuite.java | 28 +- .../IgniteDistributedInfModelBuilderTest.java | 3 +- .../org/apache/ignite/ml/nn/MLPTestSuite.java | 27 +- .../ignite/ml/nn/MLPTrainerIntegrationTest.java | 2 +- .../MLPTrainerMnistIntegrationTest.java | 2 +- .../ignite/ml/selection/SelectionTestSuite.java | 41 +- ...reeClassificationTrainerIntegrationTest.java | 2 +- ...ionTreeRegressionTrainerIntegrationTest.java | 2 +- .../ignite/ml/tree/DecisionTreeTestSuite.java | 40 +- .../DecisionTreeMNISTIntegrationTest.java | 2 +- .../stream/mqtt/IgniteMqttStreamerTest.java | 23 +- .../protocols/http/jetty/GridRestSuite.java | 3 +- .../http/jetty/RestSetupSimpleTest.java | 5 + .../stream/rocketmq/RocketMQStreamerTest.java | 5 + .../rocketmq/RocketMQStreamerTestSuite.java | 6 +- .../schedule/GridScheduleSelfTest.java | 13 +- .../testsuites/IgniteSchedulerTestSuite.java | 8 +- .../logger/slf4j/Slf4jLoggerMarkerTest.java | 5 + .../ignite/testsuites/IgniteSlf4jTestSuite.java | 3 +- .../spark/JavaEmbeddedIgniteRDDSelfTest.java | 10 +- .../spark/JavaStandaloneIgniteRDDSelfTest.java | 11 +- .../ignite/testsuites/IgniteRDDTestSuite.java | 8 +- .../IgniteSpringDataCrudSelfTest.java | 10 + .../IgniteSpringDataQueriesSelfTest.java | 23 + .../testsuites/IgniteSpringData2TestSuite.java | 8 +- .../IgniteSpringDataCrudSelfTest.java | 10 + .../IgniteSpringDataQueriesSelfTest.java | 24 + .../testsuites/IgniteSpringDataTestSuite.java | 8 +- .../GridSpringCacheManagerAbstractTest.java | 19 + .../GridSpringCacheManagerMultiJvmSelfTest.java | 5 + .../SpringCacheManagerContextInjectionTest.java | 6 + .../ignite/cache/spring/SpringCacheTest.java | 12 + .../jdbc/CacheJdbcBlobStoreFactorySelfTest.java | 7 + .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java | 7 + .../SpringEncryptedCacheRestartTest.java | 9 + .../ignite/internal/GridFactorySelfTest.java | 25 + .../GridSpringBeanSerializationSelfTest.java | 5 + .../internal/IgniteDynamicCacheConfigTest.java | 10 + .../ignite/internal/IgniteSpringBeanTest.java | 6 + .../resource/GridLoggerInjectionSelfTest.java | 9 +- .../resource/GridResourceProcessorSelfTest.java | 12 +- .../resource/GridServiceInjectionSelfTest.java | 16 +- .../GridSpringResourceInjectionSelfTest.java | 18 + .../GridTransformSpringInjectionSelfTest.java | 5 + .../p2p/GridP2PUserVersionChangeSelfTest.java | 11 +- .../IgniteExcludeInConfigurationTest.java | 8 +- .../IgniteStartFromStreamConfigurationTest.java | 7 +- .../GridServiceInjectionSpringResourceTest.java | 5 + ...teSpringBeanSpringResourceInjectionTest.java | 6 + .../testsuites/IgniteResourceSelfTestSuite.java | 14 +- .../testsuites/IgniteSpringTestSuite.java | 55 +- ...ridSpringTransactionManagerAbstractTest.java | 9 + ...gTransactionManagerContextInjectionTest.java | 8 +- .../internal/IgniteNodeStartUtilsSelfTest.java | 7 +- ...gniteProjectionStartStopRestartSelfTest.java | 22 +- .../IgniteStartStopRestartTestSuite.java | 8 +- .../storm/IgniteStormStreamerSelfTestSuite.java | 7 +- .../storm/StormIgniteStreamerSelfTest.java | 5 + .../twitter/IgniteTwitterStreamerTest.java | 8 +- .../twitter/IgniteTwitterStreamerTestSuite.java | 6 +- .../GridTaskUriDeploymentDeadlockSelfTest.java | 7 +- .../ignite/p2p/GridP2PDisabledSelfTest.java | 8 + ...loymentClassLoaderMultiThreadedSelfTest.java | 7 +- .../GridUriDeploymentClassLoaderSelfTest.java | 8 +- ...riDeploymentClassloaderRegisterSelfTest.java | 8 +- .../uri/GridUriDeploymentConfigSelfTest.java | 7 +- .../GridUriDeploymentFileProcessorSelfTest.java | 8 + .../uri/GridUriDeploymentMd5CheckSelfTest.java | 6 + ...loymentMultiScannersErrorThrottlingTest.java | 5 + .../GridUriDeploymentMultiScannersSelfTest.java | 7 +- .../uri/GridUriDeploymentSimpleSelfTest.java | 12 +- .../file/GridFileDeploymentSelfTest.java | 11 + .../GridFileDeploymentUndeploySelfTest.java | 7 +- .../http/GridHttpDeploymentSelfTest.java | 6 + .../testsuites/IgniteToolsSelfTestSuite.java | 8 +- .../IgniteUriDeploymentTestSuite.java | 34 +- .../apache/ignite/tools/GridToolsSelfTest.java | 13 +- .../IgniteWebSessionSelfTestSuite.java | 18 +- .../internal/websession/WebSessionSelfTest.java | 16 +- .../org/apache/ignite/IgniteYarnTestSuite.java | 8 +- .../yarn/IgniteApplicationMasterSelfTest.java | 28 +- .../stream/zeromq/IgniteZeroMqStreamerTest.java | 8 + .../zeromq/IgniteZeroMqStreamerTestSuite.java | 6 +- .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java | 12 + ...CacheEntryListenerWithZkDiscoAtomicTest.java | 5 + .../zk/ZookeeperDiscoverySpiTestSuite1.java | 12 +- .../zk/ZookeeperDiscoverySpiTestSuite2.java | 13 +- .../zk/ZookeeperDiscoverySpiTestSuite3.java | 19 +- .../zk/ZookeeperDiscoverySpiTestSuite4.java | 15 +- ...ZookeeperDiscoverySuitePreprocessorTest.java | 5 + .../zk/internal/ZookeeperClientTest.java | 22 + ...ZookeeperDiscoverySpiSaslFailedAuthTest.java | 5 + ...eeperDiscoverySpiSaslSuccessfulAuthTest.java | 6 + .../zk/internal/ZookeeperDiscoverySpiTest.java | 112 +++ 613 files changed, 6980 insertions(+), 1552 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/examples/src/test/java/org/apache/ignite/testsuites/IgniteExamplesSelfTestSuite.java ---------------------------------------------------------------------- diff --git a/examples/src/test/java/org/apache/ignite/testsuites/IgniteExamplesSelfTestSuite.java b/examples/src/test/java/org/apache/ignite/testsuites/IgniteExamplesSelfTestSuite.java index 1c93a4b..7e847d7 100644 --- a/examples/src/test/java/org/apache/ignite/testsuites/IgniteExamplesSelfTestSuite.java +++ b/examples/src/test/java/org/apache/ignite/testsuites/IgniteExamplesSelfTestSuite.java @@ -104,7 +104,7 @@ public class IgniteExamplesSelfTestSuite extends TestSuite { suite.addTest(IgniteExamplesMLTestSuite.suite()); // Encryption. - suite.addTestSuite(EncryptedCacheExampleSelfTest.class); + suite.addTest(new JUnit4TestAdapter(EncryptedCacheExampleSelfTest.class)); return suite; } http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/gridify/AbstractAopTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/gridify/AbstractAopTest.java b/modules/aop/src/test/java/org/apache/ignite/gridify/AbstractAopTest.java index 947ba76..f5f061f 100644 --- a/modules/aop/src/test/java/org/apache/ignite/gridify/AbstractAopTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/gridify/AbstractAopTest.java @@ -33,6 +33,9 @@ import org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder; import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder; import org.apache.ignite.testframework.GridTestClassLoader; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; import static org.apache.ignite.events.EventType.EVT_CLASS_DEPLOYED; import static org.apache.ignite.events.EventType.EVT_TASK_DEPLOYED; @@ -41,6 +44,7 @@ import static org.apache.ignite.events.EventType.EVT_TASK_DEPLOYED; * Abstract AOP test. */ @SuppressWarnings( {"OverlyStrongTypeCast", "ProhibitedExceptionDeclared", "IfMayBeConditional"}) +@RunWith(JUnit4.class) public abstract class AbstractAopTest extends GridCommonAbstractTest { /** */ private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true); @@ -65,6 +69,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultPrivate() throws Exception { checkDefault(DeploymentMode.PRIVATE); } @@ -72,6 +77,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultIsolated() throws Exception { checkDefault(DeploymentMode.ISOLATED); } @@ -79,6 +85,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultContinuous() throws Exception { checkDefault(DeploymentMode.CONTINUOUS); } @@ -86,6 +93,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultShared() throws Exception { checkDefault(DeploymentMode.SHARED); } @@ -93,6 +101,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultWithUserClassLoaderPrivate() throws Exception { checkDefaultWithUserClassLoader(DeploymentMode.PRIVATE); } @@ -100,6 +109,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultWithUserClassLoaderIsolated() throws Exception { checkDefaultWithUserClassLoader(DeploymentMode.ISOLATED); } @@ -107,6 +117,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultWithUserClassLoaderContinuous() throws Exception { checkDefaultWithUserClassLoader(DeploymentMode.CONTINUOUS); } @@ -114,6 +125,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultWithUserClassLoaderShared() throws Exception { checkDefaultWithUserClassLoader(DeploymentMode.SHARED); } @@ -121,6 +133,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testSingleDeploymentWithUserClassLoaderPrivate() throws Exception { checkSingleDeploymentWithUserClassLoader(DeploymentMode.PRIVATE); } @@ -128,6 +141,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testSingleDeploymentWithUserClassLoaderIsolated() throws Exception { checkSingleDeploymentWithUserClassLoader(DeploymentMode.ISOLATED); } @@ -135,6 +149,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testSingleDeploymentWithUserClassLoaderContinuous() throws Exception { checkSingleDeploymentWithUserClassLoader(DeploymentMode.CONTINUOUS); } @@ -142,6 +157,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testSingleDeploymentWithUserClassLoaderShared() throws Exception { checkSingleDeploymentWithUserClassLoader(DeploymentMode.SHARED); } @@ -149,6 +165,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceWithUserClassLoaderPrivate() throws Exception { checkDefaultResourceWithUserClassLoader(DeploymentMode.PRIVATE); } @@ -156,6 +173,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceWithUserClassLoaderIsolated() throws Exception { checkDefaultResourceWithUserClassLoader(DeploymentMode.ISOLATED); } @@ -163,6 +181,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceWithUserClassLoaderContinuous() throws Exception { checkDefaultResourceWithUserClassLoader(DeploymentMode.CONTINUOUS); } @@ -170,6 +189,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceWithUserClassLoaderShared() throws Exception { checkDefaultResourceWithUserClassLoader(DeploymentMode.SHARED); } @@ -177,6 +197,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassPrivate() throws Exception { checkNonDefaultClass(DeploymentMode.PRIVATE); } @@ -184,6 +205,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassIsolated() throws Exception { checkNonDefaultClass(DeploymentMode.ISOLATED); } @@ -191,6 +213,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassContinuous() throws Exception { checkNonDefaultClass(DeploymentMode.CONTINUOUS); } @@ -198,6 +221,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassShared() throws Exception { checkNonDefaultClass(DeploymentMode.SHARED); } @@ -205,6 +229,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNamePrivate() throws Exception { checkNonDefaultName(DeploymentMode.PRIVATE); } @@ -212,6 +237,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameIsolated() throws Exception { checkNonDefaultName(DeploymentMode.ISOLATED); } @@ -219,6 +245,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameContinuous() throws Exception { checkNonDefaultName(DeploymentMode.CONTINUOUS); } @@ -226,6 +253,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameShared() throws Exception { checkNonDefaultName(DeploymentMode.SHARED); } @@ -233,6 +261,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionPrivate() throws Exception { checkDefaultException(DeploymentMode.PRIVATE); } @@ -240,6 +269,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionIsolated() throws Exception { checkDefaultException(DeploymentMode.ISOLATED); } @@ -247,6 +277,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionContinuous() throws Exception { checkDefaultException(DeploymentMode.CONTINUOUS); } @@ -254,6 +285,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionShared() throws Exception { checkDefaultException(DeploymentMode.SHARED); } @@ -261,6 +293,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourcePrivate() throws Exception { checkDefaultResource(DeploymentMode.PRIVATE); } @@ -268,6 +301,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceIsolated() throws Exception { checkDefaultResource(DeploymentMode.ISOLATED); } @@ -275,6 +309,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceContinuous() throws Exception { checkDefaultResource(DeploymentMode.CONTINUOUS); } @@ -282,6 +317,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceShared() throws Exception { checkDefaultResource(DeploymentMode.SHARED); } @@ -289,6 +325,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourcePrivate() throws Exception { checkNonDefaultClassResource(DeploymentMode.PRIVATE); } @@ -296,6 +333,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourceIsolated() throws Exception { checkNonDefaultClassResource(DeploymentMode.ISOLATED); } @@ -303,6 +341,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourceContinuous() throws Exception { checkNonDefaultClassResource(DeploymentMode.CONTINUOUS); } @@ -310,6 +349,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourceShared() throws Exception { checkNonDefaultClassResource(DeploymentMode.SHARED); } @@ -317,6 +357,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourcePrivate() throws Exception { checkNonDefaultNameResource(DeploymentMode.PRIVATE); } @@ -324,6 +365,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourceIsolated() throws Exception { checkNonDefaultNameResource(DeploymentMode.ISOLATED); } @@ -331,6 +373,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourceContinuous() throws Exception { checkNonDefaultNameResource(DeploymentMode.CONTINUOUS); } @@ -338,6 +381,7 @@ public abstract class AbstractAopTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourceShared() throws Exception { checkNonDefaultNameResource(DeploymentMode.SHARED); } http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/gridify/BasicAopSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/gridify/BasicAopSelfTest.java b/modules/aop/src/test/java/org/apache/ignite/gridify/BasicAopSelfTest.java index 54ac74f..024a536 100644 --- a/modules/aop/src/test/java/org/apache/ignite/gridify/BasicAopSelfTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/gridify/BasicAopSelfTest.java @@ -26,6 +26,9 @@ import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import java.util.Collection; import java.util.List; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Tries to execute dummy gridified task. It should fail because grid is not started. @@ -33,10 +36,12 @@ import java.util.List; * The main purpose of this test is to check that AOP is properly configured. It should * be included in all suites that require AOP. */ +@RunWith(JUnit4.class) public class BasicAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If failed. */ + @Test public void testAop() throws Exception { try { gridify(); @@ -71,4 +76,4 @@ public class BasicAopSelfTest extends GridCommonAbstractTest { return null; } } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXNonSpringAopSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXNonSpringAopSelfTest.java b/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXNonSpringAopSelfTest.java index 2ebd272..14a7bff 100644 --- a/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXNonSpringAopSelfTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXNonSpringAopSelfTest.java @@ -25,6 +25,9 @@ import java.util.Iterator; import java.util.List; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import org.apache.ignite.testframework.junits.common.GridCommonTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * To run this test with JBoss AOP make sure of the following: @@ -51,10 +54,12 @@ import org.apache.ignite.testframework.junits.common.GridCommonTest; * 2. Classpath should contains the ${IGNITE_HOME}/modules/tests/config/aop/aspectj folder. */ @GridCommonTest(group="AOP") +@RunWith(JUnit4.class) public class GridifySetToXXXNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If failed. */ + @Test public void testGridifySetToSet() throws Exception { try { startGrid("GridifySetToSetTarget"); @@ -111,6 +116,7 @@ public class GridifySetToXXXNonSpringAopSelfTest extends GridCommonAbstractTest /** * @throws Exception If failed. */ + @Test public void testGridifySetToValue() throws Exception { try { startGrid("GridifySetToValueTarget"); @@ -206,4 +212,4 @@ public class GridifySetToXXXNonSpringAopSelfTest extends GridCommonAbstractTest return iter.next(); } } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXSpringAopSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXSpringAopSelfTest.java b/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXSpringAopSelfTest.java index 1dd499a..7ff56d0 100644 --- a/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXSpringAopSelfTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/gridify/GridifySetToXXXSpringAopSelfTest.java @@ -26,6 +26,9 @@ import java.util.List; import org.apache.ignite.compute.gridify.aop.spring.GridifySpringEnhancer; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import org.apache.ignite.testframework.junits.common.GridCommonTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * To run this test with JBoss AOP make sure of the following: @@ -52,10 +55,12 @@ import org.apache.ignite.testframework.junits.common.GridCommonTest; * 2. Classpath should contains the ${IGNITE_HOME}/modules/tests/config/aop/aspectj folder. */ @GridCommonTest(group="AOP") +@RunWith(JUnit4.class) public class GridifySetToXXXSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If failed. */ + @Test public void testGridifySetToSet() throws Exception { try { startGrid("GridifySetToSetTarget"); @@ -112,6 +117,7 @@ public class GridifySetToXXXSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If failed. */ + @Test public void testGridifySetToValue() throws Exception { try { startGrid("GridifySetToValueTarget"); @@ -207,4 +213,4 @@ public class GridifySetToXXXSpringAopSelfTest extends GridCommonAbstractTest { return iter.next(); } } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/gridify/hierarchy/GridifyHierarchyTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/gridify/hierarchy/GridifyHierarchyTest.java b/modules/aop/src/test/java/org/apache/ignite/gridify/hierarchy/GridifyHierarchyTest.java index 3dc8d53..232d928 100644 --- a/modules/aop/src/test/java/org/apache/ignite/gridify/hierarchy/GridifyHierarchyTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/gridify/hierarchy/GridifyHierarchyTest.java @@ -18,10 +18,14 @@ package org.apache.ignite.gridify.hierarchy; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Gridify hierarchy test. */ +@RunWith(JUnit4.class) public class GridifyHierarchyTest extends GridCommonAbstractTest { /** */ public GridifyHierarchyTest() { @@ -38,6 +42,7 @@ public class GridifyHierarchyTest extends GridCommonAbstractTest { /** * @throws Exception If failed. */ + @Test public void testGridifyHierarchyPrivate() throws Exception { Target target = new Target(); @@ -48,4 +53,4 @@ public class GridifyHierarchyTest extends GridCommonAbstractTest { @Override public String getTestIgniteInstanceName() { return "GridifyHierarchyTest"; } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerAopTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerAopTest.java b/modules/aop/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerAopTest.java index 8236f43..672225f 100644 --- a/modules/aop/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerAopTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/internal/marshaller/optimized/OptimizedMarshallerAopTest.java @@ -26,6 +26,9 @@ import org.apache.ignite.internal.util.typedef.G; import org.apache.ignite.internal.util.typedef.X; import org.apache.ignite.lang.IgnitePredicate; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; import static org.apache.ignite.events.EventType.EVT_TASK_FINISHED; @@ -44,6 +47,7 @@ import static org.apache.ignite.events.EventType.EVT_TASK_FINISHED; * * */ +@RunWith(JUnit4.class) public class OptimizedMarshallerAopTest extends GridCommonAbstractTest { /** */ private static final AtomicInteger cntr = new AtomicInteger(); @@ -71,6 +75,7 @@ public class OptimizedMarshallerAopTest extends GridCommonAbstractTest { * * @throws Exception If failed. */ + @Test public void testUp() throws Exception { G.ignite().events().localListen(new IgnitePredicate() { @Override public boolean apply(Event evt) { @@ -95,4 +100,4 @@ public class OptimizedMarshallerAopTest extends GridCommonAbstractTest { private void gridify1() { X.println("Executes on grid"); } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/p2p/P2PGridifySelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/p2p/P2PGridifySelfTest.java b/modules/aop/src/test/java/org/apache/ignite/p2p/P2PGridifySelfTest.java index 7511d61..42e527c 100644 --- a/modules/aop/src/test/java/org/apache/ignite/p2p/P2PGridifySelfTest.java +++ b/modules/aop/src/test/java/org/apache/ignite/p2p/P2PGridifySelfTest.java @@ -28,12 +28,16 @@ import org.apache.ignite.configuration.IgniteConfiguration; import org.apache.ignite.testframework.GridTestClassLoader; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import org.apache.ignite.testframework.junits.common.GridCommonTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * */ @SuppressWarnings({"ProhibitedExceptionDeclared"}) @GridCommonTest(group = "P2P") +@RunWith(JUnit4.class) public class P2PGridifySelfTest extends GridCommonAbstractTest { /** Current deployment mode. Used in {@link #getConfiguration(String)}. */ private DeploymentMode depMode; @@ -174,6 +178,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testPrivateMode() throws Exception { processTestBothNodesDeploy(DeploymentMode.PRIVATE); } @@ -183,6 +188,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testIsolatedMode() throws Exception { processTestBothNodesDeploy(DeploymentMode.ISOLATED); } @@ -192,6 +198,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testContinuousMode() throws Exception { processTestBothNodesDeploy(DeploymentMode.CONTINUOUS); } @@ -201,6 +208,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testSharedMode() throws Exception { processTestBothNodesDeploy(DeploymentMode.SHARED); } @@ -210,6 +218,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testResourcePrivateMode() throws Exception { processTestGridifyResource(DeploymentMode.PRIVATE); } @@ -219,6 +228,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testResourceIsolatedMode() throws Exception { processTestGridifyResource(DeploymentMode.ISOLATED); } @@ -228,6 +238,7 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testResourceContinuousMode() throws Exception { processTestGridifyResource(DeploymentMode.CONTINUOUS); } @@ -237,7 +248,8 @@ public class P2PGridifySelfTest extends GridCommonAbstractTest { * * @throws Exception if error occur. */ + @Test public void testResourceSharedMode() throws Exception { processTestGridifyResource(DeploymentMode.SHARED); } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java b/modules/aop/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java index b2dcea2..830633c 100644 --- a/modules/aop/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java +++ b/modules/aop/src/test/java/org/apache/ignite/testsuites/IgniteAopSelfTestSuite.java @@ -17,6 +17,7 @@ package org.apache.ignite.testsuites; +import junit.framework.JUnit4TestAdapter; import junit.framework.TestSuite; import org.apache.ignite.gridify.BasicAopSelfTest; import org.apache.ignite.gridify.GridifySetToXXXNonSpringAopSelfTest; @@ -34,23 +35,22 @@ import static org.apache.ignite.IgniteSystemProperties.IGNITE_OVERRIDE_MCAST_GRP public class IgniteAopSelfTestSuite extends TestSuite { /** * @return AOP test suite. - * @throws Exception If failed. */ - public static TestSuite suite() throws Exception { + public static TestSuite suite() { TestSuite suite = new TestSuite("Ignite AOP Test Suite"); // Test configuration. - suite.addTestSuite(BasicAopSelfTest.class); + suite.addTest(new JUnit4TestAdapter(BasicAopSelfTest.class)); - suite.addTestSuite(SpringAopSelfTest.class); - suite.addTestSuite(NonSpringAopSelfTest.class); - suite.addTestSuite(GridifySetToXXXSpringAopSelfTest.class); - suite.addTestSuite(GridifySetToXXXNonSpringAopSelfTest.class); - suite.addTestSuite(ExternalNonSpringAopSelfTest.class); + suite.addTest(new JUnit4TestAdapter(SpringAopSelfTest.class)); + suite.addTest(new JUnit4TestAdapter(NonSpringAopSelfTest.class)); + suite.addTest(new JUnit4TestAdapter(GridifySetToXXXSpringAopSelfTest.class)); + suite.addTest(new JUnit4TestAdapter(GridifySetToXXXNonSpringAopSelfTest.class)); + suite.addTest(new JUnit4TestAdapter(ExternalNonSpringAopSelfTest.class)); // Examples System.setProperty(IGNITE_OVERRIDE_MCAST_GRP, GridTestUtils.getNextMulticastGroup(IgniteAopSelfTestSuite.class)); return suite; } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/loadtests/direct/singlesplit/SingleSplitsLoadTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/loadtests/direct/singlesplit/SingleSplitsLoadTest.java b/modules/aop/src/test/java/org/apache/loadtests/direct/singlesplit/SingleSplitsLoadTest.java index 61429dc..ef76cd8 100644 --- a/modules/aop/src/test/java/org/apache/loadtests/direct/singlesplit/SingleSplitsLoadTest.java +++ b/modules/aop/src/test/java/org/apache/loadtests/direct/singlesplit/SingleSplitsLoadTest.java @@ -31,11 +31,15 @@ import org.apache.ignite.testframework.config.GridTestProperties; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import org.apache.ignite.testframework.junits.common.GridCommonTest; import org.apache.log4j.Level; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Single split load test. */ @GridCommonTest(group = "Load Test") +@RunWith(JUnit4.class) public class SingleSplitsLoadTest extends GridCommonAbstractTest { /** */ public SingleSplitsLoadTest() { @@ -80,6 +84,7 @@ public class SingleSplitsLoadTest extends GridCommonAbstractTest { * * @throws Exception If task execution failed. */ + @Test public void testLoad() throws Exception { final Ignite ignite = G.ignite(getTestIgniteInstanceName()); http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/apache/loadtests/gridify/GridifySingleSplitLoadTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/apache/loadtests/gridify/GridifySingleSplitLoadTest.java b/modules/aop/src/test/java/org/apache/loadtests/gridify/GridifySingleSplitLoadTest.java index 7f4403d..f417c3c 100644 --- a/modules/aop/src/test/java/org/apache/loadtests/gridify/GridifySingleSplitLoadTest.java +++ b/modules/aop/src/test/java/org/apache/loadtests/gridify/GridifySingleSplitLoadTest.java @@ -31,11 +31,15 @@ import org.apache.ignite.testframework.config.GridTestProperties; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import org.apache.ignite.testframework.junits.common.GridCommonTest; import org.apache.log4j.Level; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Gridify single split load test. */ @GridCommonTest(group = "Load Test") +@RunWith(JUnit4.class) public class GridifySingleSplitLoadTest extends GridCommonAbstractTest { /** */ public GridifySingleSplitLoadTest() { @@ -97,6 +101,7 @@ public class GridifySingleSplitLoadTest extends GridCommonAbstractTest { * * @throws Exception If task execution failed. */ + @Test public void testGridifyLoad() throws Exception { Ignite ignite = G.ignite(getTestIgniteInstanceName()); http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aop/src/test/java/org/test/gridify/ExternalNonSpringAopSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aop/src/test/java/org/test/gridify/ExternalNonSpringAopSelfTest.java b/modules/aop/src/test/java/org/test/gridify/ExternalNonSpringAopSelfTest.java index 9428208..c5d3e28 100644 --- a/modules/aop/src/test/java/org/test/gridify/ExternalNonSpringAopSelfTest.java +++ b/modules/aop/src/test/java/org/test/gridify/ExternalNonSpringAopSelfTest.java @@ -25,6 +25,9 @@ import org.apache.ignite.internal.util.typedef.G; import org.apache.ignite.spi.deployment.local.LocalDeploymentSpi; import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest; import org.apache.ignite.testframework.junits.common.GridCommonTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * To run this test with JBoss AOP make sure of the following: @@ -51,6 +54,7 @@ import org.apache.ignite.testframework.junits.common.GridCommonTest; * 2. Classpath should contains the ${IGNITE_HOME}/modules/tests/config/aop/aspectj folder. */ @GridCommonTest(group="AOP") +@RunWith(JUnit4.class) public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** */ private DeploymentMode depMode = DeploymentMode.PRIVATE; @@ -78,6 +82,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultPrivate() throws Exception { checkDefault(DeploymentMode.PRIVATE); } @@ -85,6 +90,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultIsolated() throws Exception { checkDefault(DeploymentMode.ISOLATED); } @@ -92,6 +98,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultContinuous() throws Exception { checkDefault(DeploymentMode.CONTINUOUS); } @@ -99,6 +106,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultShared() throws Exception { checkDefault(DeploymentMode.SHARED); } @@ -106,6 +114,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassPrivate() throws Exception { checkNonDefaultClass(DeploymentMode.PRIVATE); } @@ -113,6 +122,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassIsolated() throws Exception { checkNonDefaultClass(DeploymentMode.ISOLATED); } @@ -120,6 +130,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultContinuous() throws Exception { checkNonDefaultClass(DeploymentMode.CONTINUOUS); } @@ -127,6 +138,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultShared() throws Exception { checkNonDefaultClass(DeploymentMode.SHARED); } @@ -134,6 +146,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNamePrivate() throws Exception { checkNonDefaultName(DeploymentMode.PRIVATE); } @@ -141,6 +154,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameIsolated() throws Exception { checkNonDefaultName(DeploymentMode.ISOLATED); } @@ -148,6 +162,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameContinuous() throws Exception { checkNonDefaultName(DeploymentMode.CONTINUOUS); } @@ -155,6 +170,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameShared() throws Exception { checkNonDefaultName(DeploymentMode.SHARED); } @@ -162,6 +178,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testTaskNameAndTaskClassPrivate() throws Exception { checkTaskNameAndTaskClass(DeploymentMode.PRIVATE); } @@ -169,6 +186,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testTaskNameAndTaskClassIsolated() throws Exception { checkTaskNameAndTaskClass(DeploymentMode.ISOLATED); } @@ -176,6 +194,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testTaskNameAndTaskClassContinuous() throws Exception { checkTaskNameAndTaskClass(DeploymentMode.CONTINUOUS); } @@ -183,6 +202,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testTaskNameAndTaskClassShared() throws Exception { checkTaskNameAndTaskClass(DeploymentMode.SHARED); } @@ -190,6 +210,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionPrivate() throws Exception { checkDefaultException(DeploymentMode.PRIVATE); } @@ -197,6 +218,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionIsolated() throws Exception { checkDefaultException(DeploymentMode.ISOLATED); } @@ -204,6 +226,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionContinuous() throws Exception { checkDefaultException(DeploymentMode.CONTINUOUS); } @@ -211,6 +234,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultExceptionShared() throws Exception { checkDefaultException(DeploymentMode.SHARED); } @@ -218,6 +242,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourcePrivate() throws Exception { checkDefaultResource(DeploymentMode.PRIVATE); } @@ -225,6 +250,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceIsolated() throws Exception { checkDefaultResource(DeploymentMode.ISOLATED); } @@ -232,6 +258,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceContinuous() throws Exception { checkDefaultResource(DeploymentMode.CONTINUOUS); } @@ -239,6 +266,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testDefaultResourceShared() throws Exception { checkDefaultResource(DeploymentMode.SHARED); } @@ -246,6 +274,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourcePrivate() throws Exception { checkNonDefaultClassResource(DeploymentMode.PRIVATE); } @@ -253,6 +282,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourceIsolated() throws Exception { checkNonDefaultClassResource(DeploymentMode.ISOLATED); } @@ -260,6 +290,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourceContinuous() throws Exception { checkNonDefaultClassResource(DeploymentMode.CONTINUOUS); } @@ -267,6 +298,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultClassResourceShared() throws Exception { checkNonDefaultClassResource(DeploymentMode.SHARED); } @@ -274,6 +306,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourcePrivate() throws Exception { checkNonDefaultNameResource(DeploymentMode.PRIVATE); } @@ -281,6 +314,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourceIsolated() throws Exception { checkNonDefaultNameResource(DeploymentMode.ISOLATED); } @@ -288,6 +322,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourceContinuous() throws Exception { checkNonDefaultNameResource(DeploymentMode.CONTINUOUS); } @@ -295,6 +330,7 @@ public class ExternalNonSpringAopSelfTest extends GridCommonAbstractTest { /** * @throws Exception If test failed. */ + @Test public void testNonDefaultNameResourceShared() throws Exception { checkNonDefaultNameResource(DeploymentMode.SHARED); } http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java index acda385..7816e7b 100644 --- a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java +++ b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointManagerSelfTest.java @@ -23,10 +23,14 @@ import org.apache.ignite.configuration.IgniteConfiguration; import org.apache.ignite.internal.managers.checkpoint.GridCheckpointManagerAbstractSelfTest; import org.apache.ignite.testsuites.IgniteIgnore; import org.apache.ignite.testsuites.IgniteS3TestSuite; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Checkpoint manager test using {@link S3CheckpointSpi}. */ +@RunWith(JUnit4.class) public class S3CheckpointManagerSelfTest extends GridCheckpointManagerAbstractSelfTest { /** {@inheritDoc} */ @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception { @@ -52,6 +56,7 @@ public class S3CheckpointManagerSelfTest extends GridCheckpointManagerAbstractSe * @throws Exception Thrown if any exception occurs. */ @IgniteIgnore("https://issues.apache.org/jira/browse/IGNITE-2420") + @Test public void testS3Based() throws Exception { retries = 6; @@ -62,9 +67,10 @@ public class S3CheckpointManagerSelfTest extends GridCheckpointManagerAbstractSe * @throws Exception Thrown if any exception occurs. */ @IgniteIgnore("https://issues.apache.org/jira/browse/IGNITE-2420") + @Test public void testMultiNodeS3Based() throws Exception { retries = 6; doMultiNodeTest("s3"); } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiConfigSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiConfigSelfTest.java b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiConfigSelfTest.java index 727845b..446c715 100644 --- a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiConfigSelfTest.java +++ b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiConfigSelfTest.java @@ -19,16 +19,21 @@ package org.apache.ignite.spi.checkpoint.s3; import org.apache.ignite.testframework.junits.spi.GridSpiAbstractConfigTest; import org.apache.ignite.testframework.junits.spi.GridSpiTest; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Grid S3 checkpoint SPI config self test. */ @GridSpiTest(spi = S3CheckpointSpi.class, group = "Checkpoint SPI") +@RunWith(JUnit4.class) public class S3CheckpointSpiConfigSelfTest extends GridSpiAbstractConfigTest { /** * @throws Exception If failed. */ + @Test public void testNegativeConfig() throws Exception { checkNegativeSpiProperty(new S3CheckpointSpi(), "awsCredentials", null); } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java index cb38083..a25b5be 100644 --- a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java +++ b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiSelfTest.java @@ -39,11 +39,15 @@ import org.apache.ignite.testframework.junits.spi.GridSpiAbstractTest; import org.apache.ignite.testframework.junits.spi.GridSpiTest; import org.apache.ignite.testsuites.IgniteIgnore; import org.apache.ignite.testsuites.IgniteS3TestSuite; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Grid S3 checkpoint SPI self test. */ @GridSpiTest(spi = S3CheckpointSpi.class, group = "Checkpoint SPI") +@RunWith(JUnit4.class) public class S3CheckpointSpiSelfTest extends GridSpiAbstractTest { /** */ private static final int CHECK_POINT_COUNT = 10; @@ -96,6 +100,7 @@ public class S3CheckpointSpiSelfTest extends GridSpiAbstractTest { - /** {@inheritDoc} */ @Override protected void spiConfigure(S3CheckpointSpi spi) throws Exception { AWSCredentials cred = new BasicAWSCredentials(IgniteS3TestSuite.getAccessKey(), @@ -43,8 +46,9 @@ public class S3CheckpointSpiStartStopBucketEndpointSelfTest extends GridSpiStart } /** {@inheritDoc} */ - @IgniteIgnore("https://issues.apache.org/jira/browse/IGNITE-2420") + @Ignore("https://issues.apache.org/jira/browse/IGNITE-2420") + @Test @Override public void testStartStop() throws Exception { super.testStartStop(); } -} \ No newline at end of file +} http://git-wip-us.apache.org/repos/asf/ignite/blob/c5197e0a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java ---------------------------------------------------------------------- diff --git a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java index 7bfb75d..cf44952 100644 --- a/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java +++ b/modules/aws/src/test/java/org/apache/ignite/spi/checkpoint/s3/S3CheckpointSpiStartStopSSEAlgorithmSelfTest.java @@ -21,13 +21,17 @@ import com.amazonaws.auth.AWSCredentials; import com.amazonaws.auth.BasicAWSCredentials; import org.apache.ignite.spi.GridSpiStartStopAbstractTest; import org.apache.ignite.testframework.junits.spi.GridSpiTest; -import org.apache.ignite.testsuites.IgniteIgnore; import org.apache.ignite.testsuites.IgniteS3TestSuite; +import org.junit.Ignore; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.junit.runners.JUnit4; /** * Grid S3 checkpoint SPI start stop self test. */ @GridSpiTest(spi = S3CheckpointSpi.class, group = "Checkpoint SPI") +@RunWith(JUnit4.class) public class S3CheckpointSpiStartStopSSEAlgorithmSelfTest extends GridSpiStartStopAbstractTest { /** {@inheritDoc} */ @Override protected void spiConfigure(S3CheckpointSpi spi) throws Exception { @@ -42,8 +46,9 @@ public class S3CheckpointSpiStartStopSSEAlgorithmSelfTest extends GridSpiStartSt } /** {@inheritDoc} */ - @IgniteIgnore("https://issues.apache.org/jira/browse/IGNITE-2420") + @Ignore("https://issues.apache.org/jira/browse/IGNITE-2420") + @Test @Override public void testStartStop() throws Exception { super.testStartStop(); } -} \ No newline at end of file +}