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