Class KinesisIO.RecordAggregation.Builder
java.lang.Object
org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.RecordAggregation.Builder
- Enclosing class:
KinesisIO.RecordAggregation
-
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionbuild()abstract KinesisIO.RecordAggregation.BuildermaxBufferedTime(Duration interval) Buffer timeout for user records.abstract KinesisIO.RecordAggregation.BuildermaxBytes(int bytes) Max bytes per aggregated record.abstract KinesisIO.RecordAggregation.BuildershardRefreshInterval(Duration interval) Refresh interval for shards.
-
Constructor Details
-
Builder
public Builder()
-
-
Method Details
-
maxBytes
Max bytes per aggregated record. -
maxBufferedTime
Buffer timeout for user records.Note: This is only attempted on a best effort basis. In case request latency is too high, timeouts can be delayed.
-
shardRefreshInterval
Refresh interval for shards.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.ZEROto disable loading shards. -
build
-