Class PubsubLiteWriteSchemaTransformProvider
java.lang.Object
org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider<PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration>
org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider
- All Implemented Interfaces:
 SchemaTransformProvider
@AutoService(SchemaTransformProvider.class)
public class PubsubLiteWriteSchemaTransformProvider
extends TypedSchemaTransformProvider<PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration>
- 
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionstatic classstatic classstatic class - 
Field Summary
Fields - 
Constructor Summary
Constructors - 
Method Summary
Modifier and TypeMethodDescriptionReturns a description regarding theSchemaTransformrepresented by theSchemaTransformProvider.from(PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration configuration) Produce a SchemaTransform from ConfigT.static SerializableFunction<Row, byte[]> getRowToRawBytesFunction(String rowFieldName) static SchemagetSchemaWithoutAttributes(Schema inputSchema, List<String> attributes) Returns an id that uniquely represents this transform.Returns the input collection names of this transform.Returns the output collection names of this transform.Methods inherited from class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProvider
configurationSchema, dependencies, from 
- 
Field Details
- 
SUPPORTED_FORMATS_STR
- See Also:
 
 - 
SUPPORTED_FORMATS
 - 
OUTPUT_TAG
 - 
ERROR_TAG
 
 - 
 - 
Constructor Details
- 
PubsubLiteWriteSchemaTransformProvider
public PubsubLiteWriteSchemaTransformProvider() 
 - 
 - 
Method Details
- 
configurationClass
protected Class<PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration> configurationClass() - 
description
Description copied from interface:SchemaTransformProviderReturns a description regarding theSchemaTransformrepresented by theSchemaTransformProvider. Please keep the language generic (i.e. not specific to any programming language). The description may be markdown formatted. - 
from
public SchemaTransform from(PubsubLiteWriteSchemaTransformProvider.PubsubLiteWriteSchemaTransformConfiguration configuration) Description copied from class:TypedSchemaTransformProviderProduce a SchemaTransform from ConfigT. Can throw aInvalidConfigurationExceptionor aInvalidSchemaException. - 
getSchemaWithoutAttributes
 - 
getRowToRawBytesFunction
 - 
identifier
Description copied from interface:SchemaTransformProviderReturns an id that uniquely represents this transform. - 
inputCollectionNames
Description copied from interface:SchemaTransformProviderReturns the input collection names of this transform. - 
outputCollectionNames
Description copied from interface:SchemaTransformProviderReturns the output collection names of this transform. 
 -