Class ExecutableOperationUtils
- java.lang.Object
-
- org.apache.flink.table.operations.utils.ExecutableOperationUtils
-
@Internal public class ExecutableOperationUtils extends Object
Utils for the executable operation.
-
-
Constructor Summary
Constructors Constructor Description ExecutableOperationUtils()
-
Method Summary
All Methods Static Methods Concrete Methods Modifier and Type Method Description static org.apache.flink.table.connector.sink.DynamicTableSink
createDynamicTableSink(org.apache.flink.table.catalog.Catalog catalog, Supplier<Optional<org.apache.flink.table.factories.DynamicTableSinkFactory>> sinkFactorySupplier, org.apache.flink.table.catalog.ObjectIdentifier objectIdentifier, org.apache.flink.table.catalog.ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, org.apache.flink.configuration.ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSink
from aCatalogTable
.
-
-
-
Method Detail
-
createDynamicTableSink
public static org.apache.flink.table.connector.sink.DynamicTableSink createDynamicTableSink(@Nullable org.apache.flink.table.catalog.Catalog catalog, Supplier<Optional<org.apache.flink.table.factories.DynamicTableSinkFactory>> sinkFactorySupplier, org.apache.flink.table.catalog.ObjectIdentifier objectIdentifier, org.apache.flink.table.catalog.ResolvedCatalogTable catalogTable, Map<String,String> enrichmentOptions, org.apache.flink.configuration.ReadableConfig configuration, ClassLoader classLoader, boolean isTemporary)
Creates aDynamicTableSink
from aCatalogTable
.It'll try to create table sink from to {@param catalog}, then try to create from {@param sinkFactorySupplier} passed secondly. Otherwise, an attempt is made to discover a matching factory using Java SPI (see
Factory
for details).
-
-