|
Change Parameter Type bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in method package Buckets(basePath Path, bucketAssigner BucketAssigner<IN,BucketID>, bucketFactory BucketFactory<IN,BucketID>, partFileWriterFactory PartFileWriter.PartFileFactory<IN,BucketID>, rollingPolicy RollingPolicy<IN,BucketID>, subtaskIndex int) in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method public withBucketAssigner(assigner BucketAssigner<IN,BucketID>) : StreamingFileSink.RowFormatBuilder<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method package BulkFormatBuilder(basePath Path, writerFactory BulkWriter.Factory<IN>, assigner BucketAssigner<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Change Parameter Type context : Bucketer.Context to context : BucketAssigner.Context in method public getBucketId(element IN, context BucketAssigner.Context) : String in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.DateTimeBucketAssigner |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,ID> to assigner : BucketAssigner<IN,ID> in method public withBucketAssigner(assigner BucketAssigner<IN,ID>) : StreamingFileSink.BulkFormatBuilder<IN,ID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Change Parameter Type context : Bucketer.Context to context : BucketAssigner.Context in method public getBucketId(element IN, context BucketAssigner.Context) : BucketID in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketAssigner |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method private RowFormatBuilder(basePath Path, encoder Encoder<IN>, assigner BucketAssigner<IN,BucketID>, policy RollingPolicy<IN,BucketID>, bucketCheckInterval long, bucketFactory BucketFactory<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,ID> to assigner : BucketAssigner<IN,ID> in method public withBucketAssignerAndPolicy(assigner BucketAssigner<IN,ID>, policy RollingPolicy<IN,ID>) : StreamingFileSink.RowFormatBuilder<IN,ID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Change Parameter Type context : Bucketer.Context to context : BucketAssigner.Context in method public getBucketId(element T, context BucketAssigner.Context) : String in class org.apache.flink.streaming.api.functions.sink.filesystem.bucketassigners.BasePathBucketAssigner |
From |
To |
|
Change Parameter Type bucketer : Bucketer<Tuple2<String,Integer>,String> to bucketer : BucketAssigner<Tuple2<String,Integer>,String> in method package createTestSinkWithBulkEncoder(outDir File, totalParallelism int, taskIdx int, bucketCheckInterval long, bucketer BucketAssigner<Tuple2<String,Integer>,String>, writer BulkWriter.Factory<Tuple2<String,Integer>>, bucketFactory BucketFactory<Tuple2<String,Integer>,String>) : OneInputStreamOperatorTestHarness<Tuple2<String,Integer>,Object> in class org.apache.flink.streaming.api.functions.sink.filesystem.TestUtils |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method private BulkFormatBuilder(basePath Path, writerFactory BulkWriter.Factory<IN>, assigner BucketAssigner<IN,BucketID>, bucketCheckInterval long, bucketFactory BucketFactory<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Change Parameter Type bucketer : Bucketer<Tuple2<String,Integer>,String> to bucketer : BucketAssigner<Tuple2<String,Integer>,String> in method package createCustomRescalingTestSink(outDir File, totalParallelism int, taskIdx int, bucketCheckInterval long, bucketer BucketAssigner<Tuple2<String,Integer>,String>, writer Encoder<Tuple2<String,Integer>>, rollingPolicy RollingPolicy<Tuple2<String,Integer>,String>, bucketFactory BucketFactory<Tuple2<String,Integer>,String>) : OneInputStreamOperatorTestHarness<Tuple2<String,Integer>,Object> in class org.apache.flink.streaming.api.functions.sink.filesystem.TestUtils |
From |
To |
|
Change Parameter Type bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in method package RowFormatBuilder(basePath Path, encoder Encoder<IN>, bucketAssigner BucketAssigner<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Method public onCheckpointAcknowledgment(checkpointId long) : void renamed to package onSuccessfulCompletionOfCheckpoint(checkpointId long) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Method package publishUpToCheckpoint(checkpointId long) : void renamed to package commitUpToCheckpoint(checkpointId long) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Method public withBucketerAndPolicy(bucketer Bucketer<IN,ID>, policy RollingPolicy<IN,ID>) : StreamingFileSink.RowFormatBuilder<IN,ID> renamed to public withBucketAssignerAndPolicy(assigner BucketAssigner<IN,ID>, policy RollingPolicy<IN,ID>) : StreamingFileSink.RowFormatBuilder<IN,ID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Method public withBucketer(bucketer Bucketer<IN,BucketID>) : StreamingFileSink.RowFormatBuilder<IN,BucketID> renamed to public withBucketAssigner(assigner BucketAssigner<IN,BucketID>) : StreamingFileSink.RowFormatBuilder<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Method public getPendingPerCheckpoint() : Map<Long,List<RecoverableWriter.CommitRecoverable>> renamed to package getCommittableFilesPerCheckpoint() : Map<Long,List<RecoverableWriter.CommitRecoverable>> in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Method public getCreationTime() : long renamed to package getInProgressFileCreationTime() : long in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Method public getInProgress() : RecoverableWriter.ResumeRecoverable renamed to package getInProgressResumableFile() : RecoverableWriter.ResumeRecoverable in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Method public dispose() : void renamed to package disposePartFile() : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Method private getNewPartPath() : Path renamed to private assembleNewPartPath() : Path in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Method public withBucketer(bucketer Bucketer<IN,ID>) : StreamingFileSink.BulkFormatBuilder<IN,ID> renamed to public withBucketAssigner(assigner BucketAssigner<IN,ID>) : StreamingFileSink.BulkFormatBuilder<IN,ID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Rename Method public onCheckpoint(checkpointId long) : BucketState<BucketID> renamed to package onReceptionOfCheckpoint(checkpointId long) : BucketState<BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable commitable : RecoverableWriter.CommitRecoverable to committable : RecoverableWriter.CommitRecoverable in method package onSuccessfulCompletionOfCheckpoint(checkpointId long) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable resumable : RecoverableWriter.ResumeRecoverable to inProgressResumable : RecoverableWriter.ResumeRecoverable in method package onReceptionOfCheckpoint(checkpointId long) : BucketState<BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable creationTime : long to inProgressFileCreationTime : long in method package onReceptionOfCheckpoint(checkpointId long) : BucketState<BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable commitable : RecoverableWriter.CommitRecoverable to committable : RecoverableWriter.CommitRecoverable in method private commitRecoveredPendingFiles(state BucketState<BucketID>) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable commitable : RecoverableWriter.CommitRecoverable to committable : RecoverableWriter.CommitRecoverable in method package merge(bucket Bucket<IN,BucketID>) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable commitable : RecoverableWriter.CommitRecoverable to committable : RecoverableWriter.CommitRecoverable in method private closePartFile() : RecoverableWriter.CommitRecoverable in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Variable commitables : List<RecoverableWriter.CommitRecoverable> to committables : List<RecoverableWriter.CommitRecoverable> in method private commitRecoveredPendingFiles(state BucketState<BucketID>) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Attribute bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Rename Attribute currentPart : PartFileWriter<IN,BucketID> to inProgressPart : PartFileWriter<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.Bucket |
From |
To |
|
Rename Attribute fileSystemWriter : RecoverableWriter to fsWriter : RecoverableWriter in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Attribute inProgress : RecoverableWriter.ResumeRecoverable to inProgressResumableFile : RecoverableWriter.ResumeRecoverable in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Attribute maxPartCounterUsed : long to maxPartCounter : long in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Attribute pendingPerCheckpoint : Map<Long,List<RecoverableWriter.CommitRecoverable>> to committableFilesPerCheckpoint : Map<Long,List<RecoverableWriter.CommitRecoverable>> in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Attribute creationTime : long to inProgressFileCreationTime : long in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Attribute bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Attribute bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method package BulkFormatBuilder(basePath Path, writerFactory BulkWriter.Factory<IN>, assigner BucketAssigner<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Rename Parameter bucketStates : ListState<byte[]> to bucketStatesContainer : ListState<byte[]> in method private snapshotActiveBuckets(checkpointId long, bucketStatesContainer ListState<byte[]>) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in method package RowFormatBuilder(basePath Path, encoder Encoder<IN>, bucketAssigner BucketAssigner<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Parameter partCounterState : ListState<Long> to partCounterStateContainer : ListState<Long> in method package snapshotState(checkpointId long, bucketStatesContainer ListState<byte[]>, partCounterStateContainer ListState<Long>) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,ID> to assigner : BucketAssigner<IN,ID> in method public withBucketAssigner(assigner BucketAssigner<IN,ID>) : StreamingFileSink.BulkFormatBuilder<IN,ID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Rename Parameter bucketStates : ListState<byte[]> to bucketStatesContainer : ListState<byte[]> in method package snapshotState(checkpointId long, bucketStatesContainer ListState<byte[]>, partCounterStateContainer ListState<Long>) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method private RowFormatBuilder(basePath Path, encoder Encoder<IN>, assigner BucketAssigner<IN,BucketID>, policy RollingPolicy<IN,BucketID>, bucketCheckInterval long, bucketFactory BucketFactory<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Parameter element : Long to elementTimestamp : Long in method package update(elementTimestamp Long, watermark long, processingTime long) : void in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets.BucketerContext |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,BucketID> to bucketAssigner : BucketAssigner<IN,BucketID> in method package Buckets(basePath Path, bucketAssigner BucketAssigner<IN,BucketID>, bucketFactory BucketFactory<IN,BucketID>, partFileWriterFactory PartFileWriter.PartFileFactory<IN,BucketID>, rollingPolicy RollingPolicy<IN,BucketID>, subtaskIndex int) in class org.apache.flink.streaming.api.functions.sink.filesystem.Buckets |
From |
To |
|
Rename Parameter rollingPolicy : RollingPolicy<IN,BucketID> to policy : RollingPolicy<IN,BucketID> in method private RowFormatBuilder(basePath Path, encoder Encoder<IN>, assigner BucketAssigner<IN,BucketID>, policy RollingPolicy<IN,BucketID>, bucketCheckInterval long, bucketFactory BucketFactory<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,ID> to assigner : BucketAssigner<IN,ID> in method public withBucketAssignerAndPolicy(assigner BucketAssigner<IN,ID>, policy RollingPolicy<IN,ID>) : StreamingFileSink.RowFormatBuilder<IN,ID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method private BulkFormatBuilder(basePath Path, writerFactory BulkWriter.Factory<IN>, assigner BucketAssigner<IN,BucketID>, bucketCheckInterval long, bucketFactory BucketFactory<IN,BucketID>) in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.BulkFormatBuilder |
From |
To |
|
Rename Parameter inProgress : RecoverableWriter.ResumeRecoverable to inProgressResumableFile : RecoverableWriter.ResumeRecoverable in method package BucketState(bucketId BucketID, bucketPath Path, inProgressFileCreationTime long, inProgressResumableFile RecoverableWriter.ResumeRecoverable, pendingCommittablesPerCheckpoint Map<Long,List<RecoverableWriter.CommitRecoverable>>) in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Parameter pendingPerCheckpoint : Map<Long,List<RecoverableWriter.CommitRecoverable>> to pendingCommittablesPerCheckpoint : Map<Long,List<RecoverableWriter.CommitRecoverable>> in method package BucketState(bucketId BucketID, bucketPath Path, inProgressFileCreationTime long, inProgressResumableFile RecoverableWriter.ResumeRecoverable, pendingCommittablesPerCheckpoint Map<Long,List<RecoverableWriter.CommitRecoverable>>) in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Parameter creationTime : long to inProgressFileCreationTime : long in method package BucketState(bucketId BucketID, bucketPath Path, inProgressFileCreationTime long, inProgressResumableFile RecoverableWriter.ResumeRecoverable, pendingCommittablesPerCheckpoint Map<Long,List<RecoverableWriter.CommitRecoverable>>) in class org.apache.flink.streaming.api.functions.sink.filesystem.BucketState |
From |
To |
|
Rename Parameter bucketer : Bucketer<IN,BucketID> to assigner : BucketAssigner<IN,BucketID> in method public withBucketAssigner(assigner BucketAssigner<IN,BucketID>) : StreamingFileSink.RowFormatBuilder<IN,BucketID> in class org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSink.RowFormatBuilder |
From |
To |