| Package | Description |
|---|---|
| org.apache.pulsar.client.impl |
| Modifier and Type | Method and Description |
|---|---|
static <T> MessageImpl<T> |
MessageImpl.create(PulsarApi.MessageMetadata.Builder msgMetadataBuilder,
ByteBuffer payload,
Schema<T> schema) |
static MessageImpl<byte[]> |
MessageImpl.deserialize(io.netty.buffer.ByteBuf headersAndPayload) |
MessageImpl<?> |
SendCallback.getNextMessage()
Return next message in chain
|
| Modifier and Type | Method and Description |
|---|---|
boolean |
BatchMessageContainerBase.add(MessageImpl<?> msg,
SendCallback callback)
Add message to the batch message container.
|
void |
SendCallback.addCallback(MessageImpl<?> msg,
SendCallback scb)
used to specify a callback to be invoked on completion of a send operation for individual messages sent in a
batch.
|
boolean |
BatchMessageContainerBase.hasSameSchema(MessageImpl<?> msg)
Check the batch message container has same schema with the message want to add.
|
boolean |
AbstractBatchMessageContainer.hasSameTxn(MessageImpl<?> msg) |
boolean |
BatchMessageContainerBase.hasSameTxn(MessageImpl<?> msg)
Check whether the added message belong to the same txn with batch message container.
|
boolean |
AbstractBatchMessageContainer.haveEnoughSpace(MessageImpl<?> msg) |
boolean |
BatchMessageContainerBase.haveEnoughSpace(MessageImpl<?> msg)
Check the batch message container have enough space for the message want to add.
|
Copyright © 2017–2020 Apache Software Foundation. All rights reserved.