Skip navigation links
A B C D E F G H I K L M N O P R S T U V W 

A

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
 
add(Class<T>, Function<T, RuntimeException>) - Method in class software.amazon.kinesis.retrieval.AWSExceptionManager
 
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 .Record records = 3;
addAllTags(Iterable<? extends Messages.Tag>) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
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;
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 .Record records = 3;
addRecords(int, Messages.Record) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
addRecords(Messages.Record.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
addRecords(int, Messages.Record.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
addRecordsBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
addRecordsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
addShardId(MetricsScope, String) - 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 .Tag tags = 4;
addTags(int, Messages.Tag) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
addTags(Messages.Tag.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
addTags(int, Messages.Tag.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
addTagsBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
addTagsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
addWorkerIdentifier(MetricsScope, String) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
 
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.
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
 
apply(Throwable) - Method in class software.amazon.kinesis.retrieval.AWSExceptionManager
 
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.
AWSExceptionManager - Class in software.amazon.kinesis.retrieval
 
AWSExceptionManager() - Constructor for class software.amazon.kinesis.retrieval.AWSExceptionManager
 

B

BlockedOnParentShardException - Exception in software.amazon.kinesis.exceptions.internal
Used internally in the Amazon Kinesis Client Library.
BlockedOnParentShardException(String) - Constructor for exception software.amazon.kinesis.exceptions.internal.BlockedOnParentShardException
Constructor.
BlockedOnParentShardException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.internal.BlockedOnParentShardException
Constructor.
BlockingRecordsPublisher - Class in software.amazon.kinesis.retrieval.polling
This is the BlockingRecordsPublisher class.
BlockingRecordsPublisher(int, GetRecordsRetrievalStrategy) - Constructor for class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
 
BlockOnParentShardTask - Class in software.amazon.kinesis.lifecycle
Task to block until processing of all data records in the parent shard(s) is completed.
BlockOnParentShardTask() - Constructor for class software.amazon.kinesis.lifecycle.BlockOnParentShardTask
 
build() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
 
build() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
 
build() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
 
buildConsumer(ShardInfo, ShardRecordProcessorFactory) - Method in class software.amazon.kinesis.coordinator.Scheduler
 
buildPartial() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
 
buildPartial() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
 
buildPartial() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
 

C

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.
canTransitionTo(ShutdownReason) - Method in enum software.amazon.kinesis.lifecycle.ShutdownReason
Indicates whether the given reason can override the current reason.
checkAndCreateLeasesForNewShards(ShardDetector, LeaseRefresher, InitialPositionInStreamExtended, boolean, boolean, MetricsScope) - Static method in class software.amazon.kinesis.leases.ShardSyncer
Check and create leases for any new shards (e.g.
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
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
 
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 .Record records = 3;
clearTags() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
clearValue() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
optional string value = 2;
clone() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
 
clone() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
 
clone() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
 
CloudWatchMetricKey - Class in software.amazon.kinesis.metrics
 
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
 
compareTo(ExtendedSequenceNumber) - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
Compares this with another ExtendedSequenceNumber using these rules.
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() - Constructor for class software.amazon.kinesis.common.ConfigsBuilder
 
consistentReads - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
 
ConsumerRegistration - Interface in software.amazon.kinesis.retrieval
 
ConsumerTask - Interface in software.amazon.kinesis.lifecycle
Interface for shard processing tasks.
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
 
convertRecordToKinesisClientRecord(KinesisClientRecord, boolean, long, String) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
 
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() - Constructor for class software.amazon.kinesis.coordinator.CoordinatorConfig
 
CoordinatorFactory - Interface in software.amazon.kinesis.coordinator
Used in the process of configuring and providing instances to the Scheduler
copy() - Method in class software.amazon.kinesis.leases.Lease
Returns a deep copy of this object.
createAttributeValue(Collection<String>) - 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
 
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
 
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, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutRetrievalFactory
 
createGetRecordsCache(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRetrievalFactory
 
createGetRecordsCache(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.polling.SynchronousBlockingRetrievalFactory
 
createGetRecordsCache(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.polling.SynchronousPrefetchingRetrievalFactory
 
createGetRecordsCache(ShardInfo, MetricsFactory) - Method in interface software.amazon.kinesis.retrieval.RetrievalFactory
 
createGetRecordsRetrievalStrategy(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutRetrievalFactory
 
createGetRecordsRetrievalStrategy(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRetrievalFactory
 
createGetRecordsRetrievalStrategy(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.polling.SynchronousBlockingRetrievalFactory
 
createGetRecordsRetrievalStrategy(ShardInfo, MetricsFactory) - Method in class software.amazon.kinesis.retrieval.polling.SynchronousPrefetchingRetrievalFactory
 
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.
createKinesisAsyncClient(KinesisAsyncClientBuilder) - Static method in class software.amazon.kinesis.common.KinesisClientUtil
Creates a client from a builder.
createLeaseCoordinator(MetricsFactory) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
 
createLeaseCoordinator(MetricsFactory) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
 
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.
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(Long, Long) - 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
 
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() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
 
createShardDetector() - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
 
createShardSyncTaskManager(MetricsFactory) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
 
createShardSyncTaskManager(MetricsFactory) - Method in interface software.amazon.kinesis.leases.LeaseManagementFactory
 
createWorkerStateChangeListener() - Method in interface software.amazon.kinesis.coordinator.CoordinatorFactory
Deprecated.

D

data - Variable in class software.amazon.kinesis.metrics.AccumulatingMetricsScope
 
DATA_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
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
 
datum - Variable in class software.amazon.kinesis.metrics.MetricDatumWithKey
Data point
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.
DEFAULT_INITIAL_LEASE_TABLE_READ_CAPACITY - Static variable in class software.amazon.kinesis.leases.dynamodb.TableConstants
Deprecated.
 
DEFAULT_INITIAL_LEASE_TABLE_WRITE_CAPACITY - Static variable in class software.amazon.kinesis.leases.dynamodb.TableConstants
Deprecated.
 
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.
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.
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
 
describeStreamConsumerRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
 
describeStreamSummaryRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
 
DimensionTrackingMetricsScope - Class in software.amazon.kinesis.metrics
DimensionTrackingMetricsScope is where we provide functionality for dimensions.
DimensionTrackingMetricsScope() - Constructor for class software.amazon.kinesis.metrics.DimensionTrackingMetricsScope
 
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.
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, long, int, int, int, MetricsFactory) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
Deprecated.
DynamoDBLeaseCoordinator(LeaseRefresher, String, long, long, int, int, int, long, long, MetricsFactory) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
Constructor.
DynamoDBLeaseManagementFactory - Class in software.amazon.kinesis.leases.dynamodb
 
DynamoDBLeaseManagementFactory(KinesisAsyncClient, String, DynamoDbAsyncClient, String, String, ExecutorService, InitialPositionInStreamExtended, long, long, int, int, int, boolean, boolean, long, boolean, long, int, int, long, int) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
Deprecated.
DynamoDBLeaseManagementFactory(KinesisAsyncClient, String, DynamoDbAsyncClient, String, String, ExecutorService, InitialPositionInStreamExtended, long, long, int, int, int, boolean, boolean, long, boolean, long, int, int, long, int, long, long) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseManagementFactory
Constructor.
DynamoDBLeaseRefresher - Class in software.amazon.kinesis.leases.dynamodb
An implementation of LeaseRefresher that uses DynamoDB.
DynamoDBLeaseRefresher() - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
 
DynamoDBLeaseRenewer - Class in software.amazon.kinesis.leases.dynamodb
An implementation of LeaseRenewer that uses DynamoDB via LeaseRefresher.
DynamoDBLeaseRenewer(LeaseRefresher, String, long, ExecutorService, MetricsFactory) - 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
An implementation of LeaseTaker that uses DynamoDB via LeaseRefresher.
DynamoDBLeaseTaker(LeaseRefresher, String, long, MetricsFactory) - Constructor for class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
 
DynamoUtils - Class in software.amazon.kinesis.leases
Static utility functions used by our LeaseSerializers.
DynamoUtils() - Constructor for class software.amazon.kinesis.leases.DynamoUtils
 

E

effectiveHashKey(String, String) - Method in class software.amazon.kinesis.retrieval.AggregatorUtil
 
end() - Method in class software.amazon.kinesis.metrics.CloudWatchMetricsScope
Once we call this method, all MetricDatums added to the scope will be enqueued to the publisher runnable.
end() - Method in class software.amazon.kinesis.metrics.EndingMetricsScope
 
end() - Method in class software.amazon.kinesis.metrics.LogMetricsScope
 
end() - Method in interface software.amazon.kinesis.metrics.MetricsScope
Flushes the data from this IMetricsScope and causes future calls to addData and addDimension to fail.
end() - Method in class software.amazon.kinesis.metrics.NullMetricsScope
 
end() - Method in class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingScope
Flushes the data from this IMetricsScope and causes future calls to addData and addDimension to fail.
EndingMetricsScope - Class in software.amazon.kinesis.metrics
 
EndingMetricsScope() - Constructor for class software.amazon.kinesis.metrics.EndingMetricsScope
 
endScope(MetricsScope) - Static method in class software.amazon.kinesis.metrics.MetricsUtil
 
enqueue(Collection<MetricDatumWithKey<CloudWatchMetricKey>>) - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
Enqueues metric data for publication.
epsilonMillis - Variable in class software.amazon.kinesis.leases.LeaseManagementConfig
 
equals(Object) - Method in class software.amazon.kinesis.leases.ShardInfo
This method assumes parentShardIds is ordered.
equals(Object) - Method in class software.amazon.kinesis.metrics.CloudWatchMetricKey
 
equals(Object) - Method in class software.amazon.kinesis.metrics.MetricDatumWithKey
 
equals(Object) - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
 
evictLease(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
Evict the current owner of lease by setting owner to null.
evictLease(Lease) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
Evict the current owner of lease by setting owner to null.
executeLifecycle() - Method in class software.amazon.kinesis.lifecycle.ShardConsumer
 
ExperimentalFanOutConfig - Class in software.amazon.kinesis.retrieval.fanout.experimental
Enables validation of sequence number for every received record.
ExperimentalFanOutConfig(KinesisAsyncClient) - Constructor for class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutConfig
 
ExperimentalFanOutRecordsPublisher - Class in software.amazon.kinesis.retrieval.fanout.experimental
A variation of FanOutRecordsPublisher that provides validation of every record received by the publisher.
ExperimentalFanOutRecordsPublisher(KinesisAsyncClient, String, String) - Constructor for class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutRecordsPublisher
Creates a new FanOutRecordsPublisher.
ExperimentalFanOutRetrievalFactory - Class in software.amazon.kinesis.retrieval.fanout.experimental
Supports validating that records did originate from the shard.
ExperimentalFanOutRetrievalFactory() - Constructor for class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutRetrievalFactory
 
EXPLICIT_HASH_KEY_INDEX_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
EXPLICIT_HASH_KEY_TABLE_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
ExtendedSequenceNumber - Class in software.amazon.kinesis.retrieval.kpl
Represents a two-part sequence number for records aggregated by the Kinesis Producer Library.
ExtendedSequenceNumber(String) - Constructor for class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
Construct an ExtendedSequenceNumber.
ExtendedSequenceNumber(String, Long) - Constructor for class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
Construct an ExtendedSequenceNumber.

F

FanOutConfig - Class in software.amazon.kinesis.retrieval.fanout
 
FanOutConfig() - Constructor for class software.amazon.kinesis.retrieval.fanout.FanOutConfig
 
FanOutConsumerRegistration - Class in software.amazon.kinesis.retrieval.fanout
 
FanOutConsumerRegistration() - Constructor for class software.amazon.kinesis.retrieval.fanout.FanOutConsumerRegistration
 
FanOutRecordsPublisher - Class in software.amazon.kinesis.retrieval.fanout
 
FanOutRecordsPublisher(KinesisAsyncClient, String, String) - Constructor for class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
Creates a new FanOutRecordsPublisher.
FanOutRetrievalFactory - Class in software.amazon.kinesis.retrieval.fanout
 
FanOutRetrievalFactory() - Constructor for class software.amazon.kinesis.retrieval.fanout.FanOutRetrievalFactory
 
FilteringMetricsScope - Class in software.amazon.kinesis.metrics
FilteringMetricsScope() - Constructor for class software.amazon.kinesis.metrics.FilteringMetricsScope
Creates a metrics scope that allows all metrics data and dimensions.
FilteringMetricsScope(MetricsLevel, Set<String>) - Constructor for class software.amazon.kinesis.metrics.FilteringMetricsScope
Creates a metrics scope that drops data with level below the given enabled level and only allows dimensions that are part of the given enabled dimensions list.
fromDynamoRecord(Map<String, AttributeValue>) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
 
fromDynamoRecord(Map<String, AttributeValue>) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
Construct a Lease object out of a DynamoDB record.
fromName(String) - Static method in enum software.amazon.kinesis.metrics.MetricsLevel
Returns metrics level associated with the given name.
fromRecord(Record) - Static method in class software.amazon.kinesis.retrieval.KinesisClientRecord
 

G

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
 
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.
getCurrentAssignments() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
 
getCurrentAssignments() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
 
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 the KinesisDataFetcher 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
 
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
 
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
 
getDynamoEvictLeaseUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
 
getDynamoEvictLeaseUpdate(Lease) - 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
Special getDynamoHashKey implementation used by LeaseRefresher.getLease(String).
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
 
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
 
getDynamoUpdateLeaseUpdate(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
 
getDynamoUpdateLeaseUpdate(Lease) - 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;
getInitialPositionInStream() - Method in class software.amazon.kinesis.common.InitialPositionInStreamExtended
Get the initial position in the stream where the application should start from.
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
 
getLease(String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
getLease(String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
 
getLog() - Method in class software.amazon.kinesis.retrieval.ThrottlingReporter
 
getName() - Method in enum software.amazon.kinesis.metrics.MetricsLevel
Returns the name for this metrics level.
getNextRecords(int) - Method in interface software.amazon.kinesis.retrieval.GetRecordsRetriever
 
getNextResult() - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
 
getOrCreateConsumerArn() - Method in class software.amazon.kinesis.retrieval.fanout.FanOutConfig
 
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;
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 .Record records = 3;
getRecords(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
repeated .Record records = 3;
getRecords(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
repeated .Record records = 3;
getRecords(int) - Method in class software.amazon.kinesis.retrieval.polling.AsynchronousGetRecordsRetrievalStrategy
 
getRecords() - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
Get records from the current position in the stream (up to maxRecords).
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 .Record records = 3;
getRecordsBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
getRecordsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
getRecordsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
repeated .Record records = 3;
getRecordsCount() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
repeated .Record records = 3;
getRecordsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
getRecordsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
repeated .Record records = 3;
getRecordsList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
repeated .Record records = 3;
getRecordsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
getRecordsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
repeated .Record records = 3;
getRecordsOrBuilder(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
repeated .Record records = 3;
getRecordsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
getRecordsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
repeated .Record records = 3;
getRecordsOrBuilderList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecordOrBuilder
repeated .Record records = 3;
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.
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
 
getShardIteratorRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
 
getTags(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTags(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
repeated .Tag tags = 4;
getTags(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
repeated .Tag tags = 4;
getTagsBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTagsBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTagsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTagsCount() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
repeated .Tag tags = 4;
getTagsCount() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
repeated .Tag tags = 4;
getTagsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTagsList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
repeated .Tag tags = 4;
getTagsList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
repeated .Tag tags = 4;
getTagsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTagsOrBuilder(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
repeated .Tag tags = 4;
getTagsOrBuilder(int) - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
repeated .Tag tags = 4;
getTagsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .Tag tags = 4;
getTagsOrBuilderList() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
repeated .Tag tags = 4;
getTagsOrBuilderList() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
repeated .Tag tags = 4;
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.
getUnknownFields() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
getUnknownFields() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
getUnknownFields() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
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
 
gracefuleShutdownStarted - Variable in class software.amazon.kinesis.coordinator.Scheduler
 
gracefulShutdown(ShutdownNotification) - Method in class software.amazon.kinesis.lifecycle.ShardConsumer
Requests the shutdown of the this ShardConsumer.

H

hasData() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
required bytes data = 3;
hasData() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
required bytes data = 3;
hasData() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
required bytes data = 3;
hasExplicitHashKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
optional uint64 explicit_hash_key_index = 2;
hasExplicitHashKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
optional uint64 explicit_hash_key_index = 2;
hasExplicitHashKeyIndex() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
optional uint64 explicit_hash_key_index = 2;
hasGracefulShutdownStarted() - Method in class software.amazon.kinesis.coordinator.Scheduler
 
hashCode() - Method in class software.amazon.kinesis.leases.ShardInfo
hashCode() - Method in class software.amazon.kinesis.metrics.CloudWatchMetricKey
 
hashCode() - Method in class software.amazon.kinesis.metrics.MetricDatumWithKey
 
hashCode() - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
 
hasKey() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
required string key = 1;
hasKey() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
required string key = 1;
hasKey() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.TagOrBuilder
required string key = 1;
hasPartitionKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
required uint64 partition_key_index = 1;
hasPartitionKeyIndex() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
required uint64 partition_key_index = 1;
hasPartitionKeyIndex() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.RecordOrBuilder
required uint64 partition_key_index = 1;
hasValue() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag.Builder
optional string value = 2;
hasValue() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
optional string value = 2;
hasValue() - Method in interface software.amazon.kinesis.retrieval.kpl.Messages.TagOrBuilder
optional string value = 2;

I

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
 
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.leases.dynamodb.DynamoDBLeaseCoordinator
 
initialize() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
Bootstrap initial set of leases from the LeaseRefresher (e.g.
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
Bootstrap initial set of leases from the LeaseRefresher (e.g.
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 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
 
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.
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
 
isCompleted() - Method in class software.amazon.kinesis.leases.ShardInfo
Whether the shard has been completely processed or not.
isEmpty() - Method in class software.amazon.kinesis.metrics.MetricAccumulatingQueue
 
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
 
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.
isRunning() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
 
isRunning() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
 
isShardEnd() - Method in interface software.amazon.kinesis.retrieval.DataFetcherResult
Indicates whether this result is at the end of the shard or not
isShardEndReached() - Method in class software.amazon.kinesis.lifecycle.TaskResult
 
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
 
IteratorBuilder - Class in software.amazon.kinesis.retrieval
 
IteratorBuilder() - Constructor for class software.amazon.kinesis.retrieval.IteratorBuilder
 

K

key - Variable in class software.amazon.kinesis.metrics.MetricDatumWithKey
An object that stores relevant information about a MetricDatum (e.g.
KEY_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
KINESIS_CLIENT_LIB_USER_AGENT - Static variable in class software.amazon.kinesis.retrieval.RetrievalConfig
User agent set when Amazon Kinesis Client Library makes AWS requests.
KINESIS_CLIENT_LIB_USER_AGENT_VERSION - Static variable in class software.amazon.kinesis.retrieval.RetrievalConfig
 
KinesisClientExperimental - Annotation Type in software.amazon.kinesis.annotations
Anything marked as experimental may be removed at any time without warning.
KinesisClientInternalApi - Annotation Type in software.amazon.kinesis.annotations
Any class/method/variable marked with this annotation is subject to breaking changes between minor releases.
KinesisClientLibDependencyException - Exception in software.amazon.kinesis.exceptions
This is thrown when the Amazon Kinesis Client Library encounters issues talking to its dependencies (e.g.
KinesisClientLibDependencyException(String) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibDependencyException
 
KinesisClientLibDependencyException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibDependencyException
 
KinesisClientLibException - Exception in software.amazon.kinesis.exceptions
Abstract class for exceptions of the Amazon Kinesis Client Library.
KinesisClientLibException(String) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibException
Constructor.
KinesisClientLibException(String, Throwable) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibException
Constructor.
KinesisClientLibIOException - Exception in software.amazon.kinesis.exceptions.internal
Thrown when we encounter issues when reading/writing information (e.g.
KinesisClientLibIOException(String) - Constructor for exception software.amazon.kinesis.exceptions.internal.KinesisClientLibIOException
Constructor.
KinesisClientLibIOException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.internal.KinesisClientLibIOException
Constructor.
KinesisClientLibNonRetryableException - Exception in software.amazon.kinesis.exceptions
Non-retryable exceptions.
KinesisClientLibNonRetryableException(String) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibNonRetryableException
Constructor.
KinesisClientLibNonRetryableException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibNonRetryableException
Constructor.
KinesisClientLibRetryableException - Exception in software.amazon.kinesis.exceptions
Retryable exceptions (e.g.
KinesisClientLibRetryableException(String) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibRetryableException
Constructor.
KinesisClientLibRetryableException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.KinesisClientLibRetryableException
Constructor.
KinesisClientRecord - Class in software.amazon.kinesis.retrieval
A converted record from Kinesis, maybe an aggregate record.
KinesisClientRecord() - Constructor for class software.amazon.kinesis.retrieval.KinesisClientRecord
 
KinesisClientUtil - Class in software.amazon.kinesis.common
Utility to setup KinesisAsyncClient to be used with KCL.
KinesisClientUtil() - Constructor for class software.amazon.kinesis.common.KinesisClientUtil
 
KinesisDataFetcher - Class in software.amazon.kinesis.retrieval.polling
Used to get data from Amazon Kinesis.
KinesisDataFetcher() - Constructor for class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
 
KinesisRequestsBuilder - Class in software.amazon.kinesis.common
 
KinesisRequestsBuilder() - Constructor for class software.amazon.kinesis.common.KinesisRequestsBuilder
 
KinesisShardDetector - Class in software.amazon.kinesis.leases
 
KinesisShardDetector() - Constructor for class software.amazon.kinesis.leases.KinesisShardDetector
 

L

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.
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
 
LeaseCoordinator - Interface in software.amazon.kinesis.leases
 
leaseCounter(Long) - Method in class software.amazon.kinesis.leases.Lease
Sets leaseCounter.
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
Provides data, and interaction about the loss of a lease to a ShardRecordProcessor.
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() - Constructor for class software.amazon.kinesis.leases.LeaseManagementConfig
 
leaseManagementFactory() - Method in class software.amazon.kinesis.leases.LeaseManagementConfig
 
LeaseManagementFactory - Interface in software.amazon.kinesis.leases
 
leaseOwner(String) - Method in class software.amazon.kinesis.leases.Lease
Sets leaseOwner.
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.
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
 
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
 
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.
listShards() - Method in class software.amazon.kinesis.leases.KinesisShardDetector
 
listShards() - Method in interface software.amazon.kinesis.leases.ShardDetector
 
listShardsRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
 
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
 

M

makeReport(Map<String, Integer>) - Method in class software.amazon.kinesis.common.MismatchedRecordReporter
 
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
 
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
 
Messages - Class in software.amazon.kinesis.retrieval.kpl
 
Messages.AggregatedRecord - Class in software.amazon.kinesis.retrieval.kpl
Protobuf type AggregatedRecord
Messages.AggregatedRecord.Builder - Class in software.amazon.kinesis.retrieval.kpl
Protobuf type AggregatedRecord
Messages.AggregatedRecordOrBuilder - Interface in software.amazon.kinesis.retrieval.kpl
 
Messages.Record - Class in software.amazon.kinesis.retrieval.kpl
Protobuf type Record
Messages.Record.Builder - Class in software.amazon.kinesis.retrieval.kpl
Protobuf type Record
Messages.RecordOrBuilder - Interface in software.amazon.kinesis.retrieval.kpl
 
Messages.Tag - Class in software.amazon.kinesis.retrieval.kpl
Protobuf type Tag
Messages.Tag.Builder - Class in software.amazon.kinesis.retrieval.kpl
Protobuf type Tag
Messages.TagOrBuilder - Interface in software.amazon.kinesis.retrieval.kpl
 
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.
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
 
MismatchedRecordReporter - Class in software.amazon.kinesis.common
 
MismatchedRecordReporter() - Constructor for class software.amazon.kinesis.common.MismatchedRecordReporter
 
MultipleSubscriberException - Exception in software.amazon.kinesis.retrieval.fanout
 
MultipleSubscriberException() - Constructor for exception software.amazon.kinesis.retrieval.fanout.MultipleSubscriberException
 

N

namespace() - Method in class software.amazon.kinesis.common.ConfigsBuilder
CloudWatch namespace for KCL metrics.
newBuilder() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
newBuilder(Messages.AggregatedRecord) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
newBuilder() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
newBuilder(Messages.Record) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
newBuilder() - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
newBuilder(Messages.Tag) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
newBuilderForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
newBuilderForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
newBuilderForType() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
newBuilderForType(GeneratedMessage.BuilderParent) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
newInitialPosition(InitialPositionInStream) - Static method in class software.amazon.kinesis.common.InitialPositionInStreamExtended
 
newInitialPositionAtTimestamp(Date) - Static method in class software.amazon.kinesis.common.InitialPositionInStreamExtended
 
NoOpShardPrioritization - Class in software.amazon.kinesis.leases
Shard Prioritization that returns the same original list of shards without any modifications.
NoOpShardPrioritization() - Constructor for class software.amazon.kinesis.leases.NoOpShardPrioritization
Empty constructor for NoOp Shard Prioritization.
NoOpWorkerStateChangeListener - Class in software.amazon.kinesis.coordinator
 
NoOpWorkerStateChangeListener() - Constructor for class software.amazon.kinesis.coordinator.NoOpWorkerStateChangeListener
Empty constructor for NoOp Worker State Change Listener
NullMetricsFactory - Class in software.amazon.kinesis.metrics
 
NullMetricsFactory() - Constructor for class software.amazon.kinesis.metrics.NullMetricsFactory
 
NullMetricsScope - Class in software.amazon.kinesis.metrics
 
NullMetricsScope() - Constructor for class software.amazon.kinesis.metrics.NullMetricsScope
 

O

offer(KeyType, MetricDatum) - Method in class software.amazon.kinesis.metrics.MetricAccumulatingQueue
We use a queue and a map in this method.
onAllInitializationAttemptsFailed(Throwable) - Method in interface software.amazon.kinesis.coordinator.WorkerStateChangeListener
 
onWorkerStateChange(WorkerStateChangeListener.WorkerState) - Method in class software.amazon.kinesis.coordinator.NoOpWorkerStateChangeListener
 
onWorkerStateChange(WorkerStateChangeListener.WorkerState) - Method in interface software.amazon.kinesis.coordinator.WorkerStateChangeListener
 
operation(String) - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
 
operation() - Method in class software.amazon.kinesis.checkpoint.dynamodb.DynamoDBCheckpointer
 
operation(String) - Method in interface software.amazon.kinesis.processor.Checkpointer
 
operation() - Method in interface software.amazon.kinesis.processor.Checkpointer
 
OPERATION_DIMENSION_NAME - Static variable in class software.amazon.kinesis.metrics.MetricsUtil
 
ownerSwitchesSinceCheckpoint(Long) - Method in class software.amazon.kinesis.leases.Lease
Sets ownerSwitchesSinceCheckpoint.

P

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(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(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(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 variable in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
PARSER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
PARSER - Static variable 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
 
PollingConfig - Class in software.amazon.kinesis.retrieval.polling
 
PollingConfig() - 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) - 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() - 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) - 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, 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, ExtendedSequenceNumber, String) - 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(Record) - 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, 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.
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
 
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) - Constructor for class software.amazon.kinesis.lifecycle.ProcessTask
 
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.

R

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
 
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
 
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.
recordsNotForShard(String, Stream<String>) - Method in class software.amazon.kinesis.common.MismatchedRecordReporter
 
RecordsPublisher - Interface in software.amazon.kinesis.retrieval
Provides a record publisher that will retrieve records from Kinesis for processing
registerAllExtensions(ExtensionRegistry) - Static method in class software.amazon.kinesis.retrieval.kpl.Messages
 
registerStreamConsumerRequestBuilder() - Static method in class software.amazon.kinesis.common.KinesisRequestsBuilder
 
removeRecords(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .Record records = 3;
removeTags(int) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .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
 
requestShutdown() - Method in class software.amazon.kinesis.coordinator.Scheduler
Deprecated.
restartIterator() - Method in class software.amazon.kinesis.retrieval.polling.KinesisDataFetcher
Gets a new iterator from the 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() - Constructor for class software.amazon.kinesis.retrieval.RetrievalConfig
 
retrievalFactory() - Method in class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutConfig
 
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 - 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.Scheduler
Start consuming data from the stream, and pass it to the application record processors.
run() - Method in class software.amazon.kinesis.metrics.CloudWatchPublisherRunnable
 
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.

S

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
 
Scheduler - Class in software.amazon.kinesis.coordinator
 
Scheduler(CheckpointConfig, CoordinatorConfig, LeaseManagementConfig, LifecycleConfig, MetricsConfig, ProcessorConfig, RetrievalConfig) - Constructor for class software.amazon.kinesis.coordinator.Scheduler
 
SchedulerCoordinatorFactory - Class in software.amazon.kinesis.coordinator
 
SchedulerCoordinatorFactory() - Constructor for class software.amazon.kinesis.coordinator.SchedulerCoordinatorFactory
 
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
 
serializer - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
 
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;
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 .Record records = 3;
setRecords(int, Messages.Record.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord.Builder
repeated .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 .Tag tags = 4;
setTags(int, Messages.Tag.Builder) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record.Builder
repeated .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
 
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) - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumer
 
ShardConsumer(RecordsPublisher, ExecutorService, ShardInfo, Optional<Long>, ShardConsumerArgument, ConsumerState, Function<ConsumerTask, ConsumerTask>, int) - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumer
 
ShardConsumerArgument - Class in software.amazon.kinesis.lifecycle
 
ShardConsumerArgument() - Constructor for class software.amazon.kinesis.lifecycle.ShardConsumerArgument
 
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.
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
ShardRecordProcessorCheckpointer - Class in software.amazon.kinesis.checkpoint
This class is used to enable RecordProcessors to checkpoint their progress.
ShardRecordProcessorCheckpointer(ShardInfo, Checkpointer) - Constructor for class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
 
ShardRecordProcessorCheckpointer(ShardInfo, Checkpointer, SequenceNumberValidator) - Constructor for class software.amazon.kinesis.checkpoint.ShardRecordProcessorCheckpointer
 
ShardRecordProcessorFactory - Interface in software.amazon.kinesis.processor
 
ShardSyncer - Class in software.amazon.kinesis.leases
Helper class to sync leases with shards of the Kinesis stream.
ShardSyncer() - Constructor for class software.amazon.kinesis.leases.ShardSyncer
 
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() - Constructor for class software.amazon.kinesis.leases.ShardSyncTaskManager
 
shutdown() - Method in class software.amazon.kinesis.coordinator.Scheduler
Signals worker to shutdown.
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
Allows a record processor to indicate it's aware of requested shutdowns, and handle the request.
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(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
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
 
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.exceptions - package software.amazon.kinesis.exceptions
 
software.amazon.kinesis.exceptions.internal - package software.amazon.kinesis.exceptions.internal
 
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.fanout.experimental - package software.amazon.kinesis.retrieval.fanout.experimental
 
software.amazon.kinesis.retrieval.kpl - package software.amazon.kinesis.retrieval.kpl
 
software.amazon.kinesis.retrieval.polling - package software.amazon.kinesis.retrieval.polling
 
start() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
 
start() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
Start background LeaseHolder and LeaseTaker threads.
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, that implement ShutdownNotificationAware, of the impending shutdown.
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.
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.
subscribe(Subscriber<? super ProcessRecordsInput>) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
 
subscribe(Subscriber<? super ProcessRecordsInput>) - Method in class software.amazon.kinesis.retrieval.polling.BlockingRecordsPublisher
 
subscribe(Subscriber<? super ProcessRecordsInput>) - 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() - 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
 
SynchronousPrefetchingRetrievalFactory - Class in software.amazon.kinesis.retrieval.polling
 
SynchronousPrefetchingRetrievalFactory() - Constructor for class software.amazon.kinesis.retrieval.polling.SynchronousPrefetchingRetrievalFactory
 
syncShardAndLeaseInfo() - Method in class software.amazon.kinesis.leases.ShardSyncTaskManager
 

T

table - Variable in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
 
TableConstants - Class in software.amazon.kinesis.leases.dynamodb
Deprecated.
TableConstants() - Constructor for class software.amazon.kinesis.leases.dynamodb.TableConstants
Deprecated.
 
tableName() - Method in class software.amazon.kinesis.common.ConfigsBuilder
Lease table name used for lease management and checkpointing.
TAGS_FIELD_NUMBER - Static variable in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
takeLease(Lease, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
Take a lease for the given owner by incrementing its leaseCounter and setting its owner field.
takeLease(Lease, String) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
Take a lease for the given owner by incrementing its leaseCounter and setting its owner field.
takeLeases() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
Compute the set of leases available to be taken and attempt to take them.
takeLeases() - Method in interface software.amazon.kinesis.leases.LeaseTaker
Compute the set of leases available to be taken and attempt to take them.
TaskResult - Class in software.amazon.kinesis.lifecycle
Used to capture information from a task that we want to communicate back to the higher layer.
TaskResult(Exception) - Constructor for class software.amazon.kinesis.lifecycle.TaskResult
 
taskType() - Method in class software.amazon.kinesis.leases.ShardSyncTask
 
taskType() - Method in class software.amazon.kinesis.lifecycle.BlockOnParentShardTask
 
taskType() - Method in interface software.amazon.kinesis.lifecycle.ConsumerTask
 
taskType() - Method in class software.amazon.kinesis.lifecycle.InitializeTask
 
taskType() - Method in class software.amazon.kinesis.lifecycle.ProcessTask
 
taskType() - Method in class software.amazon.kinesis.lifecycle.ShutdownNotificationTask
 
taskType() - Method in class software.amazon.kinesis.lifecycle.ShutdownTask
 
TaskType - Enum in software.amazon.kinesis.lifecycle
Enumerates types of tasks executed as part of processing a shard.
taskType() - Method in class software.amazon.kinesis.metrics.MetricsCollectingTaskDecorator
ThreadSafeMetricsDelegatingFactory - Class in software.amazon.kinesis.metrics
Metrics scope factory that delegates metrics scope creation to another factory, but returns metrics scope that is thread safe.
ThreadSafeMetricsDelegatingFactory(MetricsFactory) - Constructor for class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingFactory
Creates an instance of the metrics factory.
ThreadSafeMetricsDelegatingScope - Class in software.amazon.kinesis.metrics
Metrics scope that delegates to another metrics scope and is thread safe to be shared across different threads.
ThreadSafeMetricsDelegatingScope(MetricsScope) - Constructor for class software.amazon.kinesis.metrics.ThreadSafeMetricsDelegatingScope
Creates an instance of the metrics scope.
throttled() - Method in class software.amazon.kinesis.retrieval.ThrottlingReporter
 
ThrottlingException - Exception in software.amazon.kinesis.exceptions
Thrown when requests are throttled by a service (e.g.
ThrottlingException(String) - Constructor for exception software.amazon.kinesis.exceptions.ThrottlingException
 
ThrottlingException(String, Exception) - Constructor for exception software.amazon.kinesis.exceptions.ThrottlingException
 
ThrottlingReporter - Class in software.amazon.kinesis.retrieval
 
ThrottlingReporter() - Constructor for class software.amazon.kinesis.retrieval.ThrottlingReporter
 
timeSpentInCache() - Method in class software.amazon.kinesis.lifecycle.events.ProcessRecordsInput
How long the records spent waiting to be dispatched to the ShardRecordProcessor
toBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
toBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
toBuilder() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
toDynamoRecord(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseSerializer
 
toDynamoRecord(Lease) - Method in interface software.amazon.kinesis.leases.LeaseSerializer
Construct a DynamoDB record out of a Lease object
toString() - Method in class software.amazon.kinesis.metrics.MetricsCollectingTaskDecorator
 
toString() - Method in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
 
TRIM_HORIZON - Static variable in class software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber
Special value for TRIM_HORIZON.

U

update(Lease) - Method in class software.amazon.kinesis.leases.Lease
Updates this Lease's mutable, application-specific fields based on the passed-in lease object.
updateLease(Lease, UUID, String, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
 
updateLease(Lease) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
Update application-specific fields of the given lease in DynamoDB.
updateLease(Lease, UUID, String, String) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRenewer
Update application-specific fields in a currently held lease.
updateLease(Lease, UUID, String, String) - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
Updates application-specific lease values in DynamoDB.
updateLease(Lease) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
Update application-specific fields of the given lease in DynamoDB.
updateLease(Lease, UUID, String, String) - Method in interface software.amazon.kinesis.leases.LeaseRenewer
Update application-specific fields in a currently held lease.

V

validateRecords(String, SubscribeToShardEvent) - Method in class software.amazon.kinesis.retrieval.fanout.experimental.ExperimentalFanOutRecordsPublisher
 
validateRecords(String, SubscribeToShardEvent) - Method in class software.amazon.kinesis.retrieval.fanout.FanOutRecordsPublisher
Allows validating records received from SubscribeToShard
validateSequenceNumberForShard(String, String) - Method in class software.amazon.kinesis.checkpoint.SequenceNumberValidator
Validates that the sequence number provided contains the given shardId.
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.WorkerStateChangeListener.WorkerState
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.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.retrieval.DataFetchingStrategy
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.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.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.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.retrieval.DataFetchingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
versionFor(String) - Method in class software.amazon.kinesis.checkpoint.SequenceNumberValidator
Attempts to retrieve the version for a sequence number.

W

waitUntilLeaseTableExists(long, long) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseRefresher
 
waitUntilLeaseTableExists(long, long) - Method in interface software.amazon.kinesis.leases.LeaseRefresher
Blocks until the lease table exists by polling leaseTableExists.
withMaxLeasesForWorker(int) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
Worker will not acquire more than the specified max number of leases even if there are more shards that need to be processed.
withMaxLeasesToStealAtOneTime(int) - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseTaker
Max leases to steal from a more loaded Worker at one time (for load balancing).
workerIdentifier() - Method in class software.amazon.kinesis.leases.dynamodb.DynamoDBLeaseCoordinator
 
workerIdentifier() - Method in interface software.amazon.kinesis.leases.LeaseCoordinator
 
WorkerStateChangeListener - Interface in software.amazon.kinesis.coordinator
A listener for callbacks on changes worker state
WorkerStateChangeListener.WorkerState - Enum in software.amazon.kinesis.coordinator
 
writeReplace() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
writeReplace() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
writeReplace() - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
writeTo(CodedOutputStream) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.AggregatedRecord
 
writeTo(CodedOutputStream) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Record
 
writeTo(CodedOutputStream) - Method in class software.amazon.kinesis.retrieval.kpl.Messages.Tag
 
A B C D E F G H I K L M N O P R S T U V W 
Skip navigation links

Copyright © 2018. All rights reserved.