|
Change Parameter Type outputMsgBuilder : MessageBuilder to outputMsgBuilder : MessageBuilder<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtMostOnceProcessor |
From |
To |
|
Change Parameter Type outputMsgBuilder : MessageBuilder to outputMsgBuilder : MessageBuilder<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtLeastOnceProcessor |
From |
To |
|
Change Parameter Type outputMsgBuilder : MessageBuilder to outputMsgBuilder : MessageBuilder<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkProcessor |
From |
To |
|
Change Parameter Type outputMsgBuilder : MessageBuilder to outputMsgBuilder : MessageBuilder<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkEffectivelyOnceProcessor |
From |
To |
|
Change Return Type Producer<byte[]> to Producer<T> in method public getProducer(srcPartitionId String) : Producer<T> in class org.apache.pulsar.functions.instance.producers.MultiConsumersOneOuputTopicProducers |
From |
To |
|
Change Return Type Producer<byte[]> to Producer<T> in method public createProducer(client PulsarClient, topic String, schema Schema<T>) : Producer<T> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Return Type Producer<byte[]> to Producer<T> in method public getProducer(srcPartitionId String) : Producer<T> in class org.apache.pulsar.functions.instance.producers.Producers |
From |
To |
|
Change Return Type Producer<byte[]> to Producer<T> in method protected createProducer(topic String, producerName String, schema Schema<T>) : Producer<T> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Return Type Producer<byte[]> to Producer<T> in method protected createProducer(topic String, schema Schema<T>) : Producer<T> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Return Type InstanceCommunication.MetricsData to MetricsData in method public getAndResetMetrics() : MetricsData in class org.apache.pulsar.functions.instance.JavaInstance |
From |
To |
|
Change Return Type ProducerBuilder<byte[]> to ProducerBuilder<U> in method package newProducerBuilder(client PulsarClient, schema Schema<U>) : ProducerBuilder<U> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Return Type Producer<byte[]> to Producer<T> in method public createProducer(client PulsarClient, topic String, producerName String, schema Schema<T>) : Producer<T> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Variable Type producer : Producer<byte[]> to producer : Producer<T> in method public getProducer(srcPartitionId String) : Producer<T> in class org.apache.pulsar.functions.instance.producers.MultiConsumersOneOuputTopicProducers |
From |
To |
|
Change Variable Type outputMsg : Message to outputMsg : Message<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkEffectivelyOnceProcessor |
From |
To |
|
Change Variable Type outputMsg : Message<byte[]> to outputMsg : Message<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtMostOnceProcessor |
From |
To |
|
Change Variable Type producer : Producer<byte[]> to producer : Producer<T> in method public closeProducer(srcPartitionId String) : void in class org.apache.pulsar.functions.instance.producers.MultiConsumersOneOuputTopicProducers |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkEffectivelyOnceProcessor |
From |
To |
|
Change Variable Type producer : Producer<byte[]> to producer : Producer<T> in method public close() : void in class org.apache.pulsar.functions.instance.producers.MultiConsumersOneOuputTopicProducers |
From |
To |
|
Change Variable Type outputMsg : Message<byte[]> to outputMsg : Message<T> in method public sendOutputMessage(outputMsgBuilder MessageBuilder<T>, recordContext RecordContext) : void in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtLeastOnceProcessor |
From |
To |
|
Change Attribute Type producer : Producer<byte[]> to producer : Producer<T> in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtMostOnceProcessor |
From |
To |
|
Change Attribute Type outputProducer : Producers to outputProducer : Producers<T> in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkEffectivelyOnceProcessor |
From |
To |
|
Change Attribute Type inputConsumer : Consumer to inputConsumers : Map<String,org.apache.pulsar.client.api.Consumer<T>> in class org.apache.pulsar.functions.source.PulsarSource |
From |
To |
|
Change Attribute Type topicToSerDeMap : Map<String,SerDe> to topicToSerDeMap : Map<String,SerDe<T>> in class org.apache.pulsar.functions.source.PulsarSource |
From |
To |
|
Change Attribute Type producer : Producer<byte[]> to producer : Producer<T> in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtLeastOnceProcessor |
From |
To |
|
Change Attribute Type producers : Map<String,Producer<byte[]>> to producers : Map<String,Producer<T>> in class org.apache.pulsar.functions.instance.producers.MultiConsumersOneOuputTopicProducers |
From |
To |