| Package | Description |
|---|---|
| org.apache.storm.eventhubs.spout | |
| org.apache.storm.eventhubs.trident |
| Modifier and Type | Method and Description |
|---|---|
static EventData |
EventData.create(org.apache.qpid.amqp_1_0.client.Message message,
MessageId messageId) |
EventData |
SimplePartitionManager.receive() |
EventData |
PartitionManager.receive() |
EventData |
IPartitionManager.receive() |
EventData |
IEventHubReceiver.receive(long timeoutInMilliseconds) |
EventData |
EventHubReceiverImpl.receive(long timeoutInMilliseconds) |
| Modifier and Type | Method and Description |
|---|---|
int |
EventData.compareTo(EventData ed) |
| Modifier and Type | Method and Description |
|---|---|
List<EventData> |
TridentPartitionManager.receiveBatch(String offset,
int count) |
List<EventData> |
ITridentPartitionManager.receiveBatch(String offset,
int count)
receive a batch of messages from EvenHub up to “count” messages
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.