Package | Description |
---|---|
org.apache.storm.kafka.spout | |
org.apache.storm.kafka.spout.internal |
Modifier and Type | Method and Description |
---|---|
KafkaSpoutMessageId |
KafkaSpoutRetryExponentialBackoff.getMessageId(org.apache.kafka.common.TopicPartition tp,
long offset) |
KafkaSpoutMessageId |
KafkaSpoutRetryService.getMessageId(org.apache.kafka.common.TopicPartition topicPartition,
long offset)
Gets the
KafkaSpoutMessageId for the record on the given topic partition and offset. |
Modifier and Type | Method and Description |
---|---|
boolean |
KafkaSpoutRetryExponentialBackoff.isReady(KafkaSpoutMessageId msgId) |
boolean |
KafkaSpoutRetryService.isReady(KafkaSpoutMessageId msgId)
Checks if a specific failed
KafkaSpoutMessageId is ready to be retried, i.e is scheduled and has retry time that is less than current time. |
boolean |
KafkaSpoutRetryExponentialBackoff.isScheduled(KafkaSpoutMessageId msgId) |
boolean |
KafkaSpoutRetryService.isScheduled(KafkaSpoutMessageId msgId)
Checks if a specific failed
KafkaSpoutMessageId is scheduled to be retried. |
void |
KafkaTupleListener.onAck(KafkaSpoutMessageId msgId)
Called when a tuple is acked.
|
void |
EmptyKafkaTupleListener.onAck(KafkaSpoutMessageId msgId) |
void |
KafkaTupleListener.onEmit(List<Object> tuple,
KafkaSpoutMessageId msgId)
Called when the tuple is emitted and auto commit is disabled.
|
void |
EmptyKafkaTupleListener.onEmit(List<Object> tuple,
KafkaSpoutMessageId msgId) |
void |
KafkaTupleListener.onMaxRetryReached(KafkaSpoutMessageId msgId)
Called when the maximum number of retries have been reached.
|
void |
EmptyKafkaTupleListener.onMaxRetryReached(KafkaSpoutMessageId msgId) |
void |
KafkaTupleListener.onRetry(KafkaSpoutMessageId msgId)
Called when the Kafka spout sets a record for retry.
|
void |
EmptyKafkaTupleListener.onRetry(KafkaSpoutMessageId msgId) |
boolean |
KafkaSpoutRetryExponentialBackoff.remove(KafkaSpoutMessageId msgId) |
boolean |
KafkaSpoutRetryService.remove(KafkaSpoutMessageId msgId)
Removes a message from the list of messages scheduled for retrial.
|
boolean |
KafkaSpoutRetryExponentialBackoff.schedule(KafkaSpoutMessageId msgId) |
boolean |
KafkaSpoutRetryService.schedule(KafkaSpoutMessageId msgId)
Schedules this
KafkaSpoutMessageId if not yet scheduled, or updates retry time if it has already been scheduled. |
Modifier and Type | Method and Description |
---|---|
void |
OffsetManager.addToAckMsgs(KafkaSpoutMessageId msgId) |
boolean |
OffsetManager.contains(KafkaSpoutMessageId msgId) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.