Skip to content

Commit

Permalink
Enable streaming runner v2 tests that were forgotten to be enabled. (a…
Browse files Browse the repository at this point in the history
…pache#24321)

* Enable streaming runner v2 tests that were forgotten to be enabled.

These tests are run internally on Google and have been passing for quite some time.

Fixes apache#19957
Fixes apache#20726
Fixes apache#20601
Fixes apache#20734

* Explicitly enable streaming engine for runner based autosharding test
  • Loading branch information
lukecwik authored Nov 24, 2022
1 parent 23e59af commit 3b7e181
Showing 1 changed file with 9 additions and 49 deletions.
58 changes: 9 additions & 49 deletions runners/google-cloud-dataflow-java/build.gradle
Original file line number Diff line number Diff line change
Expand Up @@ -166,8 +166,7 @@ def runnerV2PipelineOptions = [
"--region=${dataflowRegion}",
"--tempRoot=${dataflowValidatesTempRoot}",
"--sdkContainerImage=${dockerJavaImageContainer}:${dockerTag}",
// TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
"--experiments=use_unified_worker,use_runner_v2,shuffle_mode=appliance",
"--experiments=use_unified_worker,use_runner_v2",
"--firestoreDb=${firestoreDb}",
]

Expand Down Expand Up @@ -388,7 +387,7 @@ task validatesRunnerStreaming {
description "Validates Dataflow runner forcing streaming mode"
dependsOn(createLegacyWorkerValidatesRunnerTest(
name: 'validatesRunnerLegacyWorkerTestStreaming',
pipelineOptions: legacyPipelineOptions + ['--streaming=true'],
pipelineOptions: legacyPipelineOptions + ['--streaming'],
excludedCategories: [
'org.apache.beam.sdk.testing.UsesCommittedMetrics',
'org.apache.beam.sdk.testing.UsesMapState',
Expand Down Expand Up @@ -463,6 +462,8 @@ task validatesRunnerV2 {
description = "Runs the ValidatesRunner tests on Dataflow Runner V2"
dependsOn(createRunnerV2ValidatesRunnerTest(
name: 'validatesRunnerV2Test',
// TODO(https://github.com/apache/beam/issues/20806) remove shuffle_mode=appliance with runner v2 once issue is resolved.
pipelineOptions: runnerV2PipelineOptions + ['--experiments=shuffle_mode=appliance'],
excludedCategories: [
'org.apache.beam.sdk.testing.UsesOnWindowExpiration',
'org.apache.beam.sdk.testing.UsesStatefulParDo',
Expand All @@ -473,6 +474,7 @@ task validatesRunnerV2 {
excludedTests: [
'org.apache.beam.sdk.transforms.ReshuffleTest.testReshuffleWithTimestampsStreaming',

// TODO(https://github.com/apache/beam/issues/18592): respect ParDo lifecycle.
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testFnCallSequenceStateful',
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testTeardownCalledAfterExceptionInFinishBundle',
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testTeardownCalledAfterExceptionInFinishBundleStateful',
Expand Down Expand Up @@ -500,55 +502,20 @@ task validatesRunnerV2Streaming {
description = "Runs the ValidatesRunner tests on Dataflow Runner V2 forcing streaming mode"
dependsOn(createRunnerV2ValidatesRunnerTest(
name: 'validatesRunnerV2TestStreaming',
pipelineOptions: runnerV2PipelineOptions + ['--streaming=true'],
pipelineOptions: runnerV2PipelineOptions + ['--streaming', '--experiments=enable_streaming_engine'],
excludedCategories: [
'org.apache.beam.sdk.testing.LargeKeys$Above10KB',
'org.apache.beam.sdk.testing.UsesBoundedSplittableParDo',
'org.apache.beam.sdk.testing.UsesCommittedMetrics',
'org.apache.beam.sdk.testing.UsesStrictTimerOrdering' /* https://github.com/apache/beam/issues/19957 */,
'org.apache.beam.sdk.testing.UsesOnWindowExpiration',
],
excludedTests: [
'org.apache.beam.sdk.transforms.windowing.WindowTest.testMergingCustomWindows',
'org.apache.beam.sdk.transforms.windowing.WindowTest.testMergingCustomWindowsKeyedCollection',
'org.apache.beam.sdk.transforms.windowing.WindowTest.testMergingCustomWindowsWithoutCustomWindowTypes',
'org.apache.beam.examples.complete.TopWikipediaSessionsTest.testComputeTopUsers',
'org.apache.beam.sdk.transforms.windowing.WindowingTest.testNonPartitioningWindowing',

'org.apache.beam.sdk.io.AvroIOTest.testWriteWindowed',
'org.apache.beam.sdk.io.AvroIOTest.testWindowedAvroIOWriteViaSink',
'org.apache.beam.sdk.extensions.sql.BeamSqlDslAggregationTest.testTriggeredTumble',
// TestStream only (partially) supported on UW
'org.apache.beam.sdk.transforms.ReshuffleTest.testReshuffleWithTimestampsStreaming',

// TODO(https://github.com/apache/beam/issues/20726) reading a side input twice fails
'org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests.testSameSideInputReadTwice',
'org.apache.beam.sdk.transforms.CombineFnsTest.testComposedCombineWithContext',
'org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests.testSimpleCombineWithContextEmpty',
'org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests.testSimpleCombineWithContext',
'org.apache.beam.sdk.transforms.CombineTest$WindowingTests.testFixedWindowsCombineWithContext',
'org.apache.beam.sdk.transforms.CombineTest$WindowingTests.testSessionsCombineWithContext',
'org.apache.beam.sdk.transforms.CombineTest$WindowingTests.testSlidingWindowsCombineWithContext',

'org.apache.beam.runners.dataflow.DataflowRunnerTest.testBatchGroupIntoBatchesOverride',

// TestStream with processing time control not supported
'org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests.testAfterProcessingTimeContinuationTriggerUsingState',
'org.apache.beam.sdk.transforms.GroupByKeyTest.testCombiningAccumulatingProcessingTime',

// TODO(https://github.com/apache/beam/issues/20601): Pipeline is hanging for these 3 tests.
'org.apache.beam.sdk.transforms.SplittableDoFnTest.testPairWithIndexBasicUnbounded',
'org.apache.beam.sdk.transforms.SplittableDoFnTest.testOutputAfterCheckpointUnbounded',
'org.apache.beam.sdk.transforms.SplittableDoFnTest.testBundleFinalizationOccursOnUnboundedSplittableDoFn',

'org.apache.beam.sdk.transforms.ParDoTest$TimerTests.testEventTimeTimerAlignAfterGcTimeUnbounded',

'org.apache.beam.sdk.metrics.MetricsTest$CommittedMetricTests.testCommittedCounterMetrics',

'org.apache.beam.sdk.transforms.WaitTest.testWaitWithSameFixedWindows',
'org.apache.beam.sdk.transforms.WaitTest.testWaitWithDifferentFixedWindows',
'org.apache.beam.sdk.transforms.WaitTest.testWaitWithSignalInSlidingWindows',
'org.apache.beam.sdk.transforms.WaitTest.testWaitInGlobalWindow',
'org.apache.beam.sdk.transforms.WaitTest.testWaitBoundedInDefaultWindow',
'org.apache.beam.sdk.transforms.WaitTest.testWaitWithSomeSignalWindowsEmpty',

// TODO(https://github.com/apache/beam/issues/18592): respect ParDo lifecycle.
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testTeardownCalledAfterExceptionInFinishBundle',
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testTeardownCalledAfterExceptionInFinishBundleStateful',
Expand All @@ -559,13 +526,6 @@ task validatesRunnerV2Streaming {
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testTeardownCalledAfterExceptionInStartBundle',
'org.apache.beam.sdk.transforms.ParDoLifecycleTest.testTeardownCalledAfterExceptionInStartBundleStateful',

// TODO(https://github.com/apache/beam/issues/20734) Empty flatten fails in streaming
"org.apache.beam.sdk.transforms.FlattenTest.testEmptyFlattenAsSideInput",
"org.apache.beam.sdk.transforms.FlattenTest.testFlattenPCollectionsEmptyThenParDo",
"org.apache.beam.sdk.transforms.FlattenTest.testFlattenPCollectionsEmpty",

'org.apache.beam.sdk.io.CountingSourceTest.testBoundedSourceSplits',

// TODO(https://github.com/apache/beam/issues/20931): Identify whether it's bug or a feature gap.
'org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests.testRewindowWithTimestampCombiner',

Expand Down

0 comments on commit 3b7e181

Please sign in to comment.