public abstract static class KinesisIO.Read<T> extends PTransform<PBegin,PCollection<T>>
KinesisIO.read().name, resourceHints| Constructor and Description | 
|---|
| Read() | 
| Modifier and Type | Method and Description | 
|---|---|
| PCollection<T> | expand(PBegin input)Override this method to specify how this  PTransformshould be expanded on the givenInputT. | 
| KinesisIO.Read<T> | withArrivalTimeWatermarkPolicy()Specifies the  WatermarkPolicyFactoryas ArrivalTimeWatermarkPolicyFactory. | 
| KinesisIO.Read<T> | withArrivalTimeWatermarkPolicy(Duration watermarkIdleDurationThreshold)Specifies the  WatermarkPolicyFactoryas ArrivalTimeWatermarkPolicyFactory. | 
| KinesisIO.Read<T> | withAWSClientsProvider(AWSClientsProvider awsClientsProvider)Allows to specify custom  AWSClientsProvider. | 
| KinesisIO.Read<T> | withAWSClientsProvider(AWSCredentialsProvider awsCredentialsProvider,
                      Regions region)Specify  AWSCredentialsProviderand region to be used to read from Kinesis. | 
| KinesisIO.Read<T> | withAWSClientsProvider(AWSCredentialsProvider awsCredentialsProvider,
                      Regions region,
                      java.lang.String serviceEndpoint)Specify  AWSCredentialsProviderand region to be used to read from Kinesis. | 
| KinesisIO.Read<T> | withAWSClientsProvider(AWSCredentialsProvider awsCredentialsProvider,
                      Regions region,
                      java.lang.String serviceEndpoint,
                      boolean verifyCertificate)Specify  AWSCredentialsProviderand region to be used to read from Kinesis. | 
| KinesisIO.Read<T> | withAWSClientsProvider(java.lang.String awsAccessKey,
                      java.lang.String awsSecretKey,
                      Regions region)Specify credential details and region to be used to read from Kinesis. | 
| KinesisIO.Read<T> | withAWSClientsProvider(java.lang.String awsAccessKey,
                      java.lang.String awsSecretKey,
                      Regions region,
                      java.lang.String serviceEndpoint)Specify credential details and region to be used to read from Kinesis. | 
| KinesisIO.Read<T> | withAWSClientsProvider(java.lang.String awsAccessKey,
                      java.lang.String awsSecretKey,
                      Regions region,
                      java.lang.String serviceEndpoint,
                      boolean verifyCertificate)Specify credential details and region to be used to read from Kinesis. | 
| KinesisIO.Read<T> | withCustomRateLimitPolicy(RateLimitPolicyFactory rateLimitPolicyFactory)Specifies the  RateLimitPolicyFactoryfor a custom rate limiter. | 
| KinesisIO.Read<T> | withCustomWatermarkPolicy(WatermarkPolicyFactory watermarkPolicyFactory)Specifies the  WatermarkPolicyFactoryas a custom watermarkPolicyFactory. | 
| KinesisIO.Read<T> | withDynamicDelayRateLimitPolicy(java.util.function.Supplier<Duration> delay)Specifies a dynamic delay rate limit policy with the given function being called at each
 polling interval to get the next delay value. | 
| KinesisIO.Read<T> | withFixedDelayRateLimitPolicy()Specifies a fixed delay rate limit policy with the default delay of 1 second. | 
| KinesisIO.Read<T> | withFixedDelayRateLimitPolicy(Duration delay)Specifies a fixed delay rate limit policy with the given delay. | 
| KinesisIO.Read<T> | withInitialPositionInStream(com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPosition)Specify reading from some initial position in stream. | 
| KinesisIO.Read<T> | withInitialTimestampInStream(Instant initialTimestamp)Specify reading beginning at given  Instant. | 
| KinesisIO.Read<T> | withMaxCapacityPerShard(java.lang.Integer maxCapacity)Specifies the maximum number of messages per one shard. | 
| KinesisIO.Read<T> | withMaxNumRecords(long maxNumRecords)Specifies to read at most a given number of records. | 
| KinesisIO.Read<T> | withMaxReadTime(Duration maxReadTime)Specifies to read records during  maxReadTime. | 
| KinesisIO.Read<T> | withProcessingTimeWatermarkPolicy()Specifies the  WatermarkPolicyFactoryas ProcessingTimeWatermarkPolicyFactory. | 
| KinesisIO.Read<T> | withRequestRecordsLimit(int limit)Specifies the maximum number of records in GetRecordsResult returned by GetRecords call which
 is limited by 10K records. | 
| KinesisIO.Read<T> | withStreamName(java.lang.String streamName)Specify reading from streamName. | 
| KinesisIO.Read<T> | withUpToDateThreshold(Duration upToDateThreshold)Specifies how late records consumed by this source can be to still be considered on time. | 
compose, compose, getAdditionalInputs, getDefaultOutputCoder, getDefaultOutputCoder, getDefaultOutputCoder, getKindString, getName, getResourceHints, populateDisplayData, setResourceHints, toString, validate, validatepublic KinesisIO.Read<T> withStreamName(java.lang.String streamName)
public KinesisIO.Read<T> withInitialPositionInStream(com.amazonaws.services.kinesis.clientlibrary.lib.worker.InitialPositionInStream initialPosition)
public KinesisIO.Read<T> withInitialTimestampInStream(Instant initialTimestamp)
Instant. This Instant must be in the past,
 i.e. before Instant.now().public KinesisIO.Read<T> withAWSClientsProvider(AWSClientsProvider awsClientsProvider)
AWSClientsProvider. AWSClientsProvider provides
 AmazonKinesis and AmazonCloudWatch instances which are later used for
 communication with Kinesis. You should use this method if withAWSClientsProvider(AWSCredentialsProvider, Regions) does not suit your needs.public KinesisIO.Read<T> withAWSClientsProvider(AWSCredentialsProvider awsCredentialsProvider, Regions region)
AWSCredentialsProvider and region to be used to read from Kinesis. If you
 need more sophisticated credential protocol, then you should look at withAWSClientsProvider(AWSClientsProvider).public KinesisIO.Read<T> withAWSClientsProvider(java.lang.String awsAccessKey, java.lang.String awsSecretKey, Regions region)
withAWSClientsProvider(AWSClientsProvider).public KinesisIO.Read<T> withAWSClientsProvider(AWSCredentialsProvider awsCredentialsProvider, Regions region, java.lang.String serviceEndpoint)
AWSCredentialsProvider and region to be used to read from Kinesis. If you
 need more sophisticated credential protocol, then you should look at withAWSClientsProvider(AWSClientsProvider).
 The serviceEndpoint sets an alternative service host. This is useful to execute
 the tests with a kinesis service emulator.
public KinesisIO.Read<T> withAWSClientsProvider(java.lang.String awsAccessKey, java.lang.String awsSecretKey, Regions region, java.lang.String serviceEndpoint)
withAWSClientsProvider(AWSClientsProvider).
 The serviceEndpoint sets an alternative service host. This is useful to execute
 the tests with a kinesis service emulator.
public KinesisIO.Read<T> withAWSClientsProvider(AWSCredentialsProvider awsCredentialsProvider, Regions region, java.lang.String serviceEndpoint, boolean verifyCertificate)
AWSCredentialsProvider and region to be used to read from Kinesis. If you
 need more sophisticated credential protocol, then you should look at withAWSClientsProvider(AWSClientsProvider).
 The serviceEndpoint sets an alternative service host. This is useful to execute
 the tests with Kinesis service emulator.
 
The verifyCertificate disables or enables certificate verification. Never set it
 to false in production.
public KinesisIO.Read<T> withAWSClientsProvider(java.lang.String awsAccessKey, java.lang.String awsSecretKey, Regions region, java.lang.String serviceEndpoint, boolean verifyCertificate)
withAWSClientsProvider(AWSClientsProvider).
 The serviceEndpoint sets an alternative service host. This is useful to execute
 the tests with Kinesis service emulator.
 
The verifyCertificate disables or enables certificate verification. Never set it
 to false in production.
public KinesisIO.Read<T> withMaxNumRecords(long maxNumRecords)
public KinesisIO.Read<T> withMaxReadTime(Duration maxReadTime)
maxReadTime.public KinesisIO.Read<T> withUpToDateThreshold(Duration upToDateThreshold)
public KinesisIO.Read<T> withRequestRecordsLimit(int limit)
public KinesisIO.Read<T> withArrivalTimeWatermarkPolicy()
WatermarkPolicyFactory as ArrivalTimeWatermarkPolicyFactory.public KinesisIO.Read<T> withArrivalTimeWatermarkPolicy(Duration watermarkIdleDurationThreshold)
WatermarkPolicyFactory as ArrivalTimeWatermarkPolicyFactory.
 Denotes the duration for which the watermark can be idle.
public KinesisIO.Read<T> withProcessingTimeWatermarkPolicy()
WatermarkPolicyFactory as ProcessingTimeWatermarkPolicyFactory.public KinesisIO.Read<T> withCustomWatermarkPolicy(WatermarkPolicyFactory watermarkPolicyFactory)
WatermarkPolicyFactory as a custom watermarkPolicyFactory.watermarkPolicyFactory - Custom Watermark policy factory.public KinesisIO.Read<T> withFixedDelayRateLimitPolicy()
public KinesisIO.Read<T> withFixedDelayRateLimitPolicy(Duration delay)
delay - Denotes the fixed delay duration.public KinesisIO.Read<T> withDynamicDelayRateLimitPolicy(java.util.function.Supplier<Duration> delay)
delay - The function to invoke to get the next delay duration.public KinesisIO.Read<T> withCustomRateLimitPolicy(RateLimitPolicyFactory rateLimitPolicyFactory)
RateLimitPolicyFactory for a custom rate limiter.rateLimitPolicyFactory - Custom rate limit policy factory.public KinesisIO.Read<T> withMaxCapacityPerShard(java.lang.Integer maxCapacity)
public PCollection<T> expand(PBegin input)
PTransformPTransform should be expanded on the given
 InputT.
 NOTE: This method should not be called directly. Instead apply the PTransform should
 be applied to the InputT using the apply method.
 
Composite transforms, which are defined in terms of other transforms, should return the output of one of the composed transforms. Non-composite transforms, which do not apply any transforms internally, should return a new unbound output and register evaluators (via backend-specific registration methods).
expand in class PTransform<PBegin,PCollection<T>>