package kinesis
- Source
- package.scala
- Alphabetic
- By Inheritance
- kinesis
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
- 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.
- case class AddTagsToStreamInput(tags: Map[TagKey, TagValue], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for
AddTagsToStream
. - type BooleanObject = kinesis.BooleanObject.Type
- 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.
- type ChildShardList = kinesis.ChildShardList.Type
- 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.
- type ConsumerARN = kinesis.ConsumerARN.Type
- type ConsumerCountObject = kinesis.ConsumerCountObject.Type
- 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.
- type ConsumerList = kinesis.ConsumerList.Type
- type ConsumerName = kinesis.ConsumerName.Type
- sealed abstract class ConsumerStatus extends Value
- case class CreateStreamInput(streamName: StreamName, shardCount: Option[PositiveIntegerObject] = None, streamModeDetails: Option[StreamModeDetails] = None) extends Product with Serializable
Represents the input for
CreateStream
. - type Data = kinesis.Data.Type
- case class DecreaseStreamRetentionPeriodInput(retentionPeriodHours: RetentionPeriodHours, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for DecreaseStreamRetentionPeriod.
- case class DeleteStreamInput(streamName: Option[StreamName] = None, enforceConsumerDeletion: Option[BooleanObject] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for DeleteStream.
- case class DeregisterStreamConsumerInput(streamARN: Option[StreamARN] = None, consumerName: Option[ConsumerName] = None, consumerARN: Option[ConsumerARN] = None) extends Product with Serializable
- case class DescribeLimitsInput() extends Product with Serializable
- case class DescribeLimitsOutput(shardLimit: ShardCountObject, openShardCount: ShardCountObject, onDemandStreamCount: OnDemandStreamCountObject, onDemandStreamCountLimit: OnDemandStreamCountLimitObject) extends Product with Serializable
- case class DescribeStreamConsumerInput(streamARN: Option[StreamARN] = None, consumerName: Option[ConsumerName] = None, consumerARN: Option[ConsumerARN] = None) extends Product with Serializable
- case class DescribeStreamConsumerOutput(consumerDescription: ConsumerDescription) extends Product with Serializable
- 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
. - type DescribeStreamInputLimit = kinesis.DescribeStreamInputLimit.Type
- case class DescribeStreamOutput(streamDescription: StreamDescription) extends Product with Serializable
Represents the output for
DescribeStream
. - case class DescribeStreamSummaryInput(streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
- case class DescribeStreamSummaryOutput(streamDescriptionSummary: StreamDescriptionSummary) extends Product with Serializable
- case class DisableEnhancedMonitoringInput(shardLevelMetrics: List[MetricsName], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for DisableEnhancedMonitoring.
- case class EnableEnhancedMonitoringInput(shardLevelMetrics: List[MetricsName], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for EnableEnhancedMonitoring.
- sealed abstract class EncryptionType extends Value
- case class EnhancedMetrics(shardLevelMetrics: Option[List[MetricsName]] = None) extends Product with Serializable
Represents enhanced metrics types.
- type EnhancedMonitoringList = kinesis.EnhancedMonitoringList.Type
- 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.
- type ErrorCode = kinesis.ErrorCode.Type
- type ErrorMessage = kinesis.ErrorMessage.Type
- 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.
- case class ExpiredNextTokenException(message: Option[ErrorMessage] = None) extends Throwable with Product with Serializable
The pagination token passed to the operation is expired.
- case class GetRecordsInput(shardIterator: ShardIterator, limit: Option[GetRecordsInputLimit] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for GetRecords.
- type GetRecordsInputLimit = kinesis.GetRecordsInputLimit.Type
- 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.
- 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
. - case class GetShardIteratorOutput(shardIterator: Option[ShardIterator] = None) extends Product with Serializable
Represents the output for
GetShardIterator
. - type HashKey = kinesis.HashKey.Type
- 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.
- case class IncreaseStreamRetentionPeriodInput(retentionPeriodHours: RetentionPeriodHours, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for IncreaseStreamRetentionPeriod.
- 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.
- 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.
- 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.
- 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.
- 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.
- 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.
- 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.
- 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.
- type KeyId = kinesis.KeyId.Type
- type Kinesis[F[_]] = KinesisGen[[I, E, O, SI, SO]F[O]]
- 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.
- sealed trait KinesisOperation[Input, Err, Output, StreamedInput, StreamedOutput] extends AnyRef
- 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.
- 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
- type ListShardsInputLimit = kinesis.ListShardsInputLimit.Type
- case class ListShardsOutput(shards: Option[List[Shard]] = None, nextToken: Option[NextToken] = None) extends Product with Serializable
- case class ListStreamConsumersInput(streamARN: StreamARN, nextToken: Option[NextToken] = None, maxResults: Option[ListStreamConsumersInputLimit] = None, streamCreationTimestamp: Option[Timestamp] = None) extends Product with Serializable
- type ListStreamConsumersInputLimit = kinesis.ListStreamConsumersInputLimit.Type
- case class ListStreamConsumersOutput(consumers: Option[List[Consumer]] = None, nextToken: Option[NextToken] = None) extends Product with Serializable
- case class ListStreamsInput(limit: Option[ListStreamsInputLimit] = None, exclusiveStartStreamName: Option[StreamName] = None, nextToken: Option[NextToken] = None) extends Product with Serializable
Represents the input for
ListStreams
. - type ListStreamsInputLimit = kinesis.ListStreamsInputLimit.Type
- 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
. - 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
. - type ListTagsForStreamInputLimit = kinesis.ListTagsForStreamInputLimit.Type
- case class ListTagsForStreamOutput(tags: List[Tag], hasMoreTags: BooleanObject) extends Product with Serializable
Represents the output for
ListTagsForStream
. - case class MergeShardsInput(shardToMerge: ShardId, adjacentShardToMerge: ShardId, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for
MergeShards
. - sealed abstract class MetricsName extends Value
- type MetricsNameList = kinesis.MetricsNameList.Type
- type MillisBehindLatest = kinesis.MillisBehindLatest.Type
- type NextToken = kinesis.NextToken.Type
- type NonNegativeIntegerObject = kinesis.NonNegativeIntegerObject.Type
- type OnDemandStreamCountLimitObject = kinesis.OnDemandStreamCountLimitObject.Type
- type OnDemandStreamCountObject = kinesis.OnDemandStreamCountObject.Type
- type PartitionKey = kinesis.PartitionKey.Type
- type PositiveIntegerObject = kinesis.PositiveIntegerObject.Type
- 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.
- 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
. - case class PutRecordOutput(shardId: ShardId, sequenceNumber: SequenceNumber, encryptionType: Option[EncryptionType] = None) extends Product with Serializable
Represents the output for
PutRecord
. - case class PutRecordsInput(records: List[PutRecordsRequestEntry], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
A
PutRecords
request. - case class PutRecordsOutput(records: List[PutRecordsResultEntry], failedRecordCount: Option[NonNegativeIntegerObject] = None, encryptionType: Option[EncryptionType] = None) extends Product with Serializable
PutRecords
results. - case class PutRecordsRequestEntry(data: Data, partitionKey: PartitionKey, explicitHashKey: Option[HashKey] = None) extends Product with Serializable
Represents the output for
PutRecords
. - type PutRecordsRequestEntryList = kinesis.PutRecordsRequestEntryList.Type
- 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 includesSequenceNumber
andShardId
in the result. A record that fails to be added to the stream includesErrorCode
andErrorMessage
in the result. - type PutRecordsResultEntryList = kinesis.PutRecordsResultEntryList.Type
- 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.
- type RecordList = kinesis.RecordList.Type
- case class RegisterStreamConsumerInput(streamARN: StreamARN, consumerName: ConsumerName) extends Product with Serializable
- case class RegisterStreamConsumerOutput(consumer: Consumer) extends Product with Serializable
- case class RemoveTagsFromStreamInput(tagKeys: List[TagKey], streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for
RemoveTagsFromStream
. - 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.
- 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.
- type RetentionPeriodHours = kinesis.RetentionPeriodHours.Type
- sealed abstract class ScalingType extends Value
- type SequenceNumber = kinesis.SequenceNumber.Type
- case class SequenceNumberRange(startingSequenceNumber: SequenceNumber, endingSequenceNumber: Option[SequenceNumber] = None) extends Product with Serializable
The range of possible sequence numbers for the shard.
- 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.
- type ShardCountObject = kinesis.ShardCountObject.Type
- 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. - sealed abstract class ShardFilterType extends Value
- type ShardId = kinesis.ShardId.Type
- type ShardIdList = kinesis.ShardIdList.Type
- type ShardIterator = kinesis.ShardIterator.Type
- sealed abstract class ShardIteratorType extends Value
- type ShardList = kinesis.ShardList.Type
- case class SplitShardInput(shardToSplit: ShardId, newStartingHashKey: HashKey, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
Represents the input for
SplitShard
. - case class StartStreamEncryptionInput(encryptionType: EncryptionType, keyId: KeyId, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
- 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.
- case class StopStreamEncryptionInput(encryptionType: EncryptionType, keyId: KeyId, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
- type StreamARN = kinesis.StreamARN.Type
- 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.
- 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
- sealed abstract class StreamMode extends Value
- 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.
- type StreamName = kinesis.StreamName.Type
- type StreamNameList = kinesis.StreamNameList.Type
- sealed abstract class StreamStatus extends Value
- 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.
- type StreamSummaryList = kinesis.StreamSummaryList.Type
- 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.
- 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.
- case class SubscribeToShardInput(consumerARN: ConsumerARN, shardId: ShardId, startingPosition: StartingPosition) extends Product with Serializable
- case class SubscribeToShardOutput() extends Product with Serializable
- case class Tag(key: TagKey, value: Option[TagValue] = None) extends Product with Serializable
Metadata assigned to the stream, consisting of a key-value pair.
- type TagKey = kinesis.TagKey.Type
- type TagKeyList = kinesis.TagKeyList.Type
- type TagList = kinesis.TagList.Type
- type TagMap = kinesis.TagMap.Type
- type TagValue = kinesis.TagValue.Type
- case class UpdateShardCountInput(targetShardCount: PositiveIntegerObject, scalingType: ScalingType, streamName: Option[StreamName] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
- case class UpdateShardCountOutput(streamName: Option[StreamName] = None, currentShardCount: Option[PositiveIntegerObject] = None, targetShardCount: Option[PositiveIntegerObject] = None, streamARN: Option[StreamARN] = None) extends Product with Serializable
- case class UpdateStreamModeInput(streamARN: StreamARN, streamModeDetails: StreamModeDetails) extends Product with Serializable
- 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
- val Kinesis: KinesisGen.type
- object AccessDeniedException extends Companion[AccessDeniedException] with Serializable
- object AddTagsToStreamInput extends Companion[AddTagsToStreamInput] with Serializable
- object BooleanObject extends Newtype[Boolean]
- object ChildShard extends Companion[ChildShard] with Serializable
- object ChildShardList extends Newtype[List[ChildShard]]
- object Consumer extends Companion[Consumer] with Serializable
- object ConsumerARN extends Newtype[String]
- object ConsumerCountObject extends Newtype[Int]
- object ConsumerDescription extends Companion[ConsumerDescription] with Serializable
- object ConsumerList extends Newtype[List[Consumer]]
- object ConsumerName extends Newtype[String]
- object ConsumerStatus extends Enumeration[ConsumerStatus] with Companion[ConsumerStatus] with Serializable
- object CreateStreamInput extends Companion[CreateStreamInput] with Serializable
- object Data extends Newtype[ByteArray]
- object DecreaseStreamRetentionPeriodInput extends Companion[DecreaseStreamRetentionPeriodInput] with Serializable
- object DeleteStreamInput extends Companion[DeleteStreamInput] with Serializable
- object DeregisterStreamConsumerInput extends Companion[DeregisterStreamConsumerInput] with Serializable
- object DescribeLimitsInput extends Companion[DescribeLimitsInput] with Serializable
- object DescribeLimitsOutput extends Companion[DescribeLimitsOutput] with Serializable
- object DescribeStreamConsumerInput extends Companion[DescribeStreamConsumerInput] with Serializable
- object DescribeStreamConsumerOutput extends Companion[DescribeStreamConsumerOutput] with Serializable
- object DescribeStreamInput extends Companion[DescribeStreamInput] with Serializable
- object DescribeStreamInputLimit extends Newtype[Int]
- object DescribeStreamOutput extends Companion[DescribeStreamOutput] with Serializable
- object DescribeStreamSummaryInput extends Companion[DescribeStreamSummaryInput] with Serializable
- object DescribeStreamSummaryOutput extends Companion[DescribeStreamSummaryOutput] with Serializable
- object DisableEnhancedMonitoringInput extends Companion[DisableEnhancedMonitoringInput] with Serializable
- object EnableEnhancedMonitoringInput extends Companion[EnableEnhancedMonitoringInput] with Serializable
- object EncryptionType extends Enumeration[EncryptionType] with Companion[EncryptionType] with Serializable
- object EnhancedMetrics extends Companion[EnhancedMetrics] with Serializable
- object EnhancedMonitoringList extends Newtype[List[EnhancedMetrics]]
- object EnhancedMonitoringOutput extends Companion[EnhancedMonitoringOutput] with Serializable
- object ErrorCode extends Newtype[String]
- object ErrorMessage extends Newtype[String]
- object ExpiredIteratorException extends Companion[ExpiredIteratorException] with Serializable
- object ExpiredNextTokenException extends Companion[ExpiredNextTokenException] with Serializable
- object GetRecordsInput extends Companion[GetRecordsInput] with Serializable
- object GetRecordsInputLimit extends Newtype[Int]
- object GetRecordsOutput extends Companion[GetRecordsOutput] with Serializable
- object GetShardIteratorInput extends Companion[GetShardIteratorInput] with Serializable
- object GetShardIteratorOutput extends Companion[GetShardIteratorOutput] with Serializable
- object HashKey extends Newtype[String]
- object HashKeyRange extends Companion[HashKeyRange] with Serializable
- object IncreaseStreamRetentionPeriodInput extends Companion[IncreaseStreamRetentionPeriodInput] with Serializable
- object InternalFailureException extends Companion[InternalFailureException] with Serializable
- object InvalidArgumentException extends Companion[InvalidArgumentException] with Serializable
- object KMSAccessDeniedException extends Companion[KMSAccessDeniedException] with Serializable
- object KMSDisabledException extends Companion[KMSDisabledException] with Serializable
- object KMSInvalidStateException extends Companion[KMSInvalidStateException] with Serializable
- object KMSNotFoundException extends Companion[KMSNotFoundException] with Serializable
- object KMSOptInRequired extends Companion[KMSOptInRequired] with Serializable
- object KMSThrottlingException extends Companion[KMSThrottlingException] with Serializable
- object KeyId extends Newtype[String]
- object KinesisGen extends Mixin[KinesisGen, KinesisOperation]
- object KinesisOperation
- object LimitExceededException extends Companion[LimitExceededException] with Serializable
- object ListShardsInput extends Companion[ListShardsInput] with Serializable
- object ListShardsInputLimit extends Newtype[Int]
- object ListShardsOutput extends Companion[ListShardsOutput] with Serializable
- object ListStreamConsumersInput extends Companion[ListStreamConsumersInput] with Serializable
- object ListStreamConsumersInputLimit extends Newtype[Int]
- object ListStreamConsumersOutput extends Companion[ListStreamConsumersOutput] with Serializable
- object ListStreamsInput extends Companion[ListStreamsInput] with Serializable
- object ListStreamsInputLimit extends Newtype[Int]
- object ListStreamsOutput extends Companion[ListStreamsOutput] with Serializable
- object ListTagsForStreamInput extends Companion[ListTagsForStreamInput] with Serializable
- object ListTagsForStreamInputLimit extends Newtype[Int]
- object ListTagsForStreamOutput extends Companion[ListTagsForStreamOutput] with Serializable
- object MergeShardsInput extends Companion[MergeShardsInput] with Serializable
- object MetricsName extends Enumeration[MetricsName] with Companion[MetricsName] with Serializable
- object MetricsNameList extends Newtype[List[MetricsName]]
- object MillisBehindLatest extends Newtype[Long]
- object NextToken extends Newtype[String]
- object NonNegativeIntegerObject extends Newtype[Int]
- object OnDemandStreamCountLimitObject extends Newtype[Int]
- object OnDemandStreamCountObject extends Newtype[Int]
- object PartitionKey extends Newtype[String]
- object PositiveIntegerObject extends Newtype[Int]
- object ProvisionedThroughputExceededException extends Companion[ProvisionedThroughputExceededException] with Serializable
- object PutRecordInput extends Companion[PutRecordInput] with Serializable
- object PutRecordOutput extends Companion[PutRecordOutput] with Serializable
- object PutRecordsInput extends Companion[PutRecordsInput] with Serializable
- object PutRecordsOutput extends Companion[PutRecordsOutput] with Serializable
- object PutRecordsRequestEntry extends Companion[PutRecordsRequestEntry] with Serializable
- object PutRecordsRequestEntryList extends Newtype[List[PutRecordsRequestEntry]]
- object PutRecordsResultEntry extends Companion[PutRecordsResultEntry] with Serializable
- object PutRecordsResultEntryList extends Newtype[List[PutRecordsResultEntry]]
- object Record extends Companion[Record] with Serializable
- object RecordList extends Newtype[List[Record]]
- object RegisterStreamConsumerInput extends Companion[RegisterStreamConsumerInput] with Serializable
- object RegisterStreamConsumerOutput extends Companion[RegisterStreamConsumerOutput] with Serializable
- object RemoveTagsFromStreamInput extends Companion[RemoveTagsFromStreamInput] with Serializable
- object ResourceInUseException extends Companion[ResourceInUseException] with Serializable
- object ResourceNotFoundException extends Companion[ResourceNotFoundException] with Serializable
- object RetentionPeriodHours extends Newtype[Int]
- object ScalingType extends Enumeration[ScalingType] with Companion[ScalingType] with Serializable
- object SequenceNumber extends Newtype[String]
- object SequenceNumberRange extends Companion[SequenceNumberRange] with Serializable
- object Shard extends Companion[Shard] with Serializable
- object ShardCountObject extends Newtype[Int]
- object ShardFilter extends Companion[ShardFilter] with Serializable
- object ShardFilterType extends Enumeration[ShardFilterType] with Companion[ShardFilterType] with Serializable
- object ShardId extends Newtype[String]
- object ShardIdList extends Newtype[List[ShardId]]
- object ShardIterator extends Newtype[String]
- object ShardIteratorType extends Enumeration[ShardIteratorType] with Companion[ShardIteratorType] with Serializable
- object ShardList extends Newtype[List[Shard]]
- object SplitShardInput extends Companion[SplitShardInput] with Serializable
- object StartStreamEncryptionInput extends Companion[StartStreamEncryptionInput] with Serializable
- object StartingPosition extends Companion[StartingPosition] with Serializable
- object StopStreamEncryptionInput extends Companion[StopStreamEncryptionInput] with Serializable
- object StreamARN extends Newtype[String]
- object StreamDescription extends Companion[StreamDescription] with Serializable
- object StreamDescriptionSummary extends Companion[StreamDescriptionSummary] with Serializable
- object StreamMode extends Enumeration[StreamMode] with Companion[StreamMode] with Serializable
- object StreamModeDetails extends Companion[StreamModeDetails] with Serializable
- object StreamName extends Newtype[String]
- object StreamNameList extends Newtype[List[StreamName]]
- object StreamStatus extends Enumeration[StreamStatus] with Companion[StreamStatus] with Serializable
- object StreamSummary extends Companion[StreamSummary] with Serializable
- object StreamSummaryList extends Newtype[List[StreamSummary]]
- object SubscribeToShardEvent extends Companion[SubscribeToShardEvent] with Serializable
- object SubscribeToShardEventStream extends Companion[SubscribeToShardEventStream] with Serializable
- object SubscribeToShardInput extends Companion[SubscribeToShardInput] with Serializable
- object SubscribeToShardOutput extends Companion[SubscribeToShardOutput] with Serializable
- object Tag extends Companion[Tag] with Serializable
- object TagKey extends Newtype[String]
- object TagKeyList extends Newtype[List[TagKey]]
- object TagList extends Newtype[List[Tag]]
- object TagMap extends Newtype[Map[TagKey, TagValue]]
- object TagValue extends Newtype[String]
- object UpdateShardCountInput extends Companion[UpdateShardCountInput] with Serializable
- object UpdateShardCountOutput extends Companion[UpdateShardCountOutput] with Serializable
- object UpdateStreamModeInput extends Companion[UpdateStreamModeInput] with Serializable
- object ValidationException extends Companion[ValidationException] with Serializable