diff --git a/flink-connector-hive/src/main/java/org/apache/flink/connectors/hive/HiveDynamicTableFactory.java b/flink-connector-hive/src/main/java/org/apache/flink/connectors/hive/HiveDynamicTableFactory.java index ed9eac94..f1a61f7d 100644 --- a/flink-connector-hive/src/main/java/org/apache/flink/connectors/hive/HiveDynamicTableFactory.java +++ b/flink-connector-hive/src/main/java/org/apache/flink/connectors/hive/HiveDynamicTableFactory.java @@ -38,6 +38,7 @@ import org.apache.hadoop.mapred.JobConf; import org.apache.hadoop.mapreduce.lib.input.FileInputFormat; +import java.util.Collections; import java.util.Set; import static org.apache.flink.connectors.hive.HiveOptions.STREAMING_SOURCE_ENABLE; @@ -79,6 +80,7 @@ public DynamicTableSink createDynamicTableSink(Context context) { null, context.getObjectIdentifier(), context.getCatalogTable(), + Collections.emptyMap(), context.getConfiguration(), context.getClassLoader(), context.isTemporary()); @@ -114,6 +116,7 @@ public DynamicTableSource createDynamicTableSource(Context context) { null, context.getObjectIdentifier(), context.getCatalogTable(), + Collections.emptyMap(), context.getConfiguration(), context.getClassLoader(), context.isTemporary()); diff --git a/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveDynamicTableFactoryTest.java b/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveDynamicTableFactoryTest.java index aa4bfffa..d2775cb4 100644 --- a/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveDynamicTableFactoryTest.java +++ b/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveDynamicTableFactoryTest.java @@ -42,6 +42,7 @@ import org.junit.Test; import java.time.Duration; +import java.util.Collections; import static org.apache.flink.connector.file.table.FileSystemConnectorOptions.PARTITION_TIME_EXTRACTOR_CLASS; import static org.apache.flink.connector.file.table.FileSystemConnectorOptions.PARTITION_TIME_EXTRACTOR_KIND; @@ -274,6 +275,7 @@ private DynamicTableSource getTableSource(String tableName) throws Exception { hiveCatalog.getFactory().orElseThrow(IllegalStateException::new), tableIdentifier, tableEnvInternal.getCatalogManager().resolveCatalogTable(catalogTable), + Collections.emptyMap(), tableEnv.getConfig(), Thread.currentThread().getContextClassLoader(), false); @@ -290,6 +292,7 @@ private DynamicTableSink getTableSink(String tableName) throws Exception { hiveCatalog.getFactory().orElseThrow(IllegalStateException::new), tableIdentifier, tableEnvInternal.getCatalogManager().resolveCatalogTable(catalogTable), + Collections.emptyMap(), tableEnv.getConfig(), Thread.currentThread().getContextClassLoader(), false); diff --git a/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveLookupJoinITCase.java b/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveLookupJoinITCase.java index e42c7db7..bb19cad4 100644 --- a/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveLookupJoinITCase.java +++ b/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveLookupJoinITCase.java @@ -49,6 +49,7 @@ import java.time.Duration; import java.util.ArrayList; import java.util.Arrays; +import java.util.Collections; import java.util.Comparator; import java.util.List; @@ -436,6 +437,7 @@ private FileSystemLookupFunction getLookupFunction(String ta tableEnvInternal .getCatalogManager() .resolveCatalogTable(catalogTable), + Collections.emptyMap(), tableEnv.getConfig(), Thread.currentThread().getContextClassLoader(), false); diff --git a/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveTableFactoryTest.java b/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveTableFactoryTest.java index d14bc726..4ce89ce3 100644 --- a/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveTableFactoryTest.java +++ b/flink-connector-hive/src/test/java/org/apache/flink/connectors/hive/HiveTableFactoryTest.java @@ -143,6 +143,7 @@ void testHiveTable() throws Exception { catalog.getFactory().orElseThrow(IllegalStateException::new), ObjectIdentifier.of("mycatalog", "mydb", "mytable"), new ResolvedCatalogTable(table, schema), + Collections.emptyMap(), new Configuration(), Thread.currentThread().getContextClassLoader(), false); @@ -154,6 +155,7 @@ void testHiveTable() throws Exception { catalog.getFactory().orElseThrow(IllegalStateException::new), ObjectIdentifier.of("mycatalog", "mydb", "mytable"), new ResolvedCatalogTable(table, schema), + Collections.emptyMap(), new Configuration(), Thread.currentThread().getContextClassLoader(), false);