类的使用
org.apache.pulsar.common.api.proto.MessageIdData
使用MessageIdData的程序包
-
org.apache.pulsar.common.api.proto中MessageIdData的使用
修饰符和类型方法说明CommandAck.addMessageId()CommandRedeliverUnacknowledgedMessages.addMessageId()MessageIdData.clear()MessageIdData.clearAckSet()MessageIdData.clearBatchIndex()MessageIdData.clearBatchSize()MessageIdData.clearEntryId()MessageIdData.clearFirstChunkMessageId()MessageIdData.clearLedgerId()MessageIdData.clearPartition()MessageIdData.copyFrom(MessageIdData _other) CommandGetLastMessageIdResponse.getConsumerMarkDeletePosition()MessageIdData.getFirstChunkMessageId()CommandGetLastMessageIdResponse.getLastMessageId()CommandMessage.getMessageId()CommandSeek.getMessageId()CommandSend.getMessageId()CommandSendReceipt.getMessageId()CommandAck.getMessageIdAt(int idx) CommandRedeliverUnacknowledgedMessages.getMessageIdAt(int idx) CommandSubscribe.getStartMessageId()MessageIdData.setBatchIndex(int batchIndex) MessageIdData.setBatchSize(int batchSize) CommandGetLastMessageIdResponse.setConsumerMarkDeletePosition()MessageIdData.setEntryId(long entryId) MessageIdData.setFirstChunkMessageId()CommandGetLastMessageIdResponse.setLastMessageId()MessageIdData.setLedgerId(long ledgerId) CommandMessage.setMessageId()CommandSeek.setMessageId()CommandSend.setMessageId()CommandSendReceipt.setMessageId()MessageIdData.setPartition(int partition) CommandSubscribe.setStartMessageId()返回变量类型为MessageIdData的类型的org.apache.pulsar.common.api.proto中的方法修饰符和类型方法说明CommandAck.getMessageIdsList()CommandRedeliverUnacknowledgedMessages.getMessageIdsList()类型变量类型为MessageIdData的org.apache.pulsar.common.api.proto中的方法参数修饰符和类型方法说明CommandAck.addAllMessageIds(Iterable<MessageIdData> messageIds) CommandRedeliverUnacknowledgedMessages.addAllMessageIds(Iterable<MessageIdData> messageIds) -
org.apache.pulsar.common.protocol中MessageIdData的使用
修饰符和类型方法说明static io.netty.buffer.ByteBufCommands.newSubscribe(String topic, String subscription, long consumerId, long requestId, CommandSubscribe.SubType subType, int priorityLevel, String consumerName, boolean isDurable, MessageIdData startMessageId, Map<String, String> metadata, boolean readCompacted, boolean isReplicated, CommandSubscribe.InitialPosition subscriptionInitialPosition, long startMessageRollbackDurationInSec, SchemaInfo schemaInfo, boolean createTopicIfDoesNotExist) static io.netty.buffer.ByteBufCommands.newSubscribe(String topic, String subscription, long consumerId, long requestId, CommandSubscribe.SubType subType, int priorityLevel, String consumerName, boolean isDurable, MessageIdData startMessageId, Map<String, String> metadata, boolean readCompacted, boolean isReplicated, CommandSubscribe.InitialPosition subscriptionInitialPosition, long startMessageRollbackDurationInSec, SchemaInfo schemaInfo, boolean createTopicIfDoesNotExist, KeySharedPolicy keySharedPolicy, Map<String, String> subscriptionProperties, long consumerEpoch) 类型变量类型为MessageIdData的org.apache.pulsar.common.protocol中的方法参数修饰符和类型方法说明static io.netty.buffer.ByteBufCommands.newAck(long consumerId, List<MessageIdData> messageIds, CommandAck.AckType ackType, CommandAck.ValidationError validationError, Map<String, Long> properties, long txnIdLeastBits, long txnIdMostBits, long requestId) static io.netty.buffer.ByteBufCommands.newRedeliverUnacknowledgedMessages(long consumerId, List<MessageIdData> messageIds)