Interface RateLimitPolicy
- All Known Implementing Classes:
- RateLimitPolicyFactory.DefaultRateLimiter,- RateLimitPolicyFactory.DelayIntervalRateLimiter
public interface RateLimitPolicy
- 
Method SummaryModifier and TypeMethodDescriptiondefault voidonSuccess(List<KinesisRecord> records) Called after Kinesis records are successfully retrieved.default voidCalled after the Kinesis client is throttled.
- 
Method Details- 
onSuccessCalled after Kinesis records are successfully retrieved.- Parameters:
- records- The list of retrieved records.
- Throws:
- InterruptedException
 
- 
onThrottleCalled after the Kinesis client is throttled.- Parameters:
- e- The- KinesisClientThrottledExceptionthrown by the client.
- Throws:
- InterruptedException
 
 
-