Modifier and Type | Method and Description |
---|---|
boolean |
DynamoDBCheckpointer.setCheckpoint(String leaseKey,
ExtendedSequenceNumber checkpoint,
UUID concurrencyToken) |
Modifier and Type | Method and Description |
---|---|
boolean |
HierarchicalShardSyncer.checkAndCreateLeaseForNewShards(ShardDetector shardDetector,
LeaseRefresher leaseRefresher,
InitialPositionInStreamExtended initialPosition,
List<software.amazon.awssdk.services.kinesis.model.Shard> latestShards,
boolean ignoreUnexpectedChildShards,
MetricsScope scope,
boolean isLeaseTableEmpty) |
boolean |
HierarchicalShardSyncer.checkAndCreateLeaseForNewShards(ShardDetector shardDetector,
LeaseRefresher leaseRefresher,
InitialPositionInStreamExtended initialPosition,
MetricsScope scope,
boolean ignoreUnexpectedChildShards,
boolean isLeaseTableEmpty)
Check and create leases for any new shards (e.g.
|
LeaseCleanupManager.LeaseCleanupResult |
LeaseCleanupManager.cleanupLease(LeasePendingDeletion leasePendingDeletion,
boolean timeToCheckForCompletedShard,
boolean timeToCheckForGarbageShard) |
boolean |
LeaseRefresher.createLeaseIfNotExists(Lease lease)
Create a new lease.
|
boolean |
LeaseRefresher.createLeaseTableIfNotExists(Long readCapacity,
Long writeCapacity)
Creates the table that will store leases.
|
void |
LeaseRefresher.deleteAll()
Delete all leases from DynamoDB.
|
void |
LeaseRefresher.deleteLease(Lease lease)
Delete the given lease from DynamoDB.
|
boolean |
LeaseRefresher.evictLease(Lease lease)
Evict the current owner of lease by setting owner to null.
|
ExtendedSequenceNumber |
LeaseRefresher.getCheckpoint(String leaseKey)
Gets the current checkpoint of the shard.
|
Lease |
LeaseRefresher.getLease(String leaseKey) |
void |
LeaseRenewer.initialize()
Bootstrap initial set of leases from the
LeaseRefresher (e.g. |
void |
LeaseCoordinator.initialize()
Initialize the lease coordinator (create the lease table if needed).
|
boolean |
LeaseRefresher.isLeaseTableEmpty()
Check (synchronously) if there are any leases in the lease table.
|
List<Lease> |
LeaseRefresher.listLeases()
List all objects in table synchronously.
|
List<Lease> |
LeaseRefresher.listLeasesForStream(StreamIdentifier streamIdentifier)
List all leases for a given stream synchronously.
|
boolean |
LeaseRefresher.renewLease(Lease lease)
Renew a lease by incrementing the lease counter.
|
void |
LeaseCoordinator.start()
Start background LeaseHolder and LeaseTaker threads.
|
boolean |
LeaseRefresher.takeLease(Lease lease,
String owner)
Take a lease for the given owner by incrementing its leaseCounter and setting its owner field.
|
boolean |
LeaseRefresher.updateLease(Lease lease)
Update application-specific fields of the given lease in DynamoDB.
|
boolean |
LeaseRenewer.updateLease(Lease lease,
UUID concurrencyToken,
String operation,
String singleStreamShardId)
Update application-specific fields in a currently held lease.
|
boolean |
LeaseCoordinator.updateLease(Lease lease,
UUID concurrencyToken,
String operation,
String singleStreamShardId)
Updates application-specific lease values in DynamoDB.
|
default void |
LeaseRefresher.updateLeaseWithMetaInfo(Lease lease,
UpdateField updateField)
Update application-specific fields of the given lease in DynamoDB.
|
Modifier and Type | Method and Description |
---|---|
protected DependencyException |
DynamoDBLeaseRefresher.convertAndRethrowExceptions(String operation,
String leaseKey,
Exception e) |
boolean |
DynamoDBLeaseRefresher.createLeaseIfNotExists(Lease lease)
Create a new lease.
|
boolean |
DynamoDBLeaseRefresher.createLeaseTableIfNotExists(Long readCapacity,
Long writeCapacity)
Creates the table that will store leases.
|
void |
DynamoDBLeaseRefresher.deleteAll()
Delete all leases from DynamoDB.
|
void |
DynamoDBLeaseRefresher.deleteLease(Lease lease)
Delete the given lease from DynamoDB.
|
boolean |
DynamoDBLeaseRefresher.evictLease(Lease lease)
Evict the current owner of lease by setting owner to null.
|
ExtendedSequenceNumber |
DynamoDBLeaseRefresher.getCheckpoint(String leaseKey)
Gets the current checkpoint of the shard.
|
Lease |
DynamoDBLeaseRefresher.getLease(String leaseKey) |
void |
DynamoDBLeaseCoordinator.initialize() |
void |
DynamoDBLeaseRenewer.initialize()
Bootstrap initial set of leases from the
LeaseRefresher (e.g. |
boolean |
DynamoDBLeaseRefresher.isLeaseTableEmpty()
Check (synchronously) if there are any leases in the lease table.
|
List<Lease> |
DynamoDBLeaseRefresher.listLeases()
List all objects in table synchronously.
|
List<Lease> |
DynamoDBLeaseRefresher.listLeasesForStream(StreamIdentifier streamIdentifier)
List all leases for a given stream synchronously.
|
boolean |
DynamoDBLeaseRefresher.renewLease(Lease lease)
Renew a lease by incrementing the lease counter.
|
void |
DynamoDBLeaseCoordinator.start() |
boolean |
DynamoDBLeaseRefresher.takeLease(Lease lease,
String owner)
Take a lease for the given owner by incrementing its leaseCounter and setting its owner field.
|
boolean |
DynamoDBLeaseRefresher.updateLease(Lease lease)
Update application-specific fields of the given lease in DynamoDB.
|
boolean |
DynamoDBLeaseCoordinator.updateLease(Lease lease,
UUID concurrencyToken,
String operation,
String singleStreamShardId) |
boolean |
DynamoDBLeaseRenewer.updateLease(Lease lease,
UUID concurrencyToken,
String operation,
String singleStreamShardId)
Update application-specific fields in a currently held lease.
|
void |
DynamoDBLeaseRefresher.updateLeaseWithMetaInfo(Lease lease,
UpdateField updateField) |
Modifier and Type | Method and Description |
---|---|
static void |
ShardSyncer.checkAndCreateLeasesForNewShards(ShardDetector shardDetector,
LeaseRefresher leaseRefresher,
InitialPositionInStreamExtended initialPosition,
boolean ignoreUnexpectedChildShards,
MetricsScope scope)
Deprecated.
|
Copyright © 2020. All rights reserved.