public class DynamoDBLeaseManagementFactory extends Object implements LeaseManagementFactory
Constructor and Description |
---|
DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient,
software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient,
String tableName,
String workerIdentifier,
ExecutorService executorService,
long failoverTimeMillis,
long epsilonMillis,
int maxLeasesForWorker,
int maxLeasesToStealAtOneTime,
int maxLeaseRenewalThreads,
boolean cleanupLeasesUponShardCompletion,
boolean ignoreUnexpectedChildShards,
long shardSyncIntervalMillis,
boolean consistentReads,
long listShardsBackoffTimeMillis,
int maxListShardsRetryAttempts,
int maxCacheMissesBeforeReload,
long listShardsCacheAllowedAgeInSeconds,
int cacheMissWarningModulus,
long initialLeaseTableReadCapacity,
long initialLeaseTableWriteCapacity,
HierarchicalShardSyncer deprecatedHierarchicalShardSyncer,
TableCreatorCallback tableCreatorCallback,
Duration dynamoDbRequestTimeout,
software.amazon.awssdk.services.dynamodb.model.BillingMode billingMode,
LeaseSerializer leaseSerializer,
Function<StreamConfig,ShardDetector> customShardDetectorProvider,
boolean isMultiStreamMode,
LeaseCleanupConfig leaseCleanupConfig)
Constructor.
|
DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient,
String streamName,
software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient,
String tableName,
String workerIdentifier,
ExecutorService executorService,
InitialPositionInStreamExtended initialPositionInStream,
long failoverTimeMillis,
long epsilonMillis,
int maxLeasesForWorker,
int maxLeasesToStealAtOneTime,
int maxLeaseRenewalThreads,
boolean cleanupLeasesUponShardCompletion,
boolean ignoreUnexpectedChildShards,
long shardSyncIntervalMillis,
boolean consistentReads,
long listShardsBackoffTimeMillis,
int maxListShardsRetryAttempts,
int maxCacheMissesBeforeReload,
long listShardsCacheAllowedAgeInSeconds,
int cacheMissWarningModulus)
Deprecated.
|
DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient,
String streamName,
software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient,
String tableName,
String workerIdentifier,
ExecutorService executorService,
InitialPositionInStreamExtended initialPositionInStream,
long failoverTimeMillis,
long epsilonMillis,
int maxLeasesForWorker,
int maxLeasesToStealAtOneTime,
int maxLeaseRenewalThreads,
boolean cleanupLeasesUponShardCompletion,
boolean ignoreUnexpectedChildShards,
long shardSyncIntervalMillis,
boolean consistentReads,
long listShardsBackoffTimeMillis,
int maxListShardsRetryAttempts,
int maxCacheMissesBeforeReload,
long listShardsCacheAllowedAgeInSeconds,
int cacheMissWarningModulus,
long initialLeaseTableReadCapacity,
long initialLeaseTableWriteCapacity)
Deprecated.
|
DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient,
String streamName,
software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient,
String tableName,
String workerIdentifier,
ExecutorService executorService,
InitialPositionInStreamExtended initialPositionInStream,
long failoverTimeMillis,
long epsilonMillis,
int maxLeasesForWorker,
int maxLeasesToStealAtOneTime,
int maxLeaseRenewalThreads,
boolean cleanupLeasesUponShardCompletion,
boolean ignoreUnexpectedChildShards,
long shardSyncIntervalMillis,
boolean consistentReads,
long listShardsBackoffTimeMillis,
int maxListShardsRetryAttempts,
int maxCacheMissesBeforeReload,
long listShardsCacheAllowedAgeInSeconds,
int cacheMissWarningModulus,
long initialLeaseTableReadCapacity,
long initialLeaseTableWriteCapacity,
HierarchicalShardSyncer hierarchicalShardSyncer,
TableCreatorCallback tableCreatorCallback)
Deprecated.
|
DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient,
String streamName,
software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient,
String tableName,
String workerIdentifier,
ExecutorService executorService,
InitialPositionInStreamExtended initialPositionInStream,
long failoverTimeMillis,
long epsilonMillis,
int maxLeasesForWorker,
int maxLeasesToStealAtOneTime,
int maxLeaseRenewalThreads,
boolean cleanupLeasesUponShardCompletion,
boolean ignoreUnexpectedChildShards,
long shardSyncIntervalMillis,
boolean consistentReads,
long listShardsBackoffTimeMillis,
int maxListShardsRetryAttempts,
int maxCacheMissesBeforeReload,
long listShardsCacheAllowedAgeInSeconds,
int cacheMissWarningModulus,
long initialLeaseTableReadCapacity,
long initialLeaseTableWriteCapacity,
HierarchicalShardSyncer hierarchicalShardSyncer,
TableCreatorCallback tableCreatorCallback,
Duration dynamoDbRequestTimeout)
Deprecated.
|
DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient,
String streamName,
software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient,
String tableName,
String workerIdentifier,
ExecutorService executorService,
InitialPositionInStreamExtended initialPositionInStream,
long failoverTimeMillis,
long epsilonMillis,
int maxLeasesForWorker,
int maxLeasesToStealAtOneTime,
int maxLeaseRenewalThreads,
boolean cleanupLeasesUponShardCompletion,
boolean ignoreUnexpectedChildShards,
long shardSyncIntervalMillis,
boolean consistentReads,
long listShardsBackoffTimeMillis,
int maxListShardsRetryAttempts,
int maxCacheMissesBeforeReload,
long listShardsCacheAllowedAgeInSeconds,
int cacheMissWarningModulus,
long initialLeaseTableReadCapacity,
long initialLeaseTableWriteCapacity,
HierarchicalShardSyncer hierarchicalShardSyncer,
TableCreatorCallback tableCreatorCallback,
Duration dynamoDbRequestTimeout,
software.amazon.awssdk.services.dynamodb.model.BillingMode billingMode)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
LeaseCleanupManager |
createLeaseCleanupManager(MetricsFactory metricsFactory)
LeaseCleanupManager cleans up leases in the lease table for shards which have either expired past the
stream's retention period or have been completely processed.
|
LeaseCoordinator |
createLeaseCoordinator(MetricsFactory metricsFactory) |
DynamoDBLeaseRefresher |
createLeaseRefresher() |
ShardDetector |
createShardDetector()
Deprecated.
|
ShardDetector |
createShardDetector(StreamConfig streamConfig)
KinesisShardDetector supports reading from service only using streamName.
|
ShardSyncTaskManager |
createShardSyncTaskManager(MetricsFactory metricsFactory)
Deprecated.
|
ShardSyncTaskManager |
createShardSyncTaskManager(MetricsFactory metricsFactory,
StreamConfig streamConfig)
Create ShardSyncTaskManager from the streamConfig passed
|
@Deprecated public DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient, String streamName, software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient, String tableName, String workerIdentifier, ExecutorService executorService, InitialPositionInStreamExtended initialPositionInStream, long failoverTimeMillis, long epsilonMillis, int maxLeasesForWorker, int maxLeasesToStealAtOneTime, int maxLeaseRenewalThreads, boolean cleanupLeasesUponShardCompletion, boolean ignoreUnexpectedChildShards, long shardSyncIntervalMillis, boolean consistentReads, long listShardsBackoffTimeMillis, int maxListShardsRetryAttempts, int maxCacheMissesBeforeReload, long listShardsCacheAllowedAgeInSeconds, int cacheMissWarningModulus)
NOTE: This constructor is deprecated and will be removed in a future release.
kinesisClient
- streamName
- dynamoDBClient
- tableName
- workerIdentifier
- executorService
- initialPositionInStream
- failoverTimeMillis
- epsilonMillis
- maxLeasesForWorker
- maxLeasesToStealAtOneTime
- maxLeaseRenewalThreads
- cleanupLeasesUponShardCompletion
- ignoreUnexpectedChildShards
- shardSyncIntervalMillis
- consistentReads
- listShardsBackoffTimeMillis
- maxListShardsRetryAttempts
- maxCacheMissesBeforeReload
- listShardsCacheAllowedAgeInSeconds
- cacheMissWarningModulus
- @Deprecated public DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient, String streamName, software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient, String tableName, String workerIdentifier, ExecutorService executorService, InitialPositionInStreamExtended initialPositionInStream, long failoverTimeMillis, long epsilonMillis, int maxLeasesForWorker, int maxLeasesToStealAtOneTime, int maxLeaseRenewalThreads, boolean cleanupLeasesUponShardCompletion, boolean ignoreUnexpectedChildShards, long shardSyncIntervalMillis, boolean consistentReads, long listShardsBackoffTimeMillis, int maxListShardsRetryAttempts, int maxCacheMissesBeforeReload, long listShardsCacheAllowedAgeInSeconds, int cacheMissWarningModulus, long initialLeaseTableReadCapacity, long initialLeaseTableWriteCapacity)
NOTE: This constructor is deprecated and will be removed in a future release.
kinesisClient
- streamName
- dynamoDBClient
- tableName
- workerIdentifier
- executorService
- initialPositionInStream
- failoverTimeMillis
- epsilonMillis
- maxLeasesForWorker
- maxLeasesToStealAtOneTime
- maxLeaseRenewalThreads
- cleanupLeasesUponShardCompletion
- ignoreUnexpectedChildShards
- shardSyncIntervalMillis
- consistentReads
- listShardsBackoffTimeMillis
- maxListShardsRetryAttempts
- maxCacheMissesBeforeReload
- listShardsCacheAllowedAgeInSeconds
- cacheMissWarningModulus
- initialLeaseTableReadCapacity
- initialLeaseTableWriteCapacity
- @Deprecated public DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient, String streamName, software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient, String tableName, String workerIdentifier, ExecutorService executorService, InitialPositionInStreamExtended initialPositionInStream, long failoverTimeMillis, long epsilonMillis, int maxLeasesForWorker, int maxLeasesToStealAtOneTime, int maxLeaseRenewalThreads, boolean cleanupLeasesUponShardCompletion, boolean ignoreUnexpectedChildShards, long shardSyncIntervalMillis, boolean consistentReads, long listShardsBackoffTimeMillis, int maxListShardsRetryAttempts, int maxCacheMissesBeforeReload, long listShardsCacheAllowedAgeInSeconds, int cacheMissWarningModulus, long initialLeaseTableReadCapacity, long initialLeaseTableWriteCapacity, HierarchicalShardSyncer hierarchicalShardSyncer, TableCreatorCallback tableCreatorCallback)
kinesisClient
- streamName
- dynamoDBClient
- tableName
- workerIdentifier
- executorService
- initialPositionInStream
- failoverTimeMillis
- epsilonMillis
- maxLeasesForWorker
- maxLeasesToStealAtOneTime
- maxLeaseRenewalThreads
- cleanupLeasesUponShardCompletion
- ignoreUnexpectedChildShards
- shardSyncIntervalMillis
- consistentReads
- listShardsBackoffTimeMillis
- maxListShardsRetryAttempts
- maxCacheMissesBeforeReload
- listShardsCacheAllowedAgeInSeconds
- cacheMissWarningModulus
- initialLeaseTableReadCapacity
- initialLeaseTableWriteCapacity
- hierarchicalShardSyncer
- tableCreatorCallback
- @Deprecated public DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient, String streamName, software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient, String tableName, String workerIdentifier, ExecutorService executorService, InitialPositionInStreamExtended initialPositionInStream, long failoverTimeMillis, long epsilonMillis, int maxLeasesForWorker, int maxLeasesToStealAtOneTime, int maxLeaseRenewalThreads, boolean cleanupLeasesUponShardCompletion, boolean ignoreUnexpectedChildShards, long shardSyncIntervalMillis, boolean consistentReads, long listShardsBackoffTimeMillis, int maxListShardsRetryAttempts, int maxCacheMissesBeforeReload, long listShardsCacheAllowedAgeInSeconds, int cacheMissWarningModulus, long initialLeaseTableReadCapacity, long initialLeaseTableWriteCapacity, HierarchicalShardSyncer hierarchicalShardSyncer, TableCreatorCallback tableCreatorCallback, Duration dynamoDbRequestTimeout)
kinesisClient
- streamName
- dynamoDBClient
- tableName
- workerIdentifier
- executorService
- initialPositionInStream
- failoverTimeMillis
- epsilonMillis
- maxLeasesForWorker
- maxLeasesToStealAtOneTime
- maxLeaseRenewalThreads
- cleanupLeasesUponShardCompletion
- ignoreUnexpectedChildShards
- shardSyncIntervalMillis
- consistentReads
- listShardsBackoffTimeMillis
- maxListShardsRetryAttempts
- maxCacheMissesBeforeReload
- listShardsCacheAllowedAgeInSeconds
- cacheMissWarningModulus
- initialLeaseTableReadCapacity
- initialLeaseTableWriteCapacity
- hierarchicalShardSyncer
- tableCreatorCallback
- dynamoDbRequestTimeout
- @Deprecated public DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient, String streamName, software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient, String tableName, String workerIdentifier, ExecutorService executorService, InitialPositionInStreamExtended initialPositionInStream, long failoverTimeMillis, long epsilonMillis, int maxLeasesForWorker, int maxLeasesToStealAtOneTime, int maxLeaseRenewalThreads, boolean cleanupLeasesUponShardCompletion, boolean ignoreUnexpectedChildShards, long shardSyncIntervalMillis, boolean consistentReads, long listShardsBackoffTimeMillis, int maxListShardsRetryAttempts, int maxCacheMissesBeforeReload, long listShardsCacheAllowedAgeInSeconds, int cacheMissWarningModulus, long initialLeaseTableReadCapacity, long initialLeaseTableWriteCapacity, HierarchicalShardSyncer hierarchicalShardSyncer, TableCreatorCallback tableCreatorCallback, Duration dynamoDbRequestTimeout, software.amazon.awssdk.services.dynamodb.model.BillingMode billingMode)
kinesisClient
- streamName
- dynamoDBClient
- tableName
- workerIdentifier
- executorService
- initialPositionInStream
- failoverTimeMillis
- epsilonMillis
- maxLeasesForWorker
- maxLeasesToStealAtOneTime
- maxLeaseRenewalThreads
- cleanupLeasesUponShardCompletion
- ignoreUnexpectedChildShards
- shardSyncIntervalMillis
- consistentReads
- listShardsBackoffTimeMillis
- maxListShardsRetryAttempts
- maxCacheMissesBeforeReload
- listShardsCacheAllowedAgeInSeconds
- cacheMissWarningModulus
- initialLeaseTableReadCapacity
- initialLeaseTableWriteCapacity
- hierarchicalShardSyncer
- tableCreatorCallback
- dynamoDbRequestTimeout
- billingMode
- public DynamoDBLeaseManagementFactory(software.amazon.awssdk.services.kinesis.KinesisAsyncClient kinesisClient, software.amazon.awssdk.services.dynamodb.DynamoDbAsyncClient dynamoDBClient, String tableName, String workerIdentifier, ExecutorService executorService, long failoverTimeMillis, long epsilonMillis, int maxLeasesForWorker, int maxLeasesToStealAtOneTime, int maxLeaseRenewalThreads, boolean cleanupLeasesUponShardCompletion, boolean ignoreUnexpectedChildShards, long shardSyncIntervalMillis, boolean consistentReads, long listShardsBackoffTimeMillis, int maxListShardsRetryAttempts, int maxCacheMissesBeforeReload, long listShardsCacheAllowedAgeInSeconds, int cacheMissWarningModulus, long initialLeaseTableReadCapacity, long initialLeaseTableWriteCapacity, HierarchicalShardSyncer deprecatedHierarchicalShardSyncer, TableCreatorCallback tableCreatorCallback, Duration dynamoDbRequestTimeout, software.amazon.awssdk.services.dynamodb.model.BillingMode billingMode, LeaseSerializer leaseSerializer, Function<StreamConfig,ShardDetector> customShardDetectorProvider, boolean isMultiStreamMode, LeaseCleanupConfig leaseCleanupConfig)
kinesisClient
- dynamoDBClient
- tableName
- workerIdentifier
- executorService
- failoverTimeMillis
- epsilonMillis
- maxLeasesForWorker
- maxLeasesToStealAtOneTime
- maxLeaseRenewalThreads
- cleanupLeasesUponShardCompletion
- ignoreUnexpectedChildShards
- shardSyncIntervalMillis
- consistentReads
- listShardsBackoffTimeMillis
- maxListShardsRetryAttempts
- maxCacheMissesBeforeReload
- listShardsCacheAllowedAgeInSeconds
- cacheMissWarningModulus
- initialLeaseTableReadCapacity
- initialLeaseTableWriteCapacity
- deprecatedHierarchicalShardSyncer
- tableCreatorCallback
- dynamoDbRequestTimeout
- billingMode
- leaseSerializer
- customShardDetectorProvider
- isMultiStreamMode
- leaseCleanupConfig
- public LeaseCoordinator createLeaseCoordinator(@NonNull MetricsFactory metricsFactory)
createLeaseCoordinator
in interface LeaseManagementFactory
@Deprecated public ShardSyncTaskManager createShardSyncTaskManager(@NonNull MetricsFactory metricsFactory)
createShardSyncTaskManager
in interface LeaseManagementFactory
public ShardSyncTaskManager createShardSyncTaskManager(MetricsFactory metricsFactory, StreamConfig streamConfig)
createShardSyncTaskManager
in interface LeaseManagementFactory
metricsFactory
- streamConfig
- public DynamoDBLeaseRefresher createLeaseRefresher()
createLeaseRefresher
in interface LeaseManagementFactory
@Deprecated public ShardDetector createShardDetector()
createShardDetector
in interface LeaseManagementFactory
public ShardDetector createShardDetector(StreamConfig streamConfig)
createShardDetector
in interface LeaseManagementFactory
streamConfig
- public LeaseCleanupManager createLeaseCleanupManager(MetricsFactory metricsFactory)
createLeaseCleanupManager
in interface LeaseManagementFactory
metricsFactory
- Copyright © 2020. All rights reserved.