Uploaded image for project: 'Oozie'
  1. Oozie
  2. OOZIE-3111

[Umbrella] Fix flaky tests in Oozie

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Open
    • Major
    • Resolution: Unresolved
    • None
    • None
    • tests
    • None

    Description

      In Oozie, we've had a number or flaky tests for quite a while. In order to have successful builds, we circumvented the problem by re-running failed tests. But this is not a good long-term solution.

      This JIRA tracks the tests that are currently flaky. We should address each of these tests to have stable builds.

      Attachments

        1.
        org.apache.oozie.tools.TestDBLoadDump#testImportInvalidDataLeavesTablesEmpty is flaky Sub-task Resolved Unassigned
        2.
        org.apache.oozie.action.hadoop.TestHiveMain#testMain is flaky Sub-task Closed Artem Ervits
        3.
        testJMXInstrumentation from the org.apache.oozie.util.TestMetricsInstrumentation class is flaky Sub-task Reopened Peter Bacsko
        4.
        Flaky test due to daylight saving changes Sub-task Closed Andras Piros
        5.
        Remove test case TestPartitionDependencyManagerEhcache.testMemoryUsageAndSpeedOverflowToDisk and testMemoryUsageAndSpeed Sub-task Closed Peter Bacsko
        6.
        TestJavaActionExecutor.testCredentialsSkip fails intermittently Sub-task Closed Peter Bacsko
        7.
        [tools] TestOozieDBCLI#testOozieDBCLI() fails Sub-task Closed Peter Bacsko
        8.
        Fix flaky test TestHiveActionExecutor#testHiveAction Sub-task Closed Peter Bacsko
        9.
        Flaky test TestJMSAccessorService#testConnectionRetryExceptionListener Sub-task Closed Peter Bacsko
        10.
        Flaky test TestJMSAccessorService#testConnectionRetry Sub-task Closed Peter Bacsko
        11.
        Flaky test TestRecoveryService#testCoordActionRecoveryServiceForWaitingRegisterPartition Sub-task Closed Peter Bacsko
        12.
        Flaky test TestBundleChangeXCommand#testBundlePauseExtendMaterializesCoordinator Sub-task Open Peter Bacsko
        13.
        Flaky test TestXCommand#testXCommandLifecycleLockingFailingToLock Sub-task Closed Peter Bacsko
        14.
        Flaky test TestJMSJobEventListener#testConnectionDrop Sub-task Closed Peter Bacsko
        15.
        Flaky test TestZKLocksService#testWriteReadLockThreads Sub-task Closed Peter Bacsko
        16.
        TestStatusTransitService.testBundleStatusCoordSubmitFails fails intermittently in Apache Oozie Core 5.0.0-SNAPSHOT Sub-task Closed Peter Bacsko
        17.
        Flaky test TestStatusTransitService#testBundleStatusTransitWithLock Sub-task Closed Peter Bacsko
        18.
        TestCoordActionInputCheckXCommand.testNone is flakey Sub-task Open Peter Bacsko
        19.
        [tests] Flaky test TestCoordActionsKillXCommand#testActionKillCommandDate Sub-task Closed Andras Salamon
        20.
        Flaky test TestCoordActionsKillXCommand#testActionKillCommandActionNumbers Sub-task Open Unassigned
        21.
        Disable JMX for ActiveMQ in the tests Sub-task Closed Peter Bacsko
        22.
        Flaky TestPurgeXCommand methods Sub-task Open Peter Bacsko
        23.
        Flaky test TestStatusTransitService#testCoordStatusTransitWithLock Sub-task Closed Peter Bacsko
        24.
        TestHive2ActionExecutor.testHive2Action is flaky Sub-task Open Unassigned
        25.
        TestCoordActionInputCheckXCommand.testCoordActionInputCheckXCommandUniqueness() is flaky Sub-task Patch Available Unassigned
        26.
        TestPriorityDelayQueue#testPoll failed intermittently in Jenkins Sub-task Closed Ostap
        27.
        Few testcases of TestStatusTransitService are failing Sub-task Resolved Unassigned
        28.
        TestHiveActionExecutor#testHiveAction still fails Sub-task Closed Peter Bacsko
        29.
        Flaky test TestZKUtilsWithSecurity#testNewUsingACLs Sub-task Open Unassigned
        30.
        Flaky test TestZKUUIDService#testResetSequence_withMultiThread Sub-task Open Peter Bacsko
        31.
        Flaky test TestCoordMaterializeTransitionXCommand#testLastOnlyMaterialization Sub-task Closed Andras Salamon
        32.
        Derby DB is used in some tests which might lead to "Too many open files" Sub-task Open Peter Bacsko
        33.
        Flaky tests in TestCoordMaterializeTriggerService class Sub-task Closed Peter Bacsko
        34.
        Flaky tests in TestCoordInputLogicPush class Sub-task Open Unassigned
        35.
        Flaky test TestCoordActionInputCheckXCommand#testActionInputCheckLatestActionCreationTimeWithPushDependency Sub-task Open Unassigned
        36.
        TestJMSAccessorService#testConnectionRetry is still flaky Sub-task Closed Peter Bacsko
        37.
        Test TestJMSAccessorService#testConnectionRetryExceptionListener is still flaky Sub-task Closed Peter Bacsko
        38.
        Flaky test TestSLACalculatorMemory#testAddMultipleRestartRemoveMultipleInstrumentedCorrectly Sub-task Closed Peter Bacsko
        39.
        Make sure that Derby is shut down after each testcase Sub-task Open Peter Bacsko
        40.
        TestConcurrentCopyFromLocal is flaky Sub-task Resolved Kinga Marton
        41.
        [tests] Flaky test TestMemoryLocks#testWriteLockSameThreadNoWait() Sub-task Closed Peter Bacsko
        42.
        [tests] TestCallableQueueService#testPriorityExecutionOrder() is flaky Sub-task Closed Peter Bacsko
        43.
        TestSubWorkflowActionExecutor#testSubWorkflowRerun() is flaky Sub-task Closed Andras Piros
        44.
        [tests] TestWorkflowActionRetryInfoXCommand#testRetryConsoleUrlForked() is flaky Sub-task Closed Andras Salamon
        45.
        TestAbandonedCoordChecker.testMessage_withMixedStatus is flaky Sub-task Resolved Purshotam Shah
        46.
        TestBulkWorkflowXCommand.testbulkWfKillSuccess is flaky Sub-task Closed Andras Salamon
        47.
        TestOozieCLI testRetryWithRetryCount and testRetryForTimeout is flaky Sub-task Closed Andras Salamon
        48.
        Flaky tests based on WorkflowTestCase Sub-task Closed Andras Salamon
        49.
        Flaky test TestOozieRollingPolicy Sub-task Closed Andras Salamon
        50.
        Flaky test TestActionStartXCommand.testActionWithEscapedStringAndCDATA Sub-task Open Unassigned
        51.
        Flaky test TestXLogService.testLog4jReload Sub-task Closed Andras Salamon
        52.
        Eliminate Thread.sleep() calls from TestCoordPushDependencyCheckXCommand Sub-task Open Peter Bacsko
        53.
        Fix TestJMSJobEventListener#testConnectionDrop flakiness (again) Sub-task Resolved Dénes Bodó

        Activity

          People

            Unassigned Unassigned
            pbacsko Peter Bacsko
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated: