|
Move Method private startSinkProducer() : void from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private startSinkProducer() : void from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Method private startSourceConsumer() : void from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private startSourceConsumer() : void from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Method private convertMessageIdToString(messageId MessageId) : String from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private convertMessageIdToString(messageId MessageId) : String from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Method private processResult(msg Message, result JavaExecutionResult, processAt long, serDe SerDe) : void from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private processResult(msg Message, result JavaExecutionResult, processAt long, serDe SerDe) : void from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private queue : LinkedBlockingQueue<Message> from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private queue : LinkedBlockingQueue<Message> from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private stats : FunctionStats from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private stats : FunctionStats from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private sinkProducer : Producer from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private sinkProducer : Producer from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private sourceConsumer : Consumer from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private sourceConsumer : Consumer from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private client : PulsarClientImpl from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private client : PulsarClientImpl from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private fnCache : FunctionCacheManager from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private fnCache : FunctionCacheManager from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private jarFile : String from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private jarFile : String from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private javaInstanceConfig : JavaInstanceConfig from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private javaInstanceConfig : JavaInstanceConfig from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private processingGuarantees : FunctionConfig.ProcessingGuarantees from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private processingGuarantees : FunctionConfig.ProcessingGuarantees from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |
|
Move Attribute private fnClassLoader : ClassLoader from class org.apache.pulsar.functions.runtime.container.ThreadFunctionContainer to private fnClassLoader : ClassLoader from class org.apache.pulsar.functions.runtime.instance.JavaInstanceRunnable |
From |
To |