Copyright | (c) 2013-2021 Brendan Hay |
---|---|
License | Mozilla Public License, v. 2.0. |
Maintainer | Brendan Hay <brendan.g.hay+amazonka@gmail.com> |
Stability | auto-generated |
Portability | non-portable (GHC extensions) |
Safe Haskell | None |
- Service Configuration
- Errors
- KMSInvalidStateException
- KMSThrottlingException
- ExpiredIteratorException
- InvalidArgumentException
- KMSOptInRequired
- ProvisionedThroughputExceededException
- KMSNotFoundException
- ExpiredNextTokenException
- KMSDisabledException
- InternalFailureException
- ResourceNotFoundException
- KMSAccessDeniedException
- LimitExceededException
- ResourceInUseException
- Waiters
- Operations
- PutRecord
- SubscribeToShard
- DecreaseStreamRetentionPeriod
- MergeShards
- DeregisterStreamConsumer
- DescribeStreamSummary
- GetShardIterator
- GetRecords
- StopStreamEncryption
- EnableEnhancedMonitoring
- DescribeLimits
- RegisterStreamConsumer
- DisableEnhancedMonitoring
- UpdateShardCount
- ListTagsForStream
- DescribeStreamConsumer
- AddTagsToStream
- PutRecords
- ListShards (Paginated)
- DeleteStream
- RemoveTagsFromStream
- ListStreams (Paginated)
- CreateStream
- StartStreamEncryption
- ListStreamConsumers (Paginated)
- SplitShard
- IncreaseStreamRetentionPeriod
- DescribeStream (Paginated)
- Types
- ConsumerStatus
- EncryptionType
- MetricsName
- ScalingType
- ShardFilterType
- ShardIteratorType
- StreamStatus
- ChildShard
- Consumer
- ConsumerDescription
- EnhancedMetrics
- EnhancedMonitoringOutput
- HashKeyRange
- PutRecordsRequestEntry
- PutRecordsResultEntry
- Record
- SequenceNumberRange
- Shard
- ShardFilter
- StartingPosition
- StreamDescription
- StreamDescriptionSummary
- SubscribeToShardEvent
- Tag
Derived from API version 2013-12-02
of the AWS service descriptions, licensed under Apache 2.0.
Amazon Kinesis Data Streams Service API Reference
Amazon Kinesis Data Streams is a managed service that scales elastically for real-time processing of streaming big data.
Synopsis
- defaultService :: Service
- _KMSInvalidStateException :: AsError a => Getting (First ServiceError) a ServiceError
- _KMSThrottlingException :: AsError a => Getting (First ServiceError) a ServiceError
- _ExpiredIteratorException :: AsError a => Getting (First ServiceError) a ServiceError
- _InvalidArgumentException :: AsError a => Getting (First ServiceError) a ServiceError
- _KMSOptInRequired :: AsError a => Getting (First ServiceError) a ServiceError
- _ProvisionedThroughputExceededException :: AsError a => Getting (First ServiceError) a ServiceError
- _KMSNotFoundException :: AsError a => Getting (First ServiceError) a ServiceError
- _ExpiredNextTokenException :: AsError a => Getting (First ServiceError) a ServiceError
- _KMSDisabledException :: AsError a => Getting (First ServiceError) a ServiceError
- _InternalFailureException :: AsError a => Getting (First ServiceError) a ServiceError
- _ResourceNotFoundException :: AsError a => Getting (First ServiceError) a ServiceError
- _KMSAccessDeniedException :: AsError a => Getting (First ServiceError) a ServiceError
- _LimitExceededException :: AsError a => Getting (First ServiceError) a ServiceError
- _ResourceInUseException :: AsError a => Getting (First ServiceError) a ServiceError
- newStreamExists :: Wait DescribeStream
- newStreamNotExists :: Wait DescribeStream
- data PutRecord = PutRecord' (Maybe Text) (Maybe Text) Text Base64 Text
- newPutRecord :: Text -> ByteString -> Text -> PutRecord
- data PutRecordResponse = PutRecordResponse' (Maybe EncryptionType) Int Text Text
- newPutRecordResponse :: Int -> Text -> Text -> PutRecordResponse
- data SubscribeToShard = SubscribeToShard' Text Text StartingPosition
- newSubscribeToShard :: Text -> Text -> StartingPosition -> SubscribeToShard
- data SubscribeToShardResponse = SubscribeToShardResponse' Int Value
- newSubscribeToShardResponse :: Int -> Value -> SubscribeToShardResponse
- data DecreaseStreamRetentionPeriod = DecreaseStreamRetentionPeriod' Text Int
- newDecreaseStreamRetentionPeriod :: Text -> Int -> DecreaseStreamRetentionPeriod
- data DecreaseStreamRetentionPeriodResponse = DecreaseStreamRetentionPeriodResponse' {
- newDecreaseStreamRetentionPeriodResponse :: DecreaseStreamRetentionPeriodResponse
- data MergeShards = MergeShards' Text Text Text
- newMergeShards :: Text -> Text -> Text -> MergeShards
- data MergeShardsResponse = MergeShardsResponse' {
- newMergeShardsResponse :: MergeShardsResponse
- data DeregisterStreamConsumer = DeregisterStreamConsumer' (Maybe Text) (Maybe Text) (Maybe Text)
- newDeregisterStreamConsumer :: DeregisterStreamConsumer
- data DeregisterStreamConsumerResponse = DeregisterStreamConsumerResponse' {
- newDeregisterStreamConsumerResponse :: DeregisterStreamConsumerResponse
- data DescribeStreamSummary = DescribeStreamSummary' Text
- newDescribeStreamSummary :: Text -> DescribeStreamSummary
- data DescribeStreamSummaryResponse = DescribeStreamSummaryResponse' Int StreamDescriptionSummary
- newDescribeStreamSummaryResponse :: Int -> StreamDescriptionSummary -> DescribeStreamSummaryResponse
- data GetShardIterator = GetShardIterator' (Maybe Text) (Maybe POSIX) Text Text ShardIteratorType
- newGetShardIterator :: Text -> Text -> ShardIteratorType -> GetShardIterator
- data GetShardIteratorResponse = GetShardIteratorResponse' (Maybe Text) Int
- newGetShardIteratorResponse :: Int -> GetShardIteratorResponse
- data GetRecords = GetRecords' (Maybe Natural) Text
- newGetRecords :: Text -> GetRecords
- data GetRecordsResponse = GetRecordsResponse' (Maybe Text) (Maybe Natural) (Maybe [ChildShard]) Int [Record]
- newGetRecordsResponse :: Int -> GetRecordsResponse
- data StopStreamEncryption = StopStreamEncryption' Text EncryptionType Text
- newStopStreamEncryption :: Text -> EncryptionType -> Text -> StopStreamEncryption
- data StopStreamEncryptionResponse = StopStreamEncryptionResponse' {
- newStopStreamEncryptionResponse :: StopStreamEncryptionResponse
- data EnableEnhancedMonitoring = EnableEnhancedMonitoring' Text [MetricsName]
- newEnableEnhancedMonitoring :: Text -> EnableEnhancedMonitoring
- data EnhancedMonitoringOutput = EnhancedMonitoringOutput' (Maybe [MetricsName]) (Maybe [MetricsName]) (Maybe Text)
- newEnhancedMonitoringOutput :: EnhancedMonitoringOutput
- data DescribeLimits = DescribeLimits' {
- newDescribeLimits :: DescribeLimits
- data DescribeLimitsResponse = DescribeLimitsResponse' Int Natural Natural
- newDescribeLimitsResponse :: Int -> Natural -> Natural -> DescribeLimitsResponse
- data RegisterStreamConsumer = RegisterStreamConsumer' Text Text
- newRegisterStreamConsumer :: Text -> Text -> RegisterStreamConsumer
- data RegisterStreamConsumerResponse = RegisterStreamConsumerResponse' Int Consumer
- newRegisterStreamConsumerResponse :: Int -> Consumer -> RegisterStreamConsumerResponse
- data DisableEnhancedMonitoring = DisableEnhancedMonitoring' Text [MetricsName]
- newDisableEnhancedMonitoring :: Text -> DisableEnhancedMonitoring
- data EnhancedMonitoringOutput = EnhancedMonitoringOutput' (Maybe [MetricsName]) (Maybe [MetricsName]) (Maybe Text)
- newEnhancedMonitoringOutput :: EnhancedMonitoringOutput
- data UpdateShardCount = UpdateShardCount' Text Natural ScalingType
- newUpdateShardCount :: Text -> Natural -> ScalingType -> UpdateShardCount
- data UpdateShardCountResponse = UpdateShardCountResponse' (Maybe Natural) (Maybe Text) (Maybe Natural) Int
- newUpdateShardCountResponse :: Int -> UpdateShardCountResponse
- data ListTagsForStream = ListTagsForStream' (Maybe Natural) (Maybe Text) Text
- newListTagsForStream :: Text -> ListTagsForStream
- data ListTagsForStreamResponse = ListTagsForStreamResponse' Int [Tag] Bool
- newListTagsForStreamResponse :: Int -> Bool -> ListTagsForStreamResponse
- data DescribeStreamConsumer = DescribeStreamConsumer' (Maybe Text) (Maybe Text) (Maybe Text)
- newDescribeStreamConsumer :: DescribeStreamConsumer
- data DescribeStreamConsumerResponse = DescribeStreamConsumerResponse' Int ConsumerDescription
- newDescribeStreamConsumerResponse :: Int -> ConsumerDescription -> DescribeStreamConsumerResponse
- data AddTagsToStream = AddTagsToStream' Text (HashMap Text Text)
- newAddTagsToStream :: Text -> AddTagsToStream
- data AddTagsToStreamResponse = AddTagsToStreamResponse' {
- newAddTagsToStreamResponse :: AddTagsToStreamResponse
- data PutRecords = PutRecords' (NonEmpty PutRecordsRequestEntry) Text
- newPutRecords :: NonEmpty PutRecordsRequestEntry -> Text -> PutRecords
- data PutRecordsResponse = PutRecordsResponse' (Maybe EncryptionType) (Maybe Natural) Int (NonEmpty PutRecordsResultEntry)
- newPutRecordsResponse :: Int -> NonEmpty PutRecordsResultEntry -> PutRecordsResponse
- data ListShards = ListShards' (Maybe ShardFilter) (Maybe Text) (Maybe Text) (Maybe POSIX) (Maybe Text) (Maybe Natural)
- newListShards :: ListShards
- data ListShardsResponse = ListShardsResponse' (Maybe Text) (Maybe [Shard]) Int
- newListShardsResponse :: Int -> ListShardsResponse
- data DeleteStream = DeleteStream' (Maybe Bool) Text
- newDeleteStream :: Text -> DeleteStream
- data DeleteStreamResponse = DeleteStreamResponse' {
- newDeleteStreamResponse :: DeleteStreamResponse
- data RemoveTagsFromStream = RemoveTagsFromStream' Text (NonEmpty Text)
- newRemoveTagsFromStream :: Text -> NonEmpty Text -> RemoveTagsFromStream
- data RemoveTagsFromStreamResponse = RemoveTagsFromStreamResponse' {
- newRemoveTagsFromStreamResponse :: RemoveTagsFromStreamResponse
- data ListStreams = ListStreams' (Maybe Natural) (Maybe Text)
- newListStreams :: ListStreams
- data ListStreamsResponse = ListStreamsResponse' Int [Text] Bool
- newListStreamsResponse :: Int -> Bool -> ListStreamsResponse
- data CreateStream = CreateStream' Text Natural
- newCreateStream :: Text -> Natural -> CreateStream
- data CreateStreamResponse = CreateStreamResponse' {
- newCreateStreamResponse :: CreateStreamResponse
- data StartStreamEncryption = StartStreamEncryption' Text EncryptionType Text
- newStartStreamEncryption :: Text -> EncryptionType -> Text -> StartStreamEncryption
- data StartStreamEncryptionResponse = StartStreamEncryptionResponse' {
- newStartStreamEncryptionResponse :: StartStreamEncryptionResponse
- data ListStreamConsumers = ListStreamConsumers' (Maybe Text) (Maybe POSIX) (Maybe Natural) Text
- newListStreamConsumers :: Text -> ListStreamConsumers
- data ListStreamConsumersResponse = ListStreamConsumersResponse' (Maybe Text) (Maybe [Consumer]) Int
- newListStreamConsumersResponse :: Int -> ListStreamConsumersResponse
- data SplitShard = SplitShard' Text Text Text
- newSplitShard :: Text -> Text -> Text -> SplitShard
- data SplitShardResponse = SplitShardResponse' {
- newSplitShardResponse :: SplitShardResponse
- data IncreaseStreamRetentionPeriod = IncreaseStreamRetentionPeriod' Text Int
- newIncreaseStreamRetentionPeriod :: Text -> Int -> IncreaseStreamRetentionPeriod
- data IncreaseStreamRetentionPeriodResponse = IncreaseStreamRetentionPeriodResponse' {
- newIncreaseStreamRetentionPeriodResponse :: IncreaseStreamRetentionPeriodResponse
- data DescribeStream = DescribeStream' (Maybe Text) (Maybe Natural) Text
- newDescribeStream :: Text -> DescribeStream
- data DescribeStreamResponse = DescribeStreamResponse' Int StreamDescription
- newDescribeStreamResponse :: Int -> StreamDescription -> DescribeStreamResponse
- newtype ConsumerStatus where
- ConsumerStatus' { }
- pattern ConsumerStatus_ACTIVE :: ConsumerStatus
- pattern ConsumerStatus_CREATING :: ConsumerStatus
- pattern ConsumerStatus_DELETING :: ConsumerStatus
- newtype EncryptionType where
- EncryptionType' { }
- pattern EncryptionType_KMS :: EncryptionType
- pattern EncryptionType_NONE :: EncryptionType
- newtype MetricsName where
- MetricsName' { }
- pattern MetricsName_ALL :: MetricsName
- pattern MetricsName_IncomingBytes :: MetricsName
- pattern MetricsName_IncomingRecords :: MetricsName
- pattern MetricsName_IteratorAgeMilliseconds :: MetricsName
- pattern MetricsName_OutgoingBytes :: MetricsName
- pattern MetricsName_OutgoingRecords :: MetricsName
- pattern MetricsName_ReadProvisionedThroughputExceeded :: MetricsName
- pattern MetricsName_WriteProvisionedThroughputExceeded :: MetricsName
- newtype ScalingType where
- ScalingType' { }
- pattern ScalingType_UNIFORM_SCALING :: ScalingType
- newtype ShardFilterType where
- ShardFilterType' { }
- pattern ShardFilterType_AFTER_SHARD_ID :: ShardFilterType
- pattern ShardFilterType_AT_LATEST :: ShardFilterType
- pattern ShardFilterType_AT_TIMESTAMP :: ShardFilterType
- pattern ShardFilterType_AT_TRIM_HORIZON :: ShardFilterType
- pattern ShardFilterType_FROM_TIMESTAMP :: ShardFilterType
- pattern ShardFilterType_FROM_TRIM_HORIZON :: ShardFilterType
- newtype ShardIteratorType where
- ShardIteratorType' { }
- pattern ShardIteratorType_AFTER_SEQUENCE_NUMBER :: ShardIteratorType
- pattern ShardIteratorType_AT_SEQUENCE_NUMBER :: ShardIteratorType
- pattern ShardIteratorType_AT_TIMESTAMP :: ShardIteratorType
- pattern ShardIteratorType_LATEST :: ShardIteratorType
- pattern ShardIteratorType_TRIM_HORIZON :: ShardIteratorType
- newtype StreamStatus where
- StreamStatus' { }
- pattern StreamStatus_ACTIVE :: StreamStatus
- pattern StreamStatus_CREATING :: StreamStatus
- pattern StreamStatus_DELETING :: StreamStatus
- pattern StreamStatus_UPDATING :: StreamStatus
- data ChildShard = ChildShard' Text [Text] HashKeyRange
- newChildShard :: Text -> HashKeyRange -> ChildShard
- data Consumer = Consumer' Text Text ConsumerStatus POSIX
- newConsumer :: Text -> Text -> ConsumerStatus -> UTCTime -> Consumer
- data ConsumerDescription = ConsumerDescription' Text Text ConsumerStatus POSIX Text
- newConsumerDescription :: Text -> Text -> ConsumerStatus -> UTCTime -> Text -> ConsumerDescription
- data EnhancedMetrics = EnhancedMetrics' (Maybe [MetricsName])
- newEnhancedMetrics :: EnhancedMetrics
- data EnhancedMonitoringOutput = EnhancedMonitoringOutput' (Maybe [MetricsName]) (Maybe [MetricsName]) (Maybe Text)
- newEnhancedMonitoringOutput :: EnhancedMonitoringOutput
- data HashKeyRange = HashKeyRange' Text Text
- newHashKeyRange :: Text -> Text -> HashKeyRange
- data PutRecordsRequestEntry = PutRecordsRequestEntry' (Maybe Text) Base64 Text
- newPutRecordsRequestEntry :: ByteString -> Text -> PutRecordsRequestEntry
- data PutRecordsResultEntry = PutRecordsResultEntry' (Maybe Text) (Maybe Text) (Maybe Text) (Maybe Text)
- newPutRecordsResultEntry :: PutRecordsResultEntry
- data Record = Record' (Maybe EncryptionType) (Maybe POSIX) Text Base64 Text
- newRecord :: Text -> ByteString -> Text -> Record
- data SequenceNumberRange = SequenceNumberRange' (Maybe Text) Text
- newSequenceNumberRange :: Text -> SequenceNumberRange
- data Shard = Shard' (Maybe Text) (Maybe Text) Text HashKeyRange SequenceNumberRange
- newShard :: Text -> HashKeyRange -> SequenceNumberRange -> Shard
- data ShardFilter = ShardFilter' (Maybe POSIX) (Maybe Text) ShardFilterType
- newShardFilter :: ShardFilterType -> ShardFilter
- data StartingPosition = StartingPosition' (Maybe Text) (Maybe POSIX) ShardIteratorType
- newStartingPosition :: ShardIteratorType -> StartingPosition
- data StreamDescription = StreamDescription' (Maybe EncryptionType) (Maybe Text) Text Text StreamStatus [Shard] Bool Int POSIX [EnhancedMetrics]
- newStreamDescription :: Text -> Text -> StreamStatus -> Bool -> Int -> UTCTime -> StreamDescription
- data StreamDescriptionSummary = StreamDescriptionSummary' (Maybe EncryptionType) (Maybe Text) (Maybe Natural) Text Text StreamStatus Int POSIX [EnhancedMetrics] Natural
- newStreamDescriptionSummary :: Text -> Text -> StreamStatus -> Int -> UTCTime -> Natural -> StreamDescriptionSummary
- data SubscribeToShardEvent = SubscribeToShardEvent' (Maybe [ChildShard]) [Record] Text Natural
- newSubscribeToShardEvent :: Text -> Natural -> SubscribeToShardEvent
- data Tag = Tag' (Maybe Text) Text
- newTag :: Text -> Tag
Service Configuration
defaultService :: Service Source #
API version 2013-12-02
of the Amazon Kinesis SDK configuration.
Errors
Error matchers are designed for use with the functions provided by
Control.Exception.Lens.
This allows catching (and rethrowing) service specific errors returned
by Kinesis
.
KMSInvalidStateException
_KMSInvalidStateException :: AsError a => Getting (First ServiceError) a ServiceError Source #
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 AWS Key Management Service Developer Guide.
KMSThrottlingException
_KMSThrottlingException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The request was denied due to request throttling. For more information about throttling, see Limits in the AWS Key Management Service Developer Guide.
ExpiredIteratorException
_ExpiredIteratorException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The provided iterator exceeds the maximum age allowed.
InvalidArgumentException
_InvalidArgumentException :: AsError a => Getting (First ServiceError) a ServiceError Source #
A specified parameter exceeds its restrictions, is not supported, or can't be used. For more information, see the returned message.
KMSOptInRequired
_KMSOptInRequired :: AsError a => Getting (First ServiceError) a ServiceError Source #
The AWS access key ID needs a subscription for the service.
ProvisionedThroughputExceededException
_ProvisionedThroughputExceededException :: AsError a => Getting (First ServiceError) a ServiceError Source #
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 AWS in the AWS General Reference.
KMSNotFoundException
_KMSNotFoundException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The request was rejected because the specified entity or resource can't be found.
ExpiredNextTokenException
_ExpiredNextTokenException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The pagination token passed to the operation is expired.
KMSDisabledException
_KMSDisabledException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The request was rejected because the specified customer master key (CMK) isn't enabled.
InternalFailureException
_InternalFailureException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The processing of the request failed because of an unknown error, exception, or failure.
ResourceNotFoundException
_ResourceNotFoundException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The requested resource could not be found. The stream might not be specified correctly.
KMSAccessDeniedException
_KMSAccessDeniedException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The ciphertext references a key that doesn't exist or that you don't have access to.
LimitExceededException
_LimitExceededException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The requested resource exceeds the maximum number allowed, or the number of concurrent stream requests exceeds the maximum number allowed.
ResourceInUseException
_ResourceInUseException :: AsError a => Getting (First ServiceError) a ServiceError Source #
The resource is not available for this operation. For successful
operation, the resource must be in the ACTIVE
state.
Waiters
Waiters poll by repeatedly sending a request until some remote success condition
configured by the Wait
specification is fulfilled. The Wait
specification
determines how many attempts should be made, in addition to delay and retry strategies.
StreamExists
newStreamExists :: Wait DescribeStream Source #
Polls DescribeStream
every 10 seconds until a successful state is reached. An error is returned after 18 failed checks.
StreamNotExists
newStreamNotExists :: Wait DescribeStream Source #
Polls DescribeStream
every 10 seconds until a successful state is reached. An error is returned after 18 failed checks.
Operations
Some AWS operations return results that are incomplete and require subsequent
requests in order to obtain the entire result set. The process of sending
subsequent requests to continue where a previous request left off is called
pagination. For example, the ListObjects
operation of Amazon S3 returns up to
1000 objects at a time, and you must send subsequent requests with the
appropriate Marker in order to retrieve the next page of results.
Operations that have an AWSPager
instance can transparently perform subsequent
requests, correctly setting Markers and other request facets to iterate through
the entire result set of a truncated API operation. Operations which support
this have an additional note in the documentation.
Many operations have the ability to filter results on the server side. See the individual operation parameters for details.
PutRecord
Represents the input for PutRecord
.
See: newPutRecord
smart constructor.
Instances
:: Text | |
-> ByteString | |
-> Text | |
-> PutRecord |
Create a value of PutRecord
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:explicitHashKey:PutRecord'
, putRecord_explicitHashKey
- The hash value used to explicitly determine the shard the data record is
assigned to by overriding the partition key hash.
$sel:sequenceNumberForOrdering:PutRecord'
, putRecord_sequenceNumberForOrdering
- Guarantees strictly increasing sequence numbers, for puts from the same
client and to the same partition key. Usage: set the
SequenceNumberForOrdering
of record n to the sequence number of
record n-1 (as returned in the result when putting record n-1). If
this parameter is not set, records are coarsely ordered based on arrival
time.
$sel:streamName:PutRecord'
, putRecord_streamName
- The name of the stream to put the data record into.
$sel:data':PutRecord'
, putRecord_data
- The data blob to put into the record, which is base64-encoded when the
blob is serialized. When the data blob (the payload before
base64-encoding) is added to the partition key size, the total size must
not exceed the maximum record size (1 MiB).--
-- Note: This Lens
automatically encodes and decodes Base64 data.
-- The underlying isomorphism will encode to Base64 representation during
-- serialisation, and decode from Base64 representation during deserialisation.
-- This Lens
accepts and returns only raw unencoded data.
$sel:partitionKey:PutRecord'
, putRecord_partitionKey
- Determines which shard in the stream the data record is assigned to.
Partition keys are Unicode strings with a maximum length limit of 256
characters for each key. Amazon Kinesis Data Streams uses the partition
key as input to a hash function that maps the partition key and
associated data to a specific shard. Specifically, an MD5 hash function
is used to map partition keys to 128-bit integer values and to map
associated data records to shards. As a result of this hashing
mechanism, all data records with the same partition key map to the same
shard within the stream.
data PutRecordResponse Source #
Represents the output for PutRecord
.
See: newPutRecordResponse
smart constructor.
Instances
:: Int | |
-> Text | |
-> Text | |
-> PutRecordResponse |
Create a value of PutRecordResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:encryptionType:PutRecordResponse'
, putRecordResponse_encryptionType
- The encryption type to use on the record. This parameter can be one of
the following values:
NONE
: Do not encrypt the records in the stream.KMS
: Use server-side encryption on the records in the stream using a customer-managed AWS KMS key.
$sel:httpStatus:PutRecordResponse'
, putRecordResponse_httpStatus
- The response's http status code.
$sel:shardId:PutRecordResponse'
, putRecordResponse_shardId
- The shard ID of the shard where the data record was placed.
$sel:sequenceNumber:PutRecordResponse'
, putRecordResponse_sequenceNumber
- The sequence number identifier that was assigned to the put data record.
The sequence number for the record is unique across all records in the
stream. A sequence number is the identifier associated with every record
put into the stream.
SubscribeToShard
data SubscribeToShard Source #
See: newSubscribeToShard
smart constructor.
Instances
:: Text | |
-> Text | |
-> StartingPosition | |
-> SubscribeToShard |
Create a value of SubscribeToShard
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:consumerARN:SubscribeToShard'
, subscribeToShard_consumerARN
- For this parameter, use the value you obtained when you called
RegisterStreamConsumer.
$sel:shardId:SubscribeToShard'
, subscribeToShard_shardId
- The ID of the shard you want to subscribe to. To see a list of all the
shards for a given stream, use ListShards.
$sel:startingPosition:SubscribeToShard'
, subscribeToShard_startingPosition
-
data SubscribeToShardResponse Source #
See: newSubscribeToShardResponse
smart constructor.
Instances
Generic SubscribeToShardResponse Source # | |
Defined in Amazonka.Kinesis.SubscribeToShard type Rep SubscribeToShardResponse :: Type -> Type # | |
NFData SubscribeToShardResponse Source # | |
Defined in Amazonka.Kinesis.SubscribeToShard rnf :: SubscribeToShardResponse -> () # | |
type Rep SubscribeToShardResponse Source # | |
Defined in Amazonka.Kinesis.SubscribeToShard type Rep SubscribeToShardResponse = D1 ('MetaData "SubscribeToShardResponse" "Amazonka.Kinesis.SubscribeToShard" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "SubscribeToShardResponse'" 'PrefixI 'True) (S1 ('MetaSel ('Just "httpStatus") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Int) :*: S1 ('MetaSel ('Just "eventStream") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Value))) |
newSubscribeToShardResponse Source #
:: Int | |
-> Value | |
-> SubscribeToShardResponse |
Create a value of SubscribeToShardResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:SubscribeToShardResponse'
, subscribeToShardResponse_httpStatus
- The response's http status code.
$sel:eventStream:SubscribeToShardResponse'
, subscribeToShardResponse_eventStream
- The event stream that your consumer can use to read records from the
shard.
DecreaseStreamRetentionPeriod
data DecreaseStreamRetentionPeriod Source #
Represents the input for DecreaseStreamRetentionPeriod.
See: newDecreaseStreamRetentionPeriod
smart constructor.
Instances
newDecreaseStreamRetentionPeriod Source #
:: Text | |
-> Int | |
-> DecreaseStreamRetentionPeriod |
Create a value of DecreaseStreamRetentionPeriod
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:DecreaseStreamRetentionPeriod'
, decreaseStreamRetentionPeriod_streamName
- The name of the stream to modify.
$sel:retentionPeriodHours:DecreaseStreamRetentionPeriod'
, decreaseStreamRetentionPeriod_retentionPeriodHours
- The new retention period of the stream, in hours. Must be less than the
current retention period.
data DecreaseStreamRetentionPeriodResponse Source #
See: newDecreaseStreamRetentionPeriodResponse
smart constructor.
Instances
Eq DecreaseStreamRetentionPeriodResponse Source # | |
Read DecreaseStreamRetentionPeriodResponse Source # | |
Show DecreaseStreamRetentionPeriodResponse Source # | |
Generic DecreaseStreamRetentionPeriodResponse Source # | |
Defined in Amazonka.Kinesis.DecreaseStreamRetentionPeriod type Rep DecreaseStreamRetentionPeriodResponse :: Type -> Type # | |
NFData DecreaseStreamRetentionPeriodResponse Source # | |
Defined in Amazonka.Kinesis.DecreaseStreamRetentionPeriod rnf :: DecreaseStreamRetentionPeriodResponse -> () # | |
type Rep DecreaseStreamRetentionPeriodResponse Source # | |
Defined in Amazonka.Kinesis.DecreaseStreamRetentionPeriod type Rep DecreaseStreamRetentionPeriodResponse = D1 ('MetaData "DecreaseStreamRetentionPeriodResponse" "Amazonka.Kinesis.DecreaseStreamRetentionPeriod" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "DecreaseStreamRetentionPeriodResponse'" 'PrefixI 'False) (U1 :: Type -> Type)) |
newDecreaseStreamRetentionPeriodResponse :: DecreaseStreamRetentionPeriodResponse Source #
Create a value of DecreaseStreamRetentionPeriodResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
MergeShards
data MergeShards Source #
Represents the input for MergeShards
.
See: newMergeShards
smart constructor.
Instances
:: Text | |
-> Text | |
-> Text | |
-> MergeShards |
Create a value of MergeShards
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:MergeShards'
, mergeShards_streamName
- The name of the stream for the merge.
$sel:shardToMerge:MergeShards'
, mergeShards_shardToMerge
- The shard ID of the shard to combine with the adjacent shard for the
merge.
$sel:adjacentShardToMerge:MergeShards'
, mergeShards_adjacentShardToMerge
- The shard ID of the adjacent shard for the merge.
data MergeShardsResponse Source #
See: newMergeShardsResponse
smart constructor.
Instances
Eq MergeShardsResponse Source # | |
Defined in Amazonka.Kinesis.MergeShards (==) :: MergeShardsResponse -> MergeShardsResponse -> Bool # (/=) :: MergeShardsResponse -> MergeShardsResponse -> Bool # | |
Read MergeShardsResponse Source # | |
Defined in Amazonka.Kinesis.MergeShards | |
Show MergeShardsResponse Source # | |
Defined in Amazonka.Kinesis.MergeShards showsPrec :: Int -> MergeShardsResponse -> ShowS # show :: MergeShardsResponse -> String # showList :: [MergeShardsResponse] -> ShowS # | |
Generic MergeShardsResponse Source # | |
Defined in Amazonka.Kinesis.MergeShards type Rep MergeShardsResponse :: Type -> Type # from :: MergeShardsResponse -> Rep MergeShardsResponse x # to :: Rep MergeShardsResponse x -> MergeShardsResponse # | |
NFData MergeShardsResponse Source # | |
Defined in Amazonka.Kinesis.MergeShards rnf :: MergeShardsResponse -> () # | |
type Rep MergeShardsResponse Source # | |
newMergeShardsResponse :: MergeShardsResponse Source #
Create a value of MergeShardsResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
DeregisterStreamConsumer
data DeregisterStreamConsumer Source #
See: newDeregisterStreamConsumer
smart constructor.
Instances
newDeregisterStreamConsumer :: DeregisterStreamConsumer Source #
Create a value of DeregisterStreamConsumer
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:consumerARN:DeregisterStreamConsumer'
, deregisterStreamConsumer_consumerARN
- The ARN returned by Kinesis Data Streams when you registered the
consumer. If you don't know the ARN of the consumer that you want to
deregister, you can use the ListStreamConsumers operation to get a list
of the descriptions of all the consumers that are currently registered
with a given data stream. The description of a consumer contains its
ARN.
$sel:streamARN:DeregisterStreamConsumer'
, deregisterStreamConsumer_streamARN
- The ARN of the Kinesis data stream that the consumer is registered with.
For more information, see
Amazon Resource Names (ARNs) and AWS Service Namespaces.
$sel:consumerName:DeregisterStreamConsumer'
, deregisterStreamConsumer_consumerName
- The name that you gave to the consumer.
data DeregisterStreamConsumerResponse Source #
See: newDeregisterStreamConsumerResponse
smart constructor.
Instances
newDeregisterStreamConsumerResponse :: DeregisterStreamConsumerResponse Source #
Create a value of DeregisterStreamConsumerResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
DescribeStreamSummary
data DescribeStreamSummary Source #
See: newDescribeStreamSummary
smart constructor.
Instances
newDescribeStreamSummary Source #
Create a value of DescribeStreamSummary
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:DescribeStreamSummary'
, describeStreamSummary_streamName
- The name of the stream to describe.
data DescribeStreamSummaryResponse Source #
See: newDescribeStreamSummaryResponse
smart constructor.
Instances
newDescribeStreamSummaryResponse Source #
:: Int | |
-> StreamDescriptionSummary |
|
-> DescribeStreamSummaryResponse |
Create a value of DescribeStreamSummaryResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:DescribeStreamSummaryResponse'
, describeStreamSummaryResponse_httpStatus
- The response's http status code.
$sel:streamDescriptionSummary:DescribeStreamSummaryResponse'
, describeStreamSummaryResponse_streamDescriptionSummary
- A StreamDescriptionSummary containing information about the stream.
GetShardIterator
data GetShardIterator Source #
Represents the input for GetShardIterator
.
See: newGetShardIterator
smart constructor.
Instances
:: Text | |
-> Text | |
-> ShardIteratorType | |
-> GetShardIterator |
Create a value of GetShardIterator
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:startingSequenceNumber:GetShardIterator'
, getShardIterator_startingSequenceNumber
- The sequence number of the data record in the shard from which to start
reading. Used with shard iterator type AT_SEQUENCE_NUMBER and
AFTER_SEQUENCE_NUMBER.
$sel:timestamp:GetShardIterator'
, getShardIterator_timestamp
- The time stamp of the data record from which to start reading. Used with
shard iterator type AT_TIMESTAMP. A time stamp is the Unix epoch date
with precision in milliseconds. For example,
2016-04-04T19:58:46.480-00:00
or 1459799926.480
. If a record with
this exact time stamp does not exist, the iterator returned is for the
next (later) record. If the time stamp is older than the current trim
horizon, the iterator returned is for the oldest untrimmed data record
(TRIM_HORIZON).
$sel:streamName:GetShardIterator'
, getShardIterator_streamName
- The name of the Amazon Kinesis data stream.
$sel:shardId:GetShardIterator'
, getShardIterator_shardId
- The shard ID of the Kinesis Data Streams shard to get the iterator for.
$sel:shardIteratorType:GetShardIterator'
, getShardIterator_shardIteratorType
- Determines how the shard iterator is used to start reading data records
from the shard.
The following are the valid Amazon Kinesis shard iterator types:
- AT_SEQUENCE_NUMBER - Start reading from the position denoted by a
specific sequence number, provided in the value
StartingSequenceNumber
. - AFTER_SEQUENCE_NUMBER - Start reading right after the position
denoted by a specific sequence number, provided in the value
StartingSequenceNumber
. - AT_TIMESTAMP - Start reading from the position denoted by a specific
time stamp, provided in the value
Timestamp
. - TRIM_HORIZON - Start reading at the last untrimmed record in the shard in the system, which is the oldest data record in the shard.
- LATEST - Start reading just after the most recent record in the shard, so that you always read the most recent data in the shard.
data GetShardIteratorResponse Source #
Represents the output for GetShardIterator
.
See: newGetShardIteratorResponse
smart constructor.
Instances
newGetShardIteratorResponse Source #
Create a value of GetShardIteratorResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:shardIterator:GetShardIteratorResponse'
, getShardIteratorResponse_shardIterator
- The position in the shard from which to start reading data records
sequentially. A shard iterator specifies this position using the
sequence number of a data record in a shard.
$sel:httpStatus:GetShardIteratorResponse'
, getShardIteratorResponse_httpStatus
- The response's http status code.
GetRecords
data GetRecords Source #
Represents the input for GetRecords.
See: newGetRecords
smart constructor.
Instances
Create a value of GetRecords
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:limit:GetRecords'
, getRecords_limit
- The maximum number of records to return. Specify a value of up to
10,000. If you specify a value that is greater than 10,000, GetRecords
throws InvalidArgumentException
. The default value is 10,000.
$sel:shardIterator:GetRecords'
, getRecords_shardIterator
- The position in the shard from which you want to start sequentially
reading data records. A shard iterator specifies this position using the
sequence number of a data record in the shard.
data GetRecordsResponse Source #
Represents the output for GetRecords.
See: newGetRecordsResponse
smart constructor.
GetRecordsResponse' (Maybe Text) (Maybe Natural) (Maybe [ChildShard]) Int [Record] |
Instances
newGetRecordsResponse Source #
Create a value of GetRecordsResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:nextShardIterator:GetRecordsResponse'
, getRecordsResponse_nextShardIterator
- The next position in the shard from which to start sequentially reading
data records. If set to null
, the shard has been closed and the
requested iterator does not return any more data.
$sel:millisBehindLatest:GetRecordsResponse'
, getRecordsResponse_millisBehindLatest
- The number of milliseconds the GetRecords response is from the tip of
the stream, indicating how far behind current time the consumer is. A
value of zero indicates that record processing is caught up, and there
are no new records to process at this moment.
$sel:childShards:GetRecordsResponse'
, getRecordsResponse_childShards
- Undocumented member.
$sel:httpStatus:GetRecordsResponse'
, getRecordsResponse_httpStatus
- The response's http status code.
$sel:records:GetRecordsResponse'
, getRecordsResponse_records
- The data records retrieved from the shard.
StopStreamEncryption
data StopStreamEncryption Source #
See: newStopStreamEncryption
smart constructor.
Instances
newStopStreamEncryption Source #
:: Text | |
-> EncryptionType | |
-> Text | |
-> StopStreamEncryption |
Create a value of StopStreamEncryption
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:StopStreamEncryption'
, stopStreamEncryption_streamName
- The name of the stream on which to stop encrypting records.
$sel:encryptionType:StopStreamEncryption'
, stopStreamEncryption_encryptionType
- The encryption type. The only valid value is KMS
.
$sel:keyId:StopStreamEncryption'
, stopStreamEncryption_keyId
- The GUID for the customer-managed AWS KMS key to use for encryption.
This value can be a globally unique identifier, a fully specified Amazon
Resource Name (ARN) to either an alias or a key, or an alias name
prefixed by "alias/".You can also use a master key owned by Kinesis
Data Streams by specifying the alias aws/kinesis
.
- Key ARN example:
arn:aws:kms:us-east-1:123456789012:key/12345678-1234-1234-1234-123456789012
- Alias ARN example:
arn:aws:kms:us-east-1:123456789012:alias/MyAliasName
- Globally unique key ID example:
12345678-1234-1234-1234-123456789012
- Alias name example:
alias/MyAliasName
- Master key owned by Kinesis Data Streams:
alias/aws/kinesis
data StopStreamEncryptionResponse Source #
See: newStopStreamEncryptionResponse
smart constructor.
Instances
newStopStreamEncryptionResponse :: StopStreamEncryptionResponse Source #
Create a value of StopStreamEncryptionResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
EnableEnhancedMonitoring
data EnableEnhancedMonitoring Source #
Represents the input for EnableEnhancedMonitoring.
See: newEnableEnhancedMonitoring
smart constructor.
Instances
newEnableEnhancedMonitoring Source #
Create a value of EnableEnhancedMonitoring
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:EnableEnhancedMonitoring'
, enableEnhancedMonitoring_streamName
- The name of the stream for which to enable enhanced monitoring.
$sel:shardLevelMetrics:EnableEnhancedMonitoring'
, enableEnhancedMonitoring_shardLevelMetrics
- List of shard-level metrics to enable.
The following are the valid shard-level metrics. The value "ALL
"
enables every metric.
IncomingBytes
IncomingRecords
OutgoingBytes
OutgoingRecords
WriteProvisionedThroughputExceeded
ReadProvisionedThroughputExceeded
IteratorAgeMilliseconds
ALL
For more information, see Monitoring the Amazon Kinesis Data Streams Service with Amazon CloudWatch in the Amazon Kinesis Data Streams Developer Guide.
data EnhancedMonitoringOutput Source #
Represents the output for EnableEnhancedMonitoring and DisableEnhancedMonitoring.
See: newEnhancedMonitoringOutput
smart constructor.
Instances
newEnhancedMonitoringOutput :: EnhancedMonitoringOutput Source #
Create a value of EnhancedMonitoringOutput
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:desiredShardLevelMetrics:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_desiredShardLevelMetrics
- Represents the list of all the metrics that would be in the enhanced
state after the operation.
$sel:currentShardLevelMetrics:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_currentShardLevelMetrics
- Represents the current state of the metrics that are in the enhanced
state before the operation.
$sel:streamName:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_streamName
- The name of the Kinesis data stream.
DescribeLimits
data DescribeLimits Source #
See: newDescribeLimits
smart constructor.
Instances
newDescribeLimits :: DescribeLimits Source #
Create a value of DescribeLimits
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
data DescribeLimitsResponse Source #
See: newDescribeLimitsResponse
smart constructor.
Instances
newDescribeLimitsResponse Source #
:: Int | |
-> Natural | |
-> Natural | |
-> DescribeLimitsResponse |
Create a value of DescribeLimitsResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:DescribeLimitsResponse'
, describeLimitsResponse_httpStatus
- The response's http status code.
$sel:shardLimit:DescribeLimitsResponse'
, describeLimitsResponse_shardLimit
- The maximum number of shards.
$sel:openShardCount:DescribeLimitsResponse'
, describeLimitsResponse_openShardCount
- The number of open shards.
RegisterStreamConsumer
data RegisterStreamConsumer Source #
See: newRegisterStreamConsumer
smart constructor.
Instances
newRegisterStreamConsumer Source #
:: Text | |
-> Text | |
-> RegisterStreamConsumer |
Create a value of RegisterStreamConsumer
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamARN:RegisterStreamConsumer'
, registerStreamConsumer_streamARN
- The ARN of the Kinesis data stream that you want to register the
consumer with. For more info, see
Amazon Resource Names (ARNs) and AWS Service Namespaces.
$sel:consumerName:RegisterStreamConsumer'
, registerStreamConsumer_consumerName
- For a given Kinesis data stream, each consumer must have a unique name.
However, consumer names don't have to be unique across data streams.
data RegisterStreamConsumerResponse Source #
See: newRegisterStreamConsumerResponse
smart constructor.
Instances
Eq RegisterStreamConsumerResponse Source # | |
Read RegisterStreamConsumerResponse Source # | |
Show RegisterStreamConsumerResponse Source # | |
Defined in Amazonka.Kinesis.RegisterStreamConsumer | |
Generic RegisterStreamConsumerResponse Source # | |
NFData RegisterStreamConsumerResponse Source # | |
Defined in Amazonka.Kinesis.RegisterStreamConsumer rnf :: RegisterStreamConsumerResponse -> () # | |
type Rep RegisterStreamConsumerResponse Source # | |
Defined in Amazonka.Kinesis.RegisterStreamConsumer type Rep RegisterStreamConsumerResponse = D1 ('MetaData "RegisterStreamConsumerResponse" "Amazonka.Kinesis.RegisterStreamConsumer" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "RegisterStreamConsumerResponse'" 'PrefixI 'True) (S1 ('MetaSel ('Just "httpStatus") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Int) :*: S1 ('MetaSel ('Just "consumer") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Consumer))) |
newRegisterStreamConsumerResponse Source #
Create a value of RegisterStreamConsumerResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:RegisterStreamConsumerResponse'
, registerStreamConsumerResponse_httpStatus
- The response's http status code.
$sel:consumer:RegisterStreamConsumerResponse'
, registerStreamConsumerResponse_consumer
- An object that represents the details of the consumer you registered.
When you register a consumer, it gets an ARN that is generated by
Kinesis Data Streams.
DisableEnhancedMonitoring
data DisableEnhancedMonitoring Source #
Represents the input for DisableEnhancedMonitoring.
See: newDisableEnhancedMonitoring
smart constructor.
Instances
newDisableEnhancedMonitoring Source #
Create a value of DisableEnhancedMonitoring
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:DisableEnhancedMonitoring'
, disableEnhancedMonitoring_streamName
- The name of the Kinesis data stream for which to disable enhanced
monitoring.
$sel:shardLevelMetrics:DisableEnhancedMonitoring'
, disableEnhancedMonitoring_shardLevelMetrics
- List of shard-level metrics to disable.
The following are the valid shard-level metrics. The value "ALL
"
disables every metric.
IncomingBytes
IncomingRecords
OutgoingBytes
OutgoingRecords
WriteProvisionedThroughputExceeded
ReadProvisionedThroughputExceeded
IteratorAgeMilliseconds
ALL
For more information, see Monitoring the Amazon Kinesis Data Streams Service with Amazon CloudWatch in the Amazon Kinesis Data Streams Developer Guide.
data EnhancedMonitoringOutput Source #
Represents the output for EnableEnhancedMonitoring and DisableEnhancedMonitoring.
See: newEnhancedMonitoringOutput
smart constructor.
Instances
newEnhancedMonitoringOutput :: EnhancedMonitoringOutput Source #
Create a value of EnhancedMonitoringOutput
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:desiredShardLevelMetrics:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_desiredShardLevelMetrics
- Represents the list of all the metrics that would be in the enhanced
state after the operation.
$sel:currentShardLevelMetrics:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_currentShardLevelMetrics
- Represents the current state of the metrics that are in the enhanced
state before the operation.
$sel:streamName:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_streamName
- The name of the Kinesis data stream.
UpdateShardCount
data UpdateShardCount Source #
See: newUpdateShardCount
smart constructor.
Instances
:: Text | |
-> Natural | |
-> ScalingType | |
-> UpdateShardCount |
Create a value of UpdateShardCount
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:UpdateShardCount'
, updateShardCount_streamName
- The name of the stream.
$sel:targetShardCount:UpdateShardCount'
, updateShardCount_targetShardCount
- The new number of shards. This value has the following default limits.
By default, you cannot do the following:
- Set this value to more than double your current shard count for a stream.
- Set this value below half your current shard count for a stream.
- Set this value to more than 500 shards in a stream (the default limit for shard count per stream is 500 per account per region), unless you request a limit increase.
- Scale a stream with more than 500 shards down unless you set this value to less than 500 shards.
$sel:scalingType:UpdateShardCount'
, updateShardCount_scalingType
- The scaling type. Uniform scaling creates shards of equal size.
data UpdateShardCountResponse Source #
See: newUpdateShardCountResponse
smart constructor.
Instances
newUpdateShardCountResponse Source #
Create a value of UpdateShardCountResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:targetShardCount:UpdateShardCount'
, updateShardCountResponse_targetShardCount
- The updated number of shards.
$sel:streamName:UpdateShardCount'
, updateShardCountResponse_streamName
- The name of the stream.
$sel:currentShardCount:UpdateShardCountResponse'
, updateShardCountResponse_currentShardCount
- The current number of shards.
$sel:httpStatus:UpdateShardCountResponse'
, updateShardCountResponse_httpStatus
- The response's http status code.
ListTagsForStream
data ListTagsForStream Source #
Represents the input for ListTagsForStream
.
See: newListTagsForStream
smart constructor.
Instances
Create a value of ListTagsForStream
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:limit:ListTagsForStream'
, listTagsForStream_limit
- The number of tags to return. If this number is less than the total
number of tags associated with the stream, HasMoreTags
is set to
true
. To list additional tags, set ExclusiveStartTagKey
to the last
key in the response.
$sel:exclusiveStartTagKey:ListTagsForStream'
, listTagsForStream_exclusiveStartTagKey
- The key to use as the starting point for the list of tags. If this
parameter is set, ListTagsForStream
gets all tags that occur after
ExclusiveStartTagKey
.
$sel:streamName:ListTagsForStream'
, listTagsForStream_streamName
- The name of the stream.
data ListTagsForStreamResponse Source #
Represents the output for ListTagsForStream
.
See: newListTagsForStreamResponse
smart constructor.
Instances
newListTagsForStreamResponse Source #
:: Int | |
-> Bool | |
-> ListTagsForStreamResponse |
Create a value of ListTagsForStreamResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:ListTagsForStreamResponse'
, listTagsForStreamResponse_httpStatus
- The response's http status code.
$sel:tags:ListTagsForStreamResponse'
, listTagsForStreamResponse_tags
- A list of tags associated with StreamName
, starting with the first tag
after ExclusiveStartTagKey
and up to the specified Limit
.
$sel:hasMoreTags:ListTagsForStreamResponse'
, listTagsForStreamResponse_hasMoreTags
- If set to true
, more tags are available. To request additional tags,
set ExclusiveStartTagKey
to the key of the last tag returned.
DescribeStreamConsumer
data DescribeStreamConsumer Source #
See: newDescribeStreamConsumer
smart constructor.
Instances
newDescribeStreamConsumer :: DescribeStreamConsumer Source #
Create a value of DescribeStreamConsumer
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:consumerARN:DescribeStreamConsumer'
, describeStreamConsumer_consumerARN
- The ARN returned by Kinesis Data Streams when you registered the
consumer.
$sel:streamARN:DescribeStreamConsumer'
, describeStreamConsumer_streamARN
- The ARN of the Kinesis data stream that the consumer is registered with.
For more information, see
Amazon Resource Names (ARNs) and AWS Service Namespaces.
$sel:consumerName:DescribeStreamConsumer'
, describeStreamConsumer_consumerName
- The name that you gave to the consumer.
data DescribeStreamConsumerResponse Source #
See: newDescribeStreamConsumerResponse
smart constructor.
Instances
Eq DescribeStreamConsumerResponse Source # | |
Read DescribeStreamConsumerResponse Source # | |
Show DescribeStreamConsumerResponse Source # | |
Defined in Amazonka.Kinesis.DescribeStreamConsumer | |
Generic DescribeStreamConsumerResponse Source # | |
NFData DescribeStreamConsumerResponse Source # | |
Defined in Amazonka.Kinesis.DescribeStreamConsumer rnf :: DescribeStreamConsumerResponse -> () # | |
type Rep DescribeStreamConsumerResponse Source # | |
Defined in Amazonka.Kinesis.DescribeStreamConsumer type Rep DescribeStreamConsumerResponse = D1 ('MetaData "DescribeStreamConsumerResponse" "Amazonka.Kinesis.DescribeStreamConsumer" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "DescribeStreamConsumerResponse'" 'PrefixI 'True) (S1 ('MetaSel ('Just "httpStatus") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Int) :*: S1 ('MetaSel ('Just "consumerDescription") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 ConsumerDescription))) |
newDescribeStreamConsumerResponse Source #
Create a value of DescribeStreamConsumerResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:DescribeStreamConsumerResponse'
, describeStreamConsumerResponse_httpStatus
- The response's http status code.
$sel:consumerDescription:DescribeStreamConsumerResponse'
, describeStreamConsumerResponse_consumerDescription
- An object that represents the details of the consumer.
AddTagsToStream
data AddTagsToStream Source #
Represents the input for AddTagsToStream
.
See: newAddTagsToStream
smart constructor.
Instances
Create a value of AddTagsToStream
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:AddTagsToStream'
, addTagsToStream_streamName
- The name of the stream.
$sel:tags:AddTagsToStream'
, addTagsToStream_tags
- A set of up to 10 key-value pairs to use to create the tags.
data AddTagsToStreamResponse Source #
See: newAddTagsToStreamResponse
smart constructor.
Instances
Eq AddTagsToStreamResponse Source # | |
Defined in Amazonka.Kinesis.AddTagsToStream | |
Read AddTagsToStreamResponse Source # | |
Show AddTagsToStreamResponse Source # | |
Defined in Amazonka.Kinesis.AddTagsToStream showsPrec :: Int -> AddTagsToStreamResponse -> ShowS # show :: AddTagsToStreamResponse -> String # showList :: [AddTagsToStreamResponse] -> ShowS # | |
Generic AddTagsToStreamResponse Source # | |
Defined in Amazonka.Kinesis.AddTagsToStream type Rep AddTagsToStreamResponse :: Type -> Type # | |
NFData AddTagsToStreamResponse Source # | |
Defined in Amazonka.Kinesis.AddTagsToStream rnf :: AddTagsToStreamResponse -> () # | |
type Rep AddTagsToStreamResponse Source # | |
newAddTagsToStreamResponse :: AddTagsToStreamResponse Source #
Create a value of AddTagsToStreamResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
PutRecords
data PutRecords Source #
A PutRecords
request.
See: newPutRecords
smart constructor.
Instances
Create a value of PutRecords
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:records:PutRecords'
, putRecords_records
- The records associated with the request.
$sel:streamName:PutRecords'
, putRecords_streamName
- The stream name associated with the request.
data PutRecordsResponse Source #
PutRecords
results.
See: newPutRecordsResponse
smart constructor.
Instances
newPutRecordsResponse Source #
Create a value of PutRecordsResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:encryptionType:PutRecordsResponse'
, putRecordsResponse_encryptionType
- The encryption type used on the records. This parameter can be one of
the following values:
NONE
: Do not encrypt the records.KMS
: Use server-side encryption on the records using a customer-managed AWS KMS key.
$sel:failedRecordCount:PutRecordsResponse'
, putRecordsResponse_failedRecordCount
- The number of unsuccessfully processed records in a PutRecords
request.
$sel:httpStatus:PutRecordsResponse'
, putRecordsResponse_httpStatus
- The response's http status code.
$sel:records:PutRecords'
, putRecordsResponse_records
- An array of successfully and unsuccessfully processed record results,
correlated with the request by natural ordering. A record that is
successfully added to a stream includes SequenceNumber
and ShardId
in the result. A record that fails to be added to a stream includes
ErrorCode
and ErrorMessage
in the result.
ListShards (Paginated)
data ListShards Source #
See: newListShards
smart constructor.
ListShards' (Maybe ShardFilter) (Maybe Text) (Maybe Text) (Maybe POSIX) (Maybe Text) (Maybe Natural) |
Instances
newListShards :: ListShards Source #
Create a value of ListShards
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:shardFilter:ListShards'
, listShards_shardFilter
- Undocumented member.
$sel:nextToken:ListShards'
, listShards_nextToken
- When the number of shards in the data stream is greater than the default
value for the MaxResults
parameter, or if you explicitly specify a
value for MaxResults
that is less than the number of shards in the
data stream, the response includes a pagination token named NextToken
.
You can specify this NextToken
value in a subsequent call to
ListShards
to list the next set of shards.
Don't specify StreamName
or StreamCreationTimestamp
if you specify
NextToken
because the latter unambiguously identifies the stream.
You can optionally specify a value for the MaxResults
parameter when
you specify NextToken
. If you specify a MaxResults
value that is
less than the number of shards that the operation returns if you don't
specify MaxResults
, the response will contain a new NextToken
value.
You can use the new NextToken
value in a subsequent call to the
ListShards
operation.
Tokens expire after 300 seconds. When you obtain a value for NextToken
in the response to a call to ListShards
, you have 300 seconds to use
that value. If you specify an expired token in a call to ListShards
,
you get ExpiredNextTokenException
.
$sel:exclusiveStartShardId:ListShards'
, listShards_exclusiveStartShardId
- Specify this parameter to indicate that you want to list the shards
starting with the shard whose ID immediately follows
ExclusiveStartShardId
.
If you don't specify this parameter, the default behavior is for
ListShards
to list the shards starting with the first one in the
stream.
You cannot specify this parameter if you specify NextToken
.
$sel:streamCreationTimestamp:ListShards'
, listShards_streamCreationTimestamp
- Specify this input parameter to distinguish data streams that have the
same name. For example, if you create a data stream and then delete it,
and you later create another data stream with the same name, you can use
this input parameter to specify which of the two streams you want to
list the shards for.
You cannot specify this parameter if you specify the NextToken
parameter.
$sel:streamName:ListShards'
, listShards_streamName
- The name of the data stream whose shards you want to list.
You cannot specify this parameter if you specify the NextToken
parameter.
$sel:maxResults:ListShards'
, listShards_maxResults
- The maximum number of shards to return in a single call to ListShards
.
The minimum value you can specify for this parameter is 1, and the
maximum is 10,000, which is also the default.
When the number of shards to be listed is greater than the value of
MaxResults
, the response contains a NextToken
value that you can use
in a subsequent call to ListShards
to list the next set of shards.
data ListShardsResponse Source #
See: newListShardsResponse
smart constructor.
Instances
newListShardsResponse Source #
Create a value of ListShardsResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:nextToken:ListShards'
, listShardsResponse_nextToken
- When the number of shards in the data stream is greater than the default
value for the MaxResults
parameter, or if you explicitly specify a
value for MaxResults
that is less than the number of shards in the
data stream, the response includes a pagination token named NextToken
.
You can specify this NextToken
value in a subsequent call to
ListShards
to list the next set of shards. For more information about
the use of this pagination token when calling the ListShards
operation, see ListShardsInput$NextToken.
Tokens expire after 300 seconds. When you obtain a value for NextToken
in the response to a call to ListShards
, you have 300 seconds to use
that value. If you specify an expired token in a call to ListShards
,
you get ExpiredNextTokenException
.
$sel:shards:ListShardsResponse'
, listShardsResponse_shards
- An array of JSON objects. Each object represents one shard and specifies
the IDs of the shard, the shard's parent, and the shard that's
adjacent to the shard's parent. Each object also contains the starting
and ending hash keys and the starting and ending sequence numbers for
the shard.
$sel:httpStatus:ListShardsResponse'
, listShardsResponse_httpStatus
- The response's http status code.
DeleteStream
data DeleteStream Source #
Represents the input for DeleteStream.
See: newDeleteStream
smart constructor.
Instances
Create a value of DeleteStream
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:enforceConsumerDeletion:DeleteStream'
, deleteStream_enforceConsumerDeletion
- If this parameter is unset (null
) or if you set it to false
, and the
stream has registered consumers, the call to DeleteStream
fails with a
ResourceInUseException
.
$sel:streamName:DeleteStream'
, deleteStream_streamName
- The name of the stream to delete.
data DeleteStreamResponse Source #
See: newDeleteStreamResponse
smart constructor.
Instances
Eq DeleteStreamResponse Source # | |
Defined in Amazonka.Kinesis.DeleteStream (==) :: DeleteStreamResponse -> DeleteStreamResponse -> Bool # (/=) :: DeleteStreamResponse -> DeleteStreamResponse -> Bool # | |
Read DeleteStreamResponse Source # | |
Show DeleteStreamResponse Source # | |
Defined in Amazonka.Kinesis.DeleteStream showsPrec :: Int -> DeleteStreamResponse -> ShowS # show :: DeleteStreamResponse -> String # showList :: [DeleteStreamResponse] -> ShowS # | |
Generic DeleteStreamResponse Source # | |
Defined in Amazonka.Kinesis.DeleteStream type Rep DeleteStreamResponse :: Type -> Type # from :: DeleteStreamResponse -> Rep DeleteStreamResponse x # to :: Rep DeleteStreamResponse x -> DeleteStreamResponse # | |
NFData DeleteStreamResponse Source # | |
Defined in Amazonka.Kinesis.DeleteStream rnf :: DeleteStreamResponse -> () # | |
type Rep DeleteStreamResponse Source # | |
newDeleteStreamResponse :: DeleteStreamResponse Source #
Create a value of DeleteStreamResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
RemoveTagsFromStream
data RemoveTagsFromStream Source #
Represents the input for RemoveTagsFromStream
.
See: newRemoveTagsFromStream
smart constructor.
Instances
newRemoveTagsFromStream Source #
:: Text | |
-> NonEmpty Text | |
-> RemoveTagsFromStream |
Create a value of RemoveTagsFromStream
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:RemoveTagsFromStream'
, removeTagsFromStream_streamName
- The name of the stream.
$sel:tagKeys:RemoveTagsFromStream'
, removeTagsFromStream_tagKeys
- A list of tag keys. Each corresponding tag is removed from the stream.
data RemoveTagsFromStreamResponse Source #
See: newRemoveTagsFromStreamResponse
smart constructor.
Instances
newRemoveTagsFromStreamResponse :: RemoveTagsFromStreamResponse Source #
Create a value of RemoveTagsFromStreamResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
ListStreams (Paginated)
data ListStreams Source #
Represents the input for ListStreams
.
See: newListStreams
smart constructor.
Instances
newListStreams :: ListStreams Source #
Create a value of ListStreams
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:limit:ListStreams'
, listStreams_limit
- The maximum number of streams to list.
$sel:exclusiveStartStreamName:ListStreams'
, listStreams_exclusiveStartStreamName
- The name of the stream to start the list with.
data ListStreamsResponse Source #
Represents the output for ListStreams
.
See: newListStreamsResponse
smart constructor.
Instances
newListStreamsResponse Source #
:: Int | |
-> Bool | |
-> ListStreamsResponse |
Create a value of ListStreamsResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:ListStreamsResponse'
, listStreamsResponse_httpStatus
- The response's http status code.
$sel:streamNames:ListStreamsResponse'
, listStreamsResponse_streamNames
- The names of the streams that are associated with the AWS account making
the ListStreams
request.
$sel:hasMoreStreams:ListStreamsResponse'
, listStreamsResponse_hasMoreStreams
- If set to true
, there are more streams available to list.
CreateStream
data CreateStream Source #
Represents the input for CreateStream
.
See: newCreateStream
smart constructor.
Instances
Create a value of CreateStream
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:CreateStream'
, createStream_streamName
- A name to identify the stream. The stream name is scoped to the AWS
account used by the application that creates the stream. It is also
scoped by AWS Region. That is, two streams in two different AWS accounts
can have the same name. Two streams in the same AWS account but in two
different Regions can also have the same name.
$sel:shardCount:CreateStream'
, createStream_shardCount
- The number of shards that the stream will use. The throughput of the
stream is a function of the number of shards; more shards are required
for greater provisioned throughput.
data CreateStreamResponse Source #
See: newCreateStreamResponse
smart constructor.
Instances
Eq CreateStreamResponse Source # | |
Defined in Amazonka.Kinesis.CreateStream (==) :: CreateStreamResponse -> CreateStreamResponse -> Bool # (/=) :: CreateStreamResponse -> CreateStreamResponse -> Bool # | |
Read CreateStreamResponse Source # | |
Show CreateStreamResponse Source # | |
Defined in Amazonka.Kinesis.CreateStream showsPrec :: Int -> CreateStreamResponse -> ShowS # show :: CreateStreamResponse -> String # showList :: [CreateStreamResponse] -> ShowS # | |
Generic CreateStreamResponse Source # | |
Defined in Amazonka.Kinesis.CreateStream type Rep CreateStreamResponse :: Type -> Type # from :: CreateStreamResponse -> Rep CreateStreamResponse x # to :: Rep CreateStreamResponse x -> CreateStreamResponse # | |
NFData CreateStreamResponse Source # | |
Defined in Amazonka.Kinesis.CreateStream rnf :: CreateStreamResponse -> () # | |
type Rep CreateStreamResponse Source # | |
newCreateStreamResponse :: CreateStreamResponse Source #
Create a value of CreateStreamResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
StartStreamEncryption
data StartStreamEncryption Source #
See: newStartStreamEncryption
smart constructor.
Instances
newStartStreamEncryption Source #
:: Text | |
-> EncryptionType | |
-> Text | |
-> StartStreamEncryption |
Create a value of StartStreamEncryption
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:StartStreamEncryption'
, startStreamEncryption_streamName
- The name of the stream for which to start encrypting records.
$sel:encryptionType:StartStreamEncryption'
, startStreamEncryption_encryptionType
- The encryption type to use. The only valid value is KMS
.
$sel:keyId:StartStreamEncryption'
, startStreamEncryption_keyId
- The GUID for the customer-managed AWS KMS key to use for encryption.
This value can be a globally unique identifier, a fully specified Amazon
Resource Name (ARN) to either an alias or a key, or an alias name
prefixed by "alias/".You can also use a master key owned by Kinesis
Data Streams by specifying the alias aws/kinesis
.
- Key ARN example:
arn:aws:kms:us-east-1:123456789012:key/12345678-1234-1234-1234-123456789012
- Alias ARN example:
arn:aws:kms:us-east-1:123456789012:alias/MyAliasName
- Globally unique key ID example:
12345678-1234-1234-1234-123456789012
- Alias name example:
alias/MyAliasName
- Master key owned by Kinesis Data Streams:
alias/aws/kinesis
data StartStreamEncryptionResponse Source #
See: newStartStreamEncryptionResponse
smart constructor.
Instances
newStartStreamEncryptionResponse :: StartStreamEncryptionResponse Source #
Create a value of StartStreamEncryptionResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
ListStreamConsumers (Paginated)
data ListStreamConsumers Source #
See: newListStreamConsumers
smart constructor.
Instances
newListStreamConsumers Source #
Create a value of ListStreamConsumers
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:nextToken:ListStreamConsumers'
, listStreamConsumers_nextToken
- When the number of consumers that are registered with the data stream is
greater than the default value for the MaxResults
parameter, or if you
explicitly specify a value for MaxResults
that is less than the number
of consumers that are registered with the data stream, the response
includes a pagination token named NextToken
. You can specify this
NextToken
value in a subsequent call to ListStreamConsumers
to list
the next set of registered consumers.
Don't specify StreamName
or StreamCreationTimestamp
if you specify
NextToken
because the latter unambiguously identifies the stream.
You can optionally specify a value for the MaxResults
parameter when
you specify NextToken
. If you specify a MaxResults
value that is
less than the number of consumers that the operation returns if you
don't specify MaxResults
, the response will contain a new NextToken
value. You can use the new NextToken
value in a subsequent call to the
ListStreamConsumers
operation to list the next set of consumers.
Tokens expire after 300 seconds. When you obtain a value for NextToken
in the response to a call to ListStreamConsumers
, you have 300 seconds
to use that value. If you specify an expired token in a call to
ListStreamConsumers
, you get ExpiredNextTokenException
.
$sel:streamCreationTimestamp:ListStreamConsumers'
, listStreamConsumers_streamCreationTimestamp
- Specify this input parameter to distinguish data streams that have the
same name. For example, if you create a data stream and then delete it,
and you later create another data stream with the same name, you can use
this input parameter to specify which of the two streams you want to
list the consumers for.
You can't specify this parameter if you specify the NextToken parameter.
$sel:maxResults:ListStreamConsumers'
, listStreamConsumers_maxResults
- The maximum number of consumers that you want a single call of
ListStreamConsumers
to return.
$sel:streamARN:ListStreamConsumers'
, listStreamConsumers_streamARN
- The ARN of the Kinesis data stream for which you want to list the
registered consumers. For more information, see
Amazon Resource Names (ARNs) and AWS Service Namespaces.
data ListStreamConsumersResponse Source #
See: newListStreamConsumersResponse
smart constructor.
Instances
newListStreamConsumersResponse Source #
Create a value of ListStreamConsumersResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:nextToken:ListStreamConsumers'
, listStreamConsumersResponse_nextToken
- When the number of consumers that are registered with the data stream is
greater than the default value for the MaxResults
parameter, or if you
explicitly specify a value for MaxResults
that is less than the number
of registered consumers, the response includes a pagination token named
NextToken
. You can specify this NextToken
value in a subsequent call
to ListStreamConsumers
to list the next set of registered consumers.
For more information about the use of this pagination token when calling
the ListStreamConsumers
operation, see
ListStreamConsumersInput$NextToken.
Tokens expire after 300 seconds. When you obtain a value for NextToken
in the response to a call to ListStreamConsumers
, you have 300 seconds
to use that value. If you specify an expired token in a call to
ListStreamConsumers
, you get ExpiredNextTokenException
.
$sel:consumers:ListStreamConsumersResponse'
, listStreamConsumersResponse_consumers
- An array of JSON objects. Each object represents one registered
consumer.
$sel:httpStatus:ListStreamConsumersResponse'
, listStreamConsumersResponse_httpStatus
- The response's http status code.
SplitShard
data SplitShard Source #
Represents the input for SplitShard
.
See: newSplitShard
smart constructor.
Instances
:: Text | |
-> Text | |
-> Text | |
-> SplitShard |
Create a value of SplitShard
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:SplitShard'
, splitShard_streamName
- The name of the stream for the shard split.
$sel:shardToSplit:SplitShard'
, splitShard_shardToSplit
- The shard ID of the shard to split.
$sel:newStartingHashKey':SplitShard'
, splitShard_newStartingHashKey
- A hash key value for the starting hash key of one of the child shards
created by the split. The hash key range for a given shard constitutes a
set of ordered contiguous positive integers. The value for
NewStartingHashKey
must be in the range of hash keys being mapped into
the shard. The NewStartingHashKey
hash key value and all higher hash
key values in hash key range are distributed to one of the child shards.
All the lower hash key values in the range are distributed to the other
child shard.
data SplitShardResponse Source #
See: newSplitShardResponse
smart constructor.
Instances
Eq SplitShardResponse Source # | |
Defined in Amazonka.Kinesis.SplitShard (==) :: SplitShardResponse -> SplitShardResponse -> Bool # (/=) :: SplitShardResponse -> SplitShardResponse -> Bool # | |
Read SplitShardResponse Source # | |
Defined in Amazonka.Kinesis.SplitShard | |
Show SplitShardResponse Source # | |
Defined in Amazonka.Kinesis.SplitShard showsPrec :: Int -> SplitShardResponse -> ShowS # show :: SplitShardResponse -> String # showList :: [SplitShardResponse] -> ShowS # | |
Generic SplitShardResponse Source # | |
Defined in Amazonka.Kinesis.SplitShard type Rep SplitShardResponse :: Type -> Type # from :: SplitShardResponse -> Rep SplitShardResponse x # to :: Rep SplitShardResponse x -> SplitShardResponse # | |
NFData SplitShardResponse Source # | |
Defined in Amazonka.Kinesis.SplitShard rnf :: SplitShardResponse -> () # | |
type Rep SplitShardResponse Source # | |
newSplitShardResponse :: SplitShardResponse Source #
Create a value of SplitShardResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
IncreaseStreamRetentionPeriod
data IncreaseStreamRetentionPeriod Source #
Represents the input for IncreaseStreamRetentionPeriod.
See: newIncreaseStreamRetentionPeriod
smart constructor.
Instances
newIncreaseStreamRetentionPeriod Source #
:: Text | |
-> Int | |
-> IncreaseStreamRetentionPeriod |
Create a value of IncreaseStreamRetentionPeriod
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:streamName:IncreaseStreamRetentionPeriod'
, increaseStreamRetentionPeriod_streamName
- The name of the stream to modify.
$sel:retentionPeriodHours:IncreaseStreamRetentionPeriod'
, increaseStreamRetentionPeriod_retentionPeriodHours
- The new retention period of the stream, in hours. Must be more than the
current retention period.
data IncreaseStreamRetentionPeriodResponse Source #
See: newIncreaseStreamRetentionPeriodResponse
smart constructor.
Instances
Eq IncreaseStreamRetentionPeriodResponse Source # | |
Read IncreaseStreamRetentionPeriodResponse Source # | |
Show IncreaseStreamRetentionPeriodResponse Source # | |
Generic IncreaseStreamRetentionPeriodResponse Source # | |
Defined in Amazonka.Kinesis.IncreaseStreamRetentionPeriod type Rep IncreaseStreamRetentionPeriodResponse :: Type -> Type # | |
NFData IncreaseStreamRetentionPeriodResponse Source # | |
Defined in Amazonka.Kinesis.IncreaseStreamRetentionPeriod rnf :: IncreaseStreamRetentionPeriodResponse -> () # | |
type Rep IncreaseStreamRetentionPeriodResponse Source # | |
Defined in Amazonka.Kinesis.IncreaseStreamRetentionPeriod type Rep IncreaseStreamRetentionPeriodResponse = D1 ('MetaData "IncreaseStreamRetentionPeriodResponse" "Amazonka.Kinesis.IncreaseStreamRetentionPeriod" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "IncreaseStreamRetentionPeriodResponse'" 'PrefixI 'False) (U1 :: Type -> Type)) |
newIncreaseStreamRetentionPeriodResponse :: IncreaseStreamRetentionPeriodResponse Source #
Create a value of IncreaseStreamRetentionPeriodResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
DescribeStream (Paginated)
data DescribeStream Source #
Represents the input for DescribeStream
.
See: newDescribeStream
smart constructor.
Instances
Create a value of DescribeStream
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:exclusiveStartShardId:DescribeStream'
, describeStream_exclusiveStartShardId
- The shard ID of the shard to start with.
$sel:limit:DescribeStream'
, describeStream_limit
- The maximum number of shards to return in a single call. The default
value is 100. If you specify a value greater than 100, at most 100
shards are returned.
$sel:streamName:DescribeStream'
, describeStream_streamName
- The name of the stream to describe.
data DescribeStreamResponse Source #
Represents the output for DescribeStream
.
See: newDescribeStreamResponse
smart constructor.
Instances
newDescribeStreamResponse Source #
Create a value of DescribeStreamResponse
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:httpStatus:DescribeStreamResponse'
, describeStreamResponse_httpStatus
- The response's http status code.
$sel:streamDescription:DescribeStreamResponse'
, describeStreamResponse_streamDescription
- The current status of the stream, the stream Amazon Resource Name (ARN),
an array of shard objects that comprise the stream, and whether there
are more shards available.
Types
ConsumerStatus
newtype ConsumerStatus Source #
pattern ConsumerStatus_ACTIVE :: ConsumerStatus | |
pattern ConsumerStatus_CREATING :: ConsumerStatus | |
pattern ConsumerStatus_DELETING :: ConsumerStatus |
Instances
EncryptionType
newtype EncryptionType Source #
pattern EncryptionType_KMS :: EncryptionType | |
pattern EncryptionType_NONE :: EncryptionType |
Instances
MetricsName
newtype MetricsName Source #
pattern MetricsName_ALL :: MetricsName | |
pattern MetricsName_IncomingBytes :: MetricsName | |
pattern MetricsName_IncomingRecords :: MetricsName | |
pattern MetricsName_IteratorAgeMilliseconds :: MetricsName | |
pattern MetricsName_OutgoingBytes :: MetricsName | |
pattern MetricsName_OutgoingRecords :: MetricsName | |
pattern MetricsName_ReadProvisionedThroughputExceeded :: MetricsName | |
pattern MetricsName_WriteProvisionedThroughputExceeded :: MetricsName |
Instances
ScalingType
newtype ScalingType Source #
pattern ScalingType_UNIFORM_SCALING :: ScalingType |
Instances
ShardFilterType
newtype ShardFilterType Source #
pattern ShardFilterType_AFTER_SHARD_ID :: ShardFilterType | |
pattern ShardFilterType_AT_LATEST :: ShardFilterType | |
pattern ShardFilterType_AT_TIMESTAMP :: ShardFilterType | |
pattern ShardFilterType_AT_TRIM_HORIZON :: ShardFilterType | |
pattern ShardFilterType_FROM_TIMESTAMP :: ShardFilterType | |
pattern ShardFilterType_FROM_TRIM_HORIZON :: ShardFilterType |
Instances
ShardIteratorType
newtype ShardIteratorType Source #
pattern ShardIteratorType_AFTER_SEQUENCE_NUMBER :: ShardIteratorType | |
pattern ShardIteratorType_AT_SEQUENCE_NUMBER :: ShardIteratorType | |
pattern ShardIteratorType_AT_TIMESTAMP :: ShardIteratorType | |
pattern ShardIteratorType_LATEST :: ShardIteratorType | |
pattern ShardIteratorType_TRIM_HORIZON :: ShardIteratorType |
Instances
StreamStatus
newtype StreamStatus Source #
pattern StreamStatus_ACTIVE :: StreamStatus | |
pattern StreamStatus_CREATING :: StreamStatus | |
pattern StreamStatus_DELETING :: StreamStatus | |
pattern StreamStatus_UPDATING :: StreamStatus |
Instances
ChildShard
data ChildShard Source #
See: newChildShard
smart constructor.
Instances
Create a value of ChildShard
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:shardId:ChildShard'
, childShard_shardId
- Undocumented member.
$sel:parentShards:ChildShard'
, childShard_parentShards
- Undocumented member.
$sel:hashKeyRange:ChildShard'
, childShard_hashKeyRange
- Undocumented member.
Consumer
An object that represents the details of the consumer you registered. This type of object is returned by RegisterStreamConsumer.
See: newConsumer
smart constructor.
Instances
Eq Consumer Source # | |
Read Consumer Source # | |
Show Consumer Source # | |
Generic Consumer Source # | |
NFData Consumer Source # | |
Defined in Amazonka.Kinesis.Types.Consumer | |
Hashable Consumer Source # | |
Defined in Amazonka.Kinesis.Types.Consumer | |
FromJSON Consumer Source # | |
type Rep Consumer Source # | |
Defined in Amazonka.Kinesis.Types.Consumer type Rep Consumer = D1 ('MetaData "Consumer" "Amazonka.Kinesis.Types.Consumer" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "Consumer'" 'PrefixI 'True) ((S1 ('MetaSel ('Just "consumerName") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Text) :*: S1 ('MetaSel ('Just "consumerARN") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Text)) :*: (S1 ('MetaSel ('Just "consumerStatus") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 ConsumerStatus) :*: S1 ('MetaSel ('Just "consumerCreationTimestamp") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 POSIX)))) |
:: Text | |
-> Text | |
-> ConsumerStatus | |
-> UTCTime | |
-> Consumer |
Create a value of Consumer
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:consumerName:Consumer'
, consumer_consumerName
- The name of the consumer is something you choose when you register the
consumer.
$sel:consumerARN:Consumer'
, consumer_consumerARN
- When you register a consumer, Kinesis Data Streams generates an ARN for
it. You need this ARN to be able to call SubscribeToShard.
If you delete a consumer and then create a new one with the same name, it won't have the same ARN. That's because consumer ARNs contain the creation timestamp. This is important to keep in mind if you have IAM policies that reference consumer ARNs.
$sel:consumerStatus:Consumer'
, consumer_consumerStatus
- A consumer can't read data while in the CREATING
or DELETING
states.
$sel:consumerCreationTimestamp:Consumer'
, consumer_consumerCreationTimestamp
-
ConsumerDescription
data ConsumerDescription Source #
An object that represents the details of a registered consumer. This type of object is returned by DescribeStreamConsumer.
See: newConsumerDescription
smart constructor.
Instances
newConsumerDescription Source #
:: Text | |
-> Text | |
-> ConsumerStatus | |
-> UTCTime | |
-> Text | |
-> ConsumerDescription |
Create a value of ConsumerDescription
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:consumerName:ConsumerDescription'
, consumerDescription_consumerName
- The name of the consumer is something you choose when you register the
consumer.
$sel:consumerARN:ConsumerDescription'
, consumerDescription_consumerARN
- When you register a consumer, Kinesis Data Streams generates an ARN for
it. You need this ARN to be able to call SubscribeToShard.
If you delete a consumer and then create a new one with the same name, it won't have the same ARN. That's because consumer ARNs contain the creation timestamp. This is important to keep in mind if you have IAM policies that reference consumer ARNs.
$sel:consumerStatus:ConsumerDescription'
, consumerDescription_consumerStatus
- A consumer can't read data while in the CREATING
or DELETING
states.
$sel:consumerCreationTimestamp:ConsumerDescription'
, consumerDescription_consumerCreationTimestamp
-
$sel:streamARN:ConsumerDescription'
, consumerDescription_streamARN
- The ARN of the stream with which you registered the consumer.
EnhancedMetrics
data EnhancedMetrics Source #
Represents enhanced metrics types.
See: newEnhancedMetrics
smart constructor.
Instances
newEnhancedMetrics :: EnhancedMetrics Source #
Create a value of EnhancedMetrics
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:shardLevelMetrics:EnhancedMetrics'
, enhancedMetrics_shardLevelMetrics
- List of shard-level metrics.
The following are the valid shard-level metrics. The value "ALL
"
enhances every metric.
IncomingBytes
IncomingRecords
OutgoingBytes
OutgoingRecords
WriteProvisionedThroughputExceeded
ReadProvisionedThroughputExceeded
IteratorAgeMilliseconds
ALL
For more information, see Monitoring the Amazon Kinesis Data Streams Service with Amazon CloudWatch in the Amazon Kinesis Data Streams Developer Guide.
EnhancedMonitoringOutput
data EnhancedMonitoringOutput Source #
Represents the output for EnableEnhancedMonitoring and DisableEnhancedMonitoring.
See: newEnhancedMonitoringOutput
smart constructor.
Instances
newEnhancedMonitoringOutput :: EnhancedMonitoringOutput Source #
Create a value of EnhancedMonitoringOutput
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:desiredShardLevelMetrics:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_desiredShardLevelMetrics
- Represents the list of all the metrics that would be in the enhanced
state after the operation.
$sel:currentShardLevelMetrics:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_currentShardLevelMetrics
- Represents the current state of the metrics that are in the enhanced
state before the operation.
$sel:streamName:EnhancedMonitoringOutput'
, enhancedMonitoringOutput_streamName
- The name of the Kinesis data stream.
HashKeyRange
data HashKeyRange Source #
The range of possible hash key values for the shard, which is a set of ordered contiguous positive integers.
See: newHashKeyRange
smart constructor.
Instances
Create a value of HashKeyRange
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:startingHashKey:HashKeyRange'
, hashKeyRange_startingHashKey
- The starting hash key of the hash key range.
$sel:endingHashKey:HashKeyRange'
, hashKeyRange_endingHashKey
- The ending hash key of the hash key range.
PutRecordsRequestEntry
data PutRecordsRequestEntry Source #
Represents the output for PutRecords
.
See: newPutRecordsRequestEntry
smart constructor.
Instances
newPutRecordsRequestEntry Source #
:: ByteString | |
-> Text | |
-> PutRecordsRequestEntry |
Create a value of PutRecordsRequestEntry
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:explicitHashKey:PutRecordsRequestEntry'
, putRecordsRequestEntry_explicitHashKey
- The hash value used to determine explicitly the shard that the data
record is assigned to by overriding the partition key hash.
$sel:data':PutRecordsRequestEntry'
, putRecordsRequestEntry_data
- The data blob to put into the record, which is base64-encoded when the
blob is serialized. When the data blob (the payload before
base64-encoding) is added to the partition key size, the total size must
not exceed the maximum record size (1 MiB).--
-- Note: This Lens
automatically encodes and decodes Base64 data.
-- The underlying isomorphism will encode to Base64 representation during
-- serialisation, and decode from Base64 representation during deserialisation.
-- This Lens
accepts and returns only raw unencoded data.
$sel:partitionKey:PutRecordsRequestEntry'
, putRecordsRequestEntry_partitionKey
- Determines which shard in the stream the data record is assigned to.
Partition keys are Unicode strings with a maximum length limit of 256
characters for each key. Amazon Kinesis Data Streams uses the partition
key as input to a hash function that maps the partition key and
associated data to a specific shard. Specifically, an MD5 hash function
is used to map partition keys to 128-bit integer values and to map
associated data records to shards. As a result of this hashing
mechanism, all data records with the same partition key map to the same
shard within the stream.
PutRecordsResultEntry
data PutRecordsResultEntry Source #
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.
See: newPutRecordsResultEntry
smart constructor.
Instances
newPutRecordsResultEntry :: PutRecordsResultEntry Source #
Create a value of PutRecordsResultEntry
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:sequenceNumber:PutRecordsResultEntry'
, putRecordsResultEntry_sequenceNumber
- The sequence number for an individual record result.
$sel:errorCode:PutRecordsResultEntry'
, putRecordsResultEntry_errorCode
- The error code for an individual record result. ErrorCodes
can be
either ProvisionedThroughputExceededException
or InternalFailure
.
$sel:errorMessage:PutRecordsResultEntry'
, putRecordsResultEntry_errorMessage
- The error message for an individual record result. An ErrorCode
value
of ProvisionedThroughputExceededException
has an error message that
includes the account ID, stream name, and shard ID. An ErrorCode
value
of InternalFailure
has the error message
"Internal Service Failure"
.
$sel:shardId:PutRecordsResultEntry'
, putRecordsResultEntry_shardId
- The shard ID for an individual record result.
Record
The unit of data of the Kinesis data stream, which is composed of a sequence number, a partition key, and a data blob.
See: newRecord
smart constructor.
Instances
:: Text | |
-> ByteString | |
-> Text | |
-> Record |
Create a value of Record
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:encryptionType:Record'
, record_encryptionType
- The encryption type used on the record. This parameter can be one of the
following values:
NONE
: Do not encrypt the records in the stream.KMS
: Use server-side encryption on the records in the stream using a customer-managed AWS KMS key.
$sel:approximateArrivalTimestamp:Record'
, record_approximateArrivalTimestamp
- The approximate time that the record was inserted into the stream.
$sel:sequenceNumber:Record'
, record_sequenceNumber
- The unique identifier of the record within its shard.
$sel:data':Record'
, record_data
- The data blob. The data in the blob is both opaque and immutable to
Kinesis Data Streams, which does not inspect, interpret, or change the
data in the blob in any way. When the data blob (the payload before
base64-encoding) is added to the partition key size, the total size must
not exceed the maximum record size (1 MiB).--
-- Note: This Lens
automatically encodes and decodes Base64 data.
-- The underlying isomorphism will encode to Base64 representation during
-- serialisation, and decode from Base64 representation during deserialisation.
-- This Lens
accepts and returns only raw unencoded data.
$sel:partitionKey:Record'
, record_partitionKey
- Identifies which shard in the stream the data record is assigned to.
SequenceNumberRange
data SequenceNumberRange Source #
The range of possible sequence numbers for the shard.
See: newSequenceNumberRange
smart constructor.
Instances
newSequenceNumberRange Source #
Create a value of SequenceNumberRange
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:endingSequenceNumber:SequenceNumberRange'
, sequenceNumberRange_endingSequenceNumber
- The ending sequence number for the range. Shards that are in the OPEN
state have an ending sequence number of null
.
$sel:startingSequenceNumber:SequenceNumberRange'
, sequenceNumberRange_startingSequenceNumber
- The starting sequence number for the range.
Shard
A uniquely identified group of data records in a Kinesis data stream.
See: newShard
smart constructor.
Instances
:: Text | |
-> HashKeyRange | |
-> SequenceNumberRange | |
-> Shard |
Create a value of Shard
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:adjacentParentShardId:Shard'
, shard_adjacentParentShardId
- The shard ID of the shard adjacent to the shard's parent.
$sel:parentShardId:Shard'
, shard_parentShardId
- The shard ID of the shard's parent.
$sel:shardId:Shard'
, shard_shardId
- The unique identifier of the shard within the stream.
$sel:hashKeyRange:Shard'
, shard_hashKeyRange
- The range of possible hash key values for the shard, which is a set of
ordered contiguous positive integers.
$sel:sequenceNumberRange:Shard'
, shard_sequenceNumberRange
- The range of possible sequence numbers for the shard.
ShardFilter
data ShardFilter Source #
See: newShardFilter
smart constructor.
Instances
Create a value of ShardFilter
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:timestamp:ShardFilter'
, shardFilter_timestamp
- Undocumented member.
$sel:shardId:ShardFilter'
, shardFilter_shardId
- Undocumented member.
$sel:type':ShardFilter'
, shardFilter_type
- Undocumented member.
StartingPosition
data StartingPosition Source #
See: newStartingPosition
smart constructor.
Instances
Create a value of StartingPosition
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:sequenceNumber:StartingPosition'
, startingPosition_sequenceNumber
- The sequence number of the data record in the shard from which to start
streaming. To specify a sequence number, set StartingPosition
to
AT_SEQUENCE_NUMBER
or AFTER_SEQUENCE_NUMBER
.
$sel:timestamp:StartingPosition'
, startingPosition_timestamp
- The time stamp of the data record from which to start reading. To
specify a time stamp, set StartingPosition
to Type AT_TIMESTAMP
. A
time stamp is the Unix epoch date with precision in milliseconds. For
example, 2016-04-04T19:58:46.480-00:00
or 1459799926.480
. If a
record with this exact time stamp does not exist, records will be
streamed from the next (later) record. If the time stamp is older than
the current trim horizon, records will be streamed from the oldest
untrimmed data record (TRIM_HORIZON
).
$sel:type':StartingPosition'
, startingPosition_type
- You can set the starting position to one of the following values:
AT_SEQUENCE_NUMBER
: Start streaming from the position denoted by the
sequence number specified in the SequenceNumber
field.
AFTER_SEQUENCE_NUMBER
: Start streaming right after the position
denoted by the sequence number specified in the SequenceNumber
field.
AT_TIMESTAMP
: Start streaming from the position denoted by the time
stamp specified in the Timestamp
field.
TRIM_HORIZON
: Start streaming at the last untrimmed record in the
shard, which is the oldest data record in the shard.
LATEST
: Start streaming just after the most recent record in the
shard, so that you always read the most recent data in the shard.
StreamDescription
data StreamDescription Source #
Represents the output for DescribeStream.
See: newStreamDescription
smart constructor.
StreamDescription' (Maybe EncryptionType) (Maybe Text) Text Text StreamStatus [Shard] Bool Int POSIX [EnhancedMetrics] |
Instances
:: Text | |
-> Text | |
-> StreamStatus | |
-> Bool | |
-> Int | |
-> UTCTime | |
-> StreamDescription |
Create a value of StreamDescription
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:encryptionType:StreamDescription'
, streamDescription_encryptionType
- The server-side encryption type used on the stream. This parameter can
be one of the following values:
NONE
: Do not encrypt the records in the stream.KMS
: Use server-side encryption on the records in the stream using a customer-managed AWS KMS key.
$sel:keyId:StreamDescription'
, streamDescription_keyId
- The GUID for the customer-managed AWS KMS key to use for encryption.
This value can be a globally unique identifier, a fully specified ARN to
either an alias or a key, or an alias name prefixed by "alias/".You
can also use a master key owned by Kinesis Data Streams by specifying
the alias aws/kinesis
.
- Key ARN example:
arn:aws:kms:us-east-1:123456789012:key/12345678-1234-1234-1234-123456789012
- Alias ARN example:
arn:aws:kms:us-east-1:123456789012:alias/MyAliasName
- Globally unique key ID example:
12345678-1234-1234-1234-123456789012
- Alias name example:
alias/MyAliasName
- Master key owned by Kinesis Data Streams:
alias/aws/kinesis
$sel:streamName:StreamDescription'
, streamDescription_streamName
- The name of the stream being described.
$sel:streamARN:StreamDescription'
, streamDescription_streamARN
- The Amazon Resource Name (ARN) for the stream being described.
$sel:streamStatus:StreamDescription'
, streamDescription_streamStatus
- The current status of the stream being described. The stream status is
one of the following states:
CREATING
- The stream is being created. Kinesis Data Streams immediately returns and setsStreamStatus
toCREATING
.DELETING
- The stream is being deleted. The specified stream is in theDELETING
state until Kinesis Data Streams completes the deletion.ACTIVE
- The stream exists and is ready for read and write operations or deletion. You should perform read and write operations only on anACTIVE
stream.UPDATING
- Shards in the stream are being merged or split. Read and write operations continue to work while the stream is in theUPDATING
state.
$sel:shards:StreamDescription'
, streamDescription_shards
- The shards that comprise the stream.
$sel:hasMoreShards:StreamDescription'
, streamDescription_hasMoreShards
- If set to true
, more shards in the stream are available to describe.
$sel:retentionPeriodHours:StreamDescription'
, streamDescription_retentionPeriodHours
- The current retention period, in hours. Minimum value of 24. Maximum
value of 168.
$sel:streamCreationTimestamp:StreamDescription'
, streamDescription_streamCreationTimestamp
- The approximate time that the stream was created.
$sel:enhancedMonitoring:StreamDescription'
, streamDescription_enhancedMonitoring
- Represents the current enhanced monitoring settings of the stream.
StreamDescriptionSummary
data StreamDescriptionSummary Source #
Represents the output for DescribeStreamSummary
See: newStreamDescriptionSummary
smart constructor.
StreamDescriptionSummary' (Maybe EncryptionType) (Maybe Text) (Maybe Natural) Text Text StreamStatus Int POSIX [EnhancedMetrics] Natural |
Instances
newStreamDescriptionSummary Source #
:: Text | |
-> Text | |
-> StreamStatus | |
-> Int | |
-> UTCTime | |
-> Natural | |
-> StreamDescriptionSummary |
Create a value of StreamDescriptionSummary
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:encryptionType:StreamDescriptionSummary'
, streamDescriptionSummary_encryptionType
- The encryption type used. This value is one of the following:
KMS
NONE
$sel:keyId:StreamDescriptionSummary'
, streamDescriptionSummary_keyId
- The GUID for the customer-managed AWS KMS key to use for encryption.
This value can be a globally unique identifier, a fully specified ARN to
either an alias or a key, or an alias name prefixed by "alias/".You
can also use a master key owned by Kinesis Data Streams by specifying
the alias aws/kinesis
.
- Key ARN example:
arn:aws:kms:us-east-1:123456789012:key/12345678-1234-1234-1234-123456789012
- Alias ARN example:
arn:aws:kms:us-east-1:123456789012:alias/MyAliasName
- Globally unique key ID example:
12345678-1234-1234-1234-123456789012
- Alias name example:
alias/MyAliasName
- Master key owned by Kinesis Data Streams:
alias/aws/kinesis
$sel:consumerCount:StreamDescriptionSummary'
, streamDescriptionSummary_consumerCount
- The number of enhanced fan-out consumers registered with the stream.
$sel:streamName:StreamDescriptionSummary'
, streamDescriptionSummary_streamName
- The name of the stream being described.
$sel:streamARN:StreamDescriptionSummary'
, streamDescriptionSummary_streamARN
- The Amazon Resource Name (ARN) for the stream being described.
$sel:streamStatus:StreamDescriptionSummary'
, streamDescriptionSummary_streamStatus
- The current status of the stream being described. The stream status is
one of the following states:
CREATING
- The stream is being created. Kinesis Data Streams immediately returns and setsStreamStatus
toCREATING
.DELETING
- The stream is being deleted. The specified stream is in theDELETING
state until Kinesis Data Streams completes the deletion.ACTIVE
- The stream exists and is ready for read and write operations or deletion. You should perform read and write operations only on anACTIVE
stream.UPDATING
- Shards in the stream are being merged or split. Read and write operations continue to work while the stream is in theUPDATING
state.
$sel:retentionPeriodHours:StreamDescriptionSummary'
, streamDescriptionSummary_retentionPeriodHours
- The current retention period, in hours.
$sel:streamCreationTimestamp:StreamDescriptionSummary'
, streamDescriptionSummary_streamCreationTimestamp
- The approximate time that the stream was created.
$sel:enhancedMonitoring:StreamDescriptionSummary'
, streamDescriptionSummary_enhancedMonitoring
- Represents the current enhanced monitoring settings of the stream.
$sel:openShardCount:StreamDescriptionSummary'
, streamDescriptionSummary_openShardCount
- The number of open shards in the stream.
SubscribeToShardEvent
data SubscribeToShardEvent Source #
After you call SubscribeToShard, Kinesis Data Streams sends events of this type over an HTTP/2 connection to your consumer.
See: newSubscribeToShardEvent
smart constructor.
Instances
newSubscribeToShardEvent Source #
:: Text | |
-> Natural | |
-> SubscribeToShardEvent |
Create a value of SubscribeToShardEvent
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:childShards:SubscribeToShardEvent'
, subscribeToShardEvent_childShards
- Undocumented member.
$sel:records:SubscribeToShardEvent'
, subscribeToShardEvent_records
-
$sel:continuationSequenceNumber:SubscribeToShardEvent'
, subscribeToShardEvent_continuationSequenceNumber
- Use this as SequenceNumber
in the next call to SubscribeToShard, with
StartingPosition
set to AT_SEQUENCE_NUMBER
or
AFTER_SEQUENCE_NUMBER
. Use ContinuationSequenceNumber
for
checkpointing because it captures your shard progress even when no data
is written to the shard.
$sel:millisBehindLatest:SubscribeToShardEvent'
, subscribeToShardEvent_millisBehindLatest
- The number of milliseconds the read records are from the tip of the
stream, indicating how far behind current time the consumer is. A value
of zero indicates that record processing is caught up, and there are no
new records to process at this moment.
Tag
Metadata assigned to the stream, consisting of a key-value pair.
See: newTag
smart constructor.
Instances
Eq Tag Source # | |
Read Tag Source # | |
Show Tag Source # | |
Generic Tag Source # | |
NFData Tag Source # | |
Defined in Amazonka.Kinesis.Types.Tag | |
Hashable Tag Source # | |
Defined in Amazonka.Kinesis.Types.Tag | |
FromJSON Tag Source # | |
type Rep Tag Source # | |
Defined in Amazonka.Kinesis.Types.Tag type Rep Tag = D1 ('MetaData "Tag" "Amazonka.Kinesis.Types.Tag" "libZSservicesZSamazonka-kinesisZSamazonka-kinesis" 'False) (C1 ('MetaCons "Tag'" 'PrefixI 'True) (S1 ('MetaSel ('Just "value") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 (Maybe Text)) :*: S1 ('MetaSel ('Just "key") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedStrict) (Rec0 Text))) |
Create a value of Tag
with all optional fields omitted.
Use generic-lens or optics to modify other optional fields.
The following record fields are available, with the corresponding lenses provided for backwards compatibility:
$sel:value:Tag'
, tag_value
- An optional string, typically used to describe or define the tag.
Maximum length: 256 characters. Valid characters: Unicode letters,
digits, white space, _ . / = + - % @
$sel:key:Tag'
, tag_key
- A unique identifier for the tag. Maximum length: 128 characters. Valid
characters: Unicode letters, digits, white space, _ . / = + - % @