|
Change Variable Type pulsarProducer : Producer<byte[]> to pulsarProducer : org.apache.pulsar.client.api.Producer<byte[]> in method public testPartitions() : void in class org.apache.pulsar.tests.integration.compat.kafka.KafkaApiTest |
From |
To |
|
Change Variable Type payload : org.apache.pulsar.shade.io.netty.buffer.ByteBuf to payload : ByteBuf in method private getTopicEntries(topicSchemaName String) : List<Entry> in class org.apache.pulsar.sql.presto.TestPulsarConnector |
From |
To |
|
Change Variable Type pulsarProducer : Producer<byte[]> to pulsarProducer : org.apache.pulsar.client.api.Producer<byte[]> in method public testConsumerSeek() : void in class org.apache.pulsar.tests.integration.compat.kafka.KafkaApiTest |
From |
To |
|
Change Variable Type pulsarProducer : Producer<byte[]> to pulsarProducer : org.apache.pulsar.client.api.Producer<byte[]> in method public testSimpleConsumer() : void in class org.apache.pulsar.tests.integration.compat.kafka.KafkaApiTest |
From |
To |
|
Change Variable Type pulsarProducer : Producer<byte[]> to pulsarProducer : org.apache.pulsar.client.api.Producer<byte[]> in method public testConsumerManualOffsetCommit() : void in class org.apache.pulsar.tests.integration.compat.kafka.KafkaApiTest |
From |
To |
|
Change Variable Type pulsarProducer : Producer<byte[]> to pulsarProducer : org.apache.pulsar.client.api.Producer<byte[]> in method public testConsumerAutoCommit() : void in class org.apache.pulsar.tests.integration.compat.kafka.KafkaApiTest |
From |
To |
|
Change Variable Type pulsarProducer : Producer<byte[]> to pulsarProducer : org.apache.pulsar.client.api.Producer<byte[]> in method public testConsumerSeekToEnd() : void in class org.apache.pulsar.tests.integration.compat.kafka.KafkaApiTest |
From |
To |