You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by tw...@apache.org on 2022/01/25 09:08:51 UTC

[flink] branch master updated (fa161d3 -> dfcf8bc)

This is an automated email from the ASF dual-hosted git repository.

twalthr pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git.


    from fa161d3  [FLINK-25391][format-json] Forward catalog table options
     add b5dcb85  [hotfix][table-common] More Javadoc on DynamicTableFactory.Context#getObjectIdentifier
     add a65c12b  [FLINK-25791][table-planner] Add Parser to the SerdeContext
     add 04f8724  [FLINK-25791][table-planner] Use serializable string for ObjectIdentifier in JSON
     add dfcf8bc  [hotfix][table-planner] Unify the JSON test utilities

No new revisions were added by this update.

Summary of changes:
 .../flink/table/factories/DynamicTableFactory.java |  20 +++-
 .../exec/serde/LogicalTypeJsonDeserializer.java    |   7 +-
 .../serde/ObjectIdentifierJsonDeserializer.java    |  35 ++++--
 .../exec/serde/ObjectIdentifierJsonSerializer.java |  11 +-
 .../plan/nodes/exec/serde/SerdeContext.java        |   8 ++
 .../table/planner/delegation/PlannerBase.scala     |   1 +
 .../nodes/exec/serde/DataTypeJsonSerdeTest.java    |   6 +-
 .../exec/serde/DynamicTableSinkSpecSerdeTest.java  |  19 +--
 .../serde/DynamicTableSourceSpecSerdeTest.java     |  18 +--
 .../plan/nodes/exec/serde/JsonSerdeMocks.java      |  76 ------------
 .../plan/nodes/exec/serde/JsonSerdeTestUtil.java   | 132 +++++++++++++++++++++
 .../nodes/exec/serde/LogicalTypeJsonSerdeTest.java |   9 +-
 .../nodes/exec/serde/LogicalWindowSerdeTest.java   |   1 +
 .../plan/nodes/exec/serde/LookupKeySerdeTest.java  |   1 +
 .../nodes/exec/serde/RelDataTypeJsonSerdeTest.java |  10 +-
 .../plan/nodes/exec/serde/RexNodeSerdeTest.java    |   1 +
 .../nodes/exec/serde/RexWindowBoundSerdeTest.java  |   1 +
 .../serde/TemporalTableSourceSpecSerdeTest.java    |   9 +-
 .../test/resources/jsonplan/testGetJsonPlan.out    |  12 +-
 .../CalcJsonPlanTest_jsonplan/testComplexCalc.out  |  12 +-
 .../CalcJsonPlanTest_jsonplan/testSimpleFilter.out |  12 +-
 .../testSimpleProject.out                          |  12 +-
 .../testChangelogSource.out                        |  12 +-
 .../testUpsertSource.out                           |  12 +-
 .../testCrossJoin.out                              |  12 +-
 .../testCrossJoinOverrideParameters.out            |  12 +-
 .../testJoinWithFilter.out                         |  12 +-
 .../testLeftOuterJoinWithLiteralTrue.out           |  12 +-
 .../testDeduplication.out                          |  12 +-
 .../ExpandJsonPlanTest_jsonplan/testExpand.out     |  12 +-
 ...tDistinctAggCalls[isMiniBatchEnabled=false].out |  12 +-
 ...stDistinctAggCalls[isMiniBatchEnabled=true].out |  12 +-
 ...gCallsWithGroupBy[isMiniBatchEnabled=false].out |  12 +-
 ...ggCallsWithGroupBy[isMiniBatchEnabled=true].out |  12 +-
 ...AggWithoutGroupBy[isMiniBatchEnabled=false].out |  12 +-
 ...eAggWithoutGroupBy[isMiniBatchEnabled=true].out |  12 +-
 ...erDefinedAggCalls[isMiniBatchEnabled=false].out |  12 +-
 ...serDefinedAggCalls[isMiniBatchEnabled=true].out |  12 +-
 .../testEventTimeHopWindow.out                     |  12 +-
 .../testEventTimeSessionWindow.out                 |  12 +-
 .../testEventTimeTumbleWindow.out                  |  12 +-
 .../testProcTimeHopWindow.out                      |  12 +-
 .../testProcTimeSessionWindow.out                  |  12 +-
 .../testProcTimeTumbleWindow.out                   |  12 +-
 .../testIncrementalAggregate.out                   |  12 +-
 ...lAggregateWithSumCountDistinctAndRetraction.out |  12 +-
 .../testProcessingTimeInnerJoinWithOnClause.out    |  18 +--
 .../testRowTimeInnerJoinWithOnClause.out           |  18 +--
 .../JoinJsonPlanTest_jsonplan/testInnerJoin.out    |  18 +--
 .../testInnerJoinWithEqualPk.out                   |  18 +--
 .../testInnerJoinWithPk.out                        |  18 +--
 .../testLeftJoinNonEqui.out                        |  18 +--
 .../LimitJsonPlanTest_jsonplan/testLimit.out       |  12 +-
 .../testJoinTemporalTable.out                      |  18 +--
 ...testJoinTemporalTableWithProjectionPushDown.out |  18 +--
 .../testMatch.out                                  |  12 +-
 .../testProcTimeBoundedNonPartitionedRangeOver.out |  12 +-
 .../testProcTimeBoundedPartitionedRangeOver.out    |  12 +-
 ...undedPartitionedRowsOverWithBuiltinProctime.out |  12 +-
 .../testProcTimeUnboundedPartitionedRangeOver.out  |  12 +-
 ...stProctimeBoundedDistinctPartitionedRowOver.out |  12 +-
 ...edDistinctWithNonDistinctPartitionedRowOver.out |  12 +-
 .../testRowTimeBoundedPartitionedRowsOver.out      |  12 +-
 .../testPythonCalc.out                             |  12 +-
 .../testPythonFunctionInWhereClause.out            |  12 +-
 .../testJoinWithFilter.out                         |  12 +-
 .../testPythonTableFunction.out                    |  12 +-
 .../tesPythonAggCallsWithGroupBy.out               |  12 +-
 .../testEventTimeHopWindow.out                     |  12 +-
 .../testEventTimeSessionWindow.out                 |  12 +-
 .../testEventTimeTumbleWindow.out                  |  12 +-
 .../testProcTimeHopWindow.out                      |  12 +-
 .../testProcTimeSessionWindow.out                  |  12 +-
 .../testProcTimeTumbleWindow.out                   |  12 +-
 .../testProcTimeBoundedNonPartitionedRangeOver.out |  12 +-
 .../testProcTimeBoundedPartitionedRangeOver.out    |  12 +-
 ...undedPartitionedRowsOverWithBuiltinProctime.out |  12 +-
 .../testProcTimeUnboundedPartitionedRangeOver.out  |  12 +-
 .../testRowTimeBoundedPartitionedRowsOver.out      |  12 +-
 .../stream/RankJsonPlanTest_jsonplan/testRank.out  |  12 +-
 .../testSortLimit.out                              |  12 +-
 .../testOverwrite.out                              |  12 +-
 .../testPartitioning.out                           |  12 +-
 .../testWritingMetadata.out                        |  12 +-
 .../testFilterPushDown.out                         |  12 +-
 .../testLimitPushDown.out                          |  12 +-
 .../testPartitionPushDown.out                      |  12 +-
 .../testProjectPushDown.out                        |  12 +-
 .../testReadingMetadata.out                        |  12 +-
 .../testWatermarkPushDown.out                      |  12 +-
 .../testJoinTemporalFunction.out                   |  18 +--
 .../testTemporalTableJoin.out                      |  18 +--
 .../testSortProcessingTime.out                     |  12 +-
 .../testSortRowTime.out                            |  12 +-
 .../UnionJsonPlanTest_jsonplan/testUnion.out       |  18 +--
 .../ValuesJsonPlanTest_jsonplan/testValues.out     |   6 +-
 .../testWatermarkAssigner.out                      |  12 +-
 .../testDistinctSplitEnabled.out                   |  12 +-
 .../testEventTimeCumulateWindow.out                |  12 +-
 .../testEventTimeCumulateWindowWithOffset.out      |  12 +-
 .../testEventTimeHopWindow.out                     |  12 +-
 .../testEventTimeHopWindowWithOffset.out           |  12 +-
 .../testEventTimeTumbleWindow.out                  |  12 +-
 .../testEventTimeTumbleWindowWithOffset.out        |  12 +-
 .../testProcTimeCumulateWindow.out                 |  12 +-
 .../testProcTimeHopWindow.out                      |  12 +-
 .../testProcTimeTumbleWindow.out                   |  12 +-
 .../testEventTimeTumbleWindow.out                  |  18 +--
 .../testFollowedByWindowDeduplicate.out            |  12 +-
 .../testFollowedByWindowJoin.out                   |  18 +--
 .../testFollowedByWindowRank.out                   |  12 +-
 .../testIndividualWindowTVF.out                    |  12 +-
 .../testIndividualWindowTVFProcessingTime.out      |  12 +-
 113 files changed, 408 insertions(+), 1169 deletions(-)
 delete mode 100644 flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/plan/nodes/exec/serde/JsonSerdeMocks.java
 create mode 100644 flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/plan/nodes/exec/serde/JsonSerdeTestUtil.java