|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testCheckUnAcknowledgedMessageTimer() : void in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testBlockUnackConsumerAckByDifferentConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type m : Message to m : Message<byte[]> in method public testSeekEarliestAfterCompaction() : void in class org.apache.pulsar.compaction.CompactionTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testReaderOnSpecificMessage() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testCancelReadRequestOnLastDisconnect() : void in class org.apache.pulsar.broker.service.PersistentQueueE2ETest |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testGetConsumersAndGetTopics() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerFlowControl() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSinglePartitionProducer() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type future_msg : CompletableFuture<Message> to future_msg : CompletableFuture<Message<byte[]>> in method public testAsyncProducerAndReceiveAsyncAndAsyncAck(batchMessageDelayMs int, ackTimeoutSec int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerStatTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testSharedAckedPartitionedTopic() : void in class org.apache.pulsar.client.impl.PerMessageUnAcknowledgedRedeliveryTest |
From |
To |
|
Change Variable Type producer2 : ProducerBase to producer2 : ProducerBase<byte[]> in method private producerFailDoesNotFailOtherProducer(topic1 String, topic2 String) : void in class org.apache.pulsar.client.api.ClientErrorsTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testTlsSyncProducerAndConsumerCorrectBrokerHost() : void in class org.apache.pulsar.client.api.AuthenticationTlsHostnameVerificationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method private receiveAllMessage(consumer Consumer<?>, ackMessages boolean) : int in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleConsumerEventsWithoutPartition() : void in class org.apache.pulsar.broker.service.PersistentFailoverE2ETest |
From |
To |
|
Change Variable Type producers : IdentityHashMap<ProducerBase,Boolean> to producers : IdentityHashMap<ProducerBase<byte[]>,Boolean> in method public testCleanProducer() : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<byte[]> in method public testChecksumReconnection() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testActiveAndInActiveConsumerEntryCacheBehavior() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type m : Message to m : Message<byte[]> in method public testCompaction() : void in class org.apache.pulsar.compaction.CompactionTest |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testSyncProducerAndConsumer() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testReaderAfterMessagesWerePublished() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBatchAndNonBatchCumulativeAcks() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type consumer1 : PatternTopicsConsumerImpl to consumer1 : PatternTopicsConsumerImpl<byte[]> in method public testAutoUnbubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testEnabledChecksumClient() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type lastunackedMsg : Message to lastunackedMsg : Message<byte[]> in method public testNonBatchCumulativeAckAfterBatchPublish() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testPartitions() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaConsumerTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testStartEmptyPatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testOutOfOrderAcksForBatchMessage() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testCancelReadRequestOnLastDisconnect() : void in class org.apache.pulsar.broker.service.PersistentQueueE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSharedConsumerAckDifferentConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type successfulConsumers : List<Consumer> to successfulConsumers : List<Consumer<byte[]>> in method public testLookupThrottlingForClientByBroker() : void in class org.apache.pulsar.broker.service.BrokerServiceThrottlingTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleBatchProducerConsumer(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testConsumerBlockingWithUnAckedMessages() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBrokerServicePersistentTopicStats() : void in class org.apache.pulsar.broker.service.BrokerServiceTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testExclusiveSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type lastunackedMsg : Message to lastunackedMsg : Message<byte[]> in method public testSimpleBatchProducerConsumer1kMessages() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<?> in method public testChoosePartitionWithKey() : void in class org.apache.pulsar.client.impl.SinglePartitionMessageRouterImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testRedeliveryFailOverConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type future : CompletableFuture<Message> to future : CompletableFuture<Message<byte[]>> in method private receiveAsync(consumer Consumer<byte[]>, totalMessage int, currentMessage int, latch CountDownLatch, consumeMsg Set<String>, executor ExecutorService) : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleBatchProducerWithFixedBatchTime(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testCloseConsumerBlockedDispatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testConsumerUnackedRedelivery() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testBinaryProtoToGetTopicsOfNamespace() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testExclusiveAckedNormalTopic() : void in class org.apache.pulsar.client.impl.PerMessageUnAcknowledgedRedeliveryTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testProducerRateLimit() : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testPartitionKey() : void in class org.apache.pulsar.broker.service.PartitionKeyTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public persistentTopicsCursorReset(topicName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testDeactivatingBacklogConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleCloseTopic() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testRedeliveryOnBlockedDistpatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<T> in method protected doAcknowledge(messageId MessageId, ackType AckType, properties Map<String,Long>) : CompletableFuture<Void> in class org.apache.pulsar.client.impl.TopicsConsumerImpl |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public persistentTopicsCursorResetAfterReset(topicName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testExclusiveCumulativeAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<?> in method public testGetProducerNameNotAssigned() : void in class org.apache.pulsar.client.impl.MessageImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleBatchProducerWithFixedBatchSizeAndTime(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<byte[]> in method public testChecksumVersionComptability() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testTlsSyncProducerAndConsumer() : void in class org.apache.pulsar.proxy.server.ProxyAuthenticatedProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testMultipleBrokerLookup() : void in class org.apache.pulsar.client.api.BrokerServiceLookupTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<T> in method private messageReceived(consumer ConsumerImpl<T>, message Message<T>) : void in class org.apache.pulsar.client.impl.TopicsConsumerImpl |
From |
To |
|
Change Variable Type consumerMsgSet2 : Set<Message> to consumerMsgSet2 : Set<Message<byte[]>> in method public testSharedConsumerAckDifferentConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testDiscoveryService() : void in class org.apache.pulsar.proxy.server.ProxyWithoutServiceDiscoveryTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testConsumerUnackedRedelivery() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type received : List<Message> to received : List<Message<byte[]>> in method public testResetCursor(subType SubscriptionType) : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testSetMessageProperties() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type msg4 : Message to msg4 : Message<byte[]> in method public testSimpleTerminationReader() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<byte[]> in method public testSillyUser() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testSillyUser() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type producer2 : ProducerImpl to producer2 : ProducerImpl<byte[]> in method public testDisconnectClientWithoutClosingConnection() : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type messages2 : Map<Message,Consumer> to messages2 : Map<Message<?>,Consumer<?>> in method public testCloseConsumerBlockedDispatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testTopicInternalStats() : void in class org.apache.pulsar.stats.client.PulsarBrokerStatsClientTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<byte[]> in method public testSimpleTerminationReader() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testPartitions() : void in class org.apache.pulsar.proxy.server.ProxyTlsTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testUnackBlockRedeliverMessages() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testBinaryProtoToGetTopicsOfNamespace() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public partitionedTopicsCursorReset(topicName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testConsumerUnackedRedelivery() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testRSAEncryption() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSendTimeout(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerStatTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testFailoverSingleAckedPartitionedTopic() : void in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type m : Message to m : Message<byte[]> in method public testBrokerRestartAfterCompaction() : void in class org.apache.pulsar.compaction.CompactionTest |
From |
To |
|
Change Variable Type consumerImpl : ConsumerImpl to consumerImpl : ConsumerImpl<byte[]> in method public testConcurrentConsumerReceiveWhileReconnect(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testShouldNotBlockConsumerIfRedeliverBeforeReceive() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testBrokerDispatchBlockAndSubAckBackRequiredMsgs() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<?> in method public testChoosePartitionWithKey() : void in class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testProducerReturnedMessageId() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type m : Message to m : Message<byte[]> in method public testCompactEmptyTopic() : void in class org.apache.pulsar.compaction.CompactionTest |
From |
To |
|
Change Variable Type producerList : List<Producer> to producerList : List<Producer<byte[]>> in method public testBrokerServiceNamespaceStats() : void in class org.apache.pulsar.broker.service.BrokerServiceTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testExclusiveSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBrokerServicePersistentRedeliverTopicStats() : void in class org.apache.pulsar.broker.service.BrokerServiceTest |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testSyncProducerAndConsumer() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSendTimeout(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testProxyAuthorization() : void in class org.apache.pulsar.proxy.server.ProxyWithAuthorizationNegTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testAutoUnbubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testFailoverAckedNormalTopic() : void in class org.apache.pulsar.client.impl.PerMessageUnAcknowledgedRedeliveryTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testSetEventTimePositive() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type c : Consumer to c : Consumer<?> in method public testLookupThrottlingForClientByBroker() : void in class org.apache.pulsar.broker.service.BrokerServiceThrottlingTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testSyncProducerAndConsumer() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testNonPersistentTopic(type SubscriptionType) : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testStartEmptyPatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleBatchProducerConsumer1kMessages() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testSubscribeUnsubscribeSingleTopic() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testUnsupportedBatchMessageConsumer(subType SubscriptionType) : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type messages : Map<Message,Consumer> to messages : Map<Message<?>,Consumer<?>> in method public testCloseConsumerBlockedDispatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public main(args String[]) : void in class org.apache.pulsar.client.tutorial.SampleConsumer |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<byte[]> in method public main(args String[]) : void in class org.apache.pulsar.client.tutorial.SampleProducer |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public run() : int in class org.apache.pulsar.client.cli.CmdProduce |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testNonBatchCumulativeAckAfterBatchPublish() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type future : CompletableFuture<Message> to future : CompletableFuture<Message<byte[]>> in method private receiveAsync(consumer Consumer<byte[]>, totalMessage int, currentMessage int, latch CountDownLatch, consumeMsg Set<String>, executor ExecutorService) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<?> in method public testChoosePartitionWithKey() : void in class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImplTest |
From |
To |
|
Change Variable Type consumer1 : PatternTopicsConsumerImpl to consumer1 : PatternTopicsConsumerImpl<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerSeek() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBlockUnackedConsumerRedeliverySpecificMessagesCloseConsumerWhileProduce() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testFailoverInactiveConsumer() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleReader() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<?> in method public testGetSequenceIdAssociated() : void in class org.apache.pulsar.client.impl.MessageImplTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public persistentTopicsCursorReset(topicName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerSeekToEnd() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConcurrentConsumerReceiveWhileReconnect(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg1 : MessageImpl to msg1 : MessageImpl<byte[]> in method public testCorruptMessageRemove() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testSharedSingleAckedPartitionedTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testExclusiveSingleAckedNormalTopic() : void in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<byte[]> in method public testSimpleTerminationConsumer() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<?> in method public testBrokerServiceNamespaceStats() : void in class org.apache.pulsar.broker.service.BrokerServiceTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testECDSAEncryption() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type producer : ProducerImpl to producer : ProducerImpl<byte[]> in method public testReplicatorProducerClosing() : void in class org.apache.pulsar.broker.service.ReplicatorTest |
From |
To |
|
Change Variable Type msg4 : Message to msg4 : Message<byte[]> in method public testSimpleTerminationConsumer() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testSharedSamePriorityConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public persistentTopicsInvalidCursorReset() : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testSharedAckedNormalTopic() : void in class org.apache.pulsar.client.impl.PerMessageUnAcknowledgedRedeliveryTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBatchProducerWithLargeMessage(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testConsumerUnackedRedelivery() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type lastMsg : Message to lastMsg : Message<byte[]> in method public testBatchProducerWithLargeMessage(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type lastunackedMsg : Message to lastunackedMsg : Message<byte[]> in method public testOutOfOrderAcksForBatchMessage() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testEncryptionFailure() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type messagesToSend : List<Message> to messagesToSend : List<Message<byte[]>> in method private generateMessages(messageBodies List<byte[]>) : List<Message<byte[]>> in class org.apache.pulsar.client.cli.CmdProduce |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleBatchProducerWithFixedBatchSize(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type consumer2 : ConsumerBase to consumer2 : ConsumerBase<byte[]> in method private subscribeFailDoesNotFailOtherConsumer(topic1 String, topic2 String) : void in class org.apache.pulsar.client.api.ClientErrorsTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testDiscoveryLookup() : void in class org.apache.pulsar.client.api.BrokerServiceLookupTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testPartitionedNonPersistentTopic(type SubscriptionType) : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testInvalidSequence() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerBlockingWithUnAckedMessages() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testPartitionTopicLookup() : void in class org.apache.pulsar.client.api.BrokerServiceLookupTest |
From |
To |
|
Change Variable Type unAckedMsg : Message to unAckedMsg : Message<byte[]> in method public testMessageRedelivery() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testSubscribeUnsubscribeSingleTopic() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testProducerCallback() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaProducerTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testFailoverSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testFailoverInactiveConsumer() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBlockUnackedConsumerRedeliverySpecificMessagesProduceWithPause() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method package receive(messages int) : void in class org.apache.pulsar.broker.service.ReplicatorTestBase.MessageConsumer |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testStartEmptyPatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleConsumer() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleProducer() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaProducerTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testSharedSingleAckedPartitionedTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testBinaryProtoToGetTopicsOfNamespace() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testMultipleBrokerDifferentClusterLookup() : void in class org.apache.pulsar.client.api.BrokerServiceLookupTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBlockUnackConsumerAckByDifferentConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<?> in method public testJsonIgnore() : void in class org.apache.pulsar.client.api.ConsumerConfigurationTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testSubscribeUnsubscribeSingleTopic() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type consumers : List<Consumer<byte[]>> to consumers : List<Consumer<?>> in method public testConsumerBlockingWithUnAckedMessagesAtDispatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBackoffAndReconnect(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testReplicator() : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type message : Message to message : Message<T> in method private removeExpiredMessagesFromQueue(messageIds Set<MessageId>) : void in class org.apache.pulsar.client.impl.TopicsConsumerImpl |
From |
To |
|
Change Variable Type consumer1 : ConsumerImpl to consumer1 : ConsumerImpl<byte[]> in method public testDisconnectClientWithoutClosingConnection() : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type producer1 : ProducerImpl to producer1 : ProducerImpl<byte[]> in method public testDisconnectClientWithoutClosingConnection() : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testReceiveWithTimeout() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type messages1 : List<Message> to messages1 : List<Message<byte[]>> in method public testRedeliveryFailOverConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg3 : Message to msg3 : Message<byte[]> in method public testSimpleTerminationReader() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerAutoCommit() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaConsumerTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<byte[]> in method public testChecksumVersionComptability() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type lastMessage : Message to lastMessage : Message<byte[]> in method public testExclusiveCumulativeAckedNormalTopic() : void in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testUnackedBlockAtBatch(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleConsumerEventsWithPartition() : void in class org.apache.pulsar.broker.service.PersistentFailoverE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testProducerExceptionAndThenUnblock() : void in class org.apache.pulsar.broker.service.BacklogQuotaManagerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSkipCorruptDataLedger() : void in class org.apache.pulsar.broker.service.BrokerBkEnsemblesTests |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testSharedSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type consumerMsgSet1 : Set<Message> to consumerMsgSet1 : Set<Message<byte[]>> in method public testSharedConsumerAckDifferentConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type consumers : List<ConsumerImpl> to consumers : List<ConsumerImpl<byte[]>> in method public testSubscribeUnsubscribeSingleTopic() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testAutoUnbubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testChecksumReconnection() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public zeroQueueSizeNormalConsumer() : void in class org.apache.pulsar.client.impl.ZeroQueueSizeTest |
From |
To |
|
Change Variable Type messages1 : List<Message> to messages1 : List<Message<byte[]>> in method public testBlockUnackedConsumerRedeliverySpecificMessagesCloseConsumerWhileProduce() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type producer1 : Producer to producer1 : Producer<byte[]> in method public testSyncProducerAndConsumer() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSyncProducerAndConsumer(batchMessageDelayMs int, ackTimeoutSec int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerStatTest |
From |
To |
|
Change Variable Type producer : ProducerImpl to producer : ProducerImpl<byte[]> in method public testChecksumReconnection() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSharedSamePriorityConsumer() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testSubscribeUnsubscribeSingleTopic() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleConsumerEvents() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg2 : MessageImpl to msg2 : MessageImpl<byte[]> in method public testCorruptMessageRemove() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type receivedMessages : List<Message> to receivedMessages : List<Message<byte[]>> in method public testActiveConsumerFailoverWithDelay() : void in class org.apache.pulsar.broker.service.PersistentFailoverE2ETest |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testAutoUnbubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type c : ConsumerConfigurationData to c : ConsumerConfigurationData<T> in method public clone() : ConsumerConfigurationData<T> in class org.apache.pulsar.client.impl.conf.ConsumerConfigurationData |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConcurrentBatchMessageAck() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testMessageRedelivery() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testAutoUnbubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type producer4 : Producer to producer4 : Producer<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testExclusiveSingleAckedPartitionedTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type consumer1 : PatternTopicsConsumerImpl to consumer1 : PatternTopicsConsumerImpl<byte[]> in method public testStartEmptyPatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testPartitions() : void in class org.apache.pulsar.proxy.server.ProxyTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public call() : Void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest.testConcurrentConsumerThreads.submit |
From |
To |
|
Change Variable Type msgBuilder : MessageBuilder to msgBuilder : MessageBuilder<byte[]> in method private generateMessages(messageBodies List<byte[]>) : List<Message<byte[]>> in class org.apache.pulsar.client.cli.CmdProduce |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testChecksumVersionComptability() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method package run() : void in class org.apache.pulsar.admin.cli.CmdPersistentTopics.PeekMessages |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testResetCursorOnPosition(namespaceName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest2 |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<?> in method public testGetProducerNameAssigned() : void in class org.apache.pulsar.client.impl.MessageImplTest |
From |
To |
|
Change Variable Type c : ConsumerBase to c : ConsumerBase<byte[]> in method private printIncomingMessageQueue(consumer Consumer<byte[]>) : BlockingQueue<Message<byte[]>> in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type peek : Message to peek : Message<T> in method private removeExpiredMessagesFromQueue(messageIds Set<MessageId>) : void in class org.apache.pulsar.client.impl.TopicsConsumerImpl |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testConsumerUnackedRedelivery() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type messages : Map<Message,Consumer> to messages : Map<Message<?>,Consumer<?>> in method public testConsumerBlockingWithUnAckedMessagesAtDispatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testFailoverSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testBinaryProtoToGetTopicsOfNamespace() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type messages : Multimap<ConsumerImpl,MessageId> to messages : Multimap<ConsumerImpl<?>,MessageId> in method public testConsumerBlockingWithUnAckedMessagesAndRedelivery() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testMutlipleSharedConsumerBlockingWithUnAckedMessages() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSendCallBack() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testProxyAuthorization() : void in class org.apache.pulsar.proxy.server.ProxyWithAuthorizationTest |
From |
To |
|
Change Variable Type builder : MessageBuilder to builder : MessageBuilder<?> in method public testSetMessageProperties() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<byte[]> in method public testPayloadCorruptionDetection() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testChoosePartitionWithoutKey() : void in class org.apache.pulsar.client.impl.RoundRobinPartitionMessageRouterImplTest |
From |
To |
|
Change Variable Type builder : MessageBuilder to builder : MessageBuilder<?> in method public testBuildMessageWithoutEventTime() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testFairDistributionForPartitionConsumers() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<byte[]> in method public testPayloadCorruptionDetection() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type consumers : List<Consumer> to consumers : List<Consumer<byte[]>> in method public testLookupThrottlingForClientByBrokerInternalRetry() : void in class org.apache.pulsar.broker.service.BrokerServiceThrottlingTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testPartitionedNonPersistentTopicWithTcpLookup(type SubscriptionType) : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testAsyncProducerAndAsyncAck(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testReaderReachEndofTopicOnMessageWithBatches() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type future : CompletableFuture<List<Message>> to future : CompletableFuture<List<Message<byte[]>>> in method public peekMessagesAsync(topic String, subName String, numMessages int) : CompletableFuture<List<Message<byte[]>>> in class org.apache.pulsar.client.admin.internal.PersistentTopicsImpl |
From |
To |
|
Change Variable Type producers : ConcurrentLongHashMap<ProducerImpl> to producers : ConcurrentLongHashMap<ProducerImpl<byte[]>> in method public testDisconnectClientWithoutClosingConnection() : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public persistentTopics(topicName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type consumers : ConcurrentLongHashMap<ConsumerImpl> to consumers : ConcurrentLongHashMap<ConsumerImpl<byte[]>> in method public testDisconnectClientWithoutClosingConnection() : void in class org.apache.pulsar.client.impl.BrokerClientIntegrationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testConsumerBlockingWithUnAckedMessagesAtDispatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testSharedSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testSendBigMessageSize() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSyncProducerAndConsumer(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public testConsumerBlockingWithUnAckedMessagesMultipleIteration() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<byte[]> in method public testSimpleReaderReachEndofTopic() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type consumer2 : Consumer to consumer2 : Consumer<byte[]> in method public testSubscriptionTypeTransitions() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testExclusiveCumulativeAckedNormalTopic() : void in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testFailoverSingleAckedPartitionedTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testSendBigMessageSizeButCompressed() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testMessageReplay() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBrokerStatsMetrics() : void in class org.apache.pulsar.broker.service.BrokerServiceTest |
From |
To |
|
Change Variable Type m : Message to m : Message<byte[]> in method public testReadCompactedBeforeCompaction() : void in class org.apache.pulsar.compaction.CompactionTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testMultipleReaders() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testMutlipleSharedConsumerBlockingWithUnAckedMessages() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testECDSAEncryption() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public producerSendAsync() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testKeyBasedProducer() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type ret : List<Message> to ret : List<Message<byte[]>> in method private getIndividualMsgsFromBatch(msgId String, data byte[], properties Map<String,String>) : List<Message<byte[]>> in class org.apache.pulsar.client.admin.internal.PersistentTopicsImpl |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testFailoverSingleAckedPartitionedTopic() : void in class org.apache.pulsar.client.impl.UnAcknowledgedMessagesTimeoutTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public main(args String[]) : void in class org.apache.pulsar.client.tutorial.SampleCryptoConsumer |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerManualOffsetCommit() : void in class org.apache.pulsar.client.kafka.compat.tests.KafkaConsumerTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type m : Message to m : Message<byte[]> in method public testReadEntriesAfterCompaction() : void in class org.apache.pulsar.compaction.CompactionTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testCrashBrokerWithoutCursorLedgerLeak() : void in class org.apache.pulsar.broker.service.BrokerBkEnsemblesTests |
From |
To |
|
Change Variable Type replicatorProducer : ProducerImpl to replicatorProducer : ProducerImpl<byte[]> in method public testCloseReplicatorStartProducer() : void in class org.apache.pulsar.broker.service.ReplicatorTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testBrokerSubscriptionRecovery(unloadBundleGracefully boolean) : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<?> in method public testChoosePartitionWithKey() : void in class org.apache.pulsar.client.impl.SinglePartitionMessageRouterImplTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<byte[]> in method public testChecksumReconnection() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method package run() : void in class org.apache.pulsar.admin.cli.CmdPersistentTopics.PeekMessages |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testBlockBrokerDispatching() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type producer3 : Producer to producer3 : Producer<byte[]> in method public testAutoSubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<byte[]> in method public testSillyUser() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testSharedSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.PersistentQueueE2ETest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testProxyAuthorization() : void in class org.apache.pulsar.proxy.server.ProxyWithAuthorizationNegTest |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<byte[]> in method public testProxyAuthorization() : void in class org.apache.pulsar.proxy.server.ProxyWithAuthorizationNegTest |
From |
To |
|
Change Variable Type builder : MessageBuilder to builder : MessageBuilder<?> in method public testSetEventTimePositive() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testProducerConsumer() : void in class org.apache.pulsar.proxy.server.ProxyTest |
From |
To |
|
Change Variable Type consumer : ConsumerImpl to consumer : ConsumerImpl<T> in method private resumeReceivingFromPausedConsumersIfNeeded() : void in class org.apache.pulsar.client.impl.TopicsConsumerImpl |
From |
To |
|
Change Variable Type nmsg : Message to nmsg : Message<byte[]> in method public testNonBatchCumulativeAckAfterBatchPublish() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testBinaryProtoToGetTopicsOfNamespace() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testPayloadCorruptionDetection() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testTlsLargeSizeMessage() : void in class org.apache.pulsar.client.api.TlsProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testBuildMessageWithoutEventTime() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testReaderOnSpecificMessageWithBatches() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testConsumerBlockingWithUnAckedMessagesAndRedelivery() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type message : Message to message : Message<?> in method public zeroQueueSizeSharedSubscription() : void in class org.apache.pulsar.client.impl.ZeroQueueSizeTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testInvalidSequence() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type consumers : ConsumerImpl[] to consumers : ConsumerImpl<?>[] in method public zeroQueueSizeSharedSubscription() : void in class org.apache.pulsar.client.impl.ZeroQueueSizeTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testReaderOnLastMessage() : void in class org.apache.pulsar.client.api.TopicReaderTest |
From |
To |
|
Change Variable Type consumers : List<ConsumerImpl<byte[]>> to consumers : List<ConsumerImpl<?>> in method public testRedeliveryOnBlockedDistpatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testAutoUnbubscribePatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public run() : int in class org.apache.pulsar.client.cli.CmdConsume |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testProducerDeduplication() : void in class org.apache.pulsar.client.api.ClientDeduplicationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testRoundRobinProducer() : void in class org.apache.pulsar.client.api.PartitionedProducerConsumerTest |
From |
To |
|
Change Variable Type lastunackedMsg : Message to lastunackedMsg : Message<byte[]> in method public testBatchAndNonBatchCumulativeAcks() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type msg2 : Message to msg2 : Message<byte[]> in method public testSimpleTerminationReader() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testSubscribeUnsubscribeSingleTopic() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSyncProducerAndConsumer(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.AuthenticatedProducerConsumerTest |
From |
To |
|
Change Variable Type message1 : Message to message1 : Message<byte[]> in method public testSharedSingleAckedNormalTopic() : void in class org.apache.pulsar.broker.service.PersistentQueueE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testGracefulClose() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testCorruptMessageRemove() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type builder : MessageBuilder to builder : MessageBuilder<?> in method public testSetEventTimeNegative() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type message2 : Message to message2 : Message<byte[]> in method public testFailoverSingleAckedPartitionedTopic() : void in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type producer : ProducerImpl to producer : ProducerImpl<byte[]> in method public testCorruptMessageRemove() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type messages1 : Map<ConsumerImpl,Set<MessageId>> to messages1 : Map<ConsumerImpl<?>,Set<MessageId>> in method public testRedeliveryOnBlockedDistpatcher() : void in class org.apache.pulsar.client.api.DispatcherBlockConsumerTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public persistentTopicsInvalidCursorReset() : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type messages : List<Message> to messages : List<Message<byte[]>> in method public run() : int in class org.apache.pulsar.client.cli.CmdProduce |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testConsumerBlockingWithUnAckedMessagesMultipleIteration() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg1 : Message to msg1 : Message<byte[]> in method public testSimpleTerminationConsumer() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type messages1 : List<Message> to messages1 : List<Message<byte[]>> in method public testBlockUnackedConsumerRedeliverySpecificMessagesProduceWithPause() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testAsyncProducerAndReceiveAsyncAndAsyncAck(batchMessageDelayMs int, ackTimeoutSec int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerStatTest |
From |
To |
|
Change Variable Type imq : BlockingQueue<Message> to imq : BlockingQueue<Message<byte[]>> in method private printIncomingMessageQueue(consumer Consumer<byte[]>) : BlockingQueue<Message<byte[]>> in class org.apache.pulsar.broker.service.ResendRequestTest |
From |
To |
|
Change Variable Type producer2 : Producer to producer2 : Producer<byte[]> in method public testStartEmptyPatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testDiscoveryLookupAuthAndAuthSuccess() : void in class org.apache.pulsar.client.api.BrokerServiceLookupTest |
From |
To |
|
Change Variable Type consumer : Consumer to consumer : Consumer<byte[]> in method public testPartitionedNonPersistentTopicWithTcpLookup(type SubscriptionType) : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type producer : Producer to producer : Producer<byte[]> in method public testPartitionedNonPersistentTopicWithTcpLookup(type SubscriptionType) : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type msg3 : Message to msg3 : Message<byte[]> in method public testSimpleTerminationConsumer() : void in class org.apache.pulsar.broker.service.TopicTerminationTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testDiscoveryLookupTls() : void in class org.apache.pulsar.client.api.BrokerServiceLookupTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public zeroQueueSizeFailoverSubscription() : void in class org.apache.pulsar.client.impl.ZeroQueueSizeTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testResetCursorOnPosition(namespaceName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest2 |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testActiveSubscriptionWithCache() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : MessageImpl to msg : MessageImpl<?> in method public testGetSequenceIdNotAssociated() : void in class org.apache.pulsar.client.impl.MessageImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testAsyncProducerAndAsyncAck(batchMessageDelayMs int, ackTimeoutSec int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerStatTest |
From |
To |
|
Change Variable Type mockedMsg : Message to mockedMsg : Message<?> in method public testChoosePartition() : void in class org.apache.pulsar.client.api.MessageRouterTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testConsumerInternalQueueMaxOut(type SubscriptionType) : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type lastunackedMsg : Message to lastunackedMsg : Message<byte[]> in method public testSimpleBatchProducerConsumer(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type consumer3 : Consumer to consumer3 : Consumer<byte[]> in method public testSubscriptionTypeTransitions() : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testUnackedBlockAtBatch(batchMessageDelayMs int) : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type consumers : List<ConsumerImpl> to consumers : List<ConsumerImpl<byte[]>> in method public testGetConsumersAndGetTopics() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type builder : MessageBuilder to builder : MessageBuilder<?> in method public testSetEventTimeZero() : void in class org.apache.pulsar.client.impl.MessageBuilderTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testCompression(compressionType CompressionType) : void in class org.apache.pulsar.broker.service.PersistentTopicE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testMultipleSubscription() : void in class org.apache.pulsar.client.api.NonPersistentTopicTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<?> in method public testChoosePartitionWithoutKey() : void in class org.apache.pulsar.client.impl.SinglePartitionMessageRouterImplTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testSyncProducerAndConsumer() : void in class org.apache.pulsar.client.impl.TopicsConsumerImplTest |
From |
To |
|
Change Variable Type c : Consumer to c : Consumer<byte[]> in method public testSimpleConsumerEvents() : void in class org.apache.pulsar.broker.service.PersistentQueueE2ETest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleBatchSyncProducerWithFixedBatchSize() : void in class org.apache.pulsar.broker.service.BatchMessageTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public persistentTopicsCursorResetAfterReset(topicName String) : void in class org.apache.pulsar.broker.admin.AdminApiTest |
From |
To |
|
Change Variable Type producer : ProducerImpl to producer : ProducerImpl<byte[]> in method public testChecksumVersionComptability() : void in class org.apache.pulsar.client.impl.MessageIdTest |
From |
To |
|
Change Variable Type message : Message to message : Message<byte[]> in method public testStartEmptyPatternConsumer() : void in class org.apache.pulsar.client.impl.PatternTopicsConsumerImplTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testUnackBlockRedeliverMessages() : void in class org.apache.pulsar.client.api.SimpleProducerConsumerTest |
From |
To |
|
Change Variable Type msg : Message to msg : Message<byte[]> in method public testSimpleConsumerEvents() : void in class org.apache.pulsar.broker.service.PersistentQueueE2ETest |
From |
To |