rkhachatryan commented on code in PR #27070:
URL: https://github.com/apache/flink/pull/27070#discussion_r2452541762


##########
flink-test-utils-parent/flink-test-utils/src/main/java/org/apache/flink/streaming/util/TestStreamEnvironment.java:
##########
@@ -206,6 +208,13 @@ private static void randomizeConfiguration(MiniCluster 
miniCluster, Configuratio
                 
ConfigOptions.key("table.exec.unbounded-over.version").intType().noDefaultValue(),
                 1,
                 2);
+        randomize(
+                conf,
+                TABLE_EXEC_SINK_UPSERT_MATERIALIZE_STRATEGY,
+                ExecutionConfigOptions.SinkUpsertMaterializeStrategy.LEGACY,
+                ExecutionConfigOptions.SinkUpsertMaterializeStrategy.VALUE,
+                ExecutionConfigOptions.SinkUpsertMaterializeStrategy.MAP,
+                ExecutionConfigOptions.SinkUpsertMaterializeStrategy.ADAPTIVE);

Review Comment:
   ```
   org.apache.flink.table.planner.runtime.stream.sql.AsyncLookupJoinITCase
   org.apache.flink.table.planner.runtime.stream.sql.ChangelogSourceITCase
   org.apache.flink.table.planner.runtime.stream.sql.DataStreamJavaITCase
   org.apache.flink.table.planner.runtime.stream.sql.OverAggregateITCase
   org.apache.flink.table.planner.runtime.stream.sql.RankITCase
   org.apache.flink.table.planner.runtime.stream.sql.TableSinkITCase
   org.apache.flink.table.planner.runtime.stream.sql.TemporalJoinITCase
   org.apache.flink.table.planner.runtime.stream.table.AggregateITCase
   org.apache.flink.table.runtime.operators.bundle.MapBundleOperatorTest
   
org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTriggerTest
   org.apache.flink.table.runtime.operators.join.RandomSortMergeInnerJoinTest
   org.apache.flink.table.runtime.operators.join.String2HashJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.String2SortMergeJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.String2SortMergeJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.interval.RowTimeIntervalJoinTest
   
org.apache.flink.table.runtime.operators.join.lookup.TableKeyedAsyncWaitOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.StreamingMiniBatchJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.StreamingSemiAntiJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingFourWayMixedInnerJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingFourWayMixedOuterJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingMultiConditionJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingThreeWayJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingThreeWayOuterJoinCustomConditionOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingThreeWayOuterJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingTwoWayInnerMultiJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingTwoWayJoinNoUniqueKeyOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingTwoWayNonEquiJoinOperatorTest
   
org.apache.flink.table.runtime.operators.join.stream.multijoin.StreamingTwoWayOuterMultiJoinOperatorTest
   
org.apache.flink.table.runtime.operators.sink.SinkUpsertMaterializerMigrationTest
   
org.apache.flink.table.runtime.operators.sink.SinkUpsertMaterializerRescalingTest
   org.apache.flink.table.runtime.operators.sink.SinkUpsertMaterializerTest
   
   ```



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: [email protected]

For queries about this service, please contact Infrastructure at:
[email protected]

Reply via email to