Class RateLimitPolicyFactory.DefaultRateLimiter

java.lang.Object
org.apache.beam.sdk.io.aws2.kinesis.RateLimitPolicyFactory.DefaultRateLimiter
All Implemented Interfaces:
RateLimitPolicy
Enclosing interface:
RateLimitPolicyFactory

public static class RateLimitPolicyFactory.DefaultRateLimiter extends Object implements RateLimitPolicy
Default rate limiter that throttles reading from a shard using an exponential backoff if the response is empty or if the consumer is throttled by AWS.