Class BatchSinkContextImpl
java.lang.Object
org.apache.beam.sdk.io.cdap.context.BatchContextImpl
org.apache.beam.sdk.io.cdap.context.BatchSinkContextImpl
- All Implemented Interfaces:
DatasetContext
,MetadataReader
,MetadataWriter
,ServiceDiscoverer
,BatchContext
,BatchSinkContext
,LineageRecorder
,LookupProvider
,StageContext
,TransformContext
Class for creating context object of different CDAP classes with batch sink type.
-
Field Summary
Fields inherited from class org.apache.beam.sdk.io.cdap.context.BatchContextImpl
DEFAULT_SCHEMA_FIELD_NAME, DEFAULT_SCHEMA_RECORD_NAME, inputFormatProvider, outputFormatProvider, settableArguments
-
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionvoid
Overrides the output configuration of this Batch job to the specifiedOutput
.boolean
Methods inherited from class org.apache.beam.sdk.io.cdap.context.BatchContextImpl
addProperties, addTags, addTags, createDataset, datasetExists, discardDataset, getArguments, getDataset, getDataset, getDataset, getDataset, getFailureCollector, getInputFormatProvider, getInputSchema, getInputSchemas, getLogicalStartTime, getMetadata, getMetadata, getMetrics, getNamespace, getOutputFormatProvider, getOutputPortSchemas, getOutputSchema, getPipelineName, getPluginProperties, getPluginProperties, getServiceURL, getServiceURL, getStageName, loadPluginClass, newPluginInstance, provide, record, releaseDataset, removeMetadata, removeProperties, removeProperties, removeTags, removeTags
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface io.cdap.cdap.etl.api.batch.BatchContext
createDataset, datasetExists, getArguments
Methods inherited from interface io.cdap.cdap.api.data.DatasetContext
discardDataset, getDataset, getDataset, getDataset, getDataset, releaseDataset
Methods inherited from interface io.cdap.cdap.etl.api.lineage.field.LineageRecorder
record
Methods inherited from interface io.cdap.cdap.etl.api.LookupProvider
provide
Methods inherited from interface io.cdap.cdap.api.metadata.MetadataReader
getMetadata, getMetadata
Methods inherited from interface io.cdap.cdap.api.metadata.MetadataWriter
addProperties, addTags, addTags, removeMetadata, removeProperties, removeProperties, removeTags, removeTags
Methods inherited from interface io.cdap.cdap.api.ServiceDiscoverer
getServiceURL, getServiceURL, getServiceURL, openConnection
Methods inherited from interface io.cdap.cdap.etl.api.StageContext
getFailureCollector, getInputSchema, getInputSchemas, getInputStages, getLogicalStartTime, getMetrics, getNamespace, getOutputPortSchemas, getOutputSchema, getPipelineName, getPluginProperties, getPluginProperties, getStageName, loadPluginClass, newPluginInstance
-
Constructor Details
-
BatchSinkContextImpl
public BatchSinkContextImpl()
-
-
Method Details
-
addOutput
Overrides the output configuration of this Batch job to the specifiedOutput
.- Specified by:
addOutput
in interfaceBatchSinkContext
-
isPreviewEnabled
public boolean isPreviewEnabled()- Specified by:
isPreviewEnabled
in interfaceBatchSinkContext
-