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.
addDatasetAlias(String, String) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression.Builder
 
addEntities(List<BrowseEntity>) - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
addEntity(BrowseEntity) - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
addFailure(String, String) - Method in interface io.cdap.cdap.etl.api.FailureCollector
Add a validation failure to this failure collector.
addKey(JoinKey) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys.Builder
 
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.
addProperties(Map<String, String>) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
addProperty(String, BrowseEntityPropertyValue) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
addProperty(String, String) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
addRelatedPlugin(PluginSpec) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec.Builder
 
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.
AutoJoiner - Interface in io.cdap.cdap.etl.api.join
Joins data from two or more input stages together.
AutoJoinerContext - Interface in io.cdap.cdap.etl.api.join
Context for an AutoJoin.

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.
BatchAutoJoiner - Class in io.cdap.cdap.etl.api.batch
Joins input data, leaving implementation details up to the application.
BatchAutoJoiner() - Constructor for class io.cdap.cdap.etl.api.batch.BatchAutoJoiner
 
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
 
BatchConnector<KEY_IN,VAL_IN> - Interface in io.cdap.cdap.etl.api.batch
Batch connector that relies on the InputFormatProvider to read from the resources
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
BatchReducibleAggregator<GROUP_KEY,GROUP_VALUE,AGG_VALUE,OUT> - Class in io.cdap.cdap.etl.api.batch
A ReducibleAggregator used in batch programs.
BatchReducibleAggregator() - Constructor for class io.cdap.cdap.etl.api.batch.BatchReducibleAggregator
 
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.
BatchSQLEngine<KEY_IN,VALUE_IN,KEY_OUT,VALUE_OUT> - Class in io.cdap.cdap.etl.api.engine.sql
Base implementation for the SQLEngine interface.
BatchSQLEngine() - Constructor for class io.cdap.cdap.etl.api.engine.sql.BatchSQLEngine
 
BroadcastError - Class in io.cdap.cdap.etl.api.join.error
An error with the broadcast settings for join
BroadcastError(String) - Constructor for class io.cdap.cdap.etl.api.join.error.BroadcastError
 
BroadcastError(String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.BroadcastError
 
browse(ConnectorContext, BrowseRequest) - Method in interface io.cdap.cdap.etl.api.connector.Connector
Browse the resources on the given request.
BrowseDetail - Class in io.cdap.cdap.etl.api.connector
The browse result for the given request.
BrowseDetail.Builder - Class in io.cdap.cdap.etl.api.connector
Builder for BrowseDetail
BrowseEntity - Class in io.cdap.cdap.etl.api.connector
An entity that is browsable or samplable, or both.
BrowseEntity.Builder - Class in io.cdap.cdap.etl.api.connector
Builder for BrowseEntity
BrowseEntityPropertyValue - Class in io.cdap.cdap.etl.api.connector
Object that represents an explore entity property.
BrowseEntityPropertyValue.Builder - Class in io.cdap.cdap.etl.api.connector
BrowseEntityPropertyValue.PropertyType - Enum in io.cdap.cdap.etl.api.connector
The property type for the browse entity property
BrowseEntityTypeInfo - Class in io.cdap.cdap.etl.api.connector
The browse entity type information, containing the sampling properties expected from the type
BrowseEntityTypeInfo(String, Collection<SamplePropertyField>) - Constructor for class io.cdap.cdap.etl.api.connector.BrowseEntityTypeInfo
 
BrowseRequest - Class in io.cdap.cdap.etl.api.connector
Request used for browse operations
BrowseRequest.Builder - Class in io.cdap.cdap.etl.api.connector
Builder for BrowseRequest
build() - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.SampleDetail.Builder
 
build() - Method in class io.cdap.cdap.etl.api.connector.SampleRequest.Builder
 
build() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression.Builder
 
build() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys.Builder
 
build() - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
build() - Method in class io.cdap.cdap.etl.api.join.JoinStage.Builder
 
builder() - Static method in class io.cdap.cdap.etl.api.connector.BrowseDetail
Get the builder to build this object
Builder() - Constructor for class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
builder(String, String, String) - Static method in class io.cdap.cdap.etl.api.connector.BrowseEntity
Get the builder to build this object
Builder(String, String, String) - Constructor for class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
builder(String, BrowseEntityPropertyValue.PropertyType) - Static method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue
Get the builder to build this object
Builder(String, BrowseEntityPropertyValue.PropertyType) - Constructor for class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue.Builder
 
builder(String) - Static method in class io.cdap.cdap.etl.api.connector.BrowseRequest
Get the builder to build this object
Builder(String) - Constructor for class io.cdap.cdap.etl.api.connector.BrowseRequest.Builder
 
builder() - Static method in class io.cdap.cdap.etl.api.connector.ConnectorSpec
Get the builder to build this object
Builder() - Constructor for class io.cdap.cdap.etl.api.connector.ConnectorSpec.Builder
 
builder() - Static method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest
Get the builder to build this object
Builder() - Constructor for class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
builder() - Static method in class io.cdap.cdap.etl.api.connector.SampleDetail
Get the builder to build this object
Builder() - Constructor for class io.cdap.cdap.etl.api.connector.SampleDetail.Builder
 
builder(int) - Static method in class io.cdap.cdap.etl.api.connector.SampleRequest
Get the builder to build this object
Builder(int) - Constructor for class io.cdap.cdap.etl.api.connector.SampleRequest.Builder
 
builder() - Static method in class io.cdap.cdap.etl.api.join.JoinDefinition
 
builder(String, Schema) - Static method in class io.cdap.cdap.etl.api.join.JoinStage
 
builder(JoinStage) - Static method in class io.cdap.cdap.etl.api.join.JoinStage
 

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
 
canBrowse(boolean) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
canBrowse() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
canJoin(SQLJoinDefinition) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
Check if the supplied Join Definition can be executed in this engine.
canSample(boolean) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
canSample() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
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
 
cleanup(String) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
Deletes all temporary datasets and cleans up all temporary data from the SQL engine.
close() - Method in interface io.cdap.cdap.etl.api.connector.Connector
 
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
 
configure(ConnectorConfigurer) - Method in interface io.cdap.cdap.etl.api.connector.Connector
Configure this connector, for example, the database connector will need to load the jdbc driver.
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(MultiInputPipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.BatchAutoJoiner
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(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.batch.BatchReducibleAggregator
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(PipelineConfigurer) - Method in class io.cdap.cdap.etl.api.engine.sql.BatchSQLEngine
 
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.
Connector - Interface in io.cdap.cdap.etl.api.connector
A connector is a plugin which is able to explore and sample an external resource
ConnectorConfigurer - Interface in io.cdap.cdap.etl.api.connector
Configurer for a connector
ConnectorContext - Interface in io.cdap.cdap.etl.api.connector
Context for a connector used in each method
ConnectorSpec - Class in io.cdap.cdap.etl.api.connector
The connector spec contains all the properties based on the path and plugin config
ConnectorSpec.Builder - Class in io.cdap.cdap.etl.api.connector
Builder for ConnectorSpec
ConnectorSpecRequest - Class in io.cdap.cdap.etl.api.connector
Request for spec generation
ConnectorSpecRequest.Builder - Class in io.cdap.cdap.etl.api.connector
count(String, int) - Method in interface io.cdap.cdap.etl.api.StageMetrics
Increases the value of the specific metric by delta.
countLong(String, long) - 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.
datasetName - Variable in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
 
datasetSchema - Variable in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
 
define(AutoJoinerContext) - Method in interface io.cdap.cdap.etl.api.join.AutoJoiner
 
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.BatchReducibleAggregator
Destroy the Batch Aggregator.
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.
DirectConnector - Interface in io.cdap.cdap.etl.api.connector
Connector that directly reads from the resources.
DistributionSizeError - Class in io.cdap.cdap.etl.api.join.error
An error with the distribution size
DistributionSizeError(String) - Constructor for class io.cdap.cdap.etl.api.join.error.DistributionSizeError
 
DistributionSizeError(String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.DistributionSizeError
 
DistributionStageError - Class in io.cdap.cdap.etl.api.join.error
An error with the distribution skewed staged
DistributionStageError(String) - Constructor for class io.cdap.cdap.etl.api.join.error.DistributionStageError
 
DistributionStageError(String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.DistributionStageError
 

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.connector.BrowseDetail
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityTypeInfo
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.PluginSpec
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.SampleDetail
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.SamplePropertyField
 
equals(Object) - Method in class io.cdap.cdap.etl.api.connector.SampleRequest
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.error.JoinError
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.error.JoinKeyError
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.error.JoinKeyFieldError
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.error.OutputSchemaError
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.error.SelectedFieldError
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.JoinField
 
equals(Object) - Method in class io.cdap.cdap.etl.api.join.JoinKey
 
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
 
exists(String) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
Check if this dataset exists in the SQL Engine.
ExpressionConditionError - Class in io.cdap.cdap.etl.api.join.error
Some error with the join expression condition.
ExpressionConditionError(String) - Constructor for class io.cdap.cdap.etl.api.join.error.ExpressionConditionError
 
ExpressionConditionError(String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.ExpressionConditionError
 

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.
finalize(GROUP_KEY, AGG_VALUE, Emitter<OUT>) - Method in interface io.cdap.cdap.etl.api.ReducibleAggregator
Finalize the grouped object for the group key into zero or more output objects.
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
 
from(Collection<JoinStage>) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
from(JoinStage...) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
fromKeyValue() - Method in interface io.cdap.cdap.etl.api.FromKeyValueTransform
 
FromKeyValueTransform<TYPE,KEY_IN,VALUE_IN> - Interface in io.cdap.cdap.etl.api
Interface for an entity which allows the transformation between an object of a given Type from a KeyValue pair.

G

gauge(String, long) - Method in interface io.cdap.cdap.etl.api.StageMetrics
Sets the specific metric to the provided value.
generateSpec(ConnectorContext, ConnectorSpecRequest) - Method in interface io.cdap.cdap.etl.api.connector.Connector
Generate spec based on the given path, the spec should contain all the properties associated with the path.
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.
getAlias() - Method in class io.cdap.cdap.etl.api.join.JoinField
 
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.
getCondition() - Method in class io.cdap.cdap.etl.api.join.JoinDefinition
 
getConnectionWithMacro() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest
 
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.join.error.JoinError
 
getCorrectiveAction() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Returns corrective action for this failure.
getDatasetAliases() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression
 
getDatasetName() - Method in interface io.cdap.cdap.etl.api.engine.sql.dataset.SQLDataset
Get the name of this dataset.
getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
Get the name of the dataset which contains the result of this operation.
getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLPullRequest
Get the name of the dataset that is getting pulled from the engine.
getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLPushRequest
Get the name of the dataset that is getting pushed to the engine.
getDatasetProperties() - Method in class io.cdap.cdap.etl.api.LookupTableConfig
 
getDatasetSchema() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
Get the schema for the result of this join operation.
getDatasetSchema() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLPullRequest
Get the schema for the records that are getting pulled from the engine.
getDatasetSchema() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLPushRequest
Get the name of the records that are getting pushed to the engine.
getDescription() - Method in class io.cdap.cdap.etl.api.connector.SamplePropertyField
 
getDescription() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldOperation
 
getDistribution() - Method in class io.cdap.cdap.etl.api.join.JoinDefinition
 
getDistributionFactor() - Method in class io.cdap.cdap.etl.api.join.JoinDistribution
 
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
 
getEntities() - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail
 
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.
getErrors() - Method in exception io.cdap.cdap.etl.api.join.InvalidJoinException
 
getExpectedType() - Method in class io.cdap.cdap.etl.api.join.error.OutputSchemaError
 
getExpirySeconds() - Method in class io.cdap.cdap.etl.api.CacheConfig
 
getExpression() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression
 
getFailureCollector() - Method in interface io.cdap.cdap.etl.api.connector.ConnectorContext
Returns a failure collector.
getFailureCollector() - Method in interface io.cdap.cdap.etl.api.join.AutoJoinerContext
 
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.
getField() - Method in class io.cdap.cdap.etl.api.join.error.OutputSchemaError
 
getField() - Method in class io.cdap.cdap.etl.api.join.error.SelectedFieldError
 
getFieldName() - Method in class io.cdap.cdap.etl.api.join.JoinField
 
getFields() - Method in class io.cdap.cdap.etl.api.join.JoinKey
 
getFullMessage() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
Returns failure message along with corrective action.
getInputDatasets() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinRequest
Get the datasets involved in this join operation.
getInputFields() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldTransformOperation
 
getInputFields() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
 
getInputFormatProvider(ConnectorContext, SampleRequest) - Method in interface io.cdap.cdap.etl.api.batch.BatchConnector
Return the input format this connector will use to do the sampling
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.
getInputStages() - Method in interface io.cdap.cdap.etl.api.join.AutoJoinerContext
 
getInputStages() - Method in interface io.cdap.cdap.etl.api.MultiInputStageConfigurer
get a list of input stage names.
getInputStages() - Method in interface io.cdap.cdap.etl.api.StageContext
Return the input stage names.
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.
getJoinDefinition() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
Get the join definition for this request.
getJoinKeys(String, INPUT_RECORD) - Method in interface io.cdap.cdap.etl.api.Joiner
Return value for the join keys on which join will be performed
getKey() - Method in class io.cdap.cdap.etl.api.join.error.JoinKeyError
 
getKeyField() - Method in class io.cdap.cdap.etl.api.join.error.JoinKeyFieldError
 
getKeys() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys
 
getLimit() - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest
Return the max number of results to retrieve, if null or less than or equal to 0, the connector will fetch all the results
getLimit() - Method in class io.cdap.cdap.etl.api.connector.SampleRequest
 
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.
getMaxPreviewRecords() - Method in interface io.cdap.cdap.etl.api.batch.BatchSourceContext
 
getMaxSize() - Method in class io.cdap.cdap.etl.api.CacheConfig
 
getMessage() - Method in class io.cdap.cdap.etl.api.join.error.JoinError
 
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.connector.BrowseEntity
 
getName() - Method in class io.cdap.cdap.etl.api.connector.PluginSpec
 
getName() - Method in class io.cdap.cdap.etl.api.connector.SamplePropertyField
 
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.
getNumRows() - Method in interface io.cdap.cdap.etl.api.engine.sql.dataset.SQLDataset
Get the number of rows stored in this dataset.
getOp() - Method in class io.cdap.cdap.etl.api.join.JoinCondition
 
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 class io.cdap.cdap.etl.api.join.JoinDefinition
 
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.
getPath() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
getPath() - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest
 
getPath() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest
Get the entity path for request, if the path is null, that means the properties contains all the path related configs
getPath() - Method in class io.cdap.cdap.etl.api.connector.SampleRequest
Get the entity path for the sample request, if the path is null, that means the properties contains all the path related configs required for the sampling
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.
getPluginConfigurer() - Method in interface io.cdap.cdap.etl.api.connector.ConnectorContext
Returns the plugin configurer.
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.
getProperties() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
getProperties() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityTypeInfo
 
getProperties() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest
 
getProperties() - Method in class io.cdap.cdap.etl.api.connector.PluginSpec
 
getProperties() - Method in class io.cdap.cdap.etl.api.connector.SampleDetail
Get the all the properties used to generate this sample, these properties can be directly used by a source/sink
getProperties() - Method in class io.cdap.cdap.etl.api.connector.SampleRequest
 
getProperty() - Method in exception io.cdap.cdap.etl.api.validation.InvalidConfigPropertyException
Deprecated.
 
getPropertyHeaders() - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail
 
getPullProvider(SQLPullRequest) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
Creates an InputFormatProvider that can be used to pull records from the specified dataset.
getPushProvider(SQLPushRequest) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
Creates an Output Format Provided that can be used to push records into a SQL Engine.
getReasons() - Method in exception io.cdap.cdap.etl.api.validation.InvalidStageException
Deprecated.
 
getRecord() - Method in interface io.cdap.cdap.etl.api.ErrorRecord
 
getRelatedPlugins() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec
 
getRequiredInputs() - Method in class io.cdap.cdap.etl.api.JoinConfig
Returns required inputs to be joined.
getSample() - Method in class io.cdap.cdap.etl.api.connector.SampleDetail
 
getSampleProperties() - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail
 
getSchema() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec
 
getSchema() - Method in interface io.cdap.cdap.etl.api.engine.sql.dataset.SQLDataset
Get the schema for the records stored in this dataset.
getSchema() - Method in class io.cdap.cdap.etl.api.join.JoinStage
 
getSchema(FormatContext) - Method in interface io.cdap.cdap.etl.api.validation.ValidatingInputFormat
Gets validated schema.
getSelectedFields() - Method in class io.cdap.cdap.etl.api.join.JoinDefinition
 
getSink() - Method in class io.cdap.cdap.etl.api.lineage.field.FieldWriteOperation
 
getSkewedStageName() - Method in class io.cdap.cdap.etl.api.join.JoinDistribution
 
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.join.error.JoinKeyFieldError
 
getStageName() - Method in class io.cdap.cdap.etl.api.join.JoinField
 
getStageName() - Method in class io.cdap.cdap.etl.api.join.JoinKey
 
getStageName() - Method in class io.cdap.cdap.etl.api.join.JoinStage
 
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.
getStages() - Method in class io.cdap.cdap.etl.api.join.JoinDefinition
 
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
 
getTotalCount() - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail
 
getType() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
getType() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue
 
getType() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityTypeInfo
 
getType() - Method in class io.cdap.cdap.etl.api.connector.PluginSpec
 
getType() - Method in class io.cdap.cdap.etl.api.join.error.JoinError
 
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().
getValue() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue
 
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.
groupBy(GROUP_VALUE, Emitter<GROUP_KEY>) - Method in interface io.cdap.cdap.etl.api.ReducibleAggregator
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.connector.BrowseDetail
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityTypeInfo
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.PluginSpec
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.SampleDetail
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.SamplePropertyField
 
hashCode() - Method in class io.cdap.cdap.etl.api.connector.SampleRequest
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.error.JoinError
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.error.JoinKeyError
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.error.JoinKeyFieldError
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.error.OutputSchemaError
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.error.SelectedFieldError
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.JoinField
 
hashCode() - Method in class io.cdap.cdap.etl.api.join.JoinKey
 
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.BatchReducibleAggregator
Initialize the Batch Reduce Aggregator.
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.
initializeAggregateValue(GROUP_VALUE) - Method in interface io.cdap.cdap.etl.api.ReducibleAggregator
Initialize the aggregated value based on the given value.
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
 
InvalidJoinException - Exception in io.cdap.cdap.etl.api.join
Thrown when a join definition is invalid.
InvalidJoinException(Collection<JoinError>) - Constructor for exception io.cdap.cdap.etl.api.join.InvalidJoinException
 
InvalidJoinException(String) - Constructor for exception io.cdap.cdap.etl.api.join.InvalidJoinException
 
InvalidJoinException(String, Collection<JoinError>) - Constructor for exception io.cdap.cdap.etl.api.join.InvalidJoinException
 
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.connector - package io.cdap.cdap.etl.api.connector
 
io.cdap.cdap.etl.api.engine.sql - package io.cdap.cdap.etl.api.engine.sql
 
io.cdap.cdap.etl.api.engine.sql.dataset - package io.cdap.cdap.etl.api.engine.sql.dataset
 
io.cdap.cdap.etl.api.engine.sql.request - package io.cdap.cdap.etl.api.engine.sql.request
 
io.cdap.cdap.etl.api.join - package io.cdap.cdap.etl.api.join
 
io.cdap.cdap.etl.api.join.error - package io.cdap.cdap.etl.api.join.error
 
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
 
isBroadcast() - Method in class io.cdap.cdap.etl.api.join.JoinStage
 
isCacheEnabled() - Method in class io.cdap.cdap.etl.api.LookupTableConfig
 
isNullSafe() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys
 
isOptional() - Method in class io.cdap.cdap.etl.api.join.JoinStage.Builder
 
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.
isRequired() - Method in class io.cdap.cdap.etl.api.join.JoinStage.Builder
 
isRequired() - Method in class io.cdap.cdap.etl.api.join.JoinStage
 
isSuccessful() - Method in interface io.cdap.cdap.etl.api.batch.BatchActionContext
Return true if the execution was successful, false otherwise.

J

join(SQLJoinRequest) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
Executes the join operation defined by the supplied join request.
JoinCondition - Class in io.cdap.cdap.etl.api.join
A condition to join on.
JoinCondition.OnExpression - Class in io.cdap.cdap.etl.api.join
Join on an arbitrary expression.
JoinCondition.OnExpression.Builder - Class in io.cdap.cdap.etl.api.join
Builder for expression join conditions
JoinCondition.OnKeys - Class in io.cdap.cdap.etl.api.join
Join on multiple keys from each stage.
JoinCondition.OnKeys.Builder - Class in io.cdap.cdap.etl.api.join
Builds an OnKeys condition.
JoinCondition.Op - Enum in io.cdap.cdap.etl.api.join
Condition operation.
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
joinDefinition - Variable in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
 
JoinDefinition - Class in io.cdap.cdap.etl.api.join
Specifies how a join should be executed.
JoinDefinition.Builder - Class in io.cdap.cdap.etl.api.join
Builds a JoinSpecification.
JoinDistribution - Class in io.cdap.cdap.etl.api.join
Join distribution settings for salting/exploding datasets to resolve skew
JoinDistribution(Integer, String) - Constructor for class io.cdap.cdap.etl.api.join.JoinDistribution
 
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.
JoinError - Class in io.cdap.cdap.etl.api.join.error
An error that contributed to an invalid JoinDefinition.
JoinError(String) - Constructor for class io.cdap.cdap.etl.api.join.error.JoinError
 
JoinError(String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.JoinError
 
JoinError(JoinError.Type, String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.JoinError
 
JoinError.Type - Enum in io.cdap.cdap.etl.api.join.error
Type of join error
JoinField - Class in io.cdap.cdap.etl.api.join
The name of a field and an optional alias to rename it to.
JoinField(String, String) - Constructor for class io.cdap.cdap.etl.api.join.JoinField
 
JoinField(String, String, String) - Constructor for class io.cdap.cdap.etl.api.join.JoinField
 
JoinKey - Class in io.cdap.cdap.etl.api.join
A list of fields from a given stage.
JoinKey(String, List<String>) - Constructor for class io.cdap.cdap.etl.api.join.JoinKey
 
JoinKeyError - Class in io.cdap.cdap.etl.api.join.error
An error related to a join key.
JoinKeyError(JoinKey, String) - Constructor for class io.cdap.cdap.etl.api.join.error.JoinKeyError
 
JoinKeyError(JoinKey, String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.JoinKeyError
 
JoinKeyFieldError - Class in io.cdap.cdap.etl.api.join.error
An error related to a specific join key field.
JoinKeyFieldError(String, String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.JoinKeyFieldError
 
joinOn(String, INPUT_RECORD) - Method in interface io.cdap.cdap.etl.api.Joiner
Deprecated.
Joiner.getJoinKeys(String, Object) should be used instead
JoinStage - Class in io.cdap.cdap.etl.api.join
Represents an input stage to the auto join.
JoinStage.Builder - Class in io.cdap.cdap.etl.api.join
Builds a JoinStage.

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.
mergePartitions(AGG_VALUE, AGG_VALUE) - Method in interface io.cdap.cdap.etl.api.ReducibleAggregator
Merge the given aggregated values from each split to a final aggregated value.
mergeValues(AGG_VALUE, GROUP_VALUE) - Method in interface io.cdap.cdap.etl.api.ReducibleAggregator
Merge the given values to a single value.
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

on(JoinCondition) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
onExpression() - Static method in class io.cdap.cdap.etl.api.join.JoinCondition
 
onKeys() - Static method in class io.cdap.cdap.etl.api.join.JoinCondition
 
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, RuntimeContext) - Method in class io.cdap.cdap.etl.api.engine.sql.BatchSQLEngine
 
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
 
OutputSchemaError - Class in io.cdap.cdap.etl.api.join.error
An error with one of the output schema fields.
OutputSchemaError(String, String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.OutputSchemaError
 
OutputSchemaError(String, String, String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.OutputSchemaError
 

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.BatchAutoJoiner
 
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.BatchReducibleAggregator
 
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 interface io.cdap.cdap.etl.api.connector.Connector
 
PLUGIN_TYPE - Static variable in class io.cdap.cdap.etl.api.engine.sql.BatchSQLEngine
 
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
 
PluginSpec - Class in io.cdap.cdap.etl.api.connector
Plugin spec on what plugins are related to the connector
PluginSpec(String, String, Map<String, String>) - Constructor for class io.cdap.cdap.etl.api.connector.PluginSpec
 
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(BatchJoinerContext) - Method in class io.cdap.cdap.etl.api.batch.BatchAutoJoiner
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(BatchAggregatorContext) - Method in class io.cdap.cdap.etl.api.batch.BatchReducibleAggregator
Prepare a pipeline run.
prepareRun(T) - Method in class io.cdap.cdap.etl.api.batch.MultiInputBatchConfigurable
Prepare the Batch run.
prepareRun(RuntimeContext) - Method in class io.cdap.cdap.etl.api.engine.sql.BatchSQLEngine
 
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.
ReducibleAggregator<GROUP_KEY,GROUP_VALUE,AGG_VALUE,OUT> - Interface in io.cdap.cdap.etl.api
Groups all input objects into collections and performs an aggregation on the entire group.
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

sample(ConnectorContext, SampleRequest) - Method in interface io.cdap.cdap.etl.api.connector.DirectConnector
Directly get the sample results from the given request
SampleDetail - Class in io.cdap.cdap.etl.api.connector
The result for the sample request
SampleDetail.Builder - Class in io.cdap.cdap.etl.api.connector
Builder for SampleDetail
SamplePropertyField - Class in io.cdap.cdap.etl.api.connector
The property field to represent additional config required for sampling
SamplePropertyField(String, String) - Constructor for class io.cdap.cdap.etl.api.connector.SamplePropertyField
 
SampleRequest - Class in io.cdap.cdap.etl.api.connector
Request for sampling operations
SampleRequest.Builder - Class in io.cdap.cdap.etl.api.connector
Builder for SampleRequest
select(List<JoinField>) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
select(JoinField...) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
SelectedFieldError - Class in io.cdap.cdap.etl.api.join.error
An error with one of the selected output fields.
SelectedFieldError(JoinField, String) - Constructor for class io.cdap.cdap.etl.api.join.error.SelectedFieldError
 
SelectedFieldError(JoinField, String, String) - Constructor for class io.cdap.cdap.etl.api.join.error.SelectedFieldError
 
SerializableTransform<IN,OUT> - Class in io.cdap.cdap.etl.api
Used to mark a transform as serializable.
SerializableTransform() - Constructor for class io.cdap.cdap.etl.api.SerializableTransform
 
set(String, String) - Method in interface io.cdap.cdap.etl.api.action.SettableArguments
Sets the name and value as specified by the input parameters.
setBroadcast(boolean) - Method in class io.cdap.cdap.etl.api.join.JoinStage.Builder
Hint that the stage data should be broadcast during the join.
setConnection(String) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
setDatasetAliases(Map<String, String>) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression.Builder
 
setDistributionFactor(int, String) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
Set the distribution factor and stage name of the skewed stage.
setEntities(List<BrowseEntity>) - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
setErrorSchema(Schema) - Method in interface io.cdap.cdap.etl.api.StageConfigurer
set the error schema for this stage, or null if its unknown.
setExpression(String) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression.Builder
 
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.
setKeys(Collection<JoinKey>) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys.Builder
 
setLimit(Integer) - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest.Builder
 
setLimit(Integer) - Method in class io.cdap.cdap.etl.api.connector.SampleRequest.Builder
 
setName(String) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
setNullSafe(boolean) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys.Builder
Whether to perform null safe equality on the join keys.
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 class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
Set the output schema for the join.
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
setOutputSchemaName(String) - Method in class io.cdap.cdap.etl.api.join.JoinDefinition.Builder
 
setOutputSchemas(Map<String, Schema>) - Method in interface io.cdap.cdap.etl.api.MultiOutputStageConfigurer
Set schema for each output port.
setPath(String) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
setPath(String) - Method in class io.cdap.cdap.etl.api.connector.BrowseRequest.Builder
 
setPath(String) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
setPath(String) - Method in class io.cdap.cdap.etl.api.connector.SampleRequest.Builder
 
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.
setProperties(Map<String, BrowseEntityPropertyValue>) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
setProperties(Map<String, String>) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
 
setProperties(Map<String, String>) - Method in class io.cdap.cdap.etl.api.connector.SampleDetail.Builder
 
setProperties(Map<String, String>) - Method in class io.cdap.cdap.etl.api.connector.SampleRequest.Builder
 
setRelatedPlugins(Set<PluginSpec>) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec.Builder
 
setRequired(boolean) - Method in class io.cdap.cdap.etl.api.join.JoinStage.Builder
Set whether the stage is required.
setSample(List<StructuredRecord>) - Method in class io.cdap.cdap.etl.api.connector.SampleDetail.Builder
 
setSampleProperties(Collection<BrowseEntityTypeInfo>) - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
setSchema(Schema) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec.Builder
 
SettableArguments - Interface in io.cdap.cdap.etl.api.action
Arguments that can be updated.
setTotalCount(int) - Method in class io.cdap.cdap.etl.api.connector.BrowseDetail.Builder
 
setType(String) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntity.Builder
 
setType(BrowseEntityPropertyValue.PropertyType) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue.Builder
 
setValue(String) - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue.Builder
 
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
 
SQLDataset - Interface in io.cdap.cdap.etl.api.engine.sql.dataset
Represents a dataset that resides in a SQL engine outside of spark.
SQLEngine<KEY_IN,VALUE_IN,KEY_OUT,VALUE_OUT> - Interface in io.cdap.cdap.etl.api.engine.sql
A SQL Engine can be used to pushdown certain dataset operations.
SQLEngineException - Exception in io.cdap.cdap.etl.api.engine.sql
Class used to represent exceptions thrown by a SQL Engine.
SQLEngineException(String) - Constructor for exception io.cdap.cdap.etl.api.engine.sql.SQLEngineException
 
SQLEngineException(Throwable) - Constructor for exception io.cdap.cdap.etl.api.engine.sql.SQLEngineException
 
SQLEngineException(String, Throwable) - Constructor for exception io.cdap.cdap.etl.api.engine.sql.SQLEngineException
 
SQLJoinDefinition - Class in io.cdap.cdap.etl.api.engine.sql.request
Class representing a Join Definition to execute on the SQL Engine.
SQLJoinDefinition(String, JoinDefinition) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
 
SQLJoinDefinition(String, JoinDefinition, Collection<SQLDataset>) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinDefinition
 
SQLJoinRequest - Class in io.cdap.cdap.etl.api.engine.sql.request
Class representing a Request to execute as join operation on a SQL engine.
SQLJoinRequest(String, JoinDefinition, Collection<SQLDataset>) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinRequest
 
SQLPullDataset<T,K,V> - Interface in io.cdap.cdap.etl.api.engine.sql.dataset
SQL Dataset which exposes an InputFormatProvider and FromKeyValueTransform used to pull records from the SQL engine.
SQLPullRequest - Class in io.cdap.cdap.etl.api.engine.sql.request
Class representing a Request to pull a dataset from a SQL engine.
SQLPullRequest(SQLDataset) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLPullRequest
 
SQLPushDataset<T,K,V> - Interface in io.cdap.cdap.etl.api.engine.sql.dataset
SQL Dataset which exposes an OutputFormatProvider and ToKeyValueTransform used to push records into the SQL engine.
SQLPushRequest - Class in io.cdap.cdap.etl.api.engine.sql.request
Class representing a Request to push a dataset to a SQL engine.
SQLPushRequest(String, Schema) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLPushRequest
 
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
 
test(ConnectorContext) - Method in interface io.cdap.cdap.etl.api.connector.Connector
Test if the connector is able to connect to the resource
toKeyValue() - Method in interface io.cdap.cdap.etl.api.ToKeyValueTransform
 
ToKeyValueTransform<TYPE,KEY_OUT,VALUE_OUT> - Interface in io.cdap.cdap.etl.api
Interface for an entity which allows the transformation between an object of a given Type into a KeyValue pair.
toString() - Method in class io.cdap.cdap.etl.api.Alert
 
toString() - Method in class io.cdap.cdap.etl.api.join.JoinField
 
toString() - Method in class io.cdap.cdap.etl.api.join.JoinKey
 
transform(KEY_IN, VAL_IN) - Method in interface io.cdap.cdap.etl.api.batch.BatchConnector
Transform the sampled key and value back to StructuredRecord
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(List<JoinStage>) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression
 
validate(List<JoinStage>) - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnKeys
 
validate(List<JoinStage>) - Method in class io.cdap.cdap.etl.api.join.JoinCondition
Validate that is condition is valid to use when joining the given stages.
validate(List<JoinStage>) - Method in class io.cdap.cdap.etl.api.join.JoinDistribution
 
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.connector.BrowseEntityPropertyValue.PropertyType
Returns the enum constant of this type with the specified name.
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.join.error.JoinError.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.cdap.cdap.etl.api.join.JoinCondition.Op
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.connector.BrowseEntityPropertyValue.PropertyType
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.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.join.error.JoinError.Type
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.join.JoinCondition.Op
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 © 2021 Cask Data, Inc. Licensed under the Apache License, Version 2.0.