- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- build() - Method in class io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition.Builder
-
Builds a DeduplicateAggregationDefinition.
- build() - Method in class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition.Builder
-
Builds a GroupByAggregationDefinition.
- build() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition.Builder
-
Builds a WindowAggregationDefinition.
- 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.aggregation.DeduplicateAggregationDefinition
-
- Builder() - Constructor for class io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition.Builder
-
- builder() - Static method in class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition
-
- Builder() - Constructor for class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition.Builder
-
- builder() - Static method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- 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
-
- 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 class io.cdap.cdap.etl.api.engine.sql.SQLEngineInput
-
Get arguments used for input configuration
- getArguments() - Method in class io.cdap.cdap.etl.api.engine.sql.SQLEngineOutput
-
Get arguments used for output configuration
- 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
-
- getCapabilities() - Method in interface io.cdap.cdap.etl.api.relational.Engine
-
- getCapabilities() - Method in interface io.cdap.cdap.etl.api.relational.ExpressionFactory
-
- 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
-
- getConsumer(SQLPushRequest, PushCapability) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
- 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.SQLDatasetDescription
-
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.
- getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLReadRequest
-
Get the name of the dataset that should be read from the source
- getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLReadResult
-
Get the name of the dataset that should be written to the sink.
- getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLRelationDefinition
-
- getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteRequest
-
Get the name of the dataset that should be written to the sink.
- getDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteResult
-
Get the name of the dataset that should be written to the sink.
- 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 interface io.cdap.cdap.etl.api.engine.sql.dataset.SQLDatasetConsumer
-
- getDescription() - Method in interface io.cdap.cdap.etl.api.engine.sql.dataset.SQLDatasetProducer
-
- 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
-
- getEngine() - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
- 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
-
- getExcludedStageNames() - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Defines which stages should not be pushed down even when the platform determines the stage must be pushed down
- 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.aggregation.DeduplicateAggregationDefinition.FilterExpression
-
- getExpression() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition.OrderByExpression
-
- getExpression() - Method in class io.cdap.cdap.etl.api.join.JoinCondition.OnExpression
-
- getExpressionFactories() - Method in interface io.cdap.cdap.etl.api.relational.Engine
-
- getExpressionFactory(ExpressionFactoryType<T>, Capability...) - Method in interface io.cdap.cdap.etl.api.relational.Engine
-
Returns expression factory of specified type with required capabilities
Example: getExpressionFactory(StringExpressionFactory.SQL)
- getExpressionFactory(ExpressionFactoryType<T>, Collection<Capability>) - Method in interface io.cdap.cdap.etl.api.relational.Engine
-
Returns expression factory of specified type with required capabilities
Example: getExpressionFactory(StringExpressionFactory.SQL)
- 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
-
- getFilterExpressions() - Method in class io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition
-
Get the list of expressions using which a single record will be selected from a group of records for deduplication.
- getFilterFunction() - Method in class io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition.FilterExpression
-
- getFollowing() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- getFullMessage() - Method in class io.cdap.cdap.etl.api.validation.ValidationFailure
-
Returns failure message along with corrective action.
- getGroupByExpressions() - Method in class io.cdap.cdap.etl.api.aggregation.AggregationDefinition
-
Get the list of expressions on which grouping is to be performed.
- getIncludedStageNames() - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Defines which stages should be pushed down even when the platform doesn't select these stages for push down.
- getInput() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLReadRequest
-
Describes the input source
- getInputDatasets() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLJoinRequest
-
Get the datasets involved in this join operation.
- getInputDataSets() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformRequest
-
- 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.
- getInputRelation(String) - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
- getInputRelationNames() - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
- getInputSchema() - Method in interface io.cdap.cdap.etl.api.MultiOutputStageConfigurer
-
Get the input schema for this stage, or null if its unknown
- getInputSchema(String) - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
Gets schema for input stage
- 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
-
- getLength() - Method in interface io.cdap.cdap.etl.api.validation.InputFile
-
- 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
-
- getName() - Method in interface io.cdap.cdap.etl.api.validation.InputFile
-
- 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
-
- getNumRecords() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteResult
-
Get the number of records that were written into the sink, if any.
- 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
-
- getOrderBy() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition.OrderByExpression
-
- getOrderByExpressions() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- getOrThrowException() - Method in interface io.cdap.cdap.etl.api.FailureCollector
-
- getOutput() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteRequest
-
Describes the sink destination
- getOutputDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformDefinition
-
- getOutputDatasetName() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformRequest
-
- 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.
- getOutputRelation() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformDefinition
-
- getOutputRelation() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformRequest
-
- getOutputRelations() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformDefinition
-
- getOutputSchema() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformDefinition
-
- getOutputSchema() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformRequest
-
- getOutputSchema() - Method in class io.cdap.cdap.etl.api.join.JoinDefinition
-
- getOutputSchema() - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
Gets the output schema for this transform context
- 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.
- getOutputSchemas() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformDefinition
-
- getPartitionExpressions() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- 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
-
- getPluginProperties(String) - Method in interface io.cdap.cdap.etl.api.StageContext
-
- getPos() - Method in class io.cdap.cdap.etl.api.validation.SeekableInputStream
-
Return the current offset from the start of the file
- getPreceding() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- getProducer(SQLPullRequest, PullCapability) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
- 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
-
- getPullCapabilities() - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Defines pull capabilities supported by this SQL Engine
- 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.
- getPushCapabilities() - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Defines push capabilities supported by this SQL Engine
- 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.
- getQualifiedColumnName(Relation, String) - Method in interface io.cdap.cdap.etl.api.relational.ExpressionFactory
-
Provides fully qualified column name to be used in expressions for a given dataset column.
- getQualifiedDataSetName(Relation) - Method in interface io.cdap.cdap.etl.api.relational.ExpressionFactory
-
Provides fully qualified name to be used in expressions for a given dataset.
- 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
-
- getRelation(SQLRelationDefinition) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Prepares Relational plugin input based on provided descripton and dataset supplier.
- getRelationalEngine() - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
- getRequiredInputs() - Method in class io.cdap.cdap.etl.api.JoinConfig
-
Returns required inputs to be joined.
- getResult() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLReadResult
-
Get the result of the execution of this read operation.
- getResult() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteResult
-
Get the result of the execution of this write operation.
- 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.SQLDatasetDescription
-
Get the schema for the records stored in this dataset.
- getSchema() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLRelationDefinition
-
- 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
-
- getSelectExpressions() - Method in class io.cdap.cdap.etl.api.aggregation.AggregationDefinition
-
Get the list of expressions which are to be selected.
- getSelectExpressions() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- 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
-
- getSqlDataset() - Method in class io.cdap.cdap.etl.api.engine.sql.request.SQLReadResult
-
Get the SQL Dataset instance
- getSqlEngineClassName() - Method in class io.cdap.cdap.etl.api.engine.sql.SQLEngineInput
-
Gets the class name for the SQL engine implementation
- getSqlEngineClassName() - Method in class io.cdap.cdap.etl.api.engine.sql.SQLEngineOutput
-
Gets the class name for the SQL engine implementation
- 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 class io.cdap.cdap.etl.api.engine.sql.SQLEngineInput
-
Gets the stage name for this input.
- getStageName() - Method in class io.cdap.cdap.etl.api.engine.sql.SQLEngineOutput
-
Gets the stage name for this output.
- 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
-
- getSupportedSampleTypes() - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpec
-
- getTable(String) - Method in class io.cdap.cdap.etl.api.LookupConfig
-
- getTimeoutMs() - Method in class io.cdap.cdap.etl.api.connector.SampleRequest
-
- 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
-
- getType() - Method in interface io.cdap.cdap.etl.api.relational.ExpressionFactory
-
- getUnboundedFollowing() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- getUnboundedPreceding() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- getValidationError() - Method in interface io.cdap.cdap.etl.api.relational.Expression
-
- getValidationError() - Method in class io.cdap.cdap.etl.api.relational.InvalidExtractableExpression
-
- getValidationError() - Method in class io.cdap.cdap.etl.api.relational.InvalidRelation
-
- getValidationError() - Method in interface io.cdap.cdap.etl.api.relational.Relation
-
- 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
-
- getValue() - Method in class io.cdap.cdap.etl.api.connector.BrowseEntityPropertyValue
-
- getWindowFrameType() - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition
-
- groupBy(List<Expression>) - Method in class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition.Builder
-
Sets the list of expressions to perform grouping by to the specified list.
- groupBy(Expression...) - Method in class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition.Builder
-
Sets the list of expressions to perform grouping by to the specified expressions.
- 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.
- groupBy(GroupByAggregationDefinition) - Method in class io.cdap.cdap.etl.api.relational.InvalidRelation
-
- groupBy(GroupByAggregationDefinition) - Method in interface io.cdap.cdap.etl.api.relational.Relation
-
Allows to perform a group by based on an aggregation definition.
- GroupByAggregationDefinition - Class in io.cdap.cdap.etl.api.aggregation
-
Specifies how a group by operation should be executed.
- GroupByAggregationDefinition.Builder - Class in io.cdap.cdap.etl.api.aggregation
-
Builds a GroupByAggregationDefinition using fields to group by and fields to select.
- 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
-
- 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(String, int, Map<String, String>, Long) - Constructor for class io.cdap.cdap.etl.api.connector.SampleRequest
-
- SampleRequest.Builder - Class in io.cdap.cdap.etl.api.connector
-
- SampleType - Enum in io.cdap.cdap.etl.api.connector
-
Enum representing type of sampling method
- seek(long) - Method in class io.cdap.cdap.etl.api.validation.SeekableInputStream
-
Seek to the given offset from the start of the file.
- SeekableInputStream - Class in io.cdap.cdap.etl.api.validation
-
An InputStream that can seek to a specified position.
- SeekableInputStream() - Constructor for class io.cdap.cdap.etl.api.validation.SeekableInputStream
-
- select(Map<String, Expression>) - Method in class io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition.Builder
-
Sets the list of expressions to select to the specified list of expressions.
- select(String, Expression) - Method in class io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition.Builder
-
Sets the list of expressions to select to the specified expressions.
- select(Map<String, Expression>) - Method in class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition.Builder
-
Sets the list of expressions to select to the specified list of expressions.
- select(String, Expression) - Method in class io.cdap.cdap.etl.api.aggregation.GroupByAggregationDefinition.Builder
-
Sets the list of expressions to select to the specified expressions.
- select(Map<String, Expression>) - Method in class io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition.Builder
-
Sets the list of expressions to select to the specified expressions.
- 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
-
- select(Map<String, Expression>) - Method in class io.cdap.cdap.etl.api.relational.InvalidRelation
-
- select(Map<String, Expression>) - Method in interface io.cdap.cdap.etl.api.relational.Relation
-
Allows to completely replace set of column with a new one.
- 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.
- setColumn(String, Expression) - Method in class io.cdap.cdap.etl.api.relational.InvalidRelation
-
- setColumn(String, Expression) - Method in interface io.cdap.cdap.etl.api.relational.Relation
-
Allows to add or replace column for a relation.
- setConnection(String) - Method in class io.cdap.cdap.etl.api.connector.ConnectorSpecRequest.Builder
-
- setDataSetAlias(Relation, String) - Method in interface io.cdap.cdap.etl.api.relational.ExpressionFactory
-
Allows to set an alias for dataset that can be used for unqualified dataset and column references.
- 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.
- setOutputRelation(Relation) - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
sets the primary output relation for the transform
- setOutputRelation(String, Relation) - Method in interface io.cdap.cdap.etl.api.relational.RelationalTranformContext
-
- 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.
- setTimeoutMs(Long) - Method in class io.cdap.cdap.etl.api.connector.SampleRequest.Builder
-
- 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
-
- skip(long) - Method in class io.cdap.cdap.etl.api.validation.DelegatingSeekableInputStream
-
- 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.
- SQLDatasetConsumer - Interface in io.cdap.cdap.etl.api.engine.sql.dataset
-
SQL Dataset which exposes a method to get a consumer to be used to write
records into the SQL engine.
- SQLDatasetDescription - Interface in io.cdap.cdap.etl.api.engine.sql.dataset
-
Represents a dataset that resides in a SQL engine outside of spark.
- SQLDatasetProducer - Interface in io.cdap.cdap.etl.api.engine.sql.dataset
-
SQL Dataset which exposes a method to get a producer that can be used to extract
records from the SQL engine.
- 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
-
- SQLEngineInput - Class in io.cdap.cdap.etl.api.engine.sql
-
Sources that want to employ optimization by an SQL Engine may push SQLEngine-specific inputs, which include a
fallback input in case the SQL Engine Input cannot be processed.
- SQLEngineInput(String, String, String, Map<String, String>) - Constructor for class io.cdap.cdap.etl.api.engine.sql.SQLEngineInput
-
- SQLEngineOutput - Class in io.cdap.cdap.etl.api.engine.sql
-
Sinks that want to employ optimization by an SQL Engine may push SQLEngine-specific outputs in addition
to regular ones
- SQLEngineOutput(String, String, String, Map<String, String>) - Constructor for class io.cdap.cdap.etl.api.engine.sql.SQLEngineOutput
-
- 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
-
- 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
-
- 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
-
- SQLReadRequest - Class in io.cdap.cdap.etl.api.engine.sql.request
-
A request to perform read operation
- SQLReadRequest(String, SQLEngineInput) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLReadRequest
-
Creates a new SQLReadRequest instance
- SQLReadResult - Class in io.cdap.cdap.etl.api.engine.sql.request
-
A request to perform read operation
- SQLReadResult(String, SQLReadResult.SQLReadOperationResult, SQLDataset) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLReadResult
-
Creates a new SQLReadResult instance
- SQLReadResult.SQLReadOperationResult - Enum in io.cdap.cdap.etl.api.engine.sql.request
-
- SQLRelationDefinition - Class in io.cdap.cdap.etl.api.engine.sql.request
-
This class defines a SQL Engine relation during relationalial transform calls
- SQLRelationDefinition(String, Schema) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLRelationDefinition
-
- SQLTransformDefinition - Class in io.cdap.cdap.etl.api.engine.sql.request
-
Defines resulting relational transform that is requested by the plugin
- SQLTransformDefinition(String, Relation, Schema, Map<String, Relation>, Map<String, Schema>) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformDefinition
-
- SQLTransformRequest - Class in io.cdap.cdap.etl.api.engine.sql.request
-
Defines a request to perform relational transformation by SQL engine
- SQLTransformRequest(Map<String, SQLDataset>, String, Relation, Schema) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLTransformRequest
-
- SQLWriteRequest - Class in io.cdap.cdap.etl.api.engine.sql.request
-
A request to perform write operation
- SQLWriteRequest(String, SQLEngineOutput) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteRequest
-
Creates a new SQLWriteRequest instance
- SQLWriteResult - Class in io.cdap.cdap.etl.api.engine.sql.request
-
A request to perform write operation
- SQLWriteResult(String, SQLWriteResult.SQLWriteOperationResult, long) - Constructor for class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteResult
-
Creates a new SQLWriteResult instance
- SQLWriteResult.SQLWriteOperationResult - Enum in io.cdap.cdap.etl.api.engine.sql.request
-
- 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
-
- StandardSQLCapabilities - Enum in io.cdap.cdap.etl.api.engine.sql
-
Defines capabilities for SQL Engine factories
- StringExpressionFactoryType - Enum in io.cdap.cdap.etl.api.relational
-
This enum lists expression factory types that compile expressions from
String
- SubmitterLifecycle<T> - Interface in io.cdap.cdap.etl.api
-
Interface for stage that supports initialize call for resource setup.
- success(String, SQLDataset) - Static method in class io.cdap.cdap.etl.api.engine.sql.request.SQLReadResult
-
Utility method to create a successful SQL Read Result
- success(String, long) - Static method in class io.cdap.cdap.etl.api.engine.sql.request.SQLWriteResult
-
Utility method to create an instance with a successful result
- 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
-
- supportsInputSchema(Schema) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Check if the supplied input schema is supported by the SQL engine
- supportsOutputSchema(Schema) - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
Check if the supplied output schema is supported by the SQL engine
- supportsRelationalTranform() - Method in interface io.cdap.cdap.etl.api.engine.sql.SQLEngine
-
- 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.aggregation.DeduplicateAggregationDefinition.FilterFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition.OrderBy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.aggregation.WindowAggregationDefinition.WindowFrameType
-
Returns the enum constant of this type with the specified name.
- 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.connector.SampleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.engine.sql.capability.DefaultPullCapability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.engine.sql.capability.DefaultPushCapability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.engine.sql.request.SQLReadResult.SQLReadOperationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.engine.sql.request.SQLWriteResult.SQLWriteOperationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.engine.sql.StandardSQLCapabilities
-
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.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.relational.CoreExpressionCapabilities
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.cdap.cdap.etl.api.relational.StringExpressionFactoryType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum io.cdap.cdap.etl.api.aggregation.DeduplicateAggregationDefinition.FilterFunction
-
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.aggregation.WindowAggregationDefinition.OrderBy
-
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.aggregation.WindowAggregationDefinition.WindowFrameType
-
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.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.connector.SampleType
-
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.sql.capability.DefaultPullCapability
-
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.sql.capability.DefaultPushCapability
-
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.sql.request.SQLReadResult.SQLReadOperationResult
-
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.sql.request.SQLWriteResult.SQLWriteOperationResult
-
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.sql.StandardSQLCapabilities
-
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.
- values() - Static method in enum io.cdap.cdap.etl.api.relational.CoreExpressionCapabilities
-
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.relational.StringExpressionFactoryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.