Interface | Description |
---|---|
KinesisShardAssigner |
Utility to map Kinesis shards to Flink subtask indices.
|
Class | Description |
---|---|
FlinkDynamoDBStreamsConsumer<T> |
Consume events from DynamoDB streams.
|
FlinkKinesisConsumer<T> |
The Flink Kinesis Consumer is an exactly-once parallel streaming data source that subscribes to
multiple AWS Kinesis streams within the same AWS service region, and can handle resharding of
streams.
|
FlinkKinesisProducer<OUT> | Deprecated
This producer based on the Kinesis Producer Library KPL has been superseded.
|
KinesisPartitioner<T> |
An interface for partitioning records.
|
Exception | Description |
---|---|
FlinkKinesisException |
A
RuntimeException wrapper indicating the exception was thrown from this connector. |
FlinkKinesisException.FlinkKinesisTimeoutException |
A semantic
RuntimeException thrown to indicate timeout errors in the Kinesis
connector. |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.