Uses of Interface
org.apache.flink.connector.file.table.TableMetaStoreFactory
-
-
Uses of TableMetaStoreFactory in org.apache.flink.connector.file.table
Classes in org.apache.flink.connector.file.table that implement TableMetaStoreFactory Modifier and Type Class Description class
EmptyMetaStoreFactory
Empty implementationTableMetaStoreFactory
.Methods in org.apache.flink.connector.file.table with parameters of type TableMetaStoreFactory Modifier and Type Method Description FileSystemOutputFormat.Builder<T>
FileSystemOutputFormat.Builder. setMetaStoreFactory(TableMetaStoreFactory metaStoreFactory)
Constructors in org.apache.flink.connector.file.table with parameters of type TableMetaStoreFactory Constructor Description FileSystemCommitter(FileSystemFactory factory, TableMetaStoreFactory metaStoreFactory, boolean overwrite, Path tmpPath, int partitionColumnSize, boolean isToLocal, ObjectIdentifier identifier, LinkedHashMap<String,String> staticPartitions, List<PartitionCommitPolicy> policies)
PartitionLoader(boolean overwrite, FileSystem sourceFs, TableMetaStoreFactory factory, boolean isToLocal, ObjectIdentifier identifier, List<PartitionCommitPolicy> policies)
-
Uses of TableMetaStoreFactory in org.apache.flink.connector.file.table.batch
Methods in org.apache.flink.connector.file.table.batch with parameters of type TableMetaStoreFactory Modifier and Type Method Description static <T> DataStreamSink<?>
BatchSink. createBatchCompactSink(DataStream<CompactMessages.CoordinatorInput> dataStream, StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> builder, CompactReader.Factory<T> readFactory, FileSystemFactory fsFactory, TableMetaStoreFactory metaStoreFactory, PartitionCommitPolicyFactory partitionCommitPolicyFactory, String[] partitionColumns, LinkedHashMap<String,String> staticPartitionSpec, Path tmpPath, ObjectIdentifier identifier, long compactAverageSize, long compactTargetSize, boolean isToLocal, boolean overwrite, int compactParallelism, boolean compactParallelismConfigured)
-
Uses of TableMetaStoreFactory in org.apache.flink.connector.file.table.batch.compact
Constructors in org.apache.flink.connector.file.table.batch.compact with parameters of type TableMetaStoreFactory Constructor Description BatchPartitionCommitterSink(FileSystemFactory fsFactory, TableMetaStoreFactory msFactory, boolean overwrite, boolean isToLocal, Path tmpPath, String[] partitionColumns, LinkedHashMap<String,String> staticPartitions, ObjectIdentifier identifier, PartitionCommitPolicyFactory partitionCommitPolicyFactory)
-
Uses of TableMetaStoreFactory in org.apache.flink.connector.file.table.stream
Methods in org.apache.flink.connector.file.table.stream with parameters of type TableMetaStoreFactory Modifier and Type Method Description static DataStreamSink<?>
StreamingSink. sink(ProviderContext providerContext, DataStream<PartitionCommitInfo> writer, Path locationPath, ObjectIdentifier identifier, List<String> partitionKeys, TableMetaStoreFactory msFactory, FileSystemFactory fsFactory, Configuration options)
Create a sink from file writer.Constructors in org.apache.flink.connector.file.table.stream with parameters of type TableMetaStoreFactory Constructor Description PartitionCommitter(Path locationPath, ObjectIdentifier tableIdentifier, List<String> partitionKeys, TableMetaStoreFactory metaStoreFactory, FileSystemFactory fsFactory, Configuration conf)
-