- accept(DiagnosticEventHandler) - Method in class software.amazon.kinesis.coordinator.ExecutorStateEvent
-
- accept(MigrationState) - Method in interface software.amazon.kinesis.coordinator.migration.ClientVersionChangeMonitor.ClientVersionChangeCallback
-
- accept() - Method in interface software.amazon.kinesis.retrieval.DataFetcherResult
-
Accepts the result, and advances the shard iterator.
- AccumulateByNameMetricsScope - Class in software.amazon.kinesis.metrics
-
This is a MetricScope with a KeyType of String.
- AccumulateByNameMetricsScope() - Constructor for class software.amazon.kinesis.metrics.AccumulateByNameMetricsScope
-
- AccumulatingMetricsScope<KeyType> - Class in software.amazon.kinesis.metrics
-
An IMetricsScope that accumulates data from multiple calls to addData with
the same name parameter.
- AccumulatingMetricsScope() - Constructor for class software.amazon.kinesis.metrics.AccumulatingMetricsScope
-
- actualOwner() - Method in class software.amazon.kinesis.leases.Lease
-
Need to handle the case during graceful shutdown where leaseOwner isn't the current owner
- add(StreamIdentifier) - Method in class software.amazon.kinesis.coordinator.DeletedStreamListProvider
-
- add(Class<T>, Function<T, RuntimeException>) - Method in class software.amazon.kinesis.retrieval.AWSExceptionManager
-
- add(double) - Method in class software.amazon.kinesis.utils.ExponentialMovingAverage
-
- addAllExplicitHashKeyTable(Iterable<String>) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- addAllPartitionKeyTable(Iterable<String>) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- addAllRecords(Iterable<? extends Messages.Record>) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addAllTags(Iterable<? extends Messages.Tag>) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addCount(MetricsScope, String, long, MetricsLevel) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addData(String, double, StandardUnit) - Method in class software.amazon.kinesis.metrics.AccumulatingMetricsScope
-
- addData(String, double, StandardUnit, MetricsLevel) - Method in class software.amazon.kinesis.metrics.AccumulatingMetricsScope
-
- addData(KeyType, String, double, StandardUnit) - Method in class software.amazon.kinesis.metrics.AccumulatingMetricsScope
-
Adds data points to an IMetricsScope.
- addData(String, double, StandardUnit) - Method in class software.amazon.kinesis.metrics.EndingMetricsScope
-
- addData(String, double, StandardUnit, MetricsLevel) - Method in class software.amazon.kinesis.metrics.EndingMetricsScope
-
- addData(String, double, StandardUnit) - Method in class software.amazon.kinesis.metrics.FilteringMetricsScope
-
Adds the data to the metrics scope at lowest metrics level.
- addData(String, double, StandardUnit, MetricsLevel) - Method in class software.amazon.kinesis.metrics.FilteringMetricsScope
-
Adds the data to the metrics scope if the given level is equal to above the enabled metrics
level.
- addData(String, double, StandardUnit) - Method in interface software.amazon.kinesis.metrics.MetricsScope
-
Adds a data point to this IMetricsScope.
- addData(String, double, StandardUnit, MetricsLevel) - Method in interface software.amazon.kinesis.metrics.MetricsScope
-
Adds a data point to this IMetricsScope if given metrics level is enabled.
- addData(String, double, StandardUnit) - Method in class software.amazon.kinesis.metrics.NullMetricsScope
-
- addData(String, double, StandardUnit, MetricsLevel) - Method in class software.amazon.kinesis.metrics.NullMetricsScope
-
- addData(String, double, StandardUnit) - Method in class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingScope
-
Adds a data point to this IMetricsScope.
- addData(String, double, StandardUnit, MetricsLevel) - Method in class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingScope
-
Adds a data point to this IMetricsScope if given metrics level is enabled.
- addDimension(String, String) - Method in class software.amazon.kinesis.metrics.DimensionTrackingMetricsScope
-
- addDimension(String, String) - Method in class software.amazon.kinesis.metrics.EndingMetricsScope
-
- addDimension(String, String) - Method in class software.amazon.kinesis.metrics.FilteringMetricsScope
-
Adds given dimension with value if allowed dimensions list contains this dimension's name.
- addDimension(String, String) - Method in interface software.amazon.kinesis.metrics.MetricsScope
-
Adds a dimension that applies to all metrics in this IMetricsScope.
- addDimension(String, String) - Method in class software.amazon.kinesis.metrics.NullMetricsScope
-
- addDimension(String, String) - Method in class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingScope
-
Adds a dimension that applies to all metrics in this IMetricsScope.
- addExplicitHashKeyTable(String) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- addExplicitHashKeyTableBytes(ByteString) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- addHistoryEntry(ClientVersion, String, long) - Method in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- addLatency(MetricsScope, String, long, MetricsLevel) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addLeasesToRenew(Collection<Lease>) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
-
Adds leases to this LeaseRenewer's set of currently held leases.
- addLeasesToRenew(Collection<Lease>) - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
Adds leases to this LeaseRenewer's set of currently held leases.
- addOperation(MetricsScope, String, String) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addPartitionKeyTable(String) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- addPartitionKeyTableBytes(ByteString) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- addRecords(Messages.Record) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addRecords(int, Messages.Record) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addRecords(Messages.Record.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addRecords(int, Messages.Record.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addRecordsBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addRecordsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- addShardId(MetricsScope, String) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addStreamId(MetricsScope, StreamIdentifier) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addSuccess(MetricsScope, String, boolean, MetricsLevel) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addSuccessAndLatency(MetricsScope, boolean, long, MetricsLevel) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addSuccessAndLatency(MetricsScope, String, boolean, long, MetricsLevel) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- addTags(Messages.Tag) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addTags(int, Messages.Tag) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addTags(Messages.Tag.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addTags(int, Messages.Tag.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addTagsBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addTagsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- addWorkerIdentifier(MetricsScope, String) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- adjustKinesisClientBuilder(KinesisAsyncClientBuilder) - Static method in class software.amazon.kinesis.common.KinesisClientUtil
-
- advanceIteratorTo(String, InitialPositionInStreamExtended) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Advances this KinesisDataFetcher's internal iterator to be at the passed-in sequence number.
- advanceIteratorTo(String, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
Advances this KinesisDataFetcher's internal iterator to be at the passed-in sequence number.
- afterTaskExecution(TaskExecutionListenerInput) - Method in class software.amazon.kinesis.lifecycle.NoOpTaskExecutionListener
-
- afterTaskExecution(TaskExecutionListenerInput) - Method in interface software.amazon.kinesis.lifecycle.TaskExecutionListener
-
- AGGREGATED_RECORD_MAGIC - Static variable in class software.amazon.kinesis.retrieval.AggregatorUtil
-
- AggregatorUtil - Class in software.amazon.kinesis.retrieval
-
- AggregatorUtil() - Constructor for class software.amazon.kinesis.retrieval.AggregatorUtil
-
- allLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- allLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
-
Default implementation returns an empty list and concrete implementaion is expected to return all leases
for the application that are in the lease table either by reading lease table or from an internal cache.
- allLeases() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Default implementation returns an empty list and concrete implementation is expected to return all leases
for the application that are in the lease table.
- allLeases() - Method in interface software.amazon.kinesis.leases.LeaseTaker
-
Default implementation returns an empty list and concrete implementaion is expected to return all leases
for the application that are in the lease table either by reading lease table or from an internal cache.
- apply(Throwable) - Method in class software.amazon.kinesis.retrieval.AWSExceptionManager
-
- appStreamTracker(Either<MultiStreamTracker, String>) - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
- ArnUtil - Class in software.amazon.kinesis.common
-
- ArnUtil() - Constructor for class software.amazon.kinesis.common.ArnUtil
-
- assignExpiredOrUnassignedLeases(List<Lease>) - Method in interface software.amazon.kinesis.coordinator.assignment.LeaseAssignmentDecider
-
Assigns expiredOrUnAssignedLeases to the available workers.
- assignExpiredOrUnassignedLeases(List<Lease>) - Method in class software.amazon.kinesis.coordinator.assignment.VarianceBasedLeaseAssignmentDecider
-
- assignLease(Lease, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Assigns given lease to newOwner owner by incrementing its leaseCounter and setting its owner field.
- assignLease(Lease, String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Assigns given lease to newOwner owner by incrementing its leaseCounter and setting its owner field.
- AsynchronousGetRecordsRetrievalStrategy - Class in software.amazon.kinesis.retrieval.polling
-
- AsynchronousGetRecordsRetrievalStrategy(KinesisDataFetcher, int, int, String) - Constructor for class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
-
- AsynchronousGetRecordsRetrievalStrategy(KinesisDataFetcher, ExecutorService, int, String) - Constructor for class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
-
- AT_TIMESTAMP - Static variable in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
Special value for AT_TIMESTAMP.
- AutoDetectionAndDeferredDeletionStrategy() - Constructor for class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.AutoDetectionAndDeferredDeletionStrategy
-
- AWSExceptionManager - Class in software.amazon.kinesis.retrieval
-
Traverses a Throwable
class inheritance in search of a mapping
function which will convert that throwable into a RuntimeException
.
- AWSExceptionManager() - Constructor for class software.amazon.kinesis.retrieval.AWSExceptionManager
-
- calculateSimpleMean(List<Double>) - Static method in class software.amazon.kinesis.utils.Statistics
-
Calculates the simple mean of the given values
- calculateStandardDeviationAndMean(List<Double>) - Static method in class software.amazon.kinesis.utils.Statistics
-
For the given values find the standard deviation (SD).
- calculateTailCheck(byte[]) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
-
- call() - Method in class software.amazon.kinesis.leases.ShardSyncTask
-
- call() - Method in class software.amazon.kinesis.lifecycle.BlockOnParentShardTask
-
- call() - Method in interface software.amazon.kinesis.lifecycle.ConsumerTask
-
Perform task logic.
- call() - Method in class software.amazon.kinesis.lifecycle.InitializeTask
-
- call() - Method in class software.amazon.kinesis.lifecycle.ProcessTask
-
- call() - Method in class software.amazon.kinesis.lifecycle.ShutdownNotificationTask
-
- call() - Method in class software.amazon.kinesis.lifecycle.ShutdownTask
-
- call() - Method in class software.amazon.kinesis.metrics.MetricsCollectingTaskDecorator
-
Perform task logic.
- callShardSyncTask() - Method in class software.amazon.kinesis.leases.ShardSyncTaskManager
-
Call a ShardSyncTask and return the Task Result.
- cancel() - Method in class software.amazon.kinesis.coordinator.migration.ClientVersionChangeMonitor
-
Cancel the monitor explicity before the condition is met, e.g.
- cancel() - Method in class software.amazon.kinesis.coordinator.migration.MigrationReadyMonitor
-
Cancel the monitor.
- canTransitionTo(ShutdownReason) - Method in enum software.amazon.kinesis.lifecycle.ShutdownReason
-
Indicates whether the given reason can override the current reason.
- capture() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv1CpuWorkerMetric
-
- capture() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv2CpuWorkerMetric
-
- capture() - Method in class software.amazon.kinesis.worker.metric.impl.container.EcsCpuWorkerMetric
-
- capture() - Method in class software.amazon.kinesis.worker.metric.impl.jmx.HeapMemoryAfterGCWorkerMetric
-
- capture() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxCpuWorkerMetric
-
- capture() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
Reads the stat file and find the total bytes (in and out) and divide it by the time elapsed since last read to
get the bytes per second.
- capture() - Method in interface software.amazon.kinesis.worker.metric.WorkerMetric
-
Current WorkerMetricValue.
- Cgroup - Class in software.amazon.kinesis.utils
-
- Cgroup() - Constructor for class software.amazon.kinesis.utils.Cgroup
-
- Cgroupv1CpuWorkerMetric - Class in software.amazon.kinesis.worker.metric.impl.container
-
Utilizes Linux Control Groups by reading cpu time and available cpu from cgroup directory.This works for Elastic
Kubernetes Service (EKS) containers running on Linux instances which use cgroupv1.
- Cgroupv1CpuWorkerMetric(OperatingRange) - Constructor for class software.amazon.kinesis.worker.metric.impl.container.Cgroupv1CpuWorkerMetric
-
- Cgroupv2CpuWorkerMetric - Class in software.amazon.kinesis.worker.metric.impl.container
-
Utilizes Linux Control Groups by reading cpu time and available cpu from cgroup directory.
- Cgroupv2CpuWorkerMetric(OperatingRange) - Constructor for class software.amazon.kinesis.worker.metric.impl.container.Cgroupv2CpuWorkerMetric
-
- checkAndCreateLeaseForNewShards(ShardDetector, LeaseRefresher, InitialPositionInStreamExtended, MetricsScope, boolean, boolean) - Method in class software.amazon.kinesis.leases.HierarchicalShardSyncer
-
Check and create leases for any new shards (e.g.
- checkAndCreateLeaseForNewShards(ShardDetector, LeaseRefresher, InitialPositionInStreamExtended, List<Shard>, boolean, MetricsScope, boolean) - Method in class software.amazon.kinesis.leases.HierarchicalShardSyncer
-
Provide a pre-collected list of shards to avoid calling ListShards API
- checkAndCreateLeasesForNewShards(ShardDetector, LeaseRefresher, InitialPositionInStreamExtended, boolean, MetricsScope) - Static method in class software.amazon.kinesis.leases.exceptions.ShardSyncer
-
Deprecated.
- Checkpoint - Class in software.amazon.kinesis.checkpoint
-
A class encapsulating the 2 pieces of state stored in a checkpoint.
- Checkpoint(ExtendedSequenceNumber, ExtendedSequenceNumber) - Constructor for class software.amazon.kinesis.checkpoint.Checkpoint
-
Deprecated.
- Checkpoint(ExtendedSequenceNumber, ExtendedSequenceNumber, byte[]) - Constructor for class software.amazon.kinesis.checkpoint.Checkpoint
-
Constructor.
- checkpoint() - Method in class software.amazon.kinesis.checkpoint.DoesNothingPreparedCheckpointer
-
This method will record a pending checkpoint.
- checkpoint() - Method in class software.amazon.kinesis.checkpoint.ShardPreparedCheckpointer
-
This method will record a pending checkpoint.
- checkpoint() - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will checkpoint the progress at the last data record that was delivered to the record processor.
- checkpoint(Record) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will checkpoint the progress at the provided record.
- checkpoint(String) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will checkpoint the progress at the provided sequenceNumber.
- checkpoint(String, long) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will checkpoint the progress at the provided sequenceNumber and subSequenceNumber, the latter for
aggregated records produced with the Producer Library.
- checkpoint(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.leases.Lease
-
Sets checkpoint.
- checkpoint() - Method in interface software.amazon.kinesis.processor.PreparedCheckpointer
-
This method will record a pending checkpoint.
- checkpoint() - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will checkpoint the progress at the last data record that was delivered to the record processor.
- checkpoint(Record) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will checkpoint the progress at the provided record.
- checkpoint(String) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will checkpoint the progress at the provided sequenceNumber.
- checkpoint(String, long) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will checkpoint the progress at the provided sequenceNumber and subSequenceNumber, the latter for
aggregated records produced with the Producer Library.
- CheckpointConfig - Class in software.amazon.kinesis.checkpoint
-
Used by the KCL to manage checkpointing.
- CheckpointConfig() - Constructor for class software.amazon.kinesis.checkpoint.CheckpointConfig
-
- checkpointConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of CheckpointConfig
- Checkpointer - Interface in software.amazon.kinesis.processor
-
Interface for checkpoint trackers.
- checkpointer() - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
- CheckpointFactory - Interface in software.amazon.kinesis.checkpoint
-
- childShardIds(Collection<String>) - Method in class software.amazon.kinesis.leases.Lease
-
Sets childShardIds.
- cleanupLease(LeasePendingDeletion, boolean, boolean) - Method in class software.amazon.kinesis.leases.LeaseCleanupManager
-
- clear() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- clear() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- clear() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- clearCurrentlyHeldLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
-
Clears this LeaseRenewer's set of currently held leases.
- clearCurrentlyHeldLeases() - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
Clears this LeaseRenewer's set of currently held leases.
- clearData() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
required bytes data = 3;
- clearExplicitHashKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
optional uint64 explicit_hash_key_index = 2;
- clearExplicitHashKeyTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- clearKey() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
required string key = 1;
- clearPartitionKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
required uint64 partition_key_index = 1;
- clearPartitionKeyTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- clearRecords() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- clearTags() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- clearValue() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
optional string value = 2;
- CLIENT_VERSION_ATTRIBUTE_NAME - Static variable in class software.amazon.kinesis.coordinator.migration.MigrationState
-
Attribute name in migration state item, whose value is used during
the KCL v3.x migration process to know whether the workers need to
perform KCL v2.x compatible operations or can perform native KCL v3.x
operations.
- ClientVersion - Enum in software.amazon.kinesis.coordinator.migration
-
ClientVersion support during upgrade from KCLv2.x to KCLv3.x
This enum is persisted in storage, so any changes to it needs to be backward compatible.
- clientVersion() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersion2xState
-
- clientVersion() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersion3xState
-
- clientVersion() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersion3xWithRollbackState
-
- clientVersion() - Method in interface software.amazon.kinesis.coordinator.migration.MigrationClientVersionState
-
The associated clientVersion this state corresponds to
- clientVersion() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersionUpgradeFrom2xState
-
- ClientVersionChangeMonitor - Class in software.amazon.kinesis.coordinator.migration
-
Change monitor for MigrationState.clientVersion to notify a callback if the value
changes from a given value.
- ClientVersionChangeMonitor() - Constructor for class software.amazon.kinesis.coordinator.migration.ClientVersionChangeMonitor
-
- ClientVersionChangeMonitor.ClientVersionChangeCallback - Interface in software.amazon.kinesis.coordinator.migration
-
Interface of a callback to invoke when monitor condition is true.
- close() - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- CloudWatchMetricKey - Class in software.amazon.kinesis.metrics
-
A representation of a key of a MetricDatum.
- CloudWatchMetricKey(MetricDatum) - Constructor for class software.amazon.kinesis.metrics.CloudWatchMetricKey
-
- CloudWatchMetricsFactory - Class in software.amazon.kinesis.metrics
-
An IMetricsFactory that creates IMetricsScopes that output themselves via CloudWatch.
- CloudWatchMetricsFactory(CloudWatchAsyncClient, String, long, int, MetricsLevel, Set<String>, int) - Constructor for class software.amazon.kinesis.metrics.CloudWatchMetricsFactory
-
Constructor.
- CloudWatchMetricsPublisher - Class in software.amazon.kinesis.metrics
-
Publisher that contains the logic to publish metrics.
- CloudWatchMetricsPublisher(CloudWatchAsyncClient, String) - Constructor for class software.amazon.kinesis.metrics.CloudWatchMetricsPublisher
-
- CloudWatchMetricsScope - Class in software.amazon.kinesis.metrics
-
Metrics scope for CloudWatch metrics.
- CloudWatchMetricsScope(CloudWatchPublisherRunnable, MetricsLevel, Set<String>) - Constructor for class software.amazon.kinesis.metrics.CloudWatchMetricsScope
-
Creates a CloudWatch metrics scope with given metrics level and enabled dimensions.
- CloudWatchPublisherRunnable - Class in software.amazon.kinesis.metrics
-
A CloudWatchPublisherRunnable contains the logic of when to publish metrics.
- CloudWatchPublisherRunnable(CloudWatchMetricsPublisher, long, int, int) - Constructor for class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
Constructor.
- CloudWatchPublisherRunnable(CloudWatchMetricsPublisher, long, int, int, int) - Constructor for class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
- CommonCalculations - Class in software.amazon.kinesis.common
-
- CommonCalculations() - Constructor for class software.amazon.kinesis.common.CommonCalculations
-
- compareTo(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
Compares this with another ExtendedSequenceNumber using these rules.
- computeMetrics() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsManager
-
- computePercentageToReachAverage(Map<String, Double>) - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
Determines percentage of load to reach the mean for the worker.
- concurrencyToken(UUID) - Method in class software.amazon.kinesis.leases.Lease
-
Sets concurrencyToken.
- ConfigsBuilder - Class in software.amazon.kinesis.common
-
This Builder is useful to create all configurations for the KCL with default values.
- ConfigsBuilder(String, String, KinesisAsyncClient, DynamoDbAsyncClient, CloudWatchAsyncClient, String, ShardRecordProcessorFactory) - Constructor for class software.amazon.kinesis.common.ConfigsBuilder
-
Constructor to initialize ConfigsBuilder for a single stream identified by name.
- ConfigsBuilder(Arn, String, KinesisAsyncClient, DynamoDbAsyncClient, CloudWatchAsyncClient, String, ShardRecordProcessorFactory) - Constructor for class software.amazon.kinesis.common.ConfigsBuilder
-
Constructor to initialize ConfigsBuilder for a single stream identified by Arn
.
- ConfigsBuilder(StreamTracker, String, KinesisAsyncClient, DynamoDbAsyncClient, CloudWatchAsyncClient, String, ShardRecordProcessorFactory) - Constructor for class software.amazon.kinesis.common.ConfigsBuilder
-
Constructor to initialize ConfigsBuilder
- consistentReads - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- constructStreamArn(Region, String, String) - Static method in class software.amazon.kinesis.common.ArnUtil
-
Construct a Kinesis stream ARN.
- ConsumerRegistration - Interface in software.amazon.kinesis.retrieval
-
- ConsumerTask - Interface in software.amazon.kinesis.lifecycle
-
Interface for shard processing tasks.
- ConsumerTaskFactory - Interface in software.amazon.kinesis.lifecycle
-
- containsMetricStat(String) - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
Returns true if given is available for the current worker else false
- convert(StreamTracker, Function<SingleStreamTracker, R>) - Static method in class software.amazon.kinesis.common.DeprecationUtils
-
Deprecated.
- convertAndRethrowExceptions(String, String, Exception) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- convertLeaseToAssignment(Lease) - Static method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
Utility method to convert the basic lease or multistream lease to ShardInfo
- convertRecordToKinesisClientRecord(KinesisClientRecord, boolean, long, String) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
-
- COORDINATOR_STATE_TABLE_HASH_KEY_ATTRIBUTE_NAME - Static variable in class software.amazon.kinesis.coordinator.CoordinatorState
-
- coordinatorConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of CoordinatorConfig
- CoordinatorConfig - Class in software.amazon.kinesis.coordinator
-
Used by the KCL to configure the coordinator.
- CoordinatorConfig(String) - Constructor for class software.amazon.kinesis.coordinator.CoordinatorConfig
-
- CoordinatorConfig.ClientVersionConfig - Enum in software.amazon.kinesis.coordinator
-
Version the KCL needs to operate in.
- CoordinatorConfig.CoordinatorStateTableConfig - Class in software.amazon.kinesis.coordinator
-
- CoordinatorFactory - Interface in software.amazon.kinesis.coordinator
-
Used in the process of configuring and providing instances to the
Scheduler
- CoordinatorState - Class in software.amazon.kinesis.coordinator
-
DataModel for CoordinatorState, this data model is used to store various state information required
for coordination across the KCL worker fleet.
- CoordinatorState() - Constructor for class software.amazon.kinesis.coordinator.CoordinatorState
-
- CoordinatorStateDAO - Class in software.amazon.kinesis.coordinator
-
Data Access Object to abstract accessing
CoordinatorState
from
the CoordinatorState DDB table.
- CoordinatorStateDAO(DynamoDbAsyncClient, CoordinatorConfig.CoordinatorStateTableConfig) - Constructor for class software.amazon.kinesis.coordinator.CoordinatorStateDAO
-
- copy() - Method in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- copy() - Method in class software.amazon.kinesis.leases.Lease
-
Returns a deep copy of this object.
- copy() - Method in class software.amazon.kinesis.leases.MultiStreamLease
-
Returns a deep copy of this object.
- create(CoordinatorStateDAO, String, MetricsFactory) - Static method in class software.amazon.kinesis.leader.DynamoDBLockBasedLeaderDecider
-
- create(long, ConcurrentMap<ShardInfo, ShardConsumer>, LeaseCoordinator) - Static method in class software.amazon.kinesis.lifecycle.LeaseGracefulShutdownHandler
-
Factory method to create a new instance of LeaseGracefulShutdownHandler.
- create() - Static method in class software.amazon.kinesis.worker.platform.Ec2Resource
-
Factory method to create an instance of Ec2Resource.
- create() - Static method in class software.amazon.kinesis.worker.platform.EcsResource
-
Factory method to create an instance of EcsResource.
- create() - Static method in class software.amazon.kinesis.worker.platform.EksResource
-
Factory method to create an instance of EksResource.
- create() - Static method in class software.amazon.kinesis.worker.WorkerMetricsSelector
-
Factory method to create an instance of WorkerMetricsSelector.
- createAttributeValue(Collection<String>) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- createAttributeValue(byte[]) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- createAttributeValue(String) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- createAttributeValue(Long) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- createAttributeValue(Double) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- createBlockOnParentTask(ShardConsumerArgument) - Method in interface software.amazon.kinesis.lifecycle.ConsumerTaskFactory
-
Creates a block on parent task.
- createBlockOnParentTask(ShardConsumerArgument) - Method in class software.amazon.kinesis.lifecycle.KinesisConsumerTaskFactory
-
- createCheckpointer(LeaseCoordinator, LeaseRefresher) - Method in interface software.amazon.kinesis.checkpoint.CheckpointFactory
-
- createCheckpointer(LeaseCoordinator, LeaseRefresher) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointFactory
-
- createConsumerRegistration(KinesisAsyncClient, String, String) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutConfig
-
- createCoordinatorStateIfNotExists(CoordinatorState) - Method in class software.amazon.kinesis.coordinator.CoordinatorStateDAO
-
- createExecutorService() - Method in interface software.amazon.kinesis.coordinator.CoordinatorFactory
-
Creates the executor service to be used by the Scheduler.
- createExecutorService() - Method in class software.amazon.kinesis.coordinator.SchedulerCoordinatorFactory
-
Creates the executor service to be used by the Scheduler.
- createGetRecordsCache(ShardInfo, StreamConfig, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRetrievalFactory
-
- createGetRecordsCache(ShardInfo, StreamConfig, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.polling.SynchronousBlockingRetrievalFactory
-
- createGetRecordsCache(ShardInfo, MetricsFactory) - Method in interface software.amazon.kinesis.retrieval.RetrievalFactory
-
- createGetRecordsCache(ShardInfo, StreamConfig, MetricsFactory) - Method in interface software.amazon.kinesis.retrieval.RetrievalFactory
-
Creates a
RecordsPublisher
instance to retrieve records for the specified shard.
- createGetRecordsRetrievalStrategy(ShardInfo, MetricsFactory) - Method in interface software.amazon.kinesis.retrieval.RetrievalFactory
-
- createGracefulShutdownCallable() - Method in class software.amazon.kinesis.coordinator.Scheduler
-
Creates a callable that will execute the graceful shutdown process.
- createGracefulShutdownCoordinator() - Method in interface software.amazon.kinesis.coordinator.CoordinatorFactory
-
Deprecated.
- createInitializeTask(ShardConsumerArgument) - Method in interface software.amazon.kinesis.lifecycle.ConsumerTaskFactory
-
Creates an initialize task.
- createInitializeTask(ShardConsumerArgument) - Method in class software.amazon.kinesis.lifecycle.KinesisConsumerTaskFactory
-
- createKinesisAsyncClient(KinesisAsyncClientBuilder) - Static method in class software.amazon.kinesis.common.KinesisClientUtil
-
Creates a client from a builder.
- createLeaseCleanupManager(MetricsFactory) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
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.
- createLeaseCleanupManager(MetricsFactory) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createLeaseCoordinator(MetricsFactory) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
- createLeaseCoordinator(MetricsFactory, ConcurrentMap<ShardInfo, ShardConsumer>) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
- createLeaseCoordinator(MetricsFactory) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createLeaseCoordinator(MetricsFactory, ConcurrentMap<ShardInfo, ShardConsumer>) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createLeaseForChildShard(ChildShard, StreamIdentifier) - Method in class software.amazon.kinesis.leases.HierarchicalShardSyncer
-
- createLeaseIfNotExists(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Create a new lease.
- createLeaseIfNotExists(Lease) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Create a new lease.
- createLeaseOwnerToLeaseKeyIndexIfNotExists() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- createLeaseOwnerToLeaseKeyIndexIfNotExists() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Creates the LeaseOwnerToLeaseKey index on the lease table if it doesn't exist and returns the status of index.
- createLeaseRefresher() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
- createLeaseRefresher() - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createLeaseTableIfNotExists(Long, Long) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Creates the table that will store leases.
- createLeaseTableIfNotExists() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Creates the table that will store leases.
- createLeaseTableIfNotExists(Long, Long) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Deprecated.
- createLeaseTableIfNotExists() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Creates the table that will store leases.
- createMetrics() - Method in class software.amazon.kinesis.metrics.CloudWatchMetricsFactory
-
- createMetrics() - Method in class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- createMetrics() - Method in class software.amazon.kinesis.metrics.LogMetricsFactory
-
- createMetrics() - Method in interface software.amazon.kinesis.metrics.MetricsFactory
-
- createMetrics(MetricsFactory) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- createMetrics() - Method in class software.amazon.kinesis.metrics.NullMetricsFactory
-
- createMetrics() - Method in class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingFactory
- createMetricsWithOperation(MetricsFactory, String) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
-
- createProcessTask(ShardConsumerArgument, ProcessRecordsInput) - Method in interface software.amazon.kinesis.lifecycle.ConsumerTaskFactory
-
Creates a process task.
- createProcessTask(ShardConsumerArgument, ProcessRecordsInput) - Method in class software.amazon.kinesis.lifecycle.KinesisConsumerTaskFactory
-
- createRecordProcessorCheckpointer(ShardInfo, Checkpointer) - Method in interface software.amazon.kinesis.coordinator.CoordinatorFactory
-
Creates a RecordProcessorChedckpointer to be used by the Scheduler.
- createRecordProcessorCheckpointer(ShardInfo, Checkpointer) - Method in class software.amazon.kinesis.coordinator.SchedulerCoordinatorFactory
-
Creates a RecordProcessorChedckpointer to be used by the Scheduler.
- createRecordsFetcher(GetRecordsRetrievalStrategy, String, MetricsFactory, int) - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- createRecordsFetcher(GetRecordsRetrievalStrategy, String, MetricsFactory, int) - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
Returns a RecordsPublisher to be used for retrieving records for a given shard.
- createShardDetector(StreamConfig) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
KinesisShardDetector supports reading from service only using streamName.
- createShardDetector() - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createShardDetector(StreamConfig) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createShardSyncTaskManager(MetricsFactory, StreamConfig, DeletedStreamListProvider) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
Create ShardSyncTaskManager from the streamConfig passed
- createShardSyncTaskManager(MetricsFactory) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createShardSyncTaskManager(MetricsFactory, StreamConfig) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createShardSyncTaskManager(MetricsFactory, StreamConfig, DeletedStreamListProvider) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
-
- createShutdownNotificationTask(ShardConsumerArgument, ShardConsumer) - Method in interface software.amazon.kinesis.lifecycle.ConsumerTaskFactory
-
Creates a shutdown notification task.
- createShutdownNotificationTask(ShardConsumerArgument, ShardConsumer) - Method in class software.amazon.kinesis.lifecycle.KinesisConsumerTaskFactory
-
- createShutdownTask(ShardConsumerArgument, ShardConsumer, ProcessRecordsInput) - Method in interface software.amazon.kinesis.lifecycle.ConsumerTaskFactory
-
Creates a shutdown task.
- createShutdownTask(ShardConsumerArgument, ShardConsumer, ProcessRecordsInput) - Method in class software.amazon.kinesis.lifecycle.KinesisConsumerTaskFactory
-
- createStreamConfig(StreamIdentifier) - Method in interface software.amazon.kinesis.processor.StreamTracker
-
Returns a new
StreamConfig
for the provided stream identifier.
- createTable(CreateTableRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- createWorkerStateChangeListener() - Method in interface software.amazon.kinesis.coordinator.CoordinatorFactory
-
Deprecated.
- CustomerApplicationException - Exception in software.amazon.kinesis.leases.exceptions
-
Exception type for all exceptions thrown by the customer implemented code.
- CustomerApplicationException(Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.CustomerApplicationException
-
- CustomerApplicationException(String, Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.CustomerApplicationException
-
- CustomerApplicationException(String) - Constructor for exception software.amazon.kinesis.leases.exceptions.CustomerApplicationException
-
- data - Variable in class software.amazon.kinesis.metrics.AccumulatingMetricsScope
-
- DATA_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- dataFetcher() - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetrievalStrategy
-
Returns a dataFetcher by first checking for an override if it exists, else using the default data fetcher.
- DataFetcher - Interface in software.amazon.kinesis.retrieval.polling
-
- dataFetcher() - Method in class software.amazon.kinesis.retrieval.polling.SynchronousGetRecordsRetrievalStrategy
-
- DataFetcherProviderConfig - Interface in software.amazon.kinesis.retrieval
-
- DataFetcherResult - Interface in software.amazon.kinesis.retrieval
-
Represents the result from the DataFetcher, and allows the receiver to accept a result
- DataFetchingStrategy - Enum in software.amazon.kinesis.retrieval
-
- dataFetchingStrategy(DataFetchingStrategy) - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- dataFetchingStrategy() - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- dataFetchingStrategy(DataFetchingStrategy) - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
Sets the dataFetchingStrategy to determine the type of RecordsPublisher to be used.
- dataFetchingStrategy() - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
- DataRetrievalUtil - Class in software.amazon.kinesis.retrieval
-
- DataRetrievalUtil() - Constructor for class software.amazon.kinesis.retrieval.DataRetrievalUtil
-
- datum - Variable in class software.amazon.kinesis.metrics.MetricDatumWithKey
-
Data point
- DdbTableConfig - Class in software.amazon.kinesis.common
-
Configurations of a DDB table created by KCL for its internal operations.
- DdbTableConfig(String, String) - Constructor for class software.amazon.kinesis.common.DdbTableConfig
-
- DdbUtil - Class in software.amazon.kinesis.utils
-
- DdbUtil() - Constructor for class software.amazon.kinesis.utils.DdbUtil
-
- deaggregate(List<KinesisClientRecord>) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
-
This method deaggregates the given list of Amazon Kinesis records into a
list of KPL user records.
- deaggregate(List<KinesisClientRecord>, String, String) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
-
Deaggregate any KPL records found.
- deaggregate(List<KinesisClientRecord>, BigInteger, BigInteger) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
-
This method deaggregates the given list of Amazon Kinesis records into a
list of KPL user records.
- decode(List<KinesisClientRecord>) - Method in class software.amazon.kinesis.schemaregistry.SchemaRegistryDecoder
-
Process the list records and return records with schema and decoded data set.
- DEFAULT_COMPLETED_LEASE_CLEANUP_INTERVAL_MILLIS - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_CONSECUTIVE_HOLES_FOR_TRIGGERING_LEASE_RECOVERY - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_ENABLE_PRIORITY_LEASE_ASSIGNMENT - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_GARBAGE_LEASE_CLEANUP_INTERVAL_MILLIS - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_INTERFACE_NAME - Static variable in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- DEFAULT_LEASE_CLEANUP_CONFIG - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_LEASE_CLEANUP_INTERVAL_MILLIS - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_LEASE_TABLE_DELETION_PROTECTION_ENABLED - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_LEASE_TABLE_PITR_ENABLED - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_MAX_RECORDS - Static variable in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- DEFAULT_NETWORK_STAT_FILE - Static variable in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- DEFAULT_NO_OF_SKIP_STAT_FOR_DEAD_WORKER_THRESHOLD - Static variable in class software.amazon.kinesis.coordinator.assignment.LeaseAssignmentManager
-
- DEFAULT_PERIODIC_SHARD_SYNC_INTERVAL_MILLIS - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_POSITION_IN_STREAM - Static variable in interface software.amazon.kinesis.processor.StreamTracker
-
Default position to begin consuming records from a Kinesis stream.
- DEFAULT_READ_TIMEOUTS_TO_IGNORE - Static variable in class software.amazon.kinesis.lifecycle.LifecycleConfig
-
- DEFAULT_REQUEST_TIMEOUT - Static variable in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- DEFAULT_REQUEST_TIMEOUT - Static variable in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- deleteAll() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Delete all leases from DynamoDB.
- deleteAll() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Delete all leases from DynamoDB.
- DeletedStreamListProvider - Class in software.amazon.kinesis.coordinator
-
This class is used for storing in-memory set of streams which are no longer existing (deleted) and needs to be
cleaned up from KCL's in memory state.
- DeletedStreamListProvider() - Constructor for class software.amazon.kinesis.coordinator.DeletedStreamListProvider
-
- deleteItem(DeleteItemRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- deleteLease(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Delete the given lease from DynamoDB.
- deleteLease(Lease) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Delete the given lease from DynamoDB.
- deleteMetrics(WorkerMetricStats) - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsDAO
-
Deletes the WorkerMetricStats entry with conditional check on lastUpdateTime, if the worker has come alive and
updated the lastUpdateTime then we no longer need to perform the deletion.
- deleteTable(DeleteTableRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- DependencyException - Exception in software.amazon.kinesis.leases.exceptions
-
Indicates that a lease operation has failed because a dependency of the leasing system has failed.
- DependencyException(Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.DependencyException
-
- DependencyException(String, Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.DependencyException
-
- DeprecationUtils - Class in software.amazon.kinesis.common
-
Utility methods to facilitate deprecated code until that deprecated code
can be safely removed.
- describeStreamConsumerRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- describeStreamSummaryRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- describeTable(DescribeTableRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- deserialize(String, String) - Static method in class software.amazon.kinesis.common.HashKeyRangeForLease
-
Deserialize from serialized hashKeyRange string from external storage.
- deserialize(String, HashMap<String, AttributeValue>) - Static method in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- deserialize(Map<String, AttributeValue>) - Static method in class software.amazon.kinesis.coordinator.migration.MigrationState.HistoryEntry
-
- DiagnosticUtils - Class in software.amazon.kinesis.common
-
- DiagnosticUtils() - Constructor for class software.amazon.kinesis.common.DiagnosticUtils
-
- DimensionTrackingMetricsScope - Class in software.amazon.kinesis.metrics
-
DimensionTrackingMetricsScope is where we provide functionality for dimensions.
- DimensionTrackingMetricsScope() - Constructor for class software.amazon.kinesis.metrics.DimensionTrackingMetricsScope
-
- discoverNewLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseDiscoverer
-
- discoverNewLeases() - Method in interface software.amazon.kinesis.leases.LeaseDiscoverer
-
Identifies the leases that are assigned to the current worker but are not being tracked and processed by the
current worker.
- DoesNothingPreparedCheckpointer - Class in software.amazon.kinesis.checkpoint
-
A special PreparedCheckpointer that does nothing, which can be used when preparing a checkpoint at the current
checkpoint sequence number where it is never necessary to do another checkpoint.
- DoesNothingPreparedCheckpointer(ExtendedSequenceNumber) - Constructor for class software.amazon.kinesis.checkpoint.DoesNothingPreparedCheckpointer
-
Constructor.
- drain(int) - Method in class software.amazon.kinesis.metrics.MetricAccumulatingQueue
-
- dropLease(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- dropLease(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
-
Stops the lease renewer from continunig to maintain the given lease.
- dropLease(Lease) - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Requests that renewals for the given lease are stopped.
- dropLease(Lease) - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
Stops the lease renewer from continunig to maintain the given lease.
- dropLeaseStats(String) - Method in class software.amazon.kinesis.leases.LeaseStatsRecorder
-
Clear the in-memory stats for the lease when a lease is reassigned (due to shut down or lease stealing)
- DynamicMigrationComponentsInitializer - Class in software.amazon.kinesis.coordinator
-
This class is responsible for initializing the KCL components that supports
seamless upgrade from v2.x to v3.x.
- dynamicModeChangeSupportNeeded() - Method in class software.amazon.kinesis.coordinator.MigrationAdaptiveLeaseAssignmentModeProvider
-
Specify whether both lease assignment algorithms should be initialized to
support dynamically changing lease mode.
- DynamoDbAsyncToSyncClientAdapter - Class in software.amazon.kinesis.coordinator
-
DDB Lock client depends on DynamoDbClient and KCL only has DynamoDbAsyncClient configured.
- DynamoDbAsyncToSyncClientAdapter(DynamoDbAsyncClient) - Constructor for class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- DynamoDBCheckpointer - Class in software.amazon.kinesis.checkpoint.dynamodb
-
- DynamoDBCheckpointer() - Constructor for class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- DynamoDBCheckpointFactory - Class in software.amazon.kinesis.checkpoint.dynamodb
-
- DynamoDBCheckpointFactory() - Constructor for class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointFactory
-
- dynamoDBClient - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- DynamoDBLeaseCoordinator - Class in software.amazon.kinesis.leases.dynamodb
-
LeaseCoordinator abstracts away LeaseTaker and LeaseRenewer from the application code that's using leasing.
- DynamoDBLeaseCoordinator(LeaseRefresher, String, long, boolean, long, int, int, int, long, long, MetricsFactory, LeaseManagementConfig.WorkerUtilizationAwareAssignmentConfig, LeaseManagementConfig.GracefulLeaseHandoffConfig, ConcurrentMap<ShardInfo, ShardConsumer>) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
Constructor.
- DynamoDBLeaseDiscoverer - Class in software.amazon.kinesis.leases.dynamodb
-
- DynamoDBLeaseDiscoverer() - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseDiscoverer
-
- DynamoDBLeaseManagementFactory - Class in software.amazon.kinesis.leases.dynamodb
-
- DynamoDBLeaseManagementFactory(KinesisAsyncClient, DynamoDbAsyncClient, String, String, ExecutorService, long, boolean, long, int, int, int, boolean, boolean, long, boolean, long, int, int, long, int, long, long, TableCreatorCallback, Duration, BillingMode, boolean, boolean, Collection<Tag>, LeaseSerializer, Function<StreamConfig, ShardDetector>, boolean, LeaseCleanupConfig, LeaseManagementConfig.WorkerUtilizationAwareAssignmentConfig, LeaseManagementConfig.GracefulLeaseHandoffConfig) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
-
Constructor.
- DynamoDBLeaseRefresher - Class in software.amazon.kinesis.leases.dynamodb
-
- DynamoDBLeaseRefresher(String, DynamoDbAsyncClient, LeaseSerializer, boolean, TableCreatorCallback, Duration, DdbTableConfig, boolean, boolean, Collection<Tag>) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Constructor.
- DynamoDBLeaseRenewer - Class in software.amazon.kinesis.leases.dynamodb
-
- DynamoDBLeaseRenewer(LeaseRefresher, String, long, ExecutorService, MetricsFactory, LeaseStatsRecorder, Consumer<Lease>) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
-
Constructor.
- DynamoDBLeaseSerializer - Class in software.amazon.kinesis.leases.dynamodb
-
An implementation of ILeaseSerializer for basic Lease objects.
- DynamoDBLeaseSerializer() - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- DynamoDBLeaseTaker - Class in software.amazon.kinesis.leases.dynamodb
-
- DynamoDBLeaseTaker(LeaseRefresher, String, long, MetricsFactory) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
-
- DynamoDBLockBasedLeaderDecider - Class in software.amazon.kinesis.leader
-
Implementation for LeaderDecider to elect leader using lock on dynamo db table.
- DynamoDBLockBasedLeaderDecider() - Constructor for class software.amazon.kinesis.leader.DynamoDBLockBasedLeaderDecider
-
- DynamoDBMultiStreamLeaseSerializer - Class in software.amazon.kinesis.leases.dynamodb
-
- DynamoDBMultiStreamLeaseSerializer() - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBMultiStreamLeaseSerializer
-
- DynamoUtils - Class in software.amazon.kinesis.leases
-
Static utility functions used by our LeaseSerializers.
- DynamoUtils() - Constructor for class software.amazon.kinesis.leases.DynamoUtils
-
- getAllWorkerMetricStats() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsDAO
-
Performs the scan on the storage and returns list of all workerMetricStats objects.
- getAssignments() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- getAssignments() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- getAttributeDefinitions() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getAttributeDefinitions() - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getAttributeDefinitions() - Static method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
- getAvailableCpusFromEffectiveCpuSet(String) - Static method in class software.amazon.kinesis.utils.Cgroup
-
Calculates the number of available cpus from the cpuset
See https://docs.kernel.org/admin-guide/cgroup-v2.html#cpuset for more information
"0-7" represents 8 cores
"0-4,6,8-10" represents 9 cores (cores 0,1,2,3,4 and core 6 and core 8,9,10)
- getCheckpoint(String) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- getCheckpoint(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Gets the current checkpoint of the shard.
- getCheckpoint(String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Gets the current checkpoint of the shard.
- getCheckpoint(String) - Method in interface software.amazon.kinesis.processor.Checkpointer
-
Get the current checkpoint stored for the specified shard.
- getCheckpointObject(String) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- getCheckpointObject(String) - Method in interface software.amazon.kinesis.processor.Checkpointer
-
Get the current checkpoint stored for the specified shard, which holds the sequence numbers for the checkpoint
and pending checkpoint.
- getChildShards(String) - Method in class software.amazon.kinesis.leases.KinesisShardDetector
-
- getChildShards(String) - Method in interface software.amazon.kinesis.leases.ShardDetector
-
Gets the children shards of a shard.
- getChildShardsFromService() - Method in class software.amazon.kinesis.leases.exceptions.LeasePendingDeletion
-
Discovers the child shards for this lease.
- getClientVersionForInitialization(MigrationState) - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersionStateInitializer
-
- getCoordinatorState(String) - Method in class software.amazon.kinesis.coordinator.CoordinatorStateDAO
-
- getCurrentAssignments() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- getCurrentAssignments() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- getCurrentClientVersion() - Method in interface software.amazon.kinesis.coordinator.migration.MigrationStateMachine
-
Get the ClientVersion of current state machine state.
- getCurrentClientVersion() - Method in class software.amazon.kinesis.coordinator.migration.MigrationStateMachineImpl
-
- getCurrentlyHeldLease(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- getCurrentlyHeldLease(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
- getCurrentlyHeldLease(String) - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- getCurrentlyHeldLease(String) - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
- getCurrentlyHeldLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
- getCurrentlyHeldLeases() - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
- getData() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
required bytes data = 3;
- getData() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
required bytes data = 3;
- getData() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
required bytes data = 3;
- getDataFetcher() - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetrievalStrategy
-
Returns a DataFetcher used to records from Kinesis.
- getDataFetcher() - Method in class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
-
- getDataFetcher() - Method in class software.amazon.kinesis.retrieval.polling.SynchronousGetRecordsRetrievalStrategy
-
- getDataFetcherOverride() - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetrievalStrategy
-
Returns a DataFetcher override if applicable, else empty for retrieving records from Kinesis.
- getDDBLockClientOptionsBuilder() - Method in class software.amazon.kinesis.coordinator.CoordinatorStateDAO
-
- getDefaultInstance() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- getDefaultInstance() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- getDefaultInstance() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- getDefaultInstanceForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- getDefaultInstanceForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- getDefaultInstanceForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- getDefaultInstanceForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- getDefaultInstanceForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- getDefaultInstanceForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- getDefaultWorkerMetrics() - Method in class software.amazon.kinesis.worker.WorkerMetricsSelector
-
Returns a list of WorkerMetricStats based on the operating range provider the worker uses.
- getDelegateSubscriber() - Method in interface software.amazon.kinesis.lifecycle.NotifyingSubscriber
-
Return the actual subscriber to which the events needs to be delegated.
- getDelegateSubscriber() - Method in class software.amazon.kinesis.lifecycle.ShardConsumerNotifyingSubscriber
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- getDescriptor() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- getDescriptorForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- getDescriptorForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- getDescriptorForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- getDimensions() - Method in class software.amazon.kinesis.metrics.DimensionTrackingMetricsScope
-
- getDynamoAssignLeaseUpdate(Lease, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
AssignLease performs the PUT action on the LeaseOwner and ADD (1) action on the leaseCounter.
- getDynamoAssignLeaseUpdate(Lease, String) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoClientVersionExpectation() - Method in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- getDynamoEvictLeaseUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoEvictLeaseUpdate(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoExistentExpectation(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoExistentExpectation(String) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoHashKey(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoHashKey(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoHashKey(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoHashKey(String) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoLeaseCounterExpectation(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoLeaseCounterExpectation(Long) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoLeaseCounterExpectation(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoLeaseCounterUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoLeaseCounterUpdate(Long) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoLeaseCounterUpdate(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoLeaseOwnerExpectation(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoLeaseOwnerExpectation(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoLeaseThroughputKbpsUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoLeaseThroughputKbpsUpdate(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoNonexistantExpectation() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoNonexistantExpectation() - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoTakeLeaseUpdate(Lease, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoTakeLeaseUpdate(Lease, String) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoUpdate() - Method in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- getDynamoUpdateLeaseUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoUpdateLeaseUpdate(Lease, UpdateField) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getDynamoUpdateLeaseUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBMultiStreamLeaseSerializer
-
- getDynamoUpdateLeaseUpdate(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getDynamoUpdateLeaseUpdate(Lease, UpdateField) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getException() - Method in class software.amazon.kinesis.lifecycle.TaskResult
-
- getExplicitHashKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
optional uint64 explicit_hash_key_index = 2;
- getExplicitHashKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
optional uint64 explicit_hash_key_index = 2;
- getExplicitHashKeyIndex() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
optional uint64 explicit_hash_key_index = 2;
- getExplicitHashKeyTable(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTable(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTable(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableBytes(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableBytes(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableBytes(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableCount() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string explicit_hash_key_table = 2;
- getExplicitHashKeyTableList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string explicit_hash_key_table = 2;
- getGetRecordsRequest(String) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Retrieves the next get records request based on the current iterator.
- getGetRecordsRequest(String) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
- getGetRecordsResponse(GetRecordsRequest) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Retrieves the response based on the request.
- getGetRecordsResponse(GetRecordsRequest) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
- getInitialPositionInStream() - Method in class software.amazon.kinesis.common.InitialPositionInStreamExtended
-
Get the initial position in the stream where the application should start from.
- getInitialState() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersionStateInitializer
-
- getItem(GetItemRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- getKey(String) - Method in class software.amazon.kinesis.metrics.AccumulateByNameMetricsScope
-
- getKey(String) - Method in class software.amazon.kinesis.metrics.AccumulatingMetricsScope
-
- getKey() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
required string key = 1;
- getKey() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
required string key = 1;
- getKey() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.TagOrBuilder
-
required string key = 1;
- getKeyBytes() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
required string key = 1;
- getKeyBytes() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
required string key = 1;
- getKeyBytes() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.TagOrBuilder
-
required string key = 1;
- getKeySchema() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getKeySchema() - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getKeySchema() - Static method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
- getKinesisRequestTimeout() - Method in interface software.amazon.kinesis.retrieval.DataFetcherProviderConfig
-
Gets timeout for kinesis request.
- getLastSuccessfulRequestDetails() - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
-
- getLastSuccessfulRequestDetails() - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
-
- getLastSuccessfulRequestDetails() - Method in class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
- getLastSuccessfulRequestDetails() - Method in interface software.amazon.kinesis.retrieval.RecordsPublisher
-
Gets last successful request details.
- getLease(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
- getLease(String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
- getLeaseAssignmentMode() - Method in class software.amazon.kinesis.coordinator.MigrationAdaptiveLeaseAssignmentModeProvider
-
Provide the current lease assignment mode in which KCL should perform lease assignment
- getLeaseKey(String, String) - Static method in class software.amazon.kinesis.leases.MultiStreamLease
-
- getLeaseKey(ShardInfo) - Static method in class software.amazon.kinesis.leases.ShardInfo
-
Utility method to derive lease key from ShardInfo.
- getLeaseKey(ShardInfo, String) - Static method in class software.amazon.kinesis.leases.ShardInfo
-
Utility method to derive lease key from ShardInfo and shardId to override.
- getListShardsResponse(ListShardsRequest) - Method in class software.amazon.kinesis.leases.KinesisShardDetector
-
- getListShardsResponse(ListShardsRequest) - Method in interface software.amazon.kinesis.leases.ShardDetector
-
Gets a list shards response based on the request.
- getLog() - Method in class software.amazon.kinesis.retrieval.ThrottlingReporter
-
- getMaxRecords() - Method in interface software.amazon.kinesis.retrieval.DataFetcherProviderConfig
-
Gets current max records allowed to process at a given time.
- getMetricsFactory() - Method in interface software.amazon.kinesis.retrieval.DataFetcherProviderConfig
-
Gets current instance of metrics factory.
- getMetricStat(String) - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
Returns the value for given WorkerMetricStats name.
- getName() - Method in enum software.amazon.kinesis.metrics.MetricsLevel
-
Returns the name for this metrics level.
- getNextIterator(GetShardIteratorRequest) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Gets the next iterator based on the request.
- getNextIterator(GetShardIteratorRequest) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
- getNextRecords(int) - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetriever
-
- getNextResult() - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
-
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv1CpuWorkerMetric
-
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv2CpuWorkerMetric
-
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metric.impl.container.EcsCpuWorkerMetric
-
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metric.impl.jmx.HeapMemoryAfterGCWorkerMetric
-
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxCpuWorkerMetric
-
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- getOperatingRange() - Method in interface software.amazon.kinesis.worker.metric.WorkerMetric
-
Gets the operating range for this workerMetrics
- getOperatingRange() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsManager
-
Gets the operating range for each WorkerMetricStats that is registered.
- getOperatingRangeDataProvider() - Method in class software.amazon.kinesis.worker.platform.Ec2Resource
-
Get the operating range data provider.
- getOperatingRangeDataProvider() - Method in class software.amazon.kinesis.worker.platform.EcsResource
-
Get the operating range data provider.
- getOperatingRangeDataProvider() - Method in class software.amazon.kinesis.worker.platform.EksResource
-
Get the operating range data provider.
- getOperatingRangeDataProvider() - Method in interface software.amazon.kinesis.worker.platform.ResourceMetadataProvider
-
Get the operating range data provider.
- getOrCreateStreamConsumerArn() - Method in interface software.amazon.kinesis.retrieval.ConsumerRegistration
-
This method is used to get or create StreamConsumer information from Kinesis.
- getOrCreateStreamConsumerArn() - Method in class software.amazon.kinesis.retrieval.fanout.FanOutConsumerRegistration
-
- getOther() - Method in class software.amazon.kinesis.metrics.MetricsCollectingTaskDecorator
-
- getParserForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- getParserForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- getParserForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- getPartitionKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
required uint64 partition_key_index = 1;
- getPartitionKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
required uint64 partition_key_index = 1;
- getPartitionKeyIndex() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
required uint64 partition_key_index = 1;
- getPartitionKeyTable(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- getPartitionKeyTable(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string partition_key_table = 1;
- getPartitionKeyTable(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string partition_key_table = 1;
- getPartitionKeyTableBytes(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- getPartitionKeyTableBytes(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string partition_key_table = 1;
- getPartitionKeyTableBytes(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string partition_key_table = 1;
- getPartitionKeyTableCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- getPartitionKeyTableCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string partition_key_table = 1;
- getPartitionKeyTableCount() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string partition_key_table = 1;
- getPartitionKeyTableList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- getPartitionKeyTableList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated string partition_key_table = 1;
- getPartitionKeyTableList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated string partition_key_table = 1;
- getPlatform() - Method in class software.amazon.kinesis.worker.platform.Ec2Resource
-
Get the name of the compute platform.
- getPlatform() - Method in class software.amazon.kinesis.worker.platform.EcsResource
-
Get the name of the compute platform.
- getPlatform() - Method in class software.amazon.kinesis.worker.platform.EksResource
-
Get the name of the compute platform.
- getPlatform() - Method in interface software.amazon.kinesis.worker.platform.ResourceMetadataProvider
-
Get the name of the compute platform.
- getPrintableStackTrace(StackTraceElement[]) - Static method in class software.amazon.kinesis.common.StackTraceUtils
-
- getReason() - Method in class software.amazon.kinesis.lifecycle.ShutdownTask
-
- getRecords(int) - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetrievalStrategy
-
Gets a set of records from Kinesis.
- getRecords(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecords(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecords(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecords(int) - Method in class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
-
- getRecords() - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Get records from the current position in the stream (up to maxRecords).
- getRecords(String) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Gets the next set of records based on the iterator.
- getRecords() - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
Get records from the current position in the stream (up to maxRecords).
- getRecords(String) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
- getRecords(int) - Method in class software.amazon.kinesis.retrieval.polling.SynchronousGetRecordsRetrievalStrategy
-
- getRecordsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsCount() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsDeliveryAck(RecordsRetrieved) - Method in interface software.amazon.kinesis.lifecycle.NotifyingSubscriber
-
Construct RecordsDeliveryAck object from the incoming data and return it
- getRecordsDeliveryAck(RecordsRetrieved) - Method in class software.amazon.kinesis.lifecycle.ShardConsumerNotifyingSubscriber
-
- getRecordsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsOrBuilder(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsOrBuilderList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- getRecordsPublisher() - Method in interface software.amazon.kinesis.lifecycle.NotifyingSubscriber
-
Return the publisher to be notified
- getRecordsPublisher() - Method in class software.amazon.kinesis.lifecycle.ShardConsumerNotifyingSubscriber
-
- getRecordsRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- GetRecordsRetrievalStrategy - Interface in software.amazon.kinesis.retrieval
-
Represents a strategy to retrieve records from Kinesis.
- GetRecordsRetriever - Interface in software.amazon.kinesis.retrieval
-
This class uses the GetRecordsRetrievalStrategy class to retrieve the next set of records and update the cache.
- getRenewerTakerIntervalMillis(long, long) - Static method in class software.amazon.kinesis.common.CommonCalculations
-
Convenience method for calculating renewer intervals in milliseconds.
- getRequestId() - Method in class software.amazon.kinesis.common.RequestDetails
-
Gets last successful request's request id.
- getResult() - Method in interface software.amazon.kinesis.retrieval.DataFetcherResult
-
The result of the request to Kinesis
- getSerializedSize() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- getSerializedSize() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- getSerializedSize() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- getShardId() - Method in interface software.amazon.kinesis.retrieval.DataFetcherProviderConfig
-
Gets shard id.
- getShardIteratorRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- getShortName() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv1CpuWorkerMetric
-
- getShortName() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv2CpuWorkerMetric
-
- getShortName() - Method in class software.amazon.kinesis.worker.metric.impl.container.EcsCpuWorkerMetric
-
- getShortName() - Method in class software.amazon.kinesis.worker.metric.impl.jmx.HeapMemoryAfterGCWorkerMetric
-
- getShortName() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxCpuWorkerMetric
-
- getShortName() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- getShortName() - Method in interface software.amazon.kinesis.worker.metric.WorkerMetric
-
WorkerMetricStats short name that is used as attribute name for it in storage.
- getStreamIdentifier() - Method in interface software.amazon.kinesis.retrieval.DataFetcherProviderConfig
-
Gets stream identifier for dataFetcher.
- getStreamIdentifier() - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Get the current account and stream information.
- getTags(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTags(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTags(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsCount() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsOrBuilder(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getTagsOrBuilderList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- getThroughputKBps(String) - Method in class software.amazon.kinesis.leases.LeaseStatsRecorder
-
Calculates the throughput in KBps for the given leaseKey.
- getTime() - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
Overrideable for testing purposes.
- getTimestamp() - Method in class software.amazon.kinesis.common.InitialPositionInStreamExtended
-
Get the timestamp from where we need to start the application.
- getTimestamp() - Method in class software.amazon.kinesis.common.RequestDetails
-
Gets last successful request's timestamp.
- getValue() - Method in enum software.amazon.kinesis.metrics.MetricsLevel
-
Returns the value for this metrics level.
- getValue() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
optional string value = 2;
- getValue() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
optional string value = 2;
- getValue() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.TagOrBuilder
-
optional string value = 2;
- getValueBytes() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
optional string value = 2;
- getValueBytes() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
optional string value = 2;
- getValueBytes() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.TagOrBuilder
-
optional string value = 2;
- getWorkerIdentifier() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
- getWorkerIdentifier() - Method in interface software.amazon.kinesis.leases.LeaseTaker
-
- getWorkerIdToLeaseKeyIndexAttributeDefinitions() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getWorkerIdToLeaseKeyIndexAttributeDefinitions() - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getWorkerIdToLeaseKeyIndexKeySchema() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- getWorkerIdToLeaseKeyIndexKeySchema() - Method in interface software.amazon.kinesis.leases.LeaseSerializer
-
- getWorkerMetricsType() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkInWorkerMetric
-
- getWorkerMetricsType() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkOutWorkerMetric
-
- getWorkerMetricsType() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- getWorkerMetricType() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv1CpuWorkerMetric
-
- getWorkerMetricType() - Method in class software.amazon.kinesis.worker.metric.impl.container.Cgroupv2CpuWorkerMetric
-
- getWorkerMetricType() - Method in class software.amazon.kinesis.worker.metric.impl.container.EcsCpuWorkerMetric
-
- getWorkerMetricType() - Method in class software.amazon.kinesis.worker.metric.impl.jmx.HeapMemoryAfterGCWorkerMetric
-
- getWorkerMetricType() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxCpuWorkerMetric
-
- getWorkerMetricType() - Method in class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- getWorkerMetricType() - Method in interface software.amazon.kinesis.worker.metric.WorkerMetric
-
Type of the current WorkerMetricStats.
- gracefuleShutdownStarted - Variable in class software.amazon.kinesis.coordinator.Scheduler
-
- GracefulLeaseHandoffConfig() - Constructor for class software.amazon.kinesis.leases.LeaseManagementConfig.GracefulLeaseHandoffConfig
-
- gracefulShutdown(ShutdownNotification) - Method in class software.amazon.kinesis.lifecycle.ShardConsumer
-
Requests the shutdown of the ShardConsumer.
- idleMillisBetweenCalls(long) - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- idleMillisBetweenCalls() - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- idleMillisBetweenCalls(long) - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
Sets the maximum idle time between two get calls.
- idleMillisBetweenCalls() - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
- idleTimeBetweenReadsInMillis(long) - Method in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
Set the value for how long the ShardConsumer should sleep in between calls to
KinesisAsyncClient.getRecords(GetRecordsRequest)
.
- InitializationInput - Class in software.amazon.kinesis.lifecycle.events
-
Container for the parameters to the ShardRecordProcessor
initialize
method.
- InitializationInput() - Constructor for class software.amazon.kinesis.lifecycle.events.InitializationInput
-
- initialize() - Method in class software.amazon.kinesis.coordinator.CoordinatorStateDAO
-
- initialize(ClientVersion) - Method in class software.amazon.kinesis.coordinator.DynamicMigrationComponentsInitializer
-
- initialize() - Method in interface software.amazon.kinesis.coordinator.LeaderDecider
-
Performs initialization tasks for decider if any.
- initialize() - Method in interface software.amazon.kinesis.coordinator.migration.MigrationStateMachine
-
Initialize the state machine by identifying the initial state when the KCL worker comes up for the first time.
- initialize() - Method in class software.amazon.kinesis.coordinator.migration.MigrationStateMachineImpl
-
- initialize() - Method in class software.amazon.kinesis.leader.DynamoDBLockBasedLeaderDecider
-
- initialize() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- initialize() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
-
- initialize() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Initialize the lease coordinator (create the lease table if needed).
- initialize() - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
- initialize(InitializationInput) - Method in interface software.amazon.kinesis.processor.ShardRecordProcessor
-
Invoked by the Amazon Kinesis Client Library before data records are delivered to the ShardRecordProcessor instance
(via processRecords).
- initialize(String, InitialPositionInStreamExtended) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Initializes this KinesisDataFetcher's iterator based on the checkpointed sequence number.
- initialize(ExtendedSequenceNumber, InitialPositionInStreamExtended) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Initializes this KinesisDataFetcher's iterator based on the checkpointed sequence number as an
ExtendedSequenceNumber.
- initialize(String, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
Initializes this KinesisDataFetcher's iterator based on the checkpointed sequence number.
- initialize(ExtendedSequenceNumber, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
- initialize() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsDAO
-
Performs initialization of the WorkerMetricStats DAO and table.
- initializeClientVersionFor2x(ClientVersion) - Method in class software.amazon.kinesis.coordinator.DynamicMigrationComponentsInitializer
-
Initialize KCL with components and configuration to run 2x compatible functionality
while allowing roll-forward.
- initializeClientVersionFor3x(ClientVersion) - Method in class software.amazon.kinesis.coordinator.DynamicMigrationComponentsInitializer
-
Initialize KCL with components and configuration to run vanilla 3x functionality.
- initializeClientVersionFor3xWithRollback(ClientVersion) - Method in class software.amazon.kinesis.coordinator.DynamicMigrationComponentsInitializer
-
Initialize KCL with components and configuration to run vanilla 3x functionality
while allowing roll-back to 2x functionality.
- initializeClientVersionForUpgradeFrom2x(ClientVersion) - Method in class software.amazon.kinesis.coordinator.DynamicMigrationComponentsInitializer
-
Initialize KCL with components and configuration to support upgrade from 2x.
- InitializeTask - Class in software.amazon.kinesis.lifecycle
-
Task for initializing shard position and invoking the ShardRecordProcessor initialize() API.
- InitializeTask() - Constructor for class software.amazon.kinesis.lifecycle.InitializeTask
-
- initialLeaseTableReadCapacity(long) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
Deprecated.
- initialLeaseTableReadCapacity(long) - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- initialLeaseTableWriteCapacity(long) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
Deprecated.
- initialLeaseTableWriteCapacity(long) - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- InitialPositionInStream - Enum in software.amazon.kinesis.common
-
Used to specify the position in the stream where a new application should start from.
- InitialPositionInStreamExtended - Class in software.amazon.kinesis.common
-
Class that houses the entities needed to specify the position in the stream from where a new application should
start.
- initialPositionInStreamExtended(InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.RetrievalConfig
-
- initiateGracefulLeaseHandoff(Lease, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Initiates a graceful handoff of the given lease to the specified new owner, allowing the current owner
to complete its processing before transferring ownership.
- initiateGracefulLeaseHandoff(Lease, String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Initiates a graceful handoff of the given lease to the specified new owner, allowing the current owner
to complete its processing before transferring ownership.
- interceptAddData(String, double, StandardUnit, MetricsScope) - Method in class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- interceptAddData(String, double, StandardUnit, MetricsLevel, MetricsScope) - Method in class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- interceptAddDimension(String, String, MetricsScope) - Method in class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- interceptCreateMetrics(MetricsScope) - Method in class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- interceptEnd(MetricsScope) - Method in class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- InterceptingMetricsFactory - Class in software.amazon.kinesis.metrics
-
- InterceptingMetricsFactory(MetricsFactory) - Constructor for class software.amazon.kinesis.metrics.InterceptingMetricsFactory
-
- internalGetFieldAccessorTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- internalGetFieldAccessorTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- internalGetFieldAccessorTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- internalGetFieldAccessorTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- internalGetFieldAccessorTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- internalGetFieldAccessorTable() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- InvalidStateException - Exception in software.amazon.kinesis.exceptions
-
This is thrown when the Amazon Kinesis Client Library encounters issues with its internal state (e.g.
- InvalidStateException(String) - Constructor for exception software.amazon.kinesis.exceptions.InvalidStateException
-
- InvalidStateException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.InvalidStateException
-
- InvalidStateException - Exception in software.amazon.kinesis.leases.exceptions
-
Indicates that a lease operation has failed because DynamoDB is an invalid state.
- InvalidStateException(Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.InvalidStateException
-
- InvalidStateException(String, Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.InvalidStateException
-
- InvalidStateException(String) - Constructor for exception software.amazon.kinesis.leases.exceptions.InvalidStateException
-
- isAnyWorkerMetricAboveAverageUtilizationOrOperatingRange(Map<String, Double>) - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
- isAnyWorkerMetricFailing() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
Returns true if any of the metric stat values has -1 in last index which represents that the metric stat value
was not successfully fetched in last attempt by worker.
- isAvailable(long, long) - Method in class software.amazon.kinesis.leases.Lease
-
- isCompleted() - Method in class software.amazon.kinesis.leases.ShardInfo
-
Whether the shard has been completely processed or not.
- isEligibleForGracefulShutdown() - Method in class software.amazon.kinesis.leases.Lease
-
Check whether lease is eligible for graceful shutdown.
- isEmpty() - Method in class software.amazon.kinesis.metrics.MetricAccumulatingQueue
-
- isEnqueuedForDeletion(LeasePendingDeletion) - Method in class software.amazon.kinesis.leases.LeaseCleanupManager
-
Check if lease was already enqueued for deletion.
- isExpired(long, long) - Method in class software.amazon.kinesis.leases.Lease
-
- isInitialized() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- isInitialized() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- isInitialized() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- isInitialized() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- isInitialized() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- isInitialized() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- isLeader(String) - Method in interface software.amazon.kinesis.coordinator.LeaderDecider
-
Method invoked to check the given workerId corresponds to one of the workers
designated to execute shard-syncs periodically.
- isLeader(String) - Method in class software.amazon.kinesis.leader.DynamoDBLockBasedLeaderDecider
-
Check the lockItem in storage and if the current worker is not leader worker, then tries to acquire lock and
returns true if it was able to acquire lock else false.
- isLeader(String) - Method in class software.amazon.kinesis.leader.MigrationAdaptiveLeaderDecider
-
- isLeaseOwnerToLeaseKeyIndexActive() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- isLeaseOwnerToLeaseKeyIndexActive() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Check if leaseOwner GSI is ACTIVE
- isLeaseTableEmpty() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Check (synchronously) if there are any leases in the lease table.
- isLeaseTableEmpty() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Check (synchronously) if there are any leases in the lease table.
- isMultiStream() - Method in interface software.amazon.kinesis.processor.MultiStreamTracker
-
- isMultiStream() - Method in class software.amazon.kinesis.processor.SingleStreamTracker
-
- isMultiStream() - Method in interface software.amazon.kinesis.processor.StreamTracker
-
Returns true if this application should accommodate the consumption of
more than one Kinesis stream.
- isOnPlatform() - Method in class software.amazon.kinesis.worker.platform.Ec2Resource
-
Check if the worker is running on the specific platform.
- isOnPlatform() - Method in class software.amazon.kinesis.worker.platform.EcsResource
-
Check if the worker is running on the specific platform.
- isOnPlatform() - Method in class software.amazon.kinesis.worker.platform.EksResource
-
Check if the worker is running on the specific platform.
- isOnPlatform() - Method in interface software.amazon.kinesis.worker.platform.ResourceMetadataProvider
-
Check if the worker is running on the specific platform.
- isProvider() - Method in enum software.amazon.kinesis.worker.platform.OperatingRangeDataProvider
-
Abstract method to check if the provider is supported on the current platform.
- isRunning() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- isRunning() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- isSentinelCheckpoint() - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
- isShardEnd() - Method in interface software.amazon.kinesis.retrieval.DataFetcherResult
-
Indicates whether this result is at the end of the shard or not
- isShardEnd() - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
- isShardEndReached() - Method in class software.amazon.kinesis.lifecycle.TaskResult
-
- isShardEndReached() - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Checks if shardEnd is reached.
- isShutdown() - Method in class software.amazon.kinesis.lifecycle.ShardConsumer
-
Used (by Worker) to check if this ShardConsumer instance has been shutdown
ShardRecordProcessor shutdown() has been invoked, as appropriate.
- isShutdown() - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
- isShutdown() - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetrievalStrategy
-
Returns whether this strategy has been shutdown.
- isShutdown() - Method in class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
-
- isShutdown() - Method in class software.amazon.kinesis.retrieval.polling.SynchronousGetRecordsRetrievalStrategy
-
- isShutdownRequested() - Method in class software.amazon.kinesis.lifecycle.ShardConsumer
-
- isUsingDefaultWorkerMetric() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
If a worker is not using an explicit WorkerMetric such as CPU, Memory, or Network, then it
is said to be using the default WorkerMetric.
- isValidResult(String, List<ChildShard>) - Static method in class software.amazon.kinesis.retrieval.DataRetrievalUtil
-
- isValidWorkerMetric() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
WorkerMetricStats entry is invalid
if any of the field from lastUpdateTime, operatingRange, resourcesStats are not present or
if resourcesStats is empty or
if any of the WorkerMetrics having resourceStats does not have operatingRange or
if operating range values are not present or
if maxUtilization is 0 for any WorkerMetric
- isWorkerMetricAboveOperatingRange(String) - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStats
-
Evaluates if the given metric stat is above operatingRange for the given WorkerMetric name.
- IteratorBuilder - Class in software.amazon.kinesis.retrieval
-
- IteratorBuilder() - Constructor for class software.amazon.kinesis.retrieval.IteratorBuilder
-
- largestPermittedCheckpointValue(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
- lastCounterIncrementNanos(Long) - Method in class software.amazon.kinesis.leases.Lease
-
Sets lastCounterIncrementNanos
- LATEST - Static variable in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
Special value for LATEST.
- LEADER_HASH_KEY - Static variable in class software.amazon.kinesis.coordinator.CoordinatorState
-
Key value for the item in the CoordinatorState table used for leader
election among the KCL workers.
- LeaderDecider - Interface in software.amazon.kinesis.coordinator
-
Used in conjunction with periodic shard sync.
- Lease - Class in software.amazon.kinesis.leases
-
This class contains data pertaining to a Lease.
- Lease(Lease) - Constructor for class software.amazon.kinesis.leases.Lease
-
Copy constructor, used by clone().
- Lease(String, String, Long, UUID, Long, ExtendedSequenceNumber, ExtendedSequenceNumber, Long, Set<String>) - Constructor for class software.amazon.kinesis.leases.Lease
-
Deprecated.
- Lease(String, String, Long, UUID, Long, ExtendedSequenceNumber, ExtendedSequenceNumber, Long, Set<String>, Set<String>, byte[], HashKeyRangeForLease) - Constructor for class software.amazon.kinesis.leases.Lease
-
- LeaseAssignmentDecider - Interface in software.amazon.kinesis.coordinator.assignment
-
- LeaseAssignmentManager - Class in software.amazon.kinesis.coordinator.assignment
-
Performs the LeaseAssignment for the application.
- LeaseAssignmentManager() - Constructor for class software.amazon.kinesis.coordinator.assignment.LeaseAssignmentManager
-
- leaseCleanedUp() - Method in class software.amazon.kinesis.leases.LeaseCleanupManager.LeaseCleanupResult
-
- LeaseCleanupConfig - Class in software.amazon.kinesis.common
-
Configuration for lease cleanup.
- LeaseCleanupConfig() - Constructor for class software.amazon.kinesis.common.LeaseCleanupConfig
-
- LeaseCleanupManager - Class in software.amazon.kinesis.leases
-
Helper class to cleanup of any expired/closed shard leases.
- LeaseCleanupManager() - Constructor for class software.amazon.kinesis.leases.LeaseCleanupManager
-
- LeaseCleanupManager.LeaseCleanupResult - Class in software.amazon.kinesis.leases
-
- LeaseCleanupResult() - Constructor for class software.amazon.kinesis.leases.LeaseCleanupManager.LeaseCleanupResult
-
- LeaseCoordinator - Interface in software.amazon.kinesis.leases
-
- leaseCounter(Long) - Method in class software.amazon.kinesis.leases.Lease
-
Sets leaseCounter.
- leaseDeletionType() - Method in class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.AutoDetectionAndDeferredDeletionStrategy
-
- leaseDeletionType() - Method in interface software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy
-
Strategy type for deleting the leases of former active streams.
- leaseDeletionType() - Method in class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.NoLeaseDeletionStrategy
-
- leaseDeletionType() - Method in class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.ProvidedStreamsDeferredDeletionStrategy
-
- LeaseDiscoverer - Interface in software.amazon.kinesis.leases
-
- LeaseGracefulShutdownHandler - Class in software.amazon.kinesis.lifecycle
-
This class handles the graceful shutdown of shard consumers.
- LeaseGracefulShutdownHandler() - Constructor for class software.amazon.kinesis.lifecycle.LeaseGracefulShutdownHandler
-
- leaseKey(String) - Method in class software.amazon.kinesis.leases.Lease
-
Sets leaseKey.
- leaseLost() - Method in class software.amazon.kinesis.lifecycle.ShardConsumer
-
Shutdown this ShardConsumer (including invoking the ShardRecordProcessor shutdown API).
- leaseLost(LeaseLostInput) - Method in interface software.amazon.kinesis.processor.ShardRecordProcessor
-
Called when the lease that tied to this record processor has been lost.
- LeaseLostInput - Class in software.amazon.kinesis.lifecycle.events
-
- LeaseLostInput() - Constructor for class software.amazon.kinesis.lifecycle.events.LeaseLostInput
-
- leaseManagementConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of LeaseManagementConfig
- LeaseManagementConfig - Class in software.amazon.kinesis.leases
-
Used by the KCL to configure lease management.
- LeaseManagementConfig(String, DynamoDbAsyncClient, KinesisAsyncClient, String, String) - Constructor for class software.amazon.kinesis.leases.LeaseManagementConfig
-
Deprecated.
- LeaseManagementConfig(String, String, DynamoDbAsyncClient, KinesisAsyncClient, String) - Constructor for class software.amazon.kinesis.leases.LeaseManagementConfig
-
- LeaseManagementConfig.GracefulLeaseHandoffConfig - Class in software.amazon.kinesis.leases
-
Configuration class for controlling the graceful handoff of leases.
- LeaseManagementConfig.WorkerMetricsTableConfig - Class in software.amazon.kinesis.leases
-
- LeaseManagementConfig.WorkerUtilizationAwareAssignmentConfig - Class in software.amazon.kinesis.leases
-
- leaseManagementFactory() - Method in class software.amazon.kinesis.leases.LeaseManagementConfig
-
- leaseManagementFactory(LeaseSerializer, boolean) - Method in class software.amazon.kinesis.leases.LeaseManagementConfig
-
Vends LeaseManagementFactory that performs serde based on leaseSerializer and shard sync based on isMultiStreamingMode
- leaseManagementFactory(LeaseManagementFactory) - Method in class software.amazon.kinesis.leases.LeaseManagementConfig
-
Set leaseManagementFactory and return the current LeaseManagementConfig instance.
- LeaseManagementFactory - Interface in software.amazon.kinesis.leases
-
- leaseOwner(String) - Method in class software.amazon.kinesis.leases.Lease
-
Sets leaseOwner.
- LeasePendingDeletion - Class in software.amazon.kinesis.leases.exceptions
-
Helper class for cleaning up leases.
- LeasePendingDeletion() - Constructor for class software.amazon.kinesis.leases.exceptions.LeasePendingDeletion
-
- leaseRefresher() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- leaseRefresher() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- LeaseRefresher - Interface in software.amazon.kinesis.leases
-
Supports basic CRUD operations for Leases.
- LeaseRenewer - Interface in software.amazon.kinesis.leases
-
ILeaseRenewer objects are used by LeaseCoordinator to renew leases held by the LeaseCoordinator.
- LeaseSerializer - Interface in software.amazon.kinesis.leases
-
Utility class that manages the mapping of Lease objects/operations to records in DynamoDB.
- LeaseStats() - Constructor for class software.amazon.kinesis.leases.LeaseStatsRecorder.LeaseStats
-
- leaseStatsRecorder() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- leaseStatsRecorder() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
- LeaseStatsRecorder - Class in software.amazon.kinesis.leases
-
This class records the stats for the leases.
- LeaseStatsRecorder() - Constructor for class software.amazon.kinesis.leases.LeaseStatsRecorder
-
- LeaseStatsRecorder.LeaseStats - Class in software.amazon.kinesis.leases
-
- leaseTableExists() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
- leaseTableExists() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
- LeaseTaker - Interface in software.amazon.kinesis.leases
-
ILeaseTaker is used by LeaseCoordinator to take new leases, or leases that other workers fail to renew.
- LeasingException - Exception in software.amazon.kinesis.leases.exceptions
-
Top-level exception type for all exceptions thrown by the leasing code.
- LeasingException(Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.LeasingException
-
- LeasingException(String, Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.LeasingException
-
- LeasingException(String) - Constructor for exception software.amazon.kinesis.leases.exceptions.LeasingException
-
- leave() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersion2xState
-
- leave() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersion3xState
-
- leave() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersion3xWithRollbackState
-
- leave() - Method in interface software.amazon.kinesis.coordinator.migration.MigrationClientVersionState
-
Invoked after the transition to another state has occurred
to allow printing any helpful logs or performing cleanup.
- leave() - Method in class software.amazon.kinesis.coordinator.migration.MigrationClientVersionUpgradeFrom2xState
-
- lifecycleConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of LifecycleConfig
- LifecycleConfig - Class in software.amazon.kinesis.lifecycle
-
Used by the KCL to configure the lifecycle.
- LifecycleConfig() - Constructor for class software.amazon.kinesis.lifecycle.LifecycleConfig
-
- LinuxCpuWorkerMetric - Class in software.amazon.kinesis.worker.metric.impl.linux
-
Reads CPU usage statistics out of /proc/stat file that is present on the EC2 instances.
- LinuxCpuWorkerMetric(OperatingRange) - Constructor for class software.amazon.kinesis.worker.metric.impl.linux.LinuxCpuWorkerMetric
-
- LinuxNetworkInWorkerMetric - Class in software.amazon.kinesis.worker.metric.impl.linux
-
- LinuxNetworkInWorkerMetric(OperatingRange, String, double) - Constructor for class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkInWorkerMetric
-
- LinuxNetworkInWorkerMetric(OperatingRange, double) - Constructor for class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkInWorkerMetric
-
- LinuxNetworkOutWorkerMetric - Class in software.amazon.kinesis.worker.metric.impl.linux
-
- LinuxNetworkOutWorkerMetric(OperatingRange, String, double) - Constructor for class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkOutWorkerMetric
-
- LinuxNetworkOutWorkerMetric(OperatingRange, double) - Constructor for class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkOutWorkerMetric
-
- LinuxNetworkWorkerMetricBase - Class in software.amazon.kinesis.worker.metric.impl.linux
-
Base class for EC2NetworkWorkerMetrics, this reads and parses /proc/net/dev file and look for the specific
interface and reads received and transmitted bytes.
- LinuxNetworkWorkerMetricBase(OperatingRange, String, String, double, Stopwatch) - Constructor for class software.amazon.kinesis.worker.metric.impl.linux.LinuxNetworkWorkerMetricBase
-
- listCoordinatorState() - Method in class software.amazon.kinesis.coordinator.CoordinatorStateDAO
-
- listLeaseKeysForWorker(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
List all leases for a given workerIdentifier synchronously.
- listLeaseKeysForWorker(String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
List all leases for a given workerIdentifier synchronously.
- listLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
List all objects in table synchronously.
- listLeases() - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
List all objects in table synchronously.
- listLeasesForStream(StreamIdentifier) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
List all leases for a given stream synchronously.
- listLeasesForStream(StreamIdentifier) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
List all leases for a given stream synchronously.
- listLeasesParallely(ExecutorService, int) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- listLeasesParallely(ExecutorService, int) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
List all leases from the storage parallely and deserialize into Lease objects.
- listShards() - Method in class software.amazon.kinesis.leases.KinesisShardDetector
-
- listShards() - Method in interface software.amazon.kinesis.leases.ShardDetector
-
List shards.
- listShardsRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- listShardsWithFilter(ShardFilter) - Method in class software.amazon.kinesis.leases.KinesisShardDetector
-
- listShardsWithFilter(ShardFilter) - Method in interface software.amazon.kinesis.leases.ShardDetector
-
List shards with shard filter.
- listShardsWithoutConsumingResourceNotFoundException() - Method in class software.amazon.kinesis.leases.KinesisShardDetector
-
- listShardsWithoutConsumingResourceNotFoundException() - Method in interface software.amazon.kinesis.leases.ShardDetector
-
This method behaves exactly similar to listShards except the fact that this does not consume and throw
ResourceNotFoundException instead of returning empty list.
- logAcquireTimeoutMessage(Throwable) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
-
- LogMetricsFactory - Class in software.amazon.kinesis.metrics
-
An IMetricsFactory that creates IMetricsScopes that output themselves via log4j.
- LogMetricsFactory() - Constructor for class software.amazon.kinesis.metrics.LogMetricsFactory
-
- LogMetricsScope - Class in software.amazon.kinesis.metrics
-
An AccumulatingMetricsScope that outputs via log4j.
- LogMetricsScope() - Constructor for class software.amazon.kinesis.metrics.LogMetricsScope
-
- MAX_TIME_BETWEEN_REQUEST_RESPONSE - Static variable in class software.amazon.kinesis.lifecycle.ShardConsumer
-
- maxByteSize(int) - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- maxByteSize() - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- maxByteSize(int) - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
Sets the max byte size for the RecordsPublisher, before further requests are blocked.
- maxByteSize() - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
- maxPendingProcessRecordsInput(int) - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- maxPendingProcessRecordsInput() - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- maxPendingProcessRecordsInput(int) - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
Sets the maximum number of ProcessRecordsInput objects the RecordsPublisher can hold, before further requests are
blocked.
- maxPendingProcessRecordsInput() - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
- maxRecords(int) - Method in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- maxRecordsCount(int) - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- maxRecordsCount() - Method in class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- maxRecordsCount(int) - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
Sets the max number of records for the RecordsPublisher can hold, before further requests are blocked.
- maxRecordsCount() - Method in interface software.amazon.kinesis.retrieval.RecordsFetcherFactory
-
- mergeFrom(Message) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- mergeFrom(Messages.AggregatedRecord) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
- mergeFrom(Message) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- mergeFrom(Messages.Record) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
- mergeFrom(Message) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- mergeFrom(Messages.Tag) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
- message() - Method in class software.amazon.kinesis.coordinator.ExecutorStateEvent
-
- Messages - Class in software.amazon.kinesis.retrieval.kpl
-
- Messages.AggregatedRecord - Class in software.amazon.kinesis.retrieval.kpl
-
Protobuf type software.amazon.kinesis.retrieval.kpl.AggregatedRecord
- Messages.AggregatedRecord.Builder - Class in software.amazon.kinesis.retrieval.kpl
-
Protobuf type software.amazon.kinesis.retrieval.kpl.AggregatedRecord
- Messages.AggregatedRecordOrBuilder - Interface in software.amazon.kinesis.retrieval.kpl
-
- Messages.Record - Class in software.amazon.kinesis.retrieval.kpl
-
Protobuf type software.amazon.kinesis.retrieval.kpl.Record
- Messages.Record.Builder - Class in software.amazon.kinesis.retrieval.kpl
-
Protobuf type software.amazon.kinesis.retrieval.kpl.Record
- Messages.RecordOrBuilder - Interface in software.amazon.kinesis.retrieval.kpl
-
- Messages.Tag - Class in software.amazon.kinesis.retrieval.kpl
-
Protobuf type software.amazon.kinesis.retrieval.kpl.Tag
- Messages.Tag.Builder - Class in software.amazon.kinesis.retrieval.kpl
-
Protobuf type software.amazon.kinesis.retrieval.kpl.Tag
- Messages.TagOrBuilder - Interface in software.amazon.kinesis.retrieval.kpl
-
- METRIC_OPERATION_LEADER_DECIDER - Static variable in interface software.amazon.kinesis.coordinator.LeaderDecider
-
- METRIC_OPERATION_LEADER_DECIDER_IS_LEADER - Static variable in interface software.amazon.kinesis.coordinator.LeaderDecider
-
- MetricAccumulatingQueue<KeyType> - Class in software.amazon.kinesis.metrics
-
Helper class for accumulating MetricDatums with the same name and dimensions.
- MetricAccumulatingQueue(int) - Constructor for class software.amazon.kinesis.metrics.MetricAccumulatingQueue
-
- MetricDatumWithKey<KeyType> - Class in software.amazon.kinesis.metrics
-
This class is used to store a MetricDatum as well as KeyType which stores specific information about
that particular MetricDatum.
- MetricDatumWithKey() - Constructor for class software.amazon.kinesis.metrics.MetricDatumWithKey
-
- METRICS_ALWAYS_ENABLED_DIMENSIONS - Static variable in class software.amazon.kinesis.metrics.MetricsConfig
-
Metrics dimensions that always will be enabled regardless of the config provided by user.
- METRICS_ALWAYS_ENABLED_DIMENSIONS_WITH_SHARD_ID - Static variable in class software.amazon.kinesis.metrics.MetricsConfig
-
Allowed dimensions for CloudWatch metrics.
- METRICS_DIMENSIONS_ALL - Static variable in class software.amazon.kinesis.metrics.MetricsConfig
-
Metrics dimensions that signify all possible dimensions.
- METRICS_DIMENSIONS_ALL - Static variable in interface software.amazon.kinesis.metrics.MetricsScope
-
Value that signifies that all dimensions are allowed for the metrics scope.
- METRICS_OPERATION - Static variable in class software.amazon.kinesis.coordinator.migration.MigrationStateMachineImpl
-
- MetricsCollectingTaskDecorator - Class in software.amazon.kinesis.metrics
-
Decorates an ConsumerTask and reports metrics about its timing and success/failure.
- MetricsCollectingTaskDecorator(ConsumerTask, MetricsFactory) - Constructor for class software.amazon.kinesis.metrics.MetricsCollectingTaskDecorator
-
Constructor.
- metricsConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of MetricsConfig
- MetricsConfig - Class in software.amazon.kinesis.metrics
-
Used by KCL to configure the metrics reported by the application.
- MetricsConfig() - Constructor for class software.amazon.kinesis.metrics.MetricsConfig
-
- metricsFactory - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- metricsFactory() - Method in class software.amazon.kinesis.leases.LeaseManagementConfig
-
Deprecated.
- metricsFactory(MetricsFactory) - Method in class software.amazon.kinesis.leases.LeaseManagementConfig
-
Deprecated.
- metricsFactory() - Method in class software.amazon.kinesis.metrics.MetricsConfig
-
- MetricsFactory - Interface in software.amazon.kinesis.metrics
-
Factory for MetricsScope objects.
- MetricsLevel - Enum in software.amazon.kinesis.metrics
-
This class defines a set of standard metrics levels that can be used to control which metrics get emitted.
- MetricsScope - Interface in software.amazon.kinesis.metrics
-
An IMetricsScope represents a set of metric data that share a set of dimensions.
- MetricsUtil - Class in software.amazon.kinesis.metrics
-
- MetricsUtil() - Constructor for class software.amazon.kinesis.metrics.MetricsUtil
-
- MIGRATION_HASH_KEY - Static variable in class software.amazon.kinesis.coordinator.migration.MigrationState
-
Key value for the item in the CoordinatorState table
- MigrationAdaptiveLeaderDecider - Class in software.amazon.kinesis.leader
-
MigrationAdaptiveLeaderDecider that wraps around the actual LeaderDecider which can dynamically
change based on the MigrationStateMachine.
- MigrationAdaptiveLeaderDecider(MetricsFactory) - Constructor for class software.amazon.kinesis.leader.MigrationAdaptiveLeaderDecider
-
- MigrationAdaptiveLeaseAssignmentModeProvider - Class in software.amazon.kinesis.coordinator
-
Provides the lease assignment mode KCL must operate in during migration
from 2.x to 3.x.
- MigrationAdaptiveLeaseAssignmentModeProvider() - Constructor for class software.amazon.kinesis.coordinator.MigrationAdaptiveLeaseAssignmentModeProvider
-
- MigrationAdaptiveLeaseAssignmentModeProvider.LeaseAssignmentMode - Enum in software.amazon.kinesis.coordinator
-
- MigrationClientVersion2xState - Class in software.amazon.kinesis.coordinator.migration
-
State for CLIENT_VERSION_2X.
- MigrationClientVersion2xState() - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationClientVersion2xState
-
- MigrationClientVersion3xState - Class in software.amazon.kinesis.coordinator.migration
-
State for CLIENT_VERSION_3X which enables KCL to run 3.x algorithms on new KCLv3.x application
or successfully upgraded application which upgraded from v2.x.
- MigrationClientVersion3xState() - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationClientVersion3xState
-
- MigrationClientVersion3xWithRollbackState - Class in software.amazon.kinesis.coordinator.migration
-
State for CLIENT_VERSION_3X_WITH_ROLLBACK which enables KCL to run its 3.x compliant algorithms
during the upgrade process after all KCL workers in the fleet are 3.x complaint.
- MigrationClientVersion3xWithRollbackState() - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationClientVersion3xWithRollbackState
-
- MigrationClientVersionState - Interface in software.amazon.kinesis.coordinator.migration
-
Interface of a state implementation for the MigrationStateMachine
- MigrationClientVersionStateInitializer - Class in software.amazon.kinesis.coordinator.migration
-
Initializer to determine start state of the state machine which identifies the
state to initialize KCL when it is starting up.
- MigrationClientVersionStateInitializer() - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationClientVersionStateInitializer
-
- MigrationClientVersionUpgradeFrom2xState - Class in software.amazon.kinesis.coordinator.migration
-
State for CLIENT_VERSION_UPGRADE_FROM_2X.
- MigrationClientVersionUpgradeFrom2xState() - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationClientVersionUpgradeFrom2xState
-
- MigrationReadyMonitor - Class in software.amazon.kinesis.coordinator.migration
-
Monitor for KCL workers 3.x readiness.
- MigrationReadyMonitor(MetricsFactory, Callable<Long>, LeaderDecider, String, WorkerMetricStatsDAO, long, LeaseRefresher, ScheduledExecutorService, Runnable, long) - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationReadyMonitor
-
- MigrationState - Class in software.amazon.kinesis.coordinator.migration
-
Data model of the Migration state.
- MigrationState(String, String) - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationState
-
- MigrationState.HistoryEntry - Class in software.amazon.kinesis.coordinator.migration
-
- MigrationStateMachine - Interface in software.amazon.kinesis.coordinator.migration
-
State machine that provides:
1.
- MigrationStateMachineImpl - Class in software.amazon.kinesis.coordinator.migration
-
- MigrationStateMachineImpl(MetricsFactory, Callable<Long>, CoordinatorStateDAO, ScheduledExecutorService, CoordinatorConfig.ClientVersionConfig, Random, DynamicMigrationComponentsInitializer, String, long) - Constructor for class software.amazon.kinesis.coordinator.migration.MigrationStateMachineImpl
-
- MIN_IDLE_MILLIS_BETWEEN_READS - Static variable in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- MODIFIED_BY_ATTRIBUTE_NAME - Static variable in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- MODIFIED_TIMESTAMP_ATTRIBUTE_NAME - Static variable in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- MultipleSubscriberException - Exception in software.amazon.kinesis.retrieval.fanout
-
- MultipleSubscriberException() - Constructor for exception software.amazon.kinesis.retrieval.fanout.MultipleSubscriberException
-
- multiStreamInstance(String) - Static method in class software.amazon.kinesis.common.StreamIdentifier
-
- multiStreamInstance(Arn, long) - Static method in class software.amazon.kinesis.common.StreamIdentifier
-
Create a multi stream instance for StreamIdentifier from stream Arn
.
- MultiStreamLease - Class in software.amazon.kinesis.leases
-
- MultiStreamLease(MultiStreamLease) - Constructor for class software.amazon.kinesis.leases.MultiStreamLease
-
- MultiStreamTracker - Interface in software.amazon.kinesis.processor
-
Tracker for consuming multiple Kinesis streams.
- ParentsFirstShardPrioritization - Class in software.amazon.kinesis.leases
-
Shard Prioritization that prioritizes parent shards first.
- ParentsFirstShardPrioritization(int) - Constructor for class software.amazon.kinesis.leases.ParentsFirstShardPrioritization
-
Creates ParentFirst prioritization with filtering based on depth of the shard.
- parentShardIds() - Method in class software.amazon.kinesis.leases.Lease
-
- parentShardIds(Collection<String>) - Method in class software.amazon.kinesis.leases.Lease
-
Sets parentShardIds.
- parentShardIds() - Method in class software.amazon.kinesis.leases.ShardInfo
-
A list of shards that are parents of this shard.
- parseDelimitedFrom(InputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseDelimitedFrom(InputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseDelimitedFrom(InputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(ByteBuffer) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(ByteString) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(byte[]) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(InputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(CodedInputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parseFrom(ByteBuffer) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(ByteString) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(byte[]) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(InputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(CodedInputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parseFrom(ByteBuffer) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(ByteString) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(byte[]) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(InputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(CodedInputStream) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- parser() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- parser() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- parser() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- PARTITION_KEY_INDEX_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Record
-
- PARTITION_KEY_TABLE_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- pendingCheckpoint() - Method in class software.amazon.kinesis.checkpoint.DoesNothingPreparedCheckpointer
- pendingCheckpoint() - Method in class software.amazon.kinesis.checkpoint.ShardPreparedCheckpointer
- pendingCheckpoint(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.leases.Lease
-
Sets pending checkpoint.
- pendingCheckpoint() - Method in interface software.amazon.kinesis.processor.PreparedCheckpointer
-
- pendingCheckpointState(byte[]) - Method in class software.amazon.kinesis.leases.Lease
-
Sets pending checkpoint state.
- performAction(TableCreatorCallbackInput) - Method in interface software.amazon.kinesis.leases.dynamodb.TableCreatorCallback
-
Actions needed to be performed on the DynamoDB lease table once the table has been created and is in the ACTIVE
status.
- pitrEnabler(DdbTableConfig, DynamoDbAsyncClient) - Static method in class software.amazon.kinesis.utils.DdbUtil
-
- PollingConfig - Class in software.amazon.kinesis.retrieval.polling
-
- PollingConfig(KinesisAsyncClient) - Constructor for class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- PollingConfig(String, KinesisAsyncClient) - Constructor for class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- PrefetchRecordsPublisher - Class in software.amazon.kinesis.retrieval.polling
-
This is the prefetch caching class, this class spins up a thread if prefetching is enabled.
- PrefetchRecordsPublisher(int, int, int, int, GetRecordsRetrievalStrategy, ExecutorService, long, MetricsFactory, String, String, ThrottlingReporter, long) - Constructor for class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
Constructor for the PrefetchRecordsPublisher.
- PrefetchRecordsPublisher(int, int, int, int, GetRecordsRetrievalStrategy, ExecutorService, long, MetricsFactory, String, String, ThrottlingReporter) - Constructor for class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
Constructor for the PrefetchRecordsPublisher.
- prepareCheckpoint(String, ExtendedSequenceNumber, String) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- prepareCheckpoint(String, ExtendedSequenceNumber, String, byte[]) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- prepareCheckpoint() - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the last data record that was delivered to the record processor.
- prepareCheckpoint(byte[]) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the last data record that was delivered to the record processor.
- prepareCheckpoint(Record, byte[]) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the at the provided record.
- prepareCheckpoint(Record) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the at the provided record.
- prepareCheckpoint(String) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber.
- prepareCheckpoint(String, byte[]) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber.
- prepareCheckpoint(String, long) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber and subSequenceNumber, the latter for
aggregated records produced with the Producer Library.
- prepareCheckpoint(String, long, byte[]) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber and subSequenceNumber, the latter for
aggregated records produced with the Producer Library.
- prepareCheckpoint(String, ExtendedSequenceNumber, String) - Method in interface software.amazon.kinesis.processor.Checkpointer
-
Record intent to checkpoint for a shard.
- prepareCheckpoint(String, ExtendedSequenceNumber, String, byte[]) - Method in interface software.amazon.kinesis.processor.Checkpointer
-
Record intent to checkpoint for a shard.
- prepareCheckpoint() - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the last data record that was delivered to the record processor.
- prepareCheckpoint(byte[]) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the last data record that was delivered to the record processor.
- prepareCheckpoint(Record) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the at the provided record.
- prepareCheckpoint(Record, byte[]) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the at the provided record.
- prepareCheckpoint(String) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber.
- prepareCheckpoint(String, byte[]) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber.
- prepareCheckpoint(String, long) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber and subSequenceNumber, the latter for
aggregated records produced with the Producer Library.
- prepareCheckpoint(String, long, byte[]) - Method in interface software.amazon.kinesis.processor.RecordProcessorCheckpointer
-
This method will record a pending checkpoint at the provided sequenceNumber and subSequenceNumber, the latter for
aggregated records produced with the Producer Library.
- PreparedCheckpointer - Interface in software.amazon.kinesis.processor
-
Objects of this class are prepared to checkpoint at a specific sequence number.
- prioritize(List<ShardInfo>) - Method in class software.amazon.kinesis.leases.NoOpShardPrioritization
-
- prioritize(List<ShardInfo>) - Method in class software.amazon.kinesis.leases.ParentsFirstShardPrioritization
-
- prioritize(List<ShardInfo>) - Method in interface software.amazon.kinesis.leases.ShardPrioritization
-
Returns new list of shards ordered based on their priority.
- processorConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of ProcessorConfig
- ProcessorConfig - Class in software.amazon.kinesis.processor
-
Used by the KCL to configure the processor for processing the records.
- ProcessorConfig() - Constructor for class software.amazon.kinesis.processor.ProcessorConfig
-
- processRecords(ProcessRecordsInput) - Method in interface software.amazon.kinesis.processor.ShardRecordProcessor
-
Process data records.
- ProcessRecordsInput - Class in software.amazon.kinesis.lifecycle.events
-
Container for the parameters to the ShardRecordProcessor's
processRecords
method.
- ProcessRecordsInput() - Constructor for class software.amazon.kinesis.lifecycle.events.ProcessRecordsInput
-
- processRecordsInput() - Method in interface software.amazon.kinesis.retrieval.RecordsRetrieved
-
Retrieves the records that have been received via one of the publishers
- ProcessTask - Class in software.amazon.kinesis.lifecycle
-
Task for fetching data records and invoking processRecords() on the record processor instance.
- ProcessTask(ShardInfo, ShardRecordProcessor, ShardRecordProcessorCheckpointer, long, boolean, ShardDetector, ThrottlingReporter, ProcessRecordsInput, boolean, long, AggregatorUtil, MetricsFactory, SchemaRegistryDecoder, LeaseStatsRecorder) - Constructor for class software.amazon.kinesis.lifecycle.ProcessTask
-
- ProvidedStreamsDeferredDeletionStrategy() - Constructor for class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.ProvidedStreamsDeferredDeletionStrategy
-
- ProvisionedThroughputException - Exception in software.amazon.kinesis.leases.exceptions
-
Indicates that a lease operation has failed due to lack of provisioned throughput for a DynamoDB table.
- ProvisionedThroughputException(Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.ProvisionedThroughputException
-
- ProvisionedThroughputException(String, Throwable) - Constructor for exception software.amazon.kinesis.leases.exceptions.ProvisionedThroughputException
-
- publishMetrics(List<MetricDatumWithKey<CloudWatchMetricKey>>) - Method in class software.amazon.kinesis.metrics.CloudWatchMetricsPublisher
-
Given a list of MetricDatumWithKey, this method extracts the MetricDatum from each
MetricDatumWithKey and publishes those datums.
- purgeAllDeletedStream() - Method in class software.amazon.kinesis.coordinator.DeletedStreamListProvider
-
Method returns and empties the current set of streams
- putItem(PutItemRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- putUpdate(AttributeValue) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
-
- readSingleLineFile(String) - Static method in class software.amazon.kinesis.utils.Cgroup
-
- reconnectRequest(SubscribeToShardRequest.Builder, String, InitialPositionInStreamExtended) - Static method in class software.amazon.kinesis.retrieval.IteratorBuilder
-
- reconnectRequest(StartingPosition.Builder, String, InitialPositionInStreamExtended) - Static method in class software.amazon.kinesis.retrieval.IteratorBuilder
-
- reconnectRequest(GetShardIteratorRequest.Builder, String, InitialPositionInStreamExtended) - Static method in class software.amazon.kinesis.retrieval.IteratorBuilder
-
Creates a GetShardIteratorRequest builder that uses AFTER_SEQUENCE_NUMBER ShardIteratorType.
- RecordProcessorCheckpointer - Interface in software.amazon.kinesis.processor
-
Used by RecordProcessors when they want to checkpoint their progress.
- RECORDS_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
-
- RecordsDeliveryAck - Interface in software.amazon.kinesis.retrieval
-
Interface to supply all the meta information for record delivery ack.
- RecordsFetcherFactory - Interface in software.amazon.kinesis.retrieval
-
This factory is used to create the records fetcher to retrieve data from Kinesis for a given shard.
- RecordsPublisher - Interface in software.amazon.kinesis.retrieval
-
Provides a record publisher that will retrieve records from Kinesis for processing
- RecordsRetrieved - Interface in software.amazon.kinesis.retrieval
-
- recordStats(LeaseStatsRecorder.LeaseStats) - Method in class software.amazon.kinesis.leases.LeaseStatsRecorder
-
This method provides happens-before semantics (i.e., the action (access or removal) from a thread happens
before the action from subsequent thread) for the stats recording in multithreaded environment.
- registerAllExtensions(ExtensionRegistryLite) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages
-
- registerAllExtensions(ExtensionRegistry) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages
-
- registerStreamConsumerRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- releaseLeadershipIfHeld() - Method in interface software.amazon.kinesis.coordinator.LeaderDecider
-
If the current worker is the leader, then releases the leadership else does nothing.
- releaseLeadershipIfHeld() - Method in class software.amazon.kinesis.leader.DynamoDBLockBasedLeaderDecider
-
- removeRecords(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- removeTags(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- renewLease(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
Renew a lease by incrementing the lease counter.
- renewLease(Lease) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
-
Renew a lease by incrementing the lease counter.
- renewLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
-
Attempt to renew all currently held leases.
- renewLeases() - Method in interface software.amazon.kinesis.leases.LeaseRenewer
-
Attempt to renew all currently held leases.
- request(SubscribeToShardRequest.Builder, String, InitialPositionInStreamExtended) - Static method in class software.amazon.kinesis.retrieval.IteratorBuilder
-
- request(StartingPosition.Builder, String, InitialPositionInStreamExtended) - Static method in class software.amazon.kinesis.retrieval.IteratorBuilder
-
- request(GetShardIteratorRequest.Builder, String, InitialPositionInStreamExtended) - Static method in class software.amazon.kinesis.retrieval.IteratorBuilder
-
Creates a GetShardIteratorRequest builder that uses AT_SEQUENCE_NUMBER ShardIteratorType.
- RequestDetails - Class in software.amazon.kinesis.common
-
- RequestDetails() - Constructor for class software.amazon.kinesis.common.RequestDetails
-
- RequestDetails(String, String) - Constructor for class software.amazon.kinesis.common.RequestDetails
-
- requestShutdown() - Method in class software.amazon.kinesis.coordinator.Scheduler
-
Deprecated.
- resetIterator(String, String, InitialPositionInStreamExtended) - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Resets the iterator by setting shardIterator, sequenceNumber and the position in the stream.
- resetIterator(String, String, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
- resolveOrCancelFuture(Future<T>, Duration) - Static method in class software.amazon.kinesis.common.FutureUtils
-
- ResourceMetadataProvider - Interface in software.amazon.kinesis.worker.platform
-
Interface for providing resource metadata for worker.
- ResourceMetadataProvider.ComputePlatform - Enum in software.amazon.kinesis.worker.platform
-
Enum representing the different compute platforms.
- restartFrom(RecordsRetrieved) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
-
- restartFrom(RecordsRetrieved) - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
-
- restartFrom(RecordsRetrieved) - Method in class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
- restartFrom(RecordsRetrieved) - Method in interface software.amazon.kinesis.retrieval.RecordsPublisher
-
Restart from the last accepted and processed
- restartIterator() - Method in interface software.amazon.kinesis.retrieval.polling.DataFetcher
-
Gets a new iterator from the last known sequence number i.e.
- restartIterator() - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
-
Gets a new next shard iterator from last known sequence number i.e.
- retrievalConfig() - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
Creates a new instance of RetrievalConfig
- RetrievalConfig - Class in software.amazon.kinesis.retrieval
-
Used by the KCL to configure the retrieval of records from Kinesis.
- RetrievalConfig(KinesisAsyncClient, String, String) - Constructor for class software.amazon.kinesis.retrieval.RetrievalConfig
-
- RetrievalConfig(KinesisAsyncClient, Arn, String) - Constructor for class software.amazon.kinesis.retrieval.RetrievalConfig
-
- RetrievalConfig(KinesisAsyncClient, StreamTracker, String) - Constructor for class software.amazon.kinesis.retrieval.RetrievalConfig
-
- retrievalFactory() - Method in class software.amazon.kinesis.retrieval.fanout.FanOutConfig
-
- retrievalFactory() - Method in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- retrievalFactory() - Method in class software.amazon.kinesis.retrieval.RetrievalConfig
-
- RetrievalFactory - Interface in software.amazon.kinesis.retrieval
-
- retrievalFactory() - Method in interface software.amazon.kinesis.retrieval.RetrievalSpecificConfig
-
Creates and returns a retrieval factory for the specific configuration
- retrievalSpecificConfig(RetrievalSpecificConfig) - Method in class software.amazon.kinesis.retrieval.RetrievalConfig
-
- RetrievalSpecificConfig - Interface in software.amazon.kinesis.retrieval
-
- RetryableRetrievalException - Exception in software.amazon.kinesis.retrieval
-
RetryableException for SubscribeToShard APIs.
- RetryableRetrievalException(String) - Constructor for exception software.amazon.kinesis.retrieval.RetryableRetrievalException
-
- RetryableRetrievalException(String, Exception) - Constructor for exception software.amazon.kinesis.retrieval.RetryableRetrievalException
-
- run() - Method in class software.amazon.kinesis.coordinator.migration.ClientVersionChangeMonitor
-
- run() - Method in class software.amazon.kinesis.coordinator.migration.MigrationReadyMonitor
-
- run() - Method in class software.amazon.kinesis.coordinator.Scheduler
-
Start consuming data from the stream, and pass it to the application record processors.
- run() - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
- run() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsReporter
-
- runLeaseRenewer() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- runLeaseRenewer() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Runs a single iteration of the lease renewer - used by integration tests.
- runLeaseTaker() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- runLeaseTaker() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Runs a single iteration of the lease taker - used by integration tests.
- runOnce() - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
Exposed for testing purposes.
- safeGetByteArray(Map<String, AttributeValue>, String) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- safeGetDouble(Map<String, AttributeValue>, String) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- safeGetLong(Map<String, AttributeValue>, String) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- safeGetSS(Map<String, AttributeValue>, String) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- safeGetString(Map<String, AttributeValue>, String) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- safeGetString(AttributeValue) - Static method in class software.amazon.kinesis.leases.DynamoUtils
-
- scan(ScanRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- scanPaginator(ScanRequest) - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- Scheduler - Class in software.amazon.kinesis.coordinator
-
- Scheduler(CheckpointConfig, CoordinatorConfig, LeaseManagementConfig, LifecycleConfig, MetricsConfig, ProcessorConfig, RetrievalConfig) - Constructor for class software.amazon.kinesis.coordinator.Scheduler
-
- Scheduler(CheckpointConfig, CoordinatorConfig, LeaseManagementConfig, LifecycleConfig, MetricsConfig, ProcessorConfig, RetrievalConfig, DiagnosticEventFactory) - Constructor for class software.amazon.kinesis.coordinator.Scheduler
-
Customers do not currently have the ability to customize the DiagnosticEventFactory, but this visibility
is desired for testing.
- SchedulerCoordinatorFactory - Class in software.amazon.kinesis.coordinator
-
- SchedulerCoordinatorFactory() - Constructor for class software.amazon.kinesis.coordinator.SchedulerCoordinatorFactory
-
- SchemaRegistryDecoder - Class in software.amazon.kinesis.schemaregistry
-
Identifies and decodes Glue Schema Registry data from incoming KinesisClientRecords.
- SchemaRegistryDecoder(GlueSchemaRegistryDeserializer) - Constructor for class software.amazon.kinesis.schemaregistry.SchemaRegistryDecoder
-
- SentinelCheckpoint - Enum in software.amazon.kinesis.checkpoint
-
Enumeration of the sentinel values of checkpoints.
- sequenceNumber() - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
- sequenceNumberAtShardEnd(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
Used to remember the last extended sequence number before SHARD_END to allow us to prevent the checkpointer
from checkpointing at the end of the shard twice (i.e.
- SequenceNumberValidator - Class in software.amazon.kinesis.checkpoint
-
This supports extracting the shardId from a sequence number.
- SequenceNumberValidator() - Constructor for class software.amazon.kinesis.checkpoint.SequenceNumberValidator
-
- serialize() - Method in class software.amazon.kinesis.common.StreamIdentifier
-
Serialize the current StreamIdentifier instance.
- serialize() - Method in class software.amazon.kinesis.coordinator.migration.MigrationState.HistoryEntry
-
- serialize() - Method in class software.amazon.kinesis.coordinator.migration.MigrationState
-
- serializedEndingHashKey() - Method in class software.amazon.kinesis.common.HashKeyRangeForLease
-
Serialize the endingHashKey for persisting in external storage
- serializedStartingHashKey() - Method in class software.amazon.kinesis.common.HashKeyRangeForLease
-
Serialize the startingHashKey for persisting in external storage
- serializer - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
-
- serviceName() - Method in class software.amazon.kinesis.coordinator.DynamoDbAsyncToSyncClientAdapter
-
- setCheckpoint(String, ExtendedSequenceNumber, String) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- setCheckpoint(String, ExtendedSequenceNumber, UUID) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
-
- setCheckpoint(String, ExtendedSequenceNumber, String) - Method in interface software.amazon.kinesis.processor.Checkpointer
-
Record a checkpoint for a shard (e.g.
- setData(ByteString) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
required bytes data = 3;
- setExplicitHashKeyIndex(long) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
optional uint64 explicit_hash_key_index = 2;
- setExplicitHashKeyTable(int, String) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string explicit_hash_key_table = 2;
- setIdleTimeBetweenReadsInMillis(long) - Method in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
Deprecated.
- setInitialCheckpointValue(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
- setKey(String) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
required string key = 1;
- setKeyBytes(ByteString) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
required string key = 1;
- setPartitionKeyIndex(long) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
required uint64 partition_key_index = 1;
- setPartitionKeyTable(int, String) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated string partition_key_table = 1;
- setRecords(int, Messages.Record) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- setRecords(int, Messages.Record.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Record records = 3;
- setShardEndReached(boolean) - Method in class software.amazon.kinesis.lifecycle.TaskResult
-
- setTags(int, Messages.Tag) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- setTags(int, Messages.Tag.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
-
repeated .software.amazon.kinesis.retrieval.kpl.Tag tags = 4;
- setValue(String) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
optional string value = 2;
- setValueBytes(ByteString) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
-
optional string value = 2;
- shard(String) - Method in class software.amazon.kinesis.leases.KinesisShardDetector
-
- shard(String) - Method in interface software.amazon.kinesis.leases.ShardDetector
-
Gets shard based on shardId.
- SHARD_END - Static variable in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
Special value for SHARD_END.
- SHARD_ID_DIMENSION_NAME - Static variable in class software.amazon.kinesis.metrics.MetricsUtil
-
- ShardConsumer - Class in software.amazon.kinesis.lifecycle
-
Responsible for consuming data records of a (specified) shard.
- ShardConsumer(RecordsPublisher, ExecutorService, ShardInfo, Optional<Long>, ShardConsumerArgument, TaskExecutionListener, int) - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumer
-
- ShardConsumer(RecordsPublisher, ExecutorService, ShardInfo, Optional<Long>, ShardConsumerArgument, ConsumerState, int, TaskExecutionListener, int) - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumer
-
- ShardConsumer(RecordsPublisher, ExecutorService, ShardInfo, Optional<Long>, ShardConsumerArgument, ConsumerState, int, TaskExecutionListener, int, ConsumerTaskFactory) - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumer
-
- ShardConsumerArgument - Class in software.amazon.kinesis.lifecycle
-
- ShardConsumerArgument() - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumerArgument
-
- ShardConsumerNotifyingSubscriber - Class in software.amazon.kinesis.lifecycle
-
- ShardConsumerNotifyingSubscriber() - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumerNotifyingSubscriber
-
- ShardConsumerShutdownNotification - Class in software.amazon.kinesis.lifecycle
-
Contains callbacks for completion of stages in a requested record processor shutdown.
- ShardConsumerShutdownNotification(LeaseCoordinator, Lease, CountDownLatch, CountDownLatch) - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumerShutdownNotification
-
Creates a new shutdown request object.
- ShardDetector - Interface in software.amazon.kinesis.leases
-
- shardEnded(ShardEndedInput) - Method in interface software.amazon.kinesis.processor.ShardRecordProcessor
-
Called when the shard that this record process is handling has been completed.
- ShardEndedInput - Class in software.amazon.kinesis.lifecycle.events
-
Provides a checkpointer that must be used to signal the completion of the shard to the Scheduler.
- ShardEndedInput() - Constructor for class software.amazon.kinesis.lifecycle.events.ShardEndedInput
-
- shardIdFor(String) - Method in class software.amazon.kinesis.checkpoint.SequenceNumberValidator
-
Attempts to retrieve the shardId from a sequence number.
- ShardInfo - Class in software.amazon.kinesis.leases
-
Used to pass shard related info among different classes and as a key to the map of shard consumers.
- ShardInfo(String, String, Collection<String>, ExtendedSequenceNumber) - Constructor for class software.amazon.kinesis.leases.ShardInfo
-
Creates a new ShardInfo object.
- ShardInfo(String, String, Collection<String>, ExtendedSequenceNumber, String) - Constructor for class software.amazon.kinesis.leases.ShardInfo
-
Creates a new ShardInfo object that has an option to pass a serialized streamIdentifier.
- ShardPreparedCheckpointer - Class in software.amazon.kinesis.checkpoint
-
Objects of this class are prepared to checkpoint at a specific sequence number.
- ShardPreparedCheckpointer(ExtendedSequenceNumber, RecordProcessorCheckpointer) - Constructor for class software.amazon.kinesis.checkpoint.ShardPreparedCheckpointer
-
Constructor.
- ShardPrioritization - Interface in software.amazon.kinesis.leases
-
Provides logic to prioritize or filter shards before their execution.
- ShardRecordProcessor - Interface in software.amazon.kinesis.processor
-
The Amazon Kinesis Client Library will instantiate record processors to process data records fetched from Amazon
Kinesis.
- shardRecordProcessor() - Method in interface software.amazon.kinesis.processor.ShardRecordProcessorFactory
-
Returns a new instance of the ShardRecordProcessor
- shardRecordProcessor(StreamIdentifier) - Method in interface software.amazon.kinesis.processor.ShardRecordProcessorFactory
-
Returns a new instance of the ShardRecordProcessor for a stream identifier
- ShardRecordProcessorCheckpointer - Class in software.amazon.kinesis.checkpoint
-
This class is used to enable RecordProcessors to checkpoint their progress.
- ShardRecordProcessorCheckpointer() - Constructor for class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
-
- ShardRecordProcessorFactory - Interface in software.amazon.kinesis.processor
-
- ShardSyncer - Class in software.amazon.kinesis.leases.exceptions
-
Deprecated.
- ShardSyncer() - Constructor for class software.amazon.kinesis.leases.exceptions.ShardSyncer
-
Deprecated.
- ShardSyncTask - Class in software.amazon.kinesis.leases
-
This task syncs leases/activies with shards of the stream.
- ShardSyncTask() - Constructor for class software.amazon.kinesis.leases.ShardSyncTask
-
- ShardSyncTaskManager - Class in software.amazon.kinesis.leases
-
The ShardSyncTaskManager is used to track the task to sync shards with leases (create leases for new
Kinesis shards, remove obsolete leases).
- ShardSyncTaskManager(ShardDetector, LeaseRefresher, InitialPositionInStreamExtended, boolean, boolean, long, ExecutorService, MetricsFactory) - Constructor for class software.amazon.kinesis.leases.ShardSyncTaskManager
-
- ShardSyncTaskManager(ShardDetector, LeaseRefresher, InitialPositionInStreamExtended, boolean, boolean, long, ExecutorService, HierarchicalShardSyncer, MetricsFactory) - Constructor for class software.amazon.kinesis.leases.ShardSyncTaskManager
-
Constructor.
- shutdown() - Method in interface software.amazon.kinesis.coordinator.LeaderDecider
-
Can be invoked, if needed, to shutdown any clients/thread-pools
being used in the LeaderDecider implementation.
- shutdown() - Method in interface software.amazon.kinesis.coordinator.migration.MigrationStateMachine
-
Shutdown state machine and perform necessary cleanup for the worker to gracefully shutdown
- shutdown() - Method in class software.amazon.kinesis.coordinator.migration.MigrationStateMachineImpl
-
- shutdown() - Method in class software.amazon.kinesis.coordinator.Scheduler
-
Signals worker to shutdown.
- shutdown() - Method in class software.amazon.kinesis.leader.DynamoDBLockBasedLeaderDecider
-
Releases the lock if held by current worker when this method is invoked.
- shutdown() - Method in class software.amazon.kinesis.leader.MigrationAdaptiveLeaderDecider
-
- shutdown() - Method in class software.amazon.kinesis.leases.LeaseCleanupManager
-
- shutdown() - Method in class software.amazon.kinesis.metrics.CloudWatchMetricsFactory
-
- shutdown() - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
-
- shutdown() - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
-
- shutdown() - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetrievalStrategy
-
Releases any resources used by the strategy.
- shutdown() - Method in class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
-
- shutdown() - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
-
- shutdown() - Method in class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
- shutdown() - Method in class software.amazon.kinesis.retrieval.polling.SynchronousGetRecordsRetrievalStrategy
-
- shutdown() - Method in interface software.amazon.kinesis.retrieval.RecordsPublisher
-
Shutdowns the publisher.
- shutdownComplete() - Method in class software.amazon.kinesis.lifecycle.ShardConsumerShutdownNotification
-
- shutdownComplete() - Method in interface software.amazon.kinesis.lifecycle.ShutdownNotification
-
Used to indicate that the record processor has completed the call to
ShardRecordProcessor#shutdown(ShutdownInput)
has
completed.
- ShutdownException - Exception in software.amazon.kinesis.exceptions
-
The ShardRecordProcessor instance has been shutdown (e.g.
- ShutdownException(String) - Constructor for exception software.amazon.kinesis.exceptions.ShutdownException
-
- ShutdownException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.ShutdownException
-
- ShutdownInput - Class in software.amazon.kinesis.lifecycle
-
Container for the parameters to the IRecordProcessor's
shutdown
method.
- ShutdownInput() - Constructor for class software.amazon.kinesis.lifecycle.ShutdownInput
-
- ShutdownNotification - Interface in software.amazon.kinesis.lifecycle
-
A shutdown request to the ShardConsumer
- ShutdownNotificationAware - Interface in software.amazon.kinesis.processor
-
- shutdownNotificationComplete() - Method in class software.amazon.kinesis.lifecycle.ShardConsumerShutdownNotification
-
- shutdownNotificationComplete() - Method in interface software.amazon.kinesis.lifecycle.ShutdownNotification
-
Used to indicate that the record processor has been notified of a requested shutdown, and given the chance to
checkpoint.
- ShutdownNotificationTask - Class in software.amazon.kinesis.lifecycle
-
Notifies record processor of incoming shutdown request, and gives them a chance to checkpoint.
- ShutdownNotificationTask() - Constructor for class software.amazon.kinesis.lifecycle.ShutdownNotificationTask
-
- ShutdownReason - Enum in software.amazon.kinesis.lifecycle
-
Reason the ShardRecordProcessor is being shutdown.
- shutdownRequested() - Method in class software.amazon.kinesis.leases.Lease
-
- shutdownRequested(ShutdownRequestedInput) - Method in interface software.amazon.kinesis.processor.ShardRecordProcessor
-
Called when the Scheduler has been requested to shutdown.
- shutdownRequested(RecordProcessorCheckpointer) - Method in interface software.amazon.kinesis.processor.ShutdownNotificationAware
-
Deprecated.
Called when the worker has been requested to shutdown, and gives the record processor a chance to checkpoint.
- ShutdownRequestedInput - Class in software.amazon.kinesis.lifecycle.events
-
Provides access to a checkpointer so that
ShardRecordProcessor
's can checkpoint
before the lease is released during shutdown.
- ShutdownRequestedInput() - Constructor for class software.amazon.kinesis.lifecycle.events.ShutdownRequestedInput
-
- ShutdownTask - Class in software.amazon.kinesis.lifecycle
-
Task for invoking the ShardRecordProcessor shutdown() callback.
- ShutdownTask() - Constructor for class software.amazon.kinesis.lifecycle.ShutdownTask
-
- SimpleRecordsFetcherFactory - Class in software.amazon.kinesis.retrieval.polling
-
- SimpleRecordsFetcherFactory() - Constructor for class software.amazon.kinesis.retrieval.polling.SimpleRecordsFetcherFactory
-
- singleStreamInstance(String) - Static method in class software.amazon.kinesis.common.StreamIdentifier
-
Create a single stream instance for StreamIdentifier from stream name.
- singleStreamInstance(Arn) - Static method in class software.amazon.kinesis.common.StreamIdentifier
-
Create a single stream instance for StreamIdentifier from AWS Kinesis stream Arn
.
- SingleStreamTracker - Class in software.amazon.kinesis.processor
-
Tracker for consuming a single Kinesis stream.
- SingleStreamTracker(String) - Constructor for class software.amazon.kinesis.processor.SingleStreamTracker
-
- SingleStreamTracker(Arn) - Constructor for class software.amazon.kinesis.processor.SingleStreamTracker
-
- SingleStreamTracker(StreamIdentifier) - Constructor for class software.amazon.kinesis.processor.SingleStreamTracker
-
- SingleStreamTracker(StreamIdentifier, InitialPositionInStreamExtended) - Constructor for class software.amazon.kinesis.processor.SingleStreamTracker
-
- SingleStreamTracker(String, InitialPositionInStreamExtended) - Constructor for class software.amazon.kinesis.processor.SingleStreamTracker
-
- SingleStreamTracker(StreamIdentifier, StreamConfig) - Constructor for class software.amazon.kinesis.processor.SingleStreamTracker
-
- size() - Method in class software.amazon.kinesis.metrics.MetricAccumulatingQueue
-
- software.amazon.kinesis.annotations - package software.amazon.kinesis.annotations
-
- software.amazon.kinesis.checkpoint - package software.amazon.kinesis.checkpoint
-
- software.amazon.kinesis.checkpoint.dynamodb - package software.amazon.kinesis.checkpoint.dynamodb
-
- software.amazon.kinesis.common - package software.amazon.kinesis.common
-
- software.amazon.kinesis.coordinator - package software.amazon.kinesis.coordinator
-
- software.amazon.kinesis.coordinator.assignment - package software.amazon.kinesis.coordinator.assignment
-
- software.amazon.kinesis.coordinator.migration - package software.amazon.kinesis.coordinator.migration
-
- software.amazon.kinesis.exceptions - package software.amazon.kinesis.exceptions
-
- software.amazon.kinesis.exceptions.internal - package software.amazon.kinesis.exceptions.internal
-
- software.amazon.kinesis.leader - package software.amazon.kinesis.leader
-
- software.amazon.kinesis.leases - package software.amazon.kinesis.leases
-
- software.amazon.kinesis.leases.dynamodb - package software.amazon.kinesis.leases.dynamodb
-
- software.amazon.kinesis.leases.exceptions - package software.amazon.kinesis.leases.exceptions
-
- software.amazon.kinesis.lifecycle - package software.amazon.kinesis.lifecycle
-
- software.amazon.kinesis.lifecycle.events - package software.amazon.kinesis.lifecycle.events
-
- software.amazon.kinesis.metrics - package software.amazon.kinesis.metrics
-
- software.amazon.kinesis.processor - package software.amazon.kinesis.processor
-
- software.amazon.kinesis.retrieval - package software.amazon.kinesis.retrieval
-
- software.amazon.kinesis.retrieval.fanout - package software.amazon.kinesis.retrieval.fanout
-
- software.amazon.kinesis.retrieval.kpl - package software.amazon.kinesis.retrieval.kpl
-
- software.amazon.kinesis.retrieval.polling - package software.amazon.kinesis.retrieval.polling
-
- software.amazon.kinesis.schemaregistry - package software.amazon.kinesis.schemaregistry
-
- software.amazon.kinesis.utils - package software.amazon.kinesis.utils
-
- software.amazon.kinesis.worker - package software.amazon.kinesis.worker
-
- software.amazon.kinesis.worker.metric - package software.amazon.kinesis.worker.metric
-
- software.amazon.kinesis.worker.metric.impl.container - package software.amazon.kinesis.worker.metric.impl.container
-
- software.amazon.kinesis.worker.metric.impl.jmx - package software.amazon.kinesis.worker.metric.impl.jmx
-
- software.amazon.kinesis.worker.metric.impl.linux - package software.amazon.kinesis.worker.metric.impl.linux
-
- software.amazon.kinesis.worker.metricstats - package software.amazon.kinesis.worker.metricstats
-
- software.amazon.kinesis.worker.platform - package software.amazon.kinesis.worker.platform
-
- StackTraceUtils - Class in software.amazon.kinesis.common
-
- StackTraceUtils() - Constructor for class software.amazon.kinesis.common.StackTraceUtils
-
- start() - Method in class software.amazon.kinesis.coordinator.assignment.LeaseAssignmentManager
-
- start(MigrationAdaptiveLeaseAssignmentModeProvider) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- start() - Method in class software.amazon.kinesis.leases.LeaseCleanupManager
-
- start(MigrationAdaptiveLeaseAssignmentModeProvider) - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Start background LeaseHolder and LeaseTaker threads.
- start() - Method in class software.amazon.kinesis.lifecycle.LeaseGracefulShutdownHandler
-
Starts the shard consumer shutdown handler thread.
- start(ExtendedSequenceNumber, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
-
- start(ExtendedSequenceNumber, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
-
- start(ExtendedSequenceNumber, InitialPositionInStreamExtended) - Method in class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
- start(ExtendedSequenceNumber, InitialPositionInStreamExtended) - Method in interface software.amazon.kinesis.retrieval.RecordsPublisher
-
Initializes the publisher with where to start processing.
- startGracefulShutdown() - Method in class software.amazon.kinesis.coordinator.Scheduler
-
Requests a graceful shutdown of the worker, notifying record processors
of the impending shutdown.
- startManager() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsManager
-
- startMonitor() - Method in class software.amazon.kinesis.coordinator.migration.ClientVersionChangeMonitor
-
- startMonitor() - Method in class software.amazon.kinesis.coordinator.migration.MigrationReadyMonitor
-
- Statistics - Class in software.amazon.kinesis.utils
-
- Statistics() - Constructor for class software.amazon.kinesis.utils.Statistics
-
- stop() - Method in class software.amazon.kinesis.coordinator.assignment.LeaseAssignmentManager
-
- stop() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- stop() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Stops background threads and waits for specific amount of time for all background tasks to complete.
- stop() - Method in class software.amazon.kinesis.lifecycle.LeaseGracefulShutdownHandler
-
Stops the shard consumer shutdown handler thread.
- stopLeaseTaker() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
-
- stopLeaseTaker() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
-
Requests the cancellation of the lease taker.
- stopManager() - Method in class software.amazon.kinesis.worker.metricstats.WorkerMetricStatsManager
-
- STREAM_IDENTIFIER - Static variable in class software.amazon.kinesis.metrics.MetricsUtil
-
- StreamConfig - Class in software.amazon.kinesis.common
-
- StreamConfig() - Constructor for class software.amazon.kinesis.common.StreamConfig
-
- streamConfigList() - Method in class software.amazon.kinesis.processor.SingleStreamTracker
-
- streamConfigList() - Method in interface software.amazon.kinesis.processor.StreamTracker
-
Returns the list of stream config, to be processed by the current application.
- StreamIdentifier - Class in software.amazon.kinesis.common
-
- StreamIdentifier() - Constructor for class software.amazon.kinesis.common.StreamIdentifier
-
- streamIdentifier() - Method in interface software.amazon.kinesis.leases.ShardDetector
-
Gets stream identifier.
- streamIdentifiersForLeaseCleanup() - Method in class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.AutoDetectionAndDeferredDeletionStrategy
-
- streamIdentifiersForLeaseCleanup() - Method in class software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.NoLeaseDeletionStrategy
-
- streamIdentifiersForLeaseCleanup() - Method in interface software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy
-
StreamIdentifiers for which leases needs to be cleaned up in the lease table.
- streamTracker(StreamTracker) - Method in class software.amazon.kinesis.common.ConfigsBuilder
-
- StreamTracker - Interface in software.amazon.kinesis.processor
-
Interface for stream trackers.
- submitShardSyncTask() - Method in class software.amazon.kinesis.leases.ShardSyncTaskManager
-
Submit a ShardSyncTask and return if the submission is successful.
- subscribe(Subscriber<? super RecordsRetrieved>) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
-
- subscribe(Subscriber<? super RecordsRetrieved>) - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
-
- subscribe(Subscriber<? super RecordsRetrieved>) - Method in class software.amazon.kinesis.retrieval.polling.PrefetchRecordsPublisher
-
- subscribeToShardRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
-
- subSequenceNumber() - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
-
- success() - Method in class software.amazon.kinesis.retrieval.ThrottlingReporter
-
- SynchronousBlockingRetrievalFactory - Class in software.amazon.kinesis.retrieval.polling
-
- SynchronousBlockingRetrievalFactory(String, KinesisAsyncClient, RecordsFetcherFactory, int, Duration, Function<DataFetcherProviderConfig, DataFetcher>) - Constructor for class software.amazon.kinesis.retrieval.polling.SynchronousBlockingRetrievalFactory
-
- SynchronousGetRecordsRetrievalStrategy - Class in software.amazon.kinesis.retrieval.polling
-
- SynchronousGetRecordsRetrievalStrategy() - Constructor for class software.amazon.kinesis.retrieval.polling.SynchronousGetRecordsRetrievalStrategy
-
- validateAndCast(Lease) - Static method in class software.amazon.kinesis.leases.MultiStreamLease
-
Validate and cast the lease to MultiStream lease
- validateArn(Arn) - Static method in class software.amazon.kinesis.common.StreamIdentifier
-
Verify the streamArn follows the appropriate formatting.
- validateSequenceNumberForShard(String, String) - Method in class software.amazon.kinesis.checkpoint.SequenceNumberValidator
-
Validates that the sequence number provided contains the given shardId.
- validateState(boolean) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutConfig
-
- validateState(boolean) - Method in class software.amazon.kinesis.retrieval.polling.PollingConfig
-
- validateState(boolean) - Method in interface software.amazon.kinesis.retrieval.RetrievalSpecificConfig
-
- VALUE_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
-
- valueOf(String) - Static method in enum software.amazon.kinesis.checkpoint.SentinelCheckpoint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.common.InitialPositionInStream
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.coordinator.CoordinatorConfig.ClientVersionConfig
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.coordinator.migration.ClientVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.coordinator.MigrationAdaptiveLeaseAssignmentModeProvider.LeaseAssignmentMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.coordinator.WorkerStateChangeListener.WorkerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.leases.UpdateField
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.lifecycle.ShutdownReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.lifecycle.TaskOutcome
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.lifecycle.TaskType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.metrics.MetricsLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.StreamsLeasesDeletionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.retrieval.DataFetchingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.worker.metric.WorkerMetricType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.worker.platform.OperatingRangeDataProvider
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum software.amazon.kinesis.worker.platform.ResourceMetadataProvider.ComputePlatform
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum software.amazon.kinesis.checkpoint.SentinelCheckpoint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.common.InitialPositionInStream
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.coordinator.CoordinatorConfig.ClientVersionConfig
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.coordinator.migration.ClientVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.coordinator.MigrationAdaptiveLeaseAssignmentModeProvider.LeaseAssignmentMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.coordinator.WorkerStateChangeListener.WorkerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.leases.UpdateField
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.lifecycle.ShutdownReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.lifecycle.TaskOutcome
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.lifecycle.TaskType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.metrics.MetricsLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.processor.FormerStreamsLeasesDeletionStrategy.StreamsLeasesDeletionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.retrieval.DataFetchingStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.worker.metric.WorkerMetricType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.worker.platform.OperatingRangeDataProvider
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum software.amazon.kinesis.worker.platform.ResourceMetadataProvider.ComputePlatform
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VarianceBasedLeaseAssignmentDecider - Class in software.amazon.kinesis.coordinator.assignment
-
VarianceBasedLeaseAssignmentDecider
This implementation of LeaseAssignmentDecider performs lease assignment by considering the WorkerMetricStats values of workers
with respect to fleet level average of that WorkerMetricStats.
- VarianceBasedLeaseAssignmentDecider(LeaseAssignmentManager.InMemoryStorageView, int, int, boolean) - Constructor for class software.amazon.kinesis.coordinator.assignment.VarianceBasedLeaseAssignmentDecider
-
- VERSION - Static variable in class software.amazon.kinesis.common.KinesisClientLibraryPackage
-
- VERSION - Static variable in class software.amazon.kinesis.common.KinesisClientLibraryPackage
-
- versionFor(String) - Method in class software.amazon.kinesis.checkpoint.SequenceNumberValidator
-
Attempts to retrieve the version for a sequence number.