c0917f23700bdef499ede8cf079aceb37bfe2710
Files Diff
- Added: 5
- Removed: 9
- Renamed: 0
- Modified: 26
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Rename Method | 1 | ||
Rename Method public initialize() : void renamed to public open(configuration Configuration) : void in class org.apache.flink.streaming.connectors.kafka.api.KafkaSink | From | To | |
Change Parameter Type | 2 | ||
Change Parameter Type value : T to value : Object in method public partition(value Object, numberOfPartitions int) : int in class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaConstantPartitioner | From | To | |
Change Parameter Type partitioner : KafkaPartitioner<IN> to partitioner : SerializableKafkaPartitioner in method public KafkaSink(zookeeperAddress String, topicId String, serializationSchema SerializationSchema<IN,byte[]>, partitioner SerializableKafkaPartitioner) in class org.apache.flink.streaming.connectors.kafka.api.KafkaSink | From | To | |
Inline Method | 1 | ||
Inline Method public createTopic(topicName String, numOfPartitions int, replicationFactor int, topicProperties Properties) : void inlined to public createTopic(topicName String, numOfPartitions int, replicationFactor int) : void in class org.apache.flink.streaming.connectors.kafka.api.simple.KafkaTopicUtils | From | To | |
Rename Variable | 1 | ||
Rename Variable errorDataLen : int to len : int in method public read(in DataInputView) : void in class org.apache.flink.runtime.taskmanager.TaskExecutionState | From | To | |
Move Attribute | 3 | ||
Move Attribute protected topicId : String from class org.apache.flink.streaming.connectors.kafka.api.simple.SimpleKafkaSource to private topicId : String from class org.apache.flink.streaming.connectors.kafka.api.simple.PersistentKafkaSource | From | To | |
Move Attribute protected zookeeperServerAddress : String from class org.apache.flink.streaming.connectors.kafka.api.simple.SimpleKafkaSource to private zookeeperServerAddress : String from class org.apache.flink.streaming.connectors.kafka.api.simple.PersistentKafkaSource | From | To | |
Move Attribute protected iterator : KafkaConsumerIterator from class org.apache.flink.streaming.connectors.kafka.api.simple.SimpleKafkaSource to private iterator : KafkaConsumerIterator from class org.apache.flink.streaming.connectors.kafka.api.simple.PersistentKafkaSource | From | To | |
Extract Attribute | 2 | ||
Extract Attribute public DEFAULT_ZOOKEEPER_SESSION_TIMEOUT_MS : int in class org.apache.flink.streaming.connectors.kafka.api.simple.KafkaTopicUtils | From | To | |
Extract Attribute public DEFAULT_ZOOKEEPER_CONNECTION_TIMEOUT_MS : int in class org.apache.flink.streaming.connectors.kafka.api.simple.KafkaTopicUtils | From | To | |
Rename Class | 3 | ||
Rename Class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner renamed to org.apache.flink.streaming.connectors.kafka.partitioner.SerializableKafkaPartitioner | From | To | |
Rename Class org.apache.flink.streaming.connectors.kafka.StringSerializerTest renamed to org.apache.flink.streaming.connectors.kafka.KafkaITCase | From | To | |
Rename Class org.apache.flink.streaming.connectors.kafka.api.simple.iterator.KafkaOnePartitionIterator renamed to org.apache.flink.streaming.connectors.kafka.api.simple.iterator.KafkaSinglePartitionIterator | From | To | |
Rename Attribute | 1 | ||
Rename Attribute zookeeperHost : String to zookeeperAddress : String in class org.apache.flink.streaming.connectors.kafka.api.KafkaSource | From | To | |
Change Variable Type | 2 | ||
Change Variable Type partition : KafkaOnePartitionIterator to partition : KafkaSinglePartitionIterator in method public initialize() : void in class org.apache.flink.streaming.connectors.kafka.api.simple.iterator.KafkaMultiplePartitionsIterator | From | To | |
Change Variable Type partition : KafkaOnePartitionIterator to partition : KafkaSinglePartitionIterator in method public nextWithOffset() : MessageWithMetadata in class org.apache.flink.streaming.connectors.kafka.api.simple.iterator.KafkaMultiplePartitionsIterator | From | To | |
Extract Interface | 1 | ||
Extract Interface org.apache.flink.streaming.connectors.kafka.partitioner.SerializableKafkaPartitioner from classes [org.apache.flink.streaming.connectors.kafka.partitioner.KafkaConstantPartitioner] | From | To | |
Change Attribute Type | 3 | ||
Change Attribute Type partitioner : KafkaPartitioner<IN> to partitioner : SerializableKafkaPartitioner in class org.apache.flink.streaming.connectors.kafka.api.KafkaSink | From | To | |
Change Attribute Type state : Map<String,OperatorState<?>> to state : byte[] in class org.apache.flink.runtime.state.LocalStateHandle | From | To | |
Change Attribute Type partitions : List<KafkaOnePartitionIterator> to partitions : List<KafkaSinglePartitionIterator> in class org.apache.flink.streaming.connectors.kafka.api.simple.iterator.KafkaMultiplePartitionsIterator | From | To | |
Rename Parameter | 8 | ||
Rename Parameter zookeeperServer : String to zookeeperAddress : String in method public KafkaTopicUtils(zookeeperAddress String, sessionTimeoutMs int, connectionTimeoutMs int) in class org.apache.flink.streaming.connectors.kafka.api.simple.KafkaTopicUtils | From | To | |
Rename Parameter zookeeperHost : String to zookeeperAddress : String in method public PersistentKafkaSource(zookeeperAddress String, topicId String, deserializationSchema DeserializationSchema<OUT>, zookeeperSyncTimeMillis int, waitOnEmptyFetchMillis int) in class org.apache.flink.streaming.connectors.kafka.api.simple.PersistentKafkaSource | From | To | |
Rename Parameter zookeeperHost : String to zookeeperAddress : String in method public KafkaSource(zookeeperAddress String, topicId String, deserializationSchema DeserializationSchema<OUT>) in class org.apache.flink.streaming.connectors.kafka.api.KafkaSource | From | To | |
Rename Parameter zookeeperHost : String to zookeeperAddress : String in method public PersistentKafkaSource(zookeeperAddress String, topicId String, deserializationSchema DeserializationSchema<OUT>) in class org.apache.flink.streaming.connectors.kafka.api.simple.PersistentKafkaSource | From | To | |
Rename Parameter zookeeperHost : String to zookeeperAddress : String in method public KafkaSource(zookeeperAddress String, topicId String, deserializationSchema DeserializationSchema<OUT>, zookeeperSyncTimeMillis long) in class org.apache.flink.streaming.connectors.kafka.api.KafkaSource | From | To | |
Rename Parameter brokerAddr : String to zookeeperAddress : String in method public KafkaSink(zookeeperAddress String, topicId String, serializationSchema SerializationSchema<IN,byte[]>, partitioner SerializableKafkaPartitioner) in class org.apache.flink.streaming.connectors.kafka.api.KafkaSink | From | To | |
Rename Parameter brokerAddr : String to zookeeperAddress : String in method public KafkaSink(zookeeperAddress String, topicId String, serializationSchema SerializationSchema<IN,byte[]>) in class org.apache.flink.streaming.connectors.kafka.api.KafkaSink | From | To | |
Rename Parameter zookeeperHost : String to zookeeperAddress : String in method public KafkaSource(zookeeperAddress String, topicId String, groupId String, deserializationSchema DeserializationSchema<OUT>, zookeeperSyncTimeMillis long) in class org.apache.flink.streaming.connectors.kafka.api.KafkaSource | From | To |