Path Lines of Code README.md 147 flink-architecture-tests/README.md 50 flink-architecture-tests/flink-architecture-tests-production/README.md 21 flink-architecture-tests/flink-architecture-tests-production/src/test/resources/archunit.properties 31 flink-architecture-tests/flink-architecture-tests-production/src/test/resources/log4j2-test.properties 26 flink-architecture-tests/flink-architecture-tests-test/README.md 47 flink-architecture-tests/flink-architecture-tests-test/src/test/resources/archunit.properties 31 flink-architecture-tests/flink-architecture-tests-test/src/test/resources/log4j2-test.properties 26 flink-clients/src/test/resources/log4j2-test.properties 26 flink-connectors/flink-connector-base/src/main/resources/log4j2.properties 23 flink-connectors/flink-connector-base/src/test/resources/archunit.properties 31 flink-connectors/flink-connector-base/src/test/resources/log4j2-test.properties 26 flink-connectors/flink-connector-datagen-test/src/test/resources/archunit.properties 27 flink-connectors/flink-connector-datagen-test/src/test/resources/log4j2-test.properties 26 flink-connectors/flink-connector-datagen/src/main/resources/log4j2.properties 23 flink-connectors/flink-connector-files/src/test/resources/archunit.properties 27 flink-connectors/flink-connector-files/src/test/resources/log4j2-test.properties 26 flink-connectors/flink-file-sink-common/src/test/resources/log4j2-test.properties 26 flink-connectors/flink-hadoop-compatibility/src/test/resources/archunit.properties 27 flink-connectors/flink-hadoop-compatibility/src/test/resources/log4j2-test.properties 28 flink-container/src/test/resources/log4j2-test.properties 26 flink-core/src/test/resources/archunit.properties 27 flink-core/src/test/resources/log4j2-test.properties 28 flink-datastream/src/test/resources/log4j2-test.properties 28 flink-dist-scala/src/main/resources/META-INF/licenses/LICENSE.scala 8 flink-dist/src/main/flink-bin/README.txt 24 flink-dist/src/main/flink-bin/conf/log4j-cli.properties 58 flink-dist/src/main/flink-bin/conf/log4j-console.properties 63 flink-dist/src/main/flink-bin/conf/log4j-session.properties 38 flink-dist/src/main/flink-bin/conf/log4j.properties 55 flink-dist/src/main/flink-bin/plugins/README.txt 16 flink-dist/src/main/resources/log4j-bash-utils.properties 24 flink-dist/src/test/resources/log4j2-test.properties 26 flink-docs/README.md 36 flink-docs/src/main/resources/log4j.properties 22 flink-dstl/flink-dstl-dfs/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/README.md 49 flink-end-to-end-tests/flink-batch-sql-test/src/test/resources/log4j2-test.properties 30 flink-end-to-end-tests/flink-end-to-end-tests-common/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/flink-end-to-end-tests-restclient/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/flink-end-to-end-tests-scala/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/flink-end-to-end-tests-sql/src/test/resources/log4j2-test.properties 31 flink-end-to-end-tests/flink-metrics-availability-test/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/flink-metrics-reporter-prometheus-test/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/flink-parent-child-classloading-test-lib-package/src/main/resources/parent-child-test.properties 18 flink-end-to-end-tests/flink-parent-child-classloading-test-program/src/main/resources/parent-child-test.properties 18 flink-end-to-end-tests/flink-sql-client-test/src/test/resources/log4j2-test.properties 31 flink-end-to-end-tests/flink-sql-gateway-test/src/test/resources/log4j2-test.properties 26 flink-end-to-end-tests/flink-tpcds-test/README.md 9 flink-end-to-end-tests/flink-tpcds-test/tpcds-tool/README.md 33 flink-end-to-end-tests/test-scripts/docker-hadoop-secure-cluster/README.md 70 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/async/AsyncClient.java 21 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/async/AsyncIOExample.java 80 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/datagen/DataGenerator.java 25 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/datagen/DataGeneratorPerCheckpoint.java 29 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/dsv2/eventtime/CountNewsClicks.java 184 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/dsv2/join/Join.java 127 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/dsv2/watermark/CountSales.java 164 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/dsv2/windowing/CountProductSalesWindowing.java 114 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/dsv2/wordcount/WordCount.java 118 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/gpu/MatrixVectorMul.java 139 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/join/WindowJoin.java 108 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/join/WindowJoinSampleData.java 33 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/sideoutput/SideOutputExample.java 130 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/socket/SocketWindowWordCount.java 67 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/README.md 38 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/StateMachineExample.java 164 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/dfa/EventTypeAndState.java 10 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/dfa/State.java 53 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/dfa/Transition.java 46 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/event/Alert.java 49 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/event/Event.java 42 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/event/EventType.java 10 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/generator/EventsGenerator.java 75 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/generator/EventsGeneratorFunction.java 29 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/generator/StandaloneThreadedGenerator.java 154 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/kafka/EventDeSerializationSchema.java 35 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/statemachine/kafka/KafkaStandaloneGenerator.java 51 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/utils/ThrottledIterator.java 58 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/GroupedProcessingTimeWindowExample.java 104 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/SessionWindowing.java 76 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/TopSpeedWindowing.java 124 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/WindowWordCount.java 73 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/util/CarGeneratorFunction.java 44 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/util/SessionWindowingData.java 6 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/windowing/util/TopSpeedWindowingExampleData.java 349 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/wordcount/WordCount.java 83 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/wordcount/util/CLI.java 120 flink-examples/flink-examples-streaming/src/main/java/org/apache/flink/streaming/examples/wordcount/util/WordCountData.java 41 flink-examples/flink-examples-streaming/src/main/resources/log4j2.properties 23 flink-examples/flink-examples-streaming/src/test/java/org/apache/flink/streaming/test/examples/DSv2ExamplesITCase.java 60 flink-examples/flink-examples-streaming/src/test/java/org/apache/flink/streaming/test/examples/join/WindowJoinData.java 206 flink-examples/flink-examples-streaming/src/test/java/org/apache/flink/streaming/test/examples/windowing/TopSpeedWindowingExampleITCase.java 38 flink-examples/flink-examples-streaming/src/test/resources/log4j2-test.properties 26 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/basics/GettingStartedExample.java 150 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/basics/StreamSQLExample.java 57 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/basics/StreamWindowSQLExample.java 50 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/basics/TemporalJoinSQLExample.java 119 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/basics/UpdatingTopCityExample.java 101 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/basics/WordCountSQLExample.java 18 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/ChangelogCsvDeserializer.java 60 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/ChangelogCsvFormat.java 36 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/ChangelogCsvFormatFactory.java 38 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/ChangelogSocketExample.java 36 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/SocketDynamicTableFactory.java 57 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/SocketDynamicTableSource.java 69 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/connectors/SocketSource.java 188 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/functions/AdvancedFunctionsExample.java 67 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/functions/InternalRowMergerFunction.java 80 flink-examples/flink-examples-table/src/main/java/org/apache/flink/table/examples/java/functions/LastDatedValueFunction.java 59 flink-examples/flink-examples-table/src/main/resources/log4j2.properties 23 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/java/basics/GettingStartedExampleITCase.java 14 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/java/basics/StreamSQLExampleITCase.java 15 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/java/basics/TemporalJoinSQLExampleITCase.java 20 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/java/basics/UpdatingTopCityExampleITCase.java 18 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/java/basics/WordCountSQLExampleITCase.java 14 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/java/functions/AdvancedFunctionsExampleITCase.java 28 flink-examples/flink-examples-table/src/test/java/org/apache/flink/table/examples/utils/ExampleOutputTestBase.java 32 flink-filesystems/flink-azure-fs-hadoop/src/test/resources/archunit.properties 27 flink-filesystems/flink-azure-fs-hadoop/src/test/resources/log4j2-test.properties 26 flink-filesystems/flink-gs-fs-hadoop/src/test/resources/archunit.properties 27 flink-filesystems/flink-gs-fs-hadoop/src/test/resources/log4j2-test.properties 26 flink-filesystems/flink-hadoop-fs/src/test/resources/archunit.properties 27 flink-filesystems/flink-hadoop-fs/src/test/resources/log4j2-test.properties 26 flink-filesystems/flink-oss-fs-hadoop/src/test/resources/archunit.properties 27 flink-filesystems/flink-oss-fs-hadoop/src/test/resources/log4j2-test.properties 26 flink-filesystems/flink-s3-fs-base/src/test/resources/archunit.properties 27 flink-filesystems/flink-s3-fs-base/src/test/resources/log4j2-test.properties 26 flink-filesystems/flink-s3-fs-hadoop/src/test/resources/archunit.properties 27 flink-filesystems/flink-s3-fs-hadoop/src/test/resources/log4j2-test.properties 26 flink-filesystems/flink-s3-fs-presto/src/test/resources/archunit.properties 27 flink-filesystems/flink-s3-fs-presto/src/test/resources/log4j2-test.properties 26 flink-formats/flink-avro-confluent-registry/src/test/resources/archunit.properties 27 flink-formats/flink-avro-confluent-registry/src/test/resources/debezium-test-schema.json 191 flink-formats/flink-avro/src/test/resources/archunit.properties 27 flink-formats/flink-avro/src/test/resources/log4j2-test.properties 28 flink-formats/flink-compress/src/test/resources/archunit.properties 27 flink-formats/flink-compress/src/test/resources/log4j2-test.properties 26 flink-formats/flink-csv/src/test/resources/archunit.properties 27 flink-formats/flink-csv/src/test/resources/log4j2-test.properties 26 flink-formats/flink-hadoop-bulk/src/test/resources/archunit.properties 27 flink-formats/flink-hadoop-bulk/src/test/resources/log4j2-test.properties 26 flink-formats/flink-json/src/test/resources/archunit.properties 27 flink-formats/flink-json/src/test/resources/complex-schema.json 113 flink-formats/flink-json/src/test/resources/debezium-data-schema-exclude.txt 16 flink-formats/flink-json/src/test/resources/debezium-postgres-data-replica-identity.txt 16 flink-formats/flink-json/src/test/resources/debezium-postgres-data-schema-exclude.txt 16 flink-formats/flink-json/src/test/resources/maxwell-data.txt 20 flink-formats/flink-json/src/test/resources/ogg-data.txt 16 flink-formats/flink-json/src/test/resources/reference-schema.json 60 flink-formats/flink-orc-nohive/src/test/resources/archunit.properties 27 flink-formats/flink-orc/src/test/resources/archunit.properties 27 flink-formats/flink-orc/src/test/resources/log4j2-test.properties 26 flink-formats/flink-parquet/src/test/resources/archunit.properties 27 flink-formats/flink-parquet/src/test/resources/log4j2-test.properties 26 flink-formats/flink-sequence-file/src/test/resources/archunit.properties 27 flink-formats/flink-sequence-file/src/test/resources/log4j2-test.properties 26 flink-fs-tests/src/test/resources/log4j2-test.properties 28 flink-kubernetes/src/test/resources/log4j2-test.properties 26 flink-libraries/flink-cep/src/test/resources/log4j2-test.properties 28 flink-metrics/flink-metrics-datadog/src/test/resources/log4j2-test.properties 26 flink-metrics/flink-metrics-dropwizard/src/test/resources/log4j2-test.properties 26 flink-metrics/flink-metrics-influxdb/src/test/resources/log4j2-test.properties 26 flink-metrics/flink-metrics-jmx/src/test/resources/log4j2-test.properties 26 flink-metrics/flink-metrics-otel/src/test/resources/log4j2-test.properties 27 flink-metrics/flink-metrics-prometheus/src/test/resources/log4j2-test.properties 26 flink-metrics/flink-metrics-slf4j/src/test/resources/log4j2-test.properties 26 flink-metrics/flink-metrics-statsd/src/test/resources/log4j2-test.properties 26 flink-python/README.md 49 flink-python/apache-flink-libraries/README.md 5 flink-python/dev/dev-requirements.txt 35 flink-python/pyflink/examples/datastream/basic_operations.py 32 flink-python/pyflink/examples/datastream/connectors/elasticsearch.py 91 flink-python/pyflink/examples/datastream/connectors/kafka_avro_format.py 41 flink-python/pyflink/examples/datastream/connectors/kafka_csv_format.py 38 flink-python/pyflink/examples/datastream/connectors/kafka_json_format.py 41 flink-python/pyflink/examples/datastream/connectors/pulsar.py 41 flink-python/pyflink/examples/datastream/event_time_timer.py 53 flink-python/pyflink/examples/datastream/process_json_data.py 24 flink-python/pyflink/examples/datastream/state_access.py 44 flink-python/pyflink/examples/datastream/streaming_word_count.py 61 flink-python/pyflink/examples/datastream/windowing/session_with_dynamic_gap_window.py 60 flink-python/pyflink/examples/datastream/windowing/session_with_gap_window.py 60 flink-python/pyflink/examples/datastream/windowing/sliding_time_window.py 56 flink-python/pyflink/examples/datastream/windowing/tumbling_count_window.py 48 flink-python/pyflink/examples/datastream/windowing/tumbling_time_window.py 56 flink-python/pyflink/examples/datastream/word_count.py 97 flink-python/pyflink/examples/table/basic_operations.py 180 flink-python/pyflink/examples/table/mixing_use_of_datastream_and_table.py 41 flink-python/pyflink/examples/table/multi_sink.py 24 flink-python/pyflink/examples/table/pandas/conversion_from_dataframe.py 17 flink-python/pyflink/examples/table/pandas/pandas_udaf.py 55 flink-python/pyflink/examples/table/process_json_data.py 29 flink-python/pyflink/examples/table/process_json_data_with_udf.py 36 flink-python/pyflink/examples/table/streaming_word_count.py 66 flink-python/pyflink/examples/table/windowing/over_window.py 53 flink-python/pyflink/examples/table/windowing/session_window.py 49 flink-python/pyflink/examples/table/windowing/sliding_window.py 51 flink-python/pyflink/examples/table/windowing/tumble_window.py 51 flink-python/pyflink/examples/table/word_count.py 109 flink-python/tox.ini 51 flink-queryable-state/flink-queryable-state-client-java/src/test/resources/log4j2-test.properties 26 flink-queryable-state/flink-queryable-state-runtime/src/test/resources/log4j2-test.properties 26 flink-quickstart/flink-quickstart-java/src/main/resources/archetype-resources/src/main/resources/log4j2.properties 23 flink-quickstart/flink-quickstart-java/src/test/resources/projects/testArtifact/archetype.properties 20 flink-quickstart/flink-quickstart-java/src/test/resources/projects/testArtifact/goal.txt 1 flink-rpc/flink-rpc-akka/src/main/resources/META-INF/licenses/LICENSE.scala 24 flink-rpc/flink-rpc-akka/src/test/resources/log4j2-test.properties 26 flink-runtime-web/README.md 80 flink-runtime-web/src/test/resources/log4j2-test.properties 26 flink-runtime-web/web-dashboard/angular.json 135 flink-runtime-web/web-dashboard/package.json 78 flink-runtime-web/web-dashboard/proxy.conf.json 7 flink-runtime-web/web-dashboard/src/assets/favicon/manifest.json 17 flink-runtime-web/web-dashboard/src/assets/favicon/safari-pinned-tab.svg 221 flink-runtime-web/web-dashboard/src/assets/images/flink.svg 719 flink-runtime-web/web-dashboard/src/assets/images/memory-model.svg 542 flink-runtime-web/web-dashboard/src/tsconfig.app.json 9 flink-runtime-web/web-dashboard/tsconfig.json 29 flink-runtime/src/test/resources/log4j2-test.properties 31 flink-state-backends/flink-statebackend-changelog/src/test/resources/log4j2-test.properties 26 flink-state-backends/flink-statebackend-forst/src/test/resources/log4j2-test.properties 26 flink-state-backends/flink-statebackend-rocksdb/src/test/resources/log4j2-test.properties 26 flink-streaming-java/src/test/resources/log4j2-test.properties 28 flink-table/README.md 56 flink-table/flink-sql-client/src/test/resources/log4j2-test.properties 26 flink-table/flink-sql-client/src/test/resources/sql/_HOW_TO_USE.md 132 flink-table/flink-sql-gateway/src/test/resources/log4j2-test.properties 26 flink-table/flink-sql-jdbc-driver/src/main/resources/org/apache/flink/table/jdbc/driver.properties 16 flink-table/flink-sql-parser/src/main/resources/org.apache.flink.sql.parser.utils/ParserResource.properties 23 flink-table/flink-table-api-java-bridge/src/test/resources/log4j2-test.properties 26 flink-table/flink-table-api-java/src/test/resources/log4j2-test.properties 26 flink-table/flink-table-api-scala/src/test/resources/log4j2-test.properties 28 flink-table/flink-table-code-splitter/src/test/resources/groups/code/IfInWhile.txt 22 flink-table/flink-table-code-splitter/src/test/resources/groups/code/WhileInIf.txt 24 flink-table/flink-table-code-splitter/src/test/resources/groups/expected/IfInWhile.txt 4 flink-table/flink-table-code-splitter/src/test/resources/groups/expected/WhileInIf.txt 4 flink-table/flink-table-planner-loader-bundle/src/main/resources/META-INF/licenses/LICENSE.scala 8 flink-table/flink-table-planner/README.md 18 flink-table/flink-table-planner/src/test/resources/archunit.properties 27 flink-table/flink-table-planner/src/test/resources/json/json-exists.json 19 flink-table/flink-table-planner/src/test/resources/json/json-query.json 6 flink-table/flink-table-planner/src/test/resources/json/json-value.json 12 flink-table/flink-table-planner/src/test/resources/jsonplan/testInvalidTypeJsonPlan.json 216 flink-table/flink-table-planner/src/test/resources/lineage-graph/query-batch.json 70 flink-table/flink-table-planner/src/test/resources/lineage-graph/query-stream.json 70 flink-table/flink-table-planner/src/test/resources/lineage-graph/union-batch.json 117 flink-table/flink-table-planner/src/test/resources/lineage-graph/union-stream.json 117 flink-table/flink-table-planner/src/test/resources/log4j2-test.properties 31 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-filter-pushdown/plan/calc-filter-pushdown.json 89 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-filter/plan/calc-filter.json 138 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-project-pushdown/plan/calc-project-pushdown.json 132 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-sarg/plan/calc-sarg.json 129 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-simple/plan/calc-simple.json 110 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-udf-complex/plan/calc-udf-complex.json 269 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-calc_1/calc-udf-simple/plan/calc-udf-simple.json 108 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-correlate_1/correlate-catalog-func/plan/correlate-catalog-func.json 142 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-correlate_1/correlate-cross-join-unnest/plan/correlate-cross-join-unnest.json 135 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-correlate_1/correlate-join-filter/plan/correlate-join-filter.json 209 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-correlate_1/correlate-left-join/plan/correlate-left-join.json 138 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-correlate_1/correlate-system-func/plan/correlate-system-func.json 142 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-expand_1/expand/plan/expand.json 534 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-inner-join-with-duplicate-key/plan/join-inner-join-with-duplicate-key.json 293 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-inner-join-with-non-equi-join/plan/join-inner-join-with-non-equi-join.json 255 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-left-join/plan/join-left-join.json 250 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-non-window-inner-join-with-null-cond/plan/join-non-window-inner-join-with-null-cond.json 362 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-non-window-inner-join/plan/join-non-window-inner-join.json 362 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-outer-join/plan/join-outer-join.json 250 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-right-join/plan/join-right-join.json 250 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-semi-join/plan/join-semi-join.json 243 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-join_1/join-with-filter/plan/join-with-filter.json 313 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-limit_1/limit/plan/limit.json 184 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-lookup-join_1/lookup-join-filter-pushdown/plan/lookup-join-filter-pushdown.json 285 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-lookup-join_1/lookup-join-left-join/plan/lookup-join-left-join.json 300 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-lookup-join_1/lookup-join-pre-filter/plan/lookup-join-pre-filter.json 300 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-complex/plan/match-complex.json 485 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-order-by-event-time/plan/match-order-by-event-time.json 506 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-order-by-int-column/plan/match-order-by-int-column.json 510 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-simple/plan/match-simple.json 350 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-skip-past-last-row/plan/match-skip-past-last-row.json 386 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-skip-to-first/plan/match-skip-to-first.json 388 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-skip-to-last/plan/match-skip-to-last.json 388 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-match_1/match-skip-to-next-row/plan/match-skip-to-next-row.json 386 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-over-aggregate_1/over-aggregate-bounded-partitioned-preceding-rows/plan/over-aggregate-bounded-partitioned-preceding-rows.json 444 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-over-aggregate_1/over-aggregate-unbounded-partitioned-rows/plan/over-aggregate-unbounded-partitioned-rows.json 434 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-rank_1/rank-2-test/plan/rank-2-test.json 329 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-rank_1/rank-n-test/plan/rank-n-test.json 442 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-rank_1/rank-test-append-fast-strategy/plan/rank-test-append-fast-strategy.json 268 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-rank_1/rank-test-update-fast-strategy/plan/rank-test-update-fast-strategy.json 356 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-bucketing_hash-with-keys-with-count/plan/sink-bucketing_hash-with-keys-with-count.json 118 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-bucketing_range_with_keys_without_count/plan/sink-bucketing_range_with_keys_without_count.json 117 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-bucketing_with-count/plan/sink-bucketing_with-count.json 118 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-bucketing_with-keys-and-count/plan/sink-bucketing_with-keys-and-count.json 118 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-overwrite/plan/sink-overwrite.json 81 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-partial-insert/plan/sink-partial-insert.json 125 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-partition/plan/sink-partition.json 123 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sink_1/sink-writing-metadata/plan/sink-writing-metadata.json 84 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sort-limit_1/sort-limit-asc/plan/sort-limit-asc.json 194 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sort-limit_1/sort-limit-desc/plan/sort-limit-desc.json 194 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sort_1/sort-asc/plan/sort-asc.json 169 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-sort_1/sort-desc/plan/sort-desc.json 169 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-filter-pushdown/plan/table-source-scan-filter-pushdown.json 95 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-limit-pushdown/plan/table-source-scan-limit-pushdown.json 145 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-partition-pushdown/plan/table-source-scan-partition-pushdown.json 130 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-project-push-down-disabled/plan/table-source-scan-project-push-down-disabled.json 113 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-project-pushdown/plan/table-source-scan-project-pushdown.json 83 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-reading-metadata/plan/table-source-scan-reading-metadata.json 91 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-table-source-scan_1/table-source-scan-reuse-source/plan/table-source-scan-reuse-source.json 176 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-union_1/union-all-two-sources/plan/union-all-two-sources.json 143 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-union_1/union-all-with-filter/plan/union-all-with-filter.json 239 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-union_1/union-two-sources/plan/union-two-sources.json 229 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-values_1/values-test/plan/values-test.json 80 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-cumulate-tvf-agg/plan/window-table-function-cumulate-tvf-agg.json 391 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-cumulate-tvf/plan/window-table-function-cumulate-tvf.json 270 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-hop-tvf-agg/plan/window-table-function-hop-tvf-agg.json 391 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-hop-tvf/plan/window-table-function-hop-tvf.json 270 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-tumble-tvf-agg/plan/window-table-function-tumble-tvf-agg.json 390 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-tumble-tvf-negative-offset/plan/window-table-function-tumble-tvf-negative-offset.json 270 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-tumble-tvf-positive-offset/plan/window-table-function-tumble-tvf-positive-offset.json 270 flink-table/flink-table-planner/src/test/resources/restore-tests/batch-exec-window-table-function_1/window-table-function-tumble-tvf/plan/window-table-function-tumble-tvf.json 269 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-async-calc_1/async-calc-complex/plan/async-calc-complex.json 564 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-async-calc_1/async-calc-condition/plan/async-calc-condition.json 186 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-async-calc_1/async-calc-failure-exception/plan/async-calc-failure-exception.json 104 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-async-calc_1/async-calc-nested/plan/async-calc-nested.json 226 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-async-calc_1/async-calc-simple/plan/async-calc-simple.json 146 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-filter-pushdown/plan/calc-filter-pushdown.json 92 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-filter/plan/calc-filter.json 141 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-project-pushdown/plan/calc-project-pushdown.json 135 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-sarg/plan/calc-sarg.json 132 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-simple/plan/calc-simple.json 113 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-udf-complex/plan/calc-udf-complex.json 272 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-calc_1/calc-udf-simple/plan/calc-udf-simple.json 111 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-changelog-normalize_1/changelog-normalize-source-mini-batch/plan/changelog-normalize-source-mini-batch.json 178 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-changelog-normalize_1/changelog-normalize-source/plan/changelog-normalize-source.json 155 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-changelog-normalize_1/changelog-normalize-upsert-filter/plan/changelog-normalize-upsert-filter.json 155 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-changelog-normalize_1/changelog-normalize-upsert/plan/changelog-normalize-upsert.json 136 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-correlate_1/correlate-catalog-func/plan/correlate-catalog-func.json 145 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-correlate_1/correlate-cross-join-unnest/plan/correlate-cross-join-unnest.json 138 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-correlate_1/correlate-join-filter/plan/correlate-join-filter.json 212 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-correlate_1/correlate-left-join/plan/correlate-left-join.json 141 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-correlate_1/correlate-system-func/plan/correlate-system-func.json 145 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-deduplicate_1/deduplicate-asc-proctime/plan/deduplicate-asc-proctime.json 337 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-deduplicate_1/deduplicate-asc/plan/deduplicate-asc.json 376 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-deduplicate_1/deduplicate-desc/plan/deduplicate-desc.json 376 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-expand_1/expand/plan/expand.json 480 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/agg-with-state-ttl-hint/plan/agg-with-state-ttl-hint.json 272 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-distinct-mini-batch/plan/group-aggregate-distinct-mini-batch.json 621 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-distinct/plan/group-aggregate-distinct.json 359 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-simple-mini-batch/plan/group-aggregate-simple-mini-batch.json 351 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-simple/plan/group-aggregate-simple.json 272 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-udf-with-merge-mini-batch/plan/group-aggregate-udf-with-merge-mini-batch.json 400 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-udf-with-merge/plan/group-aggregate-udf-with-merge.json 211 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-udf-without-merge-mini-batch/plan/group-aggregate-udf-without-merge-mini-batch.json 254 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-aggregate_1/group-aggregate-udf-without-merge/plan/group-aggregate-udf-without-merge.json 231 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-window-aggregate_1/group-window-aggregate-hop-event-time/plan/group-window-aggregate-hop-event-time.json 328 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-window-aggregate_1/group-window-aggregate-hop-proc-time/plan/group-window-aggregate-hop-proc-time.json 414 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-window-aggregate_1/group-window-aggregate-session-event-time/plan/group-window-aggregate-session-event-time.json 326 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-window-aggregate_1/group-window-aggregate-session-proc-time/plan/group-window-aggregate-session-proc-time.json 412 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-window-aggregate_1/group-window-aggregate-tumble-event-time/plan/group-window-aggregate-tumble-event-time.json 511 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-group-window-aggregate_1/group-window-aggregate-tumble-proc-time/plan/group-window-aggregate-tumble-proc-time.json 478 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-incremental-group-aggregate_1/incremental-group-aggregate-complex/plan/incremental-group-aggregate-complex.json 573 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-incremental-group-aggregate_1/incremental-group-aggregate-simple/plan/incremental-group-aggregate-simple.json 373 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-interval-join_1/interval-join-event-time/plan/interval-join-event-time.json 545 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-interval-join_1/interval-join-negative-interval/plan/interval-join-negative-interval.json 545 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-interval-join_1/interval-join-proc-time/plan/interval-join-proc-time.json 445 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-anti-join/plan/join-anti-join.json 273 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-cross-join/plan/join-cross-join.json 211 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-inner-join-with-duplicate-key/plan/join-inner-join-with-duplicate-key.json 242 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-inner-join-with-equal-pk/plan/join-inner-join-with-equal-pk.json 322 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-inner-join-with-non-equi-join/plan/join-inner-join-with-non-equi-join.json 247 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-inner-join-with-pk/plan/join-inner-join-with-pk.json 426 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-left-join/plan/join-left-join.json 242 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-non-window-inner-join-with-null-cond/plan/join-non-window-inner-join-with-null-cond.json 354 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-non-window-inner-join/plan/join-non-window-inner-join.json 354 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-outer-join/plan/join-outer-join.json 242 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-right-join/plan/join-right-join.json 242 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-semi-join/plan/join-semi-join.json 235 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-with-filter/plan/join-with-filter.json 305 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-join_1/join-with-state-ttl-hint/plan/join-with-state-ttl-hint.json 322 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-limit_1/limit/plan/limit.json 186 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-async-hint/plan/lookup-join-async-hint.json 251 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-filter-pushdown/plan/lookup-join-filter-pushdown.json 264 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-left-join/plan/lookup-join-left-join.json 279 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-post-filter/plan/lookup-join-post-filter.json 266 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-pre-filter/plan/lookup-join-pre-filter.json 279 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-pre-post-filter/plan/lookup-join-pre-post-filter.json 281 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-project-pushdown/plan/lookup-join-project-pushdown.json 248 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-retry-hint/plan/lookup-join-retry-hint.json 252 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-lookup-join_1/lookup-join-with-try-resolve/plan/lookup-join-with-try-resolve.json 266 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-complex/plan/match-complex.json 510 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-order-by-event-time-with-out-of-order-data/plan/match-order-by-event-time-with-out-of-order-data.json 597 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-order-by-int-column-with-out-of-order-data/plan/match-order-by-int-column-with-out-of-order-data.json 601 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-simple/plan/match-simple.json 369 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-skip-past-last-row/plan/match-skip-past-last-row.json 405 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-skip-to-first/plan/match-skip-to-first.json 407 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-skip-to-last/plan/match-skip-to-last.json 407 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-match_1/match-skip-to-next-row/plan/match-skip-to-next-row.json 405 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-mini-batch-assigner_1/mini-batch-assigner-proc-time/plan/mini-batch-assigner-proc-time.json 257 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-mini-batch-assigner_1/mini-batch-assigner-row-time/plan/mini-batch-assigner-row-time.json 854 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-bounded-non-partitioned-rows-with-out-of-order-records/plan/over-aggregate-bounded-non-partitioned-rows-with-out-of-order-records.json 591 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-bounded-non-partitioned-rows/plan/over-aggregate-bounded-non-partitioned-rows.json 590 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-bounded-partitioned-preceding-rows-with-out-of-order-records/plan/over-aggregate-bounded-partitioned-preceding-rows-with-out-of-order-records.json 592 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-bounded-partitioned-preceding-rows/plan/over-aggregate-bounded-partitioned-preceding-rows.json 592 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-bounded-partitioned-rows-with-out-of-order-records/plan/over-aggregate-bounded-partitioned-rows-with-out-of-order-records.json 592 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-bounded-partitioned-rows/plan/over-aggregate-bounded-partitioned-rows.json 592 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-lag/plan/over-aggregate-lag.json 318 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-avg-append-mode/plan/over-aggregate-non-time-range-unbounded-avg-append-mode.json 237 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-multiple-aggs-append-mode/plan/over-aggregate-non-time-range-unbounded-multiple-aggs-append-mode.json 244 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-append-mode/plan/over-aggregate-non-time-range-unbounded-sum-append-mode.json 227 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-no-partition-by/plan/over-aggregate-non-time-range-unbounded-sum-no-partition-by.json 226 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-retract-mode-sink-primary-key/plan/over-aggregate-non-time-range-unbounded-sum-retract-mode-sink-primary-key.json 238 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-retract-mode-source-primary-key/plan/over-aggregate-non-time-range-unbounded-sum-retract-mode-source-primary-key.json 233 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-retract-mode-source-sink-primary-key-partition-by-non-pk/plan/over-aggregate-non-time-range-unbounded-sum-retract-mode-source-sink-primary-key-partition-by-non-pk.json 243 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-retract-mode-source-sink-primary-key/plan/over-aggregate-non-time-range-unbounded-sum-retract-mode-source-sink-primary-key.json 307 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-non-time-range-unbounded-sum-retract-mode/plan/over-aggregate-non-time-range-unbounded-sum-retract-mode.json 227 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-unbounded-partitioned-rows-with-out-of-order-records/plan/over-aggregate-unbounded-partitioned-rows-with-out-of-order-records.json 581 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-over-aggregate_1/over-aggregate-unbounded-partitioned-rows/plan/over-aggregate-unbounded-partitioned-rows.json 582 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-rank_1/rank-n-test/plan/rank-n-test.json 301 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-rank_1/rank-test-append-fast-strategy/plan/rank-test-append-fast-strategy.json 187 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-rank_1/rank-test-retract-strategy/plan/rank-test-retract-strategy.json 187 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-rank_1/rank-test-update-fast-strategy/plan/rank-test-update-fast-strategy.json 234 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-bucketing_hash-with-keys-with-count/plan/sink-bucketing_hash-with-keys-with-count.json 88 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-bucketing_range_with_keys_without_count/plan/sink-bucketing_range_with_keys_without_count.json 87 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-bucketing_with-count/plan/sink-bucketing_with-count.json 88 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-bucketing_with-keys-and-count/plan/sink-bucketing_with-keys-and-count.json 88 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-ndf-primary-key/plan/sink-ndf-primary-key.json 123 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-overwrite/plan/sink-overwrite.json 84 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-partial-insert/plan/sink-partial-insert.json 128 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-partition/plan/sink-partition.json 126 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-upsert/plan/sink-upsert.json 141 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sink_1/sink-writing-metadata/plan/sink-writing-metadata.json 87 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sort-limit_1/sort-limit-asc/plan/sort-limit-asc.json 186 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sort-limit_1/sort-limit-desc/plan/sort-limit-desc.json 186 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sort_1/sort-asc/plan/sort-asc.json 164 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-sort_1/sort-desc/plan/sort-desc.json 164 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-filter-pushdown/plan/table-source-scan-filter-pushdown.json 98 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-limit-pushdown/plan/table-source-scan-limit-pushdown.json 147 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-multiple-pushdowns/plan/table-source-scan-multiple-pushdowns.json 204 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-partition-pushdown/plan/table-source-scan-partition-pushdown.json 133 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-project-push-down-disabled/plan/table-source-scan-project-push-down-disabled.json 116 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-project-pushdown/plan/table-source-scan-project-pushdown.json 86 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-reading-metadata/plan/table-source-scan-reading-metadata.json 94 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-reuse-source/plan/table-source-scan-reuse-source.json 183 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-table-source-scan_1/table-source-scan-source-watermark/plan/table-source-scan-source-watermark.json 139 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-temporal-join_1/temporal-join-table-join-key-from-map/plan/temporal-join-table-join-key-from-map.json 569 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-temporal-join_1/temporal-join-table-join-nested-key/plan/temporal-join-table-join-nested-key.json 600 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-temporal-join_1/temporal-join-table-join/plan/temporal-join-table-join.json 494 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-temporal-join_1/temporal-join-temporal-function/plan/temporal-join-temporal-function.json 494 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-temporal-sort_1/temporal-sort-proctime/plan/temporal-sort-proctime.json 247 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-temporal-sort_1/temporal-sort-rowtime/plan/temporal-sort-rowtime.json 305 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-union_1/union-all-two-sources/plan/union-all-two-sources.json 145 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-union_1/union-all-with-filter/plan/union-all-with-filter.json 241 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-union_1/union-two-sources/plan/union-two-sources.json 199 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-values_1/values-test/plan/values-test.json 84 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-watermark-assigner_1/watermark-assigner-basic-filter/plan/watermark-assigner-basic-filter.json 259 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-watermark-assigner_1/watermark-assigner-pushdown-metadata/plan/watermark-assigner-pushdown-metadata.json 270 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-cumulate-event-time-two-phase-distinct-split/plan/window-aggregate-cumulate-event-time-two-phase-distinct-split.json 908 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-cumulate-event-time-two-phase-with-offset/plan/window-aggregate-cumulate-event-time-two-phase-with-offset.json 649 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-cumulate-event-time-two-phase/plan/window-aggregate-cumulate-event-time-two-phase.json 647 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-cumulate-event-time-with-offset-distinct-split/plan/window-aggregate-cumulate-event-time-with-offset-distinct-split.json 912 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-cumulate-event-time-with-offset/plan/window-aggregate-cumulate-event-time-with-offset.json 499 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-cumulate-event-time/plan/window-aggregate-cumulate-event-time.json 498 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-hop-event-time-two-phase-distinct-split/plan/window-aggregate-hop-event-time-two-phase-distinct-split.json 908 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-hop-event-time-two-phase-with-offset-distinct-split/plan/window-aggregate-hop-event-time-two-phase-with-offset-distinct-split.json 912 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-hop-event-time-two-phase-with-offset/plan/window-aggregate-hop-event-time-two-phase-with-offset.json 649 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-hop-event-time-two-phase/plan/window-aggregate-hop-event-time-two-phase.json 647 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-hop-event-time-with-offset/plan/window-aggregate-hop-event-time-with-offset.json 499 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-hop-event-time/plan/window-aggregate-hop-event-time.json 498 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-session-event-time-two-phase-distinct-split/plan/window-aggregate-session-event-time-two-phase-distinct-split.json 491 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-session-event-time-two-phase/plan/window-aggregate-session-event-time-two-phase.json 491 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-session-event-time/plan/window-aggregate-session-event-time.json 491 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-session-partition-event-time-two-phase-distinct-split/plan/window-aggregate-session-partition-event-time-two-phase-distinct-split.json 499 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-session-partition-event-time-two-phase/plan/window-aggregate-session-partition-event-time-two-phase.json 499 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-session-partition-event-time/plan/window-aggregate-session-partition-event-time.json 499 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-event-time-two-phase-distinct-split/plan/window-aggregate-tumble-event-time-two-phase-distinct-split.json 904 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-event-time-two-phase-with-offset-distinct-split/plan/window-aggregate-tumble-event-time-two-phase-with-offset-distinct-split.json 908 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-event-time-two-phase-with-offset/plan/window-aggregate-tumble-event-time-two-phase-with-offset.json 647 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-event-time-two-phase/plan/window-aggregate-tumble-event-time-two-phase.json 645 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-event-time-with-offset/plan/window-aggregate-tumble-event-time-with-offset.json 498 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-event-time/plan/window-aggregate-tumble-event-time.json 497 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-aggregate_1/window-aggregate-tumble-proc-time/plan/window-aggregate-tumble-proc-time.json 478 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-asc-cumulate-first-row/plan/window-deduplicate-asc-cumulate-first-row.json 669 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-asc-hop-first-row/plan/window-deduplicate-asc-hop-first-row.json 669 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-asc-partition-by-item-tumble-first-row/plan/window-deduplicate-asc-partition-by-item-tumble-first-row.json 668 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-asc-tumble-first-row-condition-1/plan/window-deduplicate-asc-tumble-first-row-condition-1.json 667 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-asc-tumble-first-row-condition-3/plan/window-deduplicate-asc-tumble-first-row-condition-3.json 667 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-asc-tumble-first-row/plan/window-deduplicate-asc-tumble-first-row.json 667 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-desc-partition-by-item-tumble-first-row/plan/window-deduplicate-desc-partition-by-item-tumble-first-row.json 668 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-deduplicate_1/window-deduplicate-desc-tumble-last-row/plan/window-deduplicate-desc-tumble-last-row.json 667 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-anti-tumble-event-time/plan/window-join-anti-tumble-event-time.json 751 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-cumulate-event-time/plan/window-join-cumulate-event-time.json 774 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-full-outer-tumble-event-time/plan/window-join-full-outer-tumble-event-time.json 770 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-hop-event-time/plan/window-join-hop-event-time.json 774 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-inner-tumble-event-time/plan/window-join-inner-tumble-event-time.json 770 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-left-tumble-event-time/plan/window-join-left-tumble-event-time.json 770 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-right-tumble-event-time/plan/window-join-right-tumble-event-time.json 770 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-join_1/window-join-semi-tumble-event-time/plan/window-join-semi-tumble-event-time.json 751 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-rank_1/window-rank-cumulate-tvf-min-top-n/plan/window-rank-cumulate-tvf-min-top-n.json 687 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-rank_1/window-rank-hop-tvf-min-top-n/plan/window-rank-hop-tvf-min-top-n.json 687 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-rank_1/window-rank-tumble-tvf-agg-max-top-n/plan/window-rank-tumble-tvf-agg-max-top-n.json 664 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-rank_1/window-rank-tumble-tvf-agg-min-top-n/plan/window-rank-tumble-tvf-agg-min-top-n.json 664 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-rank_1/window-rank-tumble-tvf-max-top-n/plan/window-rank-tumble-tvf-max-top-n.json 685 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-rank_1/window-rank-tumble-tvf-min-top-n/plan/window-rank-tumble-tvf-min-top-n.json 685 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-cumulate-tvf-agg-proc-time/plan/window-table-function-cumulate-tvf-agg-proc-time.json 443 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-cumulate-tvf-agg/plan/window-table-function-cumulate-tvf-agg.json 431 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-cumulate-tvf/plan/window-table-function-cumulate-tvf.json 382 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-hop-tvf-agg-proc-time/plan/window-table-function-hop-tvf-agg-proc-time.json 443 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-hop-tvf-agg/plan/window-table-function-hop-tvf-agg.json 431 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-hop-tvf/plan/window-table-function-hop-tvf.json 382 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-tumble-tvf-agg-proc-time/plan/window-table-function-tumble-tvf-agg-proc-time.json 442 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-tumble-tvf-agg/plan/window-table-function-tumble-tvf-agg.json 429 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-tumble-tvf-negative-offset/plan/window-table-function-tumble-tvf-negative-offset.json 382 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-tumble-tvf-positive-offset/plan/window-table-function-tumble-tvf-positive-offset.json 382 flink-table/flink-table-planner/src/test/resources/restore-tests/stream-exec-window-table-function_1/window-table-function-tumble-tvf/plan/window-table-function-tumble-tvf.json 381 flink-table/flink-table-runtime/src/test/resources/log4j2-test.properties 28 flink-test-utils-parent/flink-connector-test-utils/src/main/resources/log4j2-test.properties 26 flink-test-utils-parent/flink-migration-test-utils/README.md 82 flink-test-utils-parent/flink-table-filesystem-test-utils/src/test/resources/log4j2-test.properties 26 flink-test-utils-parent/flink-test-utils-junit/src/test/resources/log4j2-test.properties 26 flink-tests/src/test/resources/log4j2-test.properties 30 flink-walkthroughs/flink-walkthrough-datastream-java/src/main/resources/archetype-resources/src/main/resources/log4j2.properties 25 flink-yarn-tests/README.md 10 flink-yarn-tests/src/test/resources/cache.properties 19 flink-yarn-tests/src/test/resources/log4j2-test.properties 28 flink-yarn/src/test/resources/log4j2-test.properties 26 tools/ci/flink-ci-tools/src/main/resources/log4j2.properties 23 tools/ci/log4j.properties 83 tools/ci/ubuntu-mirror-list.txt 34 tools/maven/checkstyle.xml 255 tools/releasing/NOTICE-binary_PREAMBLE.txt 14