|
Change Parameter Type consumer : ConsumerBase to consumer : ConsumerBase<?> in method package cleanupConsumer(consumer ConsumerBase<?>) : void in class org.apache.pulsar.client.impl.PulsarClientImpl |
From |
To |
|
Change Parameter Type producer : ProducerBase to producer : ProducerBase<?> in method package cleanupProducer(producer ProducerBase<?>) : void in class org.apache.pulsar.client.impl.PulsarClientImpl |
From |
To |
|
Change Parameter Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in method public ConsumerStats(pulsarClient PulsarClientImpl, conf ConsumerConfigurationData<?>, consumer ConsumerImpl<?>) in class org.apache.pulsar.client.impl.ConsumerStats |
From |
To |
|
Change Parameter Type producer : ProducerImpl to producer : ProducerImpl<?> in method package create(producer ProducerImpl<?>, cnx ClientCnx, op OpSendMsg) : WriteInEventLoopCallback in class org.apache.pulsar.client.impl.ProducerImpl.WriteInEventLoopCallback |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<?> in method private getMessageIdImpl(msg Message<?>) : MessageIdImpl in class org.apache.pulsar.client.impl.ConsumerImpl |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<?> in method protected messageProcessed(msg Message<?>) : void in class org.apache.pulsar.client.impl.ConsumerImpl |
From |
To |
|
Change Parameter Type readerListener : ReaderListener to readerListener : ReaderListener<T> in method public readerListener(readerListener ReaderListener<T>) : ReaderBuilder<T> in class org.apache.pulsar.client.impl.ReaderBuilderImpl |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<?> in method public choosePartition(msg Message<?>) : int in class org.apache.pulsar.client.api.MessageRouter |
From |
To |
|
Change Parameter Type msgs : List<MessageImpl> to msgs : List<MessageImpl<?>> in method package create(msgs List<MessageImpl<?>>, cmd ByteBufPair, sequenceId long, callback SendCallback) : OpSendMsg in class org.apache.pulsar.client.impl.ProducerImpl.OpSendMsg |
From |
To |
|
Change Parameter Type consumer : Consumer to consumer : Consumer<byte[]> in method public received(consumer Consumer<byte[]>, msg Message<byte[]>) : void in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Parameter Type msg : MessageImpl to msg : MessageImpl<?> in method package hasSpaceInBatch(msg MessageImpl<?>) : boolean in class org.apache.pulsar.client.impl.BatchMessageContainer |
From |
To |
|
Change Parameter Type message : Message to message : Message<?> in method package updateNumMsgsReceived(message Message<?>) : void in class org.apache.pulsar.client.impl.ConsumerStats |
From |
To |
|
Change Parameter Type msg : MessageImpl to msg : MessageImpl<?> in method package add(msg MessageImpl<?>, callback SendCallback) : void in class org.apache.pulsar.client.impl.BatchMessageContainer |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<?> in method public choosePartition(msg Message<?>, metadata TopicMetadata) : int in class org.apache.pulsar.client.api.MessageRouter |
From |
To |
|
Change Parameter Type conf : ConsumerConfigurationData to conf : ConsumerConfigurationData<?> in method private init(conf ConsumerConfigurationData<?>) : void in class org.apache.pulsar.client.impl.ConsumerStats |
From |
To |
|
Change Parameter Type message : Message to message : Message<T> in method public sendAsync(message Message<T>) : CompletableFuture<MessageId> in class org.apache.pulsar.client.impl.ProducerImpl |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<byte[]> in method public received(consumer Consumer<byte[]>, msg Message<byte[]>) : void in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<?> in method public choosePartition(msg Message<?>, topicMetadata TopicMetadata) : int in class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImpl |
From |
To |
|
Change Parameter Type msg : MessageImpl to msg : MessageImpl<?> in method package create(msg MessageImpl<?>, cmd ByteBufPair, sequenceId long, callback SendCallback) : OpSendMsg in class org.apache.pulsar.client.impl.ProducerImpl.OpSendMsg |
From |
To |
|
Change Parameter Type message : Message to message : Message<?> in method public acknowledge(message Message<?>) : void in class org.apache.pulsar.client.impl.ConsumerBase |
From |
To |
|
Change Parameter Type consumerConf : ConsumerConfiguration to consumerConf : ConsumerConfigurationData<byte[]> in method public getSharedConsumer(consumerConf ConsumerConfigurationData<byte[]>) : Consumer<byte[]> in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Parameter Type conf : ReaderConfigurationData to conf : ReaderConfigurationData<T> in method private ReaderBuilderImpl(client PulsarClientImpl, conf ReaderConfigurationData<T>, schema Schema<T>) in class org.apache.pulsar.client.impl.ReaderBuilderImpl |
From |
To |
|
Change Parameter Type conf : ConsumerConfigurationData to conf : ConsumerConfigurationData<?> in method public ConsumerStats(pulsarClient PulsarClientImpl, conf ConsumerConfigurationData<?>, consumer ConsumerImpl<?>) in class org.apache.pulsar.client.impl.ConsumerStats |
From |
To |
|
Change Parameter Type recyclerHandle : Handle<MessageImpl> to recyclerHandle : Handle<MessageImpl<?>> in method private MessageImpl(recyclerHandle Handle<MessageImpl<?>>) in class org.apache.pulsar.client.impl.MessageImpl |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<byte[]> in method private mapToValueAndEmit(msg Message<byte[]>) : boolean in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<byte[]> in method private getRecordMetadata(topic String, msg Message<byte[]>, messageId MessageId, size int) : RecordMetadata in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Parameter Type producer : ProducerImpl to producer : ProducerImpl<?> in method package registerProducer(producerId long, producer ProducerImpl<?>) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Parameter Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in method package registerConsumer(consumerId long, consumer ConsumerImpl<?>) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Parameter Type producerConf : ProducerConfiguration to producerConf : ProducerConfigurationData in method public getSharedProducer(producerConf ProducerConfigurationData) : Producer<byte[]> in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Parameter Type message : Message to message : Message<?> in method public acknowledgeCumulativeAsync(message Message<?>) : CompletableFuture<Void> in class org.apache.pulsar.client.impl.ConsumerBase |
From |
To |
|
Change Parameter Type msg : MessageImpl to msg : MessageImpl<T> in method private doBatchSendAndAdd(msg MessageImpl<T>, callback SendCallback, payload ByteBuf) : void in class org.apache.pulsar.client.impl.ProducerImpl |
From |
To |
|
Change Parameter Type msg : Message to msg : Message<byte[]> in method private getKey(topic String, msg Message<byte[]>) : K in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Parameter Type message : Message to message : Message<?> in method public acknowledgeAsync(message Message<?>) : CompletableFuture<Void> in class org.apache.pulsar.client.impl.ConsumerBase |
From |
To |
|
Change Parameter Type readerListener : ReaderListener to readerListener : ReaderListener<T> in method public readerListener(readerListener ReaderListener<T>) : ReaderBuilder<T> in class org.apache.pulsar.client.api.ReaderBuilder |
From |
To |
|
Change Parameter Type consumer : Consumer to consumer : Consumer<byte[]> in method package QueueItem(consumer Consumer<byte[]>, message Message<byte[]>) in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer.QueueItem |
From |
To |
|
Change Parameter Type producer : ProducerImpl to producer : ProducerImpl<?> in method public ProducerStats(pulsarClient PulsarClientImpl, conf ProducerConfigurationData, producer ProducerImpl<?>) in class org.apache.pulsar.client.impl.ProducerStats |
From |
To |
|
Change Parameter Type message : Message to message : Message<?> in method public acknowledgeCumulative(message Message<?>) : void in class org.apache.pulsar.client.impl.ConsumerBase |
From |
To |
|
Change Parameter Type message : Message to message : Message<byte[]> in method package QueueItem(consumer Consumer<byte[]>, message Message<byte[]>) in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer.QueueItem |
From |
To |
|
Change Parameter Type message : Message to message : Message<T> in method public sendAsync(message Message<T>, callback SendCallback) : void in class org.apache.pulsar.client.impl.ProducerImpl |
From |
To |
|
Change Parameter Type clientConf : ClientConfiguration to clientConf : ClientConfigurationData in method public get(componentId String, clientConf ClientConfigurationData) : SharedPulsarClient in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Parameter Type messageListener : MessageListener to messageListener : MessageListener<byte[]> in method public setMessageListener(messageListener MessageListener<byte[]>) : ConsumerConfiguration in class org.apache.pulsar.client.api.ConsumerConfiguration |
From |
To |
|
Change Return Type ProducerBuilder to ProducerBuilder<T> in method public batchingMaxMessages(batchMessagesMaxMessagesPerBatch int) : ProducerBuilder<T> in class org.apache.pulsar.client.api.ProducerBuilder |
From |
To |
|
Change Return Type ConsumerBuilder to ConsumerBuilder<T> in method public patternAutoDiscoveryPeriod(periodInMinutes int) : ConsumerBuilder<T> in class org.apache.pulsar.client.impl.ConsumerBuilderImpl |
From |
To |
|
Change Return Type MessageImpl to MessageImpl<byte[]> in method public deserialize(headersAndPayload ByteBuf) : MessageImpl<byte[]> in class org.apache.pulsar.client.impl.MessageImpl |
From |
To |
|
Change Return Type Producer to Producer<byte[]> in method public getSharedProducer(producerConf ProducerConfigurationData) : Producer<byte[]> in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Return Type ConsumerBuilder to ConsumerBuilder<T> in method public topicsPattern(topicsPattern String) : ConsumerBuilder<T> in class org.apache.pulsar.client.api.ConsumerBuilder |
From |
To |
|
Change Return Type Consumer to Consumer<byte[]> in method public getSharedConsumer(consumerConf ConsumerConfigurationData<byte[]>) : Consumer<byte[]> in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Return Type MessageListener to MessageListener<byte[]> in method public getMessageListener() : MessageListener<byte[]> in class org.apache.pulsar.client.api.ConsumerConfiguration |
From |
To |
|
Change Return Type ConsumerImpl to ConsumerImpl<T> in method public getConsumer() : ConsumerImpl<T> in class org.apache.pulsar.client.impl.ReaderImpl |
From |
To |
|
Change Return Type PulsarClient to PulsarClientImpl in method public getClient() : PulsarClientImpl in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Return Type Producer to Producer<byte[]> in method private createNewProducer(topic String) : Producer<byte[]> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Return Type ConsumerBuilder to ConsumerBuilder<T> in method public patternAutoDiscoveryPeriod(periodInMinutes int) : ConsumerBuilder<T> in class org.apache.pulsar.client.api.ConsumerBuilder |
From |
To |
|
Change Return Type Message to Message<byte[]> in method private getMessage(record ProducerRecord<K,V>) : Message<byte[]> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Return Type ConsumerBuilder to ConsumerBuilder<T> in method public topicsPattern(topicsPattern Pattern) : ConsumerBuilder<T> in class org.apache.pulsar.client.api.ConsumerBuilder |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public poll(timeoutMillis long) : ConsumerRecords<K,V> in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Variable Type c : Consumer to c : Consumer<byte[]> in method public seekToEnd(partitions Collection<TopicPartition>) : void in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Variable Type currentMessageQueue : List<Message> to currentMessageQueue : List<Message<?>> in method private clearReceiverQueue() : BatchMessageIdImpl in class org.apache.pulsar.client.impl.ConsumerImpl |
From |
To |
|
Change Variable Type producerConf : ProducerConfiguration to producerBuilder : ProducerBuilder<byte[]> in method public main(args String[]) : void in class org.apache.pulsar.testclient.PerformanceProducer |
From |
To |
|
Change Variable Type clientConf : ClientConfiguration to clientBuilder : ClientBuilder in method private PulsarKafkaConsumer(config ConsumerConfig, keyDeserializer Deserializer<K>, valueDeserializer Deserializer<V>) in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Variable Type listener : ReaderListener to listener : ReaderListener<byte[]> in method public main(args String[]) : void in class org.apache.pulsar.testclient.PerformanceReader |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public fail(msgId Object) : void in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public emitNextAvailableTuple() : void in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<byte[]> in method public deserialize(headersAndPayload ByteBuf) : MessageImpl<byte[]> in class org.apache.pulsar.client.impl.MessageImpl |
From |
To |
|
Change Variable Type builder : MessageBuilder to builder : MessageBuilder<byte[]> in method private getMessage(record ProducerRecord<K,V>) : Message<byte[]> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method private doCommitOffsets(offsets Map<TopicPartition,OffsetAndMetadata>) : CompletableFuture<Void> in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in method protected handleActiveConsumerChange(change CommandActiveConsumerChange) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Variable Type clientConfiguration : ClientConfiguration to clientConf : ClientConfigurationData in method public ProxyService(proxyConfig ProxyConfiguration) in class org.apache.pulsar.proxy.server.ProxyService |
From |
To |
|
Change Variable Type c : Consumer to c : Consumer<byte[]> in method public seekToBeginning(partitions Collection<TopicPartition>) : void in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in method protected handleReachedEndOfTopic(commandReachedEndOfTopic CommandReachedEndOfTopic) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Variable Type producersToClose : List<ProducerBase> to producersToClose : List<ProducerBase<?>> in method public closeAsync() : CompletableFuture<Void> in class org.apache.pulsar.client.impl.PulsarClientImpl |
From |
To |
|
Change Variable Type consumersToClose : List<ConsumerBase> to consumersToClose : List<ConsumerBase<?>> in method public closeAsync() : CompletableFuture<Void> in class org.apache.pulsar.client.impl.PulsarClientImpl |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<byte[]> in method public send(record ProducerRecord<K,V>, callback Callback) : Future<RecordMetadata> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public ack(msgId Object) : void in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public send(record ProducerRecord<K,V>, callback Callback) : Future<RecordMetadata> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<T> in method public sendAsync(message Message<T>, callback SendCallback) : void in class org.apache.pulsar.client.impl.ProducerImpl |
From |
To |
|
Change Variable Type c : ConsumerImpl to c : ConsumerImpl<T> in method public redeliverUnacknowledgedMessages() : void in class org.apache.pulsar.client.impl.PartitionedConsumerImpl |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in method protected handleMessage(cmdMessage CommandMessage, headersAndPayload ByteBuf) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<T> in method private resumeReceivingFromPausedConsumersIfNeeded() : void in class org.apache.pulsar.client.impl.PartitionedConsumerImpl |
From |
To |
|
Change Variable Type c : Consumer to c : Consumer<byte[]> in method public seek(partition TopicPartition, offset long) : void in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Variable Type producer : ProducerImpl to producer : ProducerImpl<?> in method protected handleCloseProducer(closeProducer CommandCloseProducer) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in method protected handleCloseConsumer(closeConsumer CommandCloseConsumer) : void in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Attribute Type producer : Producer to producer : Producer<byte[]> in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Attribute Type consumer : Consumer to consumer : Consumer<byte[]> in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |
|
Change Attribute Type producer : ProducerImpl to producer : ProducerImpl<?> in class org.apache.pulsar.client.impl.ProducerImpl.WriteInEventLoopCallback |
From |
To |
|
Change Attribute Type conf : ConsumerConfigurationData to conf : ConsumerConfigurationData<T> in class org.apache.pulsar.client.impl.ConsumerBase |
From |
To |
|
Change Attribute Type producerConf : ProducerConfiguration to producerConf : ProducerConfigurationData in class org.apache.pulsar.storm.PulsarBolt |
From |
To |
|
Change Attribute Type consumers : ConcurrentMap<TopicPartition,org.apache.pulsar.client.api.Consumer> to consumers : ConcurrentMap<TopicPartition,org.apache.pulsar.client.api.Consumer<byte[]>> in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer |
From |
To |
|
Change Attribute Type msgs : List<MessageImpl> to msgs : List<MessageImpl<?>> in class org.apache.pulsar.client.impl.ProducerImpl.OpSendMsg |
From |
To |
|
Change Attribute Type message : Message to message : Message<byte[]> in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer.QueueItem |
From |
To |
|
Change Attribute Type messages : List<MessageImpl> to messages : List<MessageImpl<?>> in class org.apache.pulsar.client.impl.BatchMessageContainer |
From |
To |
|
Change Attribute Type consumer : ConsumerImpl to consumer : ConsumerImpl<?> in class org.apache.pulsar.client.impl.ConsumerStats |
From |
To |
|
Change Attribute Type clientConf : ClientConfiguration to clientConf : ClientConfigurationData in class org.apache.pulsar.storm.PulsarBolt |
From |
To |
|
Change Attribute Type producer : ProducerImpl to producer : ProducerImpl<?> in class org.apache.pulsar.client.impl.ProducerStats |
From |
To |
|
Change Attribute Type pulsarProducerConf : ProducerConfiguration to pulsarProducerBuilder : ProducerBuilder<byte[]> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Attribute Type consumer : Consumer to consumer : Consumer<byte[]> in class org.apache.kafka.clients.consumer.PulsarKafkaConsumer.QueueItem |
From |
To |
|
Change Attribute Type msg : MessageImpl to msg : MessageImpl<?> in class org.apache.pulsar.client.impl.ProducerImpl.OpSendMsg |
From |
To |
|
Change Attribute Type pausedConsumers : ConcurrentLinkedQueue<ConsumerImpl> to pausedConsumers : ConcurrentLinkedQueue<ConsumerImpl<T>> in class org.apache.pulsar.client.impl.PartitionedConsumerImpl |
From |
To |
|
Change Attribute Type producers : ConcurrentMap<String,org.apache.pulsar.client.api.Producer> to producers : ConcurrentMap<String,org.apache.pulsar.client.api.Producer<byte[]>> in class org.apache.kafka.clients.producer.PulsarKafkaProducer |
From |
To |
|
Change Attribute Type consumers : ConcurrentLongHashMap<ConsumerImpl> to consumers : ConcurrentLongHashMap<ConsumerImpl<?>> in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Attribute Type producers : ConcurrentLongHashMap<ProducerImpl> to producers : ConcurrentLongHashMap<ProducerImpl<?>> in class org.apache.pulsar.client.impl.ClientCnx |
From |
To |
|
Change Attribute Type clientConf : ClientConfiguration to clientConf : ClientConfigurationData in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Attribute Type failedMessages : Queue<Message> to failedMessages : Queue<Message<byte[]>> in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Attribute Type recyclerHandle : Handle<MessageImpl> to recyclerHandle : Handle<MessageImpl<?>> in class org.apache.pulsar.client.impl.MessageImpl |
From |
To |
|
Change Attribute Type RECYCLER : Recycler<MessageImpl> to RECYCLER : Recycler<MessageImpl<?>> in class org.apache.pulsar.client.impl.MessageImpl |
From |
To |
|
Change Attribute Type consumer : Consumer to consumer : Consumer<byte[]> in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Attribute Type consumerConf : ConsumerConfiguration to consumerConf : ConsumerConfigurationData<byte[]> in class org.apache.pulsar.storm.PulsarSpout |
From |
To |
|
Change Attribute Type client : PulsarClient to client : PulsarClientImpl in class org.apache.pulsar.storm.SharedPulsarClient |
From |
To |