public abstract static class KinesisIO.Write extends PTransform<PCollection<byte[]>,PDone>
KinesisIO.write().name, resourceHints| Constructor and Description | 
|---|
| Write() | 
| Modifier and Type | Method and Description | 
|---|---|
| PDone | expand(PCollection<byte[]> input)Override this method to specify how this  PTransformshould be expanded on the givenInputT. | 
| KinesisIO.Write | withAWSClientsProvider(AWSClientsProvider awsClientsProvider)Allows to specify custom  AWSClientsProvider. | 
| KinesisIO.Write | withAWSClientsProvider(java.lang.String awsAccessKey,
                      java.lang.String awsSecretKey,
                      Regions region)Specify credential details and region to be used to write to Kinesis. | 
| KinesisIO.Write | withAWSClientsProvider(java.lang.String awsAccessKey,
                      java.lang.String awsSecretKey,
                      Regions region,
                      java.lang.String serviceEndpoint)Specify credential details and region to be used to write to Kinesis. | 
| KinesisIO.Write | 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 write to Kinesis. | 
| KinesisIO.Write | withPartitioner(KinesisPartitioner partitioner)Allows to specify custom implementation of  KinesisPartitioner. | 
| KinesisIO.Write | withPartitionKey(java.lang.String partitionKey)Specify default partition key. | 
| KinesisIO.Write | withProducerProperties(java.util.Properties properties)Specify the configuration properties for Kinesis Producer Library (KPL). | 
| KinesisIO.Write | withStreamName(java.lang.String streamName)Specify Kinesis stream name which will be used for writing, this name is required. | 
compose, compose, getAdditionalInputs, getDefaultOutputCoder, getDefaultOutputCoder, getDefaultOutputCoder, getKindString, getName, getResourceHints, populateDisplayData, setResourceHints, toString, validatepublic KinesisIO.Write withStreamName(java.lang.String streamName)
public KinesisIO.Write withPartitionKey(java.lang.String partitionKey)
In case if you need to define more complicated logic for key partitioning then you can
 create your own implementation of KinesisPartitioner and specify it by withPartitioner(KinesisPartitioner)
 
Using one of the methods withPartitioner(KinesisPartitioner) or
 withPartitionKey(String) is required but not both in the same time.
public KinesisIO.Write withPartitioner(KinesisPartitioner partitioner)
KinesisPartitioner.
 This method should be used to balance a distribution of new written records among all stream shards.
Using one of the methods withPartitioner(KinesisPartitioner) or
 withPartitionKey(String) is required but not both in the same time.
public KinesisIO.Write withProducerProperties(java.util.Properties properties)
Example of creating new KPL configuration:
Properties properties = new Properties();
 properties.setProperty("CollectionMaxCount", "1000");
 properties.setProperty("ConnectTimeout", "10000");
public KinesisIO.Write withAWSClientsProvider(AWSClientsProvider awsClientsProvider)
AWSClientsProvider. AWSClientsProvider creates new
 IKinesisProducer which is later used for writing to Kinesis.
 This method should be used if withAWSClientsProvider(String, String,
 Regions) does not suit well.
public KinesisIO.Write withAWSClientsProvider(java.lang.String awsAccessKey, java.lang.String awsSecretKey, Regions region)
withAWSClientsProvider(AWSClientsProvider).public KinesisIO.Write 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 Kinesis service emulator.
public KinesisIO.Write 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 PDone expand(PCollection<byte[]> 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<PCollection<byte[]>,PDone>