Uses of Class
org.apache.flink.streaming.api.functions.sink.filesystem.Buckets
-
-
Uses of Buckets in org.apache.flink.connector.file.table.stream
Fields in org.apache.flink.connector.file.table.stream declared as Buckets Modifier and Type Field Description protected Buckets<IN,String>
AbstractStreamingWriter. buckets
-
Uses of Buckets in org.apache.flink.streaming.api.functions.sink.filesystem
Methods in org.apache.flink.streaming.api.functions.sink.filesystem that return Buckets Modifier and Type Method Description Buckets<IN,BucketID>
HadoopPathBasedBulkFormatBuilder. createBuckets(int subtaskIndex)
Constructors in org.apache.flink.streaming.api.functions.sink.filesystem with parameters of type Buckets Constructor Description StreamingFileSinkHelper(Buckets<IN,?> buckets, boolean isRestored, OperatorStateStore stateStore, ProcessingTimeService procTimeService, long bucketCheckInterval)
-
Uses of Buckets in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
Methods in org.apache.flink.streaming.api.functions.sink.filesystem.legacy that return Buckets Modifier and Type Method Description abstract Buckets<IN,BucketID>
StreamingFileSink.BucketsBuilder. createBuckets(int subtaskIndex)
Buckets<IN,BucketID>
StreamingFileSink.BulkFormatBuilder. createBuckets(int subtaskIndex)
Buckets<IN,BucketID>
StreamingFileSink.RowFormatBuilder. createBuckets(int subtaskIndex)
-