public class DynamoDBStreamsProxy extends KinesisProxy
Modifier | Constructor and Description |
---|---|
protected |
DynamoDBStreamsProxy(Properties configProps) |
Modifier and Type | Method and Description |
---|---|
static KinesisProxyInterface |
create(Properties configProps)
Creates a DynamoDB streams proxy.
|
protected com.amazonaws.services.kinesis.AmazonKinesis |
createKinesisClient(Properties configProps)
Creates an AmazonDynamoDBStreamsAdapterClient.
|
GetShardListResult |
getShardList(Map<String,String> streamNamesWithLastSeenShardIds)
Get shard list of multiple Kinesis streams, ignoring the shards of each stream before a
specified last seen shard id.
|
describeStream, fullJitterBackoff, getRecords, getShardIterator, isRecoverableException, isRecoverableSdkClientException
protected DynamoDBStreamsProxy(Properties configProps)
public static KinesisProxyInterface create(Properties configProps)
configProps
- configuration propertiesprotected com.amazonaws.services.kinesis.AmazonKinesis createKinesisClient(Properties configProps)
createKinesisClient
in class KinesisProxy
configProps
- configuration propertiespublic GetShardListResult getShardList(Map<String,String> streamNamesWithLastSeenShardIds) throws InterruptedException
KinesisProxy
getShardList
in interface KinesisProxyInterface
getShardList
in class KinesisProxy
streamNamesWithLastSeenShardIds
- a map with stream as key, and last seen shard id as
valueInterruptedException
- this method will retry with backoff if AWS Kinesis complains
that the operation has exceeded the rate limit; this exception will be thrown if the
backoff is interrupted.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.