public abstract static class KinesisIO.RecordAggregation.Builder
extends java.lang.Object
Constructor and Description |
---|
Builder() |
Modifier and Type | Method and Description |
---|---|
KinesisIO.RecordAggregation |
build() |
abstract KinesisIO.RecordAggregation.Builder |
maxBufferedTime(Duration interval)
Buffer timeout for user records.
|
abstract KinesisIO.RecordAggregation.Builder |
maxBytes(int bytes)
Max bytes per aggregated record.
|
abstract KinesisIO.RecordAggregation.Builder |
shardRefreshInterval(Duration interval)
Refresh interval for shards.
|
public abstract KinesisIO.RecordAggregation.Builder maxBytes(int bytes)
public abstract KinesisIO.RecordAggregation.Builder maxBufferedTime(Duration interval)
Note: This is only attempted on a best effort basis. In case request latency is too high, timeouts can be delayed.
public abstract KinesisIO.RecordAggregation.Builder shardRefreshInterval(Duration interval)
This is used for shard aware record aggregation to assign all records hashed to a
particular shard to the same explicit hash key. Set to Duration.ZERO
to disable
loading shards.
public KinesisIO.RecordAggregation build()