Modifier and Type | Method and Description |
---|---|
T |
FileSink.RowFormatBuilder.withRollingPolicy(RollingPolicy<IN,String> policy) |
Constructor and Description |
---|
RowFormatBuilder(Path basePath,
long bucketCheckInterval,
Encoder<IN> encoder,
BucketAssigner<IN,String> assigner,
RollingPolicy<IN,String> policy,
FileWriterBucketFactory<IN> bucketFactory,
OutputFileConfig outputFileConfig) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.connector.file.sink.writer.FileWriterBucket<IN> |
FileWriterBucketFactory.getNewBucket(String bucketId,
Path bucketPath,
BucketWriter<IN,String> bucketWriter,
RollingPolicy<IN,String> rollingPolicy,
OutputFileConfig outputFileConfig) |
org.apache.flink.connector.file.sink.writer.FileWriterBucket<IN> |
DefaultFileWriterBucketFactory.getNewBucket(String bucketId,
Path bucketPath,
BucketWriter<IN,String> bucketWriter,
RollingPolicy<IN,String> rollingPolicy,
OutputFileConfig outputFileConfig) |
org.apache.flink.connector.file.sink.writer.FileWriterBucket<IN> |
FileWriterBucketFactory.restoreBucket(BucketWriter<IN,String> bucketWriter,
RollingPolicy<IN,String> rollingPolicy,
FileWriterBucketState bucketState,
OutputFileConfig outputFileConfig) |
org.apache.flink.connector.file.sink.writer.FileWriterBucket<IN> |
DefaultFileWriterBucketFactory.restoreBucket(BucketWriter<IN,String> bucketWriter,
RollingPolicy<IN,String> rollingPolicy,
FileWriterBucketState bucketState,
OutputFileConfig outputFileConfig) |
Constructor and Description |
---|
FileWriter(Path basePath,
SinkWriterMetricGroup metricGroup,
BucketAssigner<IN,String> bucketAssigner,
FileWriterBucketFactory<IN> bucketFactory,
BucketWriter<IN,String> bucketWriter,
RollingPolicy<IN,String> rollingPolicy,
OutputFileConfig outputFileConfig,
Sink.ProcessingTimeService processingTimeService,
long bucketCheckInterval)
A constructor creating a new empty bucket manager.
|
Modifier and Type | Method and Description |
---|---|
Bucket<IN,BucketID> |
BucketFactory.getNewBucket(int subtaskIndex,
BucketID bucketId,
Path bucketPath,
long initialPartCounter,
BucketWriter<IN,BucketID> bucketWriter,
RollingPolicy<IN,BucketID> rollingPolicy,
FileLifeCycleListener<BucketID> fileListener,
OutputFileConfig outputFileConfig) |
Bucket<IN,BucketID> |
DefaultBucketFactoryImpl.getNewBucket(int subtaskIndex,
BucketID bucketId,
Path bucketPath,
long initialPartCounter,
BucketWriter<IN,BucketID> bucketWriter,
RollingPolicy<IN,BucketID> rollingPolicy,
FileLifeCycleListener<BucketID> fileListener,
OutputFileConfig outputFileConfig) |
Bucket<IN,BucketID> |
BucketFactory.restoreBucket(int subtaskIndex,
long initialPartCounter,
BucketWriter<IN,BucketID> bucketWriter,
RollingPolicy<IN,BucketID> rollingPolicy,
org.apache.flink.streaming.api.functions.sink.filesystem.BucketState<BucketID> bucketState,
FileLifeCycleListener<BucketID> fileListener,
OutputFileConfig outputFileConfig) |
Bucket<IN,BucketID> |
DefaultBucketFactoryImpl.restoreBucket(int subtaskIndex,
long initialPartCounter,
BucketWriter<IN,BucketID> bucketWriter,
RollingPolicy<IN,BucketID> rollingPolicy,
org.apache.flink.streaming.api.functions.sink.filesystem.BucketState<BucketID> bucketState,
FileLifeCycleListener<BucketID> fileListener,
OutputFileConfig outputFileConfig) |
<ID> StreamingFileSink.RowFormatBuilder<IN,ID,? extends StreamingFileSink.RowFormatBuilder<IN,ID,?>> |
StreamingFileSink.RowFormatBuilder.withNewBucketAssignerAndPolicy(BucketAssigner<IN,ID> assigner,
RollingPolicy<IN,ID> policy) |
T |
StreamingFileSink.RowFormatBuilder.withRollingPolicy(RollingPolicy<IN,BucketID> policy) |
Constructor and Description |
---|
Buckets(Path basePath,
BucketAssigner<IN,BucketID> bucketAssigner,
BucketFactory<IN,BucketID> bucketFactory,
BucketWriter<IN,BucketID> bucketWriter,
RollingPolicy<IN,BucketID> rollingPolicy,
int subtaskIndex,
OutputFileConfig outputFileConfig)
A constructor creating a new empty bucket manager.
|
RowFormatBuilder(Path basePath,
Encoder<IN> encoder,
BucketAssigner<IN,BucketID> assigner,
RollingPolicy<IN,BucketID> policy,
long bucketCheckInterval,
BucketFactory<IN,BucketID> bucketFactory,
OutputFileConfig outputFileConfig) |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointRollingPolicy<IN,BucketID>
An abstract
RollingPolicy which rolls on every checkpoint. |
class |
DefaultRollingPolicy<IN,BucketID>
The default implementation of the
RollingPolicy . |
class |
OnCheckpointRollingPolicy<IN,BucketID>
A
RollingPolicy which rolls (ONLY) on every checkpoint. |
Modifier and Type | Class and Description |
---|---|
static class |
FileSystemTableSink.TableRollingPolicy
Table
RollingPolicy , it extends CheckpointRollingPolicy for bulk writers. |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.