scala.com.amazonaws.kinesis.GetRecordsOutput.scala Maven / Gradle / Ivy
Show all versions of kinesis4cats-smithy4s-client_3 Show documentation
package com.amazonaws.kinesis
import smithy4s.Hints
import smithy4s.Schema
import smithy4s.ShapeId
import smithy4s.ShapeTag
import smithy4s.schema.Schema.struct
/** Represents the output for GetRecords.
* @param Records
* The data records retrieved from the shard.
* @param 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.
* @param 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.
* @param ChildShards
* The list of the current shard's child shards, returned in the GetRecords
* API's response only when the end of the current shard is reached.
*/
final case class GetRecordsOutput(records: List[Record], nextShardIterator: Option[ShardIterator] = None, millisBehindLatest: Option[MillisBehindLatest] = None, childShards: Option[List[ChildShard]] = None)
object GetRecordsOutput extends ShapeTag.Companion[GetRecordsOutput] {
val id: ShapeId = ShapeId("com.amazonaws.kinesis", "GetRecordsOutput")
val hints: Hints = Hints(
smithy.api.Documentation("Represents the output for GetRecords.
"),
smithy.api.Output(),
)
implicit val schema: Schema[GetRecordsOutput] = struct(
RecordList.underlyingSchema.required[GetRecordsOutput]("Records", _.records).addHints(smithy.api.Documentation("The data records retrieved from the shard.
")),
ShardIterator.schema.optional[GetRecordsOutput]("NextShardIterator", _.nextShardIterator).addHints(smithy.api.Documentation("The next position in the shard from which to start sequentially reading data records.\n If set to null
, the shard has been closed and the requested iterator does\n not return any more data.
")),
MillisBehindLatest.schema.optional[GetRecordsOutput]("MillisBehindLatest", _.millisBehindLatest).addHints(smithy.api.Documentation("The number of milliseconds the GetRecords response is from the tip\n of the stream, indicating how far behind current time the consumer is. A value of zero\n indicates that record processing is caught up, and there are no new records to process\n at this moment.
")),
ChildShardList.underlyingSchema.optional[GetRecordsOutput]("ChildShards", _.childShards).addHints(smithy.api.Documentation("The list of the current shard\'s child shards, returned in the GetRecords
\n API\'s response only when the end of the current shard is reached.
")),
){
GetRecordsOutput.apply
}.withId(id).addHints(hints)
}