Class BeamRowToBigtableMutation.ToBigtableRowFn

java.lang.Object
org.apache.beam.sdk.transforms.InferableFunction<Row,KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>
org.apache.beam.sdk.transforms.SimpleFunction<Row,KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>
org.apache.beam.sdk.io.gcp.bigtable.BeamRowToBigtableMutation.ToBigtableRowFn
All Implemented Interfaces:
Serializable, HasDisplayData, ProcessFunction<Row,KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>, SerializableFunction<Row,KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>
Enclosing class:
BeamRowToBigtableMutation

public static class BeamRowToBigtableMutation.ToBigtableRowFn extends SimpleFunction<Row,KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>
See Also: