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> |
The FlinkKinesisProducer allows to produce from a Flink DataStream into Kinesis.
|
KinesisPartitioner<T> |
An interface for partitioning records.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.