|
Change Parameter Type partitions : List<TopicPartition> to partitions : List<KafkaTopicPartitionLeader> in method public seekFetcherToInitialOffsets(partitions List<KafkaTopicPartitionLeader>, fetcher Fetcher) : void in class org.apache.flink.streaming.connectors.kafka.internals.OffsetHandler |
From |
To |
|
Change Parameter Type lastOffsets : long[] to lastOffsets : HashMap<KafkaTopicPartition,Long> in method public run(sourceContext SourceFunction.SourceContext<T>, valueDeserializer KeyedDeserializationSchema<T>, lastOffsets HashMap<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.Fetcher |
From |
To |
|
Change Parameter Type topic : String to topics : List<String> in method public getPartitionsForTopic(topics List<String>, properties Properties) : List<KafkaTopicPartitionLeader> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Parameter Type offsetsToCommit : Map<TopicPartition,Long> to offsetsToCommit : Map<KafkaTopicPartition,Long> in method public commit(offsetsToCommit Map<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler |
From |
To |
|
Change Parameter Type topic : String to topics : List<String> in method package PartitionInfoFetcher(topics List<String>, properties Properties) in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher.PartitionInfoFetcher |
From |
To |
|
Change Parameter Type topicPartition : TopicPartition to topicPartition : KafkaTopicPartition in method public seek(topicPartition KafkaTopicPartition, offsetToRead long) : void in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Parameter Type topic : String to topics : List<String> in method public FlinkKafkaConsumer(topics List<String>, deserializer KeyedDeserializationSchema<T>, props Properties, offsetStore OffsetStore, fetcherType FetcherType) in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Parameter Type lastOffsets : long[] to lastOffsets : HashMap<KafkaTopicPartition,Long> in method public run(sourceContext SourceFunction.SourceContext<T>, deserializer KeyedDeserializationSchema<T>, lastOffsets HashMap<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Parameter Type consumer : FlinkKafkaConsumer to consumer : FlinkKafkaConsumer<T> in method public PeriodicOffsetCommitter(commitInterval long, consumer FlinkKafkaConsumer<T>) in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer.PeriodicOffsetCommitter |
From |
To |
|
Change Parameter Type partitions : int[] to partitions : List<KafkaTopicPartitionLeader> in method protected assignPartitions(partitions List<KafkaTopicPartitionLeader>, numConsumers int, consumerIndex int) : List<KafkaTopicPartitionLeader> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Parameter Type partitions : List<TopicPartition> to partitions : List<KafkaTopicPartitionLeader> in method public seekFetcherToInitialOffsets(partitions List<KafkaTopicPartitionLeader>, fetcher Fetcher) : void in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler |
From |
To |
|
Change Parameter Type topicPartition : TopicPartition to topicPartition : KafkaTopicPartition in method public seek(topicPartition KafkaTopicPartition, offsetToRead long) : void in class org.apache.flink.streaming.connectors.kafka.internals.Fetcher |
From |
To |
|
Change Parameter Type topic : String to topic : List<String> in method public FlinkKafkaConsumer(topic List<String>, deserializer DeserializationSchema<T>, props Properties, offsetStore OffsetStore, fetcherType FetcherType) in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Parameter Type offsetsState : long[] to offsetsState : HashMap<KafkaTopicPartition,Long> in method public SimpleConsumerThread(owner LegacyFetcher, config Properties, broker Node, partitions FetchPartition[], sourceContext SourceFunction.SourceContext<T>, deserializer KeyedDeserializationSchema<T>, offsetsState HashMap<KafkaTopicPartition,Long>) in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher.SimpleConsumerThread |
From |
To |
|
Change Parameter Type restoredOffsets : long[] to restoredOffsets : HashMap<KafkaTopicPartition,Long> in method public restoreState(restoredOffsets HashMap<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Parameter Type partitions : List<TopicPartition> to partitions : List<KafkaTopicPartitionLeader> in method public LegacyFetcher(partitions List<KafkaTopicPartitionLeader>, props Properties, taskName String) in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Parameter Type offsetsToCommit : Map<TopicPartition,Long> to offsetsToCommit : Map<KafkaTopicPartition,Long> in method public commit(offsetsToCommit Map<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.OffsetHandler |
From |
To |
|
Change Variable Type p : TopicPartition to p : KafkaTopicPartitionLeader in method public testMultiplePartitionsPerConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type partitionsToSub : List<TopicPartition> to partitionsToSub : List<KafkaTopicPartitionLeader> in method protected assignPartitions(partitions List<KafkaTopicPartitionLeader>, numConsumers int, consumerIndex int) : List<KafkaTopicPartitionLeader> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Variable Type checkpointOffsets : long[] to checkpointOffsets : HashMap<KafkaTopicPartition,Long> in method public notifyCheckpointComplete(checkpointId long) : void in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Variable Type parts1 : List<TopicPartition> to parts1 : List<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type parts1new : List<TopicPartition> to parts1new : List<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type tp : TopicPartition to tp : KafkaTopicPartitionLeader in method public seekFetcherToInitialOffsets(partitions List<KafkaTopicPartitionLeader>, fetcher Fetcher) : void in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler |
From |
To |
|
Change Variable Type partitions : int[] to inPartitions : List<KafkaTopicPartitionLeader> in method public testPartitionsEqualConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type state2 : long[] to state2 : HashMap<KafkaTopicPartition,Long> in method public runCheckpointingTest() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerTestBase |
From |
To |
|
Change Variable Type topicPartition : TopicPartition to topicPartition : KafkaTopicPartitionLeader in method public run(sourceContext SourceFunction.SourceContext<T>, deserializer KeyedDeserializationSchema<T>, lastOffsets HashMap<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Variable Type allPartitionsInTopic : List<PartitionInfo> to topicPartitionWithLeaderList : List<KafkaTopicPartitionLeader> in method public run(sourceContext SourceFunction.SourceContext<T>, deserializer KeyedDeserializationSchema<T>, lastOffsets HashMap<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Variable Type parts2new : List<TopicPartition> to parts2new : List<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type partitions : List<PartitionInfo> to partitions : List<KafkaTopicPartitionLeader> in method public getPartitionsForTopic(topics List<String>, properties Properties) : List<KafkaTopicPartitionLeader> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Variable Type entry : Map.Entry<TopicPartition,Long> to entry : Map.Entry<KafkaTopicPartitionLeader,Long> in method public run(sourceContext SourceFunction.SourceContext<T>, deserializer KeyedDeserializationSchema<T>, lastOffsets HashMap<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Variable Type partitions : int[] to inPartitions : List<KafkaTopicPartitionLeader> in method public testPartitionsFewerThanConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type tp : TopicPartition to p : KafkaTopicPartitionLeader in method public LegacyFetcher(partitions List<KafkaTopicPartitionLeader>, props Properties, taskName String) in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Variable Type parts : List<TopicPartition> to parts : List<KafkaTopicPartitionLeader> in method public testPartitionsEqualConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type state1 : long[] to state1 : HashMap<KafkaTopicPartition,Long> in method public runCheckpointingTest() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerTestBase |
From |
To |
|
Change Variable Type parts2 : List<TopicPartition> to parts2 : List<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type p : TopicPartition to p : KafkaTopicPartitionLeader in method public testPartitionsFewerThanConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type offsetsToCommit : Map<TopicPartition,Long> to offsetsToCommit : Map<KafkaTopicPartition,Long> in method private commitOffsets(toCommit HashMap<KafkaTopicPartition,Long>, consumer FlinkKafkaConsumer<T>) : void in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Variable Type parts3new : List<TopicPartition> to parts3new : List<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type tp : TopicPartition to tp : KafkaTopicPartition in method public commit(offsetsToCommit Map<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler |
From |
To |
|
Change Variable Type p : TopicPartition to p : KafkaTopicPartitionLeader in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type allPartitions : Set<Integer> to allPartitions : Set<KafkaTopicPartitionLeader> in method public testMultiplePartitionsPerConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type allNewPartitions : Set<Integer> to allNewPartitions : Set<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type allInitialPartitions : Set<Integer> to allInitialPartitions : Set<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type allPartitions : Set<Integer> to allPartitions : Set<KafkaTopicPartitionLeader> in method public testPartitionsFewerThanConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type parts1 : List<TopicPartition> to parts1 : List<KafkaTopicPartitionLeader> in method public testAssignEmptyPartitions() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type partitions : List<PartitionInfo> to partitions : List<KafkaTopicPartitionLeader> in method protected createTestTopic(topic String, numberOfPartitions int, replicationFactor int) : void in class org.apache.flink.streaming.connectors.kafka.KafkaTestBase |
From |
To |
|
Change Variable Type checkpoint : long[] to checkpoint : HashMap<KafkaTopicPartition,Long> in method public testSnapshot() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerTest |
From |
To |
|
Change Variable Type offsetCommitter : PeriodicOffsetCommitter to offsetCommitter : PeriodicOffsetCommitter<T> in method public run(sourceContext SourceContext<T>) : void in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Variable Type parts2 : List<TopicPartition> to parts2 : List<KafkaTopicPartitionLeader> in method public testAssignEmptyPartitions() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type entry : Map.Entry<TopicPartition,Long> to entry : Map.Entry<KafkaTopicPartition,Long> in method public commit(offsetsToCommit Map<KafkaTopicPartition,Long>) : void in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler |
From |
To |
|
Change Variable Type parts : List<TopicPartition> to parts : List<KafkaTopicPartitionLeader> in method public testMultiplePartitionsPerConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type parts : List<TopicPartition> to parts : List<KafkaTopicPartitionLeader> in method public testPartitionsFewerThanConsumers() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Variable Type parts3 : List<TopicPartition> to parts3 : List<KafkaTopicPartitionLeader> in method public testGrowingPartitionsRemainsStable() : void in class org.apache.flink.streaming.connectors.kafka.KafkaConsumerPartitionAssignmentTest |
From |
To |
|
Change Attribute Type offsetsState : long[] to offsetsState : HashMap<KafkaTopicPartition,Long> in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher.SimpleConsumerThread |
From |
To |
|
Change Attribute Type commitedOffsets : long[] to committedOffsets : HashMap<KafkaTopicPartition,Long> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Attribute Type topic : String to topics : List<String> in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher.PartitionInfoFetcher |
From |
To |
|
Change Attribute Type restoreToOffset : long[] to restoreToOffset : HashMap<KafkaTopicPartition,Long> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Attribute Type result : List<PartitionInfo> to result : List<KafkaTopicPartitionLeader> in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher.PartitionInfoFetcher |
From |
To |
|
Change Attribute Type partitionsToRead : Map<TopicPartition,Long> to partitionsToRead : Map<KafkaTopicPartitionLeader,Long> in class org.apache.flink.streaming.connectors.kafka.internals.LegacyFetcher |
From |
To |
|
Change Attribute Type consumer : FlinkKafkaConsumer to consumer : FlinkKafkaConsumer<T> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer.PeriodicOffsetCommitter |
From |
To |
|
Change Attribute Type subscribedPartitions : List<TopicPartition> to subscribedPartitions : List<KafkaTopicPartitionLeader> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |
|
Change Attribute Type lastOffsets : long[] to lastOffsets : HashMap<KafkaTopicPartition,Long> in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer |
From |
To |