Skip navigation links
A B C D E F G H I J K L M N O P R S T V W 

A

AccessType - Enum in io.cdap.cdap.etl.api.lineage
Lineage access type, only support READ and WRITE
Action - Class in io.cdap.cdap.etl.api.action
Represents custom logic to be executed in the pipeline.
Action() - Constructor for class io.cdap.cdap.etl.api.action.Action
 
ActionContext - Interface in io.cdap.cdap.etl.api.action
Represents the context available to the action plugin during runtime.
addAttribute(String, String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure.Cause
Adds an attribute to this cause.
addFailure(String, String) - Method in interface io.cdap.cdap.etl.api.FailureCollector
Add a validation failure to this failure collector.
addOutput(Output) - Method in interface io.cdap.cdap.etl.api.batch.BatchSinkContext
Updates the output configuration of this job to also allow writing using the given output.
aggregate(GROUP_KEY, Iterator<GROUP_VALUE>, Emitter<OUT>) - Method in interface io.cdap.cdap.etl.api.Aggregator
Aggregate all objects in the same group into zero or more output objects.
Aggregator<GROUP_KEY,GROUP_VALUE,OUT> - Interface in io.cdap.cdap.etl.api
Groups all input objects into collections and performs an aggregation on the entire group.
Alert - Class in io.cdap.cdap.etl.api
An alert emitted by a stage in the pipeline.
Alert(String, Map<String, String>) - Constructor for class io.cdap.cdap.etl.api.Alert
 
AlertEmitter - Interface in io.cdap.cdap.etl.api
Emits alerts.
AlertPublisher - Class in io.cdap.cdap.etl.api
A pipeline stage that can publish any alerts emitted by the previous stage.
AlertPublisher() - Constructor for class io.cdap.cdap.etl.api.AlertPublisher
 
AlertPublisherContext - Interface in io.cdap.cdap.etl.api
Context for an AlertPublisher, exposing methods to publish messages to TMS.
apply(ConditionContext) - Method in class io.cdap.cdap.etl.api.condition.Condition
Returns the result of execution of the condition.
Arguments - Interface in io.cdap.cdap.etl.api
Provides access to the pipeline arguments at runtime.
asMap() - Method in interface io.cdap.cdap.etl.api.action.SettableArguments
Returns an unmodifiable map that represents all arguments.

B

BatchActionContext - Interface in io.cdap.cdap.etl.api.batch
Context for a batch action, giving access to whether the run was successful, the workflow token, and the state of each phase in the workflow.
BatchAggregator<GROUP_KEY,GROUP_VALUE,OUT> - Class in io.cdap.cdap.etl.api.batch
An Aggregator used in batch programs.
BatchAggregator() - Constructor for class io.cdap.cdap.etl.api.batch.BatchAggregator
 
BatchAggregatorContext - Interface in io.cdap.cdap.etl.api.batch
Context of a Batch Aggregator.
BatchConfigurable<T extends BatchContext> - Class in io.cdap.cdap.etl.api.batch
Base class for Batch run configuration methods.
BatchConfigurable() - Constructor for class io.cdap.cdap.etl.api.batch.BatchConfigurable
 
BatchContext - Interface in io.cdap.cdap.etl.api.batch
Context passed to Batch Source and Sink.
BatchJoiner<JOIN_KEY,INPUT_RECORD,OUT> - Class in io.cdap.cdap.etl.api.batch
A Joiner used for batch programs.
BatchJoiner() - Constructor for class io.cdap.cdap.etl.api.batch.BatchJoiner
 
BatchJoinerContext - Interface in io.cdap.cdap.etl.api.batch
Context of a Batch Joiner
BatchJoinerRuntimeContext - Interface in io.cdap.cdap.etl.api.batch
Runtime context for batch joiner
BatchRuntimeContext - Interface in io.cdap.cdap.etl.api.batch
Context passed to Batch Source and Sink.
BatchSink<IN,KEY_OUT,VAL_OUT> - Class in io.cdap.cdap.etl.api.batch
Batch Sink forms the last stage of a Batch ETL Pipeline.
BatchSink() - Constructor for class io.cdap.cdap.etl.api.batch.BatchSink
 
BatchSinkContext - Interface in io.cdap.cdap.etl.api.batch
Context of a Batch Sink.
BatchSource<KEY_IN,VAL_IN,OUT> - Class in io.cdap.cdap.etl.api.batch
Batch Source forms the first stage of a Batch ETL Pipeline.
BatchSource() - Constructor for class io.cdap.cdap.etl.api.batch.BatchSource
 
BatchSourceContext - Interface in io.cdap.cdap.etl.api.batch
Context of a Batch Source.

C

CacheConfig - Class in io.cdap.cdap.etl.api
Cache configuration.
CacheConfig(long, int) - Constructor for class io.cdap.cdap.etl.api.CacheConfig
 
CacheConfig() - Constructor for class io.cdap.cdap.etl.api.CacheConfig
 
Cause() - Constructor for class io.cdap.cdap.etl.api.validation.ValidationFailure.Cause
Creates a failure cause.
CauseAttributes - Class in io.cdap.cdap.etl.api.validation
Cause attributes constants.
CauseAttributes() - Constructor for class io.cdap.cdap.etl.api.validation.CauseAttributes
 
Condition - Class in io.cdap.cdap.etl.api.condition
Represents condition to be executed in the pipeline.
Condition() - Constructor for class io.cdap.cdap.etl.api.condition.Condition
 
ConditionContext - Interface in io.cdap.cdap.etl.api.condition
Represents the context available to the condition plugin during runtime.
CONFIG_ELEMENT - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.action.Action
 
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.AlertPublisher
 
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.BatchAggregator
Configure the pipeline.
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.BatchConfigurable
 
configurePipeline(MultiInputPipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.BatchJoiner
Configure the pipeline.
configurePipeline(MultiInputPipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.MultiInputBatchConfigurable
 
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.PostAction
Configure the pipeline.
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.condition.Condition
 
configurePipeline(MultiInputPipelineConfigurer) - Method in interface io.cdap.cdap.etl.api.MultiInputPipelineConfigurable
Configure an ETL pipeline, adding datasets and streams that the stage needs.
configurePipeline(MultiOutputPipelineConfigurer) - Method in interface io.cdap.cdap.etl.api.MultiOutputPipelineConfigurable
Configure a pipeline, adding datasets and streams that the stage needs.
configurePipeline(PipelineConfigurer) - Method in interface io.cdap.cdap.etl.api.PipelineConfigurable
Configure an ETL pipeline, registering datasets and plugins that the stage needs.
configurePipeline(MultiOutputPipelineConfigurer) - Method in class io.cdap.cdap.etl.api.SplitterTransform
 
configurePipeline(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.Transform
Configure an ETL pipeline.
count(String, int) - Method in interface io.cdap.cdap.etl.api.StageMetrics
Increases the value of the specific metric by delta.
createDataset(String, String, DatasetProperties) - Method in interface io.cdap.cdap.etl.api.batch.BatchContext
Create a new dataset instance.

D

datasetExists(String) - Method in interface io.cdap.cdap.etl.api.batch.BatchContext
Check whether a dataset exists in the current namespace.
destroy() - Method in class io.cdap.cdap.etl.api.AlertPublisher
 
destroy() - Method in class io.cdap.cdap.etl.api.batch.BatchAggregator
Destroy the Batch Aggregator.
destroy() - Method in class io.cdap.cdap.etl.api.batch.BatchJoiner
Destroy the Batch Joiner.
destroy() - Method in class io.cdap.cdap.etl.api.batch.BatchSink
Destroy the Batch Sink stage.
destroy() - Method in class io.cdap.cdap.etl.api.batch.BatchSource
Destroy the Batch Source stage.
destroy() - Method in interface io.cdap.cdap.etl.api.Destroyable
Invoked for resources cleanup.
destroy() - Method in class io.cdap.cdap.etl.api.SplitterTransform
 
destroy() - Method in class io.cdap.cdap.etl.api.Transform
Destroy the Transform Stage.
Destroyable - Interface in io.cdap.cdap.etl.api
Interface for stage that supports destroy call for resources cleanup.

E

emit(T) - Method in interface io.cdap.cdap.etl.api.Emitter
Emit an object.
emit(String, Object) - Method in interface io.cdap.cdap.etl.api.MultiOutputEmitter
Emit an output record to the specified port.
emitAlert(Map<String, String>) - Method in interface io.cdap.cdap.etl.api.AlertEmitter
Emit an alert.
emitError(InvalidEntry<T>) - Method in interface io.cdap.cdap.etl.api.ErrorEmitter
Emit an Error object.
Emitter<T> - Interface in io.cdap.cdap.etl.api
Used to emit one or more key, value pairs to the next stage.
Engine - Enum in io.cdap.cdap.etl.api
Execution engines.
equals(Object) - Method in class io.cdap.cdap.etl.api.Alert
 
equals(Object) - Method in class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
equals(Object) - Method in class io.cdap.cdap.etl.api.lineage.field.FieldReadOperation
 
equals(Object) - Method in class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
 
equals(Object) - Method in class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
 
equals(Object) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure.Cause
 
equals(Object) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
 
ErrorEmitter<T> - Interface in io.cdap.cdap.etl.api
Emits errors.
ErrorRecord<T> - Interface in io.cdap.cdap.etl.api
Information about a record that was emitted using ErrorEmitter.emitError(InvalidEntry).
ErrorTransform<IN,OUT> - Class in io.cdap.cdap.etl.api
A special type of Transform that will get as input all errors emitted by the previous stage.
ErrorTransform() - Constructor for class io.cdap.cdap.etl.api.ErrorTransform
 

F

FailureCollector - Interface in io.cdap.cdap.etl.api
Failure collector is responsible to collect ValidationFailures.
FieldOperation - Class in io.cdap.cdap.etl.api.lineage.field
Abstract base class to represent a field lineage operation.
FieldOperation(String, OperationType, String) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
FieldReadOperation - Class in io.cdap.cdap.etl.api.lineage.field
Represents a read operation from a data source into a collection of output fields.
FieldReadOperation(String, String, EndPoint, String...) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldReadOperation
Create an instance of read operation.
FieldReadOperation(String, String, EndPoint, List<String>) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldReadOperation
Create an instance of read operation.
FieldTransformOperation - Class in io.cdap.cdap.etl.api.lineage.field
Represent the transform operation from collection of input fields to collection of output fields.
FieldTransformOperation(String, String, List<String>, String...) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
Create the instance of a transform operation.
FieldTransformOperation(String, String, List<String>, List<String>) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
Create the instance of a transform operation.
FieldWriteOperation - Class in io.cdap.cdap.etl.api.lineage.field
Represents a write operation from a collection of input fields into a data sink.
FieldWriteOperation(String, String, EndPoint, String...) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
Create an instance of write operation.
FieldWriteOperation(String, String, EndPoint, List<String>) - Constructor for class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
Create an instance of write operation.
FORMAT_PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.BatchSink
 
FORMAT_PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.BatchSource
 
FormatContext - Class in io.cdap.cdap.etl.api.validation
Format context.
FormatContext(FailureCollector, Schema) - Constructor for class io.cdap.cdap.etl.api.validation.FormatContext
 

G

gauge(String, long) - Method in interface io.cdap.cdap.etl.api.StageMetrics
Sets the specific metric to the provided value.
get(String) - Method in interface io.cdap.cdap.etl.api.action.SettableArguments
Returns the value for the given argument name if it exist, otherwise null is returned.
get(String) - Method in interface io.cdap.cdap.etl.api.Arguments
Returns the value for the specified argument or null if none exists.
getArguments() - Method in interface io.cdap.cdap.etl.api.action.ActionContext
Returns settable pipeline arguments.
getArguments() - Method in interface io.cdap.cdap.etl.api.batch.BatchContext
Returns settable pipeline arguments.
getArguments() - Method in interface io.cdap.cdap.etl.api.condition.ConditionContext
Return the arguments which can be updated.
getArguments() - Method in interface io.cdap.cdap.etl.api.StageContext
Return the pipeline arguments for this run.
getArguments() - Method in interface io.cdap.cdap.etl.api.StageSubmitterContext
 
getAttribute(String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure.Cause
Returns value of the provided cause attribute.
getAttributes() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure.Cause
Returns all the attributes of the cause.
getCacheConfig() - Method in class io.cdap.cdap.etl.api.LookupTableConfig
 
getCauses() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Returns causes that caused this failure.
getContext() - Method in class io.cdap.cdap.etl.api.AlertPublisher
 
getContext() - Method in class io.cdap.cdap.etl.api.Transform
 
getCorrectiveAction() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Returns corrective action for this failure.
getDatasetProperties() - Method in class io.cdap.cdap.etl.api.LookupTableConfig
 
getDescription() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
getEngine() - Method in interface io.cdap.cdap.etl.api.MultiInputPipelineConfigurer
 
getEngine() - Method in interface io.cdap.cdap.etl.api.MultiOutputPipelineConfigurer
 
getEngine() - Method in interface io.cdap.cdap.etl.api.PipelineConfigurer
 
getErrorCode() - Method in interface io.cdap.cdap.etl.api.ErrorRecord
 
getErrorCode() - Method in class io.cdap.cdap.etl.api.InvalidEntry
 
getErrorMessage() - Method in interface io.cdap.cdap.etl.api.ErrorRecord
 
getErrorMsg() - Method in class io.cdap.cdap.etl.api.InvalidEntry
 
getErrorRecordsCount() - Method in interface io.cdap.cdap.etl.api.condition.StageStatistics
Get the number of error records generated by the stage.
getExpirySeconds() - Method in class io.cdap.cdap.etl.api.CacheConfig
 
getFailureCollector() - Method in interface io.cdap.cdap.etl.api.MultiInputStageConfigurer
Returns a failure collector for the stage.
getFailureCollector() - Method in interface io.cdap.cdap.etl.api.MultiOutputStageConfigurer
Returns a failure collector for the stage.
getFailureCollector() - Method in interface io.cdap.cdap.etl.api.StageConfigurer
Returns a failure collector for the stage.
getFailureCollector() - Method in interface io.cdap.cdap.etl.api.StageContext
Returns a failure collector for the stage.
getFailureCollector() - Method in class io.cdap.cdap.etl.api.validation.FormatContext
 
getFailures() - Method in exception io.cdap.cdap.etl.api.validation.ValidationException
Returns a list of validation failures.
getFullMessage() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Returns failure message along with corrective action.
getInputFields() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
 
getInputFields() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
 
getInputRecord() - Method in class io.cdap.cdap.etl.api.JoinElement
Returns input record which is part of join result
getInputRecordsCount() - Method in interface io.cdap.cdap.etl.api.condition.StageStatistics
Get the number of records given as an input to the stage.
getInputSchema() - Method in interface io.cdap.cdap.etl.api.MultiOutputStageConfigurer
Get the input schema for this stage, or null if its unknown
getInputSchema() - Method in interface io.cdap.cdap.etl.api.StageConfigurer
get the input schema for this stage, or null if its unknown
getInputSchema() - Method in interface io.cdap.cdap.etl.api.StageContext
Return the input schema for the stage.
getInputSchema() - Method in class io.cdap.cdap.etl.api.validation.FormatContext
 
getInputSchemas() - Method in interface io.cdap.cdap.etl.api.MultiInputStageConfigurer
get the map of input stageName to input schema for this stage, or return empty map if its unknown
getInputSchemas() - Method in interface io.cdap.cdap.etl.api.StageContext
Return the input schemas for the stage.
getInvalidRecord() - Method in class io.cdap.cdap.etl.api.InvalidEntry
 
getJoinConfig() - Method in interface io.cdap.cdap.etl.api.Joiner
Creates join configuration which holds information about required inputs which are needed to decide type of the join and produce join result.
getLogicalStartTime() - Method in interface io.cdap.cdap.etl.api.batch.BatchRuntimeContext
Returns the logical start time of the Batch Job.
getLogicalStartTime() - Method in interface io.cdap.cdap.etl.api.StageContext
Returns the logical start time of the batch.
getMaxSize() - Method in class io.cdap.cdap.etl.api.CacheConfig
 
getMessage() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Returns failure message.
getMetrics() - Method in interface io.cdap.cdap.etl.api.StageContext
Get an instance of StageMetrics, used to collect metrics for this stage.
getMultiInputStageConfigurer() - Method in interface io.cdap.cdap.etl.api.MultiInputPipelineConfigurer
Get multi input stage configurer for the pipeline stage
getMultiOutputStageConfigurer() - Method in interface io.cdap.cdap.etl.api.MultiOutputPipelineConfigurer
Get multi output stage configurer for the pipeline stage
getName() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
getNamespace() - Method in interface io.cdap.cdap.etl.api.StageContext
Gets the namespace of the pipeline.
getNodeStates() - Method in interface io.cdap.cdap.etl.api.batch.BatchActionContext
Return an immutable Map of node ids to WorkflowNodeState.
getOrThrowException() - Method in interface io.cdap.cdap.etl.api.FailureCollector
Throws validation exception if there are any failures that are added to the failure collector through FailureCollector.addFailure(String, String).
getOutputFields() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldReadOperation
Get the list of output fields generated by this read operation
getOutputFields() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
 
getOutputPortSchemas() - Method in interface io.cdap.cdap.etl.api.StageContext
Return the output port schemas for the stage.
getOutputRecordsCount() - Method in interface io.cdap.cdap.etl.api.condition.StageStatistics
Get the number of records generated by the stage.
getOutputSchema() - Method in interface io.cdap.cdap.etl.api.StageContext
Return the output schema of the stage, as set by this stage when the pipeline was deployed.
getPayload() - Method in class io.cdap.cdap.etl.api.Alert
 
getPipelineName() - Method in interface io.cdap.cdap.etl.api.StageContext
Gets the name of the pipeline.
getPluginProperties() - Method in interface io.cdap.cdap.etl.api.StageContext
Gets the PluginProperties associated with the stage.
getPluginProperties(String) - Method in interface io.cdap.cdap.etl.api.StageContext
Gets the PluginProperties associated with the given plugin id.
getProperty() - Method in exception io.cdap.cdap.etl.api.validation.InvalidConfigPropertyException
Deprecated.
 
getReasons() - Method in exception io.cdap.cdap.etl.api.validation.InvalidStageException
Deprecated.
 
getRecord() - Method in interface io.cdap.cdap.etl.api.ErrorRecord
 
getRequiredInputs() - Method in class io.cdap.cdap.etl.api.JoinConfig
Returns required inputs to be joined.
getSchema(FormatContext) - Method in interface io.cdap.cdap.etl.api.validation.ValidatingInputFormat
Gets validated schema.
getSink() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
 
getSource() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldReadOperation
 
getStageConfigurer() - Method in interface io.cdap.cdap.etl.api.PipelineConfigurer
Get stage configurer for the pipeline stage
getStageName() - Method in class io.cdap.cdap.etl.api.Alert
 
getStageName() - Method in interface io.cdap.cdap.etl.api.ErrorRecord
 
getStageName() - Method in class io.cdap.cdap.etl.api.JoinElement
Returns stage name to which input record belongs to
getStageName() - Method in interface io.cdap.cdap.etl.api.StageContext
Gets the unique stage name.
getStageStatistics() - Method in interface io.cdap.cdap.etl.api.condition.ConditionContext
Get a Map of stage name to the StageStatistics.
getTable(String) - Method in class io.cdap.cdap.etl.api.LookupConfig
 
getToken() - Method in interface io.cdap.cdap.etl.api.batch.BatchActionContext
 
getType() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
getType() - Method in class io.cdap.cdap.etl.api.LookupTableConfig
 
getValidationFailures() - Method in interface io.cdap.cdap.etl.api.FailureCollector
Get list of validation failures.
getValidator() - Method in interface io.cdap.cdap.etl.api.Validator
Gets the Validator Object, on which the validator function's can be invoked from user-code.
getValidatorName() - Method in interface io.cdap.cdap.etl.api.Validator
Name used as variable name for the Object returned by Validator.getValidator().
groupBy(GROUP_VALUE, Emitter<GROUP_KEY>) - Method in interface io.cdap.cdap.etl.api.Aggregator
Emit the group key(s) for a given input value.

H

has(String) - Method in interface io.cdap.cdap.etl.api.action.SettableArguments
Returns true if specified argument is provided, otherwise false is returned.
has(String) - Method in interface io.cdap.cdap.etl.api.Arguments
Returns true if the specified argument exists and false if not.
hashCode() - Method in class io.cdap.cdap.etl.api.Alert
 
hashCode() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
hashCode() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldReadOperation
 
hashCode() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
 
hashCode() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
 
hashCode() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure.Cause
 
hashCode() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
 

I

initialize(AlertPublisherContext) - Method in class io.cdap.cdap.etl.api.AlertPublisher
 
initialize(BatchRuntimeContext) - Method in class io.cdap.cdap.etl.api.batch.BatchAggregator
Initialize the Batch Aggregator.
initialize(BatchJoinerRuntimeContext) - Method in class io.cdap.cdap.etl.api.batch.BatchJoiner
Initialize the Batch Joiner.
initialize(BatchRuntimeContext) - Method in class io.cdap.cdap.etl.api.batch.BatchSink
Initialize the Batch Sink stage.
initialize(BatchRuntimeContext) - Method in class io.cdap.cdap.etl.api.batch.BatchSource
Initialize the Batch Source stage.
initialize(TransformContext) - Method in class io.cdap.cdap.etl.api.SplitterTransform
 
initialize(T) - Method in interface io.cdap.cdap.etl.api.StageLifecycle
Initialize the Stage.
initialize(TransformContext) - Method in class io.cdap.cdap.etl.api.Transform
Initialize the Transform Stage.
INPUT_SCHEMA_FIELD - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
INPUT_STAGE - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
InvalidConfigPropertyException - Exception in io.cdap.cdap.etl.api.validation
Deprecated.
InvalidConfigPropertyException(String, String) - Constructor for exception io.cdap.cdap.etl.api.validation.InvalidConfigPropertyException
Deprecated.
 
InvalidConfigPropertyException(String, Throwable, String) - Constructor for exception io.cdap.cdap.etl.api.validation.InvalidConfigPropertyException
Deprecated.
 
InvalidEntry<T> - Class in io.cdap.cdap.etl.api
Represents a record that fails validation, with provided errorCode and errorMessage
InvalidEntry(int, String, T) - Constructor for class io.cdap.cdap.etl.api.InvalidEntry
 
InvalidStageException - Exception in io.cdap.cdap.etl.api.validation
Deprecated.
InvalidStageException(String) - Constructor for exception io.cdap.cdap.etl.api.validation.InvalidStageException
Deprecated.
Used when there is a single reason that the pipeline stage is invalid.
InvalidStageException(String, Throwable) - Constructor for exception io.cdap.cdap.etl.api.validation.InvalidStageException
Deprecated.
 
InvalidStageException(List<? extends InvalidStageException>) - Constructor for exception io.cdap.cdap.etl.api.validation.InvalidStageException
Deprecated.
Used when there are multiple reasons that the pipeline stage is invalid.
io.cdap.cdap.etl.api - package io.cdap.cdap.etl.api
Packages for ETL Application Templates.
io.cdap.cdap.etl.api.action - package io.cdap.cdap.etl.api.action
 
io.cdap.cdap.etl.api.batch - package io.cdap.cdap.etl.api.batch
Packages for ETL Application Templates.
io.cdap.cdap.etl.api.condition - package io.cdap.cdap.etl.api.condition
 
io.cdap.cdap.etl.api.lineage - package io.cdap.cdap.etl.api.lineage
 
io.cdap.cdap.etl.api.lineage.field - package io.cdap.cdap.etl.api.lineage.field
 
io.cdap.cdap.etl.api.lookup - package io.cdap.cdap.etl.api.lookup
Packages for ETL Application Templates.
io.cdap.cdap.etl.api.validation - package io.cdap.cdap.etl.api.validation
 
isCacheEnabled() - Method in class io.cdap.cdap.etl.api.LookupTableConfig
 
isPreviewEnabled() - Method in interface io.cdap.cdap.etl.api.batch.BatchSinkContext
Indicates whether the pipeline is running in preview.
isPreviewEnabled() - Method in interface io.cdap.cdap.etl.api.batch.BatchSourceContext
Indicates whether the pipeline is running in preview.
isSuccessful() - Method in interface io.cdap.cdap.etl.api.batch.BatchActionContext
Return true if the execution was successful, false otherwise.

J

JoinConfig - Class in io.cdap.cdap.etl.api
Join configuration to hold information about join to be performed
JoinConfig(Iterable<String>) - Constructor for class io.cdap.cdap.etl.api.JoinConfig
Creates new instance of JoinConfig
JoinElement<INPUT_RECORD> - Class in io.cdap.cdap.etl.api
Join element to hold join record per stage
JoinElement(String, INPUT_RECORD) - Constructor for class io.cdap.cdap.etl.api.JoinElement
 
Joiner<JOIN_KEY,INPUT_RECORD,OUT> - Interface in io.cdap.cdap.etl.api
Provides join keys on which join needs to be performed and merges the join results.
joinOn(String, INPUT_RECORD) - Method in interface io.cdap.cdap.etl.api.Joiner
Return value for the join key on which join will be performed

K

KeyValueTableLookup - Class in io.cdap.cdap.etl.api.lookup
Lookup implementation for KeyValueTable.
KeyValueTableLookup(KeyValueTable) - Constructor for class io.cdap.cdap.etl.api.lookup.KeyValueTableLookup
 

L

LineageRecorder - Interface in io.cdap.cdap.etl.api.lineage.field
Interface for recording field lineage information from plugins.
loadPluginClass(String) - Method in interface io.cdap.cdap.etl.api.StageContext
Loads and returns a plugin class as specified by the given plugin id.
Lookup<T> - Interface in io.cdap.cdap.etl.api
Exposes read-only lookup operations on datasets.
lookup(String) - Method in class io.cdap.cdap.etl.api.lookup.KeyValueTableLookup
 
lookup(String...) - Method in class io.cdap.cdap.etl.api.lookup.KeyValueTableLookup
 
lookup(Set<String>) - Method in class io.cdap.cdap.etl.api.lookup.KeyValueTableLookup
 
lookup(String) - Method in interface io.cdap.cdap.etl.api.Lookup
Performs a single lookup.
lookup(String...) - Method in interface io.cdap.cdap.etl.api.Lookup
Performs a batch lookup.
lookup(Set<String>) - Method in interface io.cdap.cdap.etl.api.Lookup
Performs a batch lookup.
lookup(String) - Method in class io.cdap.cdap.etl.api.lookup.TableLookup
 
lookup(String...) - Method in class io.cdap.cdap.etl.api.lookup.TableLookup
 
lookup(Set<String>) - Method in class io.cdap.cdap.etl.api.lookup.TableLookup
 
LookupConfig - Class in io.cdap.cdap.etl.api
Configuration for an ETL stage using Lookup.
LookupConfig(Map<String, LookupTableConfig>) - Constructor for class io.cdap.cdap.etl.api.LookupConfig
 
LookupProvider - Interface in io.cdap.cdap.etl.api
Provides Lookup instances given a dataset name.
LookupTableConfig - Class in io.cdap.cdap.etl.api
Configuration for a particular Lookup table.
LookupTableConfig(LookupTableConfig.TableType, CacheConfig, Map<String, String>, boolean) - Constructor for class io.cdap.cdap.etl.api.LookupTableConfig
 
LookupTableConfig(LookupTableConfig.TableType) - Constructor for class io.cdap.cdap.etl.api.LookupTableConfig
 
LookupTableConfig.TableType - Enum in io.cdap.cdap.etl.api
Type of lookup table.

M

merge(JOIN_KEY, Iterable<JoinElement<INPUT_RECORD>>) - Method in interface io.cdap.cdap.etl.api.Joiner
Merges records present in joinResult and returns merged output.
MultiInputBatchConfigurable<T extends BatchContext> - Class in io.cdap.cdap.etl.api.batch
Base class for multi input Batch run configuration methods.
MultiInputBatchConfigurable() - Constructor for class io.cdap.cdap.etl.api.batch.MultiInputBatchConfigurable
 
MultiInputPipelineConfigurable - Interface in io.cdap.cdap.etl.api
Allows the stage with multiple inputs to configure pipeline.
MultiInputPipelineConfigurer - Interface in io.cdap.cdap.etl.api
Configures an ETL Pipeline.
MultiInputStageConfigurer - Interface in io.cdap.cdap.etl.api
This stores the input schemas that are passed to this stage from other stages in the pipeline and the output schema that could be sent to the next stages from this stage.
MultiOutputEmitter<T> - Interface in io.cdap.cdap.etl.api
Used to emit one or more key-value pairs to output ports.
MultiOutputPipelineConfigurable - Interface in io.cdap.cdap.etl.api
Allows a stage with multiple outputs to configure the pipeline.
MultiOutputPipelineConfigurer - Interface in io.cdap.cdap.etl.api
Configures a Pipeline.
MultiOutputStageConfigurer - Interface in io.cdap.cdap.etl.api
This stores the input schemas that are passed to this stage from other stages in the pipeline and the output schema that could be sent to the next stages from this stage.
MultiOutputTransformation<IN,E> - Interface in io.cdap.cdap.etl.api
Transforms an input object into zero or more output objects, emitted to specific output ports.

N

newPluginInstance(String) - Method in interface io.cdap.cdap.etl.api.StageContext
Creates a new instance of a plugin.

O

onRunFinish(boolean, T) - Method in class io.cdap.cdap.etl.api.batch.BatchConfigurable
Invoked after the Batch run finishes.
onRunFinish(boolean, T) - Method in class io.cdap.cdap.etl.api.batch.MultiInputBatchConfigurable
Invoked after the Batch run finishes.
onRunFinish(boolean, StageSubmitterContext) - Method in class io.cdap.cdap.etl.api.SplitterTransform
 
onRunFinish(boolean, T) - Method in interface io.cdap.cdap.etl.api.SubmitterLifecycle
Invoked after the run finishes.
onRunFinish(boolean, StageSubmitterContext) - Method in class io.cdap.cdap.etl.api.Transform
 
OperationType - Enum in io.cdap.cdap.etl.api.lineage.field
Represents operation types.
OUTPUT_PORT - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
OUTPUT_SCHEMA_FIELD - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 

P

PipelineConfigurable - Interface in io.cdap.cdap.etl.api
Allows the stage to configure pipeline.
PipelineConfigurer - Interface in io.cdap.cdap.etl.api
Configures an ETL Pipeline.
pipelineCount(String, int) - Method in interface io.cdap.cdap.etl.api.StageMetrics
Increases the value of the specific metric by delta.
pipelineGauge(String, long) - Method in interface io.cdap.cdap.etl.api.StageMetrics
Sets the specific metric to the provided value.
PLUGIN_ID - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
PLUGIN_NAME - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.action.Action
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.AlertPublisher
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.BatchAggregator
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.BatchJoiner
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.BatchSink
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.BatchSource
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.batch.PostAction
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.condition.Condition
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.ErrorTransform
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.SplitterTransform
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.Transform
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
PLUGIN_TYPE - Static variable in interface io.cdap.cdap.etl.api.validation.ValidatingInputFormat
 
PLUGIN_TYPE - Static variable in interface io.cdap.cdap.etl.api.validation.ValidatingOutputFormat
 
PostAction - Class in io.cdap.cdap.etl.api.batch
Defines some logic that runs at the end of a workflow run.
PostAction() - Constructor for class io.cdap.cdap.etl.api.batch.PostAction
 
prepareRun(BatchAggregatorContext) - Method in class io.cdap.cdap.etl.api.batch.BatchAggregator
Prepare a pipeline run.
prepareRun(T) - Method in class io.cdap.cdap.etl.api.batch.BatchConfigurable
Prepare the Batch run.
prepareRun(BatchJoinerContext) - Method in class io.cdap.cdap.etl.api.batch.BatchJoiner
Prepare a pipeline run.
prepareRun(T) - Method in class io.cdap.cdap.etl.api.batch.MultiInputBatchConfigurable
Prepare the Batch run.
prepareRun(StageSubmitterContext) - Method in class io.cdap.cdap.etl.api.SplitterTransform
 
prepareRun(T) - Method in interface io.cdap.cdap.etl.api.SubmitterLifecycle
Prepare the run.
prepareRun(StageSubmitterContext) - Method in class io.cdap.cdap.etl.api.Transform
 
provide(String, Map<String, String>) - Method in interface io.cdap.cdap.etl.api.LookupProvider
 
publish(Iterator<Alert>) - Method in class io.cdap.cdap.etl.api.AlertPublisher
Publish a collection of alerts.

R

record(List<FieldOperation>) - Method in interface io.cdap.cdap.etl.api.action.ActionContext
Deprecated.
use LineageRecorder.record(Collection) to emit field operations for actions, that method requires the input field to contain the previous originated operation name. Using that DAG can be computed so the field linage can be computed.
record(List<FieldOperation>) - Method in interface io.cdap.cdap.etl.api.lineage.field.LineageRecorder
Record specified operations for the lineage purpose.
registerLineage(String, AccessType) - Method in interface io.cdap.cdap.etl.api.action.ActionContext
Register lineage for this Spark program using the given reference name
REQUESTED_ARTIFACT_NAME - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
REQUESTED_ARTIFACT_SCOPE - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
REQUESTED_ARTIFACT_VERSION - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
run(ActionContext) - Method in class io.cdap.cdap.etl.api.action.Action
Implement this method to execute the code as a part of action run.
run(BatchActionContext) - Method in class io.cdap.cdap.etl.api.batch.PostAction
Run the action.

S

set(String, String) - Method in interface io.cdap.cdap.etl.api.action.SettableArguments
Sets the name and value as specified by the input parameters.
setErrorSchema(Schema) - Method in interface io.cdap.cdap.etl.api.StageConfigurer
set the error schema for this stage, or null if its unknown.
setGroupKeyClass(Class<?>) - Method in interface io.cdap.cdap.etl.api.batch.BatchAggregatorContext
Set the group key class.
setGroupValueClass(Class<?>) - Method in interface io.cdap.cdap.etl.api.batch.BatchAggregatorContext
Set the group value class.
setInput(Input) - Method in interface io.cdap.cdap.etl.api.batch.BatchSourceContext
Overrides the input configuration of this Batch job to the specified Input.
setJoinInputRecordClass(Class<?>) - Method in interface io.cdap.cdap.etl.api.batch.BatchJoinerContext
Set the join input record class.
setJoinKeyClass(Class<?>) - Method in interface io.cdap.cdap.etl.api.batch.BatchJoinerContext
Set the join key class.
setNumPartitions(int) - Method in interface io.cdap.cdap.etl.api.batch.BatchAggregatorContext
Set the number of partitions to use to group values.
setNumPartitions(int) - Method in interface io.cdap.cdap.etl.api.batch.BatchJoinerContext
Set the number of partitions to use to join values.
setOutputSchema(Schema) - Method in interface io.cdap.cdap.etl.api.MultiInputStageConfigurer
set output schema for this stage, or null if its unknown
setOutputSchema(Schema) - Method in interface io.cdap.cdap.etl.api.StageConfigurer
set the output schema for this stage, or null if its unknown
setOutputSchemas(Map<String, Schema>) - Method in interface io.cdap.cdap.etl.api.MultiOutputStageConfigurer
Set schema for each output port.
setPipelineProperties(Map<String, String>) - Method in interface io.cdap.cdap.etl.api.MultiInputPipelineConfigurer
Set pipeline properties that will be applied to each run of the pipeline.
setPipelineProperties(Map<String, String>) - Method in interface io.cdap.cdap.etl.api.MultiOutputPipelineConfigurer
Set pipeline properties that will be applied to each run of the pipeline.
setPipelineProperties(Map<String, String>) - Method in interface io.cdap.cdap.etl.api.PipelineConfigurer
Set pipeline properties that will be applied to each run of the pipeline.
SettableArguments - Interface in io.cdap.cdap.etl.api.action
Arguments that can be updated.
SplitterTransform<T,E> - Class in io.cdap.cdap.etl.api
A Transform that can split its input among multiple output ports.
SplitterTransform() - Constructor for class io.cdap.cdap.etl.api.SplitterTransform
 
STACKTRACE - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
STAGE_CONFIG - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
StageConfigurer - Interface in io.cdap.cdap.etl.api
This stores the input schema that is passed to this stage from other stages in the pipeline and the output schema that could be sent to the next stages from this stage.
StageContext - Interface in io.cdap.cdap.etl.api
Context for a pipeline stage, providing access to information about the stage, metrics, and plugins.
StageLifecycle<T> - Interface in io.cdap.cdap.etl.api
Interface for stage that supports initialize call for resource setup.
StageMetrics - Interface in io.cdap.cdap.etl.api
The interface exposes method for emitting user metrics from ETL stage.
StageStatistics - Interface in io.cdap.cdap.etl.api.condition
Represents statistics associated with the each stage in the pipeline.
StageSubmitterContext - Interface in io.cdap.cdap.etl.api
Similar to TransformContext, but also exposing functionality of MessagingContext.
SubmitterLifecycle<T> - Interface in io.cdap.cdap.etl.api
Interface for stage that supports initialize call for resource setup.
SUGGESTED_ARTIFACT_NAME - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
SUGGESTED_ARTIFACT_SCOPE - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 
SUGGESTED_ARTIFACT_VERSION - Static variable in class io.cdap.cdap.etl.api.validation.CauseAttributes
 

T

TableLookup - Class in io.cdap.cdap.etl.api.lookup
Lookup implementation for Table.
TableLookup(Table) - Constructor for class io.cdap.cdap.etl.api.lookup.TableLookup
 
toString() - Method in class io.cdap.cdap.etl.api.Alert
 
transform(IN, Emitter<KeyValue<KEY_OUT, VAL_OUT>>) - Method in class io.cdap.cdap.etl.api.batch.BatchSink
Transform the input received from previous stage to a KeyValue pair which can be consumed by the output, as set in BatchConfigurable.prepareRun(T).
transform(KeyValue<KEY_IN, VAL_IN>, Emitter<OUT>) - Method in class io.cdap.cdap.etl.api.batch.BatchSource
Transform the KeyValue pair produced by the input, as set in BatchConfigurable.prepareRun(T), to a single object and emit it to the next stage.
transform(IN, MultiOutputEmitter<E>) - Method in interface io.cdap.cdap.etl.api.MultiOutputTransformation
Transform the input and emit output using MultiOutputEmitter.
Transform<IN,OUT> - Class in io.cdap.cdap.etl.api
Transform Stage.
Transform() - Constructor for class io.cdap.cdap.etl.api.Transform
 
transform(IN, Emitter<OUT>) - Method in interface io.cdap.cdap.etl.api.Transformation
Transform the input and emit output using Emitter.
Transformation<IN,OUT> - Interface in io.cdap.cdap.etl.api
Transforms an input object into zero or more output objects.
TransformContext - Interface in io.cdap.cdap.etl.api
Context passed to ETL Transform stages.

V

validate(FormatContext) - Method in interface io.cdap.cdap.etl.api.validation.ValidatingInputFormat
Validates configurations of input format.
validate(FormatContext) - Method in interface io.cdap.cdap.etl.api.validation.ValidatingOutputFormat
Validates configurations of output format.
ValidatingInputFormat - Interface in io.cdap.cdap.etl.api.validation
Validating input format provider.
ValidatingOutputFormat - Interface in io.cdap.cdap.etl.api.validation
Validating output format provider.
ValidationException - Exception in io.cdap.cdap.etl.api.validation
Validation exception that carries multiple validation failures.
ValidationException(List<ValidationFailure>) - Constructor for exception io.cdap.cdap.etl.api.validation.ValidationException
Creates a validation exception with list of failures.
ValidationFailure - Class in io.cdap.cdap.etl.api.validation
Represents a failure condition occurred during validation.
ValidationFailure(String) - Constructor for class io.cdap.cdap.etl.api.validation.ValidationFailure
Creates a validation failure with provided message.
ValidationFailure(String, String) - Constructor for class io.cdap.cdap.etl.api.validation.ValidationFailure
Creates a validation failure with provided message and corrective action.
ValidationFailure(String, String, String, Map<String, Schema>) - Constructor for class io.cdap.cdap.etl.api.validation.ValidationFailure
Creates a validation failure with provided message and corrective action.
ValidationFailure.Cause - Class in io.cdap.cdap.etl.api.validation
Represents a cause of a failure.
Validator - Interface in io.cdap.cdap.etl.api
Utility for obtaining an object which implements a set of validator functions; this object is usually assigned to a variable specified by the Validator.getValidatorName() value.
valueOf(String) - Static method in enum io.cdap.cdap.etl.api.Engine
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.cdap.cdap.etl.api.lineage.AccessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.cdap.cdap.etl.api.lineage.field.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.cdap.cdap.etl.api.LookupTableConfig.TableType
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.cdap.cdap.etl.api.Engine
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.cdap.cdap.etl.api.lineage.AccessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.cdap.cdap.etl.api.lineage.field.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.cdap.cdap.etl.api.LookupTableConfig.TableType
Returns an array containing the constants of this enum type, in the order they are declared.

W

withCause(ValidationFailure.Cause) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds provided cause to this validation failure.
withConfigElement(String, String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes for failure cause that represents an invalid element in the list associated with given stage configure property.
withConfigProperty(String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents invalid stage configure property failure cause.
withInputSchemaField(String, String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents invalid input schema field failure cause.
withInputSchemaField(String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents invalid input schema field failure cause.
withOutputSchemaField(String, String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents invalid output schema field failure cause.
withOutputSchemaField(String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents invalid output schema field failure cause.
withPluginNotFound(String, String, String) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents plugin not found failure cause.
withPluginNotFound(String, String, String, ArtifactId, ArtifactId) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents plugin not found failure cause.
withStacktrace(StackTraceElement[]) - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Adds cause attributes that represents a stacktrace.
A B C D E F G H I J K L M N O P R S T V W 
Skip navigation links

Copyright © 2020 Cask Data, Inc. Licensed under the Apache License, Version 2.0.