|
Change Return Type Producer<byte[]> to Producer<T> in method public createProducer(client PulsarClient, topic String, schema Schema<T>, producerName String) : Producer<T> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Return Type ProducerBuilder<byte[]> to ProducerBuilder<T> in method package newProducerBuilder(client PulsarClient, schema Schema<T>) : ProducerBuilder<T> in class org.apache.pulsar.functions.instance.producers.AbstractOneOuputTopicProducers |
From |
To |
|
Change Return Type PulsarClient to PulsarClientImpl in method private getPulsarClient() : PulsarClientImpl in class org.apache.pulsar.functions.sink.PulsarSinkTest |
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 SerDe to SerDe<?> in method public initializeSerDe(serdeClassName String, clsLoader ClassLoader, typeArg Class<?>) : SerDe<?> in class org.apache.pulsar.functions.instance.InstanceUtils |
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 PulsarClient to PulsarClientImpl in method private getPulsarClient() : PulsarClientImpl in class org.apache.pulsar.functions.source.PulsarSourceTest |
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 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 topicSerdeClassNameMap : Map<String,String> to topicSerdeClassNameMap : Map<String,ConsumerConfig> in method public testInconsistentInputType() : void in class org.apache.pulsar.functions.source.PulsarSourceTest |
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 pulsarClient : PulsarClient to pulsarClient : PulsarClientImpl in method private getPulsarClient() : PulsarClientImpl in class org.apache.pulsar.functions.sink.PulsarSinkTest |
From |
To |
|
Change Variable Type msgBuilder : MessageBuilder to msg : TypedMessageBuilder<T> in method public write(record Record<T>) : void in class org.apache.pulsar.functions.sink.PulsarSink |
From |
To |
|
Change Variable Type pulsarClient : PulsarClient to pulsarClient : PulsarClientImpl in method private getPulsarClient() : PulsarClientImpl in class org.apache.pulsar.functions.source.PulsarSourceTest |
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 Attribute Type message : Message<byte[]> to message : Message<T> in class org.apache.pulsar.functions.source.PulsarRecord |
From |
To |
|
Change Attribute Type producers : MultiConsumersOneOuputTopicProducers to producers : MultiConsumersOneOuputTopicProducers<byte[]> in class org.apache.pulsar.functions.instance.producers.MultiConsumersOneOutputTopicProducersTest |
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 producer : Producer<byte[]> to producer : Producer<T> in class org.apache.pulsar.functions.sink.PulsarSink.PulsarSinkAtLeastOnceProcessor |
From |
To |
|
Change Attribute Type publishProducers : Map<String,Producer> to publishProducers : Map<String,Producer<?>> in class org.apache.pulsar.functions.instance.ContextImpl |
From |
To |
|
Change Attribute Type pulsarSinkProcessor : PulsarSinkProcessor to pulsarSinkProcessor : PulsarSinkProcessor<T> in class org.apache.pulsar.functions.sink.PulsarSink |
From |
To |
|
Change Attribute Type client : PulsarClient to client : PulsarClientImpl in class org.apache.pulsar.functions.instance.ContextImplTest |
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 |
|
Change Attribute Type currentRecord : Record to currentRecord : Record<?> in class org.apache.pulsar.functions.instance.JavaInstanceRunnable |
From |
To |