|
Rename Method protected subscribedPartitions() : KafkaTopicPartitionState<KPH>[] renamed to protected subscribedPartitionStates() : KafkaTopicPartitionState<KPH>[] in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher |
From |
To |
|
Rename Method public seekPartitionsToEnd(consumer KafkaConsumer<?,?>, partitions List<TopicPartition>) : void renamed to public seekPartitionToEnd(consumer KafkaConsumer<?,?>, partition TopicPartition) : void in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010 |
From |
To |
|
Rename Method private initializePartitions(assignedPartitions List<KafkaTopicPartition>, timestampWatermarkMode int, watermarksPeriodic SerializedValue<AssignerWithPeriodicWatermarks<T>>, watermarksPunctuated SerializedValue<AssignerWithPunctuatedWatermarks<T>>, userCodeClassLoader ClassLoader) : KafkaTopicPartitionState<KPH>[] renamed to private initializeSubscribedPartitionStates(assignedPartitionsToInitialOffsets Map<KafkaTopicPartition,Long>, timestampWatermarkMode int, watermarksPeriodic SerializedValue<AssignerWithPeriodicWatermarks<T>>, watermarksPunctuated SerializedValue<AssignerWithPunctuatedWatermarks<T>>, userCodeClassLoader ClassLoader) : KafkaTopicPartitionState<KPH>[] in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher |
From |
To |
|
Rename Method public seekPartitionsToBeginning(consumer KafkaConsumer<?,?>, partitions List<TopicPartition>) : void renamed to public seekPartitionToBeginning(consumer KafkaConsumer<?,?>, partition TopicPartition) : void in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010 |
From |
To |
|
Change Parameter Type assignedPartitions : List<KafkaTopicPartition> to assignedPartitionsToInitialOffsets : Map<KafkaTopicPartition,Long> in method private initializeSubscribedPartitionStates(assignedPartitionsToInitialOffsets Map<KafkaTopicPartition,Long>, timestampWatermarkMode int, watermarksPeriodic SerializedValue<AssignerWithPeriodicWatermarks<T>>, watermarksPunctuated SerializedValue<AssignerWithPunctuatedWatermarks<T>>, userCodeClassLoader ClassLoader) : KafkaTopicPartitionState<KPH>[] in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher |
From |
To |
|
Change Parameter Type partitions : List<TopicPartition> to partition : TopicPartition in method public seekPartitionToEnd(consumer KafkaConsumer<?,?>, partition TopicPartition) : void in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010 |
From |
To |
|
Change Parameter Type partitions : List<TopicPartition> to partition : TopicPartition in method public seekPartitionToBeginning(consumer KafkaConsumer<?,?>, partition TopicPartition) : void in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010 |
From |
To |
|
Rename Variable parts3 : List<KafkaTopicPartition> to subscribedPartitions3 : List<KafkaTopicPartition> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable parts : List<KafkaTopicPartition> to subscribedPartitions : List<KafkaTopicPartition> in method public testMultiplePartitionsPerConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCommitDoesNotBlock() : void in class org.apache.flink.streaming.connectors.kafka.Kafka09FetcherTest |
From |
To |
|
Rename Variable parts2 : List<KafkaTopicPartition> to subscribedPartitions2 : List<KafkaTopicPartition> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public ensureOffsetsGetCommitted() : void in class org.apache.flink.streaming.connectors.kafka.Kafka010FetcherTest |
From |
To |
|
Rename Variable parts1 : List<KafkaTopicPartition> to subscribedPartitions1 : List<KafkaTopicPartition> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCancellationWhenEmitBlocks() : void in class org.apache.flink.streaming.connectors.kafka.Kafka010FetcherTest |
From |
To |
|
Rename Variable parts2new : List<KafkaTopicPartition> to subscribedPartitions2New : List<KafkaTopicPartition> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable kafkaTopicPartitionLongEntry : Map.Entry<KafkaTopicPartition,Long> to subscribedPartition : Map.Entry<KafkaTopicPartition,Long> in method public snapshotState(context FunctionSnapshotContext) : void in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase |
From |
To |
|
Rename Variable topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public ensureOffsetsGetCommitted() : void in class org.apache.flink.streaming.connectors.kafka.Kafka09FetcherTest |
From |
To |
|
Rename Variable parts : List<KafkaTopicPartition> to subscribedPartitions : List<KafkaTopicPartition> in method public testPartitionsFewerThanConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable parts : List<KafkaTopicPartition> to subscribedPartitions : List<KafkaTopicPartition> in method public testPartitionsEqualConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable parts1new : List<KafkaTopicPartition> to subscribedPartitions1New : List<KafkaTopicPartition> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable parts3new : List<KafkaTopicPartition> to subscribedPartitions3New : List<KafkaTopicPartition> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Rename Variable topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCommitDoesNotBlock() : void in class org.apache.flink.streaming.connectors.kafka.Kafka010FetcherTest |
From |
To |
|
Rename Variable topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCancellationWhenEmitBlocks() : void in class org.apache.flink.streaming.connectors.kafka.Kafka09FetcherTest |
From |
To |
|
Change Variable Type topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public ensureOffsetsGetCommitted() : void in class org.apache.flink.streaming.connectors.kafka.Kafka09FetcherTest |
From |
To |
|
Change Variable Type topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCommitDoesNotBlock() : void in class org.apache.flink.streaming.connectors.kafka.Kafka09FetcherTest |
From |
To |
|
Change Variable Type topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public ensureOffsetsGetCommitted() : void in class org.apache.flink.streaming.connectors.kafka.Kafka010FetcherTest |
From |
To |
|
Change Variable Type topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCancellationWhenEmitBlocks() : void in class org.apache.flink.streaming.connectors.kafka.Kafka010FetcherTest |
From |
To |
|
Change Variable Type topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCancellationWhenEmitBlocks() : void in class org.apache.flink.streaming.connectors.kafka.Kafka09FetcherTest |
From |
To |
|
Change Variable Type partition : KafkaTopicPartition to partition : Map.Entry<KafkaTopicPartition,Long> in method private initializeSubscribedPartitionStates(assignedPartitionsToInitialOffsets Map<KafkaTopicPartition,Long>, timestampWatermarkMode int, watermarksPeriodic SerializedValue<AssignerWithPeriodicWatermarks<T>>, watermarksPunctuated SerializedValue<AssignerWithPunctuatedWatermarks<T>>, userCodeClassLoader ClassLoader) : KafkaTopicPartitionState<KPH>[] in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher |
From |
To |
|
Change Variable Type topics : List<KafkaTopicPartition> to partitionsWithInitialOffsets : Map<KafkaTopicPartition,Long> in method public testCommitDoesNotBlock() : void in class org.apache.flink.streaming.connectors.kafka.Kafka010FetcherTest |
From |
To |
|
Rename Parameter partitions : List<TopicPartition> to partition : TopicPartition in method public seekPartitionToBeginning(consumer KafkaConsumer<?,?>, partition TopicPartition) : void in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010 |
From |
To |
|
Rename Parameter subscribedPartitions : KafkaTopicPartitionState<TopicPartition>[] to subscribedPartitionStates : KafkaTopicPartitionState<TopicPartition>[] in method public KafkaConsumerThread(log Logger, handover Handover, kafkaProperties Properties, subscribedPartitionStates KafkaTopicPartitionState<TopicPartition>[], kafkaMetricGroup MetricGroup, consumerCallBridge KafkaConsumerCallBridge, threadName String, pollTimeout long, useMetrics boolean) in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerThread |
From |
To |
|
Rename Parameter assignedPartitions : List<KafkaTopicPartition> to assignedPartitionsToInitialOffsets : Map<KafkaTopicPartition,Long> in method private initializeSubscribedPartitionStates(assignedPartitionsToInitialOffsets Map<KafkaTopicPartition,Long>, timestampWatermarkMode int, watermarksPeriodic SerializedValue<AssignerWithPeriodicWatermarks<T>>, watermarksPunctuated SerializedValue<AssignerWithPunctuatedWatermarks<T>>, userCodeClassLoader ClassLoader) : KafkaTopicPartitionState<KPH>[] in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher |
From |
To |
|
Rename Parameter partitions : List<TopicPartition> to partition : TopicPartition in method public seekPartitionToEnd(consumer KafkaConsumer<?,?>, partition TopicPartition) : void in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010 |
From |
To |