Packages

package kinesis

Source
package.scala
Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. kinesis
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Type Members

  1. case class AccessDeniedException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    Specifies that you do not have the permissions required to perform this operation.

  2. case class AddTagsToStreamInput(tags: Map[TagKey, TagValue], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for AddTagsToStream.

  3. type BooleanObject = kinesis.BooleanObject.Type
  4. case class ChildShard(shardId: ShardId, parentShards: List[ShardId], hashKeyRange: HashKeyRange) extends Product with Serializable

    Output parameter of the GetRecords API.

    Output parameter of the GetRecords API. The existing child shard of the current shard.

  5. type ChildShardList = kinesis.ChildShardList.Type

  6. case class Consumer(consumerName: ConsumerName, consumerARN: ConsumerARN, consumerStatus: ConsumerStatus, consumerCreationTimestamp: Timestamp) extends Product with Serializable

    An object that represents the details of the consumer you registered.

    An object that represents the details of the consumer you registered. This type of object is returned by RegisterStreamConsumer.

  7. type ConsumerARN = kinesis.ConsumerARN.Type
  8. type ConsumerCountObject = kinesis.ConsumerCountObject.Type
  9. case class ConsumerDescription(consumerName: ConsumerName, consumerARN: ConsumerARN, consumerStatus: ConsumerStatus, consumerCreationTimestamp: Timestamp, streamARN: StreamARN) extends Product with Serializable

    An object that represents the details of a registered consumer.

    An object that represents the details of a registered consumer. This type of object is returned by DescribeStreamConsumer.

  10. type ConsumerList = kinesis.ConsumerList.Type

  11. type ConsumerName = kinesis.ConsumerName.Type
  12. sealed abstract class ConsumerStatus extends Value
  13. case class CreateStreamInput(streamName: StreamName, shardCount: Option[PositiveIntegerObject] = None, streamModeDetails: Option[StreamModeDetails] = None) extends Product with Serializable

    Represents the input for CreateStream.

  14. type Data = kinesis.Data.Type
  15. case class DecreaseStreamRetentionPeriodInput(retentionPeriodHours: RetentionPeriodHours, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for DecreaseStreamRetentionPeriod.

  16. case class DeleteStreamInput(streamName: Option[StreamName] = None, enforceConsumerDeletion: Option[BooleanObject] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for DeleteStream.

  17. case class DeregisterStreamConsumerInput(streamARN: Option[StreamARN] = None, consumerName: Option[ConsumerName] = None, consumerARN: Option[ConsumerARN] = None) extends Product with Serializable

  18. case class DescribeLimitsInput() extends Product with Serializable
  19. case class DescribeLimitsOutput(shardLimit: ShardCountObject, openShardCount: ShardCountObject, onDemandStreamCount: OnDemandStreamCountObject, onDemandStreamCountLimit: OnDemandStreamCountLimitObject) extends Product with Serializable

  20. case class DescribeStreamConsumerInput(streamARN: Option[StreamARN] = None, consumerName: Option[ConsumerName] = None, consumerARN: Option[ConsumerARN] = None) extends Product with Serializable

  21. case class DescribeStreamConsumerOutput(consumerDescription: ConsumerDescription) extends Product with Serializable

  22. case class DescribeStreamInput(streamName: Option[StreamName] = None, limit: Option[DescribeStreamInputLimit] = None, exclusiveStartShardId: Option[ShardId] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for DescribeStream.

  23. type DescribeStreamInputLimit = kinesis.DescribeStreamInputLimit.Type
  24. case class DescribeStreamOutput(streamDescription: StreamDescription) extends Product with Serializable

    Represents the output for DescribeStream.

  25. case class DescribeStreamSummaryInput(streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

  26. case class DescribeStreamSummaryOutput(streamDescriptionSummary: StreamDescriptionSummary) extends Product with Serializable

  27. case class DisableEnhancedMonitoringInput(shardLevelMetrics: List[MetricsName], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for DisableEnhancedMonitoring.

  28. case class EnableEnhancedMonitoringInput(shardLevelMetrics: List[MetricsName], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for EnableEnhancedMonitoring.

  29. sealed abstract class EncryptionType extends Value
  30. case class EnhancedMetrics(shardLevelMetrics: Option[List[MetricsName]] = None) extends Product with Serializable

    Represents enhanced metrics types.

  31. type EnhancedMonitoringList = kinesis.EnhancedMonitoringList.Type

  32. case class EnhancedMonitoringOutput(streamName: Option[StreamName] = None, currentShardLevelMetrics: Option[List[MetricsName]] = None, desiredShardLevelMetrics: Option[List[MetricsName]] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the output for EnableEnhancedMonitoring and DisableEnhancedMonitoring.

  33. type ErrorCode = kinesis.ErrorCode.Type
  34. type ErrorMessage = kinesis.ErrorMessage.Type
  35. case class ExpiredIteratorException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The provided iterator exceeds the maximum age allowed.

    The provided iterator exceeds the maximum age allowed.

    message

    A message that provides information about the error.

  36. case class ExpiredNextTokenException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The pagination token passed to the operation is expired.

  37. case class GetRecordsInput(shardIterator: ShardIterator, limit: Option[GetRecordsInputLimit] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for GetRecords.

  38. type GetRecordsInputLimit = kinesis.GetRecordsInputLimit.Type
  39. case class GetRecordsOutput(records: List[Record], nextShardIterator: Option[ShardIterator] = None, millisBehindLatest: Option[MillisBehindLatest] = None, childShards: Option[List[ChildShard]] = None) extends Product with Serializable

    Represents the output for GetRecords.

  40. case class GetShardIteratorInput(shardId: ShardId, shardIteratorType: ShardIteratorType, streamName: Option[StreamName] = None, startingSequenceNumber: Option[SequenceNumber] = None, timestamp: Option[Timestamp] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for GetShardIterator.

  41. case class GetShardIteratorOutput(shardIterator: Option[ShardIterator] = None) extends Product with Serializable

    Represents the output for GetShardIterator.

  42. type HashKey = kinesis.HashKey.Type
  43. case class HashKeyRange(startingHashKey: HashKey, endingHashKey: HashKey) extends Product with Serializable

    The range of possible hash key values for the shard, which is a set of ordered contiguous positive integers.

  44. case class IncreaseStreamRetentionPeriodInput(retentionPeriodHours: RetentionPeriodHours, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for IncreaseStreamRetentionPeriod.

  45. case class InternalFailureException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The processing of the request failed because of an unknown error, exception, or failure.

  46. case class InvalidArgumentException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    A specified parameter exceeds its restrictions, is not supported, or can't be used.

    A specified parameter exceeds its restrictions, is not supported, or can't be used. For more information, see the returned message.

    message

    A message that provides information about the error.

  47. case class KMSAccessDeniedException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The ciphertext references a key that doesn't exist or that you don't have access to.

    The ciphertext references a key that doesn't exist or that you don't have access to.

    message

    A message that provides information about the error.

  48. case class KMSDisabledException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The request was rejected because the specified customer master key (CMK) isn't enabled.

    The request was rejected because the specified customer master key (CMK) isn't enabled.

    message

    A message that provides information about the error.

  49. case class KMSInvalidStateException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The request was rejected because the state of the specified resource isn't valid for this request.

    The request was rejected because the state of the specified resource isn't valid for this request. For more information, see How Key State Affects Use of a Customer Master Key in the Amazon Web Services Key Management Service Developer Guide.

    message

    A message that provides information about the error.

  50. case class KMSNotFoundException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The request was rejected because the specified entity or resource can't be found.

    The request was rejected because the specified entity or resource can't be found.

    message

    A message that provides information about the error.

  51. case class KMSOptInRequired(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The Amazon Web Services access key ID needs a subscription for the service.

    The Amazon Web Services access key ID needs a subscription for the service.

    message

    A message that provides information about the error.

  52. case class KMSThrottlingException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The request was denied due to request throttling.

    The request was denied due to request throttling. For more information about throttling, see Limits in the Amazon Web Services Key Management Service Developer Guide.

    message

    A message that provides information about the error.

  53. type KeyId = kinesis.KeyId.Type
  54. type Kinesis[F[_]] = KinesisGen[[I, E, O, SI, SO]F[O]]
  55. trait KinesisGen[F[_, _, _, _, _]] extends AnyRef

    <fullname>Amazon Kinesis Data Streams Service API Reference</fullname>

    <fullname>Amazon Kinesis Data Streams Service API Reference</fullname>

    Amazon Kinesis Data Streams is a managed service that scales elastically for real-time processing of streaming big data.

  56. sealed trait KinesisOperation[Input, Err, Output, StreamedInput, StreamedOutput] extends AnyRef
  57. case class LimitExceededException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The requested resource exceeds the maximum number allowed, or the number of concurrent stream requests exceeds the maximum number allowed.

    The requested resource exceeds the maximum number allowed, or the number of concurrent stream requests exceeds the maximum number allowed.

    message

    A message that provides information about the error.

  58. case class ListShardsInput(streamName: Option[StreamName] = None, nextToken: Option[NextToken] = None, exclusiveStartShardId: Option[ShardId] = None, maxResults: Option[ListShardsInputLimit] = None, streamCreationTimestamp: Option[Timestamp] = None, shardFilter: Option[ShardFilter] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

  59. type ListShardsInputLimit = kinesis.ListShardsInputLimit.Type
  60. case class ListShardsOutput(shards: Option[List[Shard]] = None, nextToken: Option[NextToken] = None) extends Product with Serializable

  61. case class ListStreamConsumersInput(streamARN: StreamARN, nextToken: Option[NextToken] = None, maxResults: Option[ListStreamConsumersInputLimit] = None, streamCreationTimestamp: Option[Timestamp] = None) extends Product with Serializable

  62. type ListStreamConsumersInputLimit = kinesis.ListStreamConsumersInputLimit.Type
  63. case class ListStreamConsumersOutput(consumers: Option[List[Consumer]] = None, nextToken: Option[NextToken] = None) extends Product with Serializable

  64. case class ListStreamsInput(limit: Option[ListStreamsInputLimit] = None, exclusiveStartStreamName: Option[StreamName] = None, nextToken: Option[NextToken] = None) extends Product with Serializable

    Represents the input for ListStreams.

  65. type ListStreamsInputLimit = kinesis.ListStreamsInputLimit.Type
  66. case class ListStreamsOutput(streamNames: List[StreamName], hasMoreStreams: BooleanObject, nextToken: Option[NextToken] = None, streamSummaries: Option[List[StreamSummary]] = None) extends Product with Serializable

    Represents the output for ListStreams.

  67. case class ListTagsForStreamInput(streamName: Option[StreamName] = None, exclusiveStartTagKey: Option[TagKey] = None, limit: Option[ListTagsForStreamInputLimit] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for ListTagsForStream.

  68. type ListTagsForStreamInputLimit = kinesis.ListTagsForStreamInputLimit.Type
  69. case class ListTagsForStreamOutput(tags: List[Tag], hasMoreTags: BooleanObject) extends Product with Serializable

    Represents the output for ListTagsForStream.

  70. case class MergeShardsInput(shardToMerge: ShardId, adjacentShardToMerge: ShardId, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for MergeShards.

  71. sealed abstract class MetricsName extends Value
  72. type MetricsNameList = kinesis.MetricsNameList.Type
  73. type MillisBehindLatest = kinesis.MillisBehindLatest.Type
  74. type NextToken = kinesis.NextToken.Type
  75. type NonNegativeIntegerObject = kinesis.NonNegativeIntegerObject.Type
  76. type OnDemandStreamCountLimitObject = kinesis.OnDemandStreamCountLimitObject.Type
  77. type OnDemandStreamCountObject = kinesis.OnDemandStreamCountObject.Type
  78. type PartitionKey = kinesis.PartitionKey.Type
  79. type PositiveIntegerObject = kinesis.PositiveIntegerObject.Type
  80. case class ProvisionedThroughputExceededException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The request rate for the stream is too high, or the requested data is too large for the available throughput.

    The request rate for the stream is too high, or the requested data is too large for the available throughput. Reduce the frequency or size of your requests. For more information, see Streams Limits in the Amazon Kinesis Data Streams Developer Guide, and Error Retries and Exponential Backoff in Amazon Web Services in the Amazon Web Services General Reference.

    message

    A message that provides information about the error.

  81. case class PutRecordInput(data: Data, partitionKey: PartitionKey, streamName: Option[StreamName] = None, explicitHashKey: Option[HashKey] = None, sequenceNumberForOrdering: Option[SequenceNumber] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for PutRecord.

  82. case class PutRecordOutput(shardId: ShardId, sequenceNumber: SequenceNumber, encryptionType: Option[EncryptionType] = None) extends Product with Serializable

    Represents the output for PutRecord.

  83. case class PutRecordsInput(records: List[PutRecordsRequestEntry], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    A PutRecords request.

  84. case class PutRecordsOutput(records: List[PutRecordsResultEntry], failedRecordCount: Option[NonNegativeIntegerObject] = None, encryptionType: Option[EncryptionType] = None) extends Product with Serializable

    PutRecords results.

  85. case class PutRecordsRequestEntry(data: Data, partitionKey: PartitionKey, explicitHashKey: Option[HashKey] = None) extends Product with Serializable

    Represents the output for PutRecords.

  86. type PutRecordsRequestEntryList = kinesis.PutRecordsRequestEntryList.Type

  87. case class PutRecordsResultEntry(sequenceNumber: Option[SequenceNumber] = None, shardId: Option[ShardId] = None, errorCode: Option[ErrorCode] = None, errorMessage: Option[ErrorMessage] = None) extends Product with Serializable

    Represents the result of an individual record from a PutRecords request.

    Represents the result of an individual record from a PutRecords request. A record that is successfully added to a stream includes SequenceNumber and ShardId in the result. A record that fails to be added to the stream includes ErrorCode and ErrorMessage in the result.

  88. type PutRecordsResultEntryList = kinesis.PutRecordsResultEntryList.Type

  89. case class Record(sequenceNumber: SequenceNumber, data: Data, partitionKey: PartitionKey, approximateArrivalTimestamp: Option[Timestamp] = None, encryptionType: Option[EncryptionType] = None) extends Product with Serializable

    The unit of data of the Kinesis data stream, which is composed of a sequence number, a partition key, and a data blob.

  90. type RecordList = kinesis.RecordList.Type

  91. case class RegisterStreamConsumerInput(streamARN: StreamARN, consumerName: ConsumerName) extends Product with Serializable

  92. case class RegisterStreamConsumerOutput(consumer: Consumer) extends Product with Serializable

  93. case class RemoveTagsFromStreamInput(tagKeys: List[TagKey], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for RemoveTagsFromStream.

  94. case class ResourceInUseException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The resource is not available for this operation.

    The resource is not available for this operation. For successful operation, the resource must be in the ACTIVE state.

    message

    A message that provides information about the error.

  95. case class ResourceNotFoundException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    The requested resource could not be found.

    The requested resource could not be found. The stream might not be specified correctly.

    message

    A message that provides information about the error.

  96. type RetentionPeriodHours = kinesis.RetentionPeriodHours.Type
  97. sealed abstract class ScalingType extends Value
  98. type SequenceNumber = kinesis.SequenceNumber.Type
  99. case class SequenceNumberRange(startingSequenceNumber: SequenceNumber, endingSequenceNumber: Option[SequenceNumber] = None) extends Product with Serializable

    The range of possible sequence numbers for the shard.

  100. case class Shard(shardId: ShardId, hashKeyRange: HashKeyRange, sequenceNumberRange: SequenceNumberRange, parentShardId: Option[ShardId] = None, adjacentParentShardId: Option[ShardId] = None) extends Product with Serializable

    A uniquely identified group of data records in a Kinesis data stream.

  101. type ShardCountObject = kinesis.ShardCountObject.Type
  102. case class ShardFilter(_type: ShardFilterType, shardId: Option[ShardId] = None, timestamp: Option[Timestamp] = None) extends Product with Serializable

    The request parameter used to filter out the response of the ListShards API.

  103. sealed abstract class ShardFilterType extends Value
  104. type ShardId = kinesis.ShardId.Type
  105. type ShardIdList = kinesis.ShardIdList.Type
  106. type ShardIterator = kinesis.ShardIterator.Type
  107. sealed abstract class ShardIteratorType extends Value
  108. type ShardList = kinesis.ShardList.Type

  109. case class SplitShardInput(shardToSplit: ShardId, newStartingHashKey: HashKey, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

    Represents the input for SplitShard.

  110. case class StartStreamEncryptionInput(encryptionType: EncryptionType, keyId: KeyId, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

  111. case class StartingPosition(_type: ShardIteratorType, sequenceNumber: Option[SequenceNumber] = None, timestamp: Option[Timestamp] = None) extends Product with Serializable

    The starting position in the data stream from which to start streaming.

  112. case class StopStreamEncryptionInput(encryptionType: EncryptionType, keyId: KeyId, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

  113. type StreamARN = kinesis.StreamARN.Type
  114. case class StreamDescription(streamName: StreamName, streamARN: StreamARN, streamStatus: StreamStatus, shards: List[Shard], hasMoreShards: BooleanObject, retentionPeriodHours: RetentionPeriodHours, streamCreationTimestamp: Timestamp, enhancedMonitoring: List[EnhancedMetrics], streamModeDetails: Option[StreamModeDetails] = None, encryptionType: Option[EncryptionType] = None, keyId: Option[KeyId] = None) extends Product with Serializable

    Represents the output for DescribeStream.

  115. case class StreamDescriptionSummary(streamName: StreamName, streamARN: StreamARN, streamStatus: StreamStatus, retentionPeriodHours: RetentionPeriodHours, streamCreationTimestamp: Timestamp, enhancedMonitoring: List[EnhancedMetrics], openShardCount: ShardCountObject, streamModeDetails: Option[StreamModeDetails] = None, encryptionType: Option[EncryptionType] = None, keyId: Option[KeyId] = None, consumerCount: Option[ConsumerCountObject] = None) extends Product with Serializable

    Represents the output for DescribeStreamSummary

  116. sealed abstract class StreamMode extends Value
  117. case class StreamModeDetails(streamMode: StreamMode) extends Product with Serializable

    Specifies the capacity mode to which you want to set your data stream.

    Specifies the capacity mode to which you want to set your data stream. Currently, in Kinesis Data Streams, you can choose between an on-demand capacity mode and a provisioned capacity mode for your data streams.

  118. type StreamName = kinesis.StreamName.Type
  119. type StreamNameList = kinesis.StreamNameList.Type
  120. sealed abstract class StreamStatus extends Value
  121. case class StreamSummary(streamName: StreamName, streamARN: StreamARN, streamStatus: StreamStatus, streamModeDetails: Option[StreamModeDetails] = None, streamCreationTimestamp: Option[Timestamp] = None) extends Product with Serializable

    The summary of a stream.

  122. type StreamSummaryList = kinesis.StreamSummaryList.Type

  123. case class SubscribeToShardEvent(records: List[Record], continuationSequenceNumber: SequenceNumber, millisBehindLatest: MillisBehindLatest, childShards: Option[List[ChildShard]] = None) extends Product with Serializable

    After you call SubscribeToShard, Kinesis Data Streams sends events of this type over an HTTP/2 connection to your consumer.

  124. sealed trait SubscribeToShardEventStream extends Product with Serializable

    This is a tagged union for all of the types of events an enhanced fan-out consumer can receive over HTTP/2 after a call to SubscribeToShard.

  125. case class SubscribeToShardInput(consumerARN: ConsumerARN, shardId: ShardId, startingPosition: StartingPosition) extends Product with Serializable

  126. case class SubscribeToShardOutput() extends Product with Serializable

  127. case class Tag(key: TagKey, value: Option[TagValue] = None) extends Product with Serializable

    Metadata assigned to the stream, consisting of a key-value pair.

  128. type TagKey = kinesis.TagKey.Type
  129. type TagKeyList = kinesis.TagKeyList.Type
  130. type TagList = kinesis.TagList.Type

  131. type TagMap = kinesis.TagMap.Type
  132. type TagValue = kinesis.TagValue.Type
  133. case class UpdateShardCountInput(targetShardCount: PositiveIntegerObject, scalingType: ScalingType, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

  134. case class UpdateShardCountOutput(streamName: Option[StreamName] = None, currentShardCount: Option[PositiveIntegerObject] = None, targetShardCount: Option[PositiveIntegerObject] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable

  135. case class UpdateStreamModeInput(streamARN: StreamARN, streamModeDetails: StreamModeDetails) extends Product with Serializable

  136. case class ValidationException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable

    Specifies that you tried to invoke this API for a data stream with the on-demand capacity mode.

    Specifies that you tried to invoke this API for a data stream with the on-demand capacity mode. This API is only supported for data streams with the provisioned capacity mode.

Value Members

  1. val Kinesis: KinesisGen.type
  2. object AccessDeniedException extends Companion[AccessDeniedException] with Serializable
  3. object AddTagsToStreamInput extends Companion[AddTagsToStreamInput] with Serializable
  4. object BooleanObject extends Newtype[Boolean]
  5. object ChildShard extends Companion[ChildShard] with Serializable
  6. object ChildShardList extends Newtype[List[ChildShard]]

  7. object Consumer extends Companion[Consumer] with Serializable
  8. object ConsumerARN extends Newtype[String]
  9. object ConsumerCountObject extends Newtype[Int]
  10. object ConsumerDescription extends Companion[ConsumerDescription] with Serializable
  11. object ConsumerList extends Newtype[List[Consumer]]

  12. object ConsumerName extends Newtype[String]
  13. object ConsumerStatus extends Enumeration[ConsumerStatus] with Companion[ConsumerStatus] with Serializable
  14. object CreateStreamInput extends Companion[CreateStreamInput] with Serializable
  15. object Data extends Newtype[ByteArray]
  16. object DecreaseStreamRetentionPeriodInput extends Companion[DecreaseStreamRetentionPeriodInput] with Serializable
  17. object DeleteStreamInput extends Companion[DeleteStreamInput] with Serializable
  18. object DeregisterStreamConsumerInput extends Companion[DeregisterStreamConsumerInput] with Serializable
  19. object DescribeLimitsInput extends Companion[DescribeLimitsInput] with Serializable
  20. object DescribeLimitsOutput extends Companion[DescribeLimitsOutput] with Serializable
  21. object DescribeStreamConsumerInput extends Companion[DescribeStreamConsumerInput] with Serializable
  22. object DescribeStreamConsumerOutput extends Companion[DescribeStreamConsumerOutput] with Serializable
  23. object DescribeStreamInput extends Companion[DescribeStreamInput] with Serializable
  24. object DescribeStreamInputLimit extends Newtype[Int]
  25. object DescribeStreamOutput extends Companion[DescribeStreamOutput] with Serializable
  26. object DescribeStreamSummaryInput extends Companion[DescribeStreamSummaryInput] with Serializable
  27. object DescribeStreamSummaryOutput extends Companion[DescribeStreamSummaryOutput] with Serializable
  28. object DisableEnhancedMonitoringInput extends Companion[DisableEnhancedMonitoringInput] with Serializable
  29. object EnableEnhancedMonitoringInput extends Companion[EnableEnhancedMonitoringInput] with Serializable
  30. object EncryptionType extends Enumeration[EncryptionType] with Companion[EncryptionType] with Serializable
  31. object EnhancedMetrics extends Companion[EnhancedMetrics] with Serializable
  32. object EnhancedMonitoringList extends Newtype[List[EnhancedMetrics]]

  33. object EnhancedMonitoringOutput extends Companion[EnhancedMonitoringOutput] with Serializable
  34. object ErrorCode extends Newtype[String]
  35. object ErrorMessage extends Newtype[String]
  36. object ExpiredIteratorException extends Companion[ExpiredIteratorException] with Serializable
  37. object ExpiredNextTokenException extends Companion[ExpiredNextTokenException] with Serializable
  38. object GetRecordsInput extends Companion[GetRecordsInput] with Serializable
  39. object GetRecordsInputLimit extends Newtype[Int]
  40. object GetRecordsOutput extends Companion[GetRecordsOutput] with Serializable
  41. object GetShardIteratorInput extends Companion[GetShardIteratorInput] with Serializable
  42. object GetShardIteratorOutput extends Companion[GetShardIteratorOutput] with Serializable
  43. object HashKey extends Newtype[String]
  44. object HashKeyRange extends Companion[HashKeyRange] with Serializable
  45. object IncreaseStreamRetentionPeriodInput extends Companion[IncreaseStreamRetentionPeriodInput] with Serializable
  46. object InternalFailureException extends Companion[InternalFailureException] with Serializable
  47. object InvalidArgumentException extends Companion[InvalidArgumentException] with Serializable
  48. object KMSAccessDeniedException extends Companion[KMSAccessDeniedException] with Serializable
  49. object KMSDisabledException extends Companion[KMSDisabledException] with Serializable
  50. object KMSInvalidStateException extends Companion[KMSInvalidStateException] with Serializable
  51. object KMSNotFoundException extends Companion[KMSNotFoundException] with Serializable
  52. object KMSOptInRequired extends Companion[KMSOptInRequired] with Serializable
  53. object KMSThrottlingException extends Companion[KMSThrottlingException] with Serializable
  54. object KeyId extends Newtype[String]
  55. object KinesisGen extends Mixin[KinesisGen, KinesisOperation]
  56. object KinesisOperation
  57. object LimitExceededException extends Companion[LimitExceededException] with Serializable
  58. object ListShardsInput extends Companion[ListShardsInput] with Serializable
  59. object ListShardsInputLimit extends Newtype[Int]
  60. object ListShardsOutput extends Companion[ListShardsOutput] with Serializable
  61. object ListStreamConsumersInput extends Companion[ListStreamConsumersInput] with Serializable
  62. object ListStreamConsumersInputLimit extends Newtype[Int]
  63. object ListStreamConsumersOutput extends Companion[ListStreamConsumersOutput] with Serializable
  64. object ListStreamsInput extends Companion[ListStreamsInput] with Serializable
  65. object ListStreamsInputLimit extends Newtype[Int]
  66. object ListStreamsOutput extends Companion[ListStreamsOutput] with Serializable
  67. object ListTagsForStreamInput extends Companion[ListTagsForStreamInput] with Serializable
  68. object ListTagsForStreamInputLimit extends Newtype[Int]
  69. object ListTagsForStreamOutput extends Companion[ListTagsForStreamOutput] with Serializable
  70. object MergeShardsInput extends Companion[MergeShardsInput] with Serializable
  71. object MetricsName extends Enumeration[MetricsName] with Companion[MetricsName] with Serializable
  72. object MetricsNameList extends Newtype[List[MetricsName]]
  73. object MillisBehindLatest extends Newtype[Long]
  74. object NextToken extends Newtype[String]
  75. object NonNegativeIntegerObject extends Newtype[Int]
  76. object OnDemandStreamCountLimitObject extends Newtype[Int]
  77. object OnDemandStreamCountObject extends Newtype[Int]
  78. object PartitionKey extends Newtype[String]
  79. object PositiveIntegerObject extends Newtype[Int]
  80. object ProvisionedThroughputExceededException extends Companion[ProvisionedThroughputExceededException] with Serializable
  81. object PutRecordInput extends Companion[PutRecordInput] with Serializable
  82. object PutRecordOutput extends Companion[PutRecordOutput] with Serializable
  83. object PutRecordsInput extends Companion[PutRecordsInput] with Serializable
  84. object PutRecordsOutput extends Companion[PutRecordsOutput] with Serializable
  85. object PutRecordsRequestEntry extends Companion[PutRecordsRequestEntry] with Serializable
  86. object PutRecordsRequestEntryList extends Newtype[List[PutRecordsRequestEntry]]

  87. object PutRecordsResultEntry extends Companion[PutRecordsResultEntry] with Serializable
  88. object PutRecordsResultEntryList extends Newtype[List[PutRecordsResultEntry]]

  89. object Record extends Companion[Record] with Serializable
  90. object RecordList extends Newtype[List[Record]]

  91. object RegisterStreamConsumerInput extends Companion[RegisterStreamConsumerInput] with Serializable
  92. object RegisterStreamConsumerOutput extends Companion[RegisterStreamConsumerOutput] with Serializable
  93. object RemoveTagsFromStreamInput extends Companion[RemoveTagsFromStreamInput] with Serializable
  94. object ResourceInUseException extends Companion[ResourceInUseException] with Serializable
  95. object ResourceNotFoundException extends Companion[ResourceNotFoundException] with Serializable
  96. object RetentionPeriodHours extends Newtype[Int]
  97. object ScalingType extends Enumeration[ScalingType] with Companion[ScalingType] with Serializable
  98. object SequenceNumber extends Newtype[String]
  99. object SequenceNumberRange extends Companion[SequenceNumberRange] with Serializable
  100. object Shard extends Companion[Shard] with Serializable
  101. object ShardCountObject extends Newtype[Int]
  102. object ShardFilter extends Companion[ShardFilter] with Serializable
  103. object ShardFilterType extends Enumeration[ShardFilterType] with Companion[ShardFilterType] with Serializable
  104. object ShardId extends Newtype[String]
  105. object ShardIdList extends Newtype[List[ShardId]]
  106. object ShardIterator extends Newtype[String]
  107. object ShardIteratorType extends Enumeration[ShardIteratorType] with Companion[ShardIteratorType] with Serializable
  108. object ShardList extends Newtype[List[Shard]]

  109. object SplitShardInput extends Companion[SplitShardInput] with Serializable
  110. object StartStreamEncryptionInput extends Companion[StartStreamEncryptionInput] with Serializable
  111. object StartingPosition extends Companion[StartingPosition] with Serializable
  112. object StopStreamEncryptionInput extends Companion[StopStreamEncryptionInput] with Serializable
  113. object StreamARN extends Newtype[String]
  114. object StreamDescription extends Companion[StreamDescription] with Serializable
  115. object StreamDescriptionSummary extends Companion[StreamDescriptionSummary] with Serializable
  116. object StreamMode extends Enumeration[StreamMode] with Companion[StreamMode] with Serializable
  117. object StreamModeDetails extends Companion[StreamModeDetails] with Serializable
  118. object StreamName extends Newtype[String]
  119. object StreamNameList extends Newtype[List[StreamName]]
  120. object StreamStatus extends Enumeration[StreamStatus] with Companion[StreamStatus] with Serializable
  121. object StreamSummary extends Companion[StreamSummary] with Serializable
  122. object StreamSummaryList extends Newtype[List[StreamSummary]]

  123. object SubscribeToShardEvent extends Companion[SubscribeToShardEvent] with Serializable
  124. object SubscribeToShardEventStream extends Companion[SubscribeToShardEventStream] with Serializable
  125. object SubscribeToShardInput extends Companion[SubscribeToShardInput] with Serializable
  126. object SubscribeToShardOutput extends Companion[SubscribeToShardOutput] with Serializable
  127. object Tag extends Companion[Tag] with Serializable
  128. object TagKey extends Newtype[String]
  129. object TagKeyList extends Newtype[List[TagKey]]
  130. object TagList extends Newtype[List[Tag]]

  131. object TagMap extends Newtype[Map[TagKey, TagValue]]
  132. object TagValue extends Newtype[String]
  133. object UpdateShardCountInput extends Companion[UpdateShardCountInput] with Serializable
  134. object UpdateShardCountOutput extends Companion[UpdateShardCountOutput] with Serializable
  135. object UpdateStreamModeInput extends Companion[UpdateStreamModeInput] with Serializable
  136. object ValidationException extends Companion[ValidationException] with Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped