public class KinesisClientLibConfiguration extends Object
Modifier and Type | Field and Description |
---|---|
static boolean |
DEFAULT_CLEANUP_LEASES_UPON_SHARDS_COMPLETION
Cleanup leases upon shards completion (don't wait until they expire in Kinesis).
|
static boolean |
DEFAULT_DONT_CALL_PROCESS_RECORDS_FOR_EMPTY_RECORD_LIST
Don't call processRecords() on the record processor for empty record lists.
|
static long |
DEFAULT_FAILOVER_TIME_MILLIS
Fail over time in milliseconds.
|
static long |
DEFAULT_IDLETIME_BETWEEN_READS_MILLIS
The default value for how long the
ShardConsumer should sleep if no records are returned from the call to
AmazonKinesis.getRecords(com.amazonaws.services.kinesis.model.GetRecordsRequest) . |
static int |
DEFAULT_INITIAL_LEASE_TABLE_READ_CAPACITY
The Amazon DynamoDB table used for tracking leases will be provisioned with this read capacity.
|
static int |
DEFAULT_INITIAL_LEASE_TABLE_WRITE_CAPACITY
The Amazon DynamoDB table used for tracking leases will be provisioned with this write capacity.
|
static InitialPositionInStream |
DEFAULT_INITIAL_POSITION_IN_STREAM
The location in the shard from which the KinesisClientLibrary will start fetching records from
when the application starts for the first time and there is no checkpoint for the shard.
|
static int |
DEFAULT_MAX_LEASE_RENEWAL_THREADS
The size of the thread pool to create for the lease renewer to use.
|
static int |
DEFAULT_MAX_LEASES_FOR_WORKER
The max number of leases (shards) this worker should process.
|
static int |
DEFAULT_MAX_LEASES_TO_STEAL_AT_ONE_TIME
Max leases to steal from another worker at one time (for load balancing).
|
static int |
DEFAULT_MAX_RECORDS
Max records to fetch from Kinesis in a single GetRecords call.
|
static long |
DEFAULT_METRICS_BUFFER_TIME_MILLIS
Buffer metrics for at most this long before publishing to CloudWatch.
|
static Set<String> |
DEFAULT_METRICS_ENABLED_DIMENSIONS
Allowed dimensions for CloudWatch metrics.
|
static MetricsLevel |
DEFAULT_METRICS_LEVEL
Metrics level for which to enable CloudWatch metrics.
|
static int |
DEFAULT_METRICS_MAX_QUEUE_SIZE
Buffer at most this many metrics before publishing to CloudWatch.
|
static long |
DEFAULT_PARENT_SHARD_POLL_INTERVAL_MILLIS
Interval in milliseconds between polling to check for parent shard completion.
|
static ShardPrioritization |
DEFAULT_SHARD_PRIORITIZATION
Default Shard prioritization strategy.
|
static long |
DEFAULT_SHARD_SYNC_INTERVAL_MILLIS
Shard sync interval in milliseconds - e.g.
|
static boolean |
DEFAULT_SKIP_SHARD_SYNC_AT_STARTUP_IF_LEASES_EXIST
The Worker will skip shard sync during initialization if there are one or more leases in the lease table.
|
static long |
DEFAULT_TASK_BACKOFF_TIME_MILLIS
Backoff time in milliseconds for Amazon Kinesis Client Library tasks (in the event of failures).
|
static boolean |
DEFAULT_VALIDATE_SEQUENCE_NUMBER_BEFORE_CHECKPOINTING
KCL will validate client provided sequence numbers with a call to Amazon Kinesis before checkpointing for calls
to
RecordProcessorCheckpointer.checkpoint(String) by default. |
static String |
KINESIS_CLIENT_LIB_USER_AGENT
User agent set when Amazon Kinesis Client Library makes AWS requests.
|
static Set<String> |
METRICS_ALWAYS_ENABLED_DIMENSIONS
Metrics dimensions that always will be enabled regardless of the config provided by user.
|
static Set<String> |
METRICS_DIMENSIONS_ALL
Metrics dimensions that signify all possible dimensions.
|
Constructor and Description |
---|
KinesisClientLibConfiguration(String applicationName,
String streamName,
com.amazonaws.auth.AWSCredentialsProvider kinesisCredentialsProvider,
com.amazonaws.auth.AWSCredentialsProvider dynamoDBCredentialsProvider,
com.amazonaws.auth.AWSCredentialsProvider cloudWatchCredentialsProvider,
String workerId)
Constructor.
|
KinesisClientLibConfiguration(String applicationName,
String streamName,
com.amazonaws.auth.AWSCredentialsProvider credentialsProvider,
String workerId)
Constructor.
|
KinesisClientLibConfiguration(String applicationName,
String streamName,
String kinesisEndpoint,
InitialPositionInStream initialPositionInStream,
com.amazonaws.auth.AWSCredentialsProvider kinesisCredentialsProvider,
com.amazonaws.auth.AWSCredentialsProvider dynamoDBCredentialsProvider,
com.amazonaws.auth.AWSCredentialsProvider cloudWatchCredentialsProvider,
long failoverTimeMillis,
String workerId,
int maxRecords,
long idleTimeBetweenReadsInMillis,
boolean callProcessRecordsEvenForEmptyRecordList,
long parentShardPollIntervalMillis,
long shardSyncIntervalMillis,
boolean cleanupTerminatedShardsBeforeExpiry,
com.amazonaws.ClientConfiguration kinesisClientConfig,
com.amazonaws.ClientConfiguration dynamoDBClientConfig,
com.amazonaws.ClientConfiguration cloudWatchClientConfig,
long taskBackoffTimeMillis,
long metricsBufferTimeMillis,
int metricsMaxQueueSize,
boolean validateSequenceNumberBeforeCheckpointing,
String regionName) |
KinesisClientLibConfiguration(String applicationName,
String streamName,
String kinesisEndpoint,
String dynamoDBEndpoint,
InitialPositionInStream initialPositionInStream,
com.amazonaws.auth.AWSCredentialsProvider kinesisCredentialsProvider,
com.amazonaws.auth.AWSCredentialsProvider dynamoDBCredentialsProvider,
com.amazonaws.auth.AWSCredentialsProvider cloudWatchCredentialsProvider,
long failoverTimeMillis,
String workerId,
int maxRecords,
long idleTimeBetweenReadsInMillis,
boolean callProcessRecordsEvenForEmptyRecordList,
long parentShardPollIntervalMillis,
long shardSyncIntervalMillis,
boolean cleanupTerminatedShardsBeforeExpiry,
com.amazonaws.ClientConfiguration kinesisClientConfig,
com.amazonaws.ClientConfiguration dynamoDBClientConfig,
com.amazonaws.ClientConfiguration cloudWatchClientConfig,
long taskBackoffTimeMillis,
long metricsBufferTimeMillis,
int metricsMaxQueueSize,
boolean validateSequenceNumberBeforeCheckpointing,
String regionName) |
public static final InitialPositionInStream DEFAULT_INITIAL_POSITION_IN_STREAM
public static final long DEFAULT_FAILOVER_TIME_MILLIS
public static final int DEFAULT_MAX_RECORDS
public static final long DEFAULT_IDLETIME_BETWEEN_READS_MILLIS
ShardConsumer
should sleep if no records are returned from the call to
AmazonKinesis.getRecords(com.amazonaws.services.kinesis.model.GetRecordsRequest)
.public static final boolean DEFAULT_DONT_CALL_PROCESS_RECORDS_FOR_EMPTY_RECORD_LIST
public static final long DEFAULT_PARENT_SHARD_POLL_INTERVAL_MILLIS
public static final long DEFAULT_SHARD_SYNC_INTERVAL_MILLIS
public static final boolean DEFAULT_CLEANUP_LEASES_UPON_SHARDS_COMPLETION
public static final long DEFAULT_TASK_BACKOFF_TIME_MILLIS
public static final long DEFAULT_METRICS_BUFFER_TIME_MILLIS
public static final int DEFAULT_METRICS_MAX_QUEUE_SIZE
public static final MetricsLevel DEFAULT_METRICS_LEVEL
public static final Set<String> METRICS_ALWAYS_ENABLED_DIMENSIONS
public static final Set<String> DEFAULT_METRICS_ENABLED_DIMENSIONS
public static final Set<String> METRICS_DIMENSIONS_ALL
public static final String KINESIS_CLIENT_LIB_USER_AGENT
public static final boolean DEFAULT_VALIDATE_SEQUENCE_NUMBER_BEFORE_CHECKPOINTING
RecordProcessorCheckpointer.checkpoint(String)
by default.public static final int DEFAULT_MAX_LEASES_FOR_WORKER
public static final int DEFAULT_MAX_LEASES_TO_STEAL_AT_ONE_TIME
public static final int DEFAULT_INITIAL_LEASE_TABLE_READ_CAPACITY
public static final int DEFAULT_INITIAL_LEASE_TABLE_WRITE_CAPACITY
public static final boolean DEFAULT_SKIP_SHARD_SYNC_AT_STARTUP_IF_LEASES_EXIST
public static final ShardPrioritization DEFAULT_SHARD_PRIORITIZATION
public static final int DEFAULT_MAX_LEASE_RENEWAL_THREADS
public KinesisClientLibConfiguration(String applicationName, String streamName, com.amazonaws.auth.AWSCredentialsProvider credentialsProvider, String workerId)
applicationName
- Name of the Amazon Kinesis application.
By default the application name is included in the user agent string used to make AWS requests. This
can assist with troubleshooting (e.g. distinguish requests made by separate applications).streamName
- Name of the Kinesis streamcredentialsProvider
- Provides credentials used to sign AWS requestsworkerId
- Used to distinguish different workers/processes of a Kinesis applicationpublic KinesisClientLibConfiguration(String applicationName, String streamName, com.amazonaws.auth.AWSCredentialsProvider kinesisCredentialsProvider, com.amazonaws.auth.AWSCredentialsProvider dynamoDBCredentialsProvider, com.amazonaws.auth.AWSCredentialsProvider cloudWatchCredentialsProvider, String workerId)
applicationName
- Name of the Amazon Kinesis application
By default the application name is included in the user agent string used to make AWS requests. This
can assist with troubleshooting (e.g. distinguish requests made by separate applications).streamName
- Name of the Kinesis streamkinesisCredentialsProvider
- Provides credentials used to access KinesisdynamoDBCredentialsProvider
- Provides credentials used to access DynamoDBcloudWatchCredentialsProvider
- Provides credentials used to access CloudWatchworkerId
- Used to distinguish different workers/processes of a Kinesis applicationpublic KinesisClientLibConfiguration(String applicationName, String streamName, String kinesisEndpoint, InitialPositionInStream initialPositionInStream, com.amazonaws.auth.AWSCredentialsProvider kinesisCredentialsProvider, com.amazonaws.auth.AWSCredentialsProvider dynamoDBCredentialsProvider, com.amazonaws.auth.AWSCredentialsProvider cloudWatchCredentialsProvider, long failoverTimeMillis, String workerId, int maxRecords, long idleTimeBetweenReadsInMillis, boolean callProcessRecordsEvenForEmptyRecordList, long parentShardPollIntervalMillis, long shardSyncIntervalMillis, boolean cleanupTerminatedShardsBeforeExpiry, com.amazonaws.ClientConfiguration kinesisClientConfig, com.amazonaws.ClientConfiguration dynamoDBClientConfig, com.amazonaws.ClientConfiguration cloudWatchClientConfig, long taskBackoffTimeMillis, long metricsBufferTimeMillis, int metricsMaxQueueSize, boolean validateSequenceNumberBeforeCheckpointing, String regionName)
applicationName
- Name of the Kinesis application
By default the application name is included in the user agent string used to make AWS requests. This
can assist with troubleshooting (e.g. distinguish requests made by separate applications).streamName
- Name of the Kinesis streamkinesisEndpoint
- Kinesis endpointinitialPositionInStream
- One of LATEST or TRIM_HORIZON. The KinesisClientLibrary will start fetching
records from that location in the stream when an application starts up for the first time and there
are no checkpoints. If there are checkpoints, then we start from the checkpoint position.kinesisCredentialsProvider
- Provides credentials used to access KinesisdynamoDBCredentialsProvider
- Provides credentials used to access DynamoDBcloudWatchCredentialsProvider
- Provides credentials used to access CloudWatchfailoverTimeMillis
- Lease duration (leases not renewed within this period will be claimed by others)workerId
- Used to distinguish different workers/processes of a Kinesis applicationmaxRecords
- Max records to read per Kinesis getRecords() callidleTimeBetweenReadsInMillis
- Idle time between calls to fetch data from KinesiscallProcessRecordsEvenForEmptyRecordList
- Call the IRecordProcessor::processRecords() API even if
GetRecords returned an empty record list.parentShardPollIntervalMillis
- Wait for this long between polls to check if parent shards are doneshardSyncIntervalMillis
- Time between tasks to sync leases and Kinesis shardscleanupTerminatedShardsBeforeExpiry
- Clean up shards we've finished processing (don't wait for expiration
in Kinesis)kinesisClientConfig
- Client Configuration used by Kinesis clientdynamoDBClientConfig
- Client Configuration used by DynamoDB clientcloudWatchClientConfig
- Client Configuration used by CloudWatch clienttaskBackoffTimeMillis
- Backoff period when tasks encounter an exceptionmetricsBufferTimeMillis
- Metrics are buffered for at most this long before publishing to CloudWatchmetricsMaxQueueSize
- Max number of metrics to buffer before publishing to CloudWatchvalidateSequenceNumberBeforeCheckpointing
- whether KCL should validate client provided sequence numbers
with a call to Amazon Kinesis before checkpointing for calls to
RecordProcessorCheckpointer.checkpoint(String)
regionName
- The region name for the servicepublic KinesisClientLibConfiguration(String applicationName, String streamName, String kinesisEndpoint, String dynamoDBEndpoint, InitialPositionInStream initialPositionInStream, com.amazonaws.auth.AWSCredentialsProvider kinesisCredentialsProvider, com.amazonaws.auth.AWSCredentialsProvider dynamoDBCredentialsProvider, com.amazonaws.auth.AWSCredentialsProvider cloudWatchCredentialsProvider, long failoverTimeMillis, String workerId, int maxRecords, long idleTimeBetweenReadsInMillis, boolean callProcessRecordsEvenForEmptyRecordList, long parentShardPollIntervalMillis, long shardSyncIntervalMillis, boolean cleanupTerminatedShardsBeforeExpiry, com.amazonaws.ClientConfiguration kinesisClientConfig, com.amazonaws.ClientConfiguration dynamoDBClientConfig, com.amazonaws.ClientConfiguration cloudWatchClientConfig, long taskBackoffTimeMillis, long metricsBufferTimeMillis, int metricsMaxQueueSize, boolean validateSequenceNumberBeforeCheckpointing, String regionName)
applicationName
- Name of the Kinesis application
By default the application name is included in the user agent string used to make AWS requests. This
can assist with troubleshooting (e.g. distinguish requests made by separate applications).streamName
- Name of the Kinesis streamkinesisEndpoint
- Kinesis endpointdynamoDBEndpoint
- DynamoDB endpointinitialPositionInStream
- One of LATEST or TRIM_HORIZON. The KinesisClientLibrary will start fetching
records from that location in the stream when an application starts up for the first time and there
are no checkpoints. If there are checkpoints, then we start from the checkpoint position.kinesisCredentialsProvider
- Provides credentials used to access KinesisdynamoDBCredentialsProvider
- Provides credentials used to access DynamoDBcloudWatchCredentialsProvider
- Provides credentials used to access CloudWatchfailoverTimeMillis
- Lease duration (leases not renewed within this period will be claimed by others)workerId
- Used to distinguish different workers/processes of a Kinesis applicationmaxRecords
- Max records to read per Kinesis getRecords() callidleTimeBetweenReadsInMillis
- Idle time between calls to fetch data from KinesiscallProcessRecordsEvenForEmptyRecordList
- Call the IRecordProcessor::processRecords() API even if
GetRecords returned an empty record list.parentShardPollIntervalMillis
- Wait for this long between polls to check if parent shards are doneshardSyncIntervalMillis
- Time between tasks to sync leases and Kinesis shardscleanupTerminatedShardsBeforeExpiry
- Clean up shards we've finished processing (don't wait for expiration
in Kinesis)kinesisClientConfig
- Client Configuration used by Kinesis clientdynamoDBClientConfig
- Client Configuration used by DynamoDB clientcloudWatchClientConfig
- Client Configuration used by CloudWatch clienttaskBackoffTimeMillis
- Backoff period when tasks encounter an exceptionmetricsBufferTimeMillis
- Metrics are buffered for at most this long before publishing to CloudWatchmetricsMaxQueueSize
- Max number of metrics to buffer before publishing to CloudWatchvalidateSequenceNumberBeforeCheckpointing
- whether KCL should validate client provided sequence numbers
with a call to Amazon Kinesis before checkpointing for calls to
RecordProcessorCheckpointer.checkpoint(String)
regionName
- The region name for the servicepublic String getApplicationName()
public String getTableName()
public long getFailoverTimeMillis()
public com.amazonaws.auth.AWSCredentialsProvider getKinesisCredentialsProvider()
public com.amazonaws.auth.AWSCredentialsProvider getDynamoDBCredentialsProvider()
public com.amazonaws.auth.AWSCredentialsProvider getCloudWatchCredentialsProvider()
public String getWorkerIdentifier()
public long getShardSyncIntervalMillis()
public int getMaxRecords()
public long getIdleTimeBetweenReadsInMillis()
public boolean shouldCallProcessRecordsEvenForEmptyRecordList()
public long getEpsilonMillis()
public String getStreamName()
public String getKinesisEndpoint()
public String getDynamoDBEndpoint()
public InitialPositionInStream getInitialPositionInStream()
public long getParentShardPollIntervalMillis()
public com.amazonaws.ClientConfiguration getKinesisClientConfiguration()
public com.amazonaws.ClientConfiguration getDynamoDBClientConfiguration()
public com.amazonaws.ClientConfiguration getCloudWatchClientConfiguration()
public long getTaskBackoffTimeMillis()
public long getMetricsBufferTimeMillis()
public int getMetricsMaxQueueSize()
public MetricsLevel getMetricsLevel()
public Set<String> getMetricsEnabledDimensions()
public boolean shouldCleanupLeasesUponShardCompletion()
public boolean shouldValidateSequenceNumberBeforeCheckpointing()
RecordProcessorCheckpointer.checkpoint(String)
public String getRegionName()
public boolean getSkipShardSyncAtWorkerInitializationIfLeasesExist()
public int getMaxLeasesForWorker()
public int getMaxLeasesToStealAtOneTime()
public int getInitialLeaseTableReadCapacity()
public int getInitialLeaseTableWriteCapacity()
protected com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStreamExtended getInitialPositionInStreamExtended()
public Date getTimestampAtInitialPositionInStream()
public ShardPrioritization getShardPrioritizationStrategy()
public KinesisClientLibConfiguration withTableName(String tableName)
tableName
- name of the lease table in DynamoDBpublic KinesisClientLibConfiguration withKinesisEndpoint(String kinesisEndpoint)
kinesisEndpoint
- Kinesis endpointpublic KinesisClientLibConfiguration withDynamoDBEndpoint(String dynamoDBEndpoint)
dynamoDBEndpoint
- DynamoDB endpointpublic KinesisClientLibConfiguration withInitialPositionInStream(InitialPositionInStream initialPositionInStream)
initialPositionInStream
- One of LATEST or TRIM_HORIZON. The Amazon Kinesis Client Library
will start fetching records from this position when the application starts up if there are no checkpoints.
If there are checkpoints, we will process records from the checkpoint position.public KinesisClientLibConfiguration withTimestampAtInitialPositionInStream(Date timestamp)
timestamp
- The timestamp to use with the AT_TIMESTAMP value for initialPositionInStream.public KinesisClientLibConfiguration withFailoverTimeMillis(long failoverTimeMillis)
failoverTimeMillis
- Lease duration (leases not renewed within this period will be claimed by others)public KinesisClientLibConfiguration withShardSyncIntervalMillis(long shardSyncIntervalMillis)
shardSyncIntervalMillis
- Time between tasks to sync leases and Kinesis shardspublic KinesisClientLibConfiguration withMaxRecords(int maxRecords)
maxRecords
- Max records to fetch in a Kinesis getRecords() callpublic KinesisClientLibConfiguration withIdleTimeBetweenReadsInMillis(long idleTimeBetweenReadsInMillis)
This value is only used when no records are returned; if records are returned, the ProcessTask
will
immediately retrieve the next set of records after the call to
IRecordProcessor.processRecords(ProcessRecordsInput)
has returned. Setting this value to high may result in the KCL being unable to catch up. If you are changing this
value it's recommended that you enable withCallProcessRecordsEvenForEmptyRecordList(boolean)
, and
monitor how far behind the records retrieved are by inspecting
ProcessRecordsInput.getMillisBehindLatest()
, and the
CloudWatch
Metric: GetRecords.MillisBehindLatest
idleTimeBetweenReadsInMillis
- how long to sleep between GetRecords calls when no records are returned.public KinesisClientLibConfiguration withCallProcessRecordsEvenForEmptyRecordList(boolean callProcessRecordsEvenForEmptyRecordList)
callProcessRecordsEvenForEmptyRecordList
- Call the RecordProcessor::processRecords() API even if
GetRecords returned an empty record listpublic KinesisClientLibConfiguration withParentShardPollIntervalMillis(long parentShardPollIntervalMillis)
parentShardPollIntervalMillis
- Wait for this long between polls to check if parent shards are donepublic KinesisClientLibConfiguration withCleanupLeasesUponShardCompletion(boolean cleanupLeasesUponShardCompletion)
cleanupLeasesUponShardCompletion
- Clean up shards we've finished processing (don't wait for expiration
in Kinesis)public KinesisClientLibConfiguration withCommonClientConfig(com.amazonaws.ClientConfiguration clientConfig)
clientConfig
- Common client configuration used by Kinesis/DynamoDB/CloudWatch clientpublic KinesisClientLibConfiguration withKinesisClientConfig(com.amazonaws.ClientConfiguration kinesisClientConfig)
kinesisClientConfig
- Client configuration used by Kinesis clientpublic KinesisClientLibConfiguration withDynamoDBClientConfig(com.amazonaws.ClientConfiguration dynamoDBClientConfig)
dynamoDBClientConfig
- Client configuration used by DynamoDB clientpublic KinesisClientLibConfiguration withCloudWatchClientConfig(com.amazonaws.ClientConfiguration cloudWatchClientConfig)
cloudWatchClientConfig
- Client configuration used by CloudWatch clientpublic KinesisClientLibConfiguration withUserAgent(String userAgent)
userAgent
- User agent to use in AWS requestspublic KinesisClientLibConfiguration withTaskBackoffTimeMillis(long taskBackoffTimeMillis)
taskBackoffTimeMillis
- Backoff period when tasks encounter an exceptionpublic KinesisClientLibConfiguration withMetricsBufferTimeMillis(long metricsBufferTimeMillis)
metricsBufferTimeMillis
- Metrics are buffered for at most this long before publishing to CloudWatchpublic KinesisClientLibConfiguration withMetricsMaxQueueSize(int metricsMaxQueueSize)
metricsMaxQueueSize
- Max number of metrics to buffer before publishing to CloudWatchpublic KinesisClientLibConfiguration withMetricsLevel(MetricsLevel metricsLevel)
metricsLevel
- Metrics level to enable.public KinesisClientLibConfiguration withMetricsLevel(String metricsLevel)
metricsLevel
- Metrics level to enable.public KinesisClientLibConfiguration withMetricsEnabledDimensions(Set<String> metricsEnabledDimensions)
metricsEnabledDimensions
- Set of dimensions that are allowed.public KinesisClientLibConfiguration withValidateSequenceNumberBeforeCheckpointing(boolean validateSequenceNumberBeforeCheckpointing)
validateSequenceNumberBeforeCheckpointing
- whether KCL should validate client provided sequence numbers
with a call to Amazon Kinesis before checkpointing for calls to
RecordProcessorCheckpointer.checkpoint(String)
.public KinesisClientLibConfiguration withSkipShardSyncAtStartupIfLeasesExist(boolean skipShardSyncAtStartupIfLeasesExist)
skipShardSyncAtStartupIfLeasesExist
- Should Worker skip syncing shards and leases at startup (Worker
initialization).public KinesisClientLibConfiguration withRegionName(String regionName)
regionName
- The region name for the servicepublic KinesisClientLibConfiguration withMaxLeasesForWorker(int maxLeasesForWorker)
maxLeasesForWorker
- Max leases this Worker can handle at a timepublic KinesisClientLibConfiguration withMaxLeasesToStealAtOneTime(int maxLeasesToStealAtOneTime)
maxLeasesToStealAtOneTime
- Steal up to this many leases at one time (for load balancing)public KinesisClientLibConfiguration withInitialLeaseTableReadCapacity(int initialLeaseTableReadCapacity)
initialLeaseTableReadCapacity
- Read capacity to provision when creating the lease table.public KinesisClientLibConfiguration withInitialLeaseTableWriteCapacity(int initialLeaseTableWriteCapacity)
initialLeaseTableWriteCapacity
- Write capacity to provision when creating the lease table.public KinesisClientLibConfiguration withShardPrioritizationStrategy(ShardPrioritization shardPrioritization)
shardPrioritization
- Implementation of ShardPrioritization interface that should be used during processing.public KinesisClientLibConfiguration withMaxLeaseRenewalThreads(int maxLeaseRenewalThreads)
maxLeaseRenewalThreads
- the maximum size of the lease renewal thread poolIllegalArgumentException
- if maxLeaseRenewalThreads is <= 0Copyright © 2017. All rights reserved.